Uses of Class
org.apache.hadoop.hbase.regionserver.HStore
Package
Description
-
Uses of HStore in org.apache.hadoop.hbase
Modifier and TypeMethodDescriptionHBaseTestingUtility.getFromStoreFile
(HStore store, byte[] row, NavigableSet<byte[]> columns) Deprecated.Do a small get/scan against one store.HBaseTestingUtility.getFromStoreFile
(HStore store, Get get) Deprecated.Do a small get/scan against one store. -
Uses of HStore in org.apache.hadoop.hbase.mob
Modifier and TypeMethodDescriptionprotected void
MobStoreEngine.createCompactor
(org.apache.hadoop.conf.Configuration conf, HStore store) Creates the DefaultMobCompactor.protected void
MobStoreEngine.createStoreFlusher
(org.apache.hadoop.conf.Configuration conf, HStore store) ModifierConstructorDescriptionDefaultMobStoreCompactor
(org.apache.hadoop.conf.Configuration conf, HStore store) DefaultMobStoreFlusher
(org.apache.hadoop.conf.Configuration conf, HStore store) -
Uses of HStore in org.apache.hadoop.hbase.regionserver
Modifier and TypeClassDescriptionclass
The store implementation to save MOBs (medium objects), it extends the HStore.Modifier and TypeFieldDescriptionprivate HStore
CompactedHFilesDischargeHandler.store
private HStore
CompactingMemStore.store
private final HStore
CompactSplit.CompactionRunner.store
protected HStore
StoreFlusher.store
protected final HStore
StoreScanner.store
Modifier and TypeFieldDescriptionprivate final ConcurrentMap<HStore,
Long> HRegion.lastStoreFlushTimeMap
private Collection<HStore>
FlushNonSloppyStoresFirstPolicy.regularStores
private Collection<HStore>
FlushNonSloppyStoresFirstPolicy.sloppyStores
HRegion.stores
Modifier and TypeMethodDescriptionCompactingMemStore.getStore()
private static HStore
CompactionTool.CompactionWorker.getStore
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path tableDir, TableDescriptor htd, RegionInfo hri, String familyName) HRegion.getStore
(byte[] column) private HStore
Return HStore instance.protected HStore
HRegion.instantiateHStore
(ColumnFamilyDescriptor family, boolean warmup) Modifier and TypeMethodDescriptionprivate Collection<HStore>
HRegion.getSpecificStores
(List<byte[]> families) get stores which matches the specified familiesHRegion.getStores()
private Collection<HStore>
HRegion.getStoresToFlush
(org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.FlushDescriptor flushDesc) FlushAllLargeStoresPolicy.selectStoresToFlush()
FlushAllStoresPolicy.selectStoresToFlush()
FlushNonSloppyStoresFirstPolicy.selectStoresToFlush()
Returns the stores need to be flushed.abstract Collection<HStore>
FlushPolicy.selectStoresToFlush()
Returns the stores need to be flushed.Modifier and TypeMethodDescriptionprivate void
HRegion.applyToMemStore
(HStore store, List<ExtendedCell> cells, boolean delta, MemStoreSizing memstoreAccounting) private void
BrokenStoreFileCleaner.cleanFileIfNeeded
(org.apache.hadoop.fs.FileStatus file, HStore store, AtomicLong deletedFiles, AtomicLong failedDeletes) boolean
HRegion.compact
(CompactionContext compaction, HStore store, ThroughputController throughputController) Called by compaction thread and after region is opened to compact the HStores if necessary.boolean
HRegion.compact
(CompactionContext compaction, HStore store, ThroughputController throughputController, User user) We are trying to remove / relax the region read lock for compaction.static StoreEngine<?,
?, ?, ?> StoreEngine.create
(HStore store, org.apache.hadoop.conf.Configuration conf, CellComparator cellComparator) Create the StoreEngine configured for the given Store.protected void
DefaultStoreEngine.createCompactionPolicy
(org.apache.hadoop.conf.Configuration conf, HStore store) protected void
DefaultStoreEngine.createCompactor
(org.apache.hadoop.conf.Configuration conf, HStore store) protected void
DateTieredStoreEngine.createComponents
(org.apache.hadoop.conf.Configuration conf, HStore store, CellComparator kvComparator) protected void
DefaultStoreEngine.createComponents
(org.apache.hadoop.conf.Configuration conf, HStore store, CellComparator kvComparator) protected abstract void
StoreEngine.createComponents
(org.apache.hadoop.conf.Configuration conf, HStore store, CellComparator cellComparator) Create the StoreEngine's components.protected void
StripeStoreEngine.createComponents
(org.apache.hadoop.conf.Configuration conf, HStore store, CellComparator comparator) protected final void
StoreEngine.createComponentsOnce
(org.apache.hadoop.conf.Configuration conf, HStore store, CellComparator cellComparator) private InternalScanner
MemStoreCompactorSegmentsIterator.createScanner
(HStore store, List<KeyValueScanner> scanners) Creates the scanner for compacting the pipeline.protected StoreEngine<?,
?, ?, ?> HMobStore.createStoreEngine
(HStore store, org.apache.hadoop.conf.Configuration conf, CellComparator cellComparator) Creates the mob store engine.protected StoreEngine<?,
?, ?, ?> HStore.createStoreEngine
(HStore store, org.apache.hadoop.conf.Configuration conf, CellComparator kvComparator) Creates the store engine configured for the given Store.private StoreFileTracker
StoreEngine.createStoreFileTracker
(org.apache.hadoop.conf.Configuration conf, HStore store) protected void
DefaultStoreEngine.createStoreFlusher
(org.apache.hadoop.conf.Configuration conf, HStore store) private void
BrokenStoreFileCleaner.deleteFile
(org.apache.hadoop.fs.FileStatus file, HStore store, AtomicLong deletedFiles, AtomicLong failedDeletes) private MemStoreSize
HRegion.doDropStoreMemStoreContentsForSeqId
(HStore s, long currentSeqId) private MemStoreSize
HRegion.dropMemStoreContentsForSeqId
(long seqId, HStore store) Drops the memstore contents after replaying a flush descriptor or region open event replay if the memstore edits have seqNums smaller than the given seq idprivate String
CompactSplit.getStoreNameForUnderCompaction
(HStore store) private boolean
BrokenStoreFileCleaner.isActiveStorefile
(org.apache.hadoop.fs.FileStatus file, HStore store) private boolean
BrokenStoreFileCleaner.isCompactedFile
(org.apache.hadoop.fs.FileStatus file, HStore store) private boolean
BrokenStoreFileCleaner.isCompactionResultFile
(org.apache.hadoop.fs.FileStatus file, HStore store) boolean
CompactSplit.isUnderCompaction
(HStore s) Check if this store is under compactionvoid
RegionCoprocessorHost.postCompact
(HStore store, HStoreFile resultFile, CompactionLifeCycleTracker tracker, CompactionRequest request, User user) Called after the store compaction has completed.void
RegionCoprocessorHost.postCompactSelection
(HStore store, List<HStoreFile> selected, CompactionLifeCycleTracker tracker, CompactionRequest request, User user) Called after theHStoreFile
s to be compacted have been selected from the available candidates.void
RegionCoprocessorHost.postFlush
(HStore store, HStoreFile storeFile, FlushLifeCycleTracker tracker) Invoked after a memstore flushvoid
RegionCoprocessorHost.postMemStoreCompaction
(HStore store) Invoked after in memory compaction.RegionCoprocessorHost.preCompact
(HStore store, InternalScanner scanner, ScanType scanType, CompactionLifeCycleTracker tracker, CompactionRequest request, User user) Called prior to rewriting the store files selected for compactionRegionCoprocessorHost.preCompactScannerOpen
(HStore store, ScanType scanType, CompactionLifeCycleTracker tracker, CompactionRequest request, User user) Called prior to opening store scanner for compaction.boolean
RegionCoprocessorHost.preCompactSelection
(HStore store, List<HStoreFile> candidates, CompactionLifeCycleTracker tracker, User user) Called prior to selecting theHStoreFile
s for compaction from the list of currently available candidates.RegionCoprocessorHost.preFlush
(HStore store, InternalScanner scanner, FlushLifeCycleTracker tracker) Invoked before a memstore flushRegionCoprocessorHost.preFlushScannerOpen
(HStore store, FlushLifeCycleTracker tracker) Invoked before create StoreScanner for flush.void
RegionCoprocessorHost.preMemStoreCompaction
(HStore store) Invoked before in memory compaction.RegionCoprocessorHost.preMemStoreCompactionCompact
(HStore store, InternalScanner scanner) Invoked before compacting memstore.RegionCoprocessorHost.preMemStoreCompactionCompactScannerOpen
(HStore store) Invoked before create StoreScanner for in memory compaction.RegionCoprocessorHost.preStoreScannerOpen
(HStore store, Scan scan) Called before open store scanner for user scan.private List<ExtendedCell>
HRegion.MutationBatchOperation.reckonDeltasByStore
(HStore store, Mutation mutation, long now, List<ExtendedCell> deltas, List<ExtendedCell> results) Reckon the Cells to apply to WAL, memstore, and to return to the Client in passed column family/Store.void
CompactSplit.requestCompaction
(HRegion region, HStore store, String why, int priority, CompactionLifeCycleTracker tracker, User user) protected void
CompactSplit.requestCompactionInternal
(HRegion region, HStore store, String why, int priority, boolean selectNow, CompactionLifeCycleTracker tracker, CompactSplit.CompactionCompleteTracker completeTracker, User user) void
CompactSplit.requestSystemCompaction
(HRegion region, HStore store, String why) void
CompactSplit.requestSystemCompaction
(HRegion region, HStore store, String why, boolean giveUpIfRequestedOrCompacting) protected void
HRegion.restoreEdit
(HStore s, ExtendedCell cell, MemStoreSizing memstoreAccounting) Used by testsprivate Optional<CompactionContext>
CompactSplit.selectCompaction
(HRegion region, HStore store, int priority, CompactionLifeCycleTracker tracker, CompactSplit.CompactionCompleteTracker completeTracker, User user) protected List<KeyValueScanner>
StoreScanner.selectScannersFrom
(HStore store, List<? extends KeyValueScanner> allScanners) Filters the given list of scanners using Bloom filter, time range, and TTL.protected boolean
FlushAllLargeStoresPolicy.shouldFlush
(HStore store) protected boolean
FlushLargeStoresPolicy.shouldFlush
(HStore store) (package private) boolean
HRegion.shouldFlushStore
(HStore store) Should the store be flushed because it is old enough.boolean
KeyValueScanner.shouldUseScanner
(Scan scan, HStore store, long oldestUnexpiredTS) Allows to filter out scanners (both StoreFile and memstore) that we don't want to use based on criteria such as Bloom filters and timestamp ranges.boolean
NonLazyKeyValueScanner.shouldUseScanner
(Scan scan, HStore store, long oldestUnexpiredTS) boolean
SegmentScanner.shouldUseScanner
(Scan scan, HStore store, long oldestUnexpiredTS) This functionality should be resolved in the higher level which is MemStoreScanner, currently returns true as default.boolean
StoreFileScanner.shouldUseScanner
(Scan scan, HStore store, long oldestUnexpiredTS) Modifier and TypeMethodDescriptionMetricsRegionServerWrapperImpl.RegionMetricAggregate.aggregateStores
(List<HStore> stores) private HRegion.FlushResultImpl
HRegion.internalFlushcache
(Collection<HStore> storesToFlush, MonitoredTask status, boolean writeFlushWalMarker, FlushLifeCycleTracker tracker) Flushing given stores.protected HRegion.FlushResultImpl
HRegion.internalFlushcache
(WAL wal, long myseqid, Collection<HStore> storesToFlush, MonitoredTask status, boolean writeFlushWalMarker, FlushLifeCycleTracker tracker) Flush the memstore.(package private) HRegion.FlushResultImpl
HRegion.internalFlushCacheAndCommit
(WAL wal, MonitoredTask status, HRegion.PrepareFlushResult prepareResult, Collection<HStore> storesToFlush) protected HRegion.PrepareFlushResult
HRegion.internalPrepareFlushCache
(WAL wal, long myseqid, Collection<HStore> storesToFlush, MonitoredTask status, boolean writeFlushWalMarker, FlushLifeCycleTracker tracker) private boolean
HRegion.isAllFamilies
(Collection<HStore> families) Returns True if passed Set is all families in the region.private long
HRegion.loadRecoveredHFilesIfAny
(Collection<HStore> stores) private void
HRegion.logFatLineOnFlush
(Collection<HStore> storesToFlush, long sequenceId) Utility method broken out of internalPrepareFlushCache so that method is smaller.ModifierConstructorDescriptionCompactedHFilesDischargeHandler
(Server server, EventType eventType, HStore store) CompactingMemStore
(org.apache.hadoop.conf.Configuration conf, CellComparator c, HStore store, RegionServicesForStores regionServices, MemoryCompactionPolicy compactionPolicy) CompactionRunner
(HStore store, HRegion region, CompactionContext compaction, CompactionLifeCycleTracker tracker, CompactSplit.CompactionCompleteTracker completeTracker, ThreadPoolExecutor parent, User user) DefaultStoreFlusher
(org.apache.hadoop.conf.Configuration conf, HStore store) MemStoreCompactorSegmentsIterator
(List<ImmutableSegment> segments, CellComparator comparator, int compactionKVMax, HStore store) MobStoreScanner
(HStore store, ScanInfo scanInfo, Scan scan, NavigableSet<byte[]> columns, long readPt) (package private)
ReversedMobStoreScanner
(HStore store, ScanInfo scanInfo, Scan scan, NavigableSet<byte[]> columns, long readPt) ReversedStoreScanner
(HStore store, ScanInfo scanInfo, Scan scan, NavigableSet<byte[]> columns, long readPt) Opens a scanner across memstore, snapshot, and all StoreFiles.StoreFlusher
(org.apache.hadoop.conf.Configuration conf, HStore store) private
StoreScanner
(HStore store, Scan scan, ScanInfo scanInfo, int numColumns, long readPt, boolean cacheBlocks, ScanType scanType) An internal constructor.StoreScanner
(HStore store, ScanInfo scanInfo, List<? extends KeyValueScanner> scanners, long smallestReadPoint, long earliestPutTs, byte[] dropDeletesFromRow, byte[] dropDeletesToRow) Used for compactions that drop deletes from a limited range of rows.StoreScanner
(HStore store, ScanInfo scanInfo, List<? extends KeyValueScanner> scanners, ScanType scanType, long smallestReadPoint, long earliestPutTs) Used for store file compaction and memstore compaction.private
StoreScanner
(HStore store, ScanInfo scanInfo, List<? extends KeyValueScanner> scanners, ScanType scanType, long smallestReadPoint, long earliestPutTs, byte[] dropDeletesFromRow, byte[] dropDeletesToRow) StoreScanner
(HStore store, ScanInfo scanInfo, Scan scan, NavigableSet<byte[]> columns, long readPt) Opens a scanner across memstore, snapshot, and all StoreFiles.StripeStoreFlusher
(org.apache.hadoop.conf.Configuration conf, HStore store, StripeCompactionPolicy policy, StripeStoreFileManager stripes) -
Uses of HStore in org.apache.hadoop.hbase.regionserver.compactions
Modifier and TypeMethodDescriptionprotected InternalScanner
Compactor.createScanner
(HStore store, ScanInfo scanInfo, List<StoreFileScanner> scanners, long smallestReadPoint, long earliestPutTs, byte[] dropDeletesFromRow, byte[] dropDeletesToRow) protected InternalScanner
Compactor.createScanner
(HStore store, ScanInfo scanInfo, List<StoreFileScanner> scanners, ScanType scanType, long smallestReadPoint, long earliestPutTs) void
CompactionRequester.requestCompaction
(HRegion region, HStore store, String why, int priority, CompactionLifeCycleTracker tracker, User user) Request compaction on the given store.void
CompactionRequester.requestSystemCompaction
(HRegion region, HStore store, String why, boolean giveUpIfRequestedOrCompacting) Request system compaction on the given store.ModifierConstructorDescriptionAbstractMultiOutputCompactor
(org.apache.hadoop.conf.Configuration conf, HStore store) (package private)
DateTieredCompactor
(org.apache.hadoop.conf.Configuration conf, HStore store) DefaultCompactor
(org.apache.hadoop.conf.Configuration conf, HStore store) StripeCompactor
(org.apache.hadoop.conf.Configuration conf, HStore store) -
Uses of HStore in org.apache.hadoop.hbase.regionserver.throttle
Modifier and TypeMethodDescriptionstatic String
ThroughputControlUtil.getNameForThrottling
(HStore store, String opName) Generate a name for throttling, to prevent name conflict when multiple IO operation running parallel on the same store.