public class ManagedParentQueue extends AbstractManagedParentQueue
AbstractCSQueue.CapacityConfigType
leafQueueTemplate, queueManagementPolicy
childQueues
activitiesManager, authorizer, capacityConfigType, csContext, queueEntity, readLock, writeLock
Constructor and Description |
---|
ManagedParentQueue(CapacitySchedulerContext cs,
String queueName,
CSQueue parent,
CSQueue old) |
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, 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, setMultiNodeSortingPolicyName, setParent, setupConfigurableCapacities, setupConfigurableCapacities, setupQueueConfigs, updateConfigurableResourceRequirement, updateQueueState
public ManagedParentQueue(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
protected AutoCreatedLeafQueueConfig.Builder initializeLeafQueueConfigs()
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
IOException
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
- IOException
SchedulerDynamicEditException
public void validateQueueManagementChanges(List<QueueManagementChange> queueManagementChanges) throws SchedulerDynamicEditException
SchedulerDynamicEditException
public CapacitySchedulerConfiguration getLeafQueueConfigs(String leafQueueName)
public CapacitySchedulerConfiguration getLeafQueueConfigs(CapacitySchedulerConfiguration templateConfig, String leafQueueName)
Copyright © 2008–2020 Apache Software Foundation. All rights reserved.