@InterfaceAudience.Private public class RecoveredReplicationSourceShipper extends ReplicationSourceShipper
RecoveredReplicationSource
.ReplicationSourceShipper.WorkerState
Thread.State, Thread.UncaughtExceptionHandler
Modifier and Type | Field and Description |
---|---|
private static org.slf4j.Logger |
LOG |
private ReplicationQueues |
replicationQueues |
protected RecoveredReplicationSource |
source |
conf, currentPath, entryReader, lastLoggedPosition, maxRetriesMultiplier, queue, sleepForRetries, walGroupId
MAX_PRIORITY, MIN_PRIORITY, NORM_PRIORITY
Constructor and Description |
---|
RecoveredReplicationSourceShipper(org.apache.hadoop.conf.Configuration conf,
String walGroupId,
PriorityBlockingQueue<org.apache.hadoop.fs.Path> queue,
RecoveredReplicationSource source,
ReplicationQueues replicationQueues) |
Modifier and Type | Method and Description |
---|---|
private long |
getRecoveredQueueStartPos() |
long |
getStartPosition() |
void |
run() |
private void |
terminate(String reason,
Exception cause) |
protected void |
updateLogPosition(long lastReadPosition) |
getCurrentPath, getCurrentPosition, getLogQueue, getWorkerState, isActive, isFinished, setWALReader, setWorkerState, shipEdits, sleepForRetries, startup, stopWorker
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 static final org.slf4j.Logger LOG
protected final RecoveredReplicationSource source
private final ReplicationQueues replicationQueues
public RecoveredReplicationSourceShipper(org.apache.hadoop.conf.Configuration conf, String walGroupId, PriorityBlockingQueue<org.apache.hadoop.fs.Path> queue, RecoveredReplicationSource source, ReplicationQueues replicationQueues)
public void run()
run
in interface Runnable
run
in class ReplicationSourceShipper
public long getStartPosition()
getStartPosition
in class ReplicationSourceShipper
private long getRecoveredQueueStartPos()
protected void updateLogPosition(long lastReadPosition)
updateLogPosition
in class ReplicationSourceShipper
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.