| 
 | ||||||||||
| PREV CLASS NEXT CLASS | FRAMES NO FRAMES | |||||||||
| SUMMARY: NESTED | FIELD | CONSTR | METHOD | DETAIL: FIELD | CONSTR | METHOD | |||||||||
java.lang.Objectorg.apache.hadoop.mapred.LocalJobRunner
@InterfaceAudience.Private @InterfaceStability.Unstable public class LocalJobRunner
Implements MapReduce locally, in-process, for debugging.
| Field Summary | |
|---|---|
| static String | LOCAL_MAX_MAPSThe maximum number of map tasks to run in parallel in LocalJobRunner | 
| static org.apache.commons.logging.Log | LOG | 
| Fields inherited from interface org.apache.hadoop.mapreduce.protocol.ClientProtocol | 
|---|
| versionID | 
| Constructor Summary | |
|---|---|
| LocalJobRunner(org.apache.hadoop.conf.Configuration conf) | |
| LocalJobRunner(org.apache.hadoop.mapred.JobConf conf)Deprecated. | |
| Method Summary | |
|---|---|
|  void | cancelDelegationToken(org.apache.hadoop.security.token.Token<org.apache.hadoop.mapreduce.security.token.delegation.DelegationTokenIdentifier> token) | 
|  org.apache.hadoop.mapreduce.TaskTrackerInfo[] | getActiveTrackers()Get all active trackers in cluster. | 
|  org.apache.hadoop.mapreduce.JobStatus[] | getAllJobs() | 
|  org.apache.hadoop.mapreduce.TaskTrackerInfo[] | getBlacklistedTrackers()Get all blacklisted trackers in cluster. | 
|  org.apache.hadoop.mapreduce.QueueInfo[] | getChildQueues(String queueName) | 
|  org.apache.hadoop.mapreduce.ClusterMetrics | getClusterMetrics() | 
|  org.apache.hadoop.security.token.Token<org.apache.hadoop.mapreduce.security.token.delegation.DelegationTokenIdentifier> | getDelegationToken(org.apache.hadoop.io.Text renewer) | 
|  String | getFilesystemName() | 
|  org.apache.hadoop.mapreduce.Counters | getJobCounters(org.apache.hadoop.mapreduce.JobID id) | 
|  String | getJobHistoryDir() | 
|  org.apache.hadoop.mapreduce.JobStatus | getJobStatus(org.apache.hadoop.mapreduce.JobID id) | 
|  org.apache.hadoop.mapreduce.Cluster.JobTrackerStatus | getJobTrackerStatus() | 
| static int | getLocalMaxRunningMaps(org.apache.hadoop.mapreduce.JobContext job) | 
|  org.apache.hadoop.mapreduce.v2.LogParams | getLogFileParams(org.apache.hadoop.mapreduce.JobID jobID,
                 org.apache.hadoop.mapreduce.TaskAttemptID taskAttemptID) | 
|  org.apache.hadoop.mapreduce.JobID | getNewJobID() | 
|  org.apache.hadoop.ipc.ProtocolSignature | getProtocolSignature(String protocol,
                     long clientVersion,
                     int clientMethodsHash) | 
|  long | getProtocolVersion(String protocol,
                   long clientVersion) | 
|  org.apache.hadoop.mapreduce.QueueInfo | getQueue(String queue) | 
|  org.apache.hadoop.mapreduce.QueueAclsInfo[] | getQueueAclsForCurrentUser() | 
|  org.apache.hadoop.security.authorize.AccessControlList | getQueueAdmins(String queueName) | 
|  org.apache.hadoop.mapreduce.QueueInfo[] | getQueues() | 
|  org.apache.hadoop.mapreduce.QueueInfo[] | getRootQueues() | 
|  String | getStagingAreaDir() | 
|  String | getSystemDir() | 
|  org.apache.hadoop.mapreduce.TaskCompletionEvent[] | getTaskCompletionEvents(org.apache.hadoop.mapreduce.JobID jobid,
                        int fromEventId,
                        int maxEvents) | 
|  String[] | getTaskDiagnostics(org.apache.hadoop.mapreduce.TaskAttemptID taskid)Returns the diagnostic information for a particular task in the given job. | 
|  org.apache.hadoop.mapreduce.TaskReport[] | getTaskReports(org.apache.hadoop.mapreduce.JobID id,
               org.apache.hadoop.mapreduce.TaskType type) | 
|  long | getTaskTrackerExpiryInterval() | 
|  void | killJob(org.apache.hadoop.mapreduce.JobID id) | 
|  boolean | killTask(org.apache.hadoop.mapreduce.TaskAttemptID taskId,
         boolean shouldFail)Throws UnsupportedOperationException | 
