| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractYarnScheduler<T extends SchedulerApplicationAttempt,N extends SchedulerNode> | 
| class  | SchedulerApplication<T extends SchedulerApplicationAttempt> | 
| Modifier and Type | Method and Description | 
|---|---|
| boolean | ResourceScheduler. attemptAllocationOnNode(SchedulerApplicationAttempt appAttempt,
                       org.apache.hadoop.yarn.api.records.SchedulingRequest schedulingRequest,
                       SchedulerNode schedulerNode)Attempts to allocate a SchedulerRequest on a Node. | 
| boolean | AbstractYarnScheduler. attemptAllocationOnNode(SchedulerApplicationAttempt appAttempt,
                       org.apache.hadoop.yarn.api.records.SchedulingRequest schedulingRequest,
                       SchedulerNode schedulerNode)Default implementation. | 
| List<N> | AbstractYarnScheduler. getBlacklistedNodes(SchedulerApplicationAttempt app)Add blacklisted NodeIds to the list that is passed. | 
| protected void | AbstractYarnScheduler. handleContainerUpdates(SchedulerApplicationAttempt appAttempt,
                      ContainerUpdates updates) | 
| static boolean | SchedulerAppUtils. isPlaceBlacklisted(SchedulerApplicationAttempt application,
                  SchedulerNode node,
                  org.slf4j.Logger log) | 
| void | Queue. recoverContainer(org.apache.hadoop.yarn.api.records.Resource clusterResource,
                SchedulerApplicationAttempt schedulerAttempt,
                RMContainer rmContainer)Recover the state of the queue for a given container. | 
| protected void | AbstractYarnScheduler. releaseContainers(List<org.apache.hadoop.yarn.api.records.ContainerId> containers,
                 SchedulerApplicationAttempt attempt) | 
| abstract void | SchedulerNode. reserveResource(SchedulerApplicationAttempt attempt,
               org.apache.hadoop.yarn.server.scheduler.SchedulerRequestKey schedulerKey,
               RMContainer container)Reserve container for the attempt on this node. | 
| void | SchedulerApplicationAttempt. transferStateFromPreviousAttempt(SchedulerApplicationAttempt appAttempt) | 
| abstract void | SchedulerNode. unreserveResource(SchedulerApplicationAttempt attempt)Unreserve resources on this node. | 
| Constructor and Description | 
|---|
| SchedulerAppReport(SchedulerApplicationAttempt app) | 
| Modifier and Type | Method and Description | 
|---|---|
| static void | ActivitiesLogger.APP. recordAppActivityWithAllocation(ActivitiesManager activitiesManager,
                               SchedulerNode node,
                               SchedulerApplicationAttempt application,
                               RMContainer updatedContainer,
                               ActivityState activityState) | 
| static void | ActivitiesLogger.APP. recordAppActivityWithoutAllocation(ActivitiesManager activitiesManager,
                                  SchedulerNode node,
                                  SchedulerApplicationAttempt application,
                                  org.apache.hadoop.yarn.server.scheduler.SchedulerRequestKey schedulerKey,
                                  String diagnostic,
                                  ActivityState appState,
                                  ActivityLevel level) | 
| static void | ActivitiesLogger.APP. recordRejectedAppActivityFromLeafQueue(ActivitiesManager activitiesManager,
                                      SchedulerNode node,
                                      SchedulerApplicationAttempt application,
                                      org.apache.hadoop.yarn.api.records.Priority priority,
                                      String diagnostic) | 
| static void | ActivitiesLogger.APP. recordSkippedAppActivityWithoutAllocation(ActivitiesManager activitiesManager,
                                         SchedulerNode node,
                                         SchedulerApplicationAttempt application,
                                         org.apache.hadoop.yarn.server.scheduler.SchedulerRequestKey requestKey,
                                         String diagnostic,
                                         ActivityLevel level) | 
| static void | ActivitiesLogger.APP. startAppAllocationRecording(ActivitiesManager activitiesManager,
                           FiCaSchedulerNode node,
                           long currentTime,
                           SchedulerApplicationAttempt application) | 
