Search in sources :

Example 1 with RaftOptions

use of org.apache.ignite.raft.jraft.option.RaftOptions in project ignite-3 by apache.

the class ItNodeTest method testNodeTaskOverload.

@Test
public void testNodeTaskOverload() throws Exception {
    Endpoint addr = new Endpoint(TestUtils.getLocalAddress(), TestUtils.INIT_PORT);
    PeerId peer = new PeerId(addr, 0);
    NodeOptions nodeOptions = createNodeOptions();
    RaftOptions raftOptions = new RaftOptions();
    raftOptions.setDisruptorBufferSize(2);
    nodeOptions.setRaftOptions(raftOptions);
    MockStateMachine fsm = new MockStateMachine(addr);
    nodeOptions.setFsm(fsm);
    nodeOptions.setLogUri(dataPath + File.separator + "log");
    nodeOptions.setRaftMetaUri(dataPath + File.separator + "meta");
    nodeOptions.setSnapshotUri(dataPath + File.separator + "snapshot");
    nodeOptions.setInitialConf(new Configuration(Collections.singletonList(peer)));
    RaftGroupService service = createService("unittest", new PeerId(addr, 0), nodeOptions);
    Node node = service.start();
    assertEquals(1, node.listPeers().size());
    assertTrue(node.listPeers().contains(peer));
    while (!node.isLeader()) ;
    List<Task> tasks = new ArrayList<>();
    AtomicInteger c = new AtomicInteger(0);
    for (int i = 0; i < 10; i++) {
        ByteBuffer data = ByteBuffer.wrap(("hello" + i).getBytes(UTF_8));
        int finalI = i;
        Task task = new Task(data, new JoinableClosure(status -> {
            LOG.info("{} i={}", status, finalI);
            if (!status.isOk()) {
                assertTrue(status.getRaftError() == RaftError.EBUSY || status.getRaftError() == RaftError.EPERM);
            }
            c.incrementAndGet();
        }));
        node.apply(task);
        tasks.add(task);
    }
    Task.joinAll(tasks, TimeUnit.SECONDS.toMillis(30));
    assertEquals(10, c.get());
}
Also used : SynchronizedClosure(org.apache.ignite.raft.jraft.closure.SynchronizedClosure) BeforeEach(org.junit.jupiter.api.BeforeEach) Arrays(java.util.Arrays) ExponentialBackoffTimeoutStrategy(org.apache.ignite.raft.jraft.util.ExponentialBackoffTimeoutStrategy) TaskClosure(org.apache.ignite.raft.jraft.closure.TaskClosure) SnapshotThrottle(org.apache.ignite.raft.jraft.storage.SnapshotThrottle) Disabled(org.junit.jupiter.api.Disabled) BooleanSupplier(java.util.function.BooleanSupplier) AfterAll(org.junit.jupiter.api.AfterAll) Future(java.util.concurrent.Future) ExtendWith(org.junit.jupiter.api.extension.ExtendWith) BeforeAll(org.junit.jupiter.api.BeforeAll) Path(java.nio.file.Path) Collections.synchronizedList(java.util.Collections.synchronizedList) Set(java.util.Set) Assertions.assertNotSame(org.junit.jupiter.api.Assertions.assertNotSame) ELECTION_TIMEOUT_MILLIS(org.apache.ignite.raft.jraft.core.TestCluster.ELECTION_TIMEOUT_MILLIS) TestUtils(org.apache.ignite.raft.jraft.test.TestUtils) ExecutorServiceHelper(org.apache.ignite.raft.jraft.util.ExecutorServiceHelper) Executors(java.util.concurrent.Executors) CountDownLatch(java.util.concurrent.CountDownLatch) Stream(java.util.stream.Stream) Assertions.assertTrue(org.junit.jupiter.api.Assertions.assertTrue) Endpoint(org.apache.ignite.raft.jraft.util.Endpoint) RaftError(org.apache.ignite.raft.jraft.error.RaftError) RpcServer(org.apache.ignite.raft.jraft.rpc.RpcServer) Assertions.fail(org.junit.jupiter.api.Assertions.fail) Assertions.assertNotNull(org.junit.jupiter.api.Assertions.assertNotNull) StateMachine(org.apache.ignite.raft.jraft.StateMachine) RaftException(org.apache.ignite.raft.jraft.error.RaftException) Assertions.assertNull(org.junit.jupiter.api.Assertions.assertNull) ArrayList(java.util.ArrayList) Task(org.apache.ignite.raft.jraft.entity.Task) IgniteRpcServer(org.apache.ignite.raft.jraft.rpc.impl.IgniteRpcServer) TestScaleCubeClusterServiceFactory(org.apache.ignite.network.scalecube.TestScaleCubeClusterServiceFactory) ThreadLocalRandom(java.util.concurrent.ThreadLocalRandom) Assertions.assertEquals(org.junit.jupiter.api.Assertions.assertEquals) LinkedHashSet(java.util.LinkedHashSet) NodeManager(org.apache.ignite.raft.jraft.NodeManager) LogIndexOutOfBoundsException(org.apache.ignite.raft.jraft.error.LogIndexOutOfBoundsException) RaftGroupService(org.apache.ignite.raft.jraft.RaftGroupService) LogNotFoundException(org.apache.ignite.raft.jraft.error.LogNotFoundException) DefaultRaftClientService(org.apache.ignite.raft.jraft.rpc.impl.core.DefaultRaftClientService) File(java.io.File) Assertions.assertSame(org.junit.jupiter.api.Assertions.assertSame) WorkDirectory(org.apache.ignite.internal.testframework.WorkDirectory) NetworkAddress(org.apache.ignite.network.NetworkAddress) Assertions.assertArrayEquals(org.junit.jupiter.api.Assertions.assertArrayEquals) AfterEach(org.junit.jupiter.api.AfterEach) ConsoleReporter(com.codahale.metrics.ConsoleReporter) RaftOptions(org.apache.ignite.raft.jraft.option.RaftOptions) EnumOutter(org.apache.ignite.raft.jraft.entity.EnumOutter) Assertions.assertNotEquals(org.junit.jupiter.api.Assertions.assertNotEquals) TestUtils.sender(org.apache.ignite.raft.jraft.test.TestUtils.sender) IgniteLogger(org.apache.ignite.lang.IgniteLogger) ByteBuffer(java.nio.ByteBuffer) ReadOnlyOption(org.apache.ignite.raft.jraft.option.ReadOnlyOption) Assertions.assertFalse(org.junit.jupiter.api.Assertions.assertFalse) AtomicInteger(java.util.concurrent.atomic.AtomicInteger) NodeFinder(org.apache.ignite.network.NodeFinder) Node(org.apache.ignite.raft.jraft.Node) JoinableClosure(org.apache.ignite.raft.jraft.closure.JoinableClosure) TestIgniteRpcServer(org.apache.ignite.raft.jraft.rpc.TestIgniteRpcServer) SnapshotReader(org.apache.ignite.raft.jraft.storage.snapshot.SnapshotReader) Status(org.apache.ignite.raft.jraft.Status) BootstrapOptions(org.apache.ignite.raft.jraft.option.BootstrapOptions) TestInfo(org.junit.jupiter.api.TestInfo) Utils(org.apache.ignite.raft.jraft.util.Utils) Test(org.junit.jupiter.api.Test) List(java.util.List) StaticNodeFinder(org.apache.ignite.network.StaticNodeFinder) RpcClientEx(org.apache.ignite.raft.jraft.rpc.RpcClientEx) Configuration(org.apache.ignite.raft.jraft.conf.Configuration) ReadIndexClosure(org.apache.ignite.raft.jraft.closure.ReadIndexClosure) Bits(org.apache.ignite.raft.jraft.util.Bits) ClusterServiceTestUtils(org.apache.ignite.utils.ClusterServiceTestUtils) AtomicBoolean(java.util.concurrent.atomic.AtomicBoolean) CompletableFuture(java.util.concurrent.CompletableFuture) FixedThreadsExecutorGroup(org.apache.ignite.raft.jraft.util.concurrent.FixedThreadsExecutorGroup) AtomicReference(java.util.concurrent.atomic.AtomicReference) NodeOptions(org.apache.ignite.raft.jraft.option.NodeOptions) HashSet(java.util.HashSet) BiPredicate(java.util.function.BiPredicate) Iterator(org.apache.ignite.raft.jraft.Iterator) ExecutorService(java.util.concurrent.ExecutorService) JRaftUtils(org.apache.ignite.raft.jraft.JRaftUtils) UTF_8(java.nio.charset.StandardCharsets.UTF_8) RpcRequests(org.apache.ignite.raft.jraft.rpc.RpcRequests) IgniteRpcClient(org.apache.ignite.raft.jraft.rpc.impl.IgniteRpcClient) TimeUnit(java.util.concurrent.TimeUnit) PeerId(org.apache.ignite.raft.jraft.entity.PeerId) Collectors.toList(java.util.stream.Collectors.toList) ThroughputSnapshotThrottle(org.apache.ignite.raft.jraft.storage.snapshot.ThroughputSnapshotThrottle) ClusterService(org.apache.ignite.network.ClusterService) WorkDirectoryExtension(org.apache.ignite.internal.testframework.WorkDirectoryExtension) UserLog(org.apache.ignite.raft.jraft.entity.UserLog) Collections(java.util.Collections) RaftOptions(org.apache.ignite.raft.jraft.option.RaftOptions) Task(org.apache.ignite.raft.jraft.entity.Task) Configuration(org.apache.ignite.raft.jraft.conf.Configuration) RaftGroupService(org.apache.ignite.raft.jraft.RaftGroupService) Node(org.apache.ignite.raft.jraft.Node) ArrayList(java.util.ArrayList) NodeOptions(org.apache.ignite.raft.jraft.option.NodeOptions) ByteBuffer(java.nio.ByteBuffer) Endpoint(org.apache.ignite.raft.jraft.util.Endpoint) Endpoint(org.apache.ignite.raft.jraft.util.Endpoint) JoinableClosure(org.apache.ignite.raft.jraft.closure.JoinableClosure) AtomicInteger(java.util.concurrent.atomic.AtomicInteger) PeerId(org.apache.ignite.raft.jraft.entity.PeerId) Test(org.junit.jupiter.api.Test)

