Uploaded image for project: 'Ignite'
  1. Ignite
  2. IGNITE-15729

RecordViewExample fails with two remote nodes

    XMLWordPrintableJSON

Details

    • Bug
    • Status: Resolved
    • Major
    • Resolution: Fixed
    • 3.0.0-alpha3
    • 3.0.0-alpha4
    • examples

    Description

      To reproduce:

      1. Start two nodes using the CLI tool.
      2. Run the RecordViewExample (need to check other examples as well).
      3. Observe the exception shown below.
      Exception in thread "main" java.util.concurrent.CompletionException: class org.apache.ignite.client.IgniteClientException: class org.apache.ignite.client.IgniteClientException: class org.apache.ignite.raft.jraft.rpc.impl.RaftException: ENOENT:No nodes in group 1-40f121ca-81e4-4929-8ad3-24f5742c81af_part_6
      	at java.base/java.util.concurrent.CompletableFuture.encodeRelay(CompletableFuture.java:367)
      	at java.base/java.util.concurrent.CompletableFuture.completeRelay(CompletableFuture.java:376)
      	at java.base/java.util.concurrent.CompletableFuture$UniRelay.tryFire(CompletableFuture.java:1019)
      	at java.base/java.util.concurrent.CompletableFuture.postComplete(CompletableFuture.java:506)
      	at java.base/java.util.concurrent.CompletableFuture.completeExceptionally(CompletableFuture.java:2088)
      	at org.apache.ignite.internal.client.ReliableChannel.lambda$handleServiceAsync$3(ReliableChannel.java:213)
      	at java.base/java.util.concurrent.CompletableFuture.uniHandle(CompletableFuture.java:930)
      	at java.base/java.util.concurrent.CompletableFuture$UniHandle.tryFire(CompletableFuture.java:907)
      	at java.base/java.util.concurrent.CompletableFuture.postComplete(CompletableFuture.java:506)
      	at java.base/java.util.concurrent.CompletableFuture.completeExceptionally(CompletableFuture.java:2088)
      	at org.apache.ignite.internal.client.TcpClientChannel.processNextMessage(TcpClientChannel.java:260)
      	at org.apache.ignite.internal.client.TcpClientChannel.onMessage(TcpClientChannel.java:109)
      	at org.apache.ignite.internal.client.io.netty.NettyClientConnection.onMessage(NettyClientConnection.java:85)
      	at org.apache.ignite.internal.client.io.netty.NettyClientMessageHandler.channelRead(NettyClientMessageHandler.java:33)
      	at io.netty.channel.AbstractChannelHandlerContext.invokeChannelRead(AbstractChannelHandlerContext.java:379)
      	at io.netty.channel.AbstractChannelHandlerContext.invokeChannelRead(AbstractChannelHandlerContext.java:365)
      	at io.netty.channel.AbstractChannelHandlerContext.fireChannelRead(AbstractChannelHandlerContext.java:357)
      	at io.netty.handler.codec.ByteToMessageDecoder.fireChannelRead(ByteToMessageDecoder.java:324)
      	at io.netty.handler.codec.ByteToMessageDecoder.channelRead(ByteToMessageDecoder.java:296)
      	at io.netty.channel.AbstractChannelHandlerContext.invokeChannelRead(AbstractChannelHandlerContext.java:379)
      	at io.netty.channel.AbstractChannelHandlerContext.invokeChannelRead(AbstractChannelHandlerContext.java:365)
      	at io.netty.channel.AbstractChannelHandlerContext.fireChannelRead(AbstractChannelHandlerContext.java:357)
      	at io.netty.channel.DefaultChannelPipeline$HeadContext.channelRead(DefaultChannelPipeline.java:1410)
      	at io.netty.channel.AbstractChannelHandlerContext.invokeChannelRead(AbstractChannelHandlerContext.java:379)
      	at io.netty.channel.AbstractChannelHandlerContext.invokeChannelRead(AbstractChannelHandlerContext.java:365)
      	at io.netty.channel.DefaultChannelPipeline.fireChannelRead(DefaultChannelPipeline.java:919)
      	at io.netty.channel.nio.AbstractNioByteChannel$NioByteUnsafe.read(AbstractNioByteChannel.java:166)
      	at io.netty.channel.nio.NioEventLoop.processSelectedKey(NioEventLoop.java:719)
      	at io.netty.channel.nio.NioEventLoop.processSelectedKeysOptimized(NioEventLoop.java:655)
      	at io.netty.channel.nio.NioEventLoop.processSelectedKeys(NioEventLoop.java:581)
      	at io.netty.channel.nio.NioEventLoop.run(NioEventLoop.java:493)
      	at io.netty.util.concurrent.SingleThreadEventExecutor$4.run(SingleThreadEventExecutor.java:989)
      	at io.netty.util.internal.ThreadExecutorMap$2.run(ThreadExecutorMap.java:74)
      	at io.netty.util.concurrent.FastThreadLocalRunnable.run(FastThreadLocalRunnable.java:30)
      	at java.base/java.lang.Thread.run(Thread.java:834)
      Caused by: class org.apache.ignite.client.IgniteClientException: class org.apache.ignite.client.IgniteClientException: class org.apache.ignite.raft.jraft.rpc.impl.RaftException: ENOENT:No nodes in group 1-40f121ca-81e4-4929-8ad3-24f5742c81af_part_6
      	at org.apache.ignite.internal.client.ReliableChannel.lambda$handleServiceAsync$3(ReliableChannel.java:215)
      	... 29 more
      Caused by: java.util.concurrent.CompletionException: class org.apache.ignite.client.IgniteClientException: class org.apache.ignite.raft.jraft.rpc.impl.RaftException: ENOENT:No nodes in group 1-40f121ca-81e4-4929-8ad3-24f5742c81af_part_6
      	at java.base/java.util.concurrent.CompletableFuture.encodeThrowable(CompletableFuture.java:331)
      	at java.base/java.util.concurrent.CompletableFuture.completeThrowable(CompletableFuture.java:346)
      	at java.base/java.util.concurrent.CompletableFuture$UniApply.tryFire(CompletableFuture.java:632)
      	... 27 more
      Caused by: class org.apache.ignite.client.IgniteClientException: class org.apache.ignite.raft.jraft.rpc.impl.RaftException: ENOENT:No nodes in group 1-40f121ca-81e4-4929-8ad3-24f5742c81af_part_6
      	at org.apache.ignite.internal.client.TcpClientChannel.processNextMessage(TcpClientChannel.java:259)
      	... 24 more 

      Attachments

        Issue Links

          Activity

            People

              maliev Mirza Aliev
              vkulichenko Valentin Kulichenko
              Vyacheslav Koptilin Vyacheslav Koptilin
              Votes:
              0 Vote for this issue
              Watchers:
              3 Start watching this issue

              Dates

                Created:
                Updated:
                Resolved:

                Time Tracking

                  Estimated:
                  Original Estimate - Not Specified
                  Not Specified
                  Remaining:
                  Remaining Estimate - 0h
                  0h
                  Logged:
                  Time Spent - 10m
                  10m