Package | Description |
---|---|
org.apache.hadoop.mapred | |
org.apache.hadoop.mapreduce | |
org.apache.hadoop.mapreduce.jobhistory | |
org.apache.hadoop.mapreduce.protocol |
Modifier and Type | Method and Description |
---|---|
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.
|
static <K,V> RawKeyValueIterator |
Merger.merge(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
Class<K> keyClass,
Class<V> valueClass,
org.apache.hadoop.io.compress.CompressionCodec codec,
List<Merger.Segment<K,V>> segments,
int mergeFactor,
org.apache.hadoop.fs.Path tmpDir,
org.apache.hadoop.io.RawComparator<K> comparator,
org.apache.hadoop.util.Progressable reporter,
boolean sortSegments,
Counters.Counter readsCounter,
Counters.Counter writesCounter,
org.apache.hadoop.util.Progress mergePhase,
TaskType taskType) |
Constructor and Description |
---|
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.
|
Modifier and Type | Method and Description |
---|---|
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.
|
Modifier and Type | Method and Description |
---|---|
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.
|
Constructor and Description |
---|
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.
|
Modifier and Type | Method and Description |
---|---|
TaskType |
TaskAttemptUnsuccessfulCompletionEvent.getTaskType()
Gets the task type.
|
TaskType |
TaskStartedEvent.getTaskType()
Get the task type
|
TaskType |
TaskAttemptFinishedEvent.getTaskType()
Gets the task type.
|
TaskType |
MapAttemptFinishedEvent.getTaskType()
Gets the task type.
|
TaskType |
JobHistoryParser.TaskInfo.getTaskType() |
TaskType |
JobHistoryParser.TaskAttemptInfo.getTaskType() |
TaskType |
TaskFailedEvent.getTaskType()
Gets the task type.
|
TaskType |
TaskAttemptStartedEvent.getTaskType()
Get the task type
|
TaskType |
TaskFinishedEvent.getTaskType()
Gets task type.
|
TaskType |
ReduceAttemptFinishedEvent.getTaskType()
Gets the task type.
|
TaskType |
NormalizedResourceEvent.getTaskType()
the tasktype for the event.
|
Constructor and Description |
---|
MapAttemptFinishedEvent(TaskAttemptID id,
TaskType taskType,
String taskStatus,
long mapFinishTime,
long finishTime,
String hostname,
int port,
String rackName,
String state,
Counters counters,
int[][] allSplits) |
MapAttemptFinishedEvent(TaskAttemptID id,
TaskType taskType,
String taskStatus,
long mapFinishTime,
long finishTime,
String hostname,
int port,
String rackName,
String state,
Counters counters,
int[][] allSplits,
long startTs)
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,
long 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) |
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,
long startTs)
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) |
TaskAttemptFinishedEvent(TaskAttemptID id,
TaskType taskType,
String taskStatus,
long finishTime,
String rackName,
String hostname,
String state,
Counters counters,
long startTs)
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,
org.apache.hadoop.yarn.api.records.ContainerId containerId,
String locality,
String avataar)
Create an event to record the start of an attempt
|
TaskAttemptStartedEvent(TaskAttemptID attemptId,
TaskType taskType,
long startTime,
String trackerName,
int httpPort,
int shufflePort,
String locality,
String avataar) |
TaskAttemptUnsuccessfulCompletionEvent(TaskAttemptID id,
TaskType taskType,
String status,
long finishTime,
String hostname,
int port,
String rackName,
String error,
Counters counters,
int[][] allSplits) |
TaskAttemptUnsuccessfulCompletionEvent(TaskAttemptID id,
TaskType taskType,
String status,
long finishTime,
String hostname,
int port,
String rackName,
String error,
Counters counters,
int[][] allSplits,
long startTs)
Create an event to record the unsuccessful completion of attempts.
|
TaskAttemptUnsuccessfulCompletionEvent(TaskAttemptID id,
TaskType taskType,
String status,
long finishTime,
String hostname,
int port,
String rackName,
String error,
int[][] allSplits) |
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) |
TaskFailedEvent(TaskID id,
long finishTime,
TaskType taskType,
String error,
String status,
TaskAttemptID failedDueToAttempt,
Counters counters) |
TaskFailedEvent(TaskID id,
long finishTime,
TaskType taskType,
String error,
String status,
TaskAttemptID failedDueToAttempt,
Counters counters,
long startTs)
Create an event to record task failure.
|
TaskFinishedEvent(TaskID id,
TaskAttemptID attemptId,
long finishTime,
TaskType taskType,
String status,
Counters counters) |
TaskFinishedEvent(TaskID id,
TaskAttemptID attemptId,
long finishTime,
TaskType taskType,
String status,
Counters counters,
long startTs)
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
|
Modifier and Type | Method and Description |
---|---|
TaskReport[] |
ClientProtocol.getTaskReports(JobID jobid,
TaskType type)
Grab a bunch of info on the tasks that make up the job
|
Copyright © 2022 Apache Software Foundation. All rights reserved.