| Package | Description | 
|---|---|
| org.apache.hadoop.hbase | |
| org.apache.hadoop.hbase.client | 
 Provides HBase Client 
 | 
| org.apache.hadoop.hbase.coprocessor | 
 Table of Contents 
 | 
| org.apache.hadoop.hbase.mapred | 
 Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods. 
 | 
| org.apache.hadoop.hbase.mapreduce | 
 Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods. 
 | 
| org.apache.hadoop.hbase.mapreduce.replication | |
| org.apache.hadoop.hbase.protobuf | 
 Holds classes generated from protobuf
 
src/main/protobuf definition files. | 
| org.apache.hadoop.hbase.quotas | |
| org.apache.hadoop.hbase.regionserver | |
| org.apache.hadoop.hbase.rest.client | |
| org.apache.hadoop.hbase.security.access | |
| org.apache.hadoop.hbase.security.visibility | |
| org.apache.hadoop.hbase.thrift | 
 Provides an HBase Thrift
service. 
 | 
| org.apache.hadoop.hbase.thrift2 | 
 Provides an HBase Thrift
service. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
static Result | 
MetaTableAccessor.getRegionResult(Connection connection,
               byte[] regionName)
Gets the result in hbase:meta for the specified region. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
static List<Result> | 
MetaTableAccessor.fullScan(Connection connection)
Performs a full scan of  
hbase:meta. | 
static List<Result> | 
MetaTableAccessor.fullScanOfMeta(Connection connection)
Performs a full scan of a  
hbase:meta table. | 
static NavigableMap<HRegionInfo,Result> | 
MetaTableAccessor.getServerUserRegions(Connection connection,
                    ServerName serverName)  | 
| Modifier and Type | Method and Description | 
|---|---|
static PairOfSameType<HRegionInfo> | 
HRegionInfo.getDaughterRegions(Result data)
Deprecated. 
 
use MetaTableAccessor methods for interacting with meta layouts 
 | 
static PairOfSameType<HRegionInfo> | 
MetaTableAccessor.getDaughterRegions(Result data)
Returns the daughter regions by reading the corresponding columns of the catalog table
 Result. 
 | 
static HRegionInfo | 
HRegionInfo.getHRegionInfo(Result data)
Deprecated. 
 
use MetaTableAccessor methods for interacting with meta layouts 
 | 
static HRegionInfo | 
MetaTableAccessor.getHRegionInfo(Result data)
Returns HRegionInfo object from the column
 HConstants.CATALOG_FAMILY:HConstants.REGIONINFO_QUALIFIER of the catalog
 table Result. 
 | 
static HRegionInfo | 
HRegionInfo.getHRegionInfo(Result r,
              byte[] qualifier)
Deprecated. 
 
use MetaTableAccessor methods for interacting with meta layouts 
 | 
static Pair<HRegionInfo,ServerName> | 
HRegionInfo.getHRegionInfoAndServerName(Result r)
Deprecated. 
 
use MetaTableAccessor methods for interacting with meta layouts 
 | 
static PairOfSameType<HRegionInfo> | 
HRegionInfo.getMergeRegions(Result data)
Deprecated. 
 
use MetaTableAccessor methods for interacting with meta layouts 
 | 
static PairOfSameType<HRegionInfo> | 
MetaTableAccessor.getMergeRegions(Result data)
Returns the merge regions by reading the corresponding columns of the catalog table
 Result. 
 | 
static RegionLocations | 
MetaTableAccessor.getRegionLocations(Result r)
Returns an HRegionLocationList extracted from the result. 
 | 
static long | 
HRegionInfo.getSeqNumDuringOpen(Result r)
Deprecated. 
 
use MetaTableAccessor methods for interacting with meta layouts 
 | 
static ServerName | 
HRegionInfo.getServerName(Result r)
Deprecated. 
 
use MetaTableAccessor methods for interacting with meta layouts 
 | 
