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.cloudera.sqoop.lib.SqoopRecord.java

/**
 * Interface implemented by the classes generated by sqoop's orm.ClassWriter.
 */
public abstract class SqoopRecord implements Cloneable, DBWritable, FieldMappable, Writable {

    public SqoopRecord() {

From source file com.cloudera.sqoop.mapreduce.MergeRecord.java

/**
 * Class that holds a record to be merged. This contains a SqoopRecord which
 * is the "guts" of the item, and a boolean value indicating whether it is a
 * "new" record or an "old" record. In the Reducer, we prefer to emit a new
 * record rather than an old one, if a new one is available.
 */

From source file com.cloudera.traffic.AverageWritable.java

public class AverageWritable implements Writable {

    private int numElements;
    private double average;

    public AverageWritable() {

From source file com.conductor.hadoop.TaggedInputSplit.java

/**
 * An {@link InputSplit} that tags another InputSplit with extra data for use by DelegatingInputFormat's and
 * {@link DelegatingMapper}s.
 * 
 * <p/>
 * This package-private class is taken directly from the Hadoop source code, and made public here so that we can

From source file com.conductor.kafka.Broker.java

/**
 * Wraps Kafka broker information, namely {@code host:port}, and {@code broker id}.
 * 
 * @author <a href="mailto:cgreen@conductor.com">Casey Green</a>
 */
public class Broker implements Writable {

From source file com.conductor.kafka.hadoop.KafkaInputSplit.java

/**
 * An {@link InputSplit} that has a specific {@code start} and {@code end} offset in a Kafka queue {@link Partition}.
 * 
 * @see KafkaInputFormat
 * @see MultipleKafkaInputFormat
 * @see KafkaRecordReader

From source file com.conductor.kafka.Partition.java

/**
 * Wraps Kafka partition information, namely the hosting {@link Broker}, the {@code topic} and {@code partition id}.
 * 
 * @author <a href="mailto:cgreen@conductor.com">Casey Green</a>
 */
public class Partition implements Writable {

From source file com.couchbase.sqoop.mapreduce.db.CouchbaseInputSplit.java

/**
 * The CouchbaseInputSplit contains a set of VBuckets that an individual tap stream should connect to. There is one
 * input split per mapper.
 */
public class CouchbaseInputSplit extends InputSplit implements Writable {

From source file com.dasasian.chok.index.IndexMetaData.java

@Deprecated
public class IndexMetaData implements Writable {

    private static final long serialVersionUID = 1L;

    private Text _path = new Text();

From source file com.dasasian.chok.lucene.DocumentFrequencyWritable.java

public class DocumentFrequencyWritable implements Writable {
    private ReadWriteLock _frequenciesLock = new ReentrantReadWriteLock(true);
    private Map<TermWritable, Integer> _frequencies = new HashMap<>();

    private AtomicLong _numDocs = new AtomicLong();