Uses of Enum
org.apache.hadoop.hbase.io.hfile.BlockType
Package
Description
Provides implementations of
HFile
and HFile
BlockCache
.Provides
BucketCache
, an implementation of
BlockCache
.-
Uses of BlockType in org.apache.hadoop.hbase.io.encoding
Modifier and TypeMethodDescriptionHFileBlockDefaultEncodingContext.getBlockType()
HFileBlockEncodingContext.getBlockType()
Returns the block type after encodingModifier and TypeMethodDescriptionvoid
HFileBlockDefaultEncodingContext.postEncoding
(BlockType blockType) void
HFileBlockEncodingContext.postEncoding
(BlockType blockType) Do any action that needs to be performed after the encoding. -
Uses of BlockType in org.apache.hadoop.hbase.io.hfile
Modifier and TypeFieldDescriptionprivate BlockType
BlockCacheKey.blockType
private BlockType
HFileBlock.blockType
Type of block.private BlockType
HFileBlock.Writer.blockType
Current block type.private BlockType
HFileBlockBuilder.blockType
Modifier and TypeMethodDescriptionBlockCacheKey.getBlockType()
Cacheable.getBlockType()
Returns the block type of this cached HFile blockCachedBlock.getBlockType()
HFileBlock.BlockWritable.getBlockType()
The type of block this data should use.HFileBlock.getBlockType()
TinyLfuBlockCache.CachedBlockView.getBlockType()
CompoundBloomFilterWriter.getInlineBlockType()
HFileBlockIndex.BlockIndexWriter.getInlineBlockType()
InlineBlockWriter.getInlineBlockType()
The type of blocks this block writer produces.static BlockType
BlockType.parse
(byte[] buf, int offset, int length) static BlockType
BlockType.read
(DataInputStream in) static BlockType
static BlockType
Returns the enum constant of this type with the specified name.static BlockType[]
BlockType.values()
Returns an array containing the constants of this enum type, in the order they are declared.Modifier and TypeMethodDescriptionprivate void
HFileWriterImpl.addBloomFilter
(BloomFilterWriter bfw, BlockType blockType) void
HFileDataBlockEncoder.endBlockEncoding
(HFileBlockEncodingContext encodingCtx, DataOutputStream out, byte[] uncompressedBytesWithHeader, BlockType blockType) Ends encoding for a block of KeyValues.void
HFileDataBlockEncoderImpl.endBlockEncoding
(HFileBlockEncodingContext encodingCtx, DataOutputStream out, byte[] uncompressedBytesWithHeader, BlockType blockType) void
NoOpDataBlockEncoder.endBlockEncoding
(HFileBlockEncodingContext encodingCtx, DataOutputStream out, byte[] uncompressedBytesWithHeader, BlockType blockType) private DataInput
HFileReaderImpl.getBloomFilterMetadata
(BlockType blockType) private HFileBlock
HFileReaderImpl.getCachedBlock
(BlockCacheKey cacheKey, boolean cacheBlock, boolean useLock, boolean updateCacheMetrics, BlockType expectedBlockType, DataBlockEncoding expectedDataBlockEncoding) Retrieve block from cache.void
default boolean
BlockCache.isMetaBlock
(BlockType blockType) Check if block type is meta or index blockvoid
HFileBlock.BlockIterator.nextBlockWithBlockType
(BlockType blockType) Similar toHFileBlock.BlockIterator.nextBlock()
but checks block type, throws an exception if incorrect, and returns the HFile blockHFile.CachingBlockReader.readBlock
(long offset, long onDiskBlockSize, boolean cacheBlock, boolean pread, boolean isCompaction, boolean updateCacheMetrics, BlockType expectedBlockType, DataBlockEncoding expectedDataBlockEncoding) Read in a file block.HFile.CachingBlockReader.readBlock
(long offset, long onDiskBlockSize, boolean cacheBlock, boolean pread, boolean isCompaction, boolean updateCacheMetrics, BlockType expectedBlockType, DataBlockEncoding expectedDataBlockEncoding, boolean cacheOnly) HFileReaderImpl.readBlock
(long dataBlockOffset, long onDiskBlockSize, boolean cacheBlock, boolean pread, boolean isCompaction, boolean updateCacheMetrics, BlockType expectedBlockType, DataBlockEncoding expectedDataBlockEncoding) HFileReaderImpl.readBlock
(long dataBlockOffset, long onDiskBlockSize, boolean cacheBlock, boolean pread, boolean isCompaction, boolean updateCacheMetrics, BlockType expectedBlockType, DataBlockEncoding expectedDataBlockEncoding, boolean cacheOnly) private void
HFileBlock.sanityCheckAssertion
(BlockType valueFromBuf, BlockType valueFromField) void
BlockCacheKey.setBlockType
(BlockType blockType) boolean
CacheConfig.shouldLockOnCacheMiss
(BlockType blockType) If we make sure the block could not be cached, we will not acquire the lock otherwise we will acquire lockboolean
CacheConfig.shouldReadBlockFromCache
(BlockType blockType) Return true if we may find this type of block in block cache.private boolean
HFileReaderImpl.shouldUseHeap
(BlockType expectedBlockType, boolean cacheBlock) Whether we use heap or not depends on our intent to cache the block.(package private) DataOutputStream
HFileBlock.Writer.startWriting
(BlockType newBlockType) Starts writing into the block.private void
HFileReaderImpl.validateBlockType
(HFileBlock block, BlockType expectedBlockType) Compares the actual type of a block retrieved from cache or disk with its expected type and throws an exception in case of a mismatch.HFileBlockBuilder.withBlockType
(BlockType blockType) ModifierConstructorDescriptionBlockCacheKey
(String hfileName, long offset, boolean isPrimaryReplica, BlockType blockType) (package private)
ExclusiveMemHFileBlock
(BlockType blockType, int onDiskSizeWithoutHeader, int uncompressedSizeWithoutHeader, long prevBlockOffset, ByteBuff buf, boolean fillHeader, long offset, int nextBlockOnDiskSize, int onDiskDataSizeWithHeader, HFileContext fileContext, ByteBuffAllocator alloc) HFileBlock
(BlockType blockType, int onDiskSizeWithoutHeader, int uncompressedSizeWithoutHeader, long prevBlockOffset, ByteBuff buf, boolean fillHeader, long offset, int nextBlockOnDiskSize, int onDiskDataSizeWithHeader, HFileContext fileContext, ByteBuffAllocator allocator) Creates a newHFile
block from the given fields.(package private)
SharedMemHFileBlock
(BlockType blockType, int onDiskSizeWithoutHeader, int uncompressedSizeWithoutHeader, long prevBlockOffset, ByteBuff buf, boolean fillHeader, long offset, int nextBlockOnDiskSize, int onDiskDataSizeWithHeader, HFileContext fileContext, ByteBuffAllocator alloc) -
Uses of BlockType in org.apache.hadoop.hbase.io.hfile.bucket
-
Uses of BlockType in org.apache.hadoop.hbase.regionserver
Modifier and TypeMethodDescriptionvoid
StoreFileReader.loadBloomfilter
(BlockType blockType, BloomFilterMetrics metrics) (package private) void
StoreFileReader.setBloomFilterFaulty
(BlockType blockType)