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 org.gradoop.flink.io.impl.tlf.inputformats.TLFRecordReader.java

/**
 * TLFRecordReader class to read through a given TLF document to
 * output graph blocks as records which are specified by the start tag and
 * end tag.
 */
public class TLFRecordReader extends RecordReader<LongWritable, Text> {

From source file org.gradoop.io.impl.tlf.inputformats.TLFRecordReader.java

/**
 * TLFRecordReader class to read through a given TLF document to
 * output graph blocks as records which are specified by the start tag and
 * end tag.
 */
public class TLFRecordReader extends RecordReader<LongWritable, Text> {

From source file org.huahinframework.core.lib.input.SimpleRecordReader.java

/**
 * Treats keys as offset in file and value as line.
 */
public abstract class SimpleRecordReader extends RecordReader<Key, Value> {
    private static final Log LOG = LogFactory.getLog(SimpleRecordReader.class);

From source file org.indexing.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 org.interactiverobotics.source_code_crawler.step6.TextFileRecordReader.java

/**
 * TextFileRecordReader.
 */
public class TextFileRecordReader extends RecordReader<Text, Text> {

    private FileSplit fileSplit;

From source file org.janusgraph.hadoop.formats.cassandra.CassandraBinaryRecordReader.java

/**
 * Wraps a ColumnFamilyRecordReader and converts CFRR's binary types to JanusGraph binary types.
 */
public class CassandraBinaryRecordReader extends RecordReader<StaticBuffer, Iterable<Entry>> {

    private final ColumnFamilyRecordReader reader;

From source file org.janusgraph.hadoop.formats.cassandra.CqlBridgeRecordReader.java

/**
 * <p> Background: The {@link org.apache.cassandra.hadoop.cql3.CqlRecordReader} class has changed
 * significantly in Cassandra-3 from Cassandra-2. This class acts as a bridge between
 * CqlRecordReader in Cassandra-2 to Cassandra-3. In essence, this class recreates CqlRecordReader
 * from Cassandra-3 without referring to it (because otherwise we'd get functionality from
 * CqlRecordReader on Cassandra-2 and we don't want it). </p>

From source file org.janusgraph.hadoop.formats.cql.CqlBinaryRecordReader.java

public class CqlBinaryRecordReader extends RecordReader<StaticBuffer, Iterable<Entry>> {
    private KV currentKV;
    private KV incompleteKV;

    private final CqlRecordReader reader;

From source file org.janusgraph.hadoop.formats.hbase.HBaseBinaryRecordReader.java

public class HBaseBinaryRecordReader extends RecordReader<StaticBuffer, Iterable<Entry>> {

    private final RecordReader<ImmutableBytesWritable, Result> reader;

    private final byte[] edgestoreFamilyBytes;

From source file org.janusgraph.hadoop.formats.util.GiraphRecordReader.java

/**
 * @author Marko A. Rodriguez (http://markorodriguez.com)
 */
public class GiraphRecordReader extends RecordReader<NullWritable, VertexWritable> {

    private static final Logger log = LoggerFactory.getLogger(GiraphRecordReader.class);