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

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

Introduction

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

Usage

From source file com.cloudera.impala.hive.executor.ImpalaBigIntWritable.java

@SuppressWarnings("restriction")
public class ImpalaBigIntWritable extends LongWritable {
    // Ptr (to native heap) where the value should be read from and written to.
    private final long ptr_;

    public ImpalaBigIntWritable(long ptr) {

From source file com.ibm.bi.dml.runtime.instructions.spark.data.SerLongWritable.java

/**
 * Wrapper for LongWritable in order to make it serializable as required for
 * shuffle in spark instructions.
 * 
 */
public class SerLongWritable extends LongWritable implements Serializable {

From source file edu.uci.ics.biggraph.io.LongWritable.java

/** A WritableComparable for longs. */
public class LongWritable extends org.apache.hadoop.io.LongWritable implements WritableSizable {

    public LongWritable(long value) {
        super(value);
    }

From source file org.apache.impala.hive.executor.ImpalaBigIntWritable.java

@SuppressWarnings("restriction")
public class ImpalaBigIntWritable extends LongWritable {
    // Ptr (to native heap) where the value should be read from and written to.
    private final long ptr_;

    public ImpalaBigIntWritable(long ptr) {

From source file org.apache.mahout.classifier.df.mapreduce.partial.TreeID.java

/**
 * Indicates both the tree and the data partition used to grow the tree
 */
public class TreeID extends LongWritable implements Cloneable {

    public static final int MAX_TREEID = 100000;

From source file org.apache.mahout.classifier.KnnMR.mapreduce.partial.StrataID.java

/**
 * Indicates both the strata and the data partition used to grow the strata
 */
public class StrataID extends LongWritable implements Cloneable {

    public static final int MAX_TREEID = 100000;

From source file org.apache.mahout.df.mapreduce.partial.TreeID.java

/**
 * Indicates both the tree and the data partition used to grow the tree
 */
public class TreeID extends LongWritable implements Cloneable {

    public static final int MAX_TREEID = 100000;

From source file org.apache.sysml.runtime.instructions.spark.data.SerLongWritable.java

/**
 * Wrapper for LongWritable in order to make it serializable as required for
 * shuffle in spark instructions.
 * 
 */
public class SerLongWritable extends LongWritable implements Serializable {

From source file org.mrgeo.data.tile.TileIdWritable.java

public class TileIdWritable extends LongWritable implements Serializable {
    private static final long serialVersionUID = 1L;

    public TileIdWritable() {
        super();
    }