| Package | Description |
|---|---|
| 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
HFile and HFile
BlockCache. |
| org.apache.hadoop.hbase.io.hfile.bucket |
Provides
BucketCache, an implementation of
BlockCache. |
| org.apache.hadoop.hbase.mapreduce |
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
|
| org.apache.hadoop.hbase.mob | |
| org.apache.hadoop.hbase.mob.compactions | |
| 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 |
|---|
| 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 |
|---|
| AgeSnapshot
Snapshot of block cache age in cache.
|
| BlockCache
Block cache interface.
|
| BlockCacheFactory.ExternalBlockCaches
Enum of all built in external block caches.
|
| 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.
|
| Cacheable.MemoryType
SHARED means when this Cacheable is read back from cache it refers to the same memory area as
used by the cache for caching it.
|
| CacheableDeserializer
Interface for a deserializer.
|
| CacheConfig
Stores all of the cache objects and configuration for a single HFile.
|
| CachedBlock |
| CacheStats
Class that implements cache metrics.
|
| CombinedBlockCache
CombinedBlockCache is an abstraction layer that combines
LruBlockCache and BucketCache. |
| CombinedBlockCache.CombinedCacheStats |
| CompoundBloomFilterBase |
| CompoundBloomFilterWriter.ReadyChunk
A Bloom filter chunk enqueued for writing
|
| CorruptHFileException
This exception is thrown when attempts to read an HFile fail due to corruption or truncation
issues.
|
| FixedFileTrailer
The
HFile has 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
Cacheable Blocks of an
HFile version 2 file. |
| HFileBlock.BlockIterator
Iterator for
HFileBlocks. |
| HFileBlock.BlockWritable
Something that can be written into a block.
|
| HFileBlock.FSReader
An HFile block reader with iteration ability.
|
| HFileBlock.PrefetchedHeader
Data-structure to use caching the header of the NEXT block.
|
| HFileBlock.Writer
Unified version 2
HFile block 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.
|
| HFileBlockIndex.ByteArrayKeyBlockIndexReader
An implementation of the BlockIndexReader that deals with block keys which are plain
byte[] like MetaBlock or the Bloom Block for ROW bloom.
|
| HFileBlockIndex.CellBasedKeyBlockIndexReader
An implementation of the BlockIndexReader that deals with block keys which are the key
part of a cell like the Data block index or the ROW_COL bloom blocks
This needs a comparator to work with the Cells
|
| 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
Almost identical to ConsoleReporter, but extending ScheduledReporter,
as extending ConsoleReporter in this version of dropwizard is now too much trouble.
|
| HFilePrettyPrinter.SimpleReporter.Builder
A builder for
HFilePrettyPrinter.SimpleReporter instances. |
| HFileReaderImpl.HFileScannerImpl |
| HFileScanner
A scanner allows you to position yourself within a HFile and
scan through it.
|
| 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 a
ConcurrentHashMap and with a non-blocking eviction thread giving
constant-time LruBlockCache.cacheBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey, org.apache.hadoop.hbase.io.hfile.Cacheable, boolean) and LruBlockCache.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 |
|---|
| HFile.Reader
An interface used by clients to open and iterate an
HFile. |
| HFileScanner
A scanner allows you to position yourself within a HFile and
scan through it.
|
| 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.
|
| 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 |
|---|
| 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 |
| Class and Description |
|---|
| CacheConfig
Stores all of the cache objects and configuration for a single HFile.
|
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.