Example usage for org.apache.hadoop.mapreduce OutputFormat subclass-usage

List of usage examples for org.apache.hadoop.mapreduce OutputFormat subclass-usage

Introduction

In this page you can find the example usage for org.apache.hadoop.mapreduce OutputFormat subclass-usage.

Usage

From source file com.aerospike.hadoop.mapreduce.AerospikeOutputFormat.java

public abstract class AerospikeOutputFormat<KK, VV> extends OutputFormat<KK, VV>
        implements org.apache.hadoop.mapred.OutputFormat<KK, VV> {

    private static final Log log = LogFactory.getLog(AerospikeOutputFormat.class);

    public static class AerospikeOutputCommitter extends OutputCommitter {

From source file com.aliyun.openservices.tablestore.hadoop.TableStoreOutputFormat.java

public class TableStoreOutputFormat extends OutputFormat<Writable, BatchWriteWritable> {
    public static final String OUTPUT_TABLE = "TABLESTORE_OUTPUT_TABLE";
    public static final String MAX_UPDATE_BATCH_SIZE = "TABLESTORE_MAX_UPDATE_BATCH_SIZE";

    private static final Logger logger = LoggerFactory.getLogger(TableStoreOutputFormat.class);

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

/**
 * A bridge implementation for Hadoop {@link OutputFormat}.
 * @since 0.2.5
 * @version 0.6.1
 */
public final class BridgeOutputFormat extends OutputFormat<Object, Object> {

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

/**
 * A bridge implementation for Hadoop {@link OutputFormat}.
 * @since 0.2.5
 */
public final class StageOutputFormat extends OutputFormat<Object, Object> {

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

/**
 * A temporary output format.
 * @param <T> target type
 * @since 0.2.5
 * @version 0.8.0
 */

From source file com.avira.couchdoop.exp.CouchbaseOutputFormat.java

/**
 * This output format writes writes each key-value received as a Couchbase document.
 *
 * <p>Keys received correspond to the Couchbase keys and values received to Couchbase
 * documents.</p>
 */

From source file com.basho.riak.hadoop.RiakOutputFormat.java

/**
 * Riak specific {@link OutputFormat}, just creates a {@link RiakRecordWriter}
 * 
 * @author russell
 * 
 */

From source file com.bonc.mr_roamRecognition_hjpt.comm.NewFileOutputFormat.java

/**
 * A base class for {@link OutputFormat}s that read from {@link FileSystem}s.
 */
@InterfaceAudience.Public
@InterfaceStability.Stable
public abstract class NewFileOutputFormat<K, V> extends OutputFormat<K, V> {

From source file com.buzzinate.dm.cassandra.ColumnFamilyOutputFormat.java

/**
 * The <code>ColumnFamilyOutputFormat</code> acts as a Hadoop-specific
 * OutputFormat that allows reduce tasks to store keys (and corresponding
 * values) as Cassandra rows (and respective columns) in a given
 * ColumnFamily.
 *

From source file com.cloudera.sqoop.mapreduce.AsyncSqlOutputFormat.java

/**
 * Abstract OutputFormat class that allows the RecordWriter to buffer
 * up SQL commands which should be executed in a separate thread after
 * enough commands are created.
 *
 * This supports a configurable "spill threshold" at which