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.asakusafw.thundergate.runtime.cache.mapreduce.BaseMapper.java

/**
 * Mapper class for base (which should be applied patches) input.
 * @since 0.2.3
 */
public class BaseMapper
        extends Mapper<NullWritable, ThunderGateCacheSupport, PatchApplyKey, ThunderGateCacheSupport> {

From source file com.asakusafw.thundergate.runtime.cache.mapreduce.CreateCacheMapper.java

/**
 * Logical deleted filter.
 * @since 0.2.3
 */
public class CreateCacheMapper
        extends Mapper<NullWritable, ThunderGateCacheSupport, NullWritable, ThunderGateCacheSupport> {

From source file com.asakusafw.thundergate.runtime.cache.mapreduce.DeleteMapper.java

/**
 * Logical deleted filter.
 * @since 0.2.3
 */
public class DeleteMapper
        extends Mapper<NullWritable, ThunderGateCacheSupport, NullWritable, ThunderGateCacheSupport> {

From source file com.asakusafw.thundergate.runtime.cache.mapreduce.MergeJoinBaseMapper.java

/**
 * Mapper class for base (which should be applied patches) input.
 * @since 0.2.3
 */
public class MergeJoinBaseMapper
        extends Mapper<NullWritable, ThunderGateCacheSupport, PatchApplyKey, ThunderGateCacheSupport> {

From source file com.asakusafw.thundergate.runtime.cache.mapreduce.MergeJoinPatchMapper.java

/**
 * Mapper class for base input.
 * @since 0.2.3
 */
public class MergeJoinPatchMapper
        extends Mapper<NullWritable, ThunderGateCacheSupport, PatchApplyKey, ThunderGateCacheSupport> {

From source file com.asakusafw.thundergate.runtime.cache.mapreduce.PatchMapper.java

/**
 * Mapper class for base input.
 * @since 0.2.3
 */
public class PatchMapper
        extends Mapper<NullWritable, ThunderGateCacheSupport, PatchApplyKey, ThunderGateCacheSupport> {

From source file com.asakusafw.thundergate.runtime.cache.mapreduce.TableJoinBaseMapper.java

/**
 * Patcher with distributed cache.
 * @since 0.8.1
 */
public class TableJoinBaseMapper
        extends Mapper<NullWritable, ThunderGateCacheSupport, NullWritable, ThunderGateCacheSupport> {

From source file com.asakusafw.thundergate.runtime.cache.mapreduce.TableJoinPatchMapper.java

/**
 * Logical deleted filter for patches.
 * @since 0.8.1
 */
public class TableJoinPatchMapper
        extends Mapper<NullWritable, ThunderGateCacheSupport, NullWritable, ThunderGateCacheSupport> {

From source file com.asp.tranlog.TsvImporterMapper.java

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

From source file com.avira.couchdoop.demo.ExportMapper.java

/**
 * Mapper which reads a delimited text file with recommendations computed by a
 * recommending system and reformats them to be published in Couchbase as JSON
 * documents.
 */
public class ExportMapper extends Mapper<LongWritable, Text, String, CouchbaseAction> {