Example usage for org.apache.hadoop.mapred TaskID getTaskType

List of usage examples for org.apache.hadoop.mapred TaskID getTaskType

Introduction

In this page you can find the example usage for org.apache.hadoop.mapred TaskID getTaskType.

Prototype

public TaskType getTaskType() 

Source Link

Document

Get the type of the task.

Usage

From source file:org.apache.tez.mapreduce.hadoop.IDConverter.java

License:Apache License

public static TezTaskID fromMRTaskId(org.apache.hadoop.mapreduce.TaskID taskid) {
    return TezTaskID.getInstance(TezVertexID.getInstance(fromMRJobId(taskid.getJobID()),
            (taskid.getTaskType() == TaskType.MAP ? 0 : 1)), taskid.getId());
}

From source file:skewtune.mapreduce.STJobTracker.java

License:Apache License

private Future<JobID> fastSplitTask(TaskID taskid, int n) throws IOException, InterruptedException {
    JobInProgress jip = null;/*  ww w .  j  a  va  2 s.c  om*/
    synchronized (jobs) {
        jip = jobs.get(taskid.getJobID());
    }

    if (jip == null) {
        String msg = "unknown task " + taskid;
        LOG.error(msg);
        throw new IOException(msg);
    }

    TaskInProgress tip = jip.getTaskInProgress(taskid);
    ReactionContext context = taskid.getTaskType() == TaskType.MAP ? new ReexecMap(tip, n)
            : new ReexecReduce(tip);
    return fastSplitTask(context, true);

    //        return fastSplitTask(taskid,n,true);
}