Uploaded image for project: 'Ratis'
  1. Ratis
  2. RATIS-515

IllegalStateException while updating matchIndex

    XMLWordPrintableJSON

Details

    • Bug
    • Status: Resolved
    • Critical
    • Resolution: Fixed
    • 0.4.0
    • 0.4.0
    • server

    Description

      Match index is not updated increasingly as noted in the following stack trace.

      java.lang.IllegalStateException: Failed to updateIncreasingly for matchIndex: 393 -> 0
              at org.apache.ratis.util.Preconditions.assertTrue(Preconditions.java:72)
              at org.apache.ratis.server.storage.RaftLogIndex.updateIncreasingly(RaftLogIndex.java:60)
              at org.apache.ratis.server.impl.FollowerInfo.updateMatchIndex(FollowerInfo.java:66)
              at org.apache.ratis.grpc.server.GrpcLogAppender.onSuccess(GrpcLogAppender.java:309)
              at org.apache.ratis.grpc.server.GrpcLogAppender$AppendLogResponseHandler.onNextImpl(GrpcLogAppender.java:239)
              at org.apache.ratis.grpc.server.GrpcLogAppender$AppendLogResponseHandler.onNext(GrpcLogAppender.java:224)
              at org.apache.ratis.grpc.server.GrpcLogAppender$AppendLogResponseHandler.onNext(GrpcLogAppender.java:206)
              at org.apache.ratis.thirdparty.io.grpc.stub.ClientCalls$StreamObserverToCallListenerAdapter.onMessage(ClientCalls.java:421)
              at org.apache.ratis.thirdparty.io.grpc.ForwardingClientCallListener.onMessage(ForwardingClientCallListener.java:33)
              at org.apache.ratis.thirdparty.io.grpc.ForwardingClientCallListener.onMessage(ForwardingClientCallListener.java:33)
              at org.apache.ratis.thirdparty.io.grpc.internal.ClientCallImpl$ClientStreamListenerImpl$1MessagesAvailable.runInContext(ClientCallImpl.java:519)
              at org.apache.ratis.thirdparty.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
              at org.apache.ratis.thirdparty.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:123)
              at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
              at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
              at java.lang.Thread.run(Thread.java:748)
      

      Attachments

        1. miniozonelog.txt
          4.21 MB
          Mukul Kumar Singh
        2. r515_20190506.patch
          27 kB
          Tsz-wo Sze
        3. r515_20190507.patch
          26 kB
          Tsz-wo Sze
        4. r515_20190510.patch
          26 kB
          Tsz-wo Sze

        Issue Links

          Activity

            People

              szetszwo Tsz-wo Sze
              msingh Mukul Kumar Singh
              Votes:
              0 Vote for this issue
              Watchers:
              6 Start watching this issue

              Dates

                Created:
                Updated:
                Resolved: