public interface TaskExecutorGateway extends RpcGateway
TaskExecutor
RPC gateway interfaceModifier and Type | Method and Description |
---|---|
CompletableFuture<Acknowledge> |
cancelTask(ExecutionAttemptID executionAttemptID,
Time timeout)
Cancel the given task.
|
CompletableFuture<Acknowledge> |
confirmCheckpoint(ExecutionAttemptID executionAttemptID,
long checkpointId,
long checkpointTimestamp)
Confirm a checkpoint for the given task.
|
void |
disconnectJobManager(JobID jobId,
Exception cause)
Disconnects the given JobManager from the TaskManager.
|
void |
disconnectResourceManager(Exception cause)
Disconnects the ResourceManager from the TaskManager.
|
void |
failPartition(ExecutionAttemptID executionAttemptID)
Fail all intermediate result partitions of the given task.
|
void |
heartbeatFromJobManager(ResourceID heartbeatOrigin)
Heartbeat request from the job manager
|
void |
heartbeatFromResourceManager(ResourceID heartbeatOrigin)
Heartbeat request from the resource manager
|
CompletableFuture<Acknowledge> |
requestSlot(SlotID slotId,
JobID jobId,
AllocationID allocationId,
String targetAddress,
ResourceManagerId resourceManagerId,
Time timeout)
Requests a slot from the TaskManager
|
CompletableFuture<Acknowledge> |
stopTask(ExecutionAttemptID executionAttemptID,
Time timeout)
Stop the given task.
|
CompletableFuture<Acknowledge> |
submitTask(TaskDeploymentDescriptor tdd,
JobMasterId jobMasterId,
Time timeout)
Submit a
Task to the TaskExecutor . |
CompletableFuture<Acknowledge> |
triggerCheckpoint(ExecutionAttemptID executionAttemptID,
long checkpointID,
long checkpointTimestamp,
CheckpointOptions checkpointOptions)
Trigger the checkpoint for the given task.
|
CompletableFuture<Acknowledge> |
updatePartitions(ExecutionAttemptID executionAttemptID,
Iterable<PartitionInfo> partitionInfos,
Time timeout)
Update the task where the given partitions can be found.
|
getAddress, getHostname
CompletableFuture<Acknowledge> requestSlot(SlotID slotId, JobID jobId, AllocationID allocationId, String targetAddress, ResourceManagerId resourceManagerId, Time timeout)
slotId
- slot id for the requestjobId
- for which to request a slotallocationId
- id for the requesttargetAddress
- to which to offer the requested slotsresourceManagerId
- current leader id of the ResourceManagertimeout
- for the operationCompletableFuture<Acknowledge> submitTask(TaskDeploymentDescriptor tdd, JobMasterId jobMasterId, Time timeout)
Task
to the TaskExecutor
.tdd
- describing the task to submitjobMasterId
- identifying the submitting JobMastertimeout
- 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
- for the update partitions operationvoid failPartition(ExecutionAttemptID executionAttemptID)
executionAttemptID
- identifying the taskCompletableFuture<Acknowledge> triggerCheckpoint(ExecutionAttemptID executionAttemptID, long checkpointID, long checkpointTimestamp, CheckpointOptions checkpointOptions)
executionAttemptID
- identifying the taskcheckpointID
- unique id for the checkpointcheckpointTimestamp
- is the timestamp when the checkpoint has been initiatedcheckpointOptions
- for performing the checkpointCompletableFuture<Acknowledge> confirmCheckpoint(ExecutionAttemptID executionAttemptID, long checkpointId, long checkpointTimestamp)
executionAttemptID
- identifying the taskcheckpointId
- unique id for the checkpointcheckpointTimestamp
- is the timestamp when the checkpoint has been initiatedCompletableFuture<Acknowledge> stopTask(ExecutionAttemptID executionAttemptID, Time timeout)
executionAttemptID
- identifying the tasktimeout
- for the stop operationCompletableFuture<Acknowledge> cancelTask(ExecutionAttemptID executionAttemptID, Time timeout)
executionAttemptID
- identifying the tasktimeout
- for the cancel operationvoid heartbeatFromJobManager(ResourceID heartbeatOrigin)
heartbeatOrigin
- unique id of the job managervoid heartbeatFromResourceManager(ResourceID heartbeatOrigin)
heartbeatOrigin
- unique id of the resource managervoid disconnectJobManager(JobID jobId, Exception cause)
jobId
- JobID for which the JobManager was the leadercause
- for the disconnection from the JobManagervoid disconnectResourceManager(Exception cause)
cause
- for the disconnection from the ResourceManagerCopyright © 2014–2018 The Apache Software Foundation. All rights reserved.