Uses of Class
org.apache.hadoop.mapred.JobID

Packages that use JobID
org.apache.hadoop.mapred A software framework for easily writing applications which process vast amounts of data (multi-terabyte data-sets) parallelly on large clusters (thousands of nodes) built of commodity hardware in a reliable, fault-tolerant manner. 
org.apache.hadoop.mapred.jobcontrol Utilities for managing dependent jobs. 
org.apache.hadoop.streaming Hadoop Streaming is a utility which allows users to create and run Map-Reduce jobs with any executables (e.g. 
 

Uses of JobID in org.apache.hadoop.mapred
 

Methods in org.apache.hadoop.mapred that return JobID
static JobID JobID.forName(String str)
          Construct a JobId object from given string
 JobID RunningJob.getID()
          Get the job identifier.
 JobID TaskID.getJobID()
          Returns the JobID object that this tip belongs to
 JobID JobProfile.getJobID()
          Get the job id.
 JobID JobStatus.getJobID()
           
 JobID TaskAttemptID.getJobID()
          Returns the JobID object that this task attempt belongs to
 JobID JobTracker.getNewJobId()
          Allocates a new JobId string.
static JobID JobID.read(DataInput in)
           
 

Methods in org.apache.hadoop.mapred with parameters of type JobID
 RunningJob JobClient.getJob(JobID jobid)
          Get an RunningJob object to track an ongoing job.
 org.apache.hadoop.mapred.JobInProgress JobTracker.getJob(JobID jobid)
           
 Counters JobTracker.getJobCounters(JobID jobid)
           
 JobProfile JobTracker.getJobProfile(JobID jobid)
           
 JobStatus JobTracker.getJobStatus(JobID jobid)
           
static String JobHistory.JobInfo.getLocalJobFilePath(JobID jobId)
          Get the path of the locally stored job file
static String JobTracker.getLocalJobFilePath(JobID jobId)
          Get the localized job file path on the job trackers local file system
 TaskCompletionEvent[] TaskTracker.getMapCompletionEvents(JobID jobId, int fromEventId, int maxLocs)
           
 TaskReport[] JobClient.getMapTaskReports(JobID jobId)
          Get the information of the current state of the map tasks of a job.
 TaskReport[] JobTracker.getMapTaskReports(JobID jobid)
           
 TaskReport[] JobClient.getReduceTaskReports(JobID jobId)
          Get the information of the current state of the reduce tasks of a job.
 TaskReport[] JobTracker.getReduceTaskReports(JobID jobid)
           
 TaskCompletionEvent[] JobTracker.getTaskCompletionEvents(JobID jobid, int fromEventId, int maxEvents)
           
 void JobTracker.killJob(JobID jobid)
           
static void JobHistory.JobInfo.logFailed(JobID jobid, long timestamp, int finishedMaps, int finishedReduces)
          Logs job failed event.
static void JobHistory.JobInfo.logFinished(JobID jobId, long finishTime, int finishedMaps, int finishedReduces, int failedMaps, int failedReduces, Counters counters)
          Log job finished.
static void JobHistory.JobInfo.logStarted(JobID jobId, long startTime, int totalMaps, int totalReduces)
          Logs launch time of job.
static void JobHistory.JobInfo.logSubmitted(JobID jobId, JobConf jobConf, String jobConfPath, long submitTime)
          Log job submitted event to history.
 JobStatus JobTracker.submitJob(JobID jobId)
          JobTracker.submitJob() kicks off a new job.
 

Constructors in org.apache.hadoop.mapred with parameters of type JobID
JobProfile(String user, JobID jobid, String jobFile, String url, String name)
          Construct a JobProfile the userid, jobid, job config-file, job-details url and job name.
JobStatus(JobID jobid, float mapProgress, float reduceProgress, int runState)
          Create a job status object for a given jobid.
TaskID(JobID jobId, boolean isMap, int id)
          Constructs a TaskID object from given JobID.
 

Uses of JobID in org.apache.hadoop.mapred.jobcontrol
 

Methods in org.apache.hadoop.mapred.jobcontrol that return JobID
 JobID Job.getAssignedJobID()
           
 

Methods in org.apache.hadoop.mapred.jobcontrol with parameters of type JobID
 void Job.setAssignedJobID(JobID mapredJobID)
          Set the mapred ID for this job as assigned by the mapred framework.
 

Uses of JobID in org.apache.hadoop.streaming
 

Fields in org.apache.hadoop.streaming declared as JobID
protected  JobID StreamJob.jobId_
           
 



Copyright © 2008 The Apache Software Foundation