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

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

Introduction

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

Usage

From source file com.basho.riak.hadoop.RiakInputSplit.java

/**
 * Riak specific extension of {@link InputSplit}
 * 
 * @author russell
 * 
 */

From source file com.baynote.hadoop.TaggedInputSplit.java

/**
 * An {@link InputSplit} that tags another InputSplit with extra data for use by DelegatingInputFormat's and
 * {@link DelegatingMapper}s.
 * 
 * <p>
 * This package-private class is taken directly from the Hadoop source code, and made public here so that we can

From source file com.baynote.kafka.hadoop.KafkaInputSplit.java

/**
 * An {@link InputSplit} that has a specific {@code start} and {@code end} offset in a Kafka queue {@link Partition}.
 * 
 * @see KafkaInputFormat
 * @see MultipleKafkaInputFormat
 * @see KafkaRecordReader

From source file com.chinamobile.bcbsp.io.db.TableSplit.java

/**
 * A table split corresponds to a key range (low, high). All references to row
 * below refer to the key of the row.
 */
public class TableSplit extends InputSplit implements Writable, Comparable<TableSplit> {
    /** The name of the current table. */

From source file com.chinamobile.bcbsp.io.mysql.DBInputSplit.java

/**
 * A MySQL split corresponds to a key range (low, high). All references to row
 * below refer to the key of the row.
 */
public class DBInputSplit extends InputSplit implements Writable, Comparable<DBInputSplit> {
    /** The split end */

From source file com.chinamobile.bcbsp.io.titan.TitanTableSplit.java

/**
 * TitanTableSplit describe the table split in Titan database.
 * @author Zhicheng Liu 2013/4/25
 */
public class TitanTableSplit extends InputSplit implements Writable, Comparable<TitanTableSplit> {
    /**input table name*/

From source file com.cloudera.crunch.impl.mr.run.CrunchInputSplit.java

public class CrunchInputSplit extends InputSplit implements Configurable, Writable {

    private InputSplit inputSplit;
    private Class<? extends InputFormat> inputFormatClass;
    private int nodeIndex;
    private Configuration conf;

From source file com.cloudera.recordservice.mapreduce.RecordServiceInputSplit.java

/**
 * The InputSplit implementation that is used in conjunction with the
 * Record Service. It contains the Schema of the record as well as all the
 * information required for the Record Service Worker to execute the task
 */
public class RecordServiceInputSplit extends InputSplit implements Writable {

From source file com.conductor.hadoop.TaggedInputSplit.java

/**
 * An {@link InputSplit} that tags another InputSplit with extra data for use by DelegatingInputFormat's and
 * {@link DelegatingMapper}s.
 * 
 * <p/>
 * This package-private class is taken directly from the Hadoop source code, and made public here so that we can

From source file com.conductor.kafka.hadoop.KafkaInputSplit.java

/**
 * An {@link InputSplit} that has a specific {@code start} and {@code end} offset in a Kafka queue {@link Partition}.
 * 
 * @see KafkaInputFormat
 * @see MultipleKafkaInputFormat
 * @see KafkaRecordReader