static class RegionReplicaReplicationEndpoint.RegionReplicaOutputSink extends OutputSink
OutputSink.WriterThread| 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  | 
closeCompletionService, closeThreadPool, entryBuffers, numThreads, reporter, splits, status, totalSkippedEdits| Constructor and Description | 
|---|
RegionReplicaOutputSink(WALSplitter.PipelineController controller,
                       TableDescriptors tableDescriptors,
                       EntryBuffers entryBuffers,
                       ClusterConnection connection,
                       ExecutorService pool,
                       int numWriters,
                       int operationTimeout)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
append(EntryBuffers.RegionEntryBuffer buffer)  | 
List<org.apache.hadoop.fs.Path> | 
close()  | 
(package private) void | 
flush()  | 
int | 
getNumberOfRecoveredRegions()
Returns number of regions we've recovered 
 | 
protected int | 
getNumOpenWriters()
Returns the number of currently opened writers 
 | 
Map<String,Long> | 
getOutputCounts()
Returns a map from encoded region ID to the number of edits written out for that region. 
 | 
(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. 
 | 
finishWriterThreads, restartWriterThreadsIfNeeded, startWriterThreads, updateStatusWithMsgprivate 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, EntryBuffers entryBuffers, ClusterConnection connection, ExecutorService pool, int numWriters, int operationTimeout)
public void append(EntryBuffers.RegionEntryBuffer buffer) throws IOException
append in class OutputSinkbuffer - A buffer of some number of edits for a given region.IOException - For any IO errorsvoid flush() throws IOException
IOExceptionpublic boolean keepRegionEvent(WAL.Entry entry)
OutputSinkkeepRegionEvent in class OutputSinkpublic List<org.apache.hadoop.fs.Path> close() throws IOException
close in class OutputSinkIOExceptionpublic Map<String,Long> getOutputCounts()
OutputSinkgetOutputCounts in class OutputSinkpublic int getNumberOfRecoveredRegions()
OutputSinkgetNumberOfRecoveredRegions in class OutputSinkAtomicLong getSkippedEditsCounter()
private boolean requiresReplication(TableName tableName, List<WAL.Entry> entries) throws IOException
IOExceptionprotected int getNumOpenWriters()
OutputSinkgetNumOpenWriters in class OutputSinkCopyright © 2007–2020 The Apache Software Foundation. All rights reserved.