boolean | 
MetaTableAccessor.Visitor.visit(Result r)
Visit the catalog table row. 
 | 
| Modifier and Type | Field and Description | 
|---|---|
static Result | 
Result.EMPTY_RESULT  | 
protected Result | 
ClientScanner.lastResult  | 
| Modifier and Type | Field and Description | 
|---|---|
protected LinkedList<Result> | 
ClientScanner.cache  | 
| Modifier and Type | Method and Description | 
|---|---|
Result | 
HTableWrapper.append(Append append)  | 
Result | 
Table.append(Append append)
Appends values to one or more columns within a single row. 
 | 
Result | 
HTable.append(Append append)
Appends values to one or more columns within a single row. 
 | 
Result | 
RpcRetryingCallerWithReadReplicas.call(int operationTimeout)
 Algo:
 - we put the query into the execution pool. 
 | 
Result[] | 
ScannerCallable.call(int callTimeout)  | 
static Result | 
Result.create(Cell[] cells)
Instantiate a Result with the specified array of KeyValues. 
 | 
static Result | 
Result.create(Cell[] cells,
      Boolean exists,
      boolean stale)  | 
static Result | 
Result.create(Cell[] cells,
      Boolean exists,
      boolean stale,
      boolean mayHaveMoreCellsInRow)  | 
static Result | 
Result.create(List<Cell> cells)
Instantiate a Result with the specified List of KeyValues. 
 | 
static Result | 
Result.create(List<Cell> cells,
      Boolean exists)  | 
static Result | 
Result.create(List<Cell> cells,
      Boolean exists,
      boolean stale)  | 
static Result | 
Result.create(List<Cell> cells,
      Boolean exists,
      boolean stale,
      boolean partial)  | 
static Result | 
Result.createCompleteResult(Iterable<Result> partialResults)
Forms a single result from the partial results in the partialResults list. 
 | 
static Result | 
Result.createCompleteResult(List<Result> partialResults)
Deprecated.   
 | 
static Result | 
Result.createCursorResult(Cursor cursor)  | 
Result | 
HTableWrapper.get(Get get)  | 
Result | 
Table.get(Get get)
Extracts certain cells from a given row. 
 | 
Result | 
HTable.get(Get get)
Extracts certain cells from a given row. 
 | 
Result[] | 
HTableWrapper.get(List<Get> gets)  | 
Result[] | 
Table.get(List<Get> gets)
Extracts certain cells from the given rows, in batch. 
 | 
Result[] | 
HTable.get(List<Get> gets)
Extracts certain cells from the given rows, in batch. 
 | 
Result | 
HTableWrapper.getRowOrBefore(byte[] row,
              byte[] family)
Deprecated.  
 | 
Result | 
HTableInterface.getRowOrBefore(byte[] row,
              byte[] family)
Deprecated. 
 
As of version 0.92 this method is deprecated without
 replacement. Since version 0.96+, you can use reversed scan.
 getRowOrBefore is used internally to find entries in hbase:meta and makes
 various assumptions about the table (which are true for hbase:meta but not
 in general) to be efficient. 
 | 
Result | 
HTable.getRowOrBefore(byte[] row,
              byte[] family)
Deprecated. 
 
Use reversed scan instead. 
 | 
Result | 
HTableWrapper.increment(Increment increment)  | 
Result | 
Table.increment(Increment increment)
Increments one or more columns within a single row. 
 | 
Result | 
HTable.increment(Increment increment)
Increments one or more columns within a single row. 
 | 
Result | 
TableSnapshotScanner.next()  | 
Result | 
ClientSideRegionScanner.next()  | 
Result | 
ClientScanner.next()  | 
Result | 
ResultScanner.next()
Grab the next row's worth of values. 
 | 
Result[] | 
AbstractClientScanner.next(int nbRows)
Get nbRows rows. 
 | 
