Uses of Interface
org.apache.flink.runtime.scheduler.adaptivebatch.AdaptiveExecutionHandler
-
Packages that use AdaptiveExecutionHandler Package Description org.apache.flink.runtime.scheduler.adaptivebatch -
-
Uses of AdaptiveExecutionHandler in org.apache.flink.runtime.scheduler.adaptivebatch
Classes in org.apache.flink.runtime.scheduler.adaptivebatch that implement AdaptiveExecutionHandler Modifier and Type Class Description class
DefaultAdaptiveExecutionHandler
TheDefaultAdaptiveExecutionHandler
implements theAdaptiveExecutionHandler
interface to provide an incrementally generated job graph.class
NonAdaptiveExecutionHandler
ANonAdaptiveExecutionHandler
implements theAdaptiveExecutionHandler
interface to provide an immutable static job graph.Methods in org.apache.flink.runtime.scheduler.adaptivebatch that return AdaptiveExecutionHandler Modifier and Type Method Description static AdaptiveExecutionHandler
AdaptiveExecutionHandlerFactory. create(ExecutionPlan executionPlan, boolean enableBatchJobRecovery, ClassLoader userClassLoader, Executor serializationExecutor)
Creates an instance ofAdaptiveExecutionHandler
based on the provided execution plan.Constructors in org.apache.flink.runtime.scheduler.adaptivebatch with parameters of type AdaptiveExecutionHandler 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)
-