Constructor and Description |
---|
JobStatus() |
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.
|
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,
String historyFile)
Create a job status object for a given jobid.
|
Modifier and Type | Method and Description |
---|---|
Object |
clone() |
float |
getCleanupProgress() |
String |
getFailureInfo()
Gets any available info on the reason of failure of the job.
|
long |
getFinishTime()
Get the finish time of the job.
|
String |
getHistoryFile() |
Map<org.apache.hadoop.mapreduce.JobACL,AccessControlList> |
getJobACLs()
Get the job acls.
|
String |
getJobFile()
Get the configuration file for the job.
|
JobID |
getJobID() |
String |
getJobName()
Get the user-specified job name.
|
float |
getMapProgress() |
int |
getNeededMem() |
int |
getNumReservedSlots() |
int |
getNumUsedSlots() |
JobPriority |
getPriority()
Return the priority of the job
|
String |
getQueue()
Get queue name
|
float |
getReduceProgress() |
int |
getReservedMem() |
String |
getSchedulingInfo()
Gets the Scheduling information associated to a particular Job.
|
float |
getSetupProgress() |
long |
getStartTime() |
org.apache.hadoop.mapreduce.JobStatus.State |
getState() |
String |
getTrackingUrl()
Get the link to the web-ui for details of the job.
|
int |
getUsedMem() |
String |
getUsername() |
boolean |
isJobComplete()
Returns true if the status is for a completed job.
|
boolean |
isRetired()
Check whether the job has retired.
|
boolean |
isUber()
Whether job running in uber mode
|
void |
readFields(DataInput in)
Deserialize the fields of this object from
in . |
protected void |
setCleanupProgress(float p)
Sets the cleanup progress of this job
|
protected void |
setFailureInfo(String failureInfo)
Set diagnostic information.
|
protected void |
setFinishTime(long finishTime)
Set the finish time of the job
|
protected void |
setHistoryFile(String historyFile)
Set the job history file url for a completed job
|
protected void |
setJobACLs(Map<org.apache.hadoop.mapreduce.JobACL,AccessControlList> acls)
Set the job acls.
|
protected void |
setMapProgress(float p)
Sets the map progress of this job
|
void |
setNeededMem(int n) |
void |
setNumReservedSlots(int n) |
void |
setNumUsedSlots(int n) |
protected void |
setPriority(JobPriority jp)
Set the priority of the job, defaulting to NORMAL.
|
protected void |
setQueue(String queue)
Set queue name
|
protected void |
setReduceProgress(float p)
Sets the reduce progress of this Job
|
void |
setReservedMem(int r) |
protected void |
setRetired()
Set the job retire flag to true.
|
protected void |
setSchedulingInfo(String schedulingInfo)
Used to set the scheduling information associated to a particular Job.
|
protected void |
setSetupProgress(float p)
Sets the setup progress of this job
|
protected void |
setStartTime(long startTime)
Set the start time of the job
|
protected void |
setState(org.apache.hadoop.mapreduce.JobStatus.State state)
Change the current run state of the job.
|
protected void |
setTrackingUrl(String trackingUrl)
Set the link to the web-ui for details of the job.
|
void |
setUber(boolean isUber)
Set uber-mode flag
|
void |
setUsedMem(int m) |
protected void |
setUsername(String userName) |
String |
toString() |
void |
write(DataOutput out)
Serialize the fields of this object to
out . |
public JobStatus()
public 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)
jobid
- The jobid of the jobsetupProgress
- The progress made on the setupmapProgress
- The progress made on the mapsreduceProgress
- The progress made on the reducescleanupProgress
- The progress made on the cleanuprunState
- The current state of the jobjp
- Priority of the job.user
- userid of the person who submitted the job.jobName
- user-specified job name.jobFile
- job configuration file.trackingUrl
- link to the web-ui for details of the job.public 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)
jobid
- The jobid of the jobsetupProgress
- The progress made on the setupmapProgress
- The progress made on the mapsreduceProgress
- The progress made on the reducescleanupProgress
- The progress made on the cleanuprunState
- The current state of the jobjp
- Priority of the job.user
- userid of the person who submitted the job.jobName
- user-specified job name.queue
- queue namejobFile
- job configuration file.trackingUrl
- link to the web-ui for details of the job.public 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)
jobid
- The jobid of the jobsetupProgress
- The progress made on the setupmapProgress
- The progress made on the mapsreduceProgress
- The progress made on the reducescleanupProgress
- The progress made on the cleanuprunState
- The current state of the jobjp
- Priority of the job.user
- userid of the person who submitted the job.jobName
- user-specified job name.queue
- queue namejobFile
- job configuration file.trackingUrl
- link to the web-ui for details of the job.isUber
- Whether job running in uber modepublic 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, String historyFile)
jobid
- The jobid of the jobsetupProgress
- The progress made on the setupmapProgress
- The progress made on the mapsreduceProgress
- The progress made on the reducescleanupProgress
- The progress made on the cleanuprunState
- The current state of the jobjp
- Priority of the job.user
- userid of the person who submitted the job.jobName
- user-specified job name.queue
- queue namejobFile
- job configuration file.trackingUrl
- link to the web-ui for details of the job.isUber
- Whether job running in uber modehistoryFile
- history fileprotected void setMapProgress(float p)
p
- The value of map progress to set toprotected void setCleanupProgress(float p)
p
- The value of cleanup progress to set toprotected void setSetupProgress(float p)
p
- The value of setup progress to set toprotected void setReduceProgress(float p)
p
- The value of reduce progress to set toprotected void setPriority(JobPriority jp)
jp
- new job priorityprotected void setFinishTime(long finishTime)
finishTime
- The finishTime of the jobprotected void setHistoryFile(String historyFile)
protected void setTrackingUrl(String trackingUrl)
protected void setRetired()
protected void setState(org.apache.hadoop.mapreduce.JobStatus.State state)
protected void setStartTime(long startTime)
startTime
- The startTime of the jobprotected void setUsername(String userName)
userName
- The username of the jobprotected void setSchedulingInfo(String schedulingInfo)
schedulingInfo
- Scheduling information of the jobprotected void setJobACLs(Map<org.apache.hadoop.mapreduce.JobACL,AccessControlList> acls)
acls
- Map
from JobACL
to AccessControlList
protected void setQueue(String queue)
queue
- queue nameprotected void setFailureInfo(String failureInfo)
failureInfo
- diagnostic informationpublic String getQueue()
public float getMapProgress()
public float getCleanupProgress()
public float getSetupProgress()
public float getReduceProgress()
public org.apache.hadoop.mapreduce.JobStatus.State getState()
public long getStartTime()
public JobID getJobID()
public String getUsername()
public String getSchedulingInfo()
public Map<org.apache.hadoop.mapreduce.JobACL,AccessControlList> getJobACLs()
Map
from JobACL
to AccessControlList
public JobPriority getPriority()
public String getFailureInfo()
public boolean isJobComplete()
public void write(DataOutput out) throws IOException
Writable
out
.write
in interface Writable
out
- DataOuput
to serialize this object into.IOException
public void readFields(DataInput in) throws IOException
Writable
in
.
For efficiency, implementations should attempt to re-use storage in the existing object where possible.
readFields
in interface Writable
in
- DataInput
to deseriablize this object from.IOException
public String getJobName()
public String getJobFile()
public String getTrackingUrl()
public long getFinishTime()
public boolean isRetired()
public String getHistoryFile()
public int getNumUsedSlots()
public void setNumUsedSlots(int n)
n
- number of used mapred slotspublic int getNumReservedSlots()
public void setNumReservedSlots(int n)
n
- the number of reserved slotspublic int getUsedMem()
public void setUsedMem(int m)
m
- the used memorypublic int getReservedMem()
public void setReservedMem(int r)
r
- the reserved memorypublic int getNeededMem()
public void setNeededMem(int n)
n
- the needed memorypublic boolean isUber()
public void setUber(boolean isUber)
isUber
- Whether job running in uber-modeCopyright © 2019 Apache Software Foundation. All rights reserved.