|  long | renewDelegationToken(org.apache.hadoop.security.token.Token<org.apache.hadoop.mapreduce.security.token.delegation.DelegationTokenIdentifier> token) | 
|  void | setJobPriority(org.apache.hadoop.mapreduce.JobID id,
               String jp) | 
| static void | setLocalMaxRunningMaps(org.apache.hadoop.mapreduce.JobContext job,
                       int maxMaps)Set the max number of map tasks to run concurrently in the LocalJobRunner. | 
|  org.apache.hadoop.mapreduce.JobStatus | submitJob(org.apache.hadoop.mapreduce.JobID jobid,
          String jobSubmitDir,
          org.apache.hadoop.security.Credentials credentials) | 
| Methods inherited from class java.lang.Object | 
|---|
| clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait | 
| Field Detail | 
|---|
public static final org.apache.commons.logging.Log LOG
public static final String LOCAL_MAX_MAPS
| Constructor Detail | 
|---|
public LocalJobRunner(org.apache.hadoop.conf.Configuration conf)
               throws IOException
IOException
@Deprecated
public LocalJobRunner(org.apache.hadoop.mapred.JobConf conf)
               throws IOException
IOException| Method Detail | 
|---|
public long getProtocolVersion(String protocol,
                               long clientVersion)
getProtocolVersion in interface org.apache.hadoop.ipc.VersionedProtocol
public org.apache.hadoop.ipc.ProtocolSignature getProtocolSignature(String protocol,
                                                                    long clientVersion,
                                                                    int clientMethodsHash)
                                                             throws IOException
getProtocolSignature in interface org.apache.hadoop.ipc.VersionedProtocolIOExceptionpublic org.apache.hadoop.mapreduce.JobID getNewJobID()
getNewJobID in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
public org.apache.hadoop.mapreduce.JobStatus submitJob(org.apache.hadoop.mapreduce.JobID jobid,
                                                       String jobSubmitDir,
                                                       org.apache.hadoop.security.Credentials credentials)
                                                throws IOException
submitJob in interface org.apache.hadoop.mapreduce.protocol.ClientProtocolIOExceptionpublic void killJob(org.apache.hadoop.mapreduce.JobID id)
killJob in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
public void setJobPriority(org.apache.hadoop.mapreduce.JobID id,
                           String jp)
                    throws IOException
setJobPriority in interface org.apache.hadoop.mapreduce.protocol.ClientProtocolIOException
public boolean killTask(org.apache.hadoop.mapreduce.TaskAttemptID taskId,
                        boolean shouldFail)
                 throws IOException
UnsupportedOperationException
killTask in interface org.apache.hadoop.mapreduce.protocol.ClientProtocolIOException
public org.apache.hadoop.mapreduce.TaskReport[] getTaskReports(org.apache.hadoop.mapreduce.JobID id,
                                                               org.apache.hadoop.mapreduce.TaskType type)
getTaskReports in interface org.apache.hadoop.mapreduce.protocol.ClientProtocolpublic org.apache.hadoop.mapreduce.JobStatus getJobStatus(org.apache.hadoop.mapreduce.JobID id)
getJobStatus in interface org.apache.hadoop.mapreduce.protocol.ClientProtocolpublic org.apache.hadoop.mapreduce.Counters getJobCounters(org.apache.hadoop.mapreduce.JobID id)
getJobCounters in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
public String getFilesystemName()
                         throws IOException
getFilesystemName in interface org.apache.hadoop.mapreduce.protocol.ClientProtocolIOExceptionpublic org.apache.hadoop.mapreduce.ClusterMetrics getClusterMetrics()
getClusterMetrics in interface org.apache.hadoop.mapreduce.protocol.ClientProtocolpublic org.apache.hadoop.mapreduce.Cluster.JobTrackerStatus getJobTrackerStatus()
getJobTrackerStatus in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
public long getTaskTrackerExpiryInterval()
                                  throws IOException,
                                         InterruptedException
getTaskTrackerExpiryInterval in interface org.apache.hadoop.mapreduce.protocol.ClientProtocolIOException
InterruptedException
public org.apache.hadoop.mapreduce.TaskTrackerInfo[] getActiveTrackers()
                                                                throws IOException,
                                                                       InterruptedException
getActiveTrackers in interface org.apache.hadoop.mapreduce.protocol.ClientProtocolIOException
InterruptedException
public org.apache.hadoop.mapreduce.TaskTrackerInfo[] getBlacklistedTrackers()
                                                                     throws IOException,
                                                                            InterruptedException
