Example usage for org.apache.hadoop.mapreduce Reducer subclass-usage

List of usage examples for org.apache.hadoop.mapreduce Reducer subclass-usage

Introduction

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

Usage

From source file com.datasalt.pangool.tuplemr.mapred.SimpleCombiner.java

public class SimpleCombiner
        extends Reducer<DatumWrapper<ITuple>, NullWritable, DatumWrapper<ITuple>, NullWritable> {

    public final static String CONF_COMBINER_HANDLER = SimpleCombiner.class.getName() + ".combiner.handler";

    // Following variables protected to be shared by Combiners

From source file com.datasalt.pangool.tuplemr.mapred.SimpleReducer.java

/**
 * This is a proxy {@link Reducer} implementation that delegates its
 * funcionality to a {@link TupleReducer} instance configured by
 * {@link TupleMRBuilder#setTupleReducer(TupleReducer)}
 * 
 */

From source file com.datasalt.utils.mapred.BaseReducer.java

/**
 * 
 * A reducer that includes methods for serialize/deserialize
 * 
 * @author ivan
 */

From source file com.discursive.answers.CounterReducer.java

/**
 *
 * @author Max
 */
public class CounterReducer extends Reducer<Text, IntWritable, Text, IntWritable> {

From source file com.elex.dmp.vectorizer.TFPartialVectorReducer.java

/**
 * Converts a document in to a sparse vector
 */
public class TFPartialVectorReducer extends Reducer<Text, StringTuple, Text, VectorWritable> {

    private final OpenObjectIntHashMap<String> dictionary = new OpenObjectIntHashMap<String>();

From source file com.ema.hadoop.bestclient.BCReducer.java

public class BCReducer extends Reducer<Text, IntWritable, Text, IntWritable> {

    @Override
    public void reduce(Text key, Iterable<IntWritable> values, Context context)
            throws IOException, InterruptedException {
        int sum = 0;

From source file com.ema.hadoop.wordcount.WCReducer.java

/**
 *
 * @author sharispe
 */
public class WCReducer extends Reducer<Text, IntWritable, Text, IntWritable> {

From source file com.github.sakserv.minicluster.mapreduce.SumReducer.java

public class SumReducer extends Reducer<Text, IntWritable, Text, IntWritable> {

    private IntWritable totalWordCount = new IntWritable();

    @Override
    public void reduce(Text key, Iterable<IntWritable> values, Context context)

From source file com.github.sandgorgon.parmr.UserReducer.java

/**
 *
 * @author rdevera
 */
public class UserReducer extends Reducer<Text, Text, Text, Text> {

From source file com.github.ygf.pagerank.InLinksReducer.java

public class InLinksReducer extends Reducer<IntWritable, IntWritable, IntWritable, IntWritable> {

    @Override
    protected void reduce(IntWritable inKey, Iterable<IntWritable> inValues, Context context)
            throws IOException, InterruptedException {