public class ManagedParentQueue extends AbstractManagedParentQueue
AbstractParentQueue.QueueCapacityType
AbstractCSQueue.CapacityConfigType
leafQueueTemplate, queueManagementPolicy
childQueues
activitiesManager, authorizer, capacityConfigType, configuredCapacityVectors, configuredMaxCapacityVectors, queueAllocationSettings, queueContext, queueEntity, queueNodeLabelsSettings, queuePath, readLock, writeLock
Constructor and Description |
---|
ManagedParentQueue(CapacitySchedulerQueueContext queueContext,
String queueName,
CSQueue parent,
CSQueue old) |
Modifier and Type | Method and Description |
---|---|
void |
addChildQueue(CSQueue childQueue)
Add the specified child queue.
|
List<FiCaSchedulerApp> |
getAllApplications() |
String |
getLeafQueueConfigPrefix(CapacitySchedulerConfiguration conf) |
List<FiCaSchedulerApp> |
getPendingApplications() |
List<FiCaSchedulerApp> |
getScheduleableApplications() |
protected AutoCreatedLeafQueueConfig.Builder |
initializeLeafQueueConfigs() |
void |
reinitialize(CSQueue newlyParsedQueue,
org.apache.hadoop.yarn.api.records.Resource clusterResource)
Reinitialize the queue.
|
void |
setLeafQueueConfigs(String leafQueueName) |
boolean |
shouldFailAutoCreationWhenGuaranteedCapacityExceeded() |
protected void |
validate(CSQueue newlyParsedQueue) |
void |
validateAndApplyQueueManagementChanges(List<QueueManagementChange> queueManagementChanges)
Asynchronously called from scheduler to apply queue management changes.
|
void |
validateQueueManagementChanges(List<QueueManagementChange> queueManagementChanges) |
getAutoCreatedQueueManagementPolicy, getLeafQueueTemplate, initializeLeafQueueConfigs, removeChildQueue, removeChildQueue, sumOfChildAbsCapacities, sumOfChildCapacities, validateQueueEntitlementChange
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
public ManagedParentQueue(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 AbstractManagedParentQueue
newlyParsedQueue
- new queue to re-initalize fromclusterResource
- resources in the clusterIOException
- an I/O exception has occurred.protected AutoCreatedLeafQueueConfig.Builder initializeLeafQueueConfigs() throws IOException
IOException
protected void validate(CSQueue newlyParsedQueue) throws IOException
IOException
public void addChildQueue(CSQueue childQueue) throws SchedulerDynamicEditException, IOException
AbstractManagedParentQueue
addChildQueue
in class AbstractManagedParentQueue
childQueue
- reference to the child queue to be addedSchedulerDynamicEditException
- when addChildQueue fails.IOException
- an I/O exception has occurred.public List<FiCaSchedulerApp> getScheduleableApplications()
public List<FiCaSchedulerApp> getPendingApplications()
public List<FiCaSchedulerApp> getAllApplications()
public String getLeafQueueConfigPrefix(CapacitySchedulerConfiguration conf)
public boolean shouldFailAutoCreationWhenGuaranteedCapacityExceeded()
public void validateAndApplyQueueManagementChanges(List<QueueManagementChange> queueManagementChanges) throws IOException, SchedulerDynamicEditException
queueManagementChanges
- QueueManagementChange List.IOException
- an I/O exception has occurred.SchedulerDynamicEditException
- when validate and apply QueueManagementChanges fails.public void validateQueueManagementChanges(List<QueueManagementChange> queueManagementChanges) throws SchedulerDynamicEditException
SchedulerDynamicEditException
public void setLeafQueueConfigs(String leafQueueName)
Copyright © 2008–2024 Apache Software Foundation. All rights reserved.