| Modifier and Type | Class and Description | 
|---|---|
| class  | RMContextImplRMContextImpl class holds two services context. | 
| Modifier and Type | Field and Description | 
|---|---|
| protected RMContext | ApplicationMasterService. rmContext | 
| Modifier and Type | Method and Description | 
|---|---|
| RMContext | ResourceManager. getRMContext() | 
| Modifier and Type | Method and Description | 
|---|---|
| protected AMRMTokenSecretManager | RMSecretManagerService. createAMRMTokenSecretManager(org.apache.hadoop.conf.Configuration conf,
                            RMContext rmContext) | 
| protected RMDelegationTokenSecretManager | RMSecretManagerService. createRMDelegationTokenSecretManager(org.apache.hadoop.conf.Configuration conf,
                                    RMContext rmContext) | 
| static int | RMServerUtils. getApplicableNodeCountForAM(RMContext rmContext,
                           org.apache.hadoop.conf.Configuration conf,
                           List<org.apache.hadoop.yarn.api.records.ResourceRequest> amReqs)Get applicable Node count for AM. | 
| static void | RMServerUtils. normalizeAndValidateRequests(List<org.apache.hadoop.yarn.api.records.ResourceRequest> ask,
                            org.apache.hadoop.yarn.api.records.Resource maximumAllocation,
                            String queueName,
                            YarnScheduler scheduler,
                            RMContext rmContext,
                            boolean nodeLabelsEnabled)Utility method to validate a list resource requests, by ensuring that the
 requested memory/vcore is non-negative and not greater than max | 
| static List<RMNode> | RMServerUtils. queryRMNodes(RMContext context,
            EnumSet<org.apache.hadoop.yarn.api.records.NodeState> acceptedStates) | 
| static ContainerUpdates | RMServerUtils. validateAndSplitUpdateResourceRequests(RMContext rmContext,
                                      org.apache.hadoop.yarn.api.protocolrecords.AllocateRequest request,
                                      org.apache.hadoop.yarn.api.records.Resource maximumAllocation,
                                      List<org.apache.hadoop.yarn.api.records.UpdateContainerError> updateErrors)Check if we have:
 - Request for same containerId and different target resource. | 
| Constructor and Description | 
|---|
| ApplicationAttemptEventDispatcher(RMContext rmContext) | 
| ApplicationEventDispatcher(RMContext rmContext) | 
| ApplicationMasterService(RMContext rmContext,
                        YarnScheduler scheduler) | 
| ApplicationMasterService(String name,
                        RMContext rmContext,
                        YarnScheduler scheduler) | 
| ClientRMService(RMContext rmContext,
               YarnScheduler scheduler,
               RMAppManager rmAppManager,
               org.apache.hadoop.yarn.server.security.ApplicationACLsManager applicationACLsManager,
               QueueACLsManager queueACLsManager,
               RMDelegationTokenSecretManager rmDTSecretManager) | 
| ClientRMService(RMContext rmContext,
               YarnScheduler scheduler,
               RMAppManager rmAppManager,
               org.apache.hadoop.yarn.server.security.ApplicationACLsManager applicationACLsManager,
               QueueACLsManager queueACLsManager,
               RMDelegationTokenSecretManager rmDTSecretManager,
               org.apache.hadoop.yarn.util.Clock clock) | 
| DecommissioningNodesWatcher(RMContext rmContext) | 
| NodeEventDispatcher(RMContext rmContext) | 
| NodesListManager(RMContext rmContext) | 
| OpportunisticContainerAllocatorAMService(RMContext rmContext,
                                        YarnScheduler scheduler) | 
| ResourceTrackerService(RMContext rmContext,
                      NodesListManager nodesListManager,
                      NMLivelinessMonitor nmLivelinessMonitor,
                      RMContainerTokenSecretManager containerTokenSecretManager,
                      NMTokenSecretManagerInRM nmTokenSecretManager) | 
