public class AdaptiveSchedulerFactory extends Object implements SchedulerNGFactory
Constructor and Description |
---|
AdaptiveSchedulerFactory() |
Modifier and Type | Method and Description |
---|---|
SchedulerNG |
createInstance(org.slf4j.Logger log,
JobGraph jobGraph,
Executor ioExecutor,
Configuration jobMasterConfiguration,
SlotPoolService slotPoolService,
ScheduledExecutorService futureExecutor,
ClassLoader userCodeLoader,
CheckpointRecoveryFactory checkpointRecoveryFactory,
Time rpcTimeout,
BlobWriter blobWriter,
JobManagerJobMetricGroup jobManagerJobMetricGroup,
Time slotRequestTimeout,
ShuffleMaster<?> shuffleMaster,
JobMasterPartitionTracker partitionTracker,
ExecutionDeploymentTracker executionDeploymentTracker,
long initializationTimestamp,
ComponentMainThreadExecutor mainThreadExecutor,
FatalErrorHandler fatalErrorHandler,
JobStatusListener jobStatusListener,
Collection<FailureEnricher> failureEnrichers,
BlocklistOperations blocklistOperations) |
static SlotSharingSlotAllocator |
createSlotSharingSlotAllocator(DeclarativeSlotPool declarativeSlotPool,
boolean localRecoveryEnabled) |
JobManagerOptions.SchedulerType |
getSchedulerType() |
public SchedulerNG createInstance(org.slf4j.Logger log, JobGraph jobGraph, Executor ioExecutor, Configuration jobMasterConfiguration, SlotPoolService slotPoolService, ScheduledExecutorService futureExecutor, ClassLoader userCodeLoader, CheckpointRecoveryFactory checkpointRecoveryFactory, Time rpcTimeout, BlobWriter blobWriter, JobManagerJobMetricGroup jobManagerJobMetricGroup, Time slotRequestTimeout, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker partitionTracker, ExecutionDeploymentTracker executionDeploymentTracker, long initializationTimestamp, ComponentMainThreadExecutor mainThreadExecutor, FatalErrorHandler fatalErrorHandler, JobStatusListener jobStatusListener, Collection<FailureEnricher> failureEnrichers, BlocklistOperations blocklistOperations) throws Exception
createInstance
in interface SchedulerNGFactory
Exception
public JobManagerOptions.SchedulerType getSchedulerType()
getSchedulerType
in interface SchedulerNGFactory
public static SlotSharingSlotAllocator createSlotSharingSlotAllocator(DeclarativeSlotPool declarativeSlotPool, boolean localRecoveryEnabled)
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.