Package | Description |
---|---|
org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity |
Modifier and Type | Class and Description |
---|---|
class |
AbstractAutoCreatedLeafQueue
Abstract class for dynamic auto created queues managed by an implementation
of AbstractManagedParentQueue
|
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 | Method and Description |
---|---|
static org.apache.hadoop.yarn.api.records.QueueInfo |
CSQueueInfoProvider.getQueueInfo(AbstractCSQueue csQueue) |
static void |
QueueStateHelper.setQueueState(AbstractCSQueue queue)
Sets the current state of the queue based on its previous state, its parent's state and its
configured state.
|
static void |
CSQueueUtils.updateConfiguredCapacityMetrics(org.apache.hadoop.yarn.util.resource.ResourceCalculator rc,
org.apache.hadoop.yarn.api.records.Resource partitionResource,
String partition,
AbstractCSQueue queue)
Updated configured capacity/max-capacity for queue.
|
static void |
CSQueueUtils.updateQueueStatistics(org.apache.hadoop.yarn.util.resource.ResourceCalculator rc,
org.apache.hadoop.yarn.api.records.Resource cluster,
AbstractCSQueue childQueue,
RMNodeLabelsManager nlm,
String nodePartition)
Update Queue Statistics:
|
static void |
CSQueueUtils.updateUsedCapacity(org.apache.hadoop.yarn.util.resource.ResourceCalculator rc,
org.apache.hadoop.yarn.api.records.Resource totalPartitionResource,
String nodePartition,
AbstractCSQueue childQueue)
Update partitioned resource usage, if nodePartition == null, will update
used resource for all partitions of this queue.
|
Constructor and Description |
---|
QueueAppLifetimeAndLimitSettings(CapacitySchedulerConfiguration configuration,
AbstractCSQueue q,
QueuePath queuePath) |
Copyright © 2008–2024 Apache Software Foundation. All rights reserved.