public class AbstractAutoCreatedLeafQueue extends LeafQueue
AbstractCSQueue.CapacityConfigType
Modifier and Type | Field and Description |
---|---|
protected AbstractManagedParentQueue |
parent |
maxApplications, maxApplicationsPerUser
activitiesManager, authorizer, capacityConfigType, csContext, queueEntity, readLock, writeLock
Constructor and Description |
---|
AbstractAutoCreatedLeafQueue(CapacitySchedulerContext cs,
CapacitySchedulerConfiguration leafQueueConfigs,
String queueName,
AbstractManagedParentQueue parent,
CSQueue old) |
AbstractAutoCreatedLeafQueue(CapacitySchedulerContext cs,
String queueName,
AbstractManagedParentQueue parent,
CSQueue old) |
Modifier and Type | Method and Description |
---|---|
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
|
protected void |
setupConfigurableCapacities(QueueCapacities queueCapacities) |
accept, activateApplications, apply, assignContainers, attachContainer, calculateAndGetAMResourceLimit, calculateAndGetAMResourceLimitPerPartition, canAssignToUser, collectSchedulerApplications, completedContainer, decAMUsedResource, decUsedResource, detachContainer, finishApplication, finishApplicationAttempt, getAbstractUsersManager, getAllApplications, getAllUsers, getAMResourceLimit, getAMResourceLimitPerPartition, getApplications, getChildQueues, getDefaultApplicationPriority, getHeadroom, getHeadroom, getIgnoreExclusivityRMContainers, getMaxAMResourcePerQueuePercent, getMaxApplications, getMaxApplicationsPerUser, getMinimumAllocationFactor, getNodeLocalityDelay, getNumActiveApplications, getNumActiveApplications, getNumApplications, getNumPendingApplications, getNumPendingApplications, getOrderingPolicy, getPendingApplications, getPendingAppsOrderingPolicy, getPriorityACLs, getQueueInfo, getQueueUserAclInfo, getRackLocalityAdditionalDelay, getRackLocalityFullReset, getResourceLimitForActiveUsers, getResourceLimitForAllUsers, getTotalPendingResourcesConsideringUserLimit, getUser, getUserAMResourceLimit, getUserAMResourceLimitPerPartition, getUserLimit, getUserLimitFactor, getUsersManager, incAMUsedResource, incUsedResource, recalculateQueueUsageRatio, recoverContainer, reinitialize, reinitialize, setAbsoluteCapacity, setAbsoluteCapacity, setCapacity, setCapacity, setMaxAMResourcePerQueuePercent, setMaxApplications, setMaxApplicationsPerUser, setupQueueConfigs, setupQueueConfigs, stopQueue, submitApplication, submitApplicationAttempt, submitApplicationAttempt, toString, updateApplicationPriority, updateClusterResource, validateSubmitApplication
accessibleToPartition, activeQueue, appFinished, assignContainers, decPendingResource, decReservedResource, getAbsoluteCapacity, getAbsoluteMaximumCapacity, getAbsoluteUsedCapacity, getAccessibleNodeLabels, getACLs, getCapacity, getCapacityConfigType, getDefaultApplicationLifetime, getDefaultAppLifetimeWasSpecifiedInConfig, getDefaultNodeLabelExpression, getEffectiveCapacity, getEffectiveCapacityDown, getEffectiveMaxCapacity, getEffectiveMaxCapacityDown, getIntraQueuePreemptionDisabled, getIntraQueuePreemptionDisabledInHierarchy, getKillableContainers, getMaximumAllocation, getMaximumApplicationLifetime, getMaximumCapacity, getMaxParallelApps, 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, hasChildQueues, incPendingResource, incReservedResource, recoverDrainingState, releaseResource, setMaxParallelApps, setMultiNodeSortingPolicyName, setParent, setupConfigurableCapacities, setupConfigurableCapacities, updateConfigurableResourceRequirement, updateQueueState
protected AbstractManagedParentQueue parent
public AbstractAutoCreatedLeafQueue(CapacitySchedulerContext cs, String queueName, AbstractManagedParentQueue parent, CSQueue old) throws IOException
IOException
public AbstractAutoCreatedLeafQueue(CapacitySchedulerContext cs, CapacitySchedulerConfiguration leafQueueConfigs, 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
public void setEntitlement(String nodeLabel, QueueEntitlement entitlement) throws SchedulerDynamicEditException
entitlement
- the new entitlement for the queue (capacity,
maxCapacity, etc..)SchedulerDynamicEditException
protected void setupConfigurableCapacities(QueueCapacities queueCapacities)
Copyright © 2008–2022 Apache Software Foundation. All rights reserved.