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.inmobi.databus.partition.PartitionCheckpoint.java

public class PartitionCheckpoint implements Writable, MessageCheckpoint {
    private StreamFile streamFile;
    private long lineNum;

    public PartitionCheckpoint(StreamFile streamFile, long lineNum) {
        this.streamFile = streamFile;

From source file com.inmobi.databus.partition.PartitionId.java

public class PartitionId implements Writable {

    private String cluster;
    private String collector;

    public PartitionId(String cluster, String collector) {

From source file com.inmobi.messaging.consumer.databus.Checkpoint.java

/**
 * Checkpoint for the databus stream.
 *
 * It holds checkpoint for all the partitions.
 *
 */

From source file com.intel.genomicsdb.GenomicsDBInputSplit.java

public class GenomicsDBInputSplit extends InputSplit implements Writable {

    // Note that for now the assumption is that there is
    // one GenomicsDB instance per node, hence one host
    // per split
    String[] hosts;

From source file com.intel.hadoop.graphbuilder.partition.mapreduce.keyvalue.CombinedEdgeValueType.java

/**
 * Intermediate value type of edge records and supports commutative and
 * associative add operation to merge with instances of the same type.
 * 
 */
public class CombinedEdgeValueType<VidType extends WritableComparable<VidType>, VertexData extends Writable, EdgeData extends Writable>

From source file com.intel.hadoop.graphbuilder.partition.mapreduce.keyvalue.CombinedVrecordValueType.java

/**
 * Intermediate value type of vertex records and supports commutative and
 * associative add operation through additvity of inEdges, outEdges and union of
 * the mirror set.
 * 
 */

From source file com.intel.hadoop.graphbuilder.partition.mapreduce.keyvalue.IngressValueType.java

/**
 * An abstract class for map value templated with VidType, VertexData, and
 * EdgeData. MapValue is a "union" type EdgeRecordType, and VertexRecordType.
 * Both sub types are combinable with the same subtype.
 * 
 * @param <VidType>

From source file com.intel.hadoop.graphbuilder.preprocess.mapreduce.keyvalue.PairListType.java

/**
 * A general abstract class represents a list of pairs. Used as the intermediate
 * map output value type in EdgeTransformMR for holding a list of
 * {@code VidType, EdgeData} pairs.
 * 
 * 

From source file com.intel.hadoop.graphbuilder.preprocess.mapreduce.keyvalue.VertexEdgeUnionType.java

/**
 * Abstract union type of {@code Vertex} and {@code Edge}. Used as intermediate
 * map output value to hold either a vertex or an edge.
 * 
 * 
 * @param <VidType>

From source file com.intel.hadoop.graphbuilder.types.EmptyType.java

/**
 * Basic type in the library. Represents a dummy type of empty.
 * 
 */
public class EmptyType implements Writable, Mergable<EmptyType> {
    public final static EmptyType INSTANCE = new EmptyType();