Modifier and Type | Class and Description |
---|---|
class |
FSLeafQueue |
class |
FSParentQueue |
Modifier and Type | Method and Description |
---|---|
FSQueue |
QueueManager.getQueue(String name)
Gets a queue by name.
|
Modifier and Type | Method and Description |
---|---|
List<FSQueue> |
FSLeafQueue.getChildQueues() |
List<FSQueue> |
FSParentQueue.getChildQueues() |
abstract List<FSQueue> |
FSQueue.getChildQueues()
Gets the children of this queue, if any.
|
Collection<FSQueue> |
QueueManager.getQueues()
Get a collection of all queues.
|
Modifier and Type | Method and Description |
---|---|
boolean |
MaxRunningAppsEnforcer.canAppBeRunnable(FSQueue queue,
FSAppAttempt attempt)
Checks whether making the application runnable would exceed any
maxRunningApps limits.
|
boolean |
MaxRunningAppsEnforcer.exceedQueueMaxRunningApps(FSQueue queue)
Recursively checks whether the number of queue runnable apps exceeds the
limitation.
|
void |
AllocationConfiguration.initFSQueue(FSQueue queue)
Initialize a
FSQueue with queue-specific properties and its
metrics. |
Modifier and Type | Method and Description |
---|---|
abstract void |
SchedulingPolicy.computeSteadyShares(Collection<? extends FSQueue> queues,
org.apache.hadoop.yarn.api.records.Resource totalResources)
Computes and updates the steady shares of
FSQueue s as per the
SchedulingPolicy . |
Modifier and Type | Method and Description |
---|---|
void |
FifoPolicy.computeSteadyShares(Collection<? extends FSQueue> queues,
org.apache.hadoop.yarn.api.records.Resource totalResources) |
void |
DominantResourceFairnessPolicy.computeSteadyShares(Collection<? extends FSQueue> queues,
org.apache.hadoop.yarn.api.records.Resource totalResources) |
void |
FairSharePolicy.computeSteadyShares(Collection<? extends FSQueue> queues,
org.apache.hadoop.yarn.api.records.Resource totalResources) |
static void |
ComputeFairShares.computeSteadyShares(Collection<? extends FSQueue> queues,
org.apache.hadoop.yarn.api.records.Resource totalResources,
String type)
Compute the steady fair share of the given queues.
|
Modifier and Type | Method and Description |
---|---|
protected FairSchedulerQueueInfoList |
FairSchedulerQueueInfo.getChildQueues(FSQueue queue,
FairScheduler scheduler) |
Constructor and Description |
---|
FairSchedulerQueueInfo(FSQueue queue,
FairScheduler scheduler) |
Copyright © 2008–2022 Apache Software Foundation. All rights reserved.