Class Dispatcher
- java.lang.Object
-
- org.apache.flink.runtime.rpc.RpcEndpoint
-
- org.apache.flink.runtime.rpc.FencedRpcEndpoint<DispatcherId>
-
- org.apache.flink.runtime.dispatcher.Dispatcher
-
- All Implemented Interfaces:
AutoCloseable,DispatcherGateway,org.apache.flink.runtime.rpc.FencedRpcGateway<DispatcherId>,org.apache.flink.runtime.rpc.RpcGateway,RestfulGateway,org.apache.flink.util.AutoCloseableAsync
- Direct Known Subclasses:
StandaloneDispatcher
public abstract class Dispatcher extends org.apache.flink.runtime.rpc.FencedRpcEndpoint<DispatcherId> implements DispatcherGateway
Base class for the Dispatcher component. The Dispatcher component is responsible for receiving job submissions, persisting them, spawning JobManagers to execute the jobs and to recover them in case of a master failure. Furthermore, it knows about the state of the Flink session cluster.
-
-
Nested Class Summary
Nested Classes Modifier and Type Class Description protected static classDispatcher.ExecutionTypeEnum to distinguish between initial job submission and re-submission for recovery.
-
Field Summary
Fields Modifier and Type Field Description static org.apache.flink.configuration.ConfigOption<Duration>CLIENT_ALIVENESS_CHECK_DURATIONstatic StringDISPATCHER_NAMEprotected CompletableFuture<ApplicationStatus>shutDownFuture
-
Constructor Summary
Constructors Modifier Constructor Description Dispatcher(org.apache.flink.runtime.rpc.RpcService rpcService, DispatcherId fencingToken, Collection<ExecutionPlan> recoveredJobs, Collection<JobResult> recoveredDirtyJobs, DispatcherBootstrapFactory dispatcherBootstrapFactory, DispatcherServices dispatcherServices)protectedDispatcher(org.apache.flink.runtime.rpc.RpcService rpcService, DispatcherId fencingToken, Collection<ExecutionPlan> recoveredJobs, Collection<JobResult> recoveredDirtyJobs, DispatcherBootstrapFactory dispatcherBootstrapFactory, DispatcherServices dispatcherServices, JobManagerRunnerRegistry jobManagerRunnerRegistry, ResourceCleanerFactory resourceCleanerFactory)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description CompletableFuture<Acknowledge>cancelJob(org.apache.flink.api.common.JobID jobId, Duration timeout)Cancel the given job.CompletableFuture<CoordinationResponse>deliverCoordinationRequestToCoordinator(org.apache.flink.api.common.JobID jobId, String operatorUid, org.apache.flink.util.SerializedValue<CoordinationRequest> serializedRequest, Duration timeout)Deliver a coordination request to a specified coordinator and return the response.CompletableFuture<Acknowledge>disposeSavepoint(String savepointPath, Duration timeout)Dispose the given savepoint.CompletableFuture<Integer>getBlobServerPort(Duration timeout)Returns the port of the blob server.CompletableFuture<ApplicationStatus>getShutDownFuture()CompletableFuture<OperationResult<Long>>getTriggeredCheckpointStatus(AsynchronousJobOperationKey operationKey)Get the status of a checkpoint triggered under the specified operation key.CompletableFuture<OperationResult<String>>getTriggeredSavepointStatus(AsynchronousJobOperationKey operationKey)Get the status of a savepoint triggered under the specified operation key.protected CompletableFuture<org.apache.flink.runtime.dispatcher.Dispatcher.CleanupJobState>jobReachedTerminalState(ExecutionGraphInfo executionGraphInfo)CompletableFuture<Collection<org.apache.flink.api.common.JobID>>listJobs(Duration timeout)List the current set of submitted jobs.protected voidonFatalError(Throwable throwable)CompletableFuture<Void>onRemovedExecutionPlan(org.apache.flink.api.common.JobID jobId)voidonStart()CompletableFuture<Void>onStop()CompletableFuture<Void>reportJobClientHeartbeat(org.apache.flink.api.common.JobID jobId, long expiredTimestamp, Duration timeout)The client reports the heartbeat to the dispatcher for aliveness.CompletableFuture<CheckpointStatsSnapshot>requestCheckpointStats(org.apache.flink.api.common.JobID jobId, Duration timeout)Requests theCheckpointStatsSnapshotcontaining checkpointing information.CompletableFuture<ClusterOverview>requestClusterOverview(Duration timeout)Requests the cluster status overview.CompletableFuture<ExecutionGraphInfo>requestExecutionGraphInfo(org.apache.flink.api.common.JobID jobId, Duration timeout)Requests theExecutionGraphInfocontaining additional information besides theArchivedExecutionGraph.CompletableFuture<JobResourceRequirements>requestJobResourceRequirements(org.apache.flink.api.common.JobID jobId)Read currentjob resource requirementsfor a given job.CompletableFuture<JobResult>requestJobResult(org.apache.flink.api.common.JobID jobId, Duration timeout)Requests theJobResultof a job specified by the given jobId.CompletableFuture<org.apache.flink.api.common.JobStatus>requestJobStatus(org.apache.flink.api.common.JobID jobId, Duration timeout)Request theJobStatusof the given job.CompletableFuture<Collection<String>>requestMetricQueryServiceAddresses(Duration timeout)Requests the addresses of theMetricQueryServiceto query.CompletableFuture<MultipleJobsDetails>requestMultipleJobDetails(Duration timeout)Requests job details currently being executed on the Flink cluster.CompletableFuture<Collection<org.apache.flink.api.java.tuple.Tuple2<ResourceID,String>>>requestTaskManagerMetricQueryServiceAddresses(Duration timeout)Requests the addresses for the TaskManagers'MetricQueryServiceto query.CompletableFuture<ThreadDumpInfo>requestThreadDump(Duration timeout)Requests the thread dump from the JobManager.protected voidrunPostJobGloballyTerminated(org.apache.flink.api.common.JobID jobId, org.apache.flink.api.common.JobStatus jobStatus)CompletableFuture<Acknowledge>shutDownCluster()CompletableFuture<Acknowledge>shutDownCluster(ApplicationStatus applicationStatus)CompletableFuture<Acknowledge>stopWithSavepoint(AsynchronousJobOperationKey operationKey, String targetDirectory, org.apache.flink.core.execution.SavepointFormatType formatType, TriggerSavepointMode savepointMode, Duration timeout)Stops the job with a savepoint, returning a future that completes when the operation is started.CompletableFuture<String>stopWithSavepointAndGetLocation(org.apache.flink.api.common.JobID jobId, String targetDirectory, org.apache.flink.core.execution.SavepointFormatType formatType, TriggerSavepointMode savepointMode, Duration timeout)Stops the job with a savepoint, returning a future that completes with the savepoint location when the savepoint is completed.CompletableFuture<Acknowledge>submitFailedJob(org.apache.flink.api.common.JobID jobId, String jobName, Throwable exception)CompletableFuture<Acknowledge>submitJob(ExecutionPlan executionPlan, Duration timeout)Submit a job to the dispatcher.CompletableFuture<String>triggerCheckpoint(org.apache.flink.api.common.JobID jobID, Duration timeout)CompletableFuture<Acknowledge>triggerCheckpoint(AsynchronousJobOperationKey operationKey, org.apache.flink.core.execution.CheckpointType checkpointType, Duration timeout)Triggers a checkpoint with the given savepoint directory as a target.CompletableFuture<Long>triggerCheckpointAndGetCheckpointID(org.apache.flink.api.common.JobID jobID, org.apache.flink.core.execution.CheckpointType checkpointType, Duration timeout)Triggers a checkpoint, returning a future that completes with the checkpoint id when it is complete.CompletableFuture<Acknowledge>triggerSavepoint(AsynchronousJobOperationKey operationKey, String targetDirectory, org.apache.flink.core.execution.SavepointFormatType formatType, TriggerSavepointMode savepointMode, Duration timeout)Triggers a savepoint with the given savepoint directory as a target, returning a future that completes when the operation is started.CompletableFuture<String>triggerSavepointAndGetLocation(org.apache.flink.api.common.JobID jobId, String targetDirectory, org.apache.flink.core.execution.SavepointFormatType formatType, TriggerSavepointMode savepointMode, Duration timeout)Triggers a savepoint with the given savepoint directory as a target, returning a future that completes with the savepoint location when it is complete.CompletableFuture<Acknowledge>updateJobResourceRequirements(org.apache.flink.api.common.JobID jobId, JobResourceRequirements jobResourceRequirements)Updatejob resource requirementsfor a given job.-
Methods inherited from class org.apache.flink.runtime.rpc.RpcEndpoint
callAsync, closeAsync, getAddress, getEndpointId, getHostname, getMainThreadExecutor, getMainThreadExecutor, getRpcService, getSelfGateway, getTerminationFuture, internalCallOnStart, internalCallOnStop, isRunning, registerResource, runAsync, scheduleRunAsync, scheduleRunAsync, start, stop, unregisterResource, validateRunsInMainThread
-
Methods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
-
Methods inherited from interface org.apache.flink.runtime.webmonitor.RestfulGateway
requestJob
-
-
-
-
Field Detail
-
CLIENT_ALIVENESS_CHECK_DURATION
@VisibleForTesting @Internal public static final org.apache.flink.configuration.ConfigOption<Duration> CLIENT_ALIVENESS_CHECK_DURATION
-
DISPATCHER_NAME
public static final String DISPATCHER_NAME
- See Also:
- Constant Field Values
-
shutDownFuture
protected final CompletableFuture<ApplicationStatus> shutDownFuture
-
-
Constructor Detail
-
Dispatcher
public Dispatcher(org.apache.flink.runtime.rpc.RpcService rpcService, DispatcherId fencingToken, Collection<ExecutionPlan> recoveredJobs, Collection<JobResult> recoveredDirtyJobs, DispatcherBootstrapFactory dispatcherBootstrapFactory, DispatcherServices dispatcherServices) throws Exception- Throws:
Exception
-
Dispatcher
@VisibleForTesting protected Dispatcher(org.apache.flink.runtime.rpc.RpcService rpcService, DispatcherId fencingToken, Collection<ExecutionPlan> recoveredJobs, Collection<JobResult> recoveredDirtyJobs, DispatcherBootstrapFactory dispatcherBootstrapFactory, DispatcherServices dispatcherServices, JobManagerRunnerRegistry jobManagerRunnerRegistry, ResourceCleanerFactory resourceCleanerFactory) throws Exception- Throws:
Exception
-
-
Method Detail
-
getShutDownFuture
public CompletableFuture<ApplicationStatus> getShutDownFuture()
-
onStart
public void onStart() throws Exception- Overrides:
onStartin classorg.apache.flink.runtime.rpc.RpcEndpoint- Throws:
Exception
-
onStop
public CompletableFuture<Void> onStop()
- Overrides:
onStopin classorg.apache.flink.runtime.rpc.RpcEndpoint
-
submitJob
public CompletableFuture<Acknowledge> submitJob(ExecutionPlan executionPlan, Duration timeout)
Description copied from interface:DispatcherGatewaySubmit a job to the dispatcher.- Specified by:
submitJobin interfaceDispatcherGateway- Parameters:
executionPlan- ExecutionPlan to submittimeout- RPC timeout- Returns:
- A future acknowledge if the submission succeeded
-
submitFailedJob
public CompletableFuture<Acknowledge> submitFailedJob(org.apache.flink.api.common.JobID jobId, String jobName, Throwable exception)
- Specified by:
submitFailedJobin interfaceDispatcherGateway
-
listJobs
public CompletableFuture<Collection<org.apache.flink.api.common.JobID>> listJobs(Duration timeout)
Description copied from interface:DispatcherGatewayList the current set of submitted jobs.- Specified by:
listJobsin interfaceDispatcherGateway- Parameters:
timeout- RPC timeout- Returns:
- A future collection of currently submitted jobs
-
disposeSavepoint
public CompletableFuture<Acknowledge> disposeSavepoint(String savepointPath, Duration timeout)
Description copied from interface:RestfulGatewayDispose the given savepoint.- Specified by:
disposeSavepointin interfaceRestfulGateway- Parameters:
savepointPath- identifying the savepoint to disposetimeout- RPC timeout- Returns:
- A future acknowledge if the disposal succeeded
-
cancelJob
public CompletableFuture<Acknowledge> cancelJob(org.apache.flink.api.common.JobID jobId, Duration timeout)
Description copied from interface:RestfulGatewayCancel the given job.- Specified by:
cancelJobin interfaceRestfulGateway- Parameters:
jobId- identifying the job to canceltimeout- of the operation- Returns:
- A future acknowledge if the cancellation succeeded
-
requestClusterOverview
public CompletableFuture<ClusterOverview> requestClusterOverview(Duration timeout)
Description copied from interface:RestfulGatewayRequests the cluster status overview.- Specified by:
requestClusterOverviewin interfaceRestfulGateway- Parameters:
timeout- for the asynchronous operation- Returns:
- Future containing the status overview
-
requestMultipleJobDetails
public CompletableFuture<MultipleJobsDetails> requestMultipleJobDetails(Duration timeout)
Description copied from interface:RestfulGatewayRequests job details currently being executed on the Flink cluster.- Specified by:
requestMultipleJobDetailsin interfaceRestfulGateway- Parameters:
timeout- for the asynchronous operation- Returns:
- Future containing the job details
-
requestJobStatus
public CompletableFuture<org.apache.flink.api.common.JobStatus> requestJobStatus(org.apache.flink.api.common.JobID jobId, Duration timeout)
Description copied from interface:RestfulGatewayRequest theJobStatusof the given job.- Specified by:
requestJobStatusin interfaceRestfulGateway- Parameters:
jobId- identifying the job for which to retrieve the JobStatustimeout- for the asynchronous operation- Returns:
- A future to the
JobStatusof the given job
-
requestExecutionGraphInfo
public CompletableFuture<ExecutionGraphInfo> requestExecutionGraphInfo(org.apache.flink.api.common.JobID jobId, Duration timeout)
Description copied from interface:RestfulGatewayRequests theExecutionGraphInfocontaining additional information besides theArchivedExecutionGraph. If there is no such graph, then the future is completed with aFlinkJobNotFoundException.- Specified by:
requestExecutionGraphInfoin interfaceRestfulGateway- Parameters:
jobId- identifying the job whoseExecutionGraphInfois requestedtimeout- for the asynchronous operation- Returns:
- Future containing the
ExecutionGraphInfofor the given jobId, otherwiseFlinkJobNotFoundException
-
requestCheckpointStats
public CompletableFuture<CheckpointStatsSnapshot> requestCheckpointStats(org.apache.flink.api.common.JobID jobId, Duration timeout)
Description copied from interface:RestfulGatewayRequests theCheckpointStatsSnapshotcontaining checkpointing information.- Specified by:
requestCheckpointStatsin interfaceRestfulGateway- Parameters:
jobId- identifying the job whoseCheckpointStatsSnapshotis requestedtimeout- for the asynchronous operation- Returns:
- Future containing the
CheckpointStatsSnapshotfor the given jobId
-
requestJobResult
public CompletableFuture<JobResult> requestJobResult(org.apache.flink.api.common.JobID jobId, Duration timeout)
Description copied from interface:RestfulGatewayRequests theJobResultof a job specified by the given jobId.- Specified by:
requestJobResultin interfaceRestfulGateway- Parameters:
jobId- identifying the job for which to retrieve theJobResult.timeout- for the asynchronous operation- Returns:
- Future which is completed with the job's
JobResultonce the job has finished
-
requestMetricQueryServiceAddresses
public CompletableFuture<Collection<String>> requestMetricQueryServiceAddresses(Duration timeout)
Description copied from interface:RestfulGatewayRequests the addresses of theMetricQueryServiceto query.- Specified by:
requestMetricQueryServiceAddressesin interfaceRestfulGateway- Parameters:
timeout- for the asynchronous operation- Returns:
- Future containing the collection of metric query service addresses to query
-
requestTaskManagerMetricQueryServiceAddresses
public CompletableFuture<Collection<org.apache.flink.api.java.tuple.Tuple2<ResourceID,String>>> requestTaskManagerMetricQueryServiceAddresses(Duration timeout)
Description copied from interface:RestfulGatewayRequests the addresses for the TaskManagers'MetricQueryServiceto query.- Specified by:
requestTaskManagerMetricQueryServiceAddressesin interfaceRestfulGateway- Parameters:
timeout- for the asynchronous operation- Returns:
- Future containing the collection of instance ids and the corresponding metric query service address
-
requestThreadDump
public CompletableFuture<ThreadDumpInfo> requestThreadDump(Duration timeout)
Description copied from interface:RestfulGatewayRequests the thread dump from the JobManager.- Specified by:
requestThreadDumpin interfaceRestfulGateway- Parameters:
timeout- timeout of the asynchronous operation- Returns:
- Future containing the thread dump information
-
getBlobServerPort
public CompletableFuture<Integer> getBlobServerPort(Duration timeout)
Description copied from interface:DispatcherGatewayReturns the port of the blob server.- Specified by:
getBlobServerPortin interfaceDispatcherGateway- Parameters:
timeout- of the operation- Returns:
- A future integer of the blob server port
-
triggerCheckpoint
public CompletableFuture<String> triggerCheckpoint(org.apache.flink.api.common.JobID jobID, Duration timeout)
- Specified by:
triggerCheckpointin interfaceDispatcherGateway
-
triggerCheckpoint
public CompletableFuture<Acknowledge> triggerCheckpoint(AsynchronousJobOperationKey operationKey, org.apache.flink.core.execution.CheckpointType checkpointType, Duration timeout)
Description copied from interface:RestfulGatewayTriggers a checkpoint with the given savepoint directory as a target.- Specified by:
triggerCheckpointin interfaceRestfulGateway- Parameters:
operationKey- the key of the operation, for deduplication purposescheckpointType- checkpoint backup type (configured / full / incremental)timeout- Timeout for the asynchronous operation- Returns:
- A future to the
external pointerof the savepoint.
-
getTriggeredCheckpointStatus
public CompletableFuture<OperationResult<Long>> getTriggeredCheckpointStatus(AsynchronousJobOperationKey operationKey)
Description copied from interface:RestfulGatewayGet the status of a checkpoint triggered under the specified operation key.- Specified by:
getTriggeredCheckpointStatusin interfaceRestfulGateway- Parameters:
operationKey- key of the operation- Returns:
- Future which completes immediately with the status, or fails if no operation is registered for the key
-
triggerCheckpointAndGetCheckpointID
public CompletableFuture<Long> triggerCheckpointAndGetCheckpointID(org.apache.flink.api.common.JobID jobID, org.apache.flink.core.execution.CheckpointType checkpointType, Duration timeout)
Description copied from interface:DispatcherGatewayTriggers a checkpoint, returning a future that completes with the checkpoint id when it is complete.- Specified by:
triggerCheckpointAndGetCheckpointIDin interfaceDispatcherGateway- Parameters:
jobID- the job idcheckpointType- checkpoint type of this checkpoint (configured / full / incremental)timeout- Timeout for the asynchronous operation- Returns:
- Future which is completed once the operation is triggered successfully
-
triggerSavepoint
public CompletableFuture<Acknowledge> triggerSavepoint(AsynchronousJobOperationKey operationKey, String targetDirectory, org.apache.flink.core.execution.SavepointFormatType formatType, TriggerSavepointMode savepointMode, Duration timeout)
Description copied from interface:RestfulGatewayTriggers a savepoint with the given savepoint directory as a target, returning a future that completes when the operation is started.- Specified by:
triggerSavepointin interfaceRestfulGateway- Parameters:
operationKey- the key of the operation, for deduplication purposestargetDirectory- Target directory for the savepoint.formatType- Binary format of the savepoint.savepointMode- context of the savepoint operationtimeout- Timeout for the asynchronous operation- Returns:
- Future which is completed once the operation is triggered successfully
-
triggerSavepointAndGetLocation
public CompletableFuture<String> triggerSavepointAndGetLocation(org.apache.flink.api.common.JobID jobId, String targetDirectory, org.apache.flink.core.execution.SavepointFormatType formatType, TriggerSavepointMode savepointMode, Duration timeout)
Description copied from interface:DispatcherGatewayTriggers a savepoint with the given savepoint directory as a target, returning a future that completes with the savepoint location when it is complete.- Specified by:
triggerSavepointAndGetLocationin interfaceDispatcherGateway- Parameters:
jobId- the job idtargetDirectory- Target directory for the savepoint.formatType- Binary format of the savepoint.savepointMode- context of the savepoint operationtimeout- Timeout for the asynchronous operation- Returns:
- Future which is completed once the operation is triggered successfully
-
getTriggeredSavepointStatus
public CompletableFuture<OperationResult<String>> getTriggeredSavepointStatus(AsynchronousJobOperationKey operationKey)
Description copied from interface:RestfulGatewayGet the status of a savepoint triggered under the specified operation key.- Specified by:
getTriggeredSavepointStatusin interfaceRestfulGateway- Parameters:
operationKey- key of the operation- Returns:
- Future which completes immediately with the status, or fails if no operation is registered for the key
-
stopWithSavepoint
public CompletableFuture<Acknowledge> stopWithSavepoint(AsynchronousJobOperationKey operationKey, String targetDirectory, org.apache.flink.core.execution.SavepointFormatType formatType, TriggerSavepointMode savepointMode, Duration timeout)
Description copied from interface:RestfulGatewayStops the job with a savepoint, returning a future that completes when the operation is started.- Specified by:
stopWithSavepointin interfaceRestfulGateway- Parameters:
operationKey- key of the operation, for deduplicationtargetDirectory- Target directory for the savepoint.formatType- Binary format of the savepoint.savepointMode- context of the savepoint operationtimeout- for the rpc call- Returns:
- Future which is completed once the operation is triggered successfully
-
stopWithSavepointAndGetLocation
public CompletableFuture<String> stopWithSavepointAndGetLocation(org.apache.flink.api.common.JobID jobId, String targetDirectory, org.apache.flink.core.execution.SavepointFormatType formatType, TriggerSavepointMode savepointMode, Duration timeout)
Description copied from interface:DispatcherGatewayStops the job with a savepoint, returning a future that completes with the savepoint location when the savepoint is completed.- Specified by:
stopWithSavepointAndGetLocationin interfaceDispatcherGateway- Parameters:
jobId- the job idtargetDirectory- Target directory for the savepoint.savepointMode- context of the savepoint operationtimeout- for the rpc call- Returns:
- Future which is completed with the savepoint location once it is completed
-
shutDownCluster
public CompletableFuture<Acknowledge> shutDownCluster()
- Specified by:
shutDownClusterin interfaceRestfulGateway
-
shutDownCluster
public CompletableFuture<Acknowledge> shutDownCluster(ApplicationStatus applicationStatus)
- Specified by:
shutDownClusterin interfaceDispatcherGateway
-
deliverCoordinationRequestToCoordinator
public CompletableFuture<CoordinationResponse> deliverCoordinationRequestToCoordinator(org.apache.flink.api.common.JobID jobId, String operatorUid, org.apache.flink.util.SerializedValue<CoordinationRequest> serializedRequest, Duration timeout)
Description copied from interface:RestfulGatewayDeliver a coordination request to a specified coordinator and return the response.On the client side, a unique operatorUid must be defined to identify an operator. Otherwise, the query cannot be executed correctly. Note that we use operatorUid instead of operatorID because the latter is an internal runtime concept that cannot be recognized by the client.
- Specified by:
deliverCoordinationRequestToCoordinatorin interfaceRestfulGateway- Parameters:
jobId- identifying the job which the coordinator belongs tooperatorUid- identifying the coordinator to receive the requestserializedRequest- serialized request to delivertimeout- RPC timeout- Returns:
- A future containing the response. The response will fail with a
FlinkExceptionif the task is not running, or no operator/coordinator exists for the given ID, or the coordinator cannot handle client events.
-
reportJobClientHeartbeat
public CompletableFuture<Void> reportJobClientHeartbeat(org.apache.flink.api.common.JobID jobId, long expiredTimestamp, Duration timeout)
Description copied from interface:RestfulGatewayThe client reports the heartbeat to the dispatcher for aliveness.- Specified by:
reportJobClientHeartbeatin interfaceRestfulGateway
-
requestJobResourceRequirements
public CompletableFuture<JobResourceRequirements> requestJobResourceRequirements(org.apache.flink.api.common.JobID jobId)
Description copied from interface:RestfulGatewayRead currentjob resource requirementsfor a given job.- Specified by:
requestJobResourceRequirementsin interfaceRestfulGateway- Parameters:
jobId- job to read the resource requirements for- Returns:
- Future which that contains current resource requirements.
-
updateJobResourceRequirements
public CompletableFuture<Acknowledge> updateJobResourceRequirements(org.apache.flink.api.common.JobID jobId, JobResourceRequirements jobResourceRequirements)
Description copied from interface:RestfulGatewayUpdatejob resource requirementsfor a given job. When the returned future is complete the requirements have been updated and were persisted in HA, but the job may not have been rescaled (yet).- Specified by:
updateJobResourceRequirementsin interfaceRestfulGateway- Parameters:
jobId- job the given requirements belong tojobResourceRequirements- new resource requirements for the job- Returns:
- Future which is completed successfully when requirements are updated
-
runPostJobGloballyTerminated
protected void runPostJobGloballyTerminated(org.apache.flink.api.common.JobID jobId, org.apache.flink.api.common.JobStatus jobStatus)
-
onFatalError
protected void onFatalError(Throwable throwable)
-
jobReachedTerminalState
@VisibleForTesting protected CompletableFuture<org.apache.flink.runtime.dispatcher.Dispatcher.CleanupJobState> jobReachedTerminalState(ExecutionGraphInfo executionGraphInfo)
-
onRemovedExecutionPlan
public CompletableFuture<Void> onRemovedExecutionPlan(org.apache.flink.api.common.JobID jobId)
-
-