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.pagerankcalculator.ordering.PageRankSortingMapper.java

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

From source file com.panguso.lc.analysis.format.mapreduce.FormatAnalysisMapper.java

/**
 * 
 * 
 * @author piaohailin
 * @date 2013-4-9
 */

From source file com.pivotal.hawq.mapreduce.demo.HAWQEchoMapper.java

/**
 * A mapper which echos each field of {@link com.pivotal.hawq.mapreduce.HAWQRecord} separated by ','.
 */
public class HAWQEchoMapper extends Mapper<Void, HAWQRecord, Text, Text> {
    @Override
    protected void map(Void key, HAWQRecord value, Context context) throws IOException, InterruptedException {

From source file com.pivotal.hawq.mapreduce.ft.FeatureTestAllTypesMapper.java

/**
 * Mapper class used in test_ao_alltypes and test_parquet_alltypes FT.
 */
class FeatureTestAllTypesMapper extends Mapper<Void, HAWQRecord, Text, Text> {
    private String fieldToString(Object val) throws HAWQException {
        if (val == null)

From source file com.pivotal.hawq.mapreduce.ut.UnitTestAllTypesMapper.java

/**
 * Mapper class used in test_ao_alltypes and test_parquet_alltypes UT.
 */
class UnitTestAllTypesMapper extends Mapper<Void, HAWQRecord, Text, Text> {
    private String fieldToString(Object val) throws HAWQException {
        if (val == null)

From source file com.pocketx.gravity.recommender.cf.similarity.mapreduce.ToItemVectorsMapper.java

public class ToItemVectorsMapper extends Mapper<VarLongWritable, VectorWritable, IntWritable, VectorWritable> {

    public static final String SAMPLE_SIZE = ToItemVectorsMapper.class + ".sampleSize";

    enum Elements {
        USER_RATINGS_USED, USER_RATINGS_NEGLECTED

From source file com.renaissance.mrunit.hbase.tests.HaikuMapper.java

public class HaikuMapper extends Mapper<LongWritable, Text, ImmutableBytesWritable, Put> {
    private static final byte[] TITLE_COLUMNFAMILY = Bytes.toBytes("t");
    private static final int THIRD_LINE = 4;
    private static final int SECOND_LINE = 3;
    private static final int FIRST_LINE = 2;
    private static final int TITLE = 1;

From source file com.rim.logdriver.mapreduce.avro.AvroBlockWriterMapper.java

public class AvroBlockWriterMapper extends Mapper<AvroFileHeader, BytesWritable, BytesWritable, NullWritable> {
    private static final Logger LOG = LoggerFactory.getLogger(AvroBlockWriterMapper.class);

    private AvroFileHeader header = new AvroFileHeader();

    /**

From source file com.rim.logdriver.mapreduce.boom.BoomFilterMapper.java

public class BoomFilterMapper extends Mapper<LogLineData, Text, LogLineData, Text> {
    private static final Logger LOG = LoggerFactory.getLogger(BoomFilterMapper.class);
    private List<Filter> filters = null;

    @SuppressWarnings("unchecked")
    public static List<Filter> loadFilters(String componentName, InputStream filterFile) {

From source file com.rockstor.compact.mapreduce.CompactDataMapper.java

public class CompactDataMapper extends Mapper<String, NullWritable, NullWritable, NullWritable> {

    /**
     * Called once for each key/value pair in the input split. Most applications
     * should override this, but the default is the identity function.
     */