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 com.cg.mapreduce.fpgrowth.mahout.fpm.AggregatorMapper.java

/**
 * 
 *  outputs the pattern for each item in the pattern, so that reducer can group them
 * and select the top K frequent patterns
 * 
 */

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

/**
 * 
 *  maps all items in a particular transaction like the way it is done in Hadoop
 * WordCount example
 * 
 */

From source file com.cg.mapreduce.fpgrowth.mahout.fpm.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
 * 
 */
@Deprecated

From source file com.cg.mapreduce.myfpgrowth.ParallelCountingMapper.java

/**
 * 
 *  maps all items in a particular transaction like the way it is done in Hadoop
 * WordCount example
 * 
 */

From source file com.cg.mapreduce.myfpgrowth.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, ArrayList<String>> {

From source file com.chinnu.churndetection.fuzzykmeans.FuzzyKMeansMapper.java

/**
 *
 * @author libin
 */
public class FuzzyKMeansMapper extends Mapper<LongWritable, Text, IntWritable, Vector> {

From source file com.chinnu.churndetection.kmeans.KMeansMapper.java

/**
 *
 * @author libin
 */
public class KMeansMapper extends Mapper<LongWritable, Text, IntWritable, Vector> {

From source file com.citic.zxyjs.zwlscx.mapreduce.join.api.DataJoinMapperBase.java

/**
 * This abstract class serves as the base class for the mapper class of a data
 * join job. This class expects its subclasses to implement methods for the
 * following functionalities: 1. Compute the source tag of input values 2.
 * Compute the map output value object 3. Compute the map output key object The
 * source tag will be used by the reducer to determine from which source (which

From source file com.ckelsel.hadoop.MaxTemperature.AppMapper.java

public class AppMapper extends Mapper<LongWritable, Text, Text, IntWritable> {
    @Override
    public void map(LongWritable key, Text value, Context context) throws IOException, InterruptedException {
        String line = value.toString();

    }

From source file com.cloudera.castagna.logparser.mr.StatusCodesStatsMapper.java

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

    private static final Logger log = LoggerFactory.getLogger(StatusCodesStatsMapper.class);
    private static final LogParser parser = new LogParser();

    private Text outTextKey = new Text();