Uses of Enum Class
org.apache.hadoop.hbase.regionserver.BloomType
Package
Description
Provides HBase Client
Provides implementations of
HFile
and HFile
BlockCache
.Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
Provides an HBase Thrift
service.
-
Uses of BloomType in org.apache.hadoop.hbase
Modifier and TypeFieldDescription(package private) BloomType
PerformanceEvaluation.TestOptions.bloomType
Modifier and TypeMethodDescriptionHBaseTestingUtility.createTable
(TableDescriptor htd, byte[][] families, byte[][] splitKeys, BloomType type, int blockSize, org.apache.hadoop.conf.Configuration c) Deprecated.Create a table.void
PerformanceEvaluation.TestOptions.setBloomType
(BloomType bloomType) -
Uses of BloomType in org.apache.hadoop.hbase.client
Modifier and TypeFieldDescriptionstatic final BloomType
ColumnFamilyDescriptorBuilder.DEFAULT_BLOOMFILTER
Default setting for whether or not to use bloomfilters.Modifier and TypeMethodDescriptionColumnFamilyDescriptor.getBloomFilterType()
Returns bloom filter type used for new StoreFiles in ColumnFamilyColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor.getBloomFilterType()
Modifier and TypeMethodDescriptionColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor.setBloomFilterType
(BloomType bt) ColumnFamilyDescriptorBuilder.setBloomFilterType
(BloomType value) -
Uses of BloomType in org.apache.hadoop.hbase.io.hfile
Modifier and TypeMethodDescriptionboolean
private boolean
CompoundBloomFilter.containsInternal
(Cell keyCell, ByteBuff bloom, BloomType type) ModifierConstructorDescriptionCompoundBloomFilterWriter
(int chunkByteSizeHint, float errorRate, int hashType, int maxFold, boolean cacheOnWrite, CellComparator comparator, BloomType bloomType) each chunk's size in bytes. -
Uses of BloomType in org.apache.hadoop.hbase.mapreduce
Modifier and TypeMethodDescriptionHFileOutputFormat2.createFamilyBloomTypeMap
(org.apache.hadoop.conf.Configuration conf) Runs inside the task to deserialize column family to bloom filter type map from the configuration. -
Uses of BloomType in org.apache.hadoop.hbase.mob
Modifier and TypeMethodDescriptionstatic 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. -
Uses of BloomType in org.apache.hadoop.hbase.regionserver
Modifier and TypeFieldDescriptionprivate final BloomType
StoreContext.bloomFilterType
private BloomType
StoreContext.Builder.bloomFilterType
protected BloomType
StoreFileReader.bloomFilterType
private final BloomType
StoreFileWriter.bloomType
private BloomType
StoreFileWriter.Builder.bloomType
private final BloomType
StoreFileWriter.SingleStoreFileWriter.bloomType
private final BloomType
HStoreFile.cfBloomType
Bloom filter type specified in column family configuration.Modifier and TypeMethodDescriptionStoreContext.getBloomFilterType()
StoreFileReader.getBloomFilterType()
static BloomType
Returns the enum constant of this class with the specified name.static BloomType[]
BloomType.values()
Returns an array containing the constants of this enum class, in the order they are declared.Modifier and TypeMethodDescriptionStoreContext.Builder.withBloomType
(BloomType bloomFilterType) StoreFileWriter.Builder.withBloomType
(BloomType bloomType) ModifierConstructorDescriptionHStoreFile
(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path p, org.apache.hadoop.conf.Configuration conf, CacheConfig cacheConf, BloomType cfBloomType, boolean primaryReplica, StoreFileTracker sft) 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.private
SingleStoreFileWriter
(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.private
StoreFileWriter
(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path liveFilePath, org.apache.hadoop.fs.Path historicalFilePath, org.apache.hadoop.conf.Configuration conf, CacheConfig cacheConf, BloomType bloomType, long maxKeys, InetSocketAddress[] favoredNodes, HFileContext fileContext, boolean shouldDropCacheBehind, Supplier<Collection<HStoreFile>> compactedFilesSupplier, CellComparator comparator, int maxVersions, boolean newVersionBehavior) Creates an HFile.Writer that also write helpful meta data. -
Uses of BloomType in org.apache.hadoop.hbase.thrift2
Modifier and TypeMethodDescriptionstatic BloomType
ThriftUtilities.bloomFilterFromThrift
(org.apache.hadoop.hbase.thrift2.generated.TBloomFilterType in) Modifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.thrift2.generated.TBloomFilterType
ThriftUtilities.bloomFilterFromHBase
(BloomType in) -
Uses of BloomType in org.apache.hadoop.hbase.tool
Modifier and TypeMethodDescriptionprivate static StoreFileWriter
BulkLoadHFilesTool.initStoreFileWriter
(org.apache.hadoop.conf.Configuration conf, Cell cell, HFileContext hFileContext, CacheConfig cacheConf, BloomType bloomFilterType, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path outFile, AsyncTableRegionLocator loc) -
Uses of BloomType in org.apache.hadoop.hbase.util
Modifier and TypeFieldDescriptionprotected BloomType
BloomFilterChunk.bloomType
The type of bloomprotected BloomType
LoadTestTool.bloomType
Modifier and TypeMethodDescriptionboolean
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 ofHStoreFile
writing.static byte[]
BloomFilterUtil.getBloomFilterParam
(BloomType bloomFilterType, org.apache.hadoop.conf.Configuration conf)