Uses of Interface
org.apache.flink.runtime.executiongraph.ExecutionGraph
-
-
Uses of ExecutionGraph in org.apache.flink.runtime.executiongraph
Classes in org.apache.flink.runtime.executiongraph that implement ExecutionGraph Modifier and Type Class Description class
DefaultExecutionGraph
Default implementation of theExecutionGraph
.Methods in org.apache.flink.runtime.executiongraph with parameters of type ExecutionGraph Modifier and Type Method Description static ArchivedExecutionGraph
ArchivedExecutionGraph. createFrom(ExecutionGraph executionGraph)
Create aArchivedExecutionGraph
from the givenExecutionGraph
.static ArchivedExecutionGraph
ArchivedExecutionGraph. createFrom(ExecutionGraph executionGraph, org.apache.flink.api.common.JobStatus statusOverride)
Create aArchivedExecutionGraph
from the givenExecutionGraph
.static boolean
ExecutionGraphUtils. isAnyOutputBlocking(ExecutionGraph graph)
Constructors in org.apache.flink.runtime.executiongraph with parameters of type ExecutionGraph Constructor Description ExecutionGraphCheckpointPlanCalculatorContext(ExecutionGraph executionGraph)
-
Uses of ExecutionGraph in org.apache.flink.runtime.scheduler
Methods in org.apache.flink.runtime.scheduler that return ExecutionGraph Modifier and Type Method Description ExecutionGraph
DefaultExecutionGraphFactory. 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)
ExecutionGraph
ExecutionGraphFactory. 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)
Create and restoreExecutionGraph
from the givenJobGraph
and services.ExecutionGraph
SchedulerBase. getExecutionGraph()
ExecutionGraph is exposed to make it easier to rework tests to be based on the new scheduler.Constructors in org.apache.flink.runtime.scheduler with parameters of type ExecutionGraph Constructor Description DefaultOperatorCoordinatorHandler(ExecutionGraph executionGraph, GlobalFailureHandler globalFailureHandler)
ExecutionGraphHandler(ExecutionGraph executionGraph, org.slf4j.Logger log, Executor ioExecutor, org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor mainThreadExecutor)
ExecutionGraphToInputsLocationsRetrieverAdapter(ExecutionGraph executionGraph)
KvStateHandler(ExecutionGraph executionGraph)
VertexEndOfDataListener(ExecutionGraph executionGraph)
-
Uses of ExecutionGraph in org.apache.flink.runtime.scheduler.adaptive
Methods in org.apache.flink.runtime.scheduler.adaptive with parameters of type ExecutionGraph Modifier and Type Method Description void
AdaptiveScheduler. goToCanceling(ExecutionGraph executionGraph, ExecutionGraphHandler executionGraphHandler, OperatorCoordinatorHandler operatorCoordinatorHandler, List<ExceptionHistoryEntry> failureCollection)
void
StateTransitions.ToCancelling. goToCanceling(ExecutionGraph executionGraph, ExecutionGraphHandler executionGraphHandler, OperatorCoordinatorHandler operatorCoordinatorHandler, List<ExceptionHistoryEntry> failureCollection)
Transitions into theCanceling
state.void
AdaptiveScheduler. goToCreatingExecutionGraph(ExecutionGraph previousExecutionGraph)
void
StateTransitions.ToCreatingExecutionGraph. goToCreatingExecutionGraph(ExecutionGraph previousExecutionGraph)
Transitions into theCreatingExecutionGraph
state.void
AdaptiveScheduler. goToExecuting(ExecutionGraph executionGraph, ExecutionGraphHandler executionGraphHandler, OperatorCoordinatorHandler operatorCoordinatorHandler, List<ExceptionHistoryEntry> failureCollection)
void
StateTransitions.ToExecuting. goToExecuting(ExecutionGraph executionGraph, ExecutionGraphHandler executionGraphHandler, OperatorCoordinatorHandler operatorCoordinatorHandler, List<ExceptionHistoryEntry> failureCollection)
Transitions into theExecuting
state.void
AdaptiveScheduler. goToFailing(ExecutionGraph executionGraph, ExecutionGraphHandler executionGraphHandler, OperatorCoordinatorHandler operatorCoordinatorHandler, Throwable failureCause, List<ExceptionHistoryEntry> failureCollection)
void
StateTransitions.ToFailing. goToFailing(ExecutionGraph executionGraph, ExecutionGraphHandler executionGraphHandler, OperatorCoordinatorHandler operatorCoordinatorHandler, Throwable failureCause, List<ExceptionHistoryEntry> failureCollection)
Transitions into theFailing
state.void
AdaptiveScheduler. goToRestarting(ExecutionGraph executionGraph, ExecutionGraphHandler executionGraphHandler, OperatorCoordinatorHandler operatorCoordinatorHandler, Duration backoffTime, VertexParallelism restartWithParallelism, List<ExceptionHistoryEntry> failureCollection)
void
StateTransitions.ToRestarting. goToRestarting(ExecutionGraph executionGraph, ExecutionGraphHandler executionGraphHandler, OperatorCoordinatorHandler operatorCoordinatorHandler, Duration backoffTime, VertexParallelism restartWithParallelism, List<ExceptionHistoryEntry> failureCollection)
Transitions into theRestarting
state.CompletableFuture<String>
AdaptiveScheduler. goToStopWithSavepoint(ExecutionGraph executionGraph, ExecutionGraphHandler executionGraphHandler, OperatorCoordinatorHandler operatorCoordinatorHandler, CheckpointScheduling checkpointScheduling, CompletableFuture<String> savepointFuture, List<ExceptionHistoryEntry> failureCollection)
CompletableFuture<String>
StateTransitions.ToStopWithSavepoint. goToStopWithSavepoint(ExecutionGraph executionGraph, ExecutionGraphHandler executionGraphHandler, OperatorCoordinatorHandler operatorCoordinatorHandler, CheckpointScheduling checkpointScheduling, CompletableFuture<String> savepointFuture, List<ExceptionHistoryEntry> failureCollection)
Transitions into theStopWithSavepoint
state.void
AdaptiveScheduler. goToWaitingForResources(ExecutionGraph previousExecutionGraph)
void
StateTransitions.ToWaitingForResources. goToWaitingForResources(ExecutionGraph previousExecutionGraph)
Transitions into theWaitingForResources
state.Constructors in org.apache.flink.runtime.scheduler.adaptive with parameters of type ExecutionGraph Constructor 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 previousExecutionGraph)
-
Uses of ExecutionGraph in org.apache.flink.runtime.scheduler.adaptive.allocator
Methods in org.apache.flink.runtime.scheduler.adaptive.allocator with parameters of type ExecutionGraph Modifier and Type Method Description static JobAllocationsInformation
JobAllocationsInformation. fromGraph(ExecutionGraph graph)
static StateSizeEstimates
StateSizeEstimates. fromGraph(ExecutionGraph executionGraph)
-
Uses of ExecutionGraph in org.apache.flink.runtime.scheduler.adaptivebatch
Methods in org.apache.flink.runtime.scheduler.adaptivebatch that return ExecutionGraph Modifier and Type Method Description ExecutionGraph
BatchJobRecoveryContext. getExecutionGraph()
Provides theExecutionGraph
associated with the job.Methods in org.apache.flink.runtime.scheduler.adaptivebatch with parameters of type ExecutionGraph Modifier and Type Method Description void
DefaultSpeculativeExecutionHandler. init(ExecutionGraph executionGraph, org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor mainThreadExecutor, org.apache.flink.metrics.MetricGroup metricGroup)
void
DummySpeculativeExecutionHandler. init(ExecutionGraph executionGraph, org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor mainThreadExecutor, org.apache.flink.metrics.MetricGroup metricGroup)
void
SpeculativeExecutionHandler. init(ExecutionGraph executionGraph, org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor mainThreadExecutor, org.apache.flink.metrics.MetricGroup metricGroup)
Initial speculative execution handler. -
Uses of ExecutionGraph in org.apache.flink.runtime.scheduler.slowtaskdetector
Methods in org.apache.flink.runtime.scheduler.slowtaskdetector with parameters of type ExecutionGraph Modifier and Type Method Description void
ExecutionTimeBasedSlowTaskDetector. start(ExecutionGraph executionGraph, SlowTaskDetectorListener listener, org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor mainThreadExecutor)
void
SlowTaskDetector. start(ExecutionGraph executionGraph, SlowTaskDetectorListener listener, org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor mainThreadExecutor)
Start detecting slow tasks periodically.
-