public interface TaskManagerGateway
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Acknowledge> |
cancelTask(ExecutionAttemptID executionAttemptID,
Time timeout)
Cancel the given task.
|
void |
failPartition(ExecutionAttemptID executionAttemptID)
Fail all intermediate result partitions of the given task.
|
CompletableFuture<Acknowledge> |
freeSlot(AllocationID allocationId,
Throwable cause,
Time timeout)
Frees the slot with the given allocation ID.
|
String |
getAddress()
Return the address of the task manager with which the gateway is associated.
|
void |
notifyCheckpointComplete(ExecutionAttemptID executionAttemptID,
JobID jobId,
long checkpointId,
long timestamp)
Notify the given task about a completed checkpoint.
|
CompletableFuture<StackTraceSampleResponse> |
requestStackTraceSample(ExecutionAttemptID executionAttemptID,
int sampleId,
int numSamples,
Time delayBetweenSamples,
int maxStackTraceDepth,
Time timeout)
Request a stack trace sample from the given task.
|
CompletableFuture<Acknowledge> |
stopTask(ExecutionAttemptID executionAttemptID,
Time timeout)
Stop the given task.
|
CompletableFuture<Acknowledge> |
submitTask(TaskDeploymentDescriptor tdd,
Time timeout)
Submit a task to the task manager.
|
void |
triggerCheckpoint(ExecutionAttemptID executionAttemptID,
JobID jobId,
long checkpointId,
long timestamp,
CheckpointOptions checkpointOptions)
Trigger for the given task a checkpoint.
|
CompletableFuture<Acknowledge> |
updatePartitions(ExecutionAttemptID executionAttemptID,
Iterable<PartitionInfo> partitionInfos,
Time timeout)
Update the task where the given partitions can be found.
|
String getAddress()
CompletableFuture<StackTraceSampleResponse> requestStackTraceSample(ExecutionAttemptID executionAttemptID, int sampleId, int numSamples, Time delayBetweenSamples, int maxStackTraceDepth, Time timeout)
executionAttemptID
- identifying the task to samplesampleId
- of the samplenumSamples
- to take from the given taskdelayBetweenSamples
- to wait formaxStackTraceDepth
- of the returned sampletimeout
- of the requestCompletableFuture<Acknowledge> submitTask(TaskDeploymentDescriptor tdd, Time timeout)
tdd
- describing the task to submittimeout
- of the submit operationCompletableFuture<Acknowledge> stopTask(ExecutionAttemptID executionAttemptID, Time timeout)
executionAttemptID
- identifying the tasktimeout
- of the submit operationCompletableFuture<Acknowledge> cancelTask(ExecutionAttemptID executionAttemptID, Time timeout)
executionAttemptID
- identifying the tasktimeout
- of the submit operationCompletableFuture<Acknowledge> updatePartitions(ExecutionAttemptID executionAttemptID, Iterable<PartitionInfo> partitionInfos, Time timeout)
executionAttemptID
- identifying the taskpartitionInfos
- telling where the partition can be retrieved fromtimeout
- of the submit operationvoid failPartition(ExecutionAttemptID executionAttemptID)
executionAttemptID
- identifying the taskvoid notifyCheckpointComplete(ExecutionAttemptID executionAttemptID, JobID jobId, long checkpointId, long timestamp)
executionAttemptID
- identifying the taskjobId
- identifying the job to which the task belongscheckpointId
- of the completed checkpointtimestamp
- of the completed checkpointvoid triggerCheckpoint(ExecutionAttemptID executionAttemptID, JobID jobId, long checkpointId, long timestamp, CheckpointOptions checkpointOptions)
executionAttemptID
- identifying the taskjobId
- identifying the job to which the task belongscheckpointId
- of the checkpoint to triggertimestamp
- of the checkpoint to triggercheckpointOptions
- of the checkpoint to triggerCompletableFuture<Acknowledge> freeSlot(AllocationID allocationId, Throwable cause, Time timeout)
allocationId
- identifying the slot to freecause
- of the freeing operationtimeout
- for the operationCopyright © 2014–2020 The Apache Software Foundation. All rights reserved.