Modifier and Type | Class and Description |
---|---|
class |
DefaultExecutionGraph
Default implementation of the
ExecutionGraph . |
Modifier and Type | Method and Description |
---|---|
static ArchivedExecutionGraph |
ArchivedExecutionGraph.createFrom(ExecutionGraph executionGraph)
Create a
ArchivedExecutionGraph from the given ExecutionGraph . |
static ArchivedExecutionGraph |
ArchivedExecutionGraph.createFrom(ExecutionGraph executionGraph,
JobStatus statusOverride)
Create a
ArchivedExecutionGraph from the given ExecutionGraph . |
static boolean |
ExecutionGraphUtils.isAnyOutputBlocking(ExecutionGraph graph) |
Constructor and Description |
---|
ExecutionGraphCheckpointPlanCalculatorContext(ExecutionGraph executionGraph) |
Modifier and Type | Method and Description |
---|---|
ExecutionGraph |
DefaultExecutionGraphFactory.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) |
ExecutionGraph |
ExecutionGraphFactory.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. |
ExecutionGraph |
SchedulerBase.getExecutionGraph()
ExecutionGraph is exposed to make it easier to rework tests to be based on the new scheduler.
|
Constructor and Description |
---|
DefaultOperatorCoordinatorHandler(ExecutionGraph executionGraph,
GlobalFailureHandler globalFailureHandler) |
ExecutionGraphHandler(ExecutionGraph executionGraph,
org.slf4j.Logger log,
Executor ioExecutor,
ComponentMainThreadExecutor mainThreadExecutor) |
ExecutionGraphToInputsLocationsRetrieverAdapter(ExecutionGraph executionGraph) |
KvStateHandler(ExecutionGraph executionGraph) |
VertexEndOfDataListener(ExecutionGraph executionGraph) |
Modifier and Type | Method and Description |
---|---|
void |
StateTransitions.ToCancelling.goToCanceling(ExecutionGraph executionGraph,
ExecutionGraphHandler executionGraphHandler,
OperatorCoordinatorHandler operatorCoordinatorHandler,
List<ExceptionHistoryEntry> failureCollection)
Transitions into the
Canceling state. |
void |
AdaptiveScheduler.goToCanceling(ExecutionGraph executionGraph,
ExecutionGraphHandler executionGraphHandler,
OperatorCoordinatorHandler operatorCoordinatorHandler,
List<ExceptionHistoryEntry> failureCollection) |
void |
StateTransitions.ToCreatingExecutionGraph.goToCreatingExecutionGraph(ExecutionGraph previousExecutionGraph)
Transitions into the
CreatingExecutionGraph state. |
void |
AdaptiveScheduler.goToCreatingExecutionGraph(ExecutionGraph previousExecutionGraph) |
void |
StateTransitions.ToExecuting.goToExecuting(ExecutionGraph executionGraph,
ExecutionGraphHandler executionGraphHandler,
OperatorCoordinatorHandler operatorCoordinatorHandler,
List<ExceptionHistoryEntry> failureCollection)
Transitions into the
Executing state. |
void |
AdaptiveScheduler.goToExecuting(ExecutionGraph executionGraph,
ExecutionGraphHandler executionGraphHandler,
OperatorCoordinatorHandler operatorCoordinatorHandler,
List<ExceptionHistoryEntry> failureCollection) |
void |
StateTransitions.ToFailing.goToFailing(ExecutionGraph executionGraph,
ExecutionGraphHandler executionGraphHandler,
OperatorCoordinatorHandler operatorCoordinatorHandler,
Throwable failureCause,
List<ExceptionHistoryEntry> failureCollection)
Transitions into the
Failing state. |
void |
AdaptiveScheduler.goToFailing(ExecutionGraph executionGraph,
ExecutionGraphHandler executionGraphHandler,
OperatorCoordinatorHandler operatorCoordinatorHandler,
Throwable failureCause,
List<ExceptionHistoryEntry> failureCollection) |
void |
StateTransitions.ToRestarting.goToRestarting(ExecutionGraph executionGraph,
ExecutionGraphHandler executionGraphHandler,
OperatorCoordinatorHandler operatorCoordinatorHandler,
Duration backoffTime,
List<ExceptionHistoryEntry> failureCollection)
Transitions into the
Restarting state. |
void |
AdaptiveScheduler.goToRestarting(ExecutionGraph executionGraph,
ExecutionGraphHandler executionGraphHandler,
OperatorCoordinatorHandler operatorCoordinatorHandler,
Duration backoffTime,
List<ExceptionHistoryEntry> failureCollection) |
CompletableFuture<String> |
StateTransitions.ToStopWithSavepoint.goToStopWithSavepoint(ExecutionGraph executionGraph,
ExecutionGraphHandler executionGraphHandler,
OperatorCoordinatorHandler operatorCoordinatorHandler,
CheckpointScheduling checkpointScheduling,
CompletableFuture<String> savepointFuture,
List<ExceptionHistoryEntry> failureCollection)
Transitions into the
StopWithSavepoint state. |
CompletableFuture<String> |
AdaptiveScheduler.goToStopWithSavepoint(ExecutionGraph executionGraph,
ExecutionGraphHandler executionGraphHandler,
OperatorCoordinatorHandler operatorCoordinatorHandler,
CheckpointScheduling checkpointScheduling,
CompletableFuture<String> savepointFuture,
List<ExceptionHistoryEntry> failureCollection) |
void |
StateTransitions.ToWaitingForResources.goToWaitingForResources(ExecutionGraph previousExecutionGraph)
Transitions into the
WaitingForResources state. |
void |
AdaptiveScheduler.goToWaitingForResources(ExecutionGraph previousExecutionGraph) |
boolean |
AdaptiveScheduler.shouldRescale(ExecutionGraph executionGraph,
boolean forceRescale)
In regular mode, rescale the job if added resource meets
JobManagerOptions.MIN_PARALLELISM_INCREASE . |
Constructor and Description |
---|
CreatingExecutionGraph(org.apache.flink.runtime.scheduler.adaptive.CreatingExecutionGraph.Context context,
CompletableFuture<org.apache.flink.runtime.scheduler.adaptive.CreatingExecutionGraph.ExecutionGraphWithVertexParallelism> executionGraphWithParallelismFuture,
org.slf4j.Logger logger,
org.apache.flink.runtime.scheduler.adaptive.CreatingExecutionGraph.OperatorCoordinatorHandlerFactory operatorCoordinatorFactory,
ExecutionGraph previousExecutionGraph1) |
Modifier and Type | Method and Description |
---|---|
static JobAllocationsInformation |
JobAllocationsInformation.fromGraph(ExecutionGraph graph) |
Modifier and Type | Method and Description |
---|---|
ExecutionGraph |
BatchJobRecoveryContext.getExecutionGraph()
Provides the
ExecutionGraph associated with the job. |
Modifier and Type | Method and Description |
---|---|
void |
DummySpeculativeExecutionHandler.init(ExecutionGraph executionGraph,
ComponentMainThreadExecutor mainThreadExecutor,
MetricGroup metricGroup) |
void |
SpeculativeExecutionHandler.init(ExecutionGraph executionGraph,
ComponentMainThreadExecutor mainThreadExecutor,
MetricGroup metricGroup)
Initial speculative execution handler.
|
void |
DefaultSpeculativeExecutionHandler.init(ExecutionGraph executionGraph,
ComponentMainThreadExecutor mainThreadExecutor,
MetricGroup metricGroup) |
Modifier and Type | Method and Description |
---|---|
void |
SlowTaskDetector.start(ExecutionGraph executionGraph,
SlowTaskDetectorListener listener,
ComponentMainThreadExecutor mainThreadExecutor)
Start detecting slow tasks periodically.
|
void |
ExecutionTimeBasedSlowTaskDetector.start(ExecutionGraph executionGraph,
SlowTaskDetectorListener listener,
ComponentMainThreadExecutor mainThreadExecutor) |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.