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.kiji.avro.mapreduce.AvroOutputFormatBase.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 org.kiji.avro.mapreduce.AvroSequenceFileOutputFormat.java

/**
 * A sequence file output format that knows how to write AvroKeys and AvroValues in
 * addition to Writables.
 *
 * @param <K> The job output key type (may be a Writable, AvroKey).
 * @param <V> The job output value type (may be a Writable, AvroValue).

From source file org.kiji.mapreduce.output.framework.KijiHFileOutputFormat.java

/**
 * Hadoop output format that writes HFiles that can be loaded directly into HBase region servers.
 *
 * <p> Allows writing entries to any HBase family of the target table.
 *     Each reduce task generates a set of files per HBase family.
 *

From source file org.kiji.mapreduce.output.KijiHFileOutputFormat.java

/**
 * Hadoop output format that writes HFiles that can be loaded directly into HBase region servers.
 *
 * <p> Allows writing entries to any HBase family of the target table.
 *     Each reduce task generates a set of files per HBase family.
 *

From source file org.mrgeo.data.accumulo.output.image.AccumuloMrsImagePyramidFileOutputFormat.java

public class AccumuloMrsImagePyramidFileOutputFormat extends FileOutputFormat<Key, Value> {

    private String vizStr = null;
    private ColumnVisibility cv = null;

    private AccumuloFileOutputFormat _innerFormat = null;

From source file org.mrgeo.data.accumulo.output.image.AccumuloMrsPyramidFileOutputFormat.java

public class AccumuloMrsPyramidFileOutputFormat extends FileOutputFormat<Key, Value> {

    private static final Logger log = LoggerFactory.getLogger(AccumuloMrsPyramidFileOutputFormat.class);
    private String vizStr = null;
    private ColumnVisibility cv = null;
    private AccumuloFileOutputFormat _innerFormat = null;

From source file org.mrgeo.data.csv.CsvOutputFormat.java

/**
 * It is assumed that all CSV files are in WGS84.
 * 
 * @author jason.surratt
 * 
 */

From source file org.mrgeo.format.CsvOutputFormat.java

/**
 * Reads tab separated values as geometries.
 *
 * http://code.flickr.com/blog/2009/05/21/flickr-shapefiles-public-dataset-10/
 */
public class CsvOutputFormat extends FileOutputFormat<LongWritable, Geometry> implements Serializable {

From source file org.mrgeo.format.KmlGeometryOutputFormat.java

/**
 */
public class KmlGeometryOutputFormat extends FileOutputFormat<LongWritable, GeometryWritable>
        implements Serializable {
    private static final long serialVersionUID = 1L;

From source file org.mrgeo.format.KmlOutputFormat.java

/**
 */
public class KmlOutputFormat extends FileOutputFormat<LongWritable, GeometryWritable> implements Serializable {
    private static final long serialVersionUID = 1L;

    static public class KmlRecordWriter extends RecordWriter<LongWritable, GeometryWritable> {