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.regionserver | |
org.apache.hadoop.hbase.util | |
org.apache.hadoop.hbase.util.hbck |
Modifier and Type | Method and Description |
---|---|
default StoreFileReader |
RegionObserver.postStoreFileReaderOpen(ObserverContext<RegionCoprocessorEnvironment> ctx,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path p,
FSDataInputStreamWrapper in,
long size,
CacheConfig cacheConf,
Reference r,
StoreFileReader reader)
Deprecated.
For Phoenix only, StoreFileReader is not a stable interface.
|
default StoreFileReader |
RegionObserver.preStoreFileReaderOpen(ObserverContext<RegionCoprocessorEnvironment> ctx,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path p,
FSDataInputStreamWrapper in,
long size,
CacheConfig cacheConf,
Reference r,
StoreFileReader reader)
Deprecated.
For Phoenix only, StoreFileReader is not a stable interface.
|
Constructor and Description |
---|
HalfStoreFileReader(ReaderContext context,
HFileInfo fileInfo,
CacheConfig cacheConf,
Reference r,
AtomicInteger refCount,
org.apache.hadoop.conf.Configuration conf)
Creates a half file reader for a hfile referred to by an hfilelink.
|
Modifier and Type | Field and Description |
---|---|
private CacheConfig |
HFileBlockIndex.BlockIndexWriter.cacheConf
CacheConfig, or null if cache-on-write is disabled
|
protected CacheConfig |
HFileReaderImpl.cacheConf
Block cache configuration.
|
protected CacheConfig |
HFileWriterImpl.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(org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path path,
CacheConfig cacheConf,
boolean primaryReplicaReader,
org.apache.hadoop.conf.Configuration conf) |
static HFile.Reader |
HFile.createReader(ReaderContext context,
HFileInfo fileInfo,
CacheConfig cacheConf,
org.apache.hadoop.conf.Configuration conf)
Method returns the reader given the specified arguments.
|
(package private) HFileBlock |
HFileBlock.Writer.getBlockForCaching(CacheConfig cacheConf)
Creates a new HFileBlock.
|
static HFile.WriterFactory |
HFile.getWriterFactory(org.apache.hadoop.conf.Configuration conf,
CacheConfig cacheConf)
Returns the factory to be used to create
HFile writers |
Constructor and Description |
---|
BlockIndexWriter(HFileBlock.Writer blockWriter,
CacheConfig cacheConf,
String nameForCaching)
Creates a multi-level block index writer.
|
CacheConfig(CacheConfig cacheConf)
Constructs a cache configuration copied from the specified configuration.
|
HFilePreadReader(ReaderContext context,
HFileInfo fileInfo,
CacheConfig cacheConf,
org.apache.hadoop.conf.Configuration conf) |
HFileReaderImpl(ReaderContext context,
HFileInfo fileInfo,
CacheConfig cacheConf,
org.apache.hadoop.conf.Configuration conf)
Opens a HFile.
|
HFileStreamReader(ReaderContext context,
HFileInfo fileInfo,
CacheConfig cacheConf,
org.apache.hadoop.conf.Configuration conf) |
HFileWriterImpl(org.apache.hadoop.conf.Configuration conf,
CacheConfig cacheConf,
org.apache.hadoop.fs.Path path,
org.apache.hadoop.fs.FSDataOutputStream outputStream,
HFileContext fileContext) |
WriterFactory(org.apache.hadoop.conf.Configuration conf,
CacheConfig cacheConf) |
Modifier and Type | Method and Description |
---|---|
static void |
MobUtils.cleanExpiredMobFiles(org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.conf.Configuration conf,
TableName tableName,
ColumnFamilyDescriptor columnDescriptor,
CacheConfig cacheConfig,
long current)
Cleans the expired mob files.
|
static CachedMobFile |
CachedMobFile.create(org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path path,
org.apache.hadoop.conf.Configuration conf,
CacheConfig cacheConf) |
static MobFile |
MobFile.create(org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path path,
org.apache.hadoop.conf.Configuration conf,
CacheConfig cacheConf)
Creates an instance of the MobFile.
|
static StoreFileWriter |
MobUtils.createWriter(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
ColumnFamilyDescriptor family,
MobFileName mobFileName,
org.apache.hadoop.fs.Path basePath,
long maxKeyCount,
Compression.Algorithm compression,
CacheConfig cacheConfig,
Encryption.Context cryptoContext,
boolean isCompaction)
Creates a writer for the mob file in temp directory.
|
static StoreFileWriter |
MobUtils.createWriter(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
ColumnFamilyDescriptor family,
org.apache.hadoop.fs.Path path,
long maxKeyCount,
Compression.Algorithm compression,
CacheConfig cacheConfig,
Encryption.Context cryptoContext,
ChecksumType checksumType,
int bytesPerChecksum,
int blocksize,
BloomType bloomType,
boolean isCompaction)
Creates a writer for the mob file in temp directory.
|
static StoreFileWriter |
MobUtils.createWriter(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
ColumnFamilyDescriptor family,
org.apache.hadoop.fs.Path path,
long maxKeyCount,
Compression.Algorithm compression,
CacheConfig cacheConfig,
Encryption.Context cryptoContext,
ChecksumType checksumType,
int bytesPerChecksum,
int blocksize,
BloomType bloomType,
boolean isCompaction,
Consumer<org.apache.hadoop.fs.Path> writerCreationTracker)
Creates a writer for the mob file in temp directory.
|
static StoreFileWriter |
MobUtils.createWriter(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
ColumnFamilyDescriptor family,
String date,
org.apache.hadoop.fs.Path basePath,
long maxKeyCount,
Compression.Algorithm compression,
String startKey,
CacheConfig cacheConfig,
Encryption.Context cryptoContext,
boolean isCompaction,
String regionName)
Creates a writer for the mob file in temp directory.
|
MobFile |
MobFileCache.openFile(org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path path,
CacheConfig cacheConf)
Opens a mob file.
|
Modifier and Type | Field and Description |
---|---|
private CacheConfig |
HStoreFile.cacheConf |
private CacheConfig |
StoreFileWriter.Builder.cacheConf |
private CacheConfig |
StoreContext.cacheConf |
private CacheConfig |
StoreContext.Builder.cacheConf |
Modifier and Type | Method and Description |
---|---|
protected CacheConfig |
HStore.createCacheConf(ColumnFamilyDescriptor family)
Creates the cache config.
|
CacheConfig |
HStoreFile.getCacheConf() |
CacheConfig |
StoreContext.getCacheConf() |
CacheConfig |
HStore.getCacheConfig()
Used for tests.
|
Modifier and Type | Method and Description |
---|---|
(package private) StoreFileReader |
StoreFileInfo.createReader(ReaderContext context,
CacheConfig cacheConf) |
StoreFileReader |
RegionCoprocessorHost.postStoreFileReaderOpen(org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path p,
FSDataInputStreamWrapper in,
long size,
CacheConfig cacheConf,
Reference r,
StoreFileReader reader) |
(package private) StoreFileReader |
StoreFileInfo.postStoreFileReaderOpen(ReaderContext context,
CacheConfig cacheConf,
StoreFileReader reader) |
StoreFileReader |
RegionCoprocessorHost.preStoreFileReaderOpen(org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path p,
FSDataInputStreamWrapper in,
long size,
CacheConfig cacheConf,
Reference r) |
(package private) StoreFileReader |
StoreFileInfo.preStoreFileReaderOpen(ReaderContext context,
CacheConfig cacheConf) |
StoreContext.Builder |
StoreContext.Builder.withCacheConfig(CacheConfig cacheConf) |
Constructor and Description |
---|
Builder(org.apache.hadoop.conf.Configuration conf,
CacheConfig cacheConf,
org.apache.hadoop.fs.FileSystem fs) |
HStoreFile(org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path p,
org.apache.hadoop.conf.Configuration conf,
CacheConfig cacheConf,
BloomType cfBloomType,
boolean primaryReplica)
Constructor, loads a reader and it's indices, etc.
|
HStoreFile(StoreFileInfo fileInfo,
BloomType cfBloomType,
CacheConfig cacheConf)
Constructor, loads a reader and it's indices, etc.
|
HStoreFile(StoreFileInfo fileInfo,
BloomType cfBloomType,
CacheConfig cacheConf,
BloomFilterMetrics metrics)
Constructor, loads a reader and it's indices, etc.
|
StoreFileReader(ReaderContext context,
HFileInfo fileInfo,
CacheConfig cacheConf,
AtomicInteger refCount,
org.apache.hadoop.conf.Configuration conf) |
StoreFileWriter(org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path path,
org.apache.hadoop.conf.Configuration conf,
CacheConfig cacheConf,
BloomType bloomType,
long maxKeys,
InetSocketAddress[] favoredNodes,
HFileContext fileContext,
boolean shouldDropCacheBehind,
Supplier<Collection<HStoreFile>> compactedFilesSupplier)
Creates an HFile.Writer that also write helpful meta data.
|
Modifier and Type | Method and Description |
---|---|
static BloomFilterWriter |
BloomFilterFactory.createDeleteBloomAtWrite(org.apache.hadoop.conf.Configuration conf,
CacheConfig cacheConf,
int maxKeys,
HFile.Writer writer)
Creates a new Delete Family Bloom filter at the time of
HStoreFile writing. |
static BloomFilterWriter |
BloomFilterFactory.createGeneralBloomAtWrite(org.apache.hadoop.conf.Configuration conf,
CacheConfig cacheConf,
BloomType bloomType,
int maxKeys,
HFile.Writer writer)
Creates a new general (Row or RowCol) Bloom filter at the time of
HStoreFile writing. |
Modifier and Type | Field and Description |
---|---|
(package private) CacheConfig |
HFileCorruptionChecker.cacheConf |
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.