| Interface | Description | 
|---|---|
| AbstractUsersManager | AbstractUsersManagertracks users in the system. | 
| ConfigurationMutationACLPolicy | Interface for determining whether configuration mutations are allowed. | 
| MutableConfigurationProvider | Interface for allowing changing scheduler configurations. | 
| MutableConfScheduler | Interface for a scheduler that supports changing configuration at runtime. | 
| NodeFilter | Convenience way to filter nodes based on a criteria. | 
| PreemptableResourceScheduler | Interface for a scheduler that supports preemption/killing | 
| Queue | |
| ResourceScheduler | This interface is the one implemented by the schedulers. | 
| SchedulerQueue<T extends SchedulerQueue> | Represents a queue in Scheduler. | 
| SchedulerQueueManager<T extends SchedulerQueue,E extends ReservationSchedulerConfiguration> | Context of the Queues in Scheduler. | 
| YarnScheduler | This interface is used by the components to talk to the
 scheduler for allocating of resources, cleaning up resources. | 
| Class | Description | 
|---|---|
| AbstractResourceUsage | This class can be used to track resource usage in queue/user/app. | 
| AbstractResourceUsage.UsageByLabel | UsageByLabel stores resource array for all resource usage types. | 
| AbstractYarnScheduler<T extends SchedulerApplicationAttempt,N extends SchedulerNode> | |
| ActiveUsersManager | ActiveUsersManagertracks active users in the system. | 
| Allocation | |
| ApplicationPlacementAllocatorFactory | Factory class to build various application placement policies. | 
| AppSchedulingInfo | This class keeps track of all the consumption of an application. | 
| ClusterNodeTracker<N extends SchedulerNode> | Helper library that:
 - tracks the state of all cluster  SchedulerNodes
 - provides convenience methods to filter and sort nodes | 
| ConfigurationMutationACLPolicyFactory | Factory class for creating instances of
  ConfigurationMutationACLPolicy. | 
| ContainerUpdateContext | Class encapsulates all outstanding container increase and decrease
 requests for an application. | 
| ContainerUpdates | Holder class that maintains list of container update requests | 
| CSQueueMetricsForCustomResources | This class is a main entry-point for any kind of CSQueueMetrics for
 custom resources. | 
| DefaultConfigurationMutationACLPolicy | Default configuration mutation ACL policy. | 
| FSQueueMetricsForCustomResources | This class is a main entry-point for any kind of metrics for
 custom resources. | 
| NodeReport | Node usage report. | 
| NodeResponse | The class that encapsulates response from clusterinfo for 
 updates from the node managers. | 
| PartitionQueueMetrics | |
| QueueMetrics | |
| QueueMetricsForCustomResources | |
| QueueResourceQuotas | QueueResourceQuotas by Labels for following fields by label
 - EFFECTIVE_MIN_CAPACITY
 - EFFECTIVE_MAX_CAPACITY
 This class can be used to track resource usage in queue/user/app. | 
| QueueStateManager<T extends SchedulerQueue,E extends ReservationSchedulerConfiguration> | QueueStateManager which can be used by Scheduler to manage the queue state. | 
| ResourceLimits | Resource limits for queues/applications, this means max overall (please note
 that, it's not "extra") resource you can get. | 
| ResourceUsage | Resource Usage by Labels for following fields by label - AM resource (to
 enforce max-am-resource-by-label after YARN-2637) - Used resource (includes
 AM resource usage) - Reserved resource - Pending resource - Headroom
 
 This class can be used to track resource usage in queue/user/app. | 
| SchedContainerChangeRequest | This is UpdateContainerRequest in scheduler side, it contains some
 pointers to runtime objects like RMContainer, SchedulerNode, etc. | 
| SchedulerApplication<T extends SchedulerApplicationAttempt> | |
| SchedulerApplicationAttempt | Represents an application attempt from the viewpoint of the scheduler. | 
| SchedulerAppReport | Represents an application attempt, and the resources that the attempt is 
 using. | 
| SchedulerAppUtils | |
| SchedulerHealth | |
| SchedulerHealth.DetailedInformation | |
| SchedulerNode | Represents a YARN Cluster Node from the viewpoint of the scheduler. | 
| SchedulerNodeReport | Node usage report. | 
| SchedulerUtils | Utilities shared by schedulers. | 
| SchedulerUtils.MaxResourceValidationResult | This class contains invalid resource information along with its
 resource request. | 
| Enum | Description | 
|---|---|
| AbstractResourceUsage.ResourceType | Use enum here to make implementation more cleaner and readable. | 
| NodeType | Resource classification. | 
| SchedulerApplicationAttempt.AMState | Different state for Application Master, user can see this state from web UI | 
| Exception | Description | 
|---|---|
| QueueInvalidException | |
| SchedulerDynamicEditException | 
Copyright © 2008–2023 Apache Software Foundation. All rights reserved.