org.apache.hadoop.mapreduce.jobhistory
Class TaskAttemptStartedEvent

java.lang.Object
  extended by org.apache.hadoop.mapreduce.jobhistory.TaskAttemptStartedEvent
All Implemented Interfaces:
HistoryEvent

@InterfaceAudience.Private
@InterfaceStability.Unstable
public class TaskAttemptStartedEvent
extends Object
implements HistoryEvent

Event to record start of a task attempt


Constructor Summary
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
 
Method Summary
 org.apache.hadoop.yarn.api.records.ContainerId getContainerId()
          Get the ContainerId
 Object getDatum()
          Return the Avro datum wrapped by this.
 EventType getEventType()
          Get the event type
 int getHttpPort()
          Get the HTTP port
 int getShufflePort()
          Get the shuffle port
 long getStartTime()
          Get the start time
 TaskAttemptID getTaskAttemptId()
          Get the attempt id
 TaskID getTaskId()
          Get the task id
 TaskType getTaskType()
          Get the task type
 String getTrackerName()
          Get the tracker name
 void setDatum(Object datum)
          Set the Avro datum wrapped by this.
 
Methods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
 

Constructor Detail

TaskAttemptStartedEvent

public 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

Parameters:
attemptId - Id of the attempt
taskType - Type of task
startTime - Start time of the attempt
trackerName - Name of the Task Tracker where attempt is running
httpPort - The port number of the tracker
shufflePort - The shuffle port number of the container
containerId - The containerId for the task attempt.

TaskAttemptStartedEvent

public TaskAttemptStartedEvent(TaskAttemptID attemptId,
                               TaskType taskType,
                               long startTime,
                               String trackerName,
                               int httpPort,
                               int shufflePort)
Method Detail

getDatum

public Object getDatum()
Description copied from interface: HistoryEvent
Return the Avro datum wrapped by this.

Specified by:
getDatum in interface HistoryEvent

setDatum

public void setDatum(Object datum)
Description copied from interface: HistoryEvent
Set the Avro datum wrapped by this.

Specified by:
setDatum in interface HistoryEvent

getTaskId

public TaskID getTaskId()
Get the task id


getTrackerName

public String getTrackerName()
Get the tracker name


getStartTime

public long getStartTime()
Get the start time


getTaskType

public TaskType getTaskType()
Get the task type


getHttpPort

public int getHttpPort()
Get the HTTP port


getShufflePort

public int getShufflePort()
Get the shuffle port


getTaskAttemptId

public TaskAttemptID getTaskAttemptId()
Get the attempt id


getEventType

public EventType getEventType()
Get the event type

Specified by:
getEventType in interface HistoryEvent

getContainerId

public org.apache.hadoop.yarn.api.records.ContainerId getContainerId()
Get the ContainerId



Copyright © 2012 Apache Software Foundation. All Rights Reserved.