Example usage for org.apache.hadoop.mapred.lib CombineFileInputFormat subclass-usage

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

Introduction

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

Usage

From source file com.alexholmes.hadooputils.combine.common.mapred.SplitMetricsCombineInputFormat.java

/**
 * An input format that writes split details to a sink, the default sink being a logger.
 *
 * @param <K> The key type.
 * @param <V> The value type.
 */

From source file com.blackberry.logdriver.mapred.avro.AvroBlockInputFormat.java

public class AvroBlockInputFormat extends CombineFileInputFormat<AvroFileHeader, BytesWritable> {
    private static final Logger LOG = LoggerFactory.getLogger(AvroBlockInputFormat.class);
    private static final long MAX_SPLIT_LOCATIONS = 100000;

    @SuppressWarnings("deprecation")
    @Override

From source file com.blackberry.logdriver.mapred.boom.BoomInputFormat.java

public class BoomInputFormat extends CombineFileInputFormat<LogLineData, Text> {
    private static final Logger LOG = LoggerFactory.getLogger(BoomInputFormat.class);

    private static final long MAX_SPLIT_LOCATIONS = 100000;

    @SuppressWarnings("deprecation")

From source file com.rim.logdriver.mapred.avro.AvroBlockInputFormat.java

public class AvroBlockInputFormat extends CombineFileInputFormat<AvroFileHeader, BytesWritable> {
    private static final Logger LOG = LoggerFactory.getLogger(AvroBlockInputFormat.class);
    private static final long MAX_SPLIT_LOCATIONS = 100000;

    @Override
    public RecordReader<AvroFileHeader, BytesWritable> getRecordReader(InputSplit split, JobConf job,

From source file com.rim.logdriver.mapred.boom.BoomInputFormat.java

public class BoomInputFormat extends CombineFileInputFormat<LogLineData, Text> {
    private static final Logger LOG = LoggerFactory.getLogger(BoomInputFormat.class);

    private static final long MAX_SPLIT_LOCATIONS = 100000;

    @Override

From source file org.easycloud.las.analyzer.io.CombinedInputFormat.java

/**
 * Created with IntelliJ IDEA.
 * User: ibntab
 * Date: 13-6-25
 * Time: ?11:16
 */

From source file org.icgc.dcc.release.core.hadoop.CombineSequenceInputFormat.java

public class CombineSequenceInputFormat extends CombineFileInputFormat<NullWritable, BytesWritable> {

    @Override
    @SuppressWarnings({ "rawtypes", "unchecked" })
    public RecordReader<NullWritable, BytesWritable> getRecordReader(InputSplit split, JobConf conf,
            Reporter reporter) throws IOException {

From source file org.icgc.dcc.release.core.hadoop.CombineTextInputFormat.java

public class CombineTextInputFormat extends CombineFileInputFormat<LongWritable, Text> {

    @Override
    @SuppressWarnings({ "rawtypes", "unchecked" })
    public RecordReader<LongWritable, Text> getRecordReader(InputSplit split, JobConf conf, Reporter reporter)
            throws IOException {