@InterfaceAudience.Private @InterfaceStability.Unstable public class FSParentQueue extends FSQueue
maxAMShare, maxContainerAllocation, maxRunningApps, minShare, parent, policy, recordFactory, scheduler, weights| Constructor and Description | 
|---|
| FSParentQueue(String name,
             FairScheduler scheduler,
             FSParentQueue parent) | 
| Modifier and Type | Method and Description | 
|---|---|
| org.apache.hadoop.yarn.api.records.Resource | assignContainer(FSSchedulerNode node)Assign a container on this node if possible, and return the amount of
 resources assigned. | 
| void | collectSchedulerApplications(Collection<org.apache.hadoop.yarn.api.records.ApplicationAttemptId> apps)Adds all applications in the queue and its subqueues to the given collection. | 
| protected void | dumpStateInternal(StringBuilder sb)Recursively dump states of all queues. | 
| ActiveUsersManager | getAbstractUsersManager() | 
| List<FSQueue> | getChildQueues()Gets the children of this queue, if any. | 
| org.apache.hadoop.yarn.api.records.Resource | getDemand()Maximum number of resources required by this Schedulable. | 
| org.apache.hadoop.yarn.api.records.Resource | getMaximumContainerAllocation() | 
| int | getNumRunnableApps()Return the number of apps for which containers can be allocated. | 
| List<org.apache.hadoop.yarn.api.records.QueueUserACLInfo> | getQueueUserAclInfo(org.apache.hadoop.security.UserGroupInformation user)Get queue ACLs for given  user. | 
| boolean | isEmpty() | 
| void | recoverContainer(org.apache.hadoop.yarn.api.records.Resource clusterResource,
                SchedulerApplicationAttempt schedulerAttempt,
                RMContainer rmContainer)Recover the state of the queue for a given container. | 
| void | updateDemand()Refresh the Schedulable's demand and those of its children if any. | 
decPendingResource, decReservedResource, decUsedResource, dumpState, getAccessibleNodeLabels, getDefaultApplicationPriority, getDefaultNodeLabelExpression, getFairShare, getMaxAMShare, getMaxChildQueueResource, getMaxRunningApps, getMaxShare, getMetrics, getMinShare, getName, getParent, getPolicy, getPriority, getQueueInfo, getQueueName, getQueueStatistics, getRawMaxShare, getReservedResource, getResourceUsage, getStartTime, getSteadyFairShare, getWeight, hasAccess, incPendingResource, incReservedResource, incUsedResource, isActive, isDynamic, isPreemptable, reinit, setDynamic, setFairShare, setMaxAMShare, setMaxChildQueueResource, setMaxContainerAllocation, setMaxRunningApps, setMaxShare, setMinShare, setPolicy, setWeights, toString, update, verifyAndSetPolicyFromConfpublic FSParentQueue(String name, FairScheduler scheduler, FSParentQueue parent)
public org.apache.hadoop.yarn.api.records.Resource getMaximumContainerAllocation()
getMaximumContainerAllocation in class FSQueuepublic org.apache.hadoop.yarn.api.records.Resource getDemand()
Schedulablepublic void updateDemand()
Schedulablepublic List<org.apache.hadoop.yarn.api.records.QueueUserACLInfo> getQueueUserAclInfo(org.apache.hadoop.security.UserGroupInformation user)
Queueuser.user - usernamepublic org.apache.hadoop.yarn.api.records.Resource assignContainer(FSSchedulerNode node)
Schedulablepublic List<FSQueue> getChildQueues()
FSQueuegetChildQueues in class FSQueuepublic int getNumRunnableApps()
FSQueuegetNumRunnableApps in class FSQueuepublic void collectSchedulerApplications(Collection<org.apache.hadoop.yarn.api.records.ApplicationAttemptId> apps)
FSQueuecollectSchedulerApplications in class FSQueueapps - the collection to add the applications topublic ActiveUsersManager getAbstractUsersManager()
public void recoverContainer(org.apache.hadoop.yarn.api.records.Resource clusterResource,
                             SchedulerApplicationAttempt schedulerAttempt,
                             RMContainer rmContainer)
QueueclusterResource - the resource of the clusterschedulerAttempt - the application for which the container was allocatedrmContainer - the container that was recovered.protected void dumpStateInternal(StringBuilder sb)
FSQueuedumpStateInternal in class FSQueuesb - the {code StringBuilder} which holds queue statesCopyright © 2008–2023 Apache Software Foundation. All rights reserved.