Package | Description |
---|---|
org.apache.hadoop.hbase.io.hfile |
Provides implementations of
HFile and HFile
BlockCache . |
org.apache.hadoop.hbase.mapreduce |
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
|
org.apache.hadoop.hbase.regionserver | |
org.apache.hadoop.hbase.util |
Modifier and Type | Class and Description |
---|---|
class |
HFilePreadReader
Implementation of
HFile.Reader to deal with pread. |
class |
HFileReaderImpl
Implementation that can handle all hfile versions of
HFile.Reader . |
class |
HFileStreamReader
Implementation of
HFile.Reader to deal with stream read do not perform any prefetch
operations (HFilePreadReader will do this). |
Modifier and Type | Field and Description |
---|---|
protected HFile.Reader |
HFileReaderImpl.HFileScannerImpl.reader |
private HFile.Reader |
CompoundBloomFilter.reader
Used to load chunks on demand
|
Modifier and Type | Method and Description |
---|---|
static HFile.Reader |
HFile.createReader(org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path path,
CacheConfig cacheConf,
boolean primaryReplicaReader,
org.apache.hadoop.conf.Configuration conf) |
static HFile.Reader |
HFile.createReader(org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path path,
org.apache.hadoop.conf.Configuration conf)
Creates reader with cache configuration disabled
|
static HFile.Reader |
HFile.createReader(ReaderContext context,
HFileInfo fileInfo,
CacheConfig cacheConf,
org.apache.hadoop.conf.Configuration conf)
Method returns the reader given the specified arguments.
|
HFile.Reader |
HFileReaderImpl.HFileScannerImpl.getReader() |
HFile.Reader |
HFileScanner.getReader()
Returns Reader that underlies this Scanner instance.
|
Modifier and Type | Method and Description |
---|---|
void |
HFileInfo.initMetaAndIndex(HFile.Reader reader)
should be called after initTrailerAndContext
|
private void |
HFilePrettyPrinter.printMeta(HFile.Reader reader,
Map<byte[],byte[]> fileInfo) |
Constructor and Description |
---|
CompoundBloomFilter(DataInput meta,
HFile.Reader reader,
BloomFilterMetrics metrics)
De-serialization for compound Bloom filter metadata.
|
EncodedScanner(HFile.Reader reader,
boolean cacheBlocks,
boolean pread,
boolean isCompaction,
HFileContext meta,
org.apache.hadoop.conf.Configuration conf) |
HFileScannerImpl(HFile.Reader reader,
boolean cacheBlocks,
boolean pread,
boolean isCompaction) |
Modifier and Type | Field and Description |
---|---|
private HFile.Reader |
HFileInputFormat.HFileRecordReader.in |
Modifier and Type | Field and Description |
---|---|
private HFile.Reader |
StoreFileReader.reader |
Modifier and Type | Method and Description |
---|---|
HFile.Reader |
StoreFileReader.getHFileReader() |
Constructor and Description |
---|
StoreFileReader(HFile.Reader reader,
AtomicInteger refCount,
ReaderContext context,
org.apache.hadoop.conf.Configuration conf) |
Modifier and Type | Method and Description |
---|---|
static BloomFilter |
BloomFilterFactory.createFromMeta(DataInput meta,
HFile.Reader reader)
Instantiates the correct Bloom filter class based on the version provided in the meta block
data.
|
static BloomFilter |
BloomFilterFactory.createFromMeta(DataInput meta,
HFile.Reader reader,
BloomFilterMetrics metrics) |
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.