Example usage for org.apache.hadoop.mapreduce RecordReader subclass-usage

List of usage examples for org.apache.hadoop.mapreduce RecordReader subclass-usage

Introduction

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

Usage

From source file BamRecordReader.java

/**
 * Treats keys as offset in file and value as line. 
 */
public class BamRecordReader extends RecordReader<Text, Text> {
    private static final Log LOG = LogFactory.getLog(BamRecordReader.class);
    public static byte[] head = null;//make the array large enough to fit the bam head

From source file FastqRecordReaderDouble.java

/**
 * This class define a custom RecordReader for a pair of 
 * FASTQ files for the Hadoop MapReduce framework.
    
 * @author Jos M. Abun
 */

From source file FastqRecordReader.java

/**
 * This class define a custom RecordReader for FASTQ files for the 
 * Hadoop MapReduce framework.
    
 * @author Mahmoud Parsian
 * @author Jos M. Abun

From source file ZipFileRecordReader.java

/**
 * This RecordReader implementation extracts individual files from a ZIP
 * file and hands them over to the Mapper. The "key" is the decompressed
 * file name, the "value" is the file contents.
 */
public class ZipFileRecordReader extends RecordReader<Text, BytesWritable> {

From source file alluxio.hadoop.mapreduce.KeyValueRecordReader.java

/**
 * Implements {@link RecordReader} that breaks the input from a key-value store data into records
 * and input records to the Mapper. Each record is a key-value pair stored in a partition of the
 * {@link KeyValueSystem}.
 */
@ThreadSafe

From source file andromache.hadoop.CassandraRecordReader.java

public class CassandraRecordReader extends RecordReader<ByteBuffer, SortedMap<ByteBuffer, IColumn>>

{
    private static final Logger logger = LoggerFactory.getLogger(CassandraRecordReader.class);

    public static final int TIMEOUT_DEFAULT = (int) TimeUnit.MINUTES.toMillis(1);

From source file anson.ZipFileRecordReader.java

/**
 * This RecordReader implementation extracts individual files from a ZIP
 * file and hands them over to the Mapper. The "key" is the decompressed
 * file name, the "value" is the file contents.
 */
public class ZipFileRecordReader extends RecordReader<Text, BytesWritable> {

From source file authordetect.input.SingleBookReader.java

/**
 * Created by Qiu on 4/24/15.
 * This record reader takes a single book as input.
 * Output key: Text ---> " Author(opt 0) or Book title(opt 1)  / Maximum Word Count "
 * Output value: TextArray ---> [ "Word A / Word A Count", ... ]
 */

From source file brush.FastqRecordReader.java

/**
 * A record reader for the interleaved FASTQ format.
 *
 * Reads over an input file and parses interleaved FASTQ read pairs into
 * a single Text output. This is then fed into the FastqConverter, which
 * converts the single Text instance into two AlignmentRecords.

From source file ca.sparkera.adapters.mapreduce.MainframeVBRecordReader.java

/**
 * A reader to read fixed length records from a split. Record offset is returned
 * as key and the record as bytes is returned in value.
 */
@InterfaceAudience.Private
@InterfaceStability.Evolving