Example usage for org.apache.hadoop.mapreduce.lib.input SequenceFileInputFormat subclass-usage

List of usage examples for org.apache.hadoop.mapreduce.lib.input SequenceFileInputFormat subclass-usage

Introduction

In this page you can find the example usage for org.apache.hadoop.mapreduce.lib.input SequenceFileInputFormat subclass-usage.

Usage

From source file be.uantwerpen.adrem.hadoop.util.NoSplitSequenceFileInputFormat.java

/**
 * Input format that never splits in file.
 */
public class NoSplitSequenceFileInputFormat extends SequenceFileInputFormat<Text, IntArrayWritable> {

    @Override

From source file com.google.cloud.bigtable.mapreduce.ShuffledSequenceFileInputFormat.java

/**
 * An InputFormat randomizes the order of SequenceFile splits. This is needed for the Bigtable
 * import job to spread the load across all of the Bigtable tablet servers.
 * @author igorbernstein2
 * @version $Id: $Id
 */

From source file jadoop.util.SingleRecordSplitSequenceFileInputFormat.java

/**
 * A SequenceFileInputFormat that produces splits with one key,value pair per
 * split. 
 * 
 * In hadoop each InputSplit is assigned to an individual Mapper for processing.  
 * Thus, if each key,value pair specifies a compute-bound task (as is the case with

From source file kogiri.mapreduce.common.kmermatch.KmerMatchInputFormat.java

/**
 *
 * @author iychoi
 */
public class KmerMatchInputFormat extends SequenceFileInputFormat<CompressedSequenceWritable, KmerMatchResult> {

From source file kogiri.mapreduce.preprocess.common.kmerindex.KmerIndexInputFormat.java

/**
 *
 * @author iychoi
 */
public class KmerIndexInputFormat
        extends SequenceFileInputFormat<CompressedSequenceWritable, CompressedIntArrayWritable> {

From source file libra.common.kmermatch.KmerMatchInputFormat.java

/**
 *
 * @author iychoi
 */
public class KmerMatchInputFormat extends SequenceFileInputFormat<CompressedSequenceWritable, KmerMatchResult> {

From source file libra.preprocess.common.kmerindex.KmerIndexInputFormat.java

/**
 *
 * @author iychoi
 */
public class KmerIndexInputFormat extends SequenceFileInputFormat<CompressedSequenceWritable, IntWritable> {

From source file nl.surfsara.warcutils.WarcSequenceFileInputFormat.java

/**
 * Hadoop InputFormat for warc wat and wet files which have been converted to
 * sequencefiles. The sequencefiles are expected to be in the format
 * <LongWritable, Text>. Where each text value parses as one WarcRecord from the
 * Java Web Archive Toolkit.
 * 

From source file org.apache.avro.mapreduce.AvroSequenceFileInputFormat.java

/**
 * An input format for reading from AvroSequenceFiles (sequence files that support Avro data).
 *
 * @param <K> The input key type.
 * @param <V> The input value type.
 */

From source file org.apache.mahout.fpm.hadoop.util.NoSplitSequenceFileInputFormat.java

/**
 * Input format that never splits in file
 * 
 * @author Sandy Moens & Emin Aksehirli
 */
public class NoSplitSequenceFileInputFormat extends SequenceFileInputFormat<Text, IntArrayWritable> {