Class DefaultExecutionGraphFactory
- java.lang.Object
-
- org.apache.flink.runtime.scheduler.DefaultExecutionGraphFactory
-
- All Implemented Interfaces:
ExecutionGraphFactory
public class DefaultExecutionGraphFactory extends Object implements ExecutionGraphFactory
DefaultExecutionGraphFactoryimplementation.
-
-
Constructor Summary
Constructors Constructor Description DefaultExecutionGraphFactory(org.apache.flink.configuration.Configuration configuration, ClassLoader userCodeClassLoader, ExecutionDeploymentTracker executionDeploymentTracker, ScheduledExecutorService futureExecutor, Executor ioExecutor, Duration rpcTimeout, JobManagerJobMetricGroup jobManagerJobMetricGroup, BlobWriter blobWriter, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker jobMasterPartitionTracker)DefaultExecutionGraphFactory(org.apache.flink.configuration.Configuration configuration, ClassLoader userCodeClassLoader, ExecutionDeploymentTracker executionDeploymentTracker, ScheduledExecutorService futureExecutor, Executor ioExecutor, Duration rpcTimeout, JobManagerJobMetricGroup jobManagerJobMetricGroup, BlobWriter blobWriter, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker jobMasterPartitionTracker, boolean isDynamicGraph, ExecutionJobVertex.Factory executionJobVertexFactory, boolean nonFinishedHybridPartitionShouldBeUnknown)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description ExecutionGraphcreateAndRestoreExecutionGraph(JobGraph jobGraph, CompletedCheckpointStore completedCheckpointStore, CheckpointsCleaner checkpointsCleaner, CheckpointIDCounter checkpointIdCounter, CheckpointStatsTracker checkpointStatsTracker, TaskDeploymentDescriptorFactory.PartitionLocationConstraint partitionLocationConstraint, long initializationTimestamp, VertexAttemptNumberStore vertexAttemptNumberStore, VertexParallelismStore vertexParallelismStore, ExecutionStateUpdateListener executionStateUpdateListener, MarkPartitionFinishedStrategy markPartitionFinishedStrategy, ExecutionPlanSchedulingContext executionPlanSchedulingContext, org.slf4j.Logger log)Create and restoreExecutionGraphfrom the givenJobGraphand services.
-
-
-
Constructor Detail
-
DefaultExecutionGraphFactory
public DefaultExecutionGraphFactory(org.apache.flink.configuration.Configuration configuration, ClassLoader userCodeClassLoader, ExecutionDeploymentTracker executionDeploymentTracker, ScheduledExecutorService futureExecutor, Executor ioExecutor, Duration rpcTimeout, JobManagerJobMetricGroup jobManagerJobMetricGroup, BlobWriter blobWriter, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker jobMasterPartitionTracker)
-
DefaultExecutionGraphFactory
public DefaultExecutionGraphFactory(org.apache.flink.configuration.Configuration configuration, ClassLoader userCodeClassLoader, ExecutionDeploymentTracker executionDeploymentTracker, ScheduledExecutorService futureExecutor, Executor ioExecutor, Duration rpcTimeout, JobManagerJobMetricGroup jobManagerJobMetricGroup, BlobWriter blobWriter, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker jobMasterPartitionTracker, boolean isDynamicGraph, ExecutionJobVertex.Factory executionJobVertexFactory, boolean nonFinishedHybridPartitionShouldBeUnknown)
-
-
Method Detail
-
createAndRestoreExecutionGraph
public ExecutionGraph createAndRestoreExecutionGraph(JobGraph jobGraph, CompletedCheckpointStore completedCheckpointStore, CheckpointsCleaner checkpointsCleaner, CheckpointIDCounter checkpointIdCounter, CheckpointStatsTracker checkpointStatsTracker, TaskDeploymentDescriptorFactory.PartitionLocationConstraint partitionLocationConstraint, long initializationTimestamp, VertexAttemptNumberStore vertexAttemptNumberStore, VertexParallelismStore vertexParallelismStore, ExecutionStateUpdateListener executionStateUpdateListener, MarkPartitionFinishedStrategy markPartitionFinishedStrategy, ExecutionPlanSchedulingContext executionPlanSchedulingContext, org.slf4j.Logger log) throws Exception
Description copied from interface:ExecutionGraphFactoryCreate and restoreExecutionGraphfrom the givenJobGraphand services.- Specified by:
createAndRestoreExecutionGraphin interfaceExecutionGraphFactory- Parameters:
jobGraph- jobGraph to initialize the ExecutionGraph withcompletedCheckpointStore- completedCheckpointStore to pass to the CheckpointCoordinatorcheckpointsCleaner- checkpointsCleaner to pass to the CheckpointCoordinatorcheckpointIdCounter- checkpointIdCounter to pass to the CheckpointCoordinatorcheckpointStatsTracker- TheCheckpointStatsTrackerthat's used for collecting the checkpoint-related statistics.partitionLocationConstraint- partitionLocationConstraint for this jobinitializationTimestamp- initializationTimestamp when the ExecutionGraph was createdvertexAttemptNumberStore- vertexAttemptNumberStore keeping information about the vertex attempts of previous runsvertexParallelismStore- vertexMaxParallelismStore keeping information about the vertex max parallelism settingsexecutionStateUpdateListener- listener for state transitions of the individual executionsexecutionPlanSchedulingContext- execution plan scheduling context that retrieve execution context details for adaptive batch jobslog- log to use for logging- Returns:
- restored
ExecutionGraph - Throws:
Exception- if theExecutionGraphcould not be created and restored
-
-