Uses of Class
org.apache.flink.runtime.jobmaster.JobManagerSharedServices
-
Packages that use JobManagerSharedServices Package Description org.apache.flink.runtime.dispatcher org.apache.flink.runtime.jobmaster org.apache.flink.runtime.jobmaster.factories -
-
Uses of JobManagerSharedServices in org.apache.flink.runtime.dispatcher
Methods in org.apache.flink.runtime.dispatcher with parameters of type JobManagerSharedServices Modifier and Type Method Description JobManagerRunner
JobManagerRunnerFactory. createJobManagerRunner(ExecutionPlan executionPlan, Configuration configuration, RpcService rpcService, HighAvailabilityServices highAvailabilityServices, HeartbeatServices heartbeatServices, JobManagerSharedServices jobManagerServices, JobManagerJobMetricGroupFactory jobManagerJobMetricGroupFactory, FatalErrorHandler fatalErrorHandler, Collection<FailureEnricher> failureEnrichers, long initializationTimestamp)
JobManagerRunner
JobMasterServiceLeadershipRunnerFactory. createJobManagerRunner(ExecutionPlan executionPlan, Configuration configuration, RpcService rpcService, HighAvailabilityServices highAvailabilityServices, HeartbeatServices heartbeatServices, JobManagerSharedServices jobManagerServices, JobManagerJobMetricGroupFactory jobManagerJobMetricGroupFactory, FatalErrorHandler fatalErrorHandler, Collection<FailureEnricher> failureEnrichers, long initializationTimestamp)
-
Uses of JobManagerSharedServices in org.apache.flink.runtime.jobmaster
Methods in org.apache.flink.runtime.jobmaster that return JobManagerSharedServices Modifier and Type Method Description static JobManagerSharedServices
JobManagerSharedServices. fromConfiguration(Configuration config, BlobServer blobServer, FatalErrorHandler fatalErrorHandler)
Constructors in org.apache.flink.runtime.jobmaster with parameters of type JobManagerSharedServices Constructor Description JobMaster(RpcService rpcService, JobMasterId jobMasterId, JobMasterConfiguration jobMasterConfiguration, ResourceID resourceId, ExecutionPlan executionPlan, HighAvailabilityServices highAvailabilityService, SlotPoolServiceSchedulerFactory slotPoolServiceSchedulerFactory, JobManagerSharedServices jobManagerSharedServices, HeartbeatServices heartbeatServices, JobManagerJobMetricGroupFactory jobMetricGroupFactory, OnCompletionActions jobCompletionActions, FatalErrorHandler fatalErrorHandler, ClassLoader userCodeLoader, ShuffleMaster<?> shuffleMaster, PartitionTrackerFactory partitionTrackerFactory, ExecutionDeploymentTracker executionDeploymentTracker, ExecutionDeploymentReconciler.Factory executionDeploymentReconcilerFactory, BlocklistHandler.Factory blocklistHandlerFactory, Collection<FailureEnricher> failureEnrichers, long initializationTimestamp)
-
Uses of JobManagerSharedServices in org.apache.flink.runtime.jobmaster.factories
Constructors in org.apache.flink.runtime.jobmaster.factories with parameters of type JobManagerSharedServices Constructor Description DefaultJobMasterServiceFactory(Executor executor, RpcService rpcService, JobMasterConfiguration jobMasterConfiguration, ExecutionPlan executionPlan, HighAvailabilityServices haServices, SlotPoolServiceSchedulerFactory slotPoolServiceSchedulerFactory, JobManagerSharedServices jobManagerSharedServices, HeartbeatServices heartbeatServices, JobManagerJobMetricGroupFactory jobManagerJobMetricGroupFactory, FatalErrorHandler fatalErrorHandler, ClassLoader userCodeClassloader, Collection<FailureEnricher> failureEnrichers, long initializationTimestamp)
-