Class ApplicationDispatcherGatewayServiceFactory

  • All Implemented Interfaces:
    org.apache.flink.runtime.dispatcher.runner.AbstractDispatcherLeaderProcess.DispatcherGatewayServiceFactory

    @Internal
    public class ApplicationDispatcherGatewayServiceFactory
    extends Object
    implements org.apache.flink.runtime.dispatcher.runner.AbstractDispatcherLeaderProcess.DispatcherGatewayServiceFactory
    A DispatcherGatewayServiceFactory used when executing a job in Application Mode, i.e. the user's main is executed on the same machine as the Dispatcher and the lifecycle of the cluster is the same as the one of the application.

    It instantiates a DispatcherGatewayService with an ApplicationDispatcherBootstrap containing the user's program.

    • Constructor Summary

      Constructors 
      Constructor Description
      ApplicationDispatcherGatewayServiceFactory​(org.apache.flink.configuration.Configuration configuration, org.apache.flink.runtime.dispatcher.DispatcherFactory dispatcherFactory, PackagedProgram application, org.apache.flink.runtime.rpc.RpcService rpcService, org.apache.flink.runtime.dispatcher.PartialDispatcherServices partialDispatcherServices)  
    • Method Summary

      All Methods Instance Methods Concrete Methods 
      Modifier and Type Method Description
      org.apache.flink.runtime.dispatcher.runner.AbstractDispatcherLeaderProcess.DispatcherGatewayService create​(org.apache.flink.runtime.dispatcher.DispatcherId fencingToken, Collection<org.apache.flink.streaming.api.graph.ExecutionPlan> recoveredJobs, Collection<org.apache.flink.runtime.jobmaster.JobResult> recoveredDirtyJobResults, org.apache.flink.runtime.jobmanager.ExecutionPlanWriter executionPlanWriter, org.apache.flink.runtime.highavailability.JobResultStore jobResultStore)  
    • Constructor Detail

      • ApplicationDispatcherGatewayServiceFactory

        public ApplicationDispatcherGatewayServiceFactory​(org.apache.flink.configuration.Configuration configuration,
                                                          org.apache.flink.runtime.dispatcher.DispatcherFactory dispatcherFactory,
                                                          PackagedProgram application,
                                                          org.apache.flink.runtime.rpc.RpcService rpcService,
                                                          org.apache.flink.runtime.dispatcher.PartialDispatcherServices partialDispatcherServices)
    • Method Detail

      • create

        public org.apache.flink.runtime.dispatcher.runner.AbstractDispatcherLeaderProcess.DispatcherGatewayService create​(org.apache.flink.runtime.dispatcher.DispatcherId fencingToken,
                                                                                                                          Collection<org.apache.flink.streaming.api.graph.ExecutionPlan> recoveredJobs,
                                                                                                                          Collection<org.apache.flink.runtime.jobmaster.JobResult> recoveredDirtyJobResults,
                                                                                                                          org.apache.flink.runtime.jobmanager.ExecutionPlanWriter executionPlanWriter,
                                                                                                                          org.apache.flink.runtime.highavailability.JobResultStore jobResultStore)
        Specified by:
        create in interface org.apache.flink.runtime.dispatcher.runner.AbstractDispatcherLeaderProcess.DispatcherGatewayServiceFactory