Modifier and Type | Class and Description |
---|---|
class |
AbstractCSQueue |
class |
LeafQueue |
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 List<CSQueue> |
ParentQueue.childQueues |
Modifier and Type | Method and Description |
---|---|
CSQueue |
CSQueue.getParent()
Get the parent
Queue . |
CSQueue |
AbstractCSQueue.getParent() |
CSQueue |
CapacitySchedulerQueueManager.getQueue(String queueName) |
CSQueue |
CapacityScheduler.getQueue(String queueName) |
CSQueue |
CapacitySchedulerQueueManager.getRootQueue() |
CSQueue |
CapacityScheduler.getRootQueue() |
Modifier and Type | Method and Description |
---|---|
List<CSQueue> |
ParentQueue.getChildQueues() |
List<CSQueue> |
LeafQueue.getChildQueues() |
List<CSQueue> |
CSQueue.getChildQueues()
Get child queues
|
Map<String,CSQueue> |
CapacitySchedulerQueueManager.getQueues() |
QueueStateManager<CSQueue,CapacitySchedulerConfiguration> |
CapacitySchedulerQueueManager.getQueueStateManager() |
Modifier and Type | Method and Description |
---|---|
void |
CapacitySchedulerQueueManager.addQueue(String queueName,
CSQueue queue) |
void |
ParentQueue.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) |
void |
LeafQueue.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.
|
org.apache.hadoop.yarn.api.records.Priority |
WorkflowPriorityMappingsManager.getMappedPriority(String workflowID,
CSQueue queue) |
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 |
ParentQueue.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 |
LeafQueue.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 |
CSQueue.reinitialize(CSQueue newlyParsedQueue,
org.apache.hadoop.yarn.api.records.Resource clusterResource)
Reinitialize the queue.
|
void |
CSQueue.setParent(CSQueue newParentQueue)
Set the parent
Queue . |
void |
AbstractCSQueue.setParent(CSQueue newParentQueue) |
Modifier and Type | Method and Description |
---|---|
static void |
CapacitySchedulerQueueManager.setQueueAcls(org.apache.hadoop.yarn.security.YarnAuthorizationProvider authorizer,
AppPriorityACLsManager appPriorityACLManager,
Map<String,CSQueue> queues) |
Constructor and Description |
---|
AbstractCSQueue(CapacitySchedulerContext cs,
String queueName,
CSQueue parent,
CSQueue old) |
LeafQueue(CapacitySchedulerContext cs,
String queueName,
CSQueue parent,
CSQueue old) |
ParentQueue(CapacitySchedulerContext cs,
String queueName,
CSQueue parent,
CSQueue old) |
PlanQueue(CapacitySchedulerContext cs,
String queueName,
CSQueue parent,
CSQueue old) |
Modifier and Type | Method and Description |
---|---|
CSQueue |
PriorityUtilizationQueueOrderingPolicy.PriorityQueueResourcesForSorting.getQueue() |
Modifier and Type | Method and Description |
---|---|
Iterator<CSQueue> |
QueueOrderingPolicy.getAssignmentIterator(String partition)
Return an iterator over the collection of CSQueues which orders
them for container assignment.
|
Iterator<CSQueue> |
PriorityUtilizationQueueOrderingPolicy.getAssignmentIterator(String partition) |
List<CSQueue> |
PriorityUtilizationQueueOrderingPolicy.getQueues() |
Modifier and Type | Method and Description |
---|---|
void |
QueueOrderingPolicy.setQueues(List<CSQueue> queues) |
void |
PriorityUtilizationQueueOrderingPolicy.setQueues(List<CSQueue> queues) |
Modifier and Type | Method and Description |
---|---|
void |
PreemptionManager.refreshQueues(CSQueue parent,
CSQueue current) |
Modifier and Type | Method and Description |
---|---|
protected CapacitySchedulerQueueInfoList |
CapacitySchedulerInfo.getQueues(CSQueue parent) |
Constructor and Description |
---|
CapacitySchedulerInfo(CSQueue parent,
CapacityScheduler cs) |
Copyright © 2022 Apache Software Foundation. All rights reserved.