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 fi.tkk.ics.hadoop.bam.BAMOutputFormat.java

/** Currently this only locks down the value type of the {@link
 * org.apache.hadoop.mapreduce.OutputFormat}: contains no functionality.
 */
public abstract class BAMOutputFormat<K> extends FileOutputFormat<K, SAMRecordWritable> {
}

From source file fi.tkk.ics.hadoop.bam.cli.CLIMergingAnySAMOutputFormat.java

public class CLIMergingAnySAMOutputFormat<K> extends FileOutputFormat<K, SAMRecordWritable> {
    private KeyIgnoringAnySAMOutputFormat<K> baseOF;

    private void initBaseOF(Configuration conf) {
        if (baseOF == null)
            baseOF = new KeyIgnoringAnySAMOutputFormat<K>(conf);

From source file fi.tkk.ics.hadoop.bam.cli.plugins.VCFSort.java

final class SortOutputFormat<K> extends FileOutputFormat<K, VariantContextWritable> {
    public static final String INPUT_PATH_PROP = "hadoopbam.vcfsort.inpath";

    private KeyIgnoringVCFOutputFormat<K> baseOF;

    private void initBaseOF(Configuration conf) {

From source file fi.tkk.ics.hadoop.bam.VCFOutputFormat.java

/** An abstract {@link org.apache.hadoop.mapreduce.OutputFormat} for VCF and
 * BCF files. Only locks down the value type and stores the output format
 * requested.
 */
public abstract class VCFOutputFormat<K> extends FileOutputFormat<K, VariantContextWritable> {
    /** A string property defining the output format to use. The value is read

From source file fr.ens.biologie.genomique.eoulsan.bio.io.hadoop.ExpressionOutputFormat.java

/**
 * This class define a expression output format.
 * @author Laurent Jourdren
 * @since 2.0
 */
public class ExpressionOutputFormat extends FileOutputFormat<Text, LongWritable> {

From source file fr.ens.biologie.genomique.eoulsan.bio.io.hadoop.FastqOutputFormat.java

/**
 * This class define a FASTQ output format.
 * @author Laurent Jourdren
 * @since 2.0
 */
public class FastqOutputFormat extends FileOutputFormat<Text, Text> {

From source file fr.ens.biologie.genomique.eoulsan.bio.io.hadoop.SAMOutputFormat.java

/**
 * This class define a SAM output format.
 * @author Laurent Jourdren
 * @since 2.0
 */
public class SAMOutputFormat extends FileOutputFormat<Text, Text> {

From source file gr.ntua.h2rdf.inputFormat.MultiHFileOutputFormat.java

public class MultiHFileOutputFormat extends FileOutputFormat<ImmutableBytesWritable, KeyValue> {
    static final String COMPRESSION_CONF_KEY = "hbase.hfileoutputformat.families.compression";

    Map<ImmutableBytesWritable, RecordWriter<ImmutableBytesWritable, KeyValue>> writers = new HashMap<ImmutableBytesWritable, RecordWriter<ImmutableBytesWritable, KeyValue>>();

    /* Data structure to hold a Writer and amount of data written on it. */

From source file hadoop.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 info.halo9pan.word2vec.hadoop.mr.SortOutputFormat.java

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