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 alluxio.hadoop.mapreduce.KeyValueOutputFormat.java

/**
 * An {@link OutputFormat} implementation to let MapReduce job write to a key-value store under the
 * MapReduce output directory.
 * <p>
 * There are different key-value stores under the output directory configured via MapReduce property
 * {@code mapreduce.output.fileoutputformat.outputdir} for different tasks. The stores are merged

From source file co.cask.cdap.internal.app.runtime.batch.dataset.partitioned.DynamicPartitioningOutputFormat.java

/**
 * This class extends the FileOutputFormat and allows writing dynamically to multiple partitions of a PartitionedFileSet
 * Dataset.
 *
 * This class is used in {@link PartitionedFileSetDataset} and is referred to this class by name because data-fabric
 * doesn't depends on app-fabric, while this class needs access to app-fabric class {@link BasicMapReduceTaskContext}.

From source file co.nubetech.hiho.mapreduce.lib.output.NoKeyOnlyValueOutputFormat.java

/**
 * This class ignores the key and simply prints the value. However, new line is
 * added
 * 
 * @author sgoyal
 * 

From source file com.asakusafw.lang.compiler.mapreduce.testing.mock.WritableOutputFormat.java

/**
 * An output format with {@link WritableModelOutput}.
 * @param <T> data model type
 */
public class WritableOutputFormat<T extends Writable> extends FileOutputFormat<NullWritable, T> {

From source file com.asakusafw.runtime.stage.output.EmptyFileOutputFormat.java

/**
 * An empty implementation of {@link FileOutputFormat}.
 * @since 0.2.5
 */
public final class EmptyFileOutputFormat extends FileOutputFormat<Object, Object> {

From source file com.bigfishgames.biginsights.upsight.mapreduce.MyAvroOutputFormatBase.java

/**
 * Abstract base class for output formats that write Avro container files.
 *
 * @param <K> The type of key to write.
 * @param <V> The type of value to write.
 */

From source file com.blackberry.logdriver.mapreduce.BinaryOutputFormat.java

public class BinaryOutputFormat extends FileOutputFormat<BytesWritable, NullWritable> {

    /**
     * Gets a {@link BinaryRecordWriter} for a given context.
     * 
     * @param context

From source file com.blackberry.logdriver.mapreduce.boom.PigBoomHourlyOutputFormat.java

public class PigBoomHourlyOutputFormat extends FileOutputFormat<Tuple, NullWritable> {

    @Override
    public RecordWriter<Tuple, NullWritable> getRecordWriter(TaskAttemptContext job)
            throws IOException, InterruptedException {
        return new PigBoomHourlyRecordWriter(this, job);

From source file com.blackberry.logdriver.mapreduce.boom.PigReBoomOutputFormat.java

public class PigReBoomOutputFormat extends FileOutputFormat<Tuple, NullWritable> {

    @Override
    public RecordWriter<Tuple, NullWritable> getRecordWriter(TaskAttemptContext job)
            throws IOException, InterruptedException {
        return new PigReBoomRecordWriter(this, job);

From source file com.blm.orc.OrcNewOutputFormat.java

/** An OutputFormat that writes ORC files. */
public class OrcNewOutputFormat extends FileOutputFormat<NullWritable, OrcSerdeRow> {

    private static class OrcRecordWriter extends RecordWriter<NullWritable, OrcSerdeRow> {
        private Writer writer = null;
        private final Path path;