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 id3.WineMapper.java

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

    // Checks if the path contains all the attributes.
    private boolean allAttributesChecked(String path) {
        return (path.contains(Wine.S_FI) && path.contains(Wine.S_VO) && path.contains(Wine.S_CI)
                && path.contains(Wine.S_RE) && path.contains(Wine.S_CH) && path.contains(Wine.S_FR)

From source file info.halo9pan.word2vec.hadoop.mr.ReadWordsMapper.java

/**
 * @author Halo9Pan
 *
 */
public class ReadWordsMapper extends Mapper<Object, Text, Text, IntWritable> implements ValueIgnorable<String> {

From source file io.amient.kafka.hadoop.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 io.aos.mapreduce.count.WordCountMapper.java

public class WordCountMapper extends Mapper<Object, Text, Text, IntWritable> {
    private final Text word = new Text();
    private final IntWritable one = new IntWritable(1);

    public void map(Object key, Text value, Context context) throws IOException, InterruptedException {
        context.getCounter("CounterGroup", "MAP_INPUT_RECORDS").increment(1);

From source file io.apigee.lembos.mapreduce.LembosMapper.java

/**
 * Extension of {@link Mapper} that allows a Node.js MapReduce job author to export a <strong>map</strong>
 * function to implement the map functionality for their job.
 */
public class LembosMapper extends Mapper<WritableComparable<?>, Writable, WritableComparable<?>, Writable> {

From source file io.covert.binary.analysis.BinaryAnalysisMapper.java

public class BinaryAnalysisMapper<K, V> extends Mapper<Text, BytesWritable, K, V> {
    // Counter groups
    private static final String EXIT_CODES = "EXIT CODES";
    private static final String STATS = "STATS";

    // Counters

From source file io.covert.dns.collection.CollectionMapper.java

public class CollectionMapper extends Mapper<Text, DnsRequest, Text, BytesWritable> {

    private static final String REQUEST_TIMEOUTS = "REQUEST_TIMEOUTS";
    private static final String RCODES_GROUP = "RCODES";
    public static final String COUNTER_GROUP = CollectionMapper.class.getSimpleName();
    public static final String RESOLVER_GROUP = ResolverThread.class.getSimpleName();

From source file io.covert.dns.extract.ExtractorMapper.java

public class ExtractorMapper extends Mapper<Text, Text, Text, Text> {

    public static final String EXTRACTOR_JEXL_EXPRESSION = "extractor.jexl.expression";
    public static final String STRIP_OUTER_QUOTES = "extractor.strip.outer.quotes";

    Extractor extractor;

From source file io.covert.dns.filtering.FilterMapper.java

public class FilterMapper extends Mapper<Text, Text, Text, Text> {

    public static final String FILTER_JEXL_EXPRESSION = "filter.jexl.expression";
    private static final String MATCHED = "MATCHED";
    private static final String NON_MATCHED = "NON-MATCHED";
    Filter filter;

From source file io.covert.dns.geo.GeoMapper.java

public class GeoMapper extends Mapper<Text, Text, Text, Text> {

    IpGeo geo;
    ObjectMapper objectMapper = new ObjectMapper();
    Text outKey = new Text();