Example usage for org.apache.hadoop.mapred MapRunnable run

List of usage examples for org.apache.hadoop.mapred MapRunnable run

Introduction

In this page you can find the example usage for org.apache.hadoop.mapred MapRunnable run.

Prototype

void run(RecordReader<K1, V1> input, OutputCollector<K2, V2> output, Reporter reporter) throws IOException;

Source Link

Document

Start mapping input <key, value> pairs.

Usage

From source file:org.apache.tez.mapreduce.processor.map.MapProcessor.java

License:Apache License

void runOldMapper(final JobConf job, final MRTaskReporter reporter, final MRInputLegacy input,
        final KeyValueWriter output) throws IOException, InterruptedException {

    // Initialize input in-line since it sets parameters which may be used by the processor.
    // Done only for MRInput.
    // TODO use new method in MRInput to get required info
    //input.initialize(job, master);

    InputSplit inputSplit = input.getOldInputSplit();

    updateJobWithSplit(job, inputSplit);

    RecordReader in = new OldRecordReader(input);

    OutputCollector collector = new OldOutputCollector(output);

    MapRunnable runner = (MapRunnable) ReflectionUtils.newInstance(job.getMapRunnerClass(), job);

    runner.run(in, collector, (Reporter) reporter);

    // Set progress to 1.0f if there was no exception,
    reporter.setProgress(1.0f);/*  w  w w .  java2 s. com*/
    // start the sort phase only if there are reducers
    this.statusUpdate();
}