Uploaded image for project: 'Geode'
  1. Geode
  2. GEODE-10383

lucene may log many warnings about BucketNotFound during normal operations

    XMLWordPrintableJSON

Details

    • Bug
    • Status: In Progress
    • Major
    • Resolution: Unresolved
    • 1.16.0
    • None
    • lucene
    • None

    Description

      This seems much like GEODE-1557 but it may be this exception is coming from a different place. Once again it involves a test that has primaries moving around due to new servers starting up.
      I don't see any value in logging the stack trace in this case.
      If we are going to log about this should the message also include an explanation as to why it can happen during normal operations?
      Also should it really be a warning since it can occur during normal operations? It looks like the fix for GEODE-1557 made it "debug" level.
      I see a bunch of the following warnings logged:

      .cache.lucene.internal.distributed.LuceneQueryFunction@14894ec8
      org.apache.geode.cache.execute.FunctionException: org.apache.geode.internal.cache.execute.InternalFunctionInvocationTargetException: org.apache.geode.internal.cache.BucketNotFo
      undException: Unable to find lucene index because no longer primary for bucket 326
              at org.apache.geode.internal.cache.partitioned.PRFunctionStreamingResultCollector.getResultInternal(PRFunctionStreamingResultCollector.java:126)
              at org.apache.geode.internal.cache.execute.ResultCollectorHolder.getResult(ResultCollectorHolder.java:53)
              at org.apache.geode.internal.cache.partitioned.PRFunctionStreamingResultCollector.getResult(PRFunctionStreamingResultCollector.java:87)
              at org.apache.geode.internal.cache.tier.sockets.command.ExecuteRegionFunctionGeode18.executeFunctionWithResult(ExecuteRegionFunctionGeode18.java:50)
              at org.apache.geode.internal.cache.tier.sockets.command.ExecuteRegionFunction66.cmdExecute(ExecuteRegionFunction66.java:203)
              at org.apache.geode.internal.cache.tier.sockets.BaseCommand.execute(BaseCommand.java:187)
              at org.apache.geode.internal.cache.tier.sockets.ServerConnection.doNormalMessage(ServerConnection.java:880)
              at org.apache.geode.internal.cache.tier.sockets.ServerConnection.doOneMessage(ServerConnection.java:1074)
              at org.apache.geode.internal.cache.tier.sockets.ServerConnection.run(ServerConnection.java:1356)
              at java.base/java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1136)
              at java.base/java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:635)
              at org.apache.geode.internal.cache.tier.sockets.AcceptorImpl.lambda$initializeServerConnectionThreadPool$3(AcceptorImpl.java:690)
              at org.apache.geode.logging.internal.executors.LoggingThreadFactory.lambda$newThread$0(LoggingThreadFactory.java:120)
              at java.base/java.lang.Thread.run(Thread.java:833)
      Caused by: org.apache.geode.internal.cache.execute.InternalFunctionInvocationTargetException: org.apache.geode.internal.cache.BucketNotFoundException: Unable to find lucene ind
      ex because no longer primary for bucket 326
              at org.apache.geode.internal.cache.partitioned.PRFunctionStreamingResultCollector.getResultInternal(PRFunctionStreamingResultCollector.java:125)
              ... 13 more
      

      Attachments

        Activity

          People

            jinmeiliao Jinmei Liao
            dschneider Darrel Schneider
            Votes:
            0 Vote for this issue
            Watchers:
            1 Start watching this issue

            Dates

              Created:
              Updated: