@InterfaceAudience.Private @InterfaceStability.Unstable public class RMActiveServiceContext extends Object
| Constructor and Description | 
|---|
| RMActiveServiceContext() | 
| RMActiveServiceContext(org.apache.hadoop.yarn.event.Dispatcher rmDispatcher,
                      ContainerAllocationExpirer containerAllocationExpirer,
                      AMLivelinessMonitor amLivelinessMonitor,
                      AMLivelinessMonitor amFinishingMonitor,
                      DelegationTokenRenewer delegationTokenRenewer,
                      AMRMTokenSecretManager appTokenSecretManager,
                      RMContainerTokenSecretManager containerTokenSecretManager,
                      NMTokenSecretManagerInRM nmTokenSecretManager,
                      ClientToAMTokenSecretManagerInRM clientToAMTokenSecretManager,
                      ResourceScheduler scheduler) | 
public RMActiveServiceContext()
@InterfaceAudience.Private
 @InterfaceStability.Unstable
public RMActiveServiceContext(org.apache.hadoop.yarn.event.Dispatcher rmDispatcher,
                                                                                       ContainerAllocationExpirer containerAllocationExpirer,
                                                                                       AMLivelinessMonitor amLivelinessMonitor,
                                                                                       AMLivelinessMonitor amFinishingMonitor,
                                                                                       DelegationTokenRenewer delegationTokenRenewer,
                                                                                       AMRMTokenSecretManager appTokenSecretManager,
                                                                                       RMContainerTokenSecretManager containerTokenSecretManager,
                                                                                       NMTokenSecretManagerInRM nmTokenSecretManager,
                                                                                       ClientToAMTokenSecretManagerInRM clientToAMTokenSecretManager,
                                                                                       ResourceScheduler scheduler)
