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.rockstor.compact.recovery.RecoveryMapper.java

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

    public static Logger LOG = Logger.getLogger(RecoveryMapper.class);

    /**
     * Called once for each key/value pair in the input split. Most applications

From source file com.rw.legion.DefaultMapper.java

/**
 * Default Mapper class used by Legion. Takes a <code>NullWritable</code> key
 * and a <code>LegionRecord</code> value, loops through all output tables and
 * columns specified by the current <code>LegionObjective</code>, validates and
 * cleans the data, and yields a <code>NullWritable</code> key and a
 * CSV-formatted <code>Text</code> value, which will be written to a file by

From source file com.shmsoft.dmass.main.Map.java

/**
 * Maps input key/value pairs to a set of intermediate key/value pairs.
 *
 * @author mark
 */
public class Map extends Mapper<LongWritable, Text, MD5Hash, MapWritable> {

From source file com.sirius.hadoop.job.onlinetime.StatusMapper.java

/**
 * Created by pippo on 14-9-19.
 */
public class StatusMapper extends Mapper<Object, Text, StatusKey, OnlineRecord> {

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

From source file com.sirius.hadoop.job.org.OrgMapper.java

/**
 * Created by pippo on 14-9-19.
 */
public class OrgMapper extends Mapper<Object, Text, Text, OrgInfo> {

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

From source file com.skp.experiment.common.mapreduce.IdentityMapper.java

public class IdentityMapper<K, V> extends Mapper<K, V, K, V> {
    public static String VALUE_ONLY_OUT = IdentityMapper.class.getName() + ".valueOnlyOut";
    public static String KEY_ONLY_OUT = IdentityMapper.class.getName() + ".keyOnlyOut";
    private static boolean valueOnlyOut = false;
    private static boolean keyOnlyOut = false;

From source file com.soteradefense.dga.louvain.mapreduce.LouvainTableSynthesizerMapper.java

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

    private static final Logger logger = LoggerFactory.getLogger(LouvainTableSynthesizerMapper.class);
    private static final String GIRAPH_0 = LouvainTableSynthesizer.GIRAPH_FOLDER_BASE_NAME
            + LouvainTableSynthesizer.FILE_NAME_SEPARATOR + "0";

From source file com.splunk.shuttl.integration.hadoop.hbase.CSVMapper.java

public class CSVMapper extends Mapper<LongWritable, Text, ImmutableBytesWritable, KeyValue> {

    private CSVToContextPreparator preparator;

    /**
     * @param keyProvider

From source file com.springdeveloper.hadoop.TweetCountMapper.java

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

    private final static IntWritable ONE = new IntWritable(1);
    private final ObjectMapper jsonMapper = new ObjectMapper(new JsonFactory());

    @Override

From source file com.sreejith.loganalyzer.mapreduce.LogMapper.java

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

    private static Logger logger = LoggerFactory.getLogger(LogMapper.class);
    private IntWritable hour = new IntWritable();
    private final static IntWritable one = new IntWritable(1);
    private static Pattern logPattern = Pattern