public interface TaskUmbilicalProtocol extends VersionedProtocol
| 限定符和类型 | 字段和说明 |
|---|---|
static long |
versionID
Changed the version to 2, since we have a new method getMapOutputs
Changed version to 3 to have progress() return a boolean
Changed the version to 4, since we have replaced
TaskUmbilicalProtocol.progress(String, float, String,
org.apache.hadoop.mapred.TaskStatus.Phase, Counters)
with statusUpdate(String, TaskStatus)
Version 5 changed counters representation for HADOOP-2248
Version 6 changes the TaskStatus representation for HADOOP-2208
Version 7 changes the done api (via HADOOP-3140).
|
| 限定符和类型 | 方法和说明 |
|---|---|
boolean |
canCommit(TaskAttemptID taskid,
org.apache.hadoop.mapred.JvmContext jvmContext)
Polling to know whether the task can go-ahead with commit
|
void |
commitPending(TaskAttemptID taskId,
TaskStatus taskStatus,
org.apache.hadoop.mapred.JvmContext jvmContext)
Report that the task is complete, but its commit is pending.
|
void |
done(TaskAttemptID taskid,
org.apache.hadoop.mapred.JvmContext jvmContext)
Report that the task is successfully completed.
|
void |
fatalError(TaskAttemptID taskId,
String message,
org.apache.hadoop.mapred.JvmContext jvmContext)
Report that the task encounted a fatal error.
|
void |
fsError(TaskAttemptID taskId,
String message,
org.apache.hadoop.mapred.JvmContext jvmContext)
Report that the task encounted a local filesystem error.
|
MapTaskCompletionEventsUpdate |
getMapCompletionEvents(JobID jobId,
int fromIndex,
int maxLocs,
TaskAttemptID id,
org.apache.hadoop.mapred.JvmContext jvmContext)
Called by a reduce task to get the map output locations for finished maps.
|
JvmTask |
getTask(org.apache.hadoop.mapred.JvmContext context)
Called when a child task process starts, to get its task.
|
boolean |
ping(TaskAttemptID taskid,
org.apache.hadoop.mapred.JvmContext jvmContext)
Periodically called by child to check if parent is still alive.
|
void |
reportDiagnosticInfo(TaskAttemptID taskid,
String trace,
org.apache.hadoop.mapred.JvmContext jvmContext)
Report error messages back to parent.
|
void |
reportNextRecordRange(TaskAttemptID taskid,
org.apache.hadoop.mapred.SortedRanges.Range range,
org.apache.hadoop.mapred.JvmContext jvmContext)
Report the record range which is going to process next by the Task.
|
void |
shuffleError(TaskAttemptID taskId,
String message,
org.apache.hadoop.mapred.JvmContext jvmContext)
Report that a reduce-task couldn't shuffle map-outputs.
|
boolean |
statusUpdate(TaskAttemptID taskId,
TaskStatus taskStatus,
org.apache.hadoop.mapred.JvmContext jvmContext)
Report child's progress to parent.
|
void |
updatePrivateDistributedCacheSizes(JobID jobId,
long[] sizes)
The job initializer needs to report the sizes of the archive
objects and directories in the private distributed cache.
|
getProtocolVersionstatic final long versionID
JvmTask getTask(org.apache.hadoop.mapred.JvmContext context) throws IOException
context - the JvmContext of the JVM w.r.t the TaskTracker that
launched itIOExceptionboolean statusUpdate(TaskAttemptID taskId, TaskStatus taskStatus, org.apache.hadoop.mapred.JvmContext jvmContext) throws IOException, InterruptedException
taskId - task-id of the childtaskStatus - status of the childjvmContext - context the jvmContext running the task.IOExceptionInterruptedExceptionvoid reportDiagnosticInfo(TaskAttemptID taskid, String trace, org.apache.hadoop.mapred.JvmContext jvmContext) throws IOException
taskid - the id of the task involvedtrace - the text to reportjvmContext - context the jvmContext running the task.IOExceptionvoid reportNextRecordRange(TaskAttemptID taskid, org.apache.hadoop.mapred.SortedRanges.Range range, org.apache.hadoop.mapred.JvmContext jvmContext) throws IOException
taskid - the id of the task involvedrange - the range of record sequence nosjvmContext - context the jvmContext running the task.IOExceptionboolean ping(TaskAttemptID taskid, org.apache.hadoop.mapred.JvmContext jvmContext) throws IOException
taskid - the id of the task involvedjvmContext - context the jvmContext running the task.IOExceptionvoid done(TaskAttemptID taskid, org.apache.hadoop.mapred.JvmContext jvmContext) throws IOException
taskid - task's idjvmContext - context the jvmContext running the task.IOExceptionvoid commitPending(TaskAttemptID taskId, TaskStatus taskStatus, org.apache.hadoop.mapred.JvmContext jvmContext) throws IOException, InterruptedException
taskId - task's idtaskStatus - status of the childjvmContext - context the jvmContext running the task.IOExceptionInterruptedExceptionboolean canCommit(TaskAttemptID taskid, org.apache.hadoop.mapred.JvmContext jvmContext) throws IOException
taskid - jvmContext - context the jvmContext running the task.IOExceptionvoid shuffleError(TaskAttemptID taskId, String message, org.apache.hadoop.mapred.JvmContext jvmContext) throws IOException
IOExceptionvoid fsError(TaskAttemptID taskId, String message, org.apache.hadoop.mapred.JvmContext jvmContext) throws IOException
IOExceptionvoid fatalError(TaskAttemptID taskId, String message, org.apache.hadoop.mapred.JvmContext jvmContext) throws IOException
IOExceptionMapTaskCompletionEventsUpdate getMapCompletionEvents(JobID jobId, int fromIndex, int maxLocs, TaskAttemptID id, org.apache.hadoop.mapred.JvmContext jvmContext) throws IOException
jobId - the reducer job idfromIndex - the index starting from which the locations should be
fetchedmaxLocs - the max number of locations to fetchid - The attempt id of the task that is trying to communicateMapTaskCompletionEventsUpdateIOExceptionvoid updatePrivateDistributedCacheSizes(JobID jobId, long[] sizes) throws IOException
jobId - the job to updatesizes - the array of sizes that were computedIOExceptionCopyright © 2009 The Apache Software Foundation