@InterfaceAudience.Private public class DefaultMobStoreCompactor extends DefaultCompactor
Compactor.CellSinkFactory<S>, Compactor.FileDetails, Compactor.InternalScannerFactory
Modifier and Type | Field and Description |
---|---|
private static org.slf4j.Logger |
LOG |
private long |
mobSizeThreshold |
private HMobStore |
mobStore |
private Compactor.InternalScannerFactory |
scannerFactory |
private Compactor.CellSinkFactory<StoreFileWriter> |
writerFactory |
COMPACTION_PROGRESS_LOG_INTERVAL, compactionCompression, compactionKVMax, conf, defaultScannerFactory, keepSeqIdPeriod, MAJOR_COMPACTION_DROP_CACHE, MINOR_COMPACTION_DROP_CACHE, progress, store
Constructor and Description |
---|
DefaultMobStoreCompactor(org.apache.hadoop.conf.Configuration conf,
HStore store) |
Modifier and Type | Method and Description |
---|---|
List<org.apache.hadoop.fs.Path> |
compact(CompactionRequestImpl request,
ThroughputController throughputController,
User user)
Do a minor/major compaction on an explicit set of storefiles from a Store.
|
protected boolean |
performCompaction(Compactor.FileDetails fd,
InternalScanner scanner,
CellSink writer,
long smallestReadPoint,
boolean cleanSeqId,
ThroughputController throughputController,
boolean major,
int numofFilesToCompact)
Performs compaction on a column family with the mob flag enabled.
|
abortWriter, commitWriter, compactForTesting
compact, createScanner, createScanner, createTmpWriter, getProgress
private static final org.slf4j.Logger LOG
private long mobSizeThreshold
private final Compactor.InternalScannerFactory scannerFactory
private final Compactor.CellSinkFactory<StoreFileWriter> writerFactory
public DefaultMobStoreCompactor(org.apache.hadoop.conf.Configuration conf, HStore store)
public List<org.apache.hadoop.fs.Path> compact(CompactionRequestImpl request, ThroughputController throughputController, User user) throws IOException
DefaultCompactor
compact
in class DefaultCompactor
IOException
protected boolean performCompaction(Compactor.FileDetails fd, InternalScanner scanner, CellSink writer, long smallestReadPoint, boolean cleanSeqId, ThroughputController throughputController, boolean major, int numofFilesToCompact) throws IOException
performCompaction
in class Compactor<StoreFileWriter>
fd
- File detailsscanner
- Where to read from.writer
- Where to write to.smallestReadPoint
- Smallest read point.cleanSeqId
- When true, remove seqId(used to be mvcc) value which is <= smallestReadPointthroughputController
- The compaction throughput controller.major
- Is a major compaction.numofFilesToCompact
- the number of files to compactIOException
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.