@InterfaceAudience.Private @InterfaceStability.Unstable public void setStateStore(RMStateStore store)
@InterfaceAudience.Private @InterfaceStability.Unstable public ClientRMService getClientRMService()
@InterfaceAudience.Private @InterfaceStability.Unstable public ApplicationMasterService getApplicationMasterService()
@InterfaceAudience.Private @InterfaceStability.Unstable public ResourceTrackerService getResourceTrackerService()
@InterfaceAudience.Private @InterfaceStability.Unstable public RMStateStore getStateStore()
@InterfaceAudience.Private @InterfaceStability.Unstable public ConcurrentMap<org.apache.hadoop.yarn.api.records.ApplicationId,RMApp> getRMApps()
@InterfaceAudience.Private @InterfaceStability.Unstable public ConcurrentMap<org.apache.hadoop.yarn.api.records.NodeId,RMNode> getRMNodes()
@InterfaceAudience.Private @InterfaceStability.Unstable public ConcurrentMap<org.apache.hadoop.yarn.api.records.NodeId,RMNode> getInactiveRMNodes()
@InterfaceAudience.Private @InterfaceStability.Unstable public ContainerAllocationExpirer getContainerAllocationExpirer()
@InterfaceAudience.Private @InterfaceStability.Unstable public AMLivelinessMonitor getAMLivelinessMonitor()
@InterfaceAudience.Private @InterfaceStability.Unstable public AMLivelinessMonitor getAMFinishingMonitor()
@InterfaceAudience.Private @InterfaceStability.Unstable public DelegationTokenRenewer getDelegationTokenRenewer()
@InterfaceAudience.Private @InterfaceStability.Unstable public AMRMTokenSecretManager getAMRMTokenSecretManager()
@InterfaceAudience.Private @InterfaceStability.Unstable public RMContainerTokenSecretManager getContainerTokenSecretManager()
@InterfaceAudience.Private @InterfaceStability.Unstable public NMTokenSecretManagerInRM getNMTokenSecretManager()
@InterfaceAudience.Private @InterfaceStability.Unstable public ResourceScheduler getScheduler()
@InterfaceAudience.Private @InterfaceStability.Unstable public ReservationSystem getReservationSystem()
@InterfaceAudience.Private @InterfaceStability.Unstable public NodesListManager getNodesListManager()
@InterfaceAudience.Private @InterfaceStability.Unstable public ClientToAMTokenSecretManagerInRM getClientToAMTokenSecretManager()
@InterfaceAudience.Private @InterfaceStability.Unstable public void setClientRMService(ClientRMService clientRMService)
@InterfaceAudience.Private @InterfaceStability.Unstable public RMDelegationTokenSecretManager getRMDelegationTokenSecretManager()
@InterfaceAudience.Private @InterfaceStability.Unstable public void setRMDelegationTokenSecretManager(RMDelegationTokenSecretManager delegationTokenSecretManager)
@InterfaceAudience.Private @InterfaceStability.Unstable public void setWorkPreservingRecoveryEnabled(boolean enabled)
@InterfaceAudience.Private @InterfaceStability.Unstable public boolean isWorkPreservingRecoveryEnabled()
@InterfaceAudience.Private @InterfaceStability.Unstable public long getEpoch()
@InterfaceAudience.Private @InterfaceStability.Unstable public RMNodeLabelsManager getNodeLabelManager()
@InterfaceAudience.Private @InterfaceStability.Unstable public void setNodeLabelManager(RMNodeLabelsManager mgr)
@InterfaceAudience.Private @InterfaceStability.Unstable public org.apache.hadoop.yarn.nodelabels.NodeAttributesManager getNodeAttributesManager()
@InterfaceAudience.Private @InterfaceStability.Unstable public void setNodeAttributesManager(org.apache.hadoop.yarn.nodelabels.NodeAttributesManager mgr)
@InterfaceAudience.Private @InterfaceStability.Unstable public AllocationTagsManager getAllocationTagsManager()
@InterfaceAudience.Private @InterfaceStability.Unstable public void setAllocationTagsManager(AllocationTagsManager allocationTagsManager)
@InterfaceAudience.Private @InterfaceStability.Unstable public PlacementConstraintManager getPlacementConstraintManager()
@InterfaceAudience.Private @InterfaceStability.Unstable public void setPlacementConstraintManager(PlacementConstraintManager placementConstraintManager)
@InterfaceAudience.Private @InterfaceStability.Unstable public RMDelegatedNodeLabelsUpdater getRMDelegatedNodeLabelsUpdater()
@InterfaceAudience.Private @InterfaceStability.Unstable public void setRMDelegatedNodeLabelsUpdater(RMDelegatedNodeLabelsUpdater nodeLablesUpdater)
@InterfaceAudience.Private @InterfaceStability.Unstable public MultiNodeSortingManager<SchedulerNode> getMultiNodeSortingManager()
@InterfaceAudience.Private @InterfaceStability.Unstable public void setMultiNodeSortingManager(MultiNodeSortingManager<SchedulerNode> multiNodeSortingManager)
@InterfaceAudience.Private @InterfaceStability.Unstable public void setSchedulerRecoveryStartAndWaitTime(long waitTime)
@InterfaceAudience.Private @InterfaceStability.Unstable public boolean isSchedulerReadyForAllocatingContainers()
@InterfaceAudience.Private @InterfaceStability.Unstable public void setSystemClock(org.apache.hadoop.yarn.util.Clock clock)
@InterfaceAudience.Private @InterfaceStability.Unstable public ConcurrentMap<org.apache.hadoop.yarn.api.records.ApplicationId,org.apache.hadoop.yarn.proto.YarnServerCommonServiceProtos.SystemCredentialsForAppsProto> getSystemCredentialsForApps()
@InterfaceAudience.Private @InterfaceStability.Unstable public PlacementManager getQueuePlacementManager()
@InterfaceAudience.Private @InterfaceStability.Unstable public void setQueuePlacementManager(PlacementManager placementMgr)
@InterfaceAudience.Private @InterfaceStability.Unstable public void setRMAppLifetimeMonitor(RMAppLifetimeMonitor lifetimeMonitor)
@InterfaceAudience.Private @InterfaceStability.Unstable public RMAppLifetimeMonitor getRMAppLifetimeMonitor()
@InterfaceAudience.Private @InterfaceStability.Unstable public QueueLimitCalculator getNodeManagerQueueLimitCalculator()
@InterfaceAudience.Private @InterfaceStability.Unstable public void setContainerQueueLimitCalculator(QueueLimitCalculator limitCalculator)
public ResourceProfilesManager getResourceProfilesManager()
public void setResourceProfilesManager(ResourceProfilesManager resourceProfilesManager)
@InterfaceAudience.Private @InterfaceStability.Unstable public ProxyCAManager getProxyCAManager()
@InterfaceAudience.Private @InterfaceStability.Unstable public void setProxyCAManager(ProxyCAManager proxyCAManager)
@InterfaceAudience.Private @InterfaceStability.Unstable public VolumeManager getVolumeManager()
@InterfaceAudience.Private @InterfaceStability.Unstable public void setVolumeManager(VolumeManager volumeManager)
public Long getTokenSequenceNo()
public void incrTokenSequenceNo()
Copyright © 2008–2025 Apache Software Foundation. All rights reserved.