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.bark.hadoop.lab3.RedLinkMapper.java

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

    @Override
    protected void map(LongWritable key, Text value, Context context) throws IOException, InterruptedException {
        //Possible single element nowiki tag makes xmlstreamparser to stop. Remove them first.
        String fixed = value.toString().replaceAll("<nowiki />|&lt;nowiki /&gt;", "");

From source file com.bark.hadoop.lab3.SortMapper.java

public class SortMapper extends Mapper<LongWritable, Text, DoubleWritable, Text> {

    @Override
    protected void map(LongWritable key, Text value, Context context) throws IOException, InterruptedException {
        double pageRank = 0;
        //intermediate files identify pageranks with _!0.0000.. pattern.

From source file com.basho.riak.hadoop.RiakMapper.java

/**
 * A Riak specific extension of {@link Mapper} that can be used if you wish to
 * work with domain specific types and handle sibling values in your
 * {@link Mapper#map} method
 * 
 * @author russell

From source file com.baynote.hadoop.DelegatingMapper.java

/**
 * A {@link Mapper} implementation that delegates behavior of {@link org.apache.hadoop.mapreduce.InputSplit}s to
 * multiple other mappers.
 * 
 * <p>
 * This class is taken directly from the Hadoop source code so that we can leverage {@link TaggedInputSplit} which is

From source file com.bizosys.hsearch.kv.indexing.KVMapperFile.java

public class KVMapperFile extends Mapper<LongWritable, Text, TextPair, Text> {

    private KVMapperBase kBase = new KVMapperBase();
    String[] result = null;
    boolean isSkipHeader = false;

From source file com.bizosys.hsearch.kv.indexing.KVMapperHFile.java

public class KVMapperHFile extends Mapper<Text, ImmutableBytesWritable, ImmutableBytesWritable, KeyValue> {

    FieldMapping fm = null;
    byte[] familyName = null;
    byte[] qualifier = new byte[] { 0 };

From source file com.bizosys.hsearch.kv.indexing.KVMapperLocal.java

public class KVMapperLocal extends Mapper<LongWritable, Text, TextPair, Text> {

    public class LocalMapContext extends Context {

        Configuration conf = null;
        public Map<TextPair, List<Text>> values = new HashMap<TextPair, List<Text>>();

From source file com.bizosys.hsearch.kv.indexing.KVMapperMapFile.java

public class KVMapperMapFile extends Mapper<Text, Text, TextPair, Text> {

    private static final char LINE_SEPARATOR = '\n';
    private KVMapperBase kBase = new KVMapperBase();
    String[] result = null;
    boolean isSkipHeader = false;

From source file com.blackberry.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.blackberry.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) {