public class AbstractAutoCreatedLeafQueue extends AbstractLeafQueue
AbstractCSQueue.CapacityConfigType
Modifier and Type | Field and Description |
---|---|
protected AbstractManagedParentQueue |
parent |
maxApplications, maxApplicationsPerUser
activitiesManager, authorizer, capacityConfigType, configuredCapacityVectors, configuredMaxCapacityVectors, queueAllocationSettings, queueContext, queueEntity, queueNodeLabelsSettings, queuePath, readLock, writeLock
Constructor and Description |
---|
AbstractAutoCreatedLeafQueue(CapacitySchedulerQueueContext queueContext,
String queueName,
AbstractManagedParentQueue parent,
CSQueue old) |
Modifier and Type | Method and Description |
---|---|
protected boolean |
checkConfigTypeIsAbsoluteResource(String queuePath,
String label) |
protected org.apache.hadoop.yarn.api.records.Resource |
getMaximumAbsoluteResource(String queuePath,
String label) |
protected org.apache.hadoop.yarn.api.records.Resource |
getMinimumAbsoluteResource(String queuePath,
String label) |
void |
setEntitlement(QueueEntitlement entitlement)
This methods to change capacity for a queue and adjusts its
absoluteCapacity
|
void |
setEntitlement(String nodeLabel,
QueueEntitlement entitlement)
This methods to change capacity for a queue and adjusts its
absoluteCapacity.
|
accept, activateApplications, apply, assignContainers, attachContainer, calculateAndGetAMResourceLimit, calculateAndGetAMResourceLimitPerPartition, canAssignToUser, collectSchedulerApplications, completedContainer, decAMUsedResource, decUsedResource, detachContainer, finishApplication, finishApplicationAttempt, getAbstractUsersManager, getAllApplications, getAllUsers, getAMResourceLimit, getAMResourceLimitPerPartition, getApplications, getChildQueues, getChildQueuesByTryLock, getDefaultApplicationPriority, getExtendedCapacityOrWeightString, getHeadroom, getHeadroom, getIgnoreExclusivityRMContainers, getMaxAMResourcePerQueuePercent, getMaxApplications, getMaxApplicationsPerUser, getMinimumAllocationFactor, getNodeLocalityDelay, getNumActiveApplications, getNumActiveApplications, getNumApplications, getNumPendingApplications, getNumPendingApplications, getOrCreateUser, getOrderingPolicy, getPendingApplications, getPendingAppsOrderingPolicy, getPriorityACLs, getQueueInfo, getQueueUserAclInfo, getRackLocalityAdditionalDelay, getRackLocalityFullReset, getResourceLimitForActiveUsers, getResourceLimitForAllUsers, getTotalPendingResourcesConsideringUserLimit, getUser, getUserAMResourceLimit, getUserAMResourceLimitPerPartition, getUserLimit, getUserLimitFactor, getUsersManager, incAMUsedResource, incUsedResource, isEligibleForAutoDeletion, parseAndSetDynamicTemplates, recalculateQueueUsageRatio, recoverContainer, refreshAfterResourceCalculation, reinitialize, setAbsoluteCapacity, setAbsoluteCapacity, setCapacity, setCapacity, setDynamicQueueACLProperties, setMaxAMResourcePerQueuePercent, setMaxApplications, setMaxApplicationsPerUser, setupQueueConfigs, stopQueue, submitApplication, submitApplicationAttempt, submitApplicationAttempt, toString, updateApplicationPriority, updateClusterResource, updateClusterResourceLegacyMode, validateSubmitApplication
activateQueue, appFinished, assignContainers, decPendingResource, decReservedResource, getAbsoluteCapacity, getAbsoluteMaximumCapacity, getAbsoluteUsedCapacity, getAccessibleNodeLabels, getACLs, getCapacity, getCapacityConfigType, getCapacityOrWeightString, getConfiguredCapacityVector, getConfiguredMaxCapacityVector, getConfiguredNodeLabels, getDefaultApplicationLifetime, getDefaultAppLifetimeWasSpecifiedInConfig, getDefaultNodeLabelExpression, getEffectiveCapacity, getEffectiveCapacityDown, getEffectiveMaxCapacity, getEffectiveMaxCapacityDown, getIntraQueuePreemptionDisabled, getIntraQueuePreemptionDisabledInHierarchy, getKillableContainers, getMaximumAllocation, getMaximumApplicationLifetime, getMaximumCapacity, getMaxParallelApps, getMetrics, 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, isDynamicQueue, isInactiveDynamicQueue, isReservationsContinueLooking, overrideCapacityVectorsForSpecialQueues, recoverDrainingState, releaseResource, setConfiguredMaxCapacityVector, setConfiguredMinCapacityVector, setDynamicQueue, setMaxParallelApps, setMultiNodeSortingPolicyName, setParent, setupConfigurableCapacities, updateAbsoluteCapacities, updateCapacityConfigType, updateConfigurableResourceLimits, updateQueueState
protected AbstractManagedParentQueue parent
public AbstractAutoCreatedLeafQueue(CapacitySchedulerQueueContext queueContext, String queueName, AbstractManagedParentQueue parent, CSQueue old) throws IOException
IOException
public void setEntitlement(QueueEntitlement entitlement) throws SchedulerDynamicEditException
entitlement
- the new entitlement for the queue (capacity,
maxCapacity, etc..)SchedulerDynamicEditException
- when setEntitlement fails.protected org.apache.hadoop.yarn.api.records.Resource getMinimumAbsoluteResource(String queuePath, String label)
getMinimumAbsoluteResource
in class AbstractCSQueue
protected org.apache.hadoop.yarn.api.records.Resource getMaximumAbsoluteResource(String queuePath, String label)
getMaximumAbsoluteResource
in class AbstractCSQueue
protected boolean checkConfigTypeIsAbsoluteResource(String queuePath, String label)
checkConfigTypeIsAbsoluteResource
in class AbstractCSQueue
public void setEntitlement(String nodeLabel, QueueEntitlement entitlement) throws SchedulerDynamicEditException
nodeLabel
- nodeLabel.entitlement
- the new entitlement for the queue (capacity,
maxCapacity, etc..)SchedulerDynamicEditException
- when setEntitlement fails.Copyright © 2008–2024 Apache Software Foundation. All rights reserved.