public static class TestRegionObserverScannerOpenHook.CompactionCompletionNotifyingRegion extends HRegion
HRegion.FlushResultImpl, HRegion.RowLockImpl
Region.BulkLoadListener, Region.FlushResult, Region.Operation, Region.RowLock
conf, DEEP_OVERHEAD, DEFAULT_CACHE_FLUSH_INTERVAL, DEFAULT_FLUSH_PER_CHANGES, FIXED_OVERHEAD, lastReplayedCompactionSeqId, lastReplayedOpenRegionSeqId, LOAD_CFS_ON_DEMAND_CONFIG_KEY, LOG, MAX_FLUSH_PER_CHANGES, MEMSTORE_FLUSH_PER_CHANGES, MEMSTORE_PERIODIC_FLUSH_INTERVAL, memstoreSize, META_CACHE_FLUSH_INTERVAL, stores
Constructor and Description |
---|
CompactionCompletionNotifyingRegion(Path tableDir,
WAL log,
FileSystem fs,
Configuration confParam,
HRegionInfo info,
HTableDescriptor htd,
RegionServerServices rsServices) |
Modifier and Type | Method and Description |
---|---|
boolean |
compact(CompactionContext compaction,
Store store,
CompactionThroughputController throughputController) |
boolean |
compact(CompactionContext compaction,
Store store,
CompactionThroughputController throughputController,
User user) |
CountDownLatch |
getCompactionStateChangeLatch() |
addAndGetGlobalMemstoreSize, addRegionToMETA, addRegionToSnapshot, append, append, areWritesEnabled, batchMutate, batchMutate, batchReplay, bulkLoadHFiles, checkAndMutate, checkAndRowMutate, checkFamilies, checkReadOnly, checkReadsEnabled, checkSplit, checkTimestamps, close, close, closeHRegion, closeRegionOperation, closeRegionOperation, compact, compactStores, computeHDFSBlocksDistribution, computeHDFSBlocksDistribution, createHRegion, createHRegion, createHRegion, createHRegion, createHRegion, delete, deregisterChildren, doRegionCompactionPrep, equals, execService, flush, flushcache, get, get, getBlockedRequestsCount, getCheckAndMutateChecksFailed, getCheckAndMutateChecksPassed, getClosestRowBefore, getCompactionState, getCompactPriority, getComparator, getCoprocessorHost, getDataInMemoryWithoutWAL, getEarliestFlushTimeForAllStores, getEffectiveDurability, getFilesystem, getHDFSBlocksDistribution, getLargestHStoreSize, getLockedRows, getMaxFlushedSeqId, getMaxStoreSeqId, getMemstoreFlushSize, getMemstoreSize, getMetrics, getMVCC, getNextSequenceId, getNumMutationsWithoutWAL, getOldestHfileTs, getOldestSeqIdOfStore, getOpenSeqNum, getReadpoint, getReadRequestsCount, getRegionDir, getRegionDir, getRegionFileSystem, getRegionInfo, getRegionStats, getRowLock, getRowLock, getRowLockInternal, getScanner, getScanner, getSequenceId, getSmallestReadPoint, getSplitPolicy, getStore, getStoreFileList, getStoreFileOpenAndCloseThreadPool, getStoreOpenAndCloseThreadPool, getStores, getTableDesc, getWAL, getWriteRequestsCount, hashCode, hasReferences, heapSize, increment, increment, initialize, instantiateHStore, instantiateRegionScanner, internalFlushcache, internalFlushCacheAndCommit, internalPrepareFlushCache, isAvailable, isClosed, isClosing, isLoadingCfsOnDemandDefault, isMergeable, isReadOnly, isRecovering, isSplittable, main, merge, mergeAdjacent, mutateRow, mutateRowsWithLocks, mutateRowsWithLocks, onConfigurationChange, openHRegion, openHRegion, openHRegion, openHRegion, openHRegion, openHRegion, openHRegion, openHRegion, openHRegion, openHRegion, prepareDelete, prepareDeleteTimestamps, prepareToSplit, processRowsWithLocks, processRowsWithLocks, processRowsWithLocks, put, refreshStoreFiles, registerChildren, registerService, releaseRowLocks, replayRecoveredEditsIfAny, reportCompactionRequestEnd, reportCompactionRequestStart, restoreEdit, rowIsInRange, rowIsInRange, setClosing, setCoprocessorHost, setReadsEnabled, setRecovering, startRegionOperation, startRegionOperation, toString, triggerMajorCompaction, updateCellTimestamps, updateReadRequestsCount, updateWriteRequestsCount, waitForFlushesAndCompactions, warmupHRegion
public CompactionCompletionNotifyingRegion(Path tableDir, WAL log, FileSystem fs, Configuration confParam, HRegionInfo info, HTableDescriptor htd, RegionServerServices rsServices)
public CountDownLatch getCompactionStateChangeLatch()
public boolean compact(CompactionContext compaction, Store store, CompactionThroughputController throughputController) throws IOException
compact
in class HRegion
IOException
public boolean compact(CompactionContext compaction, Store store, CompactionThroughputController throughputController, User user) throws IOException
compact
in class HRegion
IOException