Example usage for org.apache.hadoop.mapred SequenceFileInputFormat subclass-usage

List of usage examples for org.apache.hadoop.mapred SequenceFileInputFormat subclass-usage

Introduction

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

Usage

From source file com.ibm.bi.dml.runtime.matrix.sort.SamplingSortMRInputFormat.java

@SuppressWarnings("rawtypes")
public class SamplingSortMRInputFormat<K extends WritableComparable, V extends Writable>
        extends SequenceFileInputFormat<K, V> {

    public static final String PARTITION_FILENAME = "_partition.lst";
    static final String SAMPLE_SIZE = "sort.partitions.sample";

From source file com.ibm.bi.dml.runtime.util.BinaryBlockInputFormat.java

/**
 * Custom binary block input format to return the custom record reader.
 * 
 * NOTE: not used by default.
 */
public class BinaryBlockInputFormat extends SequenceFileInputFormat<MatrixIndexes, MatrixBlock> {

From source file com.ibm.jaql.fail.io.ErrorInputFormat.java

public class ErrorInputFormat extends SequenceFileInputFormat<LongWritable, ErrorWritable> {
    public static String ERROR_NAME = "ErrorInputFormat.code";
    public static String ERROR_NEXT_MAX = "ErrorInputFormat.nextMax";

    public enum Error {
        NONE, SPLIT, OPEN, BOGUS_SPLIT, NEXT, CLOSE

From source file com.iflytek.spider.segment.ContentAsTextInputFormat.java

/**
 * An input format that takes Nutch Content objects and converts them to text
 * while converting newline endings to spaces.  This format is useful for working
 * with Nutch content objects in Hadoop Streaming with other languages.
 */
public class ContentAsTextInputFormat extends SequenceFileInputFormat<Text, Text> {

From source file com.m6d.hive.protobuf.KVAsVSeqFileBinaryInputFormat.java

public class KVAsVSeqFileBinaryInputFormat extends SequenceFileInputFormat {

    public KVAsVSeqFileBinaryInputFormat() {
        super();
    }

From source file org.apache.nutch.segment.ContentAsTextInputFormat.java

/**
 * An input format that takes Nutch Content objects and converts them to text
 * while converting newline endings to spaces.  This format is useful for working
 * with Nutch content objects in Hadoop Streaming with other languages.
 */
public class ContentAsTextInputFormat extends SequenceFileInputFormat<Text, Text> {

From source file org.apache.sysml.runtime.matrix.sort.SamplingSortMRInputFormat.java

@SuppressWarnings("rawtypes")
public class SamplingSortMRInputFormat<K extends WritableComparable, V extends Writable>
        extends SequenceFileInputFormat<K, V> {

    public static final String PARTITION_FILENAME = "_partition.lst";
    static final String SAMPLE_SIZE = "sort.partitions.sample";

From source file org.apache.sysml.runtime.util.BinaryBlockInputFormat.java

/**
 * Custom binary block input format to return the custom record reader.
 * <p>
 * NOTE: Not used by default.
 * <p>
 * NOTE: Used for performance debugging of binary block HDFS reads.

From source file org.commoncrawl.hadoop.io.mapred.EscapedNewLineSequenceFileInputFormat.java

/**
 * A Text/Text sequence file inputformat that removes carriage returns and escapes tabs and newlines
 * in the record value
 * 
 * @author matpalm
 */

From source file voldemort.store.readonly.mr.serialization.JsonSequenceFileInputFormat.java

/**
 * Extends {@link SequenceFileInputFormat} to support our JSON based
 * serialization format.
 * 
 * Reads in a SequenceFile Read out the schema from Metadata and save it as keys
 * in configuration.