Class SerialReplicationSourceWALReader
java.lang.Object
java.lang.Thread
org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceWALReader
org.apache.hadoop.hbase.replication.regionserver.SerialReplicationSourceWALReader
- All Implemented Interfaces:
 Runnable
WAL reader for a serial replication peer.
- 
Nested Class Summary
Nested classes/interfaces inherited from class java.lang.Thread
Thread.State, Thread.UncaughtExceptionHandler - 
Field Summary
FieldsModifier and TypeFieldDescriptionprivate final SerialReplicationCheckerprivate Cellprivate static final org.slf4j.LoggerFields inherited from class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceWALReader
entryBatchQueueFields inherited from class java.lang.Thread
MAX_PRIORITY, MIN_PRIORITY, NORM_PRIORITY - 
Constructor Summary
ConstructorsConstructorDescriptionSerialReplicationSourceWALReader(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.conf.Configuration conf, ReplicationSourceLogQueue logQueue, long startPosition, WALEntryFilter filter, ReplicationSource source, String walGroupId)  - 
Method Summary
Modifier and TypeMethodDescriptionprotected voidreadWALEntries(WALEntryStream entryStream, WALEntryBatch batch) private voidremoveEntryFromStream(WAL.Entry entry, WALEntryStream entryStream, WALEntryBatch batch) Methods inherited from class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceWALReader
addEntryToBatch, filterEntry, getCurrentPath, isReaderRunning, poll, run, setReaderRunning, sleep, switched, takeMethods inherited from class java.lang.Thread
activeCount, checkAccess, clone, countStackFrames, currentThread, dumpStack, enumerate, getAllStackTraces, getContextClassLoader, getDefaultUncaughtExceptionHandler, getId, getName, getPriority, getStackTrace, getState, getThreadGroup, getUncaughtExceptionHandler, holdsLock, interrupt, interrupted, isAlive, isDaemon, isInterrupted, join, join, join, onSpinWait, resume, setContextClassLoader, setDaemon, setDefaultUncaughtExceptionHandler, setName, setPriority, setUncaughtExceptionHandler, sleep, sleep, start, stop, suspend, toString, yield 
- 
Field Details
- 
LOG
 - 
firstCellInEntryBeforeFiltering
 - 
checker
 
 - 
 - 
Constructor Details
- 
SerialReplicationSourceWALReader
public SerialReplicationSourceWALReader(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.conf.Configuration conf, ReplicationSourceLogQueue logQueue, long startPosition, WALEntryFilter filter, ReplicationSource source, String walGroupId)  
 - 
 - 
Method Details
- 
readWALEntries
protected void readWALEntries(WALEntryStream entryStream, WALEntryBatch batch) throws InterruptedException - Overrides:
 readWALEntriesin classReplicationSourceWALReader- Throws:
 InterruptedException
 - 
removeEntryFromStream
private void removeEntryFromStream(WAL.Entry entry, WALEntryStream entryStream, WALEntryBatch batch)  
 -