| Package | Description | 
|---|---|
| org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity | |
| org.apache.hadoop.yarn.server.resourcemanager.placement | |
| org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity | |
| org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.policy | |
| org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.preemption | |
| org.apache.hadoop.yarn.server.resourcemanager.webapp.dao | This package contains the web data access objects (DAO) for the RM. | 
| Constructor and Description | 
|---|
| TempQueuePerPartition(String queueName,
                     org.apache.hadoop.yarn.api.records.Resource current,
                     boolean preemptionDisabled,
                     String partition,
                     org.apache.hadoop.yarn.api.records.Resource killable,
                     float absCapacity,
                     float absMaxCapacity,
                     org.apache.hadoop.yarn.api.records.Resource totalPartitionResource,
                     org.apache.hadoop.yarn.api.records.Resource reserved,
                     CSQueue queue,
                     org.apache.hadoop.yarn.api.records.Resource effMinRes,
                     org.apache.hadoop.yarn.api.records.Resource effMaxRes) | 
| Modifier and Type | Method and Description | 
|---|---|
| static QueueMapping | QueuePlacementRuleUtils. validateAndGetQueueMapping(CapacitySchedulerQueueManager queueManager,
                          CSQueue queue,
                          QueueMapping mapping) | 
| static void | QueuePlacementRuleUtils. validateQueueMappingUnderParentQueue(CSQueue parentQueue,
                                    String parentQueueName,
                                    String leafQueuePath) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractAutoCreatedLeafQueueAbstract class for dynamic auto created queues managed by an implementation
 of AbstractManagedParentQueue | 
| class  | AbstractCSQueue | 
| class  | AbstractManagedParentQueueA container class for automatically created child leaf queues. | 
| class  | AutoCreatedLeafQueueLeaf queues which are auto created by an underlying implementation of
 AbstractManagedParentQueue. | 
| class  | LeafQueue | 
| class  | ManagedParentQueueAuto Creation enabled Parent queue. | 
| class  | ParentQueue | 
| class  | PlanQueueThis represents a dynamic queue managed by the  ReservationSystem. | 
| class  | ReservationQueueThis represents a dynamic  LeafQueuemanaged by theReservationSystem | 
| Modifier and Type | Field and Description | 
|---|---|
| protected List<CSQueue> | ParentQueue. childQueues | 
| Modifier and Type | Method and Description | 
|---|---|
| CSQueue | CSQueueStore. get(String name)Getter method for the queue it can find queues by both full and
 short names. | 
| CSQueue | CSQueue. getParent()Get the parent  Queue. | 
| CSQueue | AbstractCSQueue. getParent() | 
| CSQueue | QueueManagementChange. getQueue() | 
| CSQueue | CapacityScheduler. getQueue(String queueName) | 
| CSQueue | CapacitySchedulerQueueManager. getQueue(String queueName) | 
| CSQueue | CapacitySchedulerQueueManager. getQueueByFullName(String name) | 
| CSQueue | CapacityScheduler. getRootQueue() | 
| CSQueue | CapacitySchedulerQueueManager. getRootQueue() | 
| CSQueue | AbstractManagedParentQueue. removeChildQueue(String childQueueName)Remove the specified child queue. | 
| Modifier and Type | Method and Description | 
|---|---|
| List<CSQueue> | CSQueue. getChildQueues()Get child queues | 
| List<CSQueue> | ParentQueue. getChildQueues() | 
| List<CSQueue> | LeafQueue. getChildQueues() | 
| Collection<CSQueue> | CSQueueStore. getQueues()Returns all queues as a list. | 
| Map<String,CSQueue> | CapacitySchedulerQueueManager. getQueues() | 
| QueueStateManager<CSQueue,CapacitySchedulerConfiguration> | CapacitySchedulerQueueManager. getQueueStateManager() | 
| Map<String,CSQueue> | CapacitySchedulerQueueManager. getShortNameQueues() | 
| Modifier and Type | Method and Description | 
|---|---|
| void | CSQueueStore. add(CSQueue queue)Method for adding a queue to the store. | 
| void | ManagedParentQueue. addChildQueue(CSQueue childQueue) | 
| void | AbstractManagedParentQueue. addChildQueue(CSQueue childQueue)Add the specified child queue. | 
| void | CapacitySchedulerQueueManager. addQueue(String queueName,
        CSQueue queue) | 
| void | CSQueue. completedContainer(org.apache.hadoop.yarn.api.records.Resource clusterResource,
                  FiCaSchedulerApp application,
                  FiCaSchedulerNode node,
                  RMContainer container,
                  org.apache.hadoop.yarn.api.records.ContainerStatus containerStatus,
                  RMContainerEventType event,
                  CSQueue childQueue,
                  boolean sortQueues)A container assigned to the queue has completed. | 
