org.apache.hadoop.hbase.hbql.impl
Class HResultSetImpl<T,R>

java.lang.Object
  extended by org.apache.hadoop.hbase.hbql.impl.HResultSetImpl<T,R>
All Implemented Interfaces:
Iterable<T>, HResultSet<T>
Direct Known Subclasses:
NonExecutorResultSet, ResultExecutorResultSet, ResultScannerExecutorResultSet

public abstract class HResultSetImpl<T,R>
extends Object
implements HResultSet<T>


Constructor Summary
protected HResultSetImpl(Query<T> query, CompletionQueueExecutor<R> completionQueueExecutor)
           
 
Method Summary
protected  void cleanUpAtEndOfIterator()
           
 void close()
           
protected  void closeResultScanner(org.apache.hadoop.hbase.client.ResultScanner scanner, boolean removeFromList)
           
protected  AggregateRecord getAggregateRecord()
           
protected  ExpressionTree getClientExpressionTree()
           
protected  CompletionQueueExecutor<R> getCompletionQueueExecutor()
           
protected  org.apache.hadoop.hbase.client.ResultScanner getCurrentResultScanner()
           
protected  HConnectionImpl getHConnectionImpl()
           
protected  MappingContext getMappingContext()
           
protected  int getMaxVersions()
           
protected  Query<T> getQuery()
           
protected  List<org.apache.hadoop.hbase.client.ResultScanner> getResultScannerList()
           
protected  long getReturnedRecordCount()
           
protected  long getReturnedRecordLimit()
           
protected  SelectStatement getSelectStmt()
           
protected  String getTableName()
           
protected  HTableWrapper getTableWrapper()
           
protected  WithArgs getWithArgs()
           
protected  void incrementRecordCount()
           
 boolean isClosed()
           
abstract  Iterator<T> iterator()
           
protected  boolean returnedRecordLimitMet()
           
protected  void setAggregateRecord(AggregateRecord aggregateRecord)
           
protected  void setCurrentResultScanner(org.apache.hadoop.hbase.client.ResultScanner currentResultScanner)
           
protected abstract  void submitWork(List<RowRequest> rowRequestList)
           
 
Methods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
 

Constructor Detail

HResultSetImpl

protected HResultSetImpl(Query<T> query,
                         CompletionQueueExecutor<R> completionQueueExecutor)
                  throws HBqlException
Throws:
HBqlException
Method Detail

submitWork

protected abstract void submitWork(List<RowRequest> rowRequestList)

iterator

public abstract Iterator<T> iterator()
Specified by:
iterator in interface Iterable<T>

cleanUpAtEndOfIterator

protected void cleanUpAtEndOfIterator()

getCompletionQueueExecutor

protected CompletionQueueExecutor<R> getCompletionQueueExecutor()

setAggregateRecord

protected void setAggregateRecord(AggregateRecord aggregateRecord)

getAggregateRecord

protected AggregateRecord getAggregateRecord()

getResultScannerList

protected List<org.apache.hadoop.hbase.client.ResultScanner> getResultScannerList()

getCurrentResultScanner

protected org.apache.hadoop.hbase.client.ResultScanner getCurrentResultScanner()

setCurrentResultScanner

protected void setCurrentResultScanner(org.apache.hadoop.hbase.client.ResultScanner currentResultScanner)

closeResultScanner

protected void closeResultScanner(org.apache.hadoop.hbase.client.ResultScanner scanner,
                                  boolean removeFromList)

isClosed

public boolean isClosed()

close

public void close()
Specified by:
close in interface HResultSet<T>

getReturnedRecordCount

protected long getReturnedRecordCount()

incrementRecordCount

protected void incrementRecordCount()

returnedRecordLimitMet

protected boolean returnedRecordLimitMet()

getReturnedRecordLimit

protected long getReturnedRecordLimit()

getMaxVersions

protected int getMaxVersions()
                      throws HBqlException
Throws:
HBqlException

getQuery

protected Query<T> getQuery()

getClientExpressionTree

protected ExpressionTree getClientExpressionTree()

getTableWrapper

protected HTableWrapper getTableWrapper()

getHConnectionImpl

protected HConnectionImpl getHConnectionImpl()

getSelectStmt

protected SelectStatement getSelectStmt()

getMappingContext

protected MappingContext getMappingContext()

getTableName

protected String getTableName()

getWithArgs

protected WithArgs getWithArgs()


Copyright © 2011. All Rights Reserved.