Uses of Class
org.apache.hadoop.mapreduce.TaskID

Packages that use TaskID
org.apache.hadoop.mapred   
org.apache.hadoop.mapreduce   
org.apache.hadoop.mapreduce.jobhistory   
 

Uses of TaskID in org.apache.hadoop.mapred
 

Subclasses of TaskID in org.apache.hadoop.mapred
 class TaskID
          TaskID represents the immutable and unique identifier for a Map or Reduce Task.
 

Methods in org.apache.hadoop.mapred with parameters of type TaskID
static TaskID TaskID.downgrade(TaskID old)
          Downgrade a new TaskID to an old one
 org.apache.hadoop.fs.Path MROutputFiles.getInputFileForWrite(TaskID mapId, long size)
          Create a local reduce input file name.
abstract  org.apache.hadoop.fs.Path MapOutputFile.getInputFileForWrite(TaskID mapId, long size)
          Create a local reduce input file name.
 

Uses of TaskID in org.apache.hadoop.mapreduce
 

Methods in org.apache.hadoop.mapreduce that return TaskID
static TaskID TaskID.forName(String str)
          Construct a TaskID object from given string
 TaskID TaskReport.getTaskId()
          The id of the task.
 TaskID TaskAttemptID.getTaskID()
          Returns the TaskID object that this task attempt belongs to
 

Constructors in org.apache.hadoop.mapreduce with parameters of type TaskID
TaskAttemptID(TaskID taskId, int id)
          Constructs a TaskAttemptID object from given TaskID.
TaskReport(TaskID taskid, float progress, String state, String[] diagnostics, TIPStatus currentStatus, long startTime, long finishTime, Counters counters)
          Creates a new TaskReport object
 

Uses of TaskID in org.apache.hadoop.mapreduce.jobhistory
 

Methods in org.apache.hadoop.mapreduce.jobhistory that return TaskID
 TaskID TaskAttemptUnsuccessfulCompletionEvent.getTaskId()
          Get the task id
 TaskID ReduceAttemptFinishedEvent.getTaskId()
          Get the Task ID
 TaskID TaskAttemptFinishedEvent.getTaskId()
          Get the task ID
 TaskID JobHistoryParser.TaskInfo.getTaskId()
           
 TaskID TaskUpdatedEvent.getTaskId()
          Get the task ID
 TaskID MapAttemptFinishedEvent.getTaskId()
          Get the task ID
 TaskID TaskFailedEvent.getTaskId()
          Get the task id
 TaskID TaskStartedEvent.getTaskId()
          Get the task id
 TaskID TaskAttemptStartedEvent.getTaskId()
          Get the task id
 TaskID TaskFinishedEvent.getTaskId()
          Get task id
 

Methods in org.apache.hadoop.mapreduce.jobhistory that return types with arguments of type TaskID
 Map<TaskID,JobHistoryParser.TaskInfo> JobHistoryParser.JobInfo.getAllTasks()
           
 Map<String,Set<TaskID>> HistoryViewer.FilteredJob.getFilteredMap()
          Get the map of the filtered tasks
 

Constructors in org.apache.hadoop.mapreduce.jobhistory with parameters of type TaskID
TaskFailedEvent(TaskID id, long finishTime, TaskType taskType, String error, String status, TaskAttemptID failedDueToAttempt)
           
TaskFailedEvent(TaskID id, long finishTime, TaskType taskType, String error, String status, TaskAttemptID failedDueToAttempt, Counters counters)
          Create an event to record task failure
TaskFinishedEvent(TaskID id, TaskAttemptID attemptId, long finishTime, TaskType taskType, String status, Counters counters)
          Create an event to record the successful completion of a task
TaskStartedEvent(TaskID id, long startTime, TaskType taskType, String splitLocations)
          Create an event to record start of a task
TaskUpdatedEvent(TaskID id, long finishTime)
          Create an event to record task updates
 



Copyright © 2013 Apache Software Foundation. All Rights Reserved.