Example usage for org.apache.hadoop.mapred.lib MultipleOutputFormat subclass-usage

List of usage examples for org.apache.hadoop.mapred.lib MultipleOutputFormat subclass-usage

Introduction

In this page you can find the example usage for org.apache.hadoop.mapred.lib MultipleOutputFormat subclass-usage.

Usage

From source file babel.prep.corpus.MultipleXMLLangFileOutputFormat.java

/** 
 * Generates multiple XML files each containing pages in a single nalguage.
 */
class MultipleXMLLangFileOutputFormat extends MultipleOutputFormat<Text, Page> {
    static final Log LOG = LogFactory.getLog(MultipleXMLLangFileOutputFormat.class);

From source file babel.prep.datedcorpus.DatedLangFilesOutputFormat.java

public class DatedLangFilesOutputFormat extends MultipleOutputFormat<Text, Text> {
    static final Log LOG = LogFactory.getLog(DatedLangFilesOutputFormat.class);

    static final String DEFAULT_CHARSET = "UTF-8";
    static final String REJECTED_FILE = "rejected.txt";
    static final String EXTENSION = ".txt";

From source file fm.last.feathers.output.MultipleRawFileOutputFormat.java

/**
 * This class extends the MultipleOutputFormat, allowing to write the output data-
 * to different output files in raw file output format.
 */
public class MultipleRawFileOutputFormat<K, V> extends MultipleOutputFormat<K, V> {

From source file org.apache.mahout.classifier.bayes.common.BayesFeatureOutputFormat.java

/**
 * This class extends the MultipleOutputFormat, allowing to write the output data to different output files in sequence
 * file output format.
 */
public class BayesFeatureOutputFormat extends MultipleOutputFormat<WritableComparable<?>, Writable> {

From source file org.apache.mahout.classifier.bayes.common.BayesTfIdfOutputFormat.java

/**
 * This class extends the MultipleOutputFormat, allowing to write the output data to different output files in sequence
 * file output format.
 */
public class BayesTfIdfOutputFormat extends MultipleOutputFormat<WritableComparable<?>, Writable> {

From source file org.apache.mahout.classifier.bayes.common.BayesWeightSummerOutputFormat.java

/**
 * This class extends the MultipleOutputFormat, allowing to write the output data to different output files in sequence
 * file output format.
 */
public class BayesWeightSummerOutputFormat extends MultipleOutputFormat<WritableComparable<?>, Writable> {

From source file org.apache.mahout.classifier.bayes.mapreduce.common.BayesFeatureOutputFormat.java

/**
 * This class extends the MultipleOutputFormat, allowing to write the output data to different output files in
 * sequence file output format.
 */
public class BayesFeatureOutputFormat extends MultipleOutputFormat<WritableComparable<?>, Writable> {

From source file org.apache.mahout.classifier.bayes.mapreduce.common.BayesTfIdfOutputFormat.java

/**
 * This class extends the MultipleOutputFormat, allowing to write the output data to different output files in
 * sequence file output format.
 */
public class BayesTfIdfOutputFormat extends MultipleOutputFormat<WritableComparable<?>, Writable> {

From source file org.apache.mahout.classifier.bayes.mapreduce.common.BayesWeightSummerOutputFormat.java

/**
 * This class extends the MultipleOutputFormat, allowing to write the output data to different output files in
 * sequence file output format.
 */
public class BayesWeightSummerOutputFormat extends MultipleOutputFormat<WritableComparable<?>, Writable> {

From source file org.calrissian.accumulorecipes.commons.hadoop.AccumuloMultipleOuputs.java

/**
 * A wrapper around the {@link org.apache.accumulo.core.client.mapred.AccumuloFileOutputFormat} that will output
 * each group into a separate folder in HDFS. This enables keys/values for multiple tables to be partitioned, sorted,
 * and output within the same mapreduce job.`
 */
public class AccumuloMultipleOuputs extends MultipleOutputFormat<GroupedKey, Value> {