Modifier and Type | Method and Description |
---|---|
protected abstract Queue |
AbstractSchedulerPlanFollower.getPlanQueue(String planQueueName)
Get queue associated with reservable queue named.
|
protected Queue |
FairSchedulerPlanFollower.getPlanQueue(String planQueueName) |
protected Queue |
CapacitySchedulerPlanFollower.getPlanQueue(String planQueueName) |
Modifier and Type | Method and Description |
---|---|
protected abstract List<? extends Queue> |
AbstractSchedulerPlanFollower.getChildReservationQueues(Queue planQueue)
Get a list of reservation queues for this planQueue.
|
protected List<? extends Queue> |
FairSchedulerPlanFollower.getChildReservationQueues(Queue queue) |
protected List<? extends Queue> |
CapacitySchedulerPlanFollower.getChildReservationQueues(Queue queue) |
Modifier and Type | Method and Description |
---|---|
protected abstract void |
AbstractSchedulerPlanFollower.addReservationQueue(String planQueueName,
Queue queue,
String currResId)
Add a new reservation queue for reservation currResId for this planQueue.
|
protected void |
FairSchedulerPlanFollower.addReservationQueue(String planQueueName,
Queue queue,
String currResId) |
protected void |
CapacitySchedulerPlanFollower.addReservationQueue(String planQueueName,
Queue queue,
String currResId) |
protected abstract void |
AbstractSchedulerPlanFollower.createDefaultReservationQueue(String planQueueName,
Queue queue,
String defReservationQueue)
Creates the default reservation queue for use when no reservation is used
for applications submitted to this planQueue.
|
protected void |
FairSchedulerPlanFollower.createDefaultReservationQueue(String planQueueName,
Queue queue,
String defReservationId) |
protected void |
CapacitySchedulerPlanFollower.createDefaultReservationQueue(String planQueueName,
Queue queue,
String defReservationId) |
protected abstract List<? extends Queue> |
AbstractSchedulerPlanFollower.getChildReservationQueues(Queue planQueue)
Get a list of reservation queues for this planQueue.
|
protected List<? extends Queue> |
FairSchedulerPlanFollower.getChildReservationQueues(Queue queue) |
protected List<? extends Queue> |
CapacitySchedulerPlanFollower.getChildReservationQueues(Queue queue) |
protected abstract org.apache.hadoop.yarn.api.records.Resource |
AbstractSchedulerPlanFollower.getPlanResources(Plan plan,
Queue queue,
org.apache.hadoop.yarn.api.records.Resource clusterResources)
Get plan resources for this planQueue.
|
protected org.apache.hadoop.yarn.api.records.Resource |
FairSchedulerPlanFollower.getPlanResources(Plan plan,
Queue queue,
org.apache.hadoop.yarn.api.records.Resource clusterResources) |
protected org.apache.hadoop.yarn.api.records.Resource |
CapacitySchedulerPlanFollower.getPlanResources(Plan plan,
Queue queue,
org.apache.hadoop.yarn.api.records.Resource clusterResources) |
Modifier and Type | Interface and Description |
---|---|
interface |
SchedulerQueue<T extends SchedulerQueue>
Represents a queue in Scheduler.
|
Modifier and Type | Field and Description |
---|---|
protected Queue |
SchedulerApplicationAttempt.queue |
Modifier and Type | Method and Description |
---|---|
Queue |
QueueMetrics.getParentQueue() |
Queue |
SchedulerApplicationAttempt.getQueue() |
Queue |
SchedulerApplication.getQueue() |
Queue |
MutableConfScheduler.getQueue(String queueName)
Get queue object based on queue name.
|
Modifier and Type | Method and Description |
---|---|
void |
AbstractYarnScheduler.addQueue(Queue newQueue) |
void |
YarnScheduler.addQueue(Queue newQueue)
Add to the scheduler a new Queue.
|
static QueueMetrics |
QueueMetrics.forQueue(org.apache.hadoop.metrics2.MetricsSystem ms,
String queueName,
Queue parent,
boolean enableUserMetrics,
org.apache.hadoop.conf.Configuration conf) |
static QueueMetrics |
QueueMetrics.forQueue(String queueName,
Queue parent,
boolean enableUserMetrics,
org.apache.hadoop.conf.Configuration conf) |
void |
SchedulerApplicationAttempt.move(Queue newQueue) |
void |
AppSchedulingInfo.move(Queue newQueue) |
void |
AppSchedulingInfo.setQueue(Queue queue) |
void |
SchedulerApplication.setQueue(Queue queue) |
static void |
AppSchedulingInfo.updateMetrics(org.apache.hadoop.yarn.api.records.ApplicationId applicationId,
NodeType type,
SchedulerNode node,
RMContainer containerAllocated,
String user,
Queue queue) |
Constructor and Description |
---|
AppSchedulingInfo(org.apache.hadoop.yarn.api.records.ApplicationAttemptId appAttemptId,
String user,
Queue queue,
AbstractUsersManager abstractUsersManager,
long epoch,
ResourceUsage appResourceUsage,
Map<String,String> applicationSchedulingEnvs,
RMContext rmContext) |
PartitionQueueMetrics(org.apache.hadoop.metrics2.MetricsSystem ms,
String queueName,
Queue parent,
boolean enableUserMetrics,
org.apache.hadoop.conf.Configuration conf,
String partition) |
QueueMetrics(org.apache.hadoop.metrics2.MetricsSystem ms,
String queueName,
Queue parent,
boolean enableUserMetrics,
org.apache.hadoop.conf.Configuration conf) |
SchedulerApplication(Queue queue,
String user) |
SchedulerApplication(Queue queue,
String user,
org.apache.hadoop.yarn.api.records.Priority priority) |
SchedulerApplicationAttempt(org.apache.hadoop.yarn.api.records.ApplicationAttemptId applicationAttemptId,
String user,
Queue queue,
AbstractUsersManager abstractUsersManager,
RMContext rmContext) |
Modifier and Type | Interface and Description |
---|---|
interface |
CSQueue
CSQueue represents a node in the tree of
hierarchical queues in the CapacityScheduler . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractAutoCreatedLeafQueue
Abstract class for dynamic auto created queues managed by an implementation
of AbstractManagedParentQueue
|
class |
AbstractCSQueue |
class |
AbstractManagedParentQueue
A container class for automatically created child leaf queues.
|
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 |
---|---|
void |
CapacityScheduler.addQueue(Queue queue) |
static CSQueueMetrics |
CSQueueMetrics.forQueue(String queueName,
Queue parent,
boolean enableUserMetrics,
org.apache.hadoop.conf.Configuration conf) |
Constructor and Description |
---|
FiCaSchedulerApp(org.apache.hadoop.yarn.api.records.ApplicationAttemptId applicationAttemptId,
String user,
Queue queue,
AbstractUsersManager abstractUsersManager,
RMContext rmContext) |
FiCaSchedulerApp(org.apache.hadoop.yarn.api.records.ApplicationAttemptId applicationAttemptId,
String user,
Queue queue,
AbstractUsersManager abstractUsersManager,
RMContext rmContext,
org.apache.hadoop.yarn.api.records.Priority appPriority,
boolean isAttemptRecovering) |
FiCaSchedulerApp(org.apache.hadoop.yarn.api.records.ApplicationAttemptId applicationAttemptId,
String user,
Queue queue,
AbstractUsersManager abstractUsersManager,
RMContext rmContext,
org.apache.hadoop.yarn.api.records.Priority appPriority,
boolean isAttemptRecovering,
ActivitiesManager activitiesManager) |
Modifier and Type | Class and Description |
---|---|
class |
FSLeafQueue |
class |
FSParentQueue |
class |
FSQueue |
Modifier and Type | Method and Description |
---|---|
static FSQueueMetrics |
FSQueueMetrics.forQueue(org.apache.hadoop.metrics2.MetricsSystem ms,
String queueName,
Queue parent,
boolean enableUserMetrics,
org.apache.hadoop.conf.Configuration conf)
Get the FS queue metric for the given queue.
|
static FSQueueMetrics |
FSQueueMetrics.forQueue(String queueName,
Queue parent,
boolean enableUserMetrics,
org.apache.hadoop.conf.Configuration conf) |
Copyright © 2008–2023 Apache Software Foundation. All rights reserved.