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.mycompany.maprpractice.Mapper.WordCountMapper.java

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

    private final static IntWritable one = new IntWritable(1);
    private Text word = new Text();

    @Override

From source file com.nearinfinity.blur.mapreduce.BlurMapper.java

public abstract class BlurMapper<KEY, VALUE> extends Mapper<KEY, VALUE, BytesWritable, BlurMutate> {

    protected BlurMutate _mutate;
    protected BytesWritable _key;
    protected BlurTask _blurTask;
    protected Counter _recordCounter;

From source file com.nearinfinity.honeycomb.hbase.bulkload.BulkLoadMapper.java

/**
 * Mapper for loading large amounts of data into Honeycomb format.
 */
public class BulkLoadMapper extends Mapper<LongWritable, Text, ImmutableBytesWritable, Put> {
    static final Logger LOG = Logger.getLogger(BulkLoadMapper.class);
    private RowParser rowParser;

From source file com.netease.news.classifier.naivebayes.BayesTestMapper.java

/**
 * Run the input through the model and see if it matches.
 * <p/>
 * The output value is the generated label, the Pair is the expected label and true if they match:
 */
public class BayesTestMapper extends Mapper<Text, VectorWritable, Text, VectorWritable> {

From source file com.netease.news.classifier.naivebayes.IndexInstancesMapper.java

public class IndexInstancesMapper extends Mapper<Text, VectorWritable, IntWritable, VectorWritable> {

    private static final Pattern SLASH = Pattern.compile("/");

    public enum Counter {
        SKIPPED_INSTANCES

From source file com.netease.news.classifier.naivebayes.ThetaMapper.java

public class ThetaMapper extends Mapper<IntWritable, VectorWritable, Text, VectorWritable> {

    public static final String ALPHA_I = ThetaMapper.class.getName() + ".alphaI";
    static final String TRAIN_COMPLEMENTARY = ThetaMapper.class.getName() + ".trainComplementary";

    private AbstractThetaTrainer trainer;

From source file com.netease.news.classifier.naivebayes.WeightsMapper.java

public class WeightsMapper extends Mapper<IntWritable, VectorWritable, Text, VectorWritable> {

    static final String NUM_LABELS = WeightsMapper.class.getName() + ".numLabels";

    private Vector weightsPerFeature;
    private Vector weightsPerLabel;

From source file com.nikoo28.excel.mapreduce.ExcelMapper.java

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

    private static Logger LOG = LoggerFactory.getLogger(ExcelMapper.class);

    /**
     * Excel Spreadsheet is supplied in string form to the mapper.

From source file com.pagerankcalculator.calculation.PageRankCalculationMapper.java

/**
 *
 * @author mfikria
 */
public class PageRankCalculationMapper extends Mapper<LongWritable, Text, Text, Text> {

From source file com.pagerankcalculator.graphparsing.GraphParsingMapper.java

/**
 *
 * @author mfikria
 */
public class GraphParsingMapper extends Mapper<LongWritable, Text, Text, Text> {