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
Modifier and TypeFieldDescriptionprivate final SerialReplicationChecker
private Cell
private static final org.slf4j.Logger
Fields inherited from class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceWALReader
entryBatchQueue, waitingPeerEnabled
Fields inherited from class java.lang.Thread
MAX_PRIORITY, MIN_PRIORITY, NORM_PRIORITY
-
Constructor Summary
ConstructorDescriptionSerialReplicationSourceWALReader
(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 void
readWALEntries
(WALEntryStream entryStream, WALEntryBatch batch) private void
removeEntryFromStream
(WALEntryStream entryStream, WALEntryBatch batch) Methods inherited from class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceWALReader
addEntryToBatch, filterEntry, getCurrentPath, isReaderRunning, poll, run, setReaderRunning, sleep, switched, take
Methods inherited from class java.lang.Thread
activeCount, checkAccess, clone, countStackFrames, currentThread, destroy, dumpStack, enumerate, getAllStackTraces, getContextClassLoader, getDefaultUncaughtExceptionHandler, getId, getName, getPriority, getStackTrace, getState, getThreadGroup, getUncaughtExceptionHandler, holdsLock, interrupt, interrupted, isAlive, isDaemon, isInterrupted, join, join, join, resume, setContextClassLoader, setDaemon, setDefaultUncaughtExceptionHandler, setName, setPriority, setUncaughtExceptionHandler, sleep, sleep, start, stop, 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:
readWALEntries
in classReplicationSourceWALReader
- Throws:
InterruptedException
-
removeEntryFromStream
-