Class TestIOFencing.BlockCompactionsInCompletionRegion

java.lang.Object
org.apache.hadoop.hbase.regionserver.HRegion
org.apache.hadoop.hbase.TestIOFencing.CompactionBlockerRegion
org.apache.hadoop.hbase.TestIOFencing.BlockCompactionsInCompletionRegion
All Implemented Interfaces:
org.apache.hadoop.hbase.conf.ConfigurationObserver, org.apache.hadoop.hbase.conf.PropagatingConfigurationObserver, org.apache.hadoop.hbase.io.HeapSize, org.apache.hadoop.hbase.regionserver.Region
Enclosing class:
TestIOFencing

An override of HRegion that allows us park compactions in a holding pattern and then when appropriate for the test, allow them proceed again. This allows the compaction entry to go the WAL before blocking, but blocks afterwards
  • Nested Class Summary

    Nested classes/interfaces inherited from class 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

    Nested classes/interfaces inherited from interface org.apache.hadoop.hbase.regionserver.Region

    org.apache.hadoop.hbase.regionserver.Region.Operation, org.apache.hadoop.hbase.regionserver.Region.RowLock
  • Field Summary

    Fields inherited from class org.apache.hadoop.hbase.TestIOFencing.CompactionBlockerRegion

    compactCount, compactionsBlocked, compactionsWaiting

    Fields inherited from class org.apache.hadoop.hbase.regionserver.HRegion

    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_REGION_STORAGE_POLICY, 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, RECOVERED_EDITS_IGNORE_EOF, REGION_STORAGE_POLICY_KEY, rsServices, SPECIAL_RECOVERED_EDITS_DIR, SPLIT_IGNORE_BLOCKING_ENABLED_KEY, stores, SYSTEM_CACHE_FLUSH_INTERVAL, USE_META_CELL_COMPARATOR, WAL_HSYNC_CONF_KEY
  • Constructor Summary

    Constructors
    Constructor
    Description
    BlockCompactionsInCompletionRegion(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)
     
  • Method Summary

    Modifier and Type
    Method
    Description
    protected org.apache.hadoop.hbase.regionserver.HStore
    instantiateHStore(org.apache.hadoop.hbase.client.ColumnFamilyDescriptor family, boolean warmup)
     

    Methods inherited from class org.apache.hadoop.hbase.regionserver.HRegion

    addReadRequestsCount, addRegionToSnapshot, addWriteRequestsCount, append, append, areWritesEnabled, batchMutate, batchMutate, batchReplay, blockUpdates, bulkLoadHFiles, bulkLoadHFiles, checkAndMutate, checkAndMutate, checkAndMutate, checkAndMutate, checkAndRowMutate, checkAndRowMutate, checkFamilies, checkSplit, checkSplit, checkTimestamps, close, close, close, close, closeRegionOperation, closeRegionOperation, compact, compactStores, computeHDFSBlocksDistribution, computeHDFSBlocksDistribution, createHRegion, createHRegion, createHRegion, createHRegion, createRegionDir, decrementCompactionsQueuedCount, decrementFlushesQueuedCount, delete, deregisterChildren, doRegionCompactionPrep, 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, getMetricsTableRequests, getMinBlockSizeBytes, 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, 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

    Methods inherited from class java.lang.Object

    clone, finalize, getClass, notify, notifyAll, wait, wait, wait

    Methods inherited from interface org.apache.hadoop.hbase.regionserver.Region

    checkAndMutate, checkAndMutate, checkAndRowMutate, checkAndRowMutate
  • Constructor Details

    • BlockCompactionsInCompletionRegion

      public BlockCompactionsInCompletionRegion(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)
  • Method Details

    • instantiateHStore

      protected org.apache.hadoop.hbase.regionserver.HStore instantiateHStore(org.apache.hadoop.hbase.client.ColumnFamilyDescriptor family, boolean warmup) throws IOException
      Overrides:
      instantiateHStore in class org.apache.hadoop.hbase.regionserver.HRegion
      Throws:
      IOException