Package | Description |
---|---|
org.apache.hadoop.mapred |
A software framework for easily writing applications which process vast
amounts of data (multi-terabyte data-sets) parallelly on large clusters
(thousands of nodes) built of commodity hardware in a reliable, fault-tolerant
manner.
|
Modifier and Type | Method and Description |
---|---|
static TaskAttemptID |
TaskAttemptID.downgrade(TaskAttemptID old)
Downgrade a new TaskAttemptID to an old one
|
static TaskAttemptID |
TaskAttemptID.forName(java.lang.String str)
Construct a TaskAttemptID object from given string
|
TaskAttemptID |
TaskReport.getSuccessfulTaskAttempt()
Get the attempt ID that took this task to completion
|
TaskAttemptID |
TaskCompletionEvent.getTaskAttemptId()
Returns task id.
|
TaskAttemptID |
ReduceTask.ReduceCopier.MapOutputLocation.getTaskAttemptId() |
TaskAttemptID |
TaskAttemptContext.getTaskAttemptID()
Deprecated.
|
TaskAttemptID |
TaskAttemptContextImpl.getTaskAttemptID()
Deprecated.
Get the taskAttemptID.
|
TaskAttemptID |
TaskStatus.getTaskID() |
TaskAttemptID |
Task.getTaskID() |
static TaskAttemptID |
TaskAttemptID.read(java.io.DataInput in)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
java.util.List<TaskAttemptID> |
TaskStatus.getFetchFailedMaps()
Get the list of maps from which output-fetches failed.
|
java.util.Collection<TaskAttemptID> |
TaskReport.getRunningTaskAttempts()
Get the running task attempt IDs for this task
|
Modifier and Type | Method and Description |
---|---|
void |
TaskInProgress.addDiagnosticInfo(TaskAttemptID taskId,
java.lang.String diagInfo)
Save diagnostic information for a given task.
|
Task |
TaskInProgress.addRunningTask(TaskAttemptID taskid,
java.lang.String taskTracker) |
Task |
TaskInProgress.addRunningTask(TaskAttemptID taskid,
java.lang.String taskTracker,
boolean taskCleanup)
Adds a previously running task to this tip.
|
boolean |
TaskTracker.canCommit(TaskAttemptID taskid,
org.apache.hadoop.mapred.JvmContext jvmContext)
Child checking whether it can commit
|
boolean |
TaskUmbilicalProtocol.canCommit(TaskAttemptID taskid,
org.apache.hadoop.mapred.JvmContext jvmContext)
Polling to know whether the task can go-ahead with commit
|
protected void |
ReduceTask.ReduceCopier.checkAndInformJobTracker(int failures,
TaskAttemptID mapId,
boolean readError) |
void |
TaskTracker.commitPending(TaskAttemptID taskid,
TaskStatus taskStatus,
org.apache.hadoop.mapred.JvmContext jvmContext)
Task is reporting that it is in commit_pending
and it is waiting for the commit Response
|
void |
TaskUmbilicalProtocol.commitPending(TaskAttemptID taskId,
TaskStatus taskStatus,
org.apache.hadoop.mapred.JvmContext jvmContext)
Report that the task is complete, but its commit is pending.
|
void |
TaskInProgress.completed(TaskAttemptID taskid)
Indicate that one of the taskids in this TaskInProgress
has successfully completed!
|
static <K,V> Task.CombinerRunner<K,V> |
Task.CombinerRunner.create(JobConf job,
TaskAttemptID taskId,
Counters.Counter inputCounter,
Task.TaskReporter reporter,
OutputCommitter committer) |
abstract void |
TaskController.createLogDir(TaskAttemptID taskID,
boolean isCleanup)
Creates task log dir
|
void |
DefaultTaskController.createLogDir(TaskAttemptID taskID,
boolean isCleanup) |
static void |
TaskLog.createTaskAttemptLogDir(TaskAttemptID taskID,
boolean isCleanup,
java.lang.String[] localDirs)
Create log directory for the given attempt.
|
void |
TaskInProgress.doCommit(TaskAttemptID taskid)
Commit this task attempt for the tip.
|
void |
TaskTracker.done(TaskAttemptID taskid,
org.apache.hadoop.mapred.JvmContext jvmContext)
The task is done.
|
void |
TaskUmbilicalProtocol.done(TaskAttemptID taskid,
org.apache.hadoop.mapred.JvmContext jvmContext)
Report that the task is successfully completed.
|
void |
JobInProgress.failedTask(TaskInProgress tip,
TaskAttemptID taskid,
java.lang.String reason,
TaskStatus.Phase phase,
TaskStatus.State state,
java.lang.String trackerName)
Fail a task with a given reason, but without a status object.
|
void |
TaskTracker.fatalError(TaskAttemptID taskId,
java.lang.String msg,
org.apache.hadoop.mapred.JvmContext jvmContext)
A child task had a fatal error.
|
void |
TaskUmbilicalProtocol.fatalError(TaskAttemptID taskId,
java.lang.String message,
org.apache.hadoop.mapred.JvmContext jvmContext)
Report that the task encounted a fatal error.
|
void |
TaskTracker.fsError(TaskAttemptID taskId,
java.lang.String message,
org.apache.hadoop.mapred.JvmContext jvmContext)
A child task had a local filesystem error.
|
void |
TaskUmbilicalProtocol.fsError(TaskAttemptID taskId,
java.lang.String message,
org.apache.hadoop.mapred.JvmContext jvmContext)
Report that the task encounted a local filesystem error.
|
java.lang.String |
JobTracker.getAssignedTracker(TaskAttemptID taskId)
Get tracker name for a given task id.
|
java.util.List<java.lang.String> |
TaskInProgress.getDiagnosticInfo(TaskAttemptID taskId)
Get the diagnostic messages for a given task within this tip.
|
MapTaskCompletionEventsUpdate |
TaskTracker.getMapCompletionEvents(JobID jobId,
int fromEventId,
int maxLocs,
TaskAttemptID id,
org.apache.hadoop.mapred.JvmContext jvmContext) |
MapTaskCompletionEventsUpdate |
TaskUmbilicalProtocol.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.
|
static java.lang.String |
TaskLog.getTaskAttemptLogDir(TaskAttemptID taskID,
java.lang.String cleanupSuffix,
java.lang.String[] localDirs)
Get attempt log directory path for the given attempt-id under randomly
selected mapred local directory.
|
java.lang.String[] |
JobTracker.getTaskDiagnostics(TaskAttemptID taskId)
Get the diagnostics for a given task
|
java.lang.String[] |
RunningJob.getTaskDiagnostics(TaskAttemptID taskid)
Gets the diagnostic messages for a given task attempt.
|
java.lang.String[] |
LocalJobRunner.getTaskDiagnostics(TaskAttemptID taskid)
Returns the diagnostic information for a particular task in the given job.
|
static java.io.File |
TaskLog.getTaskLogFile(TaskAttemptID taskid,
boolean isCleanup,
TaskLog.LogName filter) |
TaskStatus |
TaskInProgress.getTaskStatus(TaskAttemptID taskid)
Get the status of the specified task
|
void |
TaskInProgress.incompleteSubTask(TaskAttemptID taskid,
JobStatus jobStatus)
Indicate that one of the taskids in this TaskInProgress
has failed.
|
boolean |
TaskInProgress.isCommitPending(TaskAttemptID taskId) |
boolean |
TaskInProgress.isComplete(TaskAttemptID taskid)
Is the given taskid the one that took this tip to completion?
|
boolean |
TaskInProgress.isFirstAttempt(TaskAttemptID taskId)
Is the Task associated with taskid is the first attempt of the tip?
|
boolean |
JobTracker.killTask(TaskAttemptID taskid,
boolean shouldFail) |
void |
RunningJob.killTask(TaskAttemptID taskId,
boolean shouldFail)
Kill indicated task attempt.
|
boolean |
LocalJobRunner.killTask(TaskAttemptID taskId,
boolean shouldFail)
Throws
UnsupportedOperationException |
static void |
JobHistory.MapAttempt.logFailed(TaskAttemptID taskAttemptId,
long timestamp,
java.lang.String hostName,
java.lang.String error)
|
static void |
JobHistory.ReduceAttempt.logFailed(TaskAttemptID taskAttemptId,
long timestamp,
java.lang.String hostName,
java.lang.String error)
|
static void |
JobHistory.MapAttempt.logFailed(TaskAttemptID taskAttemptId,
long timestamp,
java.lang.String hostName,
java.lang.String error,
java.lang.String taskType)
Log task attempt failed event.
|
static void |
JobHistory.ReduceAttempt.logFailed(TaskAttemptID taskAttemptId,
long timestamp,
java.lang.String hostName,
java.lang.String error,
java.lang.String taskType)
Log failed reduce task attempt.
|
static void |
JobHistory.Task.logFailed(TaskID taskId,
java.lang.String taskType,
long time,
java.lang.String error,
TaskAttemptID failedDueToAttempt) |
static void |
JobHistory.ReduceAttempt.logFinished(TaskAttemptID taskAttemptId,
long shuffleFinished,
long sortFinished,
long finishTime,
java.lang.String hostName)
|
static void |
JobHistory.ReduceAttempt.logFinished(TaskAttemptID taskAttemptId,
long shuffleFinished,
long sortFinished,
long finishTime,
java.lang.String hostName,
java.lang.String taskType,
java.lang.String stateString,
Counters counter)
Log finished event of this task.
|
static void |
JobHistory.MapAttempt.logFinished(TaskAttemptID taskAttemptId,
long finishTime,
java.lang.String hostName)
|
static void |
JobHistory.MapAttempt.logFinished(TaskAttemptID taskAttemptId,
long finishTime,
java.lang.String hostName,
java.lang.String taskType,
java.lang.String stateString,
Counters counter)
Log finish time of map task attempt.
|
static void |
JobHistory.MapAttempt.logKilled(TaskAttemptID taskAttemptId,
long timestamp,
java.lang.String hostName,
java.lang.String error)
|
static void |
JobHistory.ReduceAttempt.logKilled(TaskAttemptID taskAttemptId,
long timestamp,
java.lang.String hostName,
java.lang.String error)
|
static void |
JobHistory.MapAttempt.logKilled(TaskAttemptID taskAttemptId,
long timestamp,
java.lang.String hostName,
java.lang.String error,
java.lang.String taskType)
Log task attempt killed event.
|
static void |
JobHistory.ReduceAttempt.logKilled(TaskAttemptID taskAttemptId,
long timestamp,
java.lang.String hostName,
java.lang.String error,
java.lang.String taskType)
Log killed reduce task attempt.
|
static void |
JobHistory.MapAttempt.logStarted(TaskAttemptID taskAttemptId,
long startTime,
java.lang.String hostName)
|
static void |
JobHistory.ReduceAttempt.logStarted(TaskAttemptID taskAttemptId,
long startTime,
java.lang.String hostName)
|
static void |
JobHistory.MapAttempt.logStarted(TaskAttemptID taskAttemptId,
long startTime,
java.lang.String trackerName,
int httpPort,
java.lang.String taskType)
Log start time of this map task attempt.
|
static void |
JobHistory.ReduceAttempt.logStarted(TaskAttemptID taskAttemptId,
long startTime,
java.lang.String trackerName,
int httpPort,
java.lang.String taskType)
Log start time of Reduce task attempt.
|
void |
TaskTracker.mapOutputLost(TaskAttemptID taskid,
java.lang.String errorMsg)
A completed map task's output has been lost.
|
boolean |
TaskTracker.ping(TaskAttemptID taskid,
org.apache.hadoop.mapred.JvmContext jvmContext)
Child checking to see if we're alive.
|
boolean |
TaskUmbilicalProtocol.ping(TaskAttemptID taskid,
org.apache.hadoop.mapred.JvmContext jvmContext)
Periodically called by child to check if parent is still alive.
|
void |
TaskTracker.reportDiagnosticInfo(TaskAttemptID taskid,
java.lang.String info,
org.apache.hadoop.mapred.JvmContext jvmContext)
Called when the task dies before completion, and we want to report back
diagnostic info
|
void |
TaskUmbilicalProtocol.reportDiagnosticInfo(TaskAttemptID taskid,
java.lang.String trace,
org.apache.hadoop.mapred.JvmContext jvmContext)
Report error messages back to parent.
|
void |
Task.reportFatalError(TaskAttemptID id,
java.lang.Throwable throwable,
java.lang.String logMsg)
Report a fatal error to the parent (task) tracker.
|
void |
TaskTracker.reportNextRecordRange(TaskAttemptID taskid,
org.apache.hadoop.mapred.SortedRanges.Range range,
org.apache.hadoop.mapred.JvmContext jvmContext) |
void |
TaskUmbilicalProtocol.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 |
TaskReport.setSuccessfulAttempt(TaskAttemptID t)
set successful attempt ID of the task.
|
void |
TaskCompletionEvent.setTaskID(TaskAttemptID taskId)
Sets task id.
|
boolean |
TaskInProgress.shouldClose(TaskAttemptID taskid)
Returns whether a component task-thread should be
closed because the containing JobInProgress has completed
or the task is killed by the user
|
boolean |
TaskInProgress.shouldCommit(TaskAttemptID taskid)
Returns whether the task attempt should be committed or not
|
void |
TaskTracker.shuffleError(TaskAttemptID taskId,
java.lang.String message,
org.apache.hadoop.mapred.JvmContext jvmContext)
A reduce-task failed to shuffle the map-outputs.
|
void |
TaskUmbilicalProtocol.shuffleError(TaskAttemptID taskId,
java.lang.String message,
org.apache.hadoop.mapred.JvmContext jvmContext)
Report that a reduce-task couldn't shuffle map-outputs.
|
boolean |
TaskTracker.statusUpdate(TaskAttemptID taskid,
TaskStatus taskStatus,
org.apache.hadoop.mapred.JvmContext jvmContext)
Called periodically to report Task progress, from 0.0 to 1.0.
|
boolean |
TaskUmbilicalProtocol.statusUpdate(TaskAttemptID taskId,
TaskStatus taskStatus,
org.apache.hadoop.mapred.JvmContext jvmContext)
Report child's progress to parent.
|
static void |
TaskLog.syncLogs(java.lang.String logLocation,
TaskAttemptID taskid,
boolean isCleanup,
boolean segmented) |
Modifier and Type | Method and Description |
---|---|
void |
TaskReport.setRunningTaskAttempts(java.util.Collection<TaskAttemptID> runningAttempts)
set running attempt(s) of the task.
|
Constructor and Description |
---|
MapTask(java.lang.String jobFile,
TaskAttemptID taskId,
int partition,
JobSplit.TaskSplitIndex splitIndex,
int numSlotsRequired) |
ReduceTask.ReduceCopier.MapOutput(TaskID mapId,
TaskAttemptID mapAttemptId,
byte[] data,
int compressedLength) |
ReduceTask.ReduceCopier.MapOutput(TaskID mapId,
TaskAttemptID mapAttemptId,
org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.Path file,
long size) |
ReduceTask.ReduceCopier.MapOutputLocation(TaskAttemptID taskAttemptId,
java.lang.String ttHost,
java.net.URL taskOutput) |
ReduceTask(java.lang.String jobFile,
TaskAttemptID taskId,
int partition,
int numMaps,
int numSlotsRequired) |
Task(java.lang.String jobFile,
TaskAttemptID taskId,
int partition,
int numSlotsRequired) |
TaskCompletionEvent(int eventId,
TaskAttemptID taskId,
int idWithinJob,
boolean isMap,
TaskCompletionEvent.Status status,
java.lang.String taskTrackerHttp)
Constructor.
|
TaskStatus(TaskAttemptID taskid,
float progress,
int numSlots,
TaskStatus.State runState,
java.lang.String diagnosticInfo,
java.lang.String stateString,
java.lang.String taskTracker,
TaskStatus.Phase phase,
Counters counters) |
Copyright © 2009 The Apache Software Foundation