use of com.alipay.sofa.jraft.closure.ReadIndexClosure in project sofa-jraft by sofastack.
the class NodeTest method testRollbackStateMachineWithReadIndex_Issue317.
/**
* Test rollback stateMachine with readIndex for issue 317:
* https://github.com/sofastack/sofa-jraft/issues/317
*/
@Test
public void testRollbackStateMachineWithReadIndex_Issue317() throws Exception {
final Endpoint addr = new Endpoint(TestUtils.getMyIp(), TestUtils.INIT_PORT);
final PeerId peer = new PeerId(addr, 0);
NodeManager.getInstance().addAddress(addr);
final NodeOptions nodeOptions = createNodeOptionsWithSharedTimer();
final CountDownLatch applyCompleteLatch = new CountDownLatch(1);
final CountDownLatch applyLatch = new CountDownLatch(1);
final CountDownLatch readIndexLatch = new CountDownLatch(1);
final AtomicInteger currentValue = new AtomicInteger(-1);
final String errorMsg = this.testName.getMethodName();
final StateMachine fsm = new StateMachineAdapter() {
@Override
public void onApply(final Iterator iter) {
// Notify that the #onApply is preparing to go.
readIndexLatch.countDown();
// Wait for submitting a read-index request
try {
applyLatch.await();
} catch (InterruptedException e) {
fail();
}
int i = 0;
while (iter.hasNext()) {
byte[] data = iter.next().array();
int v = Bits.getInt(data, 0);
assertEquals(i++, v);
currentValue.set(v);
}
if (i > 0) {
// rollback
currentValue.set(i - 1);
iter.setErrorAndRollback(1, new Status(-1, errorMsg));
applyCompleteLatch.countDown();
}
}
};
nodeOptions.setFsm(fsm);
nodeOptions.setLogUri(this.dataPath + File.separator + "log");
nodeOptions.setRaftMetaUri(this.dataPath + File.separator + "meta");
nodeOptions.setSnapshotUri(this.dataPath + File.separator + "snapshot");
nodeOptions.setInitialConf(new Configuration(Collections.singletonList(peer)));
final Node node = new NodeImpl("unittest", peer);
assertTrue(node.init(nodeOptions));
assertEquals(1, node.listPeers().size());
assertTrue(node.listPeers().contains(peer));
while (!node.isLeader()) {
;
}
int n = 5;
{
// apply tasks
for (int i = 0; i < n; i++) {
byte[] b = new byte[4];
Bits.putInt(b, 0, i);
node.apply(new Task(ByteBuffer.wrap(b), null));
}
}
final AtomicInteger readIndexSuccesses = new AtomicInteger(0);
{
// Submit a read-index, wait for #onApply
readIndexLatch.await();
final CountDownLatch latch = new CountDownLatch(1);
node.readIndex(null, new ReadIndexClosure() {
@Override
public void run(final Status status, final long index, final byte[] reqCtx) {
try {
if (status.isOk()) {
readIndexSuccesses.incrementAndGet();
} else {
assertTrue("Unexpected status: " + status, status.getErrorMsg().contains(errorMsg) || status.getRaftError() == RaftError.ETIMEDOUT || status.getErrorMsg().contains("Invalid state for readIndex: STATE_ERROR"));
}
} finally {
latch.countDown();
}
}
});
// We have already submit a read-index request,
// notify #onApply can go right now
applyLatch.countDown();
// The state machine is in error state, the node should step down.
while (node.isLeader()) {
Thread.sleep(10);
}
latch.await();
applyCompleteLatch.await();
}
// No read-index request succeed.
assertEquals(0, readIndexSuccesses.get());
assertTrue(n - 1 >= currentValue.get());
node.shutdown();
node.join();
}
use of com.alipay.sofa.jraft.closure.ReadIndexClosure in project sofa-jraft by sofastack.
the class NodeTest method testReadIndexTimeout.
@Test
public void testReadIndexTimeout() throws Exception {
final List<PeerId> peers = TestUtils.generatePeers(3);
final TestCluster cluster = new TestCluster("unittest", this.dataPath, peers);
for (final PeerId peer : peers) {
assertTrue(cluster.start(peer.getEndpoint(), false, 300, true));
}
// elect leader
cluster.waitLeader();
// get leader
final Node leader = cluster.getLeader();
assertNotNull(leader);
assertEquals(3, leader.listPeers().size());
// apply tasks to leader
sendTestTaskAndWait(leader);
// first call will fail-fast when no connection
if (!assertReadIndex(leader, 11)) {
assertTrue(assertReadIndex(leader, 11));
}
// read from follower
for (final Node follower : cluster.getFollowers()) {
assertNotNull(follower);
assertReadIndex(follower, 11);
}
// read with null request context
final CountDownLatch latch = new CountDownLatch(1);
final long start = System.currentTimeMillis();
leader.readIndex(null, new ReadIndexClosure(0) {
@Override
public void run(final Status status, final long index, final byte[] reqCtx) {
assertNull(reqCtx);
if (status.isOk()) {
System.err.println("Read-index so fast: " + (System.currentTimeMillis() - start) + "ms");
} else {
assertEquals(status, new Status(RaftError.ETIMEDOUT, "read-index request timeout"));
assertEquals(index, -1);
}
latch.countDown();
}
});
latch.await();
cluster.stopAll();
}
use of com.alipay.sofa.jraft.closure.ReadIndexClosure in project sofa-jraft by sofastack.
the class NodeTest method assertReadIndex.
@SuppressWarnings({ "unused", "SameParameterValue" })
private boolean assertReadIndex(final Node node, final int index) throws InterruptedException {
final CountDownLatch latch = new CountDownLatch(1);
final byte[] requestContext = TestUtils.getRandomBytes();
final AtomicBoolean success = new AtomicBoolean(false);
node.readIndex(requestContext, new ReadIndexClosure() {
@Override
public void run(final Status status, final long theIndex, final byte[] reqCtx) {
if (status.isOk()) {
assertEquals(index, theIndex);
assertArrayEquals(requestContext, reqCtx);
success.set(true);
} else {
assertTrue(status.getErrorMsg(), status.getErrorMsg().contains("RPC exception:Check connection["));
assertTrue(status.getErrorMsg(), status.getErrorMsg().contains("] fail and try to create new one"));
}
latch.countDown();
}
});
latch.await();
return success.get();
}
use of com.alipay.sofa.jraft.closure.ReadIndexClosure in project sofa-jraft by sofastack.
the class ReadOnlyServiceTest method testAddRequest.
@Test
public void testAddRequest() throws Exception {
final byte[] requestContext = TestUtils.getRandomBytes();
this.readOnlyServiceImpl.addRequest(requestContext, new ReadIndexClosure() {
@Override
public void run(final Status status, final long index, final byte[] reqCtx) {
}
});
this.readOnlyServiceImpl.flush();
Mockito.verify(this.node).handleReadIndexRequest(Mockito.argThat(new ArgumentMatcher<ReadIndexRequest>() {
@Override
public boolean matches(final Object argument) {
if (argument instanceof ReadIndexRequest) {
final ReadIndexRequest req = (ReadIndexRequest) argument;
return req.getGroupId().equals("test") && req.getServerId().equals("localhost:8081:0") && req.getEntriesCount() == 1 && Arrays.equals(requestContext, req.getEntries(0).toByteArray());
}
return false;
}
}), Mockito.any());
}
use of com.alipay.sofa.jraft.closure.ReadIndexClosure in project sofa-jraft by sofastack.
the class ReadOnlyServiceTest method testAddRequestOnResponseFailure.
@Test
public void testAddRequestOnResponseFailure() throws Exception {
Mockito.when(this.fsmCaller.getLastAppliedIndex()).thenReturn(2L);
final byte[] requestContext = TestUtils.getRandomBytes();
final CountDownLatch latch = new CountDownLatch(1);
this.readOnlyServiceImpl.addRequest(requestContext, new ReadIndexClosure() {
@Override
public void run(final Status status, final long index, final byte[] reqCtx) {
assertFalse(status.isOk());
assertEquals(index, -1);
assertArrayEquals(reqCtx, requestContext);
latch.countDown();
}
});
this.readOnlyServiceImpl.flush();
final ArgumentCaptor<RpcResponseClosure> closureCaptor = ArgumentCaptor.forClass(RpcResponseClosure.class);
Mockito.verify(this.node).handleReadIndexRequest(Mockito.argThat(new ArgumentMatcher<ReadIndexRequest>() {
@Override
public boolean matches(final Object argument) {
if (argument instanceof ReadIndexRequest) {
final ReadIndexRequest req = (ReadIndexRequest) argument;
return req.getGroupId().equals("test") && req.getServerId().equals("localhost:8081:0") && req.getEntriesCount() == 1 && Arrays.equals(requestContext, req.getEntries(0).toByteArray());
}
return false;
}
}), closureCaptor.capture());
final RpcResponseClosure closure = closureCaptor.getValue();
assertNotNull(closure);
closure.setResponse(ReadIndexResponse.newBuilder().setIndex(1).setSuccess(true).build());
closure.run(new Status(-1, "test"));
latch.await();
}
Aggregations