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 io.apigee.lembos.mapreduce.LembosCombiner.java

/**
 * Extension of {@link Reducer} that allows a Node.js MapReduce job author to export a <strong>combine</strong>
 * function to implement the combine functionality for their job.
 */
public class LembosCombiner extends Reducer<WritableComparable<?>, Writable, WritableComparable<?>, Writable> {

From source file io.apigee.lembos.mapreduce.LembosReducer.java

/**
 * Extension of {@link Reducer} that allows a Node.js MapReduce job author to export a <strong>reduce</strong>
 * function to implement the reduce functionality for their job.
 */
public class LembosReducer extends Reducer<WritableComparable<?>, Writable, WritableComparable<?>, Writable> {

From source file io.covert.util.UniqueKeyOnlyReducer.java

public class UniqueKeyOnlyReducer<K1, V1> extends Reducer<K1, V1, K1, org.apache.hadoop.io.Text> {

    Text value = new Text("");

    protected void reduce(K1 key, Iterable<V1> ignored, Context context)
            throws java.io.IOException, InterruptedException {

From source file ipldataanalysis.DataAnalysisReducer.java

/**
 *
 * @author Gany
 */
public class DataAnalysisReducer extends Reducer<Text, Text, Text, Text> {

From source file ipldataanalysis.DataAnalysisReducer3.java

/**
 *
 * @author Gany
 */
public class DataAnalysisReducer3 extends Reducer<LongWritable, Text, Text, LongWritable> {

From source file ipldataanalysis3.DataAnalysisReducer.java

/**
 *
 * @author Gany
 */
public class DataAnalysisReducer extends Reducer<Text, IntWritable, Text, Text> {
    public void reduce(Text key, Iterable<IntWritable> values, Context context)

From source file it.crs4.pydoop.mapreduce.pipes.PipesReducer.java

/**
 * This class is used to talk to a C++ reduce task.
 */
class PipesReducer<K2 extends WritableComparable, V2 extends Writable, K3 extends WritableComparable, V3 extends Writable>
        extends Reducer<K2, V2, K3, V3> {
    private static final Log LOG = LogFactory.getLog(PipesReducer.class.getName());

From source file it.polito.dbdmg.searum.itemsets.ExpandClosedReducer.java

/**
 * 
 * @author Luigi Grimaudo
 * @version 0.0.1 groups all regular itemset and output unique itemset and
 *          support pair
 * 

From source file it.polito.dbdmg.searum.itemsets.ParallelFPGrowthCombiner.java

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

From source file it.polito.dbdmg.searum.itemsets.ParallelFPGrowthReducer.java

/**
 * takes each group of transactions and runs vanilla FPGrowth on it and outputs
 * the the Top K frequent Patterns for each group.
 * 
 */
public final class ParallelFPGrowthReducer extends Reducer<IntWritable, TransactionTree, Text, TopKStringPatterns> {