Package org.apache.hadoop.tools.rumen

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


        org.apache.hadoop.mapred.TaskAttemptID.downgrade(taskId);       
    Task task = new MapTask("dummyjobfile", taskIdOldApi, 0, "dummysplitclass",
                            null, numSlotsRequired);
    // all byte counters are 0
    TaskInfo taskInfo = new TaskInfo(0, 0, 0, 0, 0);
    MapTaskAttemptInfo taskAttemptInfo =
        new MapTaskAttemptInfo(State.SUCCEEDED, taskInfo, mapRuntime);
    TaskTrackerAction action =
        new SimulatorLaunchTaskAction(task, taskAttemptInfo);
    heartbeats.get(mapStart).get(taskTrackerName).addTaskTrackerAction(action);
    if (isKilled) {
      action = new KillTaskAction(taskIdOldApi);
View Full Code Here


    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,
          task, reduceShuffleTime, reduceSortTime, reduceRunTime);
    } else {
View Full Code Here

TOP

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

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.