Result[] | 
ResultScanner.next(int nbRows)  | 
| Modifier and Type | Method and Description | 
|---|---|
Iterator<Result> | 
AbstractClientScanner.iterator()  | 
| Modifier and Type | Method and Description | 
|---|---|
protected void | 
BatchScanResultCache.checkUpdateNumberOfCompleteRowsAndCache(Result rs)  | 
static void | 
Result.compareResults(Result res1,
              Result res2)
Does a deep comparison of two Results, down to the byte arrays. 
 | 
void | 
Result.copyFrom(Result other)
Copy another Result into this one. 
 | 
static HRegionInfo | 
MetaScanner.getHRegionInfo(Result data)
Deprecated. 
 
 | 
static long | 
Result.getTotalSizeOfCells(Result result)
Get total size of raw cells 
 | 
void | 
BatchScanResultCache.loadResultsToCache(Result[] results,
                  boolean isHeartbeatMessage)  | 
boolean | 
MetaScanner.MetaScannerVisitor.processRow(Result rowResult)
Visitor method that accepts a RowResult and the meta region location. 
 | 
boolean | 
MetaScanner.DefaultMetaScannerVisitor.processRow(Result rowResult)  | 
boolean | 
MetaScanner.TableMetaScannerVisitor.processRow(Result rowResult)  | 
abstract boolean | 
MetaScanner.DefaultMetaScannerVisitor.processRowInternal(Result rowResult)  | 
protected void | 
ScannerCallable.updateResultsMetrics(Result[] rrs)  | 
| Modifier and Type | Method and Description | 
|---|---|
static Result | 
Result.createCompleteResult(Iterable<Result> partialResults)
Forms a single result from the partial results in the partialResults list. 
 | 
static Result | 
Result.createCompleteResult(List<Result> partialResults)
Deprecated.   
 | 
static ScanResultCache | 
ConnectionUtils.createScanResultCache(Scan scan,
                     List<Result> cache)  | 
| Constructor and Description | 
|---|
BatchScanResultCache(List<Result> cache,
                    int batch)  | 
| Modifier and Type | Method and Description | 
|---|---|
Result | 
BaseRegionObserver.postAppend(ObserverContext<RegionCoprocessorEnvironment> e,
          Append append,
          Result result)  | 
Result | 
RegionObserver.postAppend(ObserverContext<RegionCoprocessorEnvironment> c,
          Append append,
          Result result)
Called after Append 
 | 
void | 
BaseRegionObserver.postGetClosestRowBefore(ObserverContext<RegionCoprocessorEnvironment> e,
                       byte[] row,
                       byte[] family,
                       Result result)  | 
void | 
RegionObserver.postGetClosestRowBefore(ObserverContext<RegionCoprocessorEnvironment> c,
                       byte[] row,
                       byte[] family,
                       Result result)
Called after a client makes a GetClosestRowBefore request. 
 | 
Result | 
BaseRegionObserver.postIncrement(ObserverContext<RegionCoprocessorEnvironment> e,
             Increment increment,
             Result result)  | 
Result | 
RegionObserver.postIncrement(ObserverContext<RegionCoprocessorEnvironment> c,
             Increment increment,
             Result result)
Called after increment 
 | 
void | 
BaseRegionObserver.preGetClosestRowBefore(ObserverContext<RegionCoprocessorEnvironment> e,
                      byte[] row,
                      byte[] family,
                      Result result)  | 
void | 
RegionObserver.preGetClosestRowBefore(ObserverContext<RegionCoprocessorEnvironment> c,
                      byte[] row,
                      byte[] family,
                      Result result)
Called before a client makes a GetClosestRowBefore request. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
boolean | 
BaseRegionObserver.postScannerNext(ObserverContext<RegionCoprocessorEnvironment> e,
               InternalScanner s,
               List<Result> results,
               int limit,
               boolean hasMore)  | 
boolean | 
RegionObserver.postScannerNext(ObserverContext<RegionCoprocessorEnvironment> c,
               InternalScanner s,
               List<Result> result,
               int limit,
               boolean hasNext)
Called after the client asks for the next row on a scanner. 
 | 
