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 com.bark.hadoop.lab3.AdjReducer.java

public class AdjReducer extends Reducer<Text, Text, Text, Text> {

    @Override
    public void reduce(Text key, Iterable<Text> values, Context context) throws IOException, InterruptedException {
        //aggregate all the pages that current page (key) links to in one tab seperated string.
        String line = "";

From source file com.bark.hadoop.lab3.PageCountReducer.java

public class PageCountReducer 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 com.bark.hadoop.lab3.PageRankReducer.java

public class PageRankReducer extends Reducer<Text, Text, Text, Text> {

    @Override
    public void reduce(Text key, Iterable<Text> values, Context context) throws IOException, InterruptedException {
        double newPageRank = 0;
        /**

From source file com.bark.hadoop.lab3.RedLinkReducer.java

public class RedLinkReducer extends Reducer<Text, Text, Text, Text> {

    @Override
    public void reduce(Text key, Iterable<Text> values, Context context) throws IOException, InterruptedException {
        boolean isRedLink = true;
        //hashset to remove duplicates

From source file com.bark.hadoop.lab3.SortReducer.java

public class SortReducer extends Reducer<DoubleWritable, Text, Text, DoubleWritable> {

    @Override
    public void reduce(DoubleWritable key, Iterable<Text> values, Context context)
            throws IOException, InterruptedException {
        //reducer is given (pagerank,page) pairs. Internally sorts it (@see MyWritableComparator). 

From source file com.bizosys.hsearch.kv.indexing.KVReducerMapFile.java

class KVReducerMapFile extends Reducer<TextPair, Text, Text, BytesWritable> {

    public static boolean DEBUG_ENABLED = IdSearchLog.l.isDebugEnabled();
    public static boolean INFO_ENABLED = IdSearchLog.l.isInfoEnabled();

    public KV onReduce(KV kv) {

From source file com.cg.mapreduce.fpgrowth.mahout.fpm.AggregatorReducer.java

/**
 * 
 *  groups all Frequent Patterns containing an item and outputs the top K patterns
 * containing that particular item
 * 
 */

From source file com.cg.mapreduce.fpgrowth.mahout.fpm.ParallelCountingReducer.java

/**
 *  sums up the item count and output the item and the count This can also be
 * used as a local Combiner. A simple summing reducer
 */
@Deprecated
public class ParallelCountingReducer extends Reducer<Text, LongWritable, Text, LongWritable> {

From source file com.cg.mapreduce.fpgrowth.mahout.fpm.ParallelFPGrowthCombiner.java

/**
 *  takes each group of dependent transactions and\ compacts it in a
 * TransactionTree structure
 */
@Deprecated
public class ParallelFPGrowthCombiner extends Reducer<IntWritable, TransactionTree, IntWritable, TransactionTree> {

From source file com.cg.mapreduce.fpgrowth.mahout.fpm.ParallelFPGrowthReducer.java

/**
 *  takes each group of transactions and runs Vanilla FPGrowth on it and
 * outputs the the Top K frequent Patterns for each group.
 * 
 */
@Deprecated