Package | Description |
---|---|
org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity | |
org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.queuemanagement |
Contains classes that are related to the newer
version of CS placement engine.
|
Modifier and Type | Method and Description |
---|---|
void |
ManagedParentQueue.addChildQueue(CSQueue childQueue) |
void |
AbstractManagedParentQueue.addChildQueue(CSQueue childQueue)
Add the specified child queue.
|
LeafQueue |
ParentQueue.addDynamicLeafQueue(String queuePath) |
ParentQueue |
ParentQueue.addDynamicParentQueue(String queuePath) |
void |
CapacitySchedulerQueueManager.addLegacyDynamicQueue(Queue queue)
Adds an
AutoCreatedLeafQueue to the manager collection and extends
the children collection of its parent. |
void |
CapacityScheduler.addQueue(Queue queue) |
void |
AutoCreatedQueueManagementPolicy.commitQueueManagementChanges(List<QueueManagementChange> queueManagementChanges)
Commit/Update state for the specified queue management changes.
|
List<QueueManagementChange> |
AutoCreatedQueueManagementPolicy.computeQueueManagementChanges()
Compute/Adjust child queue capacities
for auto created leaf queues
This computes queue entitlements but does not update LeafQueueState or
queue capacities.
|
CSQueue |
AbstractParentQueue.createNewQueue(String childQueuePath,
boolean isLeaf) |
List<String> |
CapacitySchedulerQueueManager.determineMissingParents(QueuePath queue)
Determines the missing parent paths of a potentially auto creatable queue.
|
AutoCreatedLeafQueueConfig |
AutoCreatedQueueManagementPolicy.getInitialLeafQueueConfiguration(AbstractAutoCreatedLeafQueue leafQueue)
Get initial template for the specified leaf queue.
|
void |
ReservationQueue.initializeEntitlements() |
void |
AbstractManagedParentQueue.removeChildQueue(CSQueue childQueue)
Remove the specified child queue.
|
void |
AbstractParentQueue.removeChildQueue(CSQueue queue) |
CSQueue |
AbstractManagedParentQueue.removeChildQueue(String childQueueName)
Remove the specified child queue.
|
void |
CapacitySchedulerQueueManager.removeLegacyDynamicQueue(String queueName)
Removes an
AutoCreatedLeafQueue from the manager collection and
from its parent children collection. |
void |
CapacityScheduler.removeQueue(CSQueue queue) |
void |
CapacityScheduler.removeQueue(String queueName) |
void |
AbstractAutoCreatedLeafQueue.setEntitlement(QueueEntitlement entitlement)
This methods to change capacity for a queue and adjusts its
absoluteCapacity
|
void |
AbstractAutoCreatedLeafQueue.setEntitlement(String nodeLabel,
QueueEntitlement entitlement)
This methods to change capacity for a queue and adjusts its
absoluteCapacity.
|
void |
ManagedParentQueue.validateAndApplyQueueManagementChanges(List<QueueManagementChange> queueManagementChanges)
Asynchronously called from scheduler to apply queue management changes.
|
void |
AutoCreatedLeafQueue.validateConfigurations(AutoCreatedLeafQueueConfig template) |
protected void |
AbstractManagedParentQueue.validateQueueEntitlementChange(AbstractAutoCreatedLeafQueue leafQueue,
QueueEntitlement entitlement) |
void |
ManagedParentQueue.validateQueueManagementChanges(List<QueueManagementChange> queueManagementChanges) |
Modifier and Type | Method and Description |
---|---|
void |
GuaranteedOrZeroCapacityOverTimePolicy.commitQueueManagementChanges(List<QueueManagementChange> queueManagementChanges)
Commit queue management changes - which involves updating required state
on parent/underlying leaf queues.
|
List<QueueManagementChange> |
GuaranteedOrZeroCapacityOverTimePolicy.computeQueueManagementChanges()
Computes / adjusts child queue capacities for auto created leaf queues.
|
AutoCreatedLeafQueueConfig |
GuaranteedOrZeroCapacityOverTimePolicy.getInitialLeafQueueConfiguration(AbstractAutoCreatedLeafQueue leafQueue) |
boolean |
GuaranteedOrZeroCapacityOverTimePolicy.isActive(AutoCreatedLeafQueue leafQueue,
String nodeLabel) |
Copyright © 2008–2024 Apache Software Foundation. All rights reserved.