| RMAppManager(RMContext context,
            YarnScheduler scheduler,
            ApplicationMasterService masterService,
            org.apache.hadoop.yarn.server.security.ApplicationACLsManager applicationACLsManager,
            org.apache.hadoop.conf.Configuration conf) | 
| RMCriticalThreadUncaughtExceptionHandler(RMContext rmContext) | 
| RMNMInfo(RMContext rmc,
        ResourceScheduler sched)Constructor for RMNMInfo registers the bean with JMX. | 
| Modifier and Type | Field and Description | 
|---|---|
| protected RMContext | ApplicationMasterLauncher. context | 
| Constructor and Description | 
|---|
| AMLauncher(RMContext rmContext,
          RMAppAttempt application,
          AMLauncherEventType eventType,
          org.apache.hadoop.conf.Configuration conf) | 
| ApplicationMasterLauncher(RMContext context) | 
| Constructor and Description | 
|---|
| FederationStateStoreService(RMContext rmContext) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | SchedulingEditPolicy. init(org.apache.hadoop.conf.Configuration config,
    RMContext context,
    ResourceScheduler scheduler) | 
| void | SchedulingMonitorManager. initialize(RMContext rmContext,
          org.apache.hadoop.conf.Configuration configuration) | 
| void | SchedulingMonitorManager. reinitialize(RMContext rmContext,
            org.apache.hadoop.conf.Configuration configuration) | 
| Constructor and Description | 
|---|
| SchedulingMonitor(RMContext rmContext,
                 SchedulingEditPolicy scheduleEditPolicy) | 
| Modifier and Type | Method and Description | 
|---|---|
| RMContext | ProportionalCapacityPreemptionPolicy. getRMContext() | 
| RMContext | CapacitySchedulerPreemptionContext. getRMContext() | 
| Modifier and Type | Method and Description | 
|---|---|
| void | ProportionalCapacityPreemptionPolicy. init(org.apache.hadoop.conf.Configuration config,
    RMContext context,
    ResourceScheduler sched) | 
| Constructor and Description | 
|---|
| ProportionalCapacityPreemptionPolicy(RMContext context,
                                    CapacityScheduler scheduler,
                                    org.apache.hadoop.yarn.util.Clock clock) | 
| Modifier and Type | Method and Description | 
|---|---|
| RMContext | InvariantsChecker. getContext() | 
| Modifier and Type | Method and Description | 
|---|---|
| void | InvariantsChecker. init(org.apache.hadoop.conf.Configuration config,
    RMContext rmContext,
    ResourceScheduler scheduler) | 
| void | MetricsInvariantChecker. init(org.apache.hadoop.conf.Configuration config,
    RMContext rmContext,
    ResourceScheduler scheduler) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | NodeAttributesManagerImpl. setRMContext(RMContext context) | 
| void | RMNodeLabelsManager. setRMContext(RMContext rmContext) | 
| Constructor and Description | 
|---|
| RMDelegatedNodeLabelsUpdater(RMContext rmContext) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | CapacityReservationSystem. reinitialize(org.apache.hadoop.conf.Configuration conf,
            RMContext rmContext) | 
| void | ReservationSystem. reinitialize(org.apache.hadoop.conf.Configuration conf,
            RMContext rmContext)Re-initialize the  ReservationSystem. | 
| void | FairReservationSystem. reinitialize(org.apache.hadoop.conf.Configuration conf,
            RMContext rmContext) | 
| void | AbstractReservationSystem. reinitialize(org.apache.hadoop.conf.Configuration conf,
            RMContext rmContext) | 
| void | ReservationSystem. setRMContext(RMContext rmContext)Set RMContext for  ReservationSystem. | 
| void | AbstractReservationSystem. setRMContext(RMContext rmContext) | 
| Constructor and Description | 
|---|
| InMemoryPlan(QueueMetrics queueMetrics,
            SharingPolicy policy,
            ReservationAgent agent,
            org.apache.hadoop.yarn.api.records.Resource totalCapacity,
            long step,
            org.apache.hadoop.yarn.util.resource.ResourceCalculator resCalc,
            org.apache.hadoop.yarn.api.records.Resource minAlloc,
            org.apache.hadoop.yarn.api.records.Resource maxAlloc,
            String queueName,
            Planner replanner,
            boolean getMoveOnExpiry,
            long maxPeriodicity,
            RMContext rmContext) | 
