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 Assignment5_P4_BinningPattern.Binning_IPAddress_By_Day_Mapper.java

/**
 *
 * @author Chintan
 */
public class Binning_IPAddress_By_Day_Mapper extends Mapper<Object, Text, NullWritable, Text> {
    private IntWritable createHour = new IntWritable();

From source file Assignment5_P6_StructureToHierarchyPattern.Structure_Hierarchy_Movie_Mapper.java

/**
 *
 * @author Chintan
 */
public class Structure_Hierarchy_Movie_Mapper extends Mapper<Object, Text, Text, Text> {
    public void map(Object key, Text value, Context context) throws IOException, InterruptedException {

From source file Assignment5_P6_StructureToHierarchyPattern.Structure_Hierarchy_Tag_Mapper.java

/**
 *
 * @author Chintan
 */
public class Structure_Hierarchy_Tag_Mapper extends Mapper<Object, Text, Text, Text> {
    public void map(Object key, Text value, Context context) throws IOException, InterruptedException {

From source file averagerating_youtube.AvgRating_CommCountMapper.java

/**
 *
 * @author Rajat
 */
public class AvgRating_CommCountMapper extends Mapper<Object, Text, Text, AverageRating_CommentCountTuple> {

From source file bbuzz2011.stackoverflow.preprocess.xml.StackOverflowPostXMLMapper.java

/**
 * Turns posts from a StackOverflow posts.xml file into the following output.
 * 
 * Pairs of (post id, content)
 * 
 * so they can be processed by

From source file be.uantwerpen.adrem.bigfim.AprioriPhaseMapper.java

/**
 * Mapper class for Apriori phase of BigFIM. Each mapper receives a sub part (horizontal cut) of the dataset and
 * combines a list of base itemsets in candidates of length+1 for its sub database. The latter are counted in the map
 * function. If no base itemsets are specified, all singletons are counted. The size of the sub part is depending on the
 * number of mappers and the size of the original dataset.
 * 

From source file be.uantwerpen.adrem.bigfim.ComputeTidListMapper.java

/**
 * Mapper class for the second phase of BigFIM. Each mapper receives a sub part (horizontal cut) of the dataset and
 * computes partial tidlists of the given itemsets in the sub database. The size of the sub database depends on the
 * number of mappers and the size of the original dataset.
 * 
 * <pre>

From source file be.uantwerpen.adrem.disteclat.PrefixComputerMapper.java

/**
 * Mapper class for the second cycle of DistEclat. It receives a list of singletons for which it has to create X-FIs
 * seeds by growing the lattice tree downwards. The ordering is retrieved through the distributed cache. *
 * 
 * <pre>
 * {@code

From source file be.uantwerpen.adrem.eclat.EclatMinerMapperBase.java

/**
 * MapperBase class for the Eclat phase of BigFIM and DistEclat. This mapper mines the frequent itemsets for the
 * specified prefixes (subtree).
 */
public abstract class EclatMinerMapperBase<VALUEOUT>
        extends Mapper<IntArrayWritable, IntMatrixWritable, Text, VALUEOUT> {

From source file be.ugent.intec.halvade.hadoop.mapreduce.AlignedBamMapper.java

/**
 *
 * @author ddecap
 */
public class AlignedBamMapper extends Mapper<LongWritable, SAMRecordWritable, ChromosomeRegion, SAMRecordWritable> {
    protected AlignerInstance instance;