Uses of Class
org.apache.hadoop.hbase.io.hfile.HFileBlock
Packages that use org.apache.hadoop.hbase.io.hfile.HFileBlock
Package
Description
Provides implementations of
HFile and HFile
BlockCache.-
Uses of org.apache.hadoop.hbase.io.hfile.HFileBlock in org.apache.hadoop.hbase.io.hfile
Subclasses of org.apache.hadoop.hbase.io.hfile.HFileBlock in in org.apache.hadoop.hbase.io.hfileModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.io.hfile.ExclusiveMemHFileBlockTheByteBuffAllocatorwon't allocate pooled heapByteBuffnow; at the same time, if allocate an off-heapByteBufffrom allocator, then it must be a pooled one.classorg.apache.hadoop.hbase.io.hfile.SharedMemHFileBlockTheByteBuffAllocatorwon't allocate pooled heapByteBuffnow; at the same time, if allocate an off-heapByteBufffrom allocator, then it must be a pooled one.Fields in org.apache.hadoop.hbase.io.hfile declared as org.apache.hadoop.hbase.io.hfile.HFileBlock in inModifier and TypeFieldDescriptionprotected org.apache.hadoop.hbase.io.hfile.HFileBlockHFileReaderImpl.HFileScannerImpl.curBlockFields in org.apache.hadoop.hbase.io.hfile with type parameters of type org.apache.hadoop.hbase.io.hfile.HFileBlock in inModifier and TypeFieldDescriptionprotected final ArrayList<org.apache.hadoop.hbase.io.hfile.HFileBlock>HFileReaderImpl.HFileScannerImpl.prevBlocksMethods in org.apache.hadoop.hbase.io.hfile that return org.apache.hadoop.hbase.io.hfile.HFileBlock in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.io.hfile.HFileBlockHFileBlockBuilder.build()org.apache.hadoop.hbase.io.hfile.HFileBlockHFileBlock.BlockDeserializer.deserialize(org.apache.hadoop.hbase.nio.ByteBuff buf, org.apache.hadoop.hbase.io.ByteBuffAllocator alloc) static org.apache.hadoop.hbase.io.hfile.HFileBlockBlockCacheUtil.getBlockForCaching(org.apache.hadoop.hbase.io.hfile.CacheConfig cacheConf, org.apache.hadoop.hbase.io.hfile.HFileBlock block) Similarly to HFileBlock.Writer.getBlockForCaching(), creates a HFileBlock instance without checksum for caching.org.apache.hadoop.hbase.io.hfile.HFileBlockCompoundBloomFilter.getBloomBlock(int block) org.apache.hadoop.hbase.io.hfile.HFileBlockHFileReaderImpl.getCachedBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey cacheKey, boolean cacheBlock, boolean useLock, boolean updateCacheMetrics, org.apache.hadoop.hbase.io.hfile.BlockType expectedBlockType, org.apache.hadoop.hbase.io.encoding.DataBlockEncoding expectedDataBlockEncoding) Retrieve block from cache.org.apache.hadoop.hbase.io.hfile.HFileBlockHFileReaderImpl.HFileScannerImpl.getCurBlock()org.apache.hadoop.hbase.io.hfile.HFileBlockBlockWithScanInfo.getHFileBlock()org.apache.hadoop.hbase.io.hfile.HFileBlockHFile.Reader.getMetaBlock(String metaBlockName, boolean cacheBlock) org.apache.hadoop.hbase.io.hfile.HFileBlockHFileReaderImpl.getMetaBlock(String metaBlockName, boolean cacheBlock) org.apache.hadoop.hbase.io.hfile.HFileBlockHFileBlock.BlockIterator.nextBlock()Get the next block, or null if there are no more blocks to iterate.org.apache.hadoop.hbase.io.hfile.HFileBlockHFileBlock.BlockIterator.nextBlockWithBlockType(org.apache.hadoop.hbase.io.hfile.BlockType blockType) Similar toHFileBlock.BlockIterator.nextBlock()but checks block type, throws an exception if incorrect, and returns the HFile blockorg.apache.hadoop.hbase.io.hfile.HFileBlockHFile.CachingBlockReader.readBlock(long offset, long onDiskBlockSize, boolean cacheBlock, boolean pread, boolean isCompaction, boolean updateCacheMetrics, org.apache.hadoop.hbase.io.hfile.BlockType expectedBlockType, org.apache.hadoop.hbase.io.encoding.DataBlockEncoding expectedDataBlockEncoding) Read in a file block.org.apache.hadoop.hbase.io.hfile.HFileBlockHFile.CachingBlockReader.readBlock(long offset, long onDiskBlockSize, boolean cacheBlock, boolean pread, boolean isCompaction, boolean updateCacheMetrics, org.apache.hadoop.hbase.io.hfile.BlockType expectedBlockType, org.apache.hadoop.hbase.io.encoding.DataBlockEncoding expectedDataBlockEncoding, boolean cacheOnly) org.apache.hadoop.hbase.io.hfile.HFileBlockHFileReaderImpl.readBlock(long dataBlockOffset, long onDiskBlockSize, boolean cacheBlock, boolean pread, boolean isCompaction, boolean updateCacheMetrics, org.apache.hadoop.hbase.io.hfile.BlockType expectedBlockType, org.apache.hadoop.hbase.io.encoding.DataBlockEncoding expectedDataBlockEncoding) org.apache.hadoop.hbase.io.hfile.HFileBlockHFileReaderImpl.readBlock(long dataBlockOffset, long onDiskBlockSize, boolean cacheBlock, boolean pread, boolean isCompaction, boolean updateCacheMetrics, org.apache.hadoop.hbase.io.hfile.BlockType expectedBlockType, org.apache.hadoop.hbase.io.encoding.DataBlockEncoding expectedDataBlockEncoding, boolean cacheOnly) org.apache.hadoop.hbase.io.hfile.HFileBlockHFileBlock.FSReader.readBlockData(long offset, long onDiskSize, boolean pread, boolean updateMetrics, boolean intoHeap) Reads the block at the given offset in the file with the given on-disk size and uncompressed size.protected org.apache.hadoop.hbase.io.hfile.HFileBlockHFileReaderImpl.HFileScannerImpl.readNextDataBlock()Scans blocks in the "scanned" section of theHFileuntil the next data block is found.org.apache.hadoop.hbase.io.hfile.HFileBlockHFileBlock.retain()org.apache.hadoop.hbase.io.hfile.HFileBlockHFileBlockIndex.BlockIndexReader.seekToDataBlock(org.apache.hadoop.hbase.ExtendedCell key, org.apache.hadoop.hbase.io.hfile.HFileBlock currentBlock, boolean cacheBlocks, boolean pread, boolean isCompaction, org.apache.hadoop.hbase.io.encoding.DataBlockEncoding expectedDataBlockEncoding, org.apache.hadoop.hbase.io.hfile.HFile.CachingBlockReader cachingBlockReader) Return the data block which contains this key.org.apache.hadoop.hbase.io.hfile.HFileBlockHFileBlock.touch()Calling this method in strategic locations where HFileBlocks are referenced may help diagnose potential buffer leaks.org.apache.hadoop.hbase.io.hfile.HFileBlockHFileBlock.touch(Object hint) org.apache.hadoop.hbase.io.hfile.HFileBlockHFileBlock.unpack(org.apache.hadoop.hbase.io.hfile.HFileContext fileContext, org.apache.hadoop.hbase.io.hfile.HFileBlock.FSReader reader) Retrieves the decompressed/decrypted view of this block.Methods in org.apache.hadoop.hbase.io.hfile that return types with arguments of type org.apache.hadoop.hbase.io.hfile.HFileBlock in inModifier and TypeMethodDescriptionList<org.apache.hadoop.hbase.io.hfile.HFileBlock>HFileInfo.getLoadOnOpenBlocks()Methods in org.apache.hadoop.hbase.io.hfile with parameters of type org.apache.hadoop.hbase.io.hfile.HFileBlock in inModifier and TypeMethodDescriptionBlockCache.blockFitsIntoTheCache(org.apache.hadoop.hbase.io.hfile.HFileBlock block) Checks whether there's enough space left in the cache to accommodate the passed block.CombinedBlockCache.blockFitsIntoTheCache(org.apache.hadoop.hbase.io.hfile.HFileBlock block) static org.apache.hadoop.hbase.io.hfile.HFileBlockBlockCacheUtil.getBlockForCaching(org.apache.hadoop.hbase.io.hfile.CacheConfig cacheConf, org.apache.hadoop.hbase.io.hfile.HFileBlock block) Similarly to HFileBlock.Writer.getBlockForCaching(), creates a HFileBlock instance without checksum for caching.protected org.apache.hadoop.hbase.ExtendedCellHFileReaderImpl.EncodedScanner.getFirstKeyCellInBlock(org.apache.hadoop.hbase.io.hfile.HFileBlock curBlock) protected org.apache.hadoop.hbase.ExtendedCellHFileReaderImpl.HFileScannerImpl.getFirstKeyCellInBlock(org.apache.hadoop.hbase.io.hfile.HFileBlock curBlock) voidHFileIndexBlockEncoder.EncodedSeeker.initRootIndex(org.apache.hadoop.hbase.io.hfile.HFileBlock blk, int numEntries, CellComparator comparator, int treeLevel) voidNoOpIndexBlockEncoder.NoOpEncodedSeeker.initRootIndex(org.apache.hadoop.hbase.io.hfile.HFileBlock blk, int numEntries, CellComparator comparator, int treeLevel) protected intHFileReaderImpl.EncodedScanner.loadBlockAndSeekToKey(org.apache.hadoop.hbase.io.hfile.HFileBlock seekToBlock, org.apache.hadoop.hbase.ExtendedCell nextIndexedKey, boolean rewind, org.apache.hadoop.hbase.ExtendedCell key, boolean seekBefore) protected intHFileReaderImpl.HFileScannerImpl.loadBlockAndSeekToKey(org.apache.hadoop.hbase.io.hfile.HFileBlock seekToBlock, org.apache.hadoop.hbase.ExtendedCell nextIndexedKey, boolean rewind, org.apache.hadoop.hbase.ExtendedCell key, boolean seekBefore) abstract org.apache.hadoop.hbase.io.hfile.BlockWithScanInfoHFileBlockIndex.BlockIndexReader.loadDataBlockWithScanInfo(org.apache.hadoop.hbase.ExtendedCell key, org.apache.hadoop.hbase.io.hfile.HFileBlock currentBlock, boolean cacheBlocks, boolean pread, boolean isCompaction, org.apache.hadoop.hbase.io.encoding.DataBlockEncoding expectedDataBlockEncoding, org.apache.hadoop.hbase.io.hfile.HFile.CachingBlockReader cachingBlockReader) Return the BlockWithScanInfo, a data structure which contains the Data HFileBlock with other scan info such as the key that starts the next HFileBlock.org.apache.hadoop.hbase.io.hfile.BlockWithScanInfoHFileIndexBlockEncoder.EncodedSeeker.loadDataBlockWithScanInfo(org.apache.hadoop.hbase.ExtendedCell key, org.apache.hadoop.hbase.io.hfile.HFileBlock currentBlock, boolean cacheBlocks, boolean pread, boolean isCompaction, org.apache.hadoop.hbase.io.encoding.DataBlockEncoding expectedDataBlockEncoding, org.apache.hadoop.hbase.io.hfile.HFile.CachingBlockReader cachingBlockReader) org.apache.hadoop.hbase.io.hfile.BlockWithScanInfoNoOpIndexBlockEncoder.NoOpEncodedSeeker.loadDataBlockWithScanInfo(org.apache.hadoop.hbase.ExtendedCell key, org.apache.hadoop.hbase.io.hfile.HFileBlock currentBlock, boolean cacheBlocks, boolean pread, boolean isCompaction, org.apache.hadoop.hbase.io.encoding.DataBlockEncoding expectedDataBlockEncoding, org.apache.hadoop.hbase.io.hfile.HFile.CachingBlockReader cachingBlockReader) voidHFileBlockIndex.BlockIndexReader.readMultiLevelIndexRoot(org.apache.hadoop.hbase.io.hfile.HFileBlock blk, int numEntries) Read the root-level metadata of a multi-level block index.HFileBlockIndex.BlockIndexReader.readRootIndex(org.apache.hadoop.hbase.io.hfile.HFileBlock blk, int numEntries) Read in the root-level index from the given input stream.protected voidHFileReaderImpl.HFileScannerImpl.releaseIfNotCurBlock(org.apache.hadoop.hbase.io.hfile.HFileBlock block) The curBlock will be released by shipping or close method, so only need to consider releasing the block, which was read from HFile before and not referenced by curBlock.org.apache.hadoop.hbase.io.hfile.HFileBlockHFileBlockIndex.BlockIndexReader.seekToDataBlock(org.apache.hadoop.hbase.ExtendedCell key, org.apache.hadoop.hbase.io.hfile.HFileBlock currentBlock, boolean cacheBlocks, boolean pread, boolean isCompaction, org.apache.hadoop.hbase.io.encoding.DataBlockEncoding expectedDataBlockEncoding, org.apache.hadoop.hbase.io.hfile.HFile.CachingBlockReader cachingBlockReader) Return the data block which contains this key.protected voidHFileReaderImpl.EncodedScanner.updateCurrentBlock(org.apache.hadoop.hbase.io.hfile.HFileBlock newBlock) Updates the current block to be the givenHFileBlock.protected voidHFileReaderImpl.HFileScannerImpl.updateCurrentBlock(org.apache.hadoop.hbase.io.hfile.HFileBlock newBlock) Updates the current block to be the givenHFileBlock.Constructors in org.apache.hadoop.hbase.io.hfile with parameters of type org.apache.hadoop.hbase.io.hfile.HFileBlock in inModifierConstructorDescriptionBlockWithScanInfo(org.apache.hadoop.hbase.io.hfile.HFileBlock hFileBlock, org.apache.hadoop.hbase.ExtendedCell nextIndexedKey)