Package org.apache.hadoop.hbase.wal
Class AbstractRecoveredEditsOutputSink
java.lang.Object
org.apache.hadoop.hbase.wal.OutputSink
org.apache.hadoop.hbase.wal.AbstractRecoveredEditsOutputSink
- Direct Known Subclasses:
BoundedRecoveredEditsOutputSink
,RecoveredEditsOutputSink
-
Nested Class Summary
Modifier and TypeClassDescription(package private) final class
Private data structure that wraps aWALProvider.Writer
and its Path, also collecting statistics about the data written to this output.Nested classes/interfaces inherited from class org.apache.hadoop.hbase.wal.OutputSink
OutputSink.WriterThread
-
Field Summary
Modifier and TypeFieldDescriptionprivate static final org.slf4j.Logger
private final ConcurrentMap<String,
Long> private final WALSplitter
Fields inherited from class org.apache.hadoop.hbase.wal.OutputSink
closeCompletionService, closeThreadPool, entryBuffers, numThreads, reporter, splits, status, totalSkippedEdits
-
Constructor Summary
ConstructorDescriptionAbstractRecoveredEditsOutputSink
(WALSplitter walSplitter, WALSplitter.PipelineController controller, EntryBuffers entryBuffers, int numWriters) -
Method Summary
Modifier and TypeMethodDescriptionprotected org.apache.hadoop.fs.Path
closeRecoveredEditsWriter
(AbstractRecoveredEditsOutputSink.RecoveredEditsWriter editsWriter, List<IOException> thrown) createRecoveredEditsWriter
(TableName tableName, byte[] region, long seqId) Returns a writer that wraps aWALProvider.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
Update region's maximum edit log SeqNum.Methods inherited from class org.apache.hadoop.hbase.wal.OutputSink
append, close, finishWriterThreads, getNumberOfRecoveredRegions, getNumOpenWriters, getOutputCounts, getTotalSkippedEdits, restartWriterThreadsIfNeeded, setReporter, setStatus, startWriterThreads, updateStatusWithMsg
-
Field Details
-
LOG
-
walSplitter
-
regionMaximumEditLogSeqNum
-
-
Constructor Details
-
AbstractRecoveredEditsOutputSink
public AbstractRecoveredEditsOutputSink(WALSplitter walSplitter, WALSplitter.PipelineController controller, EntryBuffers entryBuffers, int numWriters)
-
-
Method Details
-
createRecoveredEditsWriter
protected AbstractRecoveredEditsOutputSink.RecoveredEditsWriter createRecoveredEditsWriter(TableName tableName, byte[] region, long seqId) throws IOException Returns a writer that wraps aWALProvider.Writer
and its Path. Caller should close.- Throws:
IOException
-
closeRecoveredEditsWriter
protected org.apache.hadoop.fs.Path closeRecoveredEditsWriter(AbstractRecoveredEditsOutputSink.RecoveredEditsWriter editsWriter, List<IOException> thrown) throws IOException - Throws:
IOException
-
keepRegionEvent
Description copied from class:OutputSink
Some WALEdit's contain only KV's for account on what happened to a region. Not all sinks will want to get all of those edits.- Specified by:
keepRegionEvent
in classOutputSink
- Returns:
- Return true if this sink wants to accept this region-level WALEdit.
-
updateRegionMaximumEditLogSeqNum
Update region's maximum edit log SeqNum. -
deleteOneWithFewerEntries
private void deleteOneWithFewerEntries(AbstractRecoveredEditsOutputSink.RecoveredEditsWriter editsWriter, org.apache.hadoop.fs.Path dst) throws IOException - Throws:
IOException
-