Package | Description |
---|---|
org.apache.hadoop.hbase.codec | |
org.apache.hadoop.hbase.io | |
org.apache.hadoop.hbase.io.encoding | |
org.apache.hadoop.hbase.io.hfile |
Provides implementations of
HFile and HFile
BlockCache . |
org.apache.hadoop.hbase.io.hfile.bucket |
Provides
BucketCache , an implementation of
BlockCache . |
org.apache.hadoop.hbase.io.util | |
org.apache.hadoop.hbase.ipc |
Tools to help define network clients and servers.
|
org.apache.hadoop.hbase.nio | |
org.apache.hadoop.hbase.regionserver.wal | |
org.apache.hadoop.hbase.util |
Modifier and Type | Field and Description |
---|---|
protected ByteBuff |
KeyValueCodec.ByteBuffKeyValueDecoder.buf |
Modifier and Type | Method and Description |
---|---|
Codec.Decoder |
KeyValueCodecWithTags.getDecoder(ByteBuff buf) |
Codec.Decoder |
CellCodec.getDecoder(ByteBuff buf) |
Codec.Decoder |
KeyValueCodec.getDecoder(ByteBuff buf) |
Codec.Decoder |
Codec.getDecoder(ByteBuff buf) |
Codec.Decoder |
CellCodecWithTags.getDecoder(ByteBuff buf) |
Codec.Decoder |
MessageCodec.getDecoder(ByteBuff buf) |
Constructor and Description |
---|
ByteBuffKeyValueDecoder(ByteBuff buf) |
ByteBuffKeyValueDecoder(ByteBuff buf) |
Modifier and Type | Field and Description |
---|---|
private ByteBuff |
ByteBuffInputStream.buf |
Modifier and Type | Method and Description |
---|---|
int |
TagCompressionContext.uncompressTags(ByteBuff src,
byte[] dest,
int offset,
int length)
Uncompress tags from the input ByteBuffer and writes to the destination array.
|
Constructor and Description |
---|
ByteBuffInputStream(ByteBuff buf) |
Modifier and Type | Field and Description |
---|---|
private ByteBuff |
RowIndexSeekerV1.currentBuffer |
protected ByteBuff |
RowIndexSeekerV1.SeekerState.currentBuffer |
protected ByteBuff |
BufferedDataBlockEncoder.SeekerState.currentBuffer |
protected ByteBuff |
BufferedDataBlockEncoder.BufferedEncodedSeeker.currentBuffer |
private ByteBuff |
RowIndexSeekerV1.rowOffsets |
Modifier and Type | Method and Description |
---|---|
Cell |
FastDiffDeltaEncoder.getFirstKeyCellInBlock(ByteBuff block) |
Cell |
DataBlockEncoder.getFirstKeyCellInBlock(ByteBuff block)
Return first key in block as a cell.
|
Cell |
RowIndexCodecV1.getFirstKeyCellInBlock(ByteBuff block) |
Cell |
PrefixKeyDeltaEncoder.getFirstKeyCellInBlock(ByteBuff block) |
Cell |
CopyKeyDataBlockEncoder.getFirstKeyCellInBlock(ByteBuff block) |
Cell |
DiffKeyDeltaEncoder.getFirstKeyCellInBlock(ByteBuff block) |
void |
HFileBlockDecodingContext.prepareDecoding(int onDiskSizeWithoutHeader,
int uncompressedSizeWithoutHeader,
ByteBuff blockBufferWithoutHeader,
ByteBuff onDiskBlock)
Perform all actions that need to be done before the encoder's real decoding
process.
|
void |
HFileBlockDefaultDecodingContext.prepareDecoding(int onDiskSizeWithoutHeader,
int uncompressedSizeWithoutHeader,
ByteBuff blockBufferWithoutHeader,
ByteBuff onDiskBlock) |
void |
DataBlockEncoder.EncodedSeeker.setCurrentBuffer(ByteBuff buffer)
Set on which buffer there will be done seeking.
|
void |
RowIndexSeekerV1.setCurrentBuffer(ByteBuff buffer) |
void |
BufferedDataBlockEncoder.BufferedEncodedSeeker.setCurrentBuffer(ByteBuff buffer) |
Modifier and Type | Field and Description |
---|---|
private ByteBuff |
HFileReaderImpl.HFileScannerImpl.blockBuffer |
private ByteBuff |
HFileBlock.buf
The in-memory representation of the hfile block.
|
Modifier and Type | Method and Description |
---|---|
ByteBuff |
HFileBlock.getBufferReadOnly()
Returns a read-only duplicate of the buffer this block stores internally ready to be read.
|
ByteBuff |
HFileBlock.getBufferWithoutHeader()
Returns a buffer that does not include the header or checksum.
|
private ByteBuff |
HFileReaderImpl.EncodedScanner.getEncodedBuffer(HFileBlock newBlock) |
Modifier and Type | Method and Description |
---|---|
(package private) static int |
HFileBlockIndex.BlockIndexReader.binarySearchNonRootIndex(Cell key,
ByteBuff nonRootIndex,
CellComparator comparator)
Performs a binary search over a non-root level index block.
|
boolean |
CompoundBloomFilter.contains(byte[] key,
int keyOffset,
int keyLength,
ByteBuff bloom) |
boolean |
CompoundBloomFilter.contains(Cell keyCell,
ByteBuff bloom,
BloomType type) |
T |
CacheableDeserializer.deserialize(ByteBuff b)
Returns the deserialized object.
|
T |
CacheableDeserializer.deserialize(ByteBuff b,
boolean reuse,
Cacheable.MemoryType memType) |
protected byte[] |
HFileBlockIndex.BlockIndexReader.getNonRootIndexedKey(ByteBuff nonRootIndex,
int i)
The indexed key at the ith position in the nonRootIndex.
|
(package private) static int |
HFileBlockIndex.BlockIndexReader.locateNonRootIndexEntry(ByteBuff nonRootBlock,
Cell key,
CellComparator comparator)
Search for one key using the secondary index in a non-root block.
|
static BlockType |
BlockType.read(ByteBuff buf) |
(package private) static String |
HFileBlock.toStringHeader(ByteBuff buf)
Convert the contents of the block header into a human readable string.
|
void |
BlockType.write(ByteBuff buf) |
Constructor and Description |
---|
HFileBlock(ByteBuff buf,
boolean usesHBaseChecksum,
Cacheable.MemoryType memType,
long offset,
int nextBlockOnDiskSize,
HFileContext fileContext)
Creates a block from an existing buffer starting with a header.
|
Modifier and Type | Method and Description |
---|---|
void |
FileIOEngine.write(ByteBuff srcBuffer,
long offset) |
void |
FileMmapEngine.write(ByteBuff srcBuffer,
long offset) |
void |
ByteBufferIOEngine.write(ByteBuff srcBuffer,
long offset) |
void |
IOEngine.write(ByteBuff srcBuffer,
long offset)
Transfers the data from the given MultiByteBuffer to IOEngine
|
Modifier and Type | Method and Description |
---|---|
static int |
StreamUtils.readRawVarint32(ByteBuff input) |
Modifier and Type | Field and Description |
---|---|
private ByteBuff |
ServerRpcConnection.ByteBuffByteInput.buf |
private ByteBuff |
SimpleServerRpcConnection.data |
Modifier and Type | Method and Description |
---|---|
private ByteBuff |
CellBlockBuilder.decompress(org.apache.hadoop.io.compress.CompressionCodec compressor,
ByteBuff compressedCellBlock) |
Modifier and Type | Method and Description |
---|---|
(package private) static Pair<ByteBuff,RpcServer.CallCleanup> |
RpcServer.allocateByteBuffToReadInto(ByteBufferPool pool,
int minSizeForPoolUse,
int reqLen)
This is extracted to a static method for better unit testing.
|
Modifier and Type | Method and Description |
---|---|
protected int |
SimpleServerRpcConnection.channelDataRead(ReadableByteChannel channel,
ByteBuff buf) |
CellScanner |
CellBlockBuilder.createCellScannerReusingBuffers(Codec codec,
org.apache.hadoop.io.compress.CompressionCodec compressor,
ByteBuff cellBlock) |
private ByteBuff |
CellBlockBuilder.decompress(org.apache.hadoop.io.compress.CompressionCodec compressor,
ByteBuff compressedCellBlock) |
(package private) void |
NettyServerRpcConnection.process(ByteBuff buf) |
private void |
ServerRpcConnection.processConnectionHeader(ByteBuff buf) |
void |
ServerRpcConnection.processOneRpc(ByteBuff buf) |
protected void |
ServerRpcConnection.processRequest(ByteBuff buf) |
void |
ServerRpcConnection.saslReadAndProcess(ByteBuff saslToken) |
Constructor and Description |
---|
ByteBuffByteInput(ByteBuff buf,
int offset,
int length) |
Modifier and Type | Class and Description |
---|---|
class |
MultiByteBuff
Provides a unified view of all the underlying ByteBuffers and will look as if a bigger
sequential buffer.
|
class |
SingleByteBuff
An implementation of ByteBuff where a single BB backs the BBI.
|
Modifier and Type | Method and Description |
---|---|
abstract ByteBuff |
ByteBuff.duplicate()
Returns an ByteBuff which is a duplicate version of this ByteBuff.
|
abstract ByteBuff |
ByteBuff.limit(int limit)
Marks the limit of this ByteBuff.
|
abstract ByteBuff |
ByteBuff.mark()
Marks the current position of the ByteBuff
|
abstract ByteBuff |
ByteBuff.moveBack(int len)
Jumps back the current position of this ByteBuff by specified length.
|
abstract ByteBuff |
ByteBuff.position(int position)
Sets this ByteBuff's position to the given value.
|
abstract ByteBuff |
ByteBuff.put(byte b)
Writes a byte to this ByteBuff at the current position and increments the position
|
abstract ByteBuff |
ByteBuff.put(byte[] src)
Copies from the given byte[] to this ByteBuff
|
abstract ByteBuff |
ByteBuff.put(byte[] src,
int offset,
int length)
Copies from the given byte[] to this ByteBuff
|
abstract ByteBuff |
ByteBuff.put(int index,
byte b)
Writes a byte to this ByteBuff at the given index
|
abstract ByteBuff |
ByteBuff.put(int offset,
ByteBuff src,
int srcOffset,
int length)
Copies the contents from the src ByteBuff to this ByteBuff.
|
abstract ByteBuff |
ByteBuff.putInt(int value)
Writes an int to this ByteBuff at its current position.
|
abstract ByteBuff |
ByteBuff.putLong(long value)
Writes a long to this ByteBuff at its current position.
|
abstract ByteBuff |
ByteBuff.reset()
Similar to
ByteBuffer .reset(), ensures that this ByteBuff
is reset back to last marked position. |
abstract ByteBuff |
ByteBuff.rewind()
Rewinds this ByteBuff and the position is set to 0
|
abstract ByteBuff |
ByteBuff.skip(int len)
Jumps the current position of this ByteBuff by specified length.
|
abstract ByteBuff |
ByteBuff.slice()
Returns an ByteBuff which is a sliced version of this ByteBuff.
|
Modifier and Type | Method and Description |
---|---|
static int |
ByteBuff.compareTo(ByteBuff buf1,
int o1,
int len1,
ByteBuff buf2,
int o2,
int len2)
Compares two ByteBuffs
|
private static ByteBuffer |
MultiByteBuff.getItemByteBuffer(ByteBuff buf,
int index) |
abstract ByteBuff |
ByteBuff.put(int offset,
ByteBuff src,
int srcOffset,
int length)
Copies the contents from the src ByteBuff to this ByteBuff.
|
SingleByteBuff |
SingleByteBuff.put(int offset,
ByteBuff src,
int srcOffset,
int length) |
MultiByteBuff |
MultiByteBuff.put(int offset,
ByteBuff src,
int srcOffset,
int length)
Copies from a src MBB to this MBB.
|
static int |
ByteBuff.readCompressedInt(ByteBuff buf)
Read integer from ByteBuff coded in 7 bits and increment position.
|
static long |
ByteBuff.readLong(ByteBuff in,
int fitInBytes)
Read long which was written to fitInBytes bytes and increment position.
|
static long |
ByteBuff.readVLong(ByteBuff in)
Similar to
WritableUtils.readVLong(java.io.DataInput) but reads from a
ByteBuff . |
static String |
ByteBuff.toStringBinary(ByteBuff b,
int off,
int len) |
static int |
ByteBuff.unsignedBinarySearch(ByteBuff a,
int fromIndex,
int toIndex,
byte key)
Search sorted array "a" for byte "key".
|
Modifier and Type | Method and Description |
---|---|
Codec.Decoder |
WALCellCodec.getDecoder(ByteBuff buf) |
Modifier and Type | Method and Description |
---|---|
ByteBuff |
ByteBufferArray.asSubByteBuff(long offset,
int len)
Creates a ByteBuff from a given array of ByteBuffers from the given offset to the
length specified.
|
Modifier and Type | Method and Description |
---|---|
(package private) static boolean |
BloomFilterUtil.checkBit(int pos,
ByteBuff bloomBuf,
int bloomOffset)
Check if bit at specified index is 1.
|
boolean |
BloomFilter.contains(byte[] buf,
int offset,
int length,
ByteBuff bloom)
Check if the specified key is contained in the bloom filter.
|
static boolean |
BloomFilterUtil.contains(byte[] buf,
int offset,
int length,
ByteBuff bloomBuf,
int bloomOffset,
int bloomSize,
Hash hash,
int hashCount) |
private static <T> boolean |
BloomFilterUtil.contains(ByteBuff bloomBuf,
int bloomOffset,
int bloomSize,
Hash hash,
int hashCount,
HashKey<T> hashKey) |
boolean |
BloomFilter.contains(Cell keyCell,
ByteBuff bloom,
BloomType type)
Check if the specified key is contained in the bloom filter.
|
static boolean |
BloomFilterUtil.contains(Cell cell,
ByteBuff bloomBuf,
int bloomOffset,
int bloomSize,
Hash hash,
int hashCount,
BloomType type) |
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.