| InMemoryPlan(QueueMetrics queueMetrics,
            SharingPolicy policy,
            ReservationAgent agent,
            org.apache.hadoop.yarn.api.records.Resource totalCapacity,
            long step,
            org.apache.hadoop.yarn.util.resource.ResourceCalculator resCalc,
            org.apache.hadoop.yarn.api.records.Resource minAlloc,
            org.apache.hadoop.yarn.api.records.Resource maxAlloc,
            String queueName,
            Planner replanner,
            boolean getMoveOnExpiry,
            long maxPeriodicty,
            RMContext rmContext,
            org.apache.hadoop.yarn.util.Clock clock) | 
| InMemoryPlan(QueueMetrics queueMetrics,
            SharingPolicy policy,
            ReservationAgent agent,
            org.apache.hadoop.yarn.api.records.Resource totalCapacity,
            long step,
            org.apache.hadoop.yarn.util.resource.ResourceCalculator resCalc,
            org.apache.hadoop.yarn.api.records.Resource minAlloc,
            org.apache.hadoop.yarn.api.records.Resource maxAlloc,
            String queueName,
            Planner replanner,
            boolean getMoveOnExpiry,
            RMContext rmContext) | 
| Constructor and Description | 
|---|
| RMAppImpl(org.apache.hadoop.yarn.api.records.ApplicationId applicationId,
         RMContext rmContext,
         org.apache.hadoop.conf.Configuration config,
         String name,
         String user,
         String queue,
         org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext submissionContext,
         YarnScheduler scheduler,
         ApplicationMasterService masterService,
         long submitTime,
         String applicationType,
         Set<String> applicationTags,
         List<org.apache.hadoop.yarn.api.records.ResourceRequest> amReqs) | 
| RMAppImpl(org.apache.hadoop.yarn.api.records.ApplicationId applicationId,
         RMContext rmContext,
         org.apache.hadoop.conf.Configuration config,
         String name,
         String user,
         String queue,
         org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext submissionContext,
         YarnScheduler scheduler,
         ApplicationMasterService masterService,
         long submitTime,
         String applicationType,
         Set<String> applicationTags,
         List<org.apache.hadoop.yarn.api.records.ResourceRequest> amReqs,
         ApplicationPlacementContext placementContext,
         long startTime) | 
| RMAppImpl(org.apache.hadoop.yarn.api.records.ApplicationId applicationId,
         RMContext rmContext,
         org.apache.hadoop.conf.Configuration config,
         String name,
         org.apache.hadoop.security.UserGroupInformation userUgi,
         String queue,
         org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext submissionContext,
         YarnScheduler scheduler,
         ApplicationMasterService masterService,
         long submitTime,
         String applicationType,
         Set<String> applicationTags,
         List<org.apache.hadoop.yarn.api.records.ResourceRequest> amReqs,
         ApplicationPlacementContext placementContext,
         long startTime) | 
| Constructor and Description | 
|---|
| RMAppAttemptImpl(org.apache.hadoop.yarn.api.records.ApplicationAttemptId appAttemptId,
                RMContext rmContext,
                YarnScheduler scheduler,
                ApplicationMasterService masterService,
                org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext submissionContext,
                org.apache.hadoop.conf.Configuration conf,
                List<org.apache.hadoop.yarn.api.records.ResourceRequest> amReqs,
                RMApp rmApp) | 
| RMAppAttemptImpl(org.apache.hadoop.yarn.api.records.ApplicationAttemptId appAttemptId,
                RMContext rmContext,
                YarnScheduler scheduler,
                ApplicationMasterService masterService,
                org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext submissionContext,
                org.apache.hadoop.conf.Configuration conf,
                List<org.apache.hadoop.yarn.api.records.ResourceRequest> amReqs,
                RMApp rmApp,
                BlacklistManager amBlacklistManager) | 
