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 edu.ucla.sspace.hadoop.RawTextCooccurrenceMapper.java

/**
 * A {@link Mapper} implementation that maps a the text values of a document to
 * the word co-occurrences.  This class is intended to be used with the {@link
 * TextInputFormat} where the incoming text files are mapped to byte offsets and
 * the text contained there-in.  The input key values are not interpreted by
 * this mapper, only the text values.

From source file edu.udel.mxv.MxvMap.java

/**
 * Performs the multiplication between the aij and the xi
 * 
 * The vector x is loaded in each map task in the setup method. Here it is assume that the size of 
 * the vector x can fit in the mapper memory.
 * 

From source file edu.umd.cloud9.example.translation.TransProbMapper.java

public class TransProbMapper extends Mapper<LongWritable, Text, PairOfStrings, FloatWritable> {

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

From source file edu.usc.pgroup.louvain.hadoop.MapCommunity.java

/**
 * Created by Charith Wickramaarachchi on 6/30/14.
 */
public class MapCommunity extends Mapper<Text, BytesWritable, Text, BytesWritable> {

    private boolean verbose = false;

From source file fi.tkk.ics.hadoop.bam.cli.plugins.FixMate.java

final class FixMateMapper extends Mapper<LongWritable, SAMRecordWritable, Text, SAMRecordWritable> {
    @Override
    protected void map(LongWritable ignored, SAMRecordWritable wrec,
            Mapper<LongWritable, SAMRecordWritable, Text, SAMRecordWritable>.Context ctx)
            throws InterruptedException, IOException {
        Utils.correctSAMRecordForMerging(wrec.get(), ContextUtil.getConfiguration(ctx));

From source file fire.util.fileformats.tika.TikaMapper.java

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

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

        context.write(key, value);

From source file fm.last.darling.mapred.MapperWrapper.java

public class MapperWrapper extends Mapper<LongWritable, Text, NSpacePoint, IntWritable> {
    private UserMapper usermapper;
    private List<List<Dimension>> rps;

    public MapperWrapper() throws Exception {
        // TODO: read name of user's mapper class from config.

From source file fr.ens.biologie.genomique.eoulsan.modules.expression.hadoop.HTSeqCountMapper.java

/**
 * Mapper for the expression estimation with htseq-count.
 * @since 1.2
 * @author Claire Wallon
 */
public class HTSeqCountMapper extends Mapper<Text, Text, Text, LongWritable> {

From source file fr.ens.biologie.genomique.eoulsan.modules.expression.hadoop.PreTreatmentExpressionMapper.java

/**
 * This class define a mapper for the pretreatment of paired-end data before the
 * expression estimation step.
 * @since 1.2
 * @author Claire Wallon
 */

From source file fr.ens.biologie.genomique.eoulsan.modules.mapping.hadoop.PreTreatmentMapper.java

/**
 * This class defines a mapper for the pretreatment of paired-end data before
 * the reads filtering step.
 * @since 1.2
 * @author Claire Wallon
 */