Uses of Interface
org.apache.flink.runtime.scheduler.ExecutionOperations
-
Packages that use ExecutionOperations Package Description org.apache.flink.runtime.scheduler org.apache.flink.runtime.scheduler.adaptivebatch -
-
Uses of ExecutionOperations in org.apache.flink.runtime.scheduler
Classes in org.apache.flink.runtime.scheduler that implement ExecutionOperations Modifier and Type Class Description class
DefaultExecutionOperations
Default implementation ofExecutionOperations
.Methods in org.apache.flink.runtime.scheduler with parameters of type ExecutionOperations Modifier and Type Method Description DefaultExecutionDeployer
DefaultExecutionDeployer.Factory. createInstance(org.slf4j.Logger log, ExecutionSlotAllocator executionSlotAllocator, ExecutionOperations executionOperations, ExecutionVertexVersioner executionVertexVersioner, Duration partitionRegistrationTimeout, BiConsumer<ExecutionVertexID,AllocationID> allocationReservationFunc, org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor mainThreadExecutor)
ExecutionDeployer
ExecutionDeployer.Factory. createInstance(org.slf4j.Logger log, ExecutionSlotAllocator executionSlotAllocator, ExecutionOperations executionOperations, ExecutionVertexVersioner executionVertexVersioner, Duration partitionRegistrationTimeout, BiConsumer<ExecutionVertexID,AllocationID> allocationReservationFunc, org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor mainThreadExecutor)
Instantiate anExecutionDeployer
with the given params.Constructors in org.apache.flink.runtime.scheduler with parameters of type ExecutionOperations 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)
-
Uses of ExecutionOperations in org.apache.flink.runtime.scheduler.adaptivebatch
Methods in org.apache.flink.runtime.scheduler.adaptivebatch with parameters of type ExecutionOperations Modifier and Type Method Description static AdaptiveBatchScheduler
AdaptiveBatchSchedulerFactory. createScheduler(org.slf4j.Logger log, ExecutionPlan executionPlan, org.apache.flink.api.common.ExecutionConfig executionConfig, Executor ioExecutor, org.apache.flink.configuration.Configuration jobMasterConfiguration, ScheduledExecutorService futureExecutor, ClassLoader userCodeLoader, CheckpointRecoveryFactory checkpointRecoveryFactory, CheckpointsCleaner checkpointsCleaner, Duration rpcTimeout, BlobWriter blobWriter, JobManagerJobMetricGroup jobManagerJobMetricGroup, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker partitionTracker, ExecutionDeploymentTracker executionDeploymentTracker, long initializationTimestamp, org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor mainThreadExecutor, JobStatusListener jobStatusListener, Collection<org.apache.flink.core.failure.FailureEnricher> failureEnrichers, BlocklistOperations blocklistOperations, ExecutionOperations executionOperations, ExecutionSlotAllocatorFactory allocatorFactory, RestartBackoffTimeStrategy restartBackoffTimeStrategy, org.apache.flink.util.concurrent.ScheduledExecutor delayExecutor, VertexParallelismAndInputInfosDecider vertexParallelismAndInputInfosDecider, BatchJobRecoveryHandler jobRecoveryHandler)
Constructors in org.apache.flink.runtime.scheduler.adaptivebatch with parameters of type ExecutionOperations 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)
-