public class CapacitySchedulerConfiguration extends ReservationSchedulerConfiguration
Modifier and Type | Class and Description |
---|---|
static class |
CapacitySchedulerConfiguration.AbsoluteResourceType
Different resource types supported.
|
DEFAULT_CAPACITY_OVER_TIME_MULTIPLIER, DEFAULT_RESERVATION_ADMISSION_POLICY, DEFAULT_RESERVATION_AGENT_NAME, DEFAULT_RESERVATION_ENFORCEMENT_WINDOW, DEFAULT_RESERVATION_MOVE_ON_EXPIRY, DEFAULT_RESERVATION_PLANNER_NAME, DEFAULT_RESERVATION_WINDOW, DEFAULT_SHOW_RESERVATIONS_AS_QUEUES
Constructor and Description |
---|
CapacitySchedulerConfiguration() |
CapacitySchedulerConfiguration(org.apache.hadoop.conf.Configuration configuration) |
CapacitySchedulerConfiguration(org.apache.hadoop.conf.Configuration configuration,
boolean useLocalConfigurationProvider) |
Modifier and Type | Method and Description |
---|---|
Set<String> |
getAccessibleNodeLabels(String queue) |
org.apache.hadoop.security.authorize.AccessControlList |
getAcl(String queue,
org.apache.hadoop.yarn.api.records.QueueACL acl) |
Map<org.apache.hadoop.yarn.security.AccessType,org.apache.hadoop.security.authorize.AccessControlList> |
getAcls(String queue) |
Map<String,Float> |
getAllUserWeightsForQueue(String queuePath)
Get the weights of all users at this queue level from the configuration.
|
<S extends SchedulableEntity> |
getAppOrderingPolicy(String queue) |
boolean |
getAssignMultipleEnabled() |
String |
getAutoCreatedQueueManagementPolicy(String queue)
Queue Management computation policy for Auto Created queues
|
protected AutoCreatedQueueManagementPolicy |
getAutoCreatedQueueManagementPolicyClass(String queueName)
Get The policy class configured to manage capacities for auto created leaf
queues under the specified parent
|
int |
getAutoCreatedQueuesMaxChildQueuesLimit(String queuePath)
Get the max number of leaf queues that are allowed to be created under
a parent queue
|
String |
getAutoCreatedQueueTemplateConfPrefix(String queuePath)
Get the auto created leaf queue's template configuration prefix
Leaf queue's template capacities are configured at the parent queue
|
float |
getAverageCapacity(String queue)
Gets the average allowed capacity which will aggregated over the
ReservationSchedulerConfiguration.getReservationWindow(java.lang.String) by the
the SharingPolicy to check aggregate used capacity |
Set<String> |
getConfiguredNodeLabels(String queuePath)
Get configured node labels in a given queuePath
|
org.apache.hadoop.yarn.api.records.QueueState |
getConfiguredState(String queue) |
Integer |
getDefaultApplicationPriorityConfPerQueue(String queue) |
long |
getDefaultLifetimePerQueue(String queue) |
String |
getDefaultNodeLabelExpression(String queue) |
boolean |
getEnableUserMetrics() |
long |
getEnforcementWindow(String queue)
Gets the time in milliseconds for which the
Planner will verify
the Plan s satisfy the constraints |
int |
getGlobalMaximumApplicationsPerQueue() |
float |
getInstantaneousMaxCapacity(String queue)
Gets the maximum capacity at any time that the
SharingPolicy allows |
boolean |
getIntraQueuePreemptionDisabled(String queue,
boolean defaultVal)
Indicates whether intra-queue preemption is disabled on the specified queue
|
float |
getLabeledQueueCapacity(String queue,
String label) |
float |
getLabeledQueueMaximumCapacity(String queue,
String label) |
boolean |
getLazyPreemptionEnabled() |
int |
getMaxAssignPerHeartbeat() |
float |
getMaximumAMResourcePercentPerPartition(String queue,
String label) |
float |
getMaximumApplicationMasterResourcePercent() |
float |
getMaximumApplicationMasterResourcePerQueuePercent(String queue)
Get the maximum am resource percent per queue setting.
|
int |
getMaximumApplicationsPerQueue(String queue)
Get the maximum applications per queue setting.
|
long |
getMaximumLifetimePerQueue(String queue) |
org.apache.hadoop.yarn.api.records.Resource |
getMaximumResourceRequirement(String label,
String queue,
Set<String> resourceTypes)
Get absolute maximum resource requirement for a queue.
|
int |
getMaximumSystemApplications() |
Integer |
getMaxParallelAppsForQueue(String queue) |
Integer |
getMaxParallelAppsForUser(String user) |
org.apache.hadoop.yarn.api.records.Resource |
getMinimumAllocation() |
org.apache.hadoop.yarn.api.records.Resource |
getMinimumResourceRequirement(String label,
String queue,
Set<String> resourceTypes)
Get absolute minimum resource requirement for a queue.
|
boolean |
getMoveOnExpiry(String queue)
Gets whether the applications should be killed or moved to the parent queue
when the
ReservationDefinition expires |
boolean |
getMultiNodePlacementEnabled() |
Set<MultiNodePolicySpec> |
getMultiNodePlacementPolicies() |
String |
getMultiNodesSortingAlgorithmPolicy(String queue) |
int |
getNodeLocalityDelay() |
float |
getNonLabeledQueueCapacity(String queue) |
float |
getNonLabeledQueueMaximumCapacity(String queue) |
int |
getOffSwitchPerHeartbeatLimit() |
boolean |
getOverrideWithQueueMappings() |
boolean |
getOverrideWithWorkflowPriorityMappings() |
boolean |
getPreemptionDisabled(String queue,
boolean defaultVal)
Indicates whether preemption is disabled on the specified queue.
|
List<AppPriorityACLGroup> |
getPriorityAcls(String queue,
org.apache.hadoop.yarn.api.records.Priority clusterMaxPriority) |
long |
getPUOrderingPolicyUnderUtilizedPreemptionDelay()
When a reserved container of an underutilized queue is created.
|
boolean |
getPUOrderingPolicyUnderUtilizedPreemptionEnabled()
Do we allow under-utilized queue with higher priority to preempt queue
with lower priority *even if queue with lower priority is not satisfied*.
|
boolean |
getPUOrderingPolicyUnderUtilizedPreemptionMoveReservation()
When doing preemption from under-satisfied queues for priority queue.
|
List<QueueMapping> |
getQueueMappingEntity(String queueMappingSuffix) |
List<QueueMapping> |
getQueueMappings()
Get user/group mappings to queues.
|
org.apache.hadoop.yarn.api.records.Resource |
getQueueMaximumAllocation(String queue)
Get maximum_allocation setting for the specified queue from the
configuration.
|
long |
getQueueMaximumAllocationMb(String queue) |
int |
getQueueMaximumAllocationVcores(String queue) |
QueueOrderingPolicy |
getQueueOrderingPolicy(String queue,
String parentPolicy) |
static String |
getQueuePrefix(String queue) |
org.apache.hadoop.yarn.api.records.Priority |
getQueuePriority(String queue) |
String[] |
getQueues(String queue) |
int |
getRackLocalityAdditionalDelay() |
boolean |
getRackLocalityFullReset() |
String |
getReplanner(String queue)
Gets the name of the
Planner class associated with the
queue |
Map<org.apache.hadoop.yarn.api.records.ReservationACL,org.apache.hadoop.security.authorize.AccessControlList> |
getReservationAcls(String queue)
Gets a map containing the
AccessControlList of users for each
ReservationACL acl on thee specified queue. |
String |
getReservationAdmissionPolicy(String queue)
Gets the name of the
SharingPolicy class associated with the queue |
String |
getReservationAgent(String queue)
Gets the name of the
ReservationAgent class associated with the
queue |
boolean |
getReservationContinueLook() |
long |
getReservationWindow(String queue)
Gets the length of time in milliseconds for which the
SharingPolicy
checks for validity |
org.apache.hadoop.yarn.util.resource.ResourceCalculator |
getResourceCalculator() |
boolean |
getScheduleAynschronously() |
boolean |
getShouldFailAutoQueueCreationWhenGuaranteedCapacityExceeded(String queuePath)
Fail further auto leaf queue creation when parent's guaranteed capacity is
exceeded.
|
boolean |
getShowReservationAsQueues(String queuePath)
Checks whether the reservation queues be hidden or visible
|
org.apache.hadoop.yarn.api.records.QueueState |
getState(String queue) |
static String |
getUnits(String resourceValue) |
boolean |
getUsePortForNodeName() |
int |
getUserLimit(String queue) |
float |
getUserLimitFactor(String queue) |
Collection<String> |
getWorkflowPriorityMappings() |
boolean |
isAutoCreateChildQueueEnabled(String queuePath)
If true, this queue will be created as a Parent Queue which Auto Created
leaf child queues
|
boolean |
isReservable(String queue)
Checks if the queue participates in reservation based scheduling
|
void |
setAccessibleNodeLabels(String queue,
Set<String> labels) |
void |
setAcl(String queue,
org.apache.hadoop.yarn.api.records.QueueACL acl,
String aclString) |
void |
setAcls(String queue,
Map<org.apache.hadoop.yarn.api.records.QueueACL,org.apache.hadoop.security.authorize.AccessControlList> acls) |
void |
setAutoCreateChildQueueEnabled(String queuePath,
boolean autoCreationEnabled) |
void |
setAutoCreatedLeafQueueConfigCapacity(String queuePath,
float val) |
void |
setAutoCreatedLeafQueueConfigDefaultNodeLabelExpression(String queuePath,
String expression) |
void |
setAutoCreatedLeafQueueConfigMaxCapacity(String queuePath,
float val) |
void |
setAutoCreatedLeafQueueConfigUserLimit(String queuePath,
int val) |
void |
setAutoCreatedLeafQueueConfigUserLimitFactor(String queuePath,
float val) |
void |
setAutoCreatedLeafQueueTemplateCapacityByLabel(String queuePath,
String label,
float val) |
void |
setAutoCreatedLeafQueueTemplateMaxCapacity(String queuePath,
String label,
float val) |
void |
setAverageCapacity(String queue,
float avgCapacity) |
void |
setCapacity(String queue,
float capacity) |
void |
setCapacity(String queue,
String absoluteResourceCapacity) |
void |
setCapacityByLabel(String queue,
String label,
float capacity) |
void |
setCapacityByLabel(String queue,
String label,
String absoluteResourceCapacity) |
void |
setDefaultLifetimePerQueue(String queue,
long defaultLifetime) |
void |
setDefaultNodeLabelExpression(String queue,
String exp) |
void |
setGlobalMaximumApplicationsPerQueue(int val) |
void |
setInstantaneousMaxCapacity(String queue,
float instMaxCapacity) |
void |
setMaximumAMResourcePercentPerPartition(String queue,
String label,
float percent) |
void |
setMaximumApplicationMasterResourcePerQueuePercent(String queue,
float percent) |
void |
setMaximumCapacity(String queue,
float maxCapacity) |
void |
setMaximumCapacityByLabel(String queue,
String label,
float capacity) |
void |
setMaximumLifetimePerQueue(String queue,
long maximumLifetime) |
void |
setMaximumResourceRequirement(String label,
String queue,
org.apache.hadoop.yarn.api.records.Resource resource) |
void |
setMinimumResourceRequirement(String label,
String queue,
org.apache.hadoop.yarn.api.records.Resource resource) |
void |
setNodeLocalityDelay(int nodeLocalityDelay) |
void |
setOffSwitchPerHeartbeatLimit(int limit) |
void |
setOrderingPolicy(String queue,
String policy) |
void |
setOrderingPolicyParameter(String queue,
String parameterKey,
String parameterValue) |
void |
setOverrideWithQueueMappings(boolean overrideWithQueueMappings) |
void |
setPreemptionDisabled(String queue,
boolean preemptionDisabled)
Sets the disable_preemption property in order to indicate
whether or not container preemption will be disabled for the specified
queue.
|
void |
setPriorityAcls(String queue,
org.apache.hadoop.yarn.api.records.Priority priority,
org.apache.hadoop.yarn.api.records.Priority defaultPriority,
String[] acls) |
void |
setPUOrderingPolicyUnderUtilizedPreemptionDelay(long timeout) |
void |
setPUOrderingPolicyUnderUtilizedPreemptionEnabled(boolean enabled) |
void |
setPUOrderingPolicyUnderUtilizedPreemptionMoveReservation(boolean allowMoveReservation) |
void |
setQueueMappingEntities(List<QueueMapping> queueMappings,
String queueMappingSuffix) |
void |
setQueueMappings(List<QueueMapping> queueMappings) |
void |
setQueueOrderingPolicy(String queue,
String policy) |
void |
setQueuePlacementRules(Collection<String> queuePlacementRules) |
void |
setQueuePriority(String queue,
int priority) |
void |
setQueues(String queue,
String[] subQueues) |
void |
setReservable(String queue,
boolean isReservable) |
void |
setReservationAcls(String queue,
Map<org.apache.hadoop.yarn.api.records.ReservationACL,org.apache.hadoop.security.authorize.AccessControlList> acls) |
void |
setReservationAdmissionPolicy(String queue,
String reservationPolicy) |
void |
setReservationAgent(String queue,
String reservationPolicy) |
void |
setReservationWindow(String queue,
long reservationWindow) |
void |
setResourceComparator(Class<? extends org.apache.hadoop.yarn.util.resource.ResourceCalculator> resourceCalculatorClass) |
void |
setScheduleAynschronously(boolean async) |
void |
setShouldFailAutoQueueCreationWhenGuaranteedCapacityExceeded(String queuePath,
boolean autoCreationEnabled) |
void |
setState(String queue,
org.apache.hadoop.yarn.api.records.QueueState state) |
void |
setUserLimit(String queue,
int userLimit) |
void |
setUserLimitFactor(String queue,
float userLimitFactor) |
boolean |
shouldAppFailFast(org.apache.hadoop.conf.Configuration conf) |
addDefaultResource, addDeprecation, addDeprecation, addDeprecation, addDeprecation, addDeprecations, addResource, addResource, addResource, addResource, addResource, addResource, addResource, addResource, addResource, addResource, addResource, addTags, clear, dumpConfiguration, dumpConfiguration, dumpDeprecatedKeys, get, get, getAllPropertiesByTag, getAllPropertiesByTags, getBoolean, getClass, getClass, getClassByName, getClassByNameOrNull, getClasses, getClassLoader, getConfResourceAsInputStream, getConfResourceAsReader, getDouble, getEnum, getFile, getFinalParameters, getFloat, getInstances, getInt, getInts, getLocalPath, getLong, getLongBytes, getPassword, getPasswordFromConfig, getPasswordFromCredentialProviders, getPattern, getPropertySources, getProps, getPropsWithPrefix, getRange, getRaw, getResource, getSocketAddr, getSocketAddr, getStorageSize, getStorageSize, getStringCollection, getStrings, getStrings, getTimeDuration, getTimeDuration, getTimeDuration, getTimeDuration, getTimeDurationHelper, getTimeDurations, getTrimmed, getTrimmed, getTrimmedStringCollection, getTrimmedStrings, getTrimmedStrings, getValByRegex, hasWarnedDeprecation, isDeprecated, isPropertyTag, iterator, main, onlyKeyExists, readFields, reloadConfiguration, reloadExistingConfigurations, set, set, setAllowNullValueProperties, setBoolean, setBooleanIfUnset, setClass, setClassLoader, setDeprecatedProperties, setDouble, setEnum, setFloat, setIfUnset, setInt, setLong, setPattern, setQuietMode, setRestrictSystemProperties, setRestrictSystemPropertiesDefault, setRestrictSystemProps, setSocketAddr, setStorageSize, setStrings, setTimeDuration, size, toString, unset, updateConnectAddr, updateConnectAddr, write, writeXml, writeXml, writeXml
clone, equals, finalize, getClass, hashCode, notify, notifyAll, wait, wait, wait
forEach, spliterator
@InterfaceAudience.Private public static final String PREFIX
@InterfaceAudience.Private public static final String DOT
@InterfaceAudience.Private public static final String MAXIMUM_APPLICATIONS_SUFFIX
@InterfaceAudience.Private public static final String MAXIMUM_SYSTEM_APPLICATIONS
@InterfaceAudience.Private public static final String MAXIMUM_AM_RESOURCE_SUFFIX
@InterfaceAudience.Private public static final String MAXIMUM_APPLICATION_MASTERS_RESOURCE_PERCENT
@InterfaceAudience.Private public static final String QUEUES
@InterfaceAudience.Private public static final String CAPACITY
@InterfaceAudience.Private public static final String MAXIMUM_CAPACITY
@InterfaceAudience.Private public static final String USER_LIMIT
@InterfaceAudience.Private public static final String USER_LIMIT_FACTOR
@InterfaceAudience.Private public static final String USER_WEIGHT
@InterfaceAudience.Private public static final String USER_SETTINGS
@InterfaceAudience.Private public static final float DEFAULT_USER_WEIGHT
@InterfaceAudience.Private public static final String STATE
@InterfaceAudience.Private public static final String ACCESSIBLE_NODE_LABELS
@InterfaceAudience.Private public static final String DEFAULT_NODE_LABEL_EXPRESSION
public static final String RESERVE_CONT_LOOK_ALL_NODES
@InterfaceAudience.Private public static final boolean DEFAULT_RESERVE_CONT_LOOK_ALL_NODES
@InterfaceAudience.Private public static final String MAXIMUM_ALLOCATION
@InterfaceAudience.Private public static final String MAXIMUM_ALLOCATION_MB
@InterfaceAudience.Private public static final String MAXIMUM_ALLOCATION_VCORES
public static final String ORDERING_POLICY
public static final String FIFO_APP_ORDERING_POLICY
public static final String FAIR_APP_ORDERING_POLICY
public static final String FIFO_WITH_PARTITIONS_APP_ORDERING_POLICY
public static final String FIFO_FOR_PENDING_APPS
public static final String DEFAULT_APP_ORDERING_POLICY
@InterfaceAudience.Private public static final int DEFAULT_MAXIMUM_SYSTEM_APPLICATIIONS
@InterfaceAudience.Private public static final float DEFAULT_MAXIMUM_APPLICATIONMASTERS_RESOURCE_PERCENT
@InterfaceAudience.Private public static final float UNDEFINED
@InterfaceAudience.Private public static final float MINIMUM_CAPACITY_VALUE
@InterfaceAudience.Private public static final float MAXIMUM_CAPACITY_VALUE
@InterfaceAudience.Private public static final float DEFAULT_MAXIMUM_CAPACITY_VALUE
@InterfaceAudience.Private public static final int DEFAULT_USER_LIMIT
@InterfaceAudience.Private public static final float DEFAULT_USER_LIMIT_FACTOR
@InterfaceAudience.Private public static final String ALL_ACL
@InterfaceAudience.Private public static final String NONE_ACL
@InterfaceAudience.Private public static final String ENABLE_USER_METRICS
@InterfaceAudience.Private public static final boolean DEFAULT_ENABLE_USER_METRICS
@InterfaceAudience.Private public static final String RESOURCE_CALCULATOR_CLASS
@InterfaceAudience.Private public static final Class<? extends org.apache.hadoop.yarn.util.resource.ResourceCalculator> DEFAULT_RESOURCE_CALCULATOR_CLASS
@InterfaceAudience.Private public static final String ROOT
@InterfaceAudience.Private public static final String NODE_LOCALITY_DELAY
@InterfaceAudience.Private public static final int DEFAULT_NODE_LOCALITY_DELAY
@InterfaceAudience.Private public static final String RACK_LOCALITY_ADDITIONAL_DELAY
@InterfaceAudience.Private public static final int DEFAULT_RACK_LOCALITY_ADDITIONAL_DELAY
@InterfaceAudience.Private public static final String RACK_LOCALITY_FULL_RESET
@InterfaceAudience.Private public static final int DEFAULT_OFFSWITCH_PER_HEARTBEAT_LIMIT
@InterfaceAudience.Private public static final String OFFSWITCH_PER_HEARTBEAT_LIMIT
@InterfaceAudience.Private public static final boolean DEFAULT_RACK_LOCALITY_FULL_RESET
@InterfaceAudience.Private public static final String SCHEDULE_ASYNCHRONOUSLY_PREFIX
@InterfaceAudience.Private public static final String SCHEDULE_ASYNCHRONOUSLY_ENABLE
@InterfaceAudience.Private public static final String SCHEDULE_ASYNCHRONOUSLY_MAXIMUM_THREAD
@InterfaceAudience.Private public static final String SCHEDULE_ASYNCHRONOUSLY_MAXIMUM_PENDING_BACKLOGS
@InterfaceAudience.Private public static final String APP_FAIL_FAST
@InterfaceAudience.Private public static final boolean DEFAULT_APP_FAIL_FAST
@InterfaceAudience.Private public static final Integer DEFAULT_SCHEDULE_ASYNCHRONOUSLY_MAXIMUM_PENDING_BACKLOGS
@InterfaceAudience.Private public static final boolean DEFAULT_SCHEDULE_ASYNCHRONOUSLY_ENABLE
@InterfaceAudience.Private public static final String QUEUE_MAPPING
@InterfaceAudience.Private public static final String ENABLE_QUEUE_MAPPING_OVERRIDE
@InterfaceAudience.Private public static final boolean DEFAULT_ENABLE_QUEUE_MAPPING_OVERRIDE
@InterfaceAudience.Private public static final String WORKFLOW_PRIORITY_MAPPINGS
@InterfaceAudience.Private public static final String ENABLE_WORKFLOW_PRIORITY_MAPPINGS_OVERRIDE
@InterfaceAudience.Private public static final boolean DEFAULT_ENABLE_WORKFLOW_PRIORITY_MAPPINGS_OVERRIDE
@InterfaceAudience.Private public static final String QUEUE_PREEMPTION_DISABLED
@InterfaceAudience.Private public static final String DEFAULT_APPLICATION_PRIORITY
@InterfaceAudience.Private public static final Integer DEFAULT_CONFIGURATION_APPLICATION_PRIORITY
@InterfaceAudience.Private public static final String AVERAGE_CAPACITY
@InterfaceAudience.Private public static final String IS_RESERVABLE
@InterfaceAudience.Private public static final String RESERVATION_WINDOW
@InterfaceAudience.Private public static final String INSTANTANEOUS_MAX_CAPACITY
@InterfaceAudience.Private public static final String RESERVATION_ADMISSION_POLICY
@InterfaceAudience.Private public static final String RESERVATION_AGENT_NAME
@InterfaceAudience.Private public static final String RESERVATION_SHOW_RESERVATION_AS_QUEUE
@InterfaceAudience.Private public static final String RESERVATION_PLANNER_NAME
@InterfaceAudience.Private public static final String RESERVATION_MOVE_ON_EXPIRY
@InterfaceAudience.Private public static final String RESERVATION_ENFORCEMENT_WINDOW
@InterfaceAudience.Private public static final String LAZY_PREEMPTION_ENABLED
@InterfaceAudience.Private public static final boolean DEFAULT_LAZY_PREEMPTION_ENABLED
@InterfaceAudience.Private public static final String ASSIGN_MULTIPLE_ENABLED
@InterfaceAudience.Private public static final boolean DEFAULT_ASSIGN_MULTIPLE_ENABLED
@InterfaceAudience.Private public static final String MAX_ASSIGN_PER_HEARTBEAT
@InterfaceAudience.Private public static final int DEFAULT_MAX_ASSIGN_PER_HEARTBEAT
@InterfaceAudience.Private public static final String MINIMUM_RESOURCE
@InterfaceAudience.Private public static final String MAXIMUM_RESOURCE
public static final String DEFAULT_RESOURCE_TYPES
public static final String PATTERN_FOR_ABSOLUTE_RESOURCE
public static final Pattern RESOURCE_PATTERN
public static final String MAX_PARALLEL_APPLICATIONS
public static final int DEFAULT_MAX_PARALLEL_APPLICATIONS
public static final String PREEMPTION_OBSERVE_ONLY
public static final boolean DEFAULT_PREEMPTION_OBSERVE_ONLY
public static final String PREEMPTION_MONITORING_INTERVAL
public static final long DEFAULT_PREEMPTION_MONITORING_INTERVAL
public static final String PREEMPTION_WAIT_TIME_BEFORE_KILL
public static final long DEFAULT_PREEMPTION_WAIT_TIME_BEFORE_KILL
public static final String TOTAL_PREEMPTION_PER_ROUND
public static final float DEFAULT_TOTAL_PREEMPTION_PER_ROUND
public static final String PREEMPTION_MAX_IGNORED_OVER_CAPACITY
public static final double DEFAULT_PREEMPTION_MAX_IGNORED_OVER_CAPACITY
public static final String PREEMPTION_NATURAL_TERMINATION_FACTOR
PREEMPTION_MAX_IGNORED_OVER_CAPACITY
). For example, a termination factor of 0.5
will reclaim almost 95% of resources within 5 * PREEMPTION_WAIT_TIME_BEFORE_KILL
, even absent natural termination.public static final double DEFAULT_PREEMPTION_NATURAL_TERMINATION_FACTOR
public static final String ADDITIONAL_RESOURCE_BALANCE_BASED_ON_RESERVED_CONTAINERS
public static final boolean DEFAULT_ADDITIONAL_RESOURCE_BALANCE_BASED_ON_RESERVED_CONTAINERS
public static final String PREEMPTION_SELECT_CANDIDATES_FOR_RESERVED_CONTAINERS
public static final boolean DEFAULT_PREEMPTION_SELECT_CANDIDATES_FOR_RESERVED_CONTAINERS
public static final String INTRAQUEUE_PREEMPTION_ENABLED
public static final boolean DEFAULT_INTRAQUEUE_PREEMPTION_ENABLED
public static final String INTRAQUEUE_PREEMPTION_MINIMUM_THRESHOLD
public static final float DEFAULT_INTRAQUEUE_PREEMPTION_MINIMUM_THRESHOLD
public static final String INTRAQUEUE_PREEMPTION_MAX_ALLOWABLE_LIMIT
public static final float DEFAULT_INTRAQUEUE_PREEMPTION_MAX_ALLOWABLE_LIMIT
public static final String INTRAQUEUE_PREEMPTION_ORDER_POLICY
public static final String DEFAULT_INTRAQUEUE_PREEMPTION_ORDER_POLICY
public static final String CROSS_QUEUE_PREEMPTION_CONSERVATIVE_DRF
public static final Boolean DEFAULT_CROSS_QUEUE_PREEMPTION_CONSERVATIVE_DRF
public static final String IN_QUEUE_PREEMPTION_CONSERVATIVE_DRF
public static final Boolean DEFAULT_IN_QUEUE_PREEMPTION_CONSERVATIVE_DRF
public static final String PREEMPTION_TO_BALANCE_QUEUES_BEYOND_GUARANTEED
public static final boolean DEFAULT_PREEMPTION_TO_BALANCE_QUEUES_BEYOND_GUARANTEED
public static final String MAX_WAIT_BEFORE_KILL_FOR_QUEUE_BALANCE_PREEMPTION
public static final long DEFAULT_MAX_WAIT_BEFORE_KILL_FOR_QUEUE_BALANCE_PREEMPTION
@InterfaceAudience.Private public static final String QUEUE_GLOBAL_MAX_APPLICATION
public static final String QUEUE_UTILIZATION_ORDERING_POLICY
public static final String QUEUE_PRIORITY_UTILIZATION_ORDERING_POLICY
public static final String DEFAULT_QUEUE_ORDERING_POLICY
public static final String MAXIMUM_LIFETIME_SUFFIX
public static final String DEFAULT_LIFETIME_SUFFIX
@InterfaceAudience.Private public static final boolean DEFAULT_AUTO_CREATE_CHILD_QUEUE_ENABLED
@InterfaceAudience.Private public static final String AUTO_CREATE_CHILD_QUEUE_ENABLED
@InterfaceAudience.Private public static final String AUTO_CREATED_LEAF_QUEUE_TEMPLATE_PREFIX
@InterfaceAudience.Private public static final String AUTO_CREATE_QUEUE_MAX_QUEUES
@InterfaceAudience.Private public static final int DEFAULT_AUTO_CREATE_QUEUE_MAX_QUEUES
@InterfaceAudience.Private public static final String FAIL_AUTO_CREATION_ON_EXCEEDING_CAPACITY
@InterfaceAudience.Private public static final boolean DEFAULT_FAIL_AUTO_CREATION_ON_EXCEEDING_CAPACITY
@InterfaceAudience.Private public static final String AUTO_CREATED_QUEUE_MANAGEMENT_POLICY
@InterfaceAudience.Private public static final String DEFAULT_AUTO_CREATED_QUEUE_MANAGEMENT_POLICY
@InterfaceAudience.Private public static final String QUEUE_MANAGEMENT_MONITORING_INTERVAL
@InterfaceAudience.Private public static final long DEFAULT_QUEUE_MANAGEMENT_MONITORING_INTERVAL
@InterfaceAudience.Private public static final String MULTI_NODE_SORTING_POLICIES
@InterfaceAudience.Private public static final String MULTI_NODE_SORTING_POLICY_NAME
public static final String DEFAULT_NODE_SORTING_POLICY
public static final String DEFAULT_NODE_SORTING_POLICY_CLASSNAME
public static final long DEFAULT_MULTI_NODE_SORTING_INTERVAL
@InterfaceAudience.Private public static final String MULTI_NODE_PLACEMENT_ENABLED
@InterfaceAudience.Private public static final boolean DEFAULT_MULTI_NODE_PLACEMENT_ENABLED
public CapacitySchedulerConfiguration()
public CapacitySchedulerConfiguration(org.apache.hadoop.conf.Configuration configuration)
public CapacitySchedulerConfiguration(org.apache.hadoop.conf.Configuration configuration, boolean useLocalConfigurationProvider)
public int getMaximumSystemApplications()
public float getMaximumApplicationMasterResourcePercent()
public int getMaximumApplicationsPerQueue(String queue)
queue
- name of the queuepublic float getMaximumApplicationMasterResourcePerQueuePercent(String queue)
queue
- name of the queuepublic void setMaximumApplicationMasterResourcePerQueuePercent(String queue, float percent)
public float getNonLabeledQueueCapacity(String queue)
public void setCapacity(String queue, float capacity)
public float getNonLabeledQueueMaximumCapacity(String queue)
public void setMaximumCapacity(String queue, float maxCapacity)
public void setCapacityByLabel(String queue, String label, String absoluteResourceCapacity)
public void setMaximumCapacityByLabel(String queue, String label, float capacity)
public int getUserLimit(String queue)
public <S extends SchedulableEntity> OrderingPolicy<S> getAppOrderingPolicy(String queue)
public void setUserLimit(String queue, int userLimit)
public float getUserLimitFactor(String queue)
public void setUserLimitFactor(String queue, float userLimitFactor)
public org.apache.hadoop.yarn.api.records.QueueState getConfiguredState(String queue)
public org.apache.hadoop.yarn.api.records.QueueState getState(String queue)
@InterfaceAudience.Private public void setState(String queue, org.apache.hadoop.yarn.api.records.QueueState state)
public float getLabeledQueueMaximumCapacity(String queue, String label)
public float getMaximumAMResourcePercentPerPartition(String queue, String label)
public void setMaximumAMResourcePercentPerPartition(String queue, String label, float percent)
public boolean getReservationContinueLook()
public org.apache.hadoop.security.authorize.AccessControlList getAcl(String queue, org.apache.hadoop.yarn.api.records.QueueACL acl)
public void setAcl(String queue, org.apache.hadoop.yarn.api.records.QueueACL acl, String aclString)
public Map<org.apache.hadoop.yarn.api.records.ReservationACL,org.apache.hadoop.security.authorize.AccessControlList> getReservationAcls(String queue)
ReservationSchedulerConfiguration
AccessControlList
of users for each
ReservationACL
acl on thee specified queue.getReservationAcls
in class ReservationSchedulerConfiguration
queue
- the queue with which to check a user's permissions.ReservationACL
to AccessControlList
which contains a list of users that have the specified permission level.public Map<org.apache.hadoop.yarn.security.AccessType,org.apache.hadoop.security.authorize.AccessControlList> getAcls(String queue)
public void setAcls(String queue, Map<org.apache.hadoop.yarn.api.records.QueueACL,org.apache.hadoop.security.authorize.AccessControlList> acls)
public void setReservationAcls(String queue, Map<org.apache.hadoop.yarn.api.records.ReservationACL,org.apache.hadoop.security.authorize.AccessControlList> acls)
public void setPriorityAcls(String queue, org.apache.hadoop.yarn.api.records.Priority priority, org.apache.hadoop.yarn.api.records.Priority defaultPriority, String[] acls)
public List<AppPriorityACLGroup> getPriorityAcls(String queue, org.apache.hadoop.yarn.api.records.Priority clusterMaxPriority)
public org.apache.hadoop.yarn.api.records.Resource getMinimumAllocation()
@InterfaceAudience.Private public org.apache.hadoop.yarn.api.records.Priority getQueuePriority(String queue)
@InterfaceAudience.Private public void setQueuePriority(String queue, int priority)
public org.apache.hadoop.yarn.api.records.Resource getQueueMaximumAllocation(String queue)
queue
- name of the queuepublic long getQueueMaximumAllocationMb(String queue)
public int getQueueMaximumAllocationVcores(String queue)
public boolean getEnableUserMetrics()
public int getOffSwitchPerHeartbeatLimit()
public void setOffSwitchPerHeartbeatLimit(int limit)
public int getNodeLocalityDelay()
public void setNodeLocalityDelay(int nodeLocalityDelay)
public int getRackLocalityAdditionalDelay()
public boolean getRackLocalityFullReset()
public org.apache.hadoop.yarn.util.resource.ResourceCalculator getResourceCalculator()
public boolean getUsePortForNodeName()
public void setResourceComparator(Class<? extends org.apache.hadoop.yarn.util.resource.ResourceCalculator> resourceCalculatorClass)
public boolean getScheduleAynschronously()
public void setScheduleAynschronously(boolean async)
public boolean getOverrideWithQueueMappings()
@InterfaceAudience.Private public void setOverrideWithQueueMappings(boolean overrideWithQueueMappings)
public List<QueueMapping> getQueueMappingEntity(String queueMappingSuffix)
public void setQueueMappingEntities(List<QueueMapping> queueMappings, String queueMappingSuffix)
public boolean getOverrideWithWorkflowPriorityMappings()
public Collection<String> getWorkflowPriorityMappings()
public List<QueueMapping> getQueueMappings()
@InterfaceAudience.Private public void setQueuePlacementRules(Collection<String> queuePlacementRules)
@InterfaceAudience.Private public void setQueueMappings(List<QueueMapping> queueMappings)
public boolean isReservable(String queue)
ReservationSchedulerConfiguration
isReservable
in class ReservationSchedulerConfiguration
queue
- name of the queuepublic void setReservable(String queue, boolean isReservable)
public long getReservationWindow(String queue)
ReservationSchedulerConfiguration
SharingPolicy
checks for validitygetReservationWindow
in class ReservationSchedulerConfiguration
queue
- name of the queueSharingPolicy
public float getAverageCapacity(String queue)
ReservationSchedulerConfiguration
ReservationSchedulerConfiguration.getReservationWindow(java.lang.String)
by the
the SharingPolicy
to check aggregate used capacitygetAverageCapacity
in class ReservationSchedulerConfiguration
queue
- name of the queueSharingPolicy
public float getInstantaneousMaxCapacity(String queue)
ReservationSchedulerConfiguration
SharingPolicy
allowsgetInstantaneousMaxCapacity
in class ReservationSchedulerConfiguration
queue
- name of the queuepublic void setInstantaneousMaxCapacity(String queue, float instMaxCapacity)
public void setReservationWindow(String queue, long reservationWindow)
public void setAverageCapacity(String queue, float avgCapacity)
public String getReservationAdmissionPolicy(String queue)
ReservationSchedulerConfiguration
SharingPolicy
class associated with the queuegetReservationAdmissionPolicy
in class ReservationSchedulerConfiguration
queue
- name of the queueSharingPolicy
public void setReservationAdmissionPolicy(String queue, String reservationPolicy)
public String getReservationAgent(String queue)
ReservationSchedulerConfiguration
ReservationAgent
class associated with the
queuegetReservationAgent
in class ReservationSchedulerConfiguration
queue
- name of the queueReservationAgent
public boolean getShowReservationAsQueues(String queuePath)
ReservationSchedulerConfiguration
getShowReservationAsQueues
in class ReservationSchedulerConfiguration
queuePath
- name of the queuepublic String getReplanner(String queue)
ReservationSchedulerConfiguration
Planner
class associated with the
queuegetReplanner
in class ReservationSchedulerConfiguration
queue
- name of the queuePlanner
public boolean getMoveOnExpiry(String queue)
ReservationSchedulerConfiguration
ReservationDefinition
expiresgetMoveOnExpiry
in class ReservationSchedulerConfiguration
queue
- name of the queuepublic long getEnforcementWindow(String queue)
ReservationSchedulerConfiguration
Planner
will verify
the Plan
s satisfy the constraintsgetEnforcementWindow
in class ReservationSchedulerConfiguration
queue
- name of the queuepublic void setPreemptionDisabled(String queue, boolean preemptionDisabled)
queue
- queue pathpreemptionDisabled
- true if preemption is disabled on queuepublic boolean getPreemptionDisabled(String queue, boolean defaultVal)
queue
- queue path to querydefaultVal
- used as default if the disable_preemption
is not set in the configurationpublic boolean getIntraQueuePreemptionDisabled(String queue, boolean defaultVal)
queue
- queue path to querydefaultVal
- used as default if the property is not set in the
configurationpublic Set<String> getConfiguredNodeLabels(String queuePath)
public Integer getDefaultApplicationPriorityConfPerQueue(String queue)
public void setOrderingPolicyParameter(String queue, String parameterKey, String parameterValue)
public boolean getLazyPreemptionEnabled()
public boolean shouldAppFailFast(org.apache.hadoop.conf.Configuration conf)
public int getGlobalMaximumApplicationsPerQueue()
public void setGlobalMaximumApplicationsPerQueue(int val)
@InterfaceAudience.Private public void setQueueOrderingPolicy(String queue, String policy)
@InterfaceAudience.Private public QueueOrderingPolicy getQueueOrderingPolicy(String queue, String parentPolicy)
public boolean getPUOrderingPolicyUnderUtilizedPreemptionEnabled()
public void setPUOrderingPolicyUnderUtilizedPreemptionEnabled(boolean enabled)
public long getPUOrderingPolicyUnderUtilizedPreemptionDelay()
PREEMPTION_WAIT_TIME_BEFORE_KILL
.
This parameter is added to make preemption from lower priority queue which
is underutilized to be more careful. This parameter takes effect when
underutilized-preemption.enabled set to true.public void setPUOrderingPolicyUnderUtilizedPreemptionDelay(long timeout)
public boolean getPUOrderingPolicyUnderUtilizedPreemptionMoveReservation()
public void setPUOrderingPolicyUnderUtilizedPreemptionMoveReservation(boolean allowMoveReservation)
public Map<String,Float> getAllUserWeightsForQueue(String queuePath)
queuePath
- full queue pathpublic boolean getAssignMultipleEnabled()
public int getMaxAssignPerHeartbeat()
public long getMaximumLifetimePerQueue(String queue)
public void setMaximumLifetimePerQueue(String queue, long maximumLifetime)
public long getDefaultLifetimePerQueue(String queue)
public void setDefaultLifetimePerQueue(String queue, long defaultLifetime)
@InterfaceAudience.Private public boolean isAutoCreateChildQueueEnabled(String queuePath)
queuePath
- The queues path@InterfaceAudience.Private public void setAutoCreateChildQueueEnabled(String queuePath, boolean autoCreationEnabled)
@InterfaceAudience.Private public String getAutoCreatedQueueTemplateConfPrefix(String queuePath)
queuePath
- parent queue's path@InterfaceAudience.Private public boolean getShouldFailAutoQueueCreationWhenGuaranteedCapacityExceeded(String queuePath)
queuePath
- the parent queue's path@InterfaceAudience.Private public void setShouldFailAutoQueueCreationWhenGuaranteedCapacityExceeded(String queuePath, boolean autoCreationEnabled)
@InterfaceAudience.Private public int getAutoCreatedQueuesMaxChildQueuesLimit(String queuePath)
queuePath
- the paret queue's path@InterfaceAudience.Private public String getAutoCreatedQueueManagementPolicy(String queue)
queue
- The queue's path@InterfaceAudience.Private protected AutoCreatedQueueManagementPolicy getAutoCreatedQueueManagementPolicyClass(String queueName)
queueName
- The parent queue's name@InterfaceAudience.Private public void setAutoCreatedLeafQueueConfigCapacity(String queuePath, float val)
@InterfaceAudience.Private public void setAutoCreatedLeafQueueTemplateCapacityByLabel(String queuePath, String label, float val)
@InterfaceAudience.Private public void setAutoCreatedLeafQueueConfigMaxCapacity(String queuePath, float val)
@InterfaceAudience.Private public void setAutoCreatedLeafQueueTemplateMaxCapacity(String queuePath, String label, float val)
@InterfaceAudience.Private public void setAutoCreatedLeafQueueConfigUserLimit(String queuePath, int val)
@InterfaceAudience.Private public void setAutoCreatedLeafQueueConfigUserLimitFactor(String queuePath, float val)
@InterfaceAudience.Private public void setAutoCreatedLeafQueueConfigDefaultNodeLabelExpression(String queuePath, String expression)
public org.apache.hadoop.yarn.api.records.Resource getMinimumResourceRequirement(String label, String queue, Set<String> resourceTypes)
label
- NodeLabelqueue
- queue pathresourceTypes
- Resource typespublic org.apache.hadoop.yarn.api.records.Resource getMaximumResourceRequirement(String label, String queue, Set<String> resourceTypes)
label
- NodeLabelqueue
- queue pathresourceTypes
- Resource typespublic void setMinimumResourceRequirement(String label, String queue, org.apache.hadoop.yarn.api.records.Resource resource)
public void setMaximumResourceRequirement(String label, String queue, org.apache.hadoop.yarn.api.records.Resource resource)
public boolean getMultiNodePlacementEnabled()
public Set<MultiNodePolicySpec> getMultiNodePlacementPolicies()
Copyright © 2008–2021 Apache Software Foundation. All rights reserved.