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, updateStatusWithMsg
private 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 OutputSink
buffer
- A buffer of some number of edits for a given region.IOException
- For any IO errorsvoid flush() throws IOException
IOException
public boolean keepRegionEvent(WAL.Entry entry)
OutputSink
keepRegionEvent
in class OutputSink
public List<org.apache.hadoop.fs.Path> close() throws IOException
close
in class OutputSink
IOException
public Map<String,Long> getOutputCounts()
OutputSink
getOutputCounts
in class OutputSink
public int getNumberOfRecoveredRegions()
OutputSink
getNumberOfRecoveredRegions
in class OutputSink
AtomicLong getSkippedEditsCounter()
private boolean requiresReplication(TableName tableName, List<WAL.Entry> entries) throws IOException
IOException
protected int getNumOpenWriters()
OutputSink
getNumOpenWriters
in class OutputSink
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.