YARN-10425. Replace the legacy placement engine in CS with the new one. Contributed by Gergely Pollak.
This commit is contained in:
parent
cd0490e8c6
commit
567600fd80
|
@ -866,7 +866,7 @@ public class RMAppManager implements EventHandler<RMAppManagerEvent>,
|
||||||
String usernameUsedForPlacement =
|
String usernameUsedForPlacement =
|
||||||
getUserNameForPlacement(user, context, placementManager);
|
getUserNameForPlacement(user, context, placementManager);
|
||||||
placementContext = placementManager
|
placementContext = placementManager
|
||||||
.placeApplication(context, usernameUsedForPlacement);
|
.placeApplication(context, usernameUsedForPlacement, isRecovery);
|
||||||
} catch (YarnException e) {
|
} catch (YarnException e) {
|
||||||
// Placement could also fail if the user doesn't exist in system
|
// Placement could also fail if the user doesn't exist in system
|
||||||
// skip if the user is not found during recovery.
|
// skip if the user is not found during recovery.
|
||||||
|
|
|
@ -1,204 +0,0 @@
|
||||||
/**
|
|
||||||
* Licensed to the Apache Software Foundation (ASF) under one
|
|
||||||
* or more contributor license agreements. See the NOTICE file
|
|
||||||
* distributed with this work for additional information
|
|
||||||
* regarding copyright ownership. The ASF licenses this file
|
|
||||||
* to you under the Apache License, Version 2.0 (the
|
|
||||||
* "License"); you may not use this file except in compliance
|
|
||||||
* with the License. You may obtain a copy of the License at
|
|
||||||
*
|
|
||||||
* http://www.apache.org/licenses/LICENSE-2.0
|
|
||||||
*
|
|
||||||
* Unless required by applicable law or agreed to in writing, software
|
|
||||||
* distributed under the License is distributed on an "AS IS" BASIS,
|
|
||||||
* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
|
|
||||||
* See the License for the specific language governing permissions and
|
|
||||||
* limitations under the License.
|
|
||||||
*/
|
|
||||||
|
|
||||||
package org.apache.hadoop.yarn.server.resourcemanager.placement;
|
|
||||||
|
|
||||||
import org.slf4j.Logger;
|
|
||||||
import org.slf4j.LoggerFactory;
|
|
||||||
import org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext;
|
|
||||||
import org.apache.hadoop.yarn.conf.YarnConfiguration;
|
|
||||||
import org.apache.hadoop.yarn.exceptions.YarnException;
|
|
||||||
import org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceScheduler;
|
|
||||||
import org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue;
|
|
||||||
import org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler;
|
|
||||||
import org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration;
|
|
||||||
import org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerContext;
|
|
||||||
import org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerQueueManager;
|
|
||||||
|
|
||||||
import java.io.IOException;
|
|
||||||
import java.util.ArrayList;
|
|
||||||
import java.util.List;
|
|
||||||
|
|
||||||
import static org.apache.hadoop.yarn.server.resourcemanager.placement.QueuePlacementRuleUtils.getPlacementContext;
|
|
||||||
import static org.apache.hadoop.yarn.server.resourcemanager.placement.QueuePlacementRuleUtils.isStaticQueueMapping;
|
|
||||||
import static org.apache.hadoop.yarn.server.resourcemanager.placement.QueuePlacementRuleUtils.validateAndGetAutoCreatedQueueMapping;
|
|
||||||
import static org.apache.hadoop.yarn.server.resourcemanager.placement.QueuePlacementRuleUtils.validateAndGetQueueMapping;
|
|
||||||
|
|
||||||
public class AppNameMappingPlacementRule extends PlacementRule {
|
|
||||||
private static final Logger LOG = LoggerFactory
|
|
||||||
.getLogger(AppNameMappingPlacementRule.class);
|
|
||||||
|
|
||||||
public static final String CURRENT_APP_MAPPING = "%application";
|
|
||||||
|
|
||||||
private static final String QUEUE_MAPPING_NAME = "app-name";
|
|
||||||
|
|
||||||
private boolean overrideWithQueueMappings = false;
|
|
||||||
private List<QueueMapping> mappings = null;
|
|
||||||
protected CapacitySchedulerQueueManager queueManager;
|
|
||||||
|
|
||||||
public AppNameMappingPlacementRule() {
|
|
||||||
this(false, null);
|
|
||||||
}
|
|
||||||
|
|
||||||
public AppNameMappingPlacementRule(boolean overrideWithQueueMappings,
|
|
||||||
List<QueueMapping> newMappings) {
|
|
||||||
this.overrideWithQueueMappings = overrideWithQueueMappings;
|
|
||||||
this.mappings = newMappings;
|
|
||||||
}
|
|
||||||
|
|
||||||
@Override
|
|
||||||
public boolean initialize(ResourceScheduler scheduler)
|
|
||||||
throws IOException {
|
|
||||||
if (!(scheduler instanceof CapacityScheduler)) {
|
|
||||||
throw new IOException(
|
|
||||||
"AppNameMappingPlacementRule can be configured only for "
|
|
||||||
+ "CapacityScheduler");
|
|
||||||
}
|
|
||||||
CapacitySchedulerContext schedulerContext =
|
|
||||||
(CapacitySchedulerContext) scheduler;
|
|
||||||
CapacitySchedulerConfiguration conf = schedulerContext.getConfiguration();
|
|
||||||
boolean overrideWithQueueMappings = conf.getOverrideWithQueueMappings();
|
|
||||||
LOG.info(
|
|
||||||
"Initialized App Name queue mappings, override: " + overrideWithQueueMappings);
|
|
||||||
|
|
||||||
List<QueueMapping> queueMappings =
|
|
||||||
conf.getQueueMappingEntity(QUEUE_MAPPING_NAME);
|
|
||||||
|
|
||||||
// Get new user mappings
|
|
||||||
List<QueueMapping> newMappings = new ArrayList<>();
|
|
||||||
|
|
||||||
queueManager = schedulerContext.getCapacitySchedulerQueueManager();
|
|
||||||
|
|
||||||
// check if mappings refer to valid queues
|
|
||||||
for (QueueMapping mapping : queueMappings) {
|
|
||||||
if (isStaticQueueMapping(mapping)) {
|
|
||||||
//at this point mapping.getQueueName() return only the queue name, since
|
|
||||||
//the config parsing have been changed making QueueMapping more
|
|
||||||
//consistent
|
|
||||||
|
|
||||||
CSQueue queue = queueManager.getQueue(mapping.getFullPath());
|
|
||||||
if (ifQueueDoesNotExist(queue)) {
|
|
||||||
//Try getting queue by its full path name, if it exists it is a static
|
|
||||||
//leaf queue indeed, without any auto creation magic
|
|
||||||
|
|
||||||
if (queueManager.isAmbiguous(mapping.getFullPath())) {
|
|
||||||
throw new IOException(
|
|
||||||
"mapping contains ambiguous leaf queue reference " + mapping
|
|
||||||
.getFullPath());
|
|
||||||
}
|
|
||||||
|
|
||||||
//if leaf queue does not exist,
|
|
||||||
// this could be a potential auto created leaf queue
|
|
||||||
//validate if parent queue is specified,
|
|
||||||
// then it should exist and
|
|
||||||
// be an instance of AutoCreateEnabledParentQueue
|
|
||||||
QueueMapping newMapping =
|
|
||||||
validateAndGetAutoCreatedQueueMapping(queueManager, mapping);
|
|
||||||
if (newMapping == null) {
|
|
||||||
throw new IOException(
|
|
||||||
"mapping contains invalid or non-leaf queue " + mapping
|
|
||||||
.getQueue());
|
|
||||||
}
|
|
||||||
newMappings.add(newMapping);
|
|
||||||
} else {
|
|
||||||
// if queue exists, validate
|
|
||||||
// if its an instance of leaf queue
|
|
||||||
// if its an instance of auto created leaf queue,
|
|
||||||
// then extract parent queue name and update queue mapping
|
|
||||||
QueueMapping newMapping = validateAndGetQueueMapping(
|
|
||||||
queueManager, queue, mapping);
|
|
||||||
newMappings.add(newMapping);
|
|
||||||
}
|
|
||||||
} else {
|
|
||||||
//If it is a dynamic queue mapping,
|
|
||||||
// we can safely assume leaf queue name does not have '.' in it
|
|
||||||
// validate
|
|
||||||
// if parent queue is specified, then
|
|
||||||
// parent queue exists and an instance of AutoCreateEnabledParentQueue
|
|
||||||
//
|
|
||||||
QueueMapping newMapping = validateAndGetAutoCreatedQueueMapping(
|
|
||||||
queueManager, mapping);
|
|
||||||
if (newMapping != null) {
|
|
||||||
newMappings.add(newMapping);
|
|
||||||
} else{
|
|
||||||
newMappings.add(mapping);
|
|
||||||
}
|
|
||||||
}
|
|
||||||
}
|
|
||||||
|
|
||||||
if (newMappings.size() > 0) {
|
|
||||||
this.mappings = newMappings;
|
|
||||||
this.overrideWithQueueMappings = overrideWithQueueMappings;
|
|
||||||
LOG.info("get valid queue mapping from app name config: " +
|
|
||||||
newMappings.toString() + ", override: " + overrideWithQueueMappings);
|
|
||||||
return true;
|
|
||||||
}
|
|
||||||
return false;
|
|
||||||
}
|
|
||||||
|
|
||||||
private static boolean ifQueueDoesNotExist(CSQueue queue) {
|
|
||||||
return queue == null;
|
|
||||||
}
|
|
||||||
|
|
||||||
private ApplicationPlacementContext getAppPlacementContext(String user,
|
|
||||||
String applicationName) throws IOException {
|
|
||||||
for (QueueMapping mapping : mappings) {
|
|
||||||
if (mapping.getSource().equals(CURRENT_APP_MAPPING)) {
|
|
||||||
if (mapping.getQueue().equals(CURRENT_APP_MAPPING)) {
|
|
||||||
return getPlacementContext(mapping, applicationName, queueManager);
|
|
||||||
} else {
|
|
||||||
return getPlacementContext(mapping, queueManager);
|
|
||||||
}
|
|
||||||
}
|
|
||||||
if (mapping.getSource().equals(applicationName)) {
|
|
||||||
return getPlacementContext(mapping, queueManager);
|
|
||||||
}
|
|
||||||
}
|
|
||||||
return null;
|
|
||||||
}
|
|
||||||
|
|
||||||
@Override
|
|
||||||
public ApplicationPlacementContext getPlacementForApp(
|
|
||||||
ApplicationSubmissionContext asc, String user) throws YarnException {
|
|
||||||
String queueName = asc.getQueue();
|
|
||||||
String applicationName = asc.getApplicationName();
|
|
||||||
if (mappings != null && mappings.size() > 0) {
|
|
||||||
try {
|
|
||||||
ApplicationPlacementContext mappedQueue = getAppPlacementContext(user,
|
|
||||||
applicationName);
|
|
||||||
if (mappedQueue != null) {
|
|
||||||
// We have a mapping, should we use it?
|
|
||||||
if (queueName.equals(YarnConfiguration.DEFAULT_QUEUE_NAME)
|
|
||||||
//queueName will be same as mapped queue name in case of recovery
|
|
||||||
|| queueName.equals(mappedQueue.getQueue())
|
|
||||||
|| overrideWithQueueMappings) {
|
|
||||||
LOG.info("Application {} mapping [{}] to [{}] override {}",
|
|
||||||
applicationName, queueName, mappedQueue.getQueue(),
|
|
||||||
overrideWithQueueMappings);
|
|
||||||
return mappedQueue;
|
|
||||||
}
|
|
||||||
}
|
|
||||||
} catch (IOException ioex) {
|
|
||||||
String message = "Failed to submit application " + applicationName +
|
|
||||||
" reason: " + ioex.getMessage();
|
|
||||||
throw new YarnException(message);
|
|
||||||
}
|
|
||||||
}
|
|
||||||
return null;
|
|
||||||
}
|
|
||||||
}
|
|
|
@ -125,7 +125,11 @@ public class CSMappingPlacementRule extends PlacementRule {
|
||||||
overrideWithQueueMappings = conf.getOverrideWithQueueMappings();
|
overrideWithQueueMappings = conf.getOverrideWithQueueMappings();
|
||||||
|
|
||||||
if (groups == null) {
|
if (groups == null) {
|
||||||
groups = Groups.getUserToGroupsMappingService(conf);
|
//We cannot use Groups#getUserToGroupsMappingService here, because when
|
||||||
|
//tests change the HADOOP_SECURITY_GROUP_MAPPING, Groups won't refresh its
|
||||||
|
//cached instance of groups, so we might get a Group instance which
|
||||||
|
//ignores the HADOOP_SECURITY_GROUP_MAPPING settings.
|
||||||
|
groups = new Groups(conf);
|
||||||
}
|
}
|
||||||
|
|
||||||
MappingRuleValidationContext validationContext = buildValidationContext();
|
MappingRuleValidationContext validationContext = buildValidationContext();
|
||||||
|
@ -145,8 +149,8 @@ public class CSMappingPlacementRule extends PlacementRule {
|
||||||
}
|
}
|
||||||
|
|
||||||
LOG.info("Initialized queue mappings, can override user specified " +
|
LOG.info("Initialized queue mappings, can override user specified " +
|
||||||
"queues: {} number of rules: {}", overrideWithQueueMappings,
|
"queues: {} number of rules: {} mapping rules: {}",
|
||||||
mappingRules.size());
|
overrideWithQueueMappings, mappingRules.size(), mappingRules);
|
||||||
|
|
||||||
if (LOG.isDebugEnabled()) {
|
if (LOG.isDebugEnabled()) {
|
||||||
LOG.debug("Initialized with the following mapping rules:");
|
LOG.debug("Initialized with the following mapping rules:");
|
||||||
|
@ -170,6 +174,12 @@ public class CSMappingPlacementRule extends PlacementRule {
|
||||||
*/
|
*/
|
||||||
private void setupGroupsForVariableContext(VariableContext vctx, String user)
|
private void setupGroupsForVariableContext(VariableContext vctx, String user)
|
||||||
throws IOException {
|
throws IOException {
|
||||||
|
if (groups == null) {
|
||||||
|
LOG.warn(
|
||||||
|
"Group provider hasn't been set, cannot query groups for user {}",
|
||||||
|
user);
|
||||||
|
return;
|
||||||
|
}
|
||||||
Set<String> groupsSet = groups.getGroupsSet(user);
|
Set<String> groupsSet = groups.getGroupsSet(user);
|
||||||
String secondaryGroup = null;
|
String secondaryGroup = null;
|
||||||
Iterator<String> it = groupsSet.iterator();
|
Iterator<String> it = groupsSet.iterator();
|
||||||
|
@ -193,14 +203,18 @@ public class CSMappingPlacementRule extends PlacementRule {
|
||||||
}
|
}
|
||||||
|
|
||||||
private VariableContext createVariableContext(
|
private VariableContext createVariableContext(
|
||||||
ApplicationSubmissionContext asc, String user) throws IOException {
|
ApplicationSubmissionContext asc, String user) {
|
||||||
VariableContext vctx = new VariableContext();
|
VariableContext vctx = new VariableContext();
|
||||||
|
|
||||||
vctx.put("%user", user);
|
vctx.put("%user", user);
|
||||||
vctx.put("%specified", asc.getQueue());
|
vctx.put("%specified", asc.getQueue());
|
||||||
vctx.put("%application", asc.getApplicationName());
|
vctx.put("%application", asc.getApplicationName());
|
||||||
vctx.put("%default", "root.default");
|
vctx.put("%default", "root.default");
|
||||||
|
try {
|
||||||
setupGroupsForVariableContext(vctx, user);
|
setupGroupsForVariableContext(vctx, user);
|
||||||
|
} catch (IOException e) {
|
||||||
|
LOG.warn("Unable to setup groups: {}", e.getMessage());
|
||||||
|
}
|
||||||
|
|
||||||
vctx.setImmutables(immutableVariables);
|
vctx.setImmutables(immutableVariables);
|
||||||
return vctx;
|
return vctx;
|
||||||
|
@ -338,34 +352,43 @@ public class CSMappingPlacementRule extends PlacementRule {
|
||||||
@Override
|
@Override
|
||||||
public ApplicationPlacementContext getPlacementForApp(
|
public ApplicationPlacementContext getPlacementForApp(
|
||||||
ApplicationSubmissionContext asc, String user) throws YarnException {
|
ApplicationSubmissionContext asc, String user) throws YarnException {
|
||||||
|
return getPlacementForApp(asc, user, false);
|
||||||
|
}
|
||||||
|
|
||||||
|
@Override
|
||||||
|
public ApplicationPlacementContext getPlacementForApp(
|
||||||
|
ApplicationSubmissionContext asc, String user, boolean recovery)
|
||||||
|
throws YarnException {
|
||||||
//We only use the mapping rules if overrideWithQueueMappings enabled
|
//We only use the mapping rules if overrideWithQueueMappings enabled
|
||||||
//or the application is submitted to the default queue, which effectively
|
//or the application is submitted to the default queue, which effectively
|
||||||
//means the application doesn't have any specific queue.
|
//means the application doesn't have any specific queue.
|
||||||
String appQueue = asc.getQueue();
|
String appQueue = asc.getQueue();
|
||||||
|
LOG.debug("Looking placement for app '{}' originally submitted to queue " +
|
||||||
|
"'{}', with override enabled '{}'",
|
||||||
|
asc.getApplicationName(), appQueue, overrideWithQueueMappings);
|
||||||
if (appQueue != null &&
|
if (appQueue != null &&
|
||||||
!appQueue.equals(YarnConfiguration.DEFAULT_QUEUE_NAME) &&
|
!appQueue.equals(YarnConfiguration.DEFAULT_QUEUE_NAME) &&
|
||||||
!appQueue.equals(YarnConfiguration.DEFAULT_QUEUE_FULL_NAME) &&
|
!appQueue.equals(YarnConfiguration.DEFAULT_QUEUE_FULL_NAME) &&
|
||||||
!overrideWithQueueMappings) {
|
!overrideWithQueueMappings &&
|
||||||
|
!recovery) {
|
||||||
LOG.info("Have no jurisdiction over application submission '{}', " +
|
LOG.info("Have no jurisdiction over application submission '{}', " +
|
||||||
"moving to next PlacementRule engine", asc.getApplicationName());
|
"moving to next PlacementRule engine", asc.getApplicationName());
|
||||||
return null;
|
return null;
|
||||||
}
|
}
|
||||||
|
|
||||||
VariableContext variables;
|
VariableContext variables;
|
||||||
try {
|
|
||||||
variables = createVariableContext(asc, user);
|
variables = createVariableContext(asc, user);
|
||||||
} catch (IOException e) {
|
|
||||||
LOG.error("Unable to setup variable context", e);
|
|
||||||
throw new YarnException(e);
|
|
||||||
}
|
|
||||||
|
|
||||||
|
ApplicationPlacementContext ret = null;
|
||||||
for (MappingRule rule : mappingRules) {
|
for (MappingRule rule : mappingRules) {
|
||||||
MappingRuleResult result = evaluateRule(rule, variables);
|
MappingRuleResult result = evaluateRule(rule, variables);
|
||||||
switch (result.getResult()) {
|
switch (result.getResult()) {
|
||||||
case PLACE_TO_DEFAULT:
|
case PLACE_TO_DEFAULT:
|
||||||
return placeToDefault(asc, variables, rule);
|
ret = placeToDefault(asc, variables, rule);
|
||||||
|
break;
|
||||||
case PLACE:
|
case PLACE:
|
||||||
return placeToQueue(asc, rule, result);
|
ret = placeToQueue(asc, rule, result);
|
||||||
|
break;
|
||||||
case REJECT:
|
case REJECT:
|
||||||
LOG.info("Rejecting application '{}', reason: Mapping rule '{}' " +
|
LOG.info("Rejecting application '{}', reason: Mapping rule '{}' " +
|
||||||
" fallback action is set to REJECT.",
|
" fallback action is set to REJECT.",
|
||||||
|
@ -381,14 +404,39 @@ public class CSMappingPlacementRule extends PlacementRule {
|
||||||
default:
|
default:
|
||||||
LOG.error("Invalid result '{}'", result);
|
LOG.error("Invalid result '{}'", result);
|
||||||
}
|
}
|
||||||
|
|
||||||
|
//If we already have a return value, we can return it!
|
||||||
|
if (ret != null) {
|
||||||
|
break;
|
||||||
|
}
|
||||||
}
|
}
|
||||||
|
|
||||||
|
if (ret == null) {
|
||||||
//If no rule was applied we return null, to let the engine move onto the
|
//If no rule was applied we return null, to let the engine move onto the
|
||||||
//next placementRule class
|
//next placementRule class
|
||||||
LOG.info("No matching rule found for application '{}', moving to next " +
|
LOG.info("No matching rule found for application '{}', moving to next " +
|
||||||
"PlacementRule engine", asc.getApplicationName());
|
"PlacementRule engine", asc.getApplicationName());
|
||||||
|
}
|
||||||
|
|
||||||
|
if (recovery) {
|
||||||
|
//we need this part for backwards compatibility with recovery
|
||||||
|
//the legacy code checked if the placement matches the queue of the
|
||||||
|
//application to be recovered, and if it did, it created an
|
||||||
|
//ApplicationPlacementContext.
|
||||||
|
//However at a later point this is going to be changed, there are two
|
||||||
|
//major issues with this approach:
|
||||||
|
// 1) The recovery only uses LEAF queue names, which must be updated
|
||||||
|
// 2) The ORIGINAL queue which the application was submitted is NOT
|
||||||
|
// stored this might result in different placement evaluation since
|
||||||
|
// now we can have rules which give different result based on what
|
||||||
|
// the user submitted.
|
||||||
|
if (ret == null || !ret.getQueue().equals(asc.getQueue())) {
|
||||||
return null;
|
return null;
|
||||||
}
|
}
|
||||||
|
}
|
||||||
|
|
||||||
|
return ret;
|
||||||
|
}
|
||||||
|
|
||||||
private ApplicationPlacementContext placeToQueue(
|
private ApplicationPlacementContext placeToQueue(
|
||||||
ApplicationSubmissionContext asc,
|
ApplicationSubmissionContext asc,
|
||||||
|
@ -416,7 +464,7 @@ public class CSMappingPlacementRule extends PlacementRule {
|
||||||
} catch (YarnException e) {
|
} catch (YarnException e) {
|
||||||
LOG.error("Rejecting application due to a failed fallback" +
|
LOG.error("Rejecting application due to a failed fallback" +
|
||||||
" action '{}'" + ", reason: {}", asc.getApplicationName(),
|
" action '{}'" + ", reason: {}", asc.getApplicationName(),
|
||||||
e.getMessage());
|
e);
|
||||||
//We intentionally omit the details, we don't want any server side
|
//We intentionally omit the details, we don't want any server side
|
||||||
//config information to leak to the client side
|
//config information to leak to the client side
|
||||||
throw new YarnException("Application submission have been rejected by a" +
|
throw new YarnException("Application submission have been rejected by a" +
|
||||||
|
|
|
@ -154,6 +154,7 @@ public class MappingRuleValidationContextImpl
|
||||||
}
|
}
|
||||||
|
|
||||||
if (!(parentQueue instanceof ManagedParentQueue)) {
|
if (!(parentQueue instanceof ManagedParentQueue)) {
|
||||||
|
if (parentQueue.getChildQueues() != null) {
|
||||||
for (CSQueue queue : parentQueue.getChildQueues()) {
|
for (CSQueue queue : parentQueue.getChildQueues()) {
|
||||||
if (queue instanceof LeafQueue) {
|
if (queue instanceof LeafQueue) {
|
||||||
//if a non managed parent queue has at least one leaf queue, this
|
//if a non managed parent queue has at least one leaf queue, this
|
||||||
|
@ -161,13 +162,14 @@ public class MappingRuleValidationContextImpl
|
||||||
return true;
|
return true;
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
}
|
||||||
|
|
||||||
//There is no way we can place anything into the queue referenced by the
|
//There is no way we can place anything into the queue referenced by the
|
||||||
// rule, because we cannot auto create, and we don't have any leaf queues
|
// rule, because we cannot auto create, and we don't have any leaf queues
|
||||||
//Actually this branch is not accessibe with the current queue hierarchy,
|
//Actually this branch is not accessible with the current queue hierarchy,
|
||||||
//there should be no parents without any leaf queues. This condition says
|
//there should be no parents without any leaf queues. This condition says
|
||||||
//for sanity checks
|
//for sanity checks
|
||||||
throw new YarnException("Target queue path '" + path + "' has" +
|
throw new YarnException("Target queue path '" + path + "' has " +
|
||||||
"a non-managed parent queue which has no LeafQueues either.");
|
"a non-managed parent queue which has no LeafQueues either.");
|
||||||
}
|
}
|
||||||
|
|
||||||
|
|
|
@ -54,7 +54,8 @@ public class PlacementManager {
|
||||||
}
|
}
|
||||||
|
|
||||||
public ApplicationPlacementContext placeApplication(
|
public ApplicationPlacementContext placeApplication(
|
||||||
ApplicationSubmissionContext asc, String user) throws YarnException {
|
ApplicationSubmissionContext asc, String user, boolean recovery)
|
||||||
|
throws YarnException {
|
||||||
readLock.lock();
|
readLock.lock();
|
||||||
try {
|
try {
|
||||||
if (null == rules || rules.isEmpty()) {
|
if (null == rules || rules.isEmpty()) {
|
||||||
|
@ -63,7 +64,7 @@ public class PlacementManager {
|
||||||
|
|
||||||
ApplicationPlacementContext placement = null;
|
ApplicationPlacementContext placement = null;
|
||||||
for (PlacementRule rule : rules) {
|
for (PlacementRule rule : rules) {
|
||||||
placement = rule.getPlacementForApp(asc, user);
|
placement = rule.getPlacementForApp(asc, user, recovery);
|
||||||
if (placement != null) {
|
if (placement != null) {
|
||||||
break;
|
break;
|
||||||
}
|
}
|
||||||
|
@ -75,6 +76,11 @@ public class PlacementManager {
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
|
||||||
|
public ApplicationPlacementContext placeApplication(
|
||||||
|
ApplicationSubmissionContext asc, String user) throws YarnException {
|
||||||
|
return placeApplication(asc, user, false);
|
||||||
|
}
|
||||||
|
|
||||||
@VisibleForTesting
|
@VisibleForTesting
|
||||||
public List<PlacementRule> getPlacementRules() {
|
public List<PlacementRule> getPlacementRules() {
|
||||||
return rules;
|
return rules;
|
||||||
|
|
|
@ -79,4 +79,29 @@ public abstract class PlacementRule {
|
||||||
*/
|
*/
|
||||||
public abstract ApplicationPlacementContext getPlacementForApp(
|
public abstract ApplicationPlacementContext getPlacementForApp(
|
||||||
ApplicationSubmissionContext asc, String user) throws YarnException;
|
ApplicationSubmissionContext asc, String user) throws YarnException;
|
||||||
|
|
||||||
|
|
||||||
|
/**
|
||||||
|
* Return the scheduler queue name the application should be placed in
|
||||||
|
* wrapped in an {@link ApplicationPlacementContext} object.
|
||||||
|
*
|
||||||
|
* A non <code>null</code> return value places the application in a queue,
|
||||||
|
* a <code>null</code> value means the queue is not yet determined. The
|
||||||
|
* next {@link PlacementRule} in the list maintained in the
|
||||||
|
* {@link PlacementManager} will be executed.
|
||||||
|
*
|
||||||
|
* @param asc The context of the application created on submission
|
||||||
|
* @param user The name of the user submitting the application
|
||||||
|
* @param recovery Indicates if the submission is a recovery
|
||||||
|
*
|
||||||
|
* @throws YarnException for any error while executing the rule
|
||||||
|
*
|
||||||
|
* @return The queue name wrapped in {@link ApplicationPlacementContext} or
|
||||||
|
* <code>null</code> if no queue was resolved
|
||||||
|
*/
|
||||||
|
public ApplicationPlacementContext getPlacementForApp(
|
||||||
|
ApplicationSubmissionContext asc, String user, boolean recovery)
|
||||||
|
throws YarnException {
|
||||||
|
return getPlacementForApp(asc, user);
|
||||||
|
}
|
||||||
}
|
}
|
|
@ -1,558 +0,0 @@
|
||||||
/**
|
|
||||||
* Licensed to the Apache Software Foundation (ASF) under one
|
|
||||||
* or more contributor license agreements. See the NOTICE file
|
|
||||||
* distributed with this work for additional information
|
|
||||||
* regarding copyright ownership. The ASF licenses this file
|
|
||||||
* to you under the Apache License, Version 2.0 (the
|
|
||||||
* "License"); you may not use this file except in compliance
|
|
||||||
* with the License. You may obtain a copy of the License at
|
|
||||||
*
|
|
||||||
* http://www.apache.org/licenses/LICENSE-2.0
|
|
||||||
*
|
|
||||||
* Unless required by applicable law or agreed to in writing, software
|
|
||||||
* distributed under the License is distributed on an "AS IS" BASIS,
|
|
||||||
* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
|
|
||||||
* See the License for the specific language governing permissions and
|
|
||||||
* limitations under the License.
|
|
||||||
*/
|
|
||||||
|
|
||||||
package org.apache.hadoop.yarn.server.resourcemanager.placement;
|
|
||||||
|
|
||||||
import java.io.IOException;
|
|
||||||
import java.util.ArrayList;
|
|
||||||
import java.util.Iterator;
|
|
||||||
import java.util.List;
|
|
||||||
import java.util.Set;
|
|
||||||
|
|
||||||
import org.apache.commons.lang3.StringUtils;
|
|
||||||
import org.apache.hadoop.classification.InterfaceAudience.Private;
|
|
||||||
import org.apache.hadoop.security.Groups;
|
|
||||||
import org.apache.hadoop.yarn.api.records.ApplicationId;
|
|
||||||
import org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext;
|
|
||||||
import org.apache.hadoop.yarn.conf.YarnConfiguration;
|
|
||||||
import org.apache.hadoop.yarn.exceptions.YarnException;
|
|
||||||
import org.apache.hadoop.yarn.server.resourcemanager.placement.QueueMapping.MappingType;
|
|
||||||
import org.apache.hadoop.yarn.server.resourcemanager.placement.QueueMapping.QueueMappingBuilder;
|
|
||||||
import org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceScheduler;
|
|
||||||
import org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AutoCreatedLeafQueue;
|
|
||||||
import org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue;
|
|
||||||
import org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler;
|
|
||||||
import org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration;
|
|
||||||
import org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerContext;
|
|
||||||
import org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerQueueManager;
|
|
||||||
import org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue;
|
|
||||||
import org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ManagedParentQueue;
|
|
||||||
import org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ParentQueue;
|
|
||||||
import org.slf4j.Logger;
|
|
||||||
import org.slf4j.LoggerFactory;
|
|
||||||
|
|
||||||
import org.apache.hadoop.thirdparty.com.google.common.annotations.VisibleForTesting;
|
|
||||||
|
|
||||||
public class UserGroupMappingPlacementRule extends PlacementRule {
|
|
||||||
private static final Logger LOG = LoggerFactory
|
|
||||||
.getLogger(UserGroupMappingPlacementRule.class);
|
|
||||||
|
|
||||||
public static final String CURRENT_USER_MAPPING = "%user";
|
|
||||||
|
|
||||||
public static final String PRIMARY_GROUP_MAPPING = "%primary_group";
|
|
||||||
|
|
||||||
public static final String SECONDARY_GROUP_MAPPING = "%secondary_group";
|
|
||||||
|
|
||||||
private boolean overrideWithQueueMappings = false;
|
|
||||||
private List<QueueMapping> mappings = null;
|
|
||||||
private Groups groups;
|
|
||||||
private CapacitySchedulerQueueManager queueManager;
|
|
||||||
|
|
||||||
public UserGroupMappingPlacementRule(){
|
|
||||||
this(false, null, null);
|
|
||||||
}
|
|
||||||
|
|
||||||
@VisibleForTesting
|
|
||||||
UserGroupMappingPlacementRule(boolean overrideWithQueueMappings,
|
|
||||||
List<QueueMapping> newMappings, Groups groups) {
|
|
||||||
this.mappings = newMappings;
|
|
||||||
this.overrideWithQueueMappings = overrideWithQueueMappings;
|
|
||||||
this.groups = groups;
|
|
||||||
}
|
|
||||||
|
|
||||||
private String getPrimaryGroup(String user) throws IOException {
|
|
||||||
return groups.getGroupsSet(user).iterator().next();
|
|
||||||
}
|
|
||||||
|
|
||||||
private String getSecondaryGroup(String user) throws IOException {
|
|
||||||
Set<String> groupsSet = groups.getGroupsSet(user);
|
|
||||||
String secondaryGroup = null;
|
|
||||||
// Traverse all secondary groups (as there could be more than one
|
|
||||||
// and position is not guaranteed) and ensure there is queue with
|
|
||||||
// the same name
|
|
||||||
Iterator<String> it = groupsSet.iterator();
|
|
||||||
it.next();
|
|
||||||
while (it.hasNext()) {
|
|
||||||
String group = it.next();
|
|
||||||
if (this.queueManager.getQueue(group) != null) {
|
|
||||||
secondaryGroup = group;
|
|
||||||
break;
|
|
||||||
}
|
|
||||||
}
|
|
||||||
|
|
||||||
if (secondaryGroup == null && LOG.isDebugEnabled()) {
|
|
||||||
LOG.debug("User {} is not associated with any Secondary "
|
|
||||||
+ "Group. Hence it may use the 'default' queue", user);
|
|
||||||
}
|
|
||||||
return secondaryGroup;
|
|
||||||
}
|
|
||||||
|
|
||||||
private ApplicationPlacementContext getPlacementForUser(String user)
|
|
||||||
throws IOException {
|
|
||||||
for (QueueMapping mapping : mappings) {
|
|
||||||
if (mapping.getType().equals(MappingType.USER)) {
|
|
||||||
if (mapping.getSource().equals(CURRENT_USER_MAPPING)) {
|
|
||||||
if (mapping.getParentQueue() != null
|
|
||||||
&& mapping.getParentQueue().equals(PRIMARY_GROUP_MAPPING)
|
|
||||||
&& mapping.getQueue().equals(CURRENT_USER_MAPPING)) {
|
|
||||||
if (LOG.isDebugEnabled()) {
|
|
||||||
LOG.debug("Creating placement context for user {} using " +
|
|
||||||
"primary group current user mapping", user);
|
|
||||||
}
|
|
||||||
return getContextForGroupParent(user, mapping,
|
|
||||||
getPrimaryGroup(user));
|
|
||||||
} else if (mapping.getParentQueue() != null
|
|
||||||
&& mapping.getParentQueue().equals(SECONDARY_GROUP_MAPPING)
|
|
||||||
&& mapping.getQueue().equals(CURRENT_USER_MAPPING)) {
|
|
||||||
if (LOG.isDebugEnabled()) {
|
|
||||||
LOG.debug("Creating placement context for user {} using " +
|
|
||||||
"secondary group current user mapping", user);
|
|
||||||
}
|
|
||||||
return getContextForGroupParent(user, mapping,
|
|
||||||
getSecondaryGroup(user));
|
|
||||||
} else if (mapping.getQueue().equals(CURRENT_USER_MAPPING)) {
|
|
||||||
if (LOG.isDebugEnabled()) {
|
|
||||||
LOG.debug("Creating placement context for user {} using " +
|
|
||||||
"current user mapping", user);
|
|
||||||
}
|
|
||||||
return getPlacementContext(mapping, user);
|
|
||||||
} else if (mapping.getQueue().equals(PRIMARY_GROUP_MAPPING)) {
|
|
||||||
if (LOG.isDebugEnabled()) {
|
|
||||||
LOG.debug("Creating placement context for user {} using " +
|
|
||||||
"primary group mapping", user);
|
|
||||||
}
|
|
||||||
return getPlacementContext(mapping, getPrimaryGroup(user));
|
|
||||||
} else if (mapping.getQueue().equals(SECONDARY_GROUP_MAPPING)) {
|
|
||||||
if (LOG.isDebugEnabled()) {
|
|
||||||
LOG.debug("Creating placement context for user {} using " +
|
|
||||||
"secondary group mapping", user);
|
|
||||||
}
|
|
||||||
return getPlacementContext(mapping, getSecondaryGroup(user));
|
|
||||||
} else {
|
|
||||||
if (LOG.isDebugEnabled()) {
|
|
||||||
LOG.debug("Creating placement context for user {} using " +
|
|
||||||
"current user static mapping", user);
|
|
||||||
}
|
|
||||||
return getPlacementContext(mapping);
|
|
||||||
}
|
|
||||||
}
|
|
||||||
|
|
||||||
if (user.equals(mapping.getSource())) {
|
|
||||||
if (mapping.getQueue().equals(PRIMARY_GROUP_MAPPING)) {
|
|
||||||
if (LOG.isDebugEnabled()) {
|
|
||||||
LOG.debug("Creating placement context for user {} using " +
|
|
||||||
"static user primary group mapping", user);
|
|
||||||
}
|
|
||||||
return getPlacementContext(mapping, getPrimaryGroup(user));
|
|
||||||
} else if (mapping.getQueue().equals(SECONDARY_GROUP_MAPPING)) {
|
|
||||||
String secondaryGroup = getSecondaryGroup(user);
|
|
||||||
if (secondaryGroup != null) {
|
|
||||||
if (LOG.isDebugEnabled()) {
|
|
||||||
LOG.debug("Creating placement context for user {} using " +
|
|
||||||
"static user secondary group mapping", user);
|
|
||||||
}
|
|
||||||
return getPlacementContext(mapping, secondaryGroup);
|
|
||||||
} else {
|
|
||||||
if (LOG.isDebugEnabled()) {
|
|
||||||
LOG.debug("Wanted to create placement context for user {}" +
|
|
||||||
" using static user secondary group mapping," +
|
|
||||||
" but user has no secondary group!", user);
|
|
||||||
}
|
|
||||||
return null;
|
|
||||||
}
|
|
||||||
} else {
|
|
||||||
if (LOG.isDebugEnabled()) {
|
|
||||||
LOG.debug("Creating placement context for user {} using " +
|
|
||||||
"current user static mapping", user);
|
|
||||||
}
|
|
||||||
return getPlacementContext(mapping);
|
|
||||||
}
|
|
||||||
}
|
|
||||||
}
|
|
||||||
if (mapping.getType().equals(MappingType.GROUP)) {
|
|
||||||
for (String userGroups : groups.getGroupsSet(user)) {
|
|
||||||
if (userGroups.equals(mapping.getSource())) {
|
|
||||||
if (mapping.getQueue().equals(CURRENT_USER_MAPPING)) {
|
|
||||||
if (LOG.isDebugEnabled()) {
|
|
||||||
LOG.debug("Creating placement context for user {} using " +
|
|
||||||
"static group current user mapping", user);
|
|
||||||
}
|
|
||||||
return getPlacementContext(mapping, user);
|
|
||||||
}
|
|
||||||
if (LOG.isDebugEnabled()) {
|
|
||||||
LOG.debug("Creating placement context for user {} using " +
|
|
||||||
"static group static mapping", user);
|
|
||||||
}
|
|
||||||
return getPlacementContext(mapping);
|
|
||||||
}
|
|
||||||
}
|
|
||||||
}
|
|
||||||
}
|
|
||||||
return null;
|
|
||||||
}
|
|
||||||
|
|
||||||
/**
|
|
||||||
* This convenience method allows to change the parent path or a leafName in
|
|
||||||
* a mapping object, by creating a new one, using the builder and copying the
|
|
||||||
* rest of the parameters.
|
|
||||||
* @param mapping The mapping to be changed
|
|
||||||
* @param parentPath The new parentPath of the mapping
|
|
||||||
* @param leafName The new leafQueueName of the mapping
|
|
||||||
* @return The updated NEW mapping
|
|
||||||
*/
|
|
||||||
private QueueMapping alterMapping(
|
|
||||||
QueueMapping mapping, String parentPath, String leafName) {
|
|
||||||
return QueueMappingBuilder.create()
|
|
||||||
.type(mapping.getType())
|
|
||||||
.source(mapping.getSource())
|
|
||||||
.queue(leafName)
|
|
||||||
.parentQueue(parentPath)
|
|
||||||
.build();
|
|
||||||
}
|
|
||||||
|
|
||||||
// invoked for mappings:
|
|
||||||
// u:%user:%primary_group.%user
|
|
||||||
// u:%user:%secondary_group.%user
|
|
||||||
private ApplicationPlacementContext getContextForGroupParent(
|
|
||||||
String user,
|
|
||||||
QueueMapping mapping,
|
|
||||||
String group) throws IOException {
|
|
||||||
|
|
||||||
CSQueue groupQueue = this.queueManager.getQueue(group);
|
|
||||||
if (groupQueue != null) {
|
|
||||||
// replace the group string
|
|
||||||
QueueMapping resolvedGroupMapping = alterMapping(
|
|
||||||
mapping,
|
|
||||||
groupQueue.getQueuePath(),
|
|
||||||
user);
|
|
||||||
validateQueueMapping(resolvedGroupMapping);
|
|
||||||
return getPlacementContext(resolvedGroupMapping, user);
|
|
||||||
} else {
|
|
||||||
if (queueManager.isAmbiguous(group)) {
|
|
||||||
LOG.info("Queue mapping rule expect group queue to exist with name {}" +
|
|
||||||
" but the reference is ambiguous!", group);
|
|
||||||
} else {
|
|
||||||
LOG.info("Queue mapping rule expect group queue to exist with name {}" +
|
|
||||||
" but it does not exist!", group);
|
|
||||||
}
|
|
||||||
return null;
|
|
||||||
}
|
|
||||||
}
|
|
||||||
|
|
||||||
@Override
|
|
||||||
public ApplicationPlacementContext getPlacementForApp(
|
|
||||||
ApplicationSubmissionContext asc, String user)
|
|
||||||
throws YarnException {
|
|
||||||
String queueName = asc.getQueue();
|
|
||||||
ApplicationId applicationId = asc.getApplicationId();
|
|
||||||
if (mappings != null && mappings.size() > 0) {
|
|
||||||
try {
|
|
||||||
ApplicationPlacementContext mappedQueue = getPlacementForUser(user);
|
|
||||||
if (mappedQueue != null) {
|
|
||||||
// We have a mapping, should we use it?
|
|
||||||
if (queueName.equals(YarnConfiguration.DEFAULT_QUEUE_NAME)
|
|
||||||
//queueName will be same as mapped queue name in case of recovery
|
|
||||||
|| queueName.equals(mappedQueue.getQueue())
|
|
||||||
|| overrideWithQueueMappings) {
|
|
||||||
LOG.info("Application {} user {} mapping [{}] to [{}] override {}",
|
|
||||||
applicationId, user, queueName, mappedQueue.getQueue(),
|
|
||||||
overrideWithQueueMappings);
|
|
||||||
return mappedQueue;
|
|
||||||
}
|
|
||||||
}
|
|
||||||
} catch (IOException ioex) {
|
|
||||||
String message = "Failed to submit application " + applicationId +
|
|
||||||
" submitted by user " + user + " reason: " + ioex.getMessage();
|
|
||||||
throw new YarnException(message, ioex);
|
|
||||||
}
|
|
||||||
}
|
|
||||||
return null;
|
|
||||||
}
|
|
||||||
|
|
||||||
private ApplicationPlacementContext getPlacementContext(
|
|
||||||
QueueMapping mapping) throws IOException {
|
|
||||||
return getPlacementContext(mapping, mapping.getQueue());
|
|
||||||
}
|
|
||||||
|
|
||||||
private ApplicationPlacementContext getPlacementContext(QueueMapping mapping,
|
|
||||||
String leafQueueName) throws IOException {
|
|
||||||
//leafQueue name no longer identifies a queue uniquely checking ambiguity
|
|
||||||
if (!mapping.hasParentQueue() && queueManager.isAmbiguous(leafQueueName)) {
|
|
||||||
throw new IOException("mapping contains ambiguous leaf queue reference " +
|
|
||||||
leafQueueName);
|
|
||||||
}
|
|
||||||
|
|
||||||
if (!StringUtils.isEmpty(mapping.getParentQueue())) {
|
|
||||||
return getPlacementContextWithParent(mapping, leafQueueName);
|
|
||||||
} else {
|
|
||||||
return getPlacementContextNoParent(leafQueueName);
|
|
||||||
}
|
|
||||||
}
|
|
||||||
|
|
||||||
private ApplicationPlacementContext getPlacementContextWithParent(
|
|
||||||
QueueMapping mapping,
|
|
||||||
String leafQueueName) {
|
|
||||||
CSQueue parent = queueManager.getQueue(mapping.getParentQueue());
|
|
||||||
//we don't find the specified parent, so the placement rule is invalid
|
|
||||||
//for this case
|
|
||||||
if (parent == null) {
|
|
||||||
if (queueManager.isAmbiguous(mapping.getParentQueue())) {
|
|
||||||
LOG.warn("Placement rule specified a parent queue {}, but it is" +
|
|
||||||
"ambiguous.", mapping.getParentQueue());
|
|
||||||
} else {
|
|
||||||
LOG.warn("Placement rule specified a parent queue {}, but it does" +
|
|
||||||
"not exist.", mapping.getParentQueue());
|
|
||||||
}
|
|
||||||
return null;
|
|
||||||
}
|
|
||||||
|
|
||||||
String parentPath = parent.getQueuePath();
|
|
||||||
|
|
||||||
//if we have a parent which is not a managed parent, we check if the leaf
|
|
||||||
//queue exists under this parent
|
|
||||||
if (!(parent instanceof ManagedParentQueue)) {
|
|
||||||
CSQueue queue = queueManager.getQueue(parentPath + "." + leafQueueName);
|
|
||||||
//if the queue doesn't exit we return null
|
|
||||||
if (queue == null) {
|
|
||||||
LOG.warn("Placement rule specified a parent queue {}, but it is" +
|
|
||||||
" not a managed parent queue, and no queue exists with name {} " +
|
|
||||||
"under it.", mapping.getParentQueue(), leafQueueName);
|
|
||||||
return null;
|
|
||||||
}
|
|
||||||
}
|
|
||||||
//at this point we either have a managed parent or the queue actually
|
|
||||||
//exists so we have a placement context, returning it
|
|
||||||
return new ApplicationPlacementContext(leafQueueName, parentPath);
|
|
||||||
}
|
|
||||||
|
|
||||||
private ApplicationPlacementContext getPlacementContextNoParent(
|
|
||||||
String leafQueueName) {
|
|
||||||
//in this case we don't have a parent specified so we expect the queue to
|
|
||||||
//exist, otherwise the mapping will not be valid for this case
|
|
||||||
CSQueue queue = queueManager.getQueue(leafQueueName);
|
|
||||||
if (queue == null) {
|
|
||||||
if (queueManager.isAmbiguous(leafQueueName)) {
|
|
||||||
LOG.warn("Queue {} specified in placement rule is ambiguous",
|
|
||||||
leafQueueName);
|
|
||||||
} else {
|
|
||||||
LOG.warn("Queue {} specified in placement rule does not exist",
|
|
||||||
leafQueueName);
|
|
||||||
}
|
|
||||||
return null;
|
|
||||||
}
|
|
||||||
|
|
||||||
//getting parent path to make sure if the leaf name would become ambiguous
|
|
||||||
//the placement context stays valid.
|
|
||||||
CSQueue parent = queueManager.getQueue(leafQueueName).getParent();
|
|
||||||
return new ApplicationPlacementContext(
|
|
||||||
leafQueueName, parent.getQueuePath());
|
|
||||||
}
|
|
||||||
|
|
||||||
@VisibleForTesting
|
|
||||||
@Override
|
|
||||||
public boolean initialize(ResourceScheduler scheduler)
|
|
||||||
throws IOException {
|
|
||||||
if (!(scheduler instanceof CapacityScheduler)) {
|
|
||||||
throw new IOException(
|
|
||||||
"UserGroupMappingPlacementRule can be configured only for "
|
|
||||||
+ "CapacityScheduler");
|
|
||||||
}
|
|
||||||
CapacitySchedulerContext schedulerContext =
|
|
||||||
(CapacitySchedulerContext) scheduler;
|
|
||||||
CapacitySchedulerConfiguration conf = schedulerContext.getConfiguration();
|
|
||||||
boolean overrideWithQueueMappings = conf.getOverrideWithQueueMappings();
|
|
||||||
LOG.info(
|
|
||||||
"Initialized queue mappings, override: " + overrideWithQueueMappings);
|
|
||||||
|
|
||||||
List<QueueMapping> queueMappings = conf.getQueueMappings();
|
|
||||||
|
|
||||||
// Get new user/group mappings
|
|
||||||
List<QueueMapping> newMappings = new ArrayList<>();
|
|
||||||
|
|
||||||
queueManager = schedulerContext.getCapacitySchedulerQueueManager();
|
|
||||||
|
|
||||||
// check if mappings refer to valid queues
|
|
||||||
for (QueueMapping mapping : queueMappings) {
|
|
||||||
//at this point mapping.getQueueName() return only the queue name, since
|
|
||||||
//the config parsing have been changed making QueueMapping more consistent
|
|
||||||
|
|
||||||
if (isStaticQueueMapping(mapping)) {
|
|
||||||
//Try getting queue by its full path name, if it exists it is a static
|
|
||||||
//leaf queue indeed, without any auto creation magic
|
|
||||||
CSQueue queue = queueManager.getQueue(mapping.getFullPath());
|
|
||||||
if (ifQueueDoesNotExist(queue)) {
|
|
||||||
//We might not be able to find the queue, because the reference was
|
|
||||||
// ambiguous this should only happen if the queue was referenced by
|
|
||||||
// leaf name only
|
|
||||||
if (queueManager.isAmbiguous(mapping.getFullPath())) {
|
|
||||||
throw new IOException(
|
|
||||||
"mapping contains ambiguous leaf queue reference " + mapping
|
|
||||||
.getFullPath());
|
|
||||||
}
|
|
||||||
|
|
||||||
//if leaf queue does not exist,
|
|
||||||
// this could be a potential auto created leaf queue
|
|
||||||
//validate if parent queue is specified,
|
|
||||||
// then it should exist and
|
|
||||||
// be an instance of AutoCreateEnabledParentQueue
|
|
||||||
QueueMapping newMapping = validateAndGetAutoCreatedQueueMapping(
|
|
||||||
queueManager, mapping);
|
|
||||||
if (newMapping == null) {
|
|
||||||
throw new IOException(
|
|
||||||
"mapping contains invalid or non-leaf queue " + mapping
|
|
||||||
.getQueue());
|
|
||||||
}
|
|
||||||
newMappings.add(newMapping);
|
|
||||||
} else {
|
|
||||||
// if queue exists, validate
|
|
||||||
// if its an instance of leaf queue
|
|
||||||
// if its an instance of auto created leaf queue,
|
|
||||||
// then extract parent queue name and update queue mapping
|
|
||||||
QueueMapping newMapping = validateAndGetQueueMapping(queueManager,
|
|
||||||
queue, mapping);
|
|
||||||
newMappings.add(newMapping);
|
|
||||||
}
|
|
||||||
} else{
|
|
||||||
//If it is a dynamic queue mapping,
|
|
||||||
// we can safely assume leaf queue name does not have '.' in it
|
|
||||||
// validate
|
|
||||||
// if parent queue is specified, then
|
|
||||||
// parent queue exists and an instance of AutoCreateEnabledParentQueue
|
|
||||||
//
|
|
||||||
QueueMapping newMapping = validateAndGetAutoCreatedQueueMapping(
|
|
||||||
queueManager, mapping);
|
|
||||||
if (newMapping != null) {
|
|
||||||
newMappings.add(newMapping);
|
|
||||||
} else{
|
|
||||||
newMappings.add(mapping);
|
|
||||||
}
|
|
||||||
}
|
|
||||||
}
|
|
||||||
|
|
||||||
// initialize groups if mappings are present
|
|
||||||
if (newMappings.size() > 0) {
|
|
||||||
this.mappings = newMappings;
|
|
||||||
this.groups = Groups.getUserToGroupsMappingService(
|
|
||||||
((CapacityScheduler)scheduler).getConf());
|
|
||||||
this.overrideWithQueueMappings = overrideWithQueueMappings;
|
|
||||||
return true;
|
|
||||||
}
|
|
||||||
return false;
|
|
||||||
}
|
|
||||||
|
|
||||||
private static QueueMapping validateAndGetQueueMapping(
|
|
||||||
CapacitySchedulerQueueManager queueManager, CSQueue queue,
|
|
||||||
QueueMapping mapping) throws IOException {
|
|
||||||
if (!(queue instanceof LeafQueue)) {
|
|
||||||
throw new IOException(
|
|
||||||
"mapping contains invalid or non-leaf queue : " +
|
|
||||||
mapping.getFullPath());
|
|
||||||
}
|
|
||||||
|
|
||||||
if (queue instanceof AutoCreatedLeafQueue && queue
|
|
||||||
.getParent() instanceof ManagedParentQueue) {
|
|
||||||
|
|
||||||
QueueMapping newMapping = validateAndGetAutoCreatedQueueMapping(
|
|
||||||
queueManager, mapping);
|
|
||||||
if (newMapping == null) {
|
|
||||||
throw new IOException(
|
|
||||||
"mapping contains invalid or non-leaf queue "
|
|
||||||
+ mapping.getFullPath());
|
|
||||||
}
|
|
||||||
return newMapping;
|
|
||||||
}
|
|
||||||
return mapping;
|
|
||||||
}
|
|
||||||
|
|
||||||
private static boolean ifQueueDoesNotExist(CSQueue queue) {
|
|
||||||
return queue == null;
|
|
||||||
}
|
|
||||||
|
|
||||||
private static QueueMapping validateAndGetAutoCreatedQueueMapping(
|
|
||||||
CapacitySchedulerQueueManager queueManager, QueueMapping mapping)
|
|
||||||
throws IOException {
|
|
||||||
if (mapping.hasParentQueue()
|
|
||||||
&& (mapping.getParentQueue().equals(PRIMARY_GROUP_MAPPING)
|
|
||||||
|| mapping.getParentQueue().equals(SECONDARY_GROUP_MAPPING))) {
|
|
||||||
// dynamic parent queue
|
|
||||||
return mapping;
|
|
||||||
} else if (mapping.hasParentQueue()) {
|
|
||||||
//if parent queue is specified,
|
|
||||||
// then it should exist and be an instance of ManagedParentQueue
|
|
||||||
QueuePlacementRuleUtils.validateQueueMappingUnderParentQueue(
|
|
||||||
queueManager.getQueue(mapping.getParentQueue()),
|
|
||||||
mapping.getParentQueue(), mapping.getQueue());
|
|
||||||
return mapping;
|
|
||||||
}
|
|
||||||
|
|
||||||
return null;
|
|
||||||
}
|
|
||||||
|
|
||||||
private static boolean isStaticQueueMapping(QueueMapping mapping) {
|
|
||||||
return !mapping.getQueue()
|
|
||||||
.contains(UserGroupMappingPlacementRule.CURRENT_USER_MAPPING)
|
|
||||||
&& !mapping.getQueue()
|
|
||||||
.contains(UserGroupMappingPlacementRule.PRIMARY_GROUP_MAPPING)
|
|
||||||
&& !mapping.getQueue()
|
|
||||||
.contains(UserGroupMappingPlacementRule.SECONDARY_GROUP_MAPPING);
|
|
||||||
}
|
|
||||||
|
|
||||||
private void validateQueueMapping(QueueMapping queueMapping)
|
|
||||||
throws IOException {
|
|
||||||
String parentQueueName = queueMapping.getParentQueue();
|
|
||||||
String leafQueueFullName = queueMapping.getFullPath();
|
|
||||||
CSQueue parentQueue = queueManager.getQueueByFullName(parentQueueName);
|
|
||||||
CSQueue leafQueue = queueManager.getQueue(leafQueueFullName);
|
|
||||||
|
|
||||||
if (leafQueue == null || (!(leafQueue instanceof LeafQueue))) {
|
|
||||||
//this might be confusing, but a mapping is not guaranteed to provide the
|
|
||||||
//parent queue's name, which can result in ambiguous queue references
|
|
||||||
//if no parent queueName is provided mapping.getFullPath() is the same
|
|
||||||
//as mapping.getQueue()
|
|
||||||
if (leafQueue == null && queueManager.isAmbiguous(leafQueueFullName)) {
|
|
||||||
throw new IOException("mapping contains ambiguous leaf queue name: "
|
|
||||||
+ leafQueueFullName);
|
|
||||||
} else if (parentQueue == null ||
|
|
||||||
(!(parentQueue instanceof ManagedParentQueue))) {
|
|
||||||
throw new IOException("mapping contains invalid or non-leaf queue " +
|
|
||||||
" and no managed parent is found: "
|
|
||||||
+ leafQueueFullName);
|
|
||||||
}
|
|
||||||
} else if (parentQueue == null || (!(parentQueue instanceof ParentQueue))) {
|
|
||||||
throw new IOException(
|
|
||||||
"mapping contains invalid parent queue [" + parentQueueName + "]");
|
|
||||||
} else if (!parentQueue.getQueuePath()
|
|
||||||
.equals(leafQueue.getParent().getQueuePath())) {
|
|
||||||
throw new IOException("mapping contains invalid parent queue "
|
|
||||||
+ "which does not match existing leaf queue's parent : ["
|
|
||||||
+ parentQueue.getQueuePath() + "] does not match [ "
|
|
||||||
+ leafQueue.getParent().getQueuePath() + "]");
|
|
||||||
}
|
|
||||||
}
|
|
||||||
|
|
||||||
@VisibleForTesting
|
|
||||||
public List<QueueMapping> getQueueMappings() {
|
|
||||||
return mappings;
|
|
||||||
}
|
|
||||||
|
|
||||||
@VisibleForTesting
|
|
||||||
@Private
|
|
||||||
public void setQueueManager(CapacitySchedulerQueueManager queueManager) {
|
|
||||||
this.queueManager = queueManager;
|
|
||||||
}
|
|
||||||
}
|
|
|
@ -35,6 +35,10 @@ import java.util.concurrent.LinkedBlockingQueue;
|
||||||
import java.util.concurrent.atomic.AtomicBoolean;
|
import java.util.concurrent.atomic.AtomicBoolean;
|
||||||
|
|
||||||
import org.apache.commons.lang3.StringUtils;
|
import org.apache.commons.lang3.StringUtils;
|
||||||
|
import org.apache.hadoop.yarn.server.resourcemanager.placement.ApplicationPlacementContext;
|
||||||
|
import org.apache.hadoop.yarn.server.resourcemanager.placement.CSMappingPlacementRule;
|
||||||
|
import org.apache.hadoop.yarn.server.resourcemanager.placement.PlacementFactory;
|
||||||
|
import org.apache.hadoop.yarn.server.resourcemanager.placement.PlacementRule;
|
||||||
import org.slf4j.Logger;
|
import org.slf4j.Logger;
|
||||||
import org.slf4j.LoggerFactory;
|
import org.slf4j.LoggerFactory;
|
||||||
import org.slf4j.Marker;
|
import org.slf4j.Marker;
|
||||||
|
@ -71,11 +75,6 @@ import org.apache.hadoop.yarn.exceptions.YarnRuntimeException;
|
||||||
import org.apache.hadoop.yarn.proto.YarnServiceProtos.SchedulerResourceTypes;
|
import org.apache.hadoop.yarn.proto.YarnServiceProtos.SchedulerResourceTypes;
|
||||||
import org.apache.hadoop.yarn.server.resourcemanager.RMContext;
|
import org.apache.hadoop.yarn.server.resourcemanager.RMContext;
|
||||||
import org.apache.hadoop.yarn.server.resourcemanager.nodelabels.RMNodeLabelsManager;
|
import org.apache.hadoop.yarn.server.resourcemanager.nodelabels.RMNodeLabelsManager;
|
||||||
import org.apache.hadoop.yarn.server.resourcemanager.placement.AppNameMappingPlacementRule;
|
|
||||||
import org.apache.hadoop.yarn.server.resourcemanager.placement.ApplicationPlacementContext;
|
|
||||||
import org.apache.hadoop.yarn.server.resourcemanager.placement.PlacementFactory;
|
|
||||||
import org.apache.hadoop.yarn.server.resourcemanager.placement.PlacementRule;
|
|
||||||
import org.apache.hadoop.yarn.server.resourcemanager.placement.UserGroupMappingPlacementRule;
|
|
||||||
import org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore.RMState;
|
import org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore.RMState;
|
||||||
import org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationStateData;
|
import org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationStateData;
|
||||||
|
|
||||||
|
@ -679,24 +678,14 @@ public class CapacityScheduler extends
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
|
||||||
@VisibleForTesting
|
|
||||||
public PlacementRule getUserGroupMappingPlacementRule() throws IOException {
|
|
||||||
readLock.lock();
|
|
||||||
try {
|
|
||||||
UserGroupMappingPlacementRule ugRule = new UserGroupMappingPlacementRule();
|
|
||||||
ugRule.initialize(this);
|
|
||||||
return ugRule;
|
|
||||||
} finally {
|
|
||||||
readLock.unlock();
|
|
||||||
}
|
|
||||||
}
|
|
||||||
|
|
||||||
public PlacementRule getAppNameMappingPlacementRule() throws IOException {
|
@VisibleForTesting
|
||||||
|
public PlacementRule getCSMappingPlacementRule() throws IOException {
|
||||||
readLock.lock();
|
readLock.lock();
|
||||||
try {
|
try {
|
||||||
AppNameMappingPlacementRule anRule = new AppNameMappingPlacementRule();
|
CSMappingPlacementRule mappingRule = new CSMappingPlacementRule();
|
||||||
anRule.initialize(this);
|
mappingRule.initialize(this);
|
||||||
return anRule;
|
return mappingRule;
|
||||||
} finally {
|
} finally {
|
||||||
readLock.unlock();
|
readLock.unlock();
|
||||||
}
|
}
|
||||||
|
@ -718,19 +707,18 @@ public class CapacityScheduler extends
|
||||||
}
|
}
|
||||||
|
|
||||||
placementRuleStrs = new ArrayList<>(distinguishRuleSet);
|
placementRuleStrs = new ArrayList<>(distinguishRuleSet);
|
||||||
|
boolean csMappingAdded = false;
|
||||||
|
|
||||||
for (String placementRuleStr : placementRuleStrs) {
|
for (String placementRuleStr : placementRuleStrs) {
|
||||||
switch (placementRuleStr) {
|
switch (placementRuleStr) {
|
||||||
case YarnConfiguration.USER_GROUP_PLACEMENT_RULE:
|
case YarnConfiguration.USER_GROUP_PLACEMENT_RULE:
|
||||||
PlacementRule ugRule = getUserGroupMappingPlacementRule();
|
|
||||||
if (null != ugRule) {
|
|
||||||
placementRules.add(ugRule);
|
|
||||||
}
|
|
||||||
break;
|
|
||||||
case YarnConfiguration.APP_NAME_PLACEMENT_RULE:
|
case YarnConfiguration.APP_NAME_PLACEMENT_RULE:
|
||||||
PlacementRule anRule = getAppNameMappingPlacementRule();
|
if (!csMappingAdded) {
|
||||||
if (null != anRule) {
|
PlacementRule csMappingRule = getCSMappingPlacementRule();
|
||||||
placementRules.add(anRule);
|
if (null != csMappingRule) {
|
||||||
|
placementRules.add(csMappingRule);
|
||||||
|
csMappingAdded = true;
|
||||||
|
}
|
||||||
}
|
}
|
||||||
break;
|
break;
|
||||||
default:
|
default:
|
||||||
|
|
|
@ -1229,6 +1229,24 @@ public class CapacitySchedulerConfiguration extends ReservationSchedulerConfigur
|
||||||
setStrings(QUEUE_MAPPING, StringUtils.join(",", queueMappingStrs));
|
setStrings(QUEUE_MAPPING, StringUtils.join(",", queueMappingStrs));
|
||||||
}
|
}
|
||||||
|
|
||||||
|
|
||||||
|
@Private
|
||||||
|
@VisibleForTesting
|
||||||
|
public void setAppNameMappings(List<QueueMapping> queueMappings) {
|
||||||
|
if (queueMappings == null) {
|
||||||
|
return;
|
||||||
|
}
|
||||||
|
|
||||||
|
List<String> queueMappingStrs = new ArrayList<>();
|
||||||
|
for (QueueMapping mapping : queueMappings) {
|
||||||
|
String rule = mapping.toString();
|
||||||
|
String[] parts = rule.split(":");
|
||||||
|
queueMappingStrs.add(parts[1] + ":" + parts[2]);
|
||||||
|
}
|
||||||
|
|
||||||
|
setStrings(QUEUE_MAPPING_NAME, StringUtils.join(",", queueMappingStrs));
|
||||||
|
}
|
||||||
|
|
||||||
@Private
|
@Private
|
||||||
@VisibleForTesting
|
@VisibleForTesting
|
||||||
void setWorkflowPriorityMappings(
|
void setWorkflowPriorityMappings(
|
||||||
|
|
|
@ -1053,7 +1053,9 @@ public class TestAppManager extends AppManagerTestBase{
|
||||||
}
|
}
|
||||||
|
|
||||||
}).when(placementMgr).placeApplication(
|
}).when(placementMgr).placeApplication(
|
||||||
any(ApplicationSubmissionContext.class), any(String.class));
|
any(ApplicationSubmissionContext.class),
|
||||||
|
any(String.class),
|
||||||
|
any(Boolean.class));
|
||||||
rmContext.setQueuePlacementManager(placementMgr);
|
rmContext.setQueuePlacementManager(placementMgr);
|
||||||
|
|
||||||
asContext.setQueue("oldQueue");
|
asContext.setQueue("oldQueue");
|
||||||
|
|
|
@ -127,7 +127,7 @@ public class TestAppManagerWithFairScheduler extends AppManagerTestBase {
|
||||||
ApplicationSubmissionContext asContext = createAppSubmitCtx(appId, res);
|
ApplicationSubmissionContext asContext = createAppSubmitCtx(appId, res);
|
||||||
|
|
||||||
// Submit to limited queue
|
// Submit to limited queue
|
||||||
when(placementMgr.placeApplication(any(), any()))
|
when(placementMgr.placeApplication(any(), any(), any(Boolean.class)))
|
||||||
.thenReturn(new ApplicationPlacementContext("limited"));
|
.thenReturn(new ApplicationPlacementContext("limited"));
|
||||||
try {
|
try {
|
||||||
rmAppManager.submitApplication(asContext, "test");
|
rmAppManager.submitApplication(asContext, "test");
|
||||||
|
@ -138,7 +138,7 @@ public class TestAppManagerWithFairScheduler extends AppManagerTestBase {
|
||||||
}
|
}
|
||||||
|
|
||||||
// submit same app but now place it in the unlimited queue
|
// submit same app but now place it in the unlimited queue
|
||||||
when(placementMgr.placeApplication(any(), any()))
|
when(placementMgr.placeApplication(any(), any(), any(Boolean.class)))
|
||||||
.thenReturn(new ApplicationPlacementContext("root.unlimited"));
|
.thenReturn(new ApplicationPlacementContext("root.unlimited"));
|
||||||
rmAppManager.submitApplication(asContext, "test");
|
rmAppManager.submitApplication(asContext, "test");
|
||||||
}
|
}
|
||||||
|
@ -172,7 +172,7 @@ public class TestAppManagerWithFairScheduler extends AppManagerTestBase {
|
||||||
ApplicationSubmissionContext asContext = createAppSubmitCtx(appId, res);
|
ApplicationSubmissionContext asContext = createAppSubmitCtx(appId, res);
|
||||||
|
|
||||||
// Submit to no access queue
|
// Submit to no access queue
|
||||||
when(placementMgr.placeApplication(any(), any()))
|
when(placementMgr.placeApplication(any(), any(), any(Boolean.class)))
|
||||||
.thenReturn(new ApplicationPlacementContext("noaccess"));
|
.thenReturn(new ApplicationPlacementContext("noaccess"));
|
||||||
try {
|
try {
|
||||||
rmAppManager.submitApplication(asContext, "test");
|
rmAppManager.submitApplication(asContext, "test");
|
||||||
|
@ -182,13 +182,13 @@ public class TestAppManagerWithFairScheduler extends AppManagerTestBase {
|
||||||
e.getCause() instanceof AccessControlException);
|
e.getCause() instanceof AccessControlException);
|
||||||
}
|
}
|
||||||
// Submit to submit access queue
|
// Submit to submit access queue
|
||||||
when(placementMgr.placeApplication(any(), any()))
|
when(placementMgr.placeApplication(any(), any(), any(Boolean.class)))
|
||||||
.thenReturn(new ApplicationPlacementContext("submitonly"));
|
.thenReturn(new ApplicationPlacementContext("submitonly"));
|
||||||
rmAppManager.submitApplication(asContext, "test");
|
rmAppManager.submitApplication(asContext, "test");
|
||||||
// Submit second app to admin access queue
|
// Submit second app to admin access queue
|
||||||
appId = MockApps.newAppID(2);
|
appId = MockApps.newAppID(2);
|
||||||
asContext = createAppSubmitCtx(appId, res);
|
asContext = createAppSubmitCtx(appId, res);
|
||||||
when(placementMgr.placeApplication(any(), any()))
|
when(placementMgr.placeApplication(any(), any(), any(Boolean.class)))
|
||||||
.thenReturn(new ApplicationPlacementContext("adminonly"));
|
.thenReturn(new ApplicationPlacementContext("adminonly"));
|
||||||
rmAppManager.submitApplication(asContext, "test");
|
rmAppManager.submitApplication(asContext, "test");
|
||||||
}
|
}
|
||||||
|
@ -245,7 +245,7 @@ public class TestAppManagerWithFairScheduler extends AppManagerTestBase {
|
||||||
ApplicationSubmissionContext asContext = createAppSubmitCtx(appId, res);
|
ApplicationSubmissionContext asContext = createAppSubmitCtx(appId, res);
|
||||||
|
|
||||||
// Submit to noaccess parent with non existent child queue
|
// Submit to noaccess parent with non existent child queue
|
||||||
when(placementMgr.placeApplication(any(), any()))
|
when(placementMgr.placeApplication(any(), any(), any(Boolean.class)))
|
||||||
.thenReturn(new ApplicationPlacementContext("root.noaccess.child"));
|
.thenReturn(new ApplicationPlacementContext("root.noaccess.child"));
|
||||||
try {
|
try {
|
||||||
rmAppManager.submitApplication(asContext, "test");
|
rmAppManager.submitApplication(asContext, "test");
|
||||||
|
@ -255,7 +255,7 @@ public class TestAppManagerWithFairScheduler extends AppManagerTestBase {
|
||||||
e.getCause() instanceof AccessControlException);
|
e.getCause() instanceof AccessControlException);
|
||||||
}
|
}
|
||||||
// Submit to submitonly parent with non existent child queue
|
// Submit to submitonly parent with non existent child queue
|
||||||
when(placementMgr.placeApplication(any(), any()))
|
when(placementMgr.placeApplication(any(), any(), any(Boolean.class)))
|
||||||
.thenReturn(new ApplicationPlacementContext("root.submitonly.child"));
|
.thenReturn(new ApplicationPlacementContext("root.submitonly.child"));
|
||||||
rmAppManager.submitApplication(asContext, "test");
|
rmAppManager.submitApplication(asContext, "test");
|
||||||
}
|
}
|
||||||
|
|
|
@ -18,6 +18,7 @@
|
||||||
|
|
||||||
package org.apache.hadoop.yarn.server.resourcemanager.placement;
|
package org.apache.hadoop.yarn.server.resourcemanager.placement;
|
||||||
|
|
||||||
|
import org.apache.hadoop.thirdparty.com.google.common.collect.Lists;
|
||||||
import org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext;
|
import org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext;
|
||||||
import org.apache.hadoop.yarn.conf.YarnConfiguration;
|
import org.apache.hadoop.yarn.conf.YarnConfiguration;
|
||||||
import org.apache.hadoop.yarn.server.resourcemanager.MockRM;
|
import org.apache.hadoop.yarn.server.resourcemanager.MockRM;
|
||||||
|
@ -33,7 +34,6 @@ import org.junit.Before;
|
||||||
import org.junit.Test;
|
import org.junit.Test;
|
||||||
|
|
||||||
import java.util.ArrayList;
|
import java.util.ArrayList;
|
||||||
import java.util.Arrays;
|
|
||||||
import java.util.List;
|
import java.util.List;
|
||||||
|
|
||||||
import static org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration.DOT;
|
import static org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration.DOT;
|
||||||
|
@ -83,9 +83,12 @@ public class TestPlacementManager {
|
||||||
USER1))
|
USER1))
|
||||||
.build();
|
.build();
|
||||||
|
|
||||||
UserGroupMappingPlacementRule ugRule = new UserGroupMappingPlacementRule(
|
cs.getConfiguration().setQueueMappings(
|
||||||
false, Arrays.asList(userQueueMapping), null);
|
Lists.newArrayList(userQueueMapping));
|
||||||
|
CSMappingPlacementRule ugRule = new CSMappingPlacementRule();
|
||||||
|
ugRule.initialize(cs);
|
||||||
queuePlacementRules.add(ugRule);
|
queuePlacementRules.add(ugRule);
|
||||||
|
|
||||||
pm.updateRules(queuePlacementRules);
|
pm.updateRules(queuePlacementRules);
|
||||||
|
|
||||||
ApplicationSubmissionContext asc = Records.newRecord(
|
ApplicationSubmissionContext asc = Records.newRecord(
|
||||||
|
@ -102,17 +105,14 @@ public class TestPlacementManager {
|
||||||
.parentQueue(PARENT_QUEUE)
|
.parentQueue(PARENT_QUEUE)
|
||||||
.build();
|
.build();
|
||||||
|
|
||||||
AppNameMappingPlacementRule anRule = new AppNameMappingPlacementRule(false,
|
cs.getConfiguration().setAppNameMappings(
|
||||||
Arrays.asList(queueMappingEntity));
|
Lists.newArrayList(queueMappingEntity));
|
||||||
|
CSMappingPlacementRule anRule = new CSMappingPlacementRule();
|
||||||
|
anRule.initialize(cs);
|
||||||
queuePlacementRules.add(anRule);
|
queuePlacementRules.add(anRule);
|
||||||
pm.updateRules(queuePlacementRules);
|
pm.updateRules(queuePlacementRules);
|
||||||
try {
|
|
||||||
ApplicationPlacementContext pc = pm.placeApplication(asc, USER2);
|
ApplicationPlacementContext pc = pm.placeApplication(asc, USER2);
|
||||||
Assert.assertNotNull(pc);
|
Assert.assertNotNull(pc);
|
||||||
} catch (Exception e) {
|
|
||||||
e.printStackTrace();
|
|
||||||
Assert.fail("Exception not expected");
|
|
||||||
}
|
|
||||||
}
|
}
|
||||||
|
|
||||||
@Test
|
@Test
|
||||||
|
@ -121,10 +121,9 @@ public class TestPlacementManager {
|
||||||
QueueMapping userQueueMapping = QueueMappingBuilder.create()
|
QueueMapping userQueueMapping = QueueMappingBuilder.create()
|
||||||
.type(MappingType.USER).source(USER1)
|
.type(MappingType.USER).source(USER1)
|
||||||
.queue(getQueueMapping(PARENT_QUEUE, USER1)).build();
|
.queue(getQueueMapping(PARENT_QUEUE, USER1)).build();
|
||||||
UserGroupMappingPlacementRule ugRule = new UserGroupMappingPlacementRule(
|
|
||||||
false, Arrays.asList(userQueueMapping), null);
|
|
||||||
|
|
||||||
// Configure placement rule
|
CSMappingPlacementRule ugRule = new CSMappingPlacementRule();
|
||||||
|
|
||||||
conf.set(YarnConfiguration.QUEUE_PLACEMENT_RULES, ugRule.getName());
|
conf.set(YarnConfiguration.QUEUE_PLACEMENT_RULES, ugRule.getName());
|
||||||
queueMappings.add(userQueueMapping);
|
queueMappings.add(userQueueMapping);
|
||||||
conf.setQueueMappings(queueMappings);
|
conf.setQueueMappings(queueMappings);
|
||||||
|
@ -135,7 +134,7 @@ public class TestPlacementManager {
|
||||||
PlacementManager pm = cs.getRMContext().getQueuePlacementManager();
|
PlacementManager pm = cs.getRMContext().getQueuePlacementManager();
|
||||||
|
|
||||||
// As we are setting placement rule, It shouldn't update default
|
// As we are setting placement rule, It shouldn't update default
|
||||||
// placement rule ie user-group. Number of placemnt rules should be 1.
|
// placement rule ie user-group. Number of placement rules should be 1.
|
||||||
Assert.assertEquals(1, pm.getPlacementRules().size());
|
Assert.assertEquals(1, pm.getPlacementRules().size());
|
||||||
// Verifying if placement rule set is same as the one we configured
|
// Verifying if placement rule set is same as the one we configured
|
||||||
Assert.assertEquals(ugRule.getName(),
|
Assert.assertEquals(ugRule.getName(),
|
||||||
|
|
|
@ -18,7 +18,6 @@
|
||||||
|
|
||||||
package org.apache.hadoop.yarn.server.resourcemanager.placement;
|
package org.apache.hadoop.yarn.server.resourcemanager.placement;
|
||||||
|
|
||||||
import static org.junit.Assert.fail;
|
|
||||||
import static org.mockito.Mockito.mock;
|
import static org.mockito.Mockito.mock;
|
||||||
import static org.mockito.Mockito.when;
|
import static org.mockito.Mockito.when;
|
||||||
import static org.mockito.Mockito.isNull;
|
import static org.mockito.Mockito.isNull;
|
||||||
|
@ -157,7 +156,7 @@ public class TestUserGroupMappingPlacementRule {
|
||||||
.build());
|
.build());
|
||||||
}
|
}
|
||||||
|
|
||||||
@Test(expected = YarnException.class)
|
@Test
|
||||||
public void testNullGroupMapping() throws IOException, YarnException {
|
public void testNullGroupMapping() throws IOException, YarnException {
|
||||||
conf.setClass(CommonConfigurationKeys.HADOOP_SECURITY_GROUP_MAPPING,
|
conf.setClass(CommonConfigurationKeys.HADOOP_SECURITY_GROUP_MAPPING,
|
||||||
NullGroupsMapping.class, GroupMappingServiceProvider.class);
|
NullGroupsMapping.class, GroupMappingServiceProvider.class);
|
||||||
|
@ -171,7 +170,6 @@ public class TestUserGroupMappingPlacementRule {
|
||||||
.inputUser("a")
|
.inputUser("a")
|
||||||
.expectedQueue("default")
|
.expectedQueue("default")
|
||||||
.build());
|
.build());
|
||||||
fail("No Groups for user 'a'");
|
|
||||||
}
|
}
|
||||||
|
|
||||||
@Test
|
@Test
|
||||||
|
|
|
@ -159,6 +159,7 @@ public class TestAbsoluteResourceWithAutoQueue
|
||||||
|
|
||||||
csConf.setClass(YarnConfiguration.RM_SCHEDULER, CapacityScheduler.class,
|
csConf.setClass(YarnConfiguration.RM_SCHEDULER, CapacityScheduler.class,
|
||||||
ResourceScheduler.class);
|
ResourceScheduler.class);
|
||||||
|
csConf.setOverrideWithQueueMappings(true);
|
||||||
|
|
||||||
mockRM = new MockRM(csConf);
|
mockRM = new MockRM(csConf);
|
||||||
cs = (CapacityScheduler) mockRM.getResourceScheduler();
|
cs = (CapacityScheduler) mockRM.getResourceScheduler();
|
||||||
|
|
|
@ -114,9 +114,9 @@ public class TestCapacitySchedulerAutoCreatedQueueBase {
|
||||||
public static final String C = CapacitySchedulerConfiguration.ROOT + ".c";
|
public static final String C = CapacitySchedulerConfiguration.ROOT + ".c";
|
||||||
public static final String D = CapacitySchedulerConfiguration.ROOT + ".d";
|
public static final String D = CapacitySchedulerConfiguration.ROOT + ".d";
|
||||||
public static final String E = CapacitySchedulerConfiguration.ROOT + ".e";
|
public static final String E = CapacitySchedulerConfiguration.ROOT + ".e";
|
||||||
public static final String ASUBGROUP1 =
|
public static final String ESUBGROUP1 =
|
||||||
CapacitySchedulerConfiguration.ROOT + ".esubgroup1";
|
CapacitySchedulerConfiguration.ROOT + ".esubgroup1";
|
||||||
public static final String AGROUP =
|
public static final String FGROUP =
|
||||||
CapacitySchedulerConfiguration.ROOT + ".fgroup";
|
CapacitySchedulerConfiguration.ROOT + ".fgroup";
|
||||||
public static final String A1 = A + ".a1";
|
public static final String A1 = A + ".a1";
|
||||||
public static final String A2 = A + ".a2";
|
public static final String A2 = A + ".a2";
|
||||||
|
@ -124,14 +124,14 @@ public class TestCapacitySchedulerAutoCreatedQueueBase {
|
||||||
public static final String B2 = B + ".b2";
|
public static final String B2 = B + ".b2";
|
||||||
public static final String B3 = B + ".b3";
|
public static final String B3 = B + ".b3";
|
||||||
public static final String B4 = B + ".b4subgroup1";
|
public static final String B4 = B + ".b4subgroup1";
|
||||||
public static final String ASUBGROUP1_A = ASUBGROUP1 + ".e";
|
public static final String ESUBGROUP1_A = ESUBGROUP1 + ".e";
|
||||||
public static final String AGROUP_A = AGROUP + ".f";
|
public static final String FGROUP_F = FGROUP + ".f";
|
||||||
public static final float A_CAPACITY = 20f;
|
public static final float A_CAPACITY = 20f;
|
||||||
public static final float B_CAPACITY = 20f;
|
public static final float B_CAPACITY = 20f;
|
||||||
public static final float C_CAPACITY = 20f;
|
public static final float C_CAPACITY = 20f;
|
||||||
public static final float D_CAPACITY = 20f;
|
public static final float D_CAPACITY = 20f;
|
||||||
public static final float ASUBGROUP1_CAPACITY = 10f;
|
public static final float ESUBGROUP1_CAPACITY = 10f;
|
||||||
public static final float AGROUP_CAPACITY = 10f;
|
public static final float FGROUP_CAPACITY = 10f;
|
||||||
|
|
||||||
public static final float A1_CAPACITY = 30;
|
public static final float A1_CAPACITY = 30;
|
||||||
public static final float A2_CAPACITY = 70;
|
public static final float A2_CAPACITY = 70;
|
||||||
|
@ -371,8 +371,8 @@ public class TestCapacitySchedulerAutoCreatedQueueBase {
|
||||||
conf.setCapacity(B, B_CAPACITY);
|
conf.setCapacity(B, B_CAPACITY);
|
||||||
conf.setCapacity(C, C_CAPACITY);
|
conf.setCapacity(C, C_CAPACITY);
|
||||||
conf.setCapacity(D, D_CAPACITY);
|
conf.setCapacity(D, D_CAPACITY);
|
||||||
conf.setCapacity(ASUBGROUP1, ASUBGROUP1_CAPACITY);
|
conf.setCapacity(ESUBGROUP1, ESUBGROUP1_CAPACITY);
|
||||||
conf.setCapacity(AGROUP, AGROUP_CAPACITY);
|
conf.setCapacity(FGROUP, FGROUP_CAPACITY);
|
||||||
|
|
||||||
// Define 2nd-level queues
|
// Define 2nd-level queues
|
||||||
conf.setQueues(A, new String[] { "a1", "a2" });
|
conf.setQueues(A, new String[] { "a1", "a2" });
|
||||||
|
@ -391,12 +391,12 @@ public class TestCapacitySchedulerAutoCreatedQueueBase {
|
||||||
conf.setCapacity(B4, B4_CAPACITY);
|
conf.setCapacity(B4, B4_CAPACITY);
|
||||||
conf.setUserLimitFactor(B4, 100.0f);
|
conf.setUserLimitFactor(B4, 100.0f);
|
||||||
|
|
||||||
conf.setQueues(ASUBGROUP1, new String[] {"e"});
|
conf.setQueues(ESUBGROUP1, new String[] {"e"});
|
||||||
conf.setCapacity(ASUBGROUP1_A, 100f);
|
conf.setCapacity(ESUBGROUP1_A, 100f);
|
||||||
conf.setUserLimitFactor(ASUBGROUP1_A, 100.0f);
|
conf.setUserLimitFactor(ESUBGROUP1_A, 100.0f);
|
||||||
conf.setQueues(AGROUP, new String[] {"f"});
|
conf.setQueues(FGROUP, new String[] {"f"});
|
||||||
conf.setCapacity(AGROUP_A, 100f);
|
conf.setCapacity(FGROUP_F, 100f);
|
||||||
conf.setUserLimitFactor(AGROUP_A, 100.0f);
|
conf.setUserLimitFactor(FGROUP_F, 100.0f);
|
||||||
|
|
||||||
conf.setUserLimitFactor(C, 1.0f);
|
conf.setUserLimitFactor(C, 1.0f);
|
||||||
conf.setAutoCreateChildQueueEnabled(C, true);
|
conf.setAutoCreateChildQueueEnabled(C, true);
|
||||||
|
|
|
@ -86,7 +86,6 @@ import java.util.Set;
|
||||||
|
|
||||||
import static org.apache.hadoop.yarn.nodelabels.CommonNodeLabelsManager
|
import static org.apache.hadoop.yarn.nodelabels.CommonNodeLabelsManager
|
||||||
.NO_LABEL;
|
.NO_LABEL;
|
||||||
import static org.apache.hadoop.yarn.server.resourcemanager.placement.UserGroupMappingPlacementRule.CURRENT_USER_MAPPING;
|
|
||||||
import static org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueueUtils.EPSILON;
|
import static org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueueUtils.EPSILON;
|
||||||
|
|
||||||
import static org.junit.Assert.assertEquals;
|
import static org.junit.Assert.assertEquals;
|
||||||
|
@ -106,6 +105,8 @@ public class TestCapacitySchedulerAutoQueueCreation
|
||||||
private static final Logger LOG = LoggerFactory.getLogger(
|
private static final Logger LOG = LoggerFactory.getLogger(
|
||||||
TestCapacitySchedulerAutoQueueCreation.class);
|
TestCapacitySchedulerAutoQueueCreation.class);
|
||||||
|
|
||||||
|
private static final String CURRENT_USER_MAPPING = "%user";
|
||||||
|
|
||||||
private static final Resource TEMPLATE_MAX_RES = Resource.newInstance(16 *
|
private static final Resource TEMPLATE_MAX_RES = Resource.newInstance(16 *
|
||||||
GB,
|
GB,
|
||||||
48);
|
48);
|
||||||
|
@ -424,16 +425,16 @@ public class TestCapacitySchedulerAutoQueueCreation
|
||||||
|
|
||||||
//dynamic queue mapping
|
//dynamic queue mapping
|
||||||
try {
|
try {
|
||||||
setupQueueMapping(newCS, CURRENT_USER_MAPPING, "a",
|
setupQueueMapping(newCS, CURRENT_USER_MAPPING, "a1",
|
||||||
CURRENT_USER_MAPPING);
|
CURRENT_USER_MAPPING);
|
||||||
newCS.updatePlacementRules();
|
newCS.updatePlacementRules();
|
||||||
fail("Expected invalid parent queue mapping failure");
|
fail("Expected invalid parent queue mapping failure");
|
||||||
|
|
||||||
} catch (IOException e) {
|
} catch (IOException e) {
|
||||||
//expected exception
|
//expected exception
|
||||||
|
|
||||||
assertTrue(e.getMessage().contains(
|
assertTrue(e.getMessage().contains(
|
||||||
"invalid parent queue which does not have auto creation of leaf "
|
"Target queue path 'a1.%user' has a non-managed parent queue"));
|
||||||
+ "queues enabled [" + "a" + "]"));
|
|
||||||
}
|
}
|
||||||
|
|
||||||
//"a" is not auto create enabled and app_user does not exist as a leaf
|
//"a" is not auto create enabled and app_user does not exist as a leaf
|
||||||
|
@ -446,8 +447,8 @@ public class TestCapacitySchedulerAutoQueueCreation
|
||||||
fail("Expected invalid parent queue mapping failure");
|
fail("Expected invalid parent queue mapping failure");
|
||||||
} catch (IOException e) {
|
} catch (IOException e) {
|
||||||
//expected exception
|
//expected exception
|
||||||
assertTrue(e.getMessage()
|
assertTrue(e.getMessage().contains(
|
||||||
.contains("invalid parent queue [" + "INVALID_PARENT_QUEUE" + "]"));
|
"contains an invalid parent queue 'INVALID_PARENT_QUEUE'"));
|
||||||
}
|
}
|
||||||
} finally {
|
} finally {
|
||||||
if (newMockRM != null) {
|
if (newMockRM != null) {
|
||||||
|
@ -477,7 +478,7 @@ public class TestCapacitySchedulerAutoQueueCreation
|
||||||
fail("Expected invalid parent queue mapping failure");
|
fail("Expected invalid parent queue mapping failure");
|
||||||
} catch (IOException e) {
|
} catch (IOException e) {
|
||||||
//expected exception
|
//expected exception
|
||||||
assertTrue(e.getMessage().contains("invalid parent queue []"));
|
assertTrue(e.getMessage().contains("invalid parent queue"));
|
||||||
}
|
}
|
||||||
} finally {
|
} finally {
|
||||||
if (newMockRM != null) {
|
if (newMockRM != null) {
|
||||||
|
|
|
@ -25,11 +25,11 @@ import org.apache.hadoop.yarn.conf.YarnConfiguration;
|
||||||
import org.apache.hadoop.yarn.exceptions.YarnException;
|
import org.apache.hadoop.yarn.exceptions.YarnException;
|
||||||
import org.apache.hadoop.yarn.server.resourcemanager.MockRM;
|
import org.apache.hadoop.yarn.server.resourcemanager.MockRM;
|
||||||
import org.apache.hadoop.yarn.server.resourcemanager.placement.ApplicationPlacementContext;
|
import org.apache.hadoop.yarn.server.resourcemanager.placement.ApplicationPlacementContext;
|
||||||
|
import org.apache.hadoop.yarn.server.resourcemanager.placement.CSMappingPlacementRule;
|
||||||
import org.apache.hadoop.yarn.server.resourcemanager.placement.PlacementRule;
|
import org.apache.hadoop.yarn.server.resourcemanager.placement.PlacementRule;
|
||||||
import org.apache.hadoop.yarn.server.resourcemanager.placement.QueueMapping;
|
import org.apache.hadoop.yarn.server.resourcemanager.placement.QueueMapping;
|
||||||
import org.apache.hadoop.yarn.server.resourcemanager.placement.QueueMapping.MappingType;
|
import org.apache.hadoop.yarn.server.resourcemanager.placement.QueueMapping.MappingType;
|
||||||
import org.apache.hadoop.yarn.server.resourcemanager.placement.QueueMapping.QueueMappingBuilder;
|
import org.apache.hadoop.yarn.server.resourcemanager.placement.QueueMapping.QueueMappingBuilder;
|
||||||
import org.apache.hadoop.yarn.server.resourcemanager.placement.UserGroupMappingPlacementRule;
|
|
||||||
import org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceScheduler;
|
import org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceScheduler;
|
||||||
import org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.SimpleGroupsMapping;
|
import org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.SimpleGroupsMapping;
|
||||||
import org.apache.hadoop.yarn.util.Records;
|
import org.apache.hadoop.yarn.util.Records;
|
||||||
|
@ -46,10 +46,8 @@ import static org.junit.Assert.*;
|
||||||
public class TestCapacitySchedulerQueueMappingFactory {
|
public class TestCapacitySchedulerQueueMappingFactory {
|
||||||
|
|
||||||
private static final String QUEUE_MAPPING_NAME = "app-name";
|
private static final String QUEUE_MAPPING_NAME = "app-name";
|
||||||
private static final String QUEUE_MAPPING_RULE_APP_NAME =
|
private static final String QUEUE_MAPPING_RULE =
|
||||||
"org.apache.hadoop.yarn.server.resourcemanager.placement.AppNameMappingPlacementRule";
|
CSMappingPlacementRule.class.getCanonicalName();
|
||||||
private static final String QUEUE_MAPPING_RULE_USER_GROUP =
|
|
||||||
"org.apache.hadoop.yarn.server.resourcemanager.placement.UserGroupMappingPlacementRule";
|
|
||||||
public static final String USER = "user_";
|
public static final String USER = "user_";
|
||||||
public static final String PARENT_QUEUE = "c";
|
public static final String PARENT_QUEUE = "c";
|
||||||
|
|
||||||
|
@ -59,8 +57,7 @@ public class TestCapacitySchedulerQueueMappingFactory {
|
||||||
|
|
||||||
List<String> queuePlacementRules = new ArrayList<>();
|
List<String> queuePlacementRules = new ArrayList<>();
|
||||||
|
|
||||||
queuePlacementRules.add(QUEUE_MAPPING_RULE_USER_GROUP);
|
queuePlacementRules.add(QUEUE_MAPPING_RULE);
|
||||||
queuePlacementRules.add(QUEUE_MAPPING_RULE_APP_NAME);
|
|
||||||
|
|
||||||
conf.setQueuePlacementRules(queuePlacementRules);
|
conf.setQueuePlacementRules(queuePlacementRules);
|
||||||
|
|
||||||
|
@ -134,8 +131,7 @@ public class TestCapacitySchedulerQueueMappingFactory {
|
||||||
}
|
}
|
||||||
|
|
||||||
// verify both placement rules were added successfully
|
// verify both placement rules were added successfully
|
||||||
assertThat(placementRuleNames, hasItems(QUEUE_MAPPING_RULE_USER_GROUP));
|
assertThat(placementRuleNames, hasItems(QUEUE_MAPPING_RULE));
|
||||||
assertThat(placementRuleNames, hasItems(QUEUE_MAPPING_RULE_APP_NAME));
|
|
||||||
} finally {
|
} finally {
|
||||||
if(mockRM != null) {
|
if(mockRM != null) {
|
||||||
mockRM.close();
|
mockRM.close();
|
||||||
|
@ -154,7 +150,7 @@ public class TestCapacitySchedulerQueueMappingFactory {
|
||||||
SimpleGroupsMapping.class, GroupMappingServiceProvider.class);
|
SimpleGroupsMapping.class, GroupMappingServiceProvider.class);
|
||||||
|
|
||||||
List<String> queuePlacementRules = new ArrayList<>();
|
List<String> queuePlacementRules = new ArrayList<>();
|
||||||
queuePlacementRules.add(QUEUE_MAPPING_RULE_USER_GROUP);
|
queuePlacementRules.add(QUEUE_MAPPING_RULE);
|
||||||
conf.setQueuePlacementRules(queuePlacementRules);
|
conf.setQueuePlacementRules(queuePlacementRules);
|
||||||
|
|
||||||
List<QueueMapping> existingMappingsForUG = conf.getQueueMappings();
|
List<QueueMapping> existingMappingsForUG = conf.getQueueMappings();
|
||||||
|
@ -200,8 +196,8 @@ public class TestCapacitySchedulerQueueMappingFactory {
|
||||||
List<PlacementRule> rules =
|
List<PlacementRule> rules =
|
||||||
cs.getRMContext().getQueuePlacementManager().getPlacementRules();
|
cs.getRMContext().getQueuePlacementManager().getPlacementRules();
|
||||||
|
|
||||||
UserGroupMappingPlacementRule r =
|
CSMappingPlacementRule r =
|
||||||
(UserGroupMappingPlacementRule) rules.get(0);
|
(CSMappingPlacementRule) rules.get(0);
|
||||||
|
|
||||||
ApplicationPlacementContext ctx = r.getPlacementForApp(asc, "user1");
|
ApplicationPlacementContext ctx = r.getPlacementForApp(asc, "user1");
|
||||||
assertEquals("Queue", "b1", ctx.getQueue());
|
assertEquals("Queue", "b1", ctx.getQueue());
|
||||||
|
@ -327,7 +323,7 @@ public class TestCapacitySchedulerQueueMappingFactory {
|
||||||
SimpleGroupsMapping.class, GroupMappingServiceProvider.class);
|
SimpleGroupsMapping.class, GroupMappingServiceProvider.class);
|
||||||
|
|
||||||
List<String> queuePlacementRules = new ArrayList<>();
|
List<String> queuePlacementRules = new ArrayList<>();
|
||||||
queuePlacementRules.add(QUEUE_MAPPING_RULE_USER_GROUP);
|
queuePlacementRules.add(QUEUE_MAPPING_RULE);
|
||||||
conf.setQueuePlacementRules(queuePlacementRules);
|
conf.setQueuePlacementRules(queuePlacementRules);
|
||||||
|
|
||||||
List<QueueMapping> existingMappingsForUG = conf.getQueueMappings();
|
List<QueueMapping> existingMappingsForUG = conf.getQueueMappings();
|
||||||
|
@ -353,8 +349,8 @@ public class TestCapacitySchedulerQueueMappingFactory {
|
||||||
List<PlacementRule> rules =
|
List<PlacementRule> rules =
|
||||||
cs.getRMContext().getQueuePlacementManager().getPlacementRules();
|
cs.getRMContext().getQueuePlacementManager().getPlacementRules();
|
||||||
|
|
||||||
UserGroupMappingPlacementRule r =
|
CSMappingPlacementRule r =
|
||||||
(UserGroupMappingPlacementRule) rules.get(0);
|
(CSMappingPlacementRule) rules.get(0);
|
||||||
ApplicationPlacementContext ctx = r.getPlacementForApp(asc, user);
|
ApplicationPlacementContext ctx = r.getPlacementForApp(asc, user);
|
||||||
assertEquals("Queue", user, ctx.getQueue());
|
assertEquals("Queue", user, ctx.getQueue());
|
||||||
|
|
||||||
|
@ -382,7 +378,7 @@ public class TestCapacitySchedulerQueueMappingFactory {
|
||||||
SimpleGroupsMapping.class, GroupMappingServiceProvider.class);
|
SimpleGroupsMapping.class, GroupMappingServiceProvider.class);
|
||||||
|
|
||||||
List<String> queuePlacementRules = new ArrayList<>();
|
List<String> queuePlacementRules = new ArrayList<>();
|
||||||
queuePlacementRules.add(QUEUE_MAPPING_RULE_USER_GROUP);
|
queuePlacementRules.add(QUEUE_MAPPING_RULE);
|
||||||
conf.setQueuePlacementRules(queuePlacementRules);
|
conf.setQueuePlacementRules(queuePlacementRules);
|
||||||
|
|
||||||
List<QueueMapping> existingMappingsForUG = conf.getQueueMappings();
|
List<QueueMapping> existingMappingsForUG = conf.getQueueMappings();
|
||||||
|
@ -426,8 +422,8 @@ public class TestCapacitySchedulerQueueMappingFactory {
|
||||||
|
|
||||||
List<PlacementRule> rules =
|
List<PlacementRule> rules =
|
||||||
cs.getRMContext().getQueuePlacementManager().getPlacementRules();
|
cs.getRMContext().getQueuePlacementManager().getPlacementRules();
|
||||||
UserGroupMappingPlacementRule r =
|
CSMappingPlacementRule r =
|
||||||
(UserGroupMappingPlacementRule) rules.get(0);
|
(CSMappingPlacementRule) rules.get(0);
|
||||||
|
|
||||||
ApplicationPlacementContext ctx = r.getPlacementForApp(asc, "user1");
|
ApplicationPlacementContext ctx = r.getPlacementForApp(asc, "user1");
|
||||||
assertEquals("Queue", "b1", ctx.getQueue());
|
assertEquals("Queue", "b1", ctx.getQueue());
|
||||||
|
@ -451,7 +447,7 @@ public class TestCapacitySchedulerQueueMappingFactory {
|
||||||
SimpleGroupsMapping.class, GroupMappingServiceProvider.class);
|
SimpleGroupsMapping.class, GroupMappingServiceProvider.class);
|
||||||
|
|
||||||
List<String> queuePlacementRules = new ArrayList<>();
|
List<String> queuePlacementRules = new ArrayList<>();
|
||||||
queuePlacementRules.add(QUEUE_MAPPING_RULE_USER_GROUP);
|
queuePlacementRules.add(QUEUE_MAPPING_RULE);
|
||||||
conf.setQueuePlacementRules(queuePlacementRules);
|
conf.setQueuePlacementRules(queuePlacementRules);
|
||||||
|
|
||||||
List<QueueMapping> existingMappingsForUG = conf.getQueueMappings();
|
List<QueueMapping> existingMappingsForUG = conf.getQueueMappings();
|
||||||
|
@ -473,11 +469,11 @@ public class TestCapacitySchedulerQueueMappingFactory {
|
||||||
.queue("%primary_group")
|
.queue("%primary_group")
|
||||||
.build();
|
.build();
|
||||||
|
|
||||||
// u:b4:%secondary_group
|
// u:b4:c.%secondary_group
|
||||||
QueueMapping userQueueMapping3 = QueueMappingBuilder.create()
|
QueueMapping userQueueMapping3 = QueueMappingBuilder.create()
|
||||||
.type(QueueMapping.MappingType.USER)
|
.type(QueueMapping.MappingType.USER)
|
||||||
.source("e")
|
.source("e")
|
||||||
.queue("%secondary_group")
|
.queue("c.%secondary_group")
|
||||||
.build();
|
.build();
|
||||||
|
|
||||||
queueMappingsForUG.add(userQueueMapping1);
|
queueMappingsForUG.add(userQueueMapping1);
|
||||||
|
@ -503,8 +499,8 @@ public class TestCapacitySchedulerQueueMappingFactory {
|
||||||
|
|
||||||
List<PlacementRule> rules =
|
List<PlacementRule> rules =
|
||||||
cs.getRMContext().getQueuePlacementManager().getPlacementRules();
|
cs.getRMContext().getQueuePlacementManager().getPlacementRules();
|
||||||
UserGroupMappingPlacementRule r =
|
CSMappingPlacementRule r =
|
||||||
(UserGroupMappingPlacementRule) rules.get(0);
|
(CSMappingPlacementRule) rules.get(0);
|
||||||
|
|
||||||
ApplicationPlacementContext ctx = r.getPlacementForApp(asc, "user1");
|
ApplicationPlacementContext ctx = r.getPlacementForApp(asc, "user1");
|
||||||
assertEquals("Queue", "b1", ctx.getQueue());
|
assertEquals("Queue", "b1", ctx.getQueue());
|
||||||
|
@ -514,6 +510,7 @@ public class TestCapacitySchedulerQueueMappingFactory {
|
||||||
|
|
||||||
ApplicationPlacementContext ctx2 = r.getPlacementForApp(asc, "e");
|
ApplicationPlacementContext ctx2 = r.getPlacementForApp(asc, "e");
|
||||||
assertEquals("Queue", "esubgroup1", ctx2.getQueue());
|
assertEquals("Queue", "esubgroup1", ctx2.getQueue());
|
||||||
|
assertEquals("Queue", "root.c", ctx2.getParentQueue());
|
||||||
} finally {
|
} finally {
|
||||||
if (mockRM != null) {
|
if (mockRM != null) {
|
||||||
mockRM.close();
|
mockRM.close();
|
||||||
|
|
|
@ -18,15 +18,14 @@
|
||||||
package org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity;
|
package org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity;
|
||||||
|
|
||||||
import java.io.IOException;
|
import java.io.IOException;
|
||||||
|
import java.util.List;
|
||||||
|
|
||||||
|
import org.apache.hadoop.yarn.server.resourcemanager.placement.MappingRule;
|
||||||
|
import org.apache.hadoop.yarn.server.resourcemanager.placement.QueueMapping;
|
||||||
import org.slf4j.Logger;
|
import org.slf4j.Logger;
|
||||||
import org.slf4j.LoggerFactory;
|
import org.slf4j.LoggerFactory;
|
||||||
import org.apache.hadoop.yarn.conf.YarnConfiguration;
|
import org.apache.hadoop.yarn.conf.YarnConfiguration;
|
||||||
import org.apache.hadoop.yarn.server.resourcemanager.RMContext;
|
import org.apache.hadoop.yarn.server.resourcemanager.RMContext;
|
||||||
import org.apache.hadoop.yarn.server.resourcemanager.placement.QueueMapping;
|
|
||||||
import org.apache.hadoop.yarn.server.resourcemanager.placement.QueueMapping.MappingType;
|
|
||||||
import org.apache.hadoop.yarn.server.resourcemanager.placement.QueueMapping.QueueMappingBuilder;
|
|
||||||
import org.apache.hadoop.yarn.server.resourcemanager.placement.UserGroupMappingPlacementRule;
|
|
||||||
import org.junit.Assert;
|
import org.junit.Assert;
|
||||||
import org.junit.Before;
|
import org.junit.Before;
|
||||||
import org.junit.Test;
|
import org.junit.Test;
|
||||||
|
@ -92,12 +91,13 @@ public class TestQueueMappings {
|
||||||
// space trimming
|
// space trimming
|
||||||
conf.set(CapacitySchedulerConfiguration.QUEUE_MAPPING, " u : a : " + Q1);
|
conf.set(CapacitySchedulerConfiguration.QUEUE_MAPPING, " u : a : " + Q1);
|
||||||
cs.reinitialize(conf, null);
|
cs.reinitialize(conf, null);
|
||||||
checkQMapping(
|
|
||||||
QueueMappingBuilder.create()
|
List<MappingRule> rules = cs.getConfiguration().getMappingRules();
|
||||||
.type(MappingType.USER)
|
|
||||||
.source("a")
|
String ruleStr = rules.get(0).toString();
|
||||||
.queue(Q1)
|
assert(ruleStr.contains("variable='%user'"));
|
||||||
.build());
|
assert(ruleStr.contains("value='a'"));
|
||||||
|
assert(ruleStr.contains("queueName='q1'"));
|
||||||
}
|
}
|
||||||
|
|
||||||
@Test
|
@Test
|
||||||
|
@ -155,13 +155,4 @@ public class TestQueueMappings {
|
||||||
Assert.assertTrue("invalid mapping did not throw exception for " + reason,
|
Assert.assertTrue("invalid mapping did not throw exception for " + reason,
|
||||||
fail);
|
fail);
|
||||||
}
|
}
|
||||||
|
|
||||||
private void checkQMapping(QueueMapping expected)
|
|
||||||
throws IOException {
|
|
||||||
UserGroupMappingPlacementRule rule =
|
|
||||||
(UserGroupMappingPlacementRule) cs.getRMContext()
|
|
||||||
.getQueuePlacementManager().getPlacementRules().get(0);
|
|
||||||
QueueMapping queueMapping = rule.getQueueMappings().get(0);
|
|
||||||
Assert.assertEquals(queueMapping, expected);
|
|
||||||
}
|
|
||||||
}
|
}
|
||||||
|
|
Loading…
Reference in New Issue