Skip to content

Commit

Permalink
YARN-3262. Surface application outstanding resource requests table in…
Browse files Browse the repository at this point in the history
… RM web UI. (Jian He via wangda)
  • Loading branch information
wangdatan committed Feb 28, 2015
1 parent cf51ff2 commit edceced
Show file tree
Hide file tree
Showing 13 changed files with 118 additions and 33 deletions.
3 changes: 3 additions & 0 deletions hadoop-yarn-project/CHANGES.txt
Expand Up @@ -336,6 +336,9 @@ Release 2.7.0 - UNRELEASED
YARN-2820. Retry in FileSystemRMStateStore when FS's operations fail YARN-2820. Retry in FileSystemRMStateStore when FS's operations fail
due to IOException. (Zhihai Xu via ozawa) due to IOException. (Zhihai Xu via ozawa)


YARN-3262. Surface application outstanding resource requests table
in RM web UI. (Jian He via wangda)

OPTIMIZATIONS OPTIMIZATIONS


YARN-2990. FairScheduler's delay-scheduling always waits for node-local and YARN-2990. FairScheduler's delay-scheduling always waits for node-local and
Expand Down
Expand Up @@ -140,13 +140,13 @@ public void setCapability(Resource capability) {
this.capability = capability; this.capability = capability;
} }
@Override @Override
public int getNumContainers() { public synchronized int getNumContainers() {
ResourceRequestProtoOrBuilder p = viaProto ? proto : builder; ResourceRequestProtoOrBuilder p = viaProto ? proto : builder;
return (p.getNumContainers()); return (p.getNumContainers());
} }


@Override @Override
public void setNumContainers(int numContainers) { public synchronized void setNumContainers(int numContainers) {
maybeInitBuilder(); maybeInitBuilder();
builder.setNumContainers((numContainers)); builder.setNumContainers((numContainers));
} }
Expand Down
Expand Up @@ -658,4 +658,13 @@ protected void refreshMaximumAllocation(Resource newMaxAlloc) {
maxAllocWriteLock.unlock(); maxAllocWriteLock.unlock();
} }
} }

public List<ResourceRequest> getPendingResourceRequestsForAttempt(
ApplicationAttemptId attemptId) {
SchedulerApplicationAttempt attempt = getApplicationAttempt(attemptId);
if (attempt != null) {
return attempt.getAppSchedulingInfo().getAllResourceRequests();
}
return null;
}
} }
Expand Up @@ -20,12 +20,14 @@


import java.util.ArrayList; import java.util.ArrayList;
import java.util.Collection; import java.util.Collection;
import java.util.Collections;
import java.util.HashMap; import java.util.HashMap;
import java.util.HashSet; import java.util.HashSet;
import java.util.List; import java.util.List;
import java.util.Map; import java.util.Map;
import java.util.Set; import java.util.Set;
import java.util.TreeSet; import java.util.TreeSet;
import java.util.concurrent.ConcurrentHashMap;
import java.util.concurrent.atomic.AtomicLong; import java.util.concurrent.atomic.AtomicLong;


