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

A

ACK - Static variable in interface org.objectweb.dream.protocol.utobcast.message.UTOBcastChunk
The byte value for ACK message type.
ACKImpl - class org.objectweb.dream.protocol.utobcast.ACKImpl.
Implementation of the ACK component.
ACKImpl() - Constructor for class org.objectweb.dream.protocol.utobcast.ACKImpl
Constructor.
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.causality.MatrixClock
the value returned by MatrixClock.testRecvMatrix(Object, short, short)if the message has already been delivred.
AbstractAcceptSocketImpl - class org.objectweb.dream.channel.AbstractAcceptSocketImpl.
Abstract Accept socket component.
AbstractAcceptSocketImpl() - Constructor for class org.objectweb.dream.channel.AbstractAcceptSocketImpl
 
AbstractAcceptSocketImpl.AcceptTask - class org.objectweb.dream.channel.AbstractAcceptSocketImpl.AcceptTask.
 
AbstractAcceptSocketImpl.AcceptTask() - Constructor for class org.objectweb.dream.channel.AbstractAcceptSocketImpl.AcceptTask
Constructor
AbstractBufferImpl - class org.objectweb.dream.queue.AbstractBufferImpl.
Abstract implementation of a buffer.
AbstractBufferImpl() - Constructor for class org.objectweb.dream.queue.AbstractBufferImpl
 
AbstractPullOutgoingHandlerImpl - class org.objectweb.dream.queue.AbstractPullOutgoingHandlerImpl.
Abstract implementation of a Pull outgoing handler.
AbstractPullOutgoingHandlerImpl() - Constructor for class org.objectweb.dream.queue.AbstractPullOutgoingHandlerImpl
 
AbstractPushIncomingHandlerOverflowImpl - class org.objectweb.dream.queue.AbstractPushIncomingHandlerOverflowImpl.
Abstract implementation of a Push incoming handler.
AbstractPushIncomingHandlerOverflowImpl() - Constructor for class org.objectweb.dream.queue.AbstractPushIncomingHandlerOverflowImpl
 
AbstractRouterImpl - class org.objectweb.dream.router.AbstractRouterImpl.
Abstract implementation of a basic Push/Push router.
AbstractRouterImpl() - Constructor for class org.objectweb.dream.router.AbstractRouterImpl
Default contructor
AbstractRouterKeyBasedImpl - class org.objectweb.dream.router.AbstractRouterKeyBasedImpl.
Abstract implementation of a key-based Push/Push router.
AbstractRouterKeyBasedImpl() - Constructor for class org.objectweb.dream.router.AbstractRouterKeyBasedImpl
Constructor.
AddIPChannelAttributeController - interface org.objectweb.dream.channel.AddIPChannelAttributeController.
Attribute controller interface for AddIPChannel components.
AddIPChannelDestinationChunkImpl - class org.objectweb.dream.channel.AddIPChannelDestinationChunkImpl.
This message transformer adds a IPChannelDestinationChunkcontaining the inet address and the listenning port of a channel.
AddIPChannelDestinationChunkImpl() - Constructor for class org.objectweb.dream.channel.AddIPChannelDestinationChunkImpl
 
AddIPChannelSourceChunkImpl - class org.objectweb.dream.channel.AddIPChannelSourceChunkImpl.
This message transformer adds a IPChannelSourceChunkcontaining the inet address and the listenning port of a channel.
AddIPChannelSourceChunkImpl() - Constructor for class org.objectweb.dream.channel.AddIPChannelSourceChunkImpl
 
ArrowChunk - interface org.objectweb.dream.protocol.ArrowChunk.
A general purpose chunk that can be use to identify the sender and receiver processes of a message.
ArrowChunkImpl - class org.objectweb.dream.protocol.ArrowChunkImpl.
A basic Chunk interface that defines an arrow from a source process to a destination process.
ArrowChunkImpl() - Constructor for class org.objectweb.dream.protocol.ArrowChunkImpl
 
AtomicReactorImpl - class org.objectweb.dream.protocol.atomicity.AtomicReactorImpl.
Transient impelmentation of the Reactor component.
AtomicReactorImpl() - Constructor for class org.objectweb.dream.protocol.atomicity.AtomicReactorImpl
 
AtomicRouterImpl - class org.objectweb.dream.protocol.atomicity.AtomicRouterImpl.
A Router that choose a route depending on the pushing thread.
AtomicRouterImpl() - Constructor for class org.objectweb.dream.protocol.atomicity.AtomicRouterImpl
 
Attachment - class org.objectweb.dream.multiplexer.Attachment.
This class defines an Attachement.
Attachment(int, String[], Pull[], Map[], String[], Push[], Map[]) - Constructor for class org.objectweb.dream.multiplexer.Attachment
Creates a new Attachment object
acceptSocket() - Method in class org.objectweb.dream.channel.AbstractAcceptSocketImpl
Abstract method that return a newly accepted socket.
acceptSocket() - Method in class org.objectweb.dream.channel.TCPAcceptSocketImpl
 
acceptTask - Variable in class org.objectweb.dream.channel.AbstractAcceptSocketImpl
 
add(Message) - Method in class org.objectweb.dream.queue.AbstractBufferImpl
This method should not be overriden.
add(Message) - Method in interface org.objectweb.dream.queue.Buffer
Adds the specified message to the buffer.
add(Object) - Method in interface org.objectweb.dream.queue.List
Adds the specified element to the list.
add(Object) - Method in class org.objectweb.dream.queue.ListAddRemoveFirstLastFastImpl
 
add(Object) - Method in class org.objectweb.dream.queue.ListAddRemoveFirstLastImpl
 
addFirst(Message) - Method in class org.objectweb.dream.queue.AbstractBufferImpl
 
addFirst(Message) - Method in interface org.objectweb.dream.queue.BufferAddFirstLast
Inserts the given message at the beginning of this buffer.
addFirst(Object) - Method in interface org.objectweb.dream.queue.ListAddFirstLast
Inserts the given element at the beginning of this list.
addFirst(Object) - Method in class org.objectweb.dream.queue.ListAddRemoveFirstLastFastImpl
 
addFirst(Object) - Method in class org.objectweb.dream.queue.ListAddRemoveFirstLastImpl
 
addLast(Message) - Method in class org.objectweb.dream.queue.AbstractBufferImpl
 
addLast(Message) - Method in interface org.objectweb.dream.queue.BufferAddFirstLast
Inserts the given message at the end of this buffer.
addLast(Object) - Method in interface org.objectweb.dream.queue.ListAddFirstLast
Appends the given element to the end of this list.
addLast(Object) - Method in class org.objectweb.dream.queue.ListAddRemoveFirstLastFastImpl
 
addLast(Object) - Method in class org.objectweb.dream.queue.ListAddRemoveFirstLastImpl
 
addProcess(Process) - Method in interface org.objectweb.dream.protocol.utobcast.ProcessMembership
Adds a process to the group of processes.
addProcess(Process) - Method in class org.objectweb.dream.protocol.utobcast.ProcessMembershipImpl
 
attach(String[], Map[], String[], Map[], Map) - Method in interface org.objectweb.dream.multiplexer.PullPushMultiplexer
Attaches a set of inputs to a set of outputs.
attach(String[], Map[], String[], Map[], Map) - Method in class org.objectweb.dream.multiplexer.PullPushMultiplexerImpl
Attaches a set of inputs to a set of outputs.
attachmentId - Variable in class org.objectweb.dream.multiplexer.PullPushMultiplexerImpl
An integer used to generate attachment ids.
attachments - Variable in class org.objectweb.dream.multiplexer.PullPushMultiplexerImpl
The registered attachments.
availableMessagesIndicator - Variable in class org.objectweb.dream.queue.AbstractBufferImpl
An indicator on available messages into the buffer.
availableMessagesIndicator() - Method in class org.objectweb.dream.queue.AbstractBufferImpl
 
availableMessagesIndicator() - Method in interface org.objectweb.dream.queue.Buffer
Returns an indicator on available messages.
availableSocketList - Variable in class org.objectweb.dream.channel.OpenedSocketManagerMultiPersistentImpl
 
availableSpaceIndicator() - Method in class org.objectweb.dream.queue.AbstractBufferImpl
 
availableSpaceIndicator() - Method in interface org.objectweb.dream.queue.Buffer
Returns an indicator on available space.

B

BAK - Static variable in interface org.objectweb.dream.protocol.utobcast.message.UTOBcastChunk
The byte value for BAK message type.
BAKImpl - class org.objectweb.dream.protocol.utobcast.BAKImpl.
Implementation of the BAK component.
BAKImpl() - Constructor for class org.objectweb.dream.protocol.utobcast.BAKImpl
Constructor.
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.
BLOCK_OVERFLOW_POLICY_ID - Static variable in class org.objectweb.dream.queue.AbstractPushIncomingHandlerOverflowImpl
 
BackupElection - interface org.objectweb.dream.protocol.utobcast.BackupElection.
This interface defines methods to elect a new backup.
BackupElectionImpl - class org.objectweb.dream.protocol.utobcast.BackupElectionImpl.
Implementation of the BackupElection component.
BackupElectionImpl() - Constructor for class org.objectweb.dream.protocol.utobcast.BackupElectionImpl
Constructor.
BroadcastImpl - class org.objectweb.dream.protocol.utobcast.BroadcastImpl.
Implementation of the UTOBroadcast component.
BroadcastImpl() - Constructor for class org.objectweb.dream.protocol.utobcast.BroadcastImpl
Constructor.
Buffer - interface org.objectweb.dream.queue.Buffer.
This interface defines methods that must be implemented by a buffer.
BufferAddFirstLast - interface org.objectweb.dream.queue.BufferAddFirstLast.
This interface defines methods that must be implemented by a buffer for adding messages to its begining or to its end.
BufferAscendingSequenceNumberImpl - class org.objectweb.dream.queue.BufferAscendingSequenceNumberImpl.
Implementation of the Buffer interface using a sorted list.
BufferAscendingSequenceNumberImpl() - Constructor for class org.objectweb.dream.queue.BufferAscendingSequenceNumberImpl
 
BufferAscendingSequenceNumberImpl.Element - class org.objectweb.dream.queue.BufferAscendingSequenceNumberImpl.Element.
This class represents elements of a linked list.
BufferAscendingSequenceNumberImpl.Element() - Constructor for class org.objectweb.dream.queue.BufferAscendingSequenceNumberImpl.Element
 
BufferImpl - class org.objectweb.dream.queue.BufferImpl.
Basic implementation of the Buffer interface using a LinkedList.
BufferImpl() - Constructor for class org.objectweb.dream.queue.BufferImpl
 
BufferOverflowException - exception org.objectweb.dream.queue.BufferOverflowException.
Exception thrown by queues when the maximum capacity of the queue is raised and the overflow policy is exception
BufferOverflowException() - Constructor for class org.objectweb.dream.queue.BufferOverflowException
 
BufferOverflowException(String) - Constructor for class org.objectweb.dream.queue.BufferOverflowException
 
BufferOverflowException(String, Throwable) - Constructor for class org.objectweb.dream.queue.BufferOverflowException
 
BufferOverflowException(Throwable) - Constructor for class org.objectweb.dream.queue.BufferOverflowException
 
BufferRemoveFirstLast - interface org.objectweb.dream.queue.BufferRemoveFirstLast.
This interface defines methods that must be implemented by a buffer for removing messages from its begining or from its end.
backupElectionItf - Variable in class org.objectweb.dream.protocol.utobcast.DATImpl
The interface to elect a new backup.
backupElectionItf - Variable in class org.objectweb.dream.protocol.utobcast.REPImpl
The interface to elect a new backup.
beforeFirstStart(Component) - Method in class org.objectweb.dream.channel.AbstractAcceptSocketImpl
 
beforeFirstStart(Component) - Method in class org.objectweb.dream.channel.OpenedSocketManagerMultiPersistentImpl
 
beforeFirstStart(Component) - Method in class org.objectweb.dream.multiplexer.PullPushMultiplexerImpl
 
beforeFirstStart(Component) - Method in class org.objectweb.dream.pump.PumpSynchronizedImpl
 
beforeFirstStart(Component) - Method in class org.objectweb.dream.queue.PushOutgoingHandlerActiveImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.aggregator.PullPullAggregatorCollectionInputImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.aggregator.PullPullAggregatorContextualImpl
 
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.PushPullAggregatorImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.aggregator.PushPushDeAggregatorImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.cache.CacheImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.channel.AbstractAcceptSocketImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.channel.AddIPChannelDestinationChunkImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.channel.AddIPChannelSourceChunkImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.channel.GenericPushChannelInImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.channel.GenericPushChannelOutImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.channel.IPSocketManagerCachingImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.channel.IPSocketManagerTCPImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.channel.OpenedSocketManagerMonoNotPersistentImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.channel.OpenedSocketManagerMonoPersistentImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.channel.OpenedSocketManagerMultiPersistentImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.channel.SocketManagerIPChunkBasedImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.channel.SocketManagerIPStaticImpl
 
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.multiplexer.PullPushMultiplexerImpl
 
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.causality.InMessageSorterImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.protocol.causality.OutMessageStamperImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.protocol.utobcast.ACKImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.protocol.utobcast.BAKImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.protocol.utobcast.BackupElectionImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.protocol.utobcast.BroadcastImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.protocol.utobcast.DATImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.protocol.utobcast.DeliveredMessageRouterImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.protocol.utobcast.IncomingMessageRouterImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.protocol.utobcast.LeaderFaultForwarderImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.protocol.utobcast.PendingMessagesDataStructureImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.protocol.utobcast.ProcessMembershipImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.protocol.utobcast.REPImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.protocol.utobcast.UPDImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.protocol.utobcast.UTOImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.pump.PumpSynchronizedImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.pushwithreturn.KeyGeneratorIntegerImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.pushwithreturn.SynchronizerImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.queue.AbstractBufferImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.queue.AbstractPullOutgoingHandlerImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.queue.AbstractPushIncomingHandlerOverflowImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.queue.BufferAscendingSequenceNumberImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.queue.BufferImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.queue.ListAddRemoveFirstLastFastImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.queue.PushIncomingHandlerImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.queue.PushOutgoingHandlerActiveImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.queue.PushPullQueueNotSynchronizedImpl
 
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.synchro.LockPullUnlockImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.synchro.LockPushUnlockImpl
 
bindFc(String, Object) - Method in class org.objectweb.dream.xml.SaxXercesParser
 
blocking - Variable in class org.objectweb.dream.channel.IPSocketManagerCachingImpl
 
blockingPull - Variable in class org.objectweb.dream.queue.AbstractPullOutgoingHandlerImpl
 
bufferAddFirstLastItf - Variable in class org.objectweb.dream.queue.AbstractPushIncomingHandlerOverflowImpl
 
bufferItf - Variable in class org.objectweb.dream.queue.AbstractPullOutgoingHandlerImpl
 
bufferItf - Variable in class org.objectweb.dream.queue.AbstractPushIncomingHandlerOverflowImpl
 
bufferItf - Variable in class org.objectweb.dream.queue.PushIncomingHandlerImpl
 
bufferItf - Variable in class org.objectweb.dream.queue.PushOutgoingHandlerActiveImpl
 
bufferRemoveFirstLastItf - Variable in class org.objectweb.dream.queue.AbstractPullOutgoingHandlerImpl
 
bufferRemoveFirstLastItf - Variable in class org.objectweb.dream.queue.AbstractPushIncomingHandlerOverflowImpl
 
bufferRemoveFirstLastItf - Variable in class org.objectweb.dream.queue.PushOutgoingHandlerActiveImpl
 

C

CNX_RETRY_DEFAULT - Static variable in interface org.objectweb.dream.channel.IPSocketManagerTCPAttributeController
Default value of cnxRetry attribute.
CONTENT_HANDLER_ITF_NAME - Static variable in class org.objectweb.dream.xml.SaxXercesParser
The name of the ContentHandlerclient interface.
CacheAttributeController - interface org.objectweb.dream.cache.CacheAttributeController.
This class defines a controller for managing the cache attributes.
CacheImpl - class org.objectweb.dream.cache.CacheImpl.
This class defines a basic cache.
CacheImpl() - Constructor for class org.objectweb.dream.cache.CacheImpl
 
CatchPushExceptionImpl - class org.objectweb.dream.exception.CatchPushExceptionImpl.
Try to push incomming messages on the output ("out-push" client interface).
CatchPushExceptionImpl() - Constructor for class org.objectweb.dream.exception.CatchPushExceptionImpl
 
CausalityChunk - interface org.objectweb.dream.protocol.causality.CausalityChunk.
Chunk interface for causality sorted messages.
CausalityChunkImpl - class org.objectweb.dream.protocol.causality.CausalityChunkImpl.
Basic implementation of CausalityChunk
CausalityChunkImpl() - Constructor for class org.objectweb.dream.protocol.causality.CausalityChunkImpl
 
CausalityProtocolAttributeController - interface org.objectweb.dream.protocol.causality.CausalityProtocolAttributeController.
Causality protocol attribute controller interface.
CausalityTransformerAttributeController - interface org.objectweb.dream.protocol.causality.CausalityTransformerAttributeController.
Causality message transformer attribute controller interface.
ChannelOutAttributeController - interface org.objectweb.dream.channel.ChannelOutAttributeController.
ChannelOut attribute controller.
CrashedLeaderChunk - interface org.objectweb.dream.protocol.utobcast.message.CrashedLeaderChunk.
Chunk interface that indicates that the leader has crashed.
CrashedLeaderChunkImpl - class org.objectweb.dream.protocol.utobcast.message.CrashedLeaderChunkImpl.
Basic implementation of the CrashedLeaderChunkinterface.
CrashedLeaderChunkImpl() - Constructor for class org.objectweb.dream.protocol.utobcast.message.CrashedLeaderChunkImpl
 
cache - Variable in class org.objectweb.dream.channel.IPSocketManagerCachingImpl
 
cacheRemove() - Method in class org.objectweb.dream.channel.IPSocketManagerCachingImpl.CacheEntry
 
cachedMessage - Variable in class org.objectweb.dream.cache.CacheImpl
The last cached message.
canAdd(Message) - Method in class org.objectweb.dream.queue.AbstractBufferImpl
Checks whether the given message can be added into the buffer.
canAdd(Message) - Method in class org.objectweb.dream.queue.AbstractPushIncomingHandlerOverflowImpl
Checks whether the given message can be added into the buffer.
canAdd(Message) - Method in class org.objectweb.dream.queue.BufferAscendingSequenceNumberImpl
 
