org.apache.hadoop.mapred
Class ResourceMgrDelegate

java.lang.Object
  extended by org.apache.hadoop.yarn.service.AbstractService
      extended by org.apache.hadoop.yarn.client.YarnClientImpl
          extended by org.apache.hadoop.mapred.ResourceMgrDelegate
All Implemented Interfaces:
org.apache.hadoop.yarn.client.YarnClient, org.apache.hadoop.yarn.service.Service

public class ResourceMgrDelegate
extends org.apache.hadoop.yarn.client.YarnClientImpl


Nested Class Summary
 
Nested classes/interfaces inherited from interface org.apache.hadoop.yarn.service.Service
org.apache.hadoop.yarn.service.Service.STATE
 
Field Summary
 
Fields inherited from class org.apache.hadoop.yarn.client.YarnClientImpl
rmAddress, rmClient
 
Constructor Summary
ResourceMgrDelegate(org.apache.hadoop.yarn.conf.YarnConfiguration conf)
          Delegate responsible for communicating with the Resource Manager's ClientRMProtocol.
 
Method Summary
 void cancelDelegationToken(org.apache.hadoop.security.token.Token<org.apache.hadoop.mapreduce.security.token.delegation.DelegationTokenIdentifier> arg0)
           
 org.apache.hadoop.mapreduce.TaskTrackerInfo[] getActiveTrackers()
           
 org.apache.hadoop.mapreduce.JobStatus[] getAllJobs()
           
 org.apache.hadoop.yarn.api.records.ApplicationId getApplicationId()
           
 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()
           
 long renewDelegationToken(org.apache.hadoop.security.token.Token<org.apache.hadoop.mapreduce.security.token.delegation.DelegationTokenIdentifier> arg0)
           
 void setJobPriority(org.apache.hadoop.mapreduce.JobID arg0, String arg1)
           
 
Methods inherited from class org.apache.hadoop.yarn.client.YarnClientImpl
getAllQueues, getApplicationList, getApplicationReport, getChildQueueInfos, getNewApplication, getNodeReports, getQueueAclsInfo, getQueueInfo, getRMDelegationToken, getRootQueueInfos, getYarnClusterMetrics, init, killApplication, start, stop, submitApplication
 
Methods inherited from class org.apache.hadoop.yarn.service.AbstractService
getConfig, getName, getServiceState, getStartTime, register, unregister
 
Methods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
 
Methods inherited from interface org.apache.hadoop.yarn.service.Service
getConfig, getName, getServiceState, getStartTime, register, unregister
 

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.
Method Detail

cancelDelegationToken

public void cancelDelegationToken(org.apache.hadoop.security.token.Token<org.apache.hadoop.mapreduce.security.token.delegation.DelegationTokenIdentifier> arg0)
                           throws IOException,
                                  InterruptedException
Throws:
IOException
InterruptedException

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

renewDelegationToken

public long renewDelegationToken(org.apache.hadoop.security.token.Token<org.apache.hadoop.mapreduce.security.token.delegation.DelegationTokenIdentifier> arg0)
                          throws IOException,
                                 InterruptedException
Throws:
IOException
InterruptedException

getApplicationId

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


Copyright © 2012 Apache Software Foundation. All Rights Reserved.