public class DefaultExecutionGraphFactory extends Object implements ExecutionGraphFactory
ExecutionGraphFactory
implementation.Constructor and Description |
---|
DefaultExecutionGraphFactory(Configuration configuration,
ClassLoader userCodeClassLoader,
ExecutionDeploymentTracker executionDeploymentTracker,
ScheduledExecutorService futureExecutor,
Executor ioExecutor,
Time rpcTimeout,
JobManagerJobMetricGroup jobManagerJobMetricGroup,
BlobWriter blobWriter,
ShuffleMaster<?> shuffleMaster,
JobMasterPartitionTracker jobMasterPartitionTracker) |
DefaultExecutionGraphFactory(Configuration configuration,
ClassLoader userCodeClassLoader,
ExecutionDeploymentTracker executionDeploymentTracker,
ScheduledExecutorService futureExecutor,
Executor ioExecutor,
Time rpcTimeout,
JobManagerJobMetricGroup jobManagerJobMetricGroup,
BlobWriter blobWriter,
ShuffleMaster<?> shuffleMaster,
JobMasterPartitionTracker jobMasterPartitionTracker,
boolean isDynamicGraph,
ExecutionJobVertex.Factory executionJobVertexFactory,
boolean nonFinishedHybridPartitionShouldBeUnknown) |
Modifier and Type | Method and Description |
---|---|
ExecutionGraph |
createAndRestoreExecutionGraph(JobGraph jobGraph,
CompletedCheckpointStore completedCheckpointStore,
CheckpointsCleaner checkpointsCleaner,
CheckpointIDCounter checkpointIdCounter,
TaskDeploymentDescriptorFactory.PartitionLocationConstraint partitionLocationConstraint,
long initializationTimestamp,
VertexAttemptNumberStore vertexAttemptNumberStore,
VertexParallelismStore vertexParallelismStore,
ExecutionStateUpdateListener executionStateUpdateListener,
MarkPartitionFinishedStrategy markPartitionFinishedStrategy,
org.slf4j.Logger log)
Create and restore
ExecutionGraph from the given JobGraph and services. |
public DefaultExecutionGraphFactory(Configuration configuration, ClassLoader userCodeClassLoader, ExecutionDeploymentTracker executionDeploymentTracker, ScheduledExecutorService futureExecutor, Executor ioExecutor, Time rpcTimeout, JobManagerJobMetricGroup jobManagerJobMetricGroup, BlobWriter blobWriter, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker jobMasterPartitionTracker)
public DefaultExecutionGraphFactory(Configuration configuration, ClassLoader userCodeClassLoader, ExecutionDeploymentTracker executionDeploymentTracker, ScheduledExecutorService futureExecutor, Executor ioExecutor, Time rpcTimeout, JobManagerJobMetricGroup jobManagerJobMetricGroup, BlobWriter blobWriter, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker jobMasterPartitionTracker, boolean isDynamicGraph, ExecutionJobVertex.Factory executionJobVertexFactory, boolean nonFinishedHybridPartitionShouldBeUnknown)
public ExecutionGraph createAndRestoreExecutionGraph(JobGraph jobGraph, CompletedCheckpointStore completedCheckpointStore, CheckpointsCleaner checkpointsCleaner, CheckpointIDCounter checkpointIdCounter, TaskDeploymentDescriptorFactory.PartitionLocationConstraint partitionLocationConstraint, long initializationTimestamp, VertexAttemptNumberStore vertexAttemptNumberStore, VertexParallelismStore vertexParallelismStore, ExecutionStateUpdateListener executionStateUpdateListener, MarkPartitionFinishedStrategy markPartitionFinishedStrategy, org.slf4j.Logger log) throws Exception
ExecutionGraphFactory
ExecutionGraph
from the given JobGraph
and services.createAndRestoreExecutionGraph
in interface ExecutionGraphFactory
jobGraph
- jobGraph to initialize the ExecutionGraph withcompletedCheckpointStore
- completedCheckpointStore to pass to the CheckpointCoordinatorcheckpointsCleaner
- checkpointsCleaner to pass to the CheckpointCoordinatorcheckpointIdCounter
- checkpointIdCounter to pass to the CheckpointCoordinatorpartitionLocationConstraint
- 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 loggingExecutionGraph
Exception
- if the ExecutionGraph
could not be created and restoredCopyright © 2014–2024 The Apache Software Foundation. All rights reserved.