class WALSplitter.LogRecoveredEditsOutputSink extends WALSplitter.OutputSink
blacklistedRegions, closeAndCleanCompleted, controller, entryBuffers, numThreads, regionMaximumEditLogSeqNum, reporter, skippedEdits, splits, writers, writersClosed, writerThreads| Constructor and Description |
|---|
LogRecoveredEditsOutputSink(WALSplitter.PipelineController controller,
WALSplitter.EntryBuffers entryBuffers,
int numWriters) |
| Modifier and Type | Method and Description |
|---|---|
void |
append(WALSplitter.RegionEntryBuffer buffer) |
(package private) WALSplitter.WriterAndPath |
appendBuffer(WALSplitter.RegionEntryBuffer buffer,
boolean reusable) |
(package private) List<org.apache.hadoop.fs.Path> |
close()
Close all of the output streams.
|
private List<IOException> |
closeLogWriters(List<IOException> thrown) |
(package private) org.apache.hadoop.fs.Path |
closeWriter(String encodedRegionName,
WALSplitter.WriterAndPath wap,
List<IOException> thrown) |
(package private) WALSplitter.WriterAndPath |
createWAP(byte[] region,
WAL.Entry entry) |
private void |
deleteOneWithFewerEntries(WALSplitter.WriterAndPath wap,
org.apache.hadoop.fs.Path dst) |
(package private) boolean |
executeCloseTask(CompletionService<Void> completionService,
List<IOException> thrown,
List<org.apache.hadoop.fs.Path> paths) |
(package private) void |
filterCellByStore(WAL.Entry logEntry) |
List<org.apache.hadoop.fs.Path> |
finishWritingAndClose() |
int |
getNumberOfRecoveredRegions() |
Map<byte[],Long> |
getOutputCounts() |
(package private) WALSplitter.WriterAndPath |
getWriterAndPath(WAL.Entry entry,
boolean reusable)
Get a writer and path for a log starting at the given entry.
|
boolean |
keepRegionEvent(WAL.Entry entry)
Some WALEdit's contain only KV's for account on what happened to a region.
|
finishWriting, flush, getNumOpenWriters, getSkippedEdits, setReporter, startWriterThreads, updateRegionMaximumEditLogSeqNumpublic LogRecoveredEditsOutputSink(WALSplitter.PipelineController controller, WALSplitter.EntryBuffers entryBuffers, int numWriters)
public List<org.apache.hadoop.fs.Path> finishWritingAndClose() throws IOException
finishWritingAndClose in class WALSplitter.OutputSinkIOExceptionprivate void deleteOneWithFewerEntries(WALSplitter.WriterAndPath wap, org.apache.hadoop.fs.Path dst) throws IOException
IOExceptionList<org.apache.hadoop.fs.Path> close() throws IOException
IOExceptionboolean executeCloseTask(CompletionService<Void> completionService, List<IOException> thrown, List<org.apache.hadoop.fs.Path> paths) throws InterruptedException, ExecutionException
completionService - threadPool to execute the closing tasksthrown - store the exceptionspaths - arrayList to store the paths writtenInterruptedExceptionExecutionExceptionorg.apache.hadoop.fs.Path closeWriter(String encodedRegionName, WALSplitter.WriterAndPath wap, List<IOException> thrown) throws IOException
IOExceptionprivate List<IOException> closeLogWriters(List<IOException> thrown) throws IOException
IOExceptionWALSplitter.WriterAndPath getWriterAndPath(WAL.Entry entry, boolean reusable) throws IOException
IOExceptionWALSplitter.WriterAndPath createWAP(byte[] region, WAL.Entry entry) throws IOException
IOExceptionvoid filterCellByStore(WAL.Entry logEntry)
public void append(WALSplitter.RegionEntryBuffer buffer) throws IOException
append in class WALSplitter.OutputSinkbuffer - A WAL Edit EntryIOExceptionWALSplitter.WriterAndPath appendBuffer(WALSplitter.RegionEntryBuffer buffer, boolean reusable) throws IOException
IOExceptionpublic boolean keepRegionEvent(WAL.Entry entry)
WALSplitter.OutputSinkkeepRegionEvent in class WALSplitter.OutputSinkpublic Map<byte[],Long> getOutputCounts()
getOutputCounts in class WALSplitter.OutputSinkpublic int getNumberOfRecoveredRegions()
getNumberOfRecoveredRegions in class WALSplitter.OutputSinkCopyright © 2007–2020 The Apache Software Foundation. All rights reserved.