Package | Description |
---|---|
org.apache.hadoop.hbase.coprocessor |
Table of Contents
|
org.apache.hadoop.hbase.io | |
org.apache.hadoop.hbase.io.hfile |
Provides implementations of
HFile and HFile
BlockCache . |
org.apache.hadoop.hbase.mob | |
org.apache.hadoop.hbase.mob.compactions | |
org.apache.hadoop.hbase.regionserver | |
org.apache.hadoop.hbase.tmpl.regionserver | |
org.apache.hadoop.hbase.util | |
org.apache.hadoop.hbase.util.hbck |
Modifier and Type | Method and Description |
---|---|
default StoreFileReader |
RegionObserver.postStoreFileReaderOpen(ObserverContext<RegionCoprocessorEnvironment> ctx,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path p,
FSDataInputStreamWrapper in,
long size,
CacheConfig cacheConf,
Reference r,
StoreFileReader reader)
Deprecated.
For Phoenix only, StoreFileReader is not a stable interface.
|
default StoreFileReader |
RegionObserver.preStoreFileReaderOpen(ObserverContext<RegionCoprocessorEnvironment> ctx,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path p,
FSDataInputStreamWrapper in,
long size,
CacheConfig cacheConf,
Reference r,
StoreFileReader reader)
Deprecated.
For Phoenix only, StoreFileReader is not a stable interface.
|
Constructor and Description |
---|
HalfStoreFileReader(org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path p,
CacheConfig cacheConf,
Reference r,
boolean isPrimaryReplicaStoreFile,
AtomicInteger refCount,
boolean shared,
org.apache.hadoop.conf.Configuration conf)
Creates a half file reader for a normal hfile.
|
HalfStoreFileReader(org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path p,
FSDataInputStreamWrapper in,
long size,
CacheConfig cacheConf,
Reference r,
boolean isPrimaryReplicaStoreFile,
AtomicInteger refCount,
boolean shared,
org.apache.hadoop.conf.Configuration conf)
Creates a half file reader for a hfile referred to by an hfilelink.
|
Modifier and Type | Field and Description |
---|---|
private CacheConfig |
HFileBlockIndex.BlockIndexWriter.cacheConf
CacheConfig, or null if cache-on-write is disabled
|
private CacheConfig |
HFileReaderImpl.cacheConf
Block cache configuration.
|
protected CacheConfig |
HFileWriterImpl.cacheConf
Cache configuration for caching data on write.
|
protected CacheConfig |
HFile.WriterFactory.cacheConf |
static CacheConfig |
CacheConfig.DISABLED
Disabled cache configuration
|
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,
FSDataInputStreamWrapper fsdis,
long size,
CacheConfig cacheConf,
boolean primaryReplicaReader,
org.apache.hadoop.conf.Configuration conf)
The sockets and the file descriptors held by the method parameter
FSDataInputStreamWrapper passed will be freed after its usage so caller needs to ensure
that no other threads have access to the same passed reference. |
(package private) static HFile.Reader |
HFile.createReaderFromStream(org.apache.hadoop.fs.Path path,
org.apache.hadoop.fs.FSDataInputStream fsdis,
long size,
CacheConfig cacheConf,
org.apache.hadoop.conf.Configuration conf)
This factory method is used only by unit tests.
|
(package private) HFileBlock |
HFileBlock.Writer.getBlockForCaching(CacheConfig cacheConf)
Creates a new HFileBlock.
|
static HFile.WriterFactory |
HFile.getWriterFactory(org.apache.hadoop.conf.Configuration conf,
CacheConfig cacheConf)
Returns the factory to be used to create
HFile writers |
private static HFile.Reader |
HFile.openReader(org.apache.hadoop.fs.Path path,
FSDataInputStreamWrapper fsdis,
long size,
CacheConfig cacheConf,
HFileSystem hfs,
boolean primaryReplicaReader,
org.apache.hadoop.conf.Configuration conf)
Method returns the reader given the specified arguments.
|
Constructor and Description |
---|
BlockIndexWriter(HFileBlock.Writer blockWriter,
CacheConfig cacheConf,
String nameForCaching)
Creates a multi-level block index writer.
|
CacheConfig(CacheConfig cacheConf)
Constructs a cache configuration copied from the specified configuration.
|
HFileReaderImpl(org.apache.hadoop.fs.Path path,
FixedFileTrailer trailer,
FSDataInputStreamWrapper fsdis,
long fileSize,
CacheConfig cacheConf,
HFileSystem hfs,
boolean primaryReplicaReader,
org.apache.hadoop.conf.Configuration conf)
Opens a HFile.
|
HFileReaderImpl(org.apache.hadoop.fs.Path path,
FixedFileTrailer trailer,
FSDataInputStreamWrapper fsdis,
long fileSize,
CacheConfig cacheConf,
HFileSystem hfs,
org.apache.hadoop.conf.Configuration conf)
Deprecated.
|
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) |
WriterFactory(org.apache.hadoop.conf.Configuration conf,
CacheConfig cacheConf) |
Modifier and Type | Method and Description |
---|---|
static void |
MobUtils.cleanExpiredMobFiles(org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.conf.Configuration conf,
TableName tableName,
ColumnFamilyDescriptor columnDescriptor,
CacheConfig cacheConfig,
long current)
Cleans the expired mob files.
|
static org.apache.hadoop.fs.Path |
MobUtils.commitFile(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path sourceFile,
org.apache.hadoop.fs.Path targetPath,
CacheConfig cacheConfig)
Commits the mob file.
|
static CachedMobFile |
CachedMobFile.create(org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path path,
org.apache.hadoop.conf.Configuration conf,
CacheConfig cacheConf) |
static MobFile |
MobFile.create(org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path path,
org.apache.hadoop.conf.Configuration conf,
CacheConfig cacheConf)
Creates an instance of the MobFile.
|
static StoreFileWriter |
MobUtils.createDelFileWriter(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
ColumnFamilyDescriptor family,
String date,
org.apache.hadoop.fs.Path basePath,
long maxKeyCount,
Compression.Algorithm compression,
byte[] startKey,
CacheConfig cacheConfig,
Encryption.Context cryptoContext)
Creates a writer for the del file in temp directory.
|
static StoreFileWriter |
MobUtils.createRefFileWriter(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
ColumnFamilyDescriptor family,
org.apache.hadoop.fs.Path basePath,
long maxKeyCount,
CacheConfig cacheConfig,
Encryption.Context cryptoContext,
boolean isCompaction)
Creates a writer for the ref file in temp directory.
|
static StoreFileWriter |
MobUtils.createWriter(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
ColumnFamilyDescriptor family,
MobFileName mobFileName,
org.apache.hadoop.fs.Path basePath,
long maxKeyCount,
Compression.Algorithm compression,
CacheConfig cacheConfig,
Encryption.Context cryptoContext,
boolean isCompaction)
Creates a writer for the mob file in temp directory.
|
static StoreFileWriter |
MobUtils.createWriter(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
ColumnFamilyDescriptor family,
org.apache.hadoop.fs.Path path,
long maxKeyCount,
Compression.Algorithm compression,
CacheConfig cacheConfig,
Encryption.Context cryptoContext,
ChecksumType checksumType,
int bytesPerChecksum,
int blocksize,
BloomType bloomType,
boolean isCompaction)
Creates a writer for the mob file in temp directory.
|
static StoreFileWriter |
MobUtils.createWriter(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
ColumnFamilyDescriptor family,
String date,
org.apache.hadoop.fs.Path basePath,
long maxKeyCount,
Compression.Algorithm compression,
byte[] startKey,
CacheConfig cacheConfig,
Encryption.Context cryptoContext,
boolean isCompaction)
Creates a writer for the mob file in temp directory.
|
static StoreFileWriter |
MobUtils.createWriter(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
ColumnFamilyDescriptor family,
String date,
org.apache.hadoop.fs.Path basePath,
long maxKeyCount,
Compression.Algorithm compression,
String startKey,
CacheConfig cacheConfig,
Encryption.Context cryptoContext,
boolean isCompaction)
Creates a writer for the mob file in temp directory.
|
MobFile |
MobFileCache.openFile(org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path path,
CacheConfig cacheConf)
Opens a mob file.
|
private static void |
MobUtils.validateMobFile(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path path,
CacheConfig cacheConfig,
boolean primaryReplica)
Validates a mob file by opening and closing it.
|
Modifier and Type | Field and Description |
---|---|
private CacheConfig |
PartitionedMobCompactor.compactionCacheConfig |
Modifier and Type | Field and Description |
---|---|
private CacheConfig |
HStoreFile.cacheConf |
protected CacheConfig |
HStore.cacheConf |
private CacheConfig |
StoreFileWriter.Builder.cacheConf |
Modifier and Type | Method and Description |
---|---|
CacheConfig |
HStoreFile.getCacheConf() |
CacheConfig |
HStore.getCacheConfig()
Used for tests.
|
Modifier and Type | Method and Description |
---|---|
StoreFileReader |
StoreFileInfo.open(org.apache.hadoop.fs.FileSystem fs,
CacheConfig cacheConf,
boolean canUseDropBehind,
long readahead,
boolean isPrimaryReplicaStoreFile,
AtomicInteger refCount,
boolean shared)
Open a Reader for the StoreFile
|
StoreFileReader |
RegionCoprocessorHost.postStoreFileReaderOpen(org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path p,
FSDataInputStreamWrapper in,
long size,
CacheConfig cacheConf,
Reference r,
StoreFileReader reader) |
StoreFileReader |
RegionCoprocessorHost.preStoreFileReaderOpen(org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path p,
FSDataInputStreamWrapper in,
long size,
CacheConfig cacheConf,
Reference r) |
Constructor and Description |
---|
Builder(org.apache.hadoop.conf.Configuration conf,
CacheConfig cacheConf,
org.apache.hadoop.fs.FileSystem fs) |
HStoreFile(org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path p,
org.apache.hadoop.conf.Configuration conf,
CacheConfig cacheConf,
BloomType cfBloomType,
boolean primaryReplica)
Constructor, loads a reader and it's indices, etc.
|
HStoreFile(org.apache.hadoop.fs.FileSystem fs,
StoreFileInfo fileInfo,
org.apache.hadoop.conf.Configuration conf,
CacheConfig cacheConf,
BloomType cfBloomType,
boolean primaryReplica)
Constructor, loads a reader and it's indices, etc.
|
StoreFileReader(org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path path,
CacheConfig cacheConf,
boolean primaryReplicaStoreFile,
AtomicInteger refCount,
boolean shared,
org.apache.hadoop.conf.Configuration conf) |
StoreFileReader(org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path path,
FSDataInputStreamWrapper in,
long size,
CacheConfig cacheConf,
boolean primaryReplicaStoreFile,
AtomicInteger refCount,
boolean shared,
org.apache.hadoop.conf.Configuration conf) |
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.
|
Modifier and Type | Field and Description |
---|---|
private CacheConfig |
BlockCacheTmplImpl.cacheConfig |
private CacheConfig |
BlockCacheViewTmplImpl.cacheConfig |
private CacheConfig |
BlockCacheTmpl.ImplData.m_cacheConfig |
private CacheConfig |
BlockCacheViewTmpl.ImplData.m_cacheConfig |
Modifier and Type | Method and Description |
---|---|
CacheConfig |
BlockCacheTmpl.ImplData.getCacheConfig() |
CacheConfig |
BlockCacheViewTmpl.ImplData.getCacheConfig() |
Modifier and Type | Method and Description |
---|---|
private void |
BlockCacheTmplImpl.__jamon_innerUnit__bc_config(Writer jamonWriter,
CacheConfig cacheConfig) |
org.jamon.Renderer |
BlockCacheTmpl.makeRenderer(CacheConfig cacheConfig,
org.apache.hadoop.conf.Configuration config,
BlockCache bc) |
org.jamon.Renderer |
BlockCacheViewTmpl.makeRenderer(CacheConfig cacheConfig,
org.apache.hadoop.conf.Configuration conf,
String bcn,
String bcv,
BlockCache blockCache) |
void |
BlockCacheTmpl.render(Writer jamonWriter,
CacheConfig cacheConfig,
org.apache.hadoop.conf.Configuration config,
BlockCache bc) |
void |
BlockCacheViewTmpl.render(Writer jamonWriter,
CacheConfig cacheConfig,
org.apache.hadoop.conf.Configuration conf,
String bcn,
String bcv,
BlockCache blockCache) |
void |
BlockCacheTmpl.renderNoFlush(Writer jamonWriter,
CacheConfig cacheConfig,
org.apache.hadoop.conf.Configuration config,
BlockCache bc) |
void |
BlockCacheViewTmpl.renderNoFlush(Writer jamonWriter,
CacheConfig cacheConfig,
org.apache.hadoop.conf.Configuration conf,
String bcn,
String bcv,
BlockCache blockCache) |
void |
BlockCacheTmpl.ImplData.setCacheConfig(CacheConfig cacheConfig) |
void |
BlockCacheViewTmpl.ImplData.setCacheConfig(CacheConfig cacheConfig) |
Modifier and Type | Method and Description |
---|---|
static BloomFilterWriter |
BloomFilterFactory.createDeleteBloomAtWrite(org.apache.hadoop.conf.Configuration conf,
CacheConfig cacheConf,
int maxKeys,
HFile.Writer writer)
Creates a new Delete Family Bloom filter at the time of
HStoreFile writing. |
static BloomFilterWriter |
BloomFilterFactory.createGeneralBloomAtWrite(org.apache.hadoop.conf.Configuration conf,
CacheConfig cacheConf,
BloomType bloomType,
int maxKeys,
HFile.Writer writer)
Creates a new general (Row or RowCol) Bloom filter at the time of
HStoreFile writing. |
Modifier and Type | Field and Description |
---|---|
(package private) CacheConfig |
HFileCorruptionChecker.cacheConf |
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.