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 net.broomie.reducer.TokenizeReducer.java

/**
 * The reducer class for tokenizing a Japanese document.
 * @author kimura
 *
 */
public class TokenizeReducer extends Reducer<Text, IntWritable, Text, IntWritable> {

From source file net.broomie.reducer.TokenizeReducerTFIDF.java

/**
 * The reduce class for counting co-occurrence for Japanese sentence.
 * @author kimura
 */
public class TokenizeReducerTFIDF extends Reducer<Text, IntWritable, Text, DoubleWritable> {

From source file net.java.jatextmining.lib.CoOccurrenceReducer.java

/**
 * The Reducer implementation class for counting co-occurrence words.
 * @author kimura
 */
public class CoOccurrenceReducer extends Reducer<Text, Text, Text, Text> {

From source file net.java.jatextmining.lib.CountReducer.java

/**
 * The Reducer implementation class for counting words of Japanese document.
 * @author kimura
 */
public class CountReducer extends Reducer<Text, DoubleWritable, Text, DoubleWritable> {

From source file net.novogrodsky.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 net.orpiske.tcs.wc.reduce.CountReducerFile.java

/**
 * This reducer saves the output to the FS. It's available for testing purposes only
 */
@Deprecated
public class CountReducerFile extends Reducer<OccurrenceWritable, IntWritable, OccurrenceWritable, IntWritable> {
    private static final Logger logger = Logger.getLogger(CountReducerFile.class);

From source file net.orpiske.tcs.wc.reduce.CountReducerTable.java

/**
 * This reducer dumps the result to a table on Cassandra
 */
public class CountReducerTable extends Reducer<OccurrenceWritable, IntWritable, ByteBuffer, ArrayList<Mutation>> {
    private static final Logger logger = Logger.getLogger(CountReducerTable.class);

From source file nl.bioinf.wvanhelvoirt.HadoopPhredCalculator.CombineReducer.java

/**
 * CombineReducer
 *
 * The Reducer class that combines the data from all the mappers to a single array.
 *
 * @author Wout van Helvoirt

From source file nl.gridline.free.taalserver.CountDocumentsReduce.java

/**
 * Count the documents reduce
 * <p />
 * Project hadoop-taalserver<br />
 * CountDocumentsReduce.java created 21 mrt. 2011
 * <p />

From source file nl.gridline.free.taalserver.DocCountPerWordReduce.java

/**
 * Round 4 - TFIdf calculation
 * <p />
 * Project hadoop-freetaalserver<br />
 * DocCountPerWordReduce.java created Sep 12, 2011
 * <p />