Uses of Interface
org.apache.flink.runtime.executiongraph.MarkPartitionFinishedStrategy
-
Packages that use MarkPartitionFinishedStrategy Package Description org.apache.flink.runtime.executiongraph org.apache.flink.runtime.scheduler org.apache.flink.runtime.scheduler.adaptivebatch -
-
Uses of MarkPartitionFinishedStrategy in org.apache.flink.runtime.executiongraph
Methods in org.apache.flink.runtime.executiongraph that return MarkPartitionFinishedStrategy Modifier and Type Method Description MarkPartitionFinishedStrategy
DefaultExecutionGraph. getMarkPartitionFinishedStrategy()
MarkPartitionFinishedStrategy
InternalExecutionGraphAccessor. getMarkPartitionFinishedStrategy()
Methods in org.apache.flink.runtime.executiongraph with parameters of type MarkPartitionFinishedStrategy Modifier and Type Method Description static DefaultExecutionGraph
DefaultExecutionGraphBuilder. buildGraph(JobGraph jobGraph, org.apache.flink.configuration.Configuration jobManagerConfig, ScheduledExecutorService futureExecutor, Executor ioExecutor, ClassLoader classLoader, CompletedCheckpointStore completedCheckpointStore, CheckpointsCleaner checkpointsCleaner, CheckpointIDCounter checkpointIdCounter, Duration rpcTimeout, BlobWriter blobWriter, org.slf4j.Logger log, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker partitionTracker, TaskDeploymentDescriptorFactory.PartitionLocationConstraint partitionLocationConstraint, ExecutionDeploymentListener executionDeploymentListener, ExecutionStateUpdateListener executionStateUpdateListener, long initializationTimestamp, VertexAttemptNumberStore vertexAttemptNumberStore, VertexParallelismStore vertexParallelismStore, CheckpointStatsTracker checkpointStatsTracker, boolean isDynamicGraph, ExecutionJobVertex.Factory executionJobVertexFactory, MarkPartitionFinishedStrategy markPartitionFinishedStrategy, boolean nonFinishedHybridPartitionShouldBeUnknown, JobManagerJobMetricGroup jobManagerJobMetricGroup, ExecutionPlanSchedulingContext executionPlanSchedulingContext)
Constructors in org.apache.flink.runtime.executiongraph with parameters of type MarkPartitionFinishedStrategy Constructor Description DefaultExecutionGraph(JobInformation jobInformation, ScheduledExecutorService futureExecutor, Executor ioExecutor, Duration rpcTimeout, int executionHistorySizeLimit, ClassLoader userClassLoader, BlobWriter blobWriter, PartitionGroupReleaseStrategy.Factory partitionGroupReleaseStrategyFactory, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker partitionTracker, ExecutionDeploymentListener executionDeploymentListener, ExecutionStateUpdateListener executionStateUpdateListener, long initializationTimestamp, VertexAttemptNumberStore initialAttemptCounts, VertexParallelismStore vertexParallelismStore, boolean isDynamic, ExecutionJobVertex.Factory executionJobVertexFactory, List<org.apache.flink.core.execution.JobStatusHook> jobStatusHooks, MarkPartitionFinishedStrategy markPartitionFinishedStrategy, TaskDeploymentDescriptorFactory taskDeploymentDescriptorFactory, List<org.apache.flink.core.execution.JobStatusChangedListener> jobStatusChangedListeners, ExecutionPlanSchedulingContext executionPlanSchedulingContext)
-
Uses of MarkPartitionFinishedStrategy in org.apache.flink.runtime.scheduler
Methods in org.apache.flink.runtime.scheduler that return MarkPartitionFinishedStrategy Modifier and Type Method Description protected MarkPartitionFinishedStrategy
SchedulerBase. getMarkPartitionFinishedStrategy()
Methods in org.apache.flink.runtime.scheduler with parameters of type MarkPartitionFinishedStrategy 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. -
Uses of MarkPartitionFinishedStrategy in org.apache.flink.runtime.scheduler.adaptivebatch
Methods in org.apache.flink.runtime.scheduler.adaptivebatch that return MarkPartitionFinishedStrategy Modifier and Type Method Description protected MarkPartitionFinishedStrategy
AdaptiveBatchScheduler. getMarkPartitionFinishedStrategy()
-