@InterfaceAudience.Private abstract class StoreFlusher extends Object
Modifier and Type | Field and Description |
---|---|
protected org.apache.hadoop.conf.Configuration |
conf |
protected HStore |
store |
Constructor and Description |
---|
StoreFlusher(org.apache.hadoop.conf.Configuration conf,
HStore store) |
Modifier and Type | Method and Description |
---|---|
protected InternalScanner |
createScanner(List<KeyValueScanner> snapshotScanners,
FlushLifeCycleTracker tracker)
Creates the scanner for flushing snapshot.
|
protected StoreFileWriter |
createWriter(MemStoreSnapshot snapshot,
boolean alwaysIncludesTag,
Consumer<org.apache.hadoop.fs.Path> writerCreationTracker) |
protected void |
finalizeWriter(StoreFileWriter writer,
long cacheFlushSeqNum,
MonitoredTask status) |
abstract List<org.apache.hadoop.fs.Path> |
flushSnapshot(MemStoreSnapshot snapshot,
long cacheFlushSeqNum,
MonitoredTask status,
ThroughputController throughputController,
FlushLifeCycleTracker tracker,
Consumer<org.apache.hadoop.fs.Path> writerCreationTracker)
Turns a snapshot of memstore into a set of store files.
|
protected void |
performFlush(InternalScanner scanner,
CellSink sink,
ThroughputController throughputController)
Performs memstore flush, writing data from scanner into sink.
|
public StoreFlusher(org.apache.hadoop.conf.Configuration conf, HStore store)
public abstract List<org.apache.hadoop.fs.Path> flushSnapshot(MemStoreSnapshot snapshot, long cacheFlushSeqNum, MonitoredTask status, ThroughputController throughputController, FlushLifeCycleTracker tracker, Consumer<org.apache.hadoop.fs.Path> writerCreationTracker) throws IOException
snapshot
- Memstore snapshot.cacheFlushSeqNum
- Log cache flush sequence number.status
- Task that represents the flush operation and may be updated with
status.throughputController
- A controller to avoid flush too fastIOException
protected void finalizeWriter(StoreFileWriter writer, long cacheFlushSeqNum, MonitoredTask status) throws IOException
IOException
protected final StoreFileWriter createWriter(MemStoreSnapshot snapshot, boolean alwaysIncludesTag, Consumer<org.apache.hadoop.fs.Path> writerCreationTracker) throws IOException
IOException
protected final InternalScanner createScanner(List<KeyValueScanner> snapshotScanners, FlushLifeCycleTracker tracker) throws IOException
IOException
protected void performFlush(InternalScanner scanner, CellSink sink, ThroughputController throughputController) throws IOException
scanner
- Scanner to get data from.sink
- Sink to write data to. Could be StoreFile.Writer.throughputController
- A controller to avoid flush too fastIOException
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.