public interface TaskExecutorGateway extends RpcGateway
TaskExecutor
RPC gateway interface.Modifier and Type | Method and Description |
---|---|
CompletableFuture<Boolean> |
canBeReleased()
Checks whether the task executor can be released.
|
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.
|
CompletableFuture<Acknowledge> |
freeSlot(AllocationID allocationId,
Throwable cause,
Time timeout)
Frees the slot with the given allocation ID.
|
void |
heartbeatFromJobManager(ResourceID heartbeatOrigin,
AllocatedSlotReport allocatedSlotReport)
Heartbeat request from the job manager.
|
void |
heartbeatFromResourceManager(ResourceID heartbeatOrigin)
Heartbeat request from the resource manager.
|
void |
releaseOrPromotePartitions(JobID jobId,
Set<ResultPartitionID> partitionToRelease,
Set<ResultPartitionID> partitionsToPromote)
Batch release/promote intermediate result partitions.
|
CompletableFuture<TransientBlobKey> |
requestFileUpload(FileType fileType,
Time timeout)
Requests the file upload of the specified type to the cluster's
BlobServer . |
CompletableFuture<SerializableOptional<String>> |
requestMetricQueryServiceAddress(Time timeout)
Returns the gateway of Metric Query Service on the TaskManager.
|
CompletableFuture<Acknowledge> |
requestSlot(SlotID slotId,
JobID jobId,
AllocationID allocationId,
ResourceProfile resourceProfile,
String targetAddress,
ResourceManagerId resourceManagerId,
Time timeout)
Requests a slot from the TaskManager.
|
CompletableFuture<TaskBackPressureResponse> |
requestTaskBackPressure(ExecutionAttemptID executionAttemptId,
int requestId,
Time timeout) |
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,
boolean advanceToEndOfEventTime)
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, ResourceProfile resourceProfile, String targetAddress, ResourceManagerId resourceManagerId, Time timeout)
slotId
- slot id for the requestjobId
- for which to request a slotallocationId
- id for the requestresourceProfile
- of requested slot, used only for dynamic slot allocation and will be ignored otherwisetargetAddress
- to which to offer the requested slotsresourceManagerId
- current leader id of the ResourceManagertimeout
- for the operationCompletableFuture<TaskBackPressureResponse> requestTaskBackPressure(ExecutionAttemptID executionAttemptId, int requestId, Time timeout)
CompletableFuture<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 releaseOrPromotePartitions(JobID jobId, Set<ResultPartitionID> partitionToRelease, Set<ResultPartitionID> partitionsToPromote)
jobId
- id of the job that the partitions belong topartitionToRelease
- partition ids to releasepartitionsToPromote
- partitions ids to promoteCompletableFuture<Acknowledge> triggerCheckpoint(ExecutionAttemptID executionAttemptID, long checkpointID, long checkpointTimestamp, CheckpointOptions checkpointOptions, boolean advanceToEndOfEventTime)
executionAttemptID
- identifying the taskcheckpointID
- unique id for the checkpointcheckpointTimestamp
- is the timestamp when the checkpoint has been initiatedcheckpointOptions
- for performing the checkpointadvanceToEndOfEventTime
- Flag indicating if the source should inject a MAX_WATERMARK
in the pipeline
to fire any registered event-time timersCompletableFuture<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> cancelTask(ExecutionAttemptID executionAttemptID, Time timeout)
executionAttemptID
- identifying the tasktimeout
- for the cancel operationvoid heartbeatFromJobManager(ResourceID heartbeatOrigin, AllocatedSlotReport allocatedSlotReport)
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 ResourceManagerCompletableFuture<Acknowledge> freeSlot(AllocationID allocationId, Throwable cause, Time timeout)
allocationId
- identifying the slot to freecause
- of the freeing operationtimeout
- for the operationCompletableFuture<TransientBlobKey> requestFileUpload(FileType fileType, Time timeout)
BlobServer
.fileType
- to uploadtimeout
- for the asynchronous operationTransientBlobKey
of the uploaded file.CompletableFuture<SerializableOptional<String>> requestMetricQueryServiceAddress(Time timeout)
CompletableFuture<Boolean> canBeReleased()
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.