Example usage for org.apache.hadoop.io MapWritable subclass-usage

List of usage examples for org.apache.hadoop.io MapWritable subclass-usage

Introduction

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

Usage

From source file main.okapi.common.data.MapWritable.java

/**
 * Extends the MapWritable from Hadoop and adds extra functionality.
 * @author dl
 *
 */
public class MapWritable extends org.apache.hadoop.io.MapWritable {

From source file ml.grafos.okapi.common.data.MapWritable.java

/**
 * Extends the MapWritable from Hadoop and adds extra functionality.
 * @author dl
 *
 */
public class MapWritable extends org.apache.hadoop.io.MapWritable {

From source file org.apache.giraph.examples.okapi.common.data.MapWritable.java

/**
 * Extends the MapWritable from Hadoop and adds extra functionality.
 */
public class MapWritable extends org.apache.hadoop.io.MapWritable {
    @Override
    public String toString() {

From source file org.apache.pig.piggybank.squeal.backend.storm.state.MapIdxWritable.java

public abstract class MapIdxWritable<T> extends MapWritable implements IPigIdxState<T> {

    public abstract List<Pair<List<NullableTuple>, List<NullableTuple>>> getTupleBatches(T last);

    public String toString() {
        return this.getClass().getSimpleName() + "@" + this.hashCode() + ": " + this.entrySet();

From source file org.elasticsearch.hadoop.mr.LinkedMapWritable.java

/**
 * Similar to {@link MapWritable} expect that it uses a {@link LinkedHashMap} underneath to preserve insertion order (and thus its structure). Extends {@link MapWritable} for compatibility reasons.
 */
public class LinkedMapWritable extends MapWritable {

    private Map<Writable, Writable> instance;

From source file org.rad.qa.core.QuoteAnalyzerOutput.java

public class QuoteAnalyzerOutput extends MapWritable {
    private String ticker;

    public QuoteAnalyzerOutput(String ticker) {
        this.ticker = ticker;
    }

From source file org.slc.sli.aggregation.mapreduce.map.key.EmittableKey.java

/**
 * EmittableKey
 * 
 * Abstract class that defines a single or multi-value identifier used as an emit key in a
 * map / reduce job. Classes that implement this interface are usable by the IDMapper class to
 * generate map/reduce keys.