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.talis.mapreduce.dicenc.SecondReducer.java

public class SecondReducer extends Reducer<Text, Text, Text, Text> {

    private long counter = 0;
    private MultipleOutputs<Text, NullWritable> mos;

    @Override

From source file com.talis.mapreduce.dicenc.ThirdReducer.java

public class ThirdReducer extends Reducer<Text, Text, NullWritable, Text> {

    @Override
    public void reduce(Text key, Iterable<Text> values, Context context) throws IOException, InterruptedException {

        String s = null;

From source file com.talis.mapreduce.wordcount.newapi.WordCountReducer.java

public class WordCountReducer extends Reducer<Text, IntWritable, Text, IntWritable> {
    private IntWritable result = new IntWritable();

    @Override
    protected void reduce(Text key, Iterable<IntWritable> values, Context context)
            throws IOException, InterruptedException {

From source file com.tdunning.plume.local.lazy.MSCRCombiner.java

/**
 * Combiner that is used to executed MSCR in Map/reds
 */
public class MSCRCombiner extends Reducer<PlumeObject, PlumeObject, PlumeObject, PlumeObject> {

    MSCR mscr; // Current MSCR being executed

From source file com.tdunning.plume.local.lazy.MSCRReducer.java

/**
 * Reducer that is used to execute MSCR in MapReds
 */
public class MSCRReducer extends Reducer<PlumeObject, PlumeObject, NullWritable, NullWritable> {

    MultipleOutputs mos;

From source file com.telefonica.iot.tidoop.mrlib.combiners.LinesCombiner.java

/**
 * Lines Combiner.
 */
public class LinesCombiner extends Reducer<Text, Text, Text, Text> {

    @Override

From source file com.telefonica.iot.tidoop.mrlib.reducers.LinesJoiner.java

/**
 * LinesJoiner.
 */
public class LinesJoiner extends Reducer<Text, Text, NullWritable, Text> {

    @Override

From source file com.test.hadoop.unoExample.CardTotalReducer.java

public class CardTotalReducer 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.tfm.utad.reducerdata.ReducerDataPigReducer.java

public class ReducerDataPigReducer extends Reducer<LongWritable, ReducerPigKey, Text, NullWritable> {

    @Override
    public void reduce(LongWritable key, Iterable<ReducerPigKey> values, Context context)
            throws IOException, InterruptedException {
        for (ReducerPigKey value : values) {

From source file com.tfm.utad.reducerdata.ReducerDataVerticaReducer.java

public class ReducerDataVerticaReducer extends Reducer<Text, ReducerVerticaValue, Text, NullWritable> {

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