| Modifier and Type | Method and Description | 
|---|---|
| FiCaSchedulerApp | TempAppPerPartition. getFiCaSchedulerApp() | 
| Modifier and Type | Method and Description | 
|---|---|
| Collection<FiCaSchedulerApp> | FifoIntraQueuePreemptionPlugin. getPreemptableApps(String queueName,
                  String partition) | 
| Modifier and Type | Method and Description | 
|---|---|
| boolean | FifoIntraQueuePreemptionPlugin. skipContainerBasedOnIntraQueuePolicy(FiCaSchedulerApp app,
                                    org.apache.hadoop.yarn.api.records.Resource clusterResource,
                                    org.apache.hadoop.yarn.api.records.Resource usedResource,
                                    RMContainer c) | 
| Modifier and Type | Method and Description | 
|---|---|
| FiCaSchedulerApp | CSAssignment. getApplication() | 
| FiCaSchedulerApp | CapacitySchedulerContext. getApplicationAttempt(org.apache.hadoop.yarn.api.records.ApplicationAttemptId attemptId) | 
| FiCaSchedulerApp | CapacityScheduler. getApplicationAttempt(org.apache.hadoop.yarn.api.records.ApplicationAttemptId applicationAttemptId) | 
| Modifier and Type | Method and Description | 
|---|---|
| ResourceCommitRequest<FiCaSchedulerApp,FiCaSchedulerNode> | CapacityScheduler. createResourceCommitRequest(CSAssignment csAssignment) | 
| List<FiCaSchedulerApp> | ManagedParentQueue. getAllApplications() | 
| Collection<FiCaSchedulerApp> | LeafQueue. getAllApplications()Obtain (read-only) collection of all applications. | 
| Collection<FiCaSchedulerApp> | LeafQueue. getApplications()Obtain (read-only) collection of active applications. | 
| OrderingPolicy<FiCaSchedulerApp> | LeafQueue. getOrderingPolicy() | 
| List<FiCaSchedulerApp> | ManagedParentQueue. getPendingApplications() | 
| Collection<FiCaSchedulerApp> | LeafQueue. getPendingApplications()Obtain (read-only) collection of pending applications. | 
| OrderingPolicy<FiCaSchedulerApp> | LeafQueue. getPendingAppsOrderingPolicy() | 
| List<FiCaSchedulerApp> | ManagedParentQueue. getScheduleableApplications() | 
| Modifier and Type | Method and Description | 
|---|---|
| void | CSQueue. attachContainer(org.apache.hadoop.yarn.api.records.Resource clusterResource,
               FiCaSchedulerApp application,
               RMContainer container)Attach a container to this queue | 
| void | ParentQueue. attachContainer(org.apache.hadoop.yarn.api.records.Resource clusterResource,
               FiCaSchedulerApp application,
               RMContainer rmContainer) | 
| void | LeafQueue. attachContainer(org.apache.hadoop.yarn.api.records.Resource clusterResource,
               FiCaSchedulerApp application,
               RMContainer rmContainer) | 
| protected boolean | LeafQueue. canAssignToUser(org.apache.hadoop.yarn.api.records.Resource clusterResource,
               String userName,
               org.apache.hadoop.yarn.api.records.Resource limit,
               FiCaSchedulerApp application,
               String nodePartition,
               ResourceLimits currentResourceLimits) | 
| boolean | CSMaxRunningAppsEnforcer. checkRunnabilityWithUpdate(FiCaSchedulerApp attempt)Checks whether making the application runnable would exceed any
 maxRunningApps limits. | 
| void | CSQueue. completedContainer(org.apache.hadoop.yarn.api.records.Resource clusterResource,
                  FiCaSchedulerApp application,
                  FiCaSchedulerNode node,
                  RMContainer container,
                  org.apache.hadoop.yarn.api.records.ContainerStatus containerStatus,
                  RMContainerEventType event,
                  CSQueue childQueue,
                  boolean sortQueues)A container assigned to the queue has completed. | 
| void | ParentQueue. completedContainer(org.apache.hadoop.yarn.api.records.Resource clusterResource,
                  FiCaSchedulerApp application,
                  FiCaSchedulerNode node,
                  RMContainer rmContainer,
                  org.apache.hadoop.yarn.api.records.ContainerStatus containerStatus,
                  RMContainerEventType event,
                  CSQueue completedChildQueue,
                  boolean sortQueues) | 
| void | LeafQueue. completedContainer(org.apache.hadoop.yarn.api.records.Resource clusterResource,
                  FiCaSchedulerApp application,
                  FiCaSchedulerNode node,
                  RMContainer rmContainer,
                  org.apache.hadoop.yarn.api.records.ContainerStatus containerStatus,
                  RMContainerEventType event,
                  CSQueue childQueue,
                  boolean sortQueues) | 
| void | CSQueue. detachContainer(org.apache.hadoop.yarn.api.records.Resource clusterResource,
               FiCaSchedulerApp application,
               RMContainer container)Detach a container from this queue | 
| void | ParentQueue. detachContainer(org.apache.hadoop.yarn.api.records.Resource clusterResource,
               FiCaSchedulerApp application,
               RMContainer rmContainer) | 
| void | LeafQueue. detachContainer(org.apache.hadoop.yarn.api.records.Resource clusterResource,
               FiCaSchedulerApp application,
               RMContainer rmContainer) | 
| void | CSQueue. finishApplicationAttempt(FiCaSchedulerApp application,
                        String queue)An application attempt submitted to this queue has finished. | 
| void | ParentQueue. finishApplicationAttempt(FiCaSchedulerApp application,
                        String queue) | 
| void | LeafQueue. finishApplicationAttempt(FiCaSchedulerApp application,
                        String queue) | 