| RMAppAttemptMetrics(org.apache.hadoop.yarn.api.records.ApplicationAttemptId attemptId,
                   RMContext rmContext) | 
| Constructor and Description | 
|---|
| RMAppLifetimeMonitor(RMContext rmContext) | 
| Constructor and Description | 
|---|
| RMContainerImpl(org.apache.hadoop.yarn.api.records.Container container,
               org.apache.hadoop.yarn.server.scheduler.SchedulerRequestKey schedulerKey,
               org.apache.hadoop.yarn.api.records.ApplicationAttemptId appAttemptId,
               org.apache.hadoop.yarn.api.records.NodeId nodeId,
               String user,
               RMContext rmContext) | 
| RMContainerImpl(org.apache.hadoop.yarn.api.records.Container container,
               org.apache.hadoop.yarn.server.scheduler.SchedulerRequestKey schedulerKey,
               org.apache.hadoop.yarn.api.records.ApplicationAttemptId appAttemptId,
               org.apache.hadoop.yarn.api.records.NodeId nodeId,
               String user,
               RMContext rmContext,
               boolean isExternallyAllocated) | 
| RMContainerImpl(org.apache.hadoop.yarn.api.records.Container container,
               org.apache.hadoop.yarn.server.scheduler.SchedulerRequestKey schedulerKey,
               org.apache.hadoop.yarn.api.records.ApplicationAttemptId appAttemptId,
               org.apache.hadoop.yarn.api.records.NodeId nodeId,
               String user,
               RMContext rmContext,
               long creationTime,
               String nodeLabelExpression) | 
| RMContainerImpl(org.apache.hadoop.yarn.api.records.Container container,
               org.apache.hadoop.yarn.server.scheduler.SchedulerRequestKey schedulerKey,
               org.apache.hadoop.yarn.api.records.ApplicationAttemptId appAttemptId,
               org.apache.hadoop.yarn.api.records.NodeId nodeId,
               String user,
               RMContext rmContext,
               long creationTime,
               String nodeLabelExpression,
               boolean isExternallyAllocated) | 
| RMContainerImpl(org.apache.hadoop.yarn.api.records.Container container,
               org.apache.hadoop.yarn.server.scheduler.SchedulerRequestKey schedulerKey,
               org.apache.hadoop.yarn.api.records.ApplicationAttemptId appAttemptId,
               org.apache.hadoop.yarn.api.records.NodeId nodeId,
               String user,
               RMContext rmContext,
               String nodeLabelExpression) | 
| Modifier and Type | Method and Description | 
|---|---|
| RMContext | RMNodeImpl. getRMContext() | 
| RMContext | RMNode. getRMContext() | 
| Constructor and Description | 
|---|
| RMNodeImpl(org.apache.hadoop.yarn.api.records.NodeId nodeId,
          RMContext context,
          String hostName,
          int cmPort,
          int httpPort,
          org.apache.hadoop.net.Node node,
          org.apache.hadoop.yarn.api.records.Resource capability,
          String nodeManagerVersion) | 
| RMNodeImpl(org.apache.hadoop.yarn.api.records.NodeId nodeId,
          RMContext context,
          String hostName,
          int cmPort,
          int httpPort,
          org.apache.hadoop.net.Node node,
          org.apache.hadoop.yarn.api.records.Resource capability,
          String nodeManagerVersion,
          org.apache.hadoop.yarn.api.records.Resource physResource) | 
| Modifier and Type | Field and Description | 
|---|---|
| protected RMContext | SchedulerApplicationAttempt. rmContext | 
| protected RMContext | AbstractYarnScheduler. rmContext | 
| Modifier and Type | Method and Description | 
|---|---|
| RMContext | SchedContainerChangeRequest. getRmContext() | 
| RMContext | AppSchedulingInfo. getRMContext() | 
| Modifier and Type | Method and Description | 
|---|---|
| static boolean | SchedulerUtils. checkQueueLabelExpression(Set<String> queueLabels,
                         String labelExpression,
                         RMContext rmContext)Check queue label expression, check if node label in queue's
 node-label-expression existed in clusterNodeLabels if rmContext != null | 