boolean | 
BaseRegionObserver.preScannerNext(ObserverContext<RegionCoprocessorEnvironment> e,
              InternalScanner s,
              List<Result> results,
              int limit,
              boolean hasMore)  | 
boolean | 
RegionObserver.preScannerNext(ObserverContext<RegionCoprocessorEnvironment> c,
              InternalScanner s,
              List<Result> result,
              int limit,
              boolean hasNext)
Called before the client asks for the next row on a scanner. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
Result | 
TableRecordReader.createValue()  | 
Result | 
TableRecordReaderImpl.createValue()  | 
| Modifier and Type | Method and Description | 
|---|---|
org.apache.hadoop.mapred.RecordReader<ImmutableBytesWritable,Result> | 
TableSnapshotInputFormat.getRecordReader(org.apache.hadoop.mapred.InputSplit split,
               org.apache.hadoop.mapred.JobConf job,
               org.apache.hadoop.mapred.Reporter reporter)  | 
org.apache.hadoop.mapred.RecordReader<ImmutableBytesWritable,Result> | 
MultiTableSnapshotInputFormat.getRecordReader(org.apache.hadoop.mapred.InputSplit split,
               org.apache.hadoop.mapred.JobConf job,
               org.apache.hadoop.mapred.Reporter reporter)  | 
org.apache.hadoop.mapred.RecordReader<ImmutableBytesWritable,Result> | 
TableInputFormatBase.getRecordReader(org.apache.hadoop.mapred.InputSplit split,
               org.apache.hadoop.mapred.JobConf job,
               org.apache.hadoop.mapred.Reporter reporter)
Builds a TableRecordReader. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
protected byte[][] | 
GroupingTableMap.extractKeyValues(Result r)
Extract columns values from the current record. 
 | 
void | 
IdentityTableMap.map(ImmutableBytesWritable key,
   Result value,
   org.apache.hadoop.mapred.OutputCollector<ImmutableBytesWritable,Result> output,
   org.apache.hadoop.mapred.Reporter reporter)
Pass the key, value to reduce 
 | 
void | 
GroupingTableMap.map(ImmutableBytesWritable key,
   Result value,
   org.apache.hadoop.mapred.OutputCollector<ImmutableBytesWritable,Result> output,
   org.apache.hadoop.mapred.Reporter reporter)
Extract the grouping columns from value to construct a new key. 
 | 
boolean | 
TableRecordReader.next(ImmutableBytesWritable key,
    Result value)  | 
boolean | 
TableRecordReaderImpl.next(ImmutableBytesWritable key,
    Result value)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
IdentityTableMap.map(ImmutableBytesWritable key,
   Result value,
   org.apache.hadoop.mapred.OutputCollector<ImmutableBytesWritable,Result> output,
   org.apache.hadoop.mapred.Reporter reporter)
Pass the key, value to reduce 
 | 
void | 
GroupingTableMap.map(ImmutableBytesWritable key,
   Result value,
   org.apache.hadoop.mapred.OutputCollector<ImmutableBytesWritable,Result> output,
   org.apache.hadoop.mapred.Reporter reporter)
Extract the grouping columns from value to construct a new key. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
Result | 
TableRecordReader.getCurrentValue()
Returns the current value. 
 | 
Result | 
TableSnapshotInputFormatImpl.RecordReader.getCurrentValue()  | 
Result | 
TableRecordReaderImpl.getCurrentValue()
Returns the current value. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
org.apache.hadoop.mapreduce.RecordReader<ImmutableBytesWritable,Result> | 
TableSnapshotInputFormat.createRecordReader(org.apache.hadoop.mapreduce.InputSplit split,
                  org.apache.hadoop.mapreduce.TaskAttemptContext context)  | 
org.apache.hadoop.mapreduce.RecordReader<ImmutableBytesWritable,Result> | 
TableInputFormatBase.createRecordReader(org.apache.hadoop.mapreduce.InputSplit split,
                  org.apache.hadoop.mapreduce.TaskAttemptContext context)