getBlacklistedTrackers in interface org.apache.hadoop.mapreduce.protocol.ClientProtocolIOException
InterruptedException
public org.apache.hadoop.mapreduce.TaskCompletionEvent[] getTaskCompletionEvents(org.apache.hadoop.mapreduce.JobID jobid,
                                                                                 int fromEventId,
                                                                                 int maxEvents)
                                                                          throws IOException
getTaskCompletionEvents in interface org.apache.hadoop.mapreduce.protocol.ClientProtocolIOExceptionpublic org.apache.hadoop.mapreduce.JobStatus[] getAllJobs()
getAllJobs in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
public String[] getTaskDiagnostics(org.apache.hadoop.mapreduce.TaskAttemptID taskid)
                            throws IOException
getTaskDiagnostics in interface org.apache.hadoop.mapreduce.protocol.ClientProtocolIOExceptionpublic String getSystemDir()
getSystemDir in interface org.apache.hadoop.mapreduce.protocol.ClientProtocolClientProtocol.getSystemDir()
public org.apache.hadoop.security.authorize.AccessControlList getQueueAdmins(String queueName)
                                                                      throws IOException
getQueueAdmins in interface org.apache.hadoop.mapreduce.protocol.ClientProtocolIOExceptionClientProtocol.getQueueAdmins(String)
public String getStagingAreaDir()
                         throws IOException
getStagingAreaDir in interface org.apache.hadoop.mapreduce.protocol.ClientProtocolIOExceptionClientProtocol.getStagingAreaDir()public String getJobHistoryDir()
getJobHistoryDir in interface org.apache.hadoop.mapreduce.protocol.ClientProtocol
public org.apache.hadoop.mapreduce.QueueInfo[] getChildQueues(String queueName)
                                                       throws IOException
getChildQueues in interface org.apache.hadoop.mapreduce.protocol.ClientProtocolIOException
public org.apache.hadoop.mapreduce.QueueInfo[] getRootQueues()
                                                      throws IOException
getRootQueues in interface org.apache.hadoop.mapreduce.protocol.ClientProtocolIOException
public org.apache.hadoop.mapreduce.QueueInfo[] getQueues()
                                                  throws IOException
getQueues in interface org.apache.hadoop.mapreduce.protocol.ClientProtocolIOException
public org.apache.hadoop.mapreduce.QueueInfo getQueue(String queue)
                                               throws IOException
getQueue in interface org.apache.hadoop.mapreduce.protocol.ClientProtocolIOException
public org.apache.hadoop.mapreduce.QueueAclsInfo[] getQueueAclsForCurrentUser()
                                                                       throws IOException
getQueueAclsForCurrentUser in interface org.apache.hadoop.mapreduce.protocol.ClientProtocolIOException
public static void setLocalMaxRunningMaps(org.apache.hadoop.mapreduce.JobContext job,
                                          int maxMaps)
job - the job to configuremaxMaps - the maximum number of map tasks to allow.public static int getLocalMaxRunningMaps(org.apache.hadoop.mapreduce.JobContext job)
public void cancelDelegationToken(org.apache.hadoop.security.token.Token<org.apache.hadoop.mapreduce.security.token.delegation.DelegationTokenIdentifier> token)
                           throws IOException,
                                  InterruptedException
cancelDelegationToken in interface org.apache.hadoop.mapreduce.protocol.ClientProtocolIOException
InterruptedException
public org.apache.hadoop.security.token.Token<org.apache.hadoop.mapreduce.security.token.delegation.DelegationTokenIdentifier> getDelegationToken(org.apache.hadoop.io.Text renewer)
                                                                                                                                           throws IOException,
                                                                                                                                                  InterruptedException
getDelegationToken in interface org.apache.hadoop.mapreduce.protocol.ClientProtocolIOException
InterruptedException
public long renewDelegationToken(org.apache.hadoop.security.token.Token<org.apache.hadoop.mapreduce.security.token.delegation.DelegationTokenIdentifier> token)
                          throws IOException,
                                 InterruptedException
renewDelegationToken in interface org.apache.hadoop.mapreduce.protocol.ClientProtocolIOException
InterruptedException
public org.apache.hadoop.mapreduce.v2.LogParams getLogFileParams(org.apache.hadoop.mapreduce.JobID jobID,
                                                                 org.apache.hadoop.mapreduce.TaskAttemptID taskAttemptID)
                                                          throws IOException,
                                                                 InterruptedException
getLogFileParams in interface org.apache.hadoop.mapreduce.protocol.ClientProtocolIOException
InterruptedException| 
 | ||||||||||
| PREV CLASS NEXT CLASS | FRAMES NO FRAMES | |||||||||
| SUMMARY: NESTED | FIELD | CONSTR | METHOD | DETAIL: FIELD | CONSTR | METHOD | |||||||||