public static interface HFile.Reader extends Closeable, HFile.CachingBlockReader
HFile.| Modifier and Type | Method and Description | 
|---|---|
| void | close(boolean evictOnClose)Close method with optional evictOnClose | 
| CellComparator | getComparator() | 
| Compression.Algorithm | getCompressionAlgorithm() | 
| DataBlockEncoding | getDataBlockEncoding() | 
| HFileBlockIndex.BlockIndexReader | getDataBlockIndexReader() | 
| DataInput | getDeleteBloomFilterMetadata()Retrieves delete family Bloom filter metadata as appropriate for each
  HFileversion. | 
| DataBlockEncoding | getEffectiveEncodingInCache(boolean isCompaction) | 
| long | getEntries() | 
| HFileContext | getFileContext()Return the file context of the HFile this reader belongs to | 
| Optional<Cell> | getFirstKey() | 
| Optional<byte[]> | getFirstRowKey() | 
| DataInput | getGeneralBloomFilterMetadata()Retrieves general Bloom filter metadata as appropriate for each
  HFileversion. | 
| Optional<Cell> | getLastKey() | 
| Optional<byte[]> | getLastRowKey() | 
| HFileBlock | getMetaBlock(String metaBlockName,
            boolean cacheBlock) | 
| String | getName()Returns this reader's "name". | 
| org.apache.hadoop.fs.Path | getPath() | 
| HFileScanner | getScanner(boolean cacheBlocks,
          boolean pread) | 
| HFileScanner | getScanner(boolean cacheBlocks,
          boolean pread,
          boolean isCompaction) | 
| FixedFileTrailer | getTrailer() | 
| HFileBlock.FSReader | getUncachedBlockReader() | 
| boolean | hasMVCCInfo() | 
| long | indexSize() | 
| boolean | isDecodeMemStoreTS() | 
| boolean | isPrimaryReplicaReader() | 
| long | length() | 
| Map<byte[],byte[]> | loadFileInfo() | 
| Optional<Cell> | midKey() | 
| boolean | prefetchComplete() | 
| boolean | shouldIncludeMemStoreTS() | 
| void | unbufferStream()To close the stream's socket. | 
readBlock, returnBlockString getName()
CellComparator getComparator()
HFileScanner getScanner(boolean cacheBlocks, boolean pread, boolean isCompaction)
HFileBlock getMetaBlock(String metaBlockName, boolean cacheBlock) throws IOException
IOExceptionMap<byte[],byte[]> loadFileInfo() throws IOException
IOExceptionOptional<Cell> getLastKey()
Optional<Cell> midKey() throws IOException
IOExceptionlong length()
long getEntries()
Optional<Cell> getFirstKey()
long indexSize()
Optional<byte[]> getFirstRowKey()
Optional<byte[]> getLastRowKey()
FixedFileTrailer getTrailer()
HFileBlockIndex.BlockIndexReader getDataBlockIndexReader()
HFileScanner getScanner(boolean cacheBlocks, boolean pread)
Compression.Algorithm getCompressionAlgorithm()
DataInput getGeneralBloomFilterMetadata() throws IOException
HFile version.
 Knows nothing about how that metadata is structured.IOExceptionDataInput getDeleteBloomFilterMetadata() throws IOException
HFile  version.
 Knows nothing about how that metadata is structured.IOExceptionorg.apache.hadoop.fs.Path getPath()
void close(boolean evictOnClose) throws IOException
IOExceptionDataBlockEncoding getDataBlockEncoding()
boolean hasMVCCInfo()
HFileContext getFileContext()
boolean isPrimaryReplicaReader()
boolean shouldIncludeMemStoreTS()
boolean isDecodeMemStoreTS()
DataBlockEncoding getEffectiveEncodingInCache(boolean isCompaction)
HFileBlock.FSReader getUncachedBlockReader()
boolean prefetchComplete()
void unbufferStream()
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.