org.apache.hadoop.mapred
Class ResourceMgrDelegate

java.lang.Object
  extended by org.apache.hadoop.mapred.ResourceMgrDelegate

public class ResourceMgrDelegate
extends Object


Constructor Summary
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.
 
Method Summary
 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)
           
 
Methods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
 

Constructor Detail

ResourceMgrDelegate

public ResourceMgrDelegate(org.apache.hadoop.yarn.conf.YarnConfiguration conf)
Delegate responsible for communicating with the Resource Manager's ClientRMProtocol.

Parameters:
conf - the configuration object.

ResourceMgrDelegate

public ResourceMgrDelegate(org.apache.hadoop.yarn.conf.YarnConfiguration conf,
                           org.apache.hadoop.yarn.api.ClientRMProtocol applicationsManager)
Used for injecting applicationsManager, mostly for testing.

Parameters:
conf - the configuration object
applicationsManager - the handle to talk the resource managers ClientRMProtocol.
Method Detail

getActiveTrackers

public org.apache.hadoop.mapreduce.TaskTrackerInfo[] getActiveTrackers()
                                                                throws IOException,
                                                                       InterruptedException
Throws:
IOException
InterruptedException

getAllJobs

public org.apache.hadoop.mapreduce.JobStatus[] getAllJobs()
                                                   throws IOException,
                                                          InterruptedException
Throws:
IOException
InterruptedException

getBlacklistedTrackers

public org.apache.hadoop.mapreduce.TaskTrackerInfo[] getBlacklistedTrackers()
                                                                     throws IOException,
                                                                            InterruptedException
Throws:
IOException
InterruptedException

getClusterMetrics

public org.apache.hadoop.mapreduce.ClusterMetrics getClusterMetrics()
                                                             throws IOException,
                                                                    InterruptedException
Throws:
IOException
InterruptedException

getDelegationToken

public org.apache.hadoop.security.token.Token getDelegationToken(org.apache.hadoop.io.Text renewer)
                                                          throws IOException,
                                                                 InterruptedException
Throws:
IOException
InterruptedException

getFilesystemName

public String getFilesystemName()
                         throws IOException,
                                InterruptedException
Throws:
IOException
InterruptedException

getNewJobID

public org.apache.hadoop.mapreduce.JobID getNewJobID()
                                              throws IOException,
                                                     InterruptedException
Throws:
IOException
InterruptedException

getQueue

public org.apache.hadoop.mapreduce.QueueInfo getQueue(String queueName)
                                               throws IOException,
                                                      InterruptedException
Throws:
IOException
InterruptedException

getQueueAclsForCurrentUser

public org.apache.hadoop.mapreduce.QueueAclsInfo[] getQueueAclsForCurrentUser()
                                                                       throws IOException,
                                                                              InterruptedException
Throws:
IOException
InterruptedException

getQueues

public org.apache.hadoop.mapreduce.QueueInfo[] getQueues()
                                                  throws IOException,
                                                         InterruptedException
Throws:
IOException
InterruptedException

getRootQueues

public org.apache.hadoop.mapreduce.QueueInfo[] getRootQueues()
                                                      throws IOException,
                                                             InterruptedException
Throws:
IOException
InterruptedException

getChildQueues

public org.apache.hadoop.mapreduce.QueueInfo[] getChildQueues(String parent)
                                                       throws IOException,
                                                              InterruptedException
Throws:
IOException
InterruptedException

getStagingAreaDir

public String getStagingAreaDir()
                         throws IOException,
                                InterruptedException
Throws:
IOException
InterruptedException

getSystemDir

public String getSystemDir()
                    throws IOException,
                           InterruptedException
Throws:
IOException
InterruptedException

getTaskTrackerExpiryInterval

public long getTaskTrackerExpiryInterval()
                                  throws IOException,
                                         InterruptedException
Throws:
IOException
InterruptedException

setJobPriority

public void setJobPriority(org.apache.hadoop.mapreduce.JobID arg0,
                           String arg1)
                    throws IOException,
                           InterruptedException
Throws:
IOException
InterruptedException

getProtocolVersion

public long getProtocolVersion(String arg0,
                               long arg1)
                        throws IOException
Throws:
IOException

submitApplication

public org.apache.hadoop.yarn.api.records.ApplicationId submitApplication(org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext appContext)
                                                                   throws IOException
Throws:
IOException

killApplication

public void killApplication(org.apache.hadoop.yarn.api.records.ApplicationId applicationId)
                     throws IOException
Throws:
IOException

getApplicationReport

public org.apache.hadoop.yarn.api.records.ApplicationReport getApplicationReport(org.apache.hadoop.yarn.api.records.ApplicationId appId)
                                                                          throws org.apache.hadoop.yarn.exceptions.YarnRemoteException
Throws:
org.apache.hadoop.yarn.exceptions.YarnRemoteException

getApplicationId

public org.apache.hadoop.yarn.api.records.ApplicationId getApplicationId()


Copyright © 2013 Apache Software Foundation. All Rights Reserved.