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 de.unileipzig.dbs.giraph.algorithms.labelpropagation.LPVertexValue.java

/**
 * Custom vertex used by {@link LPComputation}.
 *
 * @author Kevin Gomez (k.gomez@freenet.de)
 * @author Martin Junghanns (junghanns@informatik.uni-leipzig.de)
 */

From source file eagle.log.entity.filter.QualifierFilterEntity.java

public class QualifierFilterEntity implements Writable {
    public String key;
    public String value;
    public ComparisonOperator op;
    public TokenType valueType;
    public TokenType keyType;

From source file eagle.log.entity.meta.EntityDefinition.java

/**
 *
 * This object should be regarded as read-only metadata for an entity as it will be shared across all entity object
 * with the same entity name, so don't try to set different values for any of the fields, 
 * otherwise it's not thread safe
 */

From source file eagle.log.entity.meta.MetricDefinition.java

public class MetricDefinition implements Writable {
    private final static Logger LOG = LoggerFactory.getLogger(MetricDefinition.class);
    private long interval;
    private Class<?> singleTimestampEntityClass;

    public long getInterval() {

From source file eagle.log.entity.meta.Qualifier.java

public class Qualifier implements Writable {
    private final static Logger LOG = LoggerFactory.getLogger(Qualifier.class);

    private String displayName;
    private String qualifierName;
    private EntitySerDeser<Object> serDeser;

From source file eagle.query.aggregate.raw.GroupbyKey.java

/**
 * <h3>Structure</h3>
 * <pre>
 * {
 *   List[byte[],...]
 * }

From source file eagle.query.aggregate.raw.GroupbyKeyValue.java

/**
 * <h3>Groupby KeyValue Structure</h3>
 * <pre>
 * {
 *  key: GroupbyKey
 *  value: GroupbyValue

From source file eagle.query.aggregate.raw.GroupbyValue.java

/**
 * <h3>Strucutre</h3>
 * <pre>
 * {
 *   value: List[byte[],...],
 *   meta : List[byte[],...] // byte[] may be serialized value

From source file eagle.query.aggregate.raw.WritableList.java

/**
 * @since : 11/6/14,2014
 */
public class WritableList<E extends Writable> extends ArrayList<E> implements Writable {
    private Class<E> itemTypeClass;

From source file eagle.storage.hbase.query.coprocessor.AggregateResult.java

/**
 * Aggregated writable result consist of group-by key-values list and additional meta information
 * 
 * <h2>Schema</h2>
 * <pre>
 * {