canAdd(Message) - Method in class org.objectweb.dream.queue.BufferImpl
 
canAdd(Message) - Method in class org.objectweb.dream.queue.PushIncomingHandlerOverflowImpl
 
canPass() - Method in class org.objectweb.dream.pushwithreturn.SynchronizerImpl.WaitingKey
Returns the value of canPass.
chunkName - Variable in class org.objectweb.dream.channel.AddIPChannelDestinationChunkImpl
the name of the IPChannelDestinationChunk added by this transformer.
chunkName - Variable in class org.objectweb.dream.channel.AddIPChannelSourceChunkImpl
the name of the IPChannelDestinationChunk added by this transformer.
chunkName - Variable in class org.objectweb.dream.router.RouterChunkNameImpl
the chunk name to test
clone() - Method in class org.objectweb.dream.multiplexer.Attachment
Returns a clone of this attachment.
clone() - Method in class org.objectweb.dream.multiplexer.PeriodicAttachment
Returns a clone of this attachment.
clone() - Method in interface org.objectweb.dream.protocol.Process
Clones the process.
clone() - Method in class org.objectweb.dream.protocol.ProcessImpl
 
close() - Method in interface org.objectweb.dream.channel.SocketState
Closes the connection.
close() - Method in class org.objectweb.dream.channel.SocketStateImpl
 
cnxRetry - Variable in class org.objectweb.dream.channel.IPSocketManagerTCPImpl
 
compareTo(Object) - Method in class org.objectweb.dream.protocol.ProcessImpl
 
createServerSocket() - Method in class org.objectweb.dream.channel.TCPAcceptSocketImpl
 
currentSocket - Variable in class org.objectweb.dream.channel.SocketManagerIPStaticImpl
 

D

DAT - Static variable in interface org.objectweb.dream.protocol.utobcast.message.UTOBcastChunk
The byte value for DAT message type.
DATImpl - class org.objectweb.dream.protocol.utobcast.DATImpl.
Implementation of the DAT component.
DATImpl() - Constructor for class org.objectweb.dream.protocol.utobcast.DATImpl
Constructor.
DEFAULT_NAME - Static variable in interface org.objectweb.dream.channel.IPChannelDestinationChunk
The default name of chunks of this type.
DEFAULT_NAME - Static variable in interface org.objectweb.dream.channel.IPChannelSourceChunk
The default name of chunks of this type.
DEFAULT_NAME - Static variable in interface org.objectweb.dream.protocol.ArrowChunk
The default name for chunks of this type
DEFAULT_NAME - Static variable in interface org.objectweb.dream.protocol.causality.CausalityChunk
The default name for chunks of this type
DEFAULT_NAME - Static variable in interface org.objectweb.dream.protocol.utobcast.message.CrashedLeaderChunk
The default name for chunks of this type.
DEFAULT_NAME - Static variable in interface org.objectweb.dream.protocol.utobcast.message.UPDChunk
The default name for chunks of this type.
DEFAULT_NAME - Static variable in interface org.objectweb.dream.protocol.utobcast.message.UTOBcastChunk
The default name for chunks of this type.
DEFAULT_NAME - Static variable in interface org.objectweb.dream.pushwithreturn.KeyChunk
The default name for chunks of this type
DEFAULT_NAME - Static variable in interface org.objectweb.dream.queue.SequenceNumberChunk
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.
DELEGATE_IP_SOCKET_MANAGER - Static variable in class org.objectweb.dream.channel.IPSocketManagerCachingImpl
The name of the client interface used to retreive a socket when it can't be found in the cache.
DELIVER - Static variable in interface org.objectweb.dream.protocol.causality.MatrixClock
the value returned by MatrixClock.testRecvMatrix(Object, short, short)if the message can be delivred
DELIVERY_ITF_NAME - Static variable in class org.objectweb.dream.protocol.utobcast.UTOImpl
The commonly used name to refer to the deliveryItf interface.
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_FIRST_OVERFLOW_POLICY_ID - Static variable in class org.objectweb.dream.queue.AbstractPushIncomingHandlerOverflowImpl
 
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_LAST_OVERFLOW_POLICY_ID - Static variable in class org.objectweb.dream.queue.AbstractPushIncomingHandlerOverflowImpl
 
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_PROCESSED_MESSAGE_OVERFLOW_POLICY_ID - Static variable in class org.objectweb.dream.queue.AbstractPushIncomingHandlerOverflowImpl
 
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.
DROP_QUEUE_MESSAGE_OVERFLOW_POLICY_ID - Static variable in class org.objectweb.dream.queue.AbstractPushIncomingHandlerOverflowImpl
 
DeliveredMessageRouterImpl - class org.objectweb.dream.protocol.utobcast.DeliveredMessageRouterImpl.
Implementation of the DeliveredMessageRouter component.
DeliveredMessageRouterImpl() - Constructor for class org.objectweb.dream.protocol.utobcast.DeliveredMessageRouterImpl
Constructor.
decrementNbWaitings() - Method in class org.objectweb.dream.pushwithreturn.SynchronizerImpl.WaitingKey
Decrements the number of waiting calls.
defaultOutPushItf - Variable in class org.objectweb.dream.router.AbstractRouterImpl
Default Push interface to be used if no Push interface can be found in outPushTable.
delegateOpenedSocketItf - Variable in class org.objectweb.dream.channel.OpenedSocketManagerMonoNotPersistentImpl
 
delegateOpenedSocketItf - Variable in class org.objectweb.dream.channel.OpenedSocketManagerMonoPersistentImpl
 
delegateOpenedSocketItf - Variable in class org.objectweb.dream.channel.OpenedSocketManagerMultiPersistentImpl
 
delegateSocketManagerItf - Variable in class org.objectweb.dream.channel.IPSocketManagerCachingImpl
 
delegateSocketManagerItf - Variable in class org.objectweb.dream.channel.SocketManagerIPChunkBasedImpl
 
delegateSocketManagerItf - Variable in class org.objectweb.dream.channel.SocketManagerIPStaticImpl
 
deleteChunk - Variable in class org.objectweb.dream.channel.SocketManagerIPChunkBasedImpl
 
deliveryItf - Variable in class org.objectweb.dream.protocol.utobcast.UTOImpl
The interface to deliver messages.
destinationAddress - Variable in class org.objectweb.dream.channel.SocketManagerIPStaticImpl
 
destinationChanged - Variable in class org.objectweb.dream.channel.SocketManagerIPStaticImpl
 
destinationChunkName - Variable in class org.objectweb.dream.channel.SocketManagerIPChunkBasedImpl
 
destinationPort - Variable in class org.objectweb.dream.channel.SocketManagerIPStaticImpl
 
detach(Attachment) - Method in interface org.objectweb.dream.multiplexer.PullPushMultiplexer
Detaches a set of inputs from a set of outputs.
detach(Attachment) - Method in class org.objectweb.dream.multiplexer.PullPushMultiplexerImpl
 
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.AbstractPushIncomingHandlerOverflowImpl
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.BufferImpl
 
doAdd(Message) - Method in class org.objectweb.dream.queue.PushIncomingHandlerOverflowImpl
 
doAddFirst(Message) - Method in class org.objectweb.dream.queue.AbstractBufferImpl
Adds a message to the beginning of the buffer.
doAddFirst(Message) - Method in class org.objectweb.dream.queue.BufferImpl
 
doAddLast(Message) - Method in class org.objectweb.dream.queue.AbstractBufferImpl
Adds a message to end of the buffer.
doAddLast(Message) - Method in class org.objectweb.dream.queue.BufferImpl
 
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.BufferImpl
 
doGetFirst() - Method in class org.objectweb.dream.queue.AbstractBufferImpl
Gets the first message from the buffer.
doGetFirst() - Method in class org.objectweb.dream.queue.BufferImpl
 
doGetLast() - Method in class org.objectweb.dream.queue.AbstractBufferImpl
Gets the last message from the buffer.
doGetLast() - Method in class org.objectweb.dream.queue.BufferImpl
 
doPull() - Method in class org.objectweb.dream.queue.AbstractPullOutgoingHandlerImpl
Pulls a message from the buffer (i.e. get or remove).
doPull() - Method in class org.objectweb.dream.queue.PullOutgoingHandlerImpl
 
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.BufferImpl
 
doRemoveFirst() - Method in class org.objectweb.dream.queue.AbstractBufferImpl
Removes the first message from the buffer.
doRemoveFirst() - Method in class org.objectweb.dream.queue.BufferImpl
 
doRemoveLast() - Method in class org.objectweb.dream.queue.AbstractBufferImpl
Removes the last message from the buffer.
doRemoveLast() - Method in class org.objectweb.dream.queue.BufferImpl
 

E

END_DATE - Static variable in class org.objectweb.dream.multiplexer.PeriodicAttachment
The name of the key that must be used to specify the end date of this attachment in the parameters passed to the PullPushMultiplexer.attach(String[], Map[], String[], Map[], Map)
EXCEPTION_MESSAGE_NOT_FOUND_POLICY - Static variable in interface org.objectweb.dream.queue.PushPullKeyQueueAttributeController
"Message not found" policy that throw a KeyNotFoundException exception.
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_OVERFLOW_POLICY_ID - Static variable in class org.objectweb.dream.queue.AbstractPushIncomingHandlerOverflowImpl
 
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.
elect() - Method in interface org.objectweb.dream.protocol.utobcast.BackupElection
Elects a new backup and propagate information to all the processes.
elect() - Method in class org.objectweb.dream.protocol.utobcast.BackupElectionImpl
 
electBackup() - Method in interface org.objectweb.dream.protocol.utobcast.ProcessMembership
Elects a new backup process.
electBackup() - Method in class org.objectweb.dream.protocol.utobcast.ProcessMembershipImpl
 
electBackupAsLeader(Process) - Method in interface org.objectweb.dream.protocol.utobcast.ProcessMembership
Elects the backup as new leader provided the curerntly registered leader is the one given in parameter.
electBackupAsLeader(Process) - Method in class org.objectweb.dream.protocol.utobcast.ProcessMembershipImpl
 
elements() - Method in class org.objectweb.dream.queue.ListAddRemoveFirstLastFastImpl
Returns a java.util.Enumeration enumeration over the elements of the linked list.
endDate - Variable in class org.objectweb.dream.multiplexer.PeriodicAttachment
 
equals(Object) - Method in class org.objectweb.dream.channel.IPSocketManagerCachingImpl.CacheEntry
 
equals(Object) - Method in class org.objectweb.dream.multiplexer.Attachment
Returns true iff the specified object is an Attachment with the same id.
equals(Object) - Method in class org.objectweb.dream.protocol.ProcessImpl
 
equals(Object) - Method in class org.objectweb.dream.pushwithreturn.KeyInteger
 
exceptionPushItf - Variable in class org.objectweb.dream.exception.CatchPushExceptionImpl
 
execute(Object) - Method in class org.objectweb.dream.channel.AbstractAcceptSocketImpl.AcceptTask
 
execute(Object) - Method in class org.objectweb.dream.channel.OpenedSocketManagerMultiPersistentImpl.InTask
 

F

first - Variable in class org.objectweb.dream.queue.BufferAscendingSequenceNumberImpl
The first element stored in this buffer.

G

GenericPushChannelInImpl - class org.objectweb.dream.channel.GenericPushChannelInImpl.
Generic push ChannelIn implementation.
GenericPushChannelInImpl() - Constructor for class org.objectweb.dream.channel.GenericPushChannelInImpl
 
GenericPushChannelOutImpl - class org.objectweb.dream.channel.GenericPushChannelOutImpl.
Generic Push ChannelOut.
GenericPushChannelOutImpl() - Constructor for class org.objectweb.dream.channel.GenericPushChannelOutImpl
 
GetTimeStamp - interface org.objectweb.dream.time.GetTimeStamp.
This interface defines a method to get a time stamp.
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
This method should not be overriden.
get() - Method in interface org.objectweb.dream.queue.Buffer
Gets a message from the buffer.
getArrowChunkName() - Method in interface org.objectweb.dream.protocol.causality.CausalityTransformerAttributeController
Returns the name of the ArrowChunk used to know the source or the destination process of messages.
getArrowChunkName() - Method in class org.objectweb.dream.protocol.causality.InMessageSorterImpl
 
getArrowChunkName() - Method in class org.objectweb.dream.protocol.causality.OutMessageStamperImpl
 
getAttachments() - Method in interface org.objectweb.dream.multiplexer.PullPushMultiplexer
Returns the attachments that have been registered.
getAttachments() - Method in class org.objectweb.dream.multiplexer.PullPushMultiplexerImpl
 
getBackup() - Method in interface org.objectweb.dream.protocol.utobcast.ProcessMembership
Returns the backup process.
getBackup() - Method in class org.objectweb.dream.protocol.utobcast.ProcessMembershipImpl
 
getBlocking() - Method in interface org.objectweb.dream.channel.IPSocketManagerCachingAttributeController
Returns the blocking parameter value.
getBlocking() - Method in class org.objectweb.dream.channel.IPSocketManagerCachingImpl
 
getBlocking() - Method in interface org.objectweb.dream.protocol.utobcast.ProcessMembershipAttributeController
Returns true if the ProcessMembership component is in blocking mode.
getBlocking() - Method in class org.objectweb.dream.protocol.utobcast.ProcessMembershipImpl
 
getBlockingPull() - Method in class org.objectweb.dream.queue.AbstractPullOutgoingHandlerImpl
 
getBlockingPull() - Method in interface org.objectweb.dream.queue.PullQueueAttributeController
Returns the blocking pull policy.
getCausalityChunkName() - Method in interface org.objectweb.dream.protocol.causality.CausalityTransformerAttributeController
Returns the name of the CausalityChunkwhere the matrix clock, or the updates are stored.
getCausalityChunkName() - Method in class org.objectweb.dream.protocol.causality.InMessageSorterImpl
 
getCausalityChunkName() - Method in class org.objectweb.dream.protocol.causality.OutMessageStamperImpl
 
getCausalityStamp() - Method in interface org.objectweb.dream.protocol.causality.CausalityChunk
Returns the causality stamp of this chunk
getCausalityStamp() - Method in class org.objectweb.dream.protocol.causality.CausalityChunkImpl
 
getChannelDestinationAddr() - Method in interface org.objectweb.dream.channel.IPChannelDestinationChunk
Returns the inet address of the ChannelIn.
getChannelDestinationAddr() - Method in class org.objectweb.dream.channel.IPChannelDestinationChunkImpl
 
getChannelDestinationPort() - Method in interface org.objectweb.dream.channel.IPChannelDestinationChunk
Returns the listening port of the ChannelIn.
getChannelDestinationPort() - Method in class org.objectweb.dream.channel.IPChannelDestinationChunkImpl
 
getChannelSourceAddr() - Method in interface org.objectweb.dream.channel.IPChannelSourceChunk
Returns the inet address of the ChannelOut.
getChannelSourceAddr() - Method in class org.objectweb.dream.channel.IPChannelSourceChunkImpl
 
getChannelSourcePort() - Method in interface org.objectweb.dream.channel.IPChannelSourceChunk
Returns the listening port of the ChannelOut.
getChannelSourcePort() - Method in class org.objectweb.dream.channel.IPChannelSourceChunkImpl
 
getChunkName() - Method in interface org.objectweb.dream.channel.AddIPChannelAttributeController
Returns the name of added chunks.
getChunkName() - Method in class org.objectweb.dream.channel.AddIPChannelDestinationChunkImpl
 
getChunkName() - Method in class org.objectweb.dream.channel.AddIPChannelSourceChunkImpl
 
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
 
getCnxRetry() - Method in interface org.objectweb.dream.channel.IPSocketManagerTCPAttributeController
Returns the number of connection retry before abording.
getCnxRetry() - Method in class org.objectweb.dream.channel.IPSocketManagerTCPImpl
 
getColumn() - Method in class org.objectweb.dream.protocol.causality.Update
 
getConnectionRetry() - Method in interface org.objectweb.dream.channel.ChannelOutAttributeController
Returns the number of attempt to connect to ChannelIn before abording.
getCurrentSize() - Method in class org.objectweb.dream.queue.AbstractBufferImpl
 
getCurrentSize() - Method in class org.objectweb.dream.queue.PushPullQueueNotSynchronizedImpl
 
getCurrentSize() - Method in interface org.objectweb.dream.queue.QueueAttributeController
Returns the current size of the queue.
getDeleteChunk() - Method in interface org.objectweb.dream.channel.SocketManagerIPChunkBasedAttributeController
Returns true if the destination chunk should be deleted from the message.
getDeleteChunk() - Method in class org.objectweb.dream.channel.SocketManagerIPChunkBasedImpl
 
getDestinationChunkName() - Method in interface org.objectweb.dream.channel.SocketManagerIPChunkBasedAttributeController
Returns the name of the chunks that contains the destination identification of the message.
getDestinationChunkName() - Method in class org.objectweb.dream.channel.SocketManagerIPChunkBasedImpl
 
getDestinationHostname() - Method in interface org.objectweb.dream.channel.SocketManagerIPStaticAttributeController
Returns the destination hostname.
getDestinationHostname() - Method in class org.objectweb.dream.channel.SocketManagerIPStaticImpl
 
getDestinationPort() - Method in interface org.objectweb.dream.channel.SocketManagerIPStaticAttributeController
Returns the destination port.
getDestinationPort() - Method in class org.objectweb.dream.channel.SocketManagerIPStaticImpl
 
getEndDate() - Method in class org.objectweb.dream.multiplexer.PeriodicAttachment
Returns the endDate value.
getFirst() - Method in class org.objectweb.dream.queue.AbstractBufferImpl
 
getFirst() - Method in interface org.objectweb.dream.queue.BufferRemoveFirstLast
Returns the first message in this buffer.
getFirst() - Method in class org.objectweb.dream.queue.ListAddRemoveFirstLastFastImpl
 
getFirst() - Method in class org.objectweb.dream.queue.ListAddRemoveFirstLastImpl
 
getFirst() - Method in interface org.objectweb.dream.queue.ListRemoveFirstLast
Returns the first element in this list.
getId() - Method in class org.objectweb.dream.multiplexer.Attachment
 