Example 2 with RaftOptions

use of org.apache.ignite.raft.jraft.option.RaftOptions in project ignite-3 by apache.

the class LocalSnapshotMetaTableTest method testSaveLoadIoBuffer.

@Test
public void testSaveLoadIoBuffer() throws Exception {
    LocalFileMetaOutter.LocalFileMeta meta1 = msgFactory.localFileMeta().checksum("data1").source(LocalFileMetaOutter.FileSource.FILE_SOURCE_LOCAL).build();
    assertTrue(this.table.addFile("data1", meta1));
    LocalFileMetaOutter.LocalFileMeta meta2 = msgFactory.localFileMeta().checksum("data2").source(LocalFileMetaOutter.FileSource.FILE_SOURCE_LOCAL).build();
    assertTrue(this.table.addFile("data2", meta2));
    ByteBuffer buf = this.table.saveToByteBufferAsRemote();
    assertNotNull(buf);
    assertTrue(buf.hasRemaining());
    LocalSnapshotMetaTable newTable = new LocalSnapshotMetaTable(new RaftOptions());
    assertNull(newTable.getFileMeta("data1"));
    assertNull(newTable.getFileMeta("data2"));
    assertTrue(newTable.loadFromIoBufferAsRemote(buf));
    assertEquals(meta1, newTable.getFileMeta("data1"));
    assertEquals(meta2, newTable.getFileMeta("data2"));
}
Also used : RaftOptions(org.apache.ignite.raft.jraft.option.RaftOptions) LocalFileMetaOutter(org.apache.ignite.raft.jraft.entity.LocalFileMetaOutter) ByteBuffer(java.nio.ByteBuffer) Test(org.junit.jupiter.api.Test)

