Uses of Class
org.apache.hadoop.hbase.io.hfile.HFileContext
-
Uses of HFileContext in org.apache.hadoop.hbase.io.encoding
Modifier and TypeFieldDescriptionprivate final HFileContext
HFileBlockDefaultDecodingContext.fileContext
private HFileContext
HFileBlockDefaultEncodingContext.fileContext
private HFileContext
EncodedDataBlock.meta
Modifier and TypeMethodDescriptionHFileBlockDecodingContext.getHFileContext()
Returns HFile meta informationHFileBlockDefaultDecodingContext.getHFileContext()
HFileBlockDefaultEncodingContext.getHFileContext()
HFileBlockEncodingContext.getHFileContext()
Returns HFile context informationModifier and TypeMethodDescriptionAbstractDataBlockEncoder.newDataBlockDecodingContext
(org.apache.hadoop.conf.Configuration conf, HFileContext meta) DataBlockEncoder.newDataBlockDecodingContext
(org.apache.hadoop.conf.Configuration conf, HFileContext meta) Creates an encoder specific decoding context, which will prepare the data before actual decoding store configuration HFile meta dataAbstractDataBlockEncoder.newDataBlockEncodingContext
(org.apache.hadoop.conf.Configuration conf, DataBlockEncoding encoding, byte[] header, HFileContext meta) DataBlockEncoder.newDataBlockEncodingContext
(org.apache.hadoop.conf.Configuration conf, DataBlockEncoding encoding, byte[] headerBytes, HFileContext meta) Creates a encoder specific encoding context store configuration encoding strategy used header bytes to be written, put a dummy header here if the header is unknown HFile meta dataModifierConstructorDescriptionEncodedDataBlock
(org.apache.hadoop.conf.Configuration conf, DataBlockEncoder dataBlockEncoder, DataBlockEncoding encoding, byte[] rawKVs, HFileContext meta) Create a buffer which will be encoded using dataBlockEncoder.HFileBlockDefaultDecodingContext
(org.apache.hadoop.conf.Configuration conf, HFileContext fileContext) HFileBlockDefaultEncodingContext
(org.apache.hadoop.conf.Configuration conf, DataBlockEncoding encoding, byte[] headerBytes, HFileContext fileContext) -
Uses of HFileContext in org.apache.hadoop.hbase.io.hfile
Modifier and TypeFieldDescriptionprivate HFileContext
HFile.WriterFactory.fileContext
private final HFileContext
HFileBlock.fileContext
Meta data that holds meta information on the hfileblock.private HFileContext
HFileBlock.FSReaderImpl.fileContext
private HFileContext
HFileBlock.Writer.fileContext
Meta data that holds information about the hfileblockprivate HFileContext
HFileBlockBuilder.fileContext
private HFileContext
HFileInfo.hfileContext
protected HFileContext
HFileReaderImpl.hfileContext
protected final HFileContext
HFileWriterImpl.hFileContext
Modifier and TypeMethodDescriptionHFileContextBuilder.build()
HFileContext.clone()
static HFileContext
BlockCacheUtil.cloneContext
(HFileContext context) private HFileContext
HFileInfo.createHFileContext
(org.apache.hadoop.fs.Path path, FixedFileTrailer trailer, org.apache.hadoop.conf.Configuration conf) HFile.Reader.getFileContext()
Return the file context of the HFile this reader belongs toHFile.Writer.getFileContext()
Return the file context for the HFile this writer belongs toHFileReaderImpl.getFileContext()
HFileWriterImpl.getFileContext()
HFileBlock.getHFileContext()
HFileInfo.getHFileContext()
Modifier and TypeMethodDescriptionstatic HFileContext
BlockCacheUtil.cloneContext
(HFileContext context) (package private) static HFileBlock
HFileBlock.createFromBuff
(ByteBuff buf, boolean usesHBaseChecksum, long offset, int nextBlockOnDiskSize, HFileContext fileContext, ByteBuffAllocator allocator) Creates a block from an existing buffer starting with a header.private void
HFileInfo.loadMetaInfo
(HFileBlock.BlockIterator blockIter, HFileContext hfileContext) HFileDataBlockEncoder.newDataBlockDecodingContext
(org.apache.hadoop.conf.Configuration conf, HFileContext fileContext) create a encoder specific decoding context for reading.HFileDataBlockEncoderImpl.newDataBlockDecodingContext
(org.apache.hadoop.conf.Configuration conf, HFileContext fileContext) NoOpDataBlockEncoder.newDataBlockDecodingContext
(org.apache.hadoop.conf.Configuration conf, HFileContext meta) HFileDataBlockEncoder.newDataBlockEncodingContext
(org.apache.hadoop.conf.Configuration conf, byte[] headerBytes, HFileContext fileContext) Create an encoder specific encoding context object for writing.HFileDataBlockEncoderImpl.newDataBlockEncodingContext
(org.apache.hadoop.conf.Configuration conf, byte[] dummyHeader, HFileContext fileContext) NoOpDataBlockEncoder.newDataBlockEncodingContext
(org.apache.hadoop.conf.Configuration conf, byte[] dummyHeader, HFileContext meta) (package private) HFileBlock
HFileBlock.unpack
(HFileContext fileContext, HFileBlock.FSReader reader) Retrieves the decompressed/decrypted view of this block.void
BlockCompressedSizePredicator.updateLatestBlockSizes
(HFileContext context, int uncompressed, int compressed) Updates the predicator with both compressed and uncompressed sizes of latest block written.void
PreviousBlockCompressionRatePredicator.updateLatestBlockSizes
(HFileContext context, int uncompressed, int compressed) Recalculates compression rate for the last block and adjusts the block size limit as: BLOCK_SIZE * (uncompressed/compressed).void
UncompressedBlockSizePredicator.updateLatestBlockSizes
(HFileContext context, int uncompressed, int compressed) Empty implementation.HFile.WriterFactory.withFileContext
(HFileContext fileContext) HFileBlockBuilder.withHFileContext
(HFileContext fileContext) ModifierConstructorDescriptionEncodedScanner
(HFile.Reader reader, boolean cacheBlocks, boolean pread, boolean isCompaction, HFileContext meta, org.apache.hadoop.conf.Configuration conf) (package private)
ExclusiveMemHFileBlock
(BlockType blockType, int onDiskSizeWithoutHeader, int uncompressedSizeWithoutHeader, long prevBlockOffset, ByteBuff buf, boolean fillHeader, long offset, int nextBlockOnDiskSize, int onDiskDataSizeWithHeader, HFileContext fileContext, ByteBuffAllocator alloc) (package private)
FSReaderImpl
(ReaderContext readerContext, HFileContext fileContext, ByteBuffAllocator allocator, org.apache.hadoop.conf.Configuration conf) HFileBlock
(BlockType blockType, int onDiskSizeWithoutHeader, int uncompressedSizeWithoutHeader, long prevBlockOffset, ByteBuff buf, boolean fillHeader, long offset, int nextBlockOnDiskSize, int onDiskDataSizeWithHeader, HFileContext fileContext, ByteBuffAllocator allocator) Creates a newHFile
block from the given fields.HFileContext
(HFileContext context) Copy constructorUse this constructor if you want to change a few settings only in another context.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)
SharedMemHFileBlock
(BlockType blockType, int onDiskSizeWithoutHeader, int uncompressedSizeWithoutHeader, long prevBlockOffset, ByteBuff buf, boolean fillHeader, long offset, int nextBlockOnDiskSize, int onDiskDataSizeWithHeader, HFileContext fileContext, ByteBuffAllocator alloc) Writer
(org.apache.hadoop.conf.Configuration conf, HFileDataBlockEncoder dataBlockEncoder, HFileContext fileContext) Writer
(org.apache.hadoop.conf.Configuration conf, HFileDataBlockEncoder dataBlockEncoder, HFileContext fileContext, ByteBuffAllocator allocator, int maxSizeUnCompressed) -
Uses of HFileContext in org.apache.hadoop.hbase.io.hfile.trace
Modifier and TypeFieldDescriptionprivate final HFileContext
HFileContextAttributesBuilderConsumer.hFileContext
-
Uses of HFileContext in org.apache.hadoop.hbase.regionserver
Modifier and TypeFieldDescriptionprivate HFileContext
StoreFileWriter.Builder.fileContext
private final HFileContext
StoreFileWriter.fileContext
Modifier and TypeMethodDescriptionStoreFileWriter.Builder.withFileContext
(HFileContext fileContext) ModifierConstructorDescriptionprivate
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.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 HFileContext in org.apache.hadoop.hbase.regionserver.storefiletracker
Modifier and TypeMethodDescriptionprivate HFileContext
StoreFileTrackerBase.createFileContext
(Compression.Algorithm compression, boolean includeMVCCReadpoint, boolean includesTag, Encryption.Context encryptionContext) -
Uses of HFileContext 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)