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 co.nubetech.hiho.mapreduce.OracleLoadMapper.java

public class OracleLoadMapper extends Mapper<Text, FSDataInputStream, NullWritable, NullWritable> {

    private final static Logger logger = Logger.getLogger(co.nubetech.hiho.mapreduce.OracleLoadMapper.class);

    FTPClient ftpClient;

From source file co.nubetech.hiho.mapreduce.sf.SalesForceLoadMapper.java

public class SalesForceLoadMapper<K, V> extends Mapper<LongWritable, Text, NullWritable, NullWritable> {

    private final static Logger logger = Logger.getLogger(co.nubetech.hiho.mapreduce.sf.SalesForceLoadMapper.class);

    private SFRestConnection connection;
    private JobInfo job;

From source file co.nubetech.hiho.merge.MergeKeyMapper.java

public class MergeKeyMapper<K extends Writable, V extends Writable>
        extends Mapper<K, V, HihoTuple<K>, HihoValue<V>> {

    final static Logger logger = Logger.getLogger(co.nubetech.hiho.dedup.DedupKeyMapper.class);
    protected Boolean isOld;

From source file co.nubetech.hiho.merge.MergeValueMapper.java

public class MergeValueMapper<K extends Writable, V extends Writable>
        extends Mapper<K, V, HihoTuple<V>, HihoValue<K>> {

    final static Logger logger = Logger.getLogger(co.nubetech.hiho.dedup.DedupKeyMapper.class);
    protected Boolean isOld;

From source file co.nubetech.hiho.similarity.ngram.NGramMapper.java

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

    final static Logger logger = Logger.getLogger(co.nubetech.hiho.similarity.ngram.NGramMapper.class);

    @Override
    public void map(Text key, Text val, Context context) throws IOException, InterruptedException {

From source file co.nubetech.hiho.similarity.ngram.ScoreMapper.java

public class ScoreMapper extends Mapper<ValuePair, IntWritable, ValuePair, IntWritable> {

    final static Logger logger = Logger.getLogger(co.nubetech.hiho.similarity.ngram.ScoreMapper.class);

    @Override
    public void map(ValuePair key, IntWritable val, Context context) throws IOException, InterruptedException {

From source file com.ailk.oci.ocnosql.tools.load.csvbulkload.PhoenixCsvToKeyValueMapper.java

/**
 * MapReduce mapper that converts CSV input lines into KeyValues that can be
 * written to HFiles.
 * <p/>
 * KeyValues are produced by executing UPSERT statements on a Phoenix connection
 * and then extracting the created KeyValues and rolling back the statement

From source file com.ailk.oci.ocnosql.tools.load.mutiple.MutipleColumnImporterMapper.java

/**
 * Write table content out to files in hdfs.
 */
public class MutipleColumnImporterMapper extends Mapper<LongWritable, Text, ImmutableBytesWritable, Put> {

    //   Logger LOG = LoggerFactory.getLogger(MutipleColumnImporterMapper.class);

From source file com.ailk.oci.ocnosql.tools.load.single.SingleColumnImporterMapper.java

/**
 * Write table content out to files in hdfs.
 */
public class SingleColumnImporterMapper
        extends Mapper<LongWritable, Text, ImmutableBytesWritable, TextArrayWritable> {
    static Log LOG = LogFactory.getLog(SingleColumnImporterMapper.class);

From source file com.alectenharmsel.research.FileCombineMapper.java

public class FileCombineMapper extends Mapper<LongWritable, Text, Text, LongWritable> {
    public void map(LongWritable key, Text contents, Context context) throws IOException, InterruptedException {
        context.write(contents, key);
    }
}