A B C D E F G H I K L M N O P Q R S T U W

A

AbstractBufferImpl - Class in org.objectweb.dream.queue
Abstract implementation of a buffer.
AbstractBufferImpl() - Constructor for class org.objectweb.dream.queue.AbstractBufferImpl
 
AbstractBufferKeyedAddKeyedRemoveImpl - Class in org.objectweb.dream.queue.keyed
Abstract implementation of a keyed buffer.
AbstractBufferKeyedAddKeyedRemoveImpl() - Constructor for class org.objectweb.dream.queue.keyed.AbstractBufferKeyedAddKeyedRemoveImpl
 
AbstractBufferKeyedRemoveImpl - Class in org.objectweb.dream.queue.keyed
Abstract implementation of a (partially) keyed buffer.
AbstractBufferKeyedRemoveImpl() - Constructor for class org.objectweb.dream.queue.keyed.AbstractBufferKeyedRemoveImpl
 
AbstractPumpSynchronizedImpl - Class in org.objectweb.dream.pump
Abstract implementation of a synchronized Pull/Push pump.
AbstractPumpSynchronizedImpl() - Constructor for class org.objectweb.dream.pump.AbstractPumpSynchronizedImpl
 
AbstractRouterImpl - Class in org.objectweb.dream.router
Abstract implementation of a basic Push/Push router.
AbstractRouterImpl() - Constructor for class org.objectweb.dream.router.AbstractRouterImpl
 
AbstractRouterKeyBasedImpl - Class in org.objectweb.dream.router
Abstract implementation of a key-based Push/Push router.
AbstractRouterKeyBasedImpl() - Constructor for class org.objectweb.dream.router.AbstractRouterKeyBasedImpl
Constructor.
AbstractSemaphoreQueuedImpl - Class in org.objectweb.dream.synchro
Abstract implementation of a semaphore relying on queued wait nodes.
AbstractSemaphoreQueuedImpl.WaitQueue - Class in org.objectweb.dream.synchro
Base class for internal queue classes for semaphores, etc.
AbstractSemaphoreQueuedImpl.WaitQueue() - Constructor for class org.objectweb.dream.synchro.AbstractSemaphoreQueuedImpl.WaitQueue
 
AbstractSemaphoreQueuedImpl.WaitQueue.WaitNode - Class in org.objectweb.dream.synchro
An element of the queue.
AbstractSemaphoreQueuedImpl.WaitQueue.WaitNode() - Constructor for class org.objectweb.dream.synchro.AbstractSemaphoreQueuedImpl.WaitQueue.WaitNode
 
acceptMessage(Message) - Method in interface org.objectweb.dream.queue.MessageMatcher
Tests if the specified message can be returned from a buffer.
acquire() - Method in class org.objectweb.dream.synchro.AbstractSemaphoreQueuedImpl
 
acquire() - Method in interface org.objectweb.dream.synchro.Semaphore
Waits until a permit is available, and take one
acquire() - Method in class org.objectweb.dream.synchro.SemaphoreImpl
 
acquireRead() - Method in interface org.objectweb.dream.synchro.ReadWriteLock
Gets the read lock.
acquireRead() - Method in class org.objectweb.dream.synchro.ReadWriteLockFIFOImpl
 
acquireWrite() - Method in interface org.objectweb.dream.synchro.ReadWriteLock
Gets the write lock.
acquireWrite() - Method in class org.objectweb.dream.synchro.ReadWriteLockFIFOImpl
 
add(Message) - Method in class org.objectweb.dream.queue.AbstractBufferImpl
 
add(Message) - Method in interface org.objectweb.dream.queue.BufferAdd
Adds the specified message to the buffer.
add(Message, Object) - Method in class org.objectweb.dream.queue.keyed.AbstractBufferKeyedAddKeyedRemoveImpl
 
add(Message) - Method in class org.objectweb.dream.queue.keyed.AbstractBufferKeyedRemoveImpl
 
add(Message, Object) - Method in class org.objectweb.dream.queue.keyed.BufferAscendingKeyKeyChunkAddDoubleKeyedRemoveImpl
 
add(Message, Object) - Method in interface org.objectweb.dream.queue.keyed.KeyedBufferAdd
Adds the specified message to the buffer, associated with the specified key object.
addAtHead(BufferKeyMutexSortedImpl.MessageList) - Method in class org.objectweb.dream.queue.BufferKeyMutexSortedImpl
 
AddIPExportIdChunkAttributeController - Interface in org.objectweb.dream.channel
Attribute controller interface for AddIPExportIdChunk components.
AddIPExportIdChunkImpl - Class in org.objectweb.dream.channel
This message transformer adds a ExportIdentifierChunk containing an IPExportIdentifier.
AddIPExportIdChunkImpl() - Constructor for class org.objectweb.dream.channel.AddIPExportIdChunkImpl
 
addMessageAtLast(BufferKeyMutexSortedImpl.MessageList, Message) - Method in class org.objectweb.dream.queue.BufferKeyMutexSortedImpl
 
ADDRESS - Static variable in interface org.objectweb.dream.protocol.channel.TCPIPProtocol
Key name for value used by the Protocol.createExportIdentifier(java.util.Map, org.objectweb.dream.protocol.ExportIdentifier[]) method to specify the address of the export identifier to create.
ADDRESS - Static variable in interface org.objectweb.dream.protocol.messagePassing.UDPProtocol
Key name for value used by the Protocol.createExportIdentifier(java.util.Map, org.objectweb.dream.protocol.ExportIdentifier[]) method to specify the address of the export identifier to create.
addServerSocket(ServerSocket, IPExportIdentifier) - Method in interface org.objectweb.dream.protocol.channel.ConnectionFactory
Adds a new server socket.
addServerSocket(ServerSocket, IPExportIdentifier) - Method in class org.objectweb.dream.protocol.channel.ConnectionFactoryImpl
 
ALL_INTEGER_KEY - Static variable in class org.objectweb.dream.pushwithreturn.KeyGeneratorIntegerImpl
The "All" Integer key.
ALREADY_DELIVERED - Static variable in interface org.objectweb.dream.protocol.bus.logicalClock.LogicalClock
the value returned by LogicalClock.testRecvMessage(Message)if the message has already been delivered.
AtomicReactorImpl - Class in org.objectweb.dream.protocol.atomicity
Transient impelmentation of the Reactor component.
AtomicReactorImpl() - Constructor for class org.objectweb.dream.protocol.atomicity.AtomicReactorImpl
 
AtomicRouterImpl - Class in org.objectweb.dream.protocol.atomicity
A Router that choose a route depending on the pushing thread.
AtomicRouterImpl() - Constructor for class org.objectweb.dream.protocol.atomicity.AtomicRouterImpl
 
attempt(long) - Method in class org.objectweb.dream.synchro.AbstractSemaphoreQueuedImpl
 
attempt(long) - Method in interface org.objectweb.dream.synchro.Semaphore
Waits at most msecs millisconds for a permit.
attempt(long) - Method in class org.objectweb.dream.synchro.SemaphoreImpl
 
attemptRead(long) - Method in interface org.objectweb.dream.synchro.ReadWriteLock
Attempts to get the read lock.
attemptRead(long) - Method in class org.objectweb.dream.synchro.ReadWriteLockFIFOImpl
 
attemptWrite(long) - Method in interface org.objectweb.dream.synchro.ReadWriteLock
Attempts to get the write lock.
attemptWrite(long) - Method in class org.objectweb.dream.synchro.ReadWriteLockFIFOImpl
 
availableMessagesCount - Variable in class org.objectweb.dream.queue.AbstractBufferImpl
The count of available messages in the buffer.
availableMessagesCount - Variable in class org.objectweb.dream.queue.keyed.AbstractBufferKeyedAddKeyedRemoveImpl
The count of available messages in the buffer.
availableMessagesCount - Variable in class org.objectweb.dream.queue.keyed.AbstractBufferKeyedRemoveImpl
The count of available messages in the buffer.
availableSpace() - Method in class org.objectweb.dream.queue.AbstractBufferImpl
 
availableSpace(Object) - Method in class org.objectweb.dream.queue.keyed.AbstractBufferKeyedAddKeyedRemoveImpl
 
availableSpace() - Method in class org.objectweb.dream.queue.keyed.AbstractBufferKeyedRemoveImpl
 
availableSpace() - Method in class org.objectweb.dream.queue.keyed.BufferAscendingKeyKeyChunkAddDoubleKeyedRemoveImpl
 
await() - Method in interface org.objectweb.dream.synchro.Condition
Wait for notification.
await() - Method in class org.objectweb.dream.synchro.ConditionImpl
 
await() - Method in class org.objectweb.dream.synchro.ConditionReEntrantImpl
 

B

beforeFirstStart(Component) - Method in class org.objectweb.dream.protocol.channel.ConnectionFactoryImpl
 
beforeFirstStart(Component) - Method in class org.objectweb.dream.protocol.channel.TCPIPProtocolImpl
 
beforeFirstStart(Component) - Method in class org.objectweb.dream.protocol.messagePassing.UDPProtocolImpl
 
beforeFirstStart(Component) - Method in class org.objectweb.dream.pump.PumpPeriodicSynchronizedImpl
 
beforeFirstStart(Component) - Method in class org.objectweb.dream.pump.PumpSynchronizedImpl
 
bind(ExportIdentifier, IncomingPush, Map<String, Object>) - Method in interface org.objectweb.dream.protocol.bus.BusProtocol
Binds to a previously exported ChannelFactory interface designated by the given export identifier.
bind(ExportIdentifier, IncomingPush, Map<String, Object>) - Method in class org.objectweb.dream.protocol.bus.BusProtocolImpl
 
bind(ExportIdentifier, IncomingPush, Map<String, Object>) - Method in class org.objectweb.dream.protocol.bus.logicalClock.ProtocolImpl
 
bind(ExportIdentifier, IncomingPush, Map<String, Object>) - Method in interface org.objectweb.dream.protocol.channel.ChannelProtocol
Binds to a previously exported ChannelFactory interface designated by the given export identifier.
bind(ExportIdentifier, IncomingPush, Map<String, Object>) - Method in class org.objectweb.dream.protocol.channel.MultiplexBindProtocolImpl
 
bind(ExportIdentifier, IncomingPush, Map<String, Object>) - Method in class org.objectweb.dream.protocol.channel.MultiplexExportProtocolImpl
 
bind(String, int, IncomingPush) - Method in interface org.objectweb.dream.protocol.channel.TCPIPProtocol
Utility method.
bind(ExportIdentifier, IncomingPush, Map<String, Object>) - Method in class org.objectweb.dream.protocol.channel.TCPIPProtocolImpl
 
bind(String, int, IncomingPush) - Method in class org.objectweb.dream.protocol.channel.TCPIPProtocolImpl
 
bind(ExportIdentifier, Map<String, Object>) - Method in class org.objectweb.dream.protocol.rpc.ProtocolImpl
 
bind(ExportIdentifier, Map<String, Object>) - Method in interface org.objectweb.dream.protocol.rpc.RPCProtocol
Binds to a previously exported Skeleton interface designated by the given export identifier.
BIND_REPLY_CHUNK_NAME - Static variable in class org.objectweb.dream.protocol.channel.TCPIPProtocolImpl
 
BindChunk - Class in org.objectweb.dream.protocol.channel
Chunk used by multiplex protocol.
BindChunk() - Constructor for class org.objectweb.dream.protocol.channel.BindChunk
 
BindException - Exception in org.objectweb.dream.protocol
Exception thrown when the binding can't be established.
BindException() - Constructor for exception org.objectweb.dream.protocol.BindException
 
BindException(String) - Constructor for exception org.objectweb.dream.protocol.BindException
 
BindException(String, ExportIdentifier) - Constructor for exception org.objectweb.dream.protocol.BindException
 
BindException(String, ExportIdentifier, Throwable) - Constructor for exception org.objectweb.dream.protocol.BindException
Creates an exception caused by another exception.
bindFc(String, Object) - Method in class org.objectweb.dream.aggregator.PullPullAggregatorCollectionInputImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.aggregator.PullPullAggregatorFixedNumberImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.aggregator.PullPullAggregatorWhileNotNullImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.aggregator.PushPushDisaggregatorImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.cache.CacheImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.channel.AddIPExportIdChunkImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.channel.ChannelInOutImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.channel.ChannelOutImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.channel.DestinationResolverChunkBasedImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.exception.CatchPushExceptionImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.exception.RetryPushImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.protocol.atomicity.AtomicReactorImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.protocol.atomicity.AtomicRouterImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.protocol.bus.BusProtocolImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.protocol.bus.logicalClock.ProtocolImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.protocol.bus.TCPIPLocalAccessManagerImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.protocol.channel.ConnectionFactoryImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.protocol.channel.MultiplexBindProtocolImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.protocol.channel.MultiplexExportProtocolImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.protocol.channel.TCPIPProtocolImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.protocol.messagePassing.BufferedMessagePassingProtocolImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.protocol.messagePassing.FragmentationProtocolImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.protocol.messagePassing.MessagePassingOverChannelImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.protocol.messagePassing.ReliableMessagePassingProtocolImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.protocol.messagePassing.SerializatorMessagePassingProtocolImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.protocol.messagePassing.UDPProtocolImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.protocol.rpc.ProtocolImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.pump.AbstractPumpSynchronizedImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.pushwithreturn.HandleReturnMessageImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.pushwithreturn.KeyGeneratorIntegerImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.pushwithreturn.SynchronizerAsynchronousImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.pushwithreturn.SynchronizerSynchronousImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.queue.AbstractBufferImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.queue.BufferKeyMutexSortedImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.queue.BufferMatchingImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.queue.BufferSortingImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.queue.IncomingHandlerBlockingImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.queue.IncomingHandlerDroppingImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.queue.IncomingHandlerExceptionThrowingImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.queue.IncomingHandlerRemovingImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.queue.keyed.AbstractBufferKeyedAddKeyedRemoveImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.queue.keyed.AbstractBufferKeyedRemoveImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.queue.keyed.BufferAscendingKeyKeyChunkAddDoubleKeyedRemoveImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.queue.keyed.BufferAscendingSequenceNumberKeyedAddKeyedRemoveImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.queue.keyed.DoubleKeyedOutgoingHandlerBlockingImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.queue.keyed.DoubleKeyedOutgoingHandlerNonBlockingImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.queue.keyed.KeyedIncomingHandlerBlockingImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.queue.keyed.KeyedIncomingHandlerExceptionThrowingImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.queue.keyed.KeyedIncomingHandlerNonBlockingImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.queue.keyed.KeyedOutgoingHandlerBlockingImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.queue.keyed.KeyedOutgoingHandlerNonBlockingImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.queue.OutgoingHandlerAggregatingImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.queue.OutgoingHandlerBlockingImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.queue.OutgoingHandlerNonBlockingImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.queue.PushPushUnlockKeyImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.router.AbstractRouterImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.router.RouterChunkNameImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.serializator.DeSerializatorImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.serializator.PushPushDeSerializatorImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.serializator.PushPushSerializatorImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.serializator.SerializatorImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.synchro.ConditionImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.synchro.ConditionReEntrantImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.synchro.LockPullUnlockImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.synchro.LockPushUnlockImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.synchro.ReadWriteLockFIFOImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.trash.TrashImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.xml.SaxXercesParser
 
BLOCK_OVERFLOW_POLICY - Static variable in interface org.objectweb.dream.queue.PushQueueAttributeController
An overflow policy that block incoming messages until a message is delivered on the output.
BufferAdd - Interface in org.objectweb.dream.queue
This interface defines methods that must be implemented by a buffer to allow components to add messages into it.
bufferAdd - Variable in class org.objectweb.dream.queue.IncomingHandlerBlockingImpl
The buffer into which pushed messages are added.
bufferAdd - Variable in class org.objectweb.dream.queue.IncomingHandlerDroppingImpl
The buffer into which pushed messages are added.
bufferAdd - Variable in class org.objectweb.dream.queue.IncomingHandlerExceptionThrowingImpl
The buffer into which pushed messages are added.
bufferAdd - Variable in class org.objectweb.dream.queue.IncomingHandlerRemovingImpl
The buffer into which pushed messages are added.
BufferAscendingKeyKeyChunkAddDoubleKeyedRemoveImpl - Class in org.objectweb.dream.queue.keyed
This buffer stores every incoming message according to a key (keyChunk) that is contained in the message as a AbstractChunk which name can be specified as a Fractal component attribute using the BufferAttributeControllerKeyChunkAdd interface.
BufferAscendingKeyKeyChunkAddDoubleKeyedRemoveImpl() - Constructor for class org.objectweb.dream.queue.keyed.BufferAscendingKeyKeyChunkAddDoubleKeyedRemoveImpl
 
BufferAscendingSequenceNumberImpl - Class in org.objectweb.dream.queue
Implementation of the Buffer interface using a sorted list.
BufferAscendingSequenceNumberImpl() - Constructor for class org.objectweb.dream.queue.BufferAscendingSequenceNumberImpl
 
BufferAscendingSequenceNumberImpl.Element - Class in org.objectweb.dream.queue
This class represents elements of a linked list.
BufferAscendingSequenceNumberImpl.Element() - Constructor for class org.objectweb.dream.queue.BufferAscendingSequenceNumberImpl.Element
 
BufferAscendingSequenceNumberKeyedAddKeyedRemoveImpl - Class in org.objectweb.dream.queue.keyed
This buffer stores incoming messages according to a sequence number that is retrieved using a chunk that extends the SequenceNumberChunkclass.
BufferAscendingSequenceNumberKeyedAddKeyedRemoveImpl() - Constructor for class org.objectweb.dream.queue.keyed.BufferAscendingSequenceNumberKeyedAddKeyedRemoveImpl
 
BufferAttributeController - Interface in org.objectweb.dream.queue
Base attribute controller interface for buffer implementations.
BufferAttributeControllerAscendingKeyKeyChunkAdd - Interface in org.objectweb.dream.queue.keyed
Attribute controller interface used by queues that use both ordered keys and key chunks to sort messages.
BufferAttributeControllerAscendingSequenceNumber - Interface in org.objectweb.dream.queue
Attribute controller for buffers that sort messages using an ascending sequence number.
BufferAttributeControllerAscendingSequenceNumberKeyChunkAdd - Interface in org.objectweb.dream.queue.keyed
Attribute controller interface used by queues that use both key chunks and sequence numbers to sort messages.
BufferAttributeControllerAscendingSequenceNumberKeyedAdd - Interface in org.objectweb.dream.queue.keyed
Attribute controller for buffers that sort messages by keys according to an ascending sequence number.
BufferAttributeControllerKeyChunkAdd - Interface in org.objectweb.dream.queue.keyed
Attribute controller interface used by buffers that use a key (which is a chunk of the message) to sort messages.
BufferAttributeControllerKeyed - Interface in org.objectweb.dream.queue.keyed
Attribute controller interface for buffers that use keys to sort messages.
BufferAttributeControllerSorted - Interface in org.objectweb.dream.queue
Sorted queue attribute controller.
BufferedMessagePassingProtocolImpl - Class in org.objectweb.dream.protocol.messagePassing
Implementation of a decoupling bus protocol.
BufferedMessagePassingProtocolImpl() - Constructor for class org.objectweb.dream.protocol.messagePassing.BufferedMessagePassingProtocolImpl
 
BufferedMessagePassingProtocolImpl.Session - Class in org.objectweb.dream.protocol.messagePassing
 
BufferedMessagePassingProtocolImpl.Session(IncomingPush) - Constructor for class org.objectweb.dream.protocol.messagePassing.BufferedMessagePassingProtocolImpl.Session
 
BufferedMessagePassingProtocolImpl.Session.SendTask - Class in org.objectweb.dream.protocol.messagePassing
 
BufferedMessagePassingProtocolImpl.Session.SendTask() - Constructor for class org.objectweb.dream.protocol.messagePassing.BufferedMessagePassingProtocolImpl.Session.SendTask
 
BufferFIFOImpl - Class in org.objectweb.dream.queue
A buffer in which stored messages are available to get or remove in the same order as they are added (First In First Out).
BufferFIFOImpl() - Constructor for class org.objectweb.dream.queue.BufferFIFOImpl
 
BufferKeyChunkAddKeyedRemoveImpl - Class in org.objectweb.dream.queue.keyed
This buffer stores every incoming message according to a key that is contained in the message as a chunk which name can be specified as a Fractal component attribute using the interface of type BufferAttributeControllerKeyChunkAdd.
BufferKeyChunkAddKeyedRemoveImpl() - Constructor for class org.objectweb.dream.queue.keyed.BufferKeyChunkAddKeyedRemoveImpl
 
BufferKeyedAddKeyedRemoveImpl - Class in org.objectweb.dream.queue.keyed
Buffer that uses keys to sort messages.
BufferKeyedAddKeyedRemoveImpl() - Constructor for class org.objectweb.dream.queue.keyed.BufferKeyedAddKeyedRemoveImpl
 
BufferKeyMutexSortedImpl - Class in org.objectweb.dream.queue
This buffer sorts messages using a key provided by a MessageKeyManager.
BufferKeyMutexSortedImpl() - Constructor for class org.objectweb.dream.queue.BufferKeyMutexSortedImpl
 
BufferKeyMutexSortedImpl.ListElem - Class in org.objectweb.dream.queue
Object list elements.
BufferKeyMutexSortedImpl.ListElem() - Constructor for class org.objectweb.dream.queue.BufferKeyMutexSortedImpl.ListElem
 
BufferKeyMutexSortedImpl.MessageList - Class in org.objectweb.dream.queue
Object list
BufferKeyMutexSortedImpl.MessageList() - Constructor for class org.objectweb.dream.queue.BufferKeyMutexSortedImpl.MessageList
 
BufferLIFOImpl - Class in org.objectweb.dream.queue
A buffer in which stored messages are available to get or remove in the reverse order as they are added (Last In First Out).
BufferLIFOImpl() - Constructor for class org.objectweb.dream.queue.BufferLIFOImpl
 
BufferMatchingImpl - Class in org.objectweb.dream.queue
A buffer in which stored messages are available to get or remove only if they are accepted by the message matcher bound to this component.
BufferMatchingImpl() - Constructor for class org.objectweb.dream.queue.BufferMatchingImpl
 
BufferOverflowException - Exception in org.objectweb.dream.queue
Exception thrown by queues when the maximum capacity of the queue is raised and the policy is to throw an exception.
BufferOverflowException() - Constructor for exception org.objectweb.dream.queue.BufferOverflowException
 
BufferOverflowException(String) - Constructor for exception org.objectweb.dream.queue.BufferOverflowException
 
BufferOverflowException(String, Throwable) - Constructor for exception org.objectweb.dream.queue.BufferOverflowException
 
BufferOverflowException(Throwable) - Constructor for exception org.objectweb.dream.queue.BufferOverflowException
 
BufferRemove - Interface in org.objectweb.dream.queue
This interface defines methods that must be implemented by a buffer to allow components to get or delete messages from it.
bufferRemove - Variable in class org.objectweb.dream.queue.IncomingHandlerRemovingImpl
The buffer from which message may be removed.
bufferRemove - Variable in class org.objectweb.dream.queue.OutgoingHandlerAggregatingImpl
The buffer from which pulled messages are removed.
bufferRemove - Variable in class org.objectweb.dream.queue.OutgoingHandlerBlockingImpl
The buffer from which pulled messages are removed.
bufferRemove - Variable in class org.objectweb.dream.queue.OutgoingHandlerNonBlockingImpl
The buffer from which pulled messages are removed.
BufferSortingImpl - Class in org.objectweb.dream.queue
A buffer in which stored messages are available to get or remove in the order of the "key" that is calculated for each message by the MessageComparableKeyManager component bound to this component when adding each message.
BufferSortingImpl() - Constructor for class org.objectweb.dream.queue.BufferSortingImpl
 
BusExportIdentifier - Class in org.objectweb.dream.protocol.bus
Export identifier for bus protocol.
BusExportIdentifier(ExportIdentifier[]) - Constructor for class org.objectweb.dream.protocol.bus.BusExportIdentifier
Constructor
BusOutgoingPush - Interface in org.objectweb.dream.protocol.bus
Specialized OutgoingPush interface for bus protocol.
BusProtocol - Interface in org.objectweb.dream.protocol.bus
Specialized Protocol interface for protocol components providing BusOutgoingPush interface as result of a binding.
BusProtocolImpl - Class in org.objectweb.dream.protocol.bus
Implementation of the Bus protocol.
BusProtocolImpl() - Constructor for class org.objectweb.dream.protocol.bus.BusProtocolImpl
 
BusProtocolImpl.Session - Class in org.objectweb.dream.protocol.bus
 
BusProtocolImpl.Session(BusExportIdentifier, int, IncomingPush) - Constructor for class org.objectweb.dream.protocol.bus.BusProtocolImpl.Session
 
byteArray - Variable in class org.objectweb.dream.serializator.ByteArrayChunk
The byte array.
ByteArrayChunk - Class in org.objectweb.dream.serializator
Chunk containing a byte array.
ByteArrayChunk() - Constructor for class org.objectweb.dream.serializator.ByteArrayChunk
 
byteArrayOutputStream - Variable in class org.objectweb.dream.serializator.CodecInputOutputByteArray
 

C

CacheAttributeController - Interface in org.objectweb.dream.cache
This class defines a controller for managing the cache attributes.
cachedMessage - Variable in class org.objectweb.dream.cache.CacheImpl
The last cached message.
CacheImpl - Class in org.objectweb.dream.cache
This class defines a basic cache.
CacheImpl() - Constructor for class org.objectweb.dream.cache.CacheImpl
 
