Uses of Class
org.apache.hadoop.mapred.TaskAttemptID

Packages that use TaskAttemptID
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. 
 

Uses of TaskAttemptID in org.apache.hadoop.mapred
 

Methods in org.apache.hadoop.mapred that return TaskAttemptID
static TaskAttemptID TaskAttemptID.downgrade(TaskAttemptID old)
          Deprecated. Downgrade a new TaskAttemptID to an old one
static TaskAttemptID TaskAttemptID.forName(String str)
          Deprecated. 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 TaskAttemptContext.getTaskAttemptID()
          Deprecated. Get the taskAttemptID.
static TaskAttemptID TaskAttemptID.read(DataInput in)
          Deprecated. 
 

Methods in org.apache.hadoop.mapred that return types with arguments of type TaskAttemptID
 Collection<TaskAttemptID> TaskReport.getRunningTaskAttempts()
          Get the running task attempt IDs for this task
 

Methods in org.apache.hadoop.mapred with parameters of type TaskAttemptID
 boolean TaskTracker.canCommit(TaskAttemptID taskid)
          Child checking whether it can commit
 void TaskTracker.commitPending(TaskAttemptID taskid, org.apache.hadoop.mapred.TaskStatus taskStatus)
          Task is reporting that it is in commit_pending and it is waiting for the commit Response
 void TaskTracker.done(TaskAttemptID taskid)
          The task is done.
 void TaskTracker.fatalError(TaskAttemptID taskId, String msg)
          A child task had a fatal error.
 void TaskTracker.fsError(TaskAttemptID taskId, String message)
          A child task had a local filesystem error.
 String JobTracker.getAssignedTracker(TaskAttemptID taskId)
          Get tracker name for a given task id.
 org.apache.hadoop.mapred.MapTaskCompletionEventsUpdate TaskTracker.getMapCompletionEvents(JobID jobId, int fromEventId, int maxLocs, TaskAttemptID id)
           
static File TaskLog.getRealTaskLogFileLocation(TaskAttemptID taskid, TaskLog.LogName filter)
           
 String[] RunningJob.getTaskDiagnostics(TaskAttemptID taskid)
          Gets the diagnostic messages for a given task attempt.
 String[] JobTracker.getTaskDiagnostics(TaskAttemptID taskId)
          Get the diagnostics for a given task
static File TaskLog.getTaskLogFile(TaskAttemptID taskid, TaskLog.LogName filter)
           
 void RunningJob.killTask(TaskAttemptID taskId, boolean shouldFail)
          Kill indicated task attempt.
 boolean JobTracker.killTask(TaskAttemptID taskid, boolean shouldFail)
          Mark a Task to be killed
static void JobHistory.MapAttempt.logFailed(TaskAttemptID taskAttemptId, long timestamp, String hostName, String error)
          Deprecated. Use JobHistory.MapAttempt.logFailed(TaskAttemptID, long, String, String, String)
static void JobHistory.ReduceAttempt.logFailed(TaskAttemptID taskAttemptId, long timestamp, String hostName, String error)
          Deprecated. Use JobHistory.ReduceAttempt.logFailed(TaskAttemptID, long, String, String, String)
static void JobHistory.MapAttempt.logFailed(TaskAttemptID taskAttemptId, long timestamp, String hostName, String error, String taskType)
          Log task attempt failed event.
static void JobHistory.ReduceAttempt.logFailed(TaskAttemptID taskAttemptId, long timestamp, String hostName, String error, String taskType)
          Log failed reduce task attempt.
static void JobHistory.Task.logFailed(TaskID taskId, String taskType, long time, String error, TaskAttemptID failedDueToAttempt)
           
static void JobHistory.ReduceAttempt.logFinished(TaskAttemptID taskAttemptId, long shuffleFinished, long sortFinished, long finishTime, String hostName)
          Deprecated. Use JobHistory.ReduceAttempt.logFinished(TaskAttemptID, long, long, long, String, String, String, Counters)
static void JobHistory.ReduceAttempt.logFinished(TaskAttemptID taskAttemptId, long shuffleFinished, long sortFinished, long finishTime, String hostName, String taskType, String stateString, Counters counter)
          Log finished event of this task.
