Package | Description |
---|---|
org.apache.hadoop.hbase.coprocessor |
Table of Contents
|
org.apache.hadoop.hbase.io | |
org.apache.hadoop.hbase.io.hfile |
Provides implementations of
HFile and HFile
BlockCache . |
org.apache.hadoop.hbase.mob | |
org.apache.hadoop.hbase.mob.mapreduce | |
org.apache.hadoop.hbase.regionserver | |
org.apache.hadoop.hbase.util |
Constructor and Description |
---|
HalfStoreFileReader(FileSystem fs,
Path p,
CacheConfig cacheConf,
Reference r,
Configuration conf)
Creates a half file reader for a normal hfile.
|
HalfStoreFileReader(FileSystem fs,
Path p,
FSDataInputStreamWrapper in,
long size,
CacheConfig cacheConf,
Reference r,
Configuration conf)
Creates a half file reader for a hfile referred to by an hfilelink.
|
Modifier and Type | Field and Description |
---|---|
protected CacheConfig |
AbstractHFileReader.cacheConf
Block cache configuration.
|
protected CacheConfig |
AbstractHFileWriter.cacheConf
Cache configuration for caching data on write.
|
protected CacheConfig |
HFile.WriterFactory.cacheConf |
static CacheConfig |
CacheConfig.DISABLED
Disabled cache configuration
|
Modifier and Type | Method and Description |
---|---|
static HFile.Reader |
HFile.createReader(FileSystem fs,
Path path,
CacheConfig cacheConf,
Configuration conf) |
static HFile.Reader |
HFile.createReader(FileSystem fs,
Path path,
FSDataInputStreamWrapper fsdis,
long size,
CacheConfig cacheConf,
Configuration conf) |
HFileBlock |
HFileBlock.Writer.getBlockForCaching(CacheConfig cacheConf)
Creates a new HFileBlock.
|
static HFile.WriterFactory |
HFile.getWriterFactory(Configuration conf,
CacheConfig cacheConf)
Returns the factory to be used to create
HFile writers |
Constructor and Description |
---|
AbstractHFileReader(Path path,
FixedFileTrailer trailer,
long fileSize,
CacheConfig cacheConf,
HFileSystem hfs,
Configuration conf) |
AbstractHFileWriter(CacheConfig cacheConf,
FSDataOutputStream outputStream,
Path path,
KeyValue.KVComparator comparator,
HFileContext fileContext) |
BlockIndexWriter(HFileBlock.Writer blockWriter,
CacheConfig cacheConf,
String nameForCaching)
Creates a multi-level block index writer.
|
HFileReaderV2(Path path,
FixedFileTrailer trailer,
FSDataInputStreamWrapper fsdis,
long size,
CacheConfig cacheConf,
HFileSystem hfs,
Configuration conf)
Opens a HFile.
|
HFileReaderV3(Path path,
FixedFileTrailer trailer,
FSDataInputStreamWrapper fsdis,
long size,
CacheConfig cacheConf,
HFileSystem hfs,
Configuration conf)
Opens a HFile.
|
HFileWriterV2(Configuration conf,
CacheConfig cacheConf,
FileSystem fs,
Path path,
FSDataOutputStream ostream,
KeyValue.KVComparator comparator,
HFileContext context)
Constructor that takes a path, creates and closes the output stream.
|
HFileWriterV3(Configuration conf,
CacheConfig cacheConf,
FileSystem fs,
Path path,
FSDataOutputStream ostream,
KeyValue.KVComparator comparator,
HFileContext fileContext)
Constructor that takes a path, creates and closes the output stream.
|
Modifier and Type | Class and Description |
---|---|
class |
MobCacheConfig
The cache configuration for the mob.
|
Modifier and Type | Method and Description |
---|---|
static void |
MobUtils.cleanExpiredMobFiles(FileSystem fs,
Configuration conf,
TableName tableName,
HColumnDescriptor columnDescriptor,
CacheConfig cacheConfig,
long current)
Cleans the expired mob files.
|
static Path |
MobUtils.commitFile(Configuration conf,
FileSystem fs,
Path sourceFile,
Path targetPath,
CacheConfig cacheConfig)
Commits the mob file.
|
static CachedMobFile |
CachedMobFile.create(FileSystem fs,
Path path,
Configuration conf,
CacheConfig cacheConf) |
static MobFile |
MobFile.create(FileSystem fs,
Path path,
Configuration conf,
CacheConfig cacheConf)
Creates an instance of the MobFile.
|
static StoreFile.Writer |
MobUtils.createDelFileWriter(Configuration conf,
FileSystem fs,
HColumnDescriptor family,
String date,
Path basePath,
long maxKeyCount,
Compression.Algorithm compression,
byte[] startKey,
CacheConfig cacheConfig,
Encryption.Context cryptoContext)
Creates a writer for the del file in temp directory.
|
static StoreFile.Writer |
MobUtils.createRefFileWriter(Configuration conf,
FileSystem fs,
HColumnDescriptor family,
Path basePath,
long maxKeyCount,
CacheConfig cacheConfig,
Encryption.Context cryptoContext)
Creates a writer for the ref file in temp directory.
|
static StoreFile.Writer |
MobUtils.createWriter(Configuration conf,
FileSystem fs,
HColumnDescriptor family,
String date,
Path basePath,
long maxKeyCount,
Compression.Algorithm compression,
byte[] startKey,
CacheConfig cacheConfig,
Encryption.Context cryptoContext)
Creates a writer for the mob file in temp directory.
|
static StoreFile.Writer |
MobUtils.createWriter(Configuration conf,
FileSystem fs,
HColumnDescriptor family,
String date,
Path basePath,
long maxKeyCount,
Compression.Algorithm compression,
String startKey,
CacheConfig cacheConfig,
Encryption.Context cryptoContext)
Creates a writer for the mob file in temp directory.
|
Constructor and Description |
---|
MemStoreWrapper(Context context,
FileSystem fs,
BufferedMutator table,
HColumnDescriptor hcd,
MemStore memstore,
CacheConfig cacheConfig) |
Modifier and Type | Field and Description |
---|---|
protected CacheConfig |
HStore.cacheConf |
protected CacheConfig |
HRegionServer.cacheConfig |
Modifier and Type | Method and Description |
---|---|
CacheConfig |
HRegionServer.getCacheConfig() |
CacheConfig |
HStore.getCacheConfig() |
CacheConfig |
Store.getCacheConfig()
Used for tests.
|
Modifier and Type | Method and Description |
---|---|
StoreFile.Reader |
StoreFileInfo.open(FileSystem fs,
CacheConfig cacheConf)
Open a Reader for the StoreFile
|
StoreFile.Reader |
RegionCoprocessorHost.postStoreFileReaderOpen(FileSystem fs,
Path p,
FSDataInputStreamWrapper in,
long size,
CacheConfig cacheConf,
Reference r,
StoreFile.Reader reader) |
StoreFile.Reader |
RegionCoprocessorHost.preStoreFileReaderOpen(FileSystem fs,
Path p,
FSDataInputStreamWrapper in,
long size,
CacheConfig cacheConf,
Reference r) |
Constructor and Description |
---|
Reader(FileSystem fs,
Path path,
CacheConfig cacheConf,
Configuration conf) |
Reader(FileSystem fs,
Path path,
FSDataInputStreamWrapper in,
long size,
CacheConfig cacheConf,
Configuration conf) |
StoreFile(FileSystem fs,
Path p,
Configuration conf,
CacheConfig cacheConf,
BloomType cfBloomType)
Constructor, loads a reader and it's indices, etc.
|
StoreFile(FileSystem fs,
StoreFileInfo fileInfo,
Configuration conf,
CacheConfig cacheConf,
BloomType cfBloomType)
Constructor, loads a reader and it's indices, etc.
|
WriterBuilder(Configuration conf,
CacheConfig cacheConf,
FileSystem fs) |
Modifier and Type | Method and Description |
---|---|
static BloomFilterWriter |
BloomFilterFactory.createDeleteBloomAtWrite(Configuration conf,
CacheConfig cacheConf,
int maxKeys,
HFile.Writer writer)
Creates a new Delete Family Bloom filter at the time of
StoreFile writing. |
static BloomFilterWriter |
BloomFilterFactory.createGeneralBloomAtWrite(Configuration conf,
CacheConfig cacheConf,
BloomType bloomType,
int maxKeys,
HFile.Writer writer)
Creates a new general (Row or RowCol) Bloom filter at the time of
StoreFile writing. |