| Package | Description | 
|---|---|
| org.apache.hadoop.hbase.codec.prefixtree | |
| org.apache.hadoop.hbase.coprocessor | Table of Contents | 
| org.apache.hadoop.hbase.io | |
| org.apache.hadoop.hbase.io.encoding | |
| org.apache.hadoop.hbase.io.hfile | Provides implementations of  HFileand HFileBlockCache. | 
| org.apache.hadoop.hbase.io.hfile.bucket | Provides  BucketCache, an implementation ofBlockCache. | 
| org.apache.hadoop.hbase.regionserver | |
| org.apache.hadoop.hbase.tmpl.regionserver | |
| org.apache.hadoop.hbase.util | |
| org.apache.hadoop.hbase.util.hbck | 
| Class and Description | 
|---|
| HFileContext This carries the information on some of the meta data about the HFile. | 
| Class and Description | 
|---|
| CacheConfig Stores all of the cache objects and configuration for a single HFile. | 
| Class and Description | 
|---|
| CacheConfig Stores all of the cache objects and configuration for a single HFile. | 
| HFileScanner A scanner allows you to position yourself within a HFile and
 scan through it. | 
| Class and Description | 
|---|
| BlockType Various types of HFile blocks. | 
| HFileContext This carries the information on some of the meta data about the HFile. | 
| Class and Description | 
|---|
| AbstractHFileReader Common functionality needed by all versions of  HFilereaders. | 
| AbstractHFileReader.Scanner | 
| AbstractHFileWriter Common functionality needed by all versions of  HFilewriters. | 
| AgeSnapshot Snapshot of block cache age in cache. | 
| BlockCache Block cache interface. | 
| BlockCacheKey Cache Key for use with implementations of  BlockCache | 
| BlockCacheUtil.CachedBlocksByFile Use one of these to keep a running account of cached blocks by file. | 
| BlockPriority | 
| BlockType Various types of HFile blocks. | 
| BlockType.BlockCategory | 
| BlockWithScanInfo BlockWithScanInfo is wrapper class for HFileBlock with other attributes. | 
| Cacheable Cacheable is an interface that allows for an object to be cached. | 
| CacheableDeserializer Interface for a deserializer. | 
| CacheConfig Stores all of the cache objects and configuration for a single HFile. | 
| CacheConfig.ExternalBlockCaches Enum of all built in external block caches. | 
| CachedBlock | 
| CacheStats Class that implements cache metrics. | 
| CombinedBlockCache CombinedBlockCache is an abstraction layer that combines
  LruBlockCacheandBucketCache. | 
| CombinedBlockCache.CombinedCacheStats | 
| CorruptHFileException This exception is thrown when attempts to read an HFile fail due to corruption or truncation
 issues. | 
| FixedFileTrailer The  HFilehas a fixed trailer which contains offsets to other
 variable parts of the file. | 
| HFile.CachingBlockReader An abstraction used by the block index. | 
| HFile.FileInfo Metadata for this file. | 
| HFile.Reader An interface used by clients to open and iterate an  HFile. | 
| HFile.Writer API required to write an  HFile | 
| HFile.WriterFactory This variety of ways to construct writers is used throughout the code, and
 we want to be able to swap writer implementations. | 
| HFileBlock Reading  HFileversion 1 and 2 blocks, and writing version 2 blocks. | 
| HFileBlock.AbstractFSReader A common implementation of some methods of  HFileBlock.FSReaderand some
 tools for implementing HFile format version-specific block readers. | 
| HFileBlock.BlockIterator An interface allowing to iterate  HFileBlocks. | 
| HFileBlock.BlockWritable Something that can be written into a block. | 
| HFileBlock.FSReader A full-fledged reader with iteration ability. | 
| HFileBlock.PrefetchedHeader We always prefetch the header of the next block, so that we know its
 on-disk size in advance and can read it in one operation. | 
| HFileBlock.Writer Unified version 2  HFileblock writer. | 
| HFileBlock.Writer.State | 
| HFileBlockIndex.BlockIndexChunk A single chunk of the block index in the process of writing. | 
| HFileBlockIndex.BlockIndexReader The reader will always hold the root level index in the memory. | 
| HFileBlockIndex.BlockIndexWriter Writes the block index into the output stream. | 
| HFileContext This carries the information on some of the meta data about the HFile. | 
| HFileContextBuilder A builder that helps in building up the HFileContext | 
| HFileDataBlockEncoder Controls what kind of data block encoding is used. | 
| HFilePrettyPrinter.KeyValueStatsCollector | 
| HFilePrettyPrinter.SimpleReporter | 
| HFileReaderV2 HFilereader for version 2. | 
| HFileReaderV2.AbstractScannerV2 | 
| HFileReaderV2.EncodedScannerV2 ScannerV2 that operates on encoded data blocks. | 
| HFileReaderV2.ScannerV2 Implementation of  HFileScannerinterface. | 
| HFileReaderV3 HFilereader for version 3. | 
| HFileScanner A scanner allows you to position yourself within a HFile and
 scan through it. | 
| HFileWriterV2 Writes HFile format version 2. | 
| InlineBlockWriter A way to write "inline" blocks into an  HFile. | 
| LruBlockCache A block cache implementation that is memory-aware using  HeapSize,
 memory-bound using an LRU eviction algorithm, and concurrent: backed by aConcurrentHashMapand with a non-blocking eviction thread giving
 constant-timeLruBlockCache.cacheBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey, org.apache.hadoop.hbase.io.hfile.Cacheable, boolean, boolean)andLruBlockCache.getBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey, boolean, boolean, boolean)operations. | 
| LruBlockCache.BlockBucket Used to group blocks into priority buckets. | 
| LruBlockCache.EvictionThread | 
| LruCachedBlock Represents an entry in the  LruBlockCache. | 
| LruCachedBlockQueue A memory-bound queue that will grow until an element brings
 total size >= maxSize. | 
| MemcachedBlockCache.HFileBlockTranscoder Class to encode and decode an HFileBlock to and from memecached's resulting byte arrays. | 
| NoOpDataBlockEncoder Does not perform any kind of encoding/decoding. | 
| ResizableBlockCache BlockCache which is resizable. | 
| Class and Description | 
|---|
| BlockCache Block cache interface. | 
| BlockCacheKey Cache Key for use with implementations of  BlockCache | 
| BlockPriority | 
| Cacheable Cacheable is an interface that allows for an object to be cached. | 
| CacheableDeserializer Interface for a deserializer. | 
| CachedBlock | 
| CacheStats Class that implements cache metrics. | 
| Class and Description | 
|---|
| BlockCache Block cache interface. | 
| BlockType Various types of HFile blocks. | 
| CacheConfig Stores all of the cache objects and configuration for a single HFile. | 
| CacheStats Class that implements cache metrics. | 
| HFile.Reader An interface used by clients to open and iterate an  HFile. | 
| HFile.Writer API required to write an  HFile | 
| HFileContext This carries the information on some of the meta data about the HFile. | 
| HFileDataBlockEncoder Controls what kind of data block encoding is used. | 
| HFileScanner A scanner allows you to position yourself within a HFile and
 scan through it. | 
| ResizableBlockCache BlockCache which is resizable. | 
| Class and Description | 
|---|
| BlockCache Block cache interface. | 
| BlockCacheUtil.CachedBlocksByFile Use one of these to keep a running account of cached blocks by file. | 
| CacheConfig Stores all of the cache objects and configuration for a single HFile. | 
| Class and Description | 
|---|
| BlockType Various types of HFile blocks. | 
| CacheConfig Stores all of the cache objects and configuration for a single HFile. | 
| HFile.Reader An interface used by clients to open and iterate an  HFile. | 
| HFile.Writer API required to write an  HFile | 
| HFileBlockIndex.BlockIndexReader The reader will always hold the root level index in the memory. | 
| HFileBlockIndex.BlockIndexWriter Writes the block index into the output stream. | 
| InlineBlockWriter A way to write "inline" blocks into an  HFile. | 
| Class and Description | 
|---|
| CacheConfig Stores all of the cache objects and configuration for a single HFile. | 
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.