public static class TestIOFencing.BlockCompactionsInPrepRegion extends TestIOFencing.CompactionBlockerRegion
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
compactCount, compactionsBlocked, compactionsWaiting
CLOSE_WAIT_ABORT, CLOSE_WAIT_INTERVAL, CLOSE_WAIT_TIME, COMPACTION_AFTER_BULKLOAD_ENABLE, conf, DEEP_OVERHEAD, DEFAULT_CACHE_FLUSH_INTERVAL, DEFAULT_CLOSE_WAIT_ABORT, DEFAULT_CLOSE_WAIT_INTERVAL, DEFAULT_CLOSE_WAIT_TIME, DEFAULT_FAIR_REENTRANT_CLOSE_LOCK, DEFAULT_FLUSH_PER_CHANGES, DEFAULT_HBASE_REGIONSERVER_MINIBATCH_SIZE, DEFAULT_MAX_CELL_SIZE, DEFAULT_USE_META_CELL_COMPARATOR, DEFAULT_WAL_HSYNC, FAIR_REENTRANT_CLOSE_LOCK, 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, rsServices, SPECIAL_RECOVERED_EDITS_DIR, SPLIT_IGNORE_BLOCKING_ENABLED_KEY, stores, SYSTEM_CACHE_FLUSH_INTERVAL, USE_META_CELL_COMPARATOR, WAL_HSYNC_CONF_KEY
Constructor and Description |
---|
BlockCompactionsInPrepRegion(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 |
---|---|
protected void |
doRegionCompactionPrep() |
allowCompactions, compact, compact, countStoreFiles, stopCompactions, waitForCompactionToBlock
addReadRequestsCount, addRegionToSnapshot, addWriteRequestsCount, append, append, areWritesEnabled, batchMutate, batchMutate, batchReplay, blockUpdates, bulkLoadHFiles, bulkLoadHFiles, checkAndMutate, checkAndMutate, checkAndMutate, checkAndMutate, checkAndRowMutate, checkAndRowMutate, checkFamilies, checkSplit, checkSplit, checkTimestamps, close, close, closeRegionOperation, closeRegionOperation, compact, compactStores, computeHDFSBlocksDistribution, computeHDFSBlocksDistribution, createHRegion, createHRegion, createHRegion, createHRegion, createRegionDir, decrementCompactionsQueuedCount, decrementFlushesQueuedCount, delete, deregisterChildren, equals, execService, flush, flushcache, get, get, getBlockCache, getBlockedRequestsCount, getCellComparator, getCheckAndMutateChecksFailed, getCheckAndMutateChecksPassed, getCompactionState, getCompactPriority, getCoprocessorHost, getDataInMemoryWithoutWAL, getEarliestFlushTimeForAllStores, getFilesystem, getFilteredReadRequestsCount, getHDFSBlocksDistribution, getLoadStatistics, getLockedRows, getMaxFlushedSeqId, getMaxStoreSeqId, getMemStoreDataSize, getMemStoreFlushSize, getMemStoreHeapSize, getMemStoreOffHeapSize, getMetrics, getMobFileCache, getMVCC, getNextSequenceId, getNumMutationsWithoutWAL, getOldestHfileTs, getOldestSeqIdOfStore, getOpenSeqNum, getReadLockCount, getReadOnlyConfiguration, getReadPoint, getReadRequestsCount, getRegionDir, getRegionFileSystem, getRegionInfo, getRegionServicesForStores, getReplicationScope, getRowLock, getRowLock, getRowLockInternal, getScanner, getScanner, getSmallestReadPoint, getStore, getStoreFileList, getStores, getTableDescriptor, getWAL, getWALRegionDir, getWriteRequestsCount, hashCode, hasReferences, heapSize, increment, increment, incrementCompactionsQueuedCount, incrementFlushesQueuedCount, initialize, instantiateHStore, instantiateRegionScanner, internalFlushcache, internalPrepareFlushCache, isAvailable, isClosed, isClosing, isLoadingCfsOnDemandDefault, isMergeable, isReadOnly, isSplittable, mutateRow, mutateRow, mutateRowsWithLocks, newHRegion, onConfigurationChange, openHRegion, openHRegion, openHRegion, openHRegion, openHRegion, openHRegion, openHRegion, openHRegion, openHRegionFromTableDir, openReadOnlyFileSystemHRegion, processRowsWithLocks, processRowsWithLocks, processRowsWithLocks, put, refreshStoreFiles, refreshStoreFiles, registerChildren, registerService, reportCompactionRequestEnd, reportCompactionRequestFailure, reportCompactionRequestStart, requestCompaction, requestCompaction, requestFlush, restoreEdit, rowIsInRange, rowIsInRange, setBlockCache, setClosing, setCoprocessorHost, setMobFileCache, setReadsEnabled, setRestoredRegion, setTableDescriptor, setTimeoutForWriteLock, startRegionOperation, startRegionOperation, toString, unblockUpdates, waitForFlushes, waitForFlushes, waitForFlushesAndCompactions, warmupHRegion, writeRegionOpenMarker
public BlockCompactionsInPrepRegion(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)
protected void doRegionCompactionPrep() throws IOException
doRegionCompactionPrep
in class org.apache.hadoop.hbase.regionserver.HRegion
IOException
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.