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 de.tudarmstadt.ukp.dkpro.bigdata.collocations.CollocCombiner.java

/** Combiner for pass1 of the CollocationDriver. Combines frequencies for values for the same key */
public class CollocCombiner extends Reducer<GramKey, Gram, GramKey, Gram> {

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

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

/**
 * Reducer for Pass 1 of the collocation identification job. Generates counts for ngrams and subgrams.
 */
public class CollocReducer extends Reducer<GramKey, Gram, Gram, Gram> {

    private static final Logger log = LoggerFactory.getLogger(CollocReducer.class);

From source file de.tudarmstadt.ukp.dkpro.c4corpus.hadoop.deduplication.DeDuplicationTextOutputReducer.java

/**
 * Documents that have the same bands are grouped together.
 *
 * @author Omnia Zayed
 */
public class DeDuplicationTextOutputReducer extends Reducer<Text, DocumentInfo, NullWritable, List<DocumentInfo>> {

From source file de.tudarmstadt.ukp.dkpro.c4corpus.hadoop.full.WARCWriterReducerClass.java

/**
 * Reducer for writing WARC records to output files given the language, license, etc.
 *
 * @author Ivan Habernal
 */
public class WARCWriterReducerClass extends Reducer<Text, WARCWritable, NullWritable, WARCWritable> {

From source file de.tudarmstadt.ukp.dkpro.c4corpus.hadoop.statistics.helper.DistributionReducer.java

/**
 * For each text key, writes the distribution of values into text outupt (with graduation: 100)
 */
public class DistributionReducer extends Reducer<Text, LongWritable, Text, Text> {
    @Override
    protected void reduce(Text key, Iterable<LongWritable> values, Context context)

From source file de.tudarmstadt.ukp.dkpro.c4corpus.hadoop.statistics.helper.TextLongCountingReducer.java

/**
 * Sums up the counts of text keys
 */
public class TextLongCountingReducer extends Reducer<Text, LongWritable, Text, LongWritable> {
    @Override
    protected void reduce(Text key, Iterable<LongWritable> values, Context context)

From source file demo.SsReducer.java

/**
 * Secondary sort reducer.
 * @author Jee Vang
 *
 */
public class SsReducer extends Reducer<StockKey, DoubleWritable, Text, Text> {

From source file dgCombIndexer.DgCombCombiner.java

/**
 * Reducer class for the D&G approach
 * @author tomas
 */
public class DgCombCombiner extends Reducer<Text, IntWritable, Text, PostingList> {

From source file dgCombIndexer.DgCombReduce.java

/**
 * Reducer class for the D&G approach
 * @author tomas
 */
public class DgCombReduce extends Reducer<Text, Text, Text, Text> {

From source file dgIndexer.DgReduce.java

/**
 * Reducer class for the D&G approach
 * @author tomas
 */
public class DgReduce extends Reducer<Text, IntWritable, Text, Text> {