Uses of Interface
org.apache.flink.runtime.jobmaster.SlotPoolServiceSchedulerFactory
-
Packages that use SlotPoolServiceSchedulerFactory Package Description org.apache.flink.runtime.jobmaster org.apache.flink.runtime.jobmaster.factories -
-
Uses of SlotPoolServiceSchedulerFactory in org.apache.flink.runtime.jobmaster
Classes in org.apache.flink.runtime.jobmaster that implement SlotPoolServiceSchedulerFactory Modifier and Type Class Description class
DefaultSlotPoolServiceSchedulerFactory
DefaultSlotPoolServiceSchedulerFactory
implementation.Constructors in org.apache.flink.runtime.jobmaster with parameters of type SlotPoolServiceSchedulerFactory Constructor Description JobMaster(org.apache.flink.runtime.rpc.RpcService rpcService, JobMasterId jobMasterId, JobMasterConfiguration jobMasterConfiguration, ResourceID resourceId, ExecutionPlan executionPlan, HighAvailabilityServices highAvailabilityService, SlotPoolServiceSchedulerFactory slotPoolServiceSchedulerFactory, JobManagerSharedServices jobManagerSharedServices, HeartbeatServices heartbeatServices, JobManagerJobMetricGroupFactory jobMetricGroupFactory, OnCompletionActions jobCompletionActions, org.apache.flink.runtime.rpc.FatalErrorHandler fatalErrorHandler, ClassLoader userCodeLoader, ShuffleMaster<?> shuffleMaster, PartitionTrackerFactory partitionTrackerFactory, ExecutionDeploymentTracker executionDeploymentTracker, ExecutionDeploymentReconciler.Factory executionDeploymentReconcilerFactory, BlocklistHandler.Factory blocklistHandlerFactory, Collection<org.apache.flink.core.failure.FailureEnricher> failureEnrichers, long initializationTimestamp)
-
Uses of SlotPoolServiceSchedulerFactory in org.apache.flink.runtime.jobmaster.factories
Constructors in org.apache.flink.runtime.jobmaster.factories with parameters of type SlotPoolServiceSchedulerFactory Constructor Description DefaultJobMasterServiceFactory(Executor executor, org.apache.flink.runtime.rpc.RpcService rpcService, JobMasterConfiguration jobMasterConfiguration, ExecutionPlan executionPlan, HighAvailabilityServices haServices, SlotPoolServiceSchedulerFactory slotPoolServiceSchedulerFactory, JobManagerSharedServices jobManagerSharedServices, HeartbeatServices heartbeatServices, JobManagerJobMetricGroupFactory jobManagerJobMetricGroupFactory, org.apache.flink.runtime.rpc.FatalErrorHandler fatalErrorHandler, ClassLoader userCodeClassloader, Collection<org.apache.flink.core.failure.FailureEnricher> failureEnrichers, long initializationTimestamp)
-