@InterfaceAudience.Private @InterfaceStability.Evolving public class ParentQueue extends AbstractParentQueue
AbstractParentQueue.QueueCapacityType
AbstractCSQueue.CapacityConfigType
childQueues
activitiesManager, authorizer, capacityConfigType, configuredCapacityVectors, configuredMaxCapacityVectors, queueAllocationSettings, queueContext, queueEntity, queueNodeLabelsSettings, queuePath, readLock, writeLock
Constructor and Description |
---|
ParentQueue(CapacitySchedulerQueueContext queueContext,
String queueName,
CSQueue parent,
CSQueue old) |
ParentQueue(CapacitySchedulerQueueContext queueContext,
String queueName,
CSQueue parent,
CSQueue old,
boolean isDynamic) |
Modifier and Type | Method and Description |
---|---|
LeafQueue |
addDynamicLeafQueue(String queuePath) |
ParentQueue |
addDynamicParentQueue(String queuePath) |
apply, assignContainers, attachContainer, collectSchedulerApplications, completedContainer, createNewQueue, detachContainer, finishApplication, finishApplicationAttempt, getAbstractUsersManager, getAutoCreatedQueueTemplate, getCapacityConfigurationTypeForQueues, getChildQueues, getNumApplications, getQueueInfo, getQueueOrderingPolicy, getQueueUserAclInfo, getResourceLimitsOfChild, hasChildQueues, isEligibleForAutoDeletion, isEligibleForAutoQueueCreation, recoverContainer, refreshAfterResourceCalculation, reinitialize, removeChildQueue, 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 ParentQueue(CapacitySchedulerQueueContext queueContext, String queueName, CSQueue parent, CSQueue old) throws IOException
IOException
public ParentQueue(CapacitySchedulerQueueContext queueContext, String queueName, CSQueue parent, CSQueue old, boolean isDynamic) throws IOException
IOException
public ParentQueue addDynamicParentQueue(String queuePath) throws SchedulerDynamicEditException
SchedulerDynamicEditException
public LeafQueue addDynamicLeafQueue(String queuePath) throws SchedulerDynamicEditException
SchedulerDynamicEditException
Copyright © 2008–2024 Apache Software Foundation. All rights reserved.