Example 3 with RaftOptions

use of org.apache.ignite.raft.jraft.option.RaftOptions in project ignite-3 by apache.

the class LocalSnapshotMetaTableTest method setup.

@BeforeEach
public void setup() {
    RaftOptions opts = new RaftOptions();
    this.table = new LocalSnapshotMetaTable(opts);
    this.msgFactory = opts.getRaftMessagesFactory();
}
Also used : RaftOptions(org.apache.ignite.raft.jraft.option.RaftOptions) BeforeEach(org.junit.jupiter.api.BeforeEach)

Example 4 with RaftOptions

use of org.apache.ignite.raft.jraft.option.RaftOptions in project ignite-3 by apache.

the class LocalSnapshotMetaTableTest method testSaveLoadFile.

@Test
public void testSaveLoadFile(@WorkDirectory Path workDir) throws IOException {
    LocalFileMetaOutter.LocalFileMeta meta1 = msgFactory.localFileMeta().checksum("data1").source(LocalFileMetaOutter.FileSource.FILE_SOURCE_LOCAL).build();
    assertTrue(this.table.addFile("data1", meta1));
    LocalFileMetaOutter.LocalFileMeta meta2 = msgFactory.localFileMeta().checksum("data2").source(LocalFileMetaOutter.FileSource.FILE_SOURCE_LOCAL).build();
    assertTrue(this.table.addFile("data2", meta2));
    RaftOutter.SnapshotMeta meta = msgFactory.snapshotMeta().lastIncludedIndex(1).lastIncludedTerm(1).build();
    this.table.setMeta(meta);
    assertTrue(table.listFiles().contains("data1"));
    assertTrue(table.listFiles().contains("data2"));
    assertTrue(table.hasMeta());
    String filePath = workDir.resolve("table").toString();
    table.saveToFile(filePath);
    LocalSnapshotMetaTable newTable = new LocalSnapshotMetaTable(new RaftOptions());
    assertNull(newTable.getFileMeta("data1"));
    assertNull(newTable.getFileMeta("data2"));
    assertTrue(newTable.loadFromFile(filePath));
    assertEquals(meta1, newTable.getFileMeta("data1"));
    assertEquals(meta2, newTable.getFileMeta("data2"));
    assertEquals(meta, newTable.getMeta());
}
Also used : RaftOptions(org.apache.ignite.raft.jraft.option.RaftOptions) LocalFileMetaOutter(org.apache.ignite.raft.jraft.entity.LocalFileMetaOutter) RaftOutter(org.apache.ignite.raft.jraft.entity.RaftOutter) Test(org.junit.jupiter.api.Test)

