Package | Description |
---|---|
org.apache.hadoop.hbase | |
org.apache.hadoop.hbase.client |
Provides HBase Client
|
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.mob | |
org.apache.hadoop.hbase.regionserver | |
org.apache.hadoop.hbase.thrift2 |
Provides an HBase Thrift
service.
|
org.apache.hadoop.hbase.util |
Modifier and Type | Method and Description |
---|---|
Table |
HBaseTestingUtility.createTable(TableDescriptor htd,
byte[][] families,
byte[][] splitKeys,
BloomType type,
int blockSize,
org.apache.hadoop.conf.Configuration c)
Deprecated.
Create a table.
|
Modifier and Type | Field and Description |
---|---|
static BloomType |
ColumnFamilyDescriptorBuilder.DEFAULT_BLOOMFILTER
Default setting for whether or not to use bloomfilters.
|
Modifier and Type | Method and Description |
---|---|
BloomType |
ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor.getBloomFilterType() |
BloomType |
ColumnFamilyDescriptor.getBloomFilterType()
Returns bloom filter type used for new StoreFiles in ColumnFamily
|
Modifier and Type | Method and Description |
---|---|
ColumnFamilyDescriptorBuilder |
ColumnFamilyDescriptorBuilder.setBloomFilterType(BloomType value) |
ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor |
ColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor.setBloomFilterType(BloomType bt) |
Modifier and Type | Field and Description |
---|---|
private BloomType |
CompoundBloomFilterWriter.bloomType |
Modifier and Type | Method and Description |
---|---|
boolean |
CompoundBloomFilter.contains(Cell keyCell,
ByteBuff bloom,
BloomType type) |
private boolean |
CompoundBloomFilter.containsInternal(Cell keyCell,
ByteBuff bloom,
BloomType type) |
Constructor and Description |
---|
CompoundBloomFilterWriter(int chunkByteSizeHint,
float errorRate,
int hashType,
int maxFold,
boolean cacheOnWrite,
CellComparator comparator,
BloomType bloomType)
each chunk's size in bytes.
|
Modifier and Type | Method and Description |
---|---|
(package private) static Map<byte[],BloomType> |
HFileOutputFormat2.createFamilyBloomTypeMap(org.apache.hadoop.conf.Configuration conf)
Runs inside the task to deserialize column family to bloom filter type map from the
configuration.
|
Modifier and Type | Method and Description |
---|---|
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,
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,
Consumer<org.apache.hadoop.fs.Path> writerCreationTracker)
Creates a writer for the mob file in temp directory.
|
Modifier and Type | Field and Description |
---|---|
protected BloomType |
StoreFileReader.bloomFilterType |
private BloomType |
StoreContext.bloomFilterType |
private BloomType |
StoreContext.Builder.bloomFilterType |
private BloomType |
StoreFileWriter.bloomType |
private BloomType |
StoreFileWriter.Builder.bloomType |
private BloomType |
HStoreFile.cfBloomType
Bloom filter type specified in column family configuration.
|
Modifier and Type | Method and Description |
---|---|
BloomType |
StoreFileReader.getBloomFilterType() |
BloomType |
StoreContext.getBloomFilterType() |
static BloomType |
BloomType.valueOf(String name)
Returns the enum constant of this type with the specified name.
|
static BloomType[] |
BloomType.values()
Returns an array containing the constants of this enum type, in
the order they are declared.
|
Modifier and Type | Method and Description |
---|---|
StoreContext.Builder |
StoreContext.Builder.withBloomType(BloomType bloomFilterType) |
StoreFileWriter.Builder |
StoreFileWriter.Builder.withBloomType(BloomType bloomType) |
Constructor and Description |
---|
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(StoreFileInfo fileInfo,
BloomType cfBloomType,
CacheConfig cacheConf)
Constructor, loads a reader and it's indices, etc.
|
HStoreFile(StoreFileInfo fileInfo,
BloomType cfBloomType,
CacheConfig cacheConf,
BloomFilterMetrics metrics)
Constructor, loads a reader and it's indices, etc.
|
StoreFileWriter(org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path path,
org.apache.hadoop.conf.Configuration conf,
CacheConfig cacheConf,
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 | Method and Description |
---|---|
static BloomType |
ThriftUtilities.bloomFilterFromThrift(org.apache.hadoop.hbase.thrift2.generated.TBloomFilterType in) |
Modifier and Type | Method and Description |
---|---|
static org.apache.hadoop.hbase.thrift2.generated.TBloomFilterType |
ThriftUtilities.bloomFilterFromHBase(BloomType in) |
Modifier and Type | Field and Description |
---|---|
protected BloomType |
BloomFilterChunk.bloomType
The type of bloom
|
Modifier and Type | Method and Description |
---|---|
boolean |
BloomFilter.contains(Cell keyCell,
ByteBuff bloom,
BloomType type)
Check if the specified key is contained in the bloom filter.
|
static boolean |
BloomFilterUtil.contains(Cell cell,
ByteBuff bloomBuf,
int bloomOffset,
int bloomSize,
Hash hash,
int hashCount,
BloomType type) |
static BloomFilterChunk |
BloomFilterUtil.createBySize(int byteSizeHint,
double errorRate,
int hashType,
int foldFactor,
BloomType bloomType)
Creates a Bloom filter chunk of the given size.
|
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. |
static byte[] |
BloomFilterUtil.getBloomFilterParam(BloomType bloomFilterType,
org.apache.hadoop.conf.Configuration conf) |
Constructor and Description |
---|
BloomFilterChunk(int hashType,
BloomType bloomType) |
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.