-
ae.sun.java2d.pipe.RenderQueue.unlock()
Unlocks the queue.
-
cc.mallet.types.Instance.unLock()
-
cli.System.IO.FileStream.Unlock()
-
cn.com.manager.domains.Task.unLock()
-
co.paralleluniverse.strands.concurrent.ReentrantLock.unlock()
Attempts to release this lock.
If the current strand is the holder of this lock then the hold count is decremented. If the hold count is now zero then the lock is released. If the current strand is not the holder of this lock then {@link IllegalMonitorStateException} is thrown.
@throws IllegalMonitorStateException if the current strand does nothold this lock
-
com.alibaba.otter.shared.arbitrate.impl.zookeeper.lock.DistributedLock.unlock()
释放锁对象
-
com.alibaba.otter.shared.arbitrate.impl.zookeeper.lock.DistributedReentrantLock.unlock()
-
com.alimama.mdrill.utils.TryLockFile.unlock()
-
com.aragost.javahg.Repository.unlock()
-
com.arjuna.ats.arjuna.utils.FileLock.unlock()
-
com.cloud.utils.db.GlobalLock.unlock()
-
com.cybozu.vmbkp.control.VmArchiveManager.unlock()
Unlock wrapper.
-
com.cybozu.vmbkp.profile.ProfileAllVm.unlock()
-
com.dotmarketing.beans.VersionInfo.unLock()
-
com.dotmarketing.business.RoleAPI.unLock()
@param role
@return
@throws DotDataException
-
com.dotmarketing.portlets.contentlet.business.ContentletAPI.unlock()
@param contentlet
@param user
@param respectFrontendRoles
@throws DotDataException
@throws DotSecurityException
@throws DotContentletStateException
-
com.dotmarketing.portlets.contentlet.model.ContentletVersionInfo.unLock()
-
com.ericsson.ssa.sip.persistence.ReplicationUnitOfWork.unlock()
Unlocks the dialog structure and optionally all dirty objects.
Note! Clears the thread local.
-
com.founder.fix.fixflow.core.impl.runtime.TokenEntity.unlock()
@see #lock()
-
com.google.jstestdriver.SlaveBrowser.unlock()
-
com.hazelcast.concurrent.lock.LockStoreImpl.unlock()
-
com.hazelcast.core.ILock.unlock()
Releases the lock.
-
com.hazelcast.core.IMap.unlock()
Releases the lock for the specified key. It never blocks and returns immediately.
If the current thread is the holder of this lock then the hold count is decremented. If the hold count is now zero then the lock is released. If the current thread is not the holder of this lock then {@link IllegalMonitorStateException} is thrown.
Warning:
This method uses
hashCode and
equals of binary form of the
key, not the actual implementations of
hashCode and
equals defined in
key's class.
@param key key to lock.
@throws NullPointerException if the specified key is null
@throws IllegalMonitorStateException if the current thread does not hold this lock
-
com.hazelcast.core.MultiMap.unlock()
Releases the lock for the specified key. It never blocks and returns immediately.
Warning:
This method uses hashCode and equals of binary form of the key, not the actual implementations of hashCode and equals defined in key's class.
@param key key to lock.
-
com.hazelcast.multimap.MultiMapContainer.unlock()
-
com.hazelcast.multimap.impl.MultiMapContainer.unlock()
-
com.mobixess.jodb.core.io.IOTicket.unlock()
-
com.netflix.exhibitor.core.config.PseudoLock.unlock()
Release the lock
@throws Exception errors
-
com.orientechnologies.orient.core.record.ORecord.unlock()
-
com.packtpub.java7.concurrency.chapter7.recipe08.task.MyLock.unlock()
Method that release the lock
-
com.pcmsolutions.util.RWLock.unlock()
-
com.sun.messaging.jmq.jmsserver.core.PacketReference.unlock()
-
com.taobao.datasource.tm.TransactionLocal.unlock()
Unlock the TransactionLocal using the current transaction
-
com.twitter.common.zookeeper.DistributedLock.unlock()
-
com.vaadin.server.VaadinSession.unlock()
Unlocks this session. This method should always be used in a finally block after {@link #lock()} to ensure that the lock is always released.
For UIs in this session that have its push mode set to {@link PushMode#AUTOMATIC automatic}, pending changes will be pushed to their respective clients.
@see #lock()
@see UI#push()
-
com.webobjects.eoaccess.EODatabaseContext.unlock()
-
com.webobjects.eocontrol.EOEditingContext.unlock()
-
com.webobjects.eocontrol.EOObjectStore.unlock()
-
com.webobjects.eocontrol.EOObjectStoreCoordinator.unlock()
-
com.webobjects.eocontrol.EOSharedEditingContext.unlock()
-
com.wesabe.grendel.openpgp.KeySet.unlock()
Given the keyset's passphrase, unlocks the secret keys and returns an {@link UnlockedKeySet} equivalent of {@code this}.
@param passphrase the key's passphrase
@return a {@link UnlockedKeySet} equivalent of {@code this}
@throws CryptographicException if {@code passphrase} is incorrect
-
edu.emory.mathcs.backport.java.util.concurrent.locks.Lock.unlock()
Releases the lock.
Implementation Considerations
A Lock implementation will usually impose restrictions on which thread can release a lock (typically only the holder of the lock can release it) and may throw an (unchecked) exception if the restriction is violated. Any restrictions and the exception type must be documented by that Lock implementation.
-
edu.emory.mathcs.backport.java.util.concurrent.locks.ReentrantLock.unlock()
Attempts to release this lock.
If the current thread is the holder of this lock then the hold count is decremented. If the hold count is now zero then the lock is released. If the current thread is not the holder of this lock then {@link IllegalMonitorStateException} is thrown.
@throws IllegalMonitorStateException if the current thread does nothold this lock.
-
edu.vt.rt.hyflow.benchmark.rmi.list.INode.unlock()
-
er.extensions.eof.ERXEC.unlock()
Overridden to emit log messages and pull this instance from the locked editing contexts in this thread.
-
freenet.client.async.PersistentJobRunner.CheckpointLock.unlock()
-
freenet.support.api.LockableRandomAccessBuffer.RAFLock.unlock()
-
io.fabric8.api.LockHandle.unlock()
-
java.util.concurrent.locks.Lock.unlock()
Releases the lock.
Implementation Considerations
A {@code Lock} implementation will usually imposerestrictions on which thread can release a lock (typically only the holder of the lock can release it) and may throw an (unchecked) exception if the restriction is violated. Any restrictions and the exception type must be documented by that {@code Lock} implementation.
-
java.util.concurrent.locks.ReentrantReadWriteLock.ReadLock.unlock()
-
java.util.concurrent.locks.ReentrantReadWriteLock.WriteLock.unlock()
-
javax.jcr.Node.unlock()
Unlocks the node.
-
javax.jcr.lock.LockManager.unlock()
-
nallar.tickthreading.util.concurrent.SimpleMutex.unlock()
-
net.mcft.copy.betterstorage.api.lock.IKey.unlock()
Gets called when a key is used to open a lock and returns if it's successful.
If useAbility is true, the key will use up an ability, like lockpicking or morphing.
-
net.sf.ehcache.concurrent.Sync.unlock()
Releases the lock held by the current Thread. In case of a LockType.WRITE, should the lock not be held by the current Thread, nothing happens
@param type the lock type to acquire
-
net.sf.ehcache.transaction.SoftLock.unlock()
Unlock the soft lock. Once a soft lock got unlocked, it is considered 'dead': it cannot be locked again and must be cleaned up
-
net.sourceforge.pebble.service.StaticPageService.unlock()
Unlocks a given static page.
@param staticPage the static page to unlock
@return true if the page could be unlocked, false otherwise
-
net.timewalker.ffmq3.storage.message.MessageStore.unlock()
Unlock the message associated to a given handle
@throws JMSException on storage error or invalid handle
-
nexj.core.rpc.file.ra.LockableFile.unlock()
Unlocks the file.
-
org.apache.blur.zookeeper.ZooKeeperLockManager.unlock()
-
org.apache.catalina.tribes.tipis.ReplicatedMapEntry.unlock()
Unlock after serialization
-
org.apache.commons.configuration.sync.SynchronizerSupport.unlock()
Releases a lock of this object that was obtained using the {@link #lock(LockMode)} method. This method must always be calledpair-wise with {@code lock()}. The argument must match to the one passed to the corresponding {@code lock()} call; otherwise, the behavior of the{@link Synchronizer} is unspecified.
@param mode the {@code LockMode}
-
org.apache.commons.configuration2.sync.SynchronizerSupport.unlock()
Releases a lock of this object that was obtained using the {@link #lock(LockMode)} method. This method must always be calledpair-wise with {@code lock()}. The argument must match to the one passed to the corresponding {@code lock()} call; otherwise, the behavior of the{@link Synchronizer} is unspecified.
@param mode the {@code LockMode}
-
org.apache.directory.server.core.ReferralManager.unlock()
Release the read-write lock on the referralManager. This method must be called after having read or modified the ReferralManager
-
org.apache.directory.server.core.api.ReferralManager.unlock()
Release the read-write lock on the referralManager. This method must be called after having read or modified the ReferralManager
-
org.apache.geronimo.management.geronimo.CertificationAuthority.unlock()
This method unlocks the CA.
@param password Password to unlock the CA.
-
org.apache.hadoop.hdfs.server.common.Storage.StorageDirectory.unlock()
-
org.apache.hadoop.hive.ql.lockmgr.HiveLockManager.unlock()
-
org.apache.harmony.awt.nativebridge.Int16Pointer.unlock()
-
org.apache.harmony.awt.nativebridge.Int32Pointer.unlock()
-
org.apache.harmony.awt.nativebridge.Int8Pointer.unlock()
-
org.apache.hcatalog.hbase.snapshot.lock.WriteLock.unlock()
Removes the lock or associated znode if you no longer require the lock. this also removes your request in the queue for locking in case you do not already hold the lock.
@throws RuntimeException throws a runtime exceptionif it cannot connect to zookeeper.
-
org.apache.helix.lock.HelixLock.unlock()
Release a lock
@return true if the lock was released, false if it could not be released
-
org.apache.jackrabbit.api.jsr283.lock.LockManager.unlock()
Removes the lock on the node at
absPath
. Also removes the properties
jcr:lockOwner
and
jcr:lockIsDeep
from that node. As well, the corresponding lock token is removed from the set of lock tokens held by the current
Session
.
If the node does not currently hold a lock or holds a lock for which this Session
is not the owner, then a LockException
is thrown. Note however that the system may give permission to a non-owning session to unlock a lock. Typically such "lock-superuser" capability is intended to facilitate administrational clean-up of orphaned open-scoped locks.
Note that it is possible to unlock a node even if it is checked-in (the lock-related properties will be changed despite the checked-in status).
If the current session does not have sufficient privileges to remove the lock, an AccessDeniedException
is thrown.
An InvalidItemStateException
is thrown if this node has pending unsaved changes.
An UnsupportedRepositoryOperationException
is thrown if this implementation does not support locking.
A RepositoryException
is thrown if another error occurs.
@param absPath absolute path of node to be unlocked
@throws UnsupportedRepositoryOperationException if this implementation does not support locking.
@throws LockException if this node does not currently hold a lock or holds a lock for which this Session does not have the correct lock token
@throws AccessDeniedException if the current session does not have permission to unlock this node.
@throws InvalidItemStateException if this node has pending unsaved changes.
@throws RepositoryException if another error occurs.
-
org.apache.jackrabbit.core.NodeImpl.unlock()
{@inheritDoc}
-
org.apache.jackrabbit.core.lock.LockManager.unlock()
Removes the lock on a node given by its path.
@param node node
@throws LockException if this node is not locked or the sessiondoes not have the correct lock token
@see javax.jcr.Node#unlock
-
org.apache.jackrabbit.oak.jcr.delegate.NodeDelegate.unlock()
-
org.apache.jackrabbit.ocm.manager.ObjectContentManager.unlock()
Unlock object stored on
@param path .
@param path path to stored object
@param lockToken see JCR spec: 8.4.6 Lock Token; can be null
@throws IllegalUnlockException throws if the current operation does not own the current lock
-
org.apache.lucene.index.DocumentsWriterPerThreadPool.ThreadState.unlock()
-
org.apache.maven.scm.provider.integrity.Sandbox.unlock()
Executes a 'si unlock' command using the relativeName of the file
@param memberFile Full path to the member's current sandbox location
@param relativeName Relative path from the nearest subproject or project
@return MKS API Response object
@throws APIException
-
org.apache.poi.xssf.usermodel.XSSFWorkbook.unLock()
Removes the workbook protection settings
-
org.apache.slide.lock.Lock.unlock()
Removes a lock.
@param slideToken The token to access slide.
@param lockToken Object containing all the lock information
@return true
if the lock was successfully removed
@exception ServiceAccessException Low level service access exception
@exception LockTokenNotFoundException Cannot find the Lock in the Lock Store service
-
org.apache.zookeeper.recipes.lock.WriteLock.unlock()
Removes the lock or associated znode if you no longer require the lock. this also removes your request in the queue for locking in case you do not already hold the lock.
@throws RuntimeException throws a runtime exceptionif it cannot connect to zookeeper.
-
org.codehaus.groovy.reflection.ClassInfo.unlock()
-
org.datanucleus.ManagedConnection.unlock()
unlock the access to this ManagedConnection
-
org.datanucleus.store.connection.ManagedConnection.unlock()
-
org.drools.common.InternalRuleBase.unlock()
-
org.drools.core.common.InternalRuleBase.unlock()
-
org.drools.core.impl.InternalKnowledgeBase.unlock()
-
org.dyno.visual.swing.designer.VisualDesigner.unlock()
-
org.eclipse.ecf.docshare2.DocShare.unlock()
-
org.eclipse.jgit.dircache.DirCache.unlock()
Unlock this file and abort this change.
The temporary file (if created) is deleted before returning.
-
org.eclipse.jgit.internal.storage.file.LockFile.unlock()
Unlock the given file.
This method can be used for recovering from a thrown {@link LockFailedException} . This method does not validate that the lockis or is not currently held before attempting to unlock it.
@param file
@return true if unlocked, false if unlocking failed
-
org.eclipse.jgit.storage.file.LockFile.unlock()
Unlock the given file.
This method can be used for recovering from a thrown {@link LockFailedException} . This method does not validate that the lockis or is not currently held before attempting to unlock it.
@param file
@return true if unlocked, false if unlocking failed
-
org.eclipse.jgit.storage.file.PackLock.unlock()
Remove the .keep
file that holds this pack in place.
@throws IOException if deletion of .keep file failed
-
org.exist.dom.DocumentSet.unlock()
-
org.exist.storage.lock.LockedDocumentMap.unlock()
-
org.exist.versioning.svn.WorkingCopy.unlock()
-
org.exoplatform.services.jcr.cluster.JCRWebdavConnection.unlock()
-
org.exoplatform.services.jcr.impl.core.NodeImpl.unlock()
{@inheritDoc}
-
org.gatein.cdi.contexts.beanstore.LockedBean.unlock()
-
org.h2.store.FileLock.unlock()
Unlock the file. The watchdog thread is stopped. This method does nothing if the file is already unlocked.
-
org.h2.table.Table.unlock()
Release the lock for this session.
@param s the session
-
org.hornetq.core.paging.cursor.PageCache.unlock()
You have to call this method within the same thread you called lock
-
org.infinispan.util.concurrent.locks.LockManager.unlock()
Releases the lock passed in, held by the specified owner
@param owner lock owner
-
org.jahia.services.content.JCRNodeWrapper.unlock()
-
org.jboss.as.ejb3.timerservice.TimerImpl.unlock()
-
org.jboss.as.ejb3.tx.OwnableReentrantLock.unlock()
-
org.jboss.cache.lock.LockManager.unlock()
Releases the lock passed in, held by the specified owner
@param fqn Fqn of the node to unlock
@param owner lock owner
-
org.jboss.ejb.EnterpriseContext.unlock()
-
org.jboss.ejb.EntityEnterpriseContext.unlock()
-
org.jboss.jca.core.spi.transaction.local.TransactionLocal.unlock()
Unlock the TransactionLocal using the current transaction
-
org.jboss.tm.TransactionLocal.unlock()
Unlock the TransactionLocal using the current transaction
-
org.jboss.weld.context.beanstore.LockedBean.unlock()
-
org.jbpm.examples.doorjava.Door.unlock()
-
org.jbpm.graph.exe.Token.unlock()
@see #lock(String)
-
org.jivesoftware.openfire.muc.MUCRoom.unlock()
Unlocks the room so that users can join the room. The room is locked when created and only the owner of the room can unlock it by sending the configuration form to the Multi-User Chat service.
@param senderRole the role of the occupant that unlocked the room.
@throws ForbiddenException If the user is not an owner of the room.
-
org.jpox.ManagedConnection.unlock()
unlock the access to this ManagedConnection
-
org.jruby.util.io.OpenFile.unlock()
-
org.kiji.schema.util.Lock.unlock()
Releases the lock.
@throws IOException on I/O error.
-
org.lealone.dbobject.table.Table.unlock()
Release the lock for this session.
@param s the session
-
org.locationtech.udig.project.internal.impl.SynchronizedEList.unlock()
-
org.locationtech.udig.tools.edit.support.TestHandler.unlock()
-
org.menagerie.locks.ReentrantZkLock.unlock()
Releases the currently held lock.
@inheritDoc
@throws RuntimeException wrapping:
- {@link org.apache.zookeeper.KeeperException} if the ZooKeeper server fails to process the unlockrequest
- {@link InterruptedException} if the ZooKeeper client and server have trouble communicating
-
org.modeshape.jcr.cache.MutableCachedNode.unlock()
Unlock this node.
-
org.mt4j.input.inputData.InputCursor.unlock()
Unlocks this cursor from the specified processor. If the priority by which this cursor is locked changes by that, the cursorUnlocked
method is invoked on processors with a lower priority who by that get a chance to lock this cursor again.
@param ia the AbstractCursorProcessor
-
org.netbeans.modules.editor.indent.api.Reformat.unlock()
-
org.openqa.selenium.firefox.internal.Lock.unlock()
-
org.openqa.selenium.firefox.internal.SocketLock.unlock()
@inheritDoc
-
org.openstreetmap.osmosis.core.util.FileBasedLock.unlock()
Release the lock.
-
org.platformlayer.auth.UserEntity.unlock()
-
org.platformlayer.core.model.SecretInfo.unlock()
-
org.redisson.core.RLock.unlock()
-
org.sonatype.nexus.proxy.item.RepositoryItemUidLock.unlock()
Unlocks UID. It is the responsibility of caller to use lock/unlock properly (ie. boxing of calls).
-
org.springframework.aop.framework.Lockable.unlock()
-
org.springframework.webflow.conversation.Conversation.unlock()
Unlock this conversation, making it available to others for manipulation.
-
org.springframework.webflow.execution.repository.FlowExecutionLock.unlock()
Release the flow execution lock.
-
org.terasology.world.chunks.Chunk.unlock()
-
org.terasology.world.chunks.CoreChunk.unlock()
-
org.tmatesoft.sqljet.core.internal.table.ISqlJetBtreeSchemaTable.unlock()
-
org.tmatesoft.svn.core.io.SVNRepository.unlock()
Removes lock(s) from the file(s).
Note that unlocking is never anonymous, so any server implementing this function will have to "pull" a username from the client, if it hasn't done so already.
Each path to be unlocked is handled with the provided handler
. If a path was successfully unlocked, the handler
's {@link ISVNLockHandler#handleUnlock(String,SVNLock,SVNErrorMessage) handleUnlock()}is called that receives the path and either a lock object (representing the lock that was removed from the path) or an error exception, if unlocking failed for that path.
If the username doesn't match the lock's owner and force
is false, this method call fails with throwing an SVNException. But if the force
flag is true, the lock will be "broken" by the current user.
Also if the lock token is incorrect or null and force
is false, the method fails with throwing a SVNException. However, if force
is true the lock will be removed anyway.
Paths can be both relative to the location of this driver and absolute to the repository root (starting with "/"
).
@param pathToTokens a map which keys are file paths and values are file locktokens (both keys and values are strings)
@param force true to remove the lock in any case - i.e. to "break" the lock
@param handler if not null, the lockhandler is invoked on each path to be unlocked
@throws SVNException in the following cases:
force
is false and the name of the user who tries to unlock a path does not match the lock owner - a lock token is incorrect for a path
- a failure occurred while connecting to a repository
- the user authentication failed (see {@link org.tmatesoft.svn.core.SVNAuthenticationException})
@see #lock(Map,String,boolean,ISVNLockHandler)
@see #getLocks(String)
@see #getLock(String)
@see org.tmatesoft.svn.core.SVNLock
@since SVN 1.2
-
org.uberfire.commons.cluster.ClusterService.unlock()
-
org.uberfire.commons.lock.impl.ThreadLockServiceImpl.unlock()
-
org.w3c.tools.resources.DummyResourceReference.unlock()
Unlock that resource from memory.
-
org.w3c.tools.resources.ResourceReference.unlock()
Unlock that resource from memory.
-
org.xtreemfs.babudb.log.DiskLogger.unlock()
-
org.zkoss.util.WaitLock.unlock()
Unlocks any other threads blocked by {@link #waitUntilUnlock}.
-
quicktime.std.music.MusicData.unlock()
-
sun.awt.datatransfer.ToolkitThreadBlockedHandler.unlock()
-
sun.java2d.pipe.RenderQueue.unlock()
Unlocks the queue.
-
test.aop.Lockable.unlock()
-
test.mixin.Lockable.unlock()
-
xbird.util.concurrent.lock.ILock.unlock()