Example usage for org.apache.hadoop.mapred MapRunner subclass-usage

List of usage examples for org.apache.hadoop.mapred MapRunner subclass-usage

Introduction

In this page you can find the example usage for org.apache.hadoop.mapred MapRunner subclass-usage.

Usage

From source file edu.stolaf.cs.wmrserver.streaming.PipeMapRunner.java

public class PipeMapRunner<K1, V1, K2, V2> extends MapRunner<K1, V1, K2, V2> {
    public void run(RecordReader<K1, V1> input, OutputCollector<K2, V2> output, Reporter reporter)
            throws IOException {
        PipeMapper pipeMapper = (PipeMapper) getMapper();
        pipeMapper.startOutputThreads(output, reporter);
        super.run(input, output, reporter);

From source file edu.ucsb.cs.hybrid.mappers.SingleS_Runner.java

public class SingleS_Runner
        extends MapRunner<LongWritable, FeatureWeightArrayWritable, DocDocWritable, FloatWritable> {

    protected JobConf conf;
    protected SingleS_Mapper mapper;
    /** Number of vectors assigned to each map task */

From source file it.crs4.pydoop.pipes.PipesMapRunner.java

/**
 * An adaptor to run a C++ mapper.
 */
class PipesMapRunner<K1 extends WritableComparable, V1 extends Writable, K2 extends WritableComparable, V2 extends Writable>
        extends MapRunner<K1, V1, K2, V2> {
    private JobConf job;

From source file org.apache.avro.mapred.tether.TetherMapRunner.java

class TetherMapRunner extends MapRunner<TetherData, NullWritable, TetherData, NullWritable> {

    static final Logger LOG = LoggerFactory.getLogger(TetherMapRunner.class);

    private JobConf job;
    private TetheredProcess process;

From source file org.commoncrawl.hadoop.template.SampleHadoopJob.java

/**
 * 
 * @author rana
 * 
 */
public class SampleHadoopJob extends MapRunner<Text, ArcFileItem, Text, Text> {

From source file org.commoncrawl.mapred.pipelineV3.RegExFilter.java

/**
 * 
 * @author rana
 *
 */
public class RegExFilter extends MapRunner<TextBytes, TextBytes, TextBytes, TextBytes> {