static void JobHistory.MapAttempt.logFinished(TaskAttemptID taskAttemptId, long finishTime, String hostName)
          Deprecated. Use JobHistory.MapAttempt.logFinished(TaskAttemptID, long, String, String, String, Counters)
static void JobHistory.MapAttempt.logFinished(TaskAttemptID taskAttemptId, long finishTime, String hostName, String taskType, String stateString, Counters counter)
          Log finish time of map task attempt.
static void JobHistory.MapAttempt.logKilled(TaskAttemptID taskAttemptId, long timestamp, String hostName, String error)
          Deprecated. Use JobHistory.MapAttempt.logKilled(TaskAttemptID, long, String, String, String)
static void JobHistory.ReduceAttempt.logKilled(TaskAttemptID taskAttemptId, long timestamp, String hostName, String error)
          Deprecated. Use JobHistory.ReduceAttempt.logKilled(TaskAttemptID, long, String, String, String)
static void JobHistory.MapAttempt.logKilled(TaskAttemptID taskAttemptId, long timestamp, String hostName, String error, String taskType)
          Log task attempt killed event.
static void JobHistory.ReduceAttempt.logKilled(TaskAttemptID taskAttemptId, long timestamp, String hostName, String error, String taskType)
          Log killed reduce task attempt.
static void JobHistory.MapAttempt.logStarted(TaskAttemptID taskAttemptId, long startTime, String hostName)
          Deprecated. Use JobHistory.MapAttempt.logStarted(TaskAttemptID, long, String, int, String)
static void JobHistory.ReduceAttempt.logStarted(TaskAttemptID taskAttemptId, long startTime, String hostName)
          Deprecated. Use JobHistory.ReduceAttempt.logStarted(TaskAttemptID, long, String, int, String)
static void JobHistory.MapAttempt.logStarted(TaskAttemptID taskAttemptId, long startTime, String trackerName, int httpPort, String taskType)
          Log start time of this map task attempt.
static void JobHistory.ReduceAttempt.logStarted(TaskAttemptID taskAttemptId, long startTime, String trackerName, int httpPort, String taskType)
          Log start time of Reduce task attempt.
 void TaskTracker.mapOutputLost(TaskAttemptID taskid, String errorMsg)
          A completed map task's output has been lost.
 boolean TaskTracker.ping(TaskAttemptID taskid)
          Child checking to see if we're alive.
 void TaskTracker.reportDiagnosticInfo(TaskAttemptID taskid, String info)
          Called when the task dies before completion, and we want to report back diagnostic info
 void TaskTracker.reportNextRecordRange(TaskAttemptID taskid, org.apache.hadoop.mapred.SortedRanges.Range range)
           
 void TaskReport.setSuccessfulAttempt(TaskAttemptID t)
          set successful attempt ID of the task.
 void TaskCompletionEvent.setTaskID(TaskAttemptID taskId)
          Sets task id.
 void TaskTracker.shuffleError(TaskAttemptID taskId, String message)
          A reduce-task failed to shuffle the map-outputs.
 boolean TaskTracker.statusUpdate(TaskAttemptID taskid, org.apache.hadoop.mapred.TaskStatus taskStatus)
          Called periodically to report Task progress, from 0.0 to 1.0.
static void TaskLog.syncLogs(TaskAttemptID firstTaskid, TaskAttemptID taskid)
           
static void TaskLog.syncLogs(TaskAttemptID firstTaskid, TaskAttemptID taskid, boolean isCleanup)
           
 

Method parameters in org.apache.hadoop.mapred with type arguments of type TaskAttemptID
 void TaskReport.setRunningTaskAttempts(Collection<TaskAttemptID> runningAttempts)
          set running attempt(s) of the task.
 

Constructors in org.apache.hadoop.mapred with parameters of type TaskAttemptID
TaskCompletionEvent(int eventId, TaskAttemptID taskId, int idWithinJob, boolean isMap, TaskCompletionEvent.Status status, String taskTrackerHttp)
          Constructor.
 



Copyright © 2009 The Apache Software Foundation