@InterfaceAudience.Private abstract class AbstractRecoveredEditsOutputSink extends OutputSink
Modifier and Type | Class and Description |
---|---|
(package private) class |
AbstractRecoveredEditsOutputSink.RecoveredEditsWriter
Private data structure that wraps a
WALProvider.Writer and its Path, also collecting
statistics about the data written to this output. |
OutputSink.WriterThread
Modifier and Type | Field and Description |
---|---|
private static org.slf4j.Logger |
LOG |
private ConcurrentMap<String,Long> |
regionMaximumEditLogSeqNum |
private WALSplitter |
walSplitter |
closeCompletionService, closeThreadPool, entryBuffers, numThreads, reporter, splits, status, totalSkippedEdits
Constructor and Description |
---|
AbstractRecoveredEditsOutputSink(WALSplitter walSplitter,
WALSplitter.PipelineController controller,
EntryBuffers entryBuffers,
int numWriters) |
Modifier and Type | Method and Description |
---|---|
protected org.apache.hadoop.fs.Path |
closeRecoveredEditsWriter(AbstractRecoveredEditsOutputSink.RecoveredEditsWriter editsWriter,
List<IOException> thrown) |
protected AbstractRecoveredEditsOutputSink.RecoveredEditsWriter |
createRecoveredEditsWriter(TableName tableName,
byte[] region,
long seqId)
Returns a writer that wraps a
WALProvider.Writer and its Path. |
private void |
deleteOneWithFewerEntries(AbstractRecoveredEditsOutputSink.RecoveredEditsWriter editsWriter,
org.apache.hadoop.fs.Path dst) |
boolean |
keepRegionEvent(WAL.Entry entry)
Some WALEdit's contain only KV's for account on what happened to a region.
|
(package private) void |
updateRegionMaximumEditLogSeqNum(WAL.Entry entry)
Update region's maximum edit log SeqNum.
|
append, close, finishWriterThreads, getNumberOfRecoveredRegions, getNumOpenWriters, getOutputCounts, getTotalSkippedEdits, restartWriterThreadsIfNeeded, setReporter, setStatus, startWriterThreads, updateStatusWithMsg
private static final org.slf4j.Logger LOG
private final WALSplitter walSplitter
private final ConcurrentMap<String,Long> regionMaximumEditLogSeqNum
public AbstractRecoveredEditsOutputSink(WALSplitter walSplitter, WALSplitter.PipelineController controller, EntryBuffers entryBuffers, int numWriters)
protected AbstractRecoveredEditsOutputSink.RecoveredEditsWriter createRecoveredEditsWriter(TableName tableName, byte[] region, long seqId) throws IOException
WALProvider.Writer
and its Path. Caller should close.IOException
protected org.apache.hadoop.fs.Path closeRecoveredEditsWriter(AbstractRecoveredEditsOutputSink.RecoveredEditsWriter editsWriter, List<IOException> thrown) throws IOException
IOException
public boolean keepRegionEvent(WAL.Entry entry)
OutputSink
keepRegionEvent
in class OutputSink
void updateRegionMaximumEditLogSeqNum(WAL.Entry entry)
private void deleteOneWithFewerEntries(AbstractRecoveredEditsOutputSink.RecoveredEditsWriter editsWriter, org.apache.hadoop.fs.Path dst) throws IOException
IOException
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.