Class DefaultExecutionGraphFactory
- java.lang.Object
-
- org.apache.flink.runtime.scheduler.DefaultExecutionGraphFactory
-
- All Implemented Interfaces:
ExecutionGraphFactory
public class DefaultExecutionGraphFactory extends Object implements ExecutionGraphFactory
DefaultExecutionGraphFactory
implementation.
-
-
Constructor Summary
Constructors Constructor Description DefaultExecutionGraphFactory(Configuration configuration, ClassLoader userCodeClassLoader, ExecutionDeploymentTracker executionDeploymentTracker, ScheduledExecutorService futureExecutor, Executor ioExecutor, Duration rpcTimeout, JobManagerJobMetricGroup jobManagerJobMetricGroup, BlobWriter blobWriter, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker jobMasterPartitionTracker)
DefaultExecutionGraphFactory(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 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, org.slf4j.Logger log)
Create and restoreExecutionGraph
from the givenJobGraph
and services.
-
-
-
Constructor Detail
-
DefaultExecutionGraphFactory
public DefaultExecutionGraphFactory(Configuration configuration, ClassLoader userCodeClassLoader, ExecutionDeploymentTracker executionDeploymentTracker, ScheduledExecutorService futureExecutor, Executor ioExecutor, Duration rpcTimeout, JobManagerJobMetricGroup jobManagerJobMetricGroup, BlobWriter blobWriter, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker jobMasterPartitionTracker)
-
DefaultExecutionGraphFactory
public DefaultExecutionGraphFactory(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, org.slf4j.Logger log) throws Exception
Description copied from interface:ExecutionGraphFactory
Create and restoreExecutionGraph
from the givenJobGraph
and services.- Specified by:
createAndRestoreExecutionGraph
in 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
- TheCheckpointStatsTracker
that'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 executionslog
- log to use for logging- Returns:
- restored
ExecutionGraph
- Throws:
Exception
- if theExecutionGraph
could not be created and restored
-
-