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 com.datasalt.pangool.tuplemr.mapred.lib.output.TupleOutputFormat.java

/** An {@link org.apache.hadoop.mapreduce.OutputFormat} that writes {@link com.datasalt.pangool.io.ITuple}s. */
@SuppressWarnings("serial")
public class TupleOutputFormat extends FileOutputFormat<ITuple, NullWritable> implements Serializable {

    private Schema outputSchema = null;

From source file com.datasalt.pangool.tuplemr.mapred.lib.output.TupleTextOutputFormat.java

/**
 * A special output format that supports converting a {@link ITuple} into text. It supports CSV-like semantics such as
 * separator character, quote character and escape character. It uses Open CSV underneath
 * (http://opencsv.sourceforge.net/).
 */
@SuppressWarnings("serial")

From source file com.ery.hadoop.mrddx.file.RCFileOutputFormat.java

/**
 * RCFile?
 * 
    
    
    

From source file com.ery.hadoop.mrddx.hive.HiveOutputFormat.java

/**
 * Hive?
 * 
    
    
    

From source file com.hp.hpit.cs.MyTextOutputFormat.java

/** An {@link OutputFormat} that writes plain text files. */
public class MyTextOutputFormat<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 = new byte[] { '\001' };

From source file com.jbw.tar.sf.TarOutputFormat.java

/**
 *
 * @author alvin
 * @param <K>
 * @param <V>
 */

From source file com.jbw.taroutputformat.TarOutputFormat.java

/**
 *
 * @author alvin
 */
public class TarOutputFormat<K, V> extends FileOutputFormat<K, V> {

From source file com.jyz.study.hadoop.hbase.mapreduce.HFileOutputFormatBase.java

/**
 * Writes HFiles. Passed KeyValues must arrive in order. Writes current time as
 * the sequence id for the file. Sets the major compacted attribute on created
 * hfiles. Calling write(null,null) will forceably roll all HFiles being
 * written.
 * <p>

From source file com.linkedin.cubert.io.avro.PigAvroOutputFormatAdaptor.java

public class PigAvroOutputFormatAdaptor extends FileOutputFormat<NullWritable, Object> {

    private PigAvroOutputFormat delegate;

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

From source file com.linkedin.cubert.io.rubix.RubixOutputFormat.java

public class RubixOutputFormat<K, V> extends FileOutputFormat<K, V> {
    @Override
    public RecordWriter<K, V> getRecordWriter(TaskAttemptContext context) throws IOException, InterruptedException {
        Configuration conf = context.getConfiguration();
        String extension = RubixConstants.RUBIX_EXTENSION;