Example usage for org.apache.hadoop.mapreduce RecordWriter subclass-usage

List of usage examples for org.apache.hadoop.mapreduce RecordWriter subclass-usage

Introduction

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

Usage

From source file org.apache.jena.hadoop.rdf.io.output.writers.QuadsToTriplesWriter.java

/**
 * A record writer that converts quads into triples by stripping off the graph
 * field
 * 
 * @param <TKey>
 *            Key type

From source file org.apache.mahout.common.DummyRecordWriter.java

public final class DummyRecordWriter<K extends Writable, V extends Writable> extends RecordWriter<K, V> {

    private final List<K> keysInInsertionOrder = Lists.newArrayList();
    private final Map<K, List<V>> data = Maps.newHashMap();

    @Override

From source file org.apache.mnemonic.hadoop.mapreduce.MneMapreduceRecordWriter.java

/**
 * This record writer implements the org.apache.hadoop.mapreduce API.
 *
 * @param <MV>
 *          the type of the item of value
 */

From source file org.apache.orc.mapreduce.OrcMapreduceRecordWriter.java

public class OrcMapreduceRecordWriter<V extends Writable> extends RecordWriter<NullWritable, V> {

    private final Writer writer;
    private final VectorizedRowBatch batch;
    private final TypeDescription schema;
    private final boolean isTopStruct;

From source file org.apache.parquet.hadoop.ParquetRecordWriter.java

/**
 * Writes records to a Parquet file
 *
 * @see ParquetOutputFormat
 *
 * @author Julien Le Dem

From source file org.apache.phoenix.mapreduce.PhoenixRecordWriter.java

/**
 * Default {@link RecordWriter} implementation from Phoenix
 *
 */
public class PhoenixRecordWriter<T extends DBWritable> extends RecordWriter<NullWritable, T> {

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

/**
 * 
 * {@link RecordWriter} implementation for Phoenix
 * 
 * 
 *

From source file org.apache.pig.impl.io.BinStorageRecordWriter.java

/**
 *
 */
public class BinStorageRecordWriter extends RecordWriter<org.apache.hadoop.io.WritableComparable, Tuple> {

    public static final int RECORD_1 = 0x01;

From source file org.apache.pig.impl.io.InterRecordWriter.java

/**
 * A record reader used to write data compatible with {@link InterRecordWriter}
 * It uses the default InterSedes object for serialization.
 */
public class InterRecordWriter extends RecordWriter<org.apache.hadoop.io.WritableComparable, Tuple> {

From source file org.apache.pig.impl.io.TFileRecordWriter.java

/**
 * A record reader used to write data compatible with {@link InterRecordWriter}
 * It uses the default InterSedes object for serialization.
 */
public class TFileRecordWriter extends RecordWriter<org.apache.hadoop.io.WritableComparable, Tuple> {