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 org.apache.solr.hadoop.TreeMergeOutputFormat.java

/**
 * See {@link IndexMergeTool}.
 */
public class TreeMergeOutputFormat extends FileOutputFormat<Text, NullWritable> {

    @Override

From source file org.apache.sqoop.mapreduce.AvroOutputFormat.java

/**
 * An {@link org.apache.hadoop.mapred.OutputFormat} for Avro data files.
 * <p/>
 * Note: This class is copied from the Avro project in version 1.5.4 and
 * adapted here to work with the "new" MapReduce API that's required in Sqoop.
 */

From source file org.apache.sqoop.mapreduce.RawKeyTextOutputFormat.java

/**
 * An {@link OutputFormat} that writes plain text files.
 * Only writes the key. Does not write any delimiter/newline after the key.
 */
public class RawKeyTextOutputFormat<K, V> extends FileOutputFormat<K, V> {

From source file org.apache.tez.mapreduce.examples.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 org.apache.tinkerpop.gremlin.hadoop.structure.io.CommonFileOutputFormat.java

/**
 * @author Marko A. Rodriguez (http://markorodriguez.com)
 */
public abstract class CommonFileOutputFormat extends FileOutputFormat<NullWritable, VertexWritable>
        implements PersistResultGraphAware {

From source file org.apache.trevni.avro.mapreduce.AvroTrevniKeyOutputFormat.java

/** An {@link org.apache.hadoop.mapreduce.OutputFormat} that writes Avro data to
 * Trevni files.
 *
 * This implement was modeled off 
 * {@link org.apache.avro.mapreduce.AvroKeyOutputFormat} to allow for easy
 * transition

From source file org.apache.trevni.avro.mapreduce.AvroTrevniKeyValueOutputFormat.java

/** An {@link org.apache.hadoop.mapreduce.OutputFormat} that writes Avro data to
 * Trevni files.
 * 
 * This implement was modeled off 
 * {@link org.apache.avro.mapreduce.AvroKeyValueOutputFormat} to allow for easy
 * transition 

From source file org.bgi.flexlab.gaea.data.mapreduce.output.bam.GaeaBamOutputFormat.java

public class GaeaBamOutputFormat<K> extends FileOutputFormat<K, SamRecordWritable> {
    private boolean writeHeader = true;

    @Override
    public RecordWriter<K, SamRecordWritable> getRecordWriter(TaskAttemptContext context)
            throws IOException, InterruptedException {

From source file org.bgi.flexlab.gaea.data.mapreduce.output.cram.GaeaCramOutputFormat.java

public class GaeaCramOutputFormat<K> extends FileOutputFormat<K, SAMRecordWritable> {
    private boolean writeHeader = false;

    @Override
    public RecordWriter<K, SAMRecordWritable> getRecordWriter(TaskAttemptContext context)
            throws IOException, InterruptedException {

From source file org.bgi.flexlab.gaea.data.mapreduce.output.vcf.GaeaVCFOutputFormat.java

/**
 * Created by zhangyong on 2017/3/3.
 * came form VCFsort
 */
public class GaeaVCFOutputFormat<K> extends FileOutputFormat<K, VariantContextWritable> {