Class 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.