Class DefaultExecutionGraphBuilder
- java.lang.Object
-
- org.apache.flink.runtime.executiongraph.DefaultExecutionGraphBuilder
-
public class DefaultExecutionGraphBuilder extends Object
Utility class to encapsulate the logic of building anDefaultExecutionGraphfrom aJobGraph.
-
-
Method Summary
All Methods Static Methods Concrete Methods Modifier and Type Method Description static DefaultExecutionGraphbuildGraph(JobGraph jobGraph, org.apache.flink.configuration.Configuration jobManagerConfig, ScheduledExecutorService futureExecutor, Executor ioExecutor, ClassLoader classLoader, CompletedCheckpointStore completedCheckpointStore, CheckpointsCleaner checkpointsCleaner, CheckpointIDCounter checkpointIdCounter, Duration rpcTimeout, BlobWriter blobWriter, org.slf4j.Logger log, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker partitionTracker, TaskDeploymentDescriptorFactory.PartitionLocationConstraint partitionLocationConstraint, ExecutionDeploymentListener executionDeploymentListener, ExecutionStateUpdateListener executionStateUpdateListener, long initializationTimestamp, VertexAttemptNumberStore vertexAttemptNumberStore, VertexParallelismStore vertexParallelismStore, CheckpointStatsTracker checkpointStatsTracker, boolean isDynamicGraph, ExecutionJobVertex.Factory executionJobVertexFactory, MarkPartitionFinishedStrategy markPartitionFinishedStrategy, boolean nonFinishedHybridPartitionShouldBeUnknown, JobManagerJobMetricGroup jobManagerJobMetricGroup, ExecutionPlanSchedulingContext executionPlanSchedulingContext)static voidinitJobVerticesOnMaster(Iterable<JobVertex> jobVertices, ClassLoader classLoader, org.slf4j.Logger log, VertexParallelismStore vertexParallelismStore, String jobName, org.apache.flink.api.common.JobID jobId)static booleanisCheckpointingEnabled(JobGraph jobGraph)
-
-
-
Method Detail
-
buildGraph
public static DefaultExecutionGraph buildGraph(JobGraph jobGraph, org.apache.flink.configuration.Configuration jobManagerConfig, ScheduledExecutorService futureExecutor, Executor ioExecutor, ClassLoader classLoader, CompletedCheckpointStore completedCheckpointStore, CheckpointsCleaner checkpointsCleaner, CheckpointIDCounter checkpointIdCounter, Duration rpcTimeout, BlobWriter blobWriter, org.slf4j.Logger log, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker partitionTracker, TaskDeploymentDescriptorFactory.PartitionLocationConstraint partitionLocationConstraint, ExecutionDeploymentListener executionDeploymentListener, ExecutionStateUpdateListener executionStateUpdateListener, long initializationTimestamp, VertexAttemptNumberStore vertexAttemptNumberStore, VertexParallelismStore vertexParallelismStore, CheckpointStatsTracker checkpointStatsTracker, boolean isDynamicGraph, ExecutionJobVertex.Factory executionJobVertexFactory, MarkPartitionFinishedStrategy markPartitionFinishedStrategy, boolean nonFinishedHybridPartitionShouldBeUnknown, JobManagerJobMetricGroup jobManagerJobMetricGroup, ExecutionPlanSchedulingContext executionPlanSchedulingContext) throws JobExecutionException, JobException
- Throws:
JobExecutionExceptionJobException
-
initJobVerticesOnMaster
public static void initJobVerticesOnMaster(Iterable<JobVertex> jobVertices, ClassLoader classLoader, org.slf4j.Logger log, VertexParallelismStore vertexParallelismStore, String jobName, org.apache.flink.api.common.JobID jobId) throws JobExecutionException
- Throws:
JobExecutionException
-
isCheckpointingEnabled
public static boolean isCheckpointingEnabled(JobGraph jobGraph)
-
-