@InterfaceAudience.Private @InterfaceStability.Unstable public class FiCaSchedulerApp extends SchedulerApplicationAttempt
SchedulerApplicationAttempt.AMStateappAMNodePartitionName, appSchedulingInfo, attemptId, attemptOpportunisticResourceUsage, attemptResourceUsage, attemptResourceUsageAllocatedRemotely, isStopped, lastMemoryAggregateAllocationUpdateTime, lastScheduledContainer, liveContainers, newlyAllocatedContainers, newlyDecreasedContainers, newlyDemotedContainers, newlyIncreasedContainers, newlyPromotedContainers, queue, readLock, reservedContainers, rmContext, tempContainerToKill, updateContainerErrors, updatedNMTokens, writeLock| 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 | Method and Description | 
|---|---|
| boolean | accept(org.apache.hadoop.yarn.api.records.Resource cluster,
      ResourceCommitRequest<FiCaSchedulerApp,FiCaSchedulerNode> request,
      boolean checkPending) | 
| void | addToBeRemovedIncreaseRequest(SchedContainerChangeRequest request) | 
| RMContainer | allocate(FiCaSchedulerNode node,
        org.apache.hadoop.yarn.server.scheduler.SchedulerRequestKey schedulerKey,
        org.apache.hadoop.yarn.api.records.Container container) | 
| boolean | apply(org.apache.hadoop.yarn.api.records.Resource cluster,
     ResourceCommitRequest<FiCaSchedulerApp,FiCaSchedulerNode> request,
     boolean updatePending) | 
| CSAssignment | assignContainers(org.apache.hadoop.yarn.api.records.Resource clusterResource,
                CandidateNodeSet<FiCaSchedulerNode> ps,
                ResourceLimits currentResourceLimits,
                SchedulingMode schedulingMode,
                RMContainer reservedContainer) | 
| boolean | containerCompleted(RMContainer rmContainer,
                  org.apache.hadoop.yarn.api.records.ContainerStatus containerStatus,
                  RMContainerEventType event,
                  String partition) | 
| boolean | equals(Object o) | 
| RMContainer | findNodeToUnreserve(FiCaSchedulerNode node,
                   org.apache.hadoop.yarn.server.scheduler.SchedulerRequestKey schedulerKey,
                   org.apache.hadoop.yarn.api.records.Resource minimumUnreservedResource) | 
| protected void | getActivedAppDiagnosticMessage(StringBuilder diagnosticMessage) | 
| Allocation | getAllocation(org.apache.hadoop.yarn.util.resource.ResourceCalculator resourceCalculator,
             org.apache.hadoop.yarn.api.records.Resource clusterResource,
             org.apache.hadoop.yarn.api.records.Resource minimumAllocation)This method produces an Allocation that includes the current view
 of the resources that will be allocated to and preempted from this
 application. | 
| AppPlacementAllocator<FiCaSchedulerNode> | getAppPlacementAllocator(org.apache.hadoop.yarn.server.scheduler.SchedulerRequestKey schedulerRequestKey) | 
| LeafQueue | getCSLeafQueue() | 
| org.apache.hadoop.yarn.api.records.Resource | getHeadroom()Get available headroom in terms of resources for the application's user. | 
| org.apache.hadoop.yarn.api.records.NodeId | getNodeIdToUnreserve(org.apache.hadoop.yarn.server.scheduler.SchedulerRequestKey schedulerKey,
                    org.apache.hadoop.yarn.api.records.Resource resourceNeedUnreserve,
                    org.apache.hadoop.yarn.util.resource.ResourceCalculator resourceCalculator) | 
| protected void | getPendingAppDiagnosticMessage(StringBuilder diagnosticMessage) | 
| org.apache.hadoop.yarn.api.records.ApplicationResourceUsageReport | getResourceUsageReport()Recalculates the per-app, percent of queue metric, specific to the
 Capacity Scheduler. | 
| Map<String,org.apache.hadoop.yarn.api.records.Resource> | getTotalPendingRequestsPerPartition() | 
| ReentrantReadWriteLock.WriteLock | getWriteLock() | 
| int | hashCode() | 
| boolean | isRunnable() | 
| void | markContainerForPreemption(org.apache.hadoop.yarn.api.records.ContainerId cont) | 
| boolean | moveReservation(RMContainer reservedContainer,
               FiCaSchedulerNode sourceNode,
               FiCaSchedulerNode targetNode)Move reservation from one node to another
 Comparing to unreserve container on source node and reserve a new
 container on target node. | 
