public interface JobMasterGateway extends CheckpointCoordinatorGateway, FencedRpcGateway<JobMasterId>
JobMaster
rpc gateway interfaceModifier and Type | Method and Description |
---|---|
CompletableFuture<Acknowledge> |
cancel(Time timeout)
Cancels the currently executed job.
|
void |
disconnectResourceManager(ResourceManagerId resourceManagerId,
Exception cause)
Disconnects the resource manager from the job manager because of the given cause.
|
void |
disconnectTaskManager(ResourceID resourceID,
Exception cause)
Disconnects the given
TaskExecutor from the
JobMaster . |
void |
failSlot(ResourceID taskManagerId,
AllocationID allocationId,
Exception cause)
Fails the slot with the given allocation id and cause.
|
void |
heartbeatFromResourceManager(ResourceID resourceID)
Sends heartbeat request from the resource manager
|
void |
heartbeatFromTaskManager(ResourceID resourceID)
Sends the heartbeat to job manager from task manager
|
CompletableFuture<KvStateLocation> |
lookupKvStateLocation(String registrationName)
Requests a
KvStateLocation for the specified InternalKvState registration name. |
void |
notifyKvStateRegistered(JobVertexID jobVertexId,
KeyGroupRange keyGroupRange,
String registrationName,
KvStateID kvStateId,
InetSocketAddress kvStateServerAddress)
Notifies that queryable state has been registered.
|
void |
notifyKvStateUnregistered(JobVertexID jobVertexId,
KeyGroupRange keyGroupRange,
String registrationName)
Notifies that queryable state has been unregistered.
|
CompletableFuture<Collection<SlotOffer>> |
offerSlots(ResourceID taskManagerId,
Iterable<SlotOffer> slots,
Time timeout)
Offers the given slots to the job manager.
|
CompletableFuture<RegistrationResponse> |
registerTaskManager(String taskManagerRpcAddress,
TaskManagerLocation taskManagerLocation,
Time timeout)
Registers the task manager at the job manager.
|
CompletableFuture<AccessExecutionGraph> |
requestArchivedExecutionGraph(Time timeout)
Request the
ArchivedExecutionGraph of the currently executed job. |
CompletableFuture<ClassloadingProps> |
requestClassloadingProps()
Request the classloading props of this job.
|
CompletableFuture<JobDetails> |
requestJobDetails(Time timeout)
Request the details of the executed job.
|
CompletableFuture<JobStatus> |
requestJobStatus(Time timeout)
Requests the current job status.
|
CompletableFuture<SerializedInputSplit> |
requestNextInputSplit(JobVertexID vertexID,
ExecutionAttemptID executionAttempt)
Requests the next input split for the
ExecutionJobVertex . |
CompletableFuture<ExecutionState> |
requestPartitionState(IntermediateDataSetID intermediateResultId,
ResultPartitionID partitionId)
Requests the current state of the partition.
|
CompletableFuture<Acknowledge> |
scheduleOrUpdateConsumers(ResultPartitionID partitionID,
Time timeout)
Notifies the JobManager about available data for a produced partition.
|
CompletableFuture<Acknowledge> |
stop(Time timeout)
Cancel the currently executed job.
|
CompletableFuture<Acknowledge> |
updateTaskExecutionState(TaskExecutionState taskExecutionState)
Updates the task execution state for a given task.
|
acknowledgeCheckpoint, declineCheckpoint
getFencingToken
getAddress, getHostname
CompletableFuture<Acknowledge> cancel(Time timeout)
timeout
- of this operationCompletableFuture<Acknowledge> stop(Time timeout)
timeout
- of this operationCompletableFuture<Acknowledge> updateTaskExecutionState(TaskExecutionState taskExecutionState)
taskExecutionState
- New task execution state for a given taskCompletableFuture<SerializedInputSplit> requestNextInputSplit(JobVertexID vertexID, ExecutionAttemptID executionAttempt)
ExecutionJobVertex
.
The next input split is sent back to the sender as a
SerializedInputSplit
message.vertexID
- The job vertex idexecutionAttempt
- The execution attempt idCompletableFuture<ExecutionState> requestPartitionState(IntermediateDataSetID intermediateResultId, ResultPartitionID partitionId)
intermediateResultId
- The execution attempt ID of the task requesting the partition state.partitionId
- The partition ID of the partition to request the state of.CompletableFuture<Acknowledge> scheduleOrUpdateConsumers(ResultPartitionID partitionID, Time timeout)
There is a call to this method for each ExecutionVertex
instance once per produced
ResultPartition
instance, either when first producing data (for pipelined executions)
or when all data has been produced (for staged executions).
The JobManager then can decide when to schedule the partition consumers of the given session.
partitionID
- The partition which has already produced datatimeout
- before the rpc call failsvoid disconnectTaskManager(ResourceID resourceID, Exception cause)
TaskExecutor
from the
JobMaster
.resourceID
- identifying the TaskManager to disconnectcause
- for the disconnection of the TaskManagervoid disconnectResourceManager(ResourceManagerId resourceManagerId, Exception cause)
resourceManagerId
- identifying the resource manager leader idcause
- of the disconnectCompletableFuture<KvStateLocation> lookupKvStateLocation(String registrationName)
KvStateLocation
for the specified InternalKvState
registration name.registrationName
- Name under which the KvState has been registered.InternalKvState
locationvoid notifyKvStateRegistered(JobVertexID jobVertexId, KeyGroupRange keyGroupRange, String registrationName, KvStateID kvStateId, InetSocketAddress kvStateServerAddress)
jobVertexId
- JobVertexID the KvState instance belongs to.keyGroupRange
- Key group range the KvState instance belongs to.registrationName
- Name under which the KvState has been registered.kvStateId
- ID of the registered KvState instance.kvStateServerAddress
- Server address where to find the KvState instance.void notifyKvStateUnregistered(JobVertexID jobVertexId, KeyGroupRange keyGroupRange, String registrationName)
jobVertexId
- JobVertexID the KvState instance belongs to.keyGroupRange
- Key group index the KvState instance belongs to.registrationName
- Name under which the KvState has been registered.CompletableFuture<ClassloadingProps> requestClassloadingProps()
CompletableFuture<Collection<SlotOffer>> offerSlots(ResourceID taskManagerId, Iterable<SlotOffer> slots, Time timeout)
taskManagerId
- identifying the task managerslots
- to offer to the job managertimeout
- for the rpc callvoid failSlot(ResourceID taskManagerId, AllocationID allocationId, Exception cause)
taskManagerId
- identifying the task managerallocationId
- identifying the slot to failcause
- of the failingCompletableFuture<RegistrationResponse> registerTaskManager(String taskManagerRpcAddress, TaskManagerLocation taskManagerLocation, Time timeout)
taskManagerRpcAddress
- the rpc address of the task managertaskManagerLocation
- location of the task managertimeout
- for the rpc callvoid heartbeatFromTaskManager(ResourceID resourceID)
resourceID
- unique id of the task managervoid heartbeatFromResourceManager(ResourceID resourceID)
resourceID
- unique id of the resource managerCompletableFuture<JobDetails> requestJobDetails(Time timeout)
timeout
- for the rpc callCompletableFuture<AccessExecutionGraph> requestArchivedExecutionGraph(Time timeout)
ArchivedExecutionGraph
of the currently executed job.timeout
- for the rpc callCompletableFuture<JobStatus> requestJobStatus(Time timeout)
timeout
- for the rpc callCopyright © 2014–2018 The Apache Software Foundation. All rights reserved.