| void | ParentQueue. completedContainer(org.apache.hadoop.yarn.api.records.Resource clusterResource,
                  FiCaSchedulerApp application,
                  FiCaSchedulerNode node,
                  RMContainer rmContainer,
                  org.apache.hadoop.yarn.api.records.ContainerStatus containerStatus,
                  RMContainerEventType event,
                  CSQueue completedChildQueue,
                  boolean sortQueues) | 
| void | LeafQueue. completedContainer(org.apache.hadoop.yarn.api.records.Resource clusterResource,
                  FiCaSchedulerApp application,
                  FiCaSchedulerNode node,
                  RMContainer rmContainer,
                  org.apache.hadoop.yarn.api.records.ContainerStatus containerStatus,
                  RMContainerEventType event,
                  CSQueue childQueue,
                  boolean sortQueues) | 
| static float | CSQueueUtils. computeAbsoluteMaximumCapacity(float maximumCapacity,
                              CSQueue parent) | 
| org.apache.hadoop.yarn.api.records.Priority | WorkflowPriorityMappingsManager. getMappedPriority(String workflowID,
                 CSQueue queue) | 
| org.apache.hadoop.yarn.api.records.Priority | WorkflowPriorityMappingsManager. mapWorkflowPriorityForApp(org.apache.hadoop.yarn.api.records.ApplicationId applicationId,
                         CSQueue queue,
                         String user,
                         org.apache.hadoop.yarn.api.records.Priority priority) | 
| void | PlanQueue. reinitialize(CSQueue newlyParsedQueue,
            org.apache.hadoop.yarn.api.records.Resource clusterResource) | 
| void | AutoCreatedLeafQueue. reinitialize(CSQueue newlyParsedQueue,
            org.apache.hadoop.yarn.api.records.Resource clusterResource) | 
| void | ManagedParentQueue. reinitialize(CSQueue newlyParsedQueue,
            org.apache.hadoop.yarn.api.records.Resource clusterResource) | 
| void | CSQueue. reinitialize(CSQueue newlyParsedQueue,
            org.apache.hadoop.yarn.api.records.Resource clusterResource)Reinitialize the queue. | 
| void | ReservationQueue. reinitialize(CSQueue newlyParsedQueue,
            org.apache.hadoop.yarn.api.records.Resource clusterResource) | 
| void | AbstractManagedParentQueue. reinitialize(CSQueue newlyParsedQueue,
            org.apache.hadoop.yarn.api.records.Resource clusterResource) | 
| void | ParentQueue. reinitialize(CSQueue newlyParsedQueue,
            org.apache.hadoop.yarn.api.records.Resource clusterResource) | 
| void | LeafQueue. reinitialize(CSQueue newlyParsedQueue,
            org.apache.hadoop.yarn.api.records.Resource clusterResource) | 
| protected void | LeafQueue. reinitialize(CSQueue newlyParsedQueue,
            org.apache.hadoop.yarn.api.records.Resource clusterResource,
            CapacitySchedulerConfiguration configuration) | 
| void | CSQueueStore. remove(CSQueue queue)Method for removing a queue from the store. | 
| void | AbstractManagedParentQueue. removeChildQueue(CSQueue childQueue)Remove the specified child queue. | 
| void | CSQueue. setParent(CSQueue newParentQueue)Set the parent  Queue. | 
| void | AbstractCSQueue. setParent(CSQueue newParentQueue) | 
| protected void | ManagedParentQueue. validate(CSQueue newlyParsedQueue) | 
| Modifier and Type | Method and Description | 
|---|---|
| CSQueue | PriorityUtilizationQueueOrderingPolicy.PriorityQueueResourcesForSorting. getQueue() | 
| Modifier and Type | Method and Description | 
|---|---|
| Iterator<CSQueue> | QueueOrderingPolicy. getAssignmentIterator(String partition)Return an iterator over the collection of CSQueues which orders
 them for container assignment. | 
| Iterator<CSQueue> | PriorityUtilizationQueueOrderingPolicy. getAssignmentIterator(String partition) | 
| List<CSQueue> | PriorityUtilizationQueueOrderingPolicy. getQueues() | 
| Modifier and Type | Method and Description | 
|---|---|
| void | QueueOrderingPolicy. setQueues(List<CSQueue> queues) | 
| void | PriorityUtilizationQueueOrderingPolicy. setQueues(List<CSQueue> queues) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | PreemptionManager. refreshQueues(CSQueue parent,
             CSQueue current) | 
| Modifier and Type | Method and Description | 
|---|---|
| protected CapacitySchedulerQueueInfoList | CapacitySchedulerInfo. getQueues(CapacityScheduler cs,
         CSQueue parent) | 
| Constructor and Description | 
|---|
| CapacitySchedulerInfo(CSQueue parent,
                     CapacityScheduler cs) | 
Copyright © 2008–2023 Apache Software Foundation. All rights reserved.