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

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

Introduction

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

Usage

From source file hadoop.WordCountReducer.java

/**
 * @author NHN Technology services. Kwanil Lee.
 */
public class WordCountReducer extends MapReduceBase implements Reducer<Text, IntWritable, Text, IntWritable> {
    @Override
    public void reduce(Text key, Iterator<IntWritable> values, OutputCollector<Text, IntWritable> output,

From source file hadoopProcesses.map.java

/**
 *
 * @author madhatter
 */
public class map extends MapReduceBase implements Mapper<LongWritable, Text, Text, IntWritable> {

From source file hadoopProcesses.reducer.java

/**
 *
 * @author madhatter
 */
public class reducer extends MapReduceBase implements Reducer<Text, IntWritable, Text, IntWritable> {
    public void reduce(Text key, Iterator<IntWritable> values, OutputCollector<Text, IntWritable> output,

From source file infinidb.hadoop.example.InfiniDoopInputMapper.java

public class InfiniDoopInputMapper extends MapReduceBase
        implements Mapper<LongWritable, InfiniDoopRecord, LongWritable, Text> {

    public void map(LongWritable key, InfiniDoopRecord val, OutputCollector<LongWritable, Text> output,
            Reporter reporter) throws IOException {
        output.collect(new LongWritable(val.id), new Text(val.name));

From source file infinidb.hadoop.example.InfiniDoopMapper.java

/** Dummy mapper, basically doing nothing. the real job is invoked by input format */
public class InfiniDoopMapper extends MapReduceBase
        implements Mapper<NullWritable, NullWritable, NullWritable, NullWritable> {

    public void map(NullWritable key, NullWritable val, OutputCollector<NullWritable, NullWritable> output,
            Reporter reporter) throws IOException {

From source file init.InitMapper.java

public class InitMapper extends MapReduceBase implements Mapper<WritableComparable, Text, Text, IntWritable> {

    private IntWritable one = new IntWritable(1);
    private Text word = new Text();

    public void map(WritableComparable key, Text values, OutputCollector<Text, IntWritable> output,

From source file init.UpdateDataMapper.java

public class UpdateDataMapper extends MapReduceBase implements Mapper<WritableComparable, Text, Text, Text> {

    static Logger log = Logger.getLogger(UpdateDataMapper.class);
    private HashMap<String, Integer> fmap = new HashMap<String, Integer>();
    //private final static int supp=0;

From source file invertedIndex.lineIndexMapper.java

/**
 *
 * @author madhatter
 */
public class lineIndexMapper extends MapReduceBase implements Mapper<LongWritable, Text, Text, Text> {

From source file invertedIndex.lineIndexReducer.java

/**
 *
 * @author madhatter
 */
public class lineIndexReducer extends MapReduceBase implements Reducer<Text, Text, Text, Text> {

From source file io.aos.t4f.hadoop.mapred.WordCountMapper.java

public class WordCountMapper extends MapReduceBase implements Mapper<Text, Text, Text, IntWritable> {

    private final static IntWritable one = new IntWritable(1);
    private Text word = new Text();

    @Override