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.littlehotspot.hadoop.mr.nginx.module.hdfs2hbase.api.user.UserMapper.java

/**
 * <h1>Mapper - </h1>
 *
 * @author <a href="http://www.lizhaoweb.cn">??(John.Lee)</a>
 * @version 1.0.0.0.1
 * @notes Created on 20170601<br>

From source file com.malsolo.hadoop.elephant.guide.MaxTemperatureMapper.java

/**
 *
 * @author jbeneito
 */
public class MaxTemperatureMapper extends Mapper<LongWritable, Text, Text, IntWritable> {

From source file com.mapr.db.utils.ImportCSV_MR.java

class MyMapper extends Mapper<LongWritable, Text, Value, Document> {

    static Logger logger = Logger.getLogger(MyMapper.class);

    private long id;
    private int increment;

From source file com.mapred.DepartmentMap.java

public class DepartmentMap extends Mapper<LongWritable, Text, DepDatePair, MapWritable> {

    MapWritable outputMap = new MapWritable();
    DepDatePair depKey = new DepDatePair();

    protected void map(LongWritable key, Text value, Context context) throws IOException, InterruptedException {

From source file com.mapred.EmployeeMap.java

public class EmployeeMap extends Mapper<LongWritable, Text, DepDatePair, MapWritable> {

    MapWritable outputMap = new MapWritable();
    DepDatePair depKey = new DepDatePair();

    @Override

From source file com.marcolotz.lung.mapper.LungMapper.java

/**
 * Mapper used in the HadoopLung application. All the images are processed in
 * the Map phase.
 * 
 * @author Marco Aurelio Lotz
 * 

From source file com.marklogic.contentpump.BaseMapper.java

/**
 * Content Pump base mapper with the capability to run in thread-safe mode.
 * 
 * @author jchen
 *
 * @param <KEYIN>

From source file com.marklogic.contentpump.MultithreadedMapper.java

/**
 * Multithreaded implementation for @link org.apache.hadoop.mapreduce.Mapper,
 * currently used by import operations when applicable to leverage concurrent
 * updates to MarkLogic.
 */
public class MultithreadedMapper<K1, V1, K2, V2> extends Mapper<K1, V1, K2, V2> {

From source file com.ml.hadoop.nlp.SequenceFileTokenizerMapper.java

/**
 * Tokenizes a text document and outputs tokens in a StringTuple
 */
public class SequenceFileTokenizerMapper extends Mapper<Text, Text, Text, StringTuple> {

    private Analyzer analyzer;

From source file com.ML_Hadoop.K_meansClustering.K_meansClusteringMap.java

public class K_meansClusteringMap extends Mapper<LongWritable, Text, LongWritable, FloatArrayWritable> {

    private ArrayList<Float[]> cetroid_of_clusters = new ArrayList<Float[]>();
    private ArrayList<Float[]> sum_of_members_in_a_cluster = new ArrayList<Float[]>();
    private int[] num_of_members_in_a_cluster;