Package org.apache.hadoop.hbase.index.ValuePartition

Examples of org.apache.hadoop.hbase.index.ValuePartition.PartitionType


  }

  @Override
  public void readFields(DataInput in) throws IOException {
    super.readFields(in);
    PartitionType p = PartitionType.valueOf(in.readUTF());
    if (p.equals(PartitionType.SEPARATOR)) {
      valuePartition = new SeparatorPartition();
    } else if (p.equals(PartitionType.SPATIAL)) {
      valuePartition = new SpatialPartition();
    }
    if (valuePartition != null) {
      valuePartition.readFields(in);
    }
View Full Code Here


  public void readFields(DataInput in) throws IOException {
    this.cfBytes = Bytes.readByteArray(in);
    this.qualifierBytes = Bytes.readByteArray(in);
    this.type = ValueType.valueOf(Bytes.toString(Bytes.readByteArray(in)));
    this.maxValueLength = in.readInt();
    PartitionType p = PartitionType.valueOf(in.readUTF());
    if (p.equals(PartitionType.SEPARATOR)) {
      valuePartition = new SeparatorPartition();
    } else if (p.equals(PartitionType.SPATIAL)) {
      valuePartition = new SpatialPartition();
    }
    if (valuePartition != null) {
      valuePartition.readFields(in);
    }
View Full Code Here

TOP

Related Classes of org.apache.hadoop.hbase.index.ValuePartition.PartitionType

Copyright © 2018 www.massapicom. All rights reserved.
All source code are property of their respective owners. Java is a trademark of Sun Microsystems, Inc and owned by ORACLE Inc. Contact coftware#gmail.com.