Example 5 with RaftOptions

use of org.apache.ignite.raft.jraft.option.RaftOptions in project ignite-3 by apache.

the class LocalSnapshotStorageTest method setup.

@BeforeEach
public void setup() throws Exception {
    String snapshotPath = this.path + File.separator + Snapshot.JRAFT_SNAPSHOT_PREFIX + lastSnapshotIndex;
    new File(snapshotPath).mkdirs();
    opts = new RaftOptions();
    this.table = new LocalSnapshotMetaTable(opts);
    this.table.setMeta(opts.getRaftMessagesFactory().snapshotMeta().lastIncludedIndex(this.lastSnapshotIndex).lastIncludedTerm(1).build());
    this.table.saveToFile(snapshotPath + File.separator + Snapshot.JRAFT_SNAPSHOT_META_FILE);
    this.snapshotStorage = new LocalSnapshotStorage(path.toString(), new RaftOptions());
    assertTrue(this.snapshotStorage.init(null));
}
Also used : RaftOptions(org.apache.ignite.raft.jraft.option.RaftOptions) File(java.io.File) BeforeEach(org.junit.jupiter.api.BeforeEach)

Aggregations

RaftOptions (org.apache.ignite.raft.jraft.option.RaftOptions)23 BeforeEach (org.junit.jupiter.api.BeforeEach)12 Test (org.junit.jupiter.api.Test)11 NodeOptions (org.apache.ignite.raft.jraft.option.NodeOptions)8 Endpoint (org.apache.ignite.raft.jraft.util.Endpoint)8 PeerId (org.apache.ignite.raft.jraft.entity.PeerId)6 LocalFileMetaOutter (org.apache.ignite.raft.jraft.entity.LocalFileMetaOutter)4 File (java.io.File)3 ByteBuffer (java.nio.ByteBuffer)3 TimerManager (org.apache.ignite.raft.jraft.core.TimerManager)3 CopyOptions (org.apache.ignite.raft.jraft.option.CopyOptions)3 SnapshotCopierOptions (org.apache.ignite.raft.jraft.option.SnapshotCopierOptions)3 CompletableFuture (java.util.concurrent.CompletableFuture)2 CountDownLatch (java.util.concurrent.CountDownLatch)2 ExecutorService (java.util.concurrent.ExecutorService)2 AtomicInteger (java.util.concurrent.atomic.AtomicInteger)2 AtomicReference (java.util.concurrent.atomic.AtomicReference)2 Node (org.apache.ignite.raft.jraft.Node)2 ConfigurationManager (org.apache.ignite.raft.jraft.conf.ConfigurationManager)2 RpcClientEx (org.apache.ignite.raft.jraft.rpc.RpcClientEx)2