| Package | Description | 
|---|---|
| org.apache.hadoop.hbase | |
| org.apache.hadoop.hbase.filter | Provides row-level filters applied to HRegion scan results during calls to
  ResultScanner.next(). | 
| org.apache.hadoop.hbase.io.encoding | |
| org.apache.hadoop.hbase.regionserver | |
| org.apache.hadoop.hbase.util | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ByteBufferKeyOnlyKeyValueThis is a key only Cell implementation which is identical to  KeyValue.KeyOnlyKeyValuewith respect to key serialization but have its data in the form of Byte buffer
 (onheap and offheap). | 
| class  | ByteBufferKeyValueThis Cell is an implementation of  ByteBufferExtendedCellwhere the data resides in
 off heap/ on heap ByteBuffer | 
| class  | NoTagsByteBufferKeyValueAn extension of the ByteBufferKeyValue where the tags length is always 0 | 
| private static class  | PrivateCellUtil.EmptyByteBufferExtendedCellThese cells are used in reseeks/seeks to improve the read performance. | 
| private static class  | PrivateCellUtil.FirstOnRowByteBufferExtendedCell | 
| private static class  | PrivateCellUtil.FirstOnRowColByteBufferExtendedCell | 
| private static class  | PrivateCellUtil.FirstOnRowColTSByteBufferExtendedCell | 
| private static class  | PrivateCellUtil.LastOnRowByteBufferExtendedCell | 
| private static class  | PrivateCellUtil.LastOnRowColByteBufferExtendedCell | 
| (package private) static class  | PrivateCellUtil.TagRewriteByteBufferExtendedCell | 
| (package private) static class  | PrivateCellUtil.ValueAndTagRewriteByteBufferExtendedCell | 
| class  | SizeCachedByteBufferKeyValueThis Cell is an implementation of  ByteBufferExtendedCellwhere the data resides in
 off heap/ on heap ByteBuffer | 
| class  | SizeCachedNoTagsByteBufferKeyValueThis Cell is an implementation of  ByteBufferExtendedCellwhere the data resides in
 off heap/ on heap ByteBuffer | 
| Modifier and Type | Field and Description | 
|---|---|
| protected ByteBufferExtendedCell | PrivateCellUtil.TagRewriteByteBufferExtendedCell. cell | 
| Modifier and Type | Method and Description | 
|---|---|
| private int | ByteBufferKeyValue. calculateHashForKey(ByteBufferExtendedCell cell) | 
| Constructor and Description | 
|---|
| TagRewriteByteBufferExtendedCell(ByteBufferExtendedCell cell,
                                byte[] tags) | 
| ValueAndTagRewriteByteBufferExtendedCell(ByteBufferExtendedCell cell,
                                        byte[] value,
                                        byte[] tags) | 
| Modifier and Type | Class and Description | 
|---|---|
| (package private) static class  | KeyOnlyFilter.KeyOnlyByteBufferExtendedCell | 
| Modifier and Type | Field and Description | 
|---|---|
| private ByteBufferExtendedCell | KeyOnlyFilter.KeyOnlyByteBufferExtendedCell. cell | 
| Constructor and Description | 
|---|
| KeyOnlyByteBufferExtendedCell(ByteBufferExtendedCell c,
                             boolean lenAsVal) | 
| Modifier and Type | Class and Description | 
|---|---|
| protected static class  | BufferedDataBlockEncoder.OffheapDecodedExtendedCell | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ByteBufferChunkKeyValueByteBuffer based cell which has the chunkid at the 0th offset | 
| class  | NoTagByteBufferChunkKeyValueByteBuffer based cell which has the chunkid at the 0th offset and with no tags | 
| Modifier and Type | Method and Description | 
|---|---|
| private Cell | MemStoreLABImpl. copyBBECellInto(ByteBufferExtendedCell cell,
               int maxAlloc)Mostly a duplicate of  MemStoreLABImpl.copyCellInto(Cell, int)} done for perf sake. | 
| private static Cell | MemStoreLABImpl. copyBBECToChunkCell(ByteBufferExtendedCell cell,
                   ByteBuffer buf,
                   int offset,
                   int len)Clone the passed cell by copying its data into the passed buf and create a cell with a chunkid
 out of it | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | MapReduceExtendedCellA wrapper for a cell to be used with mapreduce, as the output value class for mappers/reducers. | 
Copyright © 2007–2021 The Apache Software Foundation. All rights reserved.