public class PlanQueue extends AbstractManagedParentQueue
ReservationSystem
.
From the user perspective this is equivalent to a LeafQueue that respect
reservations, but functionality wise is a sub-class of ParentQueueAbstractCSQueue.CapacityConfigType
Modifier and Type | Field and Description |
---|---|
protected CapacitySchedulerContext |
schedulerContext |
leafQueueTemplate, queueManagementPolicy
childQueues
activitiesManager, authorizer, capacityConfigType, csContext, queueEntity, readLock, writeLock
Constructor and Description |
---|
PlanQueue(CapacitySchedulerContext cs,
String queueName,
CSQueue parent,
CSQueue old) |
Modifier and Type | Method and Description |
---|---|
int |
getMaxApplicationsForReservations()
Number of maximum applications for each of the reservations in this Plan.
|
int |
getMaxApplicationsPerUserForReservation()
Number of maximum applications per user for each of the reservations in
this Plan.
|
float |
getUserLimitFactor()
User limit factor value for each of the reservations in this Plan.
|
int |
getUserLimitForReservation()
User limit value for each of the reservations in this Plan.
|
void |
reinitialize(CSQueue newlyParsedQueue,
org.apache.hadoop.yarn.api.records.Resource clusterResource)
Reinitialize the queue.
|
boolean |
showReservationsAsQueues()
Determine whether to hide/show the ReservationQueues
|
addChildQueue, getAutoCreatedQueueManagementPolicy, getConfigurationsWithPrefix, getLeafQueueTemplate, initializeLeafQueueConfigs, removeChildQueue, removeChildQueue, sortCSConfigurations, sumOfChildAbsCapacities, sumOfChildCapacities, validateQueueEntitlementChange
apply, assignContainers, attachContainer, collectSchedulerApplications, completedContainer, detachContainer, finishApplication, finishApplicationAttempt, getAbstractUsersManager, getChildQueues, getNumApplications, getQueueInfo, getQueueOrderingPolicy, getQueueUserAclInfo, hasChildQueues, recoverContainer, setupQueueConfigs, stopQueue, submitApplication, submitApplicationAttempt, submitApplicationAttempt, toString, updateClusterResource, validateSubmitApplication
accept, accessibleToPartition, activeQueue, appFinished, assignContainers, decPendingResource, decReservedResource, decUsedResource, getAbsoluteCapacity, getAbsoluteMaximumCapacity, getAbsoluteUsedCapacity, getAccessibleNodeLabels, getACLs, getCapacity, getCapacityConfigType, getDefaultApplicationLifetime, getDefaultApplicationPriority, getDefaultAppLifetimeWasSpecifiedInConfig, getDefaultNodeLabelExpression, getEffectiveCapacity, getEffectiveCapacityDown, getEffectiveMaxCapacity, getEffectiveMaxCapacityDown, getIntraQueuePreemptionDisabled, getIntraQueuePreemptionDisabledInHierarchy, getKillableContainers, getMaximumAllocation, getMaximumApplicationLifetime, getMaximumCapacity, getMaxParallelApps, getMetrics, getMinimumAllocation, getMultiNodeSortingPolicyName, getNodeLabelsForQueue, getNumContainers, getParent, getPreemptionDisabled, getPriority, getPrivilegedEntity, getQueueCapacities, getQueueConfigurations, getQueueInfo, getQueueName, getQueuePath, getQueueResourceQuotas, getQueueResourceUsage, getQueueShortName, getQueueStatistics, getReadLock, getReservationContinueLooking, getState, getTotalKillableResource, getUsedCapacity, getUsedResources, getUserWeights, hasAccess, incPendingResource, incReservedResource, incUsedResource, recoverDrainingState, releaseResource, setMaxParallelApps, setMultiNodeSortingPolicyName, setParent, setupConfigurableCapacities, setupConfigurableCapacities, setupQueueConfigs, updateConfigurableResourceRequirement, updateQueueState
protected CapacitySchedulerContext schedulerContext
public PlanQueue(CapacitySchedulerContext cs, String queueName, CSQueue parent, CSQueue old) throws IOException
IOException
public void reinitialize(CSQueue newlyParsedQueue, org.apache.hadoop.yarn.api.records.Resource clusterResource) throws IOException
CSQueue
reinitialize
in interface CSQueue
reinitialize
in class AbstractManagedParentQueue
newlyParsedQueue
- new queue to re-initalize fromclusterResource
- resources in the clusterIOException
public int getMaxApplicationsForReservations()
public int getMaxApplicationsPerUserForReservation()
public int getUserLimitForReservation()
public float getUserLimitFactor()
public boolean showReservationsAsQueues()
Copyright © 2008–2021 Apache Software Foundation. All rights reserved.