限定符和类型 | 类和说明 |
---|---|
static class |
TaskStatus.Phase |
static class |
TaskStatus.State |
构造器和说明 |
---|
TaskStatus() |
TaskStatus(TaskAttemptID taskid,
float progress,
int numSlots,
TaskStatus.State runState,
String diagnosticInfo,
String stateString,
String taskTracker,
TaskStatus.Phase phase,
Counters counters) |
限定符和类型 | 方法和说明 |
---|---|
Object |
clone() |
Counters |
getCounters()
Get task's counters.
|
String |
getDiagnosticInfo() |
List<TaskAttemptID> |
getFetchFailedMaps()
Get the list of maps from which output-fetches failed.
|
long |
getFinishTime()
Get task finish time. if shuffleFinishTime and sortFinishTime
are not set before, these are set to finishTime.
|
boolean |
getIncludeCounters() |
abstract boolean |
getIsMap() |
org.apache.hadoop.mapred.SortedRanges.Range |
getNextRecordRange()
Get the next record range which is going to be processed by Task.
|
int |
getNumSlots() |
long |
getOutputSize()
Returns the number of bytes of output from this map.
|
TaskStatus.Phase |
getPhase()
Get current phase of this task.
|
float |
getProgress() |
TaskStatus.State |
getRunState() |
long |
getShuffleFinishTime()
Get shuffle finish time for the task.
|
long |
getSortFinishTime()
Get sort finish time for the task,.
|
long |
getStartTime()
Get start time of the task.
|
String |
getStateString() |
TaskAttemptID |
getTaskID() |
String |
getTaskTracker() |
void |
readFields(DataInput in)
Deserialize the fields of this object from
in . |
void |
setCounters(Counters counters)
Set the task's counters.
|
void |
setDiagnosticInfo(String info) |
void |
setIncludeCounters(boolean send) |
void |
setNextRecordRange(org.apache.hadoop.mapred.SortedRanges.Range nextRecordRange)
Set the next record range which is going to be processed by Task.
|
void |
setProgress(float progress) |
void |
setRunState(TaskStatus.State runState) |
void |
setStateString(String stateString) |
void |
setTaskTracker(String tracker) |
void |
write(DataOutput out)
Serialize the fields of this object to
out . |
public TaskStatus()
public TaskStatus(TaskAttemptID taskid, float progress, int numSlots, TaskStatus.State runState, String diagnosticInfo, String stateString, String taskTracker, TaskStatus.Phase phase, Counters counters)
public TaskAttemptID getTaskID()
public abstract boolean getIsMap()
public int getNumSlots()
public float getProgress()
public void setProgress(float progress)
public TaskStatus.State getRunState()
public String getTaskTracker()
public void setTaskTracker(String tracker)
public void setRunState(TaskStatus.State runState)
public String getDiagnosticInfo()
public void setDiagnosticInfo(String info)
public String getStateString()
public void setStateString(String stateString)
public org.apache.hadoop.mapred.SortedRanges.Range getNextRecordRange()
public void setNextRecordRange(org.apache.hadoop.mapred.SortedRanges.Range nextRecordRange)
nextRecordRange
- public long getFinishTime()
public long getShuffleFinishTime()
public long getSortFinishTime()
public long getStartTime()
public TaskStatus.Phase getPhase()
public boolean getIncludeCounters()
public void setIncludeCounters(boolean send)
public Counters getCounters()
public void setCounters(Counters counters)
counters
- public long getOutputSize()
public List<TaskAttemptID> getFetchFailedMaps()
public void write(DataOutput out) throws IOException
Writable
out
.write
在接口中 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
在接口中 Writable
in
- DataInput
to deseriablize this object from.IOException
Copyright © 2009 The Apache Software Foundation