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

Packages that use TaskType
org.apache.hadoop.mapred   
org.apache.hadoop.mapreduce   
org.apache.hadoop.mapreduce.jobhistory   
org.apache.hadoop.mapreduce.protocol   
 

Uses of TaskType in org.apache.hadoop.mapred
 

Methods in org.apache.hadoop.mapred with parameters of type TaskType
static String TaskAttemptID.getTaskAttemptIDsPattern(String jtIdentifier, Integer jobId, TaskType type, Integer taskId, Integer attemptId)
          Deprecated. 
static String TaskID.getTaskIDsPattern(String jtIdentifier, Integer jobId, TaskType type, Integer taskId)
          Deprecated. 
 

Constructors in org.apache.hadoop.mapred with parameters of type TaskType
TaskAttemptID(String jtIdentifier, int jobId, TaskType type, int taskId, int id)
          Constructs a TaskId object from given parts.
TaskID(JobID jobId, TaskType type, int id)
          Constructs a TaskID object from given JobID.
TaskID(String jtIdentifier, int jobId, TaskType type, int id)
          Constructs a TaskInProgressId object from given parts.
 

Uses of TaskType in org.apache.hadoop.mapreduce
 

Methods in org.apache.hadoop.mapreduce that return TaskType
 TaskType TaskID.getTaskType()
          Get the type of the task
 TaskType TaskAttemptID.getTaskType()
          Returns the TaskType of the TaskAttemptID
static TaskType TaskID.getTaskType(char c)
          Gets the TaskType corresponding to the character
static TaskType TaskType.valueOf(String name)
          Returns the enum constant of this type with the specified name.
static TaskType[] TaskType.values()
          Returns an array containing the constants of this enum type, in the order they are declared.
 

Methods in org.apache.hadoop.mapreduce with parameters of type TaskType
static char TaskID.getRepresentingCharacter(TaskType type)
          Gets the character representing the TaskType
 TaskReport[] Job.getTaskReports(TaskType type)
          Get the information of the current state of the tasks of a job.
 

Constructors in org.apache.hadoop.mapreduce with parameters of type TaskType
TaskAttemptID(String jtIdentifier, int jobId, TaskType type, int taskId, int id)
          Constructs a TaskId object from given parts.
TaskID(JobID jobId, TaskType type, int id)
          Constructs a TaskID object from given JobID.
TaskID(String jtIdentifier, int jobId, TaskType type, int id)
          Constructs a TaskInProgressId object from given parts.
 

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

Methods in org.apache.hadoop.mapreduce.jobhistory that return TaskType
 TaskType TaskFinishedEvent.getTaskType()
          Get task type
 TaskType NormalizedResourceEvent.getTaskType()
          the tasktype for the event.
 TaskType ReduceAttemptFinishedEvent.getTaskType()
          Get the task type
 TaskType TaskStartedEvent.getTaskType()
          Get the task type
 TaskType TaskAttemptStartedEvent.getTaskType()
          Get the task type
 TaskType MapAttemptFinishedEvent.getTaskType()
          Get the task type
 TaskType JobHistoryParser.TaskInfo.getTaskType()
           
 TaskType JobHistoryParser.TaskAttemptInfo.getTaskType()
           
 TaskType TaskAttemptUnsuccessfulCompletionEvent.getTaskType()
          Get the task type
 TaskType TaskFailedEvent.getTaskType()
          Get the task type
 TaskType TaskAttemptFinishedEvent.getTaskType()
          Get the task type
 

Constructors in org.apache.hadoop.mapreduce.jobhistory with parameters of type TaskType
MapAttemptFinishedEvent(TaskAttemptID id, TaskType taskType, String taskStatus, long mapFinishTime, long finishTime, String hostname, int port, String rackName, String state, Counters counters, int[][] allSplits)
          Create an event for successful completion of map attempts
MapAttemptFinishedEvent(TaskAttemptID id, TaskType taskType, String taskStatus, long mapFinishTime, long finishTime, String hostname, String state, Counters counters)
          Deprecated. please use the constructor with an additional argument, an array of splits arrays instead. See ProgressSplitsBlock for an explanation of the meaning of that parameter. Create an event for successful completion of map attempts
NormalizedResourceEvent(TaskType taskType, int memory)
          Normalized request when sent to the Resource Manager.
ReduceAttemptFinishedEvent(TaskAttemptID id, TaskType taskType, String taskStatus, long shuffleFinishTime, long sortFinishTime, long finishTime, String hostname, int port, String rackName, String state, Counters counters, int[][] allSplits)
          Create an event to record completion of a reduce attempt
ReduceAttemptFinishedEvent(TaskAttemptID id, TaskType taskType, String taskStatus, long shuffleFinishTime, long sortFinishTime, long finishTime, String hostname, String state, Counters counters)
          Deprecated. please use the constructor with an additional argument, an array of splits arrays instead. See ProgressSplitsBlock for an explanation of the meaning of that parameter. Create an event to record completion of a reduce attempt
TaskAttemptFinishedEvent(TaskAttemptID id, TaskType taskType, String taskStatus, long finishTime, String rackName, String hostname, String state, Counters counters)
          Create an event to record successful finishes for setup and cleanup attempts
TaskAttemptStartedEvent(TaskAttemptID attemptId, TaskType taskType, long startTime, String trackerName, int httpPort, int shufflePort)
           
TaskAttemptStartedEvent(TaskAttemptID attemptId, TaskType taskType, long startTime, String trackerName, int httpPort, int shufflePort, org.apache.hadoop.yarn.api.records.ContainerId containerId)
          Create an event to record the start of an attempt
TaskAttemptUnsuccessfulCompletionEvent(TaskAttemptID id, TaskType taskType, String status, long finishTime, String hostname, int port, String rackName, String error, int[][] allSplits)
          Create an event to record the unsuccessful completion of attempts
TaskAttemptUnsuccessfulCompletionEvent(TaskAttemptID id, TaskType taskType, String status, long finishTime, String hostname, String error)
          Deprecated. please use the constructor with an additional argument, an array of splits arrays instead. See ProgressSplitsBlock for an explanation of the meaning of that parameter. Create an event to record the unsuccessful completion of attempts
TaskFailedEvent(TaskID id, long finishTime, TaskType taskType, String error, String status, TaskAttemptID failedDueToAttempt)
          Create an event to record task failure
TaskFinishedEvent(TaskID id, 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
 

Uses of TaskType in org.apache.hadoop.mapreduce.protocol
 

Methods in org.apache.hadoop.mapreduce.protocol with parameters of type TaskType
 TaskReport[] ClientProtocol.getTaskReports(JobID jobid, TaskType type)
          Grab a bunch of info on the tasks that make up the job
 



Copyright © 2012 Apache Software Foundation. All Rights Reserved.