| static RMContainer | SchedulerUtils. createOpportunisticRmContainer(RMContext rmContext,
                              org.apache.hadoop.yarn.api.records.Container container,
                              boolean isRemotelyAllocated) | 
| static AppPlacementAllocator<SchedulerNode> | ApplicationPlacementAllocatorFactory. getAppPlacementAllocator(String appPlacementAllocatorName,
                        AppSchedulingInfo appSchedulingInfo,
                        org.apache.hadoop.yarn.server.scheduler.SchedulerRequestKey schedulerRequestKey,
                        RMContext rmContext)Get AppPlacementAllocator related to the placement type requested. | 
| void | ConfigurationMutationACLPolicy. init(org.apache.hadoop.conf.Configuration conf,
    RMContext rmContext)Initialize ACL policy with configuration and RMContext. | 
| void | DefaultConfigurationMutationACLPolicy. init(org.apache.hadoop.conf.Configuration conf,
    RMContext rmContext) | 
| static void | SchedulerUtils. normalizeAndValidateRequest(org.apache.hadoop.yarn.api.records.ResourceRequest resReq,
                           org.apache.hadoop.yarn.api.records.Resource maximumAllocation,
                           String queueName,
                           boolean isRecovery,
                           RMContext rmContext,
                           org.apache.hadoop.yarn.api.records.QueueInfo queueInfo,
                           boolean nodeLabelsEnabled) | 
| static void | SchedulerUtils. normalizeAndValidateRequest(org.apache.hadoop.yarn.api.records.ResourceRequest resReq,
                           org.apache.hadoop.yarn.api.records.Resource maximumAllocation,
                           String queueName,
                           RMContext rmContext,
                           org.apache.hadoop.yarn.api.records.QueueInfo queueInfo,
                           boolean nodeLabelsEnabled) | 
| void | ResourceScheduler. reinitialize(org.apache.hadoop.conf.Configuration conf,
            RMContext rmContext)Re-initialize the  ResourceScheduler. | 
| void | AbstractYarnScheduler. reinitialize(org.apache.hadoop.conf.Configuration conf,
            RMContext rmContext) | 
| void | ResourceScheduler. setRMContext(RMContext rmContext)Set RMContext for  ResourceScheduler. | 
| Constructor and Description | 
|---|
| AppSchedulingInfo(org.apache.hadoop.yarn.api.records.ApplicationAttemptId appAttemptId,
                 String user,
                 Queue queue,
                 AbstractUsersManager abstractUsersManager,
                 long epoch,
                 ResourceUsage appResourceUsage,
                 Map<String,String> applicationSchedulingEnvs,
                 RMContext rmContext) | 
| SchedContainerChangeRequest(RMContext rmContext,
                           SchedulerNode schedulerNode,
                           RMContainer rmContainer,
                           org.apache.hadoop.yarn.api.records.Resource targetCapacity) | 
| SchedulerApplicationAttempt(org.apache.hadoop.yarn.api.records.ApplicationAttemptId applicationAttemptId,
                           String user,
                           Queue queue,
                           AbstractUsersManager abstractUsersManager,
                           RMContext rmContext) | 
| Constructor and Description | 
|---|
| ActivitiesManager(RMContext rmContext) | 
| Modifier and Type | Method and Description | 
|---|---|
| RMContext | QueueManagementDynamicEditPolicy. getRmContext() | 
| RMContext | CapacitySchedulerContext. getRMContext() | 
| RMContext | CapacityScheduler. getRMContext() | 
| Modifier and Type | Method and Description | 
|---|---|
| void | QueueManagementDynamicEditPolicy. init(org.apache.hadoop.conf.Configuration config,
    RMContext context,
    ResourceScheduler sched) | 
