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

IllegalMonitorStateException could be thrown during cache close with concurrent committing transactions

    XMLWordPrintableJSON

Details

    • Bug
    • Status: Closed
    • Major
    • Resolution: Fixed
    • 1.1.0
    • 1.10.0
    • transactions
    • None

    Description

      This could occur when a client transaction is being committed and locks are hold by a thread. Another thread is concurrently closing the cache and try to release the resources (including the transactions) and could hit this issue.

      java.lang.IllegalMonitorStateException: attempt to unlock read lock, not locked by current thread
      at java.util.concurrent.locks.ReentrantReadWriteLock$Sync.unmatchedUnlockException(ReentrantReadWriteLock.java:444)
      at java.util.concurrent.locks.ReentrantReadWriteLock$Sync.tryReleaseShared(ReentrantReadWriteLock.java:428)
      at java.util.concurrent.locks.AbstractQueuedSynchronizer.releaseShared(AbstractQueuedSynchronizer.java:1341)
      at java.util.concurrent.locks.ReentrantReadWriteLock$ReadLock.unlock(ReentrantReadWriteLock.java:881)
      at org.apache.geode.internal.util.concurrent.StoppableReentrantReadWriteLock$StoppableReadLock.unlock(StoppableReentrantReadWriteLock.java:144)
      at org.apache.geode.internal.cache.locks.TXLockServiceImpl.releaseRecoveryReadLock(TXLockServiceImpl.java:270)
      at org.apache.geode.internal.cache.locks.TXLockServiceImpl.release(TXLockServiceImpl.java:237)
      at org.apache.geode.internal.cache.TXLockRequest.releaseDistributed(TXLockRequest.java:109)
      at org.apache.geode.internal.cache.TXLockRequest.cleanup(TXLockRequest.java:142)
      at org.apache.geode.internal.cache.TXState.doCleanup(TXState.java:886)
      at org.apache.geode.internal.cache.TXState.cleanup(TXState.java:872)
      at org.apache.geode.internal.cache.TXState.close(TXState.java:858)
      at org.apache.geode.internal.cache.TXStateProxyImpl.close(TXStateProxyImpl.java:924)
      at org.apache.geode.internal.cache.TXManagerImpl.removeHostedTXStatesForClients(TXManagerImpl.java:1076)
      at org.apache.geode.internal.cache.CacheServerImpl.stop(CacheServerImpl.java:484)
      at org.apache.geode.internal.cache.GemFireCacheImpl.stopServers(GemFireCacheImpl.java:2633)
      at org.apache.geode.internal.cache.GemFireCacheImpl.close(GemFireCacheImpl.java:2213)
      at org.apache.geode.distributed.internal.InternalDistributedSystem.disconnect(InternalDistributedSystem.java:1363)
      at org.apache.geode.distributed.internal.InternalDistributedSystem.disconnect(InternalDistributedSystem.java:1026)
      at hydra.RemoteTestModule$3.run(RemoteTestModule.java:416)

      Attachments

        Issue Links

          Activity

            People

              eshu Eric Shu
              eshu Eric Shu
              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