Package org.apache.hadoop.tools.rumen

Examples of org.apache.hadoop.tools.rumen.TaskAttemptInfo


    TaskID taskId = taskAttemptID.getTaskID();
    if (!taskId.isMap()) {
      assert false : "Task " + taskId + " is not MAP :";
    }
   
    TaskAttemptInfo taskAttemptInfo = jobStory.getMapTaskAttemptInfoAdjusted(
        taskId.getId(), taskAttemptID.getId(), locality);

    if (LOG.isDebugEnabled()) {
      LOG.debug("get an attempt: "
          + taskAttemptID.toString()
          + ", state="
          + taskAttemptInfo.getRunState()
          + ", runtime="
          + ((taskId.isMap()) ? taskAttemptInfo.getRuntime()
              : ((ReduceTaskAttemptInfo) taskAttemptInfo).getReduceRuntime()));
    }
    return taskAttemptInfo;
  }
View Full Code Here


      taskType = TaskType.MAP;
    } else {
      taskType = TaskType.REDUCE;
    }

    TaskAttemptInfo taskAttemptInfo = jobStory.getTaskAttemptInfo(taskType,
        taskId.getId(), taskAttemptID.getId());
    if (LOG.isDebugEnabled()) {
      LOG.debug("get an attempt: "
          + taskAttemptID.toString()
          + ", state="
          + taskAttemptInfo.getRunState()
          + ", runtime="
          + ((taskAttemptID.isMap()) ? taskAttemptInfo.getRuntime()
              : ((ReduceTaskAttemptInfo) taskAttemptInfo).getReduceRuntime()));
    }
    return taskAttemptInfo;
  }
View Full Code Here

    long mapRunTime = 5678;
    long reduceShuffleTime = 0;
    long reduceSortTime = 0;
    long reduceRunTime = 1234;
    TaskInfo task = new TaskInfo(bytesin, recsin, bytesout, recsout, maxMem);
    TaskAttemptInfo tAInfo = null;
    if (taskType == TaskType.MAP) {
      tAInfo = new MapTaskAttemptInfo(TaskStatus.State.SUCCEEDED,
          task, mapRunTime);
    } else if (taskType == TaskType.REDUCE) {
      tAInfo = new ReduceTaskAttemptInfo(TaskStatus.State.SUCCEEDED,
View Full Code Here

TOP

Related Classes of org.apache.hadoop.tools.rumen.TaskAttemptInfo

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.