| Package | Description | 
|---|---|
| org.apache.hadoop.hbase.codec.prefixtree | |
| org.apache.hadoop.hbase.io.encoding | |
| org.apache.hadoop.hbase.io.hfile | Provides implementations of  HFileand HFileBlockCache. | 
| org.apache.hadoop.hbase.regionserver | 
| Modifier and Type | Method and Description | 
|---|---|
| HFileBlockDecodingContext | PrefixTreeCodec. newDataBlockDecodingContext(HFileContext meta)Deprecated.  | 
| HFileBlockEncodingContext | PrefixTreeCodec. newDataBlockEncodingContext(DataBlockEncoding encoding,
                           byte[] header,
                           HFileContext meta)Deprecated.  | 
| 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 | HFileBlockDefaultDecodingContext. getHFileContext() | 
| HFileContext | HFileBlockDefaultEncodingContext. getHFileContext() | 
| HFileContext | HFileBlockEncodingContext. getHFileContext() | 
| Modifier and Type | Method and Description | 
|---|---|
| HFileBlockDecodingContext | BufferedDataBlockEncoder. newDataBlockDecodingContext(HFileContext meta) | 
| HFileBlockDecodingContext | DataBlockEncoder. newDataBlockDecodingContext(HFileContext meta)Creates an encoder specific decoding context, which will prepare the data
 before actual decoding | 
| HFileBlockEncodingContext | BufferedDataBlockEncoder. newDataBlockEncodingContext(DataBlockEncoding encoding,
                           byte[] header,
                           HFileContext meta) | 
| HFileBlockEncodingContext | DataBlockEncoder. newDataBlockEncodingContext(DataBlockEncoding encoding,
                           byte[] headerBytes,
                           HFileContext meta)Creates a encoder specific encoding context | 
| 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 | HFileBlock. fileContextMeta data that holds meta information on the hfileblock | 
| private HFileContext | HFileBlock.Writer. fileContextMeta data that holds information about the hfileblock | 
| protected HFileContext | HFileBlock.AbstractFSReader. fileContext | 
| private HFileContext | HFile.WriterFactory. fileContext | 
| (package private) HFileContext | HFileReaderV2. hfileContext | 
| protected HFileContext | AbstractHFileWriter. hFileContext | 
| protected HFileContext | HFileReaderV2.EncodedScannerV2. meta | 
| Modifier and Type | Method and Description | 
|---|---|
| HFileContext | HFileContextBuilder. build() | 
| HFileContext | HFileContext. clone() | 
| protected HFileContext | HFileReaderV3. createHFileContext(FSDataInputStreamWrapper fsdis,
                  long fileSize,
                  HFileSystem hfs,
                  org.apache.hadoop.fs.Path path,
                  FixedFileTrailer trailer) | 
| protected HFileContext | HFileReaderV2. createHFileContext(FSDataInputStreamWrapper fsdis,
                  long fileSize,
                  HFileSystem hfs,
                  org.apache.hadoop.fs.Path path,
                  FixedFileTrailer trailer) | 
| HFileContext | HFileWriterV2. getFileContext() | 
| HFileContext | HFileReaderV2. 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 | 
| HFileContext | HFileBlock. getHFileContext() | 
| Modifier and Type | Method and Description | 
|---|---|
| HFile.Writer | HFileWriterV2.WriterFactoryV2. createWriter(org.apache.hadoop.fs.FileSystem fs,
            org.apache.hadoop.fs.Path path,
            org.apache.hadoop.fs.FSDataOutputStream ostream,
            KeyValue.KVComparator comparator,
            HFileContext context) | 
| HFile.Writer | HFileWriterV3.WriterFactoryV3. createWriter(org.apache.hadoop.fs.FileSystem fs,
            org.apache.hadoop.fs.Path path,
            org.apache.hadoop.fs.FSDataOutputStream ostream,
            KeyValue.KVComparator comparator,
            HFileContext fileContext) | 
| protected abstract HFile.Writer | HFile.WriterFactory. createWriter(org.apache.hadoop.fs.FileSystem fs,
            org.apache.hadoop.fs.Path path,
            org.apache.hadoop.fs.FSDataOutputStream ostream,
            KeyValue.KVComparator comparator,
            HFileContext fileContext) | 
