public abstract class AbstractManagedParentQueue extends AbstractParentQueue
AbstractParentQueue.QueueCapacityType
AbstractCSQueue.CapacityConfigType
Modifier and Type | Field and Description |
---|---|
protected AutoCreatedLeafQueueConfig |
leafQueueTemplate |
protected AutoCreatedQueueManagementPolicy |
queueManagementPolicy |
childQueues
activitiesManager, authorizer, capacityConfigType, configuredCapacityVectors, configuredMaxCapacityVectors, queueAllocationSettings, queueContext, queueEntity, queueNodeLabelsSettings, queuePath, readLock, writeLock
Constructor and Description |
---|
AbstractManagedParentQueue(CapacitySchedulerQueueContext queueContext,
String queueName,
CSQueue parent,
CSQueue old) |
Modifier and Type | Method and Description |
---|---|
void |
addChildQueue(CSQueue childQueue)
Add the specified child queue.
|
AutoCreatedQueueManagementPolicy |
getAutoCreatedQueueManagementPolicy() |
AutoCreatedLeafQueueConfig |
getLeafQueueTemplate() |
protected CapacitySchedulerConfiguration |
initializeLeafQueueConfigs(String configPrefix) |
void |
reinitialize(CSQueue newlyParsedQueue,
org.apache.hadoop.yarn.api.records.Resource clusterResource)
Reinitialize the queue.
|
void |
removeChildQueue(CSQueue childQueue)
Remove the specified child queue.
|
CSQueue |
removeChildQueue(String childQueueName)
Remove the specified child queue.
|
protected float |
sumOfChildAbsCapacities() |
protected float |
sumOfChildCapacities() |
protected void |
validateQueueEntitlementChange(AbstractAutoCreatedLeafQueue leafQueue,
QueueEntitlement entitlement) |
apply, assignContainers, attachContainer, collectSchedulerApplications, completedContainer, createNewQueue, detachContainer, finishApplication, finishApplicationAttempt, getAbstractUsersManager, getAutoCreatedQueueTemplate, getCapacityConfigurationTypeForQueues, getChildQueues, getChildQueuesByTryLock, getNumApplications, getQueueInfo, getQueueOrderingPolicy, getQueueUserAclInfo, getResourceLimitsOfChild, hasChildQueues, isEligibleForAutoDeletion, isEligibleForAutoQueueCreation, recoverContainer, refreshAfterResourceCalculation, setDynamicQueueACLProperties, setupQueueConfigs, stopQueue, submitApplication, submitApplicationAttempt, submitApplicationAttempt, toString, updateClusterResource, updateClusterResourceLegacyMode, validateSubmitApplication
accept, activateQueue, appFinished, assignContainers, checkConfigTypeIsAbsoluteResource, decPendingResource, decReservedResource, decUsedResource, getAbsoluteCapacity, getAbsoluteMaximumCapacity, getAbsoluteUsedCapacity, getAccessibleNodeLabels, getACLs, getCapacity, getCapacityConfigType, getCapacityOrWeightString, getConfiguredCapacityVector, getConfiguredMaxCapacityVector, getConfiguredNodeLabels, getDefaultApplicationLifetime, getDefaultApplicationPriority, getDefaultAppLifetimeWasSpecifiedInConfig, getDefaultNodeLabelExpression, getEffectiveCapacity, getEffectiveCapacityDown, getEffectiveMaxCapacity, getEffectiveMaxCapacityDown, getIntraQueuePreemptionDisabled, getIntraQueuePreemptionDisabledInHierarchy, getKillableContainers, getMaximumAbsoluteResource, getMaximumAllocation, getMaximumApplicationLifetime, getMaximumCapacity, getMaxParallelApps, getMetrics, getMinimumAbsoluteResource, getMinimumAllocation, getMultiNodeSortingPolicyName, getNodeLabelsForQueue, getNumContainers, getParent, getPreemptionDisabled, getPriority, getPrivilegedEntity, getQueueCapacities, getQueueContext, getQueueInfo, getQueueName, getQueuePath, getQueuePathObject, getQueueResourceQuotas, getQueueResourceUsage, getQueueShortName, getReadLock, getState, getTotalKillableResource, getUsedCapacity, getUsedResources, getUserWeights, getWriteLock, hasAccess, incPendingResource, incReservedResource, incUsedResource, isDynamicQueue, isInactiveDynamicQueue, isReservationsContinueLooking, overrideCapacityVectorsForSpecialQueues, parseAndSetDynamicTemplates, recoverDrainingState, releaseResource, setConfiguredMaxCapacityVector, setConfiguredMinCapacityVector, setDynamicQueue, setMaxParallelApps, setMultiNodeSortingPolicyName, setParent, setupConfigurableCapacities, updateAbsoluteCapacities, updateCapacityConfigType, updateConfigurableResourceLimits, updateQueueState
protected AutoCreatedLeafQueueConfig leafQueueTemplate
protected AutoCreatedQueueManagementPolicy queueManagementPolicy
public AbstractManagedParentQueue(CapacitySchedulerQueueContext queueContext, 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 AbstractParentQueue
newlyParsedQueue
- new queue to re-initalize fromclusterResource
- resources in the clusterIOException
- an I/O exception has occurred.public void addChildQueue(CSQueue childQueue) throws SchedulerDynamicEditException, IOException
childQueue
- reference to the child queue to be addedSchedulerDynamicEditException
- when addChildQueue fails.IOException
- an I/O exception has occurred.public void removeChildQueue(CSQueue childQueue) throws SchedulerDynamicEditException
removeChildQueue
in class AbstractParentQueue
childQueue
- reference to the child queue to be removedSchedulerDynamicEditException
- when removeChildQueue fails.public CSQueue removeChildQueue(String childQueueName) throws SchedulerDynamicEditException
childQueueName
- name of the child queue to be removedSchedulerDynamicEditException
- when removeChildQueue fails.protected float sumOfChildCapacities()
protected float sumOfChildAbsCapacities()
public AutoCreatedLeafQueueConfig getLeafQueueTemplate()
public AutoCreatedQueueManagementPolicy getAutoCreatedQueueManagementPolicy()
protected CapacitySchedulerConfiguration initializeLeafQueueConfigs(String configPrefix)
protected void validateQueueEntitlementChange(AbstractAutoCreatedLeafQueue leafQueue, QueueEntitlement entitlement) throws SchedulerDynamicEditException
SchedulerDynamicEditException
Copyright © 2008–2024 Apache Software Foundation. All rights reserved.