Modifier and Type | Method and Description |
---|---|
ZooKeeperProtos.SplitLogTask.RecoveryMode |
SplitLogTask.getMode() |
Constructor and Description |
---|
SplitLogTask.Done(ServerName originServer,
ZooKeeperProtos.SplitLogTask.RecoveryMode mode) |
SplitLogTask.Err(ServerName originServer,
ZooKeeperProtos.SplitLogTask.RecoveryMode mode) |
SplitLogTask.Owned(ServerName originServer,
ZooKeeperProtos.SplitLogTask.RecoveryMode mode) |
SplitLogTask.Resigned(ServerName originServer,
ZooKeeperProtos.SplitLogTask.RecoveryMode mode) |
SplitLogTask.Unassigned(ServerName originServer,
ZooKeeperProtos.SplitLogTask.RecoveryMode mode) |
Modifier and Type | Method and Description |
---|---|
ZooKeeperProtos.SplitLogTask.RecoveryMode |
ZKSplitLogManagerCoordination.getRecoveryMode() |
ZooKeeperProtos.SplitLogTask.RecoveryMode |
SplitLogManagerCoordination.getRecoveryMode()
Temporary function, mostly for UTs.
|
Modifier and Type | Method and Description |
---|---|
protected static int |
ZkSplitLogWorkerCoordination.attemptToOwnTask(boolean isFirstTime,
ZooKeeperWatcher zkw,
ServerName server,
String task,
ZooKeeperProtos.SplitLogTask.RecoveryMode mode,
int taskZKVersion)
Try to own the task by transitioning the zk node data from UNASSIGNED to OWNED.
|
Modifier and Type | Method and Description |
---|---|
ZooKeeperProtos.SplitLogTask.RecoveryMode |
MasterFileSystem.getLogRecoveryMode() |
ZooKeeperProtos.SplitLogTask.RecoveryMode |
SplitLogManager.getRecoveryMode() |
Modifier and Type | Method and Description |
---|---|
ZooKeeperProtos.SplitLogTask.RecoveryMode |
ZooKeeperProtos.SplitLogTaskOrBuilder.getMode()
optional .SplitLogTask.RecoveryMode mode = 3 [default = UNKNOWN]; |
ZooKeeperProtos.SplitLogTask.RecoveryMode |
ZooKeeperProtos.SplitLogTask.getMode()
optional .SplitLogTask.RecoveryMode mode = 3 [default = UNKNOWN]; |
ZooKeeperProtos.SplitLogTask.RecoveryMode |
ZooKeeperProtos.SplitLogTask.Builder.getMode()
optional .SplitLogTask.RecoveryMode mode = 3 [default = UNKNOWN]; |
static ZooKeeperProtos.SplitLogTask.RecoveryMode |
ZooKeeperProtos.SplitLogTask.RecoveryMode.valueOf(com.google.protobuf.Descriptors.EnumValueDescriptor desc) |
static ZooKeeperProtos.SplitLogTask.RecoveryMode |
ZooKeeperProtos.SplitLogTask.RecoveryMode.valueOf(int value) |
static ZooKeeperProtos.SplitLogTask.RecoveryMode |
ZooKeeperProtos.SplitLogTask.RecoveryMode.valueOf(String name)
Returns the enum constant of this type with the specified name.
|
static ZooKeeperProtos.SplitLogTask.RecoveryMode[] |
ZooKeeperProtos.SplitLogTask.RecoveryMode.values()
Returns an array containing the constants of this enum type, in
the order they are declared.
|
Modifier and Type | Method and Description |
---|---|
static com.google.protobuf.Internal.EnumLiteMap<ZooKeeperProtos.SplitLogTask.RecoveryMode> |
ZooKeeperProtos.SplitLogTask.RecoveryMode.internalGetValueMap() |
Modifier and Type | Method and Description |
---|---|
ZooKeeperProtos.SplitLogTask.Builder |
ZooKeeperProtos.SplitLogTask.Builder.setMode(ZooKeeperProtos.SplitLogTask.RecoveryMode value)
optional .SplitLogTask.RecoveryMode mode = 3 [default = UNKNOWN]; |
Modifier and Type | Method and Description |
---|---|
SplitLogWorker.TaskExecutor.Status |
SplitLogWorker.TaskExecutor.exec(String name,
ZooKeeperProtos.SplitLogTask.RecoveryMode mode,
CancelableProgressable p) |
Constructor and Description |
---|
WALSplitterHandler(Server server,
SplitLogWorkerCoordination coordination,
SplitLogWorkerCoordination.SplitTaskDetails splitDetails,
CancelableProgressable reporter,
AtomicInteger inProgressTasks,
SplitLogWorker.TaskExecutor splitTaskExecutor,
ZooKeeperProtos.SplitLogTask.RecoveryMode mode) |
Modifier and Type | Method and Description |
---|---|
static boolean |
WALSplitter.splitLogFile(org.apache.hadoop.fs.Path rootDir,
org.apache.hadoop.fs.FileStatus logfile,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.conf.Configuration conf,
CancelableProgressable reporter,
LastSequenceId idChecker,
CoordinatedStateManager cp,
ZooKeeperProtos.SplitLogTask.RecoveryMode mode,
WALFactory factory)
Splits a WAL file into region's recovered-edits directory.
|
Copyright © 2007-2016 The Apache Software Foundation. All Rights Reserved.