You are viewing a plain text version of this content. The canonical link for it is here.
Posted to dev@lucenenet.apache.org by GitBox <gi...@apache.org> on 2020/08/11 07:00:02 UTC

[GitHub] [lucenenet] Shazwazza commented on pull request #325: Fix for LineFileDocs Bottleneck/Performance Improvements

Shazwazza commented on pull request #325:
URL: https://github.com/apache/lucenenet/pull/325#issuecomment-671766858


   I've run all tests locally twice with these changes. The first time was fine but the second time yielded one error:
   
   `TestSnapshotDeletionPolicy.TestMultiThreadedSnapshotting`
   
   ## Error
   
   ```
    TestMultiThreadedSnapshotting
      Source: TestSnapshotDeletionPolicy.cs line 352
      Duration: 16 ms
   
     Message: 
       System.Exception : Method Debug.Assert failed with 'DWPT must never be null here since we hold the lock and it holds documents
       ', and was translated to Microsoft.VisualStudio.TestPlatform.TestHost.DebugAssertException to avoid terminating the process hosting the test.
       Data:
         OriginalMessage: System.Exception: Method Debug.Assert failed with 'DWPT must never be null here since we hold the lock and it holds documents
       ', and was translated to Microsoft.VisualStudio.TestPlatform.TestHost.DebugAssertException to avoid terminating the process hosting the test.
        ---> Microsoft.VisualStudio.TestPlatform.TestHost.DebugAssertException: Method Debug.Assert failed with 'DWPT must never be null here since we hold the lock and it holds documents
       ', and was translated to Microsoft.VisualStudio.TestPlatform.TestHost.DebugAssertException to avoid terminating the process hosting the test.
          at Lucene.Net.Index.DocumentsWriterFlushControl.AddFlushableState(ThreadState perThread) in C:\Users\Shannon\Documents\_Projects\Lucene.Net\Lucenenet.4.x-copy\src\Lucene.Net\Index\DocumentsWriterFlushControl.cs:line 711
          at Lucene.Net.Index.DocumentsWriterFlushControl.MarkForFullFlush() in C:\Users\Shannon\Documents\_Projects\Lucene.Net\Lucenenet.4.x-copy\src\Lucene.Net\Index\DocumentsWriterFlushControl.cs:line 644
          at Lucene.Net.Index.DocumentsWriter.FlushAllThreads(IndexWriter indexWriter) in C:\Users\Shannon\Documents\_Projects\Lucene.Net\Lucenenet.4.x-copy\src\Lucene.Net\Index\DocumentsWriter.cs:line 738
          at Lucene.Net.Index.IndexWriter.PrepareCommitInternal() in C:\Users\Shannon\Documents\_Projects\Lucene.Net\Lucenenet.4.x-copy\src\Lucene.Net\Index\IndexWriter.cs:line 3557
          at Lucene.Net.Index.IndexWriter.CommitInternal() in C:\Users\Shannon\Documents\_Projects\Lucene.Net\Lucenenet.4.x-copy\src\Lucene.Net\Index\IndexWriter.cs:line 3750
          at Lucene.Net.Index.IndexWriter.Commit() in C:\Users\Shannon\Documents\_Projects\Lucene.Net\Lucenenet.4.x-copy\src\Lucene.Net\Index\IndexWriter.cs:line 3709
          at Lucene.Net.Index.TestSnapshotDeletionPolicy.ThreadAnonymousInnerClassHelper2.Run() in C:\Users\Shannon\Documents\_Projects\Lucene.Net\Lucenenet.4.x-copy\src\Lucene.Net.Tests\Index\TestSnapshotDeletionPolicy.cs:line 414
          at J2N.Threading.ThreadJob.SafeRun(ThreadStart start)
          at J2N.Threading.ThreadJob.<.ctor>b__4_0()
          at System.Threading.ThreadHelper.ThreadStart_Context(Object state)
          at System.Threading.ExecutionContext.RunInternal(ExecutionContext executionContext, ContextCallback callback, Object state)
          at System.Threading.ThreadHelper.ThreadStart()
       
          --- End of inner exception stack trace ---
          at Lucene.Net.Index.TestSnapshotDeletionPolicy.ThreadAnonymousInnerClassHelper2.Run() in C:\Users\Shannon\Documents\_Projects\Lucene.Net\Lucenenet.4.x-copy\src\Lucene.Net.Tests\Index\TestSnapshotDeletionPolicy.cs:line 419
          at J2N.Threading.ThreadJob.SafeRun(ThreadStart start)
       
         ----> Microsoft.VisualStudio.TestPlatform.TestHost.DebugAssertException : Method Debug.Assert failed with 'DWPT must never be null here since we hold the lock and it holds documents
       ', and was translated to Microsoft.VisualStudio.TestPlatform.TestHost.DebugAssertException to avoid terminating the process hosting the test.
     Stack Trace: 
       ThreadJob.Join()
       TestSnapshotDeletionPolicy.TestMultiThreadedSnapshotting() line 374
       --DebugAssertException
       DocumentsWriterFlushControl.AddFlushableState(ThreadState perThread) line 711
       DocumentsWriterFlushControl.MarkForFullFlush() line 644
       DocumentsWriter.FlushAllThreads(IndexWriter indexWriter) line 738
       IndexWriter.PrepareCommitInternal() line 3557
       IndexWriter.CommitInternal() line 3750
       IndexWriter.Commit() line 3709
       ThreadAnonymousInnerClassHelper2.Run() line 414
       ThreadJob.SafeRun(ThreadStart start)
       <.ctor>b__4_0()
       ThreadHelper.ThreadStart_Context(Object state)
       ExecutionContext.RunInternal(ExecutionContext executionContext, ContextCallback callback, Object state)
       ThreadHelper.ThreadStart()
   ```
   
   ## Full output
   
   ```
   Test Name:	TestMultiThreadedSnapshotting
   Test Outcome:	Failed
   Result Message:	
   System.Exception : Method Debug.Assert failed with 'DWPT must never be null here since we hold the lock and it holds documents
   ', and was translated to Microsoft.VisualStudio.TestPlatform.TestHost.DebugAssertException to avoid terminating the process hosting the test.
   Data:
     OriginalMessage: System.Exception: Method Debug.Assert failed with 'DWPT must never be null here since we hold the lock and it holds documents
   ', and was translated to Microsoft.VisualStudio.TestPlatform.TestHost.DebugAssertException to avoid terminating the process hosting the test.
    ---> Microsoft.VisualStudio.TestPlatform.TestHost.DebugAssertException: Method Debug.Assert failed with 'DWPT must never be null here since we hold the lock and it holds documents
   ', and was translated to Microsoft.VisualStudio.TestPlatform.TestHost.DebugAssertException to avoid terminating the process hosting the test.
      at Lucene.Net.Index.DocumentsWriterFlushControl.AddFlushableState(ThreadState perThread) in C:\Users\Shannon\Documents\_Projects\Lucene.Net\Lucenenet.4.x-copy\src\Lucene.Net\Index\DocumentsWriterFlushControl.cs:line 711
      at Lucene.Net.Index.DocumentsWriterFlushControl.MarkForFullFlush() in C:\Users\Shannon\Documents\_Projects\Lucene.Net\Lucenenet.4.x-copy\src\Lucene.Net\Index\DocumentsWriterFlushControl.cs:line 644
      at Lucene.Net.Index.DocumentsWriter.FlushAllThreads(IndexWriter indexWriter) in C:\Users\Shannon\Documents\_Projects\Lucene.Net\Lucenenet.4.x-copy\src\Lucene.Net\Index\DocumentsWriter.cs:line 738
      at Lucene.Net.Index.IndexWriter.PrepareCommitInternal() in C:\Users\Shannon\Documents\_Projects\Lucene.Net\Lucenenet.4.x-copy\src\Lucene.Net\Index\IndexWriter.cs:line 3557
      at Lucene.Net.Index.IndexWriter.CommitInternal() in C:\Users\Shannon\Documents\_Projects\Lucene.Net\Lucenenet.4.x-copy\src\Lucene.Net\Index\IndexWriter.cs:line 3750
      at Lucene.Net.Index.IndexWriter.Commit() in C:\Users\Shannon\Documents\_Projects\Lucene.Net\Lucenenet.4.x-copy\src\Lucene.Net\Index\IndexWriter.cs:line 3709
      at Lucene.Net.Index.TestSnapshotDeletionPolicy.ThreadAnonymousInnerClassHelper2.Run() in C:\Users\Shannon\Documents\_Projects\Lucene.Net\Lucenenet.4.x-copy\src\Lucene.Net.Tests\Index\TestSnapshotDeletionPolicy.cs:line 414
      at J2N.Threading.ThreadJob.SafeRun(ThreadStart start)
      at J2N.Threading.ThreadJob.<.ctor>b__4_0()
      at System.Threading.ThreadHelper.ThreadStart_Context(Object state)
      at System.Threading.ExecutionContext.RunInternal(ExecutionContext executionContext, ContextCallback callback, Object state)
      at System.Threading.ThreadHelper.ThreadStart()
   
      --- End of inner exception stack trace ---
      at Lucene.Net.Index.TestSnapshotDeletionPolicy.ThreadAnonymousInnerClassHelper2.Run() in C:\Users\Shannon\Documents\_Projects\Lucene.Net\Lucenenet.4.x-copy\src\Lucene.Net.Tests\Index\TestSnapshotDeletionPolicy.cs:line 419
      at J2N.Threading.ThreadJob.SafeRun(ThreadStart start)
   
     ----> Microsoft.VisualStudio.TestPlatform.TestHost.DebugAssertException : Method Debug.Assert failed with 'DWPT must never be null here since we hold the lock and it holds documents
   ', and was translated to Microsoft.VisualStudio.TestPlatform.TestHost.DebugAssertException to avoid terminating the process hosting the test.
   Result StandardOutput:	
   Culture: ru-KZ
   Time Zone: (UTC+04:00) Astrakhan, Ulyanovsk
   Default Codec: CheapBastard (CheapBastardCodec)
   Default Similarity: RandomSimilarityProvider(queryNorm=False,coord=crazy): {}
   Nightly: False
   Weekly: False
   Slow: True
   Awaits Fix: False
   Directory: random
   Verbose: True
   Random Multiplier: 1
   IFD 281 [11.08.2020 16:13:17; NonParallelWorker]: init: current segments file is ""; deletionPolicy=Lucene.Net.Index.SnapshotDeletionPolicy
   IFD 281 [11.08.2020 16:13:17; NonParallelWorker]: now checkpoint "" [0 segments ; isCommit = False]
   IFD 281 [11.08.2020 16:13:17; NonParallelWorker]: 0 msec to checkpoint
   IW 281 [11.08.2020 16:13:17; NonParallelWorker]: init: create=True
   IW 281 [11.08.2020 16:13:17; NonParallelWorker]: 
   dir=MockDirectoryWrapper(RAMDirectory@47038e lockFactory=Lucene.Net.Store.SingleInstanceLockFactory)
   index=
   version=4.8.0
   matchVersion=LUCENE_48
   analyzer=MockAnalyzer
   ramBufferSizeMB=16
   maxBufferedDocs=-1
   maxBufferedDeleteTerms=-1
   mergedSegmentWarmer=
   readerTermsIndexDivisor=3
   termIndexInterval=32
   delPolicy=SnapshotDeletionPolicy
   commit=null
   openMode=CREATE_OR_APPEND
   similarity=RandomSimilarityProvider
   mergeScheduler=ConcurrentMergeScheduler: maxThreadCount=1, maxMergeCount=2, mergeThreadPriority=-1
   default WRITE_LOCK_TIMEOUT=1000
   writeLockTimeout=1000
   codec=CheapBastard
   infoStream=ThreadNameFixingPrintStreamInfoStream
   mergePolicy=[TieredMergePolicy: maxMergeAtOnce=17, maxMergeAtOnceExplicit=11, maxMergedSegmentMB=27,6845703125, floorSegmentMB=0,9677734375, forceMergeDeletesPctAllowed=28,449725810647813, segmentsPerTier=15, maxCFSSegmentSizeMB=8796093022207,999, noCFSRatio=1
   indexerThreadPool=Lucene.Net.Index.ThreadAffinityDocumentsWriterThreadPool
   readerPooling=True
   perThreadHardLimitMB=1945
   useCompoundFile=True
   checkIntegrityAtMerge=False
   
   IW 281 [11.08.2020 16:13:17; t0]: commit: start
   IW 281 [11.08.2020 16:13:17; t0]: commit: enter lock
   IW 281 [11.08.2020 16:13:17; t0]: commit: now prepare
   IW 281 [11.08.2020 16:13:17; t0]: prepareCommit: flush
   IW 281 [11.08.2020 16:13:17; t0]:   index before flush 
   DW 281 [11.08.2020 16:13:17; t0]: startFullFlush
   DW 281 [11.08.2020 16:13:17; t0]: anyChanges? numDocsInRam=1 deletes=False hasTickets:False pendingChangesInFullFlush: False
   DWFC 281 [11.08.2020 16:13:17; t0]: addFlushableState DocumentsWriterPerThread [pendingDeletes=gen=0, segment=_0, aborting=False, numDocsInRAM=1, deleteQueue=DWDQ: [ generation: 0 ]]
   DWPT 281 [11.08.2020 16:13:17; t0]: flush postings as segment _0 numDocs=1
   DWPT 281 [11.08.2020 16:13:17; t0]: new segment has 0 deleted docs
   DWPT 281 [11.08.2020 16:13:17; t0]: new segment has no vectors; no norms; no docValues; no prox; no freqs
   DWPT 281 [11.08.2020 16:13:17; t0]: flushedFiles=[_0.fdt, _0.fdx, _0.doc, _0.tim, _0.tip, _0.fnm]
   DWPT 281 [11.08.2020 16:13:17; t0]: flushed codec=CheapBastard
   DWPT 281 [11.08.2020 16:13:17; t0]: flushed: segment=_0 ramUsed=0 MB newFlushedSize(includes docstores)=0.00033473968505859375 MB docs/MB=2987.3960113960115
   IW 281 [11.08.2020 16:13:17; t0]: create compound file _0.cfs
   DW 281 [11.08.2020 16:13:17; t0]: publishFlushedSegment seg-private updates=
   IW 281 [11.08.2020 16:13:17; t0]: publishFlushedSegment
   IW 281 [11.08.2020 16:13:17; t0]: publish sets newSegment delGen=1 seg=_0(4.8):c1
   IFD 281 [11.08.2020 16:13:17; t0]: now checkpoint "_0(4.8):c1" [1 segments ; isCommit = False]
   IFD 281 [11.08.2020 16:13:17; t0]: 0 msec to checkpoint
   IFD 281 [11.08.2020 16:13:17; t0]: delete new file "_0.fdt"
   IFD 281 [11.08.2020 16:13:17; t0]: delete "_0.fdt"
   IFD 281 [11.08.2020 16:13:17; t0]: delete new file "_0.fdx"
   IFD 281 [11.08.2020 16:13:17; t0]: delete "_0.fdx"
   IFD 281 [11.08.2020 16:13:17; t0]: delete new file "_0.doc"
   IFD 281 [11.08.2020 16:13:17; t0]: delete "_0.doc"
   IFD 281 [11.08.2020 16:13:17; t0]: delete new file "_0.tim"
   IFD 281 [11.08.2020 16:13:17; t0]: delete "_0.tim"
   IW 281 [11.08.2020 16:13:17; t1]: commit: start
   IFD 281 [11.08.2020 16:13:17; t0]: delete new file "_0.tip"
   IFD 281 [11.08.2020 16:13:17; t0]: delete "_0.tip"
   IFD 281 [11.08.2020 16:13:17; t0]: delete new file "_0.fnm"
   IFD 281 [11.08.2020 16:13:17; t0]: delete "_0.fnm"
   IW 281 [11.08.2020 16:13:17; t0]: apply all deletes during flush
   BD 281 [11.08.2020 16:13:17; t0]: applyDeletes: no deletes; skipping
   BD 281 [11.08.2020 16:13:17; t0]: prune sis=Lucene.Net.Index.SegmentInfos minGen=1 packetCount=0
   DW 281 [11.08.2020 16:13:17; t0]: t0 finishFullFlush success=True
   TMP 281 [11.08.2020 16:13:17; t0]: findMerges: 1 segments
   TMP 281 [11.08.2020 16:13:17; t0]:   seg=_0(4.8):c1 size=0,000 MB [floored]
   TMP 281 [11.08.2020 16:13:17; t0]:   allowedSegmentCount=1 vs count=1 (eligible count=1) tooBigCount=0
   CMS 281 [11.08.2020 16:13:17; t0]: now merge
   CMS 281 [11.08.2020 16:13:17; t0]:   index: _0(4.8):c1
   CMS 281 [11.08.2020 16:13:17; t0]:   no more merges pending; now return
   IW 281 [11.08.2020 16:13:17; t0]: StartCommit(): start
   IW 281 [11.08.2020 16:13:17; t0]: startCommit index=_0(4.8):c1 changeCount=4
   IW 281 [11.08.2020 16:13:17; t0]: done all syncs: [_0.cfs, _0.cfe, _0.si]
   IW 281 [11.08.2020 16:13:17; t0]: commit: pendingCommit != null
   IW 281 [11.08.2020 16:13:17; t0]: commit: wrote segments file "segments_1"
   IFD 281 [11.08.2020 16:13:17; t0]: now checkpoint "_0(4.8):c1" [1 segments ; isCommit = True]
   IW 281 [11.08.2020 16:13:17; t2]: commit: start
   IFD 281 [11.08.2020 16:13:17; t0]: 0 msec to checkpoint
   IW 281 [11.08.2020 16:13:17; t0]: commit: done
   IW 281 [11.08.2020 16:13:17; t1]: commit: enter lock
   IW 281 [11.08.2020 16:13:17; t1]: commit: now prepare
   IW 281 [11.08.2020 16:13:17; t1]: prepareCommit: flush
   IW 281 [11.08.2020 16:13:17; t1]:   index before flush _0(4.8):c1
   DW 281 [11.08.2020 16:13:17; t1]: startFullFlush
   DW 281 [11.08.2020 16:13:17; t1]: anyChanges? numDocsInRam=2 deletes=False hasTickets:False pendingChangesInFullFlush: False
   DWFC 281 [11.08.2020 16:13:17; t1]: addFlushableState DocumentsWriterPerThread [pendingDeletes=gen=0, segment=_1, aborting=False, numDocsInRAM=2, deleteQueue=DWDQ: [ generation: 1 ]]
   DWPT 281 [11.08.2020 16:13:17; t1]: flush postings as segment _1 numDocs=2
   IW 281 [11.08.2020 16:13:17; t3]: commit: start
   DWPT 281 [11.08.2020 16:13:17; t1]: new segment has 0 deleted docs
   DWPT 281 [11.08.2020 16:13:17; t1]: new segment has no vectors; no norms; no docValues; no prox; no freqs
   DWPT 281 [11.08.2020 16:13:17; t1]: flushedFiles=[_1.fdt, _1.fdx, _1.doc, _1.tim, _1.tip, _1.fnm]
   DWPT 281 [11.08.2020 16:13:17; t1]: flushed codec=CheapBastard
   DWPT 281 [11.08.2020 16:13:17; t1]: flushed: segment=_1 ramUsed=0 MB newFlushedSize(includes docstores)=0.00034332275390625 MB docs/MB=5825.422222222222
   IW 281 [11.08.2020 16:13:17; t1]: create compound file _1.cfs
   IW 281 [11.08.2020 16:13:17; t4]: commit: start
   DW 281 [11.08.2020 16:13:17; t1]: publishFlushedSegment seg-private updates=
   IW 281 [11.08.2020 16:13:17; t1]: publishFlushedSegment
   IW 281 [11.08.2020 16:13:17; t1]: publish sets newSegment delGen=3 seg=_1(4.8):c2
   IFD 281 [11.08.2020 16:13:17; t1]: now checkpoint "_0(4.8):c1 _1(4.8):c2" [2 segments ; isCommit = False]
   IFD 281 [11.08.2020 16:13:17; t1]: 0 msec to checkpoint
   IFD 281 [11.08.2020 16:13:17; t1]: delete new file "_1.fdt"
   IW 281 [11.08.2020 16:13:17; t5]: commit: start
   IFD 281 [11.08.2020 16:13:17; t1]: delete "_1.fdt"
   IFD 281 [11.08.2020 16:13:17; t1]: delete new file "_1.fdx"
   IFD 281 [11.08.2020 16:13:17; t1]: delete "_1.fdx"
   IFD 281 [11.08.2020 16:13:17; t1]: delete new file "_1.doc"
   IFD 281 [11.08.2020 16:13:17; t1]: delete "_1.doc"
   IFD 281 [11.08.2020 16:13:17; t1]: delete new file "_1.tim"
   IFD 281 [11.08.2020 16:13:17; t1]: delete "_1.tim"
   IFD 281 [11.08.2020 16:13:17; t1]: delete new file "_1.tip"
   IFD 281 [11.08.2020 16:13:17; t1]: delete "_1.tip"
   IFD 281 [11.08.2020 16:13:17; t1]: delete new file "_1.fnm"
   IFD 281 [11.08.2020 16:13:17; t1]: delete "_1.fnm"
   IW 281 [11.08.2020 16:13:17; t1]: apply all deletes during flush
   BD 281 [11.08.2020 16:13:17; t1]: applyDeletes: no deletes; skipping
   BD 281 [11.08.2020 16:13:17; t1]: prune sis=Lucene.Net.Index.SegmentInfos minGen=1 packetCount=0
   DW 281 [11.08.2020 16:13:17; t1]: t1 finishFullFlush success=True
   TMP 281 [11.08.2020 16:13:17; t1]: findMerges: 2 segments
   TMP 281 [11.08.2020 16:13:17; t1]:   seg=_1(4.8):c2 size=0,000 MB [floored]
   TMP 281 [11.08.2020 16:13:17; t1]:   seg=_0(4.8):c1 size=0,000 MB [floored]
   TMP 281 [11.08.2020 16:13:17; t1]:   allowedSegmentCount=1 vs count=2 (eligible count=2) tooBigCount=0
   CMS 281 [11.08.2020 16:13:17; t1]: now merge
   CMS 281 [11.08.2020 16:13:17; t1]:   index: _0(4.8):c1 _1(4.8):c2
   CMS 281 [11.08.2020 16:13:17; t1]:   no more merges pending; now return
   IW 281 [11.08.2020 16:13:17; t1]: StartCommit(): start
   IW 281 [11.08.2020 16:13:17; t1]: startCommit index=_0(4.8):c1 _1(4.8):c2 changeCount=6
   IW 281 [11.08.2020 16:13:17; t1]: done all syncs: [_0.cfs, _0.cfe, _0.si, _1.cfs, _1.cfe, _1.si]
   IW 281 [11.08.2020 16:13:17; t1]: commit: pendingCommit != null
   IW 281 [11.08.2020 16:13:17; t6]: commit: start
   IW 281 [11.08.2020 16:13:17; t1]: commit: wrote segments file "segments_2"
   IFD 281 [11.08.2020 16:13:17; t1]: now checkpoint "_0(4.8):c1 _1(4.8):c2" [2 segments ; isCommit = True]
   IFD 281 [11.08.2020 16:13:17; t1]: 0 msec to checkpoint
   IW 281 [11.08.2020 16:13:17; t1]: commit: done
   IW 281 [11.08.2020 16:13:17; t2]: commit: enter lock
   IW 281 [11.08.2020 16:13:17; t2]: commit: now prepare
   IW 281 [11.08.2020 16:13:17; t2]: prepareCommit: flush
   IW 281 [11.08.2020 16:13:17; t2]:   index before flush _0(4.8):c1 _1(4.8):c2
   DW 281 [11.08.2020 16:13:17; t2]: startFullFlush
   DW 281 [11.08.2020 16:13:17; t2]: anyChanges? numDocsInRam=4 deletes=False hasTickets:False pendingChangesInFullFlush: False
   DWFC 281 [11.08.2020 16:13:17; t2]: addFlushableState DocumentsWriterPerThread [pendingDeletes=gen=0, segment=_2, aborting=False, numDocsInRAM=4, deleteQueue=DWDQ: [ generation: 2 ]]
   IW 281 [11.08.2020 16:13:17; t2]: hit exception during prepareCommit
   DW 281 [11.08.2020 16:13:17; t2]: t2 finishFullFlush success=False
   DWFC 281 [11.08.2020 16:13:17; t7]: addFlushableState DocumentsWriterPerThread [pendingDeletes=gen=0, segment=_2, aborting=False, numDocsInRAM=4, deleteQueue=DWDQ: [ generation: 2 ]]
   IW 281 [11.08.2020 16:13:17; t7]: commit: start
   IW 281 [11.08.2020 16:13:17; t9]: commit: start
   IW 281 [11.08.2020 16:13:17; t8]: commit: start
   IW 281 [11.08.2020 16:13:17; t3]: commit: enter lock
   IW 281 [11.08.2020 16:13:17; t3]: commit: now prepare
   IW 281 [11.08.2020 16:13:17; t3]: prepareCommit: flush
   IW 281 [11.08.2020 16:13:17; t3]:   index before flush _0(4.8):c1 _1(4.8):c2
   DW 281 [11.08.2020 16:13:17; t3]: startFullFlush
   DW 281 [11.08.2020 16:13:17; t3]: anyChanges? numDocsInRam=7 deletes=False hasTickets:False pendingChangesInFullFlush: False
   IW 281 [11.08.2020 16:13:17; t3]: hit exception during prepareCommit
   DW 281 [11.08.2020 16:13:17; t3]: t3 finishFullFlush success=False
   IW 281 [11.08.2020 16:13:17; t4]: commit: enter lock
   IW 281 [11.08.2020 16:13:17; t4]: commit: now prepare
   IW 281 [11.08.2020 16:13:17; t4]: prepareCommit: flush
   IW 281 [11.08.2020 16:13:17; t4]:   index before flush _0(4.8):c1 _1(4.8):c2
   DW 281 [11.08.2020 16:13:17; t4]: startFullFlush
   DW 281 [11.08.2020 16:13:17; t4]: anyChanges? numDocsInRam=7 deletes=False hasTickets:False pendingChangesInFullFlush: False
   IW 281 [11.08.2020 16:13:17; t4]: hit exception during prepareCommit
   DW 281 [11.08.2020 16:13:17; t4]: t4 finishFullFlush success=False
   IW 281 [11.08.2020 16:13:17; t5]: commit: enter lock
   IW 281 [11.08.2020 16:13:17; t5]: commit: now prepare
   IW 281 [11.08.2020 16:13:17; t5]: prepareCommit: flush
   IW 281 [11.08.2020 16:13:17; t5]:   index before flush _0(4.8):c1 _1(4.8):c2
   DW 281 [11.08.2020 16:13:17; t5]: startFullFlush
   DW 281 [11.08.2020 16:13:17; t5]: anyChanges? numDocsInRam=7 deletes=False hasTickets:False pendingChangesInFullFlush: False
   IW 281 [11.08.2020 16:13:17; t5]: hit exception during prepareCommit
   DW 281 [11.08.2020 16:13:17; t5]: t5 finishFullFlush success=False
   IW 281 [11.08.2020 16:13:17; t6]: commit: enter lock
   IW 281 [11.08.2020 16:13:17; t6]: commit: now prepare
   IW 281 [11.08.2020 16:13:17; t6]: prepareCommit: flush
   IW 281 [11.08.2020 16:13:17; t6]:   index before flush _0(4.8):c1 _1(4.8):c2
   DW 281 [11.08.2020 16:13:17; t6]: startFullFlush
   DW 281 [11.08.2020 16:13:17; t6]: anyChanges? numDocsInRam=7 deletes=False hasTickets:False pendingChangesInFullFlush: False
   IW 281 [11.08.2020 16:13:17; t6]: hit exception during prepareCommit
   DW 281 [11.08.2020 16:13:17; t6]: t6 finishFullFlush success=False
   IW 281 [11.08.2020 16:13:17; t9]: commit: enter lock
   IW 281 [11.08.2020 16:13:17; t9]: commit: now prepare
   IW 281 [11.08.2020 16:13:17; t9]: prepareCommit: flush
   IW 281 [11.08.2020 16:13:17; t9]:   index before flush _0(4.8):c1 _1(4.8):c2
   DW 281 [11.08.2020 16:13:17; t9]: startFullFlush
   DW 281 [11.08.2020 16:13:17; t9]: anyChanges? numDocsInRam=7 deletes=False hasTickets:False pendingChangesInFullFlush: False
   IW 281 [11.08.2020 16:13:17; t9]: hit exception during prepareCommit
   DW 281 [11.08.2020 16:13:17; t9]: t9 finishFullFlush success=False
   IW 281 [11.08.2020 16:13:17; t8]: commit: enter lock
   IW 281 [11.08.2020 16:13:17; t8]: commit: now prepare
   IW 281 [11.08.2020 16:13:17; t8]: prepareCommit: flush
   IW 281 [11.08.2020 16:13:17; t8]:   index before flush _0(4.8):c1 _1(4.8):c2
   DW 281 [11.08.2020 16:13:17; t8]: startFullFlush
   DW 281 [11.08.2020 16:13:17; t8]: anyChanges? numDocsInRam=7 deletes=False hasTickets:False pendingChangesInFullFlush: False
   IW 281 [11.08.2020 16:13:17; t8]: hit exception during prepareCommit
   DW 281 [11.08.2020 16:13:17; t8]: t8 finishFullFlush success=False
   IW 281 [11.08.2020 16:13:17; t7]: commit: enter lock
   IW 281 [11.08.2020 16:13:17; t7]: commit: now prepare
   IW 281 [11.08.2020 16:13:17; t7]: prepareCommit: flush
   IW 281 [11.08.2020 16:13:17; t7]:   index before flush _0(4.8):c1 _1(4.8):c2
   DW 281 [11.08.2020 16:13:17; t7]: startFullFlush
   DW 281 [11.08.2020 16:13:17; t7]: anyChanges? numDocsInRam=7 deletes=False hasTickets:False pendingChangesInFullFlush: False
   IW 281 [11.08.2020 16:13:17; t7]: hit exception during prepareCommit
   DW 281 [11.08.2020 16:13:17; t7]: t7 finishFullFlush success=False
   ```


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org