canAdd(Message) - Method in class org.objectweb.dream.queue.AbstractBufferImpl
Checks whether the given message can be added into the buffer.
canAdd(Message, Object) - Method in class org.objectweb.dream.queue.keyed.AbstractBufferKeyedAddKeyedRemoveImpl
Checks whether the given message can be added into the buffer.
canAdd(Message) - Method in class org.objectweb.dream.queue.keyed.AbstractBufferKeyedRemoveImpl
Checks whether the given message can be added into the buffer.
canAdd(Message) - Method in class org.objectweb.dream.queue.keyed.BufferAscendingKeyKeyChunkAddDoubleKeyedRemoveImpl
Checks whether the given message can be added into the buffer.
canAdd(Message) - Method in class org.objectweb.dream.queue.keyed.BufferKeyChunkAddKeyedRemoveImpl
 
CatchPushExceptionImpl - Class in org.objectweb.dream.exception
Try to push incoming messages on the output ("out-push" client interface).
CatchPushExceptionImpl() - Constructor for class org.objectweb.dream.exception.CatchPushExceptionImpl
 
CHANEL_ITF_NAME - Static variable in interface org.objectweb.dream.protocol.channel.ChannelFactory
The commonly used name of this interface.
ChannelFactory - Interface in org.objectweb.dream.protocol.channel
A communication channel factory interface, that a ChannelProtocol can export.
ChannelInAttributeController - Interface in org.objectweb.dream.channel
Attribute controller interface for channel in.
ChannelInExportId - Interface in org.objectweb.dream.channel
This interface, provided by ChanelIn, can be used to retrieve the ExportIdentifier that identify the ChannelIn.
ChannelInOutImpl - Class in org.objectweb.dream.channel
ChannelIn implementation.
ChannelInOutImpl() - Constructor for class org.objectweb.dream.channel.ChannelInOutImpl
Default constructor.
ChannelOutImpl - Class in org.objectweb.dream.channel
ChannelIn implementation.
ChannelOutImpl() - Constructor for class org.objectweb.dream.channel.ChannelOutImpl
Default constructor.
ChannelProtocol - Interface in org.objectweb.dream.protocol.channel
A protocol is a naming context which can export ChannelFactory interfaces.
chunkName - Variable in class org.objectweb.dream.channel.AddIPExportIdChunkImpl
 
chunkName - Variable in class org.objectweb.dream.router.RouterChunkNameImpl
the chunk name to test
CLIENT_INTERFACE_NAMES - Static variable in class org.objectweb.dream.queue.AbstractBufferImpl
The names of client interfaces.
CLIENT_INTERFACE_NAMES - Static variable in class org.objectweb.dream.queue.BufferMatchingImpl
The names of client interfaces.
CLIENT_INTERFACE_NAMES - Static variable in class org.objectweb.dream.queue.BufferSortingImpl
The names of client interfaces.
CLIENT_INTERFACE_NAMES - Static variable in class org.objectweb.dream.queue.IncomingHandlerBlockingImpl
The names of client interfaces.
CLIENT_INTERFACE_NAMES - Static variable in class org.objectweb.dream.queue.IncomingHandlerDroppingImpl
The names of client interfaces.
CLIENT_INTERFACE_NAMES - Static variable in class org.objectweb.dream.queue.IncomingHandlerExceptionThrowingImpl
The names of client interfaces.
CLIENT_INTERFACE_NAMES - Static variable in class org.objectweb.dream.queue.IncomingHandlerRemovingImpl
The names of client interfaces.
CLIENT_INTERFACE_NAMES - Static variable in class org.objectweb.dream.queue.keyed.AbstractBufferKeyedAddKeyedRemoveImpl
The names of client interfaces.
CLIENT_INTERFACE_NAMES - Static variable in class org.objectweb.dream.queue.keyed.AbstractBufferKeyedRemoveImpl
The names of client interfaces.
CLIENT_INTERFACE_NAMES - Static variable in class org.objectweb.dream.queue.keyed.BufferAscendingKeyKeyChunkAddDoubleKeyedRemoveImpl
The names of client interfaces.
CLIENT_INTERFACE_NAMES - Static variable in class org.objectweb.dream.queue.keyed.DoubleKeyedOutgoingHandlerBlockingImpl
The names of client interfaces.
CLIENT_INTERFACE_NAMES - Static variable in class org.objectweb.dream.queue.keyed.DoubleKeyedOutgoingHandlerNonBlockingImpl
The names of client interfaces.
CLIENT_INTERFACE_NAMES - Static variable in class org.objectweb.dream.queue.keyed.KeyedIncomingHandlerBlockingImpl
The names of client interfaces.
CLIENT_INTERFACE_NAMES - Static variable in class org.objectweb.dream.queue.keyed.KeyedIncomingHandlerExceptionThrowingImpl
The names of client interfaces.
CLIENT_INTERFACE_NAMES - Static variable in class org.objectweb.dream.queue.keyed.KeyedIncomingHandlerNonBlockingImpl
The names of client interfaces.
CLIENT_INTERFACE_NAMES - Static variable in class org.objectweb.dream.queue.keyed.KeyedOutgoingHandlerBlockingImpl
The names of client interfaces.
CLIENT_INTERFACE_NAMES - Static variable in class org.objectweb.dream.queue.keyed.KeyedOutgoingHandlerNonBlockingImpl
The names of client interfaces.
CLIENT_INTERFACE_NAMES - Static variable in class org.objectweb.dream.queue.OutgoingHandlerAggregatingImpl
The names of client interfaces.
CLIENT_INTERFACE_NAMES - Static variable in class org.objectweb.dream.queue.OutgoingHandlerBlockingImpl
The names of client interfaces.
CLIENT_INTERFACE_NAMES - Static variable in class org.objectweb.dream.queue.OutgoingHandlerNonBlockingImpl
The names of client interfaces.
CLOCK_TYPE_HINT_KEY - Static variable in interface org.objectweb.dream.protocol.bus.logicalClock.LogicalClockBusProtocol
The hint value used by Protocol.createExportIdentifier(java.util.Map, ExportIdentifier[]) to specify the clock type.
CloseChunk - Class in org.objectweb.dream.protocol.channel
Chunk used by multiplex protocol.
CloseChunk() - Constructor for class org.objectweb.dream.protocol.channel.CloseChunk
 
closed - Variable in class org.objectweb.dream.protocol.bus.BusProtocolImpl.Session
 
closed - Variable in class org.objectweb.dream.protocol.messagePassing.BufferedMessagePassingProtocolImpl.Session
 
CodecInputOutputByteArray - Class in org.objectweb.dream.serializator
An CodecInputOutput that contains a ByteArrayOutputStream.
CodecInputOutputByteArray() - Constructor for class org.objectweb.dream.serializator.CodecInputOutputByteArray
 
Condition - Interface in org.objectweb.dream.synchro
A condition component aima at synchronizing the execution of several components.
ConditionImpl - Class in org.objectweb.dream.synchro
Basic implementation of the Conditioninterface.
ConditionImpl() - Constructor for class org.objectweb.dream.synchro.ConditionImpl
 
ConditionReEntrantImpl - Class in org.objectweb.dream.synchro
ReEntrant implementation of the Conditioninterface.
ConditionReEntrantImpl() - Constructor for class org.objectweb.dream.synchro.ConditionReEntrantImpl
 
CONNECTION_RETRY - Static variable in interface org.objectweb.dream.protocol.channel.TCPIPProtocol
This integer hint, used at bind time, can specify the number of connection retries before aborting.
CONNECTION_RETRY_DEFAULT - Static variable in interface org.objectweb.dream.protocol.channel.TCPIPProtocolAttributeController
Default value of connectionRetry attribute.
ConnectionFactory - Interface in org.objectweb.dream.protocol.channel
Interface provided by server session factory.
ConnectionFactoryImpl - Class in org.objectweb.dream.protocol.channel
Implementation of ConnectionFactory.
ConnectionFactoryImpl() - Constructor for class org.objectweb.dream.protocol.channel.ConnectionFactoryImpl
 
ConnectionFactoryImpl.ListenTask - Class in org.objectweb.dream.protocol.channel
 
ConnectionFactoryImpl.ListenTask() - Constructor for class org.objectweb.dream.protocol.channel.ConnectionFactoryImpl.ListenTask
 
ConnectionFactoryImpl.SessionFactory - Class in org.objectweb.dream.protocol.channel
 
ConnectionFactoryImpl.SessionFactory(ServerSocket, IPExportIdentifier) - Constructor for class org.objectweb.dream.protocol.channel.ConnectionFactoryImpl.SessionFactory
 
connectionFactoryItf - Variable in class org.objectweb.dream.protocol.channel.TCPIPProtocolImpl
 
ConnectionManager - Interface in org.objectweb.dream.protocol.channel
Interface provided by the protocol component to manage opened connections and sessions.
connectionManagerItf - Variable in class org.objectweb.dream.protocol.channel.ConnectionFactoryImpl
 
connectionRetry - Variable in class org.objectweb.dream.protocol.channel.TCPIPProtocolImpl
 
CONTENT_HANDLER_ITF_NAME - Static variable in class org.objectweb.dream.xml.SaxXercesParser
The name of the ContentHandler client interface.
createComparableKey() - Method in interface org.objectweb.dream.queue.MessageComparableKeyManager
Returns a new empty comparable key object.
createConnection(IPExportIdentifier) - Method in class org.objectweb.dream.protocol.channel.TCPIPProtocolImpl
 
createExportIdentifier(Map, ExportIdentifier[]) - Method in class org.objectweb.dream.protocol.bus.BusProtocolImpl
 
createExportIdentifier(int, String, ExportIdentifier) - Method in interface org.objectweb.dream.protocol.bus.logicalClock.LogicalClockBusProtocol
Utility method
createExportIdentifier(Map<String, Object>, ExportIdentifier[]) - Method in class org.objectweb.dream.protocol.bus.logicalClock.ProtocolImpl
 
createExportIdentifier(int, String, ExportIdentifier) - Method in class org.objectweb.dream.protocol.bus.logicalClock.ProtocolImpl
 
createExportIdentifier(Map<String, Object>, ExportIdentifier[]) - Method in class org.objectweb.dream.protocol.channel.MultiplexBindProtocolImpl
 
createExportIdentifier(Map<String, Object>, ExportIdentifier[]) - Method in class org.objectweb.dream.protocol.channel.MultiplexExportProtocolImpl
 
createExportIdentifier(String, int) - Method in interface org.objectweb.dream.protocol.channel.TCPIPProtocol
Utility method.
createExportIdentifier(Map<String, Object>, ExportIdentifier[]) - Method in class org.objectweb.dream.protocol.channel.TCPIPProtocolImpl
 
createExportIdentifier(String, int) - Method in class org.objectweb.dream.protocol.channel.TCPIPProtocolImpl
 
createExportIdentifier(Map<String, Object>, ExportIdentifier[]) - Method in class org.objectweb.dream.protocol.messagePassing.BufferedMessagePassingProtocolImpl
 
createExportIdentifier(Map<String, Object>, ExportIdentifier[]) - Method in class org.objectweb.dream.protocol.messagePassing.FragmentationProtocolImpl
 
createExportIdentifier(Map<String, Object>, ExportIdentifier[]) - Method in class org.objectweb.dream.protocol.messagePassing.MessagePassingOverChannelImpl
 
createExportIdentifier(Map<String, Object>, ExportIdentifier[]) - Method in class org.objectweb.dream.protocol.messagePassing.ReliableMessagePassingProtocolImpl
 
createExportIdentifier(Map<String, Object>, ExportIdentifier[]) - Method in class org.objectweb.dream.protocol.messagePassing.SerializatorMessagePassingProtocolImpl
 
createExportIdentifier(String, int) - Method in interface org.objectweb.dream.protocol.messagePassing.UDPProtocol
Utility method.
createExportIdentifier(Map, ExportIdentifier[]) - Method in class org.objectweb.dream.protocol.messagePassing.UDPProtocolImpl
 
createExportIdentifier(String, int) - Method in class org.objectweb.dream.protocol.messagePassing.UDPProtocolImpl
 
createExportIdentifier(Map<String, Object>, ExportIdentifier[]) - Method in interface org.objectweb.dream.protocol.Protocol
Creates a new export identifier with the provided info
createExportIdentifier(Map<String, Object>, ExportIdentifier[]) - Method in class org.objectweb.dream.protocol.rpc.ProtocolImpl
 
createKey() - Method in interface org.objectweb.dream.queue.MessageKeyManager
Returns a new empty key object.
createWaitingKey(Key) - Method in interface org.objectweb.dream.pushwithreturn.WaitingKeys
Creates a WaitingKeyobject for the given key.
createWaitingKey(Key) - Method in class org.objectweb.dream.pushwithreturn.WaitingKeysImpl
 

D

DEFAULT_NAME - Static variable in class org.objectweb.dream.protocol.bus.logicalClock.LogicalClockChunk
The default name for chunks of this type
DEFAULT_NAME - Static variable in class org.objectweb.dream.protocol.channel.BindChunk
Default name for chunks of this type.
DEFAULT_NAME - Static variable in class org.objectweb.dream.protocol.channel.CloseChunk
Default name for chunks of this type.
DEFAULT_NAME - Static variable in class org.objectweb.dream.protocol.ExceptionChunk
default name of chunk of this type.
DEFAULT_NAME - Static variable in class org.objectweb.dream.protocol.ExportIdentifierChunk
The default name of chunk of this type.
DEFAULT_NAME - Static variable in class org.objectweb.dream.protocol.messagePassing.FragmentationChunk
The default name for chunks of this type
DEFAULT_NAME - Static variable in class org.objectweb.dream.protocol.rpc.InvocationChunk
The default name of chunks of this type.
DEFAULT_NAME - Static variable in class org.objectweb.dream.protocol.rpc.ReplyChunk
The default name of chunks of this type.
DEFAULT_NAME - Static variable in class org.objectweb.dream.protocol.rpc.StubClassChunk
The default name of chunks of this type.
DEFAULT_NAME - Static variable in class org.objectweb.dream.pushwithreturn.KeyChunk
The default name for chunks of this type
DEFAULT_NAME - Static variable in class org.objectweb.dream.queue.SequenceNumberChunk
The default name for chunks of this type.
DEFAULT_NAME - Static variable in class org.objectweb.dream.serializator.ByteArrayChunk
The default name for chunks of this type.
DEFAULT_OUT_PUSH_ITF_NAME - Static variable in class org.objectweb.dream.router.AbstractRouterImpl
The name of the default Pushclient interface.
DEFAULT_RETRANSMIT_PERIOD - Static variable in interface org.objectweb.dream.protocol.messagePassing.ReliableMessagePassingProtocol
The default retransmission period (in ms).
defaultOutPushItf - Variable in class org.objectweb.dream.router.AbstractRouterImpl
Default Push interface to be used if no Push interface can be found in outPushTable.
deleteChunk - Variable in class org.objectweb.dream.channel.DestinationResolverChunkBasedImpl
 
deleteComparableKey(Comparable) - Method in interface org.objectweb.dream.queue.MessageComparableKeyManager
Delete the given comparable key instance.
deleteKey(Object) - Method in interface org.objectweb.dream.queue.MessageKeyManager
Delete the given key instance.
DELIVER - Static variable in interface org.objectweb.dream.protocol.bus.logicalClock.LogicalClock
the value returned by LogicalClock.testRecvMessage(Message) if the message can be delivered
DeSerializator - Interface in org.objectweb.dream.serializator
A deserializator defines a method deserialize that takes a byte array as parameter and returns the corresponding message.
DeSerializatorImpl - Class in org.objectweb.dream.serializator
Basic implementation of the DeSerializatorinterface.
DeSerializatorImpl() - Constructor for class org.objectweb.dream.serializator.DeSerializatorImpl
 
deSerializatorItf - Variable in class org.objectweb.dream.protocol.messagePassing.SerializatorMessagePassingProtocolImpl
 
deserializatorItf - Variable in class org.objectweb.dream.serializator.PushPushDeSerializatorImpl
 
deserialize(byte[]) - Method in interface org.objectweb.dream.serializator.DeSerializator
Deserializes the given byte array and returns a message.
deserialize(byte[]) - Method in class org.objectweb.dream.serializator.DeSerializatorImpl
 
destinationChunkName - Variable in class org.objectweb.dream.channel.DestinationResolverChunkBasedImpl
 
DestinationResolver - Interface in org.objectweb.dream.channel
Interface used by ChannelOut to resolve the destination of messages.
DestinationResolverChunkBasedAttributeController - Interface in org.objectweb.dream.channel
Attribute controller for DestinationResolver implementation that use a ExportIdentifierChunk to retrieve destination of messages.
DestinationResolverChunkBasedImpl - Class in org.objectweb.dream.channel
Destination resolver that retrieves ExportIdentifier if a ExportIdentifierChunk contained in the message.
DestinationResolverChunkBasedImpl() - Constructor for class org.objectweb.dream.channel.DestinationResolverChunkBasedImpl
 
doAdd(Message) - Method in class org.objectweb.dream.queue.AbstractBufferImpl
Adds a message to the buffer.
doAdd(Message) - Method in class org.objectweb.dream.queue.BufferAscendingSequenceNumberImpl
 
doAdd(Message) - Method in class org.objectweb.dream.queue.BufferFIFOImpl
 
doAdd(Message) - Method in class org.objectweb.dream.queue.BufferKeyMutexSortedImpl
 
doAdd(Message) - Method in class org.objectweb.dream.queue.BufferLIFOImpl
 
doAdd(Message) - Method in class org.objectweb.dream.queue.BufferMatchingImpl
 
doAdd(Message) - Method in class org.objectweb.dream.queue.BufferSortingImpl
 
doAdd(Message, Object) - Method in class org.objectweb.dream.queue.keyed.AbstractBufferKeyedAddKeyedRemoveImpl
Adds a message to the buffer.
doAdd(Message) - Method in class org.objectweb.dream.queue.keyed.AbstractBufferKeyedRemoveImpl
Adds a message to the buffer.
doAdd(Message, Object) - Method in class org.objectweb.dream.queue.keyed.BufferAscendingKeyKeyChunkAddDoubleKeyedRemoveImpl
 
doAdd(Message, Object) - Method in class org.objectweb.dream.queue.keyed.BufferAscendingSequenceNumberKeyedAddKeyedRemoveImpl
 
doAdd(Message) - Method in class org.objectweb.dream.queue.keyed.BufferKeyChunkAddKeyedRemoveImpl
 
doAdd(Message, Object) - Method in class org.objectweb.dream.queue.keyed.BufferKeyedAddKeyedRemoveImpl
 
doGet() - Method in class org.objectweb.dream.queue.AbstractBufferImpl
Gets a message from the buffer.
doGet() - Method in class org.objectweb.dream.queue.BufferAscendingSequenceNumberImpl
 
doGet() - Method in class org.objectweb.dream.queue.BufferFIFOImpl
 
doGet() - Method in class org.objectweb.dream.queue.BufferKeyMutexSortedImpl
 
doGet() - Method in class org.objectweb.dream.queue.BufferLIFOImpl
 
doGet() - Method in class org.objectweb.dream.queue.BufferMatchingImpl
 
doGet() - Method in class org.objectweb.dream.queue.BufferSortingImpl
 
doGet(Object) - Method in class org.objectweb.dream.queue.keyed.AbstractBufferKeyedAddKeyedRemoveImpl
Gets a message from the buffer.
doGet(Object) - Method in class org.objectweb.dream.queue.keyed.AbstractBufferKeyedRemoveImpl
Gets a message from the buffer.
doGet(Object) - Method in class org.objectweb.dream.queue.keyed.BufferAscendingSequenceNumberKeyedAddKeyedRemoveImpl
 
doGet(Object) - Method in class org.objectweb.dream.queue.keyed.BufferKeyChunkAddKeyedRemoveImpl
 
doGet(Object) - Method in class org.objectweb.dream.queue.keyed.BufferKeyedAddKeyedRemoveImpl
 
doRemove() - Method in class org.objectweb.dream.queue.AbstractBufferImpl
Removes a message from the buffer.
doRemove() - Method in class org.objectweb.dream.queue.BufferAscendingSequenceNumberImpl
 
doRemove() - Method in class org.objectweb.dream.queue.BufferFIFOImpl
 
doRemove() - Method in class org.objectweb.dream.queue.BufferKeyMutexSortedImpl
 
doRemove() - Method in class org.objectweb.dream.queue.BufferLIFOImpl
 
doRemove() - Method in class org.objectweb.dream.queue.BufferMatchingImpl
 
doRemove() - Method in class org.objectweb.dream.queue.BufferSortingImpl
 
doRemove(Object) - Method in class org.objectweb.dream.queue.keyed.AbstractBufferKeyedAddKeyedRemoveImpl
Removes a message from the buffer.
doRemove(Object) - Method in class org.objectweb.dream.queue.keyed.AbstractBufferKeyedRemoveImpl
Removes a message from the buffer.
doRemove(Object) - Method in class org.objectweb.dream.queue.keyed.BufferAscendingSequenceNumberKeyedAddKeyedRemoveImpl
 
doRemove(Object) - Method in class org.objectweb.dream.queue.keyed.BufferKeyChunkAddKeyedRemoveImpl
 
doRemove(Object) - Method in class org.objectweb.dream.queue.keyed.BufferKeyedAddKeyedRemoveImpl
 
doRemoveAll() - Method in class org.objectweb.dream.queue.AbstractBufferImpl
Removes all the messages stored into the buffer.
doRemoveAll() - Method in class org.objectweb.dream.queue.BufferAscendingSequenceNumberImpl
 
doRemoveAll() - Method in class org.objectweb.dream.queue.BufferFIFOImpl
 
doRemoveAll() - Method in class org.objectweb.dream.queue.BufferKeyMutexSortedImpl
 
doRemoveAll() - Method in class org.objectweb.dream.queue.BufferLIFOImpl
 
doRemoveAll() - Method in class org.objectweb.dream.queue.BufferMatchingImpl
 
doRemoveAll() - Method in class org.objectweb.dream.queue.BufferSortingImpl
 
doRemoveAll() - Method in class org.objectweb.dream.queue.keyed.AbstractBufferKeyedAddKeyedRemoveImpl
Removes all the messages stored into the buffer.
doRemoveAll() - Method in class org.objectweb.dream.queue.keyed.AbstractBufferKeyedRemoveImpl
Removes all the messages stored into the buffer.
doRemoveAll() - Method in class org.objectweb.dream.queue.keyed.BufferAscendingSequenceNumberKeyedAddKeyedRemoveImpl
 
doRemoveAll() - Method in class org.objectweb.dream.queue.keyed.BufferKeyChunkAddKeyedRemoveImpl
 
doRemoveAll() - Method in class org.objectweb.dream.queue.keyed.BufferKeyedAddKeyedRemoveImpl
 
doTimedWait(AbstractSemaphoreQueuedImpl, long) - Method in class org.objectweb.dream.synchro.AbstractSemaphoreQueuedImpl.WaitQueue.WaitNode
 
DoubleKeyedBufferRemove - Interface in org.objectweb.dream.queue.keyed
This interface defines methods that must be implemented by a buffer to allow components to get or delete messages from it, according to two keys associated with each message.
doubleKeyedBufferRemoveItf - Variable in class org.objectweb.dream.queue.keyed.DoubleKeyedOutgoingHandlerBlockingImpl
The buffer from which pulled messages are removed.
doubleKeyedBufferRemoveItf - Variable in class org.objectweb.dream.queue.keyed.DoubleKeyedOutgoingHandlerNonBlockingImpl
The buffer from which pulled messages are removed.
DoubleKeyedOutgoingHandlerBlockingImpl - Class in org.objectweb.dream.queue.keyed
An outgoing handler that implements the DoubleKeyedPullinterface.
DoubleKeyedOutgoingHandlerBlockingImpl() - Constructor for class org.objectweb.dream.queue.keyed.DoubleKeyedOutgoingHandlerBlockingImpl
 
DoubleKeyedOutgoingHandlerNonBlockingImpl - Class in org.objectweb.dream.queue.keyed
An outgoing handler that implements the DoubleKeyedPullinterface.
DoubleKeyedOutgoingHandlerNonBlockingImpl() - Constructor for class org.objectweb.dream.queue.keyed.DoubleKeyedOutgoingHandlerNonBlockingImpl
 
DoubleKeyedPull - Interface in org.objectweb.dream.queue.keyed
Interface that allows pulling messages mapping two specified keys.
doWait(AbstractSemaphoreQueuedImpl) - Method in class org.objectweb.dream.synchro.AbstractSemaphoreQueuedImpl.WaitQueue.WaitNode
 
DROP_FIRST_OVERFLOW_POLICY - Static variable in interface org.objectweb.dream.queue.PushQueueAttributeController
An overflow policy that drops the first message of the queue when it is full.
DROP_LAST_OVERFLOW_POLICY - Static variable in interface org.objectweb.dream.queue.PushQueueAttributeController
An overflow policy that drops the last message of the queue when it is full.
DROP_PROCESSED_MESSAGE_OVERFLOW_POLICY - Static variable in interface org.objectweb.dream.queue.PushQueueAttributeController
An overflow policy that drops the current message when the queue is full: this means that the message will not be inserted into the queue.
DROP_QUEUE_MESSAGE_OVERFLOW_POLICY - Static variable in interface org.objectweb.dream.queue.PushQueueAttributeController
An overflow policy that drops a message message from the queue when it is full.
duplicateComparableKey(Comparable) - Method in interface org.objectweb.dream.queue.MessageComparableKeyManager
Clones the given comparable key.
duplicateKey(Object) - Method in interface org.objectweb.dream.queue.MessageKeyManager
Clones the given key.

E

EMPTY_EXPORT_IDENTIFIER_ARRAY - Static variable in interface org.objectweb.dream.protocol.ExportIdentifier
An empty export identifier array.
EMPTY_OBJECT_ARRAY - Static variable in class org.objectweb.dream.protocol.rpc.InvocationChunk
A constant empty object array.
entryLock - Variable in class org.objectweb.dream.synchro.ReadWriteLockFIFOImpl
Fair Semaphore serving as a kind of mutual exclusion lock.
equals(Object) - Method in class org.objectweb.dream.protocol.channel.MultiplexExportIdentifier
 
equals(Object) - Method in class org.objectweb.dream.protocol.IPExportIdentifier
 
equals(Object) - Method in class org.objectweb.dream.pushwithreturn.KeyInteger
 
EXCEPTION_OVERFLOW_POLICY - Static variable in interface org.objectweb.dream.queue.PushQueueAttributeController
An overflow policy that causes the Push server interface to throw a BufferOverflowException
EXCEPTION_PUSH_ITF_NAME - Static variable in class org.objectweb.dream.exception.CatchPushExceptionImpl
The default name of the out push interface used if a PushException has been catched while a message was pushed on the normal out push.
ExceptionChunk - Class in org.objectweb.dream.protocol
General purpose chunk containing an exception.
ExceptionChunk() - Constructor for class org.objectweb.dream.protocol.ExceptionChunk
 
exceptionChunkFactory - Variable in class org.objectweb.dream.protocol.channel.TCPIPProtocolImpl
 
exceptionPushItf - Variable in class org.objectweb.dream.exception.CatchPushExceptionImpl
 
execute(Object) - Method in class org.objectweb.dream.protocol.channel.ConnectionFactoryImpl.ListenTask
 
execute(Object) - Method in class org.objectweb.dream.protocol.channel.TCPIPProtocolImpl.ReaderTask
 
execute(Object) - Method in class org.objectweb.dream.protocol.messagePassing.BufferedMessagePassingProtocolImpl.Session.SendTask
 
execute(Object) - Method in class org.objectweb.dream.protocol.messagePassing.UDPProtocolImpl.ReaderTask
 
export(ChannelFactory, Map<String, Object>) - Method in interface org.objectweb.dream.protocol.channel.ChannelProtocol
Exports a ChannelFactory interface using this protocol.
export(ChannelFactory, Map<String, Object>) - Method in class org.objectweb.dream.protocol.channel.MultiplexBindProtocolImpl
 
export(ChannelFactory, Map<String, Object>) - Method in class org.objectweb.dream.protocol.channel.MultiplexExportProtocolImpl
 
export(ChannelFactory, int, int) - Method in interface org.objectweb.dream.protocol.channel.TCPIPProtocol
Utility method.
export(ChannelFactory, Map<String, Object>) - Method in class org.objectweb.dream.protocol.channel.TCPIPProtocolImpl
 
export(ChannelFactory, int, int) - Method in class org.objectweb.dream.protocol.channel.TCPIPProtocolImpl
 
export(IncomingPush, Map<String, Object>) - Method in class org.objectweb.dream.protocol.messagePassing.BufferedMessagePassingProtocolImpl
 
export(IncomingPush, Map<String, Object>) - Method in class org.objectweb.dream.protocol.messagePassing.FragmentationProtocolImpl
 
export(IncomingPush, Map<String, Object>) - Method in class org.objectweb.dream.protocol.messagePassing.MessagePassingOverChannelImpl
 
export(IncomingPush, Map<String, Object>) - Method in interface org.objectweb.dream.protocol.messagePassing.MessagePassingProtocol
Creates an access point and returns an interface that can be used to send messages through it.
export(IncomingPush, Map<String, Object>) - Method in class org.objectweb.dream.protocol.messagePassing.ReliableMessagePassingProtocolImpl
 
export(IncomingPush, Map<String, Object>) - Method in class org.objectweb.dream.protocol.messagePassing.SerializatorMessagePassingProtocolImpl
 
export(IncomingPush, int, int, String) - Method in interface org.objectweb.dream.protocol.messagePassing.UDPProtocol
Utility method.
export(IncomingPush, Map) - Method in class org.objectweb.dream.protocol.messagePassing.UDPProtocolImpl
 
export(IncomingPush, int, int, String) - Method in class org.objectweb.dream.protocol.messagePassing.UDPProtocolImpl
 
export(Skeleton, Map<String, Object>) - Method in class org.objectweb.dream.protocol.rpc.ProtocolImpl
 
export(Skeleton, Map<String, Object>) - Method in interface org.objectweb.dream.protocol.rpc.RPCProtocol
Exports a Skeleton interface using this protocol graph.
exportBus(ExportIdentifier, IncomingPush) - Method in interface org.objectweb.dream.protocol.bus.LocalAccessManager
Export to the lower level protocol in order to create the access point of the local bus session.
exportBus(ExportIdentifier, IncomingPush) - Method in class org.objectweb.dream.protocol.bus.TCPIPLocalAccessManagerImpl
 
EXPORTED_CHANNEL_ITF_NAME - Static variable in interface org.objectweb.dream.protocol.channel.ChannelFactory
The commonly used name of this interface when it is used as a client collection interface of a protocol bound to the exported channel.
exportedChanels - Variable in class org.objectweb.dream.protocol.channel.TCPIPProtocolImpl
 
ExportException - Exception in org.objectweb.dream.protocol
Exception thrown when an export can't be done.
ExportException() - Constructor for exception org.objectweb.dream.protocol.ExportException
 
ExportException(String) - Constructor for exception org.objectweb.dream.protocol.ExportException
 
ExportException(String, Throwable) - Constructor for exception org.objectweb.dream.protocol.ExportException
Creates an exception caused by another exception.
exportIdChunkFactory - Variable in class org.objectweb.dream.channel.AddIPExportIdChunkImpl
 
exportIdentifier - Variable in class org.objectweb.dream.channel.AddIPExportIdChunkImpl
 
ExportIdentifier - Interface in org.objectweb.dream.protocol
A name which identifies an exported interface.
ExportIdentifierChunk - Class in org.objectweb.dream.protocol
A chunk containing an export identifier.
ExportIdentifierChunk() - Constructor for class org.objectweb.dream.protocol.ExportIdentifierChunk
 
exreaders - Variable in class org.objectweb.dream.synchro.ReadWriteLockFIFOImpl
Number of threads that have exited read lock.
extract() - Method in class org.objectweb.dream.synchro.AbstractSemaphoreQueuedImpl.WaitQueue
 
extract() - Method in class org.objectweb.dream.synchro.SemaphoreFIFOImpl.FIFOWaitQueue
 

F

FIFO_CLOCK_TYPE - Static variable in class org.objectweb.dream.protocol.bus.logicalClock.LogicalClockExportIdentifier
The type value corresponding to a FIFO clock.
FIFO_CLOCK_TYPE_NAME - Static variable in class org.objectweb.dream.protocol.bus.logicalClock.LogicalClockExportIdentifier
The name of the type corresponding to a FIFO clock.
FIFOClock - Class in org.objectweb.dream.protocol.bus.logicalClock
TODO Add class comment
FIFOClock(int, int, String, MessageManager) - Constructor for class org.objectweb.dream.protocol.bus.logicalClock.FIFOClock
 
fillComparableKey(Comparable, Message) - Method in interface org.objectweb.dream.queue.MessageComparableKeyManager
Fills the given comparable key to match the given message.
fillKey(Object, Message) - Method in interface org.objectweb.dream.queue.MessageKeyManager
Fills the given key to match the given message.
filterChunkName(String) - Static method in class org.objectweb.dream.protocol.bus.logicalClock.LogicalClockChunk
If the given chunkName is equals to the default name returns LogicalClockChunk.DEFAULT_NAME, returns the given string otherwise.
filterChunkName(String) - Static method in class org.objectweb.dream.protocol.messagePassing.FragmentationChunk
If the given chunkName is equal to the default name returns FragmentationChunk.DEFAULT_NAME, otherwise returns the given string.
filterChunkName(String) - Static method in class org.objectweb.dream.queue.SequenceNumberChunk
If the given chunkName is equals to the default name returns SequenceNumberChunk.DEFAULT_NAME, returns the given string otherwise.
findLocalAddress(ExportIdentifier[]) - Method in interface org.objectweb.dream.protocol.bus.LocalAccessManager
Tries to find in the given array of export identifier, the one which correspond to the local protocol.
findLocalAddress(ExportIdentifier[]) - Method in class org.objectweb.dream.protocol.bus.TCPIPLocalAccessManagerImpl
 
first - Variable in class org.objectweb.dream.protocol.messagePassing.BufferedMessagePassingProtocolImpl.Session
 
first - Variable in class org.objectweb.dream.queue.BufferAscendingSequenceNumberImpl
The first element stored in this buffer.
firstAvailable - Variable in class org.objectweb.dream.protocol.channel.ConnectionFactoryImpl
 
firstAvailable - Variable in class org.objectweb.dream.protocol.channel.TCPIPProtocolImpl
 
forceLock(Object) - Method in interface org.objectweb.dream.synchro.MutexReEntrant
Acquires the mutex with parameters that have been returned by a previous call to forceUnlock().
forceLock(Object) - Method in class org.objectweb.dream.synchro.MutexReEntrantImpl
 
forceUnlock() - Method in interface org.objectweb.dream.synchro.MutexReEntrant
Releases the mutex even if it has been acquired several times (by multiple calls to the lock() function).
forceUnlock() - Method in class org.objectweb.dream.synchro.MutexReEntrantImpl
 
FragmentationAttributeController - Interface in org.objectweb.dream.protocol.messagePassing
Attribute controller interface for fragmentation protocol.
FragmentationChunk - Class in org.objectweb.dream.protocol.messagePassing
Chunk for fragmented messages.
FragmentationChunk() - Constructor for class org.objectweb.dream.protocol.messagePassing.FragmentationChunk
 
FragmentationProtocolImpl - Class in org.objectweb.dream.protocol.messagePassing
Fragmentation protocol.
FragmentationProtocolImpl() - Constructor for class org.objectweb.dream.protocol.messagePassing.FragmentationProtocolImpl
 
FragmentationProtocolImpl.Session - Class in org.objectweb.dream.protocol.messagePassing
 
FragmentationProtocolImpl.Session(IncomingPush) - Constructor for class org.objectweb.dream.protocol.messagePassing.FragmentationProtocolImpl.Session
 
fragmentationSize - Variable in class org.objectweb.dream.protocol.messagePassing.FragmentationProtocolImpl
 
FROM_CHUNK_NAME - Static variable in interface org.objectweb.dream.protocol.messagePassing.MessagePassingProtocol
If this key is specified in the export hints map, an ExportIdentifierChunk will be added with the given name in every received messages.

G

generateKey(Message) - Method in interface org.objectweb.dream.pushwithreturn.KeyGenerator
Generates a key for the given message.
generateKey(Message) - Method in class org.objectweb.dream.pushwithreturn.KeyGeneratorIntegerImpl
 
get() - Method in class org.objectweb.dream.queue.AbstractBufferImpl
 
get() - Method in class org.objectweb.dream.queue.BufferMatchingImpl
 
get() - Method in interface org.objectweb.dream.queue.BufferRemove
Gets a message from the buffer.
get(Object) - Method in class org.objectweb.dream.queue.keyed.AbstractBufferKeyedAddKeyedRemoveImpl
 
get(Object) - Method in class org.objectweb.dream.queue.keyed.AbstractBufferKeyedRemoveImpl
 
get(Object, Object) - Method in class org.objectweb.dream.queue.keyed.BufferAscendingKeyKeyChunkAddDoubleKeyedRemoveImpl
 
get(Object, Object) - Method in interface org.objectweb.dream.queue.keyed.DoubleKeyedBufferRemove
Gets the message from the buffer that is associated with the specified keys.
get(Object) - Method in interface org.objectweb.dream.queue.keyed.KeyedBufferRemove
Gets the message from the buffer that is associated with the specified key object.
getAvailable() - Method in class org.objectweb.dream.protocol.channel.ConnectionFactoryImpl
 
getAvailable() - Method in class org.objectweb.dream.protocol.channel.TCPIPProtocolImpl
 
getAvailable() - Method in class org.objectweb.dream.protocol.messagePassing.UDPProtocolImpl
 
getBusSize() - Method in interface org.objectweb.dream.protocol.bus.BusOutgoingPush
Returns the size of the bus.
getBusSize() - Method in class org.objectweb.dream.protocol.bus.BusProtocolImpl.Session
 
getBusSize() - Method in class org.objectweb.dream.protocol.bus.logicalClock.ProtocolImpl.Session
 
getByteArray() - Method in class org.objectweb.dream.serializator.ByteArrayChunk
Returns the byte array contained in this chunk.
getByteArray() - Method in class org.objectweb.dream.serializator.CodecInputOutputByteArray
Returns the byte array associated to this codec.
getChunkName() - Method in interface org.objectweb.dream.channel.AddIPExportIdChunkAttributeController
Returns the name of added chunks.
getChunkName() - Method in class org.objectweb.dream.channel.AddIPExportIdChunkImpl
 
getChunkName() - Method in class org.objectweb.dream.protocol.bus.logicalClock.LogicalClockExportIdentifier
 
getChunkName() - Method in interface org.objectweb.dream.router.RouterChunkNameAttributeController
Returns the chunk name used by chunk name routeur.
getChunkName() - Method in class org.objectweb.dream.router.RouterChunkNameImpl
 
getClockType() - Method in class org.objectweb.dream.protocol.bus.logicalClock.LogicalClockExportIdentifier
 
getConnectionRetry() - Method in interface org.objectweb.dream.protocol.channel.TCPIPProtocolAttributeController
Returns the default value of the TCPIPProtocol.CONNECTION_RETRY hint.
getConnectionRetry() - Method in class org.objectweb.dream.protocol.channel.TCPIPProtocolImpl
 
getCurrentSize() - Method in class org.objectweb.dream.queue.AbstractBufferImpl
 
getCurrentSize() - Method in interface org.objectweb.dream.queue.BufferAttributeController
Returns the current size of the queue.
getCurrentSize() - Method in class org.objectweb.dream.queue.keyed.AbstractBufferKeyedAddKeyedRemoveImpl
 
getCurrentSize() - Method in class org.objectweb.dream.queue.keyed.AbstractBufferKeyedRemoveImpl
 
getCurrentSize() - Method in class org.objectweb.dream.queue.keyed.BufferAscendingKeyKeyChunkAddDoubleKeyedRemoveImpl
 
getCurrentSize() - Method in class org.objectweb.dream.queue.PushPullQueueFastImpl
 
getCurrentSize() - Method in class org.objectweb.dream.queue.PushPullQueueNotSynchronizedImpl
 
getDeleteChunk() - Method in interface org.objectweb.dream.channel.DestinationResolverChunkBasedAttributeController
Returns true if the destination chunk must be deleted from the message.
getDeleteChunk() - Method in class org.objectweb.dream.channel.DestinationResolverChunkBasedImpl
 
getDestinationChunkName() - Method in interface org.objectweb.dream.channel.DestinationResolverChunkBasedAttributeController
Returns the name of the chunks that contains the destination identification of the message.
getDestinationChunkName() - Method in class org.objectweb.dream.channel.DestinationResolverChunkBasedImpl
 
getException() - Method in class org.objectweb.dream.protocol.ExceptionChunk
Returns the exception.
getExportIdentifier() - Method in interface org.objectweb.dream.channel.ChannelInExportId
Returns the ExportIdentifier that identify the ChannelIn.
getExportIdentifier() - Method in class org.objectweb.dream.channel.ChannelInOutImpl
 
getExportIdentifier() - Method in class org.objectweb.dream.channel.ChannelOutImpl
 
getExportIdentifier() - Method in class org.objectweb.dream.protocol.ExportIdentifierChunk
 
getFragmentationId() - Method in class org.objectweb.dream.protocol.messagePassing.FragmentationChunk
Returns the fragmentation id.
getFragmentationSize() - Method in interface org.objectweb.dream.protocol.messagePassing.FragmentationAttributeController
Returns the fragmentationSize attribute value.
getFragmentationSize() - Method in class org.objectweb.dream.protocol.messagePassing.FragmentationProtocolImpl
 
getFragmentId() - Method in class org.objectweb.dream.protocol.messagePassing.FragmentationChunk
Returns the id of this fragment.
getFramentFrom() - Method in class org.objectweb.dream.protocol.messagePassing.FragmentationChunk
Returns the identifier of the sender of the fragment.
getFrom() - Method in class org.objectweb.dream.protocol.bus.logicalClock.LogicalClockChunk
Returns the address of the process that emit this chunk.
getFromChunkName() - Method in interface org.objectweb.dream.channel.ChannelInAttributeController
Returns the value of the fromChunkName attribute.
getFromChunkName() - Method in class org.objectweb.dream.channel.ChannelInOutImpl
 
getHostname() - Method in interface org.objectweb.dream.channel.AddIPExportIdChunkAttributeController
Returns the hostname put in chunks.
getHostname() - Method in class org.objectweb.dream.channel.AddIPExportIdChunkImpl
 
getHostName() - Method in class org.objectweb.dream.protocol.IPExportIdentifier
 
getInitialNumberOfThreads() - Method in class org.objectweb.dream.pump.PumpSynchronizedImpl
 
getInitialPermits() - Method in interface org.objectweb.dream.synchro.SemaphoreAttributeController
Returns the initial number of permits of the semaphore.
getInitialPermits() - Method in class org.objectweb.dream.synchro.SemaphoreImpl
 
getInvocationId() - Method in class org.objectweb.dream.protocol.rpc.InvocationChunk
 
getInvocationId() - Method in class org.objectweb.dream.protocol.rpc.ReplyChunk
 
getKey() - Method in class org.objectweb.dream.pushwithreturn.KeyChunk
Returns the key of this chunk.
getKey() - Method in class org.objectweb.dream.pushwithreturn.WaitingKey
Returns the key associated to this WaitingKey.
getKeyChunkName() - Method in class org.objectweb.dream.queue.keyed.BufferAscendingKeyKeyChunkAddDoubleKeyedRemoveImpl
 
getKeyChunkName() - Method in interface org.objectweb.dream.queue.keyed.BufferAttributeControllerKeyChunkAdd
Returns the name of the chunk that is used as a key.
getKeyChunkName() - Method in class org.objectweb.dream.queue.keyed.BufferKeyChunkAddKeyedRemoveImpl
 
getKeys() - Method in class org.objectweb.dream.queue.keyed.BufferAscendingKeyKeyChunkAddDoubleKeyedRemoveImpl
 
getKeys() - Method in class org.objectweb.dream.queue.keyed.BufferAscendingSequenceNumberKeyedAddKeyedRemoveImpl
 
getKeys() - Method in interface org.objectweb.dream.queue.keyed.BufferAttributeControllerKeyed
Returns an array containing the keys that are used in the buffer.
getLastInSequence() - Method in class org.objectweb.dream.queue.BufferAscendingSequenceNumberImpl
 
getLastInSequence() - Method in interface org.objectweb.dream.queue.BufferAttributeControllerAscendingSequenceNumber
Returns the sequence number of the last delivered message.
getLastInSequence(Object) - Method in class org.objectweb.dream.queue.keyed.BufferAscendingSequenceNumberKeyedAddKeyedRemoveImpl
 
getLastInSequence(Object) - Method in interface org.objectweb.dream.queue.keyed.BufferAttributeControllerAscendingSequenceNumberKeyedAdd
Returns the sequence number of the last delivered message for the given key.
getLocalAddress() - Method in interface org.objectweb.dream.protocol.bus.BusOutgoingPush
Returns the address of this protocol instance in the bus.
getLocalAddress() - Method in class org.objectweb.dream.protocol.bus.BusProtocolImpl.Session
 
getLocalAddress() - Method in class org.objectweb.dream.protocol.bus.logicalClock.ProtocolImpl.Session
 
getLocalExportIdentifier() - Method in class org.objectweb.dream.protocol.messagePassing.BufferedMessagePassingProtocolImpl.Session
 
getLocalExportIdentifier() - Method in class org.objectweb.dream.protocol.messagePassing.FragmentationProtocolImpl.Session
 
getLocalExportIdentifier() - Method in interface org.objectweb.dream.protocol.messagePassing.MessagePassingOutgoingPush
Returns the ExportIdentifier identifying the local access point.
getLocalExportIdentifier() - Method in class org.objectweb.dream.protocol.messagePassing.SerializatorMessagePassingProtocolImpl.Session
 
getLocalExportIdentifier() - Method in class org.objectweb.dream.protocol.messagePassing.UDPProtocolImpl.Session
 
getLogicalClock() - Method in class org.objectweb.dream.protocol.bus.logicalClock.LogicalClockChunk
Returns the logical clock of this chunk
getMaxCapacity() - Method in class org.objectweb.dream.queue.AbstractBufferImpl
 
getMaxCapacity() - Method in interface org.objectweb.dream.queue.BufferAttributeController
Returns the maximum capacity of the queue.
getMaxCapacity() - Method in class org.objectweb.dream.queue.keyed.AbstractBufferKeyedAddKeyedRemoveImpl
 
getMaxCapacity() - Method in class org.objectweb.dream.queue.keyed.AbstractBufferKeyedRemoveImpl
 
getMaxCapacity() - Method in class org.objectweb.dream.queue.keyed.BufferAscendingKeyKeyChunkAddDoubleKeyedRemoveImpl
 
getMaxCapacity() - Method in class org.objectweb.dream.queue.PushPullQueueFastImpl
 
getMaxCapacity() - Method in class org.objectweb.dream.queue.PushPullQueueNotSynchronizedImpl
 
getMessage() - Method in exception org.objectweb.dream.protocol.BindException
 
getMessage() - Method in exception org.objectweb.dream.protocol.InvalidExportIdentifierException
 
getMessage() - Method in class org.objectweb.dream.pushwithreturn.WaitingKey
Returns the message associated to this key.
getMethodId() - Method in class org.objectweb.dream.protocol.rpc.InvocationChunk
 
getMultiplexChunkName() - Method in class org.objectweb.dream.protocol.channel.MultiplexBindProtocolImpl
 
getMultiplexChunkName() - Method in interface org.objectweb.dream.protocol.channel.MultiplexProtocolAttributeController
Returns the name of the MultiplexChunk that the protocol will add to outgoing messages.
getNbMaxSession() - Method in interface org.objectweb.dream.protocol.messagePassing.MessagePassingOverChannelAttributeController
Returns the number of maximum opened lower session.
getNbMaxSession() - Method in class org.objectweb.dream.protocol.messagePassing.MessagePassingOverChannelImpl
 
getNbMessagesToAggregate() - Method in interface org.objectweb.dream.aggregator.PullPullAggregatorFixedNumberAttributeController
Returns the number of messages that must be aggregated.
getNbMessagesToAggregate() - Method in class org.objectweb.dream.aggregator.PullPullAggregatorFixedNumberImpl
 
getNextExportIds() - Method in class org.objectweb.dream.protocol.bus.BusExportIdentifier
 
getNextExportIds() - Method in class org.objectweb.dream.protocol.bus.logicalClock.LogicalClockExportIdentifier
 
getNextExportIds() - Method in class org.objectweb.dream.protocol.channel.MultiplexExportIdentifier
 
getNextExportIds() - Method in interface org.objectweb.dream.protocol.ExportIdentifier
Returns an array of identifiers corresponding to lower level protocol layers, if any.
getNextExportIds() - Method in class org.objectweb.dream.protocol.IPExportIdentifier
 
getNumberOfDeletedMessages() - Method in class org.objectweb.dream.trash.TrashImpl
 
getNumberOfDeletedMessages() - Method in interface org.objectweb.dream.trash.TrashMonitoring
Returns the number of deleted messages.
getNumFrags() - Method in class org.objectweb.dream.protocol.messagePassing.FragmentationChunk
Returns the number of fragments that make the message this fragment is part of.
getOutput(Message) - Method in class org.objectweb.dream.router.AbstractRouterImpl
 
getOutput(Message) - Method in class org.objectweb.dream.router.AbstractRouterKeyBasedImpl
 
getOutput(Message) - Method in class org.objectweb.dream.router.RouterRandomImpl
 
getOutput(Message) - Method in class org.objectweb.dream.router.RouterRoundRobinImpl
 
getOutput() - Method in class org.objectweb.dream.serializator.CodecInputOutputByteArray
 
getOutputKey(Message) - Method in class org.objectweb.dream.router.AbstractRouterKeyBasedImpl
Returns the key associated with the output on which the specified message must be routed.
getOverflowPolicy() - Method in interface org.objectweb.dream.queue.PushQueueAttributeController
Returns the overflow policy.
getParameters() - Method in class org.objectweb.dream.protocol.rpc.InvocationChunk
 
getPeriod() - Method in interface org.objectweb.dream.pump.PumpAttributeControllerPeriodic
Returns the pump period.
getPeriod() - Method in class org.objectweb.dream.pump.PumpPeriodicSynchronizedImpl
 
getPort() - Method in interface org.objectweb.dream.channel.AddIPExportIdChunkAttributeController
Returns the port number put in chunks.
getPort() - Method in class org.objectweb.dream.channel.AddIPExportIdChunkImpl
 
getPort() - Method in interface org.objectweb.dream.protocol.channel.TCPIPProtocolAttributeController
Returns the default value of the TCPIPProtocol.PORT hint.
getPort() - Method in class org.objectweb.dream.protocol.channel.TCPIPProtocolImpl
 
getPort() - Method in class org.objectweb.dream.protocol.IPExportIdentifier
 
getPort() - Method in interface org.objectweb.dream.protocol.messagePassing.UDPProtocolAttributeController
Returns the default value of the UDPProtocol.PORT hint.
getPort() - Method in class org.objectweb.dream.protocol.messagePassing.UDPProtocolImpl
 
getPullEmptyMessagePolicy() - Method in interface org.objectweb.dream.aggregator.PullPullAggregatorWhileNotNullAttributeController
Returns true if the aggregator must return an empty message when no message can't be aggregated.
getPullEmptyMessagePolicy() - Method in class org.objectweb.dream.aggregator.PullPullAggregatorWhileNotNullImpl
 
getPushNullPolicy() - Method in class org.objectweb.dream.pump.AbstractPumpSynchronizedImpl
 
getPushNullPolicy() - Method in interface org.objectweb.dream.pump.PumpAttributeController
Returns the PushNullPolicy.
getRecvBufferSize() - Method in interface org.objectweb.dream.protocol.messagePassing.UDPProtocolAttributeController
Returns the recvBufferSize attribute value.
getRecvBufferSize() - Method in class org.objectweb.dream.protocol.messagePassing.UDPProtocolImpl
 
getReference() - Method in class org.objectweb.dream.pushwithreturn.KeyInteger
 
getReference() - Method in class org.objectweb.dream.pushwithreturn.WaitingKey
 
getReference() - Method in class org.objectweb.dream.queue.BufferAscendingSequenceNumberImpl.Element
 
getReference() - Method in class org.objectweb.dream.queue.BufferKeyMutexSortedImpl.ListElem
 
getReference() - Method in class org.objectweb.dream.queue.BufferKeyMutexSortedImpl.MessageList
 
getReference() - Method in class org.objectweb.dream.synchro.AbstractSemaphoreQueuedImpl.WaitQueue.WaitNode
 
getReply() - Method in class org.objectweb.dream.protocol.rpc.ReplyChunk
 
getReturnMessage() - Method in class org.objectweb.dream.pushwithreturn.WaitingKey
Returns the return message.
getReturnMessageReceived() - Method in class org.objectweb.dream.pushwithreturn.WaitingKey
Returns true if the return message has been received.
getRouteId() - Method in class org.objectweb.dream.protocol.channel.BindChunk
 
getRouteId() - Method in class org.objectweb.dream.protocol.channel.CloseChunk
 
getRouteId() - Method in class org.objectweb.dream.protocol.channel.MultiplexChunk
 
getRouteId() - Method in class org.objectweb.dream.protocol.channel.MultiplexExportIdentifier
 
getSequenceNumber() - Method in class org.objectweb.dream.queue.SequenceNumberChunk
Returns the sequence number of this chunk.
getSignallee() - Method in class org.objectweb.dream.synchro.AbstractSemaphoreQueuedImpl
 
getSoLinger() - Method in interface org.objectweb.dream.protocol.channel.TCPIPProtocolAttributeController
Returns the default value of the TCPIPProtocol.SO_LINGER hint.
getSoLinger() - Method in class org.objectweb.dream.protocol.channel.TCPIPProtocolImpl
 
getSortingChunkName() - Method in class org.objectweb.dream.queue.BufferAscendingSequenceNumberImpl
 
getSortingChunkName() - Method in interface org.objectweb.dream.queue.BufferAttributeControllerSorted
Returns the name of the chunk to be used to sort messages.
getSortingChunkName() - Method in class org.objectweb.dream.queue.keyed.BufferAscendingSequenceNumberKeyedAddKeyedRemoveImpl
 
getSoTimeout() - Method in interface org.objectweb.dream.protocol.channel.TCPIPProtocolAttributeController
Returns the default value of the TCPIPProtocol.SO_TIMEOUT hint.
getSoTimeout() - Method in class org.objectweb.dream.protocol.channel.TCPIPProtocolImpl
 
getStamp(int) - Method in class org.objectweb.dream.protocol.bus.logicalClock.MatrixClock
 
getStopOnPullExceptionPolicy() - Method in class org.objectweb.dream.pump.AbstractPumpSynchronizedImpl
 
getStopOnPullExceptionPolicy() - Method in interface org.objectweb.dream.pump.PumpAttributeController
Returns the StopOnPullExceptionPolicy.
getStopOnPushExceptionPolicy() - Method in class org.objectweb.dream.pump.AbstractPumpSynchronizedImpl
 
getStopOnPushExceptionPolicy() - Method in interface org.objectweb.dream.pump.PumpAttributeController
Returns the StopOnPushExceptionPolicy.
getStub() - Method in class org.objectweb.dream.protocol.rpc.ProtocolImpl.StubSession
 
getStubClass() - Method in interface org.objectweb.dream.protocol.rpc.Skeleton
 
getStubClass() - Method in class org.objectweb.dream.protocol.rpc.StubClassChunk
 
getTcpNoDelay() - Method in interface org.objectweb.dream.protocol.channel.TCPIPProtocolAttributeController
Returns the default value of the TCPIPProtocol.TCP_NO_DELAY hint.
getTcpNoDelay() - Method in class org.objectweb.dream.protocol.channel.TCPIPProtocolImpl
 
gettersCount - Variable in class org.objectweb.dream.queue.BufferMatchingImpl
The number of calls that are waiting to get (not remove) matching messages.
getThrowable() - Method in class org.objectweb.dream.protocol.rpc.ReplyChunk
 
getTimeOut() - Method in interface org.objectweb.dream.cache.CacheAttributeController
Returns the time out.
getTimeOut() - Method in class org.objectweb.dream.cache.CacheImpl
 
getTimeStamp - Variable in class org.objectweb.dream.cache.CacheImpl
The GetTimeStamp client interface.
GetTimeStamp - Interface in org.objectweb.dream.time
This interface defines a method to get a time stamp.
getTimeStamp() - Method in interface org.objectweb.dream.time.GetTimeStamp
Returns the time stamp.
getTimeStamp() - Method in class org.objectweb.dream.time.TimeStampImpl
 
getToBeRemovedChunkName() - Method in interface org.objectweb.dream.serializator.PushPushSerializatorAttributeController
Returns the name of the chunk that is not serialized.
getToBeRemovedChunkName() - Method in class org.objectweb.dream.serializator.PushPushSerializatorImpl
 
getUsePool() - Method in class org.objectweb.dream.pump.PumpSynchronizedImpl
 

H

handlePullException(PullException) - Method in class org.objectweb.dream.pump.AbstractPumpSynchronizedImpl
Handles a PullException occurring when the activity tries to pull a message.
handlePushException(Message, PushException) - Method in class org.objectweb.dream.pump.AbstractPumpSynchronizedImpl
Handles a PushException occurring when the activity tries to push a message.
HandleReturnMessage - Interface in org.objectweb.dream.pushwithreturn
This component manages returned messages (for asynchronous synchronizers).
handleReturnMessage(WaitingKey) - Method in interface org.objectweb.dream.pushwithreturn.HandleReturnMessage
Handles the return message that is present into the waiting key.
handleReturnMessage(WaitingKey) - Method in class org.objectweb.dream.pushwithreturn.HandleReturnMessageImpl
 
HandleReturnMessageImpl - Class in org.objectweb.dream.pushwithreturn
Basic implementation of the HandleReturnMessageinterface.
HandleReturnMessageImpl() - Constructor for class org.objectweb.dream.pushwithreturn.HandleReturnMessageImpl
 
hasAvailableMessage() - Method in class org.objectweb.dream.queue.AbstractBufferImpl
Checks whether there is a message available to get or remove.
hasAvailableMessage() - Method in class org.objectweb.dream.queue.BufferMatchingImpl
 
hasAvailableMessage(Object) - Method in class org.objectweb.dream.queue.keyed.AbstractBufferKeyedAddKeyedRemoveImpl
Checks whether there is a message available to get or remove.
hasAvailableMessage(Object) - Method in class org.objectweb.dream.queue.keyed.AbstractBufferKeyedRemoveImpl
Checks whether there is a message available to get or remove.
hasAvailableMessage(Object) - Method in class org.objectweb.dream.queue.keyed.BufferAscendingSequenceNumberKeyedAddKeyedRemoveImpl
 
hashCode() - Method in class org.objectweb.dream.protocol.channel.MultiplexExportIdentifier
 
hashCode() - Method in class org.objectweb.dream.protocol.IPExportIdentifier
 
hashCode() - Method in class org.objectweb.dream.pushwithreturn.KeyInteger
 
head - Variable in class org.objectweb.dream.synchro.SemaphoreFIFOImpl.FIFOWaitQueue
 
hostname - Variable in class org.objectweb.dream.channel.AddIPExportIdChunkImpl
 
hostName - Static variable in class org.objectweb.dream.protocol.channel.TCPIPProtocolImpl
 
hostName - Static variable in class org.objectweb.dream.protocol.messagePassing.UDPProtocolImpl
 

I

id - Variable in class org.objectweb.dream.protocol.bus.BusProtocolImpl.Session
 
ID_ANNOUNCEMENT_CHUNK_NAME - Static variable in class org.objectweb.dream.protocol.messagePassing.MessagePassingOverChannelImpl
Chunk name of ExportIdentifierChunk send in first message of newly opened channel session.
ids - Variable in class org.objectweb.dream.protocol.bus.BusExportIdentifier
 
IN_DOUBLE_KEYED_PULL_ITF_NAME - Static variable in interface org.objectweb.dream.queue.keyed.DoubleKeyedPull
The commonly used name to refer to this interface when it is used as an input.
IN_KEYED_PULL_ITF_NAME - Static variable in interface org.objectweb.dream.queue.keyed.KeyedPull
The commonly used name to refer to this interface when it is used as an input.
IN_KEYED_PUSH_ITF_NAME - Static variable in interface org.objectweb.dream.queue.keyed.KeyedPush
The commonly used name to refer to this interface when it is used as an input.
INCOMING_OUT_PUSH_ITF_NAME - Static variable in class org.objectweb.dream.protocol.atomicity.AtomicReactorImpl
The name of the client interface used to pass message received on the incoming-in-push interface.
incomingClosed(Object, Exception) - Method in class org.objectweb.dream.channel.ChannelInOutImpl
 
incomingClosed(Object, Exception) - Method in class org.objectweb.dream.protocol.bus.BusProtocolImpl.Session
 
incomingClosed(Object, Exception) - Method in class org.objectweb.dream.protocol.bus.logicalClock.ProtocolImpl.Session
 
incomingClosed(Object, Exception) - Method in interface org.objectweb.dream.protocol.IncomingPush
Notifies the session, this interface belong, that the lower session accessible through the given interface has been unexpectedly closed.
incomingClosed(Object, Exception) - Method in class org.objectweb.dream.protocol.messagePassing.BufferedMessagePassingProtocolImpl.Session
 
incomingClosed(Object, Exception) - Method in class org.objectweb.dream.protocol.messagePassing.FragmentationProtocolImpl.Session
 
incomingClosed(Object, Exception) - Method in class org.objectweb.dream.protocol.messagePassing.SerializatorMessagePassingProtocolImpl.Session
 
incomingClosed(Object, Exception) - Method in class org.objectweb.dream.protocol.rpc.ProtocolImpl.SkeletonChannel.Session
 
incomingClosed(Object, Exception) - Method in class org.objectweb.dream.protocol.rpc.ProtocolImpl.StubSession
 
IncomingHandlerBlockingImpl - Class in org.objectweb.dream.queue
An incoming handler that adds pushed messages into a buffer bound to it.
IncomingHandlerBlockingImpl() - Constructor for class org.objectweb.dream.queue.IncomingHandlerBlockingImpl
 
IncomingHandlerDroppingImpl - Class in org.objectweb.dream.queue
An incoming handler that adds pushed messages into a buffer bound to it.
IncomingHandlerDroppingImpl() - Constructor for class org.objectweb.dream.queue.IncomingHandlerDroppingImpl
 
IncomingHandlerExceptionThrowingImpl - Class in org.objectweb.dream.queue
An incoming handler that adds pushed messages into a buffer bound to it.
IncomingHandlerExceptionThrowingImpl() - Constructor for class org.objectweb.dream.queue.IncomingHandlerExceptionThrowingImpl
 
IncomingHandlerRemovingImpl - Class in org.objectweb.dream.queue
An incoming handler that adds pushed messages into a buffer bound to it.
IncomingHandlerRemovingImpl() - Constructor for class org.objectweb.dream.queue.IncomingHandlerRemovingImpl
 
incomingPush(Message) - Method in class org.objectweb.dream.channel.ChannelInOutImpl
 
incomingPush(Message) - Method in class org.objectweb.dream.protocol.bus.BusProtocolImpl.Session
 
incomingPush(Message) - Method in class org.objectweb.dream.protocol.bus.logicalClock.ProtocolImpl.Session
 
IncomingPush - Interface in org.objectweb.dream.protocol
Push interface on which incoming messages are passed to a protocol.
incomingPush(Message) - Method in interface org.objectweb.dream.protocol.IncomingPush
Gives an incoming message to a protocol.
incomingPush(Message) - Method in class org.objectweb.dream.protocol.messagePassing.BufferedMessagePassingProtocolImpl.Session
 
incomingPush(Message) - Method in class org.objectweb.dream.protocol.messagePassing.FragmentationProtocolImpl.Session
 
incomingPush(Message) - Method in class org.objectweb.dream.protocol.messagePassing.SerializatorMessagePassingProtocolImpl.Session
 
incomingPush(Message) - Method in class org.objectweb.dream.protocol.rpc.ProtocolImpl.SkeletonChannel.Session
 
incomingPush(Message) - Method in class org.objectweb.dream.protocol.rpc.ProtocolImpl.StubSession
 
incrementAvailableMessagesCount(int) - Method in class org.objectweb.dream.queue.AbstractBufferImpl
Increments the count of available messages.
incrementAvailableMessagesCount(int, Object) - Method in class org.objectweb.dream.queue.keyed.AbstractBufferKeyedAddKeyedRemoveImpl
Increments the count of available messages.
incrementAvailableMessagesCount(int, Object) - Method in class org.objectweb.dream.queue.keyed.AbstractBufferKeyedRemoveImpl
Increments the count of available messages.
incrementStoredMessagesCount(int) - Method in class org.objectweb.dream.queue.AbstractBufferImpl
Increments the count of stored messages.
incrementStoredMessagesCount(int, Object) - Method in class org.objectweb.dream.queue.keyed.AbstractBufferKeyedAddKeyedRemoveImpl
Increments the count of stored messages.
incrementStoredMessagesCount(int, Object) - Method in class org.objectweb.dream.queue.keyed.AbstractBufferKeyedRemoveImpl
Increments the count of stored messages.
incrementStoredMessagesCount(int, Object) - Method in class org.objectweb.dream.queue.keyed.BufferAscendingKeyKeyChunkAddDoubleKeyedRemoveImpl
Increments the count of stored messages.
initialize(LogicalClock, BusOutgoingPush) - Method in class org.objectweb.dream.protocol.bus.logicalClock.ProtocolImpl.Session
 
initialize(MessagePassingOutgoingPush) - Method in class org.objectweb.dream.protocol.messagePassing.BufferedMessagePassingProtocolImpl.Session
 
initialize(MessagePassingOutgoingPush) - Method in class org.objectweb.dream.protocol.messagePassing.FragmentationProtocolImpl.Session
 
initialize(MessagePassingOutgoingPush) - Method in class org.objectweb.dream.protocol.messagePassing.SerializatorMessagePassingProtocolImpl.Session
 
initialized - Variable in class org.objectweb.dream.protocol.bus.logicalClock.ProtocolImpl.Session
 
initialized - Variable in class org.objectweb.dream.router.AbstractRouterImpl
true if the route table is initialized.
initialNumberOfThreads - Variable in class org.objectweb.dream.pump.PumpSynchronizedImpl
 
initRouteTable() - Method in class org.objectweb.dream.router.AbstractRouterKeyBasedImpl
This method initializes the outPushRouteTable route table.
initSession(TCPIPProtocolImpl.Session, IncomingPush) - Method in class org.objectweb.dream.protocol.channel.TCPIPProtocolImpl
 
initSession(UDPProtocolImpl.Session) - Method in class org.objectweb.dream.protocol.messagePassing.UDPProtocolImpl
 
inPull - Variable in class org.objectweb.dream.cache.CacheImpl
The Pull client interface.
inPullItf - Variable in class org.objectweb.dream.aggregator.PullPullAggregatorWhileNotNullImpl
 
inPullItf - Variable in class org.objectweb.dream.pump.AbstractPumpSynchronizedImpl
 
inPullItf - Variable in class org.objectweb.dream.synchro.LockPullUnlockImpl
 
insert(AbstractSemaphoreQueuedImpl.WaitQueue.WaitNode) - Method in class org.objectweb.dream.synchro.AbstractSemaphoreQueuedImpl.WaitQueue
 
insert(AbstractSemaphoreQueuedImpl.WaitQueue.WaitNode) - Method in class org.objectweb.dream.synchro.SemaphoreFIFOImpl.FIFOWaitQueue
 
instantiate(OutgoingPush) - Method in interface org.objectweb.dream.protocol.channel.ChannelFactory
Notify the protocol who exports this interface, that a client is opening a new communication channel.
instantiate(OutgoingPush) - Method in class org.objectweb.dream.protocol.channel.MultiplexExportProtocolImpl
 
instantiate(OutgoingPush) - Method in class org.objectweb.dream.protocol.rpc.ProtocolImpl.SkeletonChannel
 
inuse - Variable in class org.objectweb.dream.synchro.MutexImpl
The lock status.
inuse - Variable in class org.objectweb.dream.synchro.MutexReEntrantImpl
The lock status.
InvalidExportIdentifierException - Exception in org.objectweb.dream.protocol
Exception thrown when an invalid export identifier is given to a protocol.
InvalidExportIdentifierException() - Constructor for exception org.objectweb.dream.protocol.InvalidExportIdentifierException
 
InvalidExportIdentifierException(String) - Constructor for exception org.objectweb.dream.protocol.InvalidExportIdentifierException
 
InvalidExportIdentifierException(String, ExportIdentifier) - Constructor for exception org.objectweb.dream.protocol.InvalidExportIdentifierException
 
InvocationChunk - Class in org.objectweb.dream.protocol.rpc
 
InvocationException - Exception in org.objectweb.dream.protocol.rpc
 
InvocationException() - Constructor for exception org.objectweb.dream.protocol.rpc.InvocationException
 
InvocationException(String) - Constructor for exception org.objectweb.dream.protocol.rpc.InvocationException
 
InvocationException(String, Throwable) - Constructor for exception org.objectweb.dream.protocol.rpc.InvocationException
Creates an exception caused by another exception.
InvocationException(Throwable) - Constructor for exception org.objectweb.dream.protocol.rpc.InvocationException
Creates an exception caused by another exception.
invoke(InvocationChunk) - Method in interface org.objectweb.dream.protocol.rpc.Invoker
 
invoke(InvocationChunk) - Method in class org.objectweb.dream.protocol.rpc.ProtocolImpl.StubSession
 
Invoker - Interface in org.objectweb.dream.protocol.rpc
 
IPExportIdentifier - Class in org.objectweb.dream.protocol
Export identifier created by TCP/IP protocol
IPExportIdentifier() - Constructor for class org.objectweb.dream.protocol.IPExportIdentifier
Default constructor
IPExportIdentifier(String, int) - Constructor for class org.objectweb.dream.protocol.IPExportIdentifier
 
isAll() - Method in interface org.objectweb.dream.pushwithreturn.Key
Checks whether this key correspond to all possible keys generated by the generator that made it.
isAll - Variable in class org.objectweb.dream.pushwithreturn.KeyInteger
 
isAll() - Method in class org.objectweb.dream.pushwithreturn.KeyInteger
 
ITF_NAME - Static variable in interface org.objectweb.dream.channel.ChannelInExportId
Default name for interfaces of this type.
ITF_NAME - Static variable in interface org.objectweb.dream.channel.DestinationResolver
Default name for interfaces of this type.
ITF_NAME - Static variable in interface org.objectweb.dream.protocol.bus.LocalAccessManager
Default name for interfaces of this type.
ITF_NAME - Static variable in interface org.objectweb.dream.protocol.channel.ConnectionFactory
The commonly used name of this interface.
ITF_NAME - Static variable in interface org.objectweb.dream.protocol.channel.ConnectionManager
The commonly used name of this interface.
ITF_NAME - Static variable in interface org.objectweb.dream.protocol.Protocol
The default name of this interface
ITF_NAME - Static variable in interface org.objectweb.dream.pushwithreturn.HandleReturnMessage
The commonly used name to refer to this interface.
ITF_NAME - Static variable in interface org.objectweb.dream.pushwithreturn.KeyGenerator
The commonly used name to refer to this interface.
ITF_NAME - Static variable in interface org.objectweb.dream.pushwithreturn.WaitingKeys
The commonly used name to refer to this interface.
ITF_NAME - Static variable in interface org.objectweb.dream.queue.BufferAdd
The commonly used name to refer to an interface with this signature.
ITF_NAME - Static variable in interface org.objectweb.dream.queue.BufferRemove
The commonly used name to refer to an interface with this signature.
ITF_NAME - Static variable in interface org.objectweb.dream.queue.keyed.DoubleKeyedBufferRemove
The commonly used name to refer to an interface with this signature.
ITF_NAME - Static variable in interface org.objectweb.dream.queue.keyed.KeyedBufferAdd
The commonly used name to refer to an interface with this signature.
ITF_NAME - Static variable in interface org.objectweb.dream.queue.keyed.KeyedBufferRemove
The commonly used name to refer to an interface with this signature.
ITF_NAME - Static variable in interface org.objectweb.dream.queue.keyed.MissingSequenceNumberKeyBased
The commonly used name to refer to this interface.
ITF_NAME - Static variable in interface org.objectweb.dream.queue.MessageComparableKeyManager
The commonly used name to refer to an interface with this signature.
ITF_NAME - Static variable in interface org.objectweb.dream.queue.MessageKeyManager
The commonly used name to refer to an interface with this signature.
ITF_NAME - Static variable in interface org.objectweb.dream.queue.MessageMatcher
The commonly used name to refer to an interface with this signature.
ITF_NAME - Static variable in interface org.objectweb.dream.queue.MissingSequenceNumber
The commonly used name to refer to this interface.
ITF_NAME - Static variable in interface org.objectweb.dream.queue.MissingSequenceNumberKeyBased
The commonly used name to refer to this interface.
ITF_NAME - Static variable in interface org.objectweb.dream.queue.UnlockKey
The default name for interface of this type.
ITF_NAME - Static variable in interface org.objectweb.dream.serializator.DeSerializator
The default name of the DeSerializatorinterface.
ITF_NAME - Static variable in interface org.objectweb.dream.serializator.Serializator
The default name of the Serializatorinterface.
ITF_NAME - Static variable in interface org.objectweb.dream.synchro.Condition
The commonly used name to refer to this interface.
ITF_NAME - Static variable in interface org.objectweb.dream.synchro.Mutex
The default name of the Mutexinterface.
ITF_NAME - Static variable in interface org.objectweb.dream.synchro.MutexReEntrant
The default name of the MutexReEntrantinterface.
ITF_NAME - Static variable in interface org.objectweb.dream.synchro.ReadWriteLock
The default name of the ReadWriteLockinterface.
ITF_NAME - Static variable in interface org.objectweb.dream.synchro.Semaphore
The default name of the Semaphoreinterface.
ITF_NAME - Static variable in interface org.objectweb.dream.time.GetTimeStamp
The commonly used name to refer to this interface.
ITF_NAME - Static variable in interface org.objectweb.dream.time.SetTimeStamp
The commonly used name to refer to this interface.
ITF_NAME - Static variable in interface org.objectweb.dream.trash.TrashMonitoring
The commonly used name to refer to this interface.

K

Key - Interface in org.objectweb.dream.pushwithreturn
This interface defines a Key.
key - Variable in class org.objectweb.dream.pushwithreturn.KeyInteger
 
KeyChunk - Class in org.objectweb.dream.pushwithreturn
Chunk for messages containing a key.
KeyChunk() - Constructor for class org.objectweb.dream.pushwithreturn.KeyChunk
 
keyChunkName - Variable in class org.objectweb.dream.queue.keyed.BufferAscendingKeyKeyChunkAddDoubleKeyedRemoveImpl
 
keyChunkName - Variable in class org.objectweb.dream.queue.keyed.BufferKeyChunkAddKeyedRemoveImpl
 
KeyedBufferAdd - Interface in org.objectweb.dream.queue.keyed
This interface defines methods that must be implemented by a buffer to allow components to add messages into it, each message being associated with a key.
keyedBufferAdd - Variable in class org.objectweb.dream.queue.keyed.KeyedIncomingHandlerExceptionThrowingImpl
The buffer into which pushed messages are added.
keyedBufferAddItf - Variable in class org.objectweb.dream.queue.keyed.KeyedIncomingHandlerBlockingImpl
The buffer into which pushed messages are added.
keyedBufferAddItf - Variable in class org.objectweb.dream.queue.keyed.KeyedIncomingHandlerNonBlockingImpl
The buffer into which pushed messages are added.
KeyedBufferRemove - Interface in org.objectweb.dream.queue.keyed
This interface defines methods that must be implemented by a buffer to allow components to get or delete messages from it, according to the key associated with each message.
keyedBufferRemoveItf - Variable in class org.objectweb.dream.queue.keyed.KeyedOutgoingHandlerBlockingImpl
The buffer from which pulled messages are removed.
keyedBufferRemoveItf - Variable in class org.objectweb.dream.queue.keyed.KeyedOutgoingHandlerNonBlockingImpl
The buffer from which pulled messages are removed.
KeyedIncomingHandlerBlockingImpl - Class in org.objectweb.dream.queue.keyed
A, incoming handler that implements the KeyedPushinterface.
KeyedIncomingHandlerBlockingImpl() - Constructor for class org.objectweb.dream.queue.keyed.KeyedIncomingHandlerBlockingImpl
 
KeyedIncomingHandlerExceptionThrowingImpl - Class in org.objectweb.dream.queue.keyed
A push incoming handler that implements the KeyedPushinterface.
KeyedIncomingHandlerExceptionThrowingImpl() - Constructor for class org.objectweb.dream.queue.keyed.KeyedIncomingHandlerExceptionThrowingImpl
 
KeyedIncomingHandlerNonBlockingImpl - Class in org.objectweb.dream.queue.keyed
A push incoming handler that implements the KeyedPushinterface.
KeyedIncomingHandlerNonBlockingImpl() - Constructor for class org.objectweb.dream.queue.keyed.KeyedIncomingHandlerNonBlockingImpl
 
KeyedOutgoingHandlerBlockingImpl - Class in org.objectweb.dream.queue.keyed
An outgoing handler that implements the KeyedPullinterface.
KeyedOutgoingHandlerBlockingImpl() - Constructor for class org.objectweb.dream.queue.keyed.KeyedOutgoingHandlerBlockingImpl
 
KeyedOutgoingHandlerNonBlockingImpl - Class in org.objectweb.dream.queue.keyed
A outgoing handler that implements the KeyedPullinterface.
KeyedOutgoingHandlerNonBlockingImpl() - Constructor for class org.objectweb.dream.queue.keyed.KeyedOutgoingHandlerNonBlockingImpl
 
KeyedPull - Interface in org.objectweb.dream.queue.keyed
Interface that allows pulling messages mapping a specified key.
KeyedPush - Interface in org.objectweb.dream.queue.keyed
Interface that allows pushing messages and associating keys with pushed messages.
KeyGenerator - Interface in org.objectweb.dream.pushwithreturn
This interface defines a key generator.
KeyGeneratorIntegerImpl - Class in org.objectweb.dream.pushwithreturn
This generator generates KeyInteger objects with an increasing integer.
KeyGeneratorIntegerImpl() - Constructor for class org.objectweb.dream.pushwithreturn.KeyGeneratorIntegerImpl
 
KeyInteger - Class in org.objectweb.dream.pushwithreturn
Implementation of the Key interface that uses positive integers.
KeyInteger(int, boolean) - Constructor for class org.objectweb.dream.pushwithreturn.KeyInteger
Constructor.

L

last - Variable in class org.objectweb.dream.protocol.messagePassing.BufferedMessagePassingProtocolImpl.Session
 
last - Variable in class org.objectweb.dream.queue.BufferAscendingSequenceNumberImpl
The last element stored in this buffer.
lastAvailable - Variable in class org.objectweb.dream.protocol.channel.ConnectionFactoryImpl
 
lastAvailable - Variable in class org.objectweb.dream.protocol.channel.TCPIPProtocolImpl
 
lastDelivered - Variable in class org.objectweb.dream.protocol.bus.logicalClock.FIFOClock
 
lastInSequence - Variable in class org.objectweb.dream.queue.BufferAscendingSequenceNumberImpl
The last sequence number in sequence.
lastTimeStamp - Variable in class org.objectweb.dream.cache.CacheImpl
The last time stamp.
list - Variable in class org.objectweb.dream.queue.PushPullQueueFastImpl
 
list - Variable in class org.objectweb.dream.queue.PushPullQueueNotSynchronizedImpl
 
listen() - Method in class org.objectweb.dream.protocol.channel.ConnectionFactoryImpl.SessionFactory
 
listenTask - Variable in class org.objectweb.dream.protocol.channel.ConnectionFactoryImpl
 
listFc() - Method in class org.objectweb.dream.aggregator.PullPullAggregatorCollectionInputImpl
 
listFc() - Method in class org.objectweb.dream.aggregator.PullPullAggregatorFixedNumberImpl
 
listFc() - Method in class org.objectweb.dream.aggregator.PullPullAggregatorWhileNotNullImpl
 
listFc() - Method in class org.objectweb.dream.aggregator.PushPushDisaggregatorImpl
 
listFc() - Method in class org.objectweb.dream.cache.CacheImpl
 
listFc() - Method in class org.objectweb.dream.channel.AddIPExportIdChunkImpl
 
listFc() - Method in class org.objectweb.dream.channel.ChannelInOutImpl
 
listFc() - Method in class org.objectweb.dream.channel.ChannelOutImpl
 
listFc() - Method in class org.objectweb.dream.channel.DestinationResolverChunkBasedImpl
 
listFc() - Method in class org.objectweb.dream.exception.CatchPushExceptionImpl
 
listFc() - Method in class org.objectweb.dream.exception.RetryPushImpl
 
listFc() - Method in class org.objectweb.dream.protocol.atomicity.AtomicReactorImpl
 
listFc() - Method in class org.objectweb.dream.protocol.atomicity.AtomicRouterImpl
 
listFc() - Method in class org.objectweb.dream.protocol.bus.BusProtocolImpl
 
listFc() - Method in class org.objectweb.dream.protocol.bus.logicalClock.MatrixClock
 
listFc() - Method in class org.objectweb.dream.protocol.bus.logicalClock.ProtocolImpl
 
listFc() - Method in class org.objectweb.dream.protocol.bus.TCPIPLocalAccessManagerImpl
 
listFc() - Method in class org.objectweb.dream.protocol.channel.ConnectionFactoryImpl
 
listFc() - Method in class org.objectweb.dream.protocol.channel.MultiplexBindProtocolImpl
 
listFc() - Method in class org.objectweb.dream.protocol.channel.MultiplexExportProtocolImpl
 
listFc() - Method in class org.objectweb.dream.protocol.channel.TCPIPProtocolImpl
 
listFc() - Method in class org.objectweb.dream.protocol.messagePassing.BufferedMessagePassingProtocolImpl
 
listFc() - Method in class org.objectweb.dream.protocol.messagePassing.FragmentationProtocolImpl
 
listFc() - Method in class org.objectweb.dream.protocol.messagePassing.MessagePassingOverChannelImpl
 
listFc() - Method in class org.objectweb.dream.protocol.messagePassing.ReliableMessagePassingProtocolImpl
 
listFc() - Method in class org.objectweb.dream.protocol.messagePassing.SerializatorMessagePassingProtocolImpl
 
listFc() - Method in class org.objectweb.dream.protocol.messagePassing.UDPProtocolImpl
 
listFc() - Method in class org.objectweb.dream.protocol.rpc.ProtocolImpl
 
listFc() - Method in class org.objectweb.dream.pump.AbstractPumpSynchronizedImpl
 
listFc() - Method in class org.objectweb.dream.pushwithreturn.HandleReturnMessageImpl
 
listFc() - Method in class org.objectweb.dream.pushwithreturn.KeyGeneratorIntegerImpl
 
listFc() - Method in class org.objectweb.dream.pushwithreturn.SynchronizerAsynchronousImpl
 
listFc() - Method in class org.objectweb.dream.pushwithreturn.SynchronizerSynchronousImpl
 
listFc() - Method in class org.objectweb.dream.pushwithreturn.WaitingKeysImpl
 
listFc() - Method in class org.objectweb.dream.queue.AbstractBufferImpl
 
listFc() - Method in class org.objectweb.dream.queue.BufferAscendingSequenceNumberImpl
 
listFc() - Method in class org.objectweb.dream.queue.BufferKeyMutexSortedImpl
 
listFc() - Method in class org.objectweb.dream.queue.BufferMatchingImpl
 
listFc() - Method in class org.objectweb.dream.queue.BufferSortingImpl
 
listFc() - Method in class org.objectweb.dream.queue.IncomingHandlerBlockingImpl
 
listFc() - Method in class org.objectweb.dream.queue.IncomingHandlerDroppingImpl
 
listFc() - Method in class org.objectweb.dream.queue.IncomingHandlerExceptionThrowingImpl
 
listFc() - Method in class org.objectweb.dream.queue.IncomingHandlerRemovingImpl
 
listFc() - Method in class org.objectweb.dream.queue.keyed.AbstractBufferKeyedAddKeyedRemoveImpl
 
listFc() - Method in class org.objectweb.dream.queue.keyed.AbstractBufferKeyedRemoveImpl
 
listFc() - Method in class org.objectweb.dream.queue.keyed.BufferAscendingKeyKeyChunkAddDoubleKeyedRemoveImpl
 
listFc() - Method in class org.objectweb.dream.queue.keyed.BufferAscendingSequenceNumberKeyedAddKeyedRemoveImpl
 
listFc() - Method in class org.objectweb.dream.queue.keyed.DoubleKeyedOutgoingHandlerBlockingImpl
 
listFc() - Method in class org.objectweb.dream.queue.keyed.DoubleKeyedOutgoingHandlerNonBlockingImpl
 
listFc() - Method in class org.objectweb.dream.queue.keyed.KeyedIncomingHandlerBlockingImpl
 
listFc() - Method in class org.objectweb.dream.queue.keyed.KeyedIncomingHandlerExceptionThrowingImpl
 
listFc() - Method in class org.objectweb.dream.queue.keyed.KeyedIncomingHandlerNonBlockingImpl
 
listFc() - Method in class org.objectweb.dream.queue.keyed.KeyedOutgoingHandlerBlockingImpl
 
listFc() - Method in class org.objectweb.dream.queue.keyed.KeyedOutgoingHandlerNonBlockingImpl
 
listFc() - Method in class org.objectweb.dream.queue.OutgoingHandlerAggregatingImpl
 
listFc() - Method in class org.objectweb.dream.queue.OutgoingHandlerBlockingImpl
 
listFc() - Method in class org.objectweb.dream.queue.OutgoingHandlerNonBlockingImpl
 
listFc() - Method in class org.objectweb.dream.queue.PushPullQueueFastImpl
 
listFc() - Method in class org.objectweb.dream.queue.PushPullQueueNotSynchronizedImpl
 
listFc() - Method in class org.objectweb.dream.queue.PushPushUnlockKeyImpl
 
listFc() - Method in class org.objectweb.dream.router.AbstractRouterImpl
 
listFc() - Method in class org.objectweb.dream.router.RouterChunkNameImpl
 
listFc() - Method in class org.objectweb.dream.serializator.DeSerializatorImpl
 
listFc() - Method in class org.objectweb.dream.serializator.PushPushDeSerializatorImpl
 
listFc() - Method in class org.objectweb.dream.serializator.PushPushSerializatorImpl
 
listFc() - Method in class org.objectweb.dream.serializator.SerializatorImpl
 
listFc() - Method in class org.objectweb.dream.synchro.AbstractSemaphoreQueuedImpl
 
listFc() - Method in class org.objectweb.dream.synchro.ConditionImpl
 
listFc() - Method in class org.objectweb.dream.synchro.ConditionReEntrantImpl
 
listFc() - Method in class org.objectweb.dream.synchro.LockPullUnlockImpl
 
listFc() - Method in class org.objectweb.dream.synchro.LockPushUnlockImpl
 
listFc() - Method in class org.objectweb.dream.synchro.MutexImpl
 
listFc() - Method in class org.objectweb.dream.synchro.MutexReEntrantImpl
 
listFc() - Method in class org.objectweb.dream.synchro.ReadWriteLockFIFOImpl
 
listFc() - Method in class org.objectweb.dream.synchro.SemaphoreImpl
 
listFc() - Method in class org.objectweb.dream.time.TimeStampImpl
 
listFc() - Method in class org.objectweb.dream.trash.TrashImpl
 
listFc() - Method in class org.objectweb.dream.xml.SaxXercesParser
 
LOCAL_ADDRESS_HINT_KEY - Static variable in interface org.objectweb.dream.protocol.bus.BusProtocol
Hints key that can be used to specify the address of this protocol instance (ie. the index in the array of lower export identifier of the given BusExportIdentifier that other protocol instances must use to access to this one)
LocalAccessManager - Interface in org.objectweb.dream.protocol.bus
Interface used by bus protocol to try to determine the local address (if not specified in binding hints see BusProtocol.LOCAL_ADDRESS_HINT_KEY), and to export the access point of the local bus session.
localAccessManagerItf - Variable in class org.objectweb.dream.protocol.bus.BusProtocolImpl
 
lock - Variable in class org.objectweb.dream.queue.AbstractBufferImpl
The lock object.
lock - Variable in class org.objectweb.dream.queue.keyed.AbstractBufferKeyedAddKeyedRemoveImpl
The lock object.
lock - Variable in class org.objectweb.dream.queue.keyed.AbstractBufferKeyedRemoveImpl
The lock object.
lock - Variable in class org.objectweb.dream.queue.keyed.BufferAscendingKeyKeyChunkAddDoubleKeyedRemoveImpl
The lock object.
lock() - Method in interface org.objectweb.dream.synchro.Mutex
Acquires the mutex.
lock() - Method in class org.objectweb.dream.synchro.MutexImpl
 
lock() - Method in class org.objectweb.dream.synchro.MutexReEntrantImpl
 
LockPullUnlockImpl - Class in org.objectweb.dream.synchro
This component has a Pull output.
LockPullUnlockImpl() - Constructor for class org.objectweb.dream.synchro.LockPullUnlockImpl
 
LockPushUnlockImpl - Class in org.objectweb.dream.synchro
This component has a Push input.
LockPushUnlockImpl() - Constructor for class org.objectweb.dream.synchro.LockPushUnlockImpl
 
LOGICAL_CLOCK_CHUNK_NAME_HINT_TYPE - Static variable in interface org.objectweb.dream.protocol.bus.logicalClock.LogicalClockBusProtocol
The hint value used by Protocol.createExportIdentifier(java.util.Map, ExportIdentifier[]) to specify the chunk name.
LOGICAL_CLOCK_ITF_NAME - Static variable in interface org.objectweb.dream.protocol.bus.logicalClock.LogicalClock
The default name of LogicalClockinterfaces
LogicalClock - Interface in org.objectweb.dream.protocol.bus.logicalClock
Component interface to manipulate logical clock.
logicalClock - Variable in class org.objectweb.dream.protocol.bus.logicalClock.ProtocolImpl.Session
 
LogicalClockBusProtocol - Interface in org.objectweb.dream.protocol.bus.logicalClock
Convenience interface for logical clock bus protocol.
LogicalClockChunk - Class in org.objectweb.dream.protocol.bus.logicalClock
Chunk added by used by Logical clock protocol.
LogicalClockChunk() - Constructor for class org.objectweb.dream.protocol.bus.logicalClock.LogicalClockChunk
 
logicalClockChunkFactory - Variable in class org.objectweb.dream.protocol.bus.logicalClock.FIFOClock
 
logicalClockChunkFactory - Variable in class org.objectweb.dream.protocol.bus.logicalClock.MatrixClock
 
logicalClockChunkName - Variable in class org.objectweb.dream.protocol.bus.logicalClock.FIFOClock
 
logicalClockChunkName - Variable in class org.objectweb.dream.protocol.bus.logicalClock.MatrixClock
 
LogicalClockExportIdentifier - Class in org.objectweb.dream.protocol.bus.logicalClock
Export identifier handled by logical clock protocol.
LogicalClockExportIdentifier(int, String, ExportIdentifier) - Constructor for class org.objectweb.dream.protocol.bus.logicalClock.LogicalClockExportIdentifier
 
lookupFc(String) - Method in class org.objectweb.dream.xml.SaxXercesParser
 
LOWER_PROTOCOL_ITF_NAME - Static variable in interface org.objectweb.dream.protocol.Protocol
The default name of a client interface of a protocol component bound to a lower level protocol.
lowerBusOutgoingPush - Variable in class org.objectweb.dream.protocol.bus.logicalClock.ProtocolImpl.Session
 
lowerIds - Variable in class org.objectweb.dream.protocol.bus.BusProtocolImpl.Session
 
lowerLevelBusProtocolItf - Variable in class org.objectweb.dream.protocol.bus.logicalClock.ProtocolImpl
 
lowerLevelProtocolItf - Variable in class org.objectweb.dream.protocol.bus.BusProtocolImpl
 
lowerLevelProtocolItf - Variable in class org.objectweb.dream.protocol.bus.TCPIPLocalAccessManagerImpl
 
lowerLevelProtocolItf - Variable in class org.objectweb.dream.protocol.messagePassing.BufferedMessagePassingProtocolImpl
 
lowerLevelProtocolItf - Variable in class org.objectweb.dream.protocol.messagePassing.FragmentationProtocolImpl
 
lowerLevelProtocolItf - Variable in class org.objectweb.dream.protocol.messagePassing.ReliableMessagePassingProtocolImpl
 
lowerLevelProtocolItf - Variable in class org.objectweb.dream.protocol.messagePassing.SerializatorMessagePassingProtocolImpl
 
lowerOutgoingPush - Variable in class org.objectweb.dream.protocol.bus.BusProtocolImpl.Session
 
lowerOutgoingPush - Variable in class org.objectweb.dream.protocol.messagePassing.BufferedMessagePassingProtocolImpl.Session
 

M

matrix - Variable in class org.objectweb.dream.protocol.bus.logicalClock.MatrixClock
 
MATRIX_CAUSAL_CLOCK_TYPE - Static variable in class org.objectweb.dream.protocol.bus.logicalClock.LogicalClockExportIdentifier
The type value corresponding to a matrix causal clock.
MATRIX_CAUSAL_CLOCK_TYPE_NAME - Static variable in class org.objectweb.dream.protocol.bus.logicalClock.LogicalClockExportIdentifier
the name of the type corresponding to a matrix causal clock.
MatrixClock - Class in org.objectweb.dream.protocol.bus.logicalClock
Basic Implementation of a matrix clock.
MatrixClock(int, int, String, MessageManager) - Constructor for class org.objectweb.dream.protocol.bus.logicalClock.MatrixClock
 
maxCapacity - Variable in class org.objectweb.dream.queue.AbstractBufferImpl
The maximal capacity of the buffer.
maxCapacity - Variable in class org.objectweb.dream.queue.keyed.AbstractBufferKeyedAddKeyedRemoveImpl
The maximal capacity of the buffer.
maxCapacity - Variable in class org.objectweb.dream.queue.keyed.AbstractBufferKeyedRemoveImpl
The maximal capacity of the buffer.
maxCapacity - Variable in class org.objectweb.dream.queue.keyed.BufferAscendingKeyKeyChunkAddDoubleKeyedRemoveImpl
The maximal capacity of the buffer.
messageCodecItf - Variable in class org.objectweb.dream.protocol.channel.TCPIPProtocolImpl
 
messageCodecItf - Variable in class org.objectweb.dream.serializator.DeSerializatorImpl
 
messageCodecItf - Variable in class org.objectweb.dream.serializator.SerializatorImpl
 
messageComparableKeyManager - Variable in class org.objectweb.dream.queue.BufferSortingImpl
Used to calculate a key for each added message.
MessageComparableKeyManager - Interface in org.objectweb.dream.queue
Calculates keys for messages.
MessageKeyManager - Interface in org.objectweb.dream.queue
Calculates keys for messages.
messageManager - Variable in class org.objectweb.dream.protocol.bus.logicalClock.FIFOClock
 
messageManager - Variable in class org.objectweb.dream.protocol.bus.logicalClock.MatrixClock
 
messageManager - Variable in class org.objectweb.dream.queue.IncomingHandlerDroppingImpl
Used to delete dropped messages.
messageManager - Variable in class org.objectweb.dream.queue.IncomingHandlerRemovingImpl
Used to delete dropped messages.
messageManagerItf - Variable in class org.objectweb.dream.aggregator.PullPullAggregatorCollectionInputImpl
the message manager client interface of this component
messageManagerItf - Variable in class org.objectweb.dream.aggregator.PullPullAggregatorFixedNumberImpl
the message manager client interface of this component
messageManagerItf - Variable in class org.objectweb.dream.aggregator.PullPullAggregatorWhileNotNullImpl
 
messageManagerItf - Variable in class org.objectweb.dream.aggregator.PushPushDisaggregatorImpl
the message manager client interface of this component.
messageManagerItf - Variable in class org.objectweb.dream.cache.CacheImpl
The message manager client interface.
messageManagerItf - Variable in class org.objectweb.dream.channel.AddIPExportIdChunkImpl
 
messageManagerItf - Variable in class org.objectweb.dream.channel.DestinationResolverChunkBasedImpl
 
messageManagerItf - Variable in class org.objectweb.dream.protocol.bus.BusProtocolImpl
 
messageManagerItf - Variable in class org.objectweb.dream.protocol.bus.logicalClock.ProtocolImpl
 
messageManagerItf - Variable in class org.objectweb.dream.protocol.channel.TCPIPProtocolImpl
 
messageManagerItf - Variable in class org.objectweb.dream.protocol.messagePassing.BufferedMessagePassingProtocolImpl
 
messageManagerItf - Variable in class org.objectweb.dream.protocol.messagePassing.FragmentationProtocolImpl
 
messageManagerItf - Variable in class org.objectweb.dream.protocol.messagePassing.ReliableMessagePassingProtocolImpl
 
messageManagerItf - Variable in class org.objectweb.dream.protocol.messagePassing.SerializatorMessagePassingProtocolImpl
 
messageManagerItf - Variable in class org.objectweb.dream.pump.AbstractPumpSynchronizedImpl
 
messageManagerItf - Variable in class org.objectweb.dream.queue.AbstractBufferImpl
Can be used by subclasses to create aggregated messages in BufferRemove.removeAll().
messageManagerItf - Variable in class org.objectweb.dream.queue.keyed.AbstractBufferKeyedAddKeyedRemoveImpl
Can be used by subclasses to create aggregated messages in KeyedBufferRemove.removeAll().
messageManagerItf - Variable in class org.objectweb.dream.queue.keyed.AbstractBufferKeyedRemoveImpl
Can be used by subclasses to create aggregated messages in KeyedBufferRemove.removeAll().
messageManagerItf - Variable in class org.objectweb.dream.queue.keyed.BufferAscendingKeyKeyChunkAddDoubleKeyedRemoveImpl
Can be used by subclasses to create aggregated messages in DoubleKeyedBufferRemove.removeAll().
messageManagerItf - Variable in class org.objectweb.dream.queue.keyed.BufferAscendingSequenceNumberKeyedAddKeyedRemoveImpl
 
messageManagerItf - Variable in class org.objectweb.dream.router.AbstractRouterImpl
the message manager client interface of this component
messageManagerItf - Variable in class org.objectweb.dream.router.RouterChunkNameImpl
 
messageManagerItf - Variable in class org.objectweb.dream.serializator.PushPushDeSerializatorImpl
 
messageManagerItf - Variable in class org.objectweb.dream.serializator.PushPushSerializatorImpl
 
messageManagerItf - Variable in class org.objectweb.dream.trash.TrashImpl
 
MessageMatcher - Interface in org.objectweb.dream.queue
Determines which messages in a buffer can be returned by calls to BufferRemove.get() and BufferRemove.remove().
messageMatcherItf - Variable in class org.objectweb.dream.queue.BufferMatchingImpl
The message matcher that is used to select the messages that can be returned by calls to BufferMatchingImpl.get(), AbstractBufferImpl.tryGet(), BufferMatchingImpl.remove(), AbstractBufferImpl.tryRemove() and AbstractBufferImpl.removeAll().
MessagePassingOutgoingPush - Interface in org.objectweb.dream.protocol.messagePassing
Specialized OutgoingPush interface for message passing protocol.
MessagePassingOverChannelAttributeController - Interface in org.objectweb.dream.protocol.messagePassing
Attribute controller for MessagePassingOverChannelImpl component.
MessagePassingOverChannelImpl - Class in org.objectweb.dream.protocol.messagePassing
Implementation of a message passing protocol using an underlying ChannelProtocol.
MessagePassingOverChannelImpl() - Constructor for class org.objectweb.dream.protocol.messagePassing.MessagePassingOverChannelImpl
 
MessagePassingProtocol - Interface in org.objectweb.dream.protocol.messagePassing
A interface for message passing protocol.
messages - Variable in class org.objectweb.dream.queue.BufferFIFOImpl
The messages stored in this buffer, in adding order (FIFO).
messages - Variable in class org.objectweb.dream.queue.BufferLIFOImpl
The messages stored in this buffer, in adding order (FIFO).
messages - Variable in class org.objectweb.dream.queue.BufferMatchingImpl
The messages stored in this buffer, in adding order (FIFO).
messages - Variable in class org.objectweb.dream.queue.BufferSortingImpl
The messages stored in this buffer, indexed by their key.
messagesToBeReturned - Variable in class org.objectweb.dream.queue.BufferMatchingImpl
Messages that have matched BufferMatchingImpl.messageMatcherItf and that are ready to be returned.
missingSequenceNumber(long, long, Object) - Method in interface org.objectweb.dream.queue.keyed.MissingSequenceNumberKeyBased
This method is called to specify that messages ranging from snFrom to snTo are missing for the given key.
MissingSequenceNumber - Interface in org.objectweb.dream.queue
Interface that can be used by a queue sorting messages according to a sequence number (i.e. a long) to indicate that sequence numbers are missing.
missingSequenceNumber(long, long) - Method in interface org.objectweb.dream.queue.MissingSequenceNumber
This method is called to specify that messages ranging from snFrom to snTo are missing.
missingSequenceNumber(long, long, Object) - Method in interface org.objectweb.dream.queue.MissingSequenceNumberKeyBased
This method is called to specify that messages ranging from snFrom to snTo are missing for the given key.
MissingSequenceNumberKeyBased - Interface in org.objectweb.dream.queue.keyed
Interface that can be used by a queue sorting messages according to a sequence number (i.e. a long) to specify that sequence numbers are missings.
MissingSequenceNumberKeyBased - Interface in org.objectweb.dream.queue
Interface that can be used by a queue sorting messages according to a sequence number (i.e. a long) to indicate that sequence numbers are missing.
missingSequenceNumberKeyBasedItf - Variable in class org.objectweb.dream.queue.keyed.BufferAscendingSequenceNumberKeyedAddKeyedRemoveImpl
 
MultiplexBindProtocolImpl - Class in org.objectweb.dream.protocol.channel
Implementation of a binding multiplexer protocol.
MultiplexBindProtocolImpl() - Constructor for class org.objectweb.dream.protocol.channel.MultiplexBindProtocolImpl
 
MultiplexChunk - Class in org.objectweb.dream.protocol.channel
Chunk used by multiplex protocol.
MultiplexChunk() - Constructor for class org.objectweb.dream.protocol.channel.MultiplexChunk
 
MultiplexExportIdentifier - Class in org.objectweb.dream.protocol.channel
Export identifier created by multiplex protocol.
MultiplexExportIdentifier(short, ExportIdentifier) - Constructor for class org.objectweb.dream.protocol.channel.MultiplexExportIdentifier
 
MultiplexExportProtocol - Interface in org.objectweb.dream.protocol.channel
Defines constants used as hints key that can be given to a MultiplexExportProtocol.
MultiplexExportProtocolImpl - Class in org.objectweb.dream.protocol.channel
Implementation of an export multiplexer protocol.
MultiplexExportProtocolImpl() - Constructor for class org.objectweb.dream.protocol.channel.MultiplexExportProtocolImpl
 
