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.phoenix.mapreduce.PhoenixInputSplit.java

/**
 * Input split class to hold the lower and upper bound range. {@link KeyRange}
 */
public class PhoenixInputSplit extends InputSplit implements Writable {

    private List<Scan> scans;

From source file org.apache.phoenix.pig.hadoop.PhoenixInputSplit.java

/**
 * 
 * Input split class to hold the lower and upper bound range. {@link KeyRange}
 * 
 */
public class PhoenixInputSplit extends InputSplit implements Writable {

From source file org.apache.pig.backend.hadoop.executionengine.mapReduceLayer.PigSplit.java

/**
 * The main split class that maintains important
 * information about the input split.
 *
 * The reason this class implements Configurable is so that Hadoop will call
 * {@link Configurable#setConf(Configuration)} on the backend so we can use

From source file org.apache.sqoop.job.mr.SqoopSplit.java

/**
 * An input split to be read.
 */
public class SqoopSplit extends InputSplit implements Writable {

    private Partition partition;

From source file org.apache.sqoop.mapredsparkcommon.SqoopSplit.java

/**
 * An input split to be read.
 */
public class SqoopSplit extends InputSplit implements Writable, Serializable {

    private /*transient*/ Partition partition;

From source file org.apache.sqoop.mapreduce.CombineFileSplit.java

/**
 * A sub-collection of input files.
 *
 * Unlike FileSplit, CombineFileSplit class does not represent
 * a split of a file, but a split of input files into smaller sets.
 * A split may contain blocks from different file but all

From source file org.apache.sqoop.mapreduce.hcat.SqoopHCatInputSplit.java

/**
 * An abstraction of a combined HCatSplits.
 *
 */
public class SqoopHCatInputSplit extends InputSplit implements Writable {
    private List<HCatSplit> hCatSplits;

From source file org.apache.sqoop.mapreduce.mainframe.MainframeDatasetInputSplit.java

/**
 * A collection of mainframe datasets.
 *
 */
public class MainframeDatasetInputSplit extends InputSplit implements Writable {
    private List<String> mainframeDatasets;

From source file org.apache.sqoop.mapreduce.netezza.NetezzaExternalTableInputSplit.java

/**
 * Netezza dataslice specific input splitter.
 *
 */
public class NetezzaExternalTableInputSplit extends InputSplit implements Writable {

From source file org.apache.taverna.platform.execution.impl.hadoop.TavernaInputSplit.java

/**
 *
 *
 * @author David Withers
 */
public class TavernaInputSplit extends InputSplit {