public static class TestIOFencing.BlockCompactionsInCompletionHStore extends HStore
BLOCKING_STOREFILES_KEY, COMPACTCHECKER_INTERVAL_MULTIPLIER_KEY, DEEP_OVERHEAD, DEFAULT_BLOCKING_STOREFILE_COUNT, DEFAULT_COMPACTCHECKER_INTERVAL_MULTIPLIER, FIXED_OVERHEAD, memstore
NO_PRIORITY, PRIORITY_USER
Modifier | Constructor and Description |
---|---|
protected |
BlockCompactionsInCompletionHStore(HRegion region,
HColumnDescriptor family,
Configuration confParam) |
Modifier and Type | Method and Description |
---|---|
protected void |
completeCompaction(Collection<StoreFile> compactedFiles)
It works by processing a compaction that's been written to disk.
|
protected void |
completeCompaction(Collection<StoreFile> compactedFiles,
boolean removeFiles)
It works by processing a compaction that's been written to disk.
|
add, addChangedReaderObserver, areWritesEnabled, assertBulkLoadHFileOk, bulkLoadHFile, bulkLoadHFile, cancelRequestedCompaction, canSplit, close, compact, compactRecentForTestingAssumingDefaultPolicy, createFlushContext, createWriterInTmp, delete, deleteChangedReaderObserver, deregisterChildren, flushCache, getBlockingFileCount, getBytesPerChecksum, getCacheConfig, getChecksumType, getCloseCheckInterval, getColumnFamilyName, getCompactedCellsCount, getCompactedCellsSize, getCompactionCheckMultiplier, getCompactionPressure, getCompactionProgress, getCompactPriority, getComparator, getCoprocessorHost, getDataBlockEncoder, getFamily, getFileSystem, getFlushableSize, getFlushedCellsCount, getFlushedCellsSize, getHRegion, getLastCompactSize, getMajorCompactedCellsCount, getMajorCompactedCellsSize, getMaxMemstoreTS, getMaxSequenceId, getMemstoreFlushSize, getMemStoreSize, getOffPeakHours, getRegionFileSystem, getRegionInfo, getRowKeyAtOrBefore, getScanInfo, getScanner, getScanners, getSize, getSmallestReadPoint, getSnapshotSize, getSplitPoint, getStoreEngine, getStorefiles, getStorefilesCount, getStorefilesIndexSize, getStorefilesSize, getStoreFileTtl, getStoreHomedir, getStoreHomedir, getStoreSizeUncompressed, getTableName, getTotalStaticBloomSize, getTotalStaticIndexSize, hasReferences, hasTooManyStoreFiles, heapSize, isMajorCompaction, isPrimaryReplicaStore, needsCompaction, onConfigurationChange, refreshStoreFiles, refreshStoreFiles, registerChildren, replayCompactionMarker, requestCompaction, requestCompaction, rollback, throttleCompaction, timeOfOldestEdit, toString, triggerMajorCompaction, updateColumnValue, upsert
protected BlockCompactionsInCompletionHStore(HRegion region, HColumnDescriptor family, Configuration confParam) throws IOException
IOException
protected void completeCompaction(Collection<StoreFile> compactedFiles, boolean removeFiles) throws IOException
HStore
It works by processing a compaction that's been written to disk.
It is usually invoked at the end of a compaction, but might also be invoked at HStore startup, if the prior execution died midway through.
Moving the compacted TreeMap into place means:
1) Unload all replaced StoreFile, close and collect list to delete. 2) Compute new store size
completeCompaction
in class HStore
compactedFiles
- list of files that were compactedIOException
protected void completeCompaction(Collection<StoreFile> compactedFiles) throws IOException
HStore
It works by processing a compaction that's been written to disk.
It is usually invoked at the end of a compaction, but might also be invoked at HStore startup, if the prior execution died midway through.
Moving the compacted TreeMap into place means:
1) Unload all replaced StoreFile, close and collect list to delete. 2) Compute new store size
completeCompaction
in class HStore
compactedFiles
- list of files that were compactedIOException