Builds a  
TableRecordReader. | 
org.apache.hadoop.mapreduce.RecordReader<ImmutableBytesWritable,Result> | 
MultiTableInputFormatBase.createRecordReader(org.apache.hadoop.mapreduce.InputSplit split,
                  org.apache.hadoop.mapreduce.TaskAttemptContext context)
Builds a TableRecordReader. 
 | 
org.apache.hadoop.io.serializer.Deserializer<Result> | 
ResultSerialization.getDeserializer(Class<Result> c)  | 
static <K2,V2> Class<org.apache.hadoop.mapreduce.Mapper<ImmutableBytesWritable,Result,K2,V2>> | 
MultithreadedTableMapper.getMapperClass(org.apache.hadoop.mapreduce.JobContext job)
Get the application's mapper class. 
 | 
org.apache.hadoop.io.serializer.Serializer<Result> | 
ResultSerialization.getSerializer(Class<Result> c)  | 
| Modifier and Type | Method and Description | 
|---|---|
protected byte[][] | 
GroupingTableMapper.extractKeyValues(Result r)
Extract columns values from the current record. 
 | 
protected void | 
HashTable.HashMapper.map(ImmutableBytesWritable key,
   Result value,
   org.apache.hadoop.mapreduce.Mapper.Context context)  | 
void | 
Import.KeyValueImporter.map(ImmutableBytesWritable row,
   Result value,
   org.apache.hadoop.mapreduce.Mapper.Context context)  | 
protected void | 
SyncTable.SyncMapper.map(ImmutableBytesWritable key,
   Result value,
   org.apache.hadoop.mapreduce.Mapper.Context context)  | 
void | 
Import.Importer.map(ImmutableBytesWritable row,
   Result value,
   org.apache.hadoop.mapreduce.Mapper.Context context)  | 
protected void | 
IndexBuilder.Map.map(ImmutableBytesWritable rowKey,
   Result result,
   org.apache.hadoop.mapreduce.Mapper.Context context)  | 
void | 
GroupingTableMapper.map(ImmutableBytesWritable key,
   Result value,
   org.apache.hadoop.mapreduce.Mapper.Context context)
Extract the grouping columns from value to construct a new key. 
 | 
void | 
IdentityTableMapper.map(ImmutableBytesWritable key,
   Result value,
   org.apache.hadoop.mapreduce.Mapper.Context context)
Pass the key, value to reduce. 
 | 
void | 
Import.KeyValueSortImporter.map(ImmutableBytesWritable row,
   Result value,
   org.apache.hadoop.mapreduce.Mapper.Context context)  | 
protected void | 
Import.Importer.processKV(ImmutableBytesWritable key,
         Result result,
         org.apache.hadoop.mapreduce.Mapper.Context context,
         Put put,
         Delete delete)  | 
| Modifier and Type | Method and Description | 
|---|---|
org.apache.hadoop.io.serializer.Deserializer<Result> | 
ResultSerialization.getDeserializer(Class<Result> c)  | 
org.apache.hadoop.io.serializer.Serializer<Result> | 
ResultSerialization.getSerializer(Class<Result> c)  | 
static <K2,V2> void | 
MultithreadedTableMapper.setMapperClass(org.apache.hadoop.mapreduce.Job job,
              Class<? extends org.apache.hadoop.mapreduce.Mapper<ImmutableBytesWritable,Result,K2,V2>> cls)
Set the application's mapper class. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
VerifyReplication.Verifier.map(ImmutableBytesWritable row,
   Result value,
   org.apache.hadoop.mapreduce.Mapper.Context context)
Map method that compares every scanned row with the equivalent from
 a distant cluster. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
static Result[] | 
ResponseConverter.getResults(CellScanner cellScanner,
          org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse response)
Create Results from the cells using the cells meta data. 
 | 
static Result | 
ProtobufUtil.getRowOrBefore(org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService.BlockingInterface client,
              byte[] regionName,
              byte[] row,
              byte[] family)
Deprecated. 
 
since 0.99 - use reversed scanner instead. 
 | 
static Result | 
ProtobufUtil.toResult(org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result proto)
Convert a protocol buffer Result to a client Result 
 | 
static Result | 
ProtobufUtil.toResult(org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result proto,
        CellScanner scanner)
Convert a protocol buffer Result to a client Result 
 | 
| Modifier and Type | Method and Description | 
|---|---|
static org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result | 
ProtobufUtil.toResult(Result result)
Convert a client Result to a protocol buffer Result 
 | 
static org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result | 
ProtobufUtil.toResultNoData(Result result)
Convert a client Result to a protocol buffer Result. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
protected static Result | 
QuotaTableUtil.doGet(Connection connection,
     Get get)  | 
protected static Result[] | 
QuotaTableUtil.doGet(Connection connection,
     List<Get> gets)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
DefaultOperationQuota.addGetResult(Result result)  | 
void | 
OperationQuota.addGetResult(Result result)
Add a get result. 
 | 
static long | 
QuotaUtil.calculateResultSize(Result result)  | 
static void | 
QuotaTableUtil.parseNamespaceResult(Result result,
                    QuotaTableUtil.NamespaceQuotasVisitor visitor)  | 
protected static void | 
QuotaTableUtil.parseNamespaceResult(String namespace,
                    Result result,
                    QuotaTableUtil.NamespaceQuotasVisitor visitor)  | 
static void | 
QuotaTableUtil.parseResult(Result result,
           QuotaTableUtil.QuotasVisitor visitor)  | 
static void | 
QuotaTableUtil.parseTableResult(Result result,
                QuotaTableUtil.TableQuotasVisitor visitor)  | 
protected static void | 
QuotaTableUtil.parseTableResult(TableName table,
                Result result,
                QuotaTableUtil.TableQuotasVisitor visitor)  | 
static void | 
QuotaTableUtil.parseUserResult(Result result,
               QuotaTableUtil.UserQuotasVisitor visitor)  | 
protected static void | 
QuotaTableUtil.parseUserResult(String userName,
               Result result,
               QuotaTableUtil.UserQuotasVisitor visitor)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
DefaultOperationQuota.addScanResult(List<Result> results)  | 
void | 
OperationQuota.addScanResult(List<Result> results)
Add a scan result. 
 | 
static long | 
QuotaUtil.calculateResultSize(List<Result> results)  | 
| Modifier and Type | Method and Description | 
|---|---|
Result | 
HRegion.append(Append append)  | 
Result | 
HRegion.append(Append mutate,
      long nonceGroup,
      long nonce)  | 
Result | 
Region.append(Append append,
      long nonceGroup,
      long nonce)
Perform one or more append operations on a row. 
 | 
Result | 
HRegion.get(Get get)  | 
Result | 
Region.get(Get get)
Do a get based on the get parameter. 
 | 
Result | 
HRegion.getClosestRowBefore(byte[] row,
                   byte[] family)  | 
Result | 
Region.getClosestRowBefore(byte[] row,
                   byte[] family)
Return all the data for the row that matches row exactly,
 or the one that immediately preceeds it, at or immediately before
 ts. 
 | 
Result | 
HRegion.increment(Increment increment)  | 
Result | 
HRegion.increment(Increment mutation,
         long nonceGroup,
         long nonce)  | 
Result | 
Region.increment(Increment increment,
         long nonceGroup,
         long nonce)
Perform one or more increment operations on a row. 
 | 
Result | 
RegionCoprocessorHost.postAppend(Append append,
          Result result)  | 
Result | 
RegionCoprocessorHost.postIncrement(Increment increment,
             Result result)  | 