| void | nodePartitionUpdated(RMContainer rmContainer,
                    String oldPartition,
                    String newPartition) | 
| void | reserve(org.apache.hadoop.yarn.server.scheduler.SchedulerRequestKey schedulerKey,
       FiCaSchedulerNode node,
       RMContainer rmContainer,
       org.apache.hadoop.yarn.api.records.Container container,
       boolean reReservation) | 
| void | setHeadroomProvider(CapacityHeadroomProvider headroomProvider) | 
| void | setRunnable(boolean runnable) | 
| void | transferStateFromPreviousAttempt(SchedulerApplicationAttempt appAttempt) | 
| boolean | unreserve(org.apache.hadoop.yarn.server.scheduler.SchedulerRequestKey schedulerKey,
         FiCaSchedulerNode node,
         RMContainer rmContainer) | 
| void | updateAppSkipNodeDiagnostics(String message)Set the message temporarily if the reason is known for why scheduling did
 not happen for a given node, if not message will be over written | 
| void | updateNodeInfoForAMDiagnostics(FiCaSchedulerNode node) | 
addMissedNonPartitionedRequestSchedulingOpportunity, addReReservation, addRMContainer, addSchedulingOpportunity, addToNewlyAllocatedContainers, addToNewlyDecreasedContainers, addToNewlyDemotedContainers, addToUpdateContainerErrors, compareInputOrderTo, containerLaunchedOnNode, decUnconfirmedRes, getAMResource, getAMResource, getAppAMNodePartitionName, getAppAttemptResourceUsage, getApplicationAttemptId, getApplicationId, getApplicationSchedulingEnvs, getAppSchedulingInfo, getBlacklistedNodes, getCurrentConsumption, getCurrentReservation, getId, getLastScheduledContainer, getLiveContainers, getLiveContainersMap, getNewContainerId, getNumReservedContainers, getOpportunisticContainerContext, getOutstandingAsksCount, getOutstandingAsksCount, getPartition, getPendingAsk, getPendingRelease, getPriority, getQueue, getQueueName, getReReservations, getReservedContainers, getRMContainer, getSchedulerKeys, getSchedulingOpportunities, getSchedulingResourceUsage, getStartTime, getUnmanagedAM, getUpdateContext, getUser, hasPendingResourceRequest, incNumAllocatedContainers, incUnconfirmedRes, isAmRunning, isPending, isPlaceBlacklisted, isRecovering, isStopped, isWaitingForAMContainer, move, pullNewlyAllocatedContainers, pullNewlyDecreasedContainers, pullNewlyDemotedContainers, pullNewlyIncreasedContainers, pullNewlyPromotedContainers, pullPreviousAttemptContainers, pullUpdateContainerErrors, pullUpdatedNMTokens, recordContainerAllocationTime, recordContainerRequestTime, recoverContainer, recoverResourceRequestsForContainer, removeRMContainer, reserve, reserveIncreasedContainer, resetMissedNonPartitionedRequestSchedulingOpportunity, resetReReservations, resetSchedulingOpportunities, resetSchedulingOpportunities, setAMResource, setAMResource, setAmRunning, setAppAMNodePartitionName, setApplicationHeadroomForMetrics, setAttemptRecovering, setHeadroom, setOpportunisticContainerContext, setPriority, showRequests, stop, subtractSchedulingOpportunity, updateAMContainerDiagnostics, updateBlacklist, updateNMTokens, updateResourceRequests, updateSchedulingRequestspublic FiCaSchedulerApp(org.apache.hadoop.yarn.api.records.ApplicationAttemptId applicationAttemptId,
                        String user,
                        Queue queue,
                        AbstractUsersManager abstractUsersManager,
                        RMContext rmContext)
public 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)
public 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)
public boolean containerCompleted(RMContainer rmContainer, org.apache.hadoop.yarn.api.records.ContainerStatus containerStatus, RMContainerEventType event, String partition)
public RMContainer allocate(FiCaSchedulerNode node, org.apache.hadoop.yarn.server.scheduler.SchedulerRequestKey schedulerKey, org.apache.hadoop.yarn.api.records.Container container)
public boolean accept(org.apache.hadoop.yarn.api.records.Resource cluster,
                      ResourceCommitRequest<FiCaSchedulerApp,FiCaSchedulerNode> request,
                      boolean checkPending)
public boolean apply(org.apache.hadoop.yarn.api.records.Resource cluster,
                     ResourceCommitRequest<FiCaSchedulerApp,FiCaSchedulerNode> request,
                     boolean updatePending)
public boolean unreserve(org.apache.hadoop.yarn.server.scheduler.SchedulerRequestKey schedulerKey,
                         FiCaSchedulerNode node,
                         RMContainer rmContainer)
public Map<String,org.apache.hadoop.yarn.api.records.Resource> getTotalPendingRequestsPerPartition()
public void markContainerForPreemption(org.apache.hadoop.yarn.api.records.ContainerId cont)
public Allocation getAllocation(org.apache.hadoop.yarn.util.resource.ResourceCalculator resourceCalculator, org.apache.hadoop.yarn.api.records.Resource clusterResource, org.apache.hadoop.yarn.api.records.Resource minimumAllocation)
resourceCalculator - resourceCalculatorclusterResource - clusterResourceminimumAllocation - minimumAllocationpublic org.apache.hadoop.yarn.api.records.NodeId getNodeIdToUnreserve(org.apache.hadoop.yarn.server.scheduler.SchedulerRequestKey schedulerKey,
                                                                      org.apache.hadoop.yarn.api.records.Resource resourceNeedUnreserve,
                                                                      org.apache.hadoop.yarn.util.resource.ResourceCalculator resourceCalculator)
public void setHeadroomProvider(CapacityHeadroomProvider headroomProvider)
public org.apache.hadoop.yarn.api.records.Resource getHeadroom()
SchedulerApplicationAttemptgetHeadroom in class SchedulerApplicationAttemptpublic void transferStateFromPreviousAttempt(SchedulerApplicationAttempt appAttempt)
transferStateFromPreviousAttempt in class SchedulerApplicationAttemptpublic void reserve(org.apache.hadoop.yarn.server.scheduler.SchedulerRequestKey schedulerKey,
                    FiCaSchedulerNode node,
                    RMContainer rmContainer,
                    org.apache.hadoop.yarn.api.records.Container container,
                    boolean reReservation)
public RMContainer findNodeToUnreserve(FiCaSchedulerNode node, org.apache.hadoop.yarn.server.scheduler.SchedulerRequestKey schedulerKey, org.apache.hadoop.yarn.api.records.Resource minimumUnreservedResource)
public LeafQueue getCSLeafQueue()
public CSAssignment assignContainers(org.apache.hadoop.yarn.api.records.Resource clusterResource, CandidateNodeSet<FiCaSchedulerNode> ps, ResourceLimits currentResourceLimits, SchedulingMode schedulingMode, RMContainer reservedContainer)
public void nodePartitionUpdated(RMContainer rmContainer, String oldPartition, String newPartition)
protected void getPendingAppDiagnosticMessage(StringBuilder diagnosticMessage)
getPendingAppDiagnosticMessage in class SchedulerApplicationAttemptprotected void getActivedAppDiagnosticMessage(StringBuilder diagnosticMessage)
getActivedAppDiagnosticMessage in class SchedulerApplicationAttemptpublic void updateAppSkipNodeDiagnostics(String message)
message - Message of app skip diagnosticspublic void updateNodeInfoForAMDiagnostics(FiCaSchedulerNode node)
public AppPlacementAllocator<FiCaSchedulerNode> getAppPlacementAllocator(org.apache.hadoop.yarn.server.scheduler.SchedulerRequestKey schedulerRequestKey)
getAppPlacementAllocator in class SchedulerApplicationAttemptpublic org.apache.hadoop.yarn.api.records.ApplicationResourceUsageReport getResourceUsageReport()
getResourceUsageReport in class SchedulerApplicationAttemptpublic ReentrantReadWriteLock.WriteLock getWriteLock()
getWriteLock in class SchedulerApplicationAttemptpublic void addToBeRemovedIncreaseRequest(SchedContainerChangeRequest request)
public int hashCode()
hashCode in class SchedulerApplicationAttemptpublic boolean equals(Object o)
equals in class SchedulerApplicationAttemptpublic boolean moveReservation(RMContainer reservedContainer, FiCaSchedulerNode sourceNode, FiCaSchedulerNode targetNode)
reservedContainer - to be moved reserved containersourceNode - source nodetargetNode - target nodepublic void setRunnable(boolean runnable)
public boolean isRunnable()
Copyright © 2008–2023 Apache Software Foundation. All rights reserved.