public class TestSplitLogManager extends Object
Modifier and Type | Class and Description |
---|---|
(package private) class |
TestSplitLogManager.DummyMasterServices |
private static interface |
TestSplitLogManager.Expr |
Modifier and Type | Field and Description |
---|---|
static HBaseClassTestRule |
CLASS_RULE |
private org.apache.hadoop.conf.Configuration |
conf |
private static org.slf4j.Logger |
LOG |
private TestSplitLogManager.DummyMasterServices |
master |
private org.apache.hadoop.hbase.master.SplitLogManager |
slm |
private org.apache.hadoop.hbase.master.ServerManager |
sm |
private static HBaseTestingUtility |
TEST_UTIL |
private int |
to |
private org.apache.hadoop.hbase.zookeeper.ZKWatcher |
zkw |
Constructor and Description |
---|
TestSplitLogManager() |
Modifier and Type | Method and Description |
---|---|
private org.apache.hadoop.hbase.master.SplitLogManager.Task |
findOrCreateOrphanTask(String path) |
void |
setup() |
private String |
submitTaskAndWait(org.apache.hadoop.hbase.master.SplitLogManager.TaskBatch batch,
String name) |
void |
teardown() |
void |
testBatchWaitMillis() |
void |
testDeadWorker() |
void |
testEmptyLogDir() |
void |
testLogFilesAreArchived() |
void |
testMultipleResubmits() |
void |
testOrphanTaskAcquisition() |
void |
testRescanCleanup() |
void |
testTaskCreation()
Test whether the splitlog correctly creates a task in zookeeper
|
void |
testTaskDone() |
void |
testTaskErr() |
void |
testTaskResigned() |
void |
testUnassignedOrphan() |
void |
testUnassignedTimeout() |
void |
testWorkerCrash() |
private void |
waitForCounter(LongAdder ctr,
long oldval,
long newval,
long timems) |
private void |
waitForCounter(TestSplitLogManager.Expr e,
long oldval,
long newval,
long timems) |
public static final HBaseClassTestRule CLASS_RULE
private static final org.slf4j.Logger LOG
private final org.apache.hadoop.hbase.master.ServerManager sm
private org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw
private TestSplitLogManager.DummyMasterServices master
private org.apache.hadoop.hbase.master.SplitLogManager slm
private org.apache.hadoop.conf.Configuration conf
private int to
private static HBaseTestingUtility TEST_UTIL
public TestSplitLogManager()
public void teardown() throws IOException, org.apache.zookeeper.KeeperException
IOException
org.apache.zookeeper.KeeperException
public void testBatchWaitMillis()
private void waitForCounter(LongAdder ctr, long oldval, long newval, long timems) throws Exception
Exception
private void waitForCounter(TestSplitLogManager.Expr e, long oldval, long newval, long timems) throws Exception
Exception
private org.apache.hadoop.hbase.master.SplitLogManager.Task findOrCreateOrphanTask(String path)
private String submitTaskAndWait(org.apache.hadoop.hbase.master.SplitLogManager.TaskBatch batch, String name) throws org.apache.zookeeper.KeeperException, InterruptedException
org.apache.zookeeper.KeeperException
InterruptedException
public void testTaskCreation() throws Exception
Exception
public void testOrphanTaskAcquisition() throws Exception
Exception
public void testUnassignedOrphan() throws Exception
Exception
public void testMultipleResubmits() throws Exception
Exception
public void testRescanCleanup() throws Exception
Exception
public void testTaskDone() throws Exception
Exception
public void testTaskErr() throws Exception
Exception
public void testTaskResigned() throws Exception
Exception
public void testUnassignedTimeout() throws Exception
Exception
public void testDeadWorker() throws Exception
Exception
public void testWorkerCrash() throws Exception
Exception
public void testEmptyLogDir() throws Exception
Exception
public void testLogFilesAreArchived() throws Exception
Exception
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.