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

java.lang.NullPointerException: null in LogId.compareTo when handle vote request

    XMLWordPrintableJSON

Details

    • Bug
    • Status: Resolved
    • Major
    • Resolution: Fixed
    • None
    • 3.1
    • None

    Description

      TC main has started to detect NullPointerException in builds logs. This happens in ItEstimatedSizeTest#testEstimatedSize, seems like it happens when node has already been stopped, but still handle vote request with already cleared states. We need to figure out and fix NPE.

      [2024-08-30T13:58:43,614][ERROR][%iest_tes_1%JRaft-Request-Processor-13][RpcRequestProcessor] handleRequest RequestVoteRequestImpl [groupId=12_part_10, lastLogIndex=193, lastLogTerm=1, peerId=iest_tes_1, preVote=false, serverId=iest_tes_2, term=2] failed
      java.lang.NullPointerException: null
        at org.apache.ignite.raft.jraft.entity.LogId.compareTo(LogId.java:91) ~[ignite-raft-3.0.0-SNAPSHOT.jar:?]
        at org.apache.ignite.raft.jraft.core.NodeImpl.handleRequestVoteRequest(NodeImpl.java:2071) ~[ignite-raft-3.0.0-SNAPSHOT.jar:?]
        at org.apache.ignite.raft.jraft.rpc.impl.core.RequestVoteRequestProcessor.processRequest0(RequestVoteRequestProcessor.java:52) ~[ignite-raft-3.0.0-SNAPSHOT.jar:?]
        at org.apache.ignite.raft.jraft.rpc.impl.core.RequestVoteRequestProcessor.processRequest0(RequestVoteRequestProcessor.java:29) ~[ignite-raft-3.0.0-SNAPSHOT.jar:?]
        at org.apache.ignite.raft.jraft.rpc.impl.core.NodeRequestProcessor.processRequest(NodeRequestProcessor.java:55) ~[ignite-raft-3.0.0-SNAPSHOT.jar:?]
        at org.apache.ignite.raft.jraft.rpc.RpcRequestProcessor.handleRequest(RpcRequestProcessor.java:49) ~[ignite-raft-3.0.0-SNAPSHOT.jar:?]
        at org.apache.ignite.raft.jraft.rpc.RpcRequestProcessor.handleRequest(RpcRequestProcessor.java:29) ~[ignite-raft-3.0.0-SNAPSHOT.jar:?]
        at org.apache.ignite.raft.jraft.rpc.impl.IgniteRpcServer$RpcMessageHandler.lambda$onReceived$0(IgniteRpcServer.java:181) ~[ignite-raft-3.0.0-SNAPSHOT.jar:?]
        at java.base/java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1128) [?:?]
        at java.base/java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:628) [?:?]
        at java.base/java.lang.Thread.run(Thread.java:834) [?:?]
      

      https://ci.ignite.apache.org/buildConfiguration/ApacheIgnite3xGradle_Test_RunAllTests/8439410?hideProblemsFromDependencies=false&hideTestsFromDependencies=false&expandCode+Inspection=true&expandBuildChangesSection=true&expandBuildDeploymentsSection=false&expandBuildProblemsSection=true&logFilter=debug&logView=flowAware

      Attachments

        Issue Links

          Activity

            People

              maliev Mirza Aliev
              maliev Mirza Aliev
              Vladislav Pyatkov Vladislav Pyatkov
              Votes:
              0 Vote for this issue
              Watchers:
              2 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 - 20m
                  20m