MultiplexProtocolAttributeController - Interface in org.objectweb.dream.protocol.channel
Attribute controller for multiplex protocol.
Mutex - Interface in org.objectweb.dream.synchro
A mutex component aims at synchronizing the execution of several components.
MutexImpl - Class in org.objectweb.dream.synchro
Basic implementation of the Mutex interface: this mutex is non-reentrant.
MutexImpl() - Constructor for class org.objectweb.dream.synchro.MutexImpl
 
mutexItf - Variable in class org.objectweb.dream.pump.AbstractPumpSynchronizedImpl
 
mutexItf - Variable in class org.objectweb.dream.synchro.ConditionImpl
 
mutexItf - Variable in class org.objectweb.dream.synchro.LockPullUnlockImpl
 
mutexItf - Variable in class org.objectweb.dream.synchro.LockPushUnlockImpl
 
MutexReEntrant - Interface in org.objectweb.dream.synchro
A reentrant mutex component aims at synchronizing the execution of several components.
MutexReEntrantImpl - Class in org.objectweb.dream.synchro
Basic implementation of the MutexReEntrant interface: this mutex is reentrant.
MutexReEntrantImpl() - Constructor for class org.objectweb.dream.synchro.MutexReEntrantImpl
 
mutexReEntrantItf - Variable in class org.objectweb.dream.synchro.ConditionReEntrantImpl
 
myAddress - Variable in class org.objectweb.dream.protocol.bus.BusProtocolImpl.Session
 
myAddress - Variable in class org.objectweb.dream.protocol.bus.logicalClock.FIFOClock
 
myAddress - Variable in class org.objectweb.dream.protocol.bus.logicalClock.MatrixClock
 

N

newChunk() - Method in class org.objectweb.dream.protocol.bus.logicalClock.LogicalClockChunk
 
newChunk() - Method in class org.objectweb.dream.protocol.channel.BindChunk
 
newChunk() - Method in class org.objectweb.dream.protocol.channel.CloseChunk
 
newChunk() - Method in class org.objectweb.dream.protocol.channel.MultiplexChunk
 
newChunk() - Method in class org.objectweb.dream.protocol.ExceptionChunk
 
newChunk() - Method in class org.objectweb.dream.protocol.ExportIdentifierChunk
 
newChunk() - Method in class org.objectweb.dream.protocol.messagePassing.FragmentationChunk
 
newChunk() - Method in class org.objectweb.dream.protocol.rpc.InvocationChunk
 
newChunk() - Method in class org.objectweb.dream.protocol.rpc.ReplyChunk
 
newChunk() - Method in class org.objectweb.dream.protocol.rpc.StubClassChunk
 
newChunk() - Method in class org.objectweb.dream.pushwithreturn.KeyChunk
 
newChunk() - Method in class org.objectweb.dream.queue.SequenceNumberChunk
 
newChunk() - Method in class org.objectweb.dream.serializator.ByteArrayChunk
 
newConnection(Socket, IPExportIdentifier) - Method in interface org.objectweb.dream.protocol.channel.ConnectionManager
Informs the protocol component that a new connection has been opened.
newConnection(Socket, IPExportIdentifier) - Method in class org.objectweb.dream.protocol.channel.TCPIPProtocolImpl
 
newInstance() - Method in class org.objectweb.dream.serializator.DeSerializatorImpl
 
newInstance() - Method in class org.objectweb.dream.serializator.SerializatorImpl
 
noLongerMissing(long, Object) - Method in interface org.objectweb.dream.queue.keyed.MissingSequenceNumberKeyBased
This method is called to specify that a sequence number is no longer missing for the given key.
noLongerMissing(long) - Method in interface org.objectweb.dream.queue.MissingSequenceNumber
This method is called to specify that a sequence number is no longer missing.
noLongerMissing(long, Object) - Method in interface org.objectweb.dream.queue.MissingSequenceNumberKeyBased
This method is called to specify that a sequence number is no longer missing for the given key.

O

objectPoolItf - Variable in class org.objectweb.dream.serializator.DeSerializatorImpl
 
objectPoolItf - Variable in class org.objectweb.dream.serializator.SerializatorImpl
 
org.objectweb.dream.aggregator - package org.objectweb.dream.aggregator
 
org.objectweb.dream.cache - package org.objectweb.dream.cache
 
org.objectweb.dream.channel - package org.objectweb.dream.channel
 
org.objectweb.dream.exception - package org.objectweb.dream.exception
 
org.objectweb.dream.protocol - package org.objectweb.dream.protocol
 
org.objectweb.dream.protocol.atomicity - package org.objectweb.dream.protocol.atomicity
 
org.objectweb.dream.protocol.bus - package org.objectweb.dream.protocol.bus
 
org.objectweb.dream.protocol.bus.logicalClock - package org.objectweb.dream.protocol.bus.logicalClock
 
org.objectweb.dream.protocol.channel - package org.objectweb.dream.protocol.channel
 
org.objectweb.dream.protocol.messagePassing - package org.objectweb.dream.protocol.messagePassing
 
org.objectweb.dream.protocol.rpc - package org.objectweb.dream.protocol.rpc
 
org.objectweb.dream.pump - package org.objectweb.dream.pump
 
org.objectweb.dream.pushwithreturn - package org.objectweb.dream.pushwithreturn
 
org.objectweb.dream.queue - package org.objectweb.dream.queue
 
org.objectweb.dream.queue.keyed - package org.objectweb.dream.queue.keyed
 
org.objectweb.dream.router - package org.objectweb.dream.router
 
org.objectweb.dream.serializator - package org.objectweb.dream.serializator
 
org.objectweb.dream.synchro - package org.objectweb.dream.synchro
 
org.objectweb.dream.time - package org.objectweb.dream.time
 
org.objectweb.dream.trash - package org.objectweb.dream.trash
 
org.objectweb.dream.xml - package org.objectweb.dream.xml
 
OUT_DOUBLE_KEYED_PULL_ITF_NAME - Static variable in interface org.objectweb.dream.queue.keyed.DoubleKeyedPull
The commonly used name to refer to this interface when it is used as an output.
OUT_KEYED_PULL_ITF_NAME - Static variable in interface org.objectweb.dream.queue.keyed.KeyedPull
The commonly used name to refer to this interface when it is used as an output.
OUT_KEYED_PUSH_ITF_NAME - Static variable in interface org.objectweb.dream.queue.keyed.KeyedPush
The commonly used name to refer to this interface when it is used as an output.
OUT_NOT_REACT_PUSH_ITF_NAME - Static variable in class org.objectweb.dream.protocol.atomicity.AtomicRouterImpl
The name of the client interface used to push messages if the pushing thread is not the reacting thread
OUT_REACT_PUSH_ITF_NAME - Static variable in class org.objectweb.dream.protocol.atomicity.AtomicRouterImpl
the name of the client interface uesd to push messages if the pushing thread is the reacting thred
OUTGOING_OUT_PUSH_ITF_NAME - Static variable in class org.objectweb.dream.protocol.atomicity.AtomicReactorImpl
The name of the client interface used to send message pulled from the waiting list.
outgoingClose(IncomingPush) - Method in interface org.objectweb.dream.protocol.bus.BusOutgoingPush
Closes the communication channel.
outgoingClose(IncomingPush) - Method in class org.objectweb.dream.protocol.bus.BusProtocolImpl.Session
 
outgoingClose(IncomingPush) - Method in class org.objectweb.dream.protocol.bus.logicalClock.ProtocolImpl.Session
 
outgoingClose(IncomingPush) - Method in class org.objectweb.dream.protocol.channel.TCPIPProtocolImpl.Session
 
outgoingClose(IncomingPush) - Method in class org.objectweb.dream.protocol.messagePassing.BufferedMessagePassingProtocolImpl.Session
 
outgoingClose(IncomingPush) - Method in class org.objectweb.dream.protocol.messagePassing.FragmentationProtocolImpl.Session
 
outgoingClose(IncomingPush) - Method in interface org.objectweb.dream.protocol.messagePassing.MessagePassingOutgoingPush
Closes the access point.
outgoingClose(IncomingPush) - Method in class org.objectweb.dream.protocol.messagePassing.SerializatorMessagePassingProtocolImpl.Session
 
outgoingClose(IncomingPush) - Method in class org.objectweb.dream.protocol.messagePassing.UDPProtocolImpl.Session
 
outgoingClose(IncomingPush) - Method in interface org.objectweb.dream.protocol.OutgoingPush
Closes the communication channel.
OutgoingHandlerAggregatingImpl - Class in org.objectweb.dream.queue
An outgoing handler that returns messages removed from a buffer bound to it.
OutgoingHandlerAggregatingImpl() - Constructor for class org.objectweb.dream.queue.OutgoingHandlerAggregatingImpl
 
OutgoingHandlerBlockingImpl - Class in org.objectweb.dream.queue
An outgoing handler that returns messages removed from a buffer bound to it.
OutgoingHandlerBlockingImpl() - Constructor for class org.objectweb.dream.queue.OutgoingHandlerBlockingImpl
 
OutgoingHandlerNonBlockingImpl - Class in org.objectweb.dream.queue
An outgoing handler that returns messages removed from a buffer bound to it.
OutgoingHandlerNonBlockingImpl() - Constructor for class org.objectweb.dream.queue.OutgoingHandlerNonBlockingImpl
 
outgoingPush(Message, int) - Method in interface org.objectweb.dream.protocol.bus.BusOutgoingPush
Gives an outgoing message to a protocol.
outgoingPush(Message, int) - Method in class org.objectweb.dream.protocol.bus.BusProtocolImpl.Session
 
outgoingPush(Message, int) - Method in class org.objectweb.dream.protocol.bus.logicalClock.ProtocolImpl.Session
 
outgoingPush(Message) - Method in class org.objectweb.dream.protocol.channel.TCPIPProtocolImpl.Session
 
outgoingPush(Message, ExportIdentifier) - Method in class org.objectweb.dream.protocol.messagePassing.BufferedMessagePassingProtocolImpl.Session
 
outgoingPush(Message, ExportIdentifier) - Method in class org.objectweb.dream.protocol.messagePassing.FragmentationProtocolImpl.Session
 
outgoingPush(Message, ExportIdentifier) - Method in interface org.objectweb.dream.protocol.messagePassing.MessagePassingOutgoingPush
Sends the given message to the access point identified by to.
outgoingPush(Message, ExportIdentifier) - Method in class org.objectweb.dream.protocol.messagePassing.SerializatorMessagePassingProtocolImpl.Session
 
outgoingPush(Message, ExportIdentifier) - Method in class org.objectweb.dream.protocol.messagePassing.UDPProtocolImpl.Session
 
OutgoingPush - Interface in org.objectweb.dream.protocol
Push interface on which outgoing messages are passed to a protocol.
outgoingPush(Message) - Method in interface org.objectweb.dream.protocol.OutgoingPush
Gives an outgoing message to a protocol.
OUTPUSH_WITH_CHUNK_ITF_NAME - Static variable in class org.objectweb.dream.router.RouterChunkNameImpl
The name of client interface used to push messages with the specified chunk name.
OUTPUSH_WITHOUT_CHUNK_ITF_NAME - Static variable in class org.objectweb.dream.router.RouterChunkNameImpl
The name of client interface used to push messages without the specified chunk name.
outPushItf - Variable in class org.objectweb.dream.aggregator.PushPushDisaggregatorImpl
 
outPushItf - Variable in class org.objectweb.dream.channel.AddIPExportIdChunkImpl
 
outPushItf - Variable in class org.objectweb.dream.exception.CatchPushExceptionImpl
 
outPushItf - Variable in class org.objectweb.dream.exception.RetryPushImpl
 
outPushItf - Variable in class org.objectweb.dream.pump.AbstractPumpSynchronizedImpl
 
outPushItf - Variable in class org.objectweb.dream.serializator.PushPushDeSerializatorImpl
 
outPushItf - Variable in class org.objectweb.dream.serializator.PushPushSerializatorImpl
 
outPushItf - Variable in class org.objectweb.dream.synchro.LockPushUnlockImpl
 
outPushMap - Variable in class org.objectweb.dream.router.AbstractRouterImpl
Map of out-push interfaces binded to this router
outPushRouteTable - Variable in class org.objectweb.dream.router.AbstractRouterKeyBasedImpl
Route table that associates keys with Push output interfaces.
outPushWithChunkItf - Variable in class org.objectweb.dream.router.RouterChunkNameImpl
The interface used to push messages with the specified chunk name.
outPushWithoutChunkItf - Variable in class org.objectweb.dream.router.RouterChunkNameImpl
The interface used to push messages without the specified chunk name.

P

period - Variable in class org.objectweb.dream.pump.PumpPeriodicSynchronizedImpl
 
permits() - Method in interface org.objectweb.dream.synchro.Semaphore
Returns the current number of available permits.
permits - Variable in class org.objectweb.dream.synchro.SemaphoreImpl
current number of available permits *
permits() - Method in class org.objectweb.dream.synchro.SemaphoreImpl
 
port - Variable in class org.objectweb.dream.channel.AddIPExportIdChunkImpl
 
PORT - Static variable in interface org.objectweb.dream.protocol.channel.TCPIPProtocol
This integer hint, used at export time, can specify the listening port on which the TCP/IP protocol will wait incoming connection for an exported channel.
port - Variable in class org.objectweb.dream.protocol.channel.TCPIPProtocolImpl
 
PORT - Static variable in interface org.objectweb.dream.protocol.messagePassing.UDPProtocol
This integer hint, used at export time, can specify the port of the UDP socket.
PORT_RANGE - Static variable in interface org.objectweb.dream.protocol.channel.TCPIPProtocol
This integer hint, used at export time, can specify the range of listening ports on which the TCP/IP protocol will try to open server socket.
PORT_RANGE - Static variable in interface org.objectweb.dream.protocol.messagePassing.UDPProtocol
This integer hint, used at export time, can specify the range of ports on which the UDP protocol will try to open socket.
precheck() - Method in class org.objectweb.dream.synchro.AbstractSemaphoreQueuedImpl
 
prepareStopFc() - Method in class org.objectweb.dream.protocol.channel.ConnectionFactoryImpl
 
prepareStopFc() - Method in class org.objectweb.dream.protocol.channel.TCPIPProtocolImpl
 
Protocol - Interface in org.objectweb.dream.protocol
Base protocol interface, contains commonly used names to refer to protocol interfaces.
ProtocolImpl - Class in org.objectweb.dream.protocol.bus.logicalClock
Generic logical clock protocol implementation.
ProtocolImpl() - Constructor for class org.objectweb.dream.protocol.bus.logicalClock.ProtocolImpl
 
ProtocolImpl - Class in org.objectweb.dream.protocol.rpc
 
ProtocolImpl() - Constructor for class org.objectweb.dream.protocol.rpc.ProtocolImpl
 
ProtocolImpl.Session - Class in org.objectweb.dream.protocol.bus.logicalClock
 
ProtocolImpl.Session(IncomingPush) - Constructor for class org.objectweb.dream.protocol.bus.logicalClock.ProtocolImpl.Session
 
ProtocolImpl.SkeletonChannel - Class in org.objectweb.dream.protocol.rpc
 
ProtocolImpl.SkeletonChannel(Skeleton) - Constructor for class org.objectweb.dream.protocol.rpc.ProtocolImpl.SkeletonChannel
 
ProtocolImpl.SkeletonChannel.Session - Class in org.objectweb.dream.protocol.rpc
 
ProtocolImpl.SkeletonChannel.Session(OutgoingPush) - Constructor for class org.objectweb.dream.protocol.rpc.ProtocolImpl.SkeletonChannel.Session
 
ProtocolImpl.StubSession - Class in org.objectweb.dream.protocol.rpc
 
ProtocolImpl.StubSession() - Constructor for class org.objectweb.dream.protocol.rpc.ProtocolImpl.StubSession
 
ProtocolImpl.StubSession.InvocationSemaphore - Class in org.objectweb.dream.protocol.rpc
 
ProtocolImpl.StubSession.InvocationSemaphore() - Constructor for class org.objectweb.dream.protocol.rpc.ProtocolImpl.StubSession.InvocationSemaphore
 
pull() - Method in class org.objectweb.dream.aggregator.PullPullAggregatorCollectionInputImpl
 
pull() - Method in class org.objectweb.dream.aggregator.PullPullAggregatorFixedNumberImpl
 
pull() - Method in class org.objectweb.dream.aggregator.PullPullAggregatorWhileNotNullImpl
 
pull() - Method in class org.objectweb.dream.cache.CacheImpl
 
pull(Object, Object) - Method in class org.objectweb.dream.queue.keyed.DoubleKeyedOutgoingHandlerBlockingImpl
 
pull(Object, Object) - Method in class org.objectweb.dream.queue.keyed.DoubleKeyedOutgoingHandlerNonBlockingImpl
 
pull(Object, Object) - Method in interface org.objectweb.dream.queue.keyed.DoubleKeyedPull
Asks for a message matching the given keys.
pull(Object) - Method in class org.objectweb.dream.queue.keyed.KeyedOutgoingHandlerBlockingImpl
 
pull(Object) - Method in class org.objectweb.dream.queue.keyed.KeyedOutgoingHandlerNonBlockingImpl
 
pull(Object) - Method in interface org.objectweb.dream.queue.keyed.KeyedPull
Asks for a message matching the given key.
pull() - Method in class org.objectweb.dream.queue.OutgoingHandlerAggregatingImpl
 
pull() - Method in class org.objectweb.dream.queue.OutgoingHandlerBlockingImpl
 
pull() - Method in class org.objectweb.dream.queue.OutgoingHandlerNonBlockingImpl
 
pull() - Method in class org.objectweb.dream.queue.PushPullQueueFastImpl
 
pull() - Method in class org.objectweb.dream.queue.PushPullQueueNotSynchronizedImpl
 
pull() - Method in class org.objectweb.dream.synchro.LockPullUnlockImpl
 
PullPullAggregatorCollectionInputImpl - Class in org.objectweb.dream.aggregator
This aggregator has a collection of pull inputs, and a pull output.
PullPullAggregatorCollectionInputImpl() - Constructor for class org.objectweb.dream.aggregator.PullPullAggregatorCollectionInputImpl
 
PullPullAggregatorFixedNumberAttributeController - Interface in org.objectweb.dream.aggregator
Attribute controller for Pull/Pull aggregators that aggregate a fixed number of messages.
PullPullAggregatorFixedNumberImpl - Class in org.objectweb.dream.aggregator
This aggregator aggregates a fixed number of messages.
PullPullAggregatorFixedNumberImpl() - Constructor for class org.objectweb.dream.aggregator.PullPullAggregatorFixedNumberImpl
 
PullPullAggregatorWhileNotNullAttributeController - Interface in org.objectweb.dream.aggregator
Attribute controller interface for PullPullAggregatorWhileNotNullImplaggregator implementation.
PullPullAggregatorWhileNotNullImpl - Class in org.objectweb.dream.aggregator
Message aggregator, when a message is asked in the out-pull server interface, this component pulls messages on its in-pull client interface until null is returned, and then returns an aggregated message containing every pulled messages.
PullPullAggregatorWhileNotNullImpl() - Constructor for class org.objectweb.dream.aggregator.PullPullAggregatorWhileNotNullImpl
 
PumpAttributeController - Interface in org.objectweb.dream.pump
Attribute controller for pump components.
PumpAttributeControllerPeriodic - Interface in org.objectweb.dream.pump
Periodic pump attribute controller interface.
PumpAttributeControllerThreadPool - Interface in org.objectweb.dream.pump
Attribute controller for pump components that use a thread pool.
PumpPeriodicSynchronizedImpl - Class in org.objectweb.dream.pump
Implementation of a periodic pump: every T ms, a message is pulled on the input and is then pushed on the output.
PumpPeriodicSynchronizedImpl() - Constructor for class org.objectweb.dream.pump.PumpPeriodicSynchronizedImpl
 
PumpSynchronizedImpl - Class in org.objectweb.dream.pump
Synchronized implementation of a Pull/Push pump.
PumpSynchronizedImpl() - Constructor for class org.objectweb.dream.pump.PumpSynchronizedImpl
 
pumpTask - Variable in class org.objectweb.dream.pump.AbstractPumpSynchronizedImpl
 
push(Message) - Method in class org.objectweb.dream.aggregator.PushPushDisaggregatorImpl
 
push(Message) - Method in class org.objectweb.dream.channel.AddIPExportIdChunkImpl
 
push(Message) - Method in class org.objectweb.dream.channel.ChannelInOutImpl
 
push(Message) - Method in class org.objectweb.dream.channel.ChannelOutImpl
 
push(Message) - Method in class org.objectweb.dream.exception.CatchPushExceptionImpl
 
push(Message) - Method in class org.objectweb.dream.exception.RetryPushImpl
 
push(Message) - Method in class org.objectweb.dream.protocol.atomicity.AtomicReactorImpl
 
push(Message) - Method in class org.objectweb.dream.protocol.atomicity.AtomicRouterImpl
 
push(Message) - Method in class org.objectweb.dream.pushwithreturn.SynchronizerAsynchronousImpl
 
push(Message) - Method in class org.objectweb.dream.pushwithreturn.SynchronizerSynchronousImpl
 
push(Message) - Method in class org.objectweb.dream.queue.IncomingHandlerBlockingImpl
 
push(Message) - Method in class org.objectweb.dream.queue.IncomingHandlerDroppingImpl
 
push(Message) - Method in class org.objectweb.dream.queue.IncomingHandlerExceptionThrowingImpl
 
push(Message) - Method in class org.objectweb.dream.queue.IncomingHandlerRemovingImpl
 
push(Message, Object) - Method in class org.objectweb.dream.queue.keyed.KeyedIncomingHandlerBlockingImpl
 
push(Message, Object) - Method in class org.objectweb.dream.queue.keyed.KeyedIncomingHandlerExceptionThrowingImpl
 
push(Message, Object) - Method in class org.objectweb.dream.queue.keyed.KeyedIncomingHandlerNonBlockingImpl
 
push(Message, Object) - Method in interface org.objectweb.dream.queue.keyed.KeyedPush
Gives a message to a component.
push(Message) - Method in class org.objectweb.dream.queue.PushPullQueueFastImpl
 
push(Message) - Method in class org.objectweb.dream.queue.PushPullQueueNotSynchronizedImpl
 
push(Message) - Method in class org.objectweb.dream.queue.PushPushUnlockKeyImpl
 
push(Message) - Method in class org.objectweb.dream.router.AbstractRouterImpl
Sends the incoming message to one of the router's output.
push(Message) - Method in class org.objectweb.dream.router.RouterChunkNameImpl
 
push(Message) - Method in class org.objectweb.dream.serializator.PushPushDeSerializatorImpl
 
push(Message) - Method in class org.objectweb.dream.serializator.PushPushSerializatorImpl
 
push(Message) - Method in class org.objectweb.dream.synchro.LockPushUnlockImpl
 
push(Message) - Method in class org.objectweb.dream.trash.TrashImpl
 
push1(Message) - Method in class org.objectweb.dream.pushwithreturn.SynchronizerAsynchronousImpl
 
push1(Message) - Method in class org.objectweb.dream.pushwithreturn.SynchronizerSynchronousImpl
 
pushNullPolicy - Variable in class org.objectweb.dream.pump.AbstractPumpSynchronizedImpl
 
PushPullQueueFastImpl - Class in org.objectweb.dream.queue
High performance implementation of a Push/Pull queue.
PushPullQueueFastImpl() - Constructor for class org.objectweb.dream.queue.PushPullQueueFastImpl
 
PushPullQueueNotSynchronizedImpl - Class in org.objectweb.dream.queue
High performance implementation of a Push/Pull queue.
PushPullQueueNotSynchronizedImpl() - Constructor for class org.objectweb.dream.queue.PushPullQueueNotSynchronizedImpl
 
PushPushDeSerializatorImpl - Class in org.objectweb.dream.serializator
This component de-serializes messages it receives on its input and send them on its output.
PushPushDeSerializatorImpl() - Constructor for class org.objectweb.dream.serializator.PushPushDeSerializatorImpl
 
PushPushDisaggregatorImpl - Class in org.objectweb.dream.aggregator
Basic implementation of a Push/Push de-aggregator.
PushPushDisaggregatorImpl() - Constructor for class org.objectweb.dream.aggregator.PushPushDisaggregatorImpl
 
PushPushSerializatorAttributeController - Interface in org.objectweb.dream.serializator
Attribute controller interface for PushPushSerializator components.
PushPushSerializatorImpl - Class in org.objectweb.dream.serializator
This component serializes messages it receives on its input and send them on its output.
PushPushSerializatorImpl() - Constructor for class org.objectweb.dream.serializator.PushPushSerializatorImpl
 
PushPushUnlockKeyImpl - Class in org.objectweb.dream.queue
This component forwards incoming messages and then call UnlockKey.unlockKey().
PushPushUnlockKeyImpl() - Constructor for class org.objectweb.dream.queue.PushPushUnlockKeyImpl
 
PushQueueAttributeController - Interface in org.objectweb.dream.queue
Attribute controller for queue implementation with a push input.
pushWithReturn(Message) - Method in class org.objectweb.dream.pushwithreturn.SynchronizerSynchronousImpl
 

Q

queue - Variable in class org.objectweb.dream.queue.keyed.BufferAscendingKeyKeyChunkAddDoubleKeyedRemoveImpl
Used to sort the messages according to the key stored in each message as a chunk.
queue - Variable in class org.objectweb.dream.queue.keyed.BufferKeyChunkAddKeyedRemoveImpl
Used to sort the messages according to the key that is a chunk in every message added to this buffer.

R

readers - Variable in class org.objectweb.dream.synchro.ReadWriteLockFIFOImpl
Number of threads that have entered read lock.
readerTask - Variable in class org.objectweb.dream.protocol.channel.TCPIPProtocolImpl
 
