@InterfaceAudience.Public
@InterfaceStability.Stable
public class TaskReport
extends org.apache.hadoop.mapreduce.TaskReport
Constructor and Description |
---|
TaskReport() |
Modifier and Type | Method and Description |
---|---|
Counters |
getCounters() |
Collection<TaskAttemptID> |
getRunningTaskAttempts()
Get the running task attempt IDs for this task
|
TaskAttemptID |
getSuccessfulTaskAttempt()
Get the attempt ID that took this task to completion
|
String |
getTaskId()
The string of the task id.
|
TaskID |
getTaskID()
The id of the task.
|
protected void |
setFinishTime(long finishTime)
set finish time of task.
|
void |
setRunningTaskAttempts(Collection<TaskAttemptID> runningAttempts)
set running attempt(s) of the task.
|
protected void |
setStartTime(long startTime)
set start time of the task.
|
void |
setSuccessfulAttempt(TaskAttemptID t)
set successful attempt ID of the task.
|
equals, getCurrentStatus, getDiagnostics, getFinishTime, getProgress, getRunningTaskAttemptIds, getStartTime, getState, getSuccessfulTaskAttemptId, getTaskCounters, hashCode, readFields, setRunningTaskAttemptIds, setSuccessfulAttemptId, write
public String getTaskId()
getTaskId
in class org.apache.hadoop.mapreduce.TaskReport
public TaskID getTaskID()
getTaskID
in class org.apache.hadoop.mapreduce.TaskReport
public Counters getCounters()
public void setSuccessfulAttempt(TaskAttemptID t)
public TaskAttemptID getSuccessfulTaskAttempt()
public void setRunningTaskAttempts(Collection<TaskAttemptID> runningAttempts)
public Collection<TaskAttemptID> getRunningTaskAttempts()
protected void setFinishTime(long finishTime)
setFinishTime
in class org.apache.hadoop.mapreduce.TaskReport
finishTime
- finish time of task.protected void setStartTime(long startTime)
setStartTime
in class org.apache.hadoop.mapreduce.TaskReport
Copyright © 2019 Apache Software Foundation. All rights reserved.