Package | Description |
---|---|
org.apache.hadoop.hbase.io.encoding | |
org.apache.hadoop.hbase.io.hfile |
Provides implementations of
HFile and HFile
BlockCache . |
org.apache.hadoop.hbase.regionserver |
Modifier and Type | Field and Description |
---|---|
private HFileContext |
HFileBlockDefaultDecodingContext.fileContext |
private HFileContext |
HFileBlockDefaultEncodingContext.fileContext |
private HFileContext |
EncodedDataBlock.meta |
Modifier and Type | Method and Description |
---|---|
HFileContext |
HFileBlockDecodingContext.getHFileContext() |
HFileContext |
HFileBlockEncodingContext.getHFileContext() |
HFileContext |
HFileBlockDefaultDecodingContext.getHFileContext() |
HFileContext |
HFileBlockDefaultEncodingContext.getHFileContext() |
Modifier and Type | Method and Description |
---|---|
HFileBlockDecodingContext |
DataBlockEncoder.newDataBlockDecodingContext(HFileContext meta)
Creates an encoder specific decoding context, which will prepare the data
before actual decoding
|
HFileBlockDecodingContext |
AbstractDataBlockEncoder.newDataBlockDecodingContext(HFileContext meta) |
HFileBlockEncodingContext |
DataBlockEncoder.newDataBlockEncodingContext(DataBlockEncoding encoding,
byte[] headerBytes,
HFileContext meta)
Creates a encoder specific encoding context
|
HFileBlockEncodingContext |
AbstractDataBlockEncoder.newDataBlockEncodingContext(DataBlockEncoding encoding,
byte[] header,
HFileContext meta) |
Constructor and Description |
---|
EncodedDataBlock(DataBlockEncoder dataBlockEncoder,
DataBlockEncoding encoding,
byte[] rawKVs,
HFileContext meta)
Create a buffer which will be encoded using dataBlockEncoder.
|
HFileBlockDefaultDecodingContext(HFileContext fileContext) |
HFileBlockDefaultEncodingContext(DataBlockEncoding encoding,
byte[] headerBytes,
HFileContext fileContext) |
Modifier and Type | Field and Description |
---|---|
private HFileContext |
HFile.WriterFactory.fileContext |
private HFileContext |
HFileBlock.fileContext
Meta data that holds meta information on the hfileblock.
|
private HFileContext |
HFileBlock.Writer.fileContext
Meta data that holds information about the hfileblock
|
private HFileContext |
HFileBlock.FSReaderImpl.fileContext |
private HFileContext |
HFileReaderImpl.hfileContext |
protected HFileContext |
HFileWriterImpl.hFileContext |
Modifier and Type | Method and Description |
---|---|
HFileContext |
HFileContextBuilder.build() |
HFileContext |
HFileContext.clone() |
protected HFileContext |
HFileReaderImpl.createHFileContext(FSDataInputStreamWrapper fsdis,
long fileSize,
HFileSystem hfs,
org.apache.hadoop.fs.Path path,
FixedFileTrailer trailer) |
HFileContext |
HFileReaderImpl.getFileContext() |
HFileContext |
HFileWriterImpl.getFileContext() |
HFileContext |
HFile.Writer.getFileContext()
Return the file context for the HFile this writer belongs to
|
HFileContext |
HFile.Reader.getFileContext()
Return the file context of the HFile this reader belongs to
|
(package private) HFileContext |
HFileBlock.getHFileContext() |
Modifier and Type | Method and Description |
---|---|
private void |
HFileBlock.init(BlockType blockType,
int onDiskSizeWithoutHeader,
int uncompressedSizeWithoutHeader,
long prevBlockOffset,
long offset,
int onDiskDataSizeWithHeader,
int nextBlockOnDiskSize,
HFileContext fileContext)
Called from constructors.
|
HFileBlockDecodingContext |
NoOpDataBlockEncoder.newDataBlockDecodingContext(HFileContext meta) |
HFileBlockDecodingContext |
HFileDataBlockEncoder.newDataBlockDecodingContext(HFileContext fileContext)
create a encoder specific decoding context for reading.
|
HFileBlockDecodingContext |
HFileDataBlockEncoderImpl.newDataBlockDecodingContext(HFileContext fileContext) |
HFileBlockEncodingContext |
NoOpDataBlockEncoder.newDataBlockEncodingContext(byte[] dummyHeader,
HFileContext meta) |
HFileBlockEncodingContext |
HFileDataBlockEncoder.newDataBlockEncodingContext(byte[] headerBytes,
HFileContext fileContext)
Create an encoder specific encoding context object for writing.
|
HFileBlockEncodingContext |
HFileDataBlockEncoderImpl.newDataBlockEncodingContext(byte[] dummyHeader,
HFileContext fileContext) |
(package private) HFileBlock |
HFileBlock.unpack(HFileContext fileContext,
HFileBlock.FSReader reader)
Retrieves the decompressed/decrypted view of this block.
|
HFile.WriterFactory |
HFile.WriterFactory.withFileContext(HFileContext fileContext) |
Constructor and Description |
---|
EncodedScanner(HFile.Reader reader,
boolean cacheBlocks,
boolean pread,
boolean isCompaction,
HFileContext meta) |
FSReaderImpl(org.apache.hadoop.fs.FSDataInputStream istream,
long fileSize,
HFileContext fileContext)
A constructor that reads files with the latest minor version.
|
FSReaderImpl(FSDataInputStreamWrapper stream,
long fileSize,
HFileSystem hfs,
org.apache.hadoop.fs.Path path,
HFileContext fileContext) |
HFileBlock(BlockType blockType,
int onDiskSizeWithoutHeader,
int uncompressedSizeWithoutHeader,
long prevBlockOffset,
ByteBuffer b,
boolean fillHeader,
long offset,
int nextBlockOnDiskSize,
int onDiskDataSizeWithHeader,
HFileContext fileContext)
Creates a new
HFile block from the given fields. |
HFileBlock(ByteBuff buf,
boolean usesHBaseChecksum,
Cacheable.MemoryType memType,
long offset,
int nextBlockOnDiskSize,
HFileContext fileContext)
Creates a block from an existing buffer starting with a header.
|
HFileContext(HFileContext context)
Copy constructor
|
HFileContextBuilder(HFileContext hfc)
Use 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,
CellComparator comparator,
HFileContext fileContext) |
Writer(HFileDataBlockEncoder dataBlockEncoder,
HFileContext fileContext) |
Modifier and Type | Field and Description |
---|---|
private HFileContext |
StoreFileWriter.Builder.fileContext |
Modifier and Type | Method and Description |
---|---|
private HFileContext |
HStore.createFileContext(Compression.Algorithm compression,
boolean includeMVCCReadpoint,
boolean includesTag,
Encryption.Context cryptoContext) |
Modifier and Type | Method and Description |
---|---|
StoreFileWriter.Builder |
StoreFileWriter.Builder.withFileContext(HFileContext fileContext) |
Constructor and Description |
---|
StoreFileWriter(org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path path,
org.apache.hadoop.conf.Configuration conf,
CacheConfig cacheConf,
CellComparator comparator,
BloomType bloomType,
long maxKeys,
InetSocketAddress[] favoredNodes,
HFileContext fileContext,
boolean shouldDropCacheBehind,
Supplier<Collection<HStoreFile>> compactedFilesSupplier)
Creates an HFile.Writer that also write helpful meta data.
|
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.