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.wipro.ats.bdre.dq.DQFileReportMapper.java

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

    private Text outputKey = new Text();
    private IntWritable outputValue = new IntWritable();

    @Override

From source file com.wipro.ats.bdre.dq.DQMapper.java

/**
 * @author Satish Kumar
 *         <p/>
 *         Mapper Class create the Drool knowledgeBase and Validate the each record and
 *         Emits the record as GOOD or BAD based on rules defined in drool.
 */

From source file com.xiaomi.linden.hadoop.indexing.map.LindenMapper.java

public class LindenMapper extends Mapper<Object, Object, Shard, IntermediateForm> {

    private final static Logger logger = Logger.getLogger(LindenMapper.class);
    private Configuration conf;
    private Shard[] shards;

From source file com.xiaoxiaomo.mr.utils.kafka.HadoopJobMapper.java

public class HadoopJobMapper
        extends Mapper<MsgMetadataWritable, BytesWritable, MsgMetadataWritable, BytesWritable> {

    static Logger log = LoggerFactory.getLogger(HadoopJobMapper.class);

    //    private static final String CONFIG_SERDE_CLASS = "mapper.serde.class";

From source file com.yahoo.druid.hadoop.example.DruidPrintMapper.java

public class DruidPrintMapper extends Mapper<DateTime, Map<String, Object>, DateTime, Map<String, Object>> {
    @Override
    public void map(DateTime key, Map<String, Object> value, Context context) {
        System.out.print(key + " , ");
        for (Map.Entry<String, Object> e : value.entrySet()) {
            System.out.print(e.getKey() + "=" + e.getValue() + " , ");

From source file com.yahoo.glimmer.indexing.generator.DocumentMapper.java

public class DocumentMapper extends Mapper<LongWritable, Text, TermKey, TermValue> {
    private static final Log LOG = LogFactory.getLog(DocumentMapper.class);

    public static final int ALIGNMENT_INDEX = -1; // special index for
    // alignments

From source file com.yahoo.glimmer.indexing.preprocessor.TuplesToResourcesMapper.java

/**
 * Maps each input line containing a tuple of 3 or more elements to Key/Value
 * pairs of the following form KEY VALUE "subject"
 * "&lt;predicate&gt; &lt;object&gt; &lt;context&gt; ." "predicate         "PREDICATE"
 * "object" "OBJECT" "context" "CONTEXT"
 * 

From source file com.yassergonzalez.pagerank.InLinksMapper.java

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

    private IntWritable one = new IntWritable(1);

    @Override
    public void map(LongWritable inKey, Text inValue, Context context) throws IOException, InterruptedException {

From source file com.yassergonzalez.pagerank.InLinksTopNMapper.java

public class InLinksTopNMapper extends Mapper<IntWritable, IntWritable, IntWritable, IntWritable> {

    // TODO: Create base classes TopN{Mapper,Reducer} to avoid duplicate
    // code in {PageRank,InLinks}TopN{Mapper,Reducer}.

    private PriorityQueue<Map.Entry<Integer, Integer>> topN;

From source file com.yassergonzalez.pagerank.PageRankIterationMapper.java

public class PageRankIterationMapper
        extends Mapper<ShortArrayWritable, MatrixBlockWritable, ShortWritable, FloatArrayWritable> {

    @Override
    public void map(ShortArrayWritable inKey, MatrixBlockWritable inValue, Context context)
            throws IOException, InterruptedException {