Class SessionDispatcherLeaderProcess
- java.lang.Object
-
- org.apache.flink.runtime.dispatcher.runner.AbstractDispatcherLeaderProcess
-
- org.apache.flink.runtime.dispatcher.runner.SessionDispatcherLeaderProcess
-
- All Implemented Interfaces:
AutoCloseable,ExecutionPlanStore.ExecutionPlanListener,org.apache.flink.util.AutoCloseableAsync
public class SessionDispatcherLeaderProcess extends AbstractDispatcherLeaderProcess implements ExecutionPlanStore.ExecutionPlanListener
Process which encapsulates the job recovery logic and life cycle management of aDispatcher.
-
-
Nested Class Summary
-
Nested classes/interfaces inherited from class org.apache.flink.runtime.dispatcher.runner.AbstractDispatcherLeaderProcess
AbstractDispatcherLeaderProcess.DispatcherGatewayService, AbstractDispatcherLeaderProcess.DispatcherGatewayServiceFactory, AbstractDispatcherLeaderProcess.State
-
-
Field Summary
-
Fields inherited from class org.apache.flink.runtime.dispatcher.runner.AbstractDispatcherLeaderProcess
log
-
-
Method Summary
All Methods Static Methods Instance Methods Concrete Methods Modifier and Type Method Description static SessionDispatcherLeaderProcesscreate(UUID leaderSessionId, AbstractDispatcherLeaderProcess.DispatcherGatewayServiceFactory dispatcherFactory, ExecutionPlanStore executionPlanStore, JobResultStore jobResultStore, Executor ioExecutor, org.apache.flink.runtime.rpc.FatalErrorHandler fatalErrorHandler)voidonAddedExecutionPlan(org.apache.flink.api.common.JobID jobId)Callback forExecutionPlaninstances added by a differentExecutionPlanStoreinstance.protected CompletableFuture<Void>onClose()voidonRemovedExecutionPlan(org.apache.flink.api.common.JobID jobId)Callback forExecutionPlaninstances removed by a differentExecutionPlanStoreinstance.protected voidonStart()-
Methods inherited from class org.apache.flink.runtime.dispatcher.runner.AbstractDispatcherLeaderProcess
closeAsync, getDispatcherGateway, getDispatcherService, getLeaderAddressFuture, getLeaderSessionId, getShutDownFuture, start
-
-
-
-
Method Detail
-
onStart
protected void onStart()
- Specified by:
onStartin classAbstractDispatcherLeaderProcess
-
onClose
protected CompletableFuture<Void> onClose()
- Overrides:
onClosein classAbstractDispatcherLeaderProcess
-
onAddedExecutionPlan
public void onAddedExecutionPlan(org.apache.flink.api.common.JobID jobId)
Description copied from interface:ExecutionPlanStore.ExecutionPlanListenerCallback forExecutionPlaninstances added by a differentExecutionPlanStoreinstance.Important: It is possible to get false positives and be notified about a job graph, which was added by this instance.
- Specified by:
onAddedExecutionPlanin interfaceExecutionPlanStore.ExecutionPlanListener- Parameters:
jobId- TheJobIDof the added job graph
-
onRemovedExecutionPlan
public void onRemovedExecutionPlan(org.apache.flink.api.common.JobID jobId)
Description copied from interface:ExecutionPlanStore.ExecutionPlanListenerCallback forExecutionPlaninstances removed by a differentExecutionPlanStoreinstance.- Specified by:
onRemovedExecutionPlanin interfaceExecutionPlanStore.ExecutionPlanListener- Parameters:
jobId- TheJobIDof the removed job graph
-
create
public static SessionDispatcherLeaderProcess create(UUID leaderSessionId, AbstractDispatcherLeaderProcess.DispatcherGatewayServiceFactory dispatcherFactory, ExecutionPlanStore executionPlanStore, JobResultStore jobResultStore, Executor ioExecutor, org.apache.flink.runtime.rpc.FatalErrorHandler fatalErrorHandler)
-
-