public class ResourceMgrDelegate extends Object
Constructor and Description |
---|
ResourceMgrDelegate(org.apache.hadoop.yarn.conf.YarnConfiguration conf)
Delegate responsible for communicating with the Resource Manager's
ClientRMProtocol . |
ResourceMgrDelegate(org.apache.hadoop.yarn.conf.YarnConfiguration conf,
org.apache.hadoop.yarn.api.ClientRMProtocol applicationsManager)
Used for injecting applicationsManager, mostly for testing.
|
Modifier and Type | Method and Description |
---|---|
org.apache.hadoop.mapreduce.TaskTrackerInfo[] |
getActiveTrackers() |
org.apache.hadoop.mapreduce.JobStatus[] |
getAllJobs() |
org.apache.hadoop.yarn.api.records.ApplicationId |
getApplicationId() |
org.apache.hadoop.yarn.api.records.ApplicationReport |
getApplicationReport(org.apache.hadoop.yarn.api.records.ApplicationId appId) |
org.apache.hadoop.mapreduce.TaskTrackerInfo[] |
getBlacklistedTrackers() |
org.apache.hadoop.mapreduce.QueueInfo[] |
getChildQueues(String parent) |
org.apache.hadoop.mapreduce.ClusterMetrics |
getClusterMetrics() |
org.apache.hadoop.security.token.Token |
getDelegationToken(org.apache.hadoop.io.Text renewer) |
String |
getFilesystemName() |
org.apache.hadoop.mapreduce.JobID |
getNewJobID() |
long |
getProtocolVersion(String arg0,
long arg1) |
org.apache.hadoop.mapreduce.QueueInfo |
getQueue(String queueName) |
org.apache.hadoop.mapreduce.QueueAclsInfo[] |
getQueueAclsForCurrentUser() |
org.apache.hadoop.mapreduce.QueueInfo[] |
getQueues() |
org.apache.hadoop.mapreduce.QueueInfo[] |
getRootQueues() |
String |
getStagingAreaDir() |
String |
getSystemDir() |
long |
getTaskTrackerExpiryInterval() |
void |
killApplication(org.apache.hadoop.yarn.api.records.ApplicationId applicationId) |
void |
setJobPriority(org.apache.hadoop.mapreduce.JobID arg0,
String arg1) |
org.apache.hadoop.yarn.api.records.ApplicationId |
submitApplication(org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext appContext) |
public ResourceMgrDelegate(org.apache.hadoop.yarn.conf.YarnConfiguration conf)
ClientRMProtocol
.conf
- the configuration object.public ResourceMgrDelegate(org.apache.hadoop.yarn.conf.YarnConfiguration conf, org.apache.hadoop.yarn.api.ClientRMProtocol applicationsManager)
conf
- the configuration objectapplicationsManager
- the handle to talk the resource managers
ClientRMProtocol
.public org.apache.hadoop.mapreduce.TaskTrackerInfo[] getActiveTrackers() throws IOException, InterruptedException
IOException
InterruptedException
public org.apache.hadoop.mapreduce.JobStatus[] getAllJobs() throws IOException, InterruptedException
IOException
InterruptedException
public org.apache.hadoop.mapreduce.TaskTrackerInfo[] getBlacklistedTrackers() throws IOException, InterruptedException
IOException
InterruptedException
public org.apache.hadoop.mapreduce.ClusterMetrics getClusterMetrics() throws IOException, InterruptedException
IOException
InterruptedException
public org.apache.hadoop.security.token.Token getDelegationToken(org.apache.hadoop.io.Text renewer) throws IOException, InterruptedException
IOException
InterruptedException
public String getFilesystemName() throws IOException, InterruptedException
IOException
InterruptedException
public org.apache.hadoop.mapreduce.JobID getNewJobID() throws IOException, InterruptedException
IOException
InterruptedException
public org.apache.hadoop.mapreduce.QueueInfo getQueue(String queueName) throws IOException, InterruptedException
IOException
InterruptedException
public org.apache.hadoop.mapreduce.QueueAclsInfo[] getQueueAclsForCurrentUser() throws IOException, InterruptedException
IOException
InterruptedException
public org.apache.hadoop.mapreduce.QueueInfo[] getQueues() throws IOException, InterruptedException
IOException
InterruptedException
public org.apache.hadoop.mapreduce.QueueInfo[] getRootQueues() throws IOException, InterruptedException
IOException
InterruptedException
public org.apache.hadoop.mapreduce.QueueInfo[] getChildQueues(String parent) throws IOException, InterruptedException
IOException
InterruptedException
public String getStagingAreaDir() throws IOException, InterruptedException
IOException
InterruptedException
public String getSystemDir() throws IOException, InterruptedException
IOException
InterruptedException
public long getTaskTrackerExpiryInterval() throws IOException, InterruptedException
IOException
InterruptedException
public void setJobPriority(org.apache.hadoop.mapreduce.JobID arg0, String arg1) throws IOException, InterruptedException
IOException
InterruptedException
public long getProtocolVersion(String arg0, long arg1) throws IOException
IOException
public org.apache.hadoop.yarn.api.records.ApplicationId submitApplication(org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext appContext) throws IOException
IOException
public void killApplication(org.apache.hadoop.yarn.api.records.ApplicationId applicationId) throws IOException
IOException
public org.apache.hadoop.yarn.api.records.ApplicationReport getApplicationReport(org.apache.hadoop.yarn.api.records.ApplicationId appId) throws org.apache.hadoop.yarn.exceptions.YarnRemoteException
org.apache.hadoop.yarn.exceptions.YarnRemoteException
public org.apache.hadoop.yarn.api.records.ApplicationId getApplicationId()
Copyright © 2013 Apache Software Foundation. All Rights Reserved.