Example usage for org.apache.hadoop.io Writable interface-usage

List of usage examples for org.apache.hadoop.io Writable interface-usage

Introduction

In this page you can find the example usage for org.apache.hadoop.io Writable interface-usage.

Usage

From source file com.chinamobile.bcbsp.workermanager.WorkerManagerStatus.java

/**
 * Store workers' status information Encapsulate all of the information of
 * workers.
 */
public class WorkerManagerStatus implements Writable {
    /** Define Log variable for outputting messages */

From source file com.chinnu.churndetection.utils.Vector.java

/**
 *
 * @author libin
 */
public class Vector implements Writable {

From source file com.citic.zxyjs.zwlscx.mapreduce.join.api.TaggedMapOutput.java

/**
 * This abstract class serves as the base class for the values that flow from
 * the mappers to the reducers in a data join job. Typically, in such a job, the
 * mappers will compute the source tag of an input record based on its
 * attributes or based on the file name of the input file. This tag will be used
 * by the reducers to re-group the values of a given key according to their

From source file com.cloudera.bigdata.analysis.query.Condition.java

/**
 * The Class representing search condition. The condition is similar to Node
 * conception in the condition tree. There is a concrete subclass (@link
 * SimpleCondition} which is leaf node, and several {@link CompositeCondition}
 * which is none-leaf node.
 */

From source file com.cloudera.branchreduce.GlobalState.java

/**
 * An extension of {@code Writable} that supports a <i>merge</i> operation, which is
 * a deterministic rule for combining the value of this instance with the value of another
 * instance.
 */
public interface GlobalState<GS extends GlobalState<GS>> extends Writable {

From source file com.cloudera.branchreduce.onezero.PartialSolution.java

/**
 *
 */
public class PartialSolution implements Writable {

    private int fixLimit;

From source file com.cloudera.crunch.impl.mr.run.CrunchInputSplit.java

public class CrunchInputSplit extends InputSplit implements Configurable, Writable {

    private InputSplit inputSplit;
    private Class<? extends InputFormat> inputFormatClass;
    private int nodeIndex;
    private Configuration conf;

From source file com.cloudera.crunch.type.writable.GenericArrayWritable.java

public class GenericArrayWritable<T> implements Writable {
    private Writable[] values;
    private Class<? extends Writable> valueClass;

    public GenericArrayWritable(Class<? extends Writable> valueClass) {
        this.valueClass = valueClass;

From source file com.cloudera.crunch.type.writable.TextMapWritable.java

public class TextMapWritable<T extends Writable> implements Writable {

    private Class<T> valueClazz;
    private final Map<Text, T> instance;

    public TextMapWritable() {

From source file com.cloudera.flume.handlers.hdfs.WriteableEvent.java

/**
 * A wrapper to make my events hadoop/hdfs writeables.
 * 
 */
public class WriteableEvent extends EventBaseImpl implements Writable {
    final static long MAX_BODY_SIZE = FlumeConfiguration.get().getEventMaxSizeBytes();