public interface TaskManagerGateway
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 |
notifyCheckpointComplete(ExecutionAttemptID executionAttemptID,
JobID jobId,
long checkpointId,
long timestamp)
Notify the given task about a completed checkpoint.
|
void |
releasePartitions(JobID jobId,
Set<ResultPartitionID> partitionIds)
Batch release intermediate result partitions.
|
CompletableFuture<TaskBackPressureResponse> |
requestTaskBackPressure(ExecutionAttemptID executionAttemptID,
int requestId,
Time timeout)
Request the back pressure ratio for 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,
boolean advanceToEndOfEventTime)
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<TaskBackPressureResponse> requestTaskBackPressure(ExecutionAttemptID executionAttemptID, int requestId, Time timeout)
executionAttemptID
- identifying the task to request.requestId
- id of the request.timeout
- rpc request timeout.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 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, boolean advanceToEndOfEventTime)
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 triggeradvanceToEndOfEventTime
- Flag indicating if the source should inject a MAX_WATERMARK
in the pipeline
to fire any registered event-time timersCompletableFuture<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.