| void | CapacityScheduler. reinitialize(org.apache.hadoop.conf.Configuration newConf,
            RMContext rmContext) | 
| void | CapacityScheduler. reinitialize(org.apache.hadoop.conf.Configuration newConf,
            RMContext rmContext,
            boolean validation) | 
| void | QueueManagementDynamicEditPolicy. reinitialize(org.apache.hadoop.conf.Configuration config,
            RMContext context,
            ResourceScheduler sched)Reinitializes queues(Called on scheduler.reinitialize) | 
| void | CapacityScheduler. setRMContext(RMContext rmContext) | 
| static boolean | CapacitySchedulerConfigValidator. validateCSConfiguration(org.apache.hadoop.conf.Configuration oldConf,
                       org.apache.hadoop.conf.Configuration newConf,
                       RMContext rmContext) | 
| Constructor and Description | 
|---|
| QueueManagementDynamicEditPolicy(RMContext context,
                                CapacityScheduler scheduler) | 
| QueueManagementDynamicEditPolicy(RMContext context,
                                CapacityScheduler scheduler,
                                org.apache.hadoop.yarn.util.Clock clock) | 
| Constructor and Description | 
|---|
| AbstractContainerAllocator(FiCaSchedulerApp application,
                          org.apache.hadoop.yarn.util.resource.ResourceCalculator rc,
                          RMContext rmContext) | 
| AbstractContainerAllocator(FiCaSchedulerApp application,
                          org.apache.hadoop.yarn.util.resource.ResourceCalculator rc,
                          RMContext rmContext,
                          ActivitiesManager activitiesManager) | 
| ContainerAllocator(FiCaSchedulerApp application,
                  org.apache.hadoop.yarn.util.resource.ResourceCalculator rc,
                  RMContext rmContext) | 
| ContainerAllocator(FiCaSchedulerApp application,
                  org.apache.hadoop.yarn.util.resource.ResourceCalculator rc,
                  RMContext rmContext,
                  ActivitiesManager activitiesManager) | 
| RegularContainerAllocator(FiCaSchedulerApp application,
                         org.apache.hadoop.yarn.util.resource.ResourceCalculator rc,
                         RMContext rmContext,
                         ActivitiesManager activitiesManager) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | QueueAdminConfigurationMutationACLPolicy. init(org.apache.hadoop.conf.Configuration config,
    RMContext context) | 
| void | ZKConfigurationStore. initialize(org.apache.hadoop.conf.Configuration config,
          org.apache.hadoop.conf.Configuration schedConf,
          RMContext rmContext) | 
| void | FSSchedulerConfigurationStore. initialize(org.apache.hadoop.conf.Configuration fsConf,
          org.apache.hadoop.conf.Configuration vSchedConf,
          RMContext rmContext) | 
| void | LeveldbConfigurationStore. initialize(org.apache.hadoop.conf.Configuration config,
          org.apache.hadoop.conf.Configuration schedConf,
          RMContext rmContext) | 
| void | InMemoryConfigurationStore. initialize(org.apache.hadoop.conf.Configuration conf,
          org.apache.hadoop.conf.Configuration schedConf,
          RMContext rmContext) | 
| abstract void | YarnConfigurationStore. initialize(org.apache.hadoop.conf.Configuration conf,
          org.apache.hadoop.conf.Configuration schedConf,
          RMContext rmContext)Initialize the configuration store, with schedConf as the initial
 scheduler configuration. | 
| Constructor and Description | 
|---|
| FileBasedCSConfigurationProvider(RMContext rmContext)Construct file based CS configuration provider with given context. | 
| MutableCSConfigurationProvider(RMContext rmContext) | 
| Constructor and Description | 
|---|
| FiCaSchedulerApp(org.apache.hadoop.yarn.api.records.ApplicationAttemptId applicationAttemptId,
                String user,
                Queue queue,
                AbstractUsersManager abstractUsersManager,
                RMContext rmContext) | 
