static class RegionReplicaReplicationEndpoint.RegionReplicaOutputSink extends WALSplitter.OutputSink
| Modifier and Type | Field and Description |
|---|---|
private org.apache.hbase.thirdparty.com.google.common.cache.Cache<TableName,Boolean> |
memstoreReplicationEnabled |
private RegionReplicaReplicationEndpoint.RegionReplicaSinkWriter |
sinkWriter |
private TableDescriptors |
tableDescriptors |
blacklistedRegions, closeAndCleanCompleted, controller, entryBuffers, numThreads, regionMaximumEditLogSeqNum, reporter, skippedEdits, splits, writers, writersClosed, writerThreads| Constructor and Description |
|---|
RegionReplicaOutputSink(WALSplitter.PipelineController controller,
TableDescriptors tableDescriptors,
WALSplitter.EntryBuffers entryBuffers,
ClusterConnection connection,
ExecutorService pool,
int numWriters,
int operationTimeout) |
| Modifier and Type | Method and Description |
|---|---|
void |
append(WALSplitter.RegionEntryBuffer buffer) |
List<org.apache.hadoop.fs.Path> |
finishWritingAndClose() |
boolean |
flush()
WriterThread call this function to help flush internal remaining edits in buffer before close
|
int |
getNumberOfRecoveredRegions() |
Map<byte[],Long> |
getOutputCounts() |
(package private) AtomicLong |
getSkippedEditsCounter() |
boolean |
keepRegionEvent(WAL.Entry entry)
Some WALEdit's contain only KV's for account on what happened to a region.
|
private boolean |
requiresReplication(TableName tableName,
List<WAL.Entry> entries)
returns true if the specified entry must be replicated.
|
finishWriting, startWriterThreadsprivate final RegionReplicaReplicationEndpoint.RegionReplicaSinkWriter sinkWriter
private final TableDescriptors tableDescriptors
private final org.apache.hbase.thirdparty.com.google.common.cache.Cache<TableName,Boolean> memstoreReplicationEnabled
public RegionReplicaOutputSink(WALSplitter.PipelineController controller, TableDescriptors tableDescriptors, WALSplitter.EntryBuffers entryBuffers, ClusterConnection connection, ExecutorService pool, int numWriters, int operationTimeout)
public void append(WALSplitter.RegionEntryBuffer buffer) throws IOException
append in class WALSplitter.OutputSinkbuffer - A WAL Edit EntryIOExceptionpublic boolean flush() throws IOException
WALSplitter.OutputSinkflush in class WALSplitter.OutputSinkIOExceptionpublic boolean keepRegionEvent(WAL.Entry entry)
WALSplitter.OutputSinkkeepRegionEvent in class WALSplitter.OutputSinkpublic List<org.apache.hadoop.fs.Path> finishWritingAndClose() throws IOException
finishWritingAndClose in class WALSplitter.OutputSinkIOExceptionpublic Map<byte[],Long> getOutputCounts()
getOutputCounts in class WALSplitter.OutputSinkpublic int getNumberOfRecoveredRegions()
getNumberOfRecoveredRegions in class WALSplitter.OutputSinkAtomicLong getSkippedEditsCounter()
private boolean requiresReplication(TableName tableName, List<WAL.Entry> entries) throws IOException
IOExceptionCopyright © 2007–2019 The Apache Software Foundation. All rights reserved.