| HFileBlockDecodingContext | NoOpDataBlockEncoder. newDataBlockDecodingContext(HFileContext meta) | 
| HFileBlockDecodingContext | HFileDataBlockEncoderImpl. newDataBlockDecodingContext(HFileContext fileContext) | 
| HFileBlockDecodingContext | HFileDataBlockEncoder. newDataBlockDecodingContext(HFileContext fileContext)create a encoder specific decoding context for reading. | 
| HFileBlockEncodingContext | NoOpDataBlockEncoder. newDataBlockEncodingContext(byte[] dummyHeader,
                           HFileContext meta) | 
| HFileBlockEncodingContext | HFileDataBlockEncoderImpl. newDataBlockEncodingContext(byte[] dummyHeader,
                           HFileContext fileContext) | 
| HFileBlockEncodingContext | HFileDataBlockEncoder. newDataBlockEncodingContext(byte[] headerBytes,
                           HFileContext fileContext)Create an encoder specific encoding context object for writing. | 
| private static int | HFileBlock. totalChecksumBytes(HFileContext fileContext,
                  int onDiskDataSizeWithHeader) | 
| (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 | 
|---|
| AbstractHFileWriter(CacheConfig cacheConf,
                   org.apache.hadoop.fs.FSDataOutputStream outputStream,
                   org.apache.hadoop.fs.Path path,
                   KeyValue.KVComparator comparator,
                   HFileContext fileContext) | 
| HFileBlock.AbstractFSReader(long fileSize,
                           HFileSystem hfs,
                           org.apache.hadoop.fs.Path path,
                           HFileContext fileContext) | 
| HFileBlock.FSReaderImpl(org.apache.hadoop.fs.FSDataInputStream istream,
                       long fileSize,
                       HFileContext fileContext)A constructor that reads files with the latest minor version. | 
| HFileBlock.FSReaderImpl(FSDataInputStreamWrapper stream,
                       long fileSize,
                       HFileSystem hfs,
                       org.apache.hadoop.fs.Path path,
                       HFileContext fileContext) | 
| HFileBlock.Writer(HFileDataBlockEncoder dataBlockEncoder,
                 HFileContext fileContext) | 
| HFileBlock(BlockType blockType,
          int onDiskSizeWithoutHeader,
          int uncompressedSizeWithoutHeader,
          long prevBlockOffset,
          ByteBuffer buf,
          boolean fillHeader,
          long offset,
          int onDiskDataSizeWithHeader,
          HFileContext fileContext)Creates a new  HFileblock from the given fields. | 
| HFileContext(HFileContext context)Copy constructor | 
| HFileReaderV2.EncodedScannerV2(HFileReaderV2 reader,
                              boolean cacheBlocks,
                              boolean pread,
                              boolean isCompaction,
                              HFileContext meta) | 
| HFileReaderV3.EncodedScannerV3(HFileReaderV3 reader,
                              boolean cacheBlocks,
                              boolean pread,
                              boolean isCompaction,
                              HFileContext context) | 
| HFileWriterV2(org.apache.hadoop.conf.Configuration conf,
             CacheConfig cacheConf,
             org.apache.hadoop.fs.FileSystem fs,
             org.apache.hadoop.fs.Path path,
             org.apache.hadoop.fs.FSDataOutputStream ostream,
             KeyValue.KVComparator comparator,
             HFileContext context)Constructor that takes a path, creates and closes the output stream. | 
| HFileWriterV3(org.apache.hadoop.conf.Configuration conf,
             CacheConfig cacheConf,
             org.apache.hadoop.fs.FileSystem fs,
             org.apache.hadoop.fs.Path path,
             org.apache.hadoop.fs.FSDataOutputStream ostream,
             KeyValue.KVComparator comparator,
             HFileContext fileContext)Constructor that takes a path, creates and closes the output stream. | 
| Modifier and Type | Field and Description | 
|---|---|
| private HFileContext | StoreFile.WriterBuilder. 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 | 
|---|---|
| StoreFile.WriterBuilder | StoreFile.WriterBuilder. withFileContext(HFileContext fileContext) | 
| Constructor and Description | 
|---|
| StoreFile.Writer(org.apache.hadoop.fs.FileSystem fs,
                org.apache.hadoop.fs.Path path,
                org.apache.hadoop.conf.Configuration conf,
                CacheConfig cacheConf,
                KeyValue.KVComparator comparator,
                BloomType bloomType,
                long maxKeys,
                InetSocketAddress[] favoredNodes,
                HFileContext fileContext,
                boolean shouldDropCacheBehind)Creates an HFile.Writer that also write helpful meta data. | 
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.