Uses of Class
org.apache.hadoop.hbase.io.hfile.CacheConfig
Packages that use 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
Methods in org.apache.hadoop.hbase.coprocessor with parameters of type CacheConfigModifier and TypeMethodDescriptiondefault StoreFileReaderRegionObserver.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 StoreFileReaderRegionObserver.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. -
Uses of CacheConfig in org.apache.hadoop.hbase.io
Constructors in org.apache.hadoop.hbase.io with parameters of type CacheConfigModifierConstructorDescriptionHalfStoreFileReader(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
Fields in org.apache.hadoop.hbase.io.hfile declared as CacheConfigModifier and TypeFieldDescriptionprotected final CacheConfigHFile.WriterFactory.cacheConfprivate CacheConfigHFileBlockIndex.BlockIndexWriter.cacheConfCacheConfig, or null if cache-on-write is disabledprotected final CacheConfigHFileReaderImpl.cacheConfBlock cache configuration.protected final CacheConfigHFileWriterImpl.cacheConfCache configuration for caching data on write.static final CacheConfigCacheConfig.DISABLEDDisabled cache configurationMethods in org.apache.hadoop.hbase.io.hfile with parameters of type CacheConfigModifier and TypeMethodDescriptionstatic HFile.ReaderHFile.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.ReaderHFile.createReader(ReaderContext context, HFileInfo fileInfo, CacheConfig cacheConf, org.apache.hadoop.conf.Configuration conf) Method returns the reader given the specified arguments.(package private) HFileBlockHFileBlock.Writer.getBlockForCaching(CacheConfig cacheConf) Creates a new HFileBlock.static final HFile.WriterFactoryHFile.getWriterFactory(org.apache.hadoop.conf.Configuration conf, CacheConfig cacheConf) Returns the factory to be used to createHFilewritersConstructors in org.apache.hadoop.hbase.io.hfile with parameters of type CacheConfigModifierConstructorDescriptionBlockIndexWriter(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
Methods in org.apache.hadoop.hbase.io.hfile.bucket with parameters of type CacheConfigModifier and TypeMethodDescriptionstatic Optional<BucketCache>BucketCache.getBucketCacheFromCacheConfig(CacheConfig cacheConf) -
Uses of CacheConfig in org.apache.hadoop.hbase.mob
Methods in org.apache.hadoop.hbase.mob with parameters of type CacheConfigModifier and TypeMethodDescriptionstatic voidMobUtils.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 CachedMobFileCachedMobFile.create(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path path, org.apache.hadoop.conf.Configuration conf, CacheConfig cacheConf) static MobFileMobFile.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 StoreFileWriterMobUtils.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 StoreFileWriterMobUtils.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 StoreFileWriterMobUtils.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 StoreFileWriterMobUtils.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) Opens a mob file. -
Uses of CacheConfig in org.apache.hadoop.hbase.regionserver
Fields in org.apache.hadoop.hbase.regionserver declared as CacheConfigModifier and TypeFieldDescriptionprivate final CacheConfigHStoreFile.cacheConfprivate CacheConfigStoreContext.Builder.cacheConfprivate final CacheConfigStoreContext.cacheConfprivate final CacheConfigStoreFileWriter.Builder.cacheConfMethods in org.apache.hadoop.hbase.regionserver that return CacheConfigModifier and TypeMethodDescriptionprotected CacheConfigHStore.createCacheConf(ColumnFamilyDescriptor family) Creates the cache config.HStoreFile.getCacheConf()StoreContext.getCacheConf()HStore.getCacheConfig()Used for tests.Methods in org.apache.hadoop.hbase.regionserver with parameters of type CacheConfigModifier 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) StoreFileReaderStoreFileInfo.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) StoreFileReaderStoreFileInfo.preStoreFileReaderOpen(ReaderContext context, CacheConfig cacheConf) StoreContext.Builder.withCacheConfig(CacheConfig cacheConf) Constructors in org.apache.hadoop.hbase.regionserver with parameters of type CacheConfigModifierConstructorDescriptionBuilder(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, StoreFileInfo storeFileInfo, org.apache.hadoop.conf.Configuration conf) privateStoreFileWriter(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. -
Uses of CacheConfig in org.apache.hadoop.hbase.util
Methods in org.apache.hadoop.hbase.util with parameters of type CacheConfigModifier and TypeMethodDescriptionstatic BloomFilterWriterBloomFilterFactory.createDeleteBloomAtWrite(org.apache.hadoop.conf.Configuration conf, CacheConfig cacheConf, int maxKeys, HFile.Writer writer) Creates a new Delete Family Bloom filter at the time ofHStoreFilewriting.static BloomFilterWriterBloomFilterFactory.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 ofHStoreFilewriting. -
Uses of CacheConfig in org.apache.hadoop.hbase.util.hbck
Fields in org.apache.hadoop.hbase.util.hbck declared as CacheConfigModifier and TypeFieldDescription(package private) final CacheConfigHFileCorruptionChecker.cacheConf