Package org.apache.flink.runtime.dispatcher.runner
-
Interface Summary Interface Description AbstractDispatcherLeaderProcess.DispatcherGatewayService An accessor of theDispatcherGateway.AbstractDispatcherLeaderProcess.DispatcherGatewayServiceFactory DispatcherLeaderProcessFactory Factory for theDispatcherLeaderProcess.DispatcherLeaderProcessFactoryFactory Factory forDispatcherLeaderProcessFactory.DispatcherRunner TheDispatcherRunnerencapsulates how aDispatcheris being executed.DispatcherRunnerFactory Factory interface for theDispatcherRunner. -
Class Summary Class Description AbstractDispatcherLeaderProcess A baseDispatcherLeaderProcess.DefaultDispatcherGatewayService A facade over theDispatcherthat exposes specific functionality.DefaultDispatcherRunner Runner for theDispatcherwhich is responsible for the leader election.DefaultDispatcherRunnerFactory DispatcherRunnerFactoryimplementation which createsDefaultDispatcherRunnerinstances.SessionDispatcherLeaderProcess Process which encapsulates the job recovery logic and life cycle management of aDispatcher.SessionDispatcherLeaderProcessFactory Factory for theSessionDispatcherLeaderProcess.SessionDispatcherLeaderProcessFactoryFactory Factory for theSessionDispatcherLeaderProcessFactory. -
Enum Summary Enum Description AbstractDispatcherLeaderProcess.State The state of theDispatcherLeaderProcess.StoppedDispatcherLeaderProcess DispatcherLeaderProcessimplementation which is stopped.