| FiCaSchedulerApp(org.apache.hadoop.yarn.api.records.ApplicationAttemptId applicationAttemptId,
                String user,
                Queue queue,
                AbstractUsersManager abstractUsersManager,
                RMContext rmContext,
                org.apache.hadoop.yarn.api.records.Priority appPriority,
                boolean isAttemptRecovering) | 
| FiCaSchedulerApp(org.apache.hadoop.yarn.api.records.ApplicationAttemptId applicationAttemptId,
                String user,
                Queue queue,
                AbstractUsersManager abstractUsersManager,
                RMContext rmContext,
                org.apache.hadoop.yarn.api.records.Priority appPriority,
                boolean isAttemptRecovering,
                ActivitiesManager activitiesManager) | 
| Constructor and Description | 
|---|
| AllocationTagsManager(RMContext context) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | DefaultPlacementAlgorithm. init(RMContext rmContext) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | ConstraintPlacementAlgorithm. init(RMContext rmContext)Initialize the Algorithm. | 
| Modifier and Type | Method and Description | 
|---|---|
| RMContext | FairScheduler. getRMContext() | 
| Modifier and Type | Method and Description | 
|---|---|
| void | FairScheduler. reinitialize(org.apache.hadoop.conf.Configuration conf,
            RMContext rmContext) | 
| void | FairScheduler. setRMContext(RMContext rmContext) | 
| Constructor and Description | 
|---|
| FSAppAttempt(FairScheduler scheduler,
            org.apache.hadoop.yarn.api.records.ApplicationAttemptId applicationAttemptId,
            String user,
            FSLeafQueue queue,
            ActiveUsersManager activeUsersManager,
            RMContext rmContext) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | FifoScheduler. reinitialize(org.apache.hadoop.conf.Configuration conf,
            RMContext rmContext) | 
| void | FifoScheduler. setRMContext(RMContext rmContext) | 
| Modifier and Type | Field and Description | 
|---|---|
| protected RMContext | AppPlacementAllocator. rmContext | 
| Modifier and Type | Method and Description | 
|---|---|
| void | AppPlacementAllocator. initialize(AppSchedulingInfo appSchedulingInfo,
          org.apache.hadoop.yarn.server.scheduler.SchedulerRequestKey schedulerRequestKey,
          RMContext rmContext)Initialize this allocator, this will be called by Factory automatically. | 
| void | SingleConstraintAppPlacementAllocator. initialize(AppSchedulingInfo appSchedulingInfo,
          org.apache.hadoop.yarn.server.scheduler.SchedulerRequestKey schedulerRequestKey,
          RMContext rmContext) | 
| void | LocalityAppPlacementAllocator. initialize(AppSchedulingInfo appSchedulingInfo,
          org.apache.hadoop.yarn.server.scheduler.SchedulerRequestKey schedulerRequestKey,
          RMContext rmContext) | 
| void | MultiNodeSortingManager. setRMContext(RMContext context) | 
| Constructor and Description | 
|---|
| MultiNodeSorter(RMContext rmContext,
               MultiNodePolicySpec policy) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | DelegationTokenRenewer. setRMContext(RMContext rmContext) | 
| Constructor and Description | 
|---|
| AMRMTokenSecretManager(org.apache.hadoop.conf.Configuration conf,
                      RMContext rmContext)Create an  AMRMTokenSecretManager | 
| ProxyCAManager(org.apache.hadoop.yarn.server.webproxy.ProxyCA proxyCA,
              RMContext rmContext) | 
| RMDelegationTokenSecretManager(long delegationKeyUpdateInterval,
                              long delegationTokenMaxLifetime,
                              long delegationTokenRenewInterval,
                              long delegationTokenRemoverScanInterval,
                              RMContext rmContext)Create a secret manager | 
| Modifier and Type | Method and Description | 
|---|---|
| RMContext | RMWebApp. getRMContext() | 
Copyright © 2008–2023 Apache Software Foundation. All rights reserved.