Class PerJobMiniClusterFactory


  • public final class PerJobMiniClusterFactory
    extends Object
    Starts a MiniCluster for every submitted job. This class guarantees to tear down the MiniCluster in case of normal or exceptional job completion.
    • Method Detail

      • createWithFactory

        public static PerJobMiniClusterFactory createWithFactory​(org.apache.flink.configuration.Configuration configuration,
                                                                 Function<? super org.apache.flink.runtime.minicluster.MiniClusterConfiguration,​? extends org.apache.flink.runtime.minicluster.MiniCluster> miniClusterFactory)
      • submitJob

        public CompletableFuture<org.apache.flink.core.execution.JobClient> submitJob​(org.apache.flink.streaming.api.graph.ExecutionPlan executionPlan,
                                                                                      ClassLoader userCodeClassloader)
                                                                               throws Exception
        Starts a MiniCluster and submits a job.
        Throws:
        Exception