Example usage for org.apache.hadoop.mapreduce Mapper subclass-usage

List of usage examples for org.apache.hadoop.mapreduce Mapper subclass-usage

Introduction

In this page you can find the example usage for org.apache.hadoop.mapreduce Mapper subclass-usage.

Usage

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

/**
 * 
 * @author Luigi Grimaudo
 * @version 0.0.1 map each closed itemset with its complete set
 *
 */

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

/**
 * maps each transaction to all unique items groups in the transaction. mapper
 * outputs the group id as key and the transaction as value
 * 
 */
public class ParallelFPGrowthMapper extends Mapper<LongWritable, Text, IntWritable, TransactionTree> {

From source file it.polito.dbdmg.searum.itemsets.sorting.ClosedSortingMapper.java

/**
 * @author Luigi Grimaudo
 * @version 0.1
 * 
 */
public class ClosedSortingMapper extends Mapper<Text, TopKStringPatterns, LongWritable, Text> {

From source file it.polito.dbdmg.searum.itemsets.sorting.ItemsetSortingMapper.java

/**
 * @author Luigi Grimaudo
 * @version 0.1
 * 
 *          sorting mapper
 * 

From source file it.polito.dbdmg.searum.rules.RuleAggregatorMapper.java

/**
 * 
 * @author Luigi Grimaudo
 * @version 0.0.1 map each rule with the items present inside.
 */
public class RuleAggregatorMapper extends Mapper<LongWritable, Text, Text, Text> {

From source file it.polito.dbdmg.searum.rules.RuleMiningMapper.java

/**
 * 
 * @author Luigi Grimaudo
 * @version 0.0.1 map each itemset with the itemset itself and all the
 *          sub-itemset from the conditional pattern base of a single item
 *

From source file it.polito.dbdmg.searum.utils.ParallelCountingMapper.java

/**
 * Map all items in a transaction
 * 
 * @author Luigi Grimaudo
 *
 */

From source file it.uniroma1.hadoop.pagerank.job1.PageRankJob1Mapper.java

public class PageRankJob1Mapper extends Mapper<LongWritable, Text, Text, Text> {

    @Override
    public void map(LongWritable key, Text value, Context context) throws IOException, InterruptedException {

        /* Job#1 mapper will simply parse a line of the input graph creating a map with key-value(s) pairs.

From source file it.uniroma1.hadoop.pagerank.job2.PageRankJob2Mapper.java

public class PageRankJob2Mapper extends Mapper<LongWritable, Text, Text, Text> {

    @Override
    public void map(LongWritable key, Text value, Context context) throws IOException, InterruptedException {

        /* PageRank calculation algorithm (mapper)

From source file it.uniroma1.hadoop.pagerank.job3.PageRankJob3Mapper.java

public class PageRankJob3Mapper extends Mapper<LongWritable, Text, DoubleWritable, Text> {

    @Override
    public void map(LongWritable key, Text value, Context context) throws IOException, InterruptedException {

        /* Rank Ordering (mapper only)