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.ML_Hadoop.MultipleLinearRegression.MultipleLinearRegressionMap.java

public class MultipleLinearRegressionMap extends Mapper<LongWritable, Text, LongWritable, FloatWritable> {

    FileInputStream fis = null;
    BufferedInputStream bis = null;
    private Float[] theta;
    private ArrayList<ArrayList<Float>> prediction_error = new ArrayList<ArrayList<Float>>();

From source file com.ML_Hadoop.NaiveBayesClassifier_Continuous_Features.NaiveBayesClassifierMap_Continuous_Features.java

public class NaiveBayesClassifierMap_Continuous_Features
        extends Mapper<LongWritable, Text, LongWritable, MapArrayWritable> {

    private Float[] features;
    private int class_id;
    private int number_of_classes, number_of_features;

From source file com.mongodb.hadoop.examples.lolmatches.LOLMatchesdMapper.java

/**
 * The treasury yield mapper.
 */
public class LOLMatchesdMapper extends Mapper<Object, BSONObject, IntWritable, DoubleWritable>
        implements org.apache.hadoop.mapred.Mapper<Object, BSONWritable, IntWritable, DoubleWritable> {

From source file com.mongodb.hadoop.examples.treasury.TreasuryYieldMapper.java

/**
 * The treasury yield mapper.
 */
public class TreasuryYieldMapper extends Mapper<Object, BSONObject, IntWritable, DoubleWritable>
        implements org.apache.hadoop.mapred.Mapper<Object, BSONWritable, IntWritable, DoubleWritable> {

From source file com.mongodb.hadoop.examples.TreasuryYieldMapper.java

public class TreasuryYieldMapper extends Mapper<java.util.Date, BSONObject, IntWritable, DoubleWritable> {

    private static final Log log = LogFactory.getLog(TreasuryYieldMapper.class);

    public void map(java.util.Date key, BSONObject value, Context context)
            throws IOException, InterruptedException {

From source file com.mongodb.hadoop.examples.ufos.UfoSightingsMapper.java

/**
 * The UFO Sightings yield mapper.
 */
public class UfoSightingsMapper extends Mapper<Object, BSONObject, Text, IntWritable> {

    private static final Log LOG = LogFactory.getLog(UfoSightingsMapper.class);

From source file com.mongodb.hadoop.examples.WorldDevIndicatorMapper.java

/**
 * The world development indicator mapper. This example looks at:
 *
 * <pre>
 * SeriesCode : SL.GDP.PCAP.EM.KD
 * Series Name : GDP per person employed (constant 1990 PPP $)

From source file com.mongodb.hadoop.examples.world_development.WorldDevIndicatorMapper.java

/**
 * The world development indicator mapper. This example looks at:
 *
 * <pre>
 * SeriesCode : SL.GDP.PCAP.EM.KD
 * Series Name : GDP per person employed (constant 1990 PPP $)

From source file com.moz.fiji.mapreduce.FijiMapper.java

/**
 * Base class for Fiji mappers.
 *
 * @param <INKEY> The type of the input key to the mapper.
 * @param <INVALUE> The type of the input value to the mapper.
 * @param <OUTKEY> The type of the output key from the mapper.

From source file com.mycompany.hadooptrain.WordCountMapper.java

public class WordCountMapper extends Mapper<Object, Text, Text, IntWritable> {

    private final IntWritable ONE = new IntWritable(1);
    private Text word = new Text();

    public void map(Object key, Text value, Context context) throws IOException, InterruptedException {