Package | Description |
---|---|
org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity | |
org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf |
Package
org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf
contains classes related to capacity scheduler configuration management.
|
org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.converter |
This package contains classes related to the Fair Scheduler ->
Capacity Scheduler conversion.
|
org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.converter.weightconversion | |
org.apache.hadoop.yarn.server.resourcemanager.webapp.dao |
This package contains the web data access objects (DAO) for the RM.
|
Modifier and Type | Method and Description |
---|---|
CapacitySchedulerConfiguration |
CapacityScheduler.getConfiguration() |
CapacitySchedulerConfiguration |
CapacitySchedulerContext.getConfiguration() |
CapacitySchedulerConfiguration |
CapacitySchedulerQueueContext.getConfiguration() |
CapacitySchedulerConfiguration |
AutoCreatedLeafQueueConfig.getLeafQueueConfigs() |
protected CapacitySchedulerConfiguration |
AbstractManagedParentQueue.initializeLeafQueueConfigs(String configPrefix) |
Modifier and Type | Method and Description |
---|---|
QueueStateManager<CSQueue,CapacitySchedulerConfiguration> |
CapacitySchedulerQueueManager.getQueueStateManager() |
Modifier and Type | Method and Description |
---|---|
AutoCreatedLeafQueueConfig.Builder |
AutoCreatedLeafQueueConfig.Builder.configuration(CapacitySchedulerConfiguration conf) |
static UserWeights |
UserWeights.createByConfig(CapacitySchedulerConfiguration conf,
ConfigurationProperties configurationProperties,
String queuePath) |
String |
ManagedParentQueue.getLeafQueueConfigPrefix(CapacitySchedulerConfiguration conf) |
List<org.apache.hadoop.yarn.security.Permission> |
CapacitySchedulerQueueManager.getPermissionsForDynamicQueue(QueuePath queuePath,
CapacitySchedulerConfiguration csConf) |
void |
CapacitySchedulerQueueManager.initializeQueues(CapacitySchedulerConfiguration conf)
Initialized the queues.
|
static void |
CSQueueUtils.loadCapacitiesByLabelsFromConf(QueuePath queuePath,
QueueCapacities queueCapacities,
CapacitySchedulerConfiguration csConf,
Set<String> nodeLabels) |
void |
CapacitySchedulerQueueManager.reinitConfiguredNodeLabels(CapacitySchedulerConfiguration conf) |
void |
CapacitySchedulerQueueManager.reinitializeQueues(CapacitySchedulerConfiguration newConf) |
void |
AutoCreatedQueueTemplate.setTemplateEntriesForChild(CapacitySchedulerConfiguration conf,
String childQueuePath)
Sets the common template properties and parent specific template
properties of a child queue based on its parent template settings.
|
void |
AutoCreatedQueueTemplate.setTemplateEntriesForChild(CapacitySchedulerConfiguration conf,
String childQueuePath,
boolean isLeaf)
Sets the common template properties and leaf or parent specific template
properties of a child queue based on its parent template settings.
|
static void |
CapacitySchedulerConfigValidator.validateQueueHierarchy(CSQueueStore queues,
CSQueueStore newQueues,
CapacitySchedulerConfiguration newConf)
Ensure all existing queues are present.
|
Constructor and Description |
---|
AutoCreatedQueueTemplate(CapacitySchedulerConfiguration configuration,
QueuePath queuePath) |
CapacitySchedulerQueueCapacityHandler(RMNodeLabelsManager labelsManager,
CapacitySchedulerConfiguration configuration) |
ConfiguredNodeLabels(CapacitySchedulerConfiguration conf) |
CSQueuePreemptionSettings(CSQueue queue,
CapacitySchedulerConfiguration configuration) |
QueueAppLifetimeAndLimitSettings(CapacitySchedulerConfiguration configuration,
AbstractCSQueue q,
QueuePath queuePath) |
QueueNodeLabelsSettings(CapacitySchedulerConfiguration configuration,
CSQueue parent,
QueuePath queuePath,
ConfiguredNodeLabels configuredNodeLabels) |
Modifier and Type | Method and Description |
---|---|
CapacitySchedulerConfiguration |
CSConfigurationProvider.loadConfiguration(org.apache.hadoop.conf.Configuration conf)
Loads capacity scheduler configuration object.
|
CapacitySchedulerConfiguration |
MutableCSConfigurationProvider.loadConfiguration(org.apache.hadoop.conf.Configuration configuration) |
CapacitySchedulerConfiguration |
FileBasedCSConfigurationProvider.loadConfiguration(org.apache.hadoop.conf.Configuration conf) |
Modifier and Type | Method and Description |
---|---|
static Map<String,String> |
ConfigurationUpdateAssembler.constructKeyValueConfUpdate(CapacitySchedulerConfiguration proposedConf,
org.apache.hadoop.yarn.webapp.dao.SchedConfUpdateInfo mutationInfo) |
Modifier and Type | Method and Description |
---|---|
FSQueueConverterBuilder |
FSQueueConverterBuilder.withCapacitySchedulerConfig(CapacitySchedulerConfiguration capacitySchedulerConfig) |
Modifier and Type | Method and Description |
---|---|
void |
CapacityConverter.convertWeightsForChildQueues(FSQueue queue,
CapacitySchedulerConfiguration csConfig) |
void |
WeightToPercentConverter.convertWeightsForChildQueues(FSQueue queue,
CapacitySchedulerConfiguration csConfig) |
void |
WeightToWeightConverter.convertWeightsForChildQueues(FSQueue queue,
CapacitySchedulerConfiguration csConfig) |
Modifier and Type | Method and Description |
---|---|
static ArrayList<QueueAclInfo> |
CapacitySchedulerQueueInfo.getSortedQueueAclInfoList(CSQueue queue,
String queuePath,
CapacitySchedulerConfiguration conf) |
Copyright © 2008–2024 Apache Software Foundation. All rights reserved.