public interface TaskManagerGateway extends TaskExecutorOperatorEventGateway
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Acknowledge> |
cancelTask(ExecutionAttemptID executionAttemptID,
Time timeout)
Cancel 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 |
notifyCheckpointAborted(ExecutionAttemptID executionAttemptID,
JobID jobId,
long checkpointId,
long latestCompletedCheckpointId,
long timestamp)
Notify the given task about a aborted checkpoint.
|
void |
notifyCheckpointOnComplete(ExecutionAttemptID executionAttemptID,
JobID jobId,
long completedCheckpointId,
long completedTimestamp,
long lastSubsumedCheckpointId)
Notify the given task about a completed checkpoint and the last subsumed checkpoint id if
possible.
|
void |
releasePartitions(JobID jobId,
Set<ResultPartitionID> partitionIds)
Batch release intermediate result partitions.
|
CompletableFuture<Acknowledge> |
sendOperatorEventToTask(ExecutionAttemptID task,
OperatorID operator,
SerializedValue<OperatorEvent> evt)
Sends an operator event to an operator in a task executed by the Task Manager (Task
Executor).
|
CompletableFuture<Acknowledge> |
submitTask(TaskDeploymentDescriptor tdd,
Time timeout)
Submit a task to the task manager.
|
CompletableFuture<Acknowledge> |
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<Acknowledge> submitTask(TaskDeploymentDescriptor tdd, Time timeout)
tdd
- describing the task to submittimeout
- 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 releasePartitions(JobID jobId, Set<ResultPartitionID> partitionIds)
jobId
- id of the job that the partitions belong topartitionIds
- partition ids to releasevoid notifyCheckpointOnComplete(ExecutionAttemptID executionAttemptID, JobID jobId, long completedCheckpointId, long completedTimestamp, long lastSubsumedCheckpointId)
executionAttemptID
- identifying the taskjobId
- identifying the job to which the task belongscompletedCheckpointId
- of the completed checkpointcompletedTimestamp
- of the completed checkpointlastSubsumedCheckpointId
- of the last subsumed checkpoint id,void notifyCheckpointAborted(ExecutionAttemptID executionAttemptID, JobID jobId, long checkpointId, long latestCompletedCheckpointId, long timestamp)
executionAttemptID
- identifying the taskjobId
- identifying the job to which the task belongscheckpointId
- of the subsumed checkpointlatestCompletedCheckpointId
- of the latest completed checkpointtimestamp
- of the subsumed checkpointCompletableFuture<Acknowledge> 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 operationCompletableFuture<Acknowledge> sendOperatorEventToTask(ExecutionAttemptID task, OperatorID operator, SerializedValue<OperatorEvent> evt)
TaskExecutorOperatorEventGateway
The reception is acknowledged (future is completed) when the event has been dispatched to
the AbstractInvokable.dispatchOperatorEvent(OperatorID,
SerializedValue)
method. It is not guaranteed that the event is processed successfully
within the implementation. These cases are up to the task and event sender to handle (for
example with an explicit response message upon success, or by triggering failure/recovery
upon exception).
sendOperatorEventToTask
in interface TaskExecutorOperatorEventGateway
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.