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 org.schedoscope.export.kafka.outputformat.KafkaOutputFormat.java

/**
 * The Kafka output format is responsible to write data into Kafka, it
 * initializes the KafkaRecordWriter.
 *
 * @param <K>
 *            The key class.

From source file org.schedoscope.export.redis.outputformat.RedisOutputFormat.java

/**
 * The Redis output format is responsible to write data into Redis, initializes
 * the Redis Record Writer.
 *
 * @param <K>
 *            The key class,must be sub class of Rediswritable

From source file org.springframework.hadoop.mapreduce.AutowiringOutputFormat.java

/**
 * @author Dave Syer
 *
 */
public class AutowiringOutputFormat<K, V> extends OutputFormat<K, V> implements Configurable {

From source file org.voltdb.hadoop.mapreduce.VoltOutputFormat.java

public class VoltOutputFormat extends OutputFormat<Text, VoltRecord> {

    @Override
    public RecordWriter<Text, VoltRecord> getRecordWriter(TaskAttemptContext context)
            throws IOException, InterruptedException {
        return new VoltRecordWriter(context.getConfiguration());