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 classDefaultExecutionGraphDefault implementation of theExecutionGraph.Methods in org.apache.flink.runtime.executiongraph with parameters of type ExecutionGraph Modifier and Type Method Description static ArchivedExecutionGraphArchivedExecutionGraph. createFrom(ExecutionGraph executionGraph)Create aArchivedExecutionGraphfrom the givenExecutionGraph.static ArchivedExecutionGraphArchivedExecutionGraph. createFrom(ExecutionGraph executionGraph, org.apache.flink.api.common.JobStatus statusOverride)Create aArchivedExecutionGraphfrom the givenExecutionGraph.static booleanExecutionGraphUtils. 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 ExecutionGraphDefaultExecutionGraphFactory. 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)ExecutionGraphExecutionGraphFactory. 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 restoreExecutionGraphfrom the givenJobGraphand services.ExecutionGraphSchedulerBase. 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 voidAdaptiveScheduler. goToCanceling(ExecutionGraph executionGraph, ExecutionGraphHandler executionGraphHandler, OperatorCoordinatorHandler operatorCoordinatorHandler, List<ExceptionHistoryEntry> failureCollection)voidStateTransitions.ToCancelling. goToCanceling(ExecutionGraph executionGraph, ExecutionGraphHandler executionGraphHandler, OperatorCoordinatorHandler operatorCoordinatorHandler, List<ExceptionHistoryEntry> failureCollection)Transitions into theCancelingstate.voidAdaptiveScheduler. goToCreatingExecutionGraph(ExecutionGraph previousExecutionGraph)voidStateTransitions.ToCreatingExecutionGraph. goToCreatingExecutionGraph(ExecutionGraph previousExecutionGraph)Transitions into theCreatingExecutionGraphstate.voidAdaptiveScheduler. goToExecuting(ExecutionGraph executionGraph, ExecutionGraphHandler executionGraphHandler, OperatorCoordinatorHandler operatorCoordinatorHandler, List<ExceptionHistoryEntry> failureCollection)voidStateTransitions.ToExecuting. goToExecuting(ExecutionGraph executionGraph, ExecutionGraphHandler executionGraphHandler, OperatorCoordinatorHandler operatorCoordinatorHandler, List<ExceptionHistoryEntry> failureCollection)Transitions into theExecutingstate.voidAdaptiveScheduler. goToFailing(ExecutionGraph executionGraph, ExecutionGraphHandler executionGraphHandler, OperatorCoordinatorHandler operatorCoordinatorHandler, Throwable failureCause, List<ExceptionHistoryEntry> failureCollection)voidStateTransitions.ToFailing. goToFailing(ExecutionGraph executionGraph, ExecutionGraphHandler executionGraphHandler, OperatorCoordinatorHandler operatorCoordinatorHandler, Throwable failureCause, List<ExceptionHistoryEntry> failureCollection)Transitions into theFailingstate.voidAdaptiveScheduler. goToRestarting(ExecutionGraph executionGraph, ExecutionGraphHandler executionGraphHandler, OperatorCoordinatorHandler operatorCoordinatorHandler, Duration backoffTime, VertexParallelism restartWithParallelism, List<ExceptionHistoryEntry> failureCollection)voidStateTransitions.ToRestarting. goToRestarting(ExecutionGraph executionGraph, ExecutionGraphHandler executionGraphHandler, OperatorCoordinatorHandler operatorCoordinatorHandler, Duration backoffTime, VertexParallelism restartWithParallelism, List<ExceptionHistoryEntry> failureCollection)Transitions into theRestartingstate.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 theStopWithSavepointstate.voidAdaptiveScheduler. goToWaitingForResources(ExecutionGraph previousExecutionGraph)voidStateTransitions.ToWaitingForResources. goToWaitingForResources(ExecutionGraph previousExecutionGraph)Transitions into theWaitingForResourcesstate.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 JobAllocationsInformationJobAllocationsInformation. fromGraphAndState(ExecutionGraph graph, CompletedCheckpoint latestCheckpoint)static StateSizeEstimatesStateSizeEstimates. fromGraphAndState(ExecutionGraph executionGraph, CompletedCheckpoint latestCheckpoint) -
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 ExecutionGraphBatchJobRecoveryContext. getExecutionGraph()Provides theExecutionGraphassociated with the job.Methods in org.apache.flink.runtime.scheduler.adaptivebatch with parameters of type ExecutionGraph Modifier and Type Method Description voidDefaultSpeculativeExecutionHandler. init(ExecutionGraph executionGraph, org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor mainThreadExecutor, org.apache.flink.metrics.MetricGroup metricGroup)voidDummySpeculativeExecutionHandler. init(ExecutionGraph executionGraph, org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor mainThreadExecutor, org.apache.flink.metrics.MetricGroup metricGroup)voidSpeculativeExecutionHandler. 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 voidExecutionTimeBasedSlowTaskDetector. start(ExecutionGraph executionGraph, SlowTaskDetectorListener listener, org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor mainThreadExecutor)voidSlowTaskDetector. start(ExecutionGraph executionGraph, SlowTaskDetectorListener listener, org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor mainThreadExecutor)Start detecting slow tasks periodically.
-