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 drdoobs.LongSumReducer.java

/**
 *
 * @author haibane
 * @param <KEY>
 */
public class LongSumReducer<KEY> extends Reducer<KEY, LongWritable, KEY, LongWritable> {

From source file dsll.pinterest.crawler.Reduce.java

/**
 *
 * @author Ted
 */
public class Reduce extends Reducer<Text, Text, Text, Text> {
    private final static Text pin = new Text("pin");

From source file dz.lab.mapred.StartsWithCountReducer.java

public class StartsWithCountReducer extends Reducer<Text, IntWritable, Text, IntWritable> {
    @Override
    protected void reduce(Text token, Iterable<IntWritable> counts, Context context)
            throws IOException, InterruptedException {
        int sum = 0;
        for (IntWritable count : counts) {

From source file dz.lab.mapred.workflow.MostSeenStartLetterReducer.java

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

}

From source file edu.cse.analyser.components.TempReducer.java

/**
 * Common Reducer for all the Mappers used in the application.
 */
public class TempReducer extends Reducer<Text, LongWritable, Text, LongWritable> {

    private static final long SCALE = 10;

From source file edu.cuhk.hccl.hadoop.ReviewReducer.java

public class ReviewReducer extends Reducer<UserItemPair, NounPhrase, Text, Text> {

    private SentiWordNet swn = new SentiWordNet();
    private Text txtKey = new Text();
    private Text txtValue = new Text();

From source file edu.indiana.d2i.htrc.corpus.analysis.LDAAnalysisReducer.java

public class LDAAnalysisReducer extends Reducer<Text, LDAState, Text, LDAState> {

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

From source file edu.indiana.d2i.htrc.corpus.clean.CleanCorpusReducer.java

/**
 * Identity Reducer, actually can be omitted
 * 
 * @author Guangchen Ruan
 * 
 */

From source file edu.indiana.d2i.htrc.corpus.retrieve.RetrieveRawCorpusReducer.java

public class RetrieveRawCorpusReducer extends Reducer<Text, TextArrayWritable, Text, TextArrayWritable> {

    @Override
    public void reduce(Text key, Iterable<TextArrayWritable> values, Context context)
            throws IOException, InterruptedException {
        /* key is volume id, value is pages */

From source file edu.indiana.d2i.htrc.corpus.transform.CorpusTransformReducer.java

public class CorpusTransformReducer extends Reducer<Text, TextArrayWritable, Text, TextArrayWritable> {

    @Override
    public void reduce(Text key, Iterable<TextArrayWritable> values, Context context)
            throws IOException, InterruptedException {
        /* key is volume id, value is pages */