Package org.apache.hadoop.hbase.index

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


     // filter other than SingleColumnValueFilter.
    return filter;
  }

  private void handleScvfOfOR(SingleColumnValueFilter scvf) {
    ValuePartition vp = null;
    if (scvf instanceof SingleColumnValuePartitionFilter) {
      vp = ((SingleColumnValuePartitionFilter) scvf).getValuePartition();
    }
    Column key = new Column(scvf.getFamily(), scvf.getQualifier(), vp);
    if (colWithOperatorsOfOR.get(key) == null) {
View Full Code Here


      valueList.add(new Value(scvf.getOperator(), scvf.getComparator().getValue(), scvf));
    }
  }

  private void handleScvf(SingleColumnValueFilter scvf) {
    ValuePartition vp = null;
    if (scvf instanceof SingleColumnValuePartitionFilter) {
      vp = ((SingleColumnValuePartitionFilter) scvf).getValuePartition();
    }
    Column column = new Column(scvf.getFamily(), scvf.getQualifier(), vp);
    Pair<Value, Value> pair = colWithOperators.get(column);
View Full Code Here

  // filters or filter lists are there and all are combined using AND condition then it is same
  // as all within one list.
  // Default access for testability
  Filter doFiltersRestruct(Filter filter) {
    if (filter instanceof SingleColumnValueFilter) {
      ValuePartition vp = null;
      if (filter instanceof SingleColumnValuePartitionFilter) {
        vp = ((SingleColumnValuePartitionFilter) filter).getValuePartition();
      }
      SingleColumnValueFilter scvf = (SingleColumnValueFilter) filter;
      if (scvf.getOperator().equals(CompareOp.LESS)
View Full Code Here

    indexRowKey.put(value);
    indexRowKey.position(indexRowKey.position() + valuePadLength);
  }

  private static byte[] getValueFromKV(KeyValue kv, ColumnQualifier indexCQ) {
    ValuePartition vp = indexCQ.getValuePartition();
    byte value[] = null;
    if (vp != null) {
      value = vp.getPartOfValue(kv.getValue());
      if (value != null) {
        value = IndexUtils.changeValueAccToDataType(value, indexCQ.getType());
      }
    } else {
      LOG.trace("No offset or separator is mentioned. So just returning the value fetched from kv");
View Full Code Here

TOP

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

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.