|
||||||||||
PREV CLASS NEXT CLASS | FRAMES NO FRAMES | |||||||||
SUMMARY: NESTED | FIELD | CONSTR | METHOD | DETAIL: FIELD | CONSTR | METHOD |
java.lang.Objectorg.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.Schedulable
org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
@InterfaceAudience.Private @InterfaceStability.Unstable public abstract class FSQueue
Field Summary | |
---|---|
protected FSParentQueue |
parent
|
protected SchedulingPolicy |
policy
|
protected org.apache.hadoop.yarn.factories.RecordFactory |
recordFactory
|
Constructor Summary | |
---|---|
FSQueue(String name,
QueueManager queueMgr,
FairScheduler scheduler,
FSParentQueue parent)
|
Method Summary | |
---|---|
protected boolean |
assignContainerPreCheck(FSSchedulerNode node)
Helper method to check if the queue should attempt assigning resources |
abstract Collection<FSQueue> |
getChildQueues()
Gets the children of this queue, if any. |
org.apache.hadoop.yarn.api.records.Resource |
getMaxShare()
Maximum Resource share assigned to the schedulable. |
FSQueueMetrics |
getMetrics()
Get the queue metrics |
org.apache.hadoop.yarn.api.records.Resource |
getMinShare()
Minimum Resource share assigned to the schedulable. |
String |
getName()
Name of job/queue, used for debugging as well as for breaking ties in scheduling order deterministically. |
SchedulingPolicy |
getPolicy()
|
org.apache.hadoop.yarn.api.records.Priority |
getPriority()
Job priority for jobs in FIFO queues; meaningless for QueueSchedulables. |
org.apache.hadoop.yarn.api.records.QueueInfo |
getQueueInfo(boolean includeChildQueues,
boolean recursive)
Get queue information |
String |
getQueueName()
Get the queue name |
long |
getStartTime()
Start time for jobs in FIFO queues; meaningless for QueueSchedulables. |
ResourceWeights |
getWeights()
Job/queue weight in fair sharing. |
boolean |
hasAccess(org.apache.hadoop.yarn.api.records.QueueACL acl,
org.apache.hadoop.security.UserGroupInformation user)
|
abstract void |
recomputeShares()
Recomputes the shares for all child queues and applications based on this queue's current share |
void |
setFairShare(org.apache.hadoop.yarn.api.records.Resource fairShare)
Assign a fair share to this Schedulable. |
abstract void |
setPolicy(SchedulingPolicy policy)
|
protected void |
throwPolicyDoesnotApplyException(SchedulingPolicy policy)
|
Methods inherited from class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.Schedulable |
---|
assignContainer, getDemand, getFairShare, getResourceUsage, toString, updateDemand |
Methods inherited from class java.lang.Object |
---|
clone, equals, finalize, getClass, hashCode, notify, notifyAll, wait, wait, wait |
Methods inherited from interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.Queue |
---|
getQueueUserAclInfo |
Field Detail |
---|
protected final FSParentQueue parent
protected final org.apache.hadoop.yarn.factories.RecordFactory recordFactory
protected SchedulingPolicy policy
Constructor Detail |
---|
public FSQueue(String name, QueueManager queueMgr, FairScheduler scheduler, FSParentQueue parent)
Method Detail |
---|
public String getName()
Schedulable
getName
in class Schedulable
public String getQueueName()
Queue
getQueueName
in interface Queue
public SchedulingPolicy getPolicy()
protected void throwPolicyDoesnotApplyException(SchedulingPolicy policy) throws AllocationConfigurationException
AllocationConfigurationException
public abstract void setPolicy(SchedulingPolicy policy) throws AllocationConfigurationException
AllocationConfigurationException
public ResourceWeights getWeights()
Schedulable
getWeights
in class Schedulable
public org.apache.hadoop.yarn.api.records.Resource getMinShare()
Schedulable
getMinShare
in class Schedulable
public org.apache.hadoop.yarn.api.records.Resource getMaxShare()
Schedulable
getMaxShare
in class Schedulable
public long getStartTime()
Schedulable
getStartTime
in class Schedulable
public org.apache.hadoop.yarn.api.records.Priority getPriority()
Schedulable
getPriority
in class Schedulable
public org.apache.hadoop.yarn.api.records.QueueInfo getQueueInfo(boolean includeChildQueues, boolean recursive)
Queue
getQueueInfo
in interface Queue
includeChildQueues
- include child queues?recursive
- recursively get child queue information?
public FSQueueMetrics getMetrics()
Queue
getMetrics
in interface Queue
public void setFairShare(org.apache.hadoop.yarn.api.records.Resource fairShare)
Schedulable
setFairShare
in class Schedulable
public boolean hasAccess(org.apache.hadoop.yarn.api.records.QueueACL acl, org.apache.hadoop.security.UserGroupInformation user)
hasAccess
in interface Queue
public abstract void recomputeShares()
public abstract Collection<FSQueue> getChildQueues()
protected boolean assignContainerPreCheck(FSSchedulerNode node)
|
||||||||||
PREV CLASS NEXT CLASS | FRAMES NO FRAMES | |||||||||
SUMMARY: NESTED | FIELD | CONSTR | METHOD | DETAIL: FIELD | CONSTR | METHOD |