public interface CapacitySchedulerPreemptionContext
CapacityScheduler
.CapacityScheduler getScheduler()
TempQueuePerPartition getQueueByPartition(String queueName, String partition)
Collection<TempQueuePerPartition> getQueuePartitions(String queueName)
org.apache.hadoop.yarn.util.resource.ResourceCalculator getResourceCalculator()
RMContext getRMContext()
boolean isObserveOnly()
Set<org.apache.hadoop.yarn.api.records.ContainerId> getKillableContainers()
double getMaxIgnoreOverCapacity()
double getNaturalTerminationFactor()
int getClusterMaxApplicationPriority()
org.apache.hadoop.yarn.api.records.Resource getPartitionResource(String partition)
LinkedHashSet<String> getUnderServedQueuesPerPartition(String partition)
void addPartitionToUnderServedQueues(String queueName, String partition)
float getMinimumThresholdForIntraQueuePreemption()
float getMaxAllowableLimitForIntraQueuePreemption()
long getDefaultMaximumKillWaitTimeout()
@InterfaceStability.Unstable ProportionalCapacityPreemptionPolicy.IntraQueuePreemptionOrderPolicy getIntraQueuePreemptionOrderPolicy()
boolean getCrossQueuePreemptionConservativeDRF()
boolean getInQueuePreemptionConservativeDRF()
Copyright © 2008–2021 Apache Software Foundation. All rights reserved.