Package | Description |
---|---|
org.apache.hadoop.mapred | |
org.apache.hadoop.mapreduce | |
org.apache.hadoop.mapreduce.lib.jobcontrol |
Modifier and Type | Class and Description |
---|---|
class |
JobID
JobID represents the immutable and unique identifier for
the job.
|
Modifier and Type | Method and Description |
---|---|
static JobID |
JobID.downgrade(JobID old)
Downgrade a new JobID to an old one
|
Constructor and Description |
---|
TaskID(JobID jobId,
boolean isMap,
int id)
Deprecated.
|
TaskID(JobID jobId,
TaskType type,
int id)
Constructs a TaskID object from given
JobID . |
Modifier and Type | Method and Description |
---|---|
static JobID |
JobID.forName(String str)
Construct a JobId object from given string
|
JobID |
TaskID.getJobID()
Returns the
JobID object that this tip belongs to |
JobID |
TaskAttemptID.getJobID()
Returns the
JobID object that this task attempt belongs to |
JobID |
JobStatus.getJobID() |
JobID |
JobContext.getJobID()
Get the unique ID for the job.
|
Modifier and Type | Method and Description |
---|---|
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
|
Constructor and Description |
---|
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 . |
Modifier and Type | Method and Description |
---|---|
JobID |
ControlledJob.getMapredJobId() |
Copyright © 2017 Apache Software Foundation. All rights reserved.