Package | Description |
---|---|
org.apache.flink.runtime.resourcemanager | |
org.apache.flink.runtime.resourcemanager.active |
Modifier and Type | Class and 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).
|
Modifier and Type | Method and Description |
---|---|
JobLeaderIdService |
ResourceManagerRuntimeServices.getJobLeaderIdService() |
Constructor and Description |
---|
ResourceManager(RpcService rpcService,
UUID leaderSessionId,
ResourceID resourceId,
HeartbeatServices heartbeatServices,
DelegationTokenManager delegationTokenManager,
SlotManager slotManager,
ResourceManagerPartitionTrackerFactory clusterPartitionTrackerFactory,
BlocklistHandler.Factory blocklistHandlerFactory,
JobLeaderIdService jobLeaderIdService,
ClusterInformation clusterInformation,
FatalErrorHandler fatalErrorHandler,
ResourceManagerMetricGroup resourceManagerMetricGroup,
Time rpcTimeout,
Executor ioExecutor) |
ResourceManagerRuntimeServices(SlotManager slotManager,
JobLeaderIdService jobLeaderIdService) |
StandaloneResourceManager(RpcService rpcService,
UUID leaderSessionId,
ResourceID resourceId,
HeartbeatServices heartbeatServices,
DelegationTokenManager delegationTokenManager,
SlotManager slotManager,
ResourceManagerPartitionTrackerFactory clusterPartitionTrackerFactory,
BlocklistHandler.Factory blocklistHandlerFactory,
JobLeaderIdService jobLeaderIdService,
ClusterInformation clusterInformation,
FatalErrorHandler fatalErrorHandler,
ResourceManagerMetricGroup resourceManagerMetricGroup,
Time startupPeriodTime,
Time rpcTimeout,
Executor ioExecutor) |
Constructor and Description |
---|
ActiveResourceManager(ResourceManagerDriver<WorkerType> resourceManagerDriver,
Configuration flinkConfig,
RpcService rpcService,
UUID leaderSessionId,
ResourceID resourceId,
HeartbeatServices heartbeatServices,
DelegationTokenManager delegationTokenManager,
SlotManager slotManager,
ResourceManagerPartitionTrackerFactory clusterPartitionTrackerFactory,
BlocklistHandler.Factory blocklistHandlerFactory,
JobLeaderIdService jobLeaderIdService,
ClusterInformation clusterInformation,
FatalErrorHandler fatalErrorHandler,
ResourceManagerMetricGroup resourceManagerMetricGroup,
ThresholdMeter startWorkerFailureRater,
java.time.Duration retryInterval,
java.time.Duration workerRegistrationTimeout,
java.time.Duration previousWorkerRecoverTimeout,
Executor ioExecutor) |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.