public class AutoCreatedLeafQueue extends AbstractAutoCreatedLeafQueue
AbstractCSQueue.CapacityConfigType
parent
maxApplications, maxApplicationsPerUser
activitiesManager, authorizer, capacityConfigType, configuredCapacityVectors, configuredMaxCapacityVectors, queueAllocationSettings, queueContext, queueEntity, queueNodeLabelsSettings, queuePath, readLock, writeLock
Constructor and Description |
---|
AutoCreatedLeafQueue(CapacitySchedulerQueueContext queueContext,
String queueName,
ManagedParentQueue parent) |
Modifier and Type | Method and Description |
---|---|
void |
mergeCapacities(QueueCapacities capacities,
QueueResourceQuotas resourceQuotas) |
protected void |
parseAndSetDynamicTemplates()
Set properties specific to dynamic queues.
|
void |
reinitialize(CSQueue newlyParsedQueue,
org.apache.hadoop.yarn.api.records.Resource clusterResource)
Reinitialize the queue.
|
void |
reinitializeFromTemplate(AutoCreatedLeafQueueConfig leafQueueTemplate) |
void |
validateConfigurations(AutoCreatedLeafQueueConfig template) |
checkConfigTypeIsAbsoluteResource, getMaximumAbsoluteResource, getMinimumAbsoluteResource, setEntitlement, setEntitlement
accept, activateApplications, apply, assignContainers, attachContainer, calculateAndGetAMResourceLimit, calculateAndGetAMResourceLimitPerPartition, canAssignToUser, collectSchedulerApplications, completedContainer, decAMUsedResource, decUsedResource, detachContainer, finishApplication, finishApplicationAttempt, getAbstractUsersManager, getAllApplications, getAllUsers, getAMResourceLimit, getAMResourceLimitPerPartition, getApplications, getChildQueues, 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, recalculateQueueUsageRatio, recoverContainer, refreshAfterResourceCalculation, 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
public AutoCreatedLeafQueue(CapacitySchedulerQueueContext queueContext, String queueName, ManagedParentQueue parent) 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 AbstractLeafQueue
newlyParsedQueue
- new queue to re-initalize fromclusterResource
- resources in the clusterIOException
- an I/O exception has occurred.public void reinitializeFromTemplate(AutoCreatedLeafQueueConfig leafQueueTemplate)
public void mergeCapacities(QueueCapacities capacities, QueueResourceQuotas resourceQuotas)
public void validateConfigurations(AutoCreatedLeafQueueConfig template) throws SchedulerDynamicEditException
SchedulerDynamicEditException
protected void parseAndSetDynamicTemplates()
AbstractCSQueue
parseAndSetDynamicTemplates
in class AbstractLeafQueue
Copyright © 2008–2024 Apache Software Foundation. All rights reserved.