Example usage for org.apache.hadoop.mapreduce.lib.output FileOutputFormat subclass-usage

List of usage examples for org.apache.hadoop.mapreduce.lib.output FileOutputFormat subclass-usage

Introduction

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

Usage

From source file parquet.hadoop.ParquetOutputFormat.java

/**
 * OutputFormat to write to a Parquet file
 *
 * It requires a {@link WriteSupport} to convert the actual records to the underlying format.
 * It requires the schema of the incoming records. (provided by the write support)
 * It allows storing extra metadata in the footer (for example: for schema compatibility purpose when converting from a different schema language).

From source file selfy.JSONOutput.java

/**
 *
 * @author lukas
 */
public class JSONOutput extends FileOutputFormat<Text, MapWritable> {

From source file simsql.runtime.RecordOutputFormat.java

/**
 * This silly little class is here primarily to return an
 * OutputFileSerializer object
 */

public class RecordOutputFormat extends FileOutputFormat<WritableKey, WritableValue> {

From source file skewtune.mapreduce.lib.output.DummyFileOutputFormat.java

/** An {@link OutputFormat} that writes {@link SequenceFile}s. */

public final class DummyFileOutputFormat<K, V> extends FileOutputFormat<K, V> {
    @Override
    public RecordWriter<K, V> getRecordWriter(TaskAttemptContext context) throws IOException, InterruptedException {
        return new RecordWriter<K, V>() {

From source file terasort.io.TeraOutputFormat.java

/**
 * An output format that writes the key and value appended together.
 */
public class TeraOutputFormat extends FileOutputFormat<Text, Text> {

    private OutputCommitter committer = null;

From source file terasort.TeraOutputFormat.java

/**
 * An output format that writes the key and value appended together.
 */
public class TeraOutputFormat extends FileOutputFormat<Text, Text> {
    static final String FINAL_SYNC_ATTRIBUTE = "mapreduce.terasort.final.sync";
    private OutputCommitter committer = null;

From source file trec.TrecOutputFormat.java

/** An {@link OutputFormat} that writes plain text files. */
public class TrecOutputFormat<K, V> extends FileOutputFormat<K, V> {
    protected static class LineRecordWriter<K, V> extends RecordWriter<K, V> {
        private static final String utf8 = "UTF-8";
        private static final byte[] newline;
        static {

From source file uk.ac.cam.eng.extraction.hadoop.util.SimpleHFileOutputFormat.java

/**
 * Create an HFile with a block size of 64k and a Bloom Filter
 * 
 * @author Aurelien Waite
 * @date 28 May 2014
 */

From source file uk.bl.wa.hadoop.mapreduce.io.TextOutputFormat.java

/** An {@link OutputFormat} that writes plain text files. */
public class TextOutputFormat<K, V> extends FileOutputFormat<K, V> {
    protected static class LineRecordWriter<K, V> extends RecordWriter<K, V> {
        private static final String utf8 = "UTF-8";
        private static final byte[] newline;
        static {

From source file z_try.CustomFileOutputFormat.java

/**
 * Created by TAN on 6/23/2015.
 */

public class CustomFileOutputFormat extends FileOutputFormat<LongWritable, byte[]> {