Result | 
RegionCoprocessorHost.preAppend(Append append)  | 
Result | 
RegionCoprocessorHost.preAppendAfterRowLock(Append append)  | 
Result | 
RegionCoprocessorHost.preIncrement(Increment increment)  | 
Result | 
RegionCoprocessorHost.preIncrementAfterRowLock(Increment increment)  | 
| Modifier and Type | Method and Description | 
|---|---|
Result | 
RegionCoprocessorHost.postAppend(Append append,
          Result result)  | 
void | 
RegionCoprocessorHost.postGetClosestRowBefore(byte[] row,
                       byte[] family,
                       Result result)  | 
Result | 
RegionCoprocessorHost.postIncrement(Increment increment,
             Result result)  | 
boolean | 
RegionCoprocessorHost.preGetClosestRowBefore(byte[] row,
                      byte[] family,
                      Result result)  | 
| Modifier and Type | Method and Description | 
|---|---|
boolean | 
RegionCoprocessorHost.postScannerNext(InternalScanner s,
               List<Result> results,
               int limit,
               boolean hasMore)  | 
Boolean | 
RegionCoprocessorHost.preScannerNext(InternalScanner s,
              List<Result> results,
              int limit)  | 
| Modifier and Type | Method and Description | 
|---|---|
Result | 
RemoteHTable.append(Append append)  | 
protected Result[] | 
RemoteHTable.buildResultFromModel(CellSetModel model)  | 
Result | 
RemoteHTable.get(Get get)  | 
Result[] | 
RemoteHTable.get(List<Get> gets)  | 
Result | 
RemoteHTable.getRowOrBefore(byte[] row,
              byte[] family)  | 
Result | 
RemoteHTable.increment(Increment increment)  | 
| Modifier and Type | Method and Description | 
|---|---|
Result | 
AccessController.preAppend(ObserverContext<RegionCoprocessorEnvironment> c,
         Append append)  | 
Result | 
AccessController.preAppendAfterRowLock(ObserverContext<RegionCoprocessorEnvironment> c,
                     Append append)  | 
Result | 
AccessController.preIncrement(ObserverContext<RegionCoprocessorEnvironment> c,
            Increment increment)  | 
Result | 
AccessController.preIncrementAfterRowLock(ObserverContext<RegionCoprocessorEnvironment> c,
                        Increment increment)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
AccessController.preGetClosestRowBefore(ObserverContext<RegionCoprocessorEnvironment> c,
                      byte[] row,
                      byte[] family,
                      Result result)  | 
| Modifier and Type | Method and Description | 
|---|---|
boolean | 
AccessController.preScannerNext(ObserverContext<RegionCoprocessorEnvironment> c,
              InternalScanner s,
              List<Result> result,
              int limit,
              boolean hasNext)  | 
| Modifier and Type | Method and Description | 
|---|---|
Result | 
VisibilityController.preAppend(ObserverContext<RegionCoprocessorEnvironment> e,
         Append append)  | 
Result | 
VisibilityController.preIncrement(ObserverContext<RegionCoprocessorEnvironment> e,
            Increment increment)  | 
| Modifier and Type | Method and Description | 
|---|---|
boolean | 
VisibilityController.preScannerNext(ObserverContext<RegionCoprocessorEnvironment> c,
              InternalScanner s,
              List<Result> result,
              int limit,
              boolean hasNext)  | 
| Modifier and Type | Method and Description | 
|---|---|
static List<TRowResult> | 
ThriftUtilities.rowResultFromHBase(Result in)  | 
static List<TRowResult> | 
ThriftUtilities.rowResultFromHBase(Result[] in)
This utility method creates a list of Thrift TRowResult "struct" based on
 an array of Hbase RowResult objects. 
 | 
static List<TRowResult> | 
ThriftUtilities.rowResultFromHBase(Result[] in,
                  boolean sortColumns)
This utility method creates a list of Thrift TRowResult "struct" based on
 an Hbase RowResult object. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
static TResult | 
ThriftUtilities.resultFromHBase(Result in)
 | 
static List<TResult> | 
ThriftUtilities.resultsFromHBase(Result[] in)
 | 
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.