Package org.apache.hadoop.mapreduce.jobhistory

Examples of org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinishedEvent


    String containerHostName = this.container == null ? "UNKNOWN"
         : this.container.getNodeId().getHost();
    int containerNodePort =
        this.container == null ? -1 : this.container.getNodeId().getPort();
    if (attemptId.getTaskId().getTaskType() == TaskType.MAP) {
      MapAttemptFinishedEvent mfe =
         new MapAttemptFinishedEvent(TypeConverter.fromYarn(attemptId),
         TypeConverter.fromYarn(attemptId.getTaskId().getTaskType()),
         state.toString(),
         this.reportedStatus.mapFinishTime,
         finishTime,
         containerHostName,
View Full Code Here


  @SuppressWarnings({ "unchecked" })
  private void logAttemptFinishedEvent(TaskAttemptStateInternal state) {
    //Log finished events only if an attempt started.
    if (getLaunchTime() == 0) return;
    if (attemptId.getTaskId().getTaskType() == TaskType.MAP) {
      MapAttemptFinishedEvent mfe =
         new MapAttemptFinishedEvent(TypeConverter.fromYarn(attemptId),
         TypeConverter.fromYarn(attemptId.getTaskId().getTaskType()),
         state.toString(),
         this.reportedStatus.mapFinishTime,
         finishTime,
         this.containerNodeId == null ? "UNKNOWN"
View Full Code Here

   
    jobHistory.logEvent(tse, status.getTaskID().getJobID());
    TaskAttemptID statusAttemptID = status.getTaskID();

    if (status.getIsMap()){
      MapAttemptFinishedEvent mfe = new MapAttemptFinishedEvent(
          statusAttemptID, taskType, TaskStatus.State.SUCCEEDED.toString(),
          status.getMapFinishTime(),
          status.getFinishTime(),  trackerHostname, -1, trackerRackName,
          status.getStateString(),
          new org.apache.hadoop.mapreduce.Counters(status.getCounters()),
View Full Code Here

    String containerHostName = this.container == null ? "UNKNOWN"
         : this.container.getNodeId().getHost();
    int containerNodePort =
        this.container == null ? -1 : this.container.getNodeId().getPort();
    if (attemptId.getTaskId().getTaskType() == TaskType.MAP) {
      MapAttemptFinishedEvent mfe =
         new MapAttemptFinishedEvent(TypeConverter.fromYarn(attemptId),
         TypeConverter.fromYarn(attemptId.getTaskId().getTaskType()),
         state.toString(),
         this.reportedStatus.mapFinishTime,
         finishTime,
         containerHostName,
View Full Code Here

        MapAttempt20LineHistoryEventEmitter that =
            (MapAttempt20LineHistoryEventEmitter) thatg;

        if (finishTime != null && "success".equalsIgnoreCase(status)) {
          return new MapAttemptFinishedEvent
            (taskAttemptID,
              that.originalTaskType, status,
             Long.parseLong(finishTime),
             Long.parseLong(finishTime),
             hostName, -1, null, state, maybeParseCounters(counters),
View Full Code Here

        MapAttempt20LineHistoryEventEmitter that =
            (MapAttempt20LineHistoryEventEmitter) thatg;

        if (finishTime != null && "success".equalsIgnoreCase(status)) {
          return new MapAttemptFinishedEvent
            (taskAttemptID,
              that.originalTaskType, status,
             Long.parseLong(finishTime),
             Long.parseLong(finishTime),
             hostName, null, state, maybeParseCounters(counters),
View Full Code Here

  @SuppressWarnings({ "unchecked" })
  private void logAttemptFinishedEvent(TaskAttemptState state) {
    //Log finished events only if an attempt started.
    if (getLaunchTime() == 0) return;
    if (attemptId.getTaskId().getTaskType() == TaskType.MAP) {
      MapAttemptFinishedEvent mfe =
         new MapAttemptFinishedEvent(TypeConverter.fromYarn(attemptId),
         TypeConverter.fromYarn(attemptId.getTaskId().getTaskType()),
         state.toString(),
         this.reportedStatus.mapFinishTime,
         finishTime,
         this.containerNodeId == null ? "UNKNOWN"
View Full Code Here

  @SuppressWarnings({ "unchecked" })
  private void logAttemptFinishedEvent(TaskAttemptStateInternal state) {
    //Log finished events only if an attempt started.
    if (getLaunchTime() == 0) return;
    if (attemptId.getTaskId().getTaskType() == TaskType.MAP) {
      MapAttemptFinishedEvent mfe =
         new MapAttemptFinishedEvent(TypeConverter.fromYarn(attemptId),
         TypeConverter.fromYarn(attemptId.getTaskId().getTaskType()),
         state.toString(),
         this.reportedStatus.mapFinishTime,
         finishTime,
         this.containerNodeId == null ? "UNKNOWN"
View Full Code Here

  @SuppressWarnings({ "unchecked" })
  private void logAttemptFinishedEvent(TaskAttemptStateInternal state) {
    //Log finished events only if an attempt started.
    if (getLaunchTime() == 0) return;
    if (attemptId.getTaskId().getTaskType() == TaskType.MAP) {
      MapAttemptFinishedEvent mfe =
         new MapAttemptFinishedEvent(TypeConverter.fromYarn(attemptId),
         TypeConverter.fromYarn(attemptId.getTaskId().getTaskType()),
         state.toString(),
         this.reportedStatus.mapFinishTime,
         finishTime,
         this.containerNodeId == null ? "UNKNOWN"
View Full Code Here

        MapAttempt20LineHistoryEventEmitter that =
            (MapAttempt20LineHistoryEventEmitter) thatg;

        if (finishTime != null && "success".equalsIgnoreCase(status)) {
          return new MapAttemptFinishedEvent(taskAttemptID,
              that.originalTaskType, status, Long.parseLong(finishTime), Long
                  .parseLong(finishTime), hostName, state,
              maybeParseCounters(counters));
        }
      }
View Full Code Here

TOP

Related Classes of org.apache.hadoop.mapreduce.jobhistory.MapAttemptFinishedEvent

Copyright © 2018 www.massapicom. All rights reserved.
All source code are property of their respective owners. Java is a trademark of Sun Microsystems, Inc and owned by ORACLE Inc. Contact coftware#gmail.com.