public static interface HFile.Reader extends Closeable, HFile.CachingBlockReader
HFile.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> midKey() throws IOException
IOExceptionlong length()
long getEntries()
long indexSize()
Optional<byte[]> getFirstRowKey()
Optional<byte[]> getLastRowKey()
FixedFileTrailer getTrailer()
org.apache.hadoop.hbase.io.hfile.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)
org.apache.hadoop.hbase.io.hfile.HFileBlock.FSReader getUncachedBlockReader()
boolean prefetchComplete()
void unbufferStream()
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.