public class TaskExecutorGatewayDecoratorBase extends Object implements TaskExecutorGateway
TaskExecutorGateway
.
This class is meant as a base for custom decorators, to avoid having to maintain all the method overrides in each decorator.
Modifier and Type | Field and Description |
---|---|
protected TaskExecutorGateway |
originalGateway |
Modifier | Constructor and Description |
---|---|
protected |
TaskExecutorGatewayDecoratorBase(TaskExecutorGateway originalGateway) |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Acknowledge> |
abortCheckpoint(ExecutionAttemptID executionAttemptID,
long checkpointId,
long latestCompletedCheckpointId,
long checkpointTimestamp)
Abort a checkpoint for the given task.
|
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 completedCheckpointId,
long completedCheckpointTimestamp,
long lastSubsumedCheckpointId)
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 |
freeInactiveSlots(JobID jobId,
Time timeout)
Frees all currently inactive slot allocated for the given job.
|
CompletableFuture<Acknowledge> |
freeSlot(AllocationID allocationId,
Throwable cause,
Time timeout)
Frees the slot with the given allocation ID.
|
String |
getAddress()
Returns the fully qualified address under which the associated rpc endpoint is reachable.
|
String |
getHostname()
Returns the fully qualified hostname under which the associated rpc endpoint is reachable.
|
CompletableFuture<Void> |
heartbeatFromJobManager(ResourceID heartbeatOrigin,
AllocatedSlotReport allocatedSlotReport)
Heartbeat request from the job manager.
|
CompletableFuture<Void> |
heartbeatFromResourceManager(ResourceID heartbeatOrigin)
Heartbeat request from the resource manager.
|
CompletableFuture<Acknowledge> |
promotePartitions(JobID jobId,
Set<ResultPartitionID> partitionIds)
Batch promote intermediate result partitions.
|
CompletableFuture<Acknowledge> |
releaseClusterPartitions(Collection<IntermediateDataSetID> dataSetsToRelease,
Time timeout)
Releases all cluster partitions belong to any of the given data sets.
|
void |
releasePartitions(JobID jobId,
Set<ResultPartitionID> partitionIds)
Batch release intermediate result partitions.
|
CompletableFuture<TransientBlobKey> |
requestFileUploadByName(String fileName,
Time timeout)
Requests the file upload of the specified name to the cluster's
BlobServer . |
CompletableFuture<TransientBlobKey> |
requestFileUploadByType(FileType fileType,
Time timeout)
Requests the file upload of the specified type to the cluster's
BlobServer . |
CompletableFuture<Collection<LogInfo>> |
requestLogList(Time timeout)
Requests for the historical log file names on the TaskManager.
|
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<ThreadDumpInfo> |
requestThreadDump(Time timeout)
Requests the thread dump from this TaskManager.
|
CompletableFuture<TaskThreadInfoResponse> |
requestThreadInfoSamples(Collection<ExecutionAttemptID> taskExecutionAttemptIds,
ThreadInfoSamplesRequest requestParams,
Time timeout)
Request a thread info sample from the given tasks.
|
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,
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> |
updateDelegationTokens(ResourceManagerId resourceManagerId,
byte[] tokens)
Sends new delegation tokens to this TaskManager.
|
CompletableFuture<Acknowledge> |
updatePartitions(ExecutionAttemptID executionAttemptID,
Iterable<PartitionInfo> partitionInfos,
Time timeout)
Update the task where the given partitions can be found.
|
protected final TaskExecutorGateway originalGateway
protected TaskExecutorGatewayDecoratorBase(TaskExecutorGateway originalGateway)
public String getAddress()
RpcGateway
getAddress
in interface RpcGateway
public String getHostname()
RpcGateway
getHostname
in interface RpcGateway
public CompletableFuture<Acknowledge> requestSlot(SlotID slotId, JobID jobId, AllocationID allocationId, ResourceProfile resourceProfile, String targetAddress, ResourceManagerId resourceManagerId, Time timeout)
TaskExecutorGateway
requestSlot
in interface TaskExecutorGateway
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 operationpublic CompletableFuture<Acknowledge> submitTask(TaskDeploymentDescriptor tdd, JobMasterId jobMasterId, Time timeout)
TaskExecutorGateway
Task
to the TaskExecutor
.submitTask
in interface TaskExecutorGateway
tdd
- describing the task to submitjobMasterId
- identifying the submitting JobMastertimeout
- of the submit operationpublic CompletableFuture<Acknowledge> updatePartitions(ExecutionAttemptID executionAttemptID, Iterable<PartitionInfo> partitionInfos, Time timeout)
TaskExecutorGateway
updatePartitions
in interface TaskExecutorGateway
executionAttemptID
- identifying the taskpartitionInfos
- telling where the partition can be retrieved fromtimeout
- for the update partitions operationpublic void releasePartitions(JobID jobId, Set<ResultPartitionID> partitionIds)
TaskExecutorGateway
releasePartitions
in interface TaskExecutorGateway
jobId
- id of the job that the partitions belong topartitionIds
- partition ids to releasepublic CompletableFuture<Acknowledge> promotePartitions(JobID jobId, Set<ResultPartitionID> partitionIds)
TaskExecutorGateway
promotePartitions
in interface TaskExecutorGateway
jobId
- id of the job that the partitions belong topartitionIds
- partition ids to releasepublic CompletableFuture<Acknowledge> releaseClusterPartitions(Collection<IntermediateDataSetID> dataSetsToRelease, Time timeout)
TaskExecutorGateway
releaseClusterPartitions
in interface TaskExecutorGateway
dataSetsToRelease
- data sets for which all cluster partitions should be releasedtimeout
- for the partitions release operationpublic CompletableFuture<Acknowledge> triggerCheckpoint(ExecutionAttemptID executionAttemptID, long checkpointID, long checkpointTimestamp, CheckpointOptions checkpointOptions)
TaskExecutorGateway
triggerCheckpoint
in interface TaskExecutorGateway
executionAttemptID
- identifying the taskcheckpointID
- unique id for the checkpointcheckpointTimestamp
- is the timestamp when the checkpoint has been initiatedcheckpointOptions
- for performing the checkpointpublic CompletableFuture<Acknowledge> confirmCheckpoint(ExecutionAttemptID executionAttemptID, long completedCheckpointId, long completedCheckpointTimestamp, long lastSubsumedCheckpointId)
TaskExecutorGateway
confirmCheckpoint
in interface TaskExecutorGateway
executionAttemptID
- identifying the taskcompletedCheckpointId
- unique id for the completed checkpointcompletedCheckpointTimestamp
- is the timestamp when the checkpoint has been initiatedlastSubsumedCheckpointId
- unique id for the checkpoint to be subsumedpublic CompletableFuture<Acknowledge> abortCheckpoint(ExecutionAttemptID executionAttemptID, long checkpointId, long latestCompletedCheckpointId, long checkpointTimestamp)
TaskExecutorGateway
abortCheckpoint
in interface TaskExecutorGateway
executionAttemptID
- identifying the taskcheckpointId
- unique id for the checkpointlatestCompletedCheckpointId
- the id of the latest completed checkpointcheckpointTimestamp
- is the timestamp when the checkpoint has been initiatedpublic CompletableFuture<Acknowledge> cancelTask(ExecutionAttemptID executionAttemptID, Time timeout)
TaskExecutorGateway
cancelTask
in interface TaskExecutorGateway
executionAttemptID
- identifying the tasktimeout
- for the cancel operationpublic CompletableFuture<Void> heartbeatFromJobManager(ResourceID heartbeatOrigin, AllocatedSlotReport allocatedSlotReport)
TaskExecutorGateway
heartbeatFromJobManager
in interface TaskExecutorGateway
heartbeatOrigin
- unique id of the job managerpublic CompletableFuture<Void> heartbeatFromResourceManager(ResourceID heartbeatOrigin)
TaskExecutorGateway
heartbeatFromResourceManager
in interface TaskExecutorGateway
heartbeatOrigin
- unique id of the resource managerpublic void disconnectJobManager(JobID jobId, Exception cause)
TaskExecutorGateway
disconnectJobManager
in interface TaskExecutorGateway
jobId
- JobID for which the JobManager was the leadercause
- for the disconnection from the JobManagerpublic void disconnectResourceManager(Exception cause)
TaskExecutorGateway
disconnectResourceManager
in interface TaskExecutorGateway
cause
- for the disconnection from the ResourceManagerpublic CompletableFuture<Acknowledge> freeSlot(AllocationID allocationId, Throwable cause, Time timeout)
TaskExecutorGateway
freeSlot
in interface TaskExecutorGateway
allocationId
- identifying the slot to freecause
- of the freeing operationtimeout
- for the operationpublic void freeInactiveSlots(JobID jobId, Time timeout)
TaskExecutorGateway
freeInactiveSlots
in interface TaskExecutorGateway
jobId
- job for which all inactive slots should be releasedtimeout
- for the operationpublic CompletableFuture<TransientBlobKey> requestFileUploadByType(FileType fileType, Time timeout)
TaskExecutorGateway
BlobServer
.requestFileUploadByType
in interface TaskExecutorGateway
fileType
- to uploadtimeout
- for the asynchronous operationTransientBlobKey
of the uploaded file.public CompletableFuture<TransientBlobKey> requestFileUploadByName(String fileName, Time timeout)
TaskExecutorGateway
BlobServer
.requestFileUploadByName
in interface TaskExecutorGateway
fileName
- to uploadtimeout
- for the asynchronous operationTransientBlobKey
of the uploaded file.public CompletableFuture<SerializableOptional<String>> requestMetricQueryServiceAddress(Time timeout)
TaskExecutorGateway
requestMetricQueryServiceAddress
in interface TaskExecutorGateway
public CompletableFuture<Boolean> canBeReleased()
TaskExecutorGateway
canBeReleased
in interface TaskExecutorGateway
public CompletableFuture<Collection<LogInfo>> requestLogList(Time timeout)
TaskExecutorGateway
requestLogList
in interface TaskExecutorGateway
public CompletableFuture<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 TaskExecutorGateway
sendOperatorEventToTask
in interface TaskExecutorOperatorEventGateway
public CompletableFuture<ThreadDumpInfo> requestThreadDump(Time timeout)
TaskExecutorGateway
requestThreadDump
in interface TaskExecutorGateway
timeout
- timeout for the asynchronous operationThreadDumpInfo
for this TaskManager.public CompletableFuture<Acknowledge> updateDelegationTokens(ResourceManagerId resourceManagerId, byte[] tokens)
TaskExecutorGateway
updateDelegationTokens
in interface TaskExecutorGateway
resourceManagerId
- current leader id of the ResourceManagertokens
- new tokenspublic CompletableFuture<TaskThreadInfoResponse> requestThreadInfoSamples(Collection<ExecutionAttemptID> taskExecutionAttemptIds, ThreadInfoSamplesRequest requestParams, Time timeout)
TaskExecutorThreadInfoGateway
requestThreadInfoSamples
in interface TaskExecutorThreadInfoGateway
taskExecutionAttemptIds
- identifying the task to samplerequestParams
- parameters of the requesttimeout
- of the requestCopyright © 2014–2023 The Apache Software Foundation. All rights reserved.