Class ApplicationDispatcherBootstrap

  • All Implemented Interfaces:
    org.apache.flink.runtime.dispatcher.DispatcherBootstrap

    @Internal
    public class ApplicationDispatcherBootstrap
    extends Object
    implements org.apache.flink.runtime.dispatcher.DispatcherBootstrap
    A DispatcherBootstrap used for running the user's main() in "Application Mode" (see FLIP-85).

    This dispatcher bootstrap submits the recovered job graphs for re-execution (in case of recovery from a failure), and then submits the remaining jobs of the application for execution.

    To achieve this, it works in conjunction with the EmbeddedExecutor which decides if it should submit a job for execution (in case of a new job) or the job was already recovered and is running.

    • Constructor Detail

      • ApplicationDispatcherBootstrap

        public ApplicationDispatcherBootstrap​(PackagedProgram application,
                                              Collection<org.apache.flink.api.common.JobID> recoveredJobIds,
                                              org.apache.flink.configuration.Configuration configuration,
                                              org.apache.flink.runtime.dispatcher.DispatcherGateway dispatcherGateway,
                                              org.apache.flink.util.concurrent.ScheduledExecutor scheduledExecutor,
                                              org.apache.flink.runtime.rpc.FatalErrorHandler errorHandler)
    • Method Detail

      • stop

        public void stop()
        Specified by:
        stop in interface org.apache.flink.runtime.dispatcher.DispatcherBootstrap