@InterfaceAudience.Private public class HMobStore extends HStore
BLOCKING_STOREFILES_KEY, blocksize, bytesPerChecksum, cacheConf, checksumType, COMPACTCHECKER_INTERVAL_MULTIPLIER_KEY, conf, cryptoContext, DEEP_OVERHEAD, DEFAULT_BLOCKING_STOREFILE_COUNT, DEFAULT_COMPACTCHECKER_INTERVAL_MULTIPLIER, FIXED_OVERHEAD, memstore, regionNO_PRIORITY, PRIORITY_USER| Constructor and Description | 
|---|
HMobStore(HRegion region,
         HColumnDescriptor family,
         Configuration confParam)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
commitFile(Path sourceFile,
          Path targetPath)
Commits the mob file. 
 | 
List<StoreFile> | 
compact(CompactionContext compaction,
       CompactionThroughputController throughputController)
The compaction in the store of mob. 
 | 
protected void | 
createCacheConf(HColumnDescriptor family)
Creates the mob cache config. 
 | 
StoreFile.Writer | 
createDelFileWriterInTmp(Date date,
                        long maxKeyCount,
                        Compression.Algorithm compression,
                        byte[] startKey)
Creates the writer for the del file in temp directory. 
 | 
protected KeyValueScanner | 
createScanner(Scan scan,
             NavigableSet<byte[]> targetCols,
             long readPt,
             KeyValueScanner scanner)
Gets the MobStoreScanner or MobReversedStoreScanner. 
 | 
protected StoreEngine<?,?,?,?> | 
createStoreEngine(Store store,
                 Configuration conf,
                 KeyValue.KVComparator cellComparator)
Creates the mob store engine. 
 | 
StoreFile.Writer | 
createWriterInTmp(Date date,
                 long maxKeyCount,
                 Compression.Algorithm compression,
                 byte[] startKey)
Creates the writer for the mob file in temp directory. 
 | 
StoreFile.Writer | 
createWriterInTmp(MobFileName mobFileName,
                 Path basePath,
                 long maxKeyCount,
                 Compression.Algorithm compression)
Creates the writer for the mob file in temp directory. 
 | 
StoreFile.Writer | 
createWriterInTmp(String date,
                 Path basePath,
                 long maxKeyCount,
                 Compression.Algorithm compression,
                 byte[] startKey)
Creates the writer for the mob file in temp directory. 
 | 
long | 
getCellsCountCompactedFromMob()  | 
long | 
getCellsCountCompactedToMob()  | 
long | 
getCellsSizeCompactedFromMob()  | 
long | 
getCellsSizeCompactedToMob()  | 
Configuration | 
getConfiguration()
Gets current config. 
 | 
long | 
getMobFlushCount()  | 
long | 
getMobFlushedCellsCount()  | 
long | 
getMobFlushedCellsSize()  | 
long | 
getMobScanCellsCount()  | 
long | 
getMobScanCellsSize()  | 
Path | 
getPath()
Gets the mob file path. 
 | 
Cell | 
resolve(Cell reference,
       boolean cacheBlocks)
Reads the cell from the mob file, and the read point does not count. 
 | 
Cell | 
resolve(Cell reference,
       boolean cacheBlocks,
       long readPt,
       boolean readEmptyValueOnMobCellMiss)
Reads the cell from the mob file. 
 | 
