Package | Description |
---|---|
org.apache.hadoop.yarn.server.resourcemanager.resource | |
org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair |
Modifier and Type | Field and Description |
---|---|
static ResourceWeights |
ResourceWeights.NEUTRAL |
Modifier and Type | Field and Description |
---|---|
protected ResourceWeights |
FSQueue.weights |
Modifier and Type | Method and Description |
---|---|
ResourceWeights |
FairScheduler.getAppWeight(FSAppAttempt app) |
ResourceWeights |
Schedulable.getWeights()
Job/queue weight in fair sharing.
|
ResourceWeights |
FSAppAttempt.getWeights() |
ResourceWeights |
FSQueue.getWeights() |
Modifier and Type | Method and Description |
---|---|
void |
FSQueue.setWeights(ResourceWeights weights) |
Constructor and Description |
---|
AllocationConfiguration(Map<String,org.apache.hadoop.yarn.api.records.Resource> minQueueResources,
Map<String,ConfigurableResource> maxQueueResources,
Map<String,ConfigurableResource> maxChildQueueResources,
Map<String,Integer> queueMaxApps,
Map<String,Integer> userMaxApps,
Map<String,ResourceWeights> queueWeights,
Map<String,Float> queueMaxAMShares,
int userMaxAppsDefault,
int queueMaxAppsDefault,
ConfigurableResource queueMaxResourcesDefault,
float queueMaxAMShareDefault,
Map<String,SchedulingPolicy> schedulingPolicies,
SchedulingPolicy defaultSchedulingPolicy,
Map<String,Long> minSharePreemptionTimeouts,
Map<String,Long> fairSharePreemptionTimeouts,
Map<String,Float> fairSharePreemptionThresholds,
Map<String,Map<org.apache.hadoop.yarn.security.AccessType,org.apache.hadoop.security.authorize.AccessControlList>> queueAcls,
Map<String,Map<org.apache.hadoop.yarn.api.records.ReservationACL,org.apache.hadoop.security.authorize.AccessControlList>> resAcls,
QueuePlacementPolicy placementPolicy,
Map<FSQueueType,Set<String>> configuredQueues,
ReservationQueueConfiguration globalReservationQueueConfig,
Set<String> reservableQueues,
Set<String> nonPreemptableQueues) |
Copyright © 2020 Apache Software Foundation. All rights reserved.