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.crunch.types.avro.AvroPathPerKeyOutputFormat.java

/**
 * A {@link FileOutputFormat} that takes in a {@link Utf8} and an Avro record and writes the Avro records to
 * a sub-directory of the output path whose name is equal to the string-form of the {@code Utf8}.
 *
 * This {@code OutputFormat} only keeps one {@code RecordWriter} open at a time, so it's a very good idea to write
 * out all of the records for the same key at the same time within each partition so as not to be frequently opening

From source file org.apache.hadoop.examples.terasort.TeraOutputFormat.java

/**
 * An output format that writes the key and value appended together.
 */
public class TeraOutputFormat extends FileOutputFormat<Text, Text> {
    private static final Logger LOG = LoggerFactory.getLogger(TeraOutputFormat.class);
    private OutputCommitter committer = null;

From source file org.apache.hcatalog.rcfile.RCFileMapReduceOutputFormat.java

/**
 * The RC file input format using new Hadoop mapreduce APIs.
 */
public class RCFileMapReduceOutputFormat extends FileOutputFormat<WritableComparable<?>, BytesRefArrayWritable> {

    /**

From source file org.apache.hive.hcatalog.rcfile.RCFileMapReduceOutputFormat.java

/**
 * The RC file input format using new Hadoop mapreduce APIs.
 */
public class RCFileMapReduceOutputFormat extends FileOutputFormat<WritableComparable<?>, BytesRefArrayWritable> {

    /**

From source file org.apache.jena.grande.mapreduce.io.NQuadsOutputFormat.java

public class NQuadsOutputFormat extends FileOutputFormat<NullWritable, QuadWritable> {

    @Override
    public RecordWriter<NullWritable, QuadWritable> getRecordWriter(TaskAttemptContext context)
            throws IOException, InterruptedException {
        Configuration conf = context.getConfiguration();

From source file org.apache.jena.grande.pig.NTriplesPigOutputFormat.java

public class NTriplesPigOutputFormat extends FileOutputFormat<NullWritable, TripleWritable> {

    private static final Logger log = LoggerFactory.getLogger(NTriplesPigOutputFormat.class);

    @Override
    public RecordWriter<NullWritable, TripleWritable> getRecordWriter(TaskAttemptContext context)

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

/**
 * Abstract output format which takes pairs with Node keys and arbitrary values
 * and writes them as a simple line based text file
 * 
 * 
 * 

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

/**
 * An abstract implementation of an output format for line based tuple formats
 * where the key is ignored and only the tuple values will be output
 * 
 * 
 * @param <TKey>

From source file org.apache.kylin.storage.hbase.steps.HFileOutputFormat3.java

/**
 * Copied from HBase's org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2, with fix attempt on KYLIN-2788
 *
 * Writes HFiles. Passed Cells must arrive in order.
 * Writes current time as the sequence id for the file. Sets the major compacted
 * attribute on created @{link {@link HFile}s. Calling write(null,null) will forcibly roll

From source file org.apache.mahout.classifier.bayes.MultipleOutputFormat.java

/**
 * This abstract class extends the FileOutputFormat, allowing to write the
 * output data to different output files. There are three basic use cases for
 * this class.
 * 
 * Case one: This class is used for a map reduce job with at least one reducer.