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 org.apache.giraph.io.formats.multi.InputSplitWithInputFormatIndex.java

/**
 * Helper InputSplit class which holds the information about input format
 * which owns this input split.
 *
 * Used only with input formats which wrap several input formats into one
 * ({@link MultiVertexInputFormat} and {@link MultiEdgeInputFormat})

From source file org.apache.giraph.rexster.io.RexsterInputSplit.java

/**
 * A InputSplit that spans a set of vertices. This code is taken from the
 * Faunus project and was originally authored by Stephen Mallette.
 */
public class RexsterInputSplit extends InputSplit implements Writable {
    /** End index for the Rexster paging */

From source file org.apache.gora.mapreduce.GoraInputSplit.java

/**
 * InputSplit using {@link PartitionQuery}s. 
 */
public class GoraInputSplit extends InputSplit implements Writable, Configurable {

    protected PartitionQuery<?, ?> query;

From source file org.apache.hcatalog.mapreduce.HCatSplit.java

/** The HCatSplit wrapper around the InputSplit returned by the underlying InputFormat */
public class HCatSplit extends InputSplit implements Writable, org.apache.hadoop.mapred.InputSplit {

    private static final Logger LOG = LoggerFactory.getLogger(HCatSplit.class);
    /** The partition info for the split. */
    private PartInfo partitionInfo;

From source file org.apache.hcatalog.templeton.tool.NullSplit.java

/**
 * An empty splitter.
 */
public class NullSplit extends InputSplit implements Writable {
    public long getLength() {
        return 0;

From source file org.apache.hive.hcatalog.mapreduce.HCatSplit.java

/** The HCatSplit wrapper around the InputSplit returned by the underlying InputFormat */
public class HCatSplit extends InputSplit implements Writable, org.apache.hadoop.mapred.InputSplit {

    private static final Logger LOG = LoggerFactory.getLogger(HCatSplit.class);
    /** The partition info for the split. */
    private PartInfo partitionInfo;

From source file org.apache.hive.hcatalog.templeton.tool.NullSplit.java

/**
 * An empty splitter.
 */
public class NullSplit extends InputSplit implements Writable {
    public long getLength() {
        return 0;

From source file org.apache.hyracks.dataflow.hadoop.mapreduce.InputFileSplit.java

public class InputFileSplit extends InputSplit implements Writable {
    private Path file;
    private long start;
    private long length;
    private int blockId;
    private String[] hosts;

From source file org.apache.kylin.source.kafka.hadoop.KafkaInputSplit.java

/**
 * Convert Kafka topic to Hadoop InputFormat
 * Modified from the kafka-hadoop-loader in https://github.com/amient/kafka-hadoop-loader
 */
public class KafkaInputSplit extends InputSplit implements Writable {

From source file org.apache.mahout.text.LuceneSegmentInputSplit.java

/**
 * {@link InputSplit} implementation that represents a Lucene segment.
 */
public class LuceneSegmentInputSplit extends InputSplit implements Writable {

    private Path indexPath;