| protected org.apache.hadoop.yarn.api.records.Resource | LeafQueue. getHeadroom(UsersManager.User user,
           org.apache.hadoop.yarn.api.records.Resource queueCurrentLimit,
           org.apache.hadoop.yarn.api.records.Resource clusterResource,
           FiCaSchedulerApp application) | 
| protected org.apache.hadoop.yarn.api.records.Resource | LeafQueue. getHeadroom(UsersManager.User user,
           org.apache.hadoop.yarn.api.records.Resource queueCurrentLimit,
           org.apache.hadoop.yarn.api.records.Resource clusterResource,
           FiCaSchedulerApp application,
           String partition) | 
| void | CSAssignment. setApplication(FiCaSchedulerApp application) | 
| void | CSQueue. submitApplicationAttempt(FiCaSchedulerApp application,
                        String userName)Submit an application attempt to the queue. | 
| void | ParentQueue. submitApplicationAttempt(FiCaSchedulerApp application,
                        String userName) | 
| void | LeafQueue. submitApplicationAttempt(FiCaSchedulerApp application,
                        String userName) | 
| void | CSQueue. submitApplicationAttempt(FiCaSchedulerApp application,
                        String userName,
                        boolean isMoveApp)Submit an application attempt to the queue. | 
| void | ParentQueue. submitApplicationAttempt(FiCaSchedulerApp application,
                        String userName,
                        boolean isMoveApp) | 
| void | LeafQueue. submitApplicationAttempt(FiCaSchedulerApp application,
                        String userName,
                        boolean isMoveApp) | 
| void | CSMaxRunningAppsEnforcer. trackApp(FiCaSchedulerApp app) | 
| void | CSMaxRunningAppsEnforcer. untrackApp(FiCaSchedulerApp app) | 
| void | CSMaxRunningAppsEnforcer. updateRunnabilityOnAppRemoval(FiCaSchedulerApp app)Checks to see whether any other applications runnable now that the given
 application has been removed from the given queue. | 
| Modifier and Type | Method and Description | 
|---|---|
| boolean | CSQueue. accept(org.apache.hadoop.yarn.api.records.Resource cluster,
      ResourceCommitRequest<FiCaSchedulerApp,FiCaSchedulerNode> request) | 
| boolean | AbstractCSQueue. accept(org.apache.hadoop.yarn.api.records.Resource cluster,
      ResourceCommitRequest<FiCaSchedulerApp,FiCaSchedulerNode> request) | 
| boolean | LeafQueue. accept(org.apache.hadoop.yarn.api.records.Resource cluster,
      ResourceCommitRequest<FiCaSchedulerApp,FiCaSchedulerNode> request) | 
| void | CSQueue. apply(org.apache.hadoop.yarn.api.records.Resource cluster,
     ResourceCommitRequest<FiCaSchedulerApp,FiCaSchedulerNode> request) | 
| void | ParentQueue. apply(org.apache.hadoop.yarn.api.records.Resource cluster,
     ResourceCommitRequest<FiCaSchedulerApp,FiCaSchedulerNode> request) | 
| void | LeafQueue. apply(org.apache.hadoop.yarn.api.records.Resource cluster,
     ResourceCommitRequest<FiCaSchedulerApp,FiCaSchedulerNode> request) | 
| void | LeafQueue. updateApplicationPriority(SchedulerApplication<FiCaSchedulerApp> app,
                         org.apache.hadoop.yarn.api.records.Priority newAppPriority) | 
| Constructor and Description | 
|---|
| CapacityHeadroomProvider(UsersManager.User user,
                        LeafQueue queue,
                        FiCaSchedulerApp application,
                        org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue.QueueResourceLimitsInfo queueResourceLimitsInfo) | 
| CSAssignment(FiCaSchedulerApp application,
            RMContainer excessReservation) | 
| CSAssignment(org.apache.hadoop.yarn.api.records.Resource resource,
            NodeType type,
            RMContainer excessReservation,
            FiCaSchedulerApp application,
            CSAssignment.SkippedType skipped,
            boolean fulfilledReservation) | 
| Constructor and Description | 
|---|
| AbstractContainerAllocator(FiCaSchedulerApp application,
                          org.apache.hadoop.yarn.util.resource.ResourceCalculator rc,
                          RMContext rmContext) | 
| AbstractContainerAllocator(FiCaSchedulerApp application,
                          org.apache.hadoop.yarn.util.resource.ResourceCalculator rc,
                          RMContext rmContext,
                          ActivitiesManager activitiesManager) | 
| ContainerAllocator(FiCaSchedulerApp application,
                  org.apache.hadoop.yarn.util.resource.ResourceCalculator rc,
                  RMContext rmContext) | 
| ContainerAllocator(FiCaSchedulerApp application,
                  org.apache.hadoop.yarn.util.resource.ResourceCalculator rc,
                  RMContext rmContext,
                  ActivitiesManager activitiesManager) | 
| RegularContainerAllocator(FiCaSchedulerApp application,
                         org.apache.hadoop.yarn.util.resource.ResourceCalculator rc,
                         RMContext rmContext,
                         ActivitiesManager activitiesManager) | 
| Modifier and Type | Method and Description | 
|---|---|
| boolean | FiCaSchedulerApp. accept(org.apache.hadoop.yarn.api.records.Resource cluster,
      ResourceCommitRequest<FiCaSchedulerApp,FiCaSchedulerNode> request,
      boolean checkPending) | 
| boolean | FiCaSchedulerApp. apply(org.apache.hadoop.yarn.api.records.Resource cluster,
     ResourceCommitRequest<FiCaSchedulerApp,FiCaSchedulerNode> request,
     boolean updatePending) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | FifoAppAttempt | 
Copyright © 2008–2023 Apache Software Foundation. All rights reserved.