public class LlapTaskReporter extends Object implements org.apache.tez.runtime.internals.api.TaskReporterInterface
| Constructor and Description |
|---|
LlapTaskReporter(SchedulerFragmentCompletingListener completionListener,
LlapTaskUmbilicalProtocol umbilical,
long amPollInterval,
long sendCounterInterval,
int maxEventsToGet,
AtomicLong requestCounter,
String containerIdStr,
String fragmentId,
org.apache.tez.runtime.api.impl.TezEvent initialEvent,
String fragmentRequestId,
WmFragmentCounters wmCounters) |
| Modifier and Type | Method and Description |
|---|---|
void |
addEvents(org.apache.tez.dag.records.TezTaskAttemptID taskAttemptID,
Collection<org.apache.tez.runtime.api.impl.TezEvent> events) |
boolean |
canCommit(org.apache.tez.dag.records.TezTaskAttemptID taskAttemptID) |
void |
registerTask(org.apache.tez.runtime.RuntimeTask task,
org.apache.tez.runtime.task.ErrorReporter errorReporter)
Register a task to be tracked.
|
void |
shutdown() |
boolean |
taskFailed(org.apache.tez.dag.records.TezTaskAttemptID tezTaskAttemptID,
org.apache.tez.runtime.api.TaskFailureType taskFailureType,
Throwable throwable,
String diagnostics,
org.apache.tez.runtime.api.impl.EventMetaData srcMeta) |
boolean |
taskKilled(org.apache.tez.dag.records.TezTaskAttemptID tezTaskAttemptID,
Throwable throwable,
String diagnostics,
org.apache.tez.runtime.api.impl.EventMetaData srcMeta) |
boolean |
taskSucceeded(org.apache.tez.dag.records.TezTaskAttemptID taskAttemptID) |
void |
unregisterTask(org.apache.tez.dag.records.TezTaskAttemptID taskAttemptID)
This method should always be invoked before setting up heartbeats for another task running in
the same container.
|
public LlapTaskReporter(SchedulerFragmentCompletingListener completionListener, LlapTaskUmbilicalProtocol umbilical, long amPollInterval, long sendCounterInterval, int maxEventsToGet, AtomicLong requestCounter, String containerIdStr, String fragmentId, org.apache.tez.runtime.api.impl.TezEvent initialEvent, String fragmentRequestId, WmFragmentCounters wmCounters)
public void registerTask(org.apache.tez.runtime.RuntimeTask task,
org.apache.tez.runtime.task.ErrorReporter errorReporter)
registerTask in interface org.apache.tez.runtime.internals.api.TaskReporterInterfacepublic void unregisterTask(org.apache.tez.dag.records.TezTaskAttemptID taskAttemptID)
unregisterTask in interface org.apache.tez.runtime.internals.api.TaskReporterInterfacepublic void shutdown()
shutdown in interface org.apache.tez.runtime.internals.api.TaskReporterInterfacepublic boolean taskSucceeded(org.apache.tez.dag.records.TezTaskAttemptID taskAttemptID)
throws IOException,
org.apache.tez.dag.api.TezException
taskSucceeded in interface org.apache.tez.runtime.internals.api.TaskReporterInterfaceIOExceptionorg.apache.tez.dag.api.TezExceptionpublic boolean taskFailed(org.apache.tez.dag.records.TezTaskAttemptID tezTaskAttemptID,
org.apache.tez.runtime.api.TaskFailureType taskFailureType,
Throwable throwable,
String diagnostics,
org.apache.tez.runtime.api.impl.EventMetaData srcMeta)
throws IOException,
org.apache.tez.dag.api.TezException
taskFailed in interface org.apache.tez.runtime.internals.api.TaskReporterInterfaceIOExceptionorg.apache.tez.dag.api.TezExceptionpublic boolean taskKilled(org.apache.tez.dag.records.TezTaskAttemptID tezTaskAttemptID,
Throwable throwable,
String diagnostics,
org.apache.tez.runtime.api.impl.EventMetaData srcMeta)
throws IOException,
org.apache.tez.dag.api.TezException
taskKilled in interface org.apache.tez.runtime.internals.api.TaskReporterInterfaceIOExceptionorg.apache.tez.dag.api.TezExceptionpublic void addEvents(org.apache.tez.dag.records.TezTaskAttemptID taskAttemptID,
Collection<org.apache.tez.runtime.api.impl.TezEvent> events)
addEvents in interface org.apache.tez.runtime.internals.api.TaskReporterInterfacepublic boolean canCommit(org.apache.tez.dag.records.TezTaskAttemptID taskAttemptID)
throws IOException
canCommit in interface org.apache.tez.runtime.internals.api.TaskReporterInterfaceIOExceptionCopyright © 2019 The Apache Software Foundation. All Rights Reserved.