@InterfaceAudience.Private @InterfaceStability.Unstable public class CapacitySchedulerQueueManager extends Object implements SchedulerQueueManager<CSQueue,CapacitySchedulerConfiguration>
| Constructor and Description | 
|---|
| CapacitySchedulerQueueManager(org.apache.hadoop.conf.Configuration conf,
                             RMNodeLabelsManager labelManager,
                             AppPriorityACLsManager appPriorityACLManager)Construct the service. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | addQueue(String queueName,
        CSQueue queue)Add a new queue to the existing queues. | 
| LeafQueue | getAndCheckLeafQueue(String queue)Check that the String provided in input is the name of an existing,
 LeafQueue, if successful returns the queue. | 
| org.apache.hadoop.yarn.api.records.Priority | getDefaultPriorityForQueue(String queueName)Get the default priority of the queue. | 
| CSQueue | getQueue(String queueName)Get a queue matching the specified queue name. | 
| CSQueue | getQueueByFullName(String name) | 
| Map<String,CSQueue> | getQueues()Get all the queues. | 
| QueueStateManager<CSQueue,CapacitySchedulerConfiguration> | getQueueStateManager() | 
| CSQueue | getRootQueue()Get the root queue. | 
| Map<String,CSQueue> | getShortNameQueues() | 
| void | initializeQueues(CapacitySchedulerConfiguration conf)Initialized the queues. | 
| boolean | isAmbiguous(String shortName) | 
| void | reinitializeQueues(CapacitySchedulerConfiguration newConf)Reinitialize the queues. | 
| void | removeQueue(String queueName)Remove the queue from the existing queue. | 
| void | setCapacitySchedulerContext(CapacitySchedulerContext capacitySchedulerContext)Set the CapacitySchedulerContext. | 
| static void | setQueueAcls(org.apache.hadoop.yarn.security.YarnAuthorizationProvider authorizer,
            AppPriorityACLsManager appPriorityACLManager,
            CSQueueStore queues) | 
public CapacitySchedulerQueueManager(org.apache.hadoop.conf.Configuration conf,
                                     RMNodeLabelsManager labelManager,
                                     AppPriorityACLsManager appPriorityACLManager)
conf - the configurationlabelManager - the labelManagerappPriorityACLManager - App priority ACL managerpublic CSQueue getRootQueue()
SchedulerQueueManagergetRootQueue in interface SchedulerQueueManager<CSQueue,CapacitySchedulerConfiguration>public Map<String,CSQueue> getQueues()
SchedulerQueueManagergetQueues in interface SchedulerQueueManager<CSQueue,CapacitySchedulerConfiguration>public void removeQueue(String queueName)
SchedulerQueueManagerremoveQueue in interface SchedulerQueueManager<CSQueue,CapacitySchedulerConfiguration>queueName - the queue namepublic void addQueue(String queueName, CSQueue queue)
SchedulerQueueManageraddQueue in interface SchedulerQueueManager<CSQueue,CapacitySchedulerConfiguration>queueName - the queue namequeue - the queue objectpublic CSQueue getQueue(String queueName)
SchedulerQueueManagergetQueue in interface SchedulerQueueManager<CSQueue,CapacitySchedulerConfiguration>queueName - the queue namepublic boolean isAmbiguous(String shortName)
public void setCapacitySchedulerContext(CapacitySchedulerContext capacitySchedulerContext)
capacitySchedulerContext - the CapacitySchedulerContextpublic void initializeQueues(CapacitySchedulerConfiguration conf) throws IOException
conf - the CapacitySchedulerConfigurationIOException - if fails to initialize queuespublic void reinitializeQueues(CapacitySchedulerConfiguration newConf) throws IOException
SchedulerQueueManagerreinitializeQueues in interface SchedulerQueueManager<CSQueue,CapacitySchedulerConfiguration>newConf - the configurationIOException - if fails to re-initialize queuespublic static void setQueueAcls(org.apache.hadoop.yarn.security.YarnAuthorizationProvider authorizer,
                                AppPriorityACLsManager appPriorityACLManager,
                                CSQueueStore queues)
                         throws IOException
IOExceptionpublic LeafQueue getAndCheckLeafQueue(String queue) throws org.apache.hadoop.yarn.exceptions.YarnException
queue - the queue nameorg.apache.hadoop.yarn.exceptions.YarnException - if the queue does not exist or the queue
           is not the type of LeafQueue.public org.apache.hadoop.yarn.api.records.Priority getDefaultPriorityForQueue(String queueName)
queueName - the queue name@InterfaceAudience.Private public QueueStateManager<CSQueue,CapacitySchedulerConfiguration> getQueueStateManager()
Copyright © 2008–2023 Apache Software Foundation. All rights reserved.