Uses of Interface
org.apache.hadoop.hbase.regionserver.throttle.ThroughputController
Package
Description
-
Uses of ThroughputController in org.apache.hadoop.hbase
-
Uses of ThroughputController in org.apache.hadoop.hbase.mob
Modifier and TypeMethodDescriptionList<org.apache.hadoop.fs.Path>
DefaultMobStoreCompactor.compact
(CompactionRequestImpl request, ThroughputController throughputController, User user) List<org.apache.hadoop.fs.Path>
DefaultMobStoreFlusher.flushSnapshot
(MemStoreSnapshot snapshot, long cacheFlushId, MonitoredTask status, ThroughputController throughputController, FlushLifeCycleTracker tracker, Consumer<org.apache.hadoop.fs.Path> writerCreationTracker) Flushes the snapshot of the MemStore.protected boolean
DefaultMobStoreCompactor.performCompaction
(Compactor.FileDetails fd, InternalScanner scanner, CellSink writer, long smallestReadPoint, boolean cleanSeqId, ThroughputController throughputController, CompactionRequestImpl request, CompactionProgress progress) Performs compaction on a column family with the mob flag enabled.protected void
DefaultMobStoreFlusher.performMobFlush
(MemStoreSnapshot snapshot, long cacheFlushId, InternalScanner scanner, StoreFileWriter writer, MonitoredTask status, ThroughputController throughputController, Consumer<org.apache.hadoop.fs.Path> writerCreationTracker) Flushes the cells in the mob store. -
Uses of ThroughputController in org.apache.hadoop.hbase.regionserver
Modifier and TypeFieldDescriptionprivate ThroughputController
CompactSplit.compactionThroughputController
private ThroughputController
HRegionServer.flushThroughputController
Modifier and TypeMethodDescriptionCompactSplit.getCompactionThroughputController()
HRegionServer.getFlushThroughputController()
RegionServerServices.getFlushThroughputController()
Returns the controller to avoid flush too fastModifier and TypeMethodDescriptionList<org.apache.hadoop.fs.Path>
DateTieredStoreEngine.DateTieredCompactionContext.compact
(ThroughputController throughputController, User user) List<org.apache.hadoop.fs.Path>
DefaultStoreEngine.DefaultCompactionContext.compact
(ThroughputController throughputController, User user) 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.HStore.compact
(CompactionContext compaction, ThroughputController throughputController, User user) Compact the StoreFiles.List<org.apache.hadoop.fs.Path>
StripeStoreEngine.StripeCompaction.compact
(ThroughputController throughputController, User user) (package private) void
HRegion.compactStore
(byte[] family, ThroughputController throughputController) This is a helper function that compact the given store.protected List<org.apache.hadoop.fs.Path>
HStore.flushCache
(long logCacheFlushId, MemStoreSnapshot snapshot, MonitoredTask status, ThroughputController throughputController, FlushLifeCycleTracker tracker, Consumer<org.apache.hadoop.fs.Path> writerCreationTracker) Write out current snapshot.List<org.apache.hadoop.fs.Path>
DefaultStoreFlusher.flushSnapshot
(MemStoreSnapshot snapshot, long cacheFlushId, MonitoredTask status, ThroughputController throughputController, FlushLifeCycleTracker tracker, Consumer<org.apache.hadoop.fs.Path> writerCreationTracker) abstract List<org.apache.hadoop.fs.Path>
StoreFlusher.flushSnapshot
(MemStoreSnapshot snapshot, long cacheFlushSeqNum, MonitoredTask status, ThroughputController throughputController, FlushLifeCycleTracker tracker, Consumer<org.apache.hadoop.fs.Path> writerCreationTracker) Turns a snapshot of memstore into a set of store files.List<org.apache.hadoop.fs.Path>
StripeStoreFlusher.flushSnapshot
(MemStoreSnapshot snapshot, long cacheFlushSeqNum, MonitoredTask status, ThroughputController throughputController, FlushLifeCycleTracker tracker, Consumer<org.apache.hadoop.fs.Path> writerCreationTracker) protected void
StoreFlusher.performFlush
(InternalScanner scanner, CellSink sink, ThroughputController throughputController) Performs memstore flush, writing data from scanner into sink. -
Uses of ThroughputController in org.apache.hadoop.hbase.regionserver.compactions
Modifier and TypeMethodDescriptionabstract List<org.apache.hadoop.fs.Path>
CompactionContext.compact
(ThroughputController throughputController, User user) protected final List<org.apache.hadoop.fs.Path>
Compactor.compact
(CompactionRequestImpl request, Compactor.InternalScannerFactory scannerFactory, Compactor.CellSinkFactory<T> sinkFactory, ThroughputController throughputController, User user) List<org.apache.hadoop.fs.Path>
DateTieredCompactor.compact
(CompactionRequestImpl request, List<Long> lowerBoundaries, Map<Long, String> lowerBoundariesPolicies, ThroughputController throughputController, User user) List<org.apache.hadoop.fs.Path>
DefaultCompactor.compact
(CompactionRequestImpl request, ThroughputController throughputController, User user) Do a minor/major compaction on an explicit set of storefiles from a Store.List<org.apache.hadoop.fs.Path>
StripeCompactor.compact
(CompactionRequestImpl request, int targetCount, long targetSize, byte[] left, byte[] right, byte[] majorRangeFromRow, byte[] majorRangeToRow, ThroughputController throughputController, User user) List<org.apache.hadoop.fs.Path>
StripeCompactor.compact
(CompactionRequestImpl request, List<byte[]> targetBoundaries, byte[] majorRangeFromRow, byte[] majorRangeToRow, ThroughputController throughputController, User user) List<org.apache.hadoop.fs.Path>
StripeCompactionPolicy.BoundaryStripeCompactionRequest.execute
(StripeCompactor compactor, ThroughputController throughputController, User user) List<org.apache.hadoop.fs.Path>
StripeCompactionPolicy.SplitStripeCompactionRequest.execute
(StripeCompactor compactor, ThroughputController throughputController, User user) List<org.apache.hadoop.fs.Path>
StripeCompactionPolicy.StripeCompactionRequest.execute
(StripeCompactor compactor, ThroughputController throughputController) abstract List<org.apache.hadoop.fs.Path>
StripeCompactionPolicy.StripeCompactionRequest.execute
(StripeCompactor compactor, ThroughputController throughputController, User user) Executes the request against compactor (essentially, just calls correct overload of compact method), to simulate more dynamic dispatch.protected boolean
Compactor.performCompaction
(Compactor.FileDetails fd, InternalScanner scanner, CellSink writer, long smallestReadPoint, boolean cleanSeqId, ThroughputController throughputController, CompactionRequestImpl request, CompactionProgress progress) Performs the compaction. -
Uses of ThroughputController in org.apache.hadoop.hbase.regionserver.throttle
Modifier and TypeClassDescriptionclass
class
A throughput controller which uses the follow schema to limit throughput If compaction pressure is greater than 1.0, no limitation. In off peak hours, use a fixed throughput limitation "hbase.hstore.compaction.throughput.offpeak" In normal hours, the max throughput is tuned between "hbase.hstore.compaction.throughput.lower.bound" and "hbase.hstore.compaction.throughput.higher.bound", using the formula "lower + (higer - lower) * compactionPressure", where compactionPressure is in range [0.0, 1.0]class
A throughput controller which uses the follow schema to limit throughput If flush pressure is greater than or equal to 1.0, no limitation. In normal case, the max throughput is tuned between "hbase.hstore.flush.throughput.lower.bound" and "hbase.hstore.flush.throughput.upper.bound", using the formula "lower + (upper - lower) * flushPressure", where flushPressure is in range [0.0, 1.0)class
Modifier and TypeFieldDescriptionprivate static final Class<? extends ThroughputController>
FlushThroughputControllerFactory.DEFAULT_FLUSH_THROUGHPUT_CONTROLLER_CLASS
private static final Class<? extends ThroughputController>
CompactionThroughputControllerFactory.DEFAULT_THROUGHPUT_CONTROLLER_CLASS
Modifier and TypeMethodDescriptionstatic ThroughputController
CompactionThroughputControllerFactory.create
(RegionServerServices server, org.apache.hadoop.conf.Configuration conf) static ThroughputController
FlushThroughputControllerFactory.create
(RegionServerServices server, org.apache.hadoop.conf.Configuration conf) Modifier and TypeMethodDescriptionstatic Class<? extends ThroughputController>
CompactionThroughputControllerFactory.getThroughputControllerClass
(org.apache.hadoop.conf.Configuration conf) static Class<? extends ThroughputController>
FlushThroughputControllerFactory.getThroughputControllerClass
(org.apache.hadoop.conf.Configuration conf)