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

Packages that use JobID
org.apache.hadoop.mapred   
org.apache.hadoop.mapreduce   
org.apache.hadoop.mapreduce.jobhistory   
org.apache.hadoop.mapreduce.lib.jobcontrol   
org.apache.hadoop.mapreduce.lib.map   
org.apache.hadoop.mapreduce.lib.reduce   
org.apache.hadoop.mapreduce.protocol   
org.apache.hadoop.mapreduce.split   
org.apache.hadoop.mapreduce.task   
 

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
static File TaskLog.getJobDir(JobID jobid)
          Get the user log directory for the job jobid.
 

Constructors in org.apache.hadoop.mapred with parameters of type JobID
JobContextImpl(JobConf conf, JobID jobId)
           
JobContextImpl(JobConf conf, JobID jobId, org.apache.hadoop.util.Progressable progress)
           
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.
JobProfile(String user, JobID jobid, String jobFile, String url, String name, String queueName)
          Construct a JobProfile the userid, jobid, job config-file, job-details url and job name.
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 TaskID.getJobID()
          Returns the JobID object that this tip belongs to
 JobID JobContext.getJobID()
          Get the unique ID for the job.
 JobID JobStatus.getJobID()
           
 

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.
 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, 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, 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, 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, TaskType type, int id)
          Constructs a TaskID object from given JobID.
 

Uses of JobID in org.apache.hadoop.mapreduce.jobhistory
 

Methods in org.apache.hadoop.mapreduce.jobhistory that return JobID
 JobID JobFinishedEvent.getJobid()
          Get the Job ID
 JobID JobStatusChangedEvent.getJobId()
          Get the Job Id
 JobID JobUnsuccessfulCompletionEvent.getJobId()
          Get the Job ID
 JobID JobSubmittedEvent.getJobId()
          Get the Job Id
 JobID JobPriorityChangeEvent.getJobId()
          Get the Job ID
 JobID JobHistoryParser.JobInfo.getJobId()
           
 JobID JobInitedEvent.getJobId()
          Get the job ID
 JobID JobInfoChangeEvent.getJobId()
          Get the Job ID
 

Constructors in org.apache.hadoop.mapreduce.jobhistory with parameters of type JobID
JobFinishedEvent(JobID id, long finishTime, int finishedMaps, int finishedReduces, int failedMaps, int failedReduces, Counters mapCounters, Counters reduceCounters, Counters totalCounters)
          Create an event to record successful job completion
JobInfoChangeEvent(JobID id, long submitTime, long launchTime)
          Create a event to record the submit and launch time of a job
JobInitedEvent(JobID id, long launchTime, int totalMaps, int totalReduces, String jobStatus, boolean uberized)
          Create an event to record job initialization
JobPriorityChangeEvent(JobID id, JobPriority priority)
          Generate an event to record changes in Job priority
JobStatusChangedEvent(JobID id, String jobStatus)
          Create an event to record the change in the Job Status
JobSubmittedEvent(JobID id, String jobName, String userName, long submitTime, String jobConfPath, Map<JobACL,org.apache.hadoop.security.authorize.AccessControlList> jobACLs, String jobQueueName)
          Create an event to record job submission
JobSubmittedEvent(JobID id, String jobName, String userName, long submitTime, String jobConfPath, Map<JobACL,org.apache.hadoop.security.authorize.AccessControlList> jobACLs, String jobQueueName, String workflowId, String workflowName, String workflowNodeName, String workflowAdjacencies)
          Create an event to record job submission
JobSubmittedEvent(JobID id, String jobName, String userName, long submitTime, String jobConfPath, Map<JobACL,org.apache.hadoop.security.authorize.AccessControlList> jobACLs, String jobQueueName, String workflowId, String workflowName, String workflowNodeName, String workflowAdjacencies, String workflowTags)
          Create an event to record job submission
JobUnsuccessfulCompletionEvent(JobID id, long finishTime, int finishedMaps, int finishedReduces, String status)
          Create an event to record unsuccessful completion (killed/failed) of jobs
 

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

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

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

Methods in org.apache.hadoop.mapreduce.lib.map that return JobID
 JobID WrappedMapper.Context.getJobID()
           
 

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

Methods in org.apache.hadoop.mapreduce.lib.reduce that return JobID
 JobID WrappedReducer.Context.getJobID()
           
 

Uses of JobID in org.apache.hadoop.mapreduce.protocol
 

Methods in org.apache.hadoop.mapreduce.protocol that return JobID
 JobID ClientProtocol.getNewJobID()
          Allocate a name for the job.
 

Methods in org.apache.hadoop.mapreduce.protocol with parameters of type JobID
 Counters ClientProtocol.getJobCounters(JobID jobid)
          Grab the current job counters
 JobStatus ClientProtocol.getJobStatus(JobID jobid)
          Grab a handle to a job that is already known to the JobTracker.
 LogParams ClientProtocol.getLogFileParams(JobID jobID, TaskAttemptID taskAttemptID)
          Gets the location of the log file for a job if no taskAttemptId is specified, otherwise gets the log location for the taskAttemptId.
 TaskCompletionEvent[] ClientProtocol.getTaskCompletionEvents(JobID jobid, int fromEventId, int maxEvents)
          Get task completion events for the jobid, starting from fromEventId.
 TaskReport[] ClientProtocol.getTaskReports(JobID jobid, TaskType type)
          Grab a bunch of info on the tasks that make up the job
 void ClientProtocol.killJob(JobID jobid)
          Kill the indicated job
 void ClientProtocol.setJobPriority(JobID jobid, String priority)
          Set the priority of the specified job
 JobStatus ClientProtocol.submitJob(JobID jobId, String jobSubmitDir, org.apache.hadoop.security.Credentials ts)
          Submit a Job for execution.
 

Uses of JobID in org.apache.hadoop.mapreduce.split
 

Methods in org.apache.hadoop.mapreduce.split with parameters of type JobID
static JobSplit.TaskSplitMetaInfo[] SplitMetaInfoReader.readSplitMetaInfo(JobID jobId, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.Path jobSubmitDir)
           
 

Uses of JobID in org.apache.hadoop.mapreduce.task
 

Methods in org.apache.hadoop.mapreduce.task that return JobID
 JobID JobContextImpl.getJobID()
          Get the unique ID for the job.
 

Methods in org.apache.hadoop.mapreduce.task with parameters of type JobID
 void JobContextImpl.setJobID(JobID jobId)
          Set the JobID.
 

Constructors in org.apache.hadoop.mapreduce.task with parameters of type JobID
JobContextImpl(org.apache.hadoop.conf.Configuration conf, JobID jobId)
           
 



Copyright © 2013 Apache Software Foundation. All Rights Reserved.