getId() - Method in interface org.objectweb.dream.protocol.Process
Returns the identifier of the process.
getId() - Method in class org.objectweb.dream.protocol.ProcessImpl
Returns the identifier of the process.
getInetAddress() - Method in interface org.objectweb.dream.channel.AddIPChannelAttributeController
Returns the inet addresse put in chunks.
getInetAddress() - Method in class org.objectweb.dream.channel.AddIPChannelDestinationChunkImpl
 
getInetAddress() - Method in class org.objectweb.dream.channel.AddIPChannelSourceChunkImpl
 
getInitialCapacity() - Method in class org.objectweb.dream.pump.PumpSynchronizedImpl
 
getInitialNumberOfThreads() - Method in class org.objectweb.dream.pump.PumpSynchronizedImpl
 
getInput() - Method in class org.objectweb.dream.channel.SocketStateImpl
 
getInputContexts() - Method in class org.objectweb.dream.multiplexer.Attachment
 
getInputNames() - Method in class org.objectweb.dream.multiplexer.Attachment
 
getInputs() - Method in class org.objectweb.dream.multiplexer.Attachment
 
getItem(Object) - Method in class org.objectweb.dream.queue.ListAddRemoveFirstLastFastImpl
Returns the first object that is "equal" to the given object, based on the response of the Object.equals() method.
getKey() - Method in interface org.objectweb.dream.pushwithreturn.KeyChunk
Returns the key of this chunk.
getKey() - Method in class org.objectweb.dream.pushwithreturn.KeyChunkImpl
 
getKeyChunkName() - Method in interface org.objectweb.dream.queue.PushPullKeyQueueAttributeController
Returns the name of the chunk to be used as a key of the message.
getLast() - Method in class org.objectweb.dream.queue.AbstractBufferImpl
 
getLast() - Method in interface org.objectweb.dream.queue.BufferRemoveFirstLast
Returns the last message in this buffer.
getLast() - Method in class org.objectweb.dream.queue.ListAddRemoveFirstLastFastImpl
 
getLast() - Method in class org.objectweb.dream.queue.ListAddRemoveFirstLastImpl
 
getLast() - Method in interface org.objectweb.dream.queue.ListRemoveFirstLast
Returns the last element in this list.
getLeader() - Method in interface org.objectweb.dream.protocol.utobcast.ProcessMembership
Returns the leader process.
getLeader() - Method in class org.objectweb.dream.protocol.utobcast.ProcessMembershipImpl
 
getLine() - Method in class org.objectweb.dream.protocol.causality.Update
 
getListeningPort() - Method in interface org.objectweb.dream.channel.TCPAcceptSocketAttributeController
Returns the listening port.
getListeningPort() - Method in class org.objectweb.dream.channel.TCPAcceptSocketImpl
 
getMaxCapacity() - Method in class org.objectweb.dream.queue.AbstractBufferImpl
 
getMaxCapacity() - Method in class org.objectweb.dream.queue.PushPullQueueNotSynchronizedImpl
 
getMaxCapacity() - Method in interface org.objectweb.dream.queue.QueueAttributeController
Returns the maximum capacity of the queue.
getMaxOpenedSocket() - Method in interface org.objectweb.dream.channel.OpenedSocketManagerMultiAttributeController
Returns the maximum number of opened socket.
getMaxOpenedSocket() - Method in class org.objectweb.dream.channel.OpenedSocketManagerMultiPersistentImpl
 
getMessageNotFoundPolicy() - Method in interface org.objectweb.dream.queue.PushPullKeyQueueAttributeController
Returns the policy applied when a message cannot be found.
getMustClone() - Method in interface org.objectweb.dream.pushwithreturn.SynchronizerAttributeController
Returns a boolean indicating whether it is necessary to clone a return message that is destinated to several method call returns.
getMustClone() - Method in class org.objectweb.dream.pushwithreturn.SynchronizerImpl
 
getMyself() - Method in interface org.objectweb.dream.protocol.utobcast.ProcessMembership
Returns the process to which this process membership component belongs.
getMyself() - Method in class org.objectweb.dream.protocol.utobcast.ProcessMembershipImpl
 
getNbMaxSocket() - Method in interface org.objectweb.dream.channel.IPSocketManagerCachingAttributeController
Returns the number of maximum open sockets.
getNbMaxSocket() - Method in class org.objectweb.dream.channel.IPSocketManagerCachingImpl
 
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
 
getNbWaitings() - Method in class org.objectweb.dream.pushwithreturn.SynchronizerImpl.WaitingKey
Returns the number of waiting calls.
getNext() - Method in class org.objectweb.dream.protocol.causality.Update
 
getNextDeadline() - Method in class org.objectweb.dream.multiplexer.PeriodicAttachment
Returns the nextDeadline value.
getNumberOfProcess() - Method in interface org.objectweb.dream.protocol.causality.MatrixClockAttributeController
Returns the number of process implied in the causality.
getNumberOfProcess() - Method in class org.objectweb.dream.protocol.causality.MatrixClockImpl
 
getNumberOfProcess() - Method in class org.objectweb.dream.protocol.causality.MatrixClockUpdateImpl
 
getOpenRetry() - Method in interface org.objectweb.dream.channel.TCPAcceptSocketAttributeController
Returns the number of attempts to open a ServerSocket before aborting.
getOpenRetry() - Method in class org.objectweb.dream.channel.TCPAcceptSocketImpl
 
getOtherProcesses() - Method in interface org.objectweb.dream.protocol.utobcast.ProcessMembership
Returns an array containing all the processes except backup and leader processes.
getOtherProcesses() - Method in class org.objectweb.dream.protocol.utobcast.ProcessMembershipImpl
 
getOutput() - Method in class org.objectweb.dream.channel.SocketStateImpl
 
getOutput(Message, Map) - Method in class org.objectweb.dream.router.AbstractRouterImpl
 
getOutput(Message, Map) - Method in class org.objectweb.dream.router.AbstractRouterKeyBasedImpl
 
getOutput(Message, Map) - Method in class org.objectweb.dream.router.RouterRandomImpl
 
getOutput(Message, Map) - Method in class org.objectweb.dream.router.RouterRoundRobinImpl
 
getOutputContexts() - Method in class org.objectweb.dream.multiplexer.Attachment
 
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.
getOutputNames() - Method in class org.objectweb.dream.multiplexer.Attachment
 
getOutputStatus() - Method in interface org.objectweb.dream.queue.PushPushQueuePassiveAttributeController
Returns the output status.
getOutputs() - Method in class org.objectweb.dream.multiplexer.Attachment
 
getOverflowPolicy() - Method in class org.objectweb.dream.queue.AbstractPushIncomingHandlerOverflowImpl
 
getOverflowPolicy() - Method in class org.objectweb.dream.queue.PushPullQueueNotSynchronizedImpl
 
getOverflowPolicy() - Method in interface org.objectweb.dream.queue.PushQueueAttributeController
Returns the overflow policy.
getPeriod() - Method in interface org.objectweb.dream.pump.PumpPeriodicAttributeController
Returns the pump period.
getPeriod() - Method in class org.objectweb.dream.pump.PumpPeriodicSynchronizedImpl
 
getPort() - Method in interface org.objectweb.dream.channel.AddIPChannelAttributeController
Returns the port number put in chunks.
getPort() - Method in class org.objectweb.dream.channel.AddIPChannelDestinationChunkImpl
 
getPort() - Method in class org.objectweb.dream.channel.AddIPChannelSourceChunkImpl
 
getProcessFrom() - Method in interface org.objectweb.dream.protocol.utobcast.message.UTOBcastChunk
Returns the process that sent this message.
getProcessFrom() - Method in class org.objectweb.dream.protocol.utobcast.message.UTOBcastChunkImpl
 
getProcessIdFrom() - Method in interface org.objectweb.dream.protocol.ArrowChunk
Returns the identifier of the sender process.
getProcessIdFrom() - Method in class org.objectweb.dream.protocol.ArrowChunkImpl
 
getProcessIdTo() - Method in interface org.objectweb.dream.protocol.ArrowChunk
Returns the identifier of the receiver process.
getProcessIdTo() - Method in class org.objectweb.dream.protocol.ArrowChunkImpl
 
getProcessTo() - Method in interface org.objectweb.dream.protocol.utobcast.message.UTOBcastChunk
Returns the process to which this message is destinated.
getProcessTo() - Method in class org.objectweb.dream.protocol.utobcast.message.UTOBcastChunkImpl
 
getProcesses() - Method in interface org.objectweb.dream.protocol.utobcast.message.UPDChunk
Returns the process array that is exchanged between the leader and the backup.
getProcesses() - Method in class org.objectweb.dream.protocol.utobcast.message.UPDChunkImpl
 
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 interface org.objectweb.dream.pump.PumpAttributeController
Returns the PushNullPolicy.
getPushNullPolicy() - Method in class org.objectweb.dream.pump.PumpSynchronizedImpl
 
getReturnMessage() - Method in class org.objectweb.dream.pushwithreturn.SynchronizerImpl.WaitingKey
Returns the return message.
getSequenceNumber() - Method in interface org.objectweb.dream.protocol.utobcast.SequenceNumber
Returns the sequence number.
getSequenceNumber() - Method in class org.objectweb.dream.protocol.utobcast.SequenceNumberImpl
 
getSequenceNumber() - Method in interface org.objectweb.dream.protocol.utobcast.message.UPDChunk
Returns the sequence number that is exchanged between the leader and the backup.
getSequenceNumber() - Method in class org.objectweb.dream.protocol.utobcast.message.UPDChunkImpl
 
getSequenceNumber() - Method in class org.objectweb.dream.protocol.utobcast.message.UTOBcastChunkImpl
 
getSequenceNumber() - Method in interface org.objectweb.dream.queue.SequenceNumberChunk
Returns the sequence number of this message.
getSequenceNumber() - Method in class org.objectweb.dream.queue.SequenceNumberChunkImpl
 
getSoLinger() - Method in interface org.objectweb.dream.channel.IPSocketManagerTCPAttributeController
Returns the SO_LINGER parameter setted on created sockets.
getSoLinger() - Method in class org.objectweb.dream.channel.IPSocketManagerTCPImpl
 
getSoLinger() - Method in interface org.objectweb.dream.channel.TCPAcceptSocketAttributeController
Returns the SO_LINGER parameter setted on created sockets.
getSoLinger() - Method in class org.objectweb.dream.channel.TCPAcceptSocketImpl
 
getSoTimeout() - Method in interface org.objectweb.dream.channel.IPSocketManagerTCPAttributeController
Returns the SO_TIMEOUT parameter setted on created sockets.
getSoTimeout() - Method in class org.objectweb.dream.channel.IPSocketManagerTCPImpl
 
getSoTimeout() - Method in interface org.objectweb.dream.channel.TCPAcceptSocketAttributeController
Returns the SO_TIMEOUT parameter setted on created sockets.
getSoTimeout() - Method in class org.objectweb.dream.channel.TCPAcceptSocketImpl
 
getSocket(InetAddress, int) - Method in interface org.objectweb.dream.channel.IPSocketManager
Returns a socket that can be used to send message to the ChannelIn identified by the given IP address and port.
getSocket(InetAddress, int) - Method in class org.objectweb.dream.channel.IPSocketManagerCachingImpl
 
getSocket(InetAddress, int) - Method in class org.objectweb.dream.channel.IPSocketManagerTCPImpl
 
getSocket(Message) - Method in interface org.objectweb.dream.channel.SocketManager
Returns a socket that can be used to send message to a ChannelIn
getSocket(Message) - Method in class org.objectweb.dream.channel.SocketManagerIPChunkBasedImpl
 
getSocket(Message) - Method in class org.objectweb.dream.channel.SocketManagerIPStaticImpl
 
getSortingChunkName() - Method in class org.objectweb.dream.queue.BufferAscendingSequenceNumberImpl
 
getSortingChunkName() - Method in interface org.objectweb.dream.queue.QueueSortedAttributeController
Returns the name of the chunk to be used to sort messages.
getStamp(short, short) - Method in interface org.objectweb.dream.protocol.causality.MatrixClock
Generate a stamp for the specified destination identifier.
getStamp(short, short) - Method in class org.objectweb.dream.protocol.causality.MatrixClockImpl
 
getStamp(short, short) - Method in class org.objectweb.dream.protocol.causality.MatrixClockUpdateImpl
 
getStamp() - Method in class org.objectweb.dream.protocol.causality.Update
 
getStartingDate() - Method in class org.objectweb.dream.multiplexer.PeriodicAttachment
Returns the startingDate value.
getTcpNoDelay() - Method in interface org.objectweb.dream.channel.IPSocketManagerTCPAttributeController
Returns true if the Nagle's algorithm is disabled on created sockets.
getTcpNoDelay() - Method in class org.objectweb.dream.channel.IPSocketManagerTCPImpl
 
getTcpNoDelay() - Method in interface org.objectweb.dream.channel.TCPAcceptSocketAttributeController
Returns true if the Nagle's algorithm is disabled on created sockets.
getTcpNoDelay() - Method in class org.objectweb.dream.channel.TCPAcceptSocketImpl
 
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() - Method in interface org.objectweb.dream.time.GetTimeStamp
Returns the time stamp.
getTimeStamp() - Method in class org.objectweb.dream.time.TimeStampImpl
 
getType() - Method in class org.objectweb.dream.channel.IPChannelDestinationChunkImpl
 
getType() - Method in class org.objectweb.dream.channel.IPChannelSourceChunkImpl
 
getType() - Method in class org.objectweb.dream.protocol.ArrowChunkImpl
 
getType() - Method in class org.objectweb.dream.protocol.causality.CausalityChunkImpl
 
getType() - Method in class org.objectweb.dream.protocol.utobcast.message.CrashedLeaderChunkImpl
 
getType() - Method in class org.objectweb.dream.protocol.utobcast.message.UPDChunkImpl
 
getType() - Method in class org.objectweb.dream.protocol.utobcast.message.UTOBcastChunkImpl
 
getType() - Method in class org.objectweb.dream.pushwithreturn.KeyChunkImpl
 
getType() - Method in class org.objectweb.dream.queue.SequenceNumberChunkImpl
 
getUTOBcastMessageType() - Method in interface org.objectweb.dream.protocol.utobcast.message.UTOBcastChunk
Returns the UTOBcast type of the message that contains this chunk.
getUTOBcastMessageType() - Method in class org.objectweb.dream.protocol.utobcast.message.UTOBcastChunkImpl
 
getUsePool() - Method in class org.objectweb.dream.pump.PumpSynchronizedImpl
 

H

handlePushException(Message, PushException) - Method in class org.objectweb.dream.queue.PushOutgoingHandlerActiveImpl
Handles a PushExceptionoccuring when the activity try to push a message.
hasAvailableMessage() - Method in class org.objectweb.dream.queue.AbstractBufferImpl
Checks whether there is an available message.
hasAvailableMessage() - Method in class org.objectweb.dream.queue.AbstractPullOutgoingHandlerImpl
Checks whether there is an available message.
hasAvailableMessage() - Method in class org.objectweb.dream.queue.BufferAscendingSequenceNumberImpl
 
hasAvailableMessage() - Method in class org.objectweb.dream.queue.BufferImpl
 
hasAvailableMessage() - Method in class org.objectweb.dream.queue.PullOutgoingHandlerImpl
 
hasMoreElements() - Method in class org.objectweb.dream.queue.ListAddRemoveFirstLastFastImpl.FastLinkedListEnumeration
 
hashCode() - Method in class org.objectweb.dream.channel.IPSocketManagerCachingImpl.CacheEntry
 
hashCode() - Method in class org.objectweb.dream.multiplexer.Attachment
 
hashCode() - Method in class org.objectweb.dream.protocol.ProcessImpl
 
hashCode() - Method in class org.objectweb.dream.pushwithreturn.KeyInteger
 

I

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.
IPChannelDestinationChunk - interface org.objectweb.dream.channel.IPChannelDestinationChunk.
Chunk interface used to identify the IP channel a message is destinated.
IPChannelDestinationChunkImpl - class org.objectweb.dream.channel.IPChannelDestinationChunkImpl.
Basic Implementation of IPChannelDestinationChunk
IPChannelDestinationChunkImpl() - Constructor for class org.objectweb.dream.channel.IPChannelDestinationChunkImpl
 
IPChannelSourceChunk - interface org.objectweb.dream.channel.IPChannelSourceChunk.
Chunk interface used to identify the IP channel that send the message.
IPChannelSourceChunkImpl - class org.objectweb.dream.channel.IPChannelSourceChunkImpl.
Basic Implementation of IPChannelSourceChunk
IPChannelSourceChunkImpl() - Constructor for class org.objectweb.dream.channel.IPChannelSourceChunkImpl
 
IPSocketManager - interface org.objectweb.dream.channel.IPSocketManager.
Interface used by ChannelOut to retreive a socket to send a message to an IPChannelIn identified by its InetAddressand its port.
IPSocketManagerCachingAttributeController - interface org.objectweb.dream.channel.IPSocketManagerCachingAttributeController.
Attribute controller interface for socket cache.
IPSocketManagerCachingImpl - class org.objectweb.dream.channel.IPSocketManagerCachingImpl.
This component manage a cache of SocketState.
IPSocketManagerCachingImpl() - Constructor for class org.objectweb.dream.channel.IPSocketManagerCachingImpl
 
IPSocketManagerCachingImpl.CacheEntry - class org.objectweb.dream.channel.IPSocketManagerCachingImpl.CacheEntry.
 
IPSocketManagerCachingImpl.CacheEntry() - Constructor for class org.objectweb.dream.channel.IPSocketManagerCachingImpl.CacheEntry
 
IPSocketManagerTCPAttributeController - interface org.objectweb.dream.channel.IPSocketManagerTCPAttributeController.
Attribute controller for components providing an IPSocketManager interface, using TCP/IP connection.
IPSocketManagerTCPImpl - class org.objectweb.dream.channel.IPSocketManagerTCPImpl.
IPSocketManagerthat handles one TCP connection at a time.
IPSocketManagerTCPImpl() - Constructor for class org.objectweb.dream.channel.IPSocketManagerTCPImpl
 
ITF_NAME - Static variable in interface org.objectweb.dream.channel.IPSocketManager
The default name of interface of this type.
ITF_NAME - Static variable in interface org.objectweb.dream.channel.OpenedSocket
The default name for interface of this type
ITF_NAME - Static variable in interface org.objectweb.dream.channel.SendByte
The default name for interface of this type.
ITF_NAME - Static variable in interface org.objectweb.dream.channel.SocketManager
The default name of interface of this type.
ITF_NAME - Static variable in interface org.objectweb.dream.channel.WaitByte
The default name for interface of this type.
ITF_NAME - Static variable in interface org.objectweb.dream.multiplexer.PullPushMultiplexer
The commonly used name to refer to this interface.
ITF_NAME - Static variable in interface org.objectweb.dream.protocol.utobcast.BackupElection
The commonly used name to refer to this interface.
ITF_NAME - Static variable in interface org.objectweb.dream.protocol.utobcast.ProcessMembership
The commonly used name to refer to this interface.
ITF_NAME - Static variable in interface org.objectweb.dream.protocol.utobcast.ProcessMembershipUpdateNotification
The commonly used name to refer to this interface.
ITF_NAME - Static variable in interface org.objectweb.dream.protocol.utobcast.ReceiveAck
The commonly used name to refer to this interface.
ITF_NAME - Static variable in interface org.objectweb.dream.protocol.utobcast.SequenceNumber
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.queue.Buffer
The commonly used name to refer to this interface.
ITF_NAME - Static variable in interface org.objectweb.dream.queue.BufferAddFirstLast
The commonly used name to refer to this interface.
ITF_NAME - Static variable in interface org.objectweb.dream.queue.BufferRemoveFirstLast
The commonly used name to refer to this interface.
ITF_NAME - Static variable in interface org.objectweb.dream.queue.List
The commonly used name to refer to this interface.
ITF_NAME - Static variable in interface org.objectweb.dream.queue.ListAddFirstLast
The commonly used name to refer to this interface.
ITF_NAME - Static variable in interface org.objectweb.dream.queue.ListRemoveFirstLast
The commonly used name to refer to this interface.
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.
InMessageSorterImpl - class org.objectweb.dream.protocol.causality.InMessageSorterImpl.
Incomming message sorter component.
InMessageSorterImpl() - Constructor for class org.objectweb.dream.protocol.causality.InMessageSorterImpl
Default constructor
IncomingMessageRouterImpl - class org.objectweb.dream.protocol.utobcast.IncomingMessageRouterImpl.
Implementation of the IncomingMessageRouter component.
IncomingMessageRouterImpl() - Constructor for class org.objectweb.dream.protocol.utobcast.IncomingMessageRouterImpl
Constructor.
id - Variable in class org.objectweb.dream.multiplexer.Attachment
The id of the attachment.
id - Variable in class org.objectweb.dream.protocol.ProcessImpl
Identifier of the process.
inPull - Variable in class org.objectweb.dream.cache.CacheImpl
The Pull client interface.
inPullItf - Variable in class org.objectweb.dream.aggregator.PullPullAggregatorContextualImpl
 
inPullItf - Variable in class org.objectweb.dream.aggregator.PullPullAggregatorWhileNotNullImpl
 
inPullItf - Variable in class org.objectweb.dream.pump.PumpSynchronizedImpl
The server interface to which this component is bound.
inPullItf - Variable in class org.objectweb.dream.synchro.LockPullUnlockImpl
 
inTask - Variable in class org.objectweb.dream.channel.OpenedSocketManagerMultiPersistentImpl
 
inUse - Variable in class org.objectweb.dream.channel.IPSocketManagerCachingImpl.CacheEntry
 
inUse - Variable in class org.objectweb.dream.channel.SocketManagerIPStaticImpl
 
incrementAvailableMessagesIndicator(int) - Method in class org.objectweb.dream.queue.AbstractBufferImpl
Increments the indicator on available messages.
incrementNbWaitings() - Method in class org.objectweb.dream.pushwithreturn.SynchronizerImpl.WaitingKey
Increments the number of waiting calls.
incrementSequenceNumber() - Method in interface org.objectweb.dream.protocol.utobcast.SequenceNumber
Increments the sequence number.
incrementSequenceNumber() - Method in class org.objectweb.dream.protocol.utobcast.SequenceNumberImpl
 
incrementStoredMessagesIndicator(int) - Method in class org.objectweb.dream.queue.AbstractBufferImpl
Increments the indicator on stored messages.
inetAddress - Variable in class org.objectweb.dream.channel.AddIPChannelDestinationChunkImpl
the inet address set in the chunk.
inetAddress - Variable in class org.objectweb.dream.channel.AddIPChannelSourceChunkImpl
the inet address set in the chunk.
inetAddress - Variable in class org.objectweb.dream.channel.IPSocketManagerCachingImpl.CacheEntry
 
initRouteTable() - Method in class org.objectweb.dream.router.AbstractRouterKeyBasedImpl
This method initializes the outPushRouteTable route table.
initialCapacity - Variable in class org.objectweb.dream.pump.PumpSynchronizedImpl
 
initialNumberOfThreads - Variable in class org.objectweb.dream.pump.PumpSynchronizedImpl
 
initialized - Variable in class org.objectweb.dream.router.AbstractRouterImpl
true if the route table is initialized.
input - Variable in class org.objectweb.dream.channel.SocketStateImpl
 
inputContexts - Variable in class org.objectweb.dream.multiplexer.Attachment
The context to be passed to inputs when they are used.
inputNames - Variable in class org.objectweb.dream.multiplexer.Attachment
The name of attached inputs.
inputs - Variable in class org.objectweb.dream.multiplexer.Attachment
The attached inputs.
inputs - Variable in class org.objectweb.dream.multiplexer.PullPushMultiplexerImpl
An hashtable storing the intputs of this component.
inuse - Variable in class org.objectweb.dream.synchro.MutexImpl
The lock status.
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() - Method in class org.objectweb.dream.pushwithreturn.KeyInteger
 
isClosed() - Method in interface org.objectweb.dream.channel.SocketState
Returns true if the socket is closed or is deconnected.
isClosed() - Method in class org.objectweb.dream.channel.SocketStateImpl
 
isEmpty() - Method in interface org.objectweb.dream.queue.List
Returns true if the list is empty.
isEmpty() - Method in class org.objectweb.dream.queue.ListAddRemoveFirstLastFastImpl
 
isEmpty() - Method in class org.objectweb.dream.queue.ListAddRemoveFirstLastImpl
 

K

KEY - Static variable in interface org.objectweb.dream.aggregator.PullPullAggregatorContextualKey
The key that must be used to specify (in the pull context) the number of messages to be agreggated.
Key - interface org.objectweb.dream.pushwithreturn.Key.
This interface defines a Key.
KeyChunk - interface org.objectweb.dream.pushwithreturn.KeyChunk.
Chunk interface for messages containing a key.
KeyChunkImpl - class org.objectweb.dream.pushwithreturn.KeyChunkImpl.
Basic implementation of the KeyChunkinterface.
KeyChunkImpl() - Constructor for class org.objectweb.dream.pushwithreturn.KeyChunkImpl
 
KeyGenerator - interface org.objectweb.dream.pushwithreturn.KeyGenerator.
This interface defines a key generator.
KeyGeneratorIntegerImpl - class org.objectweb.dream.pushwithreturn.KeyGeneratorIntegerImpl.
This generator generates KeyInteger objects with an increasing integer.
KeyGeneratorIntegerImpl() - Constructor for class org.objectweb.dream.pushwithreturn.KeyGeneratorIntegerImpl
 
KeyInteger - class org.objectweb.dream.pushwithreturn.KeyInteger.
Implementation of the Key interface that uses positive integers.
KeyInteger(int, boolean) - Constructor for class org.objectweb.dream.pushwithreturn.KeyInteger
Constructor.
KeyNotFoundException - exception org.objectweb.dream.queue.KeyNotFoundException.
Exception thrown when a key based Push/Pull queue cannot find the requested key, and the "message not found" policy is set to PushPullKeyQueueAttributeController.EXCEPTION_MESSAGE_NOT_FOUND_POLICY.
KeyNotFoundException(Object) - Constructor for class org.objectweb.dream.queue.KeyNotFoundException
Default constructor.
key - Variable in class org.objectweb.dream.queue.KeyNotFoundException
 

L

LeaderFaultForwarderImpl - class org.objectweb.dream.protocol.utobcast.LeaderFaultForwarderImpl.
Implementation of the LeaderFaultForwarder component.
LeaderFaultForwarderImpl() - Constructor for class org.objectweb.dream.protocol.utobcast.LeaderFaultForwarderImpl
Constructor.
List - interface org.objectweb.dream.queue.List.
This interface defines methods that must be implemented by a list.
ListAddFirstLast - interface org.objectweb.dream.queue.ListAddFirstLast.
This interface defines methods that must be implemented by a list that allows adding messages at the end or beginning of the list.
ListAddRemoveFirstLastFastImpl - class org.objectweb.dream.queue.ListAddRemoveFirstLastFastImpl.
The ListAddRemoveFirstLastFastImpl class is just a linked list that supports very efficient insertion and deletion, as well as an Enumeration interface.
ListAddRemoveFirstLastFastImpl() - Constructor for class org.objectweb.dream.queue.ListAddRemoveFirstLastFastImpl
Allocates a brand new ListAddRemoveFirstLastFastImpl.
ListAddRemoveFirstLastFastImpl.Element - class org.objectweb.dream.queue.ListAddRemoveFirstLastFastImpl.Element.
This class represents elements of a linked list.
ListAddRemoveFirstLastFastImpl.Element() - Constructor for class org.objectweb.dream.queue.ListAddRemoveFirstLastFastImpl.Element
 
ListAddRemoveFirstLastFastImpl.FastLinkedListEnumeration - class org.objectweb.dream.queue.ListAddRemoveFirstLastFastImpl.FastLinkedListEnumeration.
A FastLinkedListEnumeration is a java.util.Enumeration over the ListAddRemoveFirstLastFastImpl elements.
ListAddRemoveFirstLastFastImpl.FastLinkedListEnumeration() - Constructor for class org.objectweb.dream.queue.ListAddRemoveFirstLastFastImpl.FastLinkedListEnumeration
Constructor.
ListAddRemoveFirstLastImpl - class org.objectweb.dream.queue.ListAddRemoveFirstLastImpl.
The ListAddRemoveFirstLastFastImpl class implements the List, ListAddFirstLast, and ListRemoveFirstLastinterfaces using a LinkedList.
ListAddRemoveFirstLastImpl() - Constructor for class org.objectweb.dream.queue.ListAddRemoveFirstLastImpl
 
ListRemoveFirstLast - interface org.objectweb.dream.queue.ListRemoveFirstLast.
This interface defines methods that must be implemented by a list that allows getting/removing messages from the end or beginning of the list.
LockPullUnlockImpl - class org.objectweb.dream.synchro.LockPullUnlockImpl.
This component has a Pull output.
LockPullUnlockImpl() - Constructor for class org.objectweb.dream.synchro.LockPullUnlockImpl
 
LockPushUnlockImpl - class org.objectweb.dream.synchro.LockPushUnlockImpl.
This component has a Push input.
LockPushUnlockImpl() - Constructor for class org.objectweb.dream.synchro.LockPushUnlockImpl
 
last - Variable in class org.objectweb.dream.queue.BufferAscendingSequenceNumberImpl
The last element stored in this buffer.
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.
listFc() - Method in class org.objectweb.dream.aggregator.PullPullAggregatorCollectionInputImpl
 
listFc() - Method in class org.objectweb.dream.aggregator.PullPullAggregatorContextualImpl
 
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.PushPullAggregatorImpl
 
listFc() - Method in class org.objectweb.dream.aggregator.PushPushDeAggregatorImpl
 
listFc() - Method in class org.objectweb.dream.cache.CacheImpl
 
listFc() - Method in class org.objectweb.dream.channel.AbstractAcceptSocketImpl
 
listFc() - Method in class org.objectweb.dream.channel.AddIPChannelDestinationChunkImpl
 
listFc() - Method in class org.objectweb.dream.channel.AddIPChannelSourceChunkImpl
 
listFc() - Method in class org.objectweb.dream.channel.GenericPushChannelInImpl
 
listFc() - Method in class org.objectweb.dream.channel.GenericPushChannelOutImpl
 
listFc() - Method in class org.objectweb.dream.channel.IPSocketManagerCachingImpl
 
listFc() - Method in class org.objectweb.dream.channel.IPSocketManagerTCPImpl
 
listFc() - Method in class org.objectweb.dream.channel.OpenedSocketManagerMonoNotPersistentImpl
 
listFc() - Method in class org.objectweb.dream.channel.OpenedSocketManagerMonoPersistentImpl
 
listFc() - Method in class org.objectweb.dream.channel.OpenedSocketManagerMultiPersistentImpl
 
listFc() - Method in class org.objectweb.dream.channel.SendByteStreamImpl
 
listFc() - Method in class org.objectweb.dream.channel.SocketManagerIPChunkBasedImpl
 
listFc() - Method in class org.objectweb.dream.channel.SocketManagerIPStaticImpl
 
listFc() - Method in class org.objectweb.dream.channel.WaitByteStreamImpl
 
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.multiplexer.PullPushMultiplexerImpl
 
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.causality.InMessageSorterImpl
 
listFc() - Method in class org.objectweb.dream.protocol.causality.MatrixClockImpl
 
listFc() - Method in class org.objectweb.dream.protocol.causality.MatrixClockUpdateImpl
 
listFc() - Method in class org.objectweb.dream.protocol.causality.OutMessageStamperImpl
 
listFc() - Method in class org.objectweb.dream.protocol.utobcast.ACKImpl
 
listFc() - Method in class org.objectweb.dream.protocol.utobcast.BAKImpl
 
listFc() - Method in class org.objectweb.dream.protocol.utobcast.BackupElectionImpl
 
listFc() - Method in class org.objectweb.dream.protocol.utobcast.BroadcastImpl
 
listFc() - Method in class org.objectweb.dream.protocol.utobcast.DATImpl
 
listFc() - Method in class org.objectweb.dream.protocol.utobcast.DeliveredMessageRouterImpl
 
listFc() - Method in class org.objectweb.dream.protocol.utobcast.IncomingMessageRouterImpl
 
listFc() - Method in class org.objectweb.dream.protocol.utobcast.LeaderFaultForwarderImpl
 
listFc() - Method in class org.objectweb.dream.protocol.utobcast.PendingMessagesDataStructureImpl
 
listFc() - Method in class org.objectweb.dream.protocol.utobcast.ProcessMembershipImpl
 
listFc() - Method in class org.objectweb.dream.protocol.utobcast.REPImpl
 
listFc() - Method in class org.objectweb.dream.protocol.utobcast.SequenceNumberImpl
 
listFc() - Method in class org.objectweb.dream.protocol.utobcast.UPDImpl
 
listFc() - Method in class org.objectweb.dream.protocol.utobcast.UTOImpl
 
listFc() - Method in class org.objectweb.dream.pump.PumpSynchronizedImpl
 
listFc() - Method in class org.objectweb.dream.pushwithreturn.KeyGeneratorIntegerImpl
 
listFc() - Method in class org.objectweb.dream.pushwithreturn.SynchronizerImpl
 
listFc() - Method in class org.objectweb.dream.queue.AbstractBufferImpl
 
listFc() - Method in class org.objectweb.dream.queue.AbstractPullOutgoingHandlerImpl
 
listFc() - Method in class org.objectweb.dream.queue.AbstractPushIncomingHandlerOverflowImpl
 
listFc() - Method in class org.objectweb.dream.queue.BufferAscendingSequenceNumberImpl
 
listFc() - Method in class org.objectweb.dream.queue.BufferImpl
 
listFc() - Method in class org.objectweb.dream.queue.ListAddRemoveFirstLastFastImpl
 
listFc() - Method in class org.objectweb.dream.queue.ListAddRemoveFirstLastImpl
 
listFc() - Method in class org.objectweb.dream.queue.PushIncomingHandlerImpl
 
listFc() - Method in class org.objectweb.dream.queue.PushOutgoingHandlerActiveImpl
 
listFc() - Method in class org.objectweb.dream.queue.PushPullQueueNotSynchronizedImpl
 
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.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.time.TimeStampImpl
 
listFc() - Method in class org.objectweb.dream.xml.SaxXercesParser
 
listItf - Variable in class org.objectweb.dream.queue.PushPullQueueNotSynchronizedImpl
 
listen - Variable in class org.objectweb.dream.channel.TCPAcceptSocketImpl
The ServerSocketused by this component
listeningPort - Variable in class org.objectweb.dream.channel.TCPAcceptSocketImpl
 
lock - Variable in class org.objectweb.dream.queue.AbstractBufferImpl
A lock object.
lock() - Method in interface org.objectweb.dream.synchro.Mutex
Acquires the mutex.
lock() - Method in class org.objectweb.dream.synchro.MutexImpl
 
lookupFc(String) - Method in class org.objectweb.dream.xml.SaxXercesParser
 
lruAddAtFirst() - Method in class org.objectweb.dream.channel.IPSocketManagerCachingImpl.CacheEntry
 
lruHead - Variable in class org.objectweb.dream.channel.IPSocketManagerCachingImpl
 
lruRemove() - Method in class org.objectweb.dream.channel.IPSocketManagerCachingImpl.CacheEntry
 
lruSetAtfirst() - Method in class org.objectweb.dream.channel.IPSocketManagerCachingImpl.CacheEntry
 
lruTail - Variable in class org.objectweb.dream.channel.IPSocketManagerCachingImpl
 

M

MATRIX_CLOCK_ITF_NAME - Static variable in interface org.objectweb.dream.protocol.causality.MatrixClock
The default name of MatrixClockinterfaces
MUTEX_ITF_NAME - Static variable in interface org.objectweb.dream.synchro.Mutex
The default name of the Mutexinterface.
MatrixClock - interface org.objectweb.dream.protocol.causality.MatrixClock.
Component interfae to manipulate causal matrix clock.
MatrixClockAttributeController - interface org.objectweb.dream.protocol.causality.MatrixClockAttributeController.
Matrix clock attribute controller interface.
MatrixClockImpl - class org.objectweb.dream.protocol.causality.MatrixClockImpl.
Basic Implementation of a matrix clock.
MatrixClockImpl() - Constructor for class org.objectweb.dream.protocol.causality.MatrixClockImpl
 
MatrixClockUpdateImpl - class org.objectweb.dream.protocol.causality.MatrixClockUpdateImpl.
Matric clock implementation using Updateas stamp.
MatrixClockUpdateImpl() - Constructor for class org.objectweb.dream.protocol.causality.MatrixClockUpdateImpl
 
Mutex - interface org.objectweb.dream.synchro.Mutex.
A mutex component aims at synchronizing the execution of several components.
MutexImpl - class org.objectweb.dream.synchro.MutexImpl.
Basic implementation of the Mutexinterface.
MutexImpl() - Constructor for class org.objectweb.dream.synchro.MutexImpl
 
maxCapacity - Variable in class org.objectweb.dream.queue.AbstractBufferImpl
The maximal capacity of the buffer.
maxOpenedSocket - Variable in class org.objectweb.dream.channel.OpenedSocketManagerMultiPersistentImpl
 
messageCodecItf - Variable in class org.objectweb.dream.channel.GenericPushChannelInImpl
 
messageCodecItf - Variable in class org.objectweb.dream.channel.GenericPushChannelOutImpl
 
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.PullPullAggregatorContextualImpl
 
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.PushPullAggregatorImpl
the message manager client interface of this component.
messageManagerItf - Variable in class org.objectweb.dream.aggregator.PushPushDeAggregatorImpl
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.AddIPChannelDestinationChunkImpl
the message manager client interface of this component.
messageManagerItf - Variable in class org.objectweb.dream.channel.AddIPChannelSourceChunkImpl
the message manager client interface of this component.
messageManagerItf - Variable in class org.objectweb.dream.channel.GenericPushChannelInImpl
 
messageManagerItf - Variable in class org.objectweb.dream.channel.GenericPushChannelOutImpl
 
messageManagerItf - Variable in class org.objectweb.dream.channel.SocketManagerIPChunkBasedImpl
 
messageManagerItf - Variable in class org.objectweb.dream.multiplexer.PullPushMultiplexerImpl
The message manager client interface of this component
messageManagerItf - Variable in class org.objectweb.dream.protocol.utobcast.BAKImpl
The interface to manage message lifecycle.
messageManagerItf - Variable in class org.objectweb.dream.protocol.utobcast.BackupElectionImpl
The interface to manage message lifecycle.
messageManagerItf - Variable in class org.objectweb.dream.protocol.utobcast.BroadcastImpl
The interface to manage message lifecycle.
messageManagerItf - Variable in class org.objectweb.dream.protocol.utobcast.DATImpl
The interface to manage message lifecycle.
messageManagerItf - Variable in class org.objectweb.dream.protocol.utobcast.LeaderFaultForwarderImpl
The interface to manage message lifecycle.
messageManagerItf - Variable in class org.objectweb.dream.protocol.utobcast.PendingMessagesDataStructureImpl
The interface to manage message lifecycle.
messageManagerItf - Variable in class org.objectweb.dream.protocol.utobcast.REPImpl
The interface to manage message lifecycle.
messageManagerItf - Variable in class org.objectweb.dream.protocol.utobcast.UPDImpl
The interface to manage message lifecycle.
messageManagerItf - Variable in class org.objectweb.dream.protocol.utobcast.UTOImpl
The interface to manage message lifecycle.
messageManagerItf - Variable in class org.objectweb.dream.queue.AbstractBufferImpl
The MessageManager client interface.
messageManagerItf - Variable in class org.objectweb.dream.queue.AbstractPushIncomingHandlerOverflowImpl
 
messageManagerItf - Variable in class org.objectweb.dream.queue.PushOutgoingHandlerActiveImpl
 
messageManagerItf - Variable in class org.objectweb.dream.router.AbstractRouterImpl
the message manager client interface of this component
mutexItf - Variable in class org.objectweb.dream.pump.PumpSynchronizedImpl
The server interface to which this component is bound.
mutexItf - Variable in class org.objectweb.dream.synchro.LockPullUnlockImpl
 
mutexItf - Variable in class org.objectweb.dream.synchro.LockPushUnlockImpl
 

N

nbMaxSocket - Variable in class org.objectweb.dream.channel.IPSocketManagerCachingImpl
 
nbOpenedSocket - Variable in class org.objectweb.dream.channel.OpenedSocketManagerMultiPersistentImpl
 
newBackup(Process) - Method in class org.objectweb.dream.protocol.utobcast.LeaderFaultForwarderImpl
 
newBackup(Process) - Method in interface org.objectweb.dream.protocol.utobcast.ProcessMembershipUpdateNotification
Notifies the component that a new backup has been elected.
newLeader(Process) - Method in class org.objectweb.dream.protocol.utobcast.LeaderFaultForwarderImpl
 
newLeader(Process) - Method in interface org.objectweb.dream.protocol.utobcast.ProcessMembershipUpdateNotification
Notifies the component that a new leader has been elected.
newProcesses(Process[]) - Method in class org.objectweb.dream.protocol.utobcast.LeaderFaultForwarderImpl
 
newProcesses(Process[]) - Method in interface org.objectweb.dream.protocol.utobcast.ProcessMembershipUpdateNotification
Notifies the component that new processes have joined.
next - Variable in class org.objectweb.dream.channel.IPSocketManagerCachingImpl.CacheEntry
 
nextAggregatedMessage - Variable in class org.objectweb.dream.aggregator.PushPullAggregatorImpl
The aggregated message that will be returned by the next call of the pull method.
nextDeadline - Variable in class org.objectweb.dream.multiplexer.PeriodicAttachment
 
nextElement() - Method in class org.objectweb.dream.queue.ListAddRemoveFirstLastFastImpl.FastLinkedListEnumeration
 

O

OPEN_RETRY_DEFAULT - Static variable in interface org.objectweb.dream.channel.TCPAcceptSocketAttributeController
Default value of openRetry attribute.
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.
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.
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.
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
OpenedSocket - interface org.objectweb.dream.channel.OpenedSocket.
Interface used by Push ChannelIn components to exchange open socket.
OpenedSocketManagerMonoNotPersistentImpl - class org.objectweb.dream.channel.OpenedSocketManagerMonoNotPersistentImpl.
A opened socket manager for mono connection Channel.
OpenedSocketManagerMonoNotPersistentImpl() - Constructor for class org.objectweb.dream.channel.OpenedSocketManagerMonoNotPersistentImpl
 
OpenedSocketManagerMonoPersistentImpl - class org.objectweb.dream.channel.OpenedSocketManagerMonoPersistentImpl.
A opened socket manager for persistent mono connection Channel.
OpenedSocketManagerMonoPersistentImpl() - Constructor for class org.objectweb.dream.channel.OpenedSocketManagerMonoPersistentImpl
 
OpenedSocketManagerMultiAttributeController - interface org.objectweb.dream.channel.OpenedSocketManagerMultiAttributeController.
Attribute controller for multi threaded opened socket manager.
OpenedSocketManagerMultiPersistentImpl - class org.objectweb.dream.channel.OpenedSocketManagerMultiPersistentImpl.
Opened socket manager component that lanage multiple opened sockets at a time.
OpenedSocketManagerMultiPersistentImpl() - Constructor for class org.objectweb.dream.channel.OpenedSocketManagerMultiPersistentImpl
 
OpenedSocketManagerMultiPersistentImpl.InTask - class org.objectweb.dream.channel.OpenedSocketManagerMultiPersistentImpl.InTask.
 
OpenedSocketManagerMultiPersistentImpl.InTask() - Constructor for class org.objectweb.dream.channel.OpenedSocketManagerMultiPersistentImpl.InTask
Constructor
OutMessageStamperImpl - class org.objectweb.dream.protocol.causality.OutMessageStamperImpl.
Outgoing Message stamper.
OutMessageStamperImpl() - Constructor for class org.objectweb.dream.protocol.causality.OutMessageStamperImpl
 
objectPoolItf - Variable in class org.objectweb.dream.queue.BufferAscendingSequenceNumberImpl
The client interface used to access the pool of BufferAscendingSequenceNumberImpl.Elementinstances.
objectPoolItf - Variable in class org.objectweb.dream.queue.ListAddRemoveFirstLastFastImpl
The client interface used to access the pool of ListAddRemoveFirstLastFastImpl.Elementinstances.
openRetry - Variable in class org.objectweb.dream.channel.TCPAcceptSocketImpl
 
openedSocket(SocketState) - Method in class org.objectweb.dream.channel.GenericPushChannelInImpl
 
openedSocket(SocketState) - Method in interface org.objectweb.dream.channel.OpenedSocket
Gives an opened socket.
openedSocket(SocketState) - Method in class org.objectweb.dream.channel.OpenedSocketManagerMonoNotPersistentImpl
 
openedSocket(SocketState) - Method in class org.objectweb.dream.channel.OpenedSocketManagerMonoPersistentImpl
 
openedSocket(SocketState) - Method in class org.objectweb.dream.channel.OpenedSocketManagerMultiPersistentImpl
 
openedSocketItf - Variable in class org.objectweb.dream.channel.AbstractAcceptSocketImpl
 
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
Channel components are used to exchange messages between different address spaces.
org.objectweb.dream.exception - package org.objectweb.dream.exception
 
org.objectweb.dream.multiplexer - package org.objectweb.dream.multiplexer
 
org.objectweb.dream.protocol - package org.objectweb.dream.protocol
 
org.objectweb.dream.protocol.atomicity - package org.objectweb.dream.protocol.atomicity
 
org.objectweb.dream.protocol.causality - package org.objectweb.dream.protocol.causality
 
org.objectweb.dream.protocol.utobcast - package org.objectweb.dream.protocol.utobcast
 
org.objectweb.dream.protocol.utobcast.message - package org.objectweb.dream.protocol.utobcast.message
 
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.router - package org.objectweb.dream.router
 
org.objectweb.dream.synchro - package org.objectweb.dream.synchro
 
org.objectweb.dream.time - package org.objectweb.dream.time
 
org.objectweb.dream.xml - package org.objectweb.dream.xml
 
outPushItf - Variable in class org.objectweb.dream.channel.GenericPushChannelInImpl
 
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.protocol.utobcast.BackupElectionImpl
The interface to send BAK, REP, and UPD messages.
outPushItf - Variable in class org.objectweb.dream.protocol.utobcast.BroadcastImpl
The interface to send messages to be delivered.
outPushItf - Variable in class org.objectweb.dream.protocol.utobcast.DATImpl
The interface to send REP messages to pbackup.
outPushItf - Variable in class org.objectweb.dream.protocol.utobcast.LeaderFaultForwarderImpl
The interface to send "AllKey" messages.
outPushItf - Variable in class org.objectweb.dream.protocol.utobcast.REPImpl
The interface to send UTO and ACK messages.
outPushItf - Variable in class org.objectweb.dream.protocol.utobcast.UTOImpl
The interface to send ACK messages.
outPushItf - Variable in class org.objectweb.dream.pump.PumpSynchronizedImpl
The server interface to which this component is bound.
outPushItf - Variable in class org.objectweb.dream.queue.PushOutgoingHandlerActiveImpl
 
outPushItf - Variable in class org.objectweb.dream.synchro.LockPushUnlockImpl
 
outPushItfs - Variable in class org.objectweb.dream.protocol.utobcast.IncomingMessageRouterImpl
The outputs.
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.
outPushWithReturnItf - Variable in class org.objectweb.dream.protocol.utobcast.BroadcastImpl
The interface to send messages to be UTO broadcast.
outPushWithoutChunkItf - Variable in class org.objectweb.dream.router.RouterChunkNameImpl
The interface used to push messages without the specified chunk name.
output - Variable in class org.objectweb.dream.channel.SocketStateImpl
 
outputContexts - Variable in class org.objectweb.dream.multiplexer.Attachment
The context to be passed to outputs when they are used.
outputNames - Variable in class org.objectweb.dream.multiplexer.Attachment
The name of the outputs to which inputs are attached.
outputs - Variable in class org.objectweb.dream.multiplexer.Attachment
The outputs to which inputs are attached.
outputs - Variable in class org.objectweb.dream.multiplexer.PullPushMultiplexerImpl
An hashtable storing the outputs of this component.
overflowPolicy - Variable in class org.objectweb.dream.queue.AbstractPushIncomingHandlerOverflowImpl
 
overflowPolicyId - Variable in class org.objectweb.dream.queue.AbstractPushIncomingHandlerOverflowImpl
 

P

PENDING_MESSAGES_IN_ITF_NAME - Static variable in class org.objectweb.dream.protocol.utobcast.DATImpl
The commonly used name to refer to the pendingMessageInItf interface.
PENDING_MESSAGES_IN_ITF_NAME - Static variable in class org.objectweb.dream.protocol.utobcast.REPImpl
The commonly used name to refer to the pendingMessageInItf interface.
PENDING_MESSAGES_IN_ITF_NAME - Static variable in class org.objectweb.dream.protocol.utobcast.UPDImpl
The commonly used name to refer to the pendingMessageInItf interface.
PENDING_MESSAGES_OUT_ITF_NAME - Static variable in class org.objectweb.dream.protocol.utobcast.BackupElectionImpl
The commonly used name to refer to the pendingMessageOutItf interface.
PENDING_MESSAGES_OUT_ITF_NAME - Static variable in class org.objectweb.dream.protocol.utobcast.PendingMessagesDataStructureImpl
The commonly used name to refer to the pendingMessageOutItf interface.
PERIOD_INIT_PARAM_NAME - Static variable in class org.objectweb.dream.pump.PumpPeriodicSynchronizedImpl
The initialization parameter that can be passed to this component to specify the pump's period.
PULLING_FREQUENCY - Static variable in class org.objectweb.dream.multiplexer.PeriodicAttachment
The name of the key that must be used to specify the pulling frequency of this attachment in the parameters passed to the PullPushMultiplexer.attach(String[], Map[], String[], Map[], Map)
PendingMessagesDataStructureImpl - class org.objectweb.dream.protocol.utobcast.PendingMessagesDataStructureImpl.
Implementation of the PendingMessagesDataStructure component.
PendingMessagesDataStructureImpl() - Constructor for class org.objectweb.dream.protocol.utobcast.PendingMessagesDataStructureImpl
Constructor.
PeriodicAttachment - class org.objectweb.dream.multiplexer.PeriodicAttachment.
This class defines a periodic attachment.
PeriodicAttachment(int, String[], Pull[], Map[], String[], Push[], Map[], long, long, long) - Constructor for class org.objectweb.dream.multiplexer.PeriodicAttachment
Creates a new Attachment object
PeriodicAttachment(int, String[], Pull[], Map[], String[], Push[], Map[], long, long) - Constructor for class org.objectweb.dream.multiplexer.PeriodicAttachment
Creates a new Attachment object without an end date.
Process - interface org.objectweb.dream.protocol.Process.
This interface represents a process.
ProcessImpl - class org.objectweb.dream.protocol.ProcessImpl.
Implementation of the Processinterface.
ProcessImpl(short) - Constructor for class org.objectweb.dream.protocol.ProcessImpl
Allocates a new ProcessImpl object.
ProcessMembership - interface org.objectweb.dream.protocol.utobcast.ProcessMembership.
This interface defines methods for managing a group of processes.
ProcessMembershipAttributeController - interface org.objectweb.dream.protocol.utobcast.ProcessMembershipAttributeController.
An attribute controller for the ProcessMembership component.
ProcessMembershipImpl - class org.objectweb.dream.protocol.utobcast.ProcessMembershipImpl.
Implementation of the ProcessMembershipinterface.
ProcessMembershipImpl() - Constructor for class org.objectweb.dream.protocol.utobcast.ProcessMembershipImpl
Constructor.
ProcessMembershipUpdateNotification - interface org.objectweb.dream.protocol.utobcast.ProcessMembershipUpdateNotification.
This interface defines methods for being notified about ProcessMembership updates.
PullOutgoingHandlerImpl - class org.objectweb.dream.queue.PullOutgoingHandlerImpl.
Basic implementation of a Pull outgoing handler.
PullOutgoingHandlerImpl() - Constructor for class org.objectweb.dream.queue.PullOutgoingHandlerImpl
 
PullPullAggregatorCollectionInputImpl - class org.objectweb.dream.aggregator.PullPullAggregatorCollectionInputImpl.
This aggregator has a collection of pull inputs, and a pull output.
PullPullAggregatorCollectionInputImpl() - Constructor for class org.objectweb.dream.aggregator.PullPullAggregatorCollectionInputImpl
 
PullPullAggregatorContextualImpl - class org.objectweb.dream.aggregator.PullPullAggregatorContextualImpl.
This aggregator has a pull output on which it receives pull calls requiring an aggregated message.
PullPullAggregatorContextualImpl() - Constructor for class org.objectweb.dream.aggregator.PullPullAggregatorContextualImpl
 
PullPullAggregatorContextualKey - interface org.objectweb.dream.aggregator.PullPullAggregatorContextualKey.
This interface contains the key that must be used to specify (in the pull context) the number of messages to be aggregated.
PullPullAggregatorFixedNumberAttributeController - interface org.objectweb.dream.aggregator.PullPullAggregatorFixedNumberAttributeController.
Attribute controller for Pull/Pull aggregators that aggregate a fixed number of messages.
PullPullAggregatorFixedNumberImpl - class org.objectweb.dream.aggregator.PullPullAggregatorFixedNumberImpl.
This aggregator aggregates a fixed number of messages.
PullPullAggregatorFixedNumberImpl() - Constructor for class org.objectweb.dream.aggregator.PullPullAggregatorFixedNumberImpl
 
PullPullAggregatorWhileNotNullAttributeController - interface org.objectweb.dream.aggregator.PullPullAggregatorWhileNotNullAttributeController.
Attribute controller interface for PullPullAggregatorWhileNotNullImplaggregator implementation.
PullPullAggregatorWhileNotNullImpl - class org.objectweb.dream.aggregator.PullPullAggregatorWhileNotNullImpl.
TODO Add class comment
PullPullAggregatorWhileNotNullImpl() - Constructor for class org.objectweb.dream.aggregator.PullPullAggregatorWhileNotNullImpl
 
PullPushMultiplexer - interface org.objectweb.dream.multiplexer.PullPushMultiplexer.
This interface defines a pull-push multiplexer.
PullPushMultiplexerImpl - class org.objectweb.dream.multiplexer.PullPushMultiplexerImpl.
Implementation of the PullPushMultiplexer interface.
PullPushMultiplexerImpl() - Constructor for class org.objectweb.dream.multiplexer.PullPushMultiplexerImpl
Constructor.
PullQueueAttributeController - interface org.objectweb.dream.queue.PullQueueAttributeController.
Attribute controller interface for Push/Pull queue.
PumpAttributeController - interface org.objectweb.dream.pump.PumpAttributeController.
Attribute controller for pump components.
PumpPeriodicAttributeController - interface org.objectweb.dream.pump.PumpPeriodicAttributeController.
Periodic pump attribute controller interface.
PumpPeriodicSynchronizedImpl - class org.objectweb.dream.pump.PumpPeriodicSynchronizedImpl.
Extention of the basic pump that use a period T (in ms).
PumpPeriodicSynchronizedImpl() - Constructor for class org.objectweb.dream.pump.PumpPeriodicSynchronizedImpl
Default constructor
PumpSynchronizedImpl - class org.objectweb.dream.pump.PumpSynchronizedImpl.
Synchronized implementation of a Pull/Push pump.
PumpSynchronizedImpl() - Constructor for class org.objectweb.dream.pump.PumpSynchronizedImpl
 
PushIncomingHandlerImpl - class org.objectweb.dream.queue.PushIncomingHandlerImpl.
Abstract implementation of a Push incoming handler.
PushIncomingHandlerImpl() - Constructor for class org.objectweb.dream.queue.PushIncomingHandlerImpl
 
PushIncomingHandlerOverflowImpl - class org.objectweb.dream.queue.PushIncomingHandlerOverflowImpl.
Basic implementation of a Push incoming handler.
PushIncomingHandlerOverflowImpl() - Constructor for class org.objectweb.dream.queue.PushIncomingHandlerOverflowImpl
 
PushOutgoingHandlerActiveImpl - class org.objectweb.dream.queue.PushOutgoingHandlerActiveImpl.
Basic implementation of a Pull outgoing handler.
PushOutgoingHandlerActiveImpl() - Constructor for class org.objectweb.dream.queue.PushOutgoingHandlerActiveImpl
 
PushPullAggregatorImpl - class org.objectweb.dream.aggregator.PushPullAggregatorImpl.
Basic implementation of a Push/Pull aggregator.
PushPullAggregatorImpl() - Constructor for class org.objectweb.dream.aggregator.PushPullAggregatorImpl
 
PushPullKeyQueueAttributeController - interface org.objectweb.dream.queue.PushPullKeyQueueAttributeController.
Key based Push/Pull queue attribute controller.
PushPullQueueNotSynchronizedImpl - class org.objectweb.dream.queue.PushPullQueueNotSynchronizedImpl.
High performance implementation of a Push/Pull queue.
PushPullQueueNotSynchronizedImpl() - Constructor for class org.objectweb.dream.queue.PushPullQueueNotSynchronizedImpl
 
PushPushDeAggregatorImpl - class org.objectweb.dream.aggregator.PushPushDeAggregatorImpl.
Basic implementation of a Push/Push de-aggregator.
PushPushDeAggregatorImpl() - Constructor for class org.objectweb.dream.aggregator.PushPushDeAggregatorImpl
 
PushPushQueuePassiveAttributeController - interface org.objectweb.dream.queue.PushPushQueuePassiveAttributeController.
Attribute controller interface for PushPushPassive component.
PushQueueAttributeController - interface org.objectweb.dream.queue.PushQueueAttributeController.
Attribute controller for queue implementation with a push input.
PushQueuePrimitiveComponentAttributeController - interface org.objectweb.dream.queue.PushQueuePrimitiveComponentAttributeController.
Attribute controller for queues implemented by a primitive component.
pendingMessagesInItf - Variable in class org.objectweb.dream.protocol.utobcast.DATImpl
The interface to store messages in the PendingMessage queue.
pendingMessagesInItf - Variable in class org.objectweb.dream.protocol.utobcast.REPImpl
The interface to store messages in the PendingMessage queue.
pendingMessagesInItf - Variable in class org.objectweb.dream.protocol.utobcast.UPDImpl
The interface to store messages in the PendingMessage queue.
pendingMessagesOutItf - Variable in class org.objectweb.dream.protocol.utobcast.BackupElectionImpl
The interface to retrieve messages in the PendingMessage queue.
period - Variable in class org.objectweb.dream.pump.PumpPeriodicSynchronizedImpl
 
port - Variable in class org.objectweb.dream.channel.AddIPChannelDestinationChunkImpl
the port set in the chunk.
port - Variable in class org.objectweb.dream.channel.AddIPChannelSourceChunkImpl
the port set in the chunk.
port - Variable in class org.objectweb.dream.channel.IPSocketManagerCachingImpl.CacheEntry
 
prev - Variable in class org.objectweb.dream.channel.IPSocketManagerCachingImpl.CacheEntry
 
processFrom - Variable in class org.objectweb.dream.protocol.utobcast.message.UTOBcastChunkImpl
The process that sent this chunk.
processMembershipItf - Variable in class org.objectweb.dream.protocol.utobcast.BAKImpl
The interface to retrieve process membership information.
processMembershipItf - Variable in class org.objectweb.dream.protocol.utobcast.BackupElectionImpl
The interface to retrieve process membership information.
processMembershipItf - Variable in class org.objectweb.dream.protocol.utobcast.BroadcastImpl
The interface to retrieve process membership information.
processMembershipItf - Variable in class org.objectweb.dream.protocol.utobcast.DATImpl
The interface to retrieve process membership information.
processMembershipItf - Variable in class org.objectweb.dream.protocol.utobcast.PendingMessagesDataStructureImpl
The interface to retrieve process membership information.
processMembershipItf - Variable in class org.objectweb.dream.protocol.utobcast.REPImpl
The interface to retrieve process membership information.
processMembershipItf - Variable in class org.objectweb.dream.protocol.utobcast.UPDImpl
The interface to retrieve process membership information.
processMembershipItf - Variable in class org.objectweb.dream.protocol.utobcast.UTOImpl
The interface to retrieve process membership information.
processTo - Variable in class org.objectweb.dream.protocol.utobcast.message.UTOBcastChunkImpl
The process to which this chunk is destinated.
processes - Variable in class org.objectweb.dream.protocol.utobcast.message.UPDChunkImpl
The process array.
pull(Map) - Method in class org.objectweb.dream.aggregator.PullPullAggregatorCollectionInputImpl
 
pull(Map) - Method in class org.objectweb.dream.aggregator.PullPullAggregatorContextualImpl
 
pull(Map) - Method in class org.objectweb.dream.aggregator.PullPullAggregatorFixedNumberImpl
 
pull(Map) - Method in class org.objectweb.dream.aggregator.PullPullAggregatorWhileNotNullImpl
 
pull(Map) - Method in class org.objectweb.dream.aggregator.PushPullAggregatorImpl
 
pull(Map) - Method in class org.objectweb.dream.cache.CacheImpl
 
pull(Map) - Method in class org.objectweb.dream.protocol.utobcast.PendingMessagesDataStructureImpl
 
pull(Map) - Method in class org.objectweb.dream.queue.AbstractPullOutgoingHandlerImpl
 
pull(Map) - Method in class org.objectweb.dream.queue.PushPullQueueNotSynchronizedImpl
 
pull(Map) - Method in class org.objectweb.dream.synchro.LockPullUnlockImpl
 
pullingFrequencyInMillis - Variable in class org.objectweb.dream.multiplexer.PeriodicAttachment
 
pullingFrequencyInMillis() - Method in class org.objectweb.dream.multiplexer.PeriodicAttachment
Returns the samplingFrequencyInMillis value.
pumpTask - Variable in class org.objectweb.dream.pump.PumpSynchronizedImpl
 
push(Message, Map) - Method in class org.objectweb.dream.aggregator.PushPullAggregatorImpl
 
push(Message, Map) - Method in class org.objectweb.dream.aggregator.PushPushDeAggregatorImpl
 
push(Message, Map) - Method in class org.objectweb.dream.channel.AddIPChannelDestinationChunkImpl
 
push(Message, Map) - Method in class org.objectweb.dream.channel.AddIPChannelSourceChunkImpl
 
push(Message, Map) - Method in class org.objectweb.dream.channel.GenericPushChannelOutImpl
 
push(Message, Map) - Method in class org.objectweb.dream.exception.CatchPushExceptionImpl
 
push(Message, Map) - Method in class org.objectweb.dream.exception.RetryPushImpl
 
push(Message, Map) - Method in class org.objectweb.dream.protocol.atomicity.AtomicReactorImpl
 
push(Message, Map) - Method in class org.objectweb.dream.protocol.atomicity.AtomicRouterImpl
 
push(Message, Map) - Method in class org.objectweb.dream.protocol.causality.InMessageSorterImpl
 
push(Message, Map) - Method in class org.objectweb.dream.protocol.causality.OutMessageStamperImpl
 
push(Message, Map) - Method in class org.objectweb.dream.protocol.utobcast.ACKImpl
 
push(Message, Map) - Method in class org.objectweb.dream.protocol.utobcast.BAKImpl
 
push(Message, Map) - Method in class org.objectweb.dream.protocol.utobcast.BroadcastImpl
 
push(Message, Map) - Method in class org.objectweb.dream.protocol.utobcast.DATImpl
 
push(Message, Map) - Method in class org.objectweb.dream.protocol.utobcast.DeliveredMessageRouterImpl
 
push(Message, Map) - Method in class org.objectweb.dream.protocol.utobcast.IncomingMessageRouterImpl
 
push(Message, Map) - Method in class org.objectweb.dream.protocol.utobcast.PendingMessagesDataStructureImpl
 
push(Message, Map) - Method in class org.objectweb.dream.protocol.utobcast.REPImpl
 
push(Message, Map) - Method in class org.objectweb.dream.protocol.utobcast.UPDImpl
 
push(Message, Map) - Method in class org.objectweb.dream.protocol.utobcast.UTOImpl
 
push(Message, Map) - Method in class org.objectweb.dream.pushwithreturn.SynchronizerImpl
 
push(Message, Map) - Method in class org.objectweb.dream.queue.AbstractPushIncomingHandlerOverflowImpl
 
push(Message, Map) - Method in class org.objectweb.dream.queue.PushIncomingHandlerImpl
 
push(Message, Map) - Method in class org.objectweb.dream.queue.PushPullQueueNotSynchronizedImpl
 
push(Message, Map) - Method in class org.objectweb.dream.router.AbstractRouterImpl
Sends the incoming message to one of the router's output.
push(Message, Map) - Method in class org.objectweb.dream.router.RouterChunkNameImpl
 
push(Message, Map) - Method in class org.objectweb.dream.synchro.LockPushUnlockImpl
 
push1(Message, Map) - Method in class org.objectweb.dream.pushwithreturn.SynchronizerImpl
 
pushNullPolicy - Variable in class org.objectweb.dream.pump.PumpSynchronizedImpl
 
pushWithReturn(Message, Map) - Method in class org.objectweb.dream.pushwithreturn.SynchronizerImpl
 

Q

QueueAttributeController - interface org.objectweb.dream.queue.QueueAttributeController.
Base attribute controller interface for queue implementations.
QueueSortedAttributeController - interface org.objectweb.dream.queue.QueueSortedAttributeController.
Sorted queue attribute controller.
queueTask - Variable in class org.objectweb.dream.queue.PushOutgoingHandlerActiveImpl
 

R

REP - Static variable in interface org.objectweb.dream.protocol.utobcast.message.UTOBcastChunk
The byte value for REP message type.
REPImpl - class org.objectweb.dream.protocol.utobcast.REPImpl.
Implementation of the REP component.
REPImpl() - Constructor for class org.objectweb.dream.protocol.utobcast.REPImpl
Constructor.
RETURN_NULL_MESSAGE_NOT_FOUND_POLICY - Static variable in interface org.objectweb.dream.queue.PushPullKeyQueueAttributeController
"Message not found" policy that returns null as result of the pull method.
ReceiveAck - interface org.objectweb.dream.protocol.utobcast.ReceiveAck.
This interface defines a method to notify a component that an ACK message has been received.
RetryPushImpl - class org.objectweb.dream.exception.RetryPushImpl.
This component forwards incoming messages, if a PushExceptionis catched, the message is pushed again.
RetryPushImpl() - Constructor for class org.objectweb.dream.exception.RetryPushImpl
 
RouterChunkNameAttributeController - interface org.objectweb.dream.router.RouterChunkNameAttributeController.
Chunk name router attribute controller interface.
RouterChunkNameImpl - class org.objectweb.dream.router.RouterChunkNameImpl.
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 org.objectweb.dream.router.RouterRandomImpl.
This router randomly chooses one of its outputs.
RouterRandomImpl() - Constructor for class org.objectweb.dream.router.RouterRandomImpl
 
RouterRoundRobinImpl - class org.objectweb.dream.router.RouterRoundRobinImpl.
This router implements a round-robin choice of its outputs.
RouterRoundRobinImpl() - Constructor for class org.objectweb.dream.router.RouterRoundRobinImpl
 
readExternal(ObjectInput) - Method in class org.objectweb.dream.channel.IPChannelDestinationChunkImpl
 
readExternal(ObjectInput) - Method in class org.objectweb.dream.channel.IPChannelSourceChunkImpl
 
readExternal(ObjectInput) - Method in class org.objectweb.dream.protocol.ArrowChunkImpl
 
readExternal(ObjectInput) - Method in class org.objectweb.dream.protocol.ProcessImpl
 
readExternal(ObjectInput) - Method in class org.objectweb.dream.protocol.causality.CausalityChunkImpl
 
readExternal(ObjectInput) - Method in class org.objectweb.dream.protocol.causality.Update
 
readExternal(ObjectInput) - Method in class org.objectweb.dream.pushwithreturn.KeyChunkImpl
 
readExternal(ObjectInput) - Method in class org.objectweb.dream.queue.SequenceNumberChunkImpl
 
readUpdate(ObjectInput) - Static method in class org.objectweb.dream.protocol.causality.Update
 
receiveAck(Message) - Method in class org.objectweb.dream.protocol.utobcast.PendingMessagesDataStructureImpl
 
receiveAck(Message) - Method in interface org.objectweb.dream.protocol.utobcast.ReceiveAck
Handles the received ACK message.
receiveAckItf - Variable in class org.objectweb.dream.protocol.utobcast.ACKImpl
The interface to forward ACK messages to the PendingMessageDataStructure component.
recycle() - Method in class org.objectweb.dream.channel.IPChannelDestinationChunkImpl
 
recycle() - Method in class org.objectweb.dream.channel.IPChannelSourceChunkImpl
 
recycle() - Method in class org.objectweb.dream.channel.SocketStateImpl
WARNING : The socket state must be previously closed.
recycle() - Method in class org.objectweb.dream.protocol.ArrowChunkImpl
 
recycle() - Method in class org.objectweb.dream.protocol.causality.CausalityChunkImpl
 
recycle() - Method in class org.objectweb.dream.protocol.utobcast.message.CrashedLeaderChunkImpl
 
recycle() - Method in class org.objectweb.dream.protocol.utobcast.message.UPDChunkImpl
 
recycle() - Method in class org.objectweb.dream.protocol.utobcast.message.UTOBcastChunkImpl
 
recycle() - Method in class org.objectweb.dream.pushwithreturn.KeyChunkImpl
 
recycle() - Method in class org.objectweb.dream.pushwithreturn.KeyInteger
 
recycle() - Method in class org.objectweb.dream.pushwithreturn.SynchronizerImpl.WaitingKey
 
recycle() - Method in class org.objectweb.dream.queue.BufferAscendingSequenceNumberImpl.Element
 
recycle() - Method in class org.objectweb.dream.queue.ListAddRemoveFirstLastFastImpl.Element
 
recycle() - Method in class org.objectweb.dream.queue.SequenceNumberChunkImpl
 
releaseSocket(SocketState, boolean) - Method in interface org.objectweb.dream.channel.IPSocketManager
Releases the given SocketStateImpl.
releaseSocket(SocketState, boolean) - Method in class org.objectweb.dream.channel.IPSocketManagerCachingImpl
 
releaseSocket(SocketState, boolean) - Method in class org.objectweb.dream.channel.IPSocketManagerTCPImpl
 
releaseSocket(SocketState, boolean) - Method in interface org.objectweb.dream.channel.SocketManager
Releases the given SocketState.
releaseSocket(SocketState, boolean) - Method in class org.objectweb.dream.channel.SocketManagerIPChunkBasedImpl
 
releaseSocket(SocketState, boolean) - Method in class org.objectweb.dream.channel.SocketManagerIPStaticImpl
 
remove() - Method in class org.objectweb.dream.queue.AbstractBufferImpl
This method should not be overriden.
remove() - Method in interface org.objectweb.dream.queue.Buffer
Removes a message from the buffer.
remove() - Method in interface org.objectweb.dream.queue.List
Removes an object from the list.
remove() - Method in class org.objectweb.dream.queue.ListAddRemoveFirstLastFastImpl
 
remove() - Method in class org.objectweb.dream.queue.ListAddRemoveFirstLastImpl
 
removeFirst() - Method in class org.objectweb.dream.queue.AbstractBufferImpl
 
removeFirst() - Method in interface org.objectweb.dream.queue.BufferRemoveFirstLast
Removes and returns the first message from this buffer.
removeFirst() - Method in class org.objectweb.dream.queue.ListAddRemoveFirstLastFastImpl
 
removeFirst() - Method in class org.objectweb.dream.queue.ListAddRemoveFirstLastImpl
 
removeFirst() - Method in interface org.objectweb.dream.queue.ListRemoveFirstLast
Removes and returns the first element from this list.
removeItem(Object) - Method in class org.objectweb.dream.queue.ListAddRemoveFirstLastFastImpl
Removes the first object that is "equal" to the given object, based on the response of the Object.equals() method.
removeLast() - Method in class org.objectweb.dream.queue.AbstractBufferImpl
 
removeLast() - Method in interface org.objectweb.dream.queue.BufferRemoveFirstLast
Removes and returns the last message from this buffer.
removeLast() - Method in class org.objectweb.dream.queue.ListAddRemoveFirstLastFastImpl
 
removeLast() - Method in class org.objectweb.dream.queue.ListAddRemoveFirstLastImpl
 
removeLast() - Method in interface org.objectweb.dream.queue.ListRemoveFirstLast
Removes and returns the last element from this list.
removeProcess(Process) - Method in interface org.objectweb.dream.protocol.utobcast.ProcessMembership
Removes a process from the group of processes.
removeProcess(Process) - Method in class org.objectweb.dream.protocol.utobcast.ProcessMembershipImpl
 
reusableKey - Variable in class org.objectweb.dream.channel.IPSocketManagerCachingImpl
 
reversCache - Variable in class org.objectweb.dream.channel.IPSocketManagerCachingImpl
 

S

SEND_ACK_OPT_ITF_NAME - Static variable in class org.objectweb.dream.channel.GenericPushChannelInImpl
The name of the optional client interface used by this coponent to send an acknowlegdment
SET_REACTOR_THREAD_ITF_NAME - Static variable in interface org.objectweb.dream.protocol.atomicity.SetReactorThread
the default name of this interface
SOCKET_STATE_POOL_ITF_NAME - Static variable in class org.objectweb.dream.channel.IPSocketManagerTCPImpl
The name of the client interface used to pool socket state instances
STARTING_DATE - Static variable in class org.objectweb.dream.multiplexer.PeriodicAttachment
The name of the key that must be used to specify the starting date of this attachment in the parameters passed to the PullPushMultiplexer.attach(String[], Map[], String[], Map[], Map)
SaxXercesParser - class org.objectweb.dream.xml.SaxXercesParser.
Extention of the SAXParserto give it a Fractal component behaviour.
SaxXercesParser() - Constructor for class org.objectweb.dream.xml.SaxXercesParser
 
SendByte - interface org.objectweb.dream.channel.SendByte.
Interface provided by component that can be used to send a byte over a socket.
SendByteStreamImpl - class org.objectweb.dream.channel.SendByteStreamImpl.
Write a byte from the given output used as OutputStream.
SendByteStreamImpl() - Constructor for class org.objectweb.dream.channel.SendByteStreamImpl
 
SequenceNumber - interface org.objectweb.dream.protocol.utobcast.SequenceNumber.
This interface defines methods to get, set and imcrement a sequence number.
SequenceNumberChunk - interface org.objectweb.dream.queue.SequenceNumberChunk.
Chunk interface for messages that have to be sequentially ordered.
SequenceNumberChunkImpl - class org.objectweb.dream.queue.SequenceNumberChunkImpl.
Basic implementation of the SequenceNumberChunkinterface.
SequenceNumberChunkImpl() - Constructor for class org.objectweb.dream.queue.SequenceNumberChunkImpl
 
SequenceNumberImpl - class org.objectweb.dream.protocol.utobcast.SequenceNumberImpl.
Implementation of the SequenceNumberinterface.
SequenceNumberImpl() - Constructor for class org.objectweb.dream.protocol.utobcast.SequenceNumberImpl
Constructor.
SetReactorThread - interface org.objectweb.dream.protocol.atomicity.SetReactorThread.
Component interface used to give the thread that is executing a reaction.
SetTimeStamp - interface org.objectweb.dream.time.SetTimeStamp.
This interface defines a method to set a time stamp.
SocketManager - interface org.objectweb.dream.channel.SocketManager.
Interface used by ChannelOut to retreive a socket to send a message to a ChannelIn.
SocketManagerIPChunkBasedAttributeController - interface org.objectweb.dream.channel.SocketManagerIPChunkBasedAttributeController.
Attribute controller for SocketManagerimplementation that use a chunk to identify a ChannelOut and retreive an associated socket.
SocketManagerIPChunkBasedImpl - class org.objectweb.dream.channel.SocketManagerIPChunkBasedImpl.
Socket manager that retrieves sockets using an IPSocketManagerand getting IP and port in a IPChannelDestinationChunkin messages.
SocketManagerIPChunkBasedImpl() - Constructor for class org.objectweb.dream.channel.SocketManagerIPChunkBasedImpl
 
SocketManagerIPStaticAttributeController - interface org.objectweb.dream.channel.SocketManagerIPStaticAttributeController.
Attribute controller for socket managers that only manage one opened socket.
SocketManagerIPStaticImpl - class org.objectweb.dream.channel.SocketManagerIPStaticImpl.
Socket manager managing only one open socket at a time.
SocketManagerIPStaticImpl() - Constructor for class org.objectweb.dream.channel.SocketManagerIPStaticImpl
 
SocketState - interface org.objectweb.dream.channel.SocketState.
Interface used by ChannelOut to identify a ChannelIn and to send it message.
SocketStateImpl - class org.objectweb.dream.channel.SocketStateImpl.
Basic implementation of SocketState.
SocketStateImpl() - Constructor for class org.objectweb.dream.channel.SocketStateImpl
 
SynchronizerAttributeController - interface org.objectweb.dream.pushwithreturn.SynchronizerAttributeController.
This interface defines a method to specify whether it is necessary to clone a return message that several calls wait for.
SynchronizerImpl - class org.objectweb.dream.pushwithreturn.SynchronizerImpl.
This component handles calls to the PushWithReturn.pushWithReturn(Message, Map)method (i.e. outgoing messages).
SynchronizerImpl() - Constructor for class org.objectweb.dream.pushwithreturn.SynchronizerImpl
 
SynchronizerImpl.WaitingKey - class org.objectweb.dream.pushwithreturn.SynchronizerImpl.WaitingKey.
This class represents a waiting key.
SynchronizerImpl.WaitingKey() - Constructor for class org.objectweb.dream.pushwithreturn.SynchronizerImpl.WaitingKey
 
sendAckOptItf - Variable in class org.objectweb.dream.channel.GenericPushChannelInImpl
 
sendByte(Object, int) - Method in interface org.objectweb.dream.channel.SendByte
Send a byte throuw the given output.
sendByte(Object, int) - Method in class org.objectweb.dream.channel.SendByteStreamImpl
 
sequenceNumberItf - Variable in class org.objectweb.dream.protocol.utobcast.BackupElectionImpl
The interface to get/set the sequence number.
sequenceNumberItf - Variable in class org.objectweb.dream.protocol.utobcast.DATImpl
The interface to get/set the sequence number.
sequenceNumberItf - Variable in class org.objectweb.dream.protocol.utobcast.UPDImpl
The interface to get/set the sequence number.
setArrowChunkName(String) - Method in interface org.objectweb.dream.protocol.causality.CausalityTransformerAttributeController
Sets the name of the ArrowChunkused to know the source or the destination process of messages.
setArrowChunkName(String) - Method in class org.objectweb.dream.protocol.causality.InMessageSorterImpl
 
setArrowChunkName(String) - Method in class org.objectweb.dream.protocol.causality.OutMessageStamperImpl
 
setBackup(Process) - Method in interface org.objectweb.dream.protocol.utobcast.ProcessMembership
Sets the backup process.
setBackup(Process) - Method in class org.objectweb.dream.protocol.utobcast.ProcessMembershipImpl
 
setBlocking(boolean) - Method in interface org.objectweb.dream.channel.IPSocketManagerCachingAttributeController
Sets the blocking property of this IPSocketManager.
setBlocking(boolean) - Method in class org.objectweb.dream.channel.IPSocketManagerCachingImpl
 
setBlocking(boolean) - Method in interface org.objectweb.dream.protocol.utobcast.ProcessMembershipAttributeController
Sets the blocking attribute.
setBlocking(boolean) - Method in class org.objectweb.dream.protocol.utobcast.ProcessMembershipImpl
 
setBlockingPull(boolean) - Method in class org.objectweb.dream.queue.AbstractPullOutgoingHandlerImpl
 
setBlockingPull(boolean) - Method in interface org.objectweb.dream.queue.PullQueueAttributeController
Sets the blocking pull policy.
setCanPass(boolean) - Method in class org.objectweb.dream.pushwithreturn.SynchronizerImpl.WaitingKey
Sets canPass to the given value.
setCausalityChunkName(String) - Method in interface org.objectweb.dream.protocol.causality.CausalityTransformerAttributeController
Sets the name of the CausalityChunkwhere the matrix clock, or the updates are stored.
setCausalityChunkName(String) - Method in class org.objectweb.dream.protocol.causality.InMessageSorterImpl
 
setCausalityChunkName(String) - Method in class org.objectweb.dream.protocol.causality.OutMessageStamperImpl
 
setCausalityStamp(Object) - Method in interface org.objectweb.dream.protocol.causality.CausalityChunk
Set the causality stamp of this chunk
setCausalityStamp(Object) - Method in class org.objectweb.dream.protocol.causality.CausalityChunkImpl
 
setChannelDestinationAddr(InetAddress) - Method in interface org.objectweb.dream.channel.IPChannelDestinationChunk
Sets the inet address of the ChannelIn.
setChannelDestinationAddr(InetAddress) - Method in class org.objectweb.dream.channel.IPChannelDestinationChunkImpl
 
setChannelDestinationPort(int) - Method in interface org.objectweb.dream.channel.IPChannelDestinationChunk
Sets the listening port of the ChannelIn.
setChannelDestinationPort(int) - Method in class org.objectweb.dream.channel.IPChannelDestinationChunkImpl
 
setChannelSourceAddr(InetAddress) - Method in interface org.objectweb.dream.channel.IPChannelSourceChunk
Sets the inet address of the ChannelOut.
setChannelSourceAddr(InetAddress) - Method in class org.objectweb.dream.channel.IPChannelSourceChunkImpl
 
setChannelSourcePort(int) - Method in interface org.objectweb.dream.channel.IPChannelSourceChunk
Sets the listening port of the ChannelOut.
setChannelSourcePort(int) - Method in class org.objectweb.dream.channel.IPChannelSourceChunkImpl
 
setChunkName(String) - Method in interface org.objectweb.dream.channel.AddIPChannelAttributeController
Sets the name of the added chunk.
setChunkName(String) - Method in class org.objectweb.dream.channel.AddIPChannelDestinationChunkImpl
 
setChunkName(String) - Method in class org.objectweb.dream.channel.AddIPChannelSourceChunkImpl
 
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
 
setCnxRetry(int) - Method in interface org.objectweb.dream.channel.IPSocketManagerTCPAttributeController
Sets the cnxRetry attribute's value.
setCnxRetry(int) - Method in class org.objectweb.dream.channel.IPSocketManagerTCPImpl
 
setConnectionRetry(int) - Method in interface org.objectweb.dream.channel.ChannelOutAttributeController
Sets the number of attempt to connect to ChannelIn before abording.
setDeleteChunk(boolean) - Method in interface org.objectweb.dream.channel.SocketManagerIPChunkBasedAttributeController
Set if the destination chunk should be deleted from the message.
setDeleteChunk(boolean) - Method in class org.objectweb.dream.channel.SocketManagerIPChunkBasedImpl
 
setDestinationChunkName(String) - Method in interface org.objectweb.dream.channel.SocketManagerIPChunkBasedAttributeController
Set the name of the chunks that contains the destination identification of the message.
setDestinationChunkName(String) - Method in class org.objectweb.dream.channel.SocketManagerIPChunkBasedImpl
 
setDestinationHostname(String) - Method in interface org.objectweb.dream.channel.SocketManagerIPStaticAttributeController
Sets the destinationHostname attribute value.
setDestinationHostname(String) - Method in class org.objectweb.dream.channel.SocketManagerIPStaticImpl
 
setDestinationPort(int) - Method in interface org.objectweb.dream.channel.SocketManagerIPStaticAttributeController
Sets the destinationPort attribute value.
setDestinationPort(int) - Method in class org.objectweb.dream.channel.SocketManagerIPStaticImpl
 
setEndDate(long) - Method in class org.objectweb.dream.multiplexer.PeriodicAttachment
Sets the endDate value.
setId(short) - Method in interface org.objectweb.dream.protocol.Process
Sets the identifier of the process.
setId(short) - Method in class org.objectweb.dream.protocol.ProcessImpl
 
setInetAddress(String) - Method in interface org.objectweb.dream.channel.AddIPChannelAttributeController
Sets the inet addresse put in chunks.
setInetAddress(String) - Method in class org.objectweb.dream.channel.AddIPChannelDestinationChunkImpl
 
setInetAddress(String) - Method in class org.objectweb.dream.channel.AddIPChannelSourceChunkImpl
 
setInitialCapacity(int) - Method in class org.objectweb.dream.pump.PumpSynchronizedImpl
 
setInitialNumberOfThreads(int) - Method in class org.objectweb.dream.pump.PumpSynchronizedImpl
 
setInput(Object) - Method in class org.objectweb.dream.channel.SocketStateImpl
 
setInputContexts(Map[]) - Method in class org.objectweb.dream.multiplexer.Attachment
 
setInputNames(String[]) - Method in class org.objectweb.dream.multiplexer.Attachment
 
setInputs(Pull[]) - Method in class org.objectweb.dream.multiplexer.Attachment
 
setKey(Key) - Method in interface org.objectweb.dream.pushwithreturn.KeyChunk
Sets the key of this chunk.
setKey(Key) - Method in class org.objectweb.dream.pushwithreturn.KeyChunkImpl
 
setKeyChunkName(String) - Method in interface org.objectweb.dream.queue.PushPullKeyQueueAttributeController
Sets the name of the chunk to be used as a key of the message.
setLeader(Process) - Method in interface org.objectweb.dream.protocol.utobcast.ProcessMembership
Sets the leader process.
setLeader(Process) - Method in class org.objectweb.dream.protocol.utobcast.ProcessMembershipImpl
 
setListeningPort(int) - Method in interface org.objectweb.dream.channel.TCPAcceptSocketAttributeController
Sets the listeningPort attribute's value.
setListeningPort(int) - Method in class org.objectweb.dream.channel.TCPAcceptSocketImpl
 
setMaxCapacity(int) - Method in class org.objectweb.dream.queue.AbstractBufferImpl
 
setMaxCapacity(int) - Method in class org.objectweb.dream.queue.PushPullQueueNotSynchronizedImpl
 
setMaxCapacity(int) - Method in interface org.objectweb.dream.queue.QueueAttributeController
Sets the maximum capacity of the queue.
setMaxOpenedSocket(int) - Method in interface org.objectweb.dream.channel.OpenedSocketManagerMultiAttributeController
Sets the maxOpenedSocket attribute's value.
setMaxOpenedSocket(int) - Method in class org.objectweb.dream.channel.OpenedSocketManagerMultiPersistentImpl
 
setMessageNotFoundPolicy(String) - Method in interface org.objectweb.dream.queue.PushPullKeyQueueAttributeController
Sets the policy applied when a message cannot be found.
setMustClone(boolean) - Method in interface org.objectweb.dream.pushwithreturn.SynchronizerAttributeController
Specifies whether it is necessary to clone a return message that is destinated to several method call returns.
setMustClone(boolean) - Method in class org.objectweb.dream.pushwithreturn.SynchronizerImpl
 
setMyself(Process) - Method in interface org.objectweb.dream.protocol.utobcast.ProcessMembership
Sets the process to which this process membership component belongs.
setMyself(Process) - Method in class org.objectweb.dream.protocol.utobcast.ProcessMembershipImpl
 
setNbMaxSocket(int) - Method in interface org.objectweb.dream.channel.IPSocketManagerCachingAttributeController
Sets the nbMaxSocket attribute value.
setNbMaxSocket(int) - Method in class org.objectweb.dream.channel.IPSocketManagerCachingImpl
 
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
 
setNextDeadline(long) - Method in class org.objectweb.dream.multiplexer.PeriodicAttachment
Sets the nextDeadline value.
setNumberOfProcess(short) - Method in interface org.objectweb.dream.protocol.causality.MatrixClockAttributeController
Sets the number of process implied in the causality.
setNumberOfProcess(short) - Method in class org.objectweb.dream.protocol.causality.MatrixClockImpl
 
setNumberOfProcess(short) - Method in class org.objectweb.dream.protocol.causality.MatrixClockUpdateImpl
 
setOpenRetry(int) - Method in interface org.objectweb.dream.channel.TCPAcceptSocketAttributeController
Sets the openRetry attribute's value.
setOpenRetry(int) - Method in class org.objectweb.dream.channel.TCPAcceptSocketImpl
 
setOtherProcesses(Process[]) - Method in interface org.objectweb.dream.protocol.utobcast.ProcessMembership
Sets the processes to be considered for broadcast (except backup and leader).
setOtherProcesses(Process[]) - Method in class org.objectweb.dream.protocol.utobcast.ProcessMembershipImpl
 
setOutput(Object) - Method in class org.objectweb.dream.channel.SocketStateImpl
 
setOutputContexts(Map[]) - Method in class org.objectweb.dream.multiplexer.Attachment
 
setOutputNames(String[]) - Method in class org.objectweb.dream.multiplexer.Attachment
 
setOutputStatus(boolean) - Method in interface org.objectweb.dream.queue.PushPushQueuePassiveAttributeController
Sets the output status.
setOutputs(Push[]) - Method in class org.objectweb.dream.multiplexer.Attachment
 
setOverflowPolicy(String) - Method in class org.objectweb.dream.queue.AbstractPushIncomingHandlerOverflowImpl
 
setOverflowPolicy(String) - Method in class org.objectweb.dream.queue.PushPullQueueNotSynchronizedImpl
 
setOverflowPolicy(String) - Method in interface org.objectweb.dream.queue.PushQueueAttributeController
Sets the overflow policy.
setPeriod(long) - Method in interface org.objectweb.dream.pump.PumpPeriodicAttributeController
Sets the pump period.
setPeriod(long) - Method in class org.objectweb.dream.pump.PumpPeriodicSynchronizedImpl
 
setPort(int) - Method in interface org.objectweb.dream.channel.AddIPChannelAttributeController
Sets the port number put in chunks.
setPort(int) - Method in class org.objectweb.dream.channel.AddIPChannelDestinationChunkImpl
 
setPort(int) - Method in class org.objectweb.dream.channel.AddIPChannelSourceChunkImpl
 
setProcessFrom(Process) - Method in interface org.objectweb.dream.protocol.utobcast.message.UTOBcastChunk
Sets the process that sent this message.
setProcessFrom(Process) - Method in class org.objectweb.dream.protocol.utobcast.message.UTOBcastChunkImpl
 
setProcessIdFrom(short) - Method in interface org.objectweb.dream.protocol.ArrowChunk
Sets the identifier of the sender process.
setProcessIdFrom(short) - Method in class org.objectweb.dream.protocol.ArrowChunkImpl
 
setProcessIdTo(short) - Method in interface org.objectweb.dream.protocol.ArrowChunk
Sets the identifier of the receiver process.
setProcessIdTo(short) - Method in class org.objectweb.dream.protocol.ArrowChunkImpl
 
setProcessTo(Process) - Method in interface org.objectweb.dream.protocol.utobcast.message.UTOBcastChunk
Sets the process to which this message is destinated.
setProcessTo(Process) - Method in class org.objectweb.dream.protocol.utobcast.message.UTOBcastChunkImpl
 
setProcesses(Process[]) - Method in interface org.objectweb.dream.protocol.utobcast.message.UPDChunk
Sets the process array that is exchanged between the leader and the backup.
setProcesses(Process[]) - Method in class org.objectweb.dream.protocol.utobcast.message.UPDChunkImpl
 
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 interface org.objectweb.dream.pump.PumpAttributeController
Sets the PushNullPolicy.
setPushNullPolicy(boolean) - Method in class org.objectweb.dream.pump.PumpSynchronizedImpl
 
setReactorThread(Thread) - Method in class org.objectweb.dream.protocol.atomicity.AtomicRouterImpl
 
setReactorThread(Thread) - Method in interface org.objectweb.dream.protocol.atomicity.SetReactorThread
Gives the thread that is executing a reaction.
setReturnMessage(Message) - Method in class org.objectweb.dream.pushwithreturn.SynchronizerImpl.WaitingKey
Sets the return message.
setSequenceNumber(long) - Method in interface org.objectweb.dream.protocol.utobcast.SequenceNumber
Sets the sequence number.
setSequenceNumber(long) - Method in class org.objectweb.dream.protocol.utobcast.SequenceNumberImpl
 
setSequenceNumber(long) - Method in interface org.objectweb.dream.protocol.utobcast.message.UPDChunk
Sets the sequence number that is exchanged between the leader and the backup.
setSequenceNumber(long) - Method in class org.objectweb.dream.protocol.utobcast.message.UPDChunkImpl
 
setSequenceNumber(long) - Method in class org.objectweb.dream.protocol.utobcast.message.UTOBcastChunkImpl
 
setSequenceNumber(long) - Method in interface org.objectweb.dream.queue.SequenceNumberChunk
Sets the sequence number of this message.
setSequenceNumber(long) - Method in class org.objectweb.dream.queue.SequenceNumberChunkImpl
 
setSoLinger(int) - Method in interface org.objectweb.dream.channel.IPSocketManagerTCPAttributeController
Sets the soLinger attribute's value.
setSoLinger(int) - Method in class org.objectweb.dream.channel.IPSocketManagerTCPImpl
 
setSoLinger(int) - Method in interface org.objectweb.dream.channel.TCPAcceptSocketAttributeController
Sets the soLinger attribute's value.
setSoLinger(int) - Method in class org.objectweb.dream.channel.TCPAcceptSocketImpl
 
setSoTimeout(int) - Method in interface org.objectweb.dream.channel.IPSocketManagerTCPAttributeController
Sets the soTimeout attribute's value.
setSoTimeout(int) - Method in class org.objectweb.dream.channel.IPSocketManagerTCPImpl
 
setSoTimeout(int) - Method in interface org.objectweb.dream.channel.TCPAcceptSocketAttributeController
Sets the soTimeout attribute's value.
setSoTimeout(int) - Method in class org.objectweb.dream.channel.TCPAcceptSocketImpl
 
setSocket(Socket) - Method in interface org.objectweb.dream.channel.SocketState
Sets the socket to be used as input and output.
setSocket(Socket) - Method in class org.objectweb.dream.channel.SocketStateImpl
 
setSocketOption(Socket) - Method in class org.objectweb.dream.channel.IPSocketManagerTCPImpl
 
setSocketOption(Socket) - Method in class org.objectweb.dream.channel.TCPAcceptSocketImpl
 
setSortingChunkName(String) - Method in class org.objectweb.dream.queue.BufferAscendingSequenceNumberImpl
 
setSortingChunkName(String) - Method in interface org.objectweb.dream.queue.QueueSortedAttributeController
Sets the name of the chunk to be used to sort messages.
setTcpNoDelay(boolean) - Method in interface org.objectweb.dream.channel.IPSocketManagerTCPAttributeController
Sets the tcpNoDelay attribute's value.
setTcpNoDelay(boolean) - Method in class org.objectweb.dream.channel.IPSocketManagerTCPImpl
 
setTcpNoDelay(boolean) - Method in interface org.objectweb.dream.channel.TCPAcceptSocketAttributeController
Sets the tcpNoDelay attribute's value.
setTcpNoDelay(boolean) - Method in class org.objectweb.dream.channel.TCPAcceptSocketImpl
 
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 - Variable in class org.objectweb.dream.multiplexer.PullPushMultiplexerImpl
The SetTimeStamp client interface of this component.
setTimeStamp() - Method in interface org.objectweb.dream.time.SetTimeStamp
Sets the time stamp.
setTimeStamp() - Method in class org.objectweb.dream.time.TimeStampImpl
 
setUTOBcastMessageType(byte) - Method in interface org.objectweb.dream.protocol.utobcast.message.UTOBcastChunk
Sets the UTOBcast type of the message that contains this chunk.
setUTOBcastMessageType(byte) - Method in class org.objectweb.dream.protocol.utobcast.message.UTOBcastChunkImpl
 
setUsePool(boolean) - Method in class org.objectweb.dream.pump.PumpSynchronizedImpl
 
size - Variable in class org.objectweb.dream.queue.PushPullQueueNotSynchronizedImpl
 
sn - Variable in class org.objectweb.dream.protocol.utobcast.message.UPDChunkImpl
The sequence number of this message.
sn - Variable in class org.objectweb.dream.protocol.utobcast.message.UTOBcastChunkImpl
The sequence number of this message.
sn - Variable in class org.objectweb.dream.queue.SequenceNumberChunkImpl
The sequence number.
soLinger - Variable in class org.objectweb.dream.channel.IPSocketManagerTCPImpl
 
soLinger - Variable in class org.objectweb.dream.channel.TCPAcceptSocketImpl
 
soTimeout - Variable in class org.objectweb.dream.channel.IPSocketManagerTCPImpl
 
soTimeout - Variable in class org.objectweb.dream.channel.TCPAcceptSocketImpl
 
socket - Variable in class org.objectweb.dream.channel.SocketStateImpl
 
socketManagerItf - Variable in class org.objectweb.dream.channel.GenericPushChannelOutImpl
 
socketState - Variable in class org.objectweb.dream.channel.IPSocketManagerCachingImpl.CacheEntry
 
socketStatePoolItf - Variable in class org.objectweb.dream.channel.IPSocketManagerTCPImpl
 
sortingChunkName - Variable in class org.objectweb.dream.queue.BufferAscendingSequenceNumberImpl
The name under which the chunk containing the sequence number is registered.
startFc() - Method in class org.objectweb.dream.channel.AddIPChannelDestinationChunkImpl
 
startFc() - Method in class org.objectweb.dream.channel.AddIPChannelSourceChunkImpl
 
startFc() - Method in class org.objectweb.dream.channel.OpenedSocketManagerMultiPersistentImpl
 
startFc() - Method in class org.objectweb.dream.channel.TCPAcceptSocketImpl
 
startFc() - Method in class org.objectweb.dream.protocol.causality.MatrixClockImpl
 
startFc() - Method in class org.objectweb.dream.protocol.causality.MatrixClockUpdateImpl
 
startFc() - Method in class org.objectweb.dream.pump.PumpSynchronizedImpl
 
startingDate - Variable in class org.objectweb.dream.multiplexer.PeriodicAttachment
 
stopFc() - Method in class org.objectweb.dream.channel.OpenedSocketManagerMultiPersistentImpl
 
stopFc() - Method in class org.objectweb.dream.channel.SocketManagerIPStaticImpl
 
stopFc() - Method in class org.objectweb.dream.channel.TCPAcceptSocketImpl
 
stopThread(SocketState) - Method in class org.objectweb.dream.channel.OpenedSocketManagerMultiPersistentImpl.InTask
 
storedMessagesIndicator - Variable in class org.objectweb.dream.queue.AbstractBufferImpl
An indicator on stored messages into the buffer.
storedMessagesIndicator() - Method in class org.objectweb.dream.queue.AbstractBufferImpl
 
storedMessagesIndicator() - Method in interface org.objectweb.dream.queue.Buffer
Returns an indicator on stored messages.

T

TCPAcceptSocketAttributeController - interface org.objectweb.dream.channel.TCPAcceptSocketAttributeController.
Attribute controller for IP Accept Socket, It defines the listening port.
TCPAcceptSocketImpl - class org.objectweb.dream.channel.TCPAcceptSocketImpl.
Wraps TCP ServerSocket.
TCPAcceptSocketImpl() - Constructor for class org.objectweb.dream.channel.TCPAcceptSocketImpl
 
TIMESTAMP - Static variable in class org.objectweb.dream.multiplexer.PeriodicAttachment
The name of the key that must be used in the context of the pull method to specify the time at which the pulling has been scheduled by the multiplexer.
TO_BE_DELIVERED_IN_ITF_NAME - Static variable in class org.objectweb.dream.protocol.utobcast.UTOImpl
The commonly used name to refer to the toBeDeliveredInItf interface.
TO_BE_DELIVERED_OUT_ITF_NAME - Static variable in class org.objectweb.dream.protocol.utobcast.UTOImpl
The commonly used name to refer to the toBeDeliveredOutItf interface.
TYPE - Static variable in interface org.objectweb.dream.channel.IPChannelDestinationChunk
The Chunk type of chunks that implements this interface.
TYPE - Static variable in interface org.objectweb.dream.channel.IPChannelSourceChunk
The Chunk type of chunks that implements this interface.
TYPE - Static variable in interface org.objectweb.dream.protocol.ArrowChunk
The chunk type of chunks implementing this interface.
TYPE - Static variable in interface org.objectweb.dream.protocol.causality.CausalityChunk
The Chunk type of chunks that implements this interface.
TYPE - Static variable in interface org.objectweb.dream.protocol.utobcast.message.CrashedLeaderChunk
The Chunk type of chunks that implements this interface.
TYPE - Static variable in interface org.objectweb.dream.protocol.utobcast.message.UPDChunk
The Chunk type of chunks that implements this interface.
TYPE - Static variable in interface org.objectweb.dream.protocol.utobcast.message.UTOBcastChunk
The Chunk type of chunks that implements this interface.
TYPE - Static variable in interface org.objectweb.dream.pushwithreturn.KeyChunk
The Chunk type of chunks that implements this interface.
TYPE - Static variable in interface org.objectweb.dream.queue.SequenceNumberChunk
The Chunk type of chunks that implements this interface.
TimeStampImpl - class org.objectweb.dream.time.TimeStampImpl.
Basic implementation of a time stamp component.
TimeStampImpl() - Constructor for class org.objectweb.dream.time.TimeStampImpl
 
tcpNoDelay - Variable in class org.objectweb.dream.channel.IPSocketManagerTCPImpl
 
tcpNoDelay - Variable in class org.objectweb.dream.channel.TCPAcceptSocketImpl
 
testRecvMatrix(Object, short, short) - Method in interface org.objectweb.dream.protocol.causality.MatrixClock
Test if the received message, the given stamp belong, can be delivered.
testRecvMatrix(Object, short, short) - Method in class org.objectweb.dream.protocol.causality.MatrixClockImpl
 
testRecvMatrix(Object, short, short) - Method in class org.objectweb.dream.protocol.causality.MatrixClockUpdateImpl
 
threadPoolController - Variable in class org.objectweb.dream.channel.OpenedSocketManagerMultiPersistentImpl
 
timeOut - Variable in class org.objectweb.dream.cache.CacheImpl
The cache time out.
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
 
toBeDeliveredInItf - Variable in class org.objectweb.dream.protocol.utobcast.UTOImpl
The interface to store messages in the ToBeDelivered queue.
toBeDeliveredOutItf - Variable in class org.objectweb.dream.protocol.utobcast.UTOImpl
The interface to retrieve messages to be delivered from the toBeDelivered queue.
toString() - Method in class org.objectweb.dream.channel.IPChannelDestinationChunkImpl
 
toString() - Method in class org.objectweb.dream.channel.IPChannelSourceChunkImpl
 
toString() - Method in class org.objectweb.dream.protocol.causality.Update
 
toString() - Method in class org.objectweb.dream.queue.ListAddRemoveFirstLastFastImpl
 
transfertState(Chunk) - Method in class org.objectweb.dream.channel.IPChannelDestinationChunkImpl
 
transfertState(Chunk) - Method in class org.objectweb.dream.channel.IPChannelSourceChunkImpl
 
transfertState(Chunk) - Method in class org.objectweb.dream.protocol.ArrowChunkImpl
 
transfertState(Chunk) - Method in class org.objectweb.dream.protocol.causality.CausalityChunkImpl
 
transfertState(Chunk) - Method in class org.objectweb.dream.protocol.utobcast.message.CrashedLeaderChunkImpl
 
transfertState(Chunk) - Method in class org.objectweb.dream.protocol.utobcast.message.UPDChunkImpl
 
transfertState(Chunk) - Method in class org.objectweb.dream.protocol.utobcast.message.UTOBcastChunkImpl
 
transfertState(Chunk) - Method in class org.objectweb.dream.pushwithreturn.KeyChunkImpl
 
transfertState(Chunk) - Method in class org.objectweb.dream.queue.SequenceNumberChunkImpl
 

U

UPD - Static variable in interface org.objectweb.dream.protocol.utobcast.message.UTOBcastChunk
The byte value for UPD message type.
UPDChunk - interface org.objectweb.dream.protocol.utobcast.message.UPDChunk.
Chunk interface for UPD messages.
UPDChunkImpl - class org.objectweb.dream.protocol.utobcast.message.UPDChunkImpl.
Basic implementation of the UPDChunkinterface.
UPDChunkImpl() - Constructor for class org.objectweb.dream.protocol.utobcast.message.UPDChunkImpl
 
UPDImpl - class org.objectweb.dream.protocol.utobcast.UPDImpl.
Implementation of the UPD component.
UPDImpl() - Constructor for class org.objectweb.dream.protocol.utobcast.UPDImpl
Constructor.
UTO - Static variable in interface org.objectweb.dream.protocol.utobcast.message.UTOBcastChunk
The byte value for UTO message type.
UTOBcastChunk - interface org.objectweb.dream.protocol.utobcast.message.UTOBcastChunk.
Chunk interface for UTOBcast protocol messages.
UTOBcastChunkImpl - class org.objectweb.dream.protocol.utobcast.message.UTOBcastChunkImpl.
Basic implementation of the UTOBcastChunkinterface.
UTOBcastChunkImpl() - Constructor for class org.objectweb.dream.protocol.utobcast.message.UTOBcastChunkImpl
 
UTOImpl - class org.objectweb.dream.protocol.utobcast.UTOImpl.
Implementation of the UTO component.
UTOImpl() - Constructor for class org.objectweb.dream.protocol.utobcast.UTOImpl
Constructor.
Update - class org.objectweb.dream.protocol.causality.Update.
Matrix update elements
Update() - Constructor for class org.objectweb.dream.protocol.causality.Update
Default contructor.
Update(short, short, int) - Constructor for class org.objectweb.dream.protocol.causality.Update
Creates an element in a new empty list.
Update(short, short, int, Update) - Constructor for class org.objectweb.dream.protocol.causality.Update
Creates an element and links it after the head.
unbindFc(String) - Method in class org.objectweb.dream.aggregator.PullPullAggregatorCollectionInputImpl
 
unbindFc(String) - Method in class org.objectweb.dream.channel.GenericPushChannelInImpl
 
unbindFc(String) - Method in class org.objectweb.dream.channel.GenericPushChannelOutImpl
 
unbindFc(String) - Method in class org.objectweb.dream.multiplexer.PullPushMultiplexerImpl
 
unbindFc(String) - Method in class org.objectweb.dream.protocol.utobcast.IncomingMessageRouterImpl
 
unbindFc(String) - Method in class org.objectweb.dream.protocol.utobcast.ProcessMembershipImpl
 
unbindFc(String) - Method in class org.objectweb.dream.router.AbstractRouterImpl
 
unbindFc(String) - Method in class org.objectweb.dream.xml.SaxXercesParser
 
unlock() - Method in interface org.objectweb.dream.synchro.Mutex
Releases the mutex.
unlock() - Method in class org.objectweb.dream.synchro.MutexImpl
 
update(Attachment) - Method in interface org.objectweb.dream.multiplexer.PullPushMultiplexer
Updates an attachement.
update(Attachment) - Method in class org.objectweb.dream.multiplexer.PullPushMultiplexerImpl
 
usePool - Variable in class org.objectweb.dream.pump.PumpSynchronizedImpl
 
utoBcastMessageType - Variable in class org.objectweb.dream.protocol.utobcast.message.UTOBcastChunkImpl
The type of the message that contains this chunk.

W

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.
WAIT_ACK_OPT_ITF_NAME - Static variable in class org.objectweb.dream.channel.GenericPushChannelOutImpl
The name of the optional client interface used by this coponent to wait for an acknowlegdment
WAIT_TO_DELIVER - Static variable in interface org.objectweb.dream.protocol.causality.MatrixClock
the value returned by MatrixClock.testRecvMatrix(Object, short, short)if there is other message in the causal ordering before this.
WaitByte - interface org.objectweb.dream.channel.WaitByte.
Interface provided by component that can be used to wait for a byte over a socket.
WaitByteStreamImpl - class org.objectweb.dream.channel.WaitByteStreamImpl.
Read a byte from the given input used as InputStream.
WaitByteStreamImpl() - Constructor for class org.objectweb.dream.channel.WaitByteStreamImpl
 
waitAckOptItf - Variable in class org.objectweb.dream.channel.GenericPushChannelOutImpl
 
waitByte(Object) - Method in interface org.objectweb.dream.channel.WaitByte
Wait until a byte can be read on the given input.
waitByte(Object) - Method in class org.objectweb.dream.channel.WaitByteStreamImpl
 
writeExternal(ObjectOutput) - Method in class org.objectweb.dream.channel.IPChannelDestinationChunkImpl
 
writeExternal(ObjectOutput) - Method in class org.objectweb.dream.channel.IPChannelSourceChunkImpl
 
writeExternal(ObjectOutput) - Method in class org.objectweb.dream.protocol.ArrowChunkImpl
 
writeExternal(ObjectOutput) - Method in class org.objectweb.dream.protocol.ProcessImpl
 
writeExternal(ObjectOutput) - Method in class org.objectweb.dream.protocol.causality.CausalityChunkImpl
 
writeExternal(ObjectOutput) - Method in class org.objectweb.dream.protocol.causality.Update
 
writeExternal(ObjectOutput) - Method in class org.objectweb.dream.pushwithreturn.KeyChunkImpl
 
writeExternal(ObjectOutput) - Method in class org.objectweb.dream.queue.SequenceNumberChunkImpl
 

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

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