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.impetus.code.examples.hadoop.mapred.earthquake.EarthQuakeMapper.java

/**
 * <Prove description of functionality provided by this Type>
 * 
 * @author amresh.singh
 */
public class EarthQuakeMapper extends Mapper<LongWritable, Text, Text, IntWritable> {

From source file com.impetus.code.examples.hadoop.mapred.weather.MaxTempMapper.java

/**
 * <Prove description of functionality provided by this Type>
 * 
 * @author amresh.singh
 */
public class MaxTempMapper extends Mapper<LongWritable, Text, Text, IntWritable> {

From source file com.inmobi.conduit.distcp.tools.mapred.CopyMapper.java

/**
 * Mapper class that executes the DistCp copy operation.
 * Implements the o.a.h.mapreduce.Mapper<> interface.
 */
public class CopyMapper extends Mapper<Text, FileStatus, NullWritable, Text> {

From source file com.inmobi.conduit.local.CopyMapper.java

public class CopyMapper extends Mapper<Text, FileStatus, NullWritable, Text> implements ConfigConstants {
    private static final Log LOG = LogFactory.getLog(CopyMapper.class);

    @Override
    public void map(Text key, FileStatus value, Context context) throws IOException, InterruptedException {
        Path src = value.getPath();

From source file com.inmobi.databus.local.CopyMapper.java

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

    private static final Log LOG = LogFactory.getLog(CopyMapper.class);

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

From source file com.intel.hadoop.hbase.dot.KEY.java

class GenerateRegionDataTask extends Mapper<String, Long, LongWritable, LongWritable> {

    private int colNum;
    private int cfNum = 1;
    private String tableName = null;
    private HTable ht = null;

From source file com.j.distributed.counter.CounterMapper.java

/**
 *
 * @author jonatan
 */
public class CounterMapper extends Mapper<Object, Text, Text, IntWritable> {

From source file com.j.distributed.sorter.SorterMapper.java

/**
 *
 * @author jonatan
 */
public class SorterMapper extends Mapper<Object, Text, LongWritable, Text> {

From source file com.javiertordable.mrif.SieveMapper.java

/**
 * The Sieve Mapper performs the first step in the quadratic sieve
 * algorithm, that is, the sieve itself. It receives a series of pairs of the
 * form (i, i^2 - N) and returns those pairs such that the second factor is
 * smooth over a certain set of primes.
 *

From source file com.jbw.tar.sf.SmallFileMapper.java

/**
 *
 * @author alvin
 */
public class SmallFileMapper extends Mapper<LongWritable, Text, Text, Text> {