import org.apache.commons.logging.Log; import org.apache.commons.logging.Log;
Expand Down Expand Up @@ -64,7 +66,7 @@ public class AppSchedulingInfo {
final Set<Priority> priorities = new TreeSet<Priority>( final Set<Priority> priorities = new TreeSet<Priority>(
new org.apache.hadoop.yarn.server.resourcemanager.resource.Priority.Comparator()); new org.apache.hadoop.yarn.server.resourcemanager.resource.Priority.Comparator());
final Map<Priority, Map<String, ResourceRequest>> requests = final Map<Priority, Map<String, ResourceRequest>> requests =
new HashMap<Priority, Map<String, ResourceRequest>>(); new ConcurrentHashMap<Priority, Map<String, ResourceRequest>>();
private Set<String> blacklist = new HashSet<String>(); private Set<String> blacklist = new HashSet<String>();


//private final ApplicationStore store; //private final ApplicationStore store;
Expand Down Expand Up @@ -159,7 +161,7 @@ synchronized public void updateResourceRequests(
Map<String, ResourceRequest> asks = this.requests.get(priority); Map<String, ResourceRequest> asks = this.requests.get(priority);


if (asks == null) { if (asks == null) {
asks = new HashMap<String, ResourceRequest>(); asks = new ConcurrentHashMap<String, ResourceRequest>();
this.requests.put(priority, asks); this.requests.put(priority, asks);
this.priorities.add(priority); this.priorities.add(priority);
} }
Expand Down Expand Up @@ -221,7 +223,7 @@ synchronized public Map<String, ResourceRequest> getResourceRequests(
return requests.get(priority); return requests.get(priority);
} }


synchronized public List<ResourceRequest> getAllResourceRequests() { public List<ResourceRequest> getAllResourceRequests() {
List<ResourceRequest> ret = new ArrayList<ResourceRequest>(); List<ResourceRequest> ret = new ArrayList<ResourceRequest>();
for (Map<String, ResourceRequest> r : requests.values()) { for (Map<String, ResourceRequest> r : requests.values()) {
ret.addAll(r.values()); ret.addAll(r.values());
Expand Down Expand Up @@ -300,17 +302,11 @@ synchronized private void allocateNodeLocal(SchedulerNode node,
Priority priority, ResourceRequest nodeLocalRequest, Container container, Priority priority, ResourceRequest nodeLocalRequest, Container container,
List<ResourceRequest> resourceRequests) { List<ResourceRequest> resourceRequests) {
// Update future requirements // Update future requirements
nodeLocalRequest.setNumContainers(nodeLocalRequest.getNumContainers() - 1); decResourceRequest(node.getNodeName(), priority, nodeLocalRequest);
if (nodeLocalRequest.getNumContainers() == 0) {
this.requests.get(priority).remove(node.getNodeName());
}


ResourceRequest rackLocalRequest = requests.get(priority).get( ResourceRequest rackLocalRequest = requests.get(priority).get(
node.getRackName()); node.getRackName());
rackLocalRequest.setNumContainers(rackLocalRequest.getNumContainers() - 1); decResourceRequest(node.getRackName(), priority, rackLocalRequest);
if (rackLocalRequest.getNumContainers() == 0) {
this.requests.get(priority).remove(node.getRackName());
}


ResourceRequest offRackRequest = requests.get(priority).get( ResourceRequest offRackRequest = requests.get(priority).get(
ResourceRequest.ANY); ResourceRequest.ANY);
Expand All @@ -322,6 +318,14 @@ synchronized private void allocateNodeLocal(SchedulerNode node,
resourceRequests.add(cloneResourceRequest(offRackRequest)); resourceRequests.add(cloneResourceRequest(offRackRequest));
} }


private void decResourceRequest(String resourceName, Priority priority,
ResourceRequest request) {
request.setNumContainers(request.getNumContainers() - 1);
if (request.getNumContainers() == 0) {
requests.get(priority).remove(resourceName);
}
}

/** /**
* The {@link ResourceScheduler} is allocating data-local resources to the * The {@link ResourceScheduler} is allocating data-local resources to the
* application. * application.
Expand All @@ -333,11 +337,8 @@ synchronized private void allocateRackLocal(SchedulerNode node,
Priority priority, ResourceRequest rackLocalRequest, Container container, Priority priority, ResourceRequest rackLocalRequest, Container container,
List<ResourceRequest> resourceRequests) { List<ResourceRequest> resourceRequests) {
// Update future requirements // Update future requirements
rackLocalRequest.setNumContainers(rackLocalRequest.getNumContainers() - 1); decResourceRequest(node.getRackName(), priority, rackLocalRequest);
if (rackLocalRequest.getNumContainers() == 0) {
this.requests.get(priority).remove(node.getRackName());
}

ResourceRequest offRackRequest = requests.get(priority).get( ResourceRequest offRackRequest = requests.get(priority).get(
ResourceRequest.ANY); ResourceRequest.ANY);
decrementOutstanding(offRackRequest); decrementOutstanding(offRackRequest);
Expand Down
Expand Up @@ -153,7 +153,11 @@ public SchedulerApplicationAttempt(ApplicationAttemptId applicationAttemptId,
public synchronized Collection<RMContainer> getLiveContainers() { public synchronized Collection<RMContainer> getLiveContainers() {
return new ArrayList<RMContainer>(liveContainers.values()); return new ArrayList<RMContainer>(liveContainers.values());
} }


public AppSchedulingInfo getAppSchedulingInfo() {
return this.appSchedulingInfo;
}

/** /**
* Is this application pending? * Is this application pending?
* @return true if it is else false. * @return true if it is else false.
Expand Down
Expand Up @@ -35,6 +35,7 @@
import org.apache.hadoop.yarn.api.records.FinalApplicationStatus; import org.apache.hadoop.yarn.api.records.FinalApplicationStatus;
import org.apache.hadoop.yarn.api.records.QueueACL; import org.apache.hadoop.yarn.api.records.QueueACL;
import org.apache.hadoop.yarn.api.records.Resource; import org.apache.hadoop.yarn.api.records.Resource;
import org.apache.hadoop.yarn.api.records.ResourceRequest;
import org.apache.hadoop.yarn.api.records.YarnApplicationState; import org.apache.hadoop.yarn.api.records.YarnApplicationState;
import org.apache.hadoop.yarn.server.resourcemanager.RMContext; import org.apache.hadoop.yarn.server.resourcemanager.RMContext;
import org.apache.hadoop.yarn.server.resourcemanager.ResourceManager; import org.apache.hadoop.yarn.server.resourcemanager.ResourceManager;
Expand All @@ -50,6 +51,7 @@
import org.apache.hadoop.yarn.webapp.hamlet.Hamlet; import org.apache.hadoop.yarn.webapp.hamlet.Hamlet;
import org.apache.hadoop.yarn.webapp.hamlet.Hamlet.DIV; import org.apache.hadoop.yarn.webapp.hamlet.Hamlet.DIV;
import org.apache.hadoop.yarn.webapp.hamlet.Hamlet.TABLE; import org.apache.hadoop.yarn.webapp.hamlet.Hamlet.TABLE;
import org.apache.hadoop.yarn.webapp.hamlet.Hamlet.TBODY;
import org.apache.hadoop.yarn.webapp.util.WebAppUtils; import org.apache.hadoop.yarn.webapp.util.WebAppUtils;
import org.apache.hadoop.yarn.webapp.view.HtmlBlock; import org.apache.hadoop.yarn.webapp.view.HtmlBlock;
import org.apache.hadoop.yarn.webapp.view.InfoBlock; import org.apache.hadoop.yarn.webapp.view.InfoBlock;
Expand Down Expand Up @@ -90,7 +92,8 @@ protected void render(Block html) {
puts("Application not found: "+ aid); puts("Application not found: "+ aid);
return; return;
} }
AppInfo app = new AppInfo(rmApp, true, WebAppUtils.getHttpSchemePrefix(conf)); AppInfo app =
new AppInfo(rm, rmApp, true, WebAppUtils.getHttpSchemePrefix(conf));


// Check for the authorization. // Check for the authorization.
String remoteUser = request().getRemoteUser(); String remoteUser = request().getRemoteUser();
Expand Down Expand Up @@ -134,7 +137,7 @@ protected void render(Block html) {
._("Application Type:", app.getApplicationType()) ._("Application Type:", app.getApplicationType())
._("Application Tags:", app.getApplicationTags()) ._("Application Tags:", app.getApplicationTags())
._("YarnApplicationState:", clarifyAppState(app.getState())) ._("YarnApplicationState:", clarifyAppState(app.getState()))
._("FinalStatus reported by AM:", ._("FinalStatus Reported by AM:",
clairfyAppFinalStatus(app.getFinalStatus())) clairfyAppFinalStatus(app.getFinalStatus()))
._("Started:", Times.format(app.getStartTime())) ._("Started:", Times.format(app.getStartTime()))
._("Elapsed:", ._("Elapsed:",
Expand Down Expand Up @@ -200,6 +203,45 @@ protected void render(Block html) {


table._(); table._();
div._(); div._();

createResourceRequestsTable(html, app);
}

private void createResourceRequestsTable(Block html, AppInfo app) {
TBODY<TABLE<Hamlet>> tbody =
html.table("#ResourceRequests").thead().tr()
.th(".priority", "Priority")
.th(".resourceName", "ResourceName")
.th(".totalResource", "Capability")
.th(".numContainers", "NumContainers")
.th(".relaxLocality", "RelaxLocality")
.th(".nodeLabelExpression", "NodeLabelExpression")._()._().tbody();

Resource totalResource = Resource.newInstance(0, 0);
if (app.getResourceRequests() != null) {
for (ResourceRequest request : app.getResourceRequests()) {
if (request.getNumContainers() == 0) {
continue;
}

tbody.tr()
.td(String.valueOf(request.getPriority()))
.td(request.getResourceName())
.td(String.valueOf(request.getCapability()))
.td(String.valueOf(request.getNumContainers()))
.td(String.valueOf(request.getRelaxLocality()))
.td(request.getNodeLabelExpression() == null ? "N/A" : request
.getNodeLabelExpression())._();
if (request.getResourceName().equals(ResourceRequest.ANY)) {
Resources.addTo(totalResource,
Resources.multiply(request.getCapability(),
request.getNumContainers()));
}
}
}
html.div().$class("totalResourceRequests")
.h3("Total Outstanding Resource Requests: " + totalResource)._();
tbody._()._();
} }


private String clarifyAppState(YarnApplicationState state) { private String clarifyAppState(YarnApplicationState state) {
Expand Down
Expand Up @@ -18,12 +18,16 @@


package org.apache.hadoop.yarn.server.resourcemanager.webapp; package org.apache.hadoop.yarn.server.resourcemanager.webapp;


import static org.apache.hadoop.yarn.webapp.view.JQueryUI.DATATABLES_ID;

import org.apache.hadoop.yarn.webapp.SubView; import org.apache.hadoop.yarn.webapp.SubView;


public class AppPage extends RmView { public class AppPage extends RmView {


@Override protected void preHead(Page.HTML<_> html) { @Override protected void preHead(Page.HTML<_> html) {
commonPreHead(html); commonPreHead(html);
set(DATATABLES_ID, "ResourceRequests");
setTableStyles(html, "ResourceRequests");
} }


@Override protected Class<? extends SubView> content() { @Override protected Class<? extends SubView> content() {
Expand Down
Expand Up @@ -46,12 +46,13 @@
class AppsBlock extends HtmlBlock { class AppsBlock extends HtmlBlock {
final ConcurrentMap<ApplicationId, RMApp> apps; final ConcurrentMap<ApplicationId, RMApp> apps;
private final Configuration conf; private final Configuration conf;

final ResourceManager rm;
@Inject @Inject
AppsBlock(ResourceManager rm, ViewContext ctx, Configuration conf) { AppsBlock(ResourceManager rm, ViewContext ctx, Configuration conf) {
super(ctx); super(ctx);
apps = rm.getRMContext().getRMApps(); apps = rm.getRMContext().getRMApps();
this.conf = conf; this.conf = conf;
this.rm = rm;
} }


@Override public void render(Block html) { @Override public void render(Block html) {
Expand Down Expand Up @@ -85,7 +86,7 @@ class AppsBlock extends HtmlBlock {
if (reqAppStates != null && !reqAppStates.contains(app.createApplicationState())) { if (reqAppStates != null && !reqAppStates.contains(app.createApplicationState())) {
continue; continue;
} }
AppInfo appInfo = new AppInfo(app, true, WebAppUtils.getHttpSchemePrefix(conf)); AppInfo appInfo = new AppInfo(rm, app, true, WebAppUtils.getHttpSchemePrefix(conf));
String percent = String.format("%.1f", appInfo.getProgress()); String percent = String.format("%.1f", appInfo.getProgress());
//AppID numerical value parsed by parseHadoopID in yarn.dt.plugins.js //AppID numerical value parsed by parseHadoopID in yarn.dt.plugins.js
appsTableData.append("[\"<a href='") appsTableData.append("[\"<a href='")
Expand Down
Expand Up @@ -56,7 +56,7 @@ public class FairSchedulerAppsBlock extends HtmlBlock {
final ConcurrentMap<ApplicationId, RMApp> apps; final ConcurrentMap<ApplicationId, RMApp> apps;
final FairSchedulerInfo fsinfo; final FairSchedulerInfo fsinfo;
final Configuration conf; final Configuration conf;

final ResourceManager rm;
@Inject @Inject
public FairSchedulerAppsBlock(ResourceManager rm, ViewContext ctx, public FairSchedulerAppsBlock(ResourceManager rm, ViewContext ctx,
Configuration conf) { Configuration conf) {
Expand All @@ -73,6 +73,7 @@ public FairSchedulerAppsBlock(ResourceManager rm, ViewContext ctx,
} }
} }
this.conf = conf; this.conf = conf;
this.rm = rm;
} }


@Override public void render(Block html) { @Override public void render(Block html) {
Expand Down Expand Up @@ -107,7 +108,7 @@ public FairSchedulerAppsBlock(ResourceManager rm, ViewContext ctx,
if (reqAppStates != null && !reqAppStates.contains(app.createApplicationState())) { if (reqAppStates != null && !reqAppStates.contains(app.createApplicationState())) {
continue; continue;
} }
AppInfo appInfo = new AppInfo(app, true, WebAppUtils.getHttpSchemePrefix(conf)); AppInfo appInfo = new AppInfo(rm, app, true, WebAppUtils.getHttpSchemePrefix(conf));
String percent = String.format("%.1f", appInfo.getProgress()); String percent = String.format("%.1f", appInfo.getProgress());
ApplicationAttemptId attemptId = app.getCurrentAppAttempt().getAppAttemptId(); ApplicationAttemptId attemptId = app.getCurrentAppAttempt().getAppAttemptId();
int fairShare = fsinfo.getAppFairShare(attemptId); int fairShare = fsinfo.getAppFairShare(attemptId);
Expand Down
Expand Up @@ -476,8 +476,8 @@ public AppsInfo getApps(@Context HttpServletRequest hsr,
} }
} }


AppInfo app = new AppInfo(rmapp, hasAccess(rmapp, hsr), AppInfo app = new AppInfo(rm, rmapp,
WebAppUtils.getHttpSchemePrefix(conf)); hasAccess(rmapp, hsr), WebAppUtils.getHttpSchemePrefix(conf));
allApps.add(app); allApps.add(app);
} }
return allApps; return allApps;
Expand Down Expand Up @@ -617,7 +617,7 @@ public AppInfo getApp(@Context HttpServletRequest hsr,
if (app == null) { if (app == null) {
throw new NotFoundException("app with id: " + appId + " not found"); throw new NotFoundException("app with id: " + appId + " not found");
} }
return new AppInfo(app, hasAccess(app, hsr), hsr.getScheme() + "://"); return new AppInfo(rm, app, hasAccess(app, hsr), hsr.getScheme() + "://");
} }


@GET @GET
Expand Down
Expand Up @@ -17,6 +17,8 @@
*/ */
package org.apache.hadoop.yarn.server.resourcemanager.webapp.dao; package org.apache.hadoop.yarn.server.resourcemanager.webapp.dao;


import java.util.List;

import javax.xml.bind.annotation.XmlAccessType; import javax.xml.bind.annotation.XmlAccessType;
import javax.xml.bind.annotation.XmlAccessorType; import javax.xml.bind.annotation.XmlAccessorType;
import javax.xml.bind.annotation.XmlRootElement; import javax.xml.bind.annotation.XmlRootElement;
Expand All @@ -27,11 +29,13 @@
import org.apache.hadoop.yarn.api.records.Container; import org.apache.hadoop.yarn.api.records.Container;
import org.apache.hadoop.yarn.api.records.FinalApplicationStatus; import org.apache.hadoop.yarn.api.records.FinalApplicationStatus;
import org.apache.hadoop.yarn.api.records.Resource; import org.apache.hadoop.yarn.api.records.Resource;
import org.apache.hadoop.yarn.api.records.ResourceRequest;
import org.apache.hadoop.yarn.api.records.YarnApplicationState; import org.apache.hadoop.yarn.api.records.YarnApplicationState;
import org.apache.hadoop.yarn.server.resourcemanager.ResourceManager; import org.apache.hadoop.yarn.server.resourcemanager.ResourceManager;
import org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMApp; import org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMApp;
import org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppMetrics; import org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppMetrics;
import org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttempt; import org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttempt;
import org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler;
import org.apache.hadoop.yarn.util.ConverterUtils; import org.apache.hadoop.yarn.util.ConverterUtils;
import org.apache.hadoop.yarn.util.Times; import org.apache.hadoop.yarn.util.Times;
import org.apache.hadoop.yarn.webapp.util.WebAppUtils; import org.apache.hadoop.yarn.webapp.util.WebAppUtils;
Expand Down Expand Up @@ -88,10 +92,14 @@ public class AppInfo {
protected int numNonAMContainerPreempted; protected int numNonAMContainerPreempted;
protected int numAMContainerPreempted; protected int numAMContainerPreempted;


protected List<ResourceRequest> resourceRequests;

public AppInfo() { public AppInfo() {
} // JAXB needs this } // JAXB needs this


public AppInfo(RMApp app, Boolean hasAccess, String schemePrefix) { @SuppressWarnings({ "rawtypes", "unchecked" })
public AppInfo(ResourceManager rm, RMApp app, Boolean hasAccess,
String schemePrefix) {
this.schemePrefix = schemePrefix; this.schemePrefix = schemePrefix;
if (app != null) { if (app != null) {
String trackingUrl = app.getTrackingUrl(); String trackingUrl = app.getTrackingUrl();
Expand Down Expand Up @@ -154,6 +162,9 @@ public AppInfo(RMApp app, Boolean hasAccess, String schemePrefix) {
allocatedVCores = usedResources.getVirtualCores(); allocatedVCores = usedResources.getVirtualCores();
runningContainers = resourceReport.getNumUsedContainers(); runningContainers = resourceReport.getNumUsedContainers();
} }
resourceRequests =
((AbstractYarnScheduler) rm.getRMContext().getScheduler())
.getPendingResourceRequestsForAttempt(attempt.getAppAttemptId());
} }
} }


Expand Down Expand Up @@ -299,4 +310,8 @@ public long getMemorySeconds() {
public long getVcoreSeconds() { public long getVcoreSeconds() {
return vcoreSeconds; return vcoreSeconds;
} }

public List<ResourceRequest> getResourceRequests() {
return this.resourceRequests;
}
} }

0 comments on commit edceced

Please sign in to comment.