Search Java Classes and Packages

Search Java Frameworks and Libraries

255581 classes and counting ...
Search Tips Index Status



#Locking Classes and Interfaces - 215 results found.
NameDescriptionTypePackageFramework
ArrayBlockingQueueA bounded blocking queue backed by an array.Classjava.util.concurrentJava SE
BlockingDequeA Deque that additionally supports blocking operations that wait for the deque to become non-empty when retrieving an element, and wait forInterfacejava.util.concurrentJava SE
BlockingQueueA Queue that additionally supports operations that wait for the queue to become non-empty when retrieving anInterfacejava.util.concurrentJava SE
IllegalBlockingModeExceptionUnchecked exception thrown when a blocking-mode-specific operation is invoked upon a channel in the incorrect blocking mode.Classjava.nio.channelsJava SE
LinkedBlockingDequeAn optionally-bounded blocking deque based on The optional capacity bound constructor argument serves as aClassjava.util.concurrentJava SE
LinkedBlockingQueueAn optionally-bounded blocking queue based on This queue orders elements FIFO (first-in-first-out).Classjava.util.concurrentJava SE
PriorityBlockingQueueAn unbounded blocking queue that uses the same ordering rules as class PriorityQueue and suppliesClassjava.util.concurrentJava SE
BlockingQueueConsumerSpecialized consumer encapsulating knowledge of the brokerconnections and having its own lifecycle (start and stop).Classorg.springframework.amqp.rabbit.listenerSpring AMQP
HibernateOptimisticLockingFailureExceptionHibernate-specific subclass of ObjectOptimisticLockingFailureException.Classorg.springframework.orm.hibernate3Spring MVC
HibernateOptimisticLockingFailureExceptionHibernate-specific subclass of ObjectOptimisticLockingFailureException.Classorg.springframework.orm.hibernate4Spring MVC
HibernateOptimisticLockingFailureExceptionHibernate-specific subclass of ObjectOptimisticLockingFailureException.Classorg.springframework.orm.hibernate5Spring MVC
JdoOptimisticLockingFailureExceptionJDO-specific subclass of ObjectOptimisticLockingFailureException.Classorg.springframework.orm.jdoSpring MVC
JpaOptimisticLockingFailureExceptionJPA-specific subclass of ObjectOptimisticLockingFailureException.Classorg.springframework.orm.jpaSpring MVC
ObjectOptimisticLockingFailureExceptionException thrown on an optimistic locking violation for a mapped object.Classorg.springframework.ormSpring MVC
OptimisticLockingFailureExceptionException thrown on an optimistic locking violation.Classorg.springframework.daoSpring MVC
PessimisticLockingFailureExceptionException thrown on a pessimistic locking violation.Classorg.springframework.daoSpring MVC
BlockingMessageListenerA MessageListener especially for DwrMessageConsumer that enables us to block waiting for a message.Classorg.directwebremoting.jmsDirectWebRemoting (DWR)
AWCooperativeMultithreadLockingInterfaceariba.ui.aribaweb.utilAriba Web
AWRequestLockingInterfaceariba.ui.aribaweb.coreAriba Web
GlobalLockingFinder class for the GlobalLockingServiceConstructor SummaryGlobalLocking()Classariba.util.coreAriba Web
GlobalLockingExceptionSomething went wrong in GlobalLocking, typically accessing an invalid lockClassariba.util.coreAriba Web
GlobalLockingServiceprovide services for acquiring global locks and creating lock groups.Interfaceariba.util.coreAriba Web
BlockingQueueTransportA server side HTTP based TransportChannel which processes incoming packets and adds outgoing packets onto a Queue so that they can be dispatchedClassorg.apache.activemq.transport.httpApache ActiveMQ
ArrayBlockingQueueFactoryClassorg.apache.camel.component.sedaApache Camel
BlockingQueueFactoryInterfaceorg.apache.camel.component.sedaApache Camel
DirectBlockingProducerThe direct producer.Classorg.apache.camel.component.directApache Camel
DirectVmBlockingProducerThe direct producer.Classorg.apache.camel.component.directvmApache Camel
LinkedBlockingQueueFactoryClassorg.apache.camel.component.sedaApache Camel
OptimisticLockingAggregationRepositoryA specialized AggregationRepository which also supports optimistic locking.Interfaceorg.apache.camel.spiApache Camel
OptimisticLockingAggregationRepository .OptimisticLockingExceptionException used by an AggregationRepository to indicate that an optimistic update error has occurred and that the operation should be retried by the caller.Classorg.apache.camel.spi.OptimisticLockingAggregationRepositoryApache Camel
OptimisticLockingAwareAggregationStrategyA specialized AggregationStrategy which gets a callback when the aggregated Exchange fails to add in the OptimisticLockingAggregationRepository because ofInterfaceorg.apache.camel.processor.aggregateApache Camel
PriorityBlockingQueueFactoryClassorg.apache.camel.component.sedaApache Camel
BlockingParticipantA repository participant is basically a service that needs to be initialized before it can return objects that correspond to specifiedClasscom.uwyn.rife.repRife
BlockingParticipantExpectedExceptionClasscom.uwyn.rife.rep.exceptionsRife
BlockingRepositoryThe BlockingRepository class provides a Repository implementation that loads the participants from anClasscom.uwyn.rife.repRife
BlockingRepositoryCleanupThe BlockingRepositoryCleanup class is simply a thread that calls the BlockingRepository's cleanup method.Classcom.uwyn.rife.repRife
Xml2BlockingRepositoryProcesses a Rep XML document and add all the declared participants to a BlockingRepository.Classcom.uwyn.rife.repRife
AbstractSelectLockingStrategyBase LockingStrategy implementation to support implementations based on issuing SQL SELECT statementsClassorg.hibernate.dialect.lockHibernate ORM
HSQLDialect .ReadUncommittedLockingStrategyConstructor SummaryHSQLDialect.Classorg.hibernate.dialect.HSQLDialectHibernate ORM
LockingStrategyA strategy abstraction for how locks are obtained in the underlying database.Interfaceorg.hibernate.dialect.lockHibernate ORM
LockingStrategyExceptionRepresents an error trying to apply a LockingStrategy to an entitySee Also:Serialized FormClassorg.hibernate.dialect.lockHibernate ORM
OptimisticForceIncrementLockingStrategyAn optimistic locking strategy that forces an increment of the version (after verifying that version hasn't changed).Classorg.hibernate.dialect.lockHibernate ORM
OptimisticLockingUsed to define the style of optimistic locking to be applied to an entity.Classorg.hibernate.annotationsHibernate ORM
OptimisticLockingStrategyAn optimistic locking strategy that verifies that the version hasn't changed (prior to transaction commit).Classorg.hibernate.dialect.lockHibernate ORM
PessimisticForceIncrementLockingStrategyA pessimistic locking strategy that increments the version immediately (obtaining an exclusive write lock).Classorg.hibernate.dialect.lockHibernate ORM
PessimisticReadSelectLockingStrategyA pessimistic locking strategy where the locks are obtained through select statements.Classorg.hibernate.dialect.lockHibernate ORM
PessimisticReadUpdateLockingStrategyA pessimistic locking strategy where the locks are obtained through update statements.Classorg.hibernate.dialect.lockHibernate ORM
PessimisticWriteSelectLockingStrategyA pessimistic locking strategy where the locks are obtained through select statements.Classorg.hibernate.dialect.lockHibernate ORM
PessimisticWriteUpdateLockingStrategyA pessimistic locking strategy where the locks are obtained through update statements.Classorg.hibernate.dialect.lockHibernate ORM
SelectLockingStrategyA locking strategy where the locks are obtained through select statements.Classorg.hibernate.dialect.lockHibernate ORM
UpdateLockingStrategyA locking strategy where the locks are obtained through update statements.Classorg.hibernate.dialect.lockHibernate ORM
ArrayBlockingQueueA bounded blocking queue backed by an array.Classutil.concurrentCode Trails
BlockingDequeA Deque that additionally supports blocking operations that wait for the deque to become non-empty when retrieving an element, and wait forInterfaceutil.concurrentCode Trails
BlockingQueueA Queue that additionally supports operations that wait for the queue to become non-empty when retrieving anInterfaceutil.concurrentCode Trails
AbstractNonblockingServerClassapache.blur.thirdparty.thrift_0_9_0.serverApache Blur
AbstractNonblockingServerClassapache.blur.thrift.serverApache Blur
AbstractNonblockingServer .AbstractNonblockingServerArgsClassapache.blur.thirdparty.thrift_0_9_0.server.AbstractNonblockingServerApache Blur
AbstractNonblockingServer .AbstractNonblockingServerArgsClassapache.blur.thrift.server.AbstractNonblockingServerApache Blur
TNonblockingServerA nonblocking TServer implementation.Classapache.blur.thirdparty.thrift_0_9_0.serverApache Blur
TNonblockingServer .ArgsFields inherited from class org.Classapache.blur.thirdparty.thrift_0_9_0.server.TNonblockingServerApache Blur
TNonblockingServerSocketClassapache.blur.thirdparty.thrift_0_9_0.transportApache Blur
TNonblockingServerTransportServer transport that can be operated in a nonblocking fashion.Classapache.blur.thirdparty.thrift_0_9_0.transportApache Blur
TNonblockingSocketTransport for use with async client.Classapache.blur.thirdparty.thrift_0_9_0.transportApache Blur
TNonblockingTransportClassapache.blur.thirdparty.thrift_0_9_0.transportApache Blur
BlockingBinaryEncoderA BinaryEncoder implementation that writes large arrays and maps as a sequence of blocks.Classorg.apache.avro.ioAvro
BlockingThreadPoolExecutorFactoryClassorg.infinispan.commons.executorsInfinispan
LockingConfigurationDefines the local, in-VM locking and concurrency characteristics of the cache.Classorg.infinispan.configuration.cacheInfinispan
LockingConfigurationBuilderDefines the local, in-VM locking and concurrency characteristics of the cache.Classorg.infinispan.configuration.cacheInfinispan
LockingModeDefines the locking modes that are available for transactional caches: optimistic or pessimistic.Classorg.infinispan.transactionInfinispan
FairBlockingQueueA simple implementation of a blocking queue with fairness waiting.ClassTOMCAT
MultiLockFairBlockingQueueEXPERIMENTAL AND NOT YET COMPLETE! An implementation of a blocking queue with fairness waiting and lock dispersal to avoid contention.ClassTOMCAT
NioBlockingSelectorClassTOMCAT
NioBlockingSelector .BlockPollerClassTOMCAT
NioBlockingSelector .KeyReferenceClassTOMCAT
NonBlockingCoordinatorTitle: Auto merging leader election algorithm Description: Implementation of a simple coordinator algorithm that not only selects a coordinator,ClassTOMCAT
NonBlockingCoordinator .CoordinationEventClassTOMCAT
NonBlockingCoordinator .CoordinationMessageClassTOMCAT
NonBlockingBufferedInputStreamClassorg.apache.axis.transport.httpApache Axis
BlockingEnvelopeMap BlockingEnvelopeMap is a helper class for SystemConsumer implementations.Classorg.apache.samza.utilApache Samza
CustomNonBlockingServerThis class implements a custom non-blocking thrift server, incorporating the THsHaServer features, and overriding the underlying TNonblockingServer methods, especially TNonblockingServer.Classorg.apache.accumulo.server.utilApache Accumulo
TNonblockingServerSocketWrapper around ServerSocketChannel.Classorg.apache.accumulo.server.utilApache Accumulo
BlockingRpcChannelAbstract interface for a blocking RPC channel.Interfaceakka.protobufAkka
BlockingServiceBlocking equivalent to Service.Interfaceakka.protobufAkka
BoundedBlockingQueueBoundedBlockingQueue wraps any Queue and turns the result into a BlockingQueue with a limited capacity.Classakka.utilAkka
NonBlockingBoundedMailboxNonBlockingBoundedMailbox is a high-performance, multiple-producer single-consumer, bounded MailboxType, Noteworthy is that it discards overflow as DeadLetters.Classakka.dispatchAkka
NonBlockingBoundedMailbox$Classakka.dispatchAkka
StablePriorityBlockingQueueStablePriorityBlockingQueue is a blocking priority queue that preserves order for elements of equal priority.Classakka.utilAkka
BlockingHashJoinAnnotatorClasscascading.flow.planner.rule.annotatorCascading
BlockingModeClasscascading.flow.stream.annotationsCascading
HashJoinBlockingHashJoinAnnotatorClasscascading.flow.planner.rule.annotatorCascading
NonBlockingOpDeDupProcClassorg.apache.hadoop.hive.ql.optimizerApache Hive
JDBCOptimisticLockingMetaDataOptimistick locking metadataVersion:$Revision: 1.Classorg.jboss.ejb.plugins.cmp.jdbc.metadataJBoss Server
LockingStrategyInterfaceorg.jboss.ejb.plugins.cmp.jdbcJBoss Server
LockingStrategy .AbstractStrategyNested Class SummaryNested classes inherited from class org.Classorg.jboss.ejb.plugins.cmp.jdbc.LockingStrategyJBoss Server
BlockingArrayQueueA BlockingQueue backed by a circular array capable or growing.Classorg.eclipse.jetty.utilJetty
BlockingCallbackAn implementation of Callback that blocks until success or failure.Classorg.eclipse.jetty.utilJetty
BlockingWriteCallbackClassorg.eclipse.jetty.websocket.commonJetty
BlockingWriteCallback .WriteBlockerClassorg.eclipse.jetty.websocket.common.BlockingWriteCallbackJetty
Callback .NonBlockingInterfaceorg.eclipse.jetty.util.CallbackJetty
SharedBlockingCallbackProvides a reusable Callback that can block the thread while waiting to be completed.Classorg.eclipse.jetty.utilJetty
HTTPBlockingConnectorClassorg.apache.geronimo.jetty6.connectorApache Geronimo
BlockingFixedSizePoolThis is an Pool that caches Poolable objects for reuse.Classorg.apache.excalibur.mpoolApache Avalon
ForwardingBlockingDequeA BlockingDeque which forwards all its method calls to another BlockingDeque.Classcom.google.common.collectGoogle Guava
ForwardingBlockingQueueA BlockingQueue which forwards all its method calls to another BlockingQueue.Classcom.google.common.util.concurrentGoogle Guava
BlockingInputStream RawDataBlock that expects data in 512 byte chunks.Classorg.apache.poi.utilApache POI
BlockingOperationExceptionAn IllegalStateException which is raised when a user performed a blocking operationwhen the user is in an event loop thread.Classio.netty.util.concurrentNetty
F .BlockingEventStreamClassplay.libs.FPlay
BlockingPortalCacheClasscom.liferay.portal.kernel.cacheLiferay Portal
BlockingAsyncStrategyClassninja-servlet.ninja.servlet.asyncSpark Micro Web
BlockingAsyncStrategyClassninja.servlet.asyncNinja
DefaultISMLockingDefault item state locking strategy.Classorg.apache.jackrabbit.core.stateApache JackRabbit
FineGrainedISMLockingFineGrainedISMLocking.Classorg.apache.jackrabbit.core.stateApache JackRabbit
ISMLockingISMLocking defines an interface for a locking strategy of an An implementation of ISMLocking must meet the followingInterfaceorg.apache.jackrabbit.core.stateApache JackRabbit
ISMLocking .ReadLockInterfaceorg.apache.jackrabbit.core.stateApache JackRabbit
ISMLocking .WriteLockInterfaceorg.apache.jackrabbit.core.stateApache JackRabbit
ISMLockingFactoryFactory interface for creating ISMLocking instances.Interfaceorg.apache.jackrabbit.core.stateApache JackRabbit
LockingTestTests if locking a node triggers property added events for jcr:lockOwner and jcr:lockIsDeep.Classorg.apache.jackrabbit.test.api.observationApache JackRabbit
BlockingQueueConsumerClassorg.apache.curator.framework.recipes.queueApache Curator
LockingExampleClasslockingApache Curator
BlockingVariableA statically typed variable whose get() method will block until some other thread has set a value with the set() method, or a timeout expires.Classspock.util.concurrentSpock
LockingRepository modifications of persisted aggregates.Classorg.axonframework.repositoryAxon
LockingStrategyenum LockingStrategyextends EnumEnum indicating possible locking strategies for repositories.Classorg.axonframework.contextsupport.springAxon
BlockingObservableBlockingObservable is a variety of Observable that provides blocking operators.Classrx.observablesRxJava
BlockingSingleBlockingSingle is a blocking "version" of Single that provides blocking You construct a BlockingSingle from a Single with from(Single)Classrx.singlesRxJava
OStorage .LOCKING_STRATEGYReturns the enum constant of this type with the specified name.Classcom.orientechnologies.orient.core.storage.OStorageOrientdb
AMQChannel .BlockingRpcContinuationClasscom.rabbitmq.client.impl.AMQChannelRabbitMQ
AMQChannel .SimpleBlockingRpcContinuationClasscom.rabbitmq.client.impl.AMQChannelRabbitMQ
BlockingCellSimple one-shot IPC mechanism.Classcom.rabbitmq.utilityRabbitMQ
BlockingValueOrExceptionClasscom.rabbitmq.utilityRabbitMQ
VariableLinkedBlockingQueueA clone of LinkedBlockingQueue with the addition of a setCapacity(int) method, allowing us toClasscom.rabbitmq.client.implRabbitMQ
AbstractFeatureLockingClassorg.geotools.dataGeoTools
DirectoryFeatureLockingClassorg.geotools.data.directoryGeoTools
DirectoryLockingManagerLocking manager that will delegate its work to the locking managers of the delegate data storesClassorg.geotools.data.directoryGeoTools
FeatureLockingProvides Feature based locking.Interfaceorg.geotools.dataGeoTools
FeatureLocking .ResponseIdea for a response from a high-level lock( Query ) function.Classorg.geotools.data.FeatureLockingGeoTools
InProcessLockingManagerProvides In-Process FeatureLocking support for DataStore implementations.Classorg.geotools.dataGeoTools
LockingManagerThis class describes a featureID based locking service.Interfaceorg.geotools.dataGeoTools
SimpleFeatureLockingUsed to lock feature content to protect against other threads (or depending on the source of data other applications) making modifications when you are not looking.Interfaceorg.geotools.data.simpleGeoTools
BlockingCacheA blocking decorator for an Ehcache, backed by a Ehcache.Classnet.sf.ehcache.constructs.blockingEHCache
ExplicitLockingContextThreadLocalA class that maintains a thread local to keep track of any explicit locks acquired by the app threadAuthor:Abhishek SanoujamClassnet.sf.ehcache.constructs.nonstop.concurrencyEHCache
RejoinAwareBlockingOperationA Callable implementation that accepts another callable delegate for executing it in nonstop+rejoin context.Classnet.sf.ehcache.constructs.nonstop.storeEHCache
BlockingFetchQueuesQueueing structure (intended for cells to be fetched).Classbdv.img.cacheFiji
ActivitiOptimisticLockingExceptionException that is thrown when an optimistic locking occurs in the datastore caused by concurrent access of the same data entry.Classorg.activiti.engineActiviti
AbstractStressTestNonBlockingLockManagerSuite of stress tests of the concurrency control mechanisms (without the database implementation) - See NonBlockingLockManager.Classcom.bigdata.concurrentBlazeGraph
AbstractStressTestNonBlockingLockManager .GenerateGenerates an XML file that can be used to (re-)run the concurrency control tests.Classcom.bigdata.concurrentBlazeGraph
AbstractStressTestNonBlockingLockManager .TestOptions AbstractStressTestNonBlockingLockManager.Classcom.bigdata.concurrentBlazeGraph
AbstractStressTestNonBlockingLockManager .Wait10ResourceTaskWaits 10ms once it acquires its locks.Classcom.bigdata.concurrentBlazeGraph
BlockingBuffer A buffer that will block when it is full.Classcom.bigdata.relation.accesspathBlazeGraph
BlockingBufferWithStats BlockingBuffer and to track the BOpStats as chunks are addedVersion:$Id: BlockingBufferWithStats.Classcom.bigdata.bop.engineBlazeGraph
BlockingQueueTestContains tests generally applicable to BlockingQueue implementations.Classcom.bigdata.jsr166BlazeGraph
IBlockingBuffer Interface provides an iterator to drain chunks from an IBuffer.Interfacecom.bigdata.relation.accesspathBlazeGraph
LinkedBlockingDequeAn optionally-bounded blocking deque based on The optional capacity bound constructor argument serves as aClasscom.bigdata.jsr166BlazeGraph
LinkedBlockingDequeTestClasscom.bigdata.jsr166BlazeGraph
LinkedBlockingDequeTest .BoundedClasscom.bigdata.jsr166BlazeGraph
LinkedBlockingDequeTest .UnboundedClasscom.bigdata.jsr166BlazeGraph
LinkedBlockingQueueAn optionally-bounded blocking queue based on This queue orders elements FIFO (first-in-first-out).Classcom.bigdata.jsr166BlazeGraph
LinkedBlockingQueueTestClasscom.bigdata.jsr166BlazeGraph
LinkedBlockingQueueTest .BoundedClasscom.bigdata.jsr166BlazeGraph
LinkedBlockingQueueTest .UnboundedClasscom.bigdata.jsr166BlazeGraph
MultiplexBlockingBufferA factory for skins which may be used to multiplex writes against a shared BlockingBuffer instance.Classcom.bigdata.relation.accesspathBlazeGraph
NonBlockingLockManagerThis class coordinates a schedule among concurrent operations requiring exclusive access to shared resources.Classcom.bigdata.concurrentBlazeGraph
NonBlockingLockManager .CountersCounters for the NonBlockingLockManager.Classcom.bigdata.concurrentBlazeGraph
NonBlockingLockManager .RunStateRun states for the NonBlockingLockManager.Classcom.bigdata.concurrentBlazeGraph
NonBlockingLockManagerWithNewDesignThis class coordinates a schedule among concurrent operations requiring exclusive access to shared resources.Classcom.bigdata.concurrentBlazeGraph
NonBlockingLockManagerWithNewDesign .CountersCounters for the NonBlockingLockManagerWithNewDesign.Classcom.bigdata.concurrentBlazeGraph
NonBlockingLockManagerWithNewDesign .LockFutureTaskFutureTask which executes once it holds its locks.Classcom.bigdata.concurrentBlazeGraph
NonBlockingLockManagerWithNewDesign .ResourceQueueUnbounded queue of operations waiting to gain an exclusive lock on aVersion:$Id$Author:Bryan ThompsonSee Also:LockManager, Classcom.bigdata.concurrentBlazeGraph
StressTestNonBlockingLockManagerWithPredeclaredLocksStress tests where we predeclare locks and sort the lock requests.Classcom.bigdata.concurrentBlazeGraph
StressTestNonBlockingLockManagerWithTxDagStress tests where a TxDag is used to detect deadlock.Classcom.bigdata.concurrentBlazeGraph
TestBlockingBufferTest suite for BlockingBuffer and its IAsynchronousIterator.Classcom.bigdata.relation.accesspathBlazeGraph
TestBlockingBufferPerformance740Classcom.bigdata.rdf.sparql.ast.evalBlazeGraph
TestBlockingBufferWithChunksTest suite for BlockingBuffer and its IAsynchronousIterator when using an array type for the elements (chunk processing).Classcom.bigdata.relation.accesspathBlazeGraph
TestBlockingBufferWithChunksDequeTest suite for BlockingBuffer and its IAsynchronousIterator when using an array type for the elements (chunk processing) and aClasscom.bigdata.relation.accesspathBlazeGraph
TestHierarchicalLockingTasksTest suite for hierarchical locking of indices based on namespace prefixes.Classcom.bigdata.journalBlazeGraph
TestMultiplexBlockingBufferTest suite for MultiplexBlockingBuffer.Classcom.bigdata.relation.accesspathBlazeGraph
TestNonBlockingLockManager FIXME Verify interaction with the writeService.Classcom.bigdata.concurrentBlazeGraph
TestNonBlockingLockManager .Wait10ResourceTaskWaits 10ms once it acquires its locks.Classcom.bigdata.concurrentBlazeGraph
TestNonBlockingLockManagerWithNewDesignClasscom.bigdata.concurrentBlazeGraph
TestNonBlockingLockManagerWithNewDesign .Wait10ResourceTaskWaits 10ms once it acquires its locks.Classcom.bigdata.concurrentBlazeGraph
NonBlockingGenericDialogThis is an extension of GenericDialog that is non-model.Classij.guiImageJ
BlockingInputStreamBlockingInputStream is a combination of an input stream and an output stream, connected through a (circular) buffer in memory.Classorg.exist.storage.ioExistDB
BlockingOutputStreamOutput stream adapter for a BlockingInputStream.Classorg.exist.storage.ioExistDB
AllFieldsLockingPolicyPurpose: An implementation of the OptimisticLockingPolicy interface.Classorg.eclipse.persistence.descriptorsEclipseLink
ChangedFieldsLockingPolicyPurpose: An implementation of the OptimisticLockingPolicy interface.Classorg.eclipse.persistence.descriptorsEclipseLink
FieldsLockingPolicyPurpose: An abstract superclass of some implementations of the OptimisticLockingPolicy interface.Classorg.eclipse.persistence.descriptorsEclipseLink
OptimisticLockingThe OptimisticLocking annotation is used to specify the type of optimistic locking TopLink should use when updating or deleting entities.Classorg.eclipse.persistence.annotationsEclipseLink
OptimisticLockingJPA scripting API implementation.Interfaceorg.eclipse.persistence.jpa.configEclipseLink
OptimisticLockingTypeenum OptimisticLockingTypeAn enum that is used within the OptimisticLocking annotation.Classorg.eclipse.persistence.annotationsEclipseLink
PessimisticLockingPolicy Description: This policy is used to configure bean level pessimistic locking feature.Classorg.eclipse.persistence.descriptorsEclipseLink
SelectedFieldsLockingPolicy Purpose: An implementation of the OptimisticLockingPolicy interface.Classorg.eclipse.persistence.descriptorsEclipseLink
TimestampLockingPolicyPurpose: Used to allow a single version timestamp to be used for optimistic locking.Classorg.eclipse.persistence.descriptorsEclipseLink
VersionLockingPolicyPurpose: Used to allow a single version number to be used for optimistic locking.Classorg.eclipse.persistence.descriptorsEclipseLink
EJBLockingThis interfase is used by CMP entity beans, which require explicit managing of the Enqueue locking, instead of using the implicit locking mechanisms of the EJB Container.Interfacecom.sap.engine.interfaces.ejb.lockingSAP NetWeaver
LogicalLockingProvides methods similar to the LockingContext, except that the owner may not be set explicitely.Interfacecom.sap.engine.services.applockingSAP NetWeaver
LogicalLockingFactoryGives access to an instance of the LogicalLocking, which belongs to a specified namespace.Interfacecom.sap.engine.services.applockingSAP NetWeaver
TableLockingProvides methods to lock and unlock rows in database tables.Interfacecom.sap.engine.services.applockingSAP NetWeaver
EditorLockingExceptionThe exception that indicates that an error occurred while handling locking.Classcom.sap.portal.admin.editor.exceptionSAP NetWeaver
EditorLockingStatusThe class that represents the status of the editor lock.Classcom.sap.portal.admin.editorSAP NetWeaver
EditorLockingStatus .StatusEnumClasscom.sap.portal.admin.editorSAP NetWeaver
ILockingPolicyThe interface that represents the locking policy of an editor.Interfacecom.sap.portal.admin.editorSAP NetWeaver
LockingExceptionException for problems in the area of locking.Classcom.sapportals.portal.pcd.glSAP NetWeaver
LockingCacheInterface for caches that support value lockingSince:4.Interfaceorg.alfresco.repo.cacheAlFresco
StoreObjectAccessorLockingWraps access to an object (the delegate PersistenceObjectStore.Classbrooklyn.entity.rebind.persisterBrooklyn
FlockingAgent based on Mike Miller's Java code conversion for The Computational Beauty of Nature by Gary William Flake.Classorg.jscience.computing.ai.artificiallifeJScience
AbstractBlockingThreadClassnet.yacy.kelondro.workflowYacy
BlockingThreadInterfacenet.yacy.kelondro.workflowYacy
InstantBlockingThreadClassnet.yacy.kelondro.workflowYacy
WeakPriorityBlockingQueue objects pushed on the stack must implement the hashCode() method to provide a handle for a double-check.Classnet.yacy.cora.sortingYacy
WeakPriorityBlockingQueue .AbstractElementClassnet.yacy.cora.sortingYacy
WeakPriorityBlockingQueue .ElementInterfacenet.yacy.cora.sortingYacy
WeakPriorityBlockingQueue .NaturalElementnatural ordering elements, can be used as container of objects in the priority queue the elements with smallest ordering weights are first in the queue when elements are takenClassnet.yacy.cora.sortingYacy
WeakPriorityBlockingQueue .ReverseElementreverse ordering elements, can be used as container of objects in the priority queue the elements with highest ordering weights are first in the queue when elements are takenClassnet.yacy.cora.sortingYacy
LockingFreeClassorg.checkerframework.dataflow.qualChecker
CompletableBlockingQueueA LinkedQueue that supports a terminal state.Classreactor.core.queueReactor
NonBlockingA dispatcher aware componentAuthor:Stephane MaldiniInterfacereactor.core.supportReactor