readExportIdentifierArray(ObjectInput) - Static method in class org.objectweb.dream.protocol.Util
Reads and returns an array of export identifier from an ObjectInput object.
readExternal(ObjectInput) - Method in class org.objectweb.dream.protocol.bus.BusExportIdentifier
 
readExternal(ObjectInput) - Method in class org.objectweb.dream.protocol.bus.logicalClock.LogicalClockChunk
 
readExternal(ObjectInput) - Method in class org.objectweb.dream.protocol.bus.logicalClock.LogicalClockExportIdentifier
 
readExternal(ObjectInput) - Method in class org.objectweb.dream.protocol.channel.BindChunk
 
readExternal(ObjectInput) - Method in class org.objectweb.dream.protocol.channel.CloseChunk
 
readExternal(ObjectInput) - Method in class org.objectweb.dream.protocol.channel.MultiplexChunk
 
readExternal(ObjectInput) - Method in class org.objectweb.dream.protocol.channel.MultiplexExportIdentifier
 
readExternal(ObjectInput) - Method in class org.objectweb.dream.protocol.ExceptionChunk
 
readExternal(ObjectInput) - Method in class org.objectweb.dream.protocol.ExportIdentifierChunk
 
readExternal(ObjectInput) - Method in class org.objectweb.dream.protocol.IPExportIdentifier
 
readExternal(ObjectInput) - Method in class org.objectweb.dream.protocol.messagePassing.FragmentationChunk
 
readExternal(ObjectInput) - Method in class org.objectweb.dream.protocol.rpc.InvocationChunk
 
readExternal(ObjectInput) - Method in class org.objectweb.dream.protocol.rpc.ReplyChunk
 
readExternal(ObjectInput) - Method in class org.objectweb.dream.protocol.rpc.StubClassChunk
 
readExternal(ObjectInput) - Method in class org.objectweb.dream.pushwithreturn.KeyChunk
 
readExternal(ObjectInput) - Method in class org.objectweb.dream.queue.SequenceNumberChunk
 
readExternal(ObjectInput) - Method in class org.objectweb.dream.serializator.ByteArrayChunk
 
ReadWriteLock - Interface in org.objectweb.dream.synchro
A read-write lock component aims at synchronizing the execution of several reader and writer components.
ReadWriteLockFIFOImpl - Class in org.objectweb.dream.synchro
FIFO implementation of the ReadWriteLockinterface.
ReadWriteLockFIFOImpl() - Constructor for class org.objectweb.dream.synchro.ReadWriteLockFIFOImpl
 
recheck(AbstractSemaphoreQueuedImpl.WaitQueue.WaitNode) - Method in class org.objectweb.dream.synchro.AbstractSemaphoreQueuedImpl
 
recyclableReference - Variable in class org.objectweb.dream.pushwithreturn.KeyInteger
 
recycle() - Method in class org.objectweb.dream.protocol.bus.logicalClock.LogicalClockChunk
 
recycle() - Method in class org.objectweb.dream.protocol.channel.BindChunk
 
recycle() - Method in class org.objectweb.dream.protocol.channel.CloseChunk
 
recycle() - Method in class org.objectweb.dream.protocol.channel.MultiplexChunk
 
recycle() - Method in class org.objectweb.dream.protocol.ExceptionChunk
 
recycle() - Method in class org.objectweb.dream.protocol.ExportIdentifierChunk
 
recycle() - Method in class org.objectweb.dream.protocol.messagePassing.FragmentationChunk
 
recycle() - Method in class org.objectweb.dream.protocol.rpc.InvocationChunk
 
recycle() - Method in class org.objectweb.dream.protocol.rpc.ReplyChunk
 
recycle() - Method in class org.objectweb.dream.protocol.rpc.StubClassChunk
 
recycle() - Method in class org.objectweb.dream.pushwithreturn.KeyChunk
 
recycle() - Method in class org.objectweb.dream.pushwithreturn.KeyInteger
 
recycle() - Method in class org.objectweb.dream.pushwithreturn.WaitingKey
 
recycle() - Method in class org.objectweb.dream.queue.BufferAscendingSequenceNumberImpl.Element
 
recycle() - Method in class org.objectweb.dream.queue.BufferKeyMutexSortedImpl.ListElem
 
recycle() - Method in class org.objectweb.dream.queue.BufferKeyMutexSortedImpl.MessageList
 
recycle() - Method in class org.objectweb.dream.queue.SequenceNumberChunk
 
recycle() - Method in class org.objectweb.dream.serializator.ByteArrayChunk
 
recycle() - Method in class org.objectweb.dream.serializator.CodecInputOutputByteArray
 
recycle() - Method in class org.objectweb.dream.synchro.AbstractSemaphoreQueuedImpl.WaitQueue.WaitNode
 
registered(Object) - Method in class org.objectweb.dream.protocol.channel.ConnectionFactoryImpl.ListenTask
 
registered(Object) - Method in class org.objectweb.dream.protocol.channel.TCPIPProtocolImpl.ReaderTask
 
registered(Object) - Method in class org.objectweb.dream.protocol.messagePassing.UDPProtocolImpl.ReaderTask
 
release() - Method in class org.objectweb.dream.synchro.AbstractSemaphoreQueuedImpl
 
release(long) - Method in class org.objectweb.dream.synchro.AbstractSemaphoreQueuedImpl
 
release() - Method in interface org.objectweb.dream.synchro.Semaphore
Release a permit
release(long) - Method in interface org.objectweb.dream.synchro.Semaphore
Releases N permits.
release() - Method in class org.objectweb.dream.synchro.SemaphoreImpl
 
release(long) - Method in class org.objectweb.dream.synchro.SemaphoreImpl
 
releaseRead() - Method in interface org.objectweb.dream.synchro.ReadWriteLock
Releases the read lock.
releaseRead() - Method in class org.objectweb.dream.synchro.ReadWriteLockFIFOImpl
 
releaseWrite() - Method in interface org.objectweb.dream.synchro.ReadWriteLock
Releases the write lock.
releaseWrite() - Method in class org.objectweb.dream.synchro.ReadWriteLockFIFOImpl
 
ReliableMessagePassingProtocol - Interface in org.objectweb.dream.protocol.messagePassing
Specialized interface for reliable message passing protocol.
ReliableMessagePassingProtocolImpl - Class in org.objectweb.dream.protocol.messagePassing
Implementation of a reliable bus protocol.
ReliableMessagePassingProtocolImpl() - Constructor for class org.objectweb.dream.protocol.messagePassing.ReliableMessagePassingProtocolImpl
 
remove() - Method in class org.objectweb.dream.queue.AbstractBufferImpl
 
remove() - Method in class org.objectweb.dream.queue.BufferMatchingImpl
 
remove() - Method in interface org.objectweb.dream.queue.BufferRemove
Removes a message from the buffer.
remove(Object) - Method in class org.objectweb.dream.queue.keyed.AbstractBufferKeyedAddKeyedRemoveImpl
 
remove(Object) - Method in class org.objectweb.dream.queue.keyed.AbstractBufferKeyedRemoveImpl
 
remove(Object, Object) - Method in class org.objectweb.dream.queue.keyed.BufferAscendingKeyKeyChunkAddDoubleKeyedRemoveImpl
 
remove(Object, Object) - Method in interface org.objectweb.dream.queue.keyed.DoubleKeyedBufferRemove
Removes the message from the buffer that is associated with the specified keys.
remove(Object) - Method in interface org.objectweb.dream.queue.keyed.KeyedBufferRemove
Removes the message from the buffer that is associated with the specified key object.
removeAll() - Method in class org.objectweb.dream.queue.AbstractBufferImpl
 
removeAll() - Method in interface org.objectweb.dream.queue.BufferRemove
Removes all the available messages from the buffer.
removeAll() - Method in class org.objectweb.dream.queue.keyed.AbstractBufferKeyedAddKeyedRemoveImpl
 
removeAll() - Method in class org.objectweb.dream.queue.keyed.AbstractBufferKeyedRemoveImpl
 
removeAll(Object) - Method in class org.objectweb.dream.queue.keyed.BufferAscendingKeyKeyChunkAddDoubleKeyedRemoveImpl
 
removeAll() - Method in class org.objectweb.dream.queue.keyed.BufferAscendingKeyKeyChunkAddDoubleKeyedRemoveImpl
 
removeAll(Object) - Method in interface org.objectweb.dream.queue.keyed.DoubleKeyedBufferRemove
Removes all the available messages from the buffer that maps the specified key.
removeAll() - Method in interface org.objectweb.dream.queue.keyed.DoubleKeyedBufferRemove
Removes all the available messages from the buffer.
removeAll() - Method in interface org.objectweb.dream.queue.keyed.KeyedBufferRemove
Removes all the available messages from the buffer.
removeMessageAtFirst(BufferKeyMutexSortedImpl.MessageList) - Method in class org.objectweb.dream.queue.BufferKeyMutexSortedImpl
 
removersCount - Variable in class org.objectweb.dream.queue.BufferMatchingImpl
The number of calls that are waiting to remove matching messages.
removeServerSocket(IPExportIdentifier) - Method in interface org.objectweb.dream.protocol.channel.ConnectionFactory
Removes and closes the server socket associated with the given identifier.
removeServerSocket(IPExportIdentifier) - Method in class org.objectweb.dream.protocol.channel.ConnectionFactoryImpl
 
removeTail() - Method in class org.objectweb.dream.queue.BufferKeyMutexSortedImpl
 
removeWaitingKey(Key) - Method in interface org.objectweb.dream.pushwithreturn.WaitingKeys
Returns the WaitingKeyobject corresponding to the given key.
removeWaitingKey(Key) - Method in class org.objectweb.dream.pushwithreturn.WaitingKeysImpl
 
removeWaitingKeys(Key) - Method in interface org.objectweb.dream.pushwithreturn.WaitingKeys
Returns an iterator over WaitingKeyobjects corresponding to the keys that are associated to the given key (that is an "isAll" key).
removeWaitingKeys(Key) - Method in class org.objectweb.dream.pushwithreturn.WaitingKeysImpl
 
ReplyChunk - Class in org.objectweb.dream.protocol.rpc
 
ReplyChunk() - Constructor for class org.objectweb.dream.protocol.rpc.ReplyChunk
Default constructor.
reset() - Method in class org.objectweb.dream.trash.TrashImpl
 
reset() - Method in interface org.objectweb.dream.trash.TrashMonitoring
Resets the number of deleted messages.
resolveDestination(Message) - Method in interface org.objectweb.dream.channel.DestinationResolver
Return the ExportIdentifier which identifies the destination of the given message.
resolveDestination(Message) - Method in class org.objectweb.dream.channel.DestinationResolverChunkBasedImpl
 
RETRANSMIT_PERIOD_HINT_KEY - Static variable in interface org.objectweb.dream.protocol.messagePassing.ReliableMessagePassingProtocol
The hint key used to specify the retransmission period (in ms).
RetryPushImpl - Class in org.objectweb.dream.exception
This component forwards incoming messages, if a PushExceptionis catched, the message is pushed again.
RetryPushImpl() - Constructor for class org.objectweb.dream.exception.RetryPushImpl
 
ROUTE_ID - Static variable in interface org.objectweb.dream.protocol.channel.MultiplexExportProtocol
Key name for value used by the Protocol.createExportIdentifier(java.util.Map, org.objectweb.dream.protocol.ExportIdentifier[]) method to specify the route identifier used to created the MultiplexExportIdentifier The value associated with this key must be a Number
RouterChunkNameAttributeController - Interface in org.objectweb.dream.router
Chunk name router attribute controller interface.
RouterChunkNameImpl - Class in org.objectweb.dream.router
A basic router implementation with two outputs : out-push-with-chunk and out-push-without-chunk.
RouterChunkNameImpl() - Constructor for class org.objectweb.dream.router.RouterChunkNameImpl
 
RouterRandomImpl - Class in org.objectweb.dream.router
This router randomly chooses one of its outputs.
RouterRandomImpl() - Constructor for class org.objectweb.dream.router.RouterRandomImpl
 
RouterRoundRobinImpl - Class in org.objectweb.dream.router
This router implements a round-robin choice of its outputs.
RouterRoundRobinImpl() - Constructor for class org.objectweb.dream.router.RouterRoundRobinImpl
 
RPCException - Exception in org.objectweb.dream.protocol.rpc
 
RPCException() - Constructor for exception org.objectweb.dream.protocol.rpc.RPCException
 
RPCException(String) - Constructor for exception org.objectweb.dream.protocol.rpc.RPCException
 
RPCException(String, Throwable) - Constructor for exception org.objectweb.dream.protocol.rpc.RPCException
Creates an exception caused by another exception.
RPCException(Throwable) - Constructor for exception org.objectweb.dream.protocol.rpc.RPCException
Creates an exception caused by another exception.
RPCProtocol - Interface in org.objectweb.dream.protocol.rpc
RPC Protocol. very early version !!!

S

SaxXercesParser - Class in org.objectweb.dream.xml
Extention of the SAXParser to give it a Fractal component behavior.
SaxXercesParser() - Constructor for class org.objectweb.dream.xml.SaxXercesParser
 
searchMessagesToBeReturned() - Method in class org.objectweb.dream.queue.BufferMatchingImpl
If there are waiting removers (i.e., if BufferMatchingImpl.removersCount > 0 or if BufferMatchingImpl.gettersCount > 0), iterate over the received messages, and test each message by calling MessageMatcher.acceptMessage(Message) using the bound matcher, until at most enough matching messages for waiting removers and getters have been found.
Semaphore - Interface in org.objectweb.dream.synchro
A counting semaphore component maintains a set of permits.
SemaphoreAttributeController - Interface in org.objectweb.dream.synchro
An attribute controller allowing setting the initial number of permits of the semaphore.
SemaphoreFIFOImpl - Class in org.objectweb.dream.synchro
FIFO implementation of the Semaphoreinterface.
SemaphoreFIFOImpl() - Constructor for class org.objectweb.dream.synchro.SemaphoreFIFOImpl
Constructor.
SemaphoreFIFOImpl.FIFOWaitQueue - Class in org.objectweb.dream.synchro
Simple linked list queue used in FIFOSemaphore.
SemaphoreFIFOImpl.FIFOWaitQueue() - Constructor for class org.objectweb.dream.synchro.SemaphoreFIFOImpl.FIFOWaitQueue
 
SemaphoreImpl - Class in org.objectweb.dream.synchro
Basic implementation of the Semaphoreinterface.
SemaphoreImpl() - Constructor for class org.objectweb.dream.synchro.SemaphoreImpl
 
sendTask - Variable in class org.objectweb.dream.protocol.messagePassing.BufferedMessagePassingProtocolImpl.Session
 
SequenceNumberChunk - Class in org.objectweb.dream.queue
Chunk interface for messages that have to be sequentially ordered.
SequenceNumberChunk() - Constructor for class org.objectweb.dream.queue.SequenceNumberChunk
Default constructor
SequenceNumberChunk(long) - Constructor for class org.objectweb.dream.queue.SequenceNumberChunk
 
Serializator - Interface in org.objectweb.dream.serializator
A serializator defines a method serialize that takes a message as parameter and returns a byte array representation of the message.
SerializatorImpl - Class in org.objectweb.dream.serializator
Basic implementation of the Serializator interface.
SerializatorImpl() - Constructor for class org.objectweb.dream.serializator.SerializatorImpl
 
serializatorItf - Variable in class org.objectweb.dream.protocol.messagePassing.SerializatorMessagePassingProtocolImpl
 
serializatorItf - Variable in class org.objectweb.dream.serializator.PushPushSerializatorImpl
 
SerializatorMessagePassingProtocolImpl - Class in org.objectweb.dream.protocol.messagePassing
Message passing protocol which serializes outgoing messages and de-serializes incoming messages.
SerializatorMessagePassingProtocolImpl() - Constructor for class org.objectweb.dream.protocol.messagePassing.SerializatorMessagePassingProtocolImpl
 
SerializatorMessagePassingProtocolImpl.Session - Class in org.objectweb.dream.protocol.messagePassing
 
SerializatorMessagePassingProtocolImpl.Session(IncomingPush) - Constructor for class org.objectweb.dream.protocol.messagePassing.SerializatorMessagePassingProtocolImpl.Session
 
serialize(Message) - Method in interface org.objectweb.dream.serializator.Serializator
Serializes the given message and returns a byte array representation of the message.
serialize(Message) - Method in class org.objectweb.dream.serializator.SerializatorImpl
 
sessionError(TCPIPProtocolImpl.Session, Exception) - Method in class org.objectweb.dream.protocol.channel.TCPIPProtocolImpl
 
sessionFactories - Variable in class org.objectweb.dream.protocol.channel.ConnectionFactoryImpl
 
sessions - Variable in class org.objectweb.dream.protocol.channel.TCPIPProtocolImpl
 
SET_REACTOR_THREAD_ITF_NAME - Static variable in interface org.objectweb.dream.protocol.atomicity.SetReactorThread
the default name of this interface
setAvailable(ConnectionFactoryImpl.SessionFactory) - Method in class org.objectweb.dream.protocol.channel.ConnectionFactoryImpl
 
setAvailable(TCPIPProtocolImpl.Session) - Method in class org.objectweb.dream.protocol.channel.TCPIPProtocolImpl
 
setAvailable(UDPProtocolImpl.Session) - Method in class org.objectweb.dream.protocol.messagePassing.UDPProtocolImpl
 
setByteArray(byte[]) - Method in class org.objectweb.dream.serializator.ByteArrayChunk
Sets the byte array contained in this chunk.
setChunkName(String) - Method in interface org.objectweb.dream.channel.AddIPExportIdChunkAttributeController
Sets the name of the added chunk.
setChunkName(String) - Method in class org.objectweb.dream.channel.AddIPExportIdChunkImpl
 
setChunkName(String) - Method in interface org.objectweb.dream.router.RouterChunkNameAttributeController
Sets the chunk name used by chunk name routeur.
setChunkName(String) - Method in class org.objectweb.dream.router.RouterChunkNameImpl
 
setConnectionRetry(int) - Method in interface org.objectweb.dream.protocol.channel.TCPIPProtocolAttributeController
Sets the default value of the TCPIPProtocol.CONNECTION_RETRY hint.
setConnectionRetry(int) - Method in class org.objectweb.dream.protocol.channel.TCPIPProtocolImpl
 
setDeleteChunk(boolean) - Method in interface org.objectweb.dream.channel.DestinationResolverChunkBasedAttributeController
Set if the destination chunk must be deleted from the message.
setDeleteChunk(boolean) - Method in class org.objectweb.dream.channel.DestinationResolverChunkBasedImpl
 
setDestinationChunkName(String) - Method in interface org.objectweb.dream.channel.DestinationResolverChunkBasedAttributeController
Set the name of the chunks that contains the destination identification of the message.
setDestinationChunkName(String) - Method in class org.objectweb.dream.channel.DestinationResolverChunkBasedImpl
 
setException(Exception) - Method in class org.objectweb.dream.protocol.ExceptionChunk
Sets the exception.
setExportIdentifier(ExportIdentifier) - Method in class org.objectweb.dream.protocol.ExportIdentifierChunk
 
setFragmentationId(int) - Method in class org.objectweb.dream.protocol.messagePassing.FragmentationChunk
Sets the fragmentation id.
setFragmentationSize(int) - Method in interface org.objectweb.dream.protocol.messagePassing.FragmentationAttributeController
Sets the fragmentation size.
setFragmentationSize(int) - Method in class org.objectweb.dream.protocol.messagePassing.FragmentationProtocolImpl
 
setFragmentId(int) - Method in class org.objectweb.dream.protocol.messagePassing.FragmentationChunk
Sets the fragment's id.
setFramentFrom(ExportIdentifier) - Method in class org.objectweb.dream.protocol.messagePassing.FragmentationChunk
Sets the identifier of the sender of the fragment.
setFrom(int) - Method in class org.objectweb.dream.protocol.bus.logicalClock.LogicalClockChunk
Sets the address of the process that emit this chunk.
setFromChunkName(String) - Method in interface org.objectweb.dream.channel.ChannelInAttributeController
Sets the name of the chunk that should be added in every received messages.
setFromChunkName(String) - Method in class org.objectweb.dream.channel.ChannelInOutImpl
 
setHostname(String) - Method in interface org.objectweb.dream.channel.AddIPExportIdChunkAttributeController
Sets the hostname put in chunks.
setHostname(String) - Method in class org.objectweb.dream.channel.AddIPExportIdChunkImpl
 
setInitialNumberOfThreads(int) - Method in class org.objectweb.dream.pump.PumpSynchronizedImpl
 
setInitialPermits(long) - Method in interface org.objectweb.dream.synchro.SemaphoreAttributeController
Sets the initial number of permits of the semaphore.
setInitialPermits(long) - Method in class org.objectweb.dream.synchro.SemaphoreImpl
 
setInvocationId(long) - Method in class org.objectweb.dream.protocol.rpc.InvocationChunk
 
setInvocationId(long) - Method in class org.objectweb.dream.protocol.rpc.ReplyChunk
 
setInvoker(Invoker) - Method in interface org.objectweb.dream.protocol.rpc.Stub
 
setKey(Key) - Method in class org.objectweb.dream.pushwithreturn.KeyChunk
Sets the key of this chunk.
setKey(Key) - Method in class org.objectweb.dream.pushwithreturn.WaitingKey
Sets the key associated to this waiting key.
setKeyChunkName(String) - Method in class org.objectweb.dream.queue.keyed.BufferAscendingKeyKeyChunkAddDoubleKeyedRemoveImpl
 
setKeyChunkName(String) - Method in interface org.objectweb.dream.queue.keyed.BufferAttributeControllerKeyChunkAdd
Sets the name of the chunk that is used as a key.
setKeyChunkName(String) - Method in class org.objectweb.dream.queue.keyed.BufferKeyChunkAddKeyedRemoveImpl
 
setLastInSequence(long) - Method in class org.objectweb.dream.queue.BufferAscendingSequenceNumberImpl
 
setLastInSequence(long) - Method in interface org.objectweb.dream.queue.BufferAttributeControllerAscendingSequenceNumber
Sets the sequence number of the last delivered message.
setLastInSequence(Object, long) - Method in class org.objectweb.dream.queue.keyed.BufferAscendingSequenceNumberKeyedAddKeyedRemoveImpl
 
setLastInSequence(Object, long) - Method in interface org.objectweb.dream.queue.keyed.BufferAttributeControllerAscendingSequenceNumberKeyedAdd
Sets the sequence number of the last delivered message for the given key.
setLogicalClock(Object) - Method in class org.objectweb.dream.protocol.bus.logicalClock.LogicalClockChunk
Sets the logical clock of this chunk
setMaxCapacity(int) - Method in class org.objectweb.dream.queue.AbstractBufferImpl
 
setMaxCapacity(int) - Method in interface org.objectweb.dream.queue.BufferAttributeController
Sets the maximum capacity of the queue.
setMaxCapacity(int) - Method in class org.objectweb.dream.queue.keyed.AbstractBufferKeyedAddKeyedRemoveImpl
 
setMaxCapacity(int) - Method in class org.objectweb.dream.queue.keyed.AbstractBufferKeyedRemoveImpl
 
setMaxCapacity(int) - Method in class org.objectweb.dream.queue.keyed.BufferAscendingKeyKeyChunkAddDoubleKeyedRemoveImpl
 
setMaxCapacity(int) - Method in class org.objectweb.dream.queue.PushPullQueueFastImpl
 
setMaxCapacity(int) - Method in class org.objectweb.dream.queue.PushPullQueueNotSynchronizedImpl
 
setMessage(Message) - Method in class org.objectweb.dream.pushwithreturn.WaitingKey
Sets the message associated to this key.
setMethodId(int) - Method in class org.objectweb.dream.protocol.rpc.InvocationChunk
 
setMultiplexChunkName(String) - Method in class org.objectweb.dream.protocol.channel.MultiplexBindProtocolImpl
 
setMultiplexChunkName(String) - Method in interface org.objectweb.dream.protocol.channel.MultiplexProtocolAttributeController
Sets the value of the multiplexChunkName attribute.
setNbMaxSession(int) - Method in interface org.objectweb.dream.protocol.messagePassing.MessagePassingOverChannelAttributeController
Sets the nbMaxSession attribute value.
setNbMaxSession(int) - Method in class org.objectweb.dream.protocol.messagePassing.MessagePassingOverChannelImpl
 
setNbMessagesToAggregate(int) - Method in interface org.objectweb.dream.aggregator.PullPullAggregatorFixedNumberAttributeController
Sets the number of messages that must be aggregated.
setNbMessagesToAggregate(int) - Method in class org.objectweb.dream.aggregator.PullPullAggregatorFixedNumberImpl
 
setNumFrags(int) - Method in class org.objectweb.dream.protocol.messagePassing.FragmentationChunk
Sets the number of fragments that make the message this fragment is part of.
setOverflowPolicy(String) - Method in interface org.objectweb.dream.queue.PushQueueAttributeController
Sets the overflow policy.
setParameters(Object[]) - Method in class org.objectweb.dream.protocol.rpc.InvocationChunk
 
setPeriod(long) - Method in interface org.objectweb.dream.pump.PumpAttributeControllerPeriodic
Sets the pump period.
setPeriod(long) - Method in class org.objectweb.dream.pump.PumpPeriodicSynchronizedImpl
 
setPort(int) - Method in interface org.objectweb.dream.channel.AddIPExportIdChunkAttributeController
Sets the port number put in chunks.
setPort(int) - Method in class org.objectweb.dream.channel.AddIPExportIdChunkImpl
 
setPort(int) - Method in interface org.objectweb.dream.protocol.channel.TCPIPProtocolAttributeController
Sets the default value of the TCPIPProtocol.PORT hint.
setPort(int) - Method in class org.objectweb.dream.protocol.channel.TCPIPProtocolImpl
 
setPort(int) - Method in interface org.objectweb.dream.protocol.messagePassing.UDPProtocolAttributeController
Sets the default value of the UDPProtocol.PORT hint.
setPort(int) - Method in class org.objectweb.dream.protocol.messagePassing.UDPProtocolImpl
 
setPullEmptyMessagePolicy(boolean) - Method in interface org.objectweb.dream.aggregator.PullPullAggregatorWhileNotNullAttributeController
Sets the pullEmptyMessage policy.
setPullEmptyMessagePolicy(boolean) - Method in class org.objectweb.dream.aggregator.PullPullAggregatorWhileNotNullImpl
 
setPushNullPolicy(boolean) - Method in class org.objectweb.dream.pump.AbstractPumpSynchronizedImpl
 
setPushNullPolicy(boolean) - Method in interface org.objectweb.dream.pump.PumpAttributeController
Sets the PushNullPolicy.
setReactorThread(Thread) - Method in class org.objectweb.dream.protocol.atomicity.AtomicRouterImpl
 
SetReactorThread - Interface in org.objectweb.dream.protocol.atomicity
Component interface used to give the thread that is executing a reaction.
setReactorThread(Thread) - Method in interface org.objectweb.dream.protocol.atomicity.SetReactorThread
Gives the thread that is executing a reaction.
setRecvBufferSize(int) - Method in interface org.objectweb.dream.protocol.messagePassing.UDPProtocolAttributeController
Sets the size of buffer used in DatagramPacket when receiving message.
setRecvBufferSize(int) - Method in class org.objectweb.dream.protocol.messagePassing.UDPProtocolImpl
 
setReference(Reference<? extends Recyclable>) - Method in class org.objectweb.dream.pushwithreturn.KeyInteger
 
setReference(Reference<? extends Recyclable>) - Method in class org.objectweb.dream.pushwithreturn.WaitingKey
 
setReference(Reference<? extends Recyclable>) - Method in class org.objectweb.dream.queue.BufferAscendingSequenceNumberImpl.Element
 
setReference(Reference<? extends Recyclable>) - Method in class org.objectweb.dream.queue.BufferKeyMutexSortedImpl.ListElem
 
setReference(Reference<? extends Recyclable>) - Method in class org.objectweb.dream.queue.BufferKeyMutexSortedImpl.MessageList
 
setReference(Reference<? extends Recyclable>) - Method in class org.objectweb.dream.synchro.AbstractSemaphoreQueuedImpl.WaitQueue.WaitNode
 
setReply(Object) - Method in class org.objectweb.dream.protocol.rpc.ReplyChunk
 
setReturnMessage(Message) - Method in class org.objectweb.dream.pushwithreturn.WaitingKey
Sets the return message.
setReturnMessageReceived(boolean) - Method in class org.objectweb.dream.pushwithreturn.WaitingKey
Sets the returnMessageReceived boolean to the specifed value.
setRouteId(short) - Method in class org.objectweb.dream.protocol.channel.BindChunk
 
setRouteId(short) - Method in class org.objectweb.dream.protocol.channel.CloseChunk
 
setRouteId(short) - Method in class org.objectweb.dream.protocol.channel.MultiplexChunk
 
setSequenceNumber(long) - Method in class org.objectweb.dream.queue.SequenceNumberChunk
Sets the sequence number of this chunk.
setSocketOption(Socket) - Method in class org.objectweb.dream.protocol.channel.TCPIPProtocolImpl
 
setSoLinger(int) - Method in interface org.objectweb.dream.protocol.channel.TCPIPProtocolAttributeController
Sets the default value of the TCPIPProtocol.SO_LINGER hint.
setSoLinger(int) - Method in class org.objectweb.dream.protocol.channel.TCPIPProtocolImpl
 
setSortingChunkName(String) - Method in class org.objectweb.dream.queue.BufferAscendingSequenceNumberImpl
 
setSortingChunkName(String) - Method in interface org.objectweb.dream.queue.BufferAttributeControllerSorted
Sets the name of the chunk to be used to sort messages.
setSortingChunkName(String) - Method in class org.objectweb.dream.queue.keyed.BufferAscendingSequenceNumberKeyedAddKeyedRemoveImpl
 
setSoTimeout(int) - Method in interface org.objectweb.dream.protocol.channel.TCPIPProtocolAttributeController
Sets the default value of the TCPIPProtocol.SO_TIMEOUT hint.
setSoTimeout(int) - Method in class org.objectweb.dream.protocol.channel.TCPIPProtocolImpl
 
setStopOnPullExceptionPolicy(boolean) - Method in class org.objectweb.dream.pump.AbstractPumpSynchronizedImpl
 
setStopOnPullExceptionPolicy(boolean) - Method in interface org.objectweb.dream.pump.PumpAttributeController
Sets the StopOnPullExceptionPolicy.
setStopOnPushExceptionPolicy(boolean) - Method in class org.objectweb.dream.pump.AbstractPumpSynchronizedImpl
 
setStopOnPushExceptionPolicy(boolean) - Method in interface org.objectweb.dream.pump.PumpAttributeController
Sets the StopOnPushExceptionPolicy.
setStubClass(Class) - Method in class org.objectweb.dream.protocol.rpc.StubClassChunk
 
setTcpNoDelay(boolean) - Method in interface org.objectweb.dream.protocol.channel.TCPIPProtocolAttributeController
Sets the default value of the TCPIPProtocol.TCP_NO_DELAY hint.
setTcpNoDelay(boolean) - Method in class org.objectweb.dream.protocol.channel.TCPIPProtocolImpl
 
setThreadPoolManager(ThreadPoolManager) - Method in class org.objectweb.dream.protocol.channel.TCPIPProtocolImpl
 
setThreadPoolManager(ThreadPoolManager) - Method in class org.objectweb.dream.protocol.messagePassing.UDPProtocolImpl
 
setThrowable(Throwable) - Method in class org.objectweb.dream.protocol.rpc.ReplyChunk
 
setTimeOut(long) - Method in interface org.objectweb.dream.cache.CacheAttributeController
Sets the time out of the cache component.
setTimeOut(long) - Method in class org.objectweb.dream.cache.CacheImpl
 
SetTimeStamp - Interface in org.objectweb.dream.time
This interface defines a method to set a time stamp.
setTimeStamp() - Method in interface org.objectweb.dream.time.SetTimeStamp
Sets the time stamp.
setTimeStamp() - Method in class org.objectweb.dream.time.TimeStampImpl
 
setToBeRemovedChunkName(String) - Method in interface org.objectweb.dream.serializator.PushPushSerializatorAttributeController
Returns the name of the chunk that must not been serialized.
setToBeRemovedChunkName(String) - Method in class org.objectweb.dream.serializator.PushPushSerializatorImpl
 
setUsePool(boolean) - Method in class org.objectweb.dream.pump.PumpSynchronizedImpl
 
signal() - Method in class org.objectweb.dream.synchro.AbstractSemaphoreQueuedImpl.WaitQueue.WaitNode
 
signal() - Method in interface org.objectweb.dream.synchro.Condition
Notify a waiting thread.
signal() - Method in class org.objectweb.dream.synchro.ConditionImpl
 
signal() - Method in class org.objectweb.dream.synchro.ConditionReEntrantImpl
 
signalAll() - Method in interface org.objectweb.dream.synchro.Condition
Notify all waiting threads *
signalAll() - Method in class org.objectweb.dream.synchro.ConditionImpl
 
signalAll() - Method in class org.objectweb.dream.synchro.ConditionReEntrantImpl
 
silentClose(TCPIPProtocolImpl.Session) - Method in class org.objectweb.dream.protocol.channel.TCPIPProtocolImpl
 
silentClose(Socket) - Method in class org.objectweb.dream.protocol.channel.TCPIPProtocolImpl
 
size - Variable in class org.objectweb.dream.protocol.bus.logicalClock.FIFOClock
 
size - Variable in class org.objectweb.dream.protocol.bus.logicalClock.MatrixClock
 
size - Variable in class org.objectweb.dream.queue.PushPullQueueFastImpl
 
size - Variable in class org.objectweb.dream.queue.PushPullQueueNotSynchronizedImpl
 
Skeleton - Interface in org.objectweb.dream.protocol.rpc
 
SO_LINGER - Static variable in interface org.objectweb.dream.protocol.channel.TCPIPProtocol
This integer hint, used either at export or bind time, can specify the SO_LINGER parameter of created sockets.
SO_TIMEOUT - Static variable in interface org.objectweb.dream.protocol.channel.TCPIPProtocol
This integer hint, used either at export or bind time, can specify the SO_TIMEOUT parameter of created sockets.
soLinger - Variable in class org.objectweb.dream.protocol.channel.TCPIPProtocolImpl
 
sortingChunkName - Variable in class org.objectweb.dream.queue.BufferAscendingSequenceNumberImpl
The name under which the chunk containing the sequence number is registered.
soTimeout - Variable in class org.objectweb.dream.protocol.channel.TCPIPProtocolImpl
 
stamp - Variable in class org.objectweb.dream.protocol.bus.logicalClock.FIFOClock
 
stamp(Message, int) - Method in class org.objectweb.dream.protocol.bus.logicalClock.FIFOClock
 
stamp(Message, int) - Method in interface org.objectweb.dream.protocol.bus.logicalClock.LogicalClock
Stamps the given message.
stamp(Message, int) - Method in class org.objectweb.dream.protocol.bus.logicalClock.MatrixClock
 
startFc() - Method in class org.objectweb.dream.channel.ChannelInOutImpl
 
startFc() - Method in class org.objectweb.dream.channel.ChannelOutImpl
 
startFc() - Method in class org.objectweb.dream.protocol.bus.logicalClock.MatrixClock
 
startFc() - Method in class org.objectweb.dream.pump.PumpSynchronizedImpl
 
stopOnPullExceptionPolicy - Variable in class org.objectweb.dream.pump.AbstractPumpSynchronizedImpl
 
stopOnPushExceptionPolicy - Variable in class org.objectweb.dream.pump.AbstractPumpSynchronizedImpl
 
storedMessagesCount - Variable in class org.objectweb.dream.queue.AbstractBufferImpl
The count of stored messages into the buffer.
storedMessagesCount - Variable in class org.objectweb.dream.queue.keyed.AbstractBufferKeyedAddKeyedRemoveImpl
The count of stored messages into the buffer.
storedMessagesCount - Variable in class org.objectweb.dream.queue.keyed.AbstractBufferKeyedRemoveImpl
The count of stored messages into the buffer.
storedMessagesCount - Variable in class org.objectweb.dream.queue.keyed.BufferAscendingKeyKeyChunkAddDoubleKeyedRemoveImpl
The count of stored messages into the buffer.
Stub - Interface in org.objectweb.dream.protocol.rpc
 
StubClassChunk - Class in org.objectweb.dream.protocol.rpc
 
StubClassChunk() - Constructor for class org.objectweb.dream.protocol.rpc.StubClassChunk
Default constructor.
StubClassChunk(Class) - Constructor for class org.objectweb.dream.protocol.rpc.StubClassChunk
 
SynchronizerAsynchronousImpl - Class in org.objectweb.dream.pushwithreturn
This component has one Pushinput, one Pushoutput, and one Push1input.
SynchronizerAsynchronousImpl() - Constructor for class org.objectweb.dream.pushwithreturn.SynchronizerAsynchronousImpl
 
SynchronizerSynchronousImpl - Class in org.objectweb.dream.pushwithreturn
This component handles calls to the PushWithReturn.pushWithReturn(Message)method (i.e. outgoing messages).
SynchronizerSynchronousImpl() - Constructor for class org.objectweb.dream.pushwithreturn.SynchronizerSynchronousImpl
 

T

tail - Variable in class org.objectweb.dream.synchro.SemaphoreFIFOImpl.FIFOWaitQueue
 
TCP_NO_DELAY - Static variable in interface org.objectweb.dream.protocol.channel.TCPIPProtocol
This boolean hint, used either at export or bind time, can specify if the Nagle's algorithm is disabled.
TCPIPLocalAccessManagerImpl - Class in org.objectweb.dream.protocol.bus
Local access manager specialized for lower TCP/IP protocol.
TCPIPLocalAccessManagerImpl() - Constructor for class org.objectweb.dream.protocol.bus.TCPIPLocalAccessManagerImpl
 
TCPIPProtocol - Interface in org.objectweb.dream.protocol.channel
Defines constants used as hints key that can be given to a TCP/IP protocol.
TCPIPProtocolAttributeController - Interface in org.objectweb.dream.protocol.channel
Attribute controller for TCP/IP protocol.
TCPIPProtocolImpl - Class in org.objectweb.dream.protocol.channel
Implementation of the TCP/IP protocol.
TCPIPProtocolImpl() - Constructor for class org.objectweb.dream.protocol.channel.TCPIPProtocolImpl
 
TCPIPProtocolImpl.ReaderTask - Class in org.objectweb.dream.protocol.channel
 
TCPIPProtocolImpl.ReaderTask() - Constructor for class org.objectweb.dream.protocol.channel.TCPIPProtocolImpl.ReaderTask
 
TCPIPProtocolImpl.Session - Class in org.objectweb.dream.protocol.channel
 
tcpNoDelay - Variable in class org.objectweb.dream.protocol.channel.TCPIPProtocolImpl
 
testRecvMatrix(Object, int) - Method in class org.objectweb.dream.protocol.bus.logicalClock.MatrixClock
 
testRecvMessage(Message) - Method in class org.objectweb.dream.protocol.bus.logicalClock.FIFOClock
 
testRecvMessage(Message) - Method in interface org.objectweb.dream.protocol.bus.logicalClock.LogicalClock
Test if the given message can be delivered.
testRecvMessage(Message) - Method in class org.objectweb.dream.protocol.bus.logicalClock.MatrixClock
 
threadPoolManager - Variable in class org.objectweb.dream.protocol.channel.ConnectionFactoryImpl
 
threadPoolManager - Variable in class org.objectweb.dream.protocol.channel.TCPIPProtocolImpl
 
timedLock(long) - Method in interface org.objectweb.dream.synchro.Mutex
Tries to acquire the mutex.
timedLock(long) - Method in class org.objectweb.dream.synchro.MutexImpl
 
timedLock(long) - Method in class org.objectweb.dream.synchro.MutexReEntrantImpl
 
timedwait(long) - Method in interface org.objectweb.dream.synchro.Condition
Wait for at most msecs for notification.
timedwait(long) - Method in class org.objectweb.dream.synchro.ConditionImpl
 
timedwait(long) - Method in class org.objectweb.dream.synchro.ConditionReEntrantImpl
 
timeOut - Variable in class org.objectweb.dream.cache.CacheImpl
The cache time out.
TimeStampImpl - Class in org.objectweb.dream.time
Basic implementation of a time stamp component.
TimeStampImpl() - Constructor for class org.objectweb.dream.time.TimeStampImpl
 
toBeRemovedChunkName - Variable in class org.objectweb.dream.serializator.PushPushSerializatorImpl
 
toString() - Method in class org.objectweb.dream.protocol.channel.MultiplexExportIdentifier
 
toString() - Method in class org.objectweb.dream.protocol.IPExportIdentifier
 
toString() - Method in class org.objectweb.dream.protocol.messagePassing.FragmentationChunk
 
transfertStateTo(LogicalClockChunk) - Method in class org.objectweb.dream.protocol.bus.logicalClock.LogicalClockChunk
 
transfertStateTo(BindChunk) - Method in class org.objectweb.dream.protocol.channel.BindChunk
 
transfertStateTo(CloseChunk) - Method in class org.objectweb.dream.protocol.channel.CloseChunk
 
transfertStateTo(MultiplexChunk) - Method in class org.objectweb.dream.protocol.channel.MultiplexChunk
 
transfertStateTo(ExceptionChunk) - Method in class org.objectweb.dream.protocol.ExceptionChunk
 
transfertStateTo(ExportIdentifierChunk) - Method in class org.objectweb.dream.protocol.ExportIdentifierChunk
 
transfertStateTo(FragmentationChunk) - Method in class org.objectweb.dream.protocol.messagePassing.FragmentationChunk
 
transfertStateTo(InvocationChunk) - Method in class org.objectweb.dream.protocol.rpc.InvocationChunk
 
transfertStateTo(ReplyChunk) - Method in class org.objectweb.dream.protocol.rpc.ReplyChunk
 
transfertStateTo(StubClassChunk) - Method in class org.objectweb.dream.protocol.rpc.StubClassChunk
 
transfertStateTo(KeyChunk) - Method in class org.objectweb.dream.pushwithreturn.KeyChunk
 
transfertStateTo(SequenceNumberChunk) - Method in class org.objectweb.dream.queue.SequenceNumberChunk
 
transfertStateTo(ByteArrayChunk) - Method in class org.objectweb.dream.serializator.ByteArrayChunk
 
TrashImpl - Class in org.objectweb.dream.trash
This component is a trash: received messages are deleted.
TrashImpl() - Constructor for class org.objectweb.dream.trash.TrashImpl
 
TrashMonitoring - Interface in org.objectweb.dream.trash
Interface that allows monitoring Trash components.
tryAdd(Message) - Method in class org.objectweb.dream.queue.AbstractBufferImpl
 
tryAdd(Message) - Method in interface org.objectweb.dream.queue.BufferAdd
Adds the specified message to the buffer.
tryAdd(Message, Object) - Method in class org.objectweb.dream.queue.keyed.AbstractBufferKeyedAddKeyedRemoveImpl
 
tryAdd(Message) - Method in class org.objectweb.dream.queue.keyed.AbstractBufferKeyedRemoveImpl
 
tryAdd(Message, Object) - Method in class org.objectweb.dream.queue.keyed.BufferAscendingKeyKeyChunkAddDoubleKeyedRemoveImpl
 
tryAdd(Message, Object) - Method in interface org.objectweb.dream.queue.keyed.KeyedBufferAdd
Adds the specified message to the buffer, associated with the specified key object.
tryGet() - Method in class org.objectweb.dream.queue.AbstractBufferImpl
 
tryGet() - Method in interface org.objectweb.dream.queue.BufferRemove
Gets a message from the buffer.
tryGet(Object) - Method in class org.objectweb.dream.queue.keyed.AbstractBufferKeyedAddKeyedRemoveImpl
 
tryGet(Object) - Method in class org.objectweb.dream.queue.keyed.AbstractBufferKeyedRemoveImpl
 
tryGet(Object, Object) - Method in class org.objectweb.dream.queue.keyed.BufferAscendingKeyKeyChunkAddDoubleKeyedRemoveImpl
 
tryGet(Object, Object) - Method in interface org.objectweb.dream.queue.keyed.DoubleKeyedBufferRemove
Gets the message from the buffer that is associated with the specified keys.
tryGet(Object) - Method in interface org.objectweb.dream.queue.keyed.KeyedBufferRemove
Gets the message from the buffer that is associated with the specified key object.
tryRemove() - Method in class org.objectweb.dream.queue.AbstractBufferImpl
 
tryRemove() - Method in interface org.objectweb.dream.queue.BufferRemove
Removes a message from the buffer.
tryRemove(Object) - Method in class org.objectweb.dream.queue.keyed.AbstractBufferKeyedAddKeyedRemoveImpl
 
tryRemove(Object) - Method in class org.objectweb.dream.queue.keyed.AbstractBufferKeyedRemoveImpl
 
tryRemove(Object, Object) - Method in class org.objectweb.dream.queue.keyed.BufferAscendingKeyKeyChunkAddDoubleKeyedRemoveImpl
 
tryRemove(Object, Object) - Method in interface org.objectweb.dream.queue.keyed.DoubleKeyedBufferRemove
Removes the message from the buffer that is associated with the specified keys.
tryRemove(Object) - Method in interface org.objectweb.dream.queue.keyed.KeyedBufferRemove
Removes the message from the buffer that is associated with the specified key object.

U

UDPProtocol - Interface in org.objectweb.dream.protocol.messagePassing
Defines constants used as hints key that can be given to a UDP protocol.
UDPProtocolAttributeController - Interface in org.objectweb.dream.protocol.messagePassing
Attribute controller interface of UDP protocol implementation
UDPProtocolImpl - Class in org.objectweb.dream.protocol.messagePassing
Implementation of the UDP protocol.
UDPProtocolImpl() - Constructor for class org.objectweb.dream.protocol.messagePassing.UDPProtocolImpl
 
UDPProtocolImpl.ReaderTask - Class in org.objectweb.dream.protocol.messagePassing
 
UDPProtocolImpl.ReaderTask() - Constructor for class org.objectweb.dream.protocol.messagePassing.UDPProtocolImpl.ReaderTask
 
UDPProtocolImpl.Session - Class in org.objectweb.dream.protocol.messagePassing
 
unbindFc(String) - Method in class org.objectweb.dream.aggregator.PullPullAggregatorCollectionInputImpl
 
unbindFc(String) - Method in class org.objectweb.dream.router.AbstractRouterImpl
 
unbindFc(String) - Method in class org.objectweb.dream.xml.SaxXercesParser
 
unexport(ExportIdentifier) - Method in interface org.objectweb.dream.protocol.channel.ChannelProtocol
Closes the export of a previously exported ChannelFactory interface.
unexport(ExportIdentifier) - Method in class org.objectweb.dream.protocol.channel.MultiplexBindProtocolImpl
 
unexport(ExportIdentifier) - Method in class org.objectweb.dream.protocol.channel.MultiplexExportProtocolImpl
 
unexport(ExportIdentifier) - Method in class org.objectweb.dream.protocol.channel.TCPIPProtocolImpl
 
unlock() - Method in interface org.objectweb.dream.synchro.Mutex
Releases the mutex.
unlock() - Method in class org.objectweb.dream.synchro.MutexImpl
 
unlock() - Method in class org.objectweb.dream.synchro.MutexReEntrantImpl
 
unlockKey() - Method in class org.objectweb.dream.queue.BufferKeyMutexSortedImpl
 
UnlockKey - Interface in org.objectweb.dream.queue
Interface provided by the BufferKeyMutexSortedImpl component to unlock the key of the calling thread.
unlockKey() - Method in interface org.objectweb.dream.queue.UnlockKey
Unlock the key of the calling thread.
upperIncomingPush - Variable in class org.objectweb.dream.protocol.bus.BusProtocolImpl.Session
 
upperIncomingPush - Variable in class org.objectweb.dream.protocol.bus.logicalClock.ProtocolImpl.Session
 
upperIncomingPush - Variable in class org.objectweb.dream.protocol.messagePassing.BufferedMessagePassingProtocolImpl.Session
 
usePool - Variable in class org.objectweb.dream.pump.PumpSynchronizedImpl
 
Util - Class in org.objectweb.dream.protocol
Utility methods.

W

WAIT_TO_DELIVER - Static variable in interface org.objectweb.dream.protocol.bus.logicalClock.LogicalClock
the value returned by LogicalClock.testRecvMessage(Message)if there is other messages that must be delivered before this one.
WAITING_PULL_ITF_NAME - Static variable in class org.objectweb.dream.protocol.atomicity.AtomicReactorImpl
The name of the client interface used to retrieve notifications emitted during reaction.
WaitingKey - Class in org.objectweb.dream.pushwithreturn
This class represents a waiting key.
WaitingKey() - Constructor for class org.objectweb.dream.pushwithreturn.WaitingKey
 
WaitingKeys - Interface in org.objectweb.dream.pushwithreturn
This component manages WaitingKeyobjects.
WaitingKeysImpl - Class in org.objectweb.dream.pushwithreturn
TODO
WaitingKeysImpl() - Constructor for class org.objectweb.dream.pushwithreturn.WaitingKeysImpl
 
waitingToDeliver - Variable in class org.objectweb.dream.protocol.bus.logicalClock.ProtocolImpl.Session
 
wq - Variable in class org.objectweb.dream.synchro.AbstractSemaphoreQueuedImpl
 
writeExportIdentifierArray(ObjectOutput, ExportIdentifier[]) - Static method in class org.objectweb.dream.protocol.Util
Writes an array of export identifier on an ObjectOutput object.
writeExternal(ObjectOutput) - Method in class org.objectweb.dream.protocol.bus.BusExportIdentifier
 
writeExternal(ObjectOutput) - Method in class org.objectweb.dream.protocol.bus.logicalClock.LogicalClockChunk
 
writeExternal(ObjectOutput) - Method in class org.objectweb.dream.protocol.bus.logicalClock.LogicalClockExportIdentifier
 
writeExternal(ObjectOutput) - Method in class org.objectweb.dream.protocol.channel.BindChunk
 
writeExternal(ObjectOutput) - Method in class org.objectweb.dream.protocol.channel.CloseChunk
 
writeExternal(ObjectOutput) - Method in class org.objectweb.dream.protocol.channel.MultiplexChunk
 
writeExternal(ObjectOutput) - Method in class org.objectweb.dream.protocol.channel.MultiplexExportIdentifier
 
writeExternal(ObjectOutput) - Method in class org.objectweb.dream.protocol.ExceptionChunk
 
writeExternal(ObjectOutput) - Method in class org.objectweb.dream.protocol.ExportIdentifierChunk
 
writeExternal(ObjectOutput) - Method in class org.objectweb.dream.protocol.IPExportIdentifier
 
writeExternal(ObjectOutput) - Method in class org.objectweb.dream.protocol.messagePassing.FragmentationChunk
 
writeExternal(ObjectOutput) - Method in class org.objectweb.dream.protocol.rpc.InvocationChunk
 
writeExternal(ObjectOutput) - Method in class org.objectweb.dream.protocol.rpc.ReplyChunk
 
writeExternal(ObjectOutput) - Method in class org.objectweb.dream.protocol.rpc.StubClassChunk
 
writeExternal(ObjectOutput) - Method in class org.objectweb.dream.pushwithreturn.KeyChunk
 
writeExternal(ObjectOutput) - Method in class org.objectweb.dream.queue.SequenceNumberChunk
 
writeExternal(ObjectOutput) - Method in class org.objectweb.dream.serializator.ByteArrayChunk
 

A B C D E F G H I K L M N O P Q R S T U W

Copyright © 2003, 2005 - INRIA Rhone-Alpes - All Rights Reserved.