public static class TestAtomicOperation.MockHRegion extends HRegion
Modifier and Type | Class and Description |
---|---|
class |
TestAtomicOperation.MockHRegion.WrappedRowLock |
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 |
---|
MockHRegion(Path tableDir,
WAL log,
FileSystem fs,
Configuration conf,
HRegionInfo regionInfo,
HTableDescriptor htd,
RegionServerServices rsServices) |
Modifier and Type | Method and Description |
---|---|
Region.RowLock |
getRowLockInternal(byte[] row,
boolean waitForLock)
A version of getRowLock(byte[], boolean) to use when a region operation has already been
started (the calling thread has already acquired the region-close-guard lock).
|
addAndGetGlobalMemstoreSize, addRegionToMETA, addRegionToSnapshot, append, append, areWritesEnabled, batchMutate, batchMutate, batchReplay, bulkLoadHFiles, checkAndMutate, checkAndRowMutate, checkFamilies, checkReadOnly, checkReadsEnabled, checkSplit, checkTimestamps, close, close, closeHRegion, closeRegionOperation, closeRegionOperation, compact, 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, getMaxFlushedSeqId, getMaxStoreSeqId, getMemstoreSize, getMetrics, getMVCC, getNextSequenceId, getNumMutationsWithoutWAL, getOldestHfileTs, getOldestSeqIdOfStore, getOpenSeqNum, getReadpoint, getReadRequestsCount, getRegionDir, getRegionDir, getRegionFileSystem, getRegionInfo, getRegionStats, getRowLock, getRowLock, 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 MockHRegion(Path tableDir, WAL log, FileSystem fs, Configuration conf, HRegionInfo regionInfo, HTableDescriptor htd, RegionServerServices rsServices)
public Region.RowLock getRowLockInternal(byte[] row, boolean waitForLock) throws IOException
HRegion
getRowLockInternal
in class HRegion
IOException