Uses of Class
org.apache.hadoop.hbase.io.hfile.CacheConfig
Package
Description
Table of Contents
Provides implementations of
HFile
and HFile
BlockCache
.Provides
BucketCache
, an implementation of
BlockCache
.-
Uses of CacheConfig in org.apache.hadoop.hbase.coprocessor
Modifier and TypeMethodDescriptiondefault StoreFileReader
RegionObserver.postStoreFileReaderOpen
(ObserverContext<? extends 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<? extends 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. -
Uses of CacheConfig in org.apache.hadoop.hbase.io
ModifierConstructorDescriptionHalfStoreFileReader
(ReaderContext context, HFileInfo fileInfo, CacheConfig cacheConf, Reference r, StoreFileInfo storeFileInfo, org.apache.hadoop.conf.Configuration conf) Creates a half file reader for a hfile referred to by an hfilelink. -
Uses of CacheConfig in org.apache.hadoop.hbase.io.hfile
Modifier and TypeFieldDescriptionprotected final CacheConfig
HFile.WriterFactory.cacheConf
private CacheConfig
HFileBlockIndex.BlockIndexWriter.cacheConf
CacheConfig, or null if cache-on-write is disabledprotected final CacheConfig
HFileReaderImpl.cacheConf
Block cache configuration.protected final CacheConfig
HFileWriterImpl.cacheConf
Cache configuration for caching data on write.static final CacheConfig
CacheConfig.DISABLED
Disabled cache configurationModifier and TypeMethodDescriptionstatic 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.static HFileBlock
BlockCacheUtil.getBlockForCaching
(CacheConfig cacheConf, HFileBlock block) Similarly to HFileBlock.Writer.getBlockForCaching(), creates a HFileBlock instance without checksum for caching.(package private) HFileBlock
HFileBlock.Writer.getBlockForCaching
(CacheConfig cacheConf) Creates a new HFileBlock.static final HFile.WriterFactory
HFile.getWriterFactory
(org.apache.hadoop.conf.Configuration conf, CacheConfig cacheConf) Returns the factory to be used to createHFile
writersModifierConstructorDescriptionBlockIndexWriter
(HFileBlock.Writer blockWriter, CacheConfig cacheConf, String nameForCaching, HFileIndexBlockEncoder indexBlockEncoder) 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) (package private)
WriterFactory
(org.apache.hadoop.conf.Configuration conf, CacheConfig cacheConf) -
Uses of CacheConfig in org.apache.hadoop.hbase.io.hfile.bucket
Modifier and TypeMethodDescriptionstatic Optional<BucketCache>
BucketCache.getBucketCacheFromCacheConfig
(CacheConfig cacheConf) -
Uses of CacheConfig in org.apache.hadoop.hbase.mob
Modifier and TypeMethodDescriptionstatic void
MobUtils.cleanExpiredMobFiles
(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.conf.Configuration conf, TableDescriptor htd, 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, StoreFileTracker sft) static MobFile
MobFile.create
(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path path, org.apache.hadoop.conf.Configuration conf, CacheConfig cacheConf, StoreFileTracker sft) Creates an instance of the MobFile.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.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, 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.MobFileCache.openFile
(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path path, CacheConfig cacheConf, StoreContext storeContext) Opens a mob file. -
Uses of CacheConfig in org.apache.hadoop.hbase.regionserver
Modifier and TypeFieldDescriptionprivate final CacheConfig
HStoreFile.cacheConf
private CacheConfig
StoreContext.Builder.cacheConf
private final CacheConfig
StoreContext.cacheConf
private final CacheConfig
StoreFileWriter.Builder.cacheConf
private final CacheConfig
StoreFileWriter.cacheConf
Modifier and TypeMethodDescriptionprotected CacheConfig
HStore.createCacheConf
(ColumnFamilyDescriptor family) Creates the cache config.HStoreFile.getCacheConf()
StoreContext.getCacheConf()
HStore.getCacheConfig()
Used for tests.Modifier and TypeMethodDescriptionStoreFileInfo.createReader
(ReaderContext context, CacheConfig cacheConf) 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) 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.withCacheConfig
(CacheConfig cacheConf) ModifierConstructorDescriptionBuilder
(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, StoreFileTracker sft) 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.private
SingleStoreFileWriter
(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.StoreFileReader
(ReaderContext context, HFileInfo fileInfo, CacheConfig cacheConf, StoreFileInfo storeFileInfo, org.apache.hadoop.conf.Configuration conf) private
StoreFileWriter
(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path liveFilePath, org.apache.hadoop.fs.Path historicalFilePath, org.apache.hadoop.conf.Configuration conf, CacheConfig cacheConf, BloomType bloomType, long maxKeys, InetSocketAddress[] favoredNodes, HFileContext fileContext, boolean shouldDropCacheBehind, Supplier<Collection<HStoreFile>> compactedFilesSupplier, CellComparator comparator, int maxVersions, boolean newVersionBehavior) Creates an HFile.Writer that also write helpful meta data. -
Uses of CacheConfig in org.apache.hadoop.hbase.tool
Modifier and TypeMethodDescriptionprivate static StoreFileWriter
BulkLoadHFilesTool.initStoreFileWriter
(org.apache.hadoop.conf.Configuration conf, Cell cell, HFileContext hFileContext, CacheConfig cacheConf, BloomType bloomFilterType, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path outFile, AsyncTableRegionLocator loc) -
Uses of CacheConfig in org.apache.hadoop.hbase.util
Modifier and TypeMethodDescriptionstatic 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 ofHStoreFile
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 ofHStoreFile
writing. -
Uses of CacheConfig in org.apache.hadoop.hbase.util.hbck
Modifier and TypeFieldDescription(package private) final CacheConfig
HFileCorruptionChecker.cacheConf