Package | Description |
---|---|
org.apache.hadoop.mapred | |
org.apache.hadoop.mapreduce | |
org.apache.hadoop.mapreduce.protocol | |
org.apache.hadoop.mapreduce.tools |
Modifier and Type | Class and Description |
---|---|
class |
JobStatus
Describes the current status of a job.
|
Modifier and Type | Method and Description |
---|---|
static JobStatus |
JobStatus.downgrade(JobStatus stat) |
void |
JobQueueInfo.setJobStatuses(JobStatus[] stats) |
Modifier and Type | Method and Description |
---|---|
JobStatus[] |
Cluster.getAllJobStatuses()
Get job status for all jobs in the cluster.
|
JobStatus[] |
QueueInfo.getJobStatuses()
Get the jobs submitted to queue
|
JobStatus |
Job.getStatus() |
Modifier and Type | Method and Description |
---|---|
static Job |
Job.getInstance(Cluster cluster,
JobStatus status,
org.apache.hadoop.conf.Configuration conf)
|
static Job |
Job.getInstance(JobStatus status,
org.apache.hadoop.conf.Configuration conf)
|
protected void |
QueueInfo.setJobStatuses(JobStatus[] stats) |
Constructor and Description |
---|
QueueInfo(String queueName,
String schedulingInfo,
QueueState state,
JobStatus[] stats) |
Modifier and Type | Method and Description |
---|---|
JobStatus[] |
ClientProtocol.getAllJobs()
Get all the jobs submitted.
|
JobStatus |
ClientProtocol.getJobStatus(JobID jobid)
Grab a handle to a job that is already known to the JobTracker.
|
JobStatus |
ClientProtocol.submitJob(JobID jobId,
String jobSubmitDir,
org.apache.hadoop.security.Credentials ts)
Submit a Job for execution.
|
Modifier and Type | Method and Description |
---|---|
void |
CLI.displayJobList(JobStatus[] jobs) |
void |
CLI.displayJobList(JobStatus[] jobs,
PrintWriter writer) |
Copyright © 2008–2022 Apache Software Foundation. All rights reserved.