| Modifier and Type | Method and Description | 
|---|---|
| boolean | CapacityScheduler. attemptAllocationOnNode(SchedulerApplicationAttempt appAttempt,
                       org.apache.hadoop.yarn.api.records.SchedulingRequest schedulingRequest,
                       SchedulerNode schedulerNode) | 
| void | LeafQueue. decAMUsedResource(String nodeLabel,
                 org.apache.hadoop.yarn.api.records.Resource resourceToDec,
                 SchedulerApplicationAttempt application) | 
| void | CSQueue. decUsedResource(String nodePartition,
               org.apache.hadoop.yarn.api.records.Resource resourceToDec,
               SchedulerApplicationAttempt application)When partition of node updated, we will update queue's resource usage if it
 has container(s) running on that. | 
| void | AbstractCSQueue. decUsedResource(String nodeLabel,
               org.apache.hadoop.yarn.api.records.Resource resourceToDec,
               SchedulerApplicationAttempt application) | 
| void | LeafQueue. decUsedResource(String nodeLabel,
               org.apache.hadoop.yarn.api.records.Resource resourceToDec,
               SchedulerApplicationAttempt application) | 
| void | LeafQueue. incAMUsedResource(String nodeLabel,
                 org.apache.hadoop.yarn.api.records.Resource resourceToInc,
                 SchedulerApplicationAttempt application) | 
| void | CSQueue. incUsedResource(String nodePartition,
               org.apache.hadoop.yarn.api.records.Resource resourceToInc,
               SchedulerApplicationAttempt application)When partition of node updated, we will update queue's resource usage if it
 has container(s) running on that. | 
| void | AbstractCSQueue. incUsedResource(String nodeLabel,
               org.apache.hadoop.yarn.api.records.Resource resourceToInc,
               SchedulerApplicationAttempt application) | 
| void | LeafQueue. incUsedResource(String nodeLabel,
               org.apache.hadoop.yarn.api.records.Resource resourceToInc,
               SchedulerApplicationAttempt application) | 
| void | ParentQueue. recoverContainer(org.apache.hadoop.yarn.api.records.Resource clusterResource,
                SchedulerApplicationAttempt attempt,
                RMContainer rmContainer) | 
| void | LeafQueue. recoverContainer(org.apache.hadoop.yarn.api.records.Resource clusterResource,
                SchedulerApplicationAttempt attempt,
                RMContainer rmContainer) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ContainerAllocationProposal<A extends SchedulerApplicationAttempt,N extends SchedulerNode>Proposal to allocate/reserve a new container | 
| class  | ResourceCommitRequest<A extends SchedulerApplicationAttempt,N extends SchedulerNode> | 
| class  | SchedulerContainer<A extends SchedulerApplicationAttempt,N extends SchedulerNode>Contexts for a container inside scheduler | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | FiCaSchedulerAppRepresents an application attempt from the viewpoint of the FIFO or Capacity
 scheduler. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | FiCaSchedulerNode. reserveResource(SchedulerApplicationAttempt application,
               org.apache.hadoop.yarn.server.scheduler.SchedulerRequestKey priority,
               RMContainer container) | 
| void | FiCaSchedulerApp. transferStateFromPreviousAttempt(SchedulerApplicationAttempt appAttempt) | 
| void | FiCaSchedulerNode. unreserveResource(SchedulerApplicationAttempt application) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | FSAppAttemptRepresents an application attempt from the viewpoint of the Fair Scheduler. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | FSParentQueue. recoverContainer(org.apache.hadoop.yarn.api.records.Resource clusterResource,
                SchedulerApplicationAttempt schedulerAttempt,
                RMContainer rmContainer) | 
| void | FSLeafQueue. recoverContainer(org.apache.hadoop.yarn.api.records.Resource clusterResource,
                SchedulerApplicationAttempt schedulerAttempt,
                RMContainer rmContainer) | 
| void | FSSchedulerNode. reserveResource(SchedulerApplicationAttempt application,
               org.apache.hadoop.yarn.server.scheduler.SchedulerRequestKey schedulerKey,
               RMContainer container) | 
| void | FSSchedulerNode. unreserveResource(SchedulerApplicationAttempt application) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | FifoAppAttempt | 
Copyright © 2008–2023 Apache Software Foundation. All rights reserved.