public class ReservationQueue extends AbstractAutoCreatedLeafQueue
LeafQueue
managed by the
ReservationSystem
AbstractCSQueue.CapacityConfigType
maxApplications, maxApplicationsPerUser
activitiesManager, authorizer, capacityConfigType, csContext, queueEntity, readLock, writeLock
Constructor and Description |
---|
ReservationQueue(CapacitySchedulerContext cs,
String queueName,
PlanQueue parent) |
Modifier and Type | Method and Description |
---|---|
void |
reinitialize(CSQueue newlyParsedQueue,
org.apache.hadoop.yarn.api.records.Resource clusterResource)
Reinitialize the queue.
|
protected void |
setupConfigurableCapacities(CapacitySchedulerConfiguration configuration) |
setEntitlement, setEntitlement, setupConfigurableCapacities
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, 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, updateConfigurableResourceRequirement, updateQueueState
public ReservationQueue(CapacitySchedulerContext cs, String queueName, PlanQueue 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 LeafQueue
newlyParsedQueue
- new queue to re-initalize fromclusterResource
- resources in the clusterIOException
- an I/O exception has occurred.protected void setupConfigurableCapacities(CapacitySchedulerConfiguration configuration)
setupConfigurableCapacities
in class AbstractCSQueue
Copyright © 2008–2023 Apache Software Foundation. All rights reserved.