Uses of Interface
org.apache.flink.runtime.resourcemanager.JobLeaderIdService
-
Packages that use JobLeaderIdService Package Description org.apache.flink.runtime.resourcemanager org.apache.flink.runtime.resourcemanager.active -
-
Uses of JobLeaderIdService in org.apache.flink.runtime.resourcemanager
Classes in org.apache.flink.runtime.resourcemanager that implement JobLeaderIdService Modifier and Type Class Description class
DefaultJobLeaderIdService
Service which retrieves for a registered job the current job leader id (the leader id of the job manager responsible for the job).Methods in org.apache.flink.runtime.resourcemanager that return JobLeaderIdService Modifier and Type Method Description JobLeaderIdService
ResourceManagerRuntimeServices. getJobLeaderIdService()
Constructors in org.apache.flink.runtime.resourcemanager with parameters of type JobLeaderIdService Constructor Description ResourceManager(org.apache.flink.runtime.rpc.RpcService rpcService, UUID leaderSessionId, ResourceID resourceId, HeartbeatServices heartbeatServices, DelegationTokenManager delegationTokenManager, SlotManager slotManager, ResourceManagerPartitionTrackerFactory clusterPartitionTrackerFactory, BlocklistHandler.Factory blocklistHandlerFactory, JobLeaderIdService jobLeaderIdService, ClusterInformation clusterInformation, org.apache.flink.runtime.rpc.FatalErrorHandler fatalErrorHandler, ResourceManagerMetricGroup resourceManagerMetricGroup, Duration rpcTimeout, Executor ioExecutor)
ResourceManagerRuntimeServices(SlotManager slotManager, JobLeaderIdService jobLeaderIdService)
StandaloneResourceManager(org.apache.flink.runtime.rpc.RpcService rpcService, UUID leaderSessionId, ResourceID resourceId, HeartbeatServices heartbeatServices, DelegationTokenManager delegationTokenManager, SlotManager slotManager, ResourceManagerPartitionTrackerFactory clusterPartitionTrackerFactory, BlocklistHandler.Factory blocklistHandlerFactory, JobLeaderIdService jobLeaderIdService, ClusterInformation clusterInformation, org.apache.flink.runtime.rpc.FatalErrorHandler fatalErrorHandler, ResourceManagerMetricGroup resourceManagerMetricGroup, Duration startupPeriodTime, Duration rpcTimeout, Executor ioExecutor)
-
Uses of JobLeaderIdService in org.apache.flink.runtime.resourcemanager.active
Constructors in org.apache.flink.runtime.resourcemanager.active with parameters of type JobLeaderIdService Constructor Description ActiveResourceManager(ResourceManagerDriver<WorkerType> resourceManagerDriver, org.apache.flink.configuration.Configuration flinkConfig, org.apache.flink.runtime.rpc.RpcService rpcService, UUID leaderSessionId, ResourceID resourceId, HeartbeatServices heartbeatServices, DelegationTokenManager delegationTokenManager, SlotManager slotManager, ResourceManagerPartitionTrackerFactory clusterPartitionTrackerFactory, BlocklistHandler.Factory blocklistHandlerFactory, JobLeaderIdService jobLeaderIdService, ClusterInformation clusterInformation, org.apache.flink.runtime.rpc.FatalErrorHandler fatalErrorHandler, ResourceManagerMetricGroup resourceManagerMetricGroup, ThresholdMeter startWorkerFailureRater, Duration retryInterval, Duration workerRegistrationTimeout, Duration previousWorkerRecoverTimeout, Executor ioExecutor)
-