Uses of Interface
org.apache.flink.runtime.scheduler.adaptivebatch.ExecutionPlanSchedulingContext
-
Packages that use ExecutionPlanSchedulingContext Package Description org.apache.flink.runtime.executiongraph org.apache.flink.runtime.scheduler org.apache.flink.runtime.scheduler.adaptivebatch -
-
Uses of ExecutionPlanSchedulingContext in org.apache.flink.runtime.executiongraph
Methods in org.apache.flink.runtime.executiongraph with parameters of type ExecutionPlanSchedulingContext 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)
protected void
ExecutionJobVertex. initialize(int executionHistorySizeLimit, Duration timeout, long createTimestamp, SubtaskAttemptNumberStore initialAttemptCounts, ExecutionPlanSchedulingContext executionPlanSchedulingContext)
Constructors in org.apache.flink.runtime.executiongraph with parameters of type ExecutionPlanSchedulingContext 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)
IntermediateResult(IntermediateDataSet intermediateDataSet, ExecutionJobVertex producer, int numParallelProducers, ResultPartitionType resultType, ExecutionPlanSchedulingContext executionPlanSchedulingContext)
-
Uses of ExecutionPlanSchedulingContext in org.apache.flink.runtime.scheduler
Methods in org.apache.flink.runtime.scheduler with parameters of type ExecutionPlanSchedulingContext 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.Constructors in org.apache.flink.runtime.scheduler with parameters of type ExecutionPlanSchedulingContext Constructor Description DefaultScheduler(org.slf4j.Logger log, JobGraph jobGraph, Executor ioExecutor, org.apache.flink.configuration.Configuration jobMasterConfiguration, Consumer<org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor> startUpAction, org.apache.flink.util.concurrent.ScheduledExecutor delayExecutor, ClassLoader userCodeLoader, CheckpointsCleaner checkpointsCleaner, CheckpointRecoveryFactory checkpointRecoveryFactory, JobManagerJobMetricGroup jobManagerJobMetricGroup, SchedulingStrategyFactory schedulingStrategyFactory, FailoverStrategy.Factory failoverStrategyFactory, RestartBackoffTimeStrategy restartBackoffTimeStrategy, ExecutionOperations executionOperations, ExecutionVertexVersioner executionVertexVersioner, ExecutionSlotAllocatorFactory executionSlotAllocatorFactory, long initializationTimestamp, org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor mainThreadExecutor, JobStatusListener jobStatusListener, Collection<org.apache.flink.core.failure.FailureEnricher> failureEnrichers, ExecutionGraphFactory executionGraphFactory, ShuffleMaster<?> shuffleMaster, Duration rpcTimeout, VertexParallelismStore vertexParallelismStore, ExecutionDeployer.Factory executionDeployerFactory, ExecutionPlanSchedulingContext executionPlanSchedulingContext)
SchedulerBase(org.slf4j.Logger log, JobGraph jobGraph, Executor ioExecutor, org.apache.flink.configuration.Configuration jobMasterConfiguration, CheckpointsCleaner checkpointsCleaner, CheckpointRecoveryFactory checkpointRecoveryFactory, JobManagerJobMetricGroup jobManagerJobMetricGroup, ExecutionVertexVersioner executionVertexVersioner, long initializationTimestamp, org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor mainThreadExecutor, JobStatusListener jobStatusListener, ExecutionGraphFactory executionGraphFactory, VertexParallelismStore vertexParallelismStore, ExecutionPlanSchedulingContext executionPlanSchedulingContext)
-
Uses of ExecutionPlanSchedulingContext in org.apache.flink.runtime.scheduler.adaptivebatch
Classes in org.apache.flink.runtime.scheduler.adaptivebatch that implement ExecutionPlanSchedulingContext Modifier and Type Class Description class
AdaptiveExecutionPlanSchedulingContext
TheAdaptiveExecutionPlanSchedulingContext
class implements theExecutionPlanSchedulingContext
interface to provide a dynamic scheduling context that adapts execution plans based on runtime conditions.class
NonAdaptiveExecutionPlanSchedulingContext
TheNonAdaptiveExecutionPlanSchedulingContext
is a final class that implements a scheduling context for execution plans that do not require adaptive changes.Methods in org.apache.flink.runtime.scheduler.adaptivebatch that return ExecutionPlanSchedulingContext Modifier and Type Method Description ExecutionPlanSchedulingContext
AdaptiveExecutionHandler. createExecutionPlanSchedulingContext(int defaultMaxParallelism)
Creates an instance ofExecutionPlanSchedulingContext
.ExecutionPlanSchedulingContext
DefaultAdaptiveExecutionHandler. createExecutionPlanSchedulingContext(int defaultMaxParallelism)
ExecutionPlanSchedulingContext
NonAdaptiveExecutionHandler. createExecutionPlanSchedulingContext(int defaultMaxParallelism)
Constructors in org.apache.flink.runtime.scheduler.adaptivebatch with parameters of type ExecutionPlanSchedulingContext Constructor Description AdaptiveBatchScheduler(org.slf4j.Logger log, AdaptiveExecutionHandler adaptiveExecutionHandler, Executor ioExecutor, org.apache.flink.configuration.Configuration jobMasterConfiguration, Consumer<org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor> startUpAction, org.apache.flink.util.concurrent.ScheduledExecutor delayExecutor, ClassLoader userCodeLoader, CheckpointsCleaner checkpointsCleaner, CheckpointRecoveryFactory checkpointRecoveryFactory, JobManagerJobMetricGroup jobManagerJobMetricGroup, SchedulingStrategyFactory schedulingStrategyFactory, FailoverStrategy.Factory failoverStrategyFactory, RestartBackoffTimeStrategy restartBackoffTimeStrategy, ExecutionOperations executionOperations, ExecutionVertexVersioner executionVertexVersioner, ExecutionSlotAllocatorFactory executionSlotAllocatorFactory, long initializationTimestamp, org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor mainThreadExecutor, JobStatusListener jobStatusListener, Collection<org.apache.flink.core.failure.FailureEnricher> failureEnrichers, ExecutionGraphFactory executionGraphFactory, ShuffleMaster<?> shuffleMaster, Duration rpcTimeout, VertexParallelismAndInputInfosDecider vertexParallelismAndInputInfosDecider, int defaultMaxParallelism, BlocklistOperations blocklistOperations, org.apache.flink.configuration.JobManagerOptions.HybridPartitionDataConsumeConstraint hybridPartitionDataConsumeConstraint, BatchJobRecoveryHandler jobRecoveryHandler, ExecutionPlanSchedulingContext executionPlanSchedulingContext)
-