Uses of Interface
org.apache.flink.runtime.jobmaster.slotpool.SlotPoolService
-
-
Uses of SlotPoolService in org.apache.flink.runtime.jobmaster
Methods in org.apache.flink.runtime.jobmaster that return SlotPoolService Modifier and Type Method Description SlotPoolService
DefaultSlotPoolServiceSchedulerFactory. createSlotPoolService(JobID jid, DeclarativeSlotPoolFactory declarativeSlotPoolFactory, ComponentMainThreadExecutor componentMainThreadExecutor)
SlotPoolService
SlotPoolServiceSchedulerFactory. createSlotPoolService(JobID jid, DeclarativeSlotPoolFactory declarativeSlotPoolFactory, ComponentMainThreadExecutor componentMainThreadExecutor)
Creates aSlotPoolService
.Methods in org.apache.flink.runtime.jobmaster with parameters of type SlotPoolService Modifier and Type Method Description SchedulerNG
DefaultSlotPoolServiceSchedulerFactory. createScheduler(org.slf4j.Logger log, ExecutionPlan executionPlan, Executor ioExecutor, Configuration configuration, SlotPoolService slotPoolService, ScheduledExecutorService futureExecutor, ClassLoader userCodeLoader, CheckpointRecoveryFactory checkpointRecoveryFactory, Duration rpcTimeout, BlobWriter blobWriter, JobManagerJobMetricGroup jobManagerJobMetricGroup, Duration slotRequestTimeout, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker partitionTracker, ExecutionDeploymentTracker executionDeploymentTracker, long initializationTimestamp, ComponentMainThreadExecutor mainThreadExecutor, FatalErrorHandler fatalErrorHandler, JobStatusListener jobStatusListener, Collection<FailureEnricher> failureEnrichers, BlocklistOperations blocklistOperations)
SchedulerNG
SlotPoolServiceSchedulerFactory. createScheduler(org.slf4j.Logger log, ExecutionPlan executionPlan, Executor ioExecutor, Configuration configuration, SlotPoolService slotPoolService, ScheduledExecutorService futureExecutor, ClassLoader userCodeLoader, CheckpointRecoveryFactory checkpointRecoveryFactory, Duration rpcTimeout, BlobWriter blobWriter, JobManagerJobMetricGroup jobManagerJobMetricGroup, Duration slotRequestTimeout, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker partitionTracker, ExecutionDeploymentTracker executionDeploymentTracker, long initializationTimestamp, ComponentMainThreadExecutor mainThreadExecutor, FatalErrorHandler fatalErrorHandler, JobStatusListener jobStatusListener, Collection<FailureEnricher> failureEnrichers, BlocklistOperations blocklistOperations)
Creates aSchedulerNG
. -
Uses of SlotPoolService in org.apache.flink.runtime.jobmaster.slotpool
Classes in org.apache.flink.runtime.jobmaster.slotpool that implement SlotPoolService Modifier and Type Class Description class
DeclarativeSlotPoolBridge
SlotPool
implementation which uses theDeclarativeSlotPool
to allocate slots.class
DeclarativeSlotPoolService
SlotPoolService
implementation for theDeclarativeSlotPool
.Methods in org.apache.flink.runtime.jobmaster.slotpool that return SlotPoolService Modifier and Type Method Description SlotPoolService
DeclarativeSlotPoolBridgeServiceFactory. createSlotPoolService(JobID jobId, DeclarativeSlotPoolFactory declarativeSlotPoolFactory, ComponentMainThreadExecutor componentMainThreadExecutor)
SlotPoolService
DeclarativeSlotPoolServiceFactory. createSlotPoolService(JobID jobId, DeclarativeSlotPoolFactory declarativeSlotPoolFactory, ComponentMainThreadExecutor componentMainThreadExecutor)
SlotPoolService
SlotPoolServiceFactory. createSlotPoolService(JobID jobId, DeclarativeSlotPoolFactory declarativeSlotPoolFactory, ComponentMainThreadExecutor componentMainThreadExecutor)
-
Uses of SlotPoolService in org.apache.flink.runtime.scheduler
Methods in org.apache.flink.runtime.scheduler with parameters of type SlotPoolService Modifier and Type Method Description SchedulerNG
DefaultSchedulerFactory. createInstance(org.slf4j.Logger log, ExecutionPlan executionPlan, Executor ioExecutor, Configuration jobMasterConfiguration, SlotPoolService slotPoolService, ScheduledExecutorService futureExecutor, ClassLoader userCodeLoader, CheckpointRecoveryFactory checkpointRecoveryFactory, Duration rpcTimeout, BlobWriter blobWriter, JobManagerJobMetricGroup jobManagerJobMetricGroup, Duration slotRequestTimeout, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker partitionTracker, ExecutionDeploymentTracker executionDeploymentTracker, long initializationTimestamp, ComponentMainThreadExecutor mainThreadExecutor, FatalErrorHandler fatalErrorHandler, JobStatusListener jobStatusListener, Collection<FailureEnricher> failureEnrichers, BlocklistOperations blocklistOperations)
SchedulerNG
SchedulerNGFactory. createInstance(org.slf4j.Logger log, ExecutionPlan executionPlan, Executor ioExecutor, Configuration jobMasterConfiguration, SlotPoolService slotPoolService, ScheduledExecutorService futureExecutor, ClassLoader userCodeLoader, CheckpointRecoveryFactory checkpointRecoveryFactory, Duration rpcTimeout, BlobWriter blobWriter, JobManagerJobMetricGroup jobManagerJobMetricGroup, Duration slotRequestTimeout, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker partitionTracker, ExecutionDeploymentTracker executionDeploymentTracker, long initializationTimestamp, ComponentMainThreadExecutor mainThreadExecutor, FatalErrorHandler fatalErrorHandler, JobStatusListener jobStatusListener, Collection<FailureEnricher> failureEnrichers, BlocklistOperations blocklistOperations)
-
Uses of SlotPoolService in org.apache.flink.runtime.scheduler.adaptive
Methods in org.apache.flink.runtime.scheduler.adaptive with parameters of type SlotPoolService Modifier and Type Method Description SchedulerNG
AdaptiveSchedulerFactory. createInstance(org.slf4j.Logger log, ExecutionPlan executionPlan, Executor ioExecutor, Configuration jobMasterConfiguration, SlotPoolService slotPoolService, ScheduledExecutorService futureExecutor, ClassLoader userCodeLoader, CheckpointRecoveryFactory checkpointRecoveryFactory, Duration rpcTimeout, BlobWriter blobWriter, JobManagerJobMetricGroup jobManagerJobMetricGroup, Duration slotRequestTimeout, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker partitionTracker, ExecutionDeploymentTracker executionDeploymentTracker, long initializationTimestamp, ComponentMainThreadExecutor mainThreadExecutor, FatalErrorHandler fatalErrorHandler, JobStatusListener jobStatusListener, Collection<FailureEnricher> failureEnrichers, BlocklistOperations blocklistOperations)
-
Uses of SlotPoolService in org.apache.flink.runtime.scheduler.adaptivebatch
Methods in org.apache.flink.runtime.scheduler.adaptivebatch with parameters of type SlotPoolService Modifier and Type Method Description SchedulerNG
AdaptiveBatchSchedulerFactory. createInstance(org.slf4j.Logger log, ExecutionPlan executionPlan, Executor ioExecutor, Configuration jobMasterConfiguration, SlotPoolService slotPoolService, ScheduledExecutorService futureExecutor, ClassLoader userCodeLoader, CheckpointRecoveryFactory checkpointRecoveryFactory, Duration rpcTimeout, BlobWriter blobWriter, JobManagerJobMetricGroup jobManagerJobMetricGroup, Duration slotRequestTimeout, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker partitionTracker, ExecutionDeploymentTracker executionDeploymentTracker, long initializationTimestamp, ComponentMainThreadExecutor mainThreadExecutor, FatalErrorHandler fatalErrorHandler, JobStatusListener jobStatusListener, Collection<FailureEnricher> failureEnrichers, BlocklistOperations blocklistOperations)
-