void | 
updateCellsCountCompactedFromMob(long count)  | 
void | 
updateCellsCountCompactedToMob(long count)  | 
void | 
updateCellsSizeCompactedFromMob(long size)  | 
void | 
updateCellsSizeCompactedToMob(long size)  | 
void | 
updateMobFlushCount()  | 
void | 
updateMobFlushedCellsCount(long count)  | 
void | 
updateMobFlushedCellsSize(long size)  | 
void | 
updateMobScanCellsCount(long count)  | 
void | 
updateMobScanCellsSize(long size)  | 
add, addChangedReaderObserver, areWritesEnabled, assertBulkLoadHFileOk, bulkLoadHFile, bulkLoadHFile, cancelRequestedCompaction, canSplit, close, compact, compactRecentForTestingAssumingDefaultPolicy, completeCompaction, completeCompaction, createFlushContext, createWriterInTmp, delete, deleteChangedReaderObserver, deregisterChildren, determineTTLFromFamily, flushCache, getAvgStoreFileAge, getBlockingFileCount, getBytesPerChecksum, getCacheConfig, getChecksumType, getCloseCheckInterval, getColumnFamilyName, getCompactedCellsCount, getCompactedCellsSize, getCompactionCheckMultiplier, getCompactionPressure, getCompactionProgress, getCompactPriority, getComparator, getCoprocessorHost, getDataBlockEncoder, getFamily, getFileSystem, getFlushableSize, getFlushedCellsCount, getFlushedCellsSize, getFlushedOutputFileSize, getHRegion, getLastCompactSize, getMajorCompactedCellsCount, getMajorCompactedCellsSize, getMaxMemstoreTS, getMaxSequenceId, getMaxStoreFileAge, getMemstoreFlushSize, getMemStoreSize, getMinStoreFileAge, getNumHFiles, getNumReferenceFiles, 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, preBulkLoadHFile, refreshStoreFiles, refreshStoreFiles, registerChildren, replayCompactionMarker, requestCompaction, requestCompaction, requestCompaction, rollback, throttleCompaction, timeOfOldestEdit, toString, triggerMajorCompaction, updateColumnValue, upsertpublic HMobStore(HRegion region, HColumnDescriptor family, Configuration confParam) throws IOException
IOExceptionprotected void createCacheConf(HColumnDescriptor family)
createCacheConf in class HStorefamily - The current column family.public Configuration getConfiguration()
protected KeyValueScanner createScanner(Scan scan, NavigableSet<byte[]> targetCols, long readPt, KeyValueScanner scanner) throws IOException
createScanner in class HStoreIOExceptionprotected StoreEngine<?,?,?,?> createStoreEngine(Store store, Configuration conf, KeyValue.KVComparator cellComparator) throws IOException
createStoreEngine in class HStorestore - The store. An unfortunate dependency needed due to it
              being passed to coprocessors via the compactor.conf - Store configuration.cellComparator - KVComparator for storeFileManager.IOExceptionpublic StoreFile.Writer createWriterInTmp(Date date, long maxKeyCount, Compression.Algorithm compression, byte[] startKey) throws IOException
date - The latest date of written cells.maxKeyCount - The key count.compression - The compression algorithm.startKey - The start key.IOExceptionpublic StoreFile.Writer createDelFileWriterInTmp(Date date, long maxKeyCount, Compression.Algorithm compression, byte[] startKey) throws IOException
date - The latest date of written cells.maxKeyCount - The key count.compression - The compression algorithm.startKey - The start key.IOExceptionpublic StoreFile.Writer createWriterInTmp(String date, Path basePath, long maxKeyCount, Compression.Algorithm compression, byte[] startKey) throws IOException
date - The date string, its format is yyyymmmdd.basePath - The basic path for a temp directory.maxKeyCount - The key count.compression - The compression algorithm.startKey - The start key.IOExceptionpublic StoreFile.Writer createWriterInTmp(MobFileName mobFileName, Path basePath, long maxKeyCount, Compression.Algorithm compression) throws IOException
mobFileName - The mob file name.basePath - The basic path for a temp directory.maxKeyCount - The key count.compression - The compression algorithm.IOExceptionpublic void commitFile(Path sourceFile,
                       Path targetPath)
                throws IOException
sourceFile - The source file.targetPath - The directory path where the source file is renamed to.IOExceptionpublic Cell resolve(Cell reference, boolean cacheBlocks) throws IOException
reference - The cell found in the HBase, its value is a path to a mob file.cacheBlocks - Whether the scanner should cache blocks.IOExceptionpublic Cell resolve(Cell reference, boolean cacheBlocks, long readPt, boolean readEmptyValueOnMobCellMiss) throws IOException
reference - The cell found in the HBase, its value is a path to a mob file.cacheBlocks - Whether the scanner should cache blocks.readPt - the read point.readEmptyValueOnMobCellMiss - Whether return null value when the mob file is
        missing or corrupt.IOExceptionpublic Path getPath()
public List<StoreFile> compact(CompactionContext compaction, CompactionThroughputController throughputController) throws IOException
compact in interface Storecompact in class HStorecompaction - compaction details obtained from requestCompaction()IOExceptionpublic void updateCellsCountCompactedToMob(long count)
public long getCellsCountCompactedToMob()
public void updateCellsCountCompactedFromMob(long count)
public long getCellsCountCompactedFromMob()
public void updateCellsSizeCompactedToMob(long size)
public long getCellsSizeCompactedToMob()
public void updateCellsSizeCompactedFromMob(long size)
public long getCellsSizeCompactedFromMob()
public void updateMobFlushCount()
public long getMobFlushCount()
public void updateMobFlushedCellsCount(long count)
public long getMobFlushedCellsCount()
public void updateMobFlushedCellsSize(long size)
public long getMobFlushedCellsSize()
public void updateMobScanCellsCount(long count)
public long getMobScanCellsCount()
public void updateMobScanCellsSize(long size)
public long getMobScanCellsSize()