public abstract static class TestIOFencing.CompactionBlockerRegion extends org.apache.hadoop.hbase.regionserver.HRegion
org.apache.hadoop.hbase.regionserver.HRegion.BulkLoadListener, org.apache.hadoop.hbase.regionserver.HRegion.FlushResult, org.apache.hadoop.hbase.regionserver.HRegion.FlushResultImpl, org.apache.hadoop.hbase.regionserver.HRegion.RowLockImpl
Modifier and Type | Field and Description |
---|---|
(package private) AtomicInteger |
compactCount |
(package private) CountDownLatch |
compactionsBlocked |
(package private) CountDownLatch |
compactionsWaiting |
conf, DEEP_OVERHEAD, DEFAULT_CACHE_FLUSH_INTERVAL, DEFAULT_FLUSH_PER_CHANGES, DEFAULT_HBASE_REGIONSERVER_MINIBATCH_SIZE, DEFAULT_MAX_CELL_SIZE, FIXED_OVERHEAD, HBASE_MAX_CELL_SIZE_KEY, HBASE_REGIONSERVER_MINIBATCH_SIZE, lastReplayedCompactionSeqId, lastReplayedOpenRegionSeqId, LOAD_CFS_ON_DEMAND_CONFIG_KEY, MAX_FLUSH_PER_CHANGES, MEMSTORE_FLUSH_PER_CHANGES, MEMSTORE_PERIODIC_FLUSH_INTERVAL, stores, SYSTEM_CACHE_FLUSH_INTERVAL
Constructor and Description |
---|
CompactionBlockerRegion(org.apache.hadoop.fs.Path tableDir,
org.apache.hadoop.hbase.wal.WAL log,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.conf.Configuration confParam,
org.apache.hadoop.hbase.client.RegionInfo info,
org.apache.hadoop.hbase.client.TableDescriptor htd,
org.apache.hadoop.hbase.regionserver.RegionServerServices rsServices) |
Modifier and Type | Method and Description |
---|---|
void |
allowCompactions() |
boolean |
compact(org.apache.hadoop.hbase.regionserver.compactions.CompactionContext compaction,
org.apache.hadoop.hbase.regionserver.HStore store,
org.apache.hadoop.hbase.regionserver.throttle.ThroughputController throughputController) |
boolean |
compact(org.apache.hadoop.hbase.regionserver.compactions.CompactionContext compaction,
org.apache.hadoop.hbase.regionserver.HStore store,
org.apache.hadoop.hbase.regionserver.throttle.ThroughputController throughputController,
org.apache.hadoop.hbase.security.User user) |
int |
countStoreFiles() |
void |
stopCompactions() |
void |
waitForCompactionToBlock() |
addRegionToSnapshot, append, append, areWritesEnabled, batchMutate, batchMutate, batchMutate, batchReplay, blockUpdates, bulkLoadHFiles, bulkLoadHFiles, checkAndMutate, checkAndRowMutate, checkFamilies, checkReadOnly, checkReadsEnabled, checkSplit, checkTimestamps, close, close, closeRegionOperation, closeRegionOperation, compact, compactStores, computeHDFSBlocksDistribution, computeHDFSBlocksDistribution, createHRegion, createHRegion, createRegionDir, decrementCompactionsQueuedCount, delete, deregisterChildren, doRegionCompactionPrep, dropMemStoreContents, equals, execService, flush, flushcache, get, get, get, getBlockedRequestsCount, getCellComparator, getCheckAndMutateChecksFailed, getCheckAndMutateChecksPassed, getCompactionState, getCompactPriority, getCoprocessorHost, getDataInMemoryWithoutWAL, getEarliestFlushTimeForAllStores, getEffectiveDurability, getFilesystem, getFilteredReadRequestsCount, getHDFSBlocksDistribution, getLoadStatistics, getLockedRows, getMaxFlushedSeqId, getMaxStoreSeqId, getMemStoreDataSize, getMemStoreFlushSize, getMemStoreHeapSize, getMemStoreOffHeapSize, getMetrics, getMVCC, getNextSequenceId, getNumMutationsWithoutWAL, getOldestHfileTs, getOldestSeqIdOfStore, getOpenSeqNum, getReadLockCount, getReadPoint, getReadPoint, getReadRequestsCount, getRegionDir, getRegionFileSystem, getRegionInfo, getRegionServicesForStores, getReplicationScope, getRowLock, getRowLock, getRowLockInternal, getScanner, getScanner, getSmallestReadPoint, getSplitPolicy, getStore, getStoreFileList, getStoreFileOpenAndCloseThreadPool, getStoreOpenAndCloseThreadPool, getStores, getTableDescriptor, getWAL, getWALRegionDir, getWriteRequestsCount, hashCode, hasReferences, heapSize, increment, increment, incrementCompactionsQueuedCount, incrementFlushesQueuedCount, initialize, instantiateHStore, instantiateRegionScanner, instantiateRegionScanner, internalFlushcache, internalFlushCacheAndCommit, internalPrepareFlushCache, isAvailable, isClosed, isClosing, isLoadingCfsOnDemandDefault, isMergeable, isReadOnly, isSplittable, mutateRow, mutateRowsWithLocks, onConfigurationChange, openHRegion, openHRegion, openHRegion, openHRegion, openHRegion, openHRegion, openHRegion, openHRegion, openHRegion, openHRegion, openReadOnlyFileSystemHRegion, prepareDelete, prepareDeleteTimestamps, processRowsWithLocks, processRowsWithLocks, processRowsWithLocks, put, refreshStoreFiles, refreshStoreFiles, registerChildren, registerService, replayRecoveredEditsIfAny, reportCompactionRequestEnd, reportCompactionRequestFailure, reportCompactionRequestStart, requestCompaction, requestCompaction, requestFlush, restoreEdit, rowIsInRange, rowIsInRange, setClosing, setCoprocessorHost, setReadsEnabled, setTimeoutForWriteLock, startRegionOperation, startRegionOperation, toString, unblockUpdates, waitForFlushes, waitForFlushes, waitForFlushesAndCompactions, warmupHRegion
AtomicInteger compactCount
volatile CountDownLatch compactionsBlocked
volatile CountDownLatch compactionsWaiting
public CompactionBlockerRegion(org.apache.hadoop.fs.Path tableDir, org.apache.hadoop.hbase.wal.WAL log, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.conf.Configuration confParam, org.apache.hadoop.hbase.client.RegionInfo info, org.apache.hadoop.hbase.client.TableDescriptor htd, org.apache.hadoop.hbase.regionserver.RegionServerServices rsServices)
public void stopCompactions()
public void allowCompactions()
public void waitForCompactionToBlock() throws IOException
IOException
public boolean compact(org.apache.hadoop.hbase.regionserver.compactions.CompactionContext compaction, org.apache.hadoop.hbase.regionserver.HStore store, org.apache.hadoop.hbase.regionserver.throttle.ThroughputController throughputController) throws IOException
compact
in class org.apache.hadoop.hbase.regionserver.HRegion
IOException
public boolean compact(org.apache.hadoop.hbase.regionserver.compactions.CompactionContext compaction, org.apache.hadoop.hbase.regionserver.HStore store, org.apache.hadoop.hbase.regionserver.throttle.ThroughputController throughputController, org.apache.hadoop.hbase.security.User user) throws IOException
compact
in class org.apache.hadoop.hbase.regionserver.HRegion
IOException
public int countStoreFiles()
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.