Package | Description |
---|---|
org.apache.flink.runtime.executiongraph | |
org.apache.flink.runtime.jobmanager.scheduler | |
org.apache.flink.runtime.jobmaster | |
org.apache.flink.runtime.scheduler |
Modifier and Type | Method and Description |
---|---|
void |
DefaultExecutionGraph.attachJobGraph(List<JobVertex> topologicallySorted) |
void |
ExecutionGraph.attachJobGraph(List<JobVertex> topologicallySorted) |
static DefaultExecutionGraph |
DefaultExecutionGraphBuilder.buildGraph(JobGraph jobGraph,
Configuration jobManagerConfig,
ScheduledExecutorService futureExecutor,
Executor ioExecutor,
ClassLoader classLoader,
CompletedCheckpointStore completedCheckpointStore,
CheckpointsCleaner checkpointsCleaner,
CheckpointIDCounter checkpointIdCounter,
Time rpcTimeout,
BlobWriter blobWriter,
org.slf4j.Logger log,
ShuffleMaster<?> shuffleMaster,
JobMasterPartitionTracker partitionTracker,
TaskDeploymentDescriptorFactory.PartitionLocationConstraint partitionLocationConstraint,
ExecutionDeploymentListener executionDeploymentListener,
ExecutionStateUpdateListener executionStateUpdateListener,
long initializationTimestamp,
VertexAttemptNumberStore vertexAttemptNumberStore,
VertexParallelismStore vertexParallelismStore,
java.util.function.Supplier<CheckpointStatsTracker> checkpointStatsTrackerFactory,
boolean isDynamicGraph,
ExecutionJobVertex.Factory executionJobVertexFactory) |
void |
ExecutionJobVertex.connectToPredecessors(Map<IntermediateDataSetID,IntermediateResult> intermediateDataSets) |
void |
ExecutionVertex.deploy() |
void |
Execution.deploy()
Deploys the execution to the previously assigned resource.
|
void |
ExecutionVertex.deployToSlot(LogicalSlot slot) |
protected void |
ExecutionJobVertex.initialize(int executionHistorySizeLimit,
Time timeout,
long createTimestamp,
SubtaskAttemptNumberStore initialAttemptCounts,
CoordinatorStore coordinatorStore) |
void |
DefaultExecutionGraph.initializeJobVertex(ExecutionJobVertex ejv,
long createTimestamp) |
void |
ExecutionGraph.initializeJobVertex(ExecutionJobVertex ejv,
long createTimestamp)
Initialize the given execution job vertex, mainly includes creating execution vertices
according to the parallelism, and connecting to the predecessors.
|
Constructor and Description |
---|
ExecutionJobVertex(InternalExecutionGraphAccessor graph,
JobVertex jobVertex,
VertexParallelismInformation parallelismInfo) |
SpeculativeExecutionJobVertex(InternalExecutionGraphAccessor graph,
JobVertex jobVertex,
VertexParallelismInformation parallelismInfo) |
Modifier and Type | Class and Description |
---|---|
class |
NoResourceAvailableException
Indicates resource allocation failures.
|
Modifier and Type | Class and Description |
---|---|
class |
JobNotFinishedException
Exception indicating that a Flink job has not been finished.
|
Modifier and Type | Class and Description |
---|---|
class |
ClusterDatasetCorruptedException
Indicates some task fail to consume cluster dataset.
|
Modifier and Type | Method and Description |
---|---|
void |
DefaultExecutionOperations.deploy(Execution execution) |
void |
ExecutionOperations.deploy(Execution execution)
Deploy the execution.
|
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.