| Package | Description | 
|---|---|
| org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity | 
| Modifier and Type | Method and Description | 
|---|---|
| TempQueuePerPartition | ProportionalCapacityPreemptionPolicy. getQueueByPartition(String queueName,
                   String partition)Get queue partition by given queueName and partitionName | 
| TempQueuePerPartition | CapacitySchedulerPreemptionContext. getQueueByPartition(String queueName,
                   String partition) | 
| Modifier and Type | Method and Description | 
|---|---|
| ArrayList<TempQueuePerPartition> | TempQueuePerPartition. getChildren() | 
| Collection<TempQueuePerPartition> | ProportionalCapacityPreemptionPolicy. getQueuePartitions(String queueName)Get all queue partitions by given queueName | 
| Collection<TempQueuePerPartition> | CapacitySchedulerPreemptionContext. getQueuePartitions(String queueName) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | TempQueuePerPartition. addChild(TempQueuePerPartition q)When adding a child we also aggregate its pending resource needs. | 
| void | FifoIntraQueuePreemptionPlugin. computeAppsIdealAllocation(org.apache.hadoop.yarn.api.records.Resource clusterResource,
                          TempQueuePerPartition tq,
                          Map<org.apache.hadoop.yarn.api.records.ApplicationAttemptId,Set<RMContainer>> selectedCandidates,
                          org.apache.hadoop.yarn.api.records.Resource totalPreemptedResourceAllowed,
                          org.apache.hadoop.yarn.api.records.Resource queueReassignableResource,
                          float maxAllowablePreemptLimit) | 
| protected void | AbstractPreemptableResourceCalculator. initIdealAssignment(org.apache.hadoop.yarn.api.records.Resource totGuarant,
                   TempQueuePerPartition q,
                   org.apache.hadoop.yarn.api.records.Resource initIdealAssigned)This method is visible to allow sub-classes to override the initialization
 behavior. | 
| protected void | PreemptableResourceCalculator. recursivelyComputeIdealAssignment(TempQueuePerPartition root,
                                 org.apache.hadoop.yarn.api.records.Resource totalPreemptionAllowed)This method recursively computes the ideal assignment of resources to each
 level of the hierarchy. | 
| Modifier and Type | Method and Description | 
|---|---|
| protected void | AbstractPreemptableResourceCalculator. computeFixpointAllocation(org.apache.hadoop.yarn.api.records.Resource totGuarant,
                         Collection<TempQueuePerPartition> qAlloc,
                         org.apache.hadoop.yarn.api.records.Resource unassigned,
                         boolean ignoreGuarantee)Given a set of queues compute the fix-point distribution of unassigned
 resources among them. | 
| protected void | PreemptableResourceCalculator. computeIdealResourceDistribution(org.apache.hadoop.yarn.util.resource.ResourceCalculator rc,
                                List<TempQueuePerPartition> queues,
                                org.apache.hadoop.yarn.api.records.Resource totalPreemptionAllowed,
                                org.apache.hadoop.yarn.api.records.Resource tot_guarant)This method computes (for a single level in the tree, passed as a  List<TempQueue>) the ideal assignment of resources. | 
Copyright © 2008–2023 Apache Software Foundation. All rights reserved.