Uses of Class
org.apache.hadoop.hbase.regionserver.HStore
Packages that use HStore
Package
Description
-
Uses of HStore in org.apache.hadoop.hbase.mob
Methods in org.apache.hadoop.hbase.mob with parameters of type HStoreModifier and TypeMethodDescriptionprotected voidMobStoreEngine.createCompactor(org.apache.hadoop.conf.Configuration conf, HStore store) Creates the DefaultMobCompactor.protected voidMobStoreEngine.createStoreFlusher(org.apache.hadoop.conf.Configuration conf, HStore store) Constructors in org.apache.hadoop.hbase.mob with parameters of type HStoreModifierConstructorDescriptionDefaultMobStoreCompactor(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
Subclasses of HStore in org.apache.hadoop.hbase.regionserverModifier and TypeClassDescriptionclassThe store implementation to save MOBs (medium objects), it extends the HStore.Fields in org.apache.hadoop.hbase.regionserver declared as HStoreModifier and TypeFieldDescriptionprivate HStoreCompactedHFilesDischargeHandler.storeprivate HStoreCompactingMemStore.storeprivate final HStoreCompactSplit.CompactionRunner.storeprotected HStoreStoreFlusher.storeprotected final HStoreStoreScanner.storeFields in org.apache.hadoop.hbase.regionserver with type parameters of type HStoreModifier and TypeFieldDescriptionprivate final ConcurrentMap<HStore,Long> HRegion.lastStoreFlushTimeMapprivate Collection<HStore>FlushNonSloppyStoresFirstPolicy.regularStoresprivate Collection<HStore>FlushNonSloppyStoresFirstPolicy.sloppyStoresHRegion.storesMethods in org.apache.hadoop.hbase.regionserver that return HStoreModifier and TypeMethodDescriptionCompactingMemStore.getStore()private static HStoreCompactionTool.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 HStoreReturn HStore instance.protected HStoreHRegion.instantiateHStore(ColumnFamilyDescriptor family, boolean warmup) Methods in org.apache.hadoop.hbase.regionserver that return types with arguments of type HStoreModifier and TypeMethodDescriptionprivate Collection<HStore>HRegion.getSpecificStores(List<byte[]> families) get stores which matches the specified familiesHRegion.getStores()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.Methods in org.apache.hadoop.hbase.regionserver with parameters of type HStoreModifier and TypeMethodDescriptionprivate voidHRegion.applyToMemStore(HStore store, List<Cell> cells, boolean delta, MemStoreSizing memstoreAccounting) private voidHRegion.applyToMemStore(HStore store, Cell cell, MemStoreSizing memstoreAccounting) private voidBrokenStoreFileCleaner.cleanFileIfNeeded(org.apache.hadoop.fs.FileStatus file, HStore store, AtomicLong deletedFiles, AtomicLong failedDeletes) booleanHRegion.compact(CompactionContext compaction, HStore store, ThroughputController throughputController) Called by compaction thread and after region is opened to compact the HStores if necessary.booleanHRegion.compact(CompactionContext compaction, HStore store, ThroughputController throughputController, User user) static StoreEngine<?,?, ?, ?> StoreEngine.create(HStore store, org.apache.hadoop.conf.Configuration conf, CellComparator cellComparator) Create the StoreEngine configured for the given Store.protected voidDefaultStoreEngine.createCompactionPolicy(org.apache.hadoop.conf.Configuration conf, HStore store) protected voidDefaultStoreEngine.createCompactor(org.apache.hadoop.conf.Configuration conf, HStore store) protected voidDateTieredStoreEngine.createComponents(org.apache.hadoop.conf.Configuration conf, HStore store, CellComparator kvComparator) protected voidDefaultStoreEngine.createComponents(org.apache.hadoop.conf.Configuration conf, HStore store, CellComparator kvComparator) protected abstract voidStoreEngine.createComponents(org.apache.hadoop.conf.Configuration conf, HStore store, CellComparator cellComparator) Create the StoreEngine's components.protected voidStripeStoreEngine.createComponents(org.apache.hadoop.conf.Configuration conf, HStore store, CellComparator comparator) protected final voidStoreEngine.createComponentsOnce(org.apache.hadoop.conf.Configuration conf, HStore store, CellComparator cellComparator) private InternalScannerMemStoreCompactorSegmentsIterator.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 StoreFileTrackerStoreEngine.createStoreFileTracker(org.apache.hadoop.conf.Configuration conf, HStore store) protected voidDefaultStoreEngine.createStoreFlusher(org.apache.hadoop.conf.Configuration conf, HStore store) private voidBrokenStoreFileCleaner.deleteFile(org.apache.hadoop.fs.FileStatus file, HStore store, AtomicLong deletedFiles, AtomicLong failedDeletes) private MemStoreSizeHRegion.doDropStoreMemStoreContentsForSeqId(HStore s, long currentSeqId) private MemStoreSizeHRegion.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 StringCompactSplit.getStoreNameForUnderCompaction(HStore store) private booleanBrokenStoreFileCleaner.isActiveStorefile(org.apache.hadoop.fs.FileStatus file, HStore store) private booleanBrokenStoreFileCleaner.isCompactedFile(org.apache.hadoop.fs.FileStatus file, HStore store) private booleanBrokenStoreFileCleaner.isCompactionResultFile(org.apache.hadoop.fs.FileStatus file, HStore store) booleanCompactSplit.isUnderCompaction(HStore s) Check if this store is under compactionvoidRegionCoprocessorHost.postCompact(HStore store, HStoreFile resultFile, CompactionLifeCycleTracker tracker, CompactionRequest request, User user) Called after the store compaction has completed.voidRegionCoprocessorHost.postCompactSelection(HStore store, List<HStoreFile> selected, CompactionLifeCycleTracker tracker, CompactionRequest request, User user) Called after theHStoreFiles to be compacted have been selected from the available candidates.voidRegionCoprocessorHost.postFlush(HStore store, HStoreFile storeFile, FlushLifeCycleTracker tracker) Invoked after a memstore flushvoidRegionCoprocessorHost.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.booleanRegionCoprocessorHost.preCompactSelection(HStore store, List<HStoreFile> candidates, CompactionLifeCycleTracker tracker, User user) Called prior to selecting theHStoreFiles 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.voidRegionCoprocessorHost.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.HRegion.MutationBatchOperation.reckonDeltasByStore(HStore store, Mutation mutation, long now, List<Cell> deltas, List<Cell> results) Reckon the Cells to apply to WAL, memstore, and to return to the Client in passed column family/Store.voidCompactSplit.requestCompaction(HRegion region, HStore store, String why, int priority, CompactionLifeCycleTracker tracker, User user) protected voidCompactSplit.requestCompactionInternal(HRegion region, HStore store, String why, int priority, boolean selectNow, CompactionLifeCycleTracker tracker, CompactSplit.CompactionCompleteTracker completeTracker, User user) voidCompactSplit.requestSystemCompaction(HRegion region, HStore store, String why) voidCompactSplit.requestSystemCompaction(HRegion region, HStore store, String why, boolean giveUpIfRequestedOrCompacting) protected voidHRegion.restoreEdit(HStore s, Cell 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 booleanFlushAllLargeStoresPolicy.shouldFlush(HStore store) protected booleanFlushLargeStoresPolicy.shouldFlush(HStore store) (package private) booleanHRegion.shouldFlushStore(HStore store) Should the store be flushed because it is old enough.booleanKeyValueScanner.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.booleanNonLazyKeyValueScanner.shouldUseScanner(Scan scan, HStore store, long oldestUnexpiredTS) booleanSegmentScanner.shouldUseScanner(Scan scan, HStore store, long oldestUnexpiredTS) This functionality should be resolved in the higher level which is MemStoreScanner, currently returns true as default.booleanStoreFileScanner.shouldUseScanner(Scan scan, HStore store, long oldestUnexpiredTS) Method parameters in org.apache.hadoop.hbase.regionserver with type arguments of type HStoreModifier and TypeMethodDescriptionMetricsRegionServerWrapperImpl.RegionMetricAggregate.aggregateStores(List<HStore> stores) private HRegion.FlushResultImplHRegion.internalFlushcache(Collection<HStore> storesToFlush, MonitoredTask status, boolean writeFlushWalMarker, FlushLifeCycleTracker tracker) Flushing given stores.protected HRegion.FlushResultImplHRegion.internalFlushcache(WAL wal, long myseqid, Collection<HStore> storesToFlush, MonitoredTask status, boolean writeFlushWalMarker, FlushLifeCycleTracker tracker) Flush the memstore.(package private) HRegion.FlushResultImplHRegion.internalFlushCacheAndCommit(WAL wal, MonitoredTask status, HRegion.PrepareFlushResult prepareResult, Collection<HStore> storesToFlush) protected HRegion.PrepareFlushResultHRegion.internalPrepareFlushCache(WAL wal, long myseqid, Collection<HStore> storesToFlush, MonitoredTask status, boolean writeFlushWalMarker, FlushLifeCycleTracker tracker) private booleanHRegion.isAllFamilies(Collection<HStore> families) Returns True if passed Set is all families in the region.private longHRegion.loadRecoveredHFilesIfAny(Collection<HStore> stores) private voidHRegion.logFatLineOnFlush(Collection<HStore> storesToFlush, long sequenceId) Utility method broken out of internalPrepareFlushCache so that method is smaller.Constructors in org.apache.hadoop.hbase.regionserver with parameters of type HStoreModifierConstructorDescriptionCompactedHFilesDischargeHandler(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) privateStoreScanner(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.privateStoreScanner(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
Fields in org.apache.hadoop.hbase.regionserver.compactions declared as HStoreMethods in org.apache.hadoop.hbase.regionserver.compactions with parameters of type HStoreModifier and TypeMethodDescriptionprotected InternalScannerCompactor.createScanner(HStore store, ScanInfo scanInfo, List<StoreFileScanner> scanners, long smallestReadPoint, long earliestPutTs, byte[] dropDeletesFromRow, byte[] dropDeletesToRow) protected InternalScannerCompactor.createScanner(HStore store, ScanInfo scanInfo, List<StoreFileScanner> scanners, ScanType scanType, long smallestReadPoint, long earliestPutTs) voidCompactionRequester.requestCompaction(HRegion region, HStore store, String why, int priority, CompactionLifeCycleTracker tracker, User user) Request compaction on the given store.voidCompactionRequester.requestSystemCompaction(HRegion region, HStore store, String why, boolean giveUpIfRequestedOrCompacting) Request system compaction on the given store.Constructors in org.apache.hadoop.hbase.regionserver.compactions with parameters of type HStoreModifierConstructorDescriptionAbstractMultiOutputCompactor(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
Methods in org.apache.hadoop.hbase.regionserver.throttle with parameters of type HStoreModifier and TypeMethodDescriptionstatic StringThroughputControlUtil.getNameForThrottling(HStore store, String opName) Generate a name for throttling, to prevent name conflict when multiple IO operation running parallel on the same store.