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 DAAL.NaiveBayesStep2TrainingReducerAndPrediction.java

public class NaiveBayesStep2TrainingReducerAndPrediction
        extends Reducer<IntWritable, WriteableData, IntWritable, WriteableData> {

    private static final long nClasses = 20;

    private static final int nDataFeatures = 20;

From source file DAAL.PcaCorStep2Reducer.java

public class PcaCorStep2Reducer extends Reducer<IntWritable, WriteableData, IntWritable, WriteableData> {

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

From source file DAAL.PcaSvdStep2Reducer.java

public class PcaSvdStep2Reducer extends Reducer<IntWritable, WriteableData, IntWritable, WriteableData> {

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

From source file DAAL.QRStep2Reducer.java

public class QRStep2Reducer extends Reducer<IntWritable, WriteableData, IntWritable, WriteableData> {

    private static final int nFeatures = 18;
    private static final int nVectors = 16000;
    private static final int nVectorsInBlock = 4000;
    private int nBlocks;

From source file DAAL.SVDStep2Reducer.java

public class SVDStep2Reducer extends Reducer<IntWritable, WriteableData, IntWritable, WriteableData> {

    private static final int nFeatures = 18;
    private static final int nVectors = 16000;
    private static final int nVectorsInBlock = 4000;
    private int nBlocks;

From source file datafu.hourglass.mapreduce.DelegatingCombiner.java

/**
 * A Hadoop combiner which delegates to an implementation read from the distributed cache.
 * 
 * @author "Matthew Hayes"
 *
 */

From source file datafu.hourglass.mapreduce.DelegatingReducer.java

/**
 * A Hadoop reducer which delegates to an implementation read from the distributed cache.
 * 
 * @author "Matthew Hayes"
 *
 */

From source file dbscan.DBScanReducer.java

/**
 * This class realizes the reduce function.
 * 
 * @author Marco Sero
 *
 */

From source file de.l3s.common.features.hadoop.TimeSeriesReducer.java

public class TimeSeriesReducer extends Reducer<Text, Timeseries, Text, DoubleWritable> {

    TimeSeriesFeatures eval = new TimeSeriesFeatures();

    public void reduce(Text key, Iterator<Timeseries> values, Context context)
            throws IOException, InterruptedException {

From source file de.tudarmstadt.ukp.dkpro.bigdata.collocations.AssocReducer.java

/**
 * Reducer for pass 2 of the collocation discovery job. Collects ngram and
 * sub-ngram frequencies and performs the Log-likelihood ratio calculation.
 */
public class AssocReducer extends Reducer<Gram, Gram, Text, DoubleWritable> {