| Modifier and Type | Field and Description | 
|---|---|
| protected ResourceScheduler | ResourceManager. scheduler | 
| Modifier and Type | Method and Description | 
|---|---|
| protected ResourceScheduler | ResourceManager. createScheduler() | 
| ResourceScheduler | ResourceManager. getResourceScheduler()return the scheduler. | 
| ResourceScheduler | RMActiveServiceContext. getScheduler() | 
| ResourceScheduler | RMContextImpl. getScheduler() | 
| ResourceScheduler | RMContext. getScheduler() | 
| Modifier and Type | Method and Description | 
|---|---|
| protected QueueACLsManager | ResourceManager. createQueueACLsManager(ResourceScheduler scheduler,
                      org.apache.hadoop.conf.Configuration conf) | 
| void | RMContextImpl. setScheduler(ResourceScheduler scheduler) | 
| Constructor and Description | 
|---|
| RMActiveServiceContext(org.apache.hadoop.yarn.event.Dispatcher rmDispatcher,
                      ContainerAllocationExpirer containerAllocationExpirer,
                      AMLivelinessMonitor amLivelinessMonitor,
                      AMLivelinessMonitor amFinishingMonitor,
                      DelegationTokenRenewer delegationTokenRenewer,
                      AMRMTokenSecretManager appTokenSecretManager,
                      RMContainerTokenSecretManager containerTokenSecretManager,
                      NMTokenSecretManagerInRM nmTokenSecretManager,
                      ClientToAMTokenSecretManagerInRM clientToAMTokenSecretManager,
                      ResourceScheduler scheduler) | 
| RMContextImpl(org.apache.hadoop.yarn.event.Dispatcher rmDispatcher,
             ContainerAllocationExpirer containerAllocationExpirer,
             AMLivelinessMonitor amLivelinessMonitor,
             AMLivelinessMonitor amFinishingMonitor,
             DelegationTokenRenewer delegationTokenRenewer,
             AMRMTokenSecretManager appTokenSecretManager,
             RMContainerTokenSecretManager containerTokenSecretManager,
             NMTokenSecretManagerInRM nmTokenSecretManager,
             ClientToAMTokenSecretManagerInRM clientToAMTokenSecretManager,
             ResourceScheduler scheduler) | 
| RMNMInfo(RMContext rmc,
        ResourceScheduler sched)Constructor for RMNMInfo registers the bean with JMX. | 
| Constructor and Description | 
|---|
| FederationStateStoreHeartbeat(org.apache.hadoop.yarn.server.federation.store.records.SubClusterId subClusterId,
                             org.apache.hadoop.yarn.server.federation.store.FederationStateStore stateStoreClient,
                             ResourceScheduler scheduler) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | SchedulingEditPolicy. init(org.apache.hadoop.conf.Configuration config,
    RMContext context,
    ResourceScheduler scheduler) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | ProportionalCapacityPreemptionPolicy. init(org.apache.hadoop.conf.Configuration config,
    RMContext context,
    ResourceScheduler sched) | 
| Modifier and Type | Method and Description | 
|---|---|
| ResourceScheduler | InvariantsChecker. getScheduler() | 
| Modifier and Type | Method and Description | 
|---|---|
| void | InvariantsChecker. init(org.apache.hadoop.conf.Configuration config,
    RMContext rmContext,
    ResourceScheduler scheduler) | 
| void | MetricsInvariantChecker. init(org.apache.hadoop.conf.Configuration config,
    RMContext rmContext,
    ResourceScheduler scheduler) | 
| Modifier and Type | Method and Description | 
|---|---|
| boolean | PrimaryGroupPlacementRule. initialize(ResourceScheduler scheduler) | 
| abstract boolean | PlacementRule. initialize(ResourceScheduler scheduler)Initialize the rule with the scheduler. | 
| boolean | RejectPlacementRule. initialize(ResourceScheduler scheduler) | 
| boolean | UserGroupMappingPlacementRule. initialize(ResourceScheduler scheduler) | 
| boolean | AppNameMappingPlacementRule. initialize(ResourceScheduler scheduler) | 
| boolean | FSPlacementRule. initialize(ResourceScheduler scheduler)Standard initialisation for  FairSchedulerrules, shared by all
 rules. | 
| boolean | SpecifiedPlacementRule. initialize(ResourceScheduler scheduler) | 
| boolean | DefaultPlacementRule. initialize(ResourceScheduler scheduler) | 
| boolean | SecondaryGroupExistingPlacementRule. initialize(ResourceScheduler scheduler) | 
| Modifier and Type | Method and Description | 
|---|---|
| static String | AbstractReservationSystem. getDefaultReservationSystem(ResourceScheduler scheduler)Get the default reservation system corresponding to the scheduler | 
| void | PlanFollower. init(org.apache.hadoop.yarn.util.Clock clock,
    ResourceScheduler sched,
    Collection<Plan> plans)Init function that configures the PlanFollower, by providing: | 
| void | AbstractSchedulerPlanFollower. init(org.apache.hadoop.yarn.util.Clock clock,
    ResourceScheduler sched,
    Collection<Plan> plans) | 
| void | FairSchedulerPlanFollower. init(org.apache.hadoop.yarn.util.Clock clock,
    ResourceScheduler sched,
    Collection<Plan> plans) | 
| void | CapacitySchedulerPlanFollower. init(org.apache.hadoop.yarn.util.Clock clock,
    ResourceScheduler sched,
    Collection<Plan> plans) | 
| Modifier and Type | Interface and Description | 
|---|---|
| interface  | MutableConfSchedulerInterface for a scheduler that supports changing configuration at runtime. | 
| interface  | PreemptableResourceSchedulerInterface for a scheduler that supports preemption/killing | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractYarnScheduler<T extends SchedulerApplicationAttempt,N extends SchedulerNode> | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | CapacityScheduler | 
| Modifier and Type | Method and Description | 
|---|---|
| void | QueueManagementDynamicEditPolicy. init(org.apache.hadoop.conf.Configuration config,
    RMContext context,
    ResourceScheduler sched) | 
| void | QueueManagementDynamicEditPolicy. reinitialize(org.apache.hadoop.conf.Configuration config,
            RMContext context,
            ResourceScheduler sched)Reinitializes queues(Called on scheduler.reinitialize) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | FairSchedulerA scheduler that schedules resources between a set of queues. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | FifoScheduler | 
| Constructor and Description | 
|---|
| QueueACLsManager(ResourceScheduler scheduler,
                org.apache.hadoop.conf.Configuration conf) | 
| ReservationsACLsManager(ResourceScheduler scheduler,
                       org.apache.hadoop.conf.Configuration conf) | 
| Constructor and Description | 
|---|
| ClusterMetricsInfo(ResourceScheduler rs) | 
| NodeInfo(RMNode ni,
        ResourceScheduler sched) | 
Copyright © 2008–2023 Apache Software Foundation. All rights reserved.