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

Packages that use JobID
org.apache.hadoop.mapred   
org.apache.hadoop.mapreduce   
org.apache.hadoop.mapreduce.lib.jobcontrol   
 

Uses of JobID in org.apache.hadoop.mapred
 

Subclasses of JobID in org.apache.hadoop.mapred
 class JobID
          JobID represents the immutable and unique identifier for the job.
 

Methods in org.apache.hadoop.mapred with parameters of type JobID
static JobID JobID.downgrade(JobID old)
          Downgrade a new JobID to an old one
 

Constructors in org.apache.hadoop.mapred with parameters of type JobID
TaskID(JobID jobId, boolean isMap, int id)
          Deprecated. Use TaskID.TaskID(String, int, TaskType, int)
TaskID(JobID jobId, TaskType type, int id)
          Constructs a TaskID object from given JobID.
 

Uses of JobID in org.apache.hadoop.mapreduce
 

Methods in org.apache.hadoop.mapreduce that return JobID
static JobID JobID.forName(String str)
          Construct a JobId object from given string
 JobID TaskAttemptID.getJobID()
          Returns the JobID object that this task attempt belongs to
 JobID JobStatus.getJobID()
           
 JobID TaskID.getJobID()
          Returns the JobID object that this tip belongs to
 JobID JobContext.getJobID()
          Get the unique ID for the job.
 

Methods in org.apache.hadoop.mapreduce with parameters of type JobID
 Job Cluster.getJob(JobID jobId)
          Get job corresponding to jobid.
 String Cluster.getJobHistoryUrl(JobID jobId)
          Get the job history file path for a given job id.
 org.apache.hadoop.mapreduce.v2.LogParams Cluster.getLogParams(JobID jobID, TaskAttemptID taskAttemptID)
          Get log parameters for the specified jobID or taskAttemptID
 

Constructors in org.apache.hadoop.mapreduce with parameters of type JobID
JobStatus(JobID jobid, float setupProgress, float mapProgress, float reduceProgress, float cleanupProgress, org.apache.hadoop.mapreduce.JobStatus.State runState, JobPriority jp, String user, String jobName, String jobFile, String trackingUrl)
          Create a job status object for a given jobid.
JobStatus(JobID jobid, float setupProgress, float mapProgress, float reduceProgress, float cleanupProgress, org.apache.hadoop.mapreduce.JobStatus.State runState, JobPriority jp, String user, String jobName, String queue, String jobFile, String trackingUrl)
          Create a job status object for a given jobid.
JobStatus(JobID jobid, float setupProgress, float mapProgress, float reduceProgress, float cleanupProgress, org.apache.hadoop.mapreduce.JobStatus.State runState, JobPriority jp, String user, String jobName, String queue, String jobFile, String trackingUrl, boolean isUber)
          Create a job status object for a given jobid.
TaskID(JobID jobId, boolean isMap, int id)
          Deprecated. 
TaskID(JobID jobId, TaskType type, int id)
          Constructs a TaskID object from given JobID.
 

Uses of JobID in org.apache.hadoop.mapreduce.lib.jobcontrol
 

Methods in org.apache.hadoop.mapreduce.lib.jobcontrol that return JobID
 JobID ControlledJob.getMapredJobId()
           
 



Copyright © 2014 Apache Software Foundation. All Rights Reserved.