Package | Description |
---|---|
org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity | |
org.apache.hadoop.yarn.server.resourcemanager.placement | |
org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity | |
org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.policy | |
org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.preemption | |
org.apache.hadoop.yarn.server.resourcemanager.scheduler.event | |
org.apache.hadoop.yarn.server.resourcemanager.webapp.dao |
This package contains the web data access objects (DAO) for the RM.
|
org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.helper |
This package contains helper classes for any Info object.
|
Constructor and Description |
---|
TempQueuePerPartition(String queueName,
org.apache.hadoop.yarn.api.records.Resource current,
boolean preemptionDisabled,
String partition,
org.apache.hadoop.yarn.api.records.Resource killable,
float absCapacity,
float absMaxCapacity,
org.apache.hadoop.yarn.api.records.Resource totalPartitionResource,
org.apache.hadoop.yarn.api.records.Resource reserved,
CSQueue queue,
org.apache.hadoop.yarn.api.records.Resource effMinRes,
org.apache.hadoop.yarn.api.records.Resource effMaxRes) |
Modifier and Type | Method and Description |
---|---|
static QueueMapping |
QueuePlacementRuleUtils.validateAndGetQueueMapping(CapacitySchedulerQueueManager queueManager,
CSQueue queue,
QueueMapping mapping) |
static void |
QueuePlacementRuleUtils.validateQueueMappingUnderParentQueue(CSQueue parentQueue,
String parentQueueName,
String leafQueuePath) |
Modifier and Type | Class and Description |
---|---|
class |
AbstractAutoCreatedLeafQueue
Abstract class for dynamic auto created queues managed by an implementation
of AbstractManagedParentQueue
|
class |
AbstractCSQueue
Provides implementation of
CSQueue methods common for every queue class in Capacity
Scheduler. |
class |
AbstractLeafQueue |
class |
AbstractManagedParentQueue
A container class for automatically created child leaf queues.
|
class |
AbstractParentQueue |
class |
AutoCreatedLeafQueue
Leaf queues which are auto created by an underlying implementation of
AbstractManagedParentQueue.
|
class |
LeafQueue |
class |
ManagedParentQueue
Auto Creation enabled Parent queue.
|
class |
ParentQueue |
class |
PlanQueue
This represents a dynamic queue managed by the
ReservationSystem . |
class |
ReservationQueue
This represents a dynamic
LeafQueue managed by the
ReservationSystem |
Modifier and Type | Field and Description |
---|---|
protected CSQueue |
ResourceCalculationDriver.queue |
Modifier and Type | Field and Description |
---|---|
protected List<CSQueue> |
AbstractParentQueue.childQueues |
Modifier and Type | Method and Description |
---|---|
CSQueue |
AbstractParentQueue.createNewQueue(String childQueuePath,
boolean isLeaf) |
CSQueue |
CSQueueStore.get(String name)
Getter method for the queue it can find queues by both full and
short names.
|
CSQueue |
CSQueue.getParent()
Get the parent
Queue . |
CSQueue |
AbstractCSQueue.getParent() |
CSQueue |
CalculationContext.getQueue() |
CSQueue |
QueueManagementChange.getQueue() |
CSQueue |
ResourceCalculationDriver.getQueue()
Returns the parent that is driving the calculation.
|
CSQueue |
CapacityScheduler.getQueue(String queueName) |
CSQueue |
CapacitySchedulerQueueManager.getQueue(String queueName) |
CSQueue |
CapacitySchedulerQueueManager.getQueueByFullName(String name) |
CSQueue |
CapacityScheduler.getRootQueue() |
CSQueue |
CapacitySchedulerQueueManager.getRootQueue() |
CSQueue |
AbstractManagedParentQueue.removeChildQueue(String childQueueName)
Remove the specified child queue.
|
Modifier and Type | Method and Description |
---|---|
List<CSQueue> |
AbstractLeafQueue.getChildQueues() |
List<CSQueue> |
CSQueue.getChildQueues()
Get child queues
|
List<CSQueue> |
AbstractParentQueue.getChildQueues() |
Collection<CSQueue> |
ResourceCalculationDriver.getChildQueues()
Returns all the children defined under the driver parent queue.
|
List<CSQueue> |
AbstractLeafQueue.getChildQueuesByTryLock() |
List<CSQueue> |
CSQueue.getChildQueuesByTryLock()
Get child queues By tryLock.
|
List<CSQueue> |
AbstractParentQueue.getChildQueuesByTryLock() |
Collection<CSQueue> |
CSQueueStore.getQueues()
Returns all queues as a list.
|
Map<String,CSQueue> |
CapacitySchedulerQueueManager.getQueues() |
QueueStateManager<CSQueue,CapacitySchedulerConfiguration> |
CapacitySchedulerQueueManager.getQueueStateManager() |
Map<String,CSQueue> |
CapacitySchedulerQueueManager.getShortNameQueues() |
Modifier and Type | Method and Description |
---|---|
void |
CSQueueStore.add(CSQueue queue)
Method for adding a queue to the store.
|
void |
ManagedParentQueue.addChildQueue(CSQueue childQueue) |
void |
AbstractManagedParentQueue.addChildQueue(CSQueue childQueue)
Add the specified child queue.
|
void |
CapacitySchedulerQueueManager.addQueue(String queueName,
CSQueue queue) |
void |
AbstractLeafQueue.completedContainer(org.apache.hadoop.yarn.api.records.Resource clusterResource,
FiCaSchedulerApp application,
FiCaSchedulerNode node,
RMContainer rmContainer,
org.apache.hadoop.yarn.api.records.ContainerStatus containerStatus,
RMContainerEventType event,
CSQueue childQueue,
boolean sortQueues) |
void |
CSQueue.completedContainer(org.apache.hadoop.yarn.api.records.Resource clusterResource,
FiCaSchedulerApp application,
FiCaSchedulerNode node,
RMContainer container,
org.apache.hadoop.yarn.api.records.ContainerStatus containerStatus,
RMContainerEventType event,
CSQueue childQueue,
boolean sortQueues)
A container assigned to the queue has completed.
|
void |
AbstractParentQueue.completedContainer(org.apache.hadoop.yarn.api.records.Resource clusterResource,
FiCaSchedulerApp application,
FiCaSchedulerNode node,
RMContainer rmContainer,
org.apache.hadoop.yarn.api.records.ContainerStatus containerStatus,
RMContainerEventType event,
CSQueue completedChildQueue,
boolean sortQueues) |
static float |
CSQueueUtils.computeAbsoluteMaximumCapacity(float maximumCapacity,
CSQueue parent) |
org.apache.hadoop.yarn.api.records.Priority |
WorkflowPriorityMappingsManager.getMappedPriority(String workflowID,
CSQueue queue) |
ResourceLimits |
AbstractParentQueue.getResourceLimitsOfChild(CSQueue child,
org.apache.hadoop.yarn.api.records.Resource clusterResource,
ResourceLimits parentLimits,
String nodePartition,
boolean netLimit) |
protected Set<String> |
AbstractQueueCapacityCalculator.getResourceNames(CSQueue queue,
String label)
Returns all resource names that are defined for the capacity type that is
handled by the calculator.
|
protected Set<String> |
AbstractQueueCapacityCalculator.getResourceNames(CSQueue queue,
String label,
QueueCapacityVector.ResourceUnitCapacityType capacityType)
Returns all resource names that are defined for a capacity type.
|
org.apache.hadoop.yarn.api.records.Priority |
WorkflowPriorityMappingsManager.mapWorkflowPriorityForApp(org.apache.hadoop.yarn.api.records.ApplicationId applicationId,
CSQueue queue,
String user,
org.apache.hadoop.yarn.api.records.Priority priority) |
void |
AutoCreatedLeafQueue.reinitialize(CSQueue newlyParsedQueue,
org.apache.hadoop.yarn.api.records.Resource clusterResource) |
void |
ManagedParentQueue.reinitialize(CSQueue newlyParsedQueue,
org.apache.hadoop.yarn.api.records.Resource clusterResource) |
void |
AbstractLeafQueue.reinitialize(CSQueue newlyParsedQueue,
org.apache.hadoop.yarn.api.records.Resource clusterResource) |
void |
CSQueue.reinitialize(CSQueue newlyParsedQueue,
org.apache.hadoop.yarn.api.records.Resource clusterResource)
Reinitialize the queue.
|
void |
AbstractManagedParentQueue.reinitialize(CSQueue newlyParsedQueue,
org.apache.hadoop.yarn.api.records.Resource clusterResource) |
void |
PlanQueue.reinitialize(CSQueue newlyParsedQueue,
org.apache.hadoop.yarn.api.records.Resource clusterResource) |
void |
AbstractParentQueue.reinitialize(CSQueue newlyParsedQueue,
org.apache.hadoop.yarn.api.records.Resource clusterResource) |
void |
ReservationQueue.reinitialize(CSQueue newlyParsedQueue,
org.apache.hadoop.yarn.api.records.Resource clusterResource) |
void |
CSQueueStore.remove(CSQueue queue)
Method for removing a queue from the store.
|
void |
AbstractManagedParentQueue.removeChildQueue(CSQueue childQueue)
Remove the specified child queue.
|
void |
AbstractParentQueue.removeChildQueue(CSQueue queue) |
void |
CapacityScheduler.removeQueue(CSQueue queue) |
void |
CSQueue.setParent(CSQueue newParentQueue)
Set the parent
Queue . |
void |
AbstractCSQueue.setParent(CSQueue newParentQueue) |
static void |
CapacitySchedulerQueueCapacityHandler.setQueueCapacities(org.apache.hadoop.yarn.api.records.Resource clusterResource,
CSQueue queue,
String label)
Sets capacity and absolute capacity values of a queue based on minimum and
maximum effective resources.
|
protected void |
CapacitySchedulerQueueManager.setRootQueue(CSQueue rootQueue) |
void |
AbsoluteResourceCapacityCalculator.updateCapacitiesAfterCalculation(ResourceCalculationDriver resourceCalculationDriver,
CSQueue queue,
String label) |
void |
PercentageQueueCapacityCalculator.updateCapacitiesAfterCalculation(ResourceCalculationDriver resourceCalculationDriver,
CSQueue queue,
String label) |
abstract void |
AbstractQueueCapacityCalculator.updateCapacitiesAfterCalculation(ResourceCalculationDriver resourceCalculationDriver,
CSQueue queue,
String label)
Sets the metrics and statistics after effective resource values calculation.
|
void |
RootQueueCapacityCalculator.updateCapacitiesAfterCalculation(ResourceCalculationDriver resourceCalculationDriver,
CSQueue queue,
String label) |
void |
WeightQueueCapacityCalculator.updateCapacitiesAfterCalculation(ResourceCalculationDriver resourceCalculationDriver,
CSQueue queue,
String label) |
QueueCapacityUpdateContext |
CapacitySchedulerQueueCapacityHandler.updateChildren(org.apache.hadoop.yarn.api.records.Resource clusterResource,
CSQueue queue)
Updates the resource and metrics values of all children under a specific queue.
|
void |
CapacitySchedulerQueueCapacityHandler.updateRoot(CSQueue rootQueue,
org.apache.hadoop.yarn.api.records.Resource clusterResource)
Updates the resource and metrics value of the root queue.
|
protected void |
ManagedParentQueue.validate(CSQueue newlyParsedQueue) |
Modifier and Type | Method and Description |
---|---|
AbstractParentQueue.QueueCapacityType |
AbstractParentQueue.getCapacityConfigurationTypeForQueues(Collection<CSQueue> queues) |
Modifier and Type | Method and Description |
---|---|
CSQueue |
PriorityUtilizationQueueOrderingPolicy.PriorityQueueResourcesForSorting.getQueue() |
Modifier and Type | Method and Description |
---|---|
Iterator<CSQueue> |
PriorityUtilizationQueueOrderingPolicy.getAssignmentIterator(String partition) |
Iterator<CSQueue> |
QueueOrderingPolicy.getAssignmentIterator(String partition)
Return an iterator over the collection of CSQueues which orders
them for container assignment.
|
List<CSQueue> |
PriorityUtilizationQueueOrderingPolicy.getQueues() |
Modifier and Type | Method and Description |
---|---|
void |
PriorityUtilizationQueueOrderingPolicy.setQueues(List<CSQueue> queues) |
void |
QueueOrderingPolicy.setQueues(List<CSQueue> queues) |
Modifier and Type | Method and Description |
---|---|
void |
PreemptionManager.refreshQueues(CSQueue parent,
CSQueue current) |
Modifier and Type | Method and Description |
---|---|
CSQueue |
AutoCreatedQueueDeletionEvent.getCheckQueue() |
Constructor and Description |
---|
AutoCreatedQueueDeletionEvent(CSQueue checkQueue) |
Modifier and Type | Method and Description |
---|---|
protected CapacitySchedulerQueueInfoList |
CapacitySchedulerInfo.getQueues(CapacityScheduler cs,
CSQueue parent) |
static ArrayList<QueueAclInfo> |
CapacitySchedulerQueueInfo.getSortedQueueAclInfoList(CSQueue queue,
String queuePath,
CapacitySchedulerConfiguration conf) |
protected void |
CapacitySchedulerLeafQueueInfo.populateQueueCapacities(CSQueue queue) |
protected void |
CapacitySchedulerQueueInfo.populateQueueCapacities(CSQueue queue) |
Constructor and Description |
---|
CapacitySchedulerInfo(CSQueue parent,
CapacityScheduler cs) |
QueueCapacitiesInfo(CSQueue queue,
boolean considerAMUsage) |
Modifier and Type | Method and Description |
---|---|
static String |
CapacitySchedulerInfoHelper.getAutoCreationEligibility(CSQueue queue) |
static String |
CapacitySchedulerInfoHelper.getCreationMethod(CSQueue queue) |
static String |
CapacitySchedulerInfoHelper.getMode(CSQueue queue) |
static String |
CapacitySchedulerInfoHelper.getQueueType(CSQueue queue) |
Copyright © 2008–2024 Apache Software Foundation. All rights reserved.