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 nl.gridline.zieook.inx.movielens.hbase.UserExportReduce.java

/**
 * [purpose]
 * <p />
 * Project zieook-movielens<br />
 * UserExportReduce.java created 4 mrt. 2011
 * <p />

From source file nl.gridline.zieook.inx.movielens.items.FilterDataReduce.java

/**
 * [purpose]
 * <p />
 * Project zieook-movielens<br />
 * FilterDataReduce.java created 5 apr. 2011
 * <p />

From source file nl.gridline.zieook.statistics.popularity.PopularityCountReduce.java

/**
 * <p>
 * </p>
 * Project zieook-movielens<br />
 * PopularityCountReduce.java created 13 dec. 2011
 * <p />

From source file nl.gridline.zieook.statistics.popularity.PopularityReduce.java

/**
 * [purpose]
 * <p />
 * Project zieook-movielens<br />
 * PopularityReduce.java created 13 dec. 2011
 * <p />

From source file nl.sanoma.hdt.report.generator.ReportGeneratorReducer.java

/**
 * Reducer to calculate the most popular category and revenue by quarter for
 * each user
 *
 * @author Richrd Ern Kiss
 */

From source file nl.tudelft.graphalytics.mapreducev2.conversion.DirectedVertexReducer.java

/**
 * Reduces a list of edges in both directions for a single vertex to a single line of output.
 *
 * @author Tim Hegeman
 */
public class DirectedVertexReducer extends Reducer<LongWritable, EdgeData, NullWritable, Text> {

From source file nl.tudelft.graphalytics.mapreducev2.conversion.UndirectedVertexReducer.java

/**
 * Reduces a set of incoming edges for a vertex to a single line of ourput.
 *
 * @author Tim Hegeman
 */
public class UndirectedVertexReducer extends Reducer<LongWritable, LongWritable, NullWritable, Text> {

From source file nutchIndexer.NutchReduce.java

/**
 * Reducer class for the Nutch approach
 * @author tomas
 */
public class NutchReduce extends Reducer<IntWritable, MapWritable, Text, Text> {
    InvertedIndex invertedIndex;

From source file org.adamr.tsponmapreduce.mr.BruteReducer.java

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

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

From source file org.ankus.mapreduce.algorithms.clustering.kmeans.KMeansClusterUpdateReducer.java

public class KMeansClusterUpdateReducer extends Reducer<IntWritable, Text, NullWritable, Text> {

    String mDelimiter; // delimiter for attribute separation

    int mIndexArr[]; // index array used as clustering feature
    int mNominalIndexArr[]; // index array of nominal attributes used as clustering features