Package | Description |
---|---|
org.apache.hadoop.mapred | |
org.apache.hadoop.mapred.jobcontrol |
Modifier and Type | Method and Description |
---|---|
static JobID |
JobID.downgrade(JobID old)
Downgrade a new JobID to an old one
|
static JobID |
JobID.forName(String str)
Construct a JobId object from given string
|
JobID |
RunningJob.getID()
Get the job identifier.
|
JobID |
TaskID.getJobID() |
JobID |
TaskAttemptID.getJobID() |
JobID |
JobStatus.getJobID() |
static JobID |
JobID.read(DataInput in)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
void |
JobClient.displayTasks(JobID jobId,
String type,
String state)
Display the information about a job's tasks, of a particular type and
in a particular state
|
TaskReport[] |
JobClient.getCleanupTaskReports(JobID jobId)
Get the information of the current state of the cleanup tasks of a job.
|
RunningJob |
JobClient.getJob(JobID jobid)
Get an
RunningJob object to track an ongoing job. |
protected RunningJob |
JobClient.getJobInner(JobID jobid) |
TaskReport[] |
JobClient.getMapTaskReports(JobID jobId)
Get the information of the current state of the map tasks of a job.
|
TaskReport[] |
JobClient.getReduceTaskReports(JobID jobId)
Get the information of the current state of the reduce tasks of a job.
|
TaskReport[] |
JobClient.getSetupTaskReports(JobID jobId)
Get the information of the current state of the setup tasks of a job.
|
Constructor and Description |
---|
JobStatus(JobID jobid,
float setupProgress,
float mapProgress,
float reduceProgress,
float cleanupProgress,
int runState,
JobPriority jp)
Deprecated.
|
JobStatus(JobID jobid,
float setupProgress,
float mapProgress,
float reduceProgress,
float cleanupProgress,
int 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,
int runState,
JobPriority jp,
String user,
String jobName,
String jobFile,
String trackingUrl,
boolean isUber)
Create a job status object for a given jobid.
|
JobStatus(JobID jobid,
float setupProgress,
float mapProgress,
float reduceProgress,
float cleanupProgress,
int 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,
int runState,
JobPriority jp,
String user,
String jobName,
String queue,
String jobFile,
String trackingUrl,
boolean isUber)
Create a job status object for a given jobid.
|
JobStatus(JobID jobid,
float mapProgress,
float reduceProgress,
float cleanupProgress,
int runState)
Deprecated.
|
JobStatus(JobID jobid,
float mapProgress,
float reduceProgress,
float cleanupProgress,
int runState,
JobPriority jp)
Deprecated.
|
JobStatus(JobID jobid,
float mapProgress,
float reduceProgress,
float cleanupProgress,
int runState,
JobPriority jp,
String user,
String jobName,
String jobFile,
String trackingUrl)
Create a job status object for a given jobid.
|
JobStatus(JobID jobid,
float mapProgress,
float reduceProgress,
float cleanupProgress,
int runState,
String user,
String jobName,
String jobFile,
String trackingUrl)
Create a job status object for a given jobid.
|
JobStatus(JobID jobid,
float mapProgress,
float reduceProgress,
int runState)
Deprecated.
|
JobStatus(JobID jobid,
float mapProgress,
float reduceProgress,
int runState,
String user,
String jobName,
String jobFile,
String trackingUrl)
Create a job status object for a given jobid.
|
Modifier and Type | Method and Description |
---|---|
JobID |
Job.getAssignedJobID() |
Modifier and Type | Method and Description |
---|---|
void |
Job.setAssignedJobID(JobID mapredJobID)
Deprecated.
setAssignedJobID should not be called.
JOBID is set by the framework.
|
Copyright © 2017 Apache Software Foundation. All rights reserved.