@InterfaceAudience.Private public class SerialReplicationSourceWALReader extends ReplicationSourceWALReader
Thread.State, Thread.UncaughtExceptionHandler
Modifier and Type | Field and Description |
---|---|
private SerialReplicationChecker |
checker |
private Cell |
firstCellInEntryBeforeFiltering |
MAX_PRIORITY, MIN_PRIORITY, NORM_PRIORITY
Constructor and Description |
---|
SerialReplicationSourceWALReader(org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.conf.Configuration conf,
PriorityBlockingQueue<org.apache.hadoop.fs.Path> logQueue,
long startPosition,
WALEntryFilter filter,
ReplicationSource source) |
Modifier and Type | Method and Description |
---|---|
protected WALEntryBatch |
readWALEntries(WALEntryStream entryStream) |
private void |
removeEntryFromStream(WALEntryStream entryStream,
WALEntryBatch batch) |
addEntryToBatch, createBatch, filterEntry, getCurrentPath, getEntrySizeExcludeBulkLoad, isReaderRunning, poll, run, setReaderRunning, switched, take
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
private Cell firstCellInEntryBeforeFiltering
private final SerialReplicationChecker checker
public SerialReplicationSourceWALReader(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.conf.Configuration conf, PriorityBlockingQueue<org.apache.hadoop.fs.Path> logQueue, long startPosition, WALEntryFilter filter, ReplicationSource source)
protected WALEntryBatch readWALEntries(WALEntryStream entryStream) throws IOException, InterruptedException
readWALEntries
in class ReplicationSourceWALReader
IOException
InterruptedException
private void removeEntryFromStream(WALEntryStream entryStream, WALEntryBatch batch) throws IOException
IOException
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.