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.marklogic.contentpump.CombineDocumentSplit.java

/**
 * InputSplit with multiple document files combined.
 * 
 * @author jchen
 *
 */

From source file com.marklogic.mapreduce.MarkLogicInputSplit.java

/**
 * MarkLogic-based InputSplit, used to represent a group of records returned by
 * MarkLogic server, and identify originating host.
 * 
 * @author jchen
 */

From source file com.mongodb.hadoop.input.MongoInputSplit.java

public class MongoInputSplit extends InputSplit implements Writable, org.apache.hadoop.mapred.InputSplit {
    private static final Log LOG = LogFactory.getLog(MongoInputSplit.class);
    //CHECKSTYLE:OFF
    protected MongoClientURI inputURI;
    protected MongoClientURI authURI;
    protected String keyField = "_id";

From source file com.netflix.aegisthus.input.AegSplit.java

@SuppressWarnings("rawtypes")
public class AegSplit extends InputSplit implements Writable {
    private static final Log LOG = LogFactory.getLog(AegSplit.class);

    public enum Type {
        commitlog, json, sstable

From source file com.netflix.aegisthus.input.splits.AegCombinedSplit.java

public class AegCombinedSplit extends InputSplit implements Writable {
    private static final LoadingCache<String, Class<AegSplit>> AEG_SPLIT_LOADING_CACHE = CacheBuilder.newBuilder()
            .build(new CacheLoader<String, Class<AegSplit>>() {
                @Override
                public Class<AegSplit> load(@Nonnull String className) throws Exception {
                    return (Class<AegSplit>) Class.forName(className);

From source file com.netflix.aegisthus.input.splits.AegSplit.java

public class AegSplit extends InputSplit implements Writable {
    private static final Logger LOG = LoggerFactory.getLogger(AegSplit.class);

    protected long end;
    protected String[] hosts;
    protected Path path;

From source file com.rockstor.compact.mapreduce.CompactDirInputSplit.java

/**
 * @author terry
 * 
 */
public class CompactDirInputSplit extends InputSplit implements Writable {
    private String taskIdName = null;

From source file com.scaleoutsoftware.soss.hserver.BucketSplit.java

/**
 * An input split that corresponds to the contents of the one or several buckets.
 */
class BucketSplit extends InputSplit implements Writable, Serializable, GridSplit {
    private static final long serialVersionUID = 1L;

From source file com.scaleoutsoftware.soss.hserver.ImageInputSplit.java

/**
 * This input split is part of the {@link GridImage}. It is wrapper over original input split containing
 * additional information which allow to read it from the bucket store.
 *
 * {@link GridImage}
 */

From source file com.splicemachine.compactions.CompactionSplit.java

/**
 * Created by jyuan on 3/24/16.
 */
public class CompactionSplit extends InputSplit implements Writable {

    String[] locations;