Skip navigation links
A B C D E F G H I J K L M N O P Q R S T U V W X 

A

AAcquisitionMechanism - Class in jadex.platform.service.security
Abstract super class for certificate acquisition mechanisms.
AAcquisitionMechanism() - Constructor for class jadex.platform.service.security.AAcquisitionMechanism
 
AbstractClock - Class in jadex.platform.service.clock
Abstract base class for all clocks.
AbstractClock(String, long, long) - Constructor for class jadex.platform.service.clock.AbstractClock
Create a new clock.
AbstractConnection - Class in jadex.platform.service.message.streams
Abstract base class for connections.
AbstractConnection(ITransportComponentIdentifier, ITransportComponentIdentifier, int, boolean, boolean, IAbstractConnectionHandler) - Constructor for class jadex.platform.service.message.streams.AbstractConnection
Create a new input connection.
AbstractConnectionHandler - Class in jadex.platform.service.message.streams
Abstract base class for connection handlers.
AbstractConnectionHandler(MessageService, Map<String, Object>) - Constructor for class jadex.platform.service.message.streams.AbstractConnectionHandler
Create a new connection handler.
AbstractConnectionHandler(MessageService, Map<String, Object>, int, long, long) - Constructor for class jadex.platform.service.message.streams.AbstractConnectionHandler
Create a new connection handler.
AbstractConnectionHandler.ConnectionPanel - Class in jadex.platform.service.message.streams
 
AbstractConnectionHandler.SendInfo - Class in jadex.platform.service.message.streams
Struct class that holds send information.
AbstractRemoteCommand - Class in jadex.platform.service.remote.commands
Default base class for remote commands.
AbstractRemoteCommand() - Constructor for class jadex.platform.service.remote.commands.AbstractRemoteCommand
Bean constructor.
AbstractRemoteCommand(Map<String, Object>) - Constructor for class jadex.platform.service.remote.commands.AbstractRemoteCommand
Bean constructor.
AbstractSendTask - Class in jadex.platform.service.message
Abstract base class for sending a message with the message service.
AbstractSendTask(ITransportComponentIdentifier[], ITransport[], ICodec[], Map<String, Object>) - Constructor for class jadex.platform.service.message.AbstractSendTask
Create a new task.
AbstractSendTask(AbstractSendTask) - Constructor for class jadex.platform.service.message.AbstractSendTask
Shallow copy a task.
acceptFile(String, String) - Method in class jadex.platform.service.chat.ChatService
Accept a waiting file transfer.
access - Variable in class jadex.platform.service.cms.ComponentManagementService
The platform access.
access - Variable in class jadex.platform.service.message.transport.httprelaymtp.HttpReceiver
The external access.
access - Variable in class jadex.platform.service.settings.SettingsService
The service provider.
access - Variable in class jadex.platform.service.simulation.SimulationService
The containing component.
account - Variable in class jadex.platform.service.email.EmailAgent
The email account.
account - Variable in class jadex.platform.service.email.SubscriptionInfo
The account.
ACKCLOSE - Static variable in class jadex.platform.service.message.streams.StreamSendTask
Acknowledge the close message.
ACKCLOSE_INPUT_INITIATOR - Static variable in class jadex.platform.service.message.streams.StreamSendTask
Ack for close - from initiator .
ACKCLOSE_OUTPUT_PARTICIPANT - Static variable in class jadex.platform.service.message.streams.StreamSendTask
Ack data/close - from participant .
ACKCLOSEREQ - Static variable in class jadex.platform.service.message.streams.StreamSendTask
Acknowledge the close request.
ACKCLOSEREQ_INPUT_PARTICIPANT - Static variable in class jadex.platform.service.message.streams.StreamSendTask
Ack for close request - from initiator .
ACKCLOSEREQ_OUTPUT_INITIATOR - Static variable in class jadex.platform.service.message.streams.StreamSendTask
Ack for close request - from initiator .
ackcnt - Variable in class jadex.platform.service.message.streams.InputConnectionHandler
The number of received elements after which an ack is sent.
ackcnt - Variable in class jadex.platform.service.message.streams.OutputConnectionHandler
The number of received elements after which an ack is sent.
ACKDATA - Static variable in class jadex.platform.service.message.streams.StreamSendTask
Acknowledge data message.
ACKDATA_INPUT_INITIATOR - Static variable in class jadex.platform.service.message.streams.StreamSendTask
Ack data - from participant .
ACKDATA_OUTPUT_PARTICIPANT - Static variable in class jadex.platform.service.message.streams.StreamSendTask
Ack data/close - from participant .
ackDataReceived(AckInfo) - Method in class jadex.platform.service.message.streams.OutputConnectionHandler
Called from message service.
AckInfo - Class in jadex.platform.service.message.streams
 
AckInfo() - Constructor for class jadex.platform.service.message.streams.AckInfo
Create a new ack info.
AckInfo(int, int, boolean) - Constructor for class jadex.platform.service.message.streams.AckInfo
Create a new ack info.
ACKINIT - Static variable in class jadex.platform.service.message.streams.StreamSendTask
Acknowledge init.
ACKINIT_INPUT_PARTICIPANT - Static variable in class jadex.platform.service.message.streams.StreamSendTask
Ack the init - from participant.
ACKINIT_OUTPUT_PARTICIPANT - Static variable in class jadex.platform.service.message.streams.StreamSendTask
Ack the init - from initiator.
ackReceived(Object, Object) - Method in class jadex.platform.service.message.streams.AbstractConnectionHandler
Called when an ack was received.
acktimeout - Variable in class jadex.platform.service.message.streams.AbstractConnectionHandler
The max delay before an acknowledgement is received.
acktimer - Variable in class jadex.platform.service.message.streams.OutputConnectionHandler
The acknowledgement timer.
acquireCertificate(String) - Method in class jadex.platform.service.security.AAcquisitionMechanism
Acquire a certificate.
acquireCertificate(String) - Method in class jadex.platform.service.security.DecentralizedAcquisitionMechanism
 
acquireCertificate(String) - Method in class jadex.platform.service.security.SecurityService
Delegates an acquire certificate call to the selected (or no) mechanism.
acquireCertificate(String) - Method in class jadex.platform.service.security.TTPAcquisitionMechanism
 
acquired - Variable in class jadex.platform.service.message.AbstractSendTask
True, if the token is acquired.
activateTickTimer() - Method in class jadex.platform.service.clock.AbstractClock
Activate the tick timer.
add(String, Object) - Method in class jadex.platform.service.dht.DistributedKVStoreService
Add a key/value pair to the collection addressed by the given key.
addAwarenessInfo(AwarenessInfo) - Method in class jadex.platform.service.awareness.management.AwarenessManagementAgent
Announce the discovered components.
addCachedMethodValue(ProxyReference, ProxyInfo, Method, Object) - Static method in class jadex.platform.service.remote.RemoteReferenceModule
Add a cached method value to the proxy info.
addChangeListener(IChangeListener) - Method in class jadex.platform.service.clock.AbstractClock
Add a change listener.
addChangeListener(IChangeListener) - Method in class jadex.platform.service.clock.ClockService
Add a change listener.
addChangeListener(IChangeListener) - Method in class jadex.platform.service.clock.ContinuousClock
Add a change listener.
addChangeListener(IChangeListener) - Method in class jadex.platform.service.simulation.SimulationService
Add a change listener.
addCloneProcessor(ITraverseProcessor) - Method in class jadex.platform.service.marshal.MarshalService
Add a clone processor.
addCodec(Class) - Method in class jadex.platform.service.message.transport.codecs.CodecFactory
Add a new codec.
addComponentListener(IComponentIdentifier, ICMSComponentListener) - Method in class jadex.platform.service.cms.ComponentManagementService
Add an component listener.
addContentCodec(IContentCodec) - Method in class jadex.platform.service.message.MessageService
Add content codec type.
addData(byte[]) - Method in class jadex.platform.service.message.streams.InputConnection
Add data to the internal data buffer.
addData(int, byte[]) - Method in class jadex.platform.service.message.streams.InputConnectionHandler
Called from message service.
addDelegateClassLoader(DelegationURLClassLoader) - Method in class jadex.platform.service.library.DelegationURLClassLoader
Add a new delegate loader.
addedlinks - Variable in class jadex.platform.service.library.LibraryService
The added links.
addEvent(IEvent) - Method in class jadex.platform.service.ecarules.ClientRuleSystemAgent
Add an external event to the rule engine.
addEvent(IEvent) - Method in class jadex.platform.service.ecarules.RuleAgent
Add an external event to the rule engine.
addEvent(IMonitoringEvent) - Method in class jadex.platform.service.monitoring.MonitoringService
Add a new event to the list.
addExcludedMethod(MethodInfo) - Method in class jadex.platform.service.remote.ProxyInfo
Add an excluded method.
addFinishListener(IChangeListener<Void>) - Method in class jadex.platform.service.threadpool.ThreadPoolService
Add a finished listener.
addFutureCommand(String, Runnable) - Method in class jadex.platform.service.remote.RemoteServiceManagementService
Add a future command.
addHandler(Handler) - Method in class jadex.platform.service.cms.LoggerWrapper
Add a log Handler to receive logging messages.
addIntermediateResult(Integer, Object, boolean) - Method in class jadex.platform.service.remote.RemoteServiceManagementService.WaitingCallInfo
 
addLibraryServiceListener(ILibraryServiceListener) - Method in class jadex.platform.service.library.LibraryService
Add an Library Service listener.
addLink(IResourceIdentifier, IResourceIdentifier) - Method in class jadex.platform.service.library.LibraryService
Add a link.
addMessage(Object) - Method in class jadex.platform.service.message.MessageService.DeliverMessage
Add a message to be delivered.
addMessage(AbstractSendTask) - Method in class jadex.platform.service.message.MessageService.SendManager
Add a message to be sent.
addMessageCodec(Class) - Method in class jadex.platform.service.message.MessageService
Add message codec type.
addMessageListener(IMessageListener, IFilter) - Method in class jadex.platform.service.message.MessageService
Add a message listener.
addMethodReplacement(MethodInfo, IMethodReplacement) - Method in class jadex.platform.service.remote.ProxyInfo
Add a replacement.
addMethodTimeout(MethodInfo, long) - Method in class jadex.platform.service.remote.ProxyInfo
Add a timeout for a method.
addMultipacket(byte[]) - Method in class jadex.platform.service.message.streams.OutputConnectionHandler
Called internally.
addMultiPacketChunk(byte[]) - Method in class jadex.platform.service.message.streams.OutputConnectionHandler
Called internally.
addOrUpdateEntry(DiscoveryEntry) - Method in class jadex.platform.service.awareness.discovery.LeaseTimeHandler
Add a new entry or update an existing entry.
addParentClassLoader(DelegationURLClassLoader) - Method in class jadex.platform.service.library.DelegationURLClassLoader
Add a parent loader.
addPlatformAddresses(ITransportComponentIdentifier) - Method in class jadex.platform.service.address.TransportAddressService
Set the addresses of a platform.
addPlatformCertificate(IComponentIdentifier, Certificate) - Method in class jadex.platform.service.security.SecurityService
Add a trusted certificate of a platform.
addPowerOfTwo(int) - Method in class jadex.platform.service.dht.ID
Adds 2^powerOfTwo to the value of this ID and returns the result as new ID.
addReceiver(ITransportComponentIdentifier) - Method in class jadex.platform.service.message.transport.MessageEnvelope
Add a receiver.
addRemoteReference(RemoteReference, IComponentIdentifier) - Method in class jadex.platform.service.remote.RemoteReferenceModule
Add a new holder to a remote object.
addResourceIdentifier(IResourceIdentifier, IResourceIdentifier, boolean) - Method in class jadex.platform.service.library.LibraryService
Add a new resource identifier.
address - Variable in class jadex.platform.service.awareness.discovery.ipmulticast.MulticastDiscoveryAgent
The multicast internet address.
address - Variable in class jadex.platform.service.awareness.discovery.registry.RegistryDiscoveryAgent
The registry internet address.
address - Variable in class jadex.platform.service.awareness.management.AwarenessSettingsData
The inet address.
address - Variable in class jadex.platform.service.message.transport.httprelaymtp.HttpReceiver
The current connected server address (if any).
address - Variable in class jadex.platform.service.message.transport.niotcpmtp.NIOTCPOutputConnection
The address.
address - Variable in class jadex.platform.service.message.transport.niotcpmtp.SelectorThread.Cleaner
The address of the connection.
address - Variable in class jadex.platform.service.message.transport.tcpmtp.TCPTransport.Cleaner
The address of the connection.
ADDRESS_SCHEMES - Static variable in class jadex.platform.service.message.transport.httprelaymtp.SRelay
Relay address scheme.
addresscache - Static variable in class jadex.platform.service.message.transport.niotcpmtp.NIOTCPTransport
Cache for internet addresses to avoid slow lookup.
addresses - Variable in class jadex.platform.service.awareness.management.AwarenessManagementAgent
The addresses.
addresses - Variable in class jadex.platform.service.message.transport.httprelaymtp.HttpRelayTransport
The known addresses (address -> last used date (0 for pinging, negative for dead connections)).
addresses - Variable in class jadex.platform.service.message.transport.localmtp.LocalTransport
The addresses.
addresses - Variable in class jadex.platform.service.message.transport.niotcpmtp.NIOTCPTransport
The addresses.
addresses - Variable in class jadex.platform.service.message.transport.tcpmtp.TCPTransport
The addresses.
addresses - Variable in class jadex.platform.service.remote.RemoteServiceManagementService
The transport addresses.
addrservice - Variable in class jadex.platform.service.message.MessageService
 
addRule(IRule<?>) - Method in class jadex.platform.service.ecarules.RulebaseAgent
Add a new rule.
addSecureMethod(MethodInfo) - Method in class jadex.platform.service.remote.ProxyInfo
Add an secure method.
addSubcomponent(IInternalAccess, IComponentDescription, IModelInfo) - Method in class jadex.platform.service.cms.ComponentManagementService
Add a new component to its parent.
addSubscription(SubscriptionIntermediateFuture<Email>, SubscriptionInfo) - Method in class jadex.platform.service.email.EmailAgent
Add a new subscription.
addSubscription(SubscriptionIntermediateFuture<IMonitoringEvent>, IFilter<IMonitoringEvent>) - Method in class jadex.platform.service.monitoring.MonitoringService
Add a new subscription.
addSupport(IResourceIdentifier, IResourceIdentifier) - Method in class jadex.platform.service.library.LibraryService
Add support for a rid.
addSynchronousMethod(MethodInfo) - Method in class jadex.platform.service.remote.ProxyInfo
Add an synchronous method.
addTargetInterface(Class<?>) - Method in class jadex.platform.service.remote.ProxyInfo
Add a target interface.
addTemporaryRemoteReference(RemoteReference, IComponentIdentifier) - Method in class jadex.platform.service.remote.RemoteReferenceModule
Add a new temporary holder to a remote object.
addTickTimer(ITimer) - Method in class jadex.platform.service.clock.AbstractClock
Add a tick timer.
addTimer(ITimer) - Method in class jadex.platform.service.clock.AbstractClock
Add a timer.
addTimer(ITimer) - Method in class jadex.platform.service.clock.ContinuousClock
Add a timer.
addtodo - Variable in class jadex.platform.service.library.LibraryService
The delayed add links (could not directly be added because the parent was not there).
addTopLevelURL(URL) - Method in class jadex.platform.service.library.LibraryService
Add a top level url.
addTransport(ITransport) - Method in class jadex.platform.service.message.MessageService
Adds a transport for this outbox.
addUncachedMethod(MethodInfo) - Method in class jadex.platform.service.remote.ProxyInfo
Add an uncached method.
addURL(URL) - Method in class jadex.platform.service.library.ChangeableURLClassLoader
Add a url.
addURL(IResourceIdentifier, URL) - Method in class jadex.platform.service.library.LibraryService
Add a new url.
addVirtual(String, String) - Method in class jadex.platform.service.security.SecurityService
Add a name to the mappings of a virtual name.
advanceClock() - Method in class jadex.platform.service.simulation.SimulationService
Trigger clock execution.
advanceEvent() - Method in class jadex.platform.service.clock.ClockService
Advance one event.
advanceEvent() - Method in interface jadex.platform.service.clock.ISimulationClock
Advance one event.
advanceEvent() - Method in class jadex.platform.service.clock.SimulationEventClock
Advance one event.
advanceEvent() - Method in class jadex.platform.service.clock.SimulationTickClock
Advance one event.
agent - Variable in class jadex.platform.service.address.TransportAddressService
 
agent - Variable in class jadex.platform.service.awareness.discovery.DiscoveryAgent
The agent.
agent - Variable in class jadex.platform.service.awareness.discovery.LeaseTimeHandler
The state.
agent - Variable in class jadex.platform.service.awareness.discovery.local.LocalDiscoveryAgent
Access to agent.
agent - Variable in class jadex.platform.service.awareness.discovery.ReceiveHandler
The agent.
agent - Variable in class jadex.platform.service.awareness.discovery.SendHandler
The agent.
agent - Variable in class jadex.platform.service.awareness.management.AwarenessManagementAgent
The agent.
agent - Variable in class jadex.platform.service.chat.ChatService
The agent.
agent - Variable in class jadex.platform.service.cms.ComponentManagementService
The agent.
agent - Variable in class jadex.platform.service.dht.DhtViewerAgent
The agent.
agent - Variable in class jadex.platform.service.dht.DistributedKVStoreService
The local agent access.
agent - Variable in class jadex.platform.service.dht.RingNodeService
The agent.
agent - Variable in class jadex.platform.service.ecarules.ClientRuleSystemAgent
The agent.
agent - Variable in class jadex.platform.service.ecarules.RulebaseAgent
The agent.
agent - Variable in class jadex.platform.service.email.EmailAgent
The component.
agent - Variable in class jadex.platform.service.email.EmailFetcherAgent
The agent.
agent - Variable in class jadex.platform.service.filetransfer.FileTransferService
The agent.
agent - Variable in class jadex.platform.service.monitoring.MonitoringService
The agent.
agent - Variable in class jadex.platform.service.remote.ProxyAgent
The agent.
agent - Variable in class jadex.platform.service.remote.RemoteServiceManagementAgent
The agent.
agentCreated() - Method in class jadex.platform.service.awareness.discovery.DiscoveryAgent
 
agentCreated() - Method in class jadex.platform.service.awareness.discovery.message.MessageDiscoveryAgent
Init the agent.
agentCreated() - Method in class jadex.platform.service.awareness.management.AwarenessManagementAgent
Called once after agent creation.
agentCreated() - Method in class jadex.platform.service.remote.ProxyAgent
The agent created method.
agentCreated() - Method in class jadex.platform.service.remote.RemoteServiceManagementAgent
Called once after agent creation.
agentKilled() - Method in class jadex.platform.service.awareness.discovery.DiscoveryAgent
Called just before the agent is removed from the platform.
agentKilled() - Method in class jadex.platform.service.awareness.discovery.MasterSlaveDiscoveryAgent
 
agentKilled() - Method in class jadex.platform.service.awareness.discovery.relay.RelayDiscoveryAgent
Deregister when agent is killed.
agentKilled() - Method in class jadex.platform.service.awareness.management.AwarenessManagementAgent
Called just before the agent is removed from the platform.
agentKilled() - Method in class jadex.platform.service.remote.RemoteServiceManagementAgent
Called just before the agent is removed from the platform.
ALIVE - Static variable in class jadex.platform.service.message.streams.StreamSendTask
The alive message.
ALIVE_INITIATOR - Static variable in class jadex.platform.service.message.streams.StreamSendTask
Alive message - from initiator.
ALIVE_PARTICIPANT - Static variable in class jadex.platform.service.message.streams.StreamSendTask
Alive message - from participant.
alivetime - Variable in class jadex.platform.service.message.streams.AbstractConnectionHandler
The latest alive time.
ALIVETIME - Static variable in class jadex.platform.service.message.transport.httprelaymtp.HttpRelayTransport
The alive time for assuming a connection is working.
allcodecs - Variable in class jadex.platform.service.awareness.discovery.DiscoveryAgent
The map of all codecs.
announceAwareness(AwarenessInfo) - Method in class jadex.platform.service.awareness.discovery.message.MessageDiscoveryAgent
Announce newly arrived awareness info to management service.
announceAwareness(AwarenessInfo) - Method in class jadex.platform.service.awareness.discovery.ReceiveHandler
Announce newly arrived awareness info to management service.
announceComponentIdentifier(ITransportComponentIdentifier) - Method in interface jadex.platform.service.awareness.discovery.message.IMessageAwarenessService
Announce a potentially new component identifier.
announceComponentIdentifier(ITransportComponentIdentifier) - Method in class jadex.platform.service.awareness.discovery.message.MessageDiscoveryAgent
Announce a potentially new component identifier.
announceComponentIdentifier(ITransportComponentIdentifier) - Method in class jadex.platform.service.message.MessageService
Announce a component identifier to message awareness and address service.
announcements - Variable in class jadex.platform.service.awareness.discovery.message.MessageDiscoveryAgent
The map of announced component identifiers.
aread() - Method in class jadex.platform.service.message.streams.InputConnection
Asynchronous read.
areadNext() - Method in class jadex.platform.service.message.streams.InputConnection
Asynchronous read.
argstrustedlan - Variable in class jadex.platform.service.security.SecurityService
Determines if trusted lan was specified during creation.
argsusepass - Variable in class jadex.platform.service.security.SecurityService
Determines if password was specified during creation.
ARulebaseEvent - Class in jadex.platform.service.ecarules
 
ARulebaseEvent() - Constructor for class jadex.platform.service.ecarules.ARulebaseEvent
Create a new rule event.
ARulebaseEvent(int) - Constructor for class jadex.platform.service.ecarules.ARulebaseEvent
Create a new rule event.
async - Variable in class jadex.platform.service.message.transport.tcpmtp.TCPTransport
Should be received asynchronously? One thread for receiving is unavoidable.
AsyncExecutionService - Class in jadex.platform.service.execution
The asynchronous executor service that executes all tasks in separate executors.
AsyncExecutionService(IInternalAccess) - Constructor for class jadex.platform.service.execution.AsyncExecutionService
Create a new asynchronous executor service.
AsyncExecutionService(IInternalAccess, Map<String, Object>) - Constructor for class jadex.platform.service.execution.AsyncExecutionService
Create a new asynchronous executor service.
AsyncExecutionService.State - Enum in jadex.platform.service.execution
The possible states of the service.
ASYNCHRONOUS - Static variable in class jadex.platform.service.message.transport.tcpmtp.TCPTransport
Constant for asynchronous setting.
autocreate - Variable in class jadex.platform.service.awareness.management.AwarenessManagementAgent
Flag indicating if proxies should be automatically created.
autocreate - Variable in class jadex.platform.service.awareness.management.AwarenessSettingsData
The autocreate flag.
autodelete - Variable in class jadex.platform.service.awareness.management.AwarenessManagementAgent
Flag indicating if proxies should be automatically deleted.
autodelete - Variable in class jadex.platform.service.awareness.management.AwarenessSettingsData
The autocreate flag.
available() - Method in class jadex.platform.service.message.streams.InputConnection
Get the number of available bytes.
awaonly - Variable in class jadex.platform.service.message.transport.httprelaymtp.HttpRelayTransport
Flag if only awareness messages should be sent through relay.
AwarenessManagementAgent - Class in jadex.platform.service.awareness.management
Agent that sends multicasts to locate other Jadex awareness agents.
AwarenessManagementAgent() - Constructor for class jadex.platform.service.awareness.management.AwarenessManagementAgent
 
AwarenessManagementAgentHelper - Class in jadex.platform.service.awareness.management
Helper class for AwarenessSettings.
AwarenessManagementAgentHelper(IExternalAccess) - Constructor for class jadex.platform.service.awareness.management.AwarenessManagementAgentHelper
Create a new helper.
AwarenessSettingsData - Class in jadex.platform.service.awareness.management
The awareness settings transferred between GUI and agent.
AwarenessSettingsData() - Constructor for class jadex.platform.service.awareness.management.AwarenessSettingsData
 

B

basecl - Variable in class jadex.platform.service.library.DelegationURLClassLoader
The base class loader.
baseloader - Variable in class jadex.platform.service.library.LibraryService
The base classloader.
BasicDependencyService - Class in jadex.platform.service.library
The basic dependency service for creating (local) rids.
BasicDependencyService() - Constructor for class jadex.platform.service.library.BasicDependencyService
Bean constructor for service creation.
binpostprocs - Variable in class jadex.platform.service.remote.RemoteServiceManagementService
Postprocessors for binary decoding.
binpreprocs - Variable in class jadex.platform.service.remote.RemoteServiceManagementService
Preprocessors for binary encoding.
body() - Method in class jadex.platform.service.cms.PlatformComponent
Perform the main execution of the component (if any).
BroadcastDiscoveryAgent - Class in jadex.platform.service.awareness.discovery.ipbroadcast
Agent that sends multicasts to locate other Jadex awareness agents.
BroadcastDiscoveryAgent() - Constructor for class jadex.platform.service.awareness.discovery.ipbroadcast.BroadcastDiscoveryAgent
 
BroadcastReceiveHandler - Class in jadex.platform.service.awareness.discovery.ipbroadcast
Receiver handler for broadcast discovery.
BroadcastReceiveHandler(BroadcastDiscoveryAgent) - Constructor for class jadex.platform.service.awareness.discovery.ipbroadcast.BroadcastReceiveHandler
Create a new receive handler.
BroadcastSendHandler - Class in jadex.platform.service.awareness.discovery.ipbroadcast
Handle sending.
BroadcastSendHandler(BroadcastDiscoveryAgent) - Constructor for class jadex.platform.service.awareness.discovery.ipbroadcast.BroadcastSendHandler
Create a new lease time handling object.
buffer - Variable in class jadex.platform.service.awareness.discovery.ipbroadcast.BroadcastDiscoveryAgent
The receive buffer.
buffer - Variable in class jadex.platform.service.awareness.discovery.ipbroadcast.BroadcastReceiveHandler
The receive buffer.
buffer - Variable in class jadex.platform.service.awareness.discovery.ipmulticast.MulticastReceiveHandler
The receive buffer.
buffer - Variable in class jadex.platform.service.awareness.discovery.ipscanner.ScannerReceiveHandler
The receive buffer.
buffer - Variable in class jadex.platform.service.awareness.discovery.registry.RegistryReceiveHandler
The receive buffer.
BUFFER_SIZE - Static variable in class jadex.platform.service.message.transport.tcpmtp.TCPTransport
2MB as message buffer
buffersize - Variable in class jadex.platform.service.awareness.discovery.ipscanner.ScannerDiscoveryAgent
The buffer size.
buildDigest(long, String) - Static method in class jadex.platform.service.security.SecurityService
Build the digest given the timestamp and password.
buildDigest(byte[]) - Static method in class jadex.platform.service.security.SecurityService
Build the digest given the timestamp and password.

C

cache - Variable in class jadex.platform.service.remote.ProxyReference
The value cache.
called - Variable in class jadex.platform.service.chat.ChatService.PropProvider
 
caller - Variable in class jadex.platform.service.remote.commands.RemoteMethodInvocationCommand
The caller.
caller - Variable in class jadex.platform.service.remote.commands.RemoteSearchCommand
The caller.
callfutures - Variable in class jadex.platform.service.ecarules.RulebaseAgent
callid -> future .
callid - Variable in class jadex.platform.service.ecarules.ARulebaseEvent
The call id.
callid - Variable in class jadex.platform.service.remote.commands.RemoteDGCAddReferenceCommand
The callid.
callid - Variable in class jadex.platform.service.remote.commands.RemoteDGCRemoveReferenceCommand
The callid.
callid - Variable in class jadex.platform.service.remote.commands.RemoteFutureBackwardCommand
The call identifier.
callid - Variable in class jadex.platform.service.remote.commands.RemoteFuturePullCommand
The call identifier.
callid - Variable in class jadex.platform.service.remote.commands.RemoteFutureTerminationCommand
The call identifier.
callid - Variable in class jadex.platform.service.remote.commands.RemoteGetExternalAccessCommand
The callid.
callid - Variable in class jadex.platform.service.remote.commands.RemoteMethodInvocationCommand
The call identifier.
callid - Variable in class jadex.platform.service.remote.commands.RemoteResultCommand
The callid.
callid - Variable in class jadex.platform.service.remote.commands.RemoteSearchCommand
The callid.
callid - Variable in class jadex.platform.service.remote.RemoteServiceManagementService.TimeoutTimerTask
 
cancel() - Method in class jadex.platform.service.clock.TickTimer
Cancel the timer.
cancel() - Method in class jadex.platform.service.clock.Timer
Cancel the timer.
cancel(IExecutable) - Method in class jadex.platform.service.execution.AsyncExecutionService
Cancel a task.
cancel(IExecutable) - Method in class jadex.platform.service.execution.SyncExecutionService
Cancel a task.
cancel() - Method in class jadex.platform.service.remote.RemoteServiceManagementService.TimeoutTimerTask
 
cancelled - Variable in class jadex.platform.service.remote.RemoteServiceManagementService.TimeoutTimerTask
 
cancelTransfer(String) - Method in class jadex.platform.service.chat.ChatService
Cancel an ongoing file transfer.
catalog - Variable in class jadex.platform.service.cms.LoggerWrapper
 
catalogLocale - Variable in class jadex.platform.service.cms.LoggerWrapper
 
catalogName - Variable in class jadex.platform.service.cms.LoggerWrapper
 
ccs - Variable in class jadex.platform.service.cms.ComponentManagementService
The cleanup commands for the components (component id -> cleanup command).
cfs - Variable in class jadex.platform.service.cms.ComponentManagementService
The cleanup futures for the components (component id -> cleanup future).
ch - Variable in class jadex.platform.service.message.streams.AbstractConnection
The abstract connection handler.
ChangeableURLClassLoader - Class in jadex.platform.service.library
 
ChangeableURLClassLoader(URL[]) - Constructor for class jadex.platform.service.library.ChangeableURLClassLoader
Create a new classloader.
ChangeableURLClassLoader(URL[], ClassLoader) - Constructor for class jadex.platform.service.library.ChangeableURLClassLoader
Create a new classloader.
changeTransportPosition(boolean, ITransport) - Method in class jadex.platform.service.message.MessageService
Moves a transport up or down.
channel - Variable in class jadex.platform.service.awareness.discovery.ipscanner.ScannerDiscoveryAgent
The socket to receive.
ChatAgent - Class in jadex.platform.service.chat
Chat micro agent.
ChatAgent() - Constructor for class jadex.platform.service.chat.ChatAgent
 
ChatService - Class in jadex.platform.service.chat
Chat service implementation.
ChatService() - Constructor for class jadex.platform.service.chat.ChatService
 
ChatService.PropProvider - Class in jadex.platform.service.chat
 
CHECK_LEASE_DELAY - Static variable in class jadex.platform.service.dht.DistributedServiceRegistryService
Delay in ms between two stabilize runs
CHECK_STORED_DATA_DELAY - Static variable in class jadex.platform.service.dht.DistributedKVStoreService
Delay in ms between two stabilize runs
checkClose() - Method in class jadex.platform.service.message.streams.OutputConnectionHandler
 
checkData() - Method in class jadex.platform.service.dht.DistributedKVStoreService
Check all entries for validity and move them to another node, if necessary.
checkDataStep - Variable in class jadex.platform.service.dht.DistributedKVStoreService
 
checkDigest(byte[], List<byte[]>) - Static method in class jadex.platform.service.security.SecurityService
Check if the test digest in contained in the digest list.
checkDigests(IAuthorizable, String, Map<String, String>) - Method in class jadex.platform.service.security.SecurityService
Check if there is a shared secret.
checkformail - Variable in class jadex.platform.service.email.EmailAgent
The delay between checking for mail.
checkForNewMails() - Method in class jadex.platform.service.email.EmailAgent
Check for new emails and notify the corresponding subscribers.
checkLocalRid(IResourceIdentifier) - Method in class jadex.platform.service.library.LibraryService
Check if rid has local part and if it is null.
checkProxy(DiscoveryInfo) - Method in class jadex.platform.service.awareness.management.AwarenessManagementAgent
Check if local proxy is still available.
checkResend() - Method in class jadex.platform.service.message.streams.OutputConnectionHandler
Check resending of unacknowledged messages.
checkResend() - Method in class jadex.platform.service.message.streams.OutputConnectionHandler.DataSendInfo
Check, if the message should be resent.
checkThread() - Method in class jadex.platform.service.remote.RemoteReferenceModule
Check if correct thread access.
checkUri(URI) - Method in class jadex.platform.service.library.LibraryService
Check if a local url is backed by a file.
checkUrl(URL) - Method in class jadex.platform.service.library.LibraryService
Check if a local url is backed by a file.
checkValidity() - Method in class jadex.platform.service.dht.DistributedServiceRegistryService
Check the validity of all entries and remove them, if invalid.
checkVirtual(String[], String) - Method in class jadex.platform.service.security.SecurityService
Check if the name belongs to the mappings of one of the virtual names.
checkWaitForReady() - Method in class jadex.platform.service.message.streams.OutputConnectionHandler
 
childcounts - Variable in class jadex.platform.service.cms.ComponentManagementService
Number of non-daemon children for each autoshutdown component (cid->Integer).
cid - Variable in class jadex.platform.service.library.BasicDependencyService
The component identifier to use for creating local resource IDs.
cid - Variable in class jadex.platform.service.remote.commands.RemoteGetExternalAccessCommand
The providerid (i.e.
cidcounts - Variable in class jadex.platform.service.cms.ComponentManagementService
The cid count.
cinfo - Variable in class jadex.platform.service.clock.ClockService
The clock type.
classloader - Variable in class jadex.platform.service.message.MapSendTask
The classloader.
classloader - Variable in class jadex.platform.service.message.MessageService
The class loader of the message service (only for envelope en/decoding, content is handled by receiver class loader).
classloaders - Variable in class jadex.platform.service.library.LibraryService
The map of managed resources 2xrid (local, remote) -> delegate loader).
cleaner - Variable in class jadex.platform.service.message.transport.niotcpmtp.NIOTCPDeadConnection
The cleaner.
cleaner - Variable in class jadex.platform.service.message.transport.niotcpmtp.NIOTCPOutputConnection
The cleaner.
Cleaner(InetSocketAddress, long) - Constructor for class jadex.platform.service.message.transport.niotcpmtp.SelectorThread.Cleaner
Cleaner for a specified output connection.
cleaner - Variable in class jadex.platform.service.message.transport.tcpmtp.TCPOutputConnection
The cleaner.
Cleaner(String) - Constructor for class jadex.platform.service.message.transport.tcpmtp.TCPTransport.Cleaner
Cleaner for a specified output connection.
clfuts - Variable in class jadex.platform.service.library.LibraryService
The class loader futures for currently loading class loaders.
ClientRuleSystemAgent - Class in jadex.platform.service.ecarules
Agent that registers with an IRulebaseService and follows the master rule base.
ClientRuleSystemAgent() - Constructor for class jadex.platform.service.ecarules.ClientRuleSystemAgent
 
clock - Variable in class jadex.platform.service.clock.ClockService
The clock.
clock - Variable in class jadex.platform.service.clock.Timer
The clock.
clock - Variable in class jadex.platform.service.cms.LoggerWrapper
The clock service.
ClockAgent - Class in jadex.platform.service.clock
Agent that provides the clock service.
ClockAgent() - Constructor for class jadex.platform.service.clock.ClockAgent
 
ClockCreationInfo - Class in jadex.platform.service.clock
Clock creation info.
ClockCreationInfo(String, String) - Constructor for class jadex.platform.service.clock.ClockCreationInfo
Create a new clock info.
ClockCreationInfo(String, String, long, long) - Constructor for class jadex.platform.service.clock.ClockCreationInfo
Create a new clock info.
ClockCreationInfo(String, String, long, long, double) - Constructor for class jadex.platform.service.clock.ClockCreationInfo
Create a new clock info.
ClockService - Class in jadex.platform.service.clock
A clock service abstracts away from clock implementations.
ClockService(ClockCreationInfo, IInternalAccess, Boolean) - Constructor for class jadex.platform.service.clock.ClockService
Create a new clock service.
ClockService(ClockCreationInfo, IInternalAccess, Map, Boolean) - Constructor for class jadex.platform.service.clock.ClockService
Create a new clock service.
clockservice - Variable in class jadex.platform.service.df.DirectoryFacilitatorService
The cached clock service.
clockservice - Variable in class jadex.platform.service.message.MessageService
The cashed clock service.
clockservice - Variable in class jadex.platform.service.simulation.SimulationService
The clock service.
clocktype - Variable in class jadex.platform.service.clock.ClockCreationInfo
The clock type.
clone() - Method in class jadex.platform.service.dht.Finger
 
close() - Method in class jadex.platform.service.message.streams.AbstractConnection
Close the connection.
close() - Method in class jadex.platform.service.message.streams.AbstractConnectionHandler
Close the connection.
close() - Method in class jadex.platform.service.message.streams.LocalAbstractConnectionHandler
Close the connection.
close() - Method in class jadex.platform.service.message.streams.OutputConnection
Close the connection.
CLOSE - Static variable in class jadex.platform.service.message.streams.StreamSendTask
Close the connection.
close() - Method in class jadex.platform.service.message.transport.niotcpmtp.NIOTCPDeadConnection
Close the connection.
close() - Method in class jadex.platform.service.message.transport.niotcpmtp.NIOTCPInputConnection
Close the connection.
close() - Method in class jadex.platform.service.message.transport.niotcpmtp.NIOTCPOutputConnection
Close the connection.
close() - Method in class jadex.platform.service.message.transport.tcpmtp.TCPInputConnection
Close the connection.
close() - Method in class jadex.platform.service.message.transport.tcpmtp.TCPOutputConnection
Close the connection.
CLOSE_INPUT_PARTICIPANT - Static variable in class jadex.platform.service.message.streams.StreamSendTask
Close connection - from participant.
CLOSE_OUTPUT_INITIATOR - Static variable in class jadex.platform.service.message.streams.StreamSendTask
Close connection - from initiator.
closed - Variable in class jadex.platform.service.message.streams.AbstractConnection
 
closeKeyAttachment(SelectionKey) - Method in class jadex.platform.service.message.transport.niotcpmtp.SelectorThread
 
closeReceived(int) - Method in class jadex.platform.service.message.streams.InputConnectionHandler
From initiator.
CLOSEREQ - Static variable in class jadex.platform.service.message.streams.StreamSendTask
Close request (from participant which cannot close itself).
CLOSEREQ_INPUT_INITIATOR - Static variable in class jadex.platform.service.message.streams.StreamSendTask
Close request connection - from initiator.
CLOSEREQ_OUTPUT_PARTICIPANT - Static variable in class jadex.platform.service.message.streams.StreamSendTask
Request close connection - from participant.
closereqflag - Variable in class jadex.platform.service.message.streams.OutputConnectionHandler
Close request flag (when a closereq message was received).
closeRequestReceived() - Method in class jadex.platform.service.message.streams.OutputConnectionHandler
Received a request to close the connection.
closesent - Variable in class jadex.platform.service.message.streams.OutputConnectionHandler
Flag if close was already sent.
closing - Variable in class jadex.platform.service.message.streams.AbstractConnection
 
cmdcallid - Variable in class jadex.platform.service.remote.commands.RemoteFutureBackwardCommand
The call identifier to terminate.
cms - Variable in class jadex.platform.service.awareness.management.AwarenessManagementAgent
The cms, cached for speed.
cms - Variable in class jadex.platform.service.df.DirectoryFacilitatorService
The cached component management service.
cms - Variable in class jadex.platform.service.message.MessageService
The cms.
cnt - Variable in class jadex.platform.service.remote.commands.RemoteIntermediateResultCommand
The result cnt.
cnt - Variable in class jadex.platform.service.remote.RemoteServiceManagementService.WaitingCallInfo
The intermediate result cnt.
CODEC_ID - Static variable in class jadex.platform.service.message.transport.codecs.GZIPCodec
The gzip codec id.
CODEC_ID - Static variable in class jadex.platform.service.message.transport.codecs.JadexBinaryCodec
The JadexBinary codec id.
CODEC_ID - Static variable in class jadex.platform.service.message.transport.codecs.JadexBinaryCodec2
The JadexBinary codec id.
CODEC_ID - Static variable in class jadex.platform.service.message.transport.codecs.JadexXMLCodec
The JadexXML codec id.
CODEC_ID - Static variable in class jadex.platform.service.message.transport.codecs.NuggetsCodec
The nuggets codec id.
CODEC_ID - Static variable in class jadex.platform.service.message.transport.codecs.SerialCodec
The serial codec id.
CODEC_ID - Static variable in class jadex.platform.service.message.transport.codecs.XMLCodec
The xml codec id.
CODEC_NAMES - Static variable in class jadex.platform.service.message.transport.codecs.CodecFactory
The codec names, array index equals CODEC_ID.
codeccache - Variable in class jadex.platform.service.message.transport.codecs.CodecFactory
The codec cache (id -> codec instance).
codecclasses - Variable in class jadex.platform.service.message.transport.codecs.CodecFactory
The mapping (id -> codec class).
codecfactory - Variable in class jadex.platform.service.message.MessageService
The codec factory for messages.
CodecFactory - Class in jadex.platform.service.message.transport.codecs
The factory for codecs.
CodecFactory() - Constructor for class jadex.platform.service.message.transport.codecs.CodecFactory
Create a new codec factory.
CodecFactory(Class[], Class[]) - Constructor for class jadex.platform.service.message.transport.codecs.CodecFactory
Create a new codec factory.
codecids - Variable in class jadex.platform.service.message.AbstractSendTask
The codecids.
codecs - Variable in class jadex.platform.service.message.AbstractSendTask
The codecs.
CODECS - Static variable in class jadex.platform.service.message.MessageService
The default codecs.
collectClasspathURLs(ClassLoader, Set<URI>, Set<String>) - Method in class jadex.platform.service.library.LibraryService
Collect all URLs belonging to a class loader.
collectManifestURLs(URI, Set<URI>, Set<String>) - Method in class jadex.platform.service.library.LibraryService
Collect all URLs as specified in a manifest.
collectParts(Multipart, List<String>, List<Object>) - Method in class jadex.platform.service.email.SubscriptionInfo
 
compareTo(IID) - Method in class jadex.platform.service.dht.ID
Compare this ID with another.
component - Variable in class jadex.platform.service.clock.ClockService
The component.
component - Variable in class jadex.platform.service.execution.AsyncExecutionService
The component.
component - Variable in class jadex.platform.service.library.BasicDependencyService
The service providing component.
component - Variable in class jadex.platform.service.library.LibraryService
The component.
component - Variable in class jadex.platform.service.message.MessageService
The component.
component - Variable in class jadex.platform.service.message.transport.httprelaymtp.HttpRelayTransport
The component.
component - Variable in class jadex.platform.service.message.transport.localmtp.LocalTransport
The platform.
component - Variable in class jadex.platform.service.message.transport.niotcpmtp.NIOTCPTransport
The platform.
component - Variable in class jadex.platform.service.message.transport.tcpmtp.TCPTransport
The platform.
component - Variable in class jadex.platform.service.remote.RemoteServiceManagementService
The component.
component - Variable in class jadex.platform.service.security.SecurityService
The component.
componentfactory - Variable in class jadex.platform.service.cms.ComponentManagementService
The bootstrap component factory.
ComponentManagementService - Class in jadex.platform.service.cms
Abstract default implementation of component management service.
ComponentManagementService(IPlatformComponentAccess, IBootstrapFactory, boolean) - Constructor for class jadex.platform.service.cms.ComponentManagementService
Create a new component execution service.
components - Variable in class jadex.platform.service.cms.ComponentManagementService
The components (id->component).
components - Variable in class jadex.platform.service.df.DirectoryFacilitatorService
The registered components.
computeFlattenedDependencies(List<DelegationURLClassLoader>) - Static method in class jadex.platform.service.library.DelegationURLClassLoader
Get transitive dependencies as flattened set (without duplicates).
computeNextTimepoint() - Method in class jadex.platform.service.clock.ContinuousClock
Compute the next timepoint.
con - Variable in class jadex.platform.service.message.streams.AbstractConnectionHandler
The connection.
con - Variable in class jadex.platform.service.message.streams.LocalAbstractConnectionHandler
The connection.
con - Variable in class jadex.platform.service.message.transport.httprelaymtp.HttpReceiver.TimeoutTask
The url connection.
con - Variable in class jadex.platform.service.message.transport.niotcpmtp.SelectorThread.Cleaner
The connection associated to the address.
config(String) - Method in class jadex.platform.service.cms.LoggerWrapper
Log a CONFIG message.
conhandler - Variable in class jadex.platform.service.message.streams.LocalAbstractConnectionHandler
The other connection.
conman - Variable in class jadex.platform.service.message.transport.httprelaymtp.HttpRelayTransport
The connection manager.
connected(String) - Method in interface jadex.platform.service.awareness.discovery.relay.IRelayAwarenessService
Let the awareness know that the transport connected to an address.
connected(String) - Method in class jadex.platform.service.awareness.discovery.relay.RelayDiscoveryAgent
Let the awareness know that the transport connected to an address.
connected(String, boolean) - Method in class jadex.platform.service.message.transport.httprelaymtp.HttpRelayTransport
Called from receiver thread, when it connects to an address.
ConnectionException - Exception in jadex.platform.service.awareness.discovery
Exception denoting that discovery cannot get access to the underlying
ConnectionException(String) - Constructor for exception jadex.platform.service.awareness.discovery.ConnectionException
Create a new exception.
ConnectionException(Throwable) - Constructor for exception jadex.platform.service.awareness.discovery.ConnectionException
Create a new exception.
ConnectionException(String, Throwable) - Constructor for exception jadex.platform.service.awareness.discovery.ConnectionException
Create a new exception.
ConnectionPanel() - Constructor for class jadex.platform.service.message.streams.AbstractConnectionHandler.ConnectionPanel
 
connections - Variable in class jadex.platform.service.message.transport.tcpmtp.TCPTransport
The opened connections for addresses.
contentcodecinfos - Variable in class jadex.platform.service.message.MessageService
The map of content codec infos.
contentcodecs - Variable in class jadex.platform.service.message.MessageService
The content codecs.
context - Variable in class jadex.platform.service.remote.RemoteServiceManagementService.WaitingCallInfo
The context.
ContextAgent - Class in jadex.platform.service.context
Agent that provides the context service.
ContextAgent() - Constructor for class jadex.platform.service.context.ContextAgent
 
contextser - Variable in class jadex.platform.service.security.SecurityService
The ContextService.
ContextService - Class in jadex.platform.service.context
Java SE Implementation of IContextService
ContextService(IComponentIdentifier) - Constructor for class jadex.platform.service.context.ContextService
Create a new ContextService.
contextService - Variable in class jadex.platform.service.settings.SettingsService
The context service.
continued - Variable in class jadex.platform.service.simulation.SimulationService.IdleListener
Flag indicating an a continued execution.
ContinuousClock - Class in jadex.platform.service.clock
A continuous clock represents a real time clock that is based on the hardware clock.
ContinuousClock(String, long, double, IThreadPool) - Constructor for class jadex.platform.service.clock.ContinuousClock
Create a new clock.
ContinuousClock(String, long, double, long, IThreadPool) - Constructor for class jadex.platform.service.clock.ContinuousClock
Create a new clock.
ContinuousClock(IClock, IThreadPool) - Constructor for class jadex.platform.service.clock.ContinuousClock
Create a new clock.
convertAddresses(Address[]) - Method in class jadex.platform.service.email.SubscriptionInfo
Convert email addresses to strings.
convertBodyMessage(Message, Email) - Method in class jadex.platform.service.email.SubscriptionInfo
Convert an email message to the simple jadex email format.
convertHeaderMessage(Message, Email) - Method in class jadex.platform.service.email.SubscriptionInfo
Convert an email message to the simple jadex email format.
convertMessage(Message) - Method in class jadex.platform.service.email.SubscriptionInfo
Convert an email message to the simple jadex email format.
convertSubjectMessage(Message, Email) - Method in class jadex.platform.service.email.SubscriptionInfo
Convert an email message to the simple jadex email format.
copyFromClock(IClock) - Method in class jadex.platform.service.clock.AbstractClock
Transfer state from another clock to this clock.
copyFromClock(IClock) - Method in class jadex.platform.service.clock.ContinuousClock
Transfer state from another clock to this clock.
copyFromClock(IClock) - Method in class jadex.platform.service.clock.SystemClock
Transfer state from another clock to this clock.
count - Static variable in class jadex.platform.service.clock.Timer
The instance count.
create(ComponentCreationInfo, Collection<IComponentFeatureFactory>) - Method in class jadex.platform.service.cms.PlatformComponent
Create the component, i.e.
createAckTimer(Object) - Method in class jadex.platform.service.message.streams.AbstractConnectionHandler
Triggers resends of packets if no ack has been received in acktimeout.
createAwarenessInfo() - Method in class jadex.platform.service.awareness.discovery.DiscoveryAgent
Create awareness info of myself.
createAwarenessInfo(String, String) - Method in class jadex.platform.service.awareness.discovery.DiscoveryAgent
Create awareness info of myself.
createAwarenessInfo() - Method in class jadex.platform.service.awareness.discovery.ipbroadcast.BroadcastSendHandler
Create the awareness info.
createAwarenessInfo() - Method in class jadex.platform.service.awareness.discovery.MasterSlaveSendHandler
Create the awareness info.
createAwarenessInfo() - Method in class jadex.platform.service.awareness.discovery.SendHandler
Create the awareness info.
createBroadcastAddress(InetAddress, short) - Method in class jadex.platform.service.awareness.discovery.ipbroadcast.BroadcastSendHandler
Create broadcast address according to prefix length.
createBulkAckTimer(Object) - Method in class jadex.platform.service.message.streams.OutputConnectionHandler
Triggers resends of packets if no ack has been received in acktimeout.
createClassLoader(IResourceIdentifier, Map<IResourceIdentifier, List<IResourceIdentifier>>, IResourceIdentifier, boolean) - Method in class jadex.platform.service.library.LibraryService
Create a new classloader.
createClientSocket(String, int) - Method in class jadex.platform.service.message.transport.tcpmtp.TCPTransport
Create a client socket.
createClock(ClockCreationInfo, IThreadPool) - Static method in class jadex.platform.service.clock.ClockService
Create a clock.
createComponent(String, CreationInfo) - Method in class jadex.platform.service.cms.ComponentManagementService
Create a new component on the platform.
createComponent(String, String, CreationInfo) - Method in class jadex.platform.service.cms.ComponentManagementService
Create a new component on the platform.
createComponent(CreationInfo, String, String) - Method in class jadex.platform.service.cms.ComponentManagementService
Create a new component on the platform.
createComponent(String, String, CreationInfo, IResultListener<Collection<Tuple2<String, Object>>>) - Method in class jadex.platform.service.cms.ComponentManagementService
Create a new component on the platform.
createConnection(String) - Method in class jadex.platform.service.message.transport.tcpmtp.TCPTransport
Create a outgoing connection.
createCopy() - Method in class jadex.platform.service.ecarules.ARulebaseEvent
 
createCopy() - Method in class jadex.platform.service.ecarules.RuleAddedEvent
Copy the object.
createCopy() - Method in class jadex.platform.service.ecarules.RuleRemovedEvent
Copy the object.
createData(Object, ICodec[], ClassLoader, IEncodingContext) - Static method in class jadex.platform.service.message.MapSendTask
Create the data.
createDataTimer(long) - Method in class jadex.platform.service.message.streams.InputConnectionHandler
Create a new data ack timer.
createDFComponentDescription(IComponentIdentifier, IDFServiceDescription) - Method in class jadex.platform.service.df.DirectoryFacilitatorService
Create a df component description.
createDFComponentDescription(IComponentIdentifier, IDFServiceDescription, long) - Method in class jadex.platform.service.df.DirectoryFacilitatorService
Create a df component description.
createDFComponentDescription(IComponentIdentifier, IDFServiceDescription[], String[], String[], String[], Date) - Method in class jadex.platform.service.df.DirectoryFacilitatorService
Create a new df component description.
createDFServiceDescription(String, String, String) - Method in class jadex.platform.service.df.DirectoryFacilitatorService
Create a df service description.
createDFServiceDescription(String, String, String, String[], String[], String[], IProperty[]) - Method in class jadex.platform.service.df.DirectoryFacilitatorService
Create a df service description.
createExecutor() - Method in class jadex.platform.service.clock.ContinuousClock
Create new executor.
createGui() - Method in class jadex.platform.service.message.streams.AbstractConnectionHandler
 
createInputConnection(IComponentIdentifier, IComponentIdentifier, Map<String, Object>) - Method in class jadex.platform.service.message.MessageService
Create a virtual input connection.
createKeyPair(IComponentIdentifier, String, int, String, int) - Method in class jadex.platform.service.security.SecurityService
Create a key pair entry (with associated certificate).
createLogRecord(Level, String, long) - Method in class jadex.platform.service.cms.LoggerWrapper
 
createMasterId() - Method in class jadex.platform.service.awareness.discovery.DiscoveryAgent
Create the master id.
createMasterId() - Method in class jadex.platform.service.awareness.discovery.ipbroadcast.BroadcastDiscoveryAgent
Create the master id.
createMasterId(InetAddress, int) - Method in class jadex.platform.service.awareness.discovery.ipbroadcast.BroadcastDiscoveryAgent
Create the master id.
createMasterId() - Method in class jadex.platform.service.awareness.discovery.ipscanner.ScannerDiscoveryAgent
Create the master id.
createMasterId(InetAddress, int) - Method in class jadex.platform.service.awareness.discovery.ipscanner.ScannerDiscoveryAgent
Create the master id.
createMasterId() - Method in class jadex.platform.service.awareness.discovery.MasterSlaveDiscoveryAgent
Create the master id.
createMasterId() - Method in class jadex.platform.service.awareness.discovery.registry.RegistryDiscoveryAgent
Create the master id.
createMasterId(InetAddress, int) - Method in class jadex.platform.service.awareness.discovery.registry.RegistryDiscoveryAgent
Create the master id.
createMultipacketSendTimer(int) - Method in class jadex.platform.service.message.streams.OutputConnectionHandler
This timer automatically sends non-full multipackets after mpsendtimeout has occurred.
createNewDelegationClassLoader(IResourceIdentifier, ClassLoader, DelegationURLClassLoader[]) - Method in class jadex.platform.service.library.LibraryService
Handle instantiation here, so the DelegationURLClassLoader can be another implementation.
createObject(Class<?>, IDecodingContext) - Method in class jadex.platform.service.message.transport.codecs.LegacyMethodInfoEncoder
Creates the object during decoding.
createOrDeleteProxy(IComponentIdentifier, boolean) - Method in class jadex.platform.service.awareness.management.AwarenessManagementAgentHelper
Creates or deletes a local proxy for a given remote component.
createOutputConnection(IComponentIdentifier, IComponentIdentifier, Map<String, Object>) - Method in class jadex.platform.service.message.MessageService
Create a virtual output connection.
createPanel() - Method in class jadex.platform.service.message.streams.AbstractConnectionHandler
 
createPanel() - Method in class jadex.platform.service.message.streams.InputConnectionHandler
 
createProlog(byte[]) - Static method in class jadex.platform.service.message.MapSendTask
Create prolog data.
createProxy(DiscoveryInfo) - Method in class jadex.platform.service.awareness.management.AwarenessManagementAgent
Create a proxy using given settings.
createProxyInfo(Object, Class<?>[], ClassLoader) - Method in class jadex.platform.service.remote.RemoteReferenceModule
Create a proxy info for a service.
createRealtimeTimer(long, ITimedObject) - Method in class jadex.platform.service.clock.ClockService
Create a new realtime timer.
createReceiveHandler() - Method in class jadex.platform.service.awareness.discovery.DiscoveryAgent
Create the receive handler.
createReceiveHandler() - Method in class jadex.platform.service.awareness.discovery.ipbroadcast.BroadcastDiscoveryAgent
Create the receive handler.
createReceiveHandler() - Method in class jadex.platform.service.awareness.discovery.ipmulticast.MulticastDiscoveryAgent
Create the receive handler.
createReceiveHandler() - Method in class jadex.platform.service.awareness.discovery.ipscanner.ScannerDiscoveryAgent
Create the receive handler.
createReceiveHandler() - Method in class jadex.platform.service.awareness.discovery.message.MessageDiscoveryAgent
Create the receive handler.
createReceiveHandler() - Method in class jadex.platform.service.awareness.discovery.registry.RegistryDiscoveryAgent
Create the receive handler.
createReceiveHandler() - Method in class jadex.platform.service.awareness.discovery.relay.RelayDiscoveryAgent
Create the receive handler.
createResultListener(IResultListener<T>) - Method in class jadex.platform.service.cms.ComponentManagementService
Create result listener that tolerates when agent is null at shutdown.
createReturnFuture(IComponentIdentifier, String, Method, Class<?>, long, Map<String, Object>, ServiceInvocationContext) - Method in class jadex.platform.service.remote.RemoteMethodInvocationHandler
 
createSearchConstraints(int, int) - Method in class jadex.platform.service.df.DirectoryFacilitatorService
Create a search constraints object.
createSendHandler() - Method in class jadex.platform.service.awareness.discovery.DiscoveryAgent
Create the send handler.
createSendHandler() - Method in class jadex.platform.service.awareness.discovery.ipbroadcast.BroadcastDiscoveryAgent
Create the send handler.
createSendHandler() - Method in class jadex.platform.service.awareness.discovery.ipmulticast.MulticastDiscoveryAgent
Create the send handler.
createSendHandler() - Method in class jadex.platform.service.awareness.discovery.ipscanner.ScannerDiscoveryAgent
Create the send handler.
createSendHandler() - Method in class jadex.platform.service.awareness.discovery.message.MessageDiscoveryAgent
Create the send handler.
createSendHandler() - Method in class jadex.platform.service.awareness.discovery.registry.RegistryDiscoveryAgent
Create the send handler.
createSendHandler() - Method in class jadex.platform.service.awareness.discovery.relay.RelayDiscoveryAgent
Create the send handler.
createServerSocket() - Method in class jadex.platform.service.message.transport.tcpmtp.TCPTransport
Create a server socket.
createTask(String, byte[], Integer, Map<String, Object>) - Method in class jadex.platform.service.message.streams.AbstractConnectionHandler
Create a new task.
createTask(String, Object, boolean, Integer, Map<String, Object>) - Method in class jadex.platform.service.message.streams.AbstractConnectionHandler
Create a new task.
createTickTimer(ITimedObject) - Method in class jadex.platform.service.clock.AbstractClock
Create a new tick timer.
createTickTimer(ITimedObject) - Method in class jadex.platform.service.clock.ClockService
Create a new tick timer.
createTimer(long, ITimedObject) - Method in class jadex.platform.service.clock.AbstractClock
Create a new timer.
createTimer(long, ITimedObject) - Method in class jadex.platform.service.clock.ClockService
Create a new timer.
createTransport(IInternalAccess, String, Object) - Static method in class jadex.platform.service.message.MessageAgent
Attempts to instantiate a transport from a class name and arguments only.
createTransports(IInternalAccess, LinkedHashMap<String, Object>) - Static method in class jadex.platform.service.message.MessageAgent
Initializes the transports.
currentip - Variable in class jadex.platform.service.awareness.discovery.ipscanner.ScannerSendHandler
The current ip to send probes to.
currenttime - Variable in class jadex.platform.service.clock.AbstractClock
The current time (last measurement).
customExecute(IInternalAccess) - Method in class jadex.platform.service.dht.RepetitiveComponentStep
Insert work code in this method.
customIsValid() - Method in class jadex.platform.service.execution.AsyncExecutionService
Test if the service is valid.
customIsValid() - Method in class jadex.platform.service.execution.SyncExecutionService
Test if the service is valid.
CustomLogRecord - Class in jadex.platform.service.cms
 
CustomLogRecord(Level, String) - Constructor for class jadex.platform.service.cms.CustomLogRecord
 

D

data - Variable in class jadex.platform.service.message.AbstractSendTask
The encoded message envelope.
data - Variable in class jadex.platform.service.message.streams.InputConnection
The data.
data - Variable in class jadex.platform.service.message.streams.InputConnectionHandler
The data (stored here only as long as it is out of order or incomplete).
DATA - Static variable in class jadex.platform.service.message.streams.StreamSendTask
Send data message.
DATA_INPUT_PARTICIPANT - Static variable in class jadex.platform.service.message.streams.StreamSendTask
Send data - from participant.
DATA_OUTPUT_INITIATOR - Static variable in class jadex.platform.service.message.streams.StreamSendTask
Send data - from initiator.
dataRead() - Method in class jadex.platform.service.message.streams.InputConnection
 
dataReceived(byte[]) - Method in class jadex.platform.service.message.streams.LocalInputConnectionHandler
Called by local output connection handler to send data.
DataSendInfo(StreamSendTask) - Constructor for class jadex.platform.service.message.streams.OutputConnectionHandler.DataSendInfo
Create a send info.
datatimer - Variable in class jadex.platform.service.message.streams.InputConnectionHandler
The current timer.
DEADSPAN - Static variable in class jadex.platform.service.message.transport.niotcpmtp.NIOTCPTransport
The time span for which a failed connection is not retried.
DEADSPAN - Static variable in class jadex.platform.service.message.transport.tcpmtp.TCPDeadConnection
The time span for which this connection is dead.
deadtime - Variable in class jadex.platform.service.message.transport.niotcpmtp.NIOTCPDeadConnection
The dead connection start time.
deadtime - Variable in class jadex.platform.service.message.transport.tcpmtp.TCPDeadConnection
The dead connection start time.
DEBUG - Static variable in class jadex.platform.service.dht.ID
Debug field.
DEBUG - Variable in class jadex.platform.service.message.contentcodecs.JadexBinaryContentCodec
The debug flag.
DEBUG - Variable in class jadex.platform.service.message.contentcodecs.JadexBinaryContentCodec2
The debug flag.
DEBUG - Variable in class jadex.platform.service.message.contentcodecs.JadexXMLContentCodec
The debug flag.
DEBUG - Variable in class jadex.platform.service.message.transport.codecs.JadexBinaryCodec
The debug flag.
DEBUG - Variable in class jadex.platform.service.message.transport.codecs.JadexBinaryCodec2
The debug flag.
DEBUG - Variable in class jadex.platform.service.message.transport.codecs.JadexXMLCodec
The debug flag.
DEBUG - Static variable in class jadex.platform.service.remote.RemoteReferenceModule
Debug flag.
DecentralizedAcquisitionMechanism - Class in jadex.platform.service.security
The decentralized acquisition mechanism is based on a peer to peer scheme.
DecentralizedAcquisitionMechanism() - Constructor for class jadex.platform.service.security.DecentralizedAcquisitionMechanism
Create a new mechanism.
DecentralizedAcquisitionMechanism(int) - Constructor for class jadex.platform.service.security.DecentralizedAcquisitionMechanism
Create a new mechanism.
decode(byte[], ClassLoader, Map<Class<?>, Object[]>, IErrorReporter) - Method in class jadex.platform.service.message.contentcodecs.JadexBinaryContentCodec
Decode data with the codec.
decode(byte[], ClassLoader, Map<Class<?>, Object[]>, IErrorReporter) - Method in class jadex.platform.service.message.contentcodecs.JadexBinaryContentCodec2
Decode data with the codec.
decode(byte[], ClassLoader, Map<Class<?>, Object[]>, IErrorReporter) - Method in class jadex.platform.service.message.contentcodecs.JadexXMLContentCodec
Decode data with the codec.
decode(byte[], ClassLoader, Map<Class<?>, Object[]>, IErrorReporter) - Method in class jadex.platform.service.message.contentcodecs.JavaXMLContentCodec
Decode data with the codec.
decode(byte[], ClassLoader, Map<Class<?>, Object[]>, IErrorReporter) - Method in class jadex.platform.service.message.contentcodecs.NuggetsXMLContentCodec
Decode data with the codec.
decode(Object, ClassLoader, IErrorReporter) - Method in class jadex.platform.service.message.transport.codecs.GZIPCodec
Decode an object.
decode(Object, ClassLoader, IErrorReporter) - Method in class jadex.platform.service.message.transport.codecs.JadexBinaryCodec
Decode an object.
decode(Object, ClassLoader, IErrorReporter) - Method in class jadex.platform.service.message.transport.codecs.JadexBinaryCodec2
Decode an object.
decode(Object, ClassLoader, IErrorReporter) - Method in class jadex.platform.service.message.transport.codecs.JadexXMLCodec
Decode an object.
decode(Object, ClassLoader, IErrorReporter) - Method in class jadex.platform.service.message.transport.codecs.NuggetsCodec
Decode an object.
decode(Object, ClassLoader, IErrorReporter) - Method in class jadex.platform.service.message.transport.codecs.SerialCodec
Decode data with the codec.
decode(Object, ClassLoader, IErrorReporter) - Method in class jadex.platform.service.message.transport.codecs.XMLCodec
Decode an object.
decodeBytes(byte[], ClassLoader) - Static method in class jadex.platform.service.message.transport.codecs.GZIPCodec
Decode bytes.
decodeBytes(ByteArrayInputStream, ClassLoader) - Static method in class jadex.platform.service.message.transport.codecs.GZIPCodec
Decode bytes.
decodeMessage(byte[], Map<Byte, ICodec>, ClassLoader, IErrorReporter) - Static method in class jadex.platform.service.message.MapSendTask
Decode a message.
decodeMessage(Logger, MessageType, Map<String, Object>, ClassLoader, IComponentIdentifier, IInternalAccess) - Method in class jadex.platform.service.message.MessageService
Decode a message.
decodeObject(byte[], Map<Byte, ICodec>, ClassLoader) - Static method in class jadex.platform.service.awareness.discovery.DiscoveryAgent
Decode an object.
decProxyCount(RemoteReference) - Method in class jadex.platform.service.remote.RemoteReferenceModule
Decrease the proxy count for a remote reference.
defaddresses - Variable in class jadex.platform.service.message.transport.httprelaymtp.HttpRelayTransport
The default relay server lookup addresses.
DEFAULT_ADDRESS - Static variable in class jadex.platform.service.message.transport.httprelaymtp.SRelay
Default relay address(es) used by the platform for finding available servers.
default_codecs - Variable in class jadex.platform.service.message.transport.codecs.CodecFactory
The default codecs.
DEFAULT_DELTA - Static variable in class jadex.platform.service.clock.AbstractClock
The default delta (tick time).
default_ids - Variable in class jadex.platform.service.message.transport.codecs.CodecFactory
The default codec id.
DEFAULT_LEASETIME - Static variable in class jadex.platform.service.remote.RemoteReferenceModule
The default lease time.
DEFAULT_PORT - Static variable in class jadex.platform.service.message.transport.niotcpmtp.NIOTCPTransport
Default port.
DEFAULT_PORT - Static variable in class jadex.platform.service.message.transport.tcpmtp.TCPTransport
Default port.
DEFAULT_PORTS - Static variable in class jadex.platform.service.message.transport.httprelaymtp.SRelay
The default ports corresponding to the address schemes (http=80, https=443).
defaultcodecs - Variable in class jadex.platform.service.awareness.discovery.DiscoveryAgent
The default codecs.
DefaultEqualsMethodReplacement - Class in jadex.platform.service.remote.replacements
Default replacement code for equals() method.
DefaultEqualsMethodReplacement() - Constructor for class jadex.platform.service.remote.replacements.DefaultEqualsMethodReplacement
 
DefaultHashcodeMethodReplacement - Class in jadex.platform.service.remote.replacements
Default replacement code for hashCode() method.
DefaultHashcodeMethodReplacement() - Constructor for class jadex.platform.service.remote.replacements.DefaultHashcodeMethodReplacement
 
deflanguage - Variable in class jadex.platform.service.message.MessageService
The default content language (if not specified).
delay - Variable in class jadex.platform.service.awareness.discovery.DiscoveryAgent
The send (remotes) delay.
delay - Variable in class jadex.platform.service.awareness.management.AwarenessManagementAgent
The send delay.
delay - Variable in class jadex.platform.service.awareness.management.AwarenessSettingsData
The delay.
delay - Variable in class jadex.platform.service.message.transport.niotcpmtp.SelectorThread.Cleaner
The delay time before the cleaner gets active.
delegates - Variable in class jadex.platform.service.library.DelegationURLClassLoader
The delegation classloader.
DelegationURLClassLoader - Class in jadex.platform.service.library
The delegation url classloader is responsible for managing a own resource plus a set of fixed delegate loaders.
DelegationURLClassLoader(ClassLoader, DelegationURLClassLoader[]) - Constructor for class jadex.platform.service.library.DelegationURLClassLoader
Create a new classloader.
DelegationURLClassLoader(IResourceIdentifier, URL, ClassLoader, DelegationURLClassLoader[]) - Constructor for class jadex.platform.service.library.DelegationURLClassLoader
Create a new classloader.
deleteFile(String) - Method in class jadex.platform.service.filetransfer.FileTransferService
Delete a file.
deleteProxy(DiscoveryInfo) - Method in class jadex.platform.service.awareness.management.AwarenessManagementAgent
Delete a proxy.
deleteRemoteReference(RemoteReference) - Method in class jadex.platform.service.remote.RemoteReferenceModule
Delete a remote reference.
deliverMessage(Object) - Method in class jadex.platform.service.message.MessageService
Deliver a message to the intended components.
DeliverMessage() - Constructor for class jadex.platform.service.message.MessageService.DeliverMessage
Create a new deliver message executable.
deliverMessages(TCPInputConnection) - Method in class jadex.platform.service.message.transport.tcpmtp.TCPTransport
Deliver messages to local message service for dispatching to the components.
delivermsg - Variable in class jadex.platform.service.message.MessageService
The deliver message action executed by platform executor.
deliverToAllReceivers(IComponentIdentifier[], IComponentManagementService, ClassLoader, Map, Logger, MessageType) - Method in class jadex.platform.service.message.MessageService
 
deliverToReceiver(IComponentIdentifier[], int, IComponentManagementService, ClassLoader, Map<String, Object>, Logger, MessageType) - Method in class jadex.platform.service.message.MessageService
 
deliveryhandlers - Variable in class jadex.platform.service.message.MessageService
The delivery handler map.
delta - Variable in class jadex.platform.service.clock.AbstractClock
The clock tick delta (relative to base time).
delta - Variable in class jadex.platform.service.clock.ClockCreationInfo
The delta.
dependencies - Variable in class jadex.platform.service.library.DelegationURLClassLoader
The flattened transitive dependencies without duplicates (created lazy from delegates list).
deregister(IDFComponentDescription) - Method in class jadex.platform.service.df.DirectoryFacilitatorService
Deregister a component description.
deregisterPropertiesProvider(String) - Method in class jadex.platform.service.settings.SettingsService
Deregister a property provider.
destroyComponent(IComponentIdentifier) - Method in class jadex.platform.service.cms.ComponentManagementService
Destroy (forcefully terminate) an component on the platform.
destroyComponent(IComponentIdentifier, Future<Map<String, Object>>) - Method in class jadex.platform.service.cms.ComponentManagementService
Internal destroy method that performs the actual work.
destroyComponentLoop(IComponentIdentifier, IComponentIdentifier[], int) - Method in class jadex.platform.service.cms.ComponentManagementService
Loop for destroying subcomponents.
determineReturnType(Object, Method, Object[]) - Method in class jadex.platform.service.remote.RemoteMethodInvocationHandler
Determine return type of method.
DhtViewerAgent - Class in jadex.platform.service.dht
 
DhtViewerAgent() - Constructor for class jadex.platform.service.dht.DhtViewerAgent
 
digests - Variable in class jadex.platform.service.security.SecurityService
The currently valid digests.
dilation - Variable in class jadex.platform.service.clock.ClockCreationInfo
The dilation.
dilation - Variable in class jadex.platform.service.clock.ContinuousClock
The dilation.
DirectoryFacilitatorAgent - Class in jadex.platform.service.df
Agent that provides the DF service.
DirectoryFacilitatorAgent() - Constructor for class jadex.platform.service.df.DirectoryFacilitatorAgent
 
DirectoryFacilitatorService - Class in jadex.platform.service.df
Directory facilitator implementation for standalone platform.
DirectoryFacilitatorService() - Constructor for class jadex.platform.service.df.DirectoryFacilitatorService
Create a standalone df.
disableSchedules() - Method in class jadex.platform.service.dht.DistributedKVStoreService
 
disableSchedules() - Method in class jadex.platform.service.dht.RingNodeService
Disable stabilize, fix and search for debug purposes.
disconnected(String) - Method in interface jadex.platform.service.awareness.discovery.relay.IRelayAwarenessService
Let the awareness know that the transport was disconnected from an address.
disconnected(String) - Method in class jadex.platform.service.awareness.discovery.relay.RelayDiscoveryAgent
Let the awareness know that the transport was disconnected from an address.
discovered - Variable in class jadex.platform.service.awareness.management.AwarenessManagementAgent
The discovered components.
DISCOVERY_DIR - Static variable in class jadex.platform.service.awareness.discovery.local.LocalDiscoveryAgent
The discovery directory.
DiscoveryAgent - Class in jadex.platform.service.awareness.discovery
Base class for different kinds of discovery agents.
DiscoveryAgent() - Constructor for class jadex.platform.service.awareness.discovery.DiscoveryAgent
 
DiscoveryEntry - Class in jadex.platform.service.awareness.discovery
Simple data struct for saving discovery info.
DiscoveryEntry(AwarenessInfo, long, Object) - Constructor for class jadex.platform.service.awareness.discovery.DiscoveryEntry
Create an entry.
dispatchEvent(IJadexAndroidEvent) - Method in class jadex.platform.service.context.ContextService
Dispatches an Event to the Android UI / Activity.
dispose() - Method in class jadex.platform.service.awareness.discovery.LeaseTimeHandler
Release all resources.
dispose() - Method in class jadex.platform.service.clock.AbstractClock
Called, when the clock is no longer used.
dispose() - Method in class jadex.platform.service.clock.ContinuousClock
Called, when the clock is no longer used.
dispose() - Method in class jadex.platform.service.threadpool.ThreadPoolService
Shutdown the thread pool.
DistributedKVStoreAgent - Class in jadex.platform.service.dht
Agent that includes a Ring component and provides a storage service additionally.
DistributedKVStoreAgent() - Constructor for class jadex.platform.service.dht.DistributedKVStoreAgent
 
DistributedKVStoreService - Class in jadex.platform.service.dht
Service that allows storing of key/value pairs in a DHT ring.
DistributedKVStoreService() - Constructor for class jadex.platform.service.dht.DistributedKVStoreService
Constructor.
DistributedServiceRegistryAgent - Class in jadex.platform.service.dht
Agent that provides a distributed service registry.
DistributedServiceRegistryAgent() - Constructor for class jadex.platform.service.dht.DistributedServiceRegistryAgent
 
DistributedServiceRegistryService - Class in jadex.platform.service.dht
Distributed Service Registry
DistributedServiceRegistryService() - Constructor for class jadex.platform.service.dht.DistributedServiceRegistryService
 
doClose() - Method in class jadex.platform.service.message.streams.AbstractConnectionHandler
Called from connection.
doClose() - Method in interface jadex.platform.service.message.streams.IAbstractConnectionHandler
Called from connection.
doClose() - Method in class jadex.platform.service.message.streams.InputConnectionHandler
Called from connection.
doClose() - Method in class jadex.platform.service.message.streams.LocalAbstractConnectionHandler
Called from connection.
doClose() - Method in class jadex.platform.service.message.streams.OutputConnectionHandler
Called from connection.
doDownload(TransferInfo, TerminableIntermediateFuture<Long>, IInputConnection) - Method in class jadex.platform.service.chat.ChatService
Perform a download.
done(Exception) - Method in class jadex.platform.service.message.AbstractSendTask
The message sending is done.
doResend() - Method in class jadex.platform.service.message.streams.OutputConnectionHandler.DataSendInfo
Called when the message should be resent.
doSendData(StreamSendTask) - Method in class jadex.platform.service.message.streams.OutputConnectionHandler
 
doSendMessage() - Method in class jadex.platform.service.message.AbstractSendTask
Use transports to send the message.
doSendMessage(Map<String, Object>, MessageType, IExternalAccess, ClassLoader, Future<Void>, byte[], IEncodingContext) - Method in class jadex.platform.service.message.MessageService
Extracted method to be callable from listener.
doUpload(TransferInfo, IOutputConnection, IComponentIdentifier) - Method in class jadex.platform.service.chat.ChatService
Perform an upload.
doWaitFor(long, IComponentStep<?>) - Method in class jadex.platform.service.awareness.discovery.DiscoveryAgent
Overriden wait for to not use platform clock.
doWaitFor(long, IComponentStep<?>) - Method in class jadex.platform.service.awareness.discovery.LeaseTimeHandler
Overriden wait for to not use platform clock.
doWaitFor(long, IComponentStep<?>) - Method in class jadex.platform.service.awareness.management.AwarenessManagementAgent
Wait for impl.
downloadFile(IOutputConnection, String) - Method in class jadex.platform.service.filetransfer.FileTransferService
Download a file.
downloadResource(IResourceIdentifier) - Method in class jadex.platform.service.library.LibraryService
Download a resource from another platform.
DynamicStarter - Class in jadex.platform
Starter class for distributions which dynamically loads the .jar-files from the lib/ directory.
DynamicStarter() - Constructor for class jadex.platform.DynamicStarter
 

E

elapsed - Variable in class jadex.platform.service.clock.ContinuousClock
The elapsed time.
EmailAgent - Class in jadex.platform.service.email
The email agent can be used to send emails and subscribe for incoming mails.
EmailAgent() - Constructor for class jadex.platform.service.email.EmailAgent
 
EmailFetcherAgent - Class in jadex.platform.service.email
Agent that is responsible for fetching mails for one subscription.
EmailFetcherAgent() - Constructor for class jadex.platform.service.email.EmailFetcherAgent
 
EMPTY_BYTE_ARRAY - Static variable in class jadex.platform.service.message.streams.StreamSendTask
 
encode(Object, IEncodingContext) - Method in class jadex.platform.service.message.AbstractSendTask
Encode the object with the codecs.
encode(Object, ClassLoader, Map<Class<?>, Object[]>, IEncodingContext) - Method in class jadex.platform.service.message.contentcodecs.JadexBinaryContentCodec
Encode data with the codec.
encode(Object, ClassLoader, Map<Class<?>, Object[]>, IEncodingContext) - Method in class jadex.platform.service.message.contentcodecs.JadexBinaryContentCodec2
Encode data with the codec.
encode(Object, ClassLoader, Map<Class<?>, Object[]>, IEncodingContext) - Method in class jadex.platform.service.message.contentcodecs.JadexXMLContentCodec
Encode data with the codec.
encode(Object, ClassLoader, Map<Class<?>, Object[]>, IEncodingContext) - Method in class jadex.platform.service.message.contentcodecs.JavaXMLContentCodec
Encode data with the codec.
encode(Object, ClassLoader, Map<Class<?>, Object[]>, IEncodingContext) - Method in class jadex.platform.service.message.contentcodecs.NuggetsXMLContentCodec
Encode data with the codec.
encode(Object, ClassLoader, IEncodingContext) - Method in class jadex.platform.service.message.transport.codecs.GZIPCodec
Encode an object.
encode(Object, ClassLoader, IEncodingContext) - Method in class jadex.platform.service.message.transport.codecs.JadexBinaryCodec
Encode an object.
encode(Object, ClassLoader, IEncodingContext) - Method in class jadex.platform.service.message.transport.codecs.JadexBinaryCodec2
Encode an object.
encode(Object, ClassLoader, IEncodingContext) - Method in class jadex.platform.service.message.transport.codecs.JadexXMLCodec
Encode an object.
encode(Object, Class<?>, List<ITraverseProcessor>, Traverser, Map<Object, Object>, boolean, IEncodingContext) - Method in class jadex.platform.service.message.transport.codecs.LegacyMethodInfoEncoder
Encode the object.
encode(Object, ClassLoader, IEncodingContext) - Method in class jadex.platform.service.message.transport.codecs.NuggetsCodec
Encode an object.
encode(Object, ClassLoader, IEncodingContext) - Method in class jadex.platform.service.message.transport.codecs.SerialCodec
Encode data with the codec.
encode(Object, ClassLoader, IEncodingContext) - Method in class jadex.platform.service.message.transport.codecs.XMLCodec
Encode an object.
encodeBytes(byte[], ClassLoader) - Static method in class jadex.platform.service.message.transport.codecs.GZIPCodec
Encode an object.
encodeMessage(Object, ICodec[], ClassLoader, IEncodingContext) - Static method in class jadex.platform.service.message.MapSendTask
Encode a message.
encodeObject(Object, ICodec[], ClassLoader) - Static method in class jadex.platform.service.awareness.discovery.DiscoveryAgent
Encode an object.
ENCODER_CHAIN_CACHE - Static variable in class jadex.platform.service.message.transport.codecs.JadexBinaryCodec
Encoder chain cache.
ENCODER_CHAINS - Static variable in class jadex.platform.service.message.transport.codecs.JadexBinaryCodec
Available encoder chains.
encodingcontext - Variable in class jadex.platform.service.message.AbstractSendTask
The encoding context
endseqno - Variable in class jadex.platform.service.message.streams.AckInfo
The end seqno.
entries - Variable in class jadex.platform.service.awareness.discovery.LeaseTimeHandler
The entries.
entry - Variable in class jadex.platform.service.awareness.discovery.DiscoveryEntry
The entry.
entryDeleted(DiscoveryEntry) - Method in class jadex.platform.service.awareness.discovery.LeaseTimeHandler
Called when an entry has been deleted.
equals(Object) - Method in class jadex.platform.service.dht.Finger
 
equals(Object) - Method in class jadex.platform.service.dht.ID
 
equals(Object) - Method in class jadex.platform.service.remote.RemoteMethodInvocationHandler
Test equality.
equals(Object) - Method in class jadex.platform.service.remote.RemoteReference
Test for equality.
equals(Object) - Method in class jadex.platform.service.remote.RemoteReferenceHolder
Test for equality.
eventReceived(RingNodeEvent) - Method in class jadex.platform.service.dht.DistributedKVStoreService
Called upon events received from the ring service.
events - Variable in class jadex.platform.service.monitoring.MonitoringService
The list of events.
exception - Variable in class jadex.platform.service.cms.PlatformComponent
The failure reason (if any).
exception - Variable in class jadex.platform.service.remote.commands.RemoteFuturePullCommand
The exception.
exception - Variable in class jadex.platform.service.remote.commands.RemoteFutureTerminationCommand
The exception.
exception - Variable in class jadex.platform.service.remote.commands.RemoteResultCommand
The exception.
exceptionOccurred(Exception) - Method in class jadex.platform.service.simulation.SimulationService.IdleListener
Called when an exception occurs.
excluded - Variable in class jadex.platform.service.remote.ProxyInfo
The excluded methods.
excludes - Variable in class jadex.platform.service.awareness.discovery.DiscoveryAgent
The excludes list.
excludes - Variable in class jadex.platform.service.awareness.management.AwarenessManagementAgent
The excludes list.
excludes - Variable in class jadex.platform.service.awareness.management.AwarenessSettingsData
The excludes list.
execute(IInternalAccess) - Method in class jadex.platform.service.dht.RepetitiveComponentStep
 
execute(IExecutable) - Method in class jadex.platform.service.execution.AsyncExecutionService
Execute a task in its own thread.
execute(IExecutable) - Method in class jadex.platform.service.execution.SyncExecutionService
Execute a task.
execute() - Method in class jadex.platform.service.message.MessageService.DeliverMessage
Deliver the message.
execute() - Method in class jadex.platform.service.message.MessageService.SendManager
Send a message.
execute(IExternalAccess, RemoteServiceManagementService) - Method in class jadex.platform.service.remote.commands.RemoteDGCAddReferenceCommand
Execute the command.
execute(IExternalAccess, RemoteServiceManagementService) - Method in class jadex.platform.service.remote.commands.RemoteDGCRemoveReferenceCommand
Execute the command.
execute(IExternalAccess, RemoteServiceManagementService) - Method in class jadex.platform.service.remote.commands.RemoteFutureBackwardCommand
Execute the command.
execute(IExternalAccess, RemoteServiceManagementService) - Method in class jadex.platform.service.remote.commands.RemoteFuturePullCommand
Execute the command.
execute(IExternalAccess, RemoteServiceManagementService) - Method in class jadex.platform.service.remote.commands.RemoteFutureSourceCommand
Execute the command.
execute(IExternalAccess, RemoteServiceManagementService) - Method in class jadex.platform.service.remote.commands.RemoteFutureTerminationCommand
Execute the command.
execute(IExternalAccess, RemoteServiceManagementService) - Method in class jadex.platform.service.remote.commands.RemoteGetExternalAccessCommand
Execute the command.
execute(IExternalAccess, RemoteServiceManagementService) - Method in class jadex.platform.service.remote.commands.RemoteIntermediateResultCommand
Execute the command.
execute(IExternalAccess, RemoteServiceManagementService) - Method in class jadex.platform.service.remote.commands.RemoteMethodInvocationCommand
Execute the command.
execute(IExternalAccess, RemoteServiceManagementService) - Method in class jadex.platform.service.remote.commands.RemoteResultCommand
Execute the command.
execute(IExternalAccess, RemoteServiceManagementService) - Method in class jadex.platform.service.remote.commands.RemoteSearchCommand
Execute the command.
execute(IExternalAccess, RemoteServiceManagementService) - Method in interface jadex.platform.service.remote.IRemoteCommand
Execute the command.
execute(Runnable) - Method in class jadex.platform.service.threadpool.ThreadPoolService
Execute a task in its own thread.
executeBody() - Method in class jadex.platform.service.awareness.discovery.DiscoveryAgent
Execute the functional body of the agent.
executeBody() - Method in class jadex.platform.service.awareness.discovery.MasterSlaveDiscoveryAgent
Execute the functional body of the agent.
executeBody() - Method in class jadex.platform.service.awareness.discovery.relay.RelayDiscoveryAgent
After starting, perform initial registration at server.
executeBody() - Method in class jadex.platform.service.awareness.management.AwarenessManagementAgent
Execute the functional body of the agent.
executeBodyOnFeatures(Iterator<IComponentFeature>) - Method in class jadex.platform.service.cms.PlatformComponent
Execute feature bodies in parallel.
executeInitOnFeatures(Iterator<IComponentFeature>) - Method in class jadex.platform.service.cms.PlatformComponent
Recursively init the features.
executeShutdownOnFeatures(List<IComponentFeature>, int) - Method in class jadex.platform.service.cms.PlatformComponent
Recursively shutdown the features in inverse order.
executing - Variable in class jadex.platform.service.simulation.SimulationService
The executing flag.
executor - Variable in class jadex.platform.service.clock.ContinuousClock
The active timer watcher.
executor - Variable in class jadex.platform.service.dht.DistributedKVStoreService
The execution Feature of the agent.
executor - Variable in class jadex.platform.service.execution.SyncExecutionService
The executor.
executors - Variable in class jadex.platform.service.execution.AsyncExecutionService
The currently waiting tasks (task->executor).
exeservice - Variable in class jadex.platform.service.message.MessageService
The execution service.
exeservice - Variable in class jadex.platform.service.simulation.SimulationService
The execution service.
exitDestroy(IComponentIdentifier, IComponentDescription, Exception, Map<String, Object>) - Method in class jadex.platform.service.cms.ComponentManagementService
Exit the destroy method by setting description state and resetting maps.
expirydate - Variable in class jadex.platform.service.remote.RemoteReferenceHolder
The expiry date.
extractNames(ITransportComponentIdentifier) - Static method in class jadex.platform.service.awareness.management.AwarenessManagementAgent
Extract names for matching to includes/excludes list.

F

factor - Variable in class jadex.platform.service.awareness.discovery.LeaseTimeHandler
The timeout factor.
factories - Variable in class jadex.platform.service.cms.ComponentManagementService
The cached factories.
fast - Variable in class jadex.platform.service.awareness.discovery.DiscoveryAgent
Flag for enabling fast startup awareness (pingpong send behavior).
fast - Variable in class jadex.platform.service.awareness.management.AwarenessManagementAgent
Flag for enabling fast startup awareness (pingpong send behavior).
fast - Variable in class jadex.platform.service.awareness.management.AwarenessSettingsData
The fast awareness flag.
features - Variable in class jadex.platform.service.cms.PlatformComponent
The features.
fetchData() - Method in class jadex.platform.service.message.AbstractSendTask
Provide the data as a byte array.
fetchData() - Method in class jadex.platform.service.message.MapSendTask
Provide the data as a byte array.
fetchData() - Method in class jadex.platform.service.message.streams.StreamSendTask
Get the encoded message.
fetchEmails(SubscriptionInfo) - Method in class jadex.platform.service.email.EmailFetcherAgent
Fetch emails for a subscription.
fetchEmails(SubscriptionInfo) - Method in interface jadex.platform.service.email.IEmailFetcherService
Fetch emails for a subscription.
fetcher - Variable in class jadex.platform.service.cms.PlatformComponent
The combined value fetcher (cached for speed).
fetchProlog() - Method in class jadex.platform.service.message.AbstractSendTask
Provide the prolog as a byte array.
fetchProlog() - Method in class jadex.platform.service.message.MapSendTask
Get the prolog bytes.
fetchProlog() - Method in class jadex.platform.service.message.streams.StreamSendTask
Get the prolog bytes.
fetchServerAddresses() - Method in class jadex.platform.service.message.transport.httprelaymtp.HttpReceiver
Fetch an up-to-date server list.
filename - Variable in class jadex.platform.service.settings.SettingsService
The properties filename.
FileTransferAgent - Class in jadex.platform.service.filetransfer
Agent that provides the file transfer service.
FileTransferAgent() - Constructor for class jadex.platform.service.filetransfer.FileTransferAgent
 
FileTransferService - Class in jadex.platform.service.filetransfer
Service for deployment files on file system.
FileTransferService() - Constructor for class jadex.platform.service.filetransfer.FileTransferService
 
filter(IRingNodeService) - Method in class jadex.platform.service.dht.OverlayIdFilter
 
filter - Variable in class jadex.platform.service.email.SubscriptionInfo
The filter.
filter - Variable in class jadex.platform.service.monitoring.MonitoringService
The event filter to filter out some events.
filter - Variable in class jadex.platform.service.remote.commands.RemoteSearchCommand
The filter.
finalize() - Method in interface jadex.platform.service.remote.IFinalize
Finalize method called before gc.
finalize - Static variable in class jadex.platform.service.remote.RemoteMethodInvocationHandler
 
findDirectResource(String) - Method in class jadex.platform.service.library.DelegationURLClassLoader
Find the resource.
findDirectResources(String) - Method in class jadex.platform.service.library.DelegationURLClassLoader
Find the resource.
findPredecessor(IID) - Method in class jadex.platform.service.dht.RingNodeService
Find the predecessor of a given ID in the ring.
findPredecessor_recursive(IID, IFinger, IRingNodeService) - Method in class jadex.platform.service.dht.RingNodeService
 
findResource(String) - Method in class jadex.platform.service.library.DelegationURLClassLoader
Find the resource.
findResources(String) - Method in class jadex.platform.service.library.DelegationURLClassLoader
Find the resource.
findSuccessor(IID) - Method in class jadex.platform.service.dht.RingNodeService
Find the successor of a given ID in the ring.
findUsers() - Method in class jadex.platform.service.chat.ChatService
Search for available chat services.
fine(String) - Method in class jadex.platform.service.cms.LoggerWrapper
Log a FINE message.
finer(String) - Method in class jadex.platform.service.cms.LoggerWrapper
Log a FINER message.
finest(String) - Method in class jadex.platform.service.cms.LoggerWrapper
Log a FINEST message.
Finger - Class in jadex.platform.service.dht
Finger entry.
Finger() - Constructor for class jadex.platform.service.dht.Finger
Constructor.
Finger(IServiceIdentifier, IID, IID) - Constructor for class jadex.platform.service.dht.Finger
Constructor.
Finger(IRingNodeService, IID) - Constructor for class jadex.platform.service.dht.Finger
Constructor.
fingerChanged(int, IFinger, IFinger) - Method in interface jadex.platform.service.dht.Fingertable.FingerTableListener
 
Fingertable - Class in jadex.platform.service.dht
The Fingertable is a list of Fingers that point at other RingNodes to increase lookup times.
Fingertable(IServiceIdentifier, IID, Fingertable.FingerTableListener) - Constructor for class jadex.platform.service.dht.Fingertable
Constructor.
fingertable - Variable in class jadex.platform.service.dht.RingNodeService
The local fingertable
Fingertable.FingerTableListener - Interface in jadex.platform.service.dht
Receives events regarding changes in the fingertable.
finished - Variable in class jadex.platform.service.remote.commands.RemoteIntermediateResultCommand
The flag if is finished.
FinishedEvent - Class in jadex.platform.service.ecarules
 
FinishedEvent() - Constructor for class jadex.platform.service.ecarules.FinishedEvent
Create a new rule event.
FinishedEvent(int, int) - Constructor for class jadex.platform.service.ecarules.FinishedEvent
Create a new rule event.
FIX_DELAY - Static variable in class jadex.platform.service.dht.RingNodeService
Delay in ms between two fixfinger runs
fixFingers() - Method in class jadex.platform.service.dht.RingNodeService
Run the fixfingers algorithm.
flush() - Method in interface jadex.platform.service.message.streams.IOutputConnectionHandler
Flush the data.
flush() - Method in class jadex.platform.service.message.streams.LocalOutputConnectionHandler
Flush the data.
flush() - Method in class jadex.platform.service.message.streams.OutputConnection
Flush the data.
flush() - Method in class jadex.platform.service.message.streams.OutputConnectionHandler
Flush the data.
forwardData(byte[]) - Method in class jadex.platform.service.message.streams.InputConnectionHandler
Forward the data to the input connection.
forwardEvent(IMonitoringEvent) - Method in class jadex.platform.service.monitoring.MonitoringService
Forward event to all currently registered subscribers.
forwardEvent(IMonitoringEvent, SubscriptionIntermediateFuture<IMonitoringEvent>) - Method in class jadex.platform.service.monitoring.MonitoringService
Forward event to one subscribers.
fullconv - Variable in class jadex.platform.service.email.SubscriptionInfo
Flag if full email conversion is necessary for filtering.
fut - Variable in class jadex.platform.service.message.streams.OutputConnectionHandler.DataSendInfo
The future.
future - Variable in class jadex.platform.service.message.AbstractSendTask
The future for the sending result.
future - Variable in class jadex.platform.service.remote.RemoteServiceManagementService.TimeoutTimerTask
 
future - Variable in class jadex.platform.service.remote.RemoteServiceManagementService.WaitingCallInfo
The future.

G

generateComponentIdentifier(String, String) - Method in class jadex.platform.service.cms.ComponentManagementService
Create a component identifier that is allowed on the platform.
generateRemoteReference() - Method in class jadex.platform.service.remote.RemoteReferenceModule
Generate a remote reference.
get(IComponentIdentifier) - Static method in class jadex.platform.service.dht.ID
Hashes the given CID and returns an ID containing the hash.
get(String) - Static method in class jadex.platform.service.dht.ID
Hashes the given string and returns an ID containing the hash.
getAccount() - Method in class jadex.platform.service.email.SubscriptionInfo
Get the account.
getAcquisitionMechanisms() - Method in class jadex.platform.service.security.SecurityService
Get the supported certificate acquire mechanism infos.
getActiveDiscoveryMechanisms() - Method in class jadex.platform.service.awareness.management.AwarenessManagementAgentHelper
Returns a Set of active Discovery Mechanism types.
getAddress() - Method in class jadex.platform.service.awareness.discovery.registry.RegistryDiscoveryAgent
Get the address.
getAddress() - Method in class jadex.platform.service.message.transport.niotcpmtp.NIOTCPOutputConnection
Get the address.
getAddress(String, String, int) - Method in class jadex.platform.service.message.transport.niotcpmtp.NIOTCPTransport
Get the address of this transport.
getAddress(String) - Static method in class jadex.platform.service.message.transport.niotcpmtp.NIOTCPTransport
 
getAddress(String, String, int) - Method in class jadex.platform.service.message.transport.tcpmtp.TCPTransport
Get the address of this transport.
getAddresses() - Method in class jadex.platform.service.cms.ComponentManagementService
Get the addresses.
getAddresses() - Method in class jadex.platform.service.message.MessageService
Get the adresses of a component.
getAddresses() - Method in class jadex.platform.service.message.transport.httprelaymtp.HttpReceiver
Get the current addresses (if any).
getAddresses() - Method in class jadex.platform.service.message.transport.httprelaymtp.HttpRelayTransport
Get the addresses of this transport.
getAddresses() - Method in interface jadex.platform.service.message.transport.ITransport
Get the addresses of this transport.
getAddresses() - Method in class jadex.platform.service.message.transport.localmtp.LocalTransport
Get the addresses of this transport.
getAddresses() - Method in class jadex.platform.service.message.transport.niotcpmtp.NIOTCPTransport
Get the addresses of this transport.
getAddresses() - Method in class jadex.platform.service.message.transport.tcpmtp.TCPTransport
Get the adresses of this transport.
getAddresses() - Method in class jadex.platform.service.remote.RemoteServiceManagementService
Get the addresses.
getAddressInfo() - Method in class jadex.platform.service.awareness.discovery.ipmulticast.MulticastDiscoveryAgent
Get the address.
getAddressSchemes() - Method in class jadex.platform.service.message.MessageService
Get addresses of all transports.
getAgent() - Method in class jadex.platform.service.awareness.discovery.ipbroadcast.BroadcastReceiveHandler
Get the agent.
getAgent() - Method in class jadex.platform.service.awareness.discovery.ipbroadcast.BroadcastSendHandler
Get the agent.
getAgent() - Method in class jadex.platform.service.awareness.discovery.ipmulticast.MulticastReceiveHandler
Get the agent.
getAgent() - Method in class jadex.platform.service.awareness.discovery.ipmulticast.MulticastSendHandler
Get the agent.
getAgent() - Method in class jadex.platform.service.awareness.discovery.ipscanner.ScannerReceiveHandler
Get the agent.
getAgent() - Method in class jadex.platform.service.awareness.discovery.ipscanner.ScannerSendHandler
Get the agent.
getAgent() - Method in class jadex.platform.service.awareness.discovery.MasterSlaveReceiveHandler
Get the agent.
getAgent() - Method in class jadex.platform.service.awareness.discovery.MasterSlaveSendHandler
Get the agent.
getAgent() - Method in class jadex.platform.service.awareness.discovery.registry.RegistryReceiveHandler
Get the agent.
getAllCodecs() - Method in class jadex.platform.service.awareness.discovery.DiscoveryAgent
Get the allcodecs.
getAllCodecs() - Method in class jadex.platform.service.message.MessageService
Get the codecs with message codecs.
getAllCodecs() - Method in class jadex.platform.service.message.transport.codecs.CodecFactory
Get all codecs.
getAllowedSendSize() - Method in class jadex.platform.service.message.streams.LocalInputConnectionHandler
Get the allowed size that can be accepted (send by the output side).
getAllParentLoaders(ClassLoader, Set<ClassLoader>) - Static method in class jadex.platform.service.library.DelegationURLClassLoader
 
getAllResourceIdentifiers() - Method in class jadex.platform.service.library.DelegationURLClassLoader
Get all managed resource identifiers inlcuding all subdependencies.
getAllResourceIdentifiers() - Method in class jadex.platform.service.library.LibraryService
Get all resource identifiers (does not include urls of parent loader).
getAllURLs() - Method in class jadex.platform.service.library.LibraryService
Get all urls (managed, indirect and non-managed from parent loader).
getBaseClassLoader() - Method in class jadex.platform.service.library.DelegationURLClassLoader
 
getBinaryReadInfo() - Method in class jadex.platform.service.remote.RemoteServiceManagementService
 
getBinaryWriteInfo() - Method in class jadex.platform.service.remote.RemoteServiceManagementService
 
getBytes() - Method in class jadex.platform.service.dht.ID
Returns the bytes.
getCache() - Method in class jadex.platform.service.remote.ProxyReference
Get the cached values.
getCaller() - Method in class jadex.platform.service.remote.commands.RemoteMethodInvocationCommand
Get the caller.
getCallId() - Method in class jadex.platform.service.ecarules.ARulebaseEvent
Get the callid.
getCallId() - Method in class jadex.platform.service.remote.commands.RemoteDGCAddReferenceCommand
Get the callid.
getCallId() - Method in class jadex.platform.service.remote.commands.RemoteDGCRemoveReferenceCommand
Get the callid.
getCallId() - Method in class jadex.platform.service.remote.commands.RemoteFutureBackwardCommand
Get the callid.
getCallId() - Method in class jadex.platform.service.remote.commands.RemoteFuturePullCommand
Get the callid.
getCallId() - Method in class jadex.platform.service.remote.commands.RemoteFutureTerminationCommand
Get the callid.
getCallId() - Method in class jadex.platform.service.remote.commands.RemoteGetExternalAccessCommand
Get the callid.
getCallId() - Method in class jadex.platform.service.remote.commands.RemoteMethodInvocationCommand
Get the callid.
getCallId() - Method in class jadex.platform.service.remote.commands.RemoteResultCommand
Get the callid.
getCallId() - Method in class jadex.platform.service.remote.commands.RemoteSearchCommand
Get the callid.
getCertificate(String) - Method in class jadex.platform.service.security.SecurityService
Get a certificate with an alias name.
getChannel() - Method in class jadex.platform.service.awareness.discovery.ipscanner.ScannerDiscoveryAgent
Get or create a channel.
getChildren(IComponentIdentifier) - Method in class jadex.platform.service.cms.ComponentManagementService
Get the children components of a component.
getChildren(String) - Method in class jadex.platform.service.cms.PlatformComponent
Get the children (if any).
getChildrenAccesses(IInternalAccess) - Static method in class jadex.platform.service.awareness.management.AwarenessManagementAgentHelper
Get the children (if any).
getChildrenDescriptions(IComponentIdentifier) - Method in class jadex.platform.service.cms.ComponentManagementService
Get the children components of a component.
getClassLoader() - Method in class jadex.platform.service.cms.PlatformComponent
Get the class loader of the component.
getClassLoader(IResourceIdentifier) - Method in class jadex.platform.service.library.LibraryService
Returns the current ClassLoader.
getClassLoader(IResourceIdentifier, boolean) - Method in class jadex.platform.service.library.LibraryService
Returns the current ClassLoader.
getClassLoader(IResourceIdentifier, Map<IResourceIdentifier, List<IResourceIdentifier>>, IResourceIdentifier, boolean) - Method in class jadex.platform.service.library.LibraryService
Get or create a classloader for a rid.
getCleaner() - Method in class jadex.platform.service.message.transport.niotcpmtp.NIOTCPOutputConnection
Get the cleaner;
getClockService() - Method in class jadex.platform.service.simulation.SimulationService
Get the platform clock.
getClockService0() - Method in class jadex.platform.service.cms.ComponentManagementService
Get the clock service without exception if not found.
getClockTime() - Method in class jadex.platform.service.awareness.discovery.DiscoveryAgent
Get the current time.
getClockTime() - Method in class jadex.platform.service.awareness.discovery.LeaseTimeHandler
Get the current time.
getClockTime() - Method in class jadex.platform.service.awareness.management.AwarenessManagementAgent
Get the current time.
getClockType() - Method in class jadex.platform.service.clock.ClockCreationInfo
Get the clocktype.
getClockType() - Method in class jadex.platform.service.clock.ClockService
Get the clock type.
getCloneProcessors() - Method in class jadex.platform.service.marshal.MarshalService
Get the clone processors.
getClosestPrecedingFinger(IID) - Method in class jadex.platform.service.dht.Fingertable
Return the finger that preceeds the given ID and is closest to it in the local finger table.
getClosestPrecedingFinger(IID) - Method in class jadex.platform.service.dht.RingNodeService
Return the finger that preceeds the given ID and is closest to it in the local finger table.
getCmdCallid() - Method in class jadex.platform.service.remote.commands.RemoteFutureBackwardCommand
Get the cmdcallid.
getCnt() - Method in class jadex.platform.service.remote.RemoteServiceManagementService.WaitingCallInfo
Get the cnt.
getCodec(byte) - Method in class jadex.platform.service.message.transport.codecs.CodecFactory
Create a new default encoder.
getCodecFactory() - Method in class jadex.platform.service.message.MessageService
Get the codec factory.
getCodecId(Class) - Static method in class jadex.platform.service.message.transport.codecs.CodecFactory
Get the codec id for a codec class.
getCodecId() - Method in class jadex.platform.service.message.transport.codecs.GZIPCodec
Get the codec id.
getCodecId() - Method in class jadex.platform.service.message.transport.codecs.JadexBinaryCodec
Get the codec id.
getCodecId() - Method in class jadex.platform.service.message.transport.codecs.JadexBinaryCodec2
Get the codec id.
getCodecId() - Method in class jadex.platform.service.message.transport.codecs.JadexXMLCodec
Get the codec id.
getCodecId() - Method in class jadex.platform.service.message.transport.codecs.NuggetsCodec
Get the codec id.
getCodecId() - Method in class jadex.platform.service.message.transport.codecs.SerialCodec
Get the codec id.
getCodecId() - Method in class jadex.platform.service.message.transport.codecs.XMLCodec
Get the codec id.
getCodecIds() - Method in class jadex.platform.service.message.streams.AbstractConnectionHandler
Get the codec ids.
getCodecInfo() - Method in class jadex.platform.service.remote.RemoteServiceManagementService
Get the rms codec info that needs to be used for encoding/decoding content.
getCodecs(byte[], Map<Byte, ICodec>) - Static method in class jadex.platform.service.message.MapSendTask
Get the codecs that have been used for encoding the message.
getCodecs() - Method in class jadex.platform.service.message.streams.AbstractConnectionHandler
Get the codecs.
getComponent() - Method in class jadex.platform.service.message.MessageService
Get the component.
getComponent() - Method in class jadex.platform.service.remote.RemoteServiceManagementService
Get the component.
getComponent() - Method in class jadex.platform.service.security.SecurityService
Get the component.
getComponentDescription(IComponentIdentifier) - Method in class jadex.platform.service.cms.ComponentManagementService
Get the component description of a single component.
getComponentDescription() - Method in class jadex.platform.service.cms.PlatformComponent
Get the component description.
getComponentDescriptions() - Method in class jadex.platform.service.cms.ComponentManagementService
Get the component descriptions.
getComponentFactory(String, CreationInfo, IResourceIdentifier, boolean, boolean) - Method in class jadex.platform.service.cms.ComponentManagementService
Get a fitting component factory for a specific model.
getComponentFeature(Class<? extends T>) - Method in class jadex.platform.service.cms.PlatformComponent
Get a feature of the component.
getComponentFeature0(Class<? extends T>) - Method in class jadex.platform.service.cms.PlatformComponent
Get a feature of the component.
GetComponentFeatureMethodReplacement - Class in jadex.platform.service.remote.replacements
 
GetComponentFeatureMethodReplacement() - Constructor for class jadex.platform.service.remote.replacements.GetComponentFeatureMethodReplacement
 
getComponentFilename(String) - Method in class jadex.platform.service.cms.PlatformComponent
Get the file name for a logical type name of a subcomponent of this application.
getComponentIdentifier() - Method in class jadex.platform.service.cms.PlatformComponent
Get the id of the component.
getComponentIdentifiers() - Method in class jadex.platform.service.cms.ComponentManagementService
Get the component identifiers.
getConfiguration() - Method in class jadex.platform.service.cms.PlatformComponent
Get the start configuration or the default configuration if any.
getConnection() - Method in class jadex.platform.service.message.streams.AbstractConnectionHandler
Get the connection.
getConnection() - Method in class jadex.platform.service.message.streams.LocalAbstractConnectionHandler
Get the connection.
getConnection(InetSocketAddress) - Method in class jadex.platform.service.message.transport.niotcpmtp.SelectorThread
Get a connection to one of the given addresses.
getConnection(String, boolean) - Method in class jadex.platform.service.message.transport.tcpmtp.TCPTransport
Get the connection.
getConnectionHandler() - Method in class jadex.platform.service.message.streams.AbstractConnection
Get the connection handler.
getConnectionHandler() - Method in class jadex.platform.service.message.streams.LocalAbstractConnectionHandler
Get the conhandler.
getConnectionId() - Method in class jadex.platform.service.message.streams.AbstractConnection
Get the id.
getConnectionId() - Method in class jadex.platform.service.message.streams.AbstractConnectionHandler
Get the id.
getConnectionId() - Method in class jadex.platform.service.message.streams.LocalAbstractConnectionHandler
Get the id.
getConnectionManager() - Method in class jadex.platform.service.message.transport.httprelaymtp.HttpRelayTransport
Get the connection manager.
getConnectionState() - Method in class jadex.platform.service.remote.ProxyAgent
Get the connection state of the proxy.
getContentCodecInfo(IComponentIdentifier) - Method in class jadex.platform.service.message.MessageService
Get a matching content codec.
getContentCodecs() - Method in class jadex.platform.service.message.MessageService
Get content codecs.
getContentCodecs(IModelInfo, ClassLoader) - Method in class jadex.platform.service.message.MessageService
Get a matching content codec.
getContext() - Method in class jadex.platform.service.remote.RemoteServiceManagementService.WaitingCallInfo
Get the context.
getCount() - Method in class jadex.platform.service.remote.commands.RemoteIntermediateResultCommand
Get the cnt.
getCurrentLatency() - Method in class jadex.platform.service.remote.ProxyAgent
Get the current latency.
getData() - Method in class jadex.platform.service.message.AbstractSendTask
Get the encoded message.
getData() - Method in interface jadex.platform.service.message.ISendTask
Get the encoded message.
getDBEntries(String, String, int, int) - Method in class jadex.platform.service.message.transport.httprelaymtp.RelayConnectionManager
 
getDefaultAddresses() - Method in class jadex.platform.service.message.transport.httprelaymtp.HttpRelayTransport
Get the default addresses.
getDefaultCodecIds() - Method in class jadex.platform.service.message.transport.codecs.CodecFactory
Get the default decoder/encoder id.
getDefaultCodecs() - Method in class jadex.platform.service.awareness.discovery.DiscoveryAgent
Get the defaultcodecs.
getDefaultCodecs() - Method in class jadex.platform.service.message.MessageService
Get the default codecs.
getDefaultCodecs() - Method in class jadex.platform.service.message.transport.codecs.CodecFactory
Get the default codecs.
getDelay() - Method in class jadex.platform.service.awareness.discovery.DiscoveryAgent
Get the delay.
getDelay() - Method in class jadex.platform.service.awareness.management.AwarenessManagementAgent
Get the delay.
getDelegateClassLoaders() - Method in class jadex.platform.service.library.DelegationURLClassLoader
Get the delegates.
getDelegateResourceIdentifiers() - Method in class jadex.platform.service.library.DelegationURLClassLoader
Get the delegates.
getDelegates() - Method in class jadex.platform.service.library.DelegationURLClassLoader
Get the delegates.
getDelta() - Method in class jadex.platform.service.clock.AbstractClock
Get the clock delta.
getDelta() - Method in class jadex.platform.service.clock.ClockCreationInfo
Get the delta.
getDelta() - Method in class jadex.platform.service.clock.ClockService
Get the clock delta.
getDependencies(IResourceIdentifier, boolean) - Method in class jadex.platform.service.library.LibraryService
Get the dependent urls.
getDescription(IComponentIdentifier) - Method in class jadex.platform.service.cms.ComponentManagementService
Get the description for a component (if any).
getDigest(long, String) - Method in class jadex.platform.service.security.SecurityService
Get the digest.
getDilation() - Method in class jadex.platform.service.clock.ClockCreationInfo
Get the dilation.
getDilation() - Method in class jadex.platform.service.clock.ClockService
Get the clocks dilation.
getDilation() - Method in class jadex.platform.service.clock.ContinuousClock
Get the clocks dilation.
getDilation() - Method in interface jadex.platform.service.clock.IContinuousClock
Get the clocks dilation.
getDilation() - Method in class jadex.platform.service.clock.SystemClock
The dilation is always 1.0.
getDiscoveryInfo(IComponentIdentifier) - Method in class jadex.platform.service.awareness.management.AwarenessManagementAgent
Get a discovery info.
getDiscoveryInfos() - Method in class jadex.platform.service.awareness.management.AwarenessManagementAgent
Get the discovered.
getDiscoveryInfos() - Method in class jadex.platform.service.awareness.management.AwarenessManagementAgentHelper
Returns all remote Discovery Infos.
getEncoderChain(IEncodingContext) - Static method in class jadex.platform.service.message.transport.codecs.JadexBinaryCodec
Returns the encoder chain for the given Jadex version.
getEndSequenceNumber() - Method in class jadex.platform.service.message.streams.AckInfo
Get the endSequenceNumber.
getEndstateStart() - Method in class jadex.platform.service.cms.PlatformComponent
Get the step number when endstate began.
getEntries() - Method in class jadex.platform.service.awareness.discovery.LeaseTimeHandler
Get all entries.
getEntry() - Method in class jadex.platform.service.awareness.discovery.DiscoveryEntry
Get the entry.
getException() - Method in class jadex.platform.service.cms.PlatformComponent
Get the exception, if any.
getException() - Method in class jadex.platform.service.remote.commands.RemoteFuturePullCommand
Get the exception.
getException() - Method in class jadex.platform.service.remote.commands.RemoteFutureTerminationCommand
Get the exception.
getException() - Method in class jadex.platform.service.remote.commands.RemoteResultCommand
Get the exception.
getExcludedMethods() - Method in class jadex.platform.service.remote.ProxyInfo
Get the excluded.
getExcludes() - Method in class jadex.platform.service.awareness.discovery.DiscoveryAgent
Get the excludes.
getExcludes() - Method in class jadex.platform.service.awareness.management.AwarenessManagementAgent
Get the excludes.
getExecutorService() - Method in class jadex.platform.service.simulation.SimulationService
Get the executor service.
getExpiryDate() - Method in class jadex.platform.service.remote.RemoteReferenceHolder
Get the expirydate.
getExternalAccess(IComponentIdentifier) - Method in class jadex.platform.service.cms.ComponentManagementService
Get the external access of a component.
getExternalAccess(IComponentIdentifier, boolean) - Method in class jadex.platform.service.cms.ComponentManagementService
Get the external access of a component.
getExternalAccess() - Method in class jadex.platform.service.cms.PlatformComponent
Get the external access.
getExternalAccessProxy(IComponentIdentifier) - Method in class jadex.platform.service.remote.RemoteServiceManagementService
Get an external access proxy from a remote component.
getExternalAccessProxy(ITransportComponentIdentifier) - Method in class jadex.platform.service.remote.RemoteServiceManagementService
Get an external access proxy from a remote component.
getFetcher() - Method in class jadex.platform.service.cms.PlatformComponent
Get the fetcher.
getFile(String) - Method in class jadex.platform.service.context.ContextService
Returns a File
getFile(String) - Method in class jadex.platform.service.settings.SettingsService
Returns the File object for a path to a file.
getFileTransfers() - Method in class jadex.platform.service.chat.ChatService
Get a snapshot of the currently managed file transfers.
getFilter() - Method in class jadex.platform.service.cms.LoggerWrapper
Get the current filter for this Logger.
getFilter() - Method in class jadex.platform.service.email.SubscriptionInfo
Get the filter.
getFilter() - Method in class jadex.platform.service.remote.commands.RemoteSearchCommand
Get the filter.
getFinger(int) - Method in class jadex.platform.service.dht.Fingertable
Return the finger at the given index.
getFingers() - Method in class jadex.platform.service.dht.Fingertable
Return all fingers.
getFingers() - Method in class jadex.platform.service.dht.RingNodeService
Returns a List of all fingers.
getFingerTableString() - Method in class jadex.platform.service.dht.RingNodeService
Get the finger table as String for debugging purposes.
getFlattenedDependencies() - Method in class jadex.platform.service.library.DelegationURLClassLoader
Get transitive dependencies as flattened set (without duplicates).
getFuture() - Method in class jadex.platform.service.message.AbstractSendTask
Get the future.
getFuture() - Method in class jadex.platform.service.message.streams.OutputConnectionHandler.DataSendInfo
Get the future.
getFuture() - Method in class jadex.platform.service.remote.RemoteServiceManagementService.WaitingCallInfo
Get the future.
getHandlers() - Method in class jadex.platform.service.cms.LoggerWrapper
Get the Handlers associated with this logger.
getHashRidFile(IResourceIdentifier) - Method in class jadex.platform.service.library.LibraryService
Get the file for a hash rid.
getHolder() - Method in class jadex.platform.service.remote.commands.RemoteDGCAddReferenceCommand
Get the holder.
getHolder() - Method in class jadex.platform.service.remote.commands.RemoteDGCRemoveReferenceCommand
Get the holder.
getHolder() - Method in class jadex.platform.service.remote.RemoteReferenceHolder
Get the holder.
getId() - Method in class jadex.platform.service.dht.ID
Returns the internal byte array.
getId() - Method in class jadex.platform.service.dht.RingNodeService
Return own ID.
getId() - Method in class jadex.platform.service.ecarules.ARulebaseEvent
Get the id.
getId() - Method in class jadex.platform.service.message.streams.AbstractConnectionHandler.SendInfo
Get the id.
getIds(Class[]) - Static method in class jadex.platform.service.message.transport.codecs.CodecFactory
Get the default codec ids.
getImage() - Method in class jadex.platform.service.chat.ChatService
Get the image.
getIncludes() - Method in class jadex.platform.service.awareness.discovery.DiscoveryAgent
Get the includes.
getIncludes() - Method in class jadex.platform.service.awareness.management.AwarenessManagementAgent
Get the includes.
getInfo() - Method in class jadex.platform.service.awareness.discovery.DiscoveryEntry
Get the info.
getInfo() - Method in class jadex.platform.service.remote.commands.RemoteFutureBackwardCommand
Get the info.
getInitiator() - Method in class jadex.platform.service.message.streams.AbstractConnection
Get the initiator.
getInitiator() - Method in class jadex.platform.service.message.streams.InitInfo
Get the initiator.
getInitInfo(IComponentIdentifier) - Method in class jadex.platform.service.cms.ComponentManagementService
Get the init info for a component identifier.
getInputConnection() - Method in class jadex.platform.service.message.streams.InputConnectionHandler
Get the input connection.
getInternalAccess() - Method in class jadex.platform.service.cms.PlatformComponent
Get the user view of this platform component.
getInternalNonManagedURLs() - Method in class jadex.platform.service.library.LibraryService
Get other contained (but not directly managed) urls from parent classloaders.
getJarName(String) - Static method in class jadex.platform.service.library.LibraryService
Get the name of a jar file without extension and version info.
getKeyStore() - Method in class jadex.platform.service.security.SecurityService
Get the keystore.
getKeystoreDetails() - Method in class jadex.platform.service.security.SecurityService
Get info about the current keystore that is used.
getKeystoreInfo() - Method in class jadex.platform.service.security.SecurityService
Set the keystore info.
getKnownPlatforms() - Method in class jadex.platform.service.awareness.management.AwarenessManagementAgent
Get the currently known platforms.
getLastSeenMsg() - Method in class jadex.platform.service.email.SubscriptionInfo
Get the lastseenmsg.
getLastSeenNo() - Method in class jadex.platform.service.email.SubscriptionInfo
Get the lastseenno.
getLeasetime() - Method in class jadex.platform.service.message.streams.AbstractConnectionHandler
Get the leasetime.
getLength() - Method in class jadex.platform.service.dht.ID
Returns the length of this ID in bits.
getLevel() - Method in class jadex.platform.service.cms.LoggerWrapper
Get the log Level that has been specified for this Logger.
getLibraryService() - Method in class jadex.platform.service.remote.RemoteReferenceModule
Get the libservice.
getLocalKeySet() - Method in class jadex.platform.service.dht.DistributedKVStoreService
Returns all keys stored in this node.
getLocalPassword() - Method in class jadex.platform.service.security.SecurityService
Get the local password.
getLocals() - Method in class jadex.platform.service.awareness.discovery.MasterSlaveDiscoveryAgent
Get the locals.
getLogger() - Method in class jadex.platform.service.cms.PlatformComponent
Get the logger.
getLoggerName(IComponentIdentifier) - Static method in class jadex.platform.service.cms.PlatformComponent
Get the logger name.
getMarshalService() - Method in class jadex.platform.service.remote.RemoteReferenceModule
Get the marshalservice.
getMechanism(Class<?>) - Method in class jadex.platform.service.security.SecurityService
Get the mechanism for a type.
getMechanismInfo() - Method in class jadex.platform.service.security.AAcquisitionMechanism
Get the mechanism info for the gui.
getMechanismInfo() - Method in class jadex.platform.service.security.DecentralizedAcquisitionMechanism
Get the mechanism info for the gui.
getMechanismInfo() - Method in class jadex.platform.service.security.TTPAcquisitionMechanism
Get the mechanism info for the gui.
getMessage() - Method in class jadex.platform.service.message.AbstractSendTask
Get the message.
getMessage() - Method in interface jadex.platform.service.message.ISendTask
Get the message.
getMessage() - Method in class jadex.platform.service.message.MapSendTask
Get the message.
getMessage() - Method in class jadex.platform.service.message.streams.StreamSendTask
Get the message.
getMessage() - Method in class jadex.platform.service.message.transport.MessageEnvelope
Get native message.
getMessageCodecs(byte[]) - Method in class jadex.platform.service.message.MessageService
Get array of message codecs for codec ids.
getMessageService() - Method in class jadex.platform.service.message.transport.tcpmtp.TCPTransport
 
getMessageService0() - Method in class jadex.platform.service.cms.ComponentManagementService
Get the message service without exception if not found.
getMessageType() - Method in class jadex.platform.service.message.AbstractSendTask
Get the messagetype.
getMessageType() - Method in class jadex.platform.service.message.MapSendTask
Get the messagetype.
getMessageType(String) - Method in class jadex.platform.service.message.MessageService
Get the message type.
getMessageType(String) - Method in class jadex.platform.service.message.streams.AbstractConnectionHandler
Get the message type for a given type, e.g.
getMessageType() - Method in class jadex.platform.service.message.streams.StreamSendTask
Get the messagetype.
getMessageType(String, boolean, boolean) - Static method in class jadex.platform.service.message.streams.StreamSendTask
Get the message type.
getMethodInfo(Object, Class<?>, boolean) - Static method in class jadex.platform.service.remote.RemoteReferenceModule
Get method info.
getMethodName() - Method in class jadex.platform.service.remote.commands.RemoteMethodInvocationCommand
Get the methodname.
getMethodName() - Method in class jadex.platform.service.remote.commands.RemoteResultCommand
Get the methodname.
getMethodReplacement(Method) - Method in class jadex.platform.service.remote.ProxyInfo
Get a replacements.
getMethodReplacements() - Method in class jadex.platform.service.remote.ProxyInfo
Get the replacements
getMethodTimeout(IComponentIdentifier, Method) - Method in class jadex.platform.service.remote.ProxyInfo
Get a timeout.
getMethodTimeouts() - Method in class jadex.platform.service.remote.ProxyInfo
Get the timeouts
getMicroAgent() - Method in class jadex.platform.service.awareness.discovery.DiscoveryAgent
Get the agent.
getMinLeaseTime(IComponentIdentifier) - Static method in class jadex.platform.service.message.streams.StreamSendTask
Get the minimum lease time.
getMode() - Method in class jadex.platform.service.simulation.SimulationService
Get the execution mode.
getModel() - Method in class jadex.platform.service.cms.PlatformComponent
Get the model of the component.
getMyMasterId() - Method in class jadex.platform.service.awareness.discovery.ipbroadcast.BroadcastDiscoveryAgent
Get the local master id.
getMyMasterId() - Method in class jadex.platform.service.awareness.discovery.ipscanner.ScannerDiscoveryAgent
Get the local master id.
getMyMasterId() - Method in class jadex.platform.service.awareness.discovery.MasterSlaveDiscoveryAgent
Get the local master id.
getMyMasterId() - Method in class jadex.platform.service.awareness.discovery.registry.RegistryDiscoveryAgent
Get the local master id.
getName() - Method in class jadex.platform.service.clock.AbstractClock
Get the current time.
getName() - Method in class jadex.platform.service.clock.ClockCreationInfo
Get the name.
getName() - Method in class jadex.platform.service.cms.LoggerWrapper
Get the name for this logger.
getNetworkIps() - Method in class jadex.platform.service.context.ContextService
Get the network ips.
getNetworkPassword(String) - Method in class jadex.platform.service.security.SecurityService
Get the password for a network.
getNetworkPasswords() - Method in class jadex.platform.service.security.SecurityService
Get all stored network passwords.
getNewEmails() - Method in class jadex.platform.service.email.SubscriptionInfo
Fetch new emails from the inbox.
getNextByteArray() - Method in class jadex.platform.service.message.streams.InputConnection
Get the next data byte array.
getNextIdleFuture() - Method in class jadex.platform.service.execution.AsyncExecutionService
Get the future indicating that executor is idle.
getNextIdleFuture() - Method in class jadex.platform.service.execution.SyncExecutionService
Get the future indicating that executor is idle.
getNextReceivedSequenceNumber() - Method in class jadex.platform.service.message.streams.InputConnectionHandler
Get the next received sequence number.
getNextSequenceNumber() - Method in class jadex.platform.service.message.streams.OutputConnectionHandler
Get The next seqnumber.
getNextTimer() - Method in class jadex.platform.service.clock.AbstractClock
Get the next timer.
getNextTimer() - Method in class jadex.platform.service.clock.ClockService
Get the next timer.
getNFProps(boolean) - Method in class jadex.platform.service.remote.commands.RemoteMethodInvocationCommand
Get the non functional props from the executed call.
getNickName() - Method in class jadex.platform.service.chat.ChatService
Get the user name.
getNodeId() - Method in class jadex.platform.service.dht.Finger
Get the Node ID of this Finger.
getNonFunctionalProperties() - Method in class jadex.platform.service.message.AbstractSendTask
Get the non-functional requirements.
getNonFunctionalProperties() - Method in interface jadex.platform.service.message.ISendTask
Get the non-functional requirements.
getNonFunctionalProperties() - Method in class jadex.platform.service.message.streams.AbstractConnection
Get the non-functional properties of the connection.
getNonFunctionalProperties() - Method in class jadex.platform.service.message.streams.AbstractConnectionHandler
Get the non-functional properties.
getNonFunctionalProperties() - Method in interface jadex.platform.service.message.streams.IAbstractConnectionHandler
Get the non-functional properties.
getNonFunctionalProperties() - Method in class jadex.platform.service.message.streams.InitInfo
Get the nonFunctionalProperties.
getNonFunctionalProperties() - Method in class jadex.platform.service.message.streams.LocalAbstractConnectionHandler
Get the non-functional properties of the connection.
getNonFunctionalProperties() - Method in class jadex.platform.service.remote.commands.AbstractRemoteCommand
Get the non-functional properties of the call.
getNonFunctionalProperty(String) - Method in class jadex.platform.service.remote.commands.AbstractRemoteCommand
Get a non-func value.
getNonManagedURLs() - Method in class jadex.platform.service.library.LibraryService
Get other contained (but not directly managed) urls from parent classloaders.
getNotificationTime() - Method in class jadex.platform.service.clock.Timer
Get the next absolute alarm timepoint.
getNumber() - Method in class jadex.platform.service.clock.Timer
Get the number.
getNumber() - Method in class jadex.platform.service.remote.TemporaryRemoteReferenceHolder
Get the number.
getOrigin() - Method in class jadex.platform.service.remote.commands.AbstractRemoteCommand
The origin of the request.
getOriginalFuture() - Method in class jadex.platform.service.remote.commands.RemoteIntermediateResultCommand
Get the original future.
getOutputConnection() - Method in class jadex.platform.service.message.streams.OutputConnectionHandler
Get the output connection.
getOverlayId() - Method in class jadex.platform.service.dht.OverlayIdFilter
 
getOverlayId() - Method in class jadex.platform.service.dht.RingNodeService
 
getParameterGuesser() - Method in class jadex.platform.service.cms.PlatformComponent
Get the parameter guesser.
getParameterTypes() - Method in class jadex.platform.service.remote.commands.RemoteMethodInvocationCommand
Get the parametertypes.
getParameterValues() - Method in class jadex.platform.service.remote.commands.RemoteMethodInvocationCommand
Get the parametervalues.
getParent(IComponentIdentifier) - Method in class jadex.platform.service.cms.ComponentManagementService
Get the parent component of a component.
getParent() - Method in class jadex.platform.service.cms.LoggerWrapper
Return the parent for this Logger.
getParentClassLoaders() - Method in class jadex.platform.service.library.DelegationURLClassLoader
Get the parent class loaders.
getParentComponent(CreationInfo) - Method in class jadex.platform.service.cms.ComponentManagementService
Get the parent component.
getParentIdentifier(CreationInfo) - Method in class jadex.platform.service.cms.ComponentManagementService
Get the parent component of a component.
getParentInfo(CreationInfo) - Method in class jadex.platform.service.cms.ComponentManagementService
Get the info of the parent component.
getParticipant() - Method in class jadex.platform.service.message.streams.AbstractConnection
Get the participant.
getParticipant() - Method in class jadex.platform.service.message.streams.InitInfo
Get the participant.
getParticipantInputConnection(int, ITransportComponentIdentifier, ITransportComponentIdentifier, Map<String, Object>) - Method in class jadex.platform.service.message.MessageService
 
getParticipantOutputConnection(int, ITransportComponentIdentifier, ITransportComponentIdentifier, Map<String, Object>) - Method in class jadex.platform.service.message.MessageService
 
getPass() - Method in class jadex.platform.service.remote.xml.RMIPostProcessor
Get the pass number.
getPeerServers(String, String, String, int, boolean) - Method in class jadex.platform.service.message.transport.httprelaymtp.RelayConnectionManager
Get known servers from a peer server.
getPlatformAddresses(IComponentIdentifier) - Method in class jadex.platform.service.address.TransportAddressService
Remove the addresses of a platform.
getPlatformCertificate(IComponentIdentifier) - Method in class jadex.platform.service.security.SecurityService
Get the certificate of a platform.
getPlatformInfo(IComponentIdentifier) - Method in class jadex.platform.service.awareness.management.AwarenessManagementAgent
Get the discovery info for a platform, if any.
getPlatformPassword(IComponentIdentifier) - Method in class jadex.platform.service.security.SecurityService
Get the password for a target component.
getPlatformPasswords() - Method in class jadex.platform.service.security.SecurityService
Get all stored passwords.
getPort() - Method in class jadex.platform.service.awareness.discovery.ipbroadcast.BroadcastDiscoveryAgent
Get the port.
getPort() - Method in class jadex.platform.service.awareness.discovery.ipscanner.ScannerDiscoveryAgent
Get the port.
getPort() - Method in class jadex.platform.service.awareness.discovery.registry.RegistryDiscoveryAgent
Get the port.
getPredecessor() - Method in class jadex.platform.service.dht.Fingertable
Returns the predecessor of the local node.
getPredecessor() - Method in class jadex.platform.service.dht.RingNodeService
Return the predecessor of this node.
getProcessingCall(String) - Method in class jadex.platform.service.remote.RemoteServiceManagementService
Get a processing call future.
getProlog() - Method in class jadex.platform.service.message.AbstractSendTask
Get the prolog bytes.
getProlog() - Method in interface jadex.platform.service.message.ISendTask
Get the prolog bytes.
getProperties() - Method in class jadex.platform.service.awareness.management.AwarenessManagementAgent
Write current state into properties.
getProperties() - Method in class jadex.platform.service.chat.ChatService.PropProvider
Write current state into properties.
getProperties() - Method in class jadex.platform.service.clock.ClockService
Write current state into properties.
getProperties() - Method in class jadex.platform.service.library.LibraryService
Write current state into properties.
getProperties() - Method in class jadex.platform.service.security.AAcquisitionMechanism
Get the properties of the mechanism.
getProperties() - Method in class jadex.platform.service.security.DecentralizedAcquisitionMechanism
Get the properties of the mechanism.
getProperties() - Method in class jadex.platform.service.security.TTPAcquisitionMechanism
Get the properties of the mechanism.
getProperties(String) - Method in class jadex.platform.service.settings.SettingsService
Get the properties for a given id.
getProperties() - Method in class jadex.platform.service.simulation.SimulationService
Write current state into properties.
getProviderId() - Method in class jadex.platform.service.remote.commands.RemoteSearchCommand
Get the providerid.
getProxy(ProxyReference, ClassLoader) - Method in class jadex.platform.service.remote.RemoteReferenceModule
Get a proxy for a proxy reference.
getProxyInfo() - Method in class jadex.platform.service.remote.ProxyReference
Get the proxy info.
getProxyReference() - Method in class jadex.platform.service.remote.RemoteMethodInvocationHandler
Get the pr.
getProxyReference(Object, IComponentIdentifier, ClassLoader) - Method in class jadex.platform.service.remote.RemoteReferenceModule
Get a remote reference for a component for transport.
getPullCallId() - Method in class jadex.platform.service.remote.commands.RemoteFuturePullCommand
Get the pullcallid.
getRealReceiver() - Method in class jadex.platform.service.remote.commands.AbstractRemoteCommand
Get the real receiver (other than rms).
getRealReceiver() - Method in class jadex.platform.service.remote.commands.RemoteMethodInvocationCommand
Get the real receiver (other than rms).
getReceiveBehavior(long) - Method in class jadex.platform.service.email.EmailAgent
Get (or create, or renew) the receive behavior.
getReceiver() - Method in class jadex.platform.service.awareness.discovery.DiscoveryAgent
Get the receiver.
getReceiver() - Method in class jadex.platform.service.remote.commands.AbstractRemoteCommand
Get the receiver (rms of other side).
getReceivers() - Method in class jadex.platform.service.message.AbstractSendTask
Get the receivers.
getReceivers() - Method in interface jadex.platform.service.message.ISendTask
Get the receivers.
getReceivers() - Method in class jadex.platform.service.message.transport.MessageEnvelope
Get the receivers.
getReleaseDate(MessageType, Map<String, Object>) - Method in class jadex.platform.service.message.MessageService
Get the release date from a message.
getRemoteCMS(IComponentIdentifier) - Method in class jadex.platform.service.cms.ComponentManagementService
Get the remote component management system for a specific component id.
getRemoteComponentIdentifier() - Method in class jadex.platform.service.remote.ProxyAgent
Get the component identifier of the remote platform.
getRemoteInterfaces(Object, ClassLoader) - Method in class jadex.platform.service.marshal.MarshalService
Get the proxy interfaces (empty list if none).
getRemoteManagementServiceIdentifier() - Method in class jadex.platform.service.remote.RemoteReference
Get the rms.
getRemoteReference() - Method in class jadex.platform.service.remote.commands.RemoteDGCAddReferenceCommand
Get the remote reference.
getRemoteReference() - Method in class jadex.platform.service.remote.commands.RemoteDGCRemoveReferenceCommand
Get the remote reference.
getRemoteReference() - Method in class jadex.platform.service.remote.commands.RemoteMethodInvocationCommand
Get the remote reference.
getRemoteReference() - Method in class jadex.platform.service.remote.ProxyReference
Get the remoteReference.
getRemoteReference(Object) - Method in class jadex.platform.service.remote.RemoteReferenceModule
Get a remote reference.
getRemoteReference(Object, Object, boolean) - Method in class jadex.platform.service.remote.RemoteReferenceModule
Get a remote reference.
getRemoteReferenceModule() - Method in class jadex.platform.service.remote.RemoteServiceManagementService
Get the remote reference module.
getRemotes() - Method in class jadex.platform.service.awareness.discovery.MasterSlaveDiscoveryAgent
Get the remotes.
getRemovableLinks() - Method in class jadex.platform.service.library.LibraryService
Get the removable links.
getResourceAsStream(IResourceIdentifier) - Method in class jadex.platform.service.library.LibraryService
Get a resource as stream (jar).
getResourceBundle() - Method in class jadex.platform.service.cms.LoggerWrapper
Retrieve the localization resource bundle for this logger for the current default locale.
getResourceBundleName() - Method in class jadex.platform.service.cms.LoggerWrapper
Retrieve the localization resource bundle name for this logger.
getResourceIdentifier(CreationInfo) - Method in class jadex.platform.service.cms.ComponentManagementService
Find the class loader for a new (local) component.
getResourceIdentifier(URL) - Method in class jadex.platform.service.library.BasicDependencyService
Get the resource identifier for an url.
getResourceIdentifier() - Method in class jadex.platform.service.library.DelegationURLClassLoader
Get the resource identifier.
getResourceIdentifier(URL) - Method in class jadex.platform.service.library.LibraryService
Get the resource identifier for an url.
getResourceIdentifier(IExternalAccess, IComponentIdentifier) - Static method in class jadex.platform.service.remote.RemoteServiceManagementService
 
getResourceIdentifiers() - Method in class jadex.platform.service.library.LibraryService
Get the rids.
getResult() - Method in class jadex.platform.service.message.streams.AbstractConnectionHandler.SendInfo
Get the result.
getResult() - Method in class jadex.platform.service.remote.commands.RemoteResultCommand
Get the result.
getRIDClassLoader(Map, MessageType) - Method in class jadex.platform.service.message.MessageService
Get the classloader for a resource identifier.
getRidUrl(IResourceIdentifier) - Method in class jadex.platform.service.library.LibraryService
Get the local file url for a rid.
getRingService(IFinger) - Method in class jadex.platform.service.dht.RingNodeService
Get the RingNode service for a given finger entry.
getRMSComponentIdentifier() - Method in class jadex.platform.service.remote.RemoteServiceManagementService
Get the rms component identifier.
getRoot() - Method in class jadex.platform.service.awareness.discovery.DiscoveryAgent
Get the root.
getRootIdentifier() - Method in class jadex.platform.service.cms.ComponentManagementService
Get the root identifier (platform).
getRootResourceIdentifier() - Method in class jadex.platform.service.library.LibraryService
Get the root resource identifier.
getRoots() - Method in class jadex.platform.service.filetransfer.FileTransferService
Get the root devices.
getRule() - Method in class jadex.platform.service.ecarules.RuleAddedEvent
Get the rule.
getRulebase() - Method in class jadex.platform.service.ecarules.RuleAgent
Get the rulebase.
getRulebase() - Method in class jadex.platform.service.ecarules.RulebaseAgent
Get the rulebase.
getRuleName() - Method in class jadex.platform.service.ecarules.RuleRemovedEvent
Get the rulename.
getRunningTasks() - Method in class jadex.platform.service.execution.AsyncExecutionService
Get the currently running tasks.
getRunningTasks() - Method in class jadex.platform.service.execution.SyncExecutionService
Get the currently running or waiting tasks.
getScanFactor() - Method in class jadex.platform.service.awareness.discovery.ipscanner.ScannerDiscoveryAgent
Get the scanfactor.
getScope() - Method in class jadex.platform.service.remote.commands.RemoteSearchCommand
Get the scope.
getSecureMethods() - Method in class jadex.platform.service.remote.ProxyInfo
Get the secure.
getSecurityLevel() - Method in class jadex.platform.service.remote.commands.RemoteDGCAddReferenceCommand
Get the security level of the request.
getSecurityLevel() - Method in class jadex.platform.service.remote.commands.RemoteDGCRemoveReferenceCommand
Get the security level of the request.
getSecurityLevel() - Method in class jadex.platform.service.remote.commands.RemoteFutureBackwardCommand
Get the security level of the request.
getSecurityLevel() - Method in class jadex.platform.service.remote.commands.RemoteFuturePullCommand
Get the security level of the request.
getSecurityLevel() - Method in class jadex.platform.service.remote.commands.RemoteFutureTerminationCommand
Get the security level of the request.
getSecurityLevel() - Method in class jadex.platform.service.remote.commands.RemoteGetExternalAccessCommand
Get the security level of the request.
getSecurityLevel() - Method in class jadex.platform.service.remote.commands.RemoteMethodInvocationCommand
Get the security level of the request.
getSecurityLevel() - Method in class jadex.platform.service.remote.commands.RemoteResultCommand
Get the security level of the request.
getSecurityLevel() - Method in class jadex.platform.service.remote.commands.RemoteSearchCommand
Return security level determined by post-process.
getSecurityService() - Method in class jadex.platform.service.security.AAcquisitionMechanism
Get the security service.
getSelectedAcquisitionMechanism() - Method in class jadex.platform.service.security.SecurityService
Get the active acquisition mechanism.
getSelf() - Method in class jadex.platform.service.dht.Fingertable
Return the local finger entry.
getSender() - Method in class jadex.platform.service.awareness.discovery.DiscoveryAgent
Get the sender.
getSender() - Method in class jadex.platform.service.remote.commands.AbstractRemoteCommand
Get the sender component (if other than rms).
getSender() - Method in class jadex.platform.service.remote.commands.RemoteMethodInvocationCommand
Get the receiver component (if other than rms).
getSender() - Method in class jadex.platform.service.remote.commands.RemoteResultCommand
Get the sender.
getSender() - Method in class jadex.platform.service.remote.commands.RemoteSearchCommand
Get the sender component (if other than rms).
getSendId() - Method in class jadex.platform.service.awareness.discovery.SendHandler
Get the sendid.
getSendManager(IComponentIdentifier) - Method in class jadex.platform.service.message.MessageService
Get a send target manager for addresses.
getSequenceNumber() - Method in class jadex.platform.service.message.streams.InputConnectionHandler
Get the last received sequence number.
getSequenceNumber() - Method in class jadex.platform.service.message.streams.OutputConnectionHandler.DataSendInfo
Get the sequence number.
getSequenceNumber() - Method in class jadex.platform.service.message.streams.OutputConnectionHandler
Get the seqnumber.
getSequenceNumber() - Method in class jadex.platform.service.message.streams.StreamSendTask
Get the sequence number.
getServers(String) - Method in class jadex.platform.service.message.transport.httprelaymtp.RelayConnectionManager
Get known servers from a server.
getServiceIdentifier() - Method in class jadex.platform.service.security.SecurityService
Get the service identifier.
getServiceProxies(IComponentIdentifier, IComponentIdentifier, Class<T>, String, IAsyncFilter<T>) - Method in class jadex.platform.service.remote.RemoteServiceManagementService
Get all service proxies from a remote component.
getServiceProxies(IComponentIdentifier, IComponentIdentifier, Class<T>, String, boolean, IAsyncFilter<T>) - Method in class jadex.platform.service.remote.RemoteServiceManagementService
Get all service proxies from a remote component.
getServiceProxies(IComponentIdentifier, ITransportComponentIdentifier, Class<T>, String, boolean, IAsyncFilter<T>) - Method in class jadex.platform.service.remote.RemoteServiceManagementService
Get all service proxies from a remote component.
getServiceProxy(IComponentIdentifier, IComponentIdentifier, Class<T>, String, IAsyncFilter<T>) - Method in class jadex.platform.service.remote.RemoteServiceManagementService
Get a service proxy from a remote component.
getServiceSchemas() - Method in class jadex.platform.service.message.transport.httprelaymtp.HttpRelayTransport
Returns the prefix of this transport
getServiceSchemas() - Method in interface jadex.platform.service.message.transport.ITransport
Returns the prefixes of this transport
getServiceSchemas() - Method in class jadex.platform.service.message.transport.localmtp.LocalTransport
Returns the prefix of this transport
getServiceSchemas() - Method in class jadex.platform.service.message.transport.niotcpmtp.NIOTCPTransport
Returns the prefix of this transport
getServiceSchemas() - Method in class jadex.platform.service.message.transport.tcpmtp.TCPTransport
Returns the prefix of this transport
getSettings() - Method in class jadex.platform.service.awareness.management.AwarenessManagementAgentHelper
Asks the AwarenessManagementAgent for the current Settings.
getSettingsService() - Method in class jadex.platform.service.security.SecurityService
Get the settings service.
getSharedPreferences(String) - Method in class jadex.platform.service.context.ContextService
Gets a Shared Preference Container.
getSid() - Method in class jadex.platform.service.dht.Finger
Get the SID of this Finger.
getSocket() - Method in class jadex.platform.service.awareness.discovery.ipbroadcast.BroadcastDiscoveryAgent
Get or create a receiver socket.
getSocket() - Method in class jadex.platform.service.awareness.discovery.ipmulticast.MulticastDiscoveryAgent
Get or create a socket.
getSocket() - Method in class jadex.platform.service.awareness.discovery.registry.RegistryDiscoveryAgent
Get or create a receiver socket.
getSocketChannel() - Method in class jadex.platform.service.message.transport.niotcpmtp.NIOTCPOutputConnection
Get the channel.
getSourceClassName() - Method in class jadex.platform.service.cms.CustomLogRecord
Get the name of the class that (allegedly) issued the logging request.
getSourceMethodName() - Method in class jadex.platform.service.cms.CustomLogRecord
Get the name of the method that (allegedly) issued the logging request.
getStart() - Method in class jadex.platform.service.clock.ClockCreationInfo
Get the start.
getStart() - Method in class jadex.platform.service.dht.Finger
Get the start IID Key of this Finger.
getStartSequenceNumber() - Method in class jadex.platform.service.message.streams.AckInfo
Get the startSequenceNumber.
getStarttime() - Method in class jadex.platform.service.clock.AbstractClock
Get the clocks start time.
getStarttime() - Method in class jadex.platform.service.clock.ClockService
Get the clocks start time.
getState() - Method in class jadex.platform.service.clock.AbstractClock
Get the clock state.
getState() - Method in class jadex.platform.service.clock.ClockService
Get the clock state.
getState() - Method in class jadex.platform.service.dht.RingNodeService
Returns the current state of this ring node.
getStatus() - Method in class jadex.platform.service.chat.ChatService
Get the current status.
getStoredDataSize() - Method in class jadex.platform.service.message.streams.InputConnection
Get the size of the stored data.
getStoreService(IFinger) - Method in class jadex.platform.service.dht.DistributedKVStoreService
Lookup the storage service for a given finger.
getSubname() - Method in class jadex.platform.service.chat.ChatService
Get the "semi-qualified" sub name for settings.
getSuccessor() - Method in class jadex.platform.service.dht.Fingertable
Return the Successor of the local node.
getSuccessor() - Method in class jadex.platform.service.dht.RingNodeService
Return the successor of this node.
getSynchronousMethods() - Method in class jadex.platform.service.remote.ProxyInfo
Get the synchronous.
getTargetId() - Method in class jadex.platform.service.remote.commands.RemoteGetExternalAccessCommand
Get the target id.
getTargetIdentifier() - Method in class jadex.platform.service.remote.RemoteReference
Get the target id.
getTargetInterfaces() - Method in class jadex.platform.service.remote.ProxyInfo
Get the target remote interfaces.
getTargetObject(RemoteReference) - Method in class jadex.platform.service.remote.RemoteReferenceModule
Get a target object per remote reference.
getTargetResolver() - Method in class jadex.platform.service.remote.RemoteMethodInvocationHandler
Get the target resolver.
getTargetResolverClazz() - Method in class jadex.platform.service.remote.ProxyInfo
Get the target determiner clazz.
getTask() - Method in class jadex.platform.service.message.streams.AbstractConnectionHandler.SendInfo
Get the task.
getTerminateCallId() - Method in class jadex.platform.service.remote.commands.RemoteFutureTerminationCommand
Get the terminate call id.
getThreadPool() - Method in class jadex.platform.service.message.transport.httprelaymtp.HttpRelayTransport
Get the thread pool.
getTick() - Method in class jadex.platform.service.clock.AbstractClock
Get the current tick.
getTick() - Method in class jadex.platform.service.clock.ClockService
Get the current tick.
getTickTimers() - Method in class jadex.platform.service.clock.AbstractClock
Get all active tick timers.
getTime() - Method in class jadex.platform.service.awareness.discovery.DiscoveryEntry
Get the time.
getTime() - Method in class jadex.platform.service.clock.AbstractClock
Get the clocks name.
getTime() - Method in class jadex.platform.service.clock.ClockService
Get the current time.
getTime() - Method in class jadex.platform.service.clock.ContinuousClock
Get the clocks name.
getTime() - Method in class jadex.platform.service.clock.SystemClock
The current time is always the same as the system time.
getTime() - Method in class jadex.platform.service.cms.LoggerWrapper
Get the time.
getTimedObject() - Method in class jadex.platform.service.clock.Timer
Get the timed object.
getTimer() - Method in class jadex.platform.service.message.streams.AbstractConnectionHandler.SendInfo
Get the timer.
getTimer() - Method in class jadex.platform.service.remote.RemoteServiceManagementService
Get the timer.
getTimers() - Method in class jadex.platform.service.clock.AbstractClock
Get all active timers.
getTimers() - Method in class jadex.platform.service.clock.ClockService
Get all active timers.
getTimerTask() - Method in class jadex.platform.service.remote.RemoteServiceManagementService.WaitingCallInfo
Get the timertask.
getTotal() - Method in class jadex.platform.service.email.SubscriptionInfo
Get the total.
getTransportAddresses() - Method in class jadex.platform.service.address.TransportAddressService
Get direct access to the map of the addresses.
getTransportComponentIdentifier(IComponentIdentifier) - Method in class jadex.platform.service.address.TransportAddressService
Create a transport component identifier.
getTransportComponentIdentifier(IComponentIdentifier, TransportAddressBook) - Static method in class jadex.platform.service.address.TransportAddressService
Internal convert method for identifiers.
getTransportComponentIdentifiers(IComponentIdentifier[]) - Method in class jadex.platform.service.address.TransportAddressService
Create a transport component identifiers.
getTransports() - Method in class jadex.platform.service.message.AbstractSendTask
Get the transports.
getTransports() - Method in class jadex.platform.service.message.MessageService
Get the transports.
getTransports() - Method in class jadex.platform.service.message.streams.AbstractConnectionHandler
Get the transports.
getTryCnt() - Method in class jadex.platform.service.message.streams.AbstractConnectionHandler.SendInfo
Get the trycnt.
getTTPSecurityService() - Method in class jadex.platform.service.security.TTPAcquisitionMechanism
Get the security service of the ttp.
getType() - Method in class jadex.platform.service.clock.ContinuousClock
Get the clock type.
getType() - Method in class jadex.platform.service.clock.SimulationEventClock
Get the clock type.
getType() - Method in class jadex.platform.service.clock.SimulationTickClock
Get the clock type.
getType() - Method in class jadex.platform.service.clock.SystemClock
Get the type of the clock.
getType() - Method in class jadex.platform.service.remote.commands.RemoteSearchCommand
Get the type.
getTypeName() - Method in class jadex.platform.service.message.transport.MessageEnvelope
Get the type (e.g.
getUncachedMethods() - Method in class jadex.platform.service.remote.ProxyInfo
Get the uncached.
getURL() - Method in class jadex.platform.service.library.DelegationURLClassLoader
Get the own url.
getURLs() - Method in class jadex.platform.service.library.ChangeableURLClassLoader
Get the urls.
getUseParentHandlers() - Method in class jadex.platform.service.cms.LoggerWrapper
Discover whether or not this logger is sending its output to its parent logger.
getValidityDuration() - Method in class jadex.platform.service.security.SecurityService
Get the validity duration.
getVirtuals() - Method in class jadex.platform.service.security.SecurityService
Get the virtual names and their contents.
getWaitingCall(String) - Method in class jadex.platform.service.remote.RemoteServiceManagementService
Get a waiting call future.
getXMLReadInfo() - Method in class jadex.platform.service.remote.RemoteServiceManagementService
Get the specific xml read info for rms.
getXMLWriteInfo() - Method in class jadex.platform.service.remote.RemoteServiceManagementService
 
GZIPCodec - Class in jadex.platform.service.message.transport.codecs
Converts byte[] -> byte[] in both directions.
GZIPCodec() - Constructor for class jadex.platform.service.message.transport.codecs.GZIPCodec
Create a new codec.

H

handleAccept(SelectionKey) - Method in class jadex.platform.service.message.transport.niotcpmtp.SelectorThread
Accept a connection request.
handleConnect(SelectionKey) - Method in class jadex.platform.service.message.transport.niotcpmtp.SelectorThread
Read data from a connection.
handleConnection(String) - Method in class jadex.platform.service.message.transport.httprelaymtp.HttpReceiver
Main thread while connected.
handleRead(SelectionKey) - Method in class jadex.platform.service.message.transport.niotcpmtp.SelectorThread
Read data from a connection.
handleReceivedPacket(InetAddress, int, byte[], AwarenessInfo) - Method in class jadex.platform.service.awareness.discovery.MasterSlaveReceiveHandler
Handle a received packet.
handleReceivedPacket(InetAddress, int, byte[], AwarenessInfo) - Method in class jadex.platform.service.awareness.discovery.ReceiveHandler
Handle a received packet.
handleResultFuture(boolean, RemoteServiceManagementService, String, Object, boolean, String, IComponentIdentifier, IntermediateFuture<IRemoteCommand>) - Method in class jadex.platform.service.remote.commands.RemoteMethodInvocationCommand
Handle the result future by checking what future it is and sending intermediate results as commands.
handleWrite(SelectionKey) - Method in class jadex.platform.service.message.transport.niotcpmtp.SelectorThread
Write data to a connection.
hashCode() - Method in class jadex.platform.service.dht.Finger
 
hashCode() - Method in class jadex.platform.service.dht.ID
 
hashCode() - Method in class jadex.platform.service.remote.RemoteMethodInvocationHandler
Hash code.
hashCode() - Method in class jadex.platform.service.remote.RemoteReference
Get the hashcode.
hashCode() - Method in class jadex.platform.service.remote.RemoteReferenceHolder
Get the hashcode.
hashCode() - Method in class jadex.platform.service.remote.TemporaryRemoteReferenceHolder
Get the hashcode.
hasListeners() - Method in class jadex.platform.service.clock.AbstractClock
Check if the clock has listeners.
hasParentClassLoader() - Method in class jadex.platform.service.library.DelegationURLClassLoader
Test if has parent classloader.
holder - Variable in class jadex.platform.service.remote.commands.RemoteDGCAddReferenceCommand
The reference holder (rms).
holder - Variable in class jadex.platform.service.remote.commands.RemoteDGCRemoveReferenceCommand
The reference holder (rms).
holder - Variable in class jadex.platform.service.remote.RemoteReferenceHolder
The holder (cid of rms).
holders - Variable in class jadex.platform.service.remote.RemoteReferenceModule
The remote reference holders of a object (rr -> holder (rms cid)).
httpAddress(String) - Static method in class jadex.platform.service.message.transport.httprelaymtp.RelayConnectionManager
Convert a potential 'relay-' address to normal http(s) address.
HttpReceiver - Class in jadex.platform.service.message.transport.httprelaymtp
The receiver connects to the relay server and accepts messages.
HttpReceiver(HttpRelayTransport, IExternalAccess) - Constructor for class jadex.platform.service.message.transport.httprelaymtp.HttpReceiver
Create a new receiver.
HttpReceiver.TimeoutTask - Class in jadex.platform.service.message.transport.httprelaymtp
The timeout task
HttpRelayTransport - Class in jadex.platform.service.message.transport.httprelaymtp
A transport that allows communication and awareness using relay servers.
HttpRelayTransport(IInternalAccess, String, boolean, boolean) - Constructor for class jadex.platform.service.message.transport.httprelaymtp.HttpRelayTransport
Create a new relay transport.
HttpRelayTransport.Worker - Class in jadex.platform.service.message.transport.httprelaymtp
Worker for sending messages.

I

IAbstractConnectionHandler - Interface in jadex.platform.service.message.streams
 
icons - Variable in class jadex.platform.service.message.MessageService
The initiator connections.
IContinuousClock - Interface in jadex.platform.service.clock
Continuous clock interface extends a normal clock by adding a method getting the dilation.
ID - Class in jadex.platform.service.dht
This class is an identifier.
ID() - Constructor for class jadex.platform.service.dht.ID
Constructor.
ID(byte[]) - Constructor for class jadex.platform.service.dht.ID
Constructor.
id - Variable in class jadex.platform.service.dht.ID
The byte array containing the id information.
id - Variable in class jadex.platform.service.ecarules.ARulebaseEvent
The id.
id - Variable in class jadex.platform.service.message.streams.AbstractConnection
The connection id.
id - Variable in class jadex.platform.service.message.streams.AbstractConnectionHandler.SendInfo
The id.
idcnt - Variable in class jadex.platform.service.remote.RemoteReferenceModule
The id counter.
idlefuture - Variable in class jadex.platform.service.execution.AsyncExecutionService
The idle future.
idlefuture - Variable in class jadex.platform.service.execution.SyncExecutionService
The idle future.
idlelistener - Variable in class jadex.platform.service.simulation.SimulationService
The idle future listener.
IdleListener() - Constructor for class jadex.platform.service.simulation.SimulationService.IdleListener
 
IEmailFetcherService - Interface in jadex.platform.service.email
Email fetching service.
ifeatures - Variable in class jadex.platform.service.cms.PlatformComponent
The inited feature instances as list (for shutdown after failed init).
IFinalize - Interface in jadex.platform.service.remote
Interface that is needed for dynamic proxy objects.
ifuture - Variable in class jadex.platform.service.message.streams.InputConnection
The read futures.
IInputConnectionHandler - Interface in jadex.platform.service.message.streams
 
image - Variable in class jadex.platform.service.chat.ChatService
The image.
IMessageAwarenessService - Interface in jadex.platform.service.awareness.discovery.message
Discovery service called when a message is received.
IMethodReplacement - Interface in jadex.platform.service.remote
Interface to be implemented by the user for replacing a remote method with custom code.
includes - Variable in class jadex.platform.service.awareness.discovery.DiscoveryAgent
The includes list.
includes - Variable in class jadex.platform.service.awareness.management.AwarenessManagementAgent
The includes list.
includes - Variable in class jadex.platform.service.awareness.management.AwarenessSettingsData
The includes list.
includes(Object[], Object[]) - Method in class jadex.platform.service.df.DirectoryFacilitatorService
Test if one array of objects is included in the other (without considering the order).
incProxyCount(RemoteReference) - Method in class jadex.platform.service.remote.RemoteReferenceModule
Increment the proxy count for a remote reference.
info - Variable in class jadex.platform.service.awareness.discovery.DiscoveryEntry
The awareness info.
info(String) - Method in class jadex.platform.service.cms.LoggerWrapper
Log an INFO message.
info - Variable in class jadex.platform.service.cms.PlatformComponent
The creation info.
info - Variable in class jadex.platform.service.remote.commands.RemoteFutureBackwardCommand
The exception.
informListeners(DiscoveryInfo) - Method in class jadex.platform.service.awareness.management.AwarenessManagementAgent
Inform listeners about a changed discovery info.
ini - Variable in class jadex.platform.service.message.streams.AbstractConnection
The initiator flag.
init() - Method in class jadex.platform.service.cms.PlatformComponent
Perform the initialization of the component.
init(IID) - Method in class jadex.platform.service.dht.RingNodeService
Initialize the node with its own id.
init() - Method in class jadex.platform.service.ecarules.ClientRuleSystemAgent
Init method.
init() - Method in class jadex.platform.service.ecarules.RuleAgent
Init method.
init(ClassLoader) - Static method in class jadex.platform.service.message.contentcodecs.NuggetsXMLContentCodec
Init the static methods.
INIT - Static variable in class jadex.platform.service.message.streams.StreamSendTask
Init a connection.
init(ClassLoader) - Static method in class jadex.platform.service.message.transport.codecs.NuggetsCodec
Init the static methods.
init(SecurityService) - Method in class jadex.platform.service.security.AAcquisitionMechanism
Init the mechanism.
INIT_INPUT_INITIATOR - Static variable in class jadex.platform.service.message.streams.StreamSendTask
Create virtual input connection - from initiator.
INIT_OUTPUT_INITIATOR - Static variable in class jadex.platform.service.message.streams.StreamSendTask
Create virtual output connection - from initiator.
initArguments() - Method in class jadex.platform.service.awareness.management.AwarenessManagementAgent
Read arguments and set initial values.
inited - Variable in class jadex.platform.service.message.streams.AbstractConnection
Boolean flag if connection is inited, closing, closed.
initialized - Variable in class jadex.platform.service.dht.DistributedKVStoreService
Flag that indicates whether this Service is already usable.
initialized - Variable in class jadex.platform.service.dht.RingNodeService
Flag that indicates whether this Service is already usable.
initiator - Variable in class jadex.platform.service.message.streams.AbstractConnection
The connection initiator.
initiator - Variable in class jadex.platform.service.message.streams.InitInfo
The initiator.
InitInfo - Class in jadex.platform.service.message.streams
Info sent as content of the init message.
InitInfo() - Constructor for class jadex.platform.service.message.streams.InitInfo
Create a new init info.
InitInfo(ITransportComponentIdentifier, ITransportComponentIdentifier, Map<String, Object>) - Constructor for class jadex.platform.service.message.streams.InitInfo
Create a new init info.
initinfos - Variable in class jadex.platform.service.cms.ComponentManagementService
The init adapters and descriptions, i.e.
initInputConnection(int, ITransportComponentIdentifier, ITransportComponentIdentifier, Map<String, Object>) - Method in class jadex.platform.service.message.MessageService
Create local input connection side after receiving a remote init output message.
initLogger(Logger) - Method in class jadex.platform.service.cms.PlatformComponent
Init the logger with capability settings.
initNetworkRessource() - Method in class jadex.platform.service.awareness.discovery.DiscoveryAgent
(Re)init sending/receiving ressource.
initNetworkRessource() - Method in class jadex.platform.service.awareness.discovery.ipbroadcast.BroadcastDiscoveryAgent
(Re)init receiving.
initNetworkRessource() - Method in class jadex.platform.service.awareness.discovery.ipmulticast.MulticastDiscoveryAgent
(Re)init receiving.
initNetworkRessource() - Method in class jadex.platform.service.awareness.discovery.ipscanner.ScannerDiscoveryAgent
(Re)init receiving.
initNetworkRessource() - Method in class jadex.platform.service.awareness.discovery.message.MessageDiscoveryAgent
(Re)init sending/receiving ressource.
initNetworkRessource() - Method in class jadex.platform.service.awareness.discovery.registry.RegistryDiscoveryAgent
(Re)init receiving.
initNetworkRessource() - Method in class jadex.platform.service.awareness.discovery.relay.RelayDiscoveryAgent
(Re)init sending/receiving ressource.
initOutputConnection(int, ITransportComponentIdentifier, ITransportComponentIdentifier, Map<String, Object>) - Method in class jadex.platform.service.message.MessageService
Create local output connection side after receiving a remote init input message.
initReceived() - Method in class jadex.platform.service.message.streams.AbstractConnectionHandler
Received the init message.
initReceived() - Method in class jadex.platform.service.message.streams.LocalAbstractConnectionHandler
Received the init message.
initurls - Variable in class jadex.platform.service.library.LibraryService
The init urls.
injected - Variable in class jadex.platform.service.remote.ProxyAgent
The injected flag.
input - Variable in class jadex.platform.service.message.streams.AbstractConnection
The input flag.
InputConnection - Class in jadex.platform.service.message.streams
Input connection implementation for byte streams.
InputConnection(ITransportComponentIdentifier, ITransportComponentIdentifier, int, boolean, IAbstractConnectionHandler) - Constructor for class jadex.platform.service.message.streams.InputConnection
Create a new input connection.
InputConnectionHandler - Class in jadex.platform.service.message.streams
Handler that sits between connection and message service.
InputConnectionHandler(MessageService, Map<String, Object>) - Constructor for class jadex.platform.service.message.streams.InputConnectionHandler
Create a new input connection handler.
InputConnectionHandler.InputConnectionPanel - Class in jadex.platform.service.message.streams
 
InputConnectionPanel() - Constructor for class jadex.platform.service.message.streams.InputConnectionHandler.InputConnectionPanel
 
interest - Variable in class jadex.platform.service.message.AbstractSendTask
Is some transport interested in the task?
internalCreateInputConnection(IComponentIdentifier, IComponentIdentifier, Map<String, Object>) - Method in class jadex.platform.service.message.MessageService
Create a virtual input connection.
internalCreateOutputConnection(IComponentIdentifier, IComponentIdentifier, Map<String, Object>) - Method in class jadex.platform.service.message.MessageService
Create a virtual output connection.
internalDeliverMessage(Object) - Method in class jadex.platform.service.message.MessageService
Deliver a message to the receivers.
internalGetAddresses() - Method in class jadex.platform.service.message.MessageService
Get the adresses of a component.
internalgetAllResourceIdentifiers() - Method in class jadex.platform.service.library.LibraryService
Get all managed resource identifiers inlcuding all subdependencies.
internalGetChildren(IComponentIdentifier) - Method in class jadex.platform.service.cms.ComponentManagementService
Get the children of a component.
internalGetConnection(InetSocketAddress) - Method in class jadex.platform.service.message.transport.niotcpmtp.SelectorThread
 
internalGetResourceIdentifier(URL) - Method in class jadex.platform.service.library.LibraryService
Get the resource identifier for an url.
internalGetResourceIdentifiers() - Method in class jadex.platform.service.library.LibraryService
 
internalPutConnection(InetSocketAddress, Object) - Method in class jadex.platform.service.message.transport.niotcpmtp.SelectorThread
 
internalRead() - Method in class jadex.platform.service.message.streams.InputConnection
Non-blocking read.
internalRemoveConnection(InetSocketAddress) - Method in class jadex.platform.service.message.transport.niotcpmtp.SelectorThread
 
internalSendMessage(String, ISendTask) - Method in class jadex.platform.service.message.transport.httprelaymtp.HttpRelayTransport
Schedule message sending.
invoke(Object, Object[]) - Method in interface jadex.platform.service.remote.IMethodReplacement
Invoke the method on the given object with the given args.
invoke(Object, Method, Object[]) - Method in class jadex.platform.service.remote.RemoteMethodInvocationHandler
Invoke a method.
invoke(Object, Object[]) - Method in class jadex.platform.service.remote.replacements.DefaultEqualsMethodReplacement
Invoke the method on the given object with the given args.
invoke(Object, Object[]) - Method in class jadex.platform.service.remote.replacements.DefaultHashcodeMethodReplacement
Invoke the method on the given object with the given args.
invoke(Object, Object[]) - Method in class jadex.platform.service.remote.replacements.GetComponentFeatureMethodReplacement
Invoke the method on the given object with the given args.
invokeMethod(IntermediateFuture<IRemoteCommand>, RemoteServiceManagementService) - Method in class jadex.platform.service.remote.commands.RemoteMethodInvocationCommand
Invoke remote method.
IOutputConnectionHandler - Interface in jadex.platform.service.message.streams
 
IRelayAwarenessService - Interface in jadex.platform.service.awareness.discovery.relay
A service to be called from the relay transport to handle disconnects and reconnects.
IRemoteCommand - Interface in jadex.platform.service.remote
Remote command interface for commands that the remote service management can execute.
is - Variable in class jadex.platform.service.message.transport.tcpmtp.TCPInputConnection
The input stream.
isApplicable(Object, Type, boolean, ClassLoader) - Method in class jadex.platform.service.message.transport.codecs.LegacyMethodInfoEncoder
Test if the processor is applicable.
isApplicable(Class<?>) - Method in class jadex.platform.service.message.transport.codecs.LegacyMethodInfoEncoder
Tests if the decoder can decode the class.
isApplicable(String) - Method in class jadex.platform.service.message.transport.httprelaymtp.HttpRelayTransport
Test if a transport is applicable for the target address.
isApplicable(String) - Method in interface jadex.platform.service.message.transport.ITransport
Test if a transport is applicable for the target address.
isApplicable(String) - Method in class jadex.platform.service.message.transport.localmtp.LocalTransport
Test if a transport is applicable for the target address.
isApplicable(String) - Method in class jadex.platform.service.message.transport.niotcpmtp.NIOTCPTransport
Test if a transport is applicable for the target address.
isApplicable(String) - Method in class jadex.platform.service.message.transport.tcpmtp.TCPTransport
Test if a transport is applicable for the target address.
isAutoCreateProxy() - Method in class jadex.platform.service.awareness.management.AwarenessManagementAgent
Get the autocreate.
isAutoDeleteProxy() - Method in class jadex.platform.service.awareness.management.AwarenessManagementAgent
Get the autodelete.
isAvailable(IResourceIdentifier) - Method in class jadex.platform.service.library.LibraryService
Test, if a resource is available locally.
isCalled() - Method in class jadex.platform.service.chat.ChatService.PropProvider
 
isCancelled() - Method in class jadex.platform.service.remote.RemoteServiceManagementService.TimeoutTimerTask
 
isClassLoaderCompatible(Class<?>) - Method in class jadex.platform.service.library.DelegationURLClassLoader
 
isClosed() - Method in class jadex.platform.service.message.streams.AbstractConnection
Get the closed.
isClosed() - Method in class jadex.platform.service.message.streams.AbstractConnectionHandler
Get the closed.
isClosed() - Method in class jadex.platform.service.message.transport.tcpmtp.TCPOutputConnection
Test if the connection is closed.
isCloseRequested() - Method in class jadex.platform.service.message.streams.OutputConnectionHandler
Get the closereq.
isClosing() - Method in class jadex.platform.service.message.streams.AbstractConnection
Get the closed.
isConnectionAlive() - Method in class jadex.platform.service.message.streams.AbstractConnectionHandler
Test if the connection is alive.
isDataAckFinished() - Method in class jadex.platform.service.message.streams.OutputConnectionHandler
Tests if the data processing of the connection is finished.
isDataSendFinished() - Method in class jadex.platform.service.message.streams.OutputConnectionHandler
Tests if the data processing of the connection is finished.
ISendTask - Interface in jadex.platform.service.message
Public interface of send task to be passed to transports.
isExcluded(Method) - Method in class jadex.platform.service.remote.ProxyInfo
Test if method is excluded.
isExecuting() - Method in class jadex.platform.service.simulation.SimulationService
Test if context is executing.
isFast() - Method in class jadex.platform.service.awareness.discovery.DiscoveryAgent
Get the fast startup awareness flag.
isFastAwareness() - Method in class jadex.platform.service.awareness.management.AwarenessManagementAgent
Get the fast startup awareness flag.
isFinished() - Method in class jadex.platform.service.remote.commands.RemoteIntermediateResultCommand
Get the finished.
ISimulationClock - Interface in jadex.platform.service.clock
Simulation clock interface extends a normal clock by adding a method for advancing the method time.
isIncluded(ITransportComponentIdentifier, String[], String[]) - Static method in class jadex.platform.service.awareness.management.AwarenessManagementAgent
Test if a platform is included and/or not excluded.
isInInterval(IID, IID, boolean, boolean) - Method in class jadex.platform.service.dht.ID
Check whether this ID is in the given interval.
isInInterval(IID, IID) - Method in class jadex.platform.service.dht.ID
Check whether this ID is in the given closed interval.
isInited() - Method in class jadex.platform.service.message.streams.AbstractConnection
Get the inited.
isInitialized() - Method in class jadex.platform.service.dht.DistributedKVStoreService
Gets the initialized flag.
isInitialized() - Method in class jadex.platform.service.dht.RingNodeService
Gets the initialized flag.
isInitiatorSide() - Method in class jadex.platform.service.message.streams.AbstractConnection
Test if this connection is the initiator side.
isInitSuspend(CreationInfo, IModelInfo) - Method in class jadex.platform.service.cms.ComponentManagementService
Test if a component should be suspended after init is done.
isInputConnection() - Method in class jadex.platform.service.message.streams.AbstractConnection
Test if this connection is an input connection.
isKilled() - Method in class jadex.platform.service.awareness.discovery.DiscoveryAgent
Get the killed.
isLocalReference(Object) - Method in class jadex.platform.service.marshal.MarshalService
Test if an object has reference semantics.
isLoggable(Level) - Method in class jadex.platform.service.cms.LoggerWrapper
Check if a message of the given level would actually be logged by this logger.
isMaster() - Method in class jadex.platform.service.awareness.discovery.ipbroadcast.BroadcastDiscoveryAgent
Test if is master.
isMaster() - Method in class jadex.platform.service.awareness.discovery.ipscanner.ScannerDiscoveryAgent
Test if is master.
isMaster() - Method in class jadex.platform.service.awareness.discovery.MasterSlaveDiscoveryAgent
Test if is master.
isMaster() - Method in class jadex.platform.service.awareness.discovery.registry.RegistryDiscoveryAgent
Test if is master.
isMultiple() - Method in class jadex.platform.service.remote.commands.RemoteSearchCommand
Get the multiple.
isNonFunctionalSatisfied(Map<String, Object>, String) - Method in class jadex.platform.service.message.transport.httprelaymtp.HttpRelayTransport
Test if a transport satisfies the non-functional requirements.
isNonFunctionalSatisfied(Map<String, Object>, String) - Method in interface jadex.platform.service.message.transport.ITransport
Test if a transport satisfies the non-functional requirements.
isNonFunctionalSatisfied(Map<String, Object>, String) - Method in class jadex.platform.service.message.transport.localmtp.LocalTransport
Test if a transport satisfies the non-functional requirements.
isNonFunctionalSatisfied(Map<String, Object>, String) - Method in class jadex.platform.service.message.transport.niotcpmtp.NIOTCPTransport
Test if a transport satisfies the non-functional requirements.
isNonFunctionalSatisfied(Map<String, Object>, String) - Method in class jadex.platform.service.message.transport.tcpmtp.TCPTransport
Test if a transport satisfies the non-functional requirements.
isObjectReference() - Method in class jadex.platform.service.remote.RemoteReference
Test if reference is object reference (not service or component).
isref - Variable in class jadex.platform.service.remote.commands.RemoteResultCommand
The flag if result is declared as reference.
isReference(Object, boolean) - Method in class jadex.platform.service.marshal.MarshalService
Test if an object has reference semantics.
isRegistry() - Method in class jadex.platform.service.awareness.discovery.registry.RegistryDiscoveryAgent
Get the registry.
isRegistry(InetAddress, int) - Method in class jadex.platform.service.awareness.discovery.registry.RegistryDiscoveryAgent
Get the registry.
isRemoteComponent(IComponentIdentifier) - Method in class jadex.platform.service.cms.ComponentManagementService
Test if a component identifier is a remote component.
isRemoteObject(Object) - Method in class jadex.platform.service.marshal.MarshalService
Test if an object is a remote object.
isRemoteReference(Object) - Method in class jadex.platform.service.marshal.MarshalService
Test if an object has reference semantics.
isReplaced(Method) - Method in class jadex.platform.service.remote.ProxyInfo
Test if method is replaced.
isReturnValueReference() - Method in class jadex.platform.service.remote.commands.RemoteMethodInvocationCommand
Get the returnisref.
isRunning() - Method in class jadex.platform.service.threadpool.ThreadPoolService
Test if the thread pool is running.
isSameServer(String, String) - Static method in class jadex.platform.service.message.transport.httprelaymtp.RelayConnectionManager
Test if two addresses refer to the same server.
isSecure() - Method in class jadex.platform.service.message.transport.httprelaymtp.HttpRelayTransport
Flag if receiver connection should use https.
isSecure(Method) - Method in class jadex.platform.service.remote.ProxyInfo
Test if method is secure.
isSendAllowed() - Method in class jadex.platform.service.message.streams.OutputConnectionHandler
 
isStarted() - Method in class jadex.platform.service.awareness.discovery.DiscoveryAgent
Get the started.
isStop() - Method in class jadex.platform.service.message.streams.AckInfo
Get the stop.
isStop() - Method in class jadex.platform.service.message.streams.InputConnectionHandler
Test if stop is activated (too much data arrived).
isStop() - Method in class jadex.platform.service.message.streams.OutputConnectionHandler
 
isSwitchCall() - Method in class jadex.platform.service.remote.RemoteMethodInvocationHandler
Check if a switch call should be done.
isSynchronous(Method) - Method in class jadex.platform.service.remote.ProxyInfo
Test if method is synchronous.
isTrustedLanMode() - Method in class jadex.platform.service.security.SecurityService
Get the trusted lan mode.
isUncached(Method) - Method in class jadex.platform.service.remote.ProxyInfo
Test if method is uncached.
isUsePassword() - Method in class jadex.platform.service.security.SecurityService
Check if password protection is enabled.
ITransport - Interface in jadex.platform.service.message.transport
Interface for Jadex Standalone transports.

J

jadex.platform - package jadex.platform
 
jadex.platform.sensor - package jadex.platform.sensor
 
jadex.platform.sensor.system - package jadex.platform.sensor.system
 
jadex.platform.service.address - package jadex.platform.service.address
 
jadex.platform.service.awareness.discovery - package jadex.platform.service.awareness.discovery
 
jadex.platform.service.awareness.discovery.ipbroadcast - package jadex.platform.service.awareness.discovery.ipbroadcast
 
jadex.platform.service.awareness.discovery.ipmulticast - package jadex.platform.service.awareness.discovery.ipmulticast
 
jadex.platform.service.awareness.discovery.ipscanner - package jadex.platform.service.awareness.discovery.ipscanner
 
jadex.platform.service.awareness.discovery.local - package jadex.platform.service.awareness.discovery.local
 
jadex.platform.service.awareness.discovery.message - package jadex.platform.service.awareness.discovery.message
 
jadex.platform.service.awareness.discovery.registry - package jadex.platform.service.awareness.discovery.registry
 
jadex.platform.service.awareness.discovery.relay - package jadex.platform.service.awareness.discovery.relay
 
jadex.platform.service.awareness.management - package jadex.platform.service.awareness.management
 
jadex.platform.service.chat - package jadex.platform.service.chat
 
jadex.platform.service.clock - package jadex.platform.service.clock
 
jadex.platform.service.cms - package jadex.platform.service.cms
 
jadex.platform.service.context - package jadex.platform.service.context
 
jadex.platform.service.df - package jadex.platform.service.df
 
jadex.platform.service.dht - package jadex.platform.service.dht
 
jadex.platform.service.ecarules - package jadex.platform.service.ecarules
 
jadex.platform.service.email - package jadex.platform.service.email
 
jadex.platform.service.execution - package jadex.platform.service.execution
 
jadex.platform.service.filetransfer - package jadex.platform.service.filetransfer
 
jadex.platform.service.library - package jadex.platform.service.library
 
jadex.platform.service.marshal - package jadex.platform.service.marshal
 
jadex.platform.service.message - package jadex.platform.service.message
 
jadex.platform.service.message.contentcodecs - package jadex.platform.service.message.contentcodecs
 
jadex.platform.service.message.streams - package jadex.platform.service.message.streams
 
jadex.platform.service.message.transport - package jadex.platform.service.message.transport
 
jadex.platform.service.message.transport.codecs - package jadex.platform.service.message.transport.codecs
 
jadex.platform.service.message.transport.httprelaymtp - package jadex.platform.service.message.transport.httprelaymtp
 
jadex.platform.service.message.transport.localmtp - package jadex.platform.service.message.transport.localmtp
 
jadex.platform.service.message.transport.niotcpmtp - package jadex.platform.service.message.transport.niotcpmtp
 
jadex.platform.service.message.transport.tcpmtp - package jadex.platform.service.message.transport.tcpmtp
 
jadex.platform.service.monitoring - package jadex.platform.service.monitoring
 
jadex.platform.service.remote - package jadex.platform.service.remote
 
jadex.platform.service.remote.commands - package jadex.platform.service.remote.commands
 
jadex.platform.service.remote.replacements - package jadex.platform.service.remote.replacements
 
jadex.platform.service.remote.xml - package jadex.platform.service.remote.xml
 
jadex.platform.service.security - package jadex.platform.service.security
 
jadex.platform.service.settings - package jadex.platform.service.settings
 
jadex.platform.service.simulation - package jadex.platform.service.simulation
 
jadex.platform.service.threadpool - package jadex.platform.service.threadpool
 
JADEX_BINARY - Static variable in class jadex.platform.service.message.contentcodecs.JadexBinaryContentCodec
The language identifier.
JADEX_BINARY - Static variable in class jadex.platform.service.message.contentcodecs.JadexBinaryContentCodec2
The language identifier.
JADEX_XML - Static variable in class jadex.platform.service.message.contentcodecs.JadexXMLContentCodec
The language identifier.
JadexBinaryCodec - Class in jadex.platform.service.message.transport.codecs
The Jadex Binary codec.
JadexBinaryCodec() - Constructor for class jadex.platform.service.message.transport.codecs.JadexBinaryCodec
 
JadexBinaryCodec2 - Class in jadex.platform.service.message.transport.codecs
The Jadex Binary codec.
JadexBinaryCodec2() - Constructor for class jadex.platform.service.message.transport.codecs.JadexBinaryCodec2
 
JadexBinaryContentCodec - Class in jadex.platform.service.message.contentcodecs
Content codec using the Jadex binary framework.
JadexBinaryContentCodec() - Constructor for class jadex.platform.service.message.contentcodecs.JadexBinaryContentCodec
 
JadexBinaryContentCodec2 - Class in jadex.platform.service.message.contentcodecs
Content codec using the Jadex binary framework.
JadexBinaryContentCodec2() - Constructor for class jadex.platform.service.message.contentcodecs.JadexBinaryContentCodec2
 
JadexXMLCodec - Class in jadex.platform.service.message.transport.codecs
The Jadex XML codec.
JadexXMLCodec() - Constructor for class jadex.platform.service.message.transport.codecs.JadexXMLCodec
 
JadexXMLContentCodec - Class in jadex.platform.service.message.contentcodecs
Content condec using the Jadex-XML framework.
JadexXMLContentCodec() - Constructor for class jadex.platform.service.message.contentcodecs.JadexXMLContentCodec
 
JAVA_XML - Static variable in class jadex.platform.service.message.contentcodecs.JavaXMLContentCodec
The java xml language.
JavaXMLContentCodec - Class in jadex.platform.service.message.contentcodecs
The XML codec based on the standard Java 1.4 XMLCodec.
JavaXMLContentCodec() - Constructor for class jadex.platform.service.message.contentcodecs.JavaXMLContentCodec
 
join(IRingNodeService) - Method in class jadex.platform.service.dht.RingNodeService
Join the ring.

K

keyMap - Variable in class jadex.platform.service.dht.DistributedKVStoreService
Map that stores the actual data.
keypass - Variable in class jadex.platform.service.security.SecurityService
The key password.
keystore - Variable in class jadex.platform.service.security.SecurityService
The keystore.
killComponent() - Method in class jadex.platform.service.cms.PlatformComponent
Kill the component.
killComponent(Exception) - Method in class jadex.platform.service.cms.PlatformComponent
Kill the component.
killed - Variable in class jadex.platform.service.awareness.discovery.DiscoveryAgent
Flag indicating agent killed.

L

lastack - Variable in class jadex.platform.service.message.streams.InputConnectionHandler
The last in order sequence number acknowledged.
lastpostedfile - Variable in class jadex.platform.service.awareness.discovery.local.LocalDiscoveryAgent
The last awareness file that has been posted.
lastseenmsg - Variable in class jadex.platform.service.email.SubscriptionInfo
 
lastseenno - Variable in class jadex.platform.service.email.SubscriptionInfo
 
lastsend - Variable in class jadex.platform.service.message.streams.OutputConnectionHandler.DataSendInfo
The sequence number during the last sending.
lastseqno - Variable in class jadex.platform.service.message.streams.InputConnectionHandler
The last sequence number.
laststart - Variable in class jadex.platform.service.clock.ContinuousClock
The last starting real time measurement point.
lastval - Variable in class jadex.platform.service.remote.ProxyLatencyProperty
The last measured value.
leasetime - Variable in class jadex.platform.service.message.streams.AbstractConnectionHandler
The lease time.
LeaseTimeHandler - Class in jadex.platform.service.awareness.discovery
Used to a list of entries that is automatically removed in case no updates are received via addOrUpdate method.
LeaseTimeHandler(DiscoveryAgent) - Constructor for class jadex.platform.service.awareness.discovery.LeaseTimeHandler
Create a new lease time handling object.
LeaseTimeHandler(DiscoveryAgent, double) - Constructor for class jadex.platform.service.awareness.discovery.LeaseTimeHandler
Create a new lease time handling object.
LegacyMethodInfoEncoder - Class in jadex.platform.service.message.transport.codecs
 
LegacyMethodInfoEncoder() - Constructor for class jadex.platform.service.message.transport.codecs.LegacyMethodInfoEncoder
 
lfeatures - Variable in class jadex.platform.service.cms.PlatformComponent
The feature instances as list (for reverse execution, cached for speed).
LIBRARY_SERVICE - Static variable in class jadex.platform.service.library.LibraryService
The (standard) Library service name.
LibraryAgent - Class in jadex.platform.service.library
Agent that provides the library service.
LibraryAgent() - Constructor for class jadex.platform.service.library.LibraryAgent
 
LibraryService - Class in jadex.platform.service.library
Library service for loading classpath elements.
LibraryService() - Constructor for class jadex.platform.service.library.LibraryService
Creates a new LibraryService.
LibraryService(Object[]) - Constructor for class jadex.platform.service.library.LibraryService
Creates a new LibraryService.
LibraryService(ClassLoader) - Constructor for class jadex.platform.service.library.LibraryService
Creates a new LibraryService.
LibraryService(Object[], ClassLoader) - Constructor for class jadex.platform.service.library.LibraryService
Creates a new LibraryService.
LibraryService(Object[], ClassLoader, Map<String, Object>) - Constructor for class jadex.platform.service.library.LibraryService
Creates a new LibraryService.
libservice - Variable in class jadex.platform.service.message.MessageService
The library service.
libservice - Variable in class jadex.platform.service.remote.RemoteReferenceModule
The library service.
listDirectory(String) - Method in class jadex.platform.service.filetransfer.FileTransferService
List the contents of a directory.
listeners - Variable in class jadex.platform.service.awareness.management.AwarenessManagementAgent
The discovery listeners.
listeners - Variable in class jadex.platform.service.clock.AbstractClock
The change listeners.
listeners - Variable in class jadex.platform.service.clock.ClockService
The clock listeners.
listeners - Variable in class jadex.platform.service.cms.ComponentManagementService
The listeners.
listeners - Variable in class jadex.platform.service.library.LibraryService
LibraryService listeners.
listeners - Variable in class jadex.platform.service.message.MessageService
The listeners (listener->filter).
listeners - Variable in class jadex.platform.service.simulation.SimulationService
The listeners.
loadClass(String, boolean) - Method in class jadex.platform.service.library.DelegationURLClassLoader
Load class.
loadComponentModel(String, IResourceIdentifier) - Method in class jadex.platform.service.cms.ComponentManagementService
Load a component model.
loadDependencies(IResourceIdentifier, boolean) - Method in class jadex.platform.service.library.BasicDependencyService
Load dependencies from a resource identifier.
loadDirectClass(String, boolean) - Method in class jadex.platform.service.library.DelegationURLClassLoader
Load a class directly, without delegation to dependencies or base class loader
loadProperties() - Method in class jadex.platform.service.settings.SettingsService
Load the default platform properties.
LocalAbstractConnectionHandler - Class in jadex.platform.service.message.streams
 
LocalAbstractConnectionHandler(Map<String, Object>) - Constructor for class jadex.platform.service.message.streams.LocalAbstractConnectionHandler
 
LocalAbstractConnectionHandler(Map<String, Object>, LocalAbstractConnectionHandler) - Constructor for class jadex.platform.service.message.streams.LocalAbstractConnectionHandler
 
LocalDiscoveryAgent - Class in jadex.platform.service.awareness.discovery.local
Agent providing local discovery using the file system.
LocalDiscoveryAgent() - Constructor for class jadex.platform.service.awareness.discovery.local.LocalDiscoveryAgent
 
LocalInputConnectionHandler - Class in jadex.platform.service.message.streams
Local version of the input connection handler.
LocalInputConnectionHandler(Map<String, Object>) - Constructor for class jadex.platform.service.message.streams.LocalInputConnectionHandler
Create new local input connection handler.
LocalInputConnectionHandler(Map<String, Object>, LocalAbstractConnectionHandler) - Constructor for class jadex.platform.service.message.streams.LocalInputConnectionHandler
Create new local input connection handler.
LocalOutputConnectionHandler - Class in jadex.platform.service.message.streams
 
LocalOutputConnectionHandler(Map<String, Object>) - Constructor for class jadex.platform.service.message.streams.LocalOutputConnectionHandler
 
LocalOutputConnectionHandler(Map<String, Object>, LocalAbstractConnectionHandler) - Constructor for class jadex.platform.service.message.streams.LocalOutputConnectionHandler
 
locals - Variable in class jadex.platform.service.awareness.discovery.MasterSlaveDiscoveryAgent
The local slaves.
LocalTransport - Class in jadex.platform.service.message.transport.localmtp
The local transport for sending messages on the same platform (just calls the local deliver method).
LocalTransport(IInternalAccess) - Constructor for class jadex.platform.service.message.transport.localmtp.LocalTransport
Init the transport.
localtypes - Variable in class jadex.platform.service.cms.ComponentManagementService
The local filename cache (tuple(parent filename, child filename) -> local typename)
lockentries - Variable in class jadex.platform.service.cms.ComponentManagementService
The locked components (component are locked till init is finished, i.e.
log(LogRecord) - Method in class jadex.platform.service.cms.LoggerWrapper
Log a LogRecord.
log(Level, String) - Method in class jadex.platform.service.cms.LoggerWrapper
Log a message, with no arguments.
log(Level, String, Object) - Method in class jadex.platform.service.cms.LoggerWrapper
Log a message, with one object parameter.
log(Level, String, Object[]) - Method in class jadex.platform.service.cms.LoggerWrapper
Log a message, with an array of object arguments.
log(Level, String, Throwable) - Method in class jadex.platform.service.cms.LoggerWrapper
Log a message, with associated Throwable information.
log(String) - Method in class jadex.platform.service.dht.DistributedKVStoreService
 
log(Level, String) - Method in class jadex.platform.service.message.transport.httprelaymtp.HttpReceiver
Do some log output.
logger - Variable in class jadex.platform.service.cms.ComponentManagementService
The logger.
logger - Variable in class jadex.platform.service.cms.LoggerWrapper
The original logger.
logger - Variable in class jadex.platform.service.cms.PlatformComponent
The logger.
logger - Variable in class jadex.platform.service.dht.DistributedKVStoreService
The logger.
logger - Variable in class jadex.platform.service.dht.RingNodeService
The logger.
logger - Variable in class jadex.platform.service.library.BasicDependencyService
The logger.
logger - Variable in class jadex.platform.service.message.MessageService
The logger.
logger - Variable in class jadex.platform.service.message.transport.httprelaymtp.HttpReceiver
The logger (set on first access).
logger - Variable in class jadex.platform.service.message.transport.niotcpmtp.NIOTCPTransport
The logger.
logger - Variable in class jadex.platform.service.message.transport.niotcpmtp.SelectorThread
The logger.
logger - Variable in class jadex.platform.service.message.transport.tcpmtp.TCPTransport
The logger.
LoggerWrapper - Class in jadex.platform.service.cms
The logger wrapper is used to encapsulate a logger and redirect messages to the logger with the correct time (according to a clock service).
LoggerWrapper(Logger, IClockService) - Constructor for class jadex.platform.service.cms.LoggerWrapper
Create a new logger wrapper.
logp(Level, String, String, String) - Method in class jadex.platform.service.cms.LoggerWrapper
Log a message, specifying source class and method, with no arguments.
logp(Level, String, String, String, Object) - Method in class jadex.platform.service.cms.LoggerWrapper
Log a message, specifying source class and method, with a single object parameter to the log message.
logp(Level, String, String, String, Object[]) - Method in class jadex.platform.service.cms.LoggerWrapper
Log a message, specifying source class and method, with an array of object arguments.
logp(Level, String, String, String, Throwable) - Method in class jadex.platform.service.cms.LoggerWrapper
Log a message, specifying source class and method, with associated Throwable information.
logrb(Level, String, String, String, String) - Method in class jadex.platform.service.cms.LoggerWrapper
Log a message, specifying source class, method, and resource bundle name with no arguments.
logrb(Level, String, String, String, String, Object) - Method in class jadex.platform.service.cms.LoggerWrapper
Log a message, specifying source class, method, and resource bundle name, with a single object parameter to the log message.
logrb(Level, String, String, String, String, Object[]) - Method in class jadex.platform.service.cms.LoggerWrapper
Log a message, specifying source class, method, and resource bundle name, with an array of object arguments.
logrb(Level, String, String, String, String, Throwable) - Method in class jadex.platform.service.cms.LoggerWrapper
Log a message, specifying source class, method, and resource bundle name, with associated Throwable information.
lookup(String) - Method in class jadex.platform.service.dht.DistributedKVStoreService
Lookup a key in the ring and return the saved value, if any.
lookup(String, IID) - Method in class jadex.platform.service.dht.DistributedKVStoreService
Lookup a key in the ring and return the saved value, if any.
lookup(String) - Method in class jadex.platform.service.dht.DistributedServiceRegistryService
 
lookup(String, IID) - Method in class jadex.platform.service.dht.DistributedServiceRegistryService
 
lookupResponsibleStore(String) - Method in class jadex.platform.service.dht.DistributedKVStoreService
Lookup a key and return the responsible Node ID.

M

main(String[]) - Static method in class jadex.platform.DynamicStarter
 
main(String[]) - Static method in class jadex.platform.service.filetransfer.FileTransferService
 
main(String[]) - Static method in class jadex.platform.service.message.MessageService
 
main(String[]) - Static method in class jadex.platform.service.security.SecurityService
Main for testing.
managers - Variable in class jadex.platform.service.message.MessageService
The target managers (platform id->manager).
MapSendTask - Class in jadex.platform.service.message
The manager send task is responsible for coordinating the sending of a message to a single destination using multiple available transports.
MapSendTask(Map<String, Object>, MessageType, ITransportComponentIdentifier[], ITransport[], ICodec[], ClassLoader, IEncodingContext) - Constructor for class jadex.platform.service.message.MapSendTask
Create a new manager send task.
marshal - Variable in class jadex.platform.service.remote.RemoteServiceManagementService
The marshal service.
MarshalAgent - Class in jadex.platform.service.marshal
Agent that provides the marshal service.
MarshalAgent() - Constructor for class jadex.platform.service.marshal.MarshalAgent
 
MarshalService - Class in jadex.platform.service.marshal
Marshal service implementation.
MarshalService(IInternalAccess) - Constructor for class jadex.platform.service.marshal.MarshalService
Create marshal service.
marshalservice - Variable in class jadex.platform.service.remote.RemoteReferenceModule
The marshal service.
MasterSlaveDiscoveryAgent - Class in jadex.platform.service.awareness.discovery
Agent that sends multicasts to locate other Jadex awareness agents.
MasterSlaveDiscoveryAgent() - Constructor for class jadex.platform.service.awareness.discovery.MasterSlaveDiscoveryAgent
 
MasterSlaveReceiveHandler - Class in jadex.platform.service.awareness.discovery
Master slave receiving handler.
MasterSlaveReceiveHandler(MasterSlaveDiscoveryAgent) - Constructor for class jadex.platform.service.awareness.discovery.MasterSlaveReceiveHandler
Create a new receive handler.
MasterSlaveSendHandler - Class in jadex.platform.service.awareness.discovery
Handle sending.
MasterSlaveSendHandler(DiscoveryAgent) - Constructor for class jadex.platform.service.awareness.discovery.MasterSlaveSendHandler
Create a new lease time handling object.
match(IDFComponentDescription, IDFComponentDescription) - Method in class jadex.platform.service.df.DirectoryFacilitatorService
Test if a component description matches a given template.
match(IDFServiceDescription, IDFServiceDescription) - Method in class jadex.platform.service.df.DirectoryFacilitatorService
Test if a service description matches a given template.
match(Properties) - Method in class jadex.platform.service.message.contentcodecs.JadexBinaryContentCodec
Test if the codec can be used with the provided meta information.
match(Properties) - Method in class jadex.platform.service.message.contentcodecs.JadexBinaryContentCodec2
Test if the codec can be used with the provided meta information.
match(Properties) - Method in class jadex.platform.service.message.contentcodecs.JadexXMLContentCodec
Test if the codec can be used with the provided meta information.
match(Properties) - Method in class jadex.platform.service.message.contentcodecs.JavaXMLContentCodec
Test if the codec can be used with the provided meta information.
match(Properties) - Method in class jadex.platform.service.message.contentcodecs.NuggetsXMLContentCodec
Test if the codec can be used with the provided meta information.
max - Variable in class jadex.platform.service.monitoring.MonitoringService
The maximum number of events to keep, -1 for unrestricted.
MAX_CONNECTIONS - Static variable in class jadex.platform.service.message.transport.tcpmtp.TCPTransport
Maximum number of outgoing connections
MAX_KEEPALIVE - Static variable in class jadex.platform.service.message.transport.niotcpmtp.NIOTCPTransport
How long to keep connections alive (5 min).
MAX_KEEPALIVE - Static variable in class jadex.platform.service.message.transport.tcpmtp.TCPTransport
How long to keep output connections alive (5 min).
MAX_WORKERS - Static variable in class jadex.platform.service.message.transport.httprelaymtp.HttpRelayTransport
The maximum number of workers for an address.
maxackseqno - Variable in class jadex.platform.service.message.streams.InputConnectionHandler
The highest yet (may be out of order) acknowledged sequence number (only used to trigger new acks every x messages).
maxbuf - Variable in class jadex.platform.service.message.streams.InputConnectionHandler
The maximum buffer size for out of order packets.
maxqueued - Variable in class jadex.platform.service.message.streams.OutputConnectionHandler
The max number of messages that can be sending concurrently (i.e.
maxresends - Variable in class jadex.platform.service.message.streams.AbstractConnectionHandler
The maximum number of resends.
maxsend - Variable in class jadex.platform.service.message.streams.OutputConnectionHandler
The max number of packets that can be sent without an ack is received.
maxseqno - Variable in class jadex.platform.service.message.streams.InputConnectionHandler
The highest yet (may be out of order) received sequence number.
maxstored - Variable in class jadex.platform.service.message.streams.InputConnectionHandler
The maximum bytes of data that can be stored in connection (without being consumed).
maxstored - Variable in class jadex.platform.service.message.streams.LocalInputConnectionHandler
The maximum bytes of data that can be stored in connection (without being consumed).
maxstored - Variable in class jadex.platform.service.message.streams.LocalOutputConnectionHandler
The maximum bytes of data that can be stored in connection (without being consumed).
measureValue() - Method in class jadex.platform.service.remote.ProxyLatencyProperty
Measure the value.
mechanisms - Variable in class jadex.platform.service.security.SecurityService
The list of key aquire mechanisms.
message(String, String, boolean) - Method in class jadex.platform.service.chat.ChatService
Post a message
message(String, IComponentIdentifier[], boolean) - Method in class jadex.platform.service.chat.ChatService
Post a message.
message - Variable in class jadex.platform.service.message.MapSendTask
The message.
message - Variable in class jadex.platform.service.message.streams.StreamSendTask
The binary message part.
message - Variable in class jadex.platform.service.message.transport.MessageEnvelope
The message.
message_type - Variable in class jadex.platform.service.message.transport.MessageEnvelope
The message type.
MESSAGE_TYPE_MAP - Static variable in class jadex.platform.service.message.MapSendTask
Constant for string based map message.
MESSAGE_TYPE_STREAM - Static variable in class jadex.platform.service.message.streams.StreamSendTask
The message type for streams.
MessageAgent - Class in jadex.platform.service.message
Agent that provides the message service.
MessageAgent() - Constructor for class jadex.platform.service.message.MessageAgent
 
messageArrived(Map<String, Object>, MessageType) - Method in class jadex.platform.service.remote.RemoteServiceManagementAgent
Called, whenever a message is received.
MessageDiscoveryAgent - Class in jadex.platform.service.awareness.discovery.message
Discovery agent that is based on message receipt.
MessageDiscoveryAgent() - Constructor for class jadex.platform.service.awareness.discovery.message.MessageDiscoveryAgent
 
MessageEnvelope - Class in jadex.platform.service.message.transport
The message envelope holding the native message, the receivers and the message type.
MessageEnvelope() - Constructor for class jadex.platform.service.message.transport.MessageEnvelope
Create a new message envelope.
MessageEnvelope(Map<String, Object>, Collection<ITransportComponentIdentifier>, String) - Constructor for class jadex.platform.service.message.transport.MessageEnvelope
Create a new message envelope.
messages - Variable in class jadex.platform.service.message.MessageService.DeliverMessage
The list of messages to send.
MessageService - Class in jadex.platform.service.message
The Message service serves several message-oriented purposes: a) sending and delivering messages by using transports b) management of transports (add/remove) The message service performs sending and delivering messages by separate actions that are individually executed on the execution service, i.e.
MessageService(IInternalAccess, Logger, ITransport[], MessageType[]) - Constructor for class jadex.platform.service.message.MessageService
Constructor for Outbox.
MessageService(IInternalAccess, Logger, ITransport[], MessageType[], IContentCodec[], String, CodecFactory, boolean) - Constructor for class jadex.platform.service.message.MessageService
Constructor for Outbox.
MessageService.DeliverMessage - Class in jadex.platform.service.message
Deliver message(s) executable.
MessageService.SendManager - Class in jadex.platform.service.message
Send message(s) executable.
messagetype - Variable in class jadex.platform.service.message.MapSendTask
The message type.
messagetypes - Variable in class jadex.platform.service.message.MessageService
The message types.
MESSAGETYPES - Static variable in class jadex.platform.service.message.streams.StreamSendTask
String type, boolean input, boolean initiator.
method - Variable in class jadex.platform.service.remote.commands.RemoteMethodInvocationCommand
The method.
methodname - Variable in class jadex.platform.service.remote.commands.RemoteMethodInvocationCommand
The methodname.
methodname - Variable in class jadex.platform.service.remote.commands.RemoteResultCommand
The method name.
mode - Variable in class jadex.platform.service.simulation.SimulationService
The execution mode.
modify(IDFComponentDescription) - Method in class jadex.platform.service.df.DirectoryFacilitatorService
Modify a component description.
MonitoringAgent - Class in jadex.platform.service.monitoring
Default monitoring agent.
MonitoringAgent() - Constructor for class jadex.platform.service.monitoring.MonitoringAgent
 
MonitoringService - Class in jadex.platform.service.monitoring
Basic monitoring service implementation that stores the events in memory.
MonitoringService() - Constructor for class jadex.platform.service.monitoring.MonitoringService
Create a new MonitoringService.
MonitoringService(long, IFilter<IMonitoringEvent>) - Constructor for class jadex.platform.service.monitoring.MonitoringService
Create a new MonitoringService.
mpfut - Variable in class jadex.platform.service.message.streams.OutputConnectionHandler
The current multipacket future (shared by all write requests that put data in the same multi packet).
mpmaxsize - Variable in class jadex.platform.service.message.streams.OutputConnectionHandler
The packet size to collect (in bytes).
mpsendtimeout - Variable in class jadex.platform.service.message.streams.OutputConnectionHandler
The max delay before a multipacket is sent (even if not full).
mpsendtimer - Variable in class jadex.platform.service.message.streams.OutputConnectionHandler
The multipacket send timer.
mpsize - Variable in class jadex.platform.service.message.streams.OutputConnectionHandler
The current multipacket size.
ms - Variable in class jadex.platform.service.message.streams.AbstractConnectionHandler
The message service.
msg - Variable in class jadex.platform.service.message.transport.niotcpmtp.NIOTCPInputConnection
The current result message.
msg_len - Variable in class jadex.platform.service.message.transport.niotcpmtp.NIOTCPInputConnection
The current message length (-1 for none).
msg_pos - Variable in class jadex.platform.service.message.transport.niotcpmtp.NIOTCPInputConnection
The msg pos.
msgservice - Variable in class jadex.platform.service.message.transport.localmtp.LocalTransport
The message service.
msgservice - Variable in class jadex.platform.service.message.transport.niotcpmtp.SelectorThread
The message service for delivering received messages.
msgservice - Variable in class jadex.platform.service.message.transport.tcpmtp.TCPTransport
The message service .
msgservice - Variable in class jadex.platform.service.remote.RemoteServiceManagementService
The message service.
MSGTYPE_AWAINFO - Static variable in class jadex.platform.service.message.transport.httprelaymtp.SRelay
The awareness info message type (awareness info content).
MSGTYPE_DEFAULT - Static variable in class jadex.platform.service.message.transport.httprelaymtp.SRelay
The default message type (followed by arbitrary message content from some sender).
MSGTYPE_PING - Static variable in class jadex.platform.service.message.transport.httprelaymtp.SRelay
The ping message type (just the type byte and no content).
MulticastDiscoveryAgent - Class in jadex.platform.service.awareness.discovery.ipmulticast
Agent that sends multicasts to locate other Jadex awareness agents.
MulticastDiscoveryAgent() - Constructor for class jadex.platform.service.awareness.discovery.ipmulticast.MulticastDiscoveryAgent
 
MulticastReceiveHandler - Class in jadex.platform.service.awareness.discovery.ipmulticast
 
MulticastReceiveHandler(DiscoveryAgent) - Constructor for class jadex.platform.service.awareness.discovery.ipmulticast.MulticastReceiveHandler
Create a new receive handler.
MulticastSendHandler - Class in jadex.platform.service.awareness.discovery.ipmulticast
Handle sending.
MulticastSendHandler(DiscoveryAgent) - Constructor for class jadex.platform.service.awareness.discovery.ipmulticast.MulticastSendHandler
Create a new lease time handling object.
multipacket - Variable in class jadex.platform.service.message.streams.OutputConnectionHandler
The collected data for a packet.
multipackets - Variable in class jadex.platform.service.message.streams.OutputConnectionHandler
Flag if multipackets should be used.
multiple - Variable in class jadex.platform.service.remote.commands.RemoteSearchCommand
The multiple flag.
myaddress - Variable in class jadex.platform.service.awareness.discovery.ipmulticast.MulticastDiscoveryAgent
The current receive address.
myId - Variable in class jadex.platform.service.dht.DistributedKVStoreService
The local ID
myId - Variable in class jadex.platform.service.dht.RingNodeService
ID of this ring node

N

name - Variable in class jadex.platform.service.clock.AbstractClock
The clock name.
name - Variable in class jadex.platform.service.clock.ClockCreationInfo
The clock name.
networkips - Variable in class jadex.platform.service.security.SecurityService
The network ips, cached for speed.
networkpasses - Variable in class jadex.platform.service.security.SecurityService
The stored passwords.
nick - Variable in class jadex.platform.service.chat.ChatService
The local nick name.
NIOTCPDeadConnection - Class in jadex.platform.service.message.transport.niotcpmtp
Dead connection identifier.
NIOTCPDeadConnection(SelectorThread.Cleaner) - Constructor for class jadex.platform.service.message.transport.niotcpmtp.NIOTCPDeadConnection
Create a new dead connection.
NIOTCPInputConnection - Class in jadex.platform.service.message.transport.niotcpmtp
The input connection (channel) for incoming requests.
NIOTCPInputConnection(SocketChannel) - Constructor for class jadex.platform.service.message.transport.niotcpmtp.NIOTCPInputConnection
Constructor for InputConnection.
NIOTCPOutputConnection - Class in jadex.platform.service.message.transport.niotcpmtp
Struct for holding information about an output connection.
NIOTCPOutputConnection(SocketChannel, InetSocketAddress, SelectorThread.Cleaner) - Constructor for class jadex.platform.service.message.transport.niotcpmtp.NIOTCPOutputConnection
Create a new output connection.
NIOTCPTransport - Class in jadex.platform.service.message.transport.niotcpmtp
The tcp transport for sending messages over tcp/ip connections.
NIOTCPTransport(IInternalAccess, int, Logger) - Constructor for class jadex.platform.service.message.transport.niotcpmtp.NIOTCPTransport
Init the transport.
nodeId - Variable in class jadex.platform.service.dht.Finger
ID of the Node
nonfunc - Variable in class jadex.platform.service.message.AbstractSendTask
The non-functional properties.
nonfunc - Variable in class jadex.platform.service.message.streams.AbstractConnectionHandler
The non-functional properties.
nonfunc - Variable in class jadex.platform.service.message.streams.InitInfo
The non-functional properties.
nonfunc - Variable in class jadex.platform.service.message.streams.LocalAbstractConnectionHandler
The non-functional properties.
nonfunc - Variable in class jadex.platform.service.remote.commands.AbstractRemoteCommand
The non-functional properties.
nonmanaged - Variable in class jadex.platform.service.library.LibraryService
The non-managed urls (cached for speed).
notify(IFinger) - Method in class jadex.platform.service.dht.RingNodeService
Notifies this node about a possible new predecessor.
notifyAdditionListeners(IResourceIdentifier, IResourceIdentifier) - Method in class jadex.platform.service.library.LibraryService
Notify listeners about addition.
notifyBad(IFinger) - Method in class jadex.platform.service.dht.RingNodeService
Notifies this node about another node that may be bad.
notifyCurrentState(SubscriptionIntermediateFuture<IRulebaseEvent>) - Method in class jadex.platform.service.ecarules.RulebaseAgent
Notify the current state.
notifyDataRead() - Method in interface jadex.platform.service.message.streams.IInputConnectionHandler
Called by connection when user read some data so that other side can continue to send.
notifyDataRead() - Method in class jadex.platform.service.message.streams.InputConnectionHandler
Called by connection when user read some data so that other side can continue to send.
notifyDataRead() - Method in class jadex.platform.service.message.streams.LocalInputConnectionHandler
Called by connection when user read some data so that other side can continue to send.
notifyInited() - Method in class jadex.platform.service.message.streams.AbstractConnectionHandler
 
notifyInited() - Method in interface jadex.platform.service.message.streams.IAbstractConnectionHandler
 
notifyInited() - Method in class jadex.platform.service.message.streams.LocalAbstractConnectionHandler
 
notifyInited() - Method in class jadex.platform.service.message.streams.OutputConnectionHandler
 
notifyListeners(ChangeEvent) - Method in class jadex.platform.service.clock.AbstractClock
Notify the listeners.
notifyListeners(ChangeEvent) - Method in class jadex.platform.service.simulation.SimulationService
Notify the listeners.
notifyListenersAdded(IComponentIdentifier, IComponentDescription) - Method in class jadex.platform.service.cms.ComponentManagementService
Notify the cms listeners of an addition.
notifyListenersChanged(IComponentIdentifier, IComponentDescription) - Method in class jadex.platform.service.cms.ComponentManagementService
Notify the cms listeners of a change.
notifyListenersRemoved(IComponentIdentifier, IComponentDescription, Map) - Method in class jadex.platform.service.cms.ComponentManagementService
Notify the cms listeners of a removal.
notifyRemovalListeners(IResourceIdentifier, IResourceIdentifier) - Method in class jadex.platform.service.library.LibraryService
Notify listeners about removal.
notifySubscribers(RingNodeEvent) - Method in class jadex.platform.service.dht.RingNodeService
Notify all subscribers about events.
notifySubscribers(ARulebaseEvent, Set<Integer>) - Method in class jadex.platform.service.ecarules.RulebaseAgent
Notify all subscribers of an event.
NUGGETS_XML - Static variable in class jadex.platform.service.message.contentcodecs.NuggetsXMLContentCodec
The language identifier.
NuggetsCodec - Class in jadex.platform.service.message.transport.codecs
The Nuggets XML codec.
NuggetsCodec() - Constructor for class jadex.platform.service.message.transport.codecs.NuggetsCodec
 
NuggetsXMLContentCodec - Class in jadex.platform.service.message.contentcodecs
The XML codec based on the nuggets framework.
NuggetsXMLContentCodec() - Constructor for class jadex.platform.service.message.contentcodecs.NuggetsXMLContentCodec
 
number - Variable in class jadex.platform.service.clock.Timer
The instance number.
number - Variable in class jadex.platform.service.remote.TemporaryRemoteReferenceHolder
Number of open protocls.

O

offset - Variable in class jadex.platform.service.message.streams.InputConnection
The offset (startvalue of current first row).
offValue - Static variable in class jadex.platform.service.cms.LoggerWrapper
 
ofuture - Variable in class jadex.platform.service.message.streams.InputConnection
 
ofx - Static variable in class jadex.platform.service.message.contentcodecs.NuggetsXMLContentCodec
ObjectFromXML method.
ofx - Static variable in class jadex.platform.service.message.transport.codecs.NuggetsCodec
ObjectFromXML method.
onCreate() - Method in class jadex.platform.service.dht.DhtViewerAgent
 
onCreate() - Method in class jadex.platform.service.dht.DistributedKVStoreAgent
 
onCreate() - Method in class jadex.platform.service.dht.RingNodeAgent
 
onServiceStarted() - Method in class jadex.platform.service.dht.DistributedKVStoreService
 
onServiceStarted() - Method in class jadex.platform.service.dht.DistributedServiceRegistryService
 
onStart() - Method in class jadex.platform.service.dht.RingNodeService
 
opencalls - Variable in class jadex.platform.service.ecarules.RulebaseAgent
The open calls (callid -> set of event ids that have to be acked.
openFile(String) - Method in class jadex.platform.service.context.ContextService
Opens a File with the default application.
openFile(String) - Method in class jadex.platform.service.filetransfer.FileTransferService
Execute a file.
openReceiverConnection(String, IComponentIdentifier) - Method in class jadex.platform.service.message.transport.httprelaymtp.RelayConnectionManager
Open a receiving connection.
orig - Variable in class jadex.platform.service.remote.commands.RemoteIntermediateResultCommand
The original future (not transmitted).
otx - Static variable in class jadex.platform.service.message.contentcodecs.NuggetsXMLContentCodec
ObjectToXML method.
otx - Static variable in class jadex.platform.service.message.transport.codecs.NuggetsCodec
ObjectToXML method.
outdated - Variable in class jadex.platform.service.simulation.SimulationService.IdleListener
Flag to indicate an outdated listener that should not do anything.
OutputConnection - Class in jadex.platform.service.message.streams
Output connection for writing data.
OutputConnection(ITransportComponentIdentifier, ITransportComponentIdentifier, int, boolean, IOutputConnectionHandler) - Constructor for class jadex.platform.service.message.streams.OutputConnection
Create a new connection.
OutputConnectionHandler - Class in jadex.platform.service.message.streams
The output connection handler.
OutputConnectionHandler(MessageService, Map<String, Object>) - Constructor for class jadex.platform.service.message.streams.OutputConnectionHandler
Create a new handler.
OutputConnectionHandler.DataSendInfo - Class in jadex.platform.service.message.streams
Info about a sent but not yet acknowledged data message.
overlayId - Variable in class jadex.platform.service.dht.RingNodeAgent
Identifier for the overlay for this node to be part of.
overlayId - Variable in class jadex.platform.service.dht.RingNodeService
Ring overlay identifier.
OverlayIdFilter - Class in jadex.platform.service.dht
 
OverlayIdFilter() - Constructor for class jadex.platform.service.dht.OverlayIdFilter
 
OverlayIdFilter(String) - Constructor for class jadex.platform.service.dht.OverlayIdFilter
 

P

parametertypes - Variable in class jadex.platform.service.remote.commands.RemoteMethodInvocationCommand
The parameter types.
parametervalues - Variable in class jadex.platform.service.remote.commands.RemoteMethodInvocationCommand
The parameter values.
parents - Variable in class jadex.platform.service.library.DelegationURLClassLoader
The parent classloaders (i.e.
parseAddress(String) - Method in class jadex.platform.service.message.transport.niotcpmtp.NIOTCPTransport
Parse an address.
participant - Variable in class jadex.platform.service.message.streams.AbstractConnection
The participant.
participant - Variable in class jadex.platform.service.message.streams.InitInfo
The participant.
password - Variable in class jadex.platform.service.security.SecurityService
The local password (if any).
pause() - Method in class jadex.platform.service.simulation.SimulationService
Pause the execution (can be resumed via start or step).
pcons - Variable in class jadex.platform.service.message.MessageService
The participant connections.
performAnnouncements(ITransportComponentIdentifier) - Method in class jadex.platform.service.awareness.discovery.message.MessageDiscoveryAgent
Perform continuous announcements until no ping answers are received any longer.
pi - Variable in class jadex.platform.service.remote.ProxyReference
The proxy info.
ping(String) - Method in class jadex.platform.service.message.transport.httprelaymtp.RelayConnectionManager
Ping a relay server.
PING_DELAY - Static variable in class jadex.platform.service.message.transport.httprelaymtp.SRelay
The delay (ms) between server pings (for checking if receiving connection is still active).
platform - Variable in class jadex.platform.service.remote.RemoteServiceManagementService
The local platform.
PlatformAgent - Class in jadex.platform
Basic standalone platform services provided as a micro agent.
PlatformAgent() - Constructor for class jadex.platform.PlatformAgent
 
PlatformComponent - Class in jadex.platform.service.cms
Standalone platform component implementation.
PlatformComponent() - Constructor for class jadex.platform.service.cms.PlatformComponent
 
platformpasses - Variable in class jadex.platform.service.security.SecurityService
The stored passwords.
port - Variable in class jadex.platform.service.awareness.discovery.ipbroadcast.BroadcastDiscoveryAgent
The receiver port.
port - Variable in class jadex.platform.service.awareness.discovery.ipmulticast.MulticastDiscoveryAgent
The receiver port.
port - Variable in class jadex.platform.service.awareness.discovery.ipscanner.ScannerDiscoveryAgent
The receiver port.
port - Variable in class jadex.platform.service.awareness.discovery.registry.RegistryDiscoveryAgent
The receiver port.
port - Variable in class jadex.platform.service.awareness.management.AwarenessSettingsData
The port.
port - Variable in class jadex.platform.service.message.transport.niotcpmtp.NIOTCPTransport
The port.
PORT - Static variable in class jadex.platform.service.message.transport.tcpmtp.TCPTransport
The receiving port.
port - Variable in class jadex.platform.service.message.transport.tcpmtp.TCPTransport
The port.
position - Variable in class jadex.platform.service.message.streams.InputConnection
The position.
postAwarenessInfo(byte[], int, Map<Byte, ICodec>) - Method in class jadex.platform.service.message.transport.httprelaymtp.HttpReceiver
Post a received awareness info to awareness service (if any).
postInfo() - Method in class jadex.platform.service.awareness.discovery.local.LocalDiscoveryAgent
 
postMessage(String, IComponentIdentifier, byte[][]) - Method in class jadex.platform.service.message.transport.httprelaymtp.RelayConnectionManager
Post a message.
postProcess(IContext, Object) - Method in class jadex.platform.service.remote.xml.RMIPostProcessor
Post-process an object after an XML has been loaded.
postprocessCommand(IInternalAccess, RemoteReferenceModule, IComponentIdentifier) - Method in class jadex.platform.service.remote.commands.AbstractRemoteCommand
Post-process a received command before execution for e.g.
postprocessCommand(IInternalAccess, RemoteReferenceModule, IComponentIdentifier) - Method in class jadex.platform.service.remote.commands.RemoteMethodInvocationCommand
Post-process a received command before execution for e.g.
postprocessCommand(IInternalAccess, RemoteReferenceModule, IComponentIdentifier) - Method in class jadex.platform.service.remote.commands.RemoteSearchCommand
Post-process a received command before execution for e.g.
pr - Variable in class jadex.platform.service.remote.RemoteMethodInvocationHandler
The proxy reference.
predecessorChanged(IFinger, IFinger) - Method in interface jadex.platform.service.dht.Fingertable.FingerTableListener
 
preProcess(IContext, Object) - Method in class jadex.platform.service.remote.xml.RMIPreProcessor
Pre-process an object before the xml is written.
preprocessCommand(IInternalAccess, RemoteReferenceModule, IComponentIdentifier) - Method in class jadex.platform.service.remote.commands.AbstractRemoteCommand
Preprocess command and replace if they are remote references.
preprocessCommand(IInternalAccess, RemoteReferenceModule, IComponentIdentifier) - Method in class jadex.platform.service.remote.commands.RemoteMethodInvocationCommand
Preprocess command and replace if they are remote references.
preprocessCommand(IInternalAccess, RemoteReferenceModule, IComponentIdentifier) - Method in class jadex.platform.service.remote.commands.RemoteResultCommand
Preprocess command and replace if they are remote references.
preprocessRequest(IAuthorizable, IComponentIdentifier) - Method in class jadex.platform.service.security.SecurityService
Preprocess a request.
printpass - Variable in class jadex.platform.service.security.SecurityService
Print password on startup or change.
processingcalls - Variable in class jadex.platform.service.remote.RemoteServiceManagementService
The map of processing calls (callid -> terniable future).
processors - Variable in class jadex.platform.service.marshal.MarshalService
The clone processors.
PROEPRTIES_ID - Static variable in class jadex.platform.service.security.SecurityService
Properties id for the settings service.
prolog - Variable in class jadex.platform.service.message.AbstractSendTask
The message prolog.
PropProvider() - Constructor for class jadex.platform.service.chat.ChatService.PropProvider
 
props - Variable in class jadex.platform.service.settings.SettingsService
The current properties.
provider - Variable in class jadex.platform.service.df.DirectoryFacilitatorService
The platform.
provider - Variable in class jadex.platform.service.execution.SyncExecutionService
The provider.
providerid - Variable in class jadex.platform.service.remote.commands.RemoteSearchCommand
The providerid (i.e.
providers - Variable in class jadex.platform.service.settings.SettingsService
The registered properties provider (id->provider).
ProxyAgent - Class in jadex.platform.service.remote
A proxy agent is a pseudo component that mirrors services of a remote platform (or component).
ProxyAgent() - Constructor for class jadex.platform.service.remote.ProxyAgent
 
proxycount - Variable in class jadex.platform.service.remote.RemoteReferenceModule
The proxycount count map.
proxydates - Variable in class jadex.platform.service.remote.RemoteReferenceModule
The proxy dates (date -> rr).
ProxyInfo - Class in jadex.platform.service.remote
Info struct that holds all necessary model information to generate a proxy on the local platform.
ProxyInfo() - Constructor for class jadex.platform.service.remote.ProxyInfo
Create a new proxy info.
ProxyInfo(Class<?>[]) - Constructor for class jadex.platform.service.remote.ProxyInfo
Create a new proxy info.
proxyinfos - Variable in class jadex.platform.service.remote.RemoteReferenceModule
The cache of proxy infos (class -> proxy info).
ProxyLatencyProperty - Class in jadex.platform.service.remote
The latency of a remote platform.
ProxyLatencyProperty(IInternalAccess) - Constructor for class jadex.platform.service.remote.ProxyLatencyProperty
Create a new property.
ProxyReference - Class in jadex.platform.service.remote
A proxy reference is the transfer format of a remote reference which should be made to a proxy on the other side.
ProxyReference() - Constructor for class jadex.platform.service.remote.ProxyReference
Create a new proxy reference.
ProxyReference(ProxyInfo, RemoteReference) - Constructor for class jadex.platform.service.remote.ProxyReference
Create a new proxy reference.
publish(String, IServiceIdentifier) - Method in class jadex.platform.service.dht.DistributedServiceRegistryService
Publish a service in the distributed registry.
publishCurrentState() - Method in class jadex.platform.service.security.SecurityService
Publish the current state.
publishEvent(String, String, IComponentIdentifier, Object) - Method in class jadex.platform.service.chat.ChatService
Post an event to registered subscribers.
publishEvent(String, String, IComponentIdentifier, Object, boolean, byte[]) - Method in class jadex.platform.service.chat.ChatService
Post an event to registered subscribers.
publishEvent(RuleEvent) - Method in class jadex.platform.service.ecarules.ClientRuleSystemAgent
 
publishEvent(RuleEvent) - Method in class jadex.platform.service.ecarules.RuleAgent
 
publishEvent(IMonitoringEvent) - Method in class jadex.platform.service.monitoring.MonitoringService
Publish a new event.
publishEvent(ChangeEvent<Object>) - Method in class jadex.platform.service.security.SecurityService
Publish events to all subscribers.
pullcallid - Variable in class jadex.platform.service.remote.commands.RemoteFuturePullCommand
The call identifier to pull.
pullEntries(IID) - Method in class jadex.platform.service.dht.DistributedKVStoreService
Returns all entries that belong to the given node Id and deletes them on this node.
pushEntries(Collection<StoreEntry>) - Method in class jadex.platform.service.dht.DistributedKVStoreService
 
put(String, Object) - Method in class jadex.platform.service.dht.DistributedKVStoreService
Publish a key/value pair in the corresponding node.
putCache(String, Object) - Method in class jadex.platform.service.remote.ProxyReference
Get the cached values.
putInitInfo(IComponentIdentifier, ComponentManagementService.InitInfo) - Method in class jadex.platform.service.cms.ComponentManagementService
Put an init info.
putProcessingCall(String, Object) - Method in class jadex.platform.service.remote.RemoteServiceManagementService
Add a new processing call.
putWaitingCall(String, Future<Object>, RemoteServiceManagementService.TimeoutTimerTask, Object) - Method in class jadex.platform.service.remote.RemoteServiceManagementService
Add a new waiting call.

Q

queue - Variable in class jadex.platform.service.execution.SyncExecutionService
The queue of tasks to be executed.
queuecnt - Variable in class jadex.platform.service.message.streams.OutputConnectionHandler
The number of sending messages (i.e.
queueDoSendTask(String, ISendTask) - Method in class jadex.platform.service.message.transport.httprelaymtp.HttpRelayTransport
Queue a send task for execution on a worker thread.
queueReadySendTask(String, ISendTask, boolean) - Method in class jadex.platform.service.message.transport.httprelaymtp.HttpRelayTransport
Queue a ready send task for execution after a ping.

R

rb - Variable in class jadex.platform.service.message.transport.niotcpmtp.NIOTCPInputConnection
The read buffer for reading out the messages.
rbsubscribers - Variable in class jadex.platform.service.ecarules.RulebaseAgent
The subscriptions.
rcid - Variable in class jadex.platform.service.remote.ProxyAgent
The remote component identifier.
rcms - Variable in class jadex.platform.service.remote.ProxyAgent
The remote cms.
read() - Method in class jadex.platform.service.message.streams.InputConnection
Non-blocking read.
read(byte[]) - Method in class jadex.platform.service.message.streams.InputConnection
Non-blocking read.
read() - Method in class jadex.platform.service.message.transport.niotcpmtp.NIOTCPInputConnection
Read a message from the channel.
read() - Method in class jadex.platform.service.message.transport.tcpmtp.TCPInputConnection
Receive a message from a socket.
readByte() - Method in class jadex.platform.service.message.transport.tcpmtp.TCPInputConnection
Read a byte from the stream.
reader - Variable in class jadex.platform.service.remote.RemoteServiceManagementService
The rmi xml to object reader.
readMessage(InputStream) - Static method in class jadex.platform.service.message.transport.httprelaymtp.HttpReceiver
Read a complete message from the stream.
readOrCreateProperties() - Method in class jadex.platform.service.settings.SettingsService
 
readPropertiesFromStore() - Method in class jadex.platform.service.settings.SettingsService
Reads and returns the stored Properties, usually from a file.
ready(IResultCommand<IFuture<Void>, Void>) - Method in class jadex.platform.service.message.AbstractSendTask
Called by the transport when is is ready to send the message, i.e.
ready(IResultCommand<IFuture<Void>, Void>) - Method in interface jadex.platform.service.message.ISendTask
Called by the transport when is is ready to send the message, i.e.
ready(int) - Method in class jadex.platform.service.message.streams.LocalOutputConnectionHandler
Called by local input connection handler to signal that user has read some data.
readyfuture - Variable in class jadex.platform.service.message.streams.LocalOutputConnectionHandler
The ready future.
readyfuture - Variable in class jadex.platform.service.message.streams.OutputConnectionHandler
Future used in waitForReady().
readyqueue - Variable in class jadex.platform.service.message.transport.httprelaymtp.HttpRelayTransport
The ready queue per address (tasks to reschedule after ping).
receive() - Method in class jadex.platform.service.awareness.discovery.ipbroadcast.BroadcastReceiveHandler
Receive a packet.
receive() - Method in class jadex.platform.service.awareness.discovery.ipmulticast.MulticastReceiveHandler
Receive a packet.
receive() - Method in class jadex.platform.service.awareness.discovery.ipscanner.ScannerReceiveHandler
Receive a packet.
receive() - Method in class jadex.platform.service.awareness.discovery.ReceiveHandler
Receive a packet.
receive() - Method in class jadex.platform.service.awareness.discovery.registry.RegistryReceiveHandler
Receive a packet.
receive - Variable in class jadex.platform.service.email.EmailAgent
The receive behavior.
received_self - Variable in class jadex.platform.service.awareness.discovery.DiscoveryAgent
Flag indicating that the agent has received its own discovery info.
received_self - Variable in class jadex.platform.service.awareness.discovery.ReceiveHandler
Flag indicating that the agent has received its own discovery info.
ReceiveHandler - Class in jadex.platform.service.awareness.discovery
Abstract receive handler base class.
ReceiveHandler(DiscoveryAgent) - Constructor for class jadex.platform.service.awareness.discovery.ReceiveHandler
Create a new lease time handling object.
receiver - Variable in class jadex.platform.service.awareness.discovery.DiscoveryAgent
The receive handler.
receiver - Variable in class jadex.platform.service.message.transport.httprelaymtp.HttpRelayTransport
The receiver process.
receiver - Variable in class jadex.platform.service.remote.commands.AbstractRemoteCommand
The receiver (for processing the command in rmipreprocessor, will not be transferred).
receiver - Variable in class jadex.platform.service.remote.RemoteServiceManagementService.TimeoutTimerTask
 
receivers - Variable in class jadex.platform.service.message.AbstractSendTask
The managed receivers.
receivers - Variable in class jadex.platform.service.message.transport.MessageEnvelope
The receivers.
REFERENCES - Static variable in class jadex.platform.service.marshal.MarshalService
The predefined reference settings (clazz->boolean (is reference)).
references - Variable in class jadex.platform.service.marshal.MarshalService
The reference class cache (clazz->boolean (is reference)).
refresh() - Method in class jadex.platform.service.message.transport.niotcpmtp.SelectorThread.Cleaner
Refresh the timeout.
refresh() - Method in class jadex.platform.service.message.transport.tcpmtp.TCPTransport.Cleaner
Refresh the timeout.
refresh() - Method in class jadex.platform.service.remote.RemoteServiceManagementService.WaitingCallInfo
 
refreshAddresses() - Method in class jadex.platform.service.message.MessageService
Announce that addresses of transports might have changed.
refreshComponentIdentifier(ITransportComponentIdentifier, long) - Method in class jadex.platform.service.awareness.discovery.message.MessageDiscoveryAgent
Refresh a component identifier.
refreshLatency() - Method in class jadex.platform.service.remote.ProxyAgent
Refresh the latency value.
register(IDFComponentDescription) - Method in class jadex.platform.service.df.DirectoryFacilitatorService
Register a component description.
registerPropertiesProvider(String, IPropertiesProvider) - Method in class jadex.platform.service.settings.SettingsService
Register a property provider.
RegistryDiscoveryAgent - Class in jadex.platform.service.awareness.discovery.registry
The registry awareness uses a dedicated registry awareness service at which all nodes register.
RegistryDiscoveryAgent() - Constructor for class jadex.platform.service.awareness.discovery.registry.RegistryDiscoveryAgent
 
RegistryReceiveHandler - Class in jadex.platform.service.awareness.discovery.registry
 
RegistryReceiveHandler(RegistryDiscoveryAgent) - Constructor for class jadex.platform.service.awareness.discovery.registry.RegistryReceiveHandler
Create a new lease time handling object.
rejectFile(String) - Method in class jadex.platform.service.chat.ChatService
Reject a waiting file transfer.
relayAddress(String) - Static method in class jadex.platform.service.message.transport.httprelaymtp.RelayConnectionManager
Convert a potential non 'relay-' address to relay address.
RelayConnectionManager - Class in jadex.platform.service.message.transport.httprelaymtp
The connection manager performs http requests and further allows asynchronously terminating open connections to avoid hanging on e.g.
RelayConnectionManager() - Constructor for class jadex.platform.service.message.transport.httprelaymtp.RelayConnectionManager
 
RelayDiscoveryAgent - Class in jadex.platform.service.awareness.discovery.relay
Control the discovery mechanism of the relay transport.
RelayDiscoveryAgent() - Constructor for class jadex.platform.service.awareness.discovery.relay.RelayDiscoveryAgent
 
releasedatecache - Variable in class jadex.platform.service.message.MessageService
Release date cache
REMOTE_EXCLUDED - Static variable in class jadex.platform.service.remote.RemoteServiceManagementService
Excluded remote methods (for all methods) Excluded methods throw UnsupportedOperationException.
REMOTE_METHODREPLACEMENT - Static variable in class jadex.platform.service.remote.RemoteServiceManagementService
Replacement methods to be executed instead of remote method invocation.
REMOTE_SYNCHRONOUS - Static variable in class jadex.platform.service.remote.RemoteServiceManagementService
Synchronous remote methods (for methods with void return value).
REMOTE_TIMEOUT - Static variable in class jadex.platform.service.remote.RemoteServiceManagementService
Timeout for remote method invocation.
REMOTE_UNCACHED - Static variable in class jadex.platform.service.remote.RemoteServiceManagementService
Uncached remote methods (for methods with no parameters) Uncached methods will be invoked on every call.
RemoteDGCAddReferenceCommand - Class in jadex.platform.service.remote.commands
Distributed garbage collection 'addRef(rr)' command.
RemoteDGCAddReferenceCommand() - Constructor for class jadex.platform.service.remote.commands.RemoteDGCAddReferenceCommand
Create a new add reference command.
RemoteDGCAddReferenceCommand(RemoteReference, IComponentIdentifier, String) - Constructor for class jadex.platform.service.remote.commands.RemoteDGCAddReferenceCommand
Create a new add reference command.
RemoteDGCRemoveReferenceCommand - Class in jadex.platform.service.remote.commands
Distributed garbage collection 'removeRef(rr)' command.
RemoteDGCRemoveReferenceCommand() - Constructor for class jadex.platform.service.remote.commands.RemoteDGCRemoveReferenceCommand
Create a new add reference command.
RemoteDGCRemoveReferenceCommand(RemoteReference, IComponentIdentifier, String) - Constructor for class jadex.platform.service.remote.commands.RemoteDGCRemoveReferenceCommand
Create a new add reference command.
RemoteFutureBackwardCommand - Class in jadex.platform.service.remote.commands
Command for sending back an info to the src of a future.
RemoteFutureBackwardCommand() - Constructor for class jadex.platform.service.remote.commands.RemoteFutureBackwardCommand
Create a new remote method invocation command.
RemoteFutureBackwardCommand(String, String, Object) - Constructor for class jadex.platform.service.remote.commands.RemoteFutureBackwardCommand
Create a new remote method invocation command.
RemoteFuturePullCommand - Class in jadex.platform.service.remote.commands
Command for executing a remote method.
RemoteFuturePullCommand() - Constructor for class jadex.platform.service.remote.commands.RemoteFuturePullCommand
Create a new remote method invocation command.
RemoteFuturePullCommand(String, String) - Constructor for class jadex.platform.service.remote.commands.RemoteFuturePullCommand
Create a new remote method invocation command.
RemoteFutureSourceCommand - Class in jadex.platform.service.remote.commands
 
RemoteFutureSourceCommand() - Constructor for class jadex.platform.service.remote.commands.RemoteFutureSourceCommand
Create a new remote intermediate result command.
RemoteFutureSourceCommand(IComponentIdentifier, Object, String, boolean, String, Map<String, Object>) - Constructor for class jadex.platform.service.remote.commands.RemoteFutureSourceCommand
Create a new remote intermediate result command.
RemoteFutureTerminationCommand - Class in jadex.platform.service.remote.commands
Command for executing a remote method.
RemoteFutureTerminationCommand() - Constructor for class jadex.platform.service.remote.commands.RemoteFutureTerminationCommand
Create a new remote method invocation command.
RemoteFutureTerminationCommand(String, String, Exception) - Constructor for class jadex.platform.service.remote.commands.RemoteFutureTerminationCommand
Create a new remote method invocation command.
RemoteGetExternalAccessCommand - Class in jadex.platform.service.remote.commands
Command for getting a remote external access.
RemoteGetExternalAccessCommand() - Constructor for class jadex.platform.service.remote.commands.RemoteGetExternalAccessCommand
Create a new remote search command.
RemoteGetExternalAccessCommand(IComponentIdentifier, String) - Constructor for class jadex.platform.service.remote.commands.RemoteGetExternalAccessCommand
Create a new remote search command.
RemoteIntermediateResultCommand - Class in jadex.platform.service.remote.commands
 
RemoteIntermediateResultCommand() - Constructor for class jadex.platform.service.remote.commands.RemoteIntermediateResultCommand
Create a new remote intermediate result command.
RemoteIntermediateResultCommand(IComponentIdentifier, Object, String, boolean, String, boolean, Map<String, Object>, IFuture<?>, int) - Constructor for class jadex.platform.service.remote.commands.RemoteIntermediateResultCommand
Create a new remote intermediate result command.
RemoteMethodInvocationCommand - Class in jadex.platform.service.remote.commands
Command for executing a remote method.
RemoteMethodInvocationCommand() - Constructor for class jadex.platform.service.remote.commands.RemoteMethodInvocationCommand
Create a new remote method invocation command.
RemoteMethodInvocationCommand(RemoteReference, Method, Object[], String, IComponentIdentifier, Map<String, Object>) - Constructor for class jadex.platform.service.remote.commands.RemoteMethodInvocationCommand
Create a new remote method invocation command.
RemoteMethodInvocationHandler - Class in jadex.platform.service.remote
Class that implements the Java proxy InvocationHandler, which is called when a method on a proxy is called.
RemoteMethodInvocationHandler(RemoteServiceManagementService, ProxyReference) - Constructor for class jadex.platform.service.remote.RemoteMethodInvocationHandler
Create a new invocation handler.
RemoteReference - Class in jadex.platform.service.remote
Remote reference for locating a specific target object in another platform.
RemoteReference() - Constructor for class jadex.platform.service.remote.RemoteReference
Create a new remote reference.
RemoteReference(ITransportComponentIdentifier, Object) - Constructor for class jadex.platform.service.remote.RemoteReference
Create a new remote reference.
RemoteReferenceHolder - Class in jadex.platform.service.remote
 
RemoteReferenceHolder(IComponentIdentifier, long) - Constructor for class jadex.platform.service.remote.RemoteReferenceHolder
Create a new holder.
RemoteReferenceModule - Class in jadex.platform.service.remote
This class implements the rmi handling.
RemoteReferenceModule(RemoteServiceManagementService, ILibraryService, IMarshalService) - Constructor for class jadex.platform.service.remote.RemoteReferenceModule
Create a new remote reference module.
remoterefs - Variable in class jadex.platform.service.remote.RemoteReferenceModule
The inverse map of target object to remote references (target objects -> rr).
RemoteResultCommand - Class in jadex.platform.service.remote.commands
Command that represents the result(s) of a remote command.
RemoteResultCommand() - Constructor for class jadex.platform.service.remote.commands.RemoteResultCommand
Create a new remote result command.
RemoteResultCommand(IComponentIdentifier, Object, Exception, String, boolean, String, Map<String, Object>) - Constructor for class jadex.platform.service.remote.commands.RemoteResultCommand
Create a new remote result command.
remotes - Variable in class jadex.platform.service.awareness.discovery.MasterSlaveDiscoveryAgent
The local slaves.
RemoteSearchCommand - Class in jadex.platform.service.remote.commands
Command for performing a remote service search.
RemoteSearchCommand() - Constructor for class jadex.platform.service.remote.commands.RemoteSearchCommand
Create a new remote search command.
RemoteSearchCommand(IComponentIdentifier, Class<?>, boolean, String, String, IAsyncFilter<IService>, IComponentIdentifier) - Constructor for class jadex.platform.service.remote.commands.RemoteSearchCommand
Create a new remote search command.
RemoteServiceManagementAgent - Class in jadex.platform.service.remote
Remote service management service that hosts the corresponding service.
RemoteServiceManagementAgent() - Constructor for class jadex.platform.service.remote.RemoteServiceManagementAgent
 
RemoteServiceManagementService - Class in jadex.platform.service.remote
The remote service management service is responsible for handling remote service invocations (similar to RMI).
RemoteServiceManagementService(IExternalAccess, ILibraryService, IMarshalService, IMessageService, TransportAddressBook) - Constructor for class jadex.platform.service.remote.RemoteServiceManagementService
Create a new remote service management service.
RemoteServiceManagementService.TimeoutTimerTask - Class in jadex.platform.service.remote
Timeout timer task for sent messages.
RemoteServiceManagementService.WaitingCallInfo - Class in jadex.platform.service.remote
Waiting call info.
remove() - Method in class jadex.platform.service.message.transport.niotcpmtp.SelectorThread.Cleaner
Remove this cleaner.
remove() - Method in class jadex.platform.service.message.transport.tcpmtp.TCPTransport.Cleaner
Remove this cleaner.
removeChangeListener(IChangeListener) - Method in class jadex.platform.service.clock.AbstractClock
Remove a change listener.
removeChangeListener(IChangeListener) - Method in class jadex.platform.service.clock.ClockService
Remove a change listener.
removeChangeListener(IChangeListener) - Method in class jadex.platform.service.simulation.SimulationService
Remove a change listener.
removeCloneProcessor(ITraverseProcessor) - Method in class jadex.platform.service.marshal.MarshalService
Remove a clone processor.
removeCodec(Class) - Method in class jadex.platform.service.message.transport.codecs.CodecFactory
Remove a codec via its id.
removeComponentListener(IComponentIdentifier, ICMSComponentListener) - Method in class jadex.platform.service.cms.ComponentManagementService
Remove a listener.
removeConnection(String) - Method in class jadex.platform.service.message.transport.tcpmtp.TCPTransport
Remove a cached connection.
removeContentCodec(IContentCodec) - Method in class jadex.platform.service.message.MessageService
Remove content codec type.
removeDelegateClassLoader(DelegationURLClassLoader) - Method in class jadex.platform.service.library.DelegationURLClassLoader
Remove a new delegate loader.
removedfut - Variable in class jadex.platform.service.execution.SyncExecutionService
The removed listeners.
removedlinks - Variable in class jadex.platform.service.library.LibraryService
The remove links.
removedtask - Variable in class jadex.platform.service.execution.SyncExecutionService
Flag that indicates that the current task has been removed.
removeFutureCommands(String) - Method in class jadex.platform.service.remote.RemoteServiceManagementService
Remove a future command.
removeHandler(Handler) - Method in class jadex.platform.service.cms.LoggerWrapper
Remove a log Handler.
removeid - Variable in class jadex.platform.service.remote.RemoteReferenceModule
The remove behaviour id.
removeInitInfo(IComponentIdentifier) - Method in class jadex.platform.service.cms.ComponentManagementService
Remove an init info.
removeKeyStoreEntry(String) - Method in class jadex.platform.service.security.SecurityService
Remove a key store entry.
removeLibraryServiceListener(ILibraryServiceListener) - Method in class jadex.platform.service.library.LibraryService
Remove an Library Service listener.
removeLink(IResourceIdentifier, IResourceIdentifier) - Method in class jadex.platform.service.library.LibraryService
Remove a link.
removeMessageCodec(Class) - Method in class jadex.platform.service.message.MessageService
Remove message codec type.
removeMessageListener(IMessageListener) - Method in class jadex.platform.service.message.MessageService
Remove a message listener.
removeParentClassLoader(DelegationURLClassLoader) - Method in class jadex.platform.service.library.DelegationURLClassLoader
Remove a parent classloader.
removePlatformAddresses(ITransportComponentIdentifier) - Method in class jadex.platform.service.address.TransportAddressService
Remove the addresses of a platform.
removeProcessingCall(String) - Method in class jadex.platform.service.remote.RemoteServiceManagementService
Remove a processing call.
removeRemoteReference(RemoteReference, IComponentIdentifier) - Method in class jadex.platform.service.remote.RemoteReferenceModule
Remove a new holder from a remote object.
removeResourceIdentifier(IResourceIdentifier, IResourceIdentifier) - Method in class jadex.platform.service.library.LibraryService
Remove a resource identifier.
removeRule(String) - Method in class jadex.platform.service.ecarules.RulebaseAgent
Remove a rule.
removeSubscription(SubscriptionIntermediateFuture<Email>) - Method in class jadex.platform.service.email.EmailAgent
Remove an existing subscription.
removeSubscription(SubscriptionIntermediateFuture<IMonitoringEvent>) - Method in class jadex.platform.service.monitoring.MonitoringService
Remove an existing subscription.
removeSupport(IResourceIdentifier, IResourceIdentifier) - Method in class jadex.platform.service.library.LibraryService
Remove support for a rid.
removeTargetObject(RemoteReference) - Method in class jadex.platform.service.remote.RemoteReferenceModule
Remove a target object.
removeTickTimer(ITimer) - Method in class jadex.platform.service.clock.AbstractClock
Remove a tick timer.
removeTimer(ITimer) - Method in class jadex.platform.service.clock.AbstractClock
Remove a timer.
removeTimer(ITimer) - Method in class jadex.platform.service.clock.ContinuousClock
Remove a timer.
removeTopLevelURL(URL) - Method in class jadex.platform.service.library.LibraryService
Remove a top level url.
removeTransport(ITransport) - Method in class jadex.platform.service.message.MessageService
Remove a transport for the outbox.
removeURL(URL) - Method in class jadex.platform.service.library.ChangeableURLClassLoader
Remove a url.
removeURL(IResourceIdentifier, URL) - Method in class jadex.platform.service.library.LibraryService
Remove a new url.
removeVirtual(String, String) - Method in class jadex.platform.service.security.SecurityService
Remove a name from the mappings of a virtual name.
removeWaitingCall(String) - Method in class jadex.platform.service.remote.RemoteServiceManagementService
Remove a waiting call.
renameFile(String, String) - Method in class jadex.platform.service.filetransfer.FileTransferService
Rename a file.
renewid - Variable in class jadex.platform.service.remote.RemoteReferenceModule
The renew behaviour id.
RepetitiveComponentStep<T> - Class in jadex.platform.service.dht
A component step that repeats itself.
RepetitiveComponentStep(long) - Constructor for class jadex.platform.service.dht.RepetitiveComponentStep
Constructor.
replacements - Variable in class jadex.platform.service.remote.ProxyInfo
The replacements for methods (method-info -> replacement method).
republish() - Method in class jadex.platform.service.awareness.discovery.DiscoveryAgent
Republish the awareness info.
republish() - Method in class jadex.platform.service.awareness.discovery.local.LocalDiscoveryAgent
Republish the awareness info.
republish() - Method in class jadex.platform.service.awareness.discovery.relay.RelayDiscoveryAgent
Republish the awareness info.
reschedule() - Method in class jadex.platform.service.dht.RepetitiveComponentStep
Reschedules this step.
reset() - Method in class jadex.platform.service.clock.AbstractClock
Reset the clock.
reset() - Method in class jadex.platform.service.clock.ContinuousClock
Reset the clock.
resolveFilename(String, CreationInfo, IResourceIdentifier) - Method in class jadex.platform.service.cms.ComponentManagementService
Find the file name and local component type name for a component to be started.
responses - Variable in class jadex.platform.service.security.DecentralizedAcquisitionMechanism
The number of responses (<1=disabled).
resubscribers - Variable in class jadex.platform.service.ecarules.ClientRuleSystemAgent
The subscriptions.
resubscribers - Variable in class jadex.platform.service.ecarules.RuleAgent
The subscriptions.
result - Variable in class jadex.platform.service.message.streams.AbstractConnectionHandler.SendInfo
The result future of the call.
result - Variable in class jadex.platform.service.remote.commands.RemoteResultCommand
The result.
resultAvailable(Object) - Method in class jadex.platform.service.simulation.SimulationService.IdleListener
Called when the execution service is idle.
results - Variable in class jadex.platform.service.remote.RemoteServiceManagementService.WaitingCallInfo
The results per cnt.
resumeComponent(IComponentIdentifier) - Method in class jadex.platform.service.cms.ComponentManagementService
Resume the execution of an component.
resumeComponent(IComponentIdentifier, boolean) - Method in class jadex.platform.service.cms.ComponentManagementService
Resume the execution of an component.
retry() - Method in class jadex.platform.service.message.streams.OutputConnectionHandler.DataSendInfo
Retry sending the message.
RETRY_OTHER_DELAY - Static variable in class jadex.platform.service.dht.RingNodeService
Delay in ms to wait before retrying any remote calls
RETRY_SEARCH_DELAY - Static variable in class jadex.platform.service.dht.RingNodeService
Delay in ms to wait before restarting the search for other ring nodes
returnisref - Variable in class jadex.platform.service.remote.commands.RemoteMethodInvocationCommand
The declared reference flag for the return value.
rid - Variable in class jadex.platform.service.library.DelegationURLClassLoader
The resource identifier.
rids - Variable in class jadex.platform.service.library.LibraryService
The dependencies.
ring - Variable in class jadex.platform.service.dht.DistributedKVStoreService
The local Ring Node to access the DHT Ring.
ring - Variable in class jadex.platform.service.dht.RingNodeAgent
The local ringnode service
RingNodeAgent - Class in jadex.platform.service.dht
This Agent represents a part of the DHT ring, providing a Ring Node Service.
RingNodeAgent() - Constructor for class jadex.platform.service.dht.RingNodeAgent
 
RingNodeService - Class in jadex.platform.service.dht
This service provides a ring node, which connects to other ring nodes and forms a circular hierarchy using the Chord DHT protocol.
RingNodeService(String) - Constructor for class jadex.platform.service.dht.RingNodeService
Constructor.
RMIPostProcessor - Class in jadex.platform.service.remote.xml
The rmi postprocessor has the task to create a proxy from a proxyinfo.
RMIPostProcessor(RemoteReferenceModule) - Constructor for class jadex.platform.service.remote.xml.RMIPostProcessor
Create a new post processor.
RMIPreProcessor - Class in jadex.platform.service.remote.xml
Preprocessor for RMI.
RMIPreProcessor(RemoteReferenceModule) - Constructor for class jadex.platform.service.remote.xml.RMIPreProcessor
Create a new pre processor.
rms - Variable in class jadex.platform.service.remote.RemoteReference
The rms.
rms - Variable in class jadex.platform.service.remote.RemoteServiceManagementAgent
The remote management service.
rms - Variable in class jadex.platform.service.remote.RemoteServiceManagementService.TimeoutTimerTask
 
rnd - Variable in class jadex.platform.service.security.TTPAcquisitionMechanism
The random generator.
root - Variable in class jadex.platform.service.awareness.discovery.DiscoveryAgent
The root component id.
root - Variable in class jadex.platform.service.awareness.management.AwarenessManagementAgent
The root component id.
rootloader - Variable in class jadex.platform.service.library.LibraryService
The delegation root loader.
rootrid - Variable in class jadex.platform.service.library.LibraryService
 
rr - Variable in class jadex.platform.service.remote.commands.RemoteDGCAddReferenceCommand
The remote reference.
rr - Variable in class jadex.platform.service.remote.commands.RemoteDGCRemoveReferenceCommand
The remote reference.
rr - Variable in class jadex.platform.service.remote.commands.RemoteMethodInvocationCommand
The remote reference.
rr - Variable in class jadex.platform.service.remote.ProxyReference
The remote reference.
rrm - Variable in class jadex.platform.service.remote.RemoteServiceManagementService
The remote reference module.
rrm - Variable in class jadex.platform.service.remote.xml.RMIPostProcessor
The remote reference module.
rrm - Variable in class jadex.platform.service.remote.xml.RMIPreProcessor
The remote reference module.
rseqno - Variable in class jadex.platform.service.message.streams.InputConnectionHandler
The last in order received sequence number.
rsms - Variable in class jadex.platform.service.remote.RemoteMethodInvocationHandler
The remote service management service.
rsms - Variable in class jadex.platform.service.remote.RemoteReferenceModule
The remote management service.
rule - Variable in class jadex.platform.service.ecarules.RuleAddedEvent
The rule.
RuleAddedEvent - Class in jadex.platform.service.ecarules
 
RuleAddedEvent() - Constructor for class jadex.platform.service.ecarules.RuleAddedEvent
Create a new rule added event.
RuleAddedEvent(int, IRule<?>) - Constructor for class jadex.platform.service.ecarules.RuleAddedEvent
Create a new rule added event.
RuleAddedEvent(RuleAddedEvent) - Constructor for class jadex.platform.service.ecarules.RuleAddedEvent
Create a new rule added event.
RuleAgent - Class in jadex.platform.service.ecarules
Agent that exposes an eca rule engine as service.
RuleAgent() - Constructor for class jadex.platform.service.ecarules.RuleAgent
 
rulebase - Variable in class jadex.platform.service.ecarules.RulebaseAgent
The rulebase.
RulebaseAgent - Class in jadex.platform.service.ecarules
Agent that encapsulates a rulebase and allows for tracking changes of it.
RulebaseAgent() - Constructor for class jadex.platform.service.ecarules.RulebaseAgent
 
rulename - Variable in class jadex.platform.service.ecarules.RuleRemovedEvent
The rule name.
RuleRemovedEvent - Class in jadex.platform.service.ecarules
 
RuleRemovedEvent() - Constructor for class jadex.platform.service.ecarules.RuleRemovedEvent
Create a new rule added event.
RuleRemovedEvent(int, String) - Constructor for class jadex.platform.service.ecarules.RuleRemovedEvent
Create a new rule removed event.
RuleRemovedEvent(RuleRemovedEvent) - Constructor for class jadex.platform.service.ecarules.RuleRemovedEvent
Create a new rule removed event.
rulesystem - Variable in class jadex.platform.service.ecarules.ClientRuleSystemAgent
The rule system.
rulesystem - Variable in class jadex.platform.service.ecarules.RuleAgent
The rule engine.
run() - Method in class jadex.platform.service.message.transport.httprelaymtp.HttpReceiver.TimeoutTask
 
run() - Method in class jadex.platform.service.message.transport.httprelaymtp.HttpRelayTransport.Worker
 
run() - Method in class jadex.platform.service.message.transport.niotcpmtp.SelectorThread
Main cycle.
run() - Method in class jadex.platform.service.remote.RemoteServiceManagementService.TimeoutTimerTask
Run the task.
running - Variable in class jadex.platform.service.chat.ChatService
Flag to avoid duplicate initialization/shutdown due to duplicate use of implementation.
running - Variable in class jadex.platform.service.cms.ComponentManagementService
Flag to avoid double initialization.
running - Variable in class jadex.platform.service.message.transport.niotcpmtp.SelectorThread
Flag indicating the thread should be running (set to false for shutdown).
runningexes - Variable in class jadex.platform.service.execution.AsyncExecutionService
The running (i.e.

S

saveKeyStore() - Method in class jadex.platform.service.security.SecurityService
Save the keystore.
saveonexit - Variable in class jadex.platform.service.settings.SettingsService
Save settings on exit?.
saveProperties() - Method in class jadex.platform.service.settings.SettingsService
Save the platform properties to the default location.
saveProperties(boolean) - Method in class jadex.platform.service.settings.SettingsService
Save the platform properties to the default location.
sc - Variable in class jadex.platform.service.message.transport.niotcpmtp.NIOTCPInputConnection
The socket channel for receiving messages.
sc - Variable in class jadex.platform.service.message.transport.niotcpmtp.NIOTCPOutputConnection
The socket channel.
scan() - Method in class jadex.platform.service.awareness.discovery.local.LocalDiscoveryAgent
Scans for new local awareness infos.
scanfactor - Variable in class jadex.platform.service.awareness.discovery.ipscanner.ScannerDiscoveryAgent
The scan delay factor.
ScannerDiscoveryAgent - Class in jadex.platform.service.awareness.discovery.ipscanner
Agent that sends multicasts to locate other Jadex awareness agents.
ScannerDiscoveryAgent() - Constructor for class jadex.platform.service.awareness.discovery.ipscanner.ScannerDiscoveryAgent
 
ScannerReceiveHandler - Class in jadex.platform.service.awareness.discovery.ipscanner
Receiver handler for scanner.
ScannerReceiveHandler(ScannerDiscoveryAgent) - Constructor for class jadex.platform.service.awareness.discovery.ipscanner.ScannerReceiveHandler
Create a new receive handler.
ScannerSendHandler - Class in jadex.platform.service.awareness.discovery.ipscanner
Handle sending.
ScannerSendHandler(DiscoveryAgent) - Constructor for class jadex.platform.service.awareness.discovery.ipscanner.ScannerSendHandler
Create a new lease time handling object.
scheduleAdvanceClock() - Method in class jadex.platform.service.simulation.SimulationService
Start clock execution.
scheduleStep(IComponentStep<E>) - Method in class jadex.platform.service.message.streams.AbstractConnectionHandler
Schedule a step on the message service component.
schedulestep - Static variable in class jadex.platform.service.remote.RemoteMethodInvocationHandler
 
SCHEMAS - Static variable in class jadex.platform.service.message.transport.localmtp.LocalTransport
The schema name.
SCHEMAS - Static variable in class jadex.platform.service.message.transport.niotcpmtp.NIOTCPTransport
The schema name.
SCHEMAS - Static variable in class jadex.platform.service.message.transport.tcpmtp.TCPTransport
The schema name.
scope - Variable in class jadex.platform.service.remote.commands.RemoteSearchCommand
The scope.
search(IDFComponentDescription, ISearchConstraints) - Method in class jadex.platform.service.df.DirectoryFacilitatorService
Search for components matching the given description.
search(IDFComponentDescription, ISearchConstraints, boolean) - Method in class jadex.platform.service.df.DirectoryFacilitatorService
Search for components matching the given description.
searchComponents(IComponentDescription, ISearchConstraints) - Method in class jadex.platform.service.cms.ComponentManagementService
Search for components matching the given description.
searchComponents(IComponentDescription, ISearchConstraints, boolean) - Method in class jadex.platform.service.cms.ComponentManagementService
Search for components matching the given description.
secser - Variable in class jadex.platform.service.security.AAcquisitionMechanism
The component.
secure - Variable in class jadex.platform.service.message.transport.httprelaymtp.HttpRelayTransport
Flag if receiver connection should use https.
secure - Variable in class jadex.platform.service.remote.ProxyInfo
The secure transport methods.
secureAddress(String) - Static method in class jadex.platform.service.message.transport.httprelaymtp.RelayConnectionManager
Convert a potential non-https address to an https address.
SecurityAgent - Class in jadex.platform.service.security
Agent that provides the security service.
SecurityAgent() - Constructor for class jadex.platform.service.security.SecurityAgent
 
securitylevel - Variable in class jadex.platform.service.remote.commands.RemoteMethodInvocationCommand
The security level (set by postprocessing).
securitylevel - Variable in class jadex.platform.service.remote.commands.RemoteSearchCommand
The security level (set by postprocessing).
SecurityService - Class in jadex.platform.service.security
 
SecurityService() - Constructor for class jadex.platform.service.security.SecurityService
Create a security service.
SecurityService(Boolean, boolean, Boolean, String[], String[]) - Constructor for class jadex.platform.service.security.SecurityService
Create a security service.
SecurityService(Boolean, boolean, Boolean, String[], String[], AAcquisitionMechanism[], Map<String, Set<String>>, Long) - Constructor for class jadex.platform.service.security.SecurityService
Create a security service.
selectComponentFactory(Iterator<IComponentFactory>, String, CreationInfo, IResourceIdentifier) - Method in class jadex.platform.service.cms.ComponentManagementService
Selects a component factory from a collection of factories.
selectFallbackFactory(String, CreationInfo, IResourceIdentifier) - Method in class jadex.platform.service.cms.ComponentManagementService
Select the fallback factory.
selector - Variable in class jadex.platform.service.awareness.discovery.ipscanner.ScannerDiscoveryAgent
 
selector - Variable in class jadex.platform.service.message.transport.niotcpmtp.SelectorThread
The NIO selector.
selectorthread - Variable in class jadex.platform.service.message.transport.niotcpmtp.NIOTCPTransport
The selector thread.
SelectorThread - Class in jadex.platform.service.message.transport.niotcpmtp
The selector thread waits for NIO events and issues the appropriate actions for asynchronous sending and receiving as data becomes available.
SelectorThread(Selector, IMessageService, Logger) - Constructor for class jadex.platform.service.message.transport.niotcpmtp.SelectorThread
Create a NIO selector thread.
SelectorThread.Cleaner - Class in jadex.platform.service.message.transport.niotcpmtp
Class for cleaning output connections after max keep alive time has been reached.
selectServer(String) - Method in class jadex.platform.service.message.transport.httprelaymtp.HttpReceiver
Select a server to connect to.
selmech - Variable in class jadex.platform.service.security.SecurityService
The currently selected mechanism.
send(AwarenessInfo) - Method in class jadex.platform.service.awareness.discovery.ipbroadcast.BroadcastSendHandler
Method to send messages.
send(byte[], InetAddress, int) - Method in class jadex.platform.service.awareness.discovery.ipbroadcast.BroadcastSendHandler
Send a packet.
send(AwarenessInfo) - Method in class jadex.platform.service.awareness.discovery.ipmulticast.MulticastSendHandler
Method to send messages.
send(byte[], InetAddress, int) - Method in class jadex.platform.service.awareness.discovery.ipmulticast.MulticastSendHandler
Send a packet.
send(AwarenessInfo) - Method in class jadex.platform.service.awareness.discovery.ipscanner.ScannerSendHandler
Method to send messages.
send(byte[], InetAddress, int) - Method in class jadex.platform.service.awareness.discovery.ipscanner.ScannerSendHandler
Send a packet.
send(AwarenessInfo) - Method in class jadex.platform.service.awareness.discovery.MasterSlaveSendHandler
Method to send messages.
send(byte[], InetAddress, int) - Method in class jadex.platform.service.awareness.discovery.MasterSlaveSendHandler
Send a packet.
send(AwarenessInfo) - Method in class jadex.platform.service.awareness.discovery.SendHandler
Method to send messages.
send(byte[]) - Method in interface jadex.platform.service.message.streams.IOutputConnectionHandler
Called from connection.
send(byte[]) - Method in class jadex.platform.service.message.streams.LocalOutputConnectionHandler
Called from connection.
send(byte[]) - Method in class jadex.platform.service.message.streams.OutputConnectionHandler
Called from connection.
send(byte[], byte[], ISendTask) - Method in class jadex.platform.service.message.transport.tcpmtp.TCPOutputConnection
Send a message.
sendAcknowledgedMessage(AbstractSendTask, Object) - Method in class jadex.platform.service.message.streams.AbstractConnectionHandler
Send a message and wait for an ack.
sendAcknowledgedMultiPacket() - Method in class jadex.platform.service.message.streams.OutputConnectionHandler
Called internally.
sendAddRemoteReference(RemoteReference) - Method in class jadex.platform.service.remote.RemoteReferenceModule
Send addRef to the origin process of the remote reference.
sendAlive() - Method in class jadex.platform.service.message.streams.AbstractConnectionHandler
Send alive message.
sendcount - Variable in class jadex.platform.service.awareness.discovery.ipscanner.ScannerSendHandler
The send count.
sendData(StreamSendTask) - Method in class jadex.platform.service.message.streams.OutputConnectionHandler
Send or resend a data message.
sendDataAck() - Method in class jadex.platform.service.message.streams.InputConnectionHandler
Send ack data.
sendDataAck(int, int, boolean) - Method in class jadex.platform.service.message.streams.InputConnectionHandler
 
sendEmail(Email, EmailAccount) - Method in class jadex.platform.service.email.EmailAgent
Send an email.
sender - Variable in class jadex.platform.service.awareness.discovery.DiscoveryAgent
The send handler.
sender - Variable in class jadex.platform.service.remote.commands.RemoteResultCommand
The sending component.
sendFile(String, String, long, String, IInputConnection) - Method in class jadex.platform.service.chat.ChatService
Send a file.
sendFile(String, IComponentIdentifier) - Method in class jadex.platform.service.chat.ChatService
Send a local file to the target component.
SendHandler - Class in jadex.platform.service.awareness.discovery
Automatically reinvokes send method in intervals determined by the delay (in state).
SendHandler(DiscoveryAgent) - Constructor for class jadex.platform.service.awareness.discovery.SendHandler
Create a new lease time handling object.
sendid - Variable in class jadex.platform.service.awareness.discovery.ReceiveHandler
The current send id.
sendid - Variable in class jadex.platform.service.awareness.discovery.SendHandler
The current send id.
sendInfo(boolean) - Method in class jadex.platform.service.awareness.discovery.relay.RelayDiscoveryAgent
Send an awareness info.
SendInfo(AbstractSendTask, Object, int, TimerTask, Future<Object>) - Constructor for class jadex.platform.service.message.streams.AbstractConnectionHandler.SendInfo
Create a new send info.
sendInit() - Method in class jadex.platform.service.message.streams.AbstractConnectionHandler
Send init message.
sendInit() - Method in interface jadex.platform.service.message.streams.IAbstractConnectionHandler
Send init message.
sendInit() - Method in class jadex.platform.service.message.streams.LocalAbstractConnectionHandler
Send init message.
SendManager() - Constructor for class jadex.platform.service.message.MessageService.SendManager
Send manager.
sendMessage(Map<String, Object>, MessageType, IComponentIdentifier, IResourceIdentifier, IComponentIdentifier, byte[]) - Method in class jadex.platform.service.message.MessageService
Send a message.
sendMessage(String, ISendTask) - Method in class jadex.platform.service.message.transport.httprelaymtp.HttpRelayTransport
Send a message to the given address.
sendMessage(String, ISendTask) - Method in interface jadex.platform.service.message.transport.ITransport
Send a message to the given address.
sendMessage(String, ISendTask) - Method in class jadex.platform.service.message.transport.localmtp.LocalTransport
Send a message to the given address.
sendMessage(String, ISendTask) - Method in class jadex.platform.service.message.transport.niotcpmtp.NIOTCPTransport
Send a message to the given address.
sendMessage(NIOTCPOutputConnection, byte[], byte[]) - Method in class jadex.platform.service.message.transport.niotcpmtp.SelectorThread
Send a message using the given connection.
sendMessage(String, ISendTask) - Method in class jadex.platform.service.message.transport.tcpmtp.TCPTransport
Send a message to the given address.
sendMessage(IComponentIdentifier, IComponentIdentifier, Object, String, long, Future<Object>, Map<String, Object>, Object) - Method in class jadex.platform.service.remote.RemoteServiceManagementService
Send the request message of a remote method invocation.
sendqueue - Variable in class jadex.platform.service.message.transport.httprelaymtp.HttpRelayTransport
The send queue per address (tasks to send on worker thread).
sendRemoveRemoteReference(RemoteReference) - Method in class jadex.platform.service.remote.RemoteReferenceModule
Send removeRef to the origin process of the remote reference.
sendStored() - Method in class jadex.platform.service.message.streams.OutputConnectionHandler
Called internally.
sendTask(AbstractSendTask) - Method in class jadex.platform.service.message.streams.AbstractConnectionHandler
Send a task.
sendTo(String, IComponentIdentifier, boolean) - Method in class jadex.platform.service.chat.ChatService
Helper method for sending message to cid.
sendToDiscover(byte[], int) - Method in class jadex.platform.service.awareness.discovery.ipbroadcast.BroadcastSendHandler
Send/forward to discover.
sendToDiscover(byte[], int) - Method in class jadex.platform.service.awareness.discovery.ipscanner.ScannerSendHandler
Send/forward to discover.
sendToDiscover(byte[]) - Method in class jadex.platform.service.awareness.discovery.MasterSlaveSendHandler
Send/forward to discover.
sendToDiscover(byte[], int) - Method in class jadex.platform.service.awareness.discovery.MasterSlaveSendHandler
Send/forward to discover.
sendToLocals(byte[]) - Method in class jadex.platform.service.awareness.discovery.MasterSlaveSendHandler
Send/forward to locals.
sendToMaster(byte[]) - Method in class jadex.platform.service.awareness.discovery.ipbroadcast.BroadcastSendHandler
Send to local masters.
sendToMaster(byte[]) - Method in class jadex.platform.service.awareness.discovery.ipscanner.ScannerSendHandler
Send to local masters.
sendToMaster(byte[]) - Method in class jadex.platform.service.awareness.discovery.MasterSlaveSendHandler
Send to local masters.
sendToRemotes(byte[]) - Method in class jadex.platform.service.awareness.discovery.MasterSlaveSendHandler
Send awareness info to remote scanner services.
sendToRemotes(byte[], int) - Method in class jadex.platform.service.awareness.discovery.MasterSlaveSendHandler
Send awareness info to remote scanner services.
SensorHolderAgent - Class in jadex.platform.sensor
Component that holds the sensors in the platform.
SensorHolderAgent() - Constructor for class jadex.platform.sensor.SensorHolderAgent
 
sent - Variable in class jadex.platform.service.message.streams.OutputConnectionHandler
The data sent (not acknowledged).
seqnumber - Variable in class jadex.platform.service.message.streams.OutputConnectionHandler
The current sequence number.
seqnumber - Variable in class jadex.platform.service.message.streams.StreamSendTask
The sequence number.
SerialCodec - Class in jadex.platform.service.message.transport.codecs
The serial codec allows for encoding and decoding objects via the Java serialization mechanism.
SerialCodec() - Constructor for class jadex.platform.service.message.transport.codecs.SerialCodec
 
serversocket - Variable in class jadex.platform.service.message.transport.tcpmtp.TCPTransport
The server socket for receiving messages.
set(IFinger) - Method in class jadex.platform.service.dht.Finger
Use nodeId and Sid of the given finger.
setAccount(EmailAccount) - Method in class jadex.platform.service.email.SubscriptionInfo
Set the account.
setAcquisitionMechanism(Class<?>) - Method in class jadex.platform.service.security.SecurityService
Set the acquire mechanism.
setAcquisitionMechanismParameterValue(Class<?>, String, Object) - Method in class jadex.platform.service.security.SecurityService
Set a mechanism parameter.
setAddressInfo(InetAddress, int) - Method in class jadex.platform.service.awareness.discovery.ipmulticast.MulticastDiscoveryAgent
Set the address.
setAliveTime(long) - Method in class jadex.platform.service.message.streams.AbstractConnectionHandler
Set the alive time of the other connection side.
setAutoCreateProxy(boolean) - Method in class jadex.platform.service.awareness.management.AwarenessManagementAgent
Set the autocreate.
setAutoDeleteProxy(boolean) - Method in class jadex.platform.service.awareness.management.AwarenessManagementAgent
Set the autodelete.
setCache(Map<String, Object>) - Method in class jadex.platform.service.remote.ProxyReference
Set the cached values.
setCaller(IComponentIdentifier) - Method in class jadex.platform.service.remote.commands.RemoteMethodInvocationCommand
Set the caller.
setCallId(int) - Method in class jadex.platform.service.ecarules.ARulebaseEvent
Set the callid.
setCallId(String) - Method in class jadex.platform.service.remote.commands.RemoteDGCAddReferenceCommand
Set the callid.
setCallId(String) - Method in class jadex.platform.service.remote.commands.RemoteDGCRemoveReferenceCommand
Set the callid.
setCallId(String) - Method in class jadex.platform.service.remote.commands.RemoteFutureBackwardCommand
Set the call id.
setCallId(String) - Method in class jadex.platform.service.remote.commands.RemoteFuturePullCommand
Set the call id.
setCallId(String) - Method in class jadex.platform.service.remote.commands.RemoteFutureTerminationCommand
Set the call id.
setCallId(String) - Method in class jadex.platform.service.remote.commands.RemoteGetExternalAccessCommand
Set the callid.
setCallId(String) - Method in class jadex.platform.service.remote.commands.RemoteMethodInvocationCommand
Set the callid.
setCallId(String) - Method in class jadex.platform.service.remote.commands.RemoteResultCommand
Set the callid.
setCallId(String) - Method in class jadex.platform.service.remote.commands.RemoteSearchCommand
Set the callid.
setClock(String, IThreadPool) - Method in class jadex.platform.service.clock.ClockService
Set the clock.
setClockType(String) - Method in class jadex.platform.service.clock.ClockCreationInfo
Set the clocktype.
setClockType(String) - Method in class jadex.platform.service.simulation.SimulationService
Set the clock type.
setClosed() - Method in class jadex.platform.service.message.streams.AbstractConnection
Set the connection to closed.
setClosed() - Method in class jadex.platform.service.message.streams.InputConnection
Set the stream to be closed.
setClosed() - Method in class jadex.platform.service.message.streams.OutputConnectionHandler
Set the connection closed.
setClosing() - Method in class jadex.platform.service.message.streams.AbstractConnection
Set the connection to closed.
setCmdCallid(String) - Method in class jadex.platform.service.remote.commands.RemoteFutureBackwardCommand
Set the cmdcallid.
setCnt(int) - Method in class jadex.platform.service.remote.RemoteServiceManagementService.WaitingCallInfo
Set the cnt.
setComponentBreakpoints(IComponentIdentifier, String[]) - Method in class jadex.platform.service.cms.ComponentManagementService
Set breakpoints for a component.
setComponentState(IComponentIdentifier, String) - Method in class jadex.platform.service.cms.ComponentManagementService
Set the state of a component (i.e.
setConnection(AbstractConnection) - Method in class jadex.platform.service.message.streams.AbstractConnectionHandler
Set the connection (needed as connection and handler need each other).
setConnection(AbstractConnection) - Method in interface jadex.platform.service.message.streams.IAbstractConnectionHandler
Set the connection (needed as connection and handler need each other).
setConnection(AbstractConnection) - Method in class jadex.platform.service.message.streams.LocalAbstractConnectionHandler
Set the connection (needed as connection and handler need each other).
setConnectionHandler(LocalAbstractConnectionHandler) - Method in class jadex.platform.service.message.streams.LocalAbstractConnectionHandler
Set the connection handler of the other side.
setContentCodecInfo(IComponentIdentifier, Map<Class<?>, Object[]>) - Method in class jadex.platform.service.message.MessageService
Get a matching content codec.
setCount(int) - Method in class jadex.platform.service.remote.commands.RemoteIntermediateResultCommand
Set the cnt.
setDefaultCodecIds(byte[]) - Method in class jadex.platform.service.message.transport.codecs.CodecFactory
Set the default decoder/encoder id.
setDelay(long) - Method in class jadex.platform.service.awareness.discovery.DiscoveryAgent
Set the delay.
setDelay(long) - Method in class jadex.platform.service.awareness.discovery.local.LocalDiscoveryAgent
Set the send delay.
setDelay(long) - Method in class jadex.platform.service.awareness.management.AwarenessManagementAgent
Set the delay.
setDelta(long) - Method in class jadex.platform.service.clock.AbstractClock
Set the clock delta.
setDelta(long) - Method in class jadex.platform.service.clock.ClockCreationInfo
Set the delta.
setDelta(long) - Method in class jadex.platform.service.clock.ClockService
Set the clock delta.
setDilation(double) - Method in class jadex.platform.service.clock.ClockCreationInfo
Set the dilation.
setDilation(double) - Method in class jadex.platform.service.clock.ClockService
Set the clocks dilation.
setDilation(double) - Method in class jadex.platform.service.clock.ContinuousClock
Set the clocks dilation.
setDilation(double) - Method in interface jadex.platform.service.clock.IContinuousClock
Set the clocks dilation.
setDiscoveryMechanismState(String, boolean) - Method in class jadex.platform.service.awareness.management.AwarenessManagementAgentHelper
Enables or disables Discovery Mechanisms.
setEndSequenceNumber(int) - Method in class jadex.platform.service.message.streams.AckInfo
Set the endSequenceNumber.
setEntry(Object) - Method in class jadex.platform.service.awareness.discovery.DiscoveryEntry
Set the entry.
setException(Exception) - Method in class jadex.platform.service.remote.commands.RemoteFuturePullCommand
Set the exception.
setException(Exception) - Method in class jadex.platform.service.remote.commands.RemoteFutureTerminationCommand
Set the exception.
setException(Exception) - Method in class jadex.platform.service.remote.commands.RemoteResultCommand
Set the exception.
setExcludedMethods(Set<MethodInfo>) - Method in class jadex.platform.service.remote.ProxyInfo
Set the excluded.
setExcludes(String[]) - Method in class jadex.platform.service.awareness.discovery.DiscoveryAgent
Set the excludes.
setExcludes(String[]) - Method in class jadex.platform.service.awareness.discovery.local.LocalDiscoveryAgent
Set the excludes.
setExcludes(String[]) - Method in class jadex.platform.service.awareness.discovery.relay.RelayDiscoveryAgent
Set the excludes.
setExcludes(String[]) - Method in class jadex.platform.service.awareness.management.AwarenessManagementAgent
Set the excludes.
setExecuting(boolean) - Method in class jadex.platform.service.simulation.SimulationService
Set the executing state.
setExpiryDate(long) - Method in class jadex.platform.service.remote.RemoteReferenceHolder
Set the expirydate.
setFast(boolean) - Method in class jadex.platform.service.awareness.discovery.DiscoveryAgent
Set the fast startup awareness flag
setFast(boolean) - Method in class jadex.platform.service.awareness.discovery.local.LocalDiscoveryAgent
Set the fast awareness flag.
setFastAwareness(boolean) - Method in class jadex.platform.service.awareness.management.AwarenessManagementAgent
Set the fast startup awareness flag
setFilter(Filter) - Method in class jadex.platform.service.cms.LoggerWrapper
Set a filter to control output on this Logger.
setFilter(IFilter<Email>) - Method in class jadex.platform.service.email.SubscriptionInfo
Set the filter.
setFilter(IAsyncFilter<IService>) - Method in class jadex.platform.service.remote.commands.RemoteSearchCommand
Set the filter.
setFinished(IBackwardCommandFuture) - Method in class jadex.platform.service.ecarules.ARulebaseEvent
 
setFinished(boolean) - Method in class jadex.platform.service.remote.commands.RemoteIntermediateResultCommand
Set the finished.
setFuture(Future<Object>) - Method in class jadex.platform.service.remote.RemoteServiceManagementService.WaitingCallInfo
Set the future.
setHolder(IComponentIdentifier) - Method in class jadex.platform.service.remote.commands.RemoteDGCAddReferenceCommand
Set the holder.
setHolder(IComponentIdentifier) - Method in class jadex.platform.service.remote.commands.RemoteDGCRemoveReferenceCommand
Set the holder.
setHolder(IComponentIdentifier) - Method in class jadex.platform.service.remote.RemoteReferenceHolder
Set the holder.
setId(byte[]) - Method in class jadex.platform.service.dht.ID
Sets the internal byte array.
setId(int) - Method in class jadex.platform.service.ecarules.ARulebaseEvent
Set the id.
setId(Object) - Method in class jadex.platform.service.message.streams.AbstractConnectionHandler.SendInfo
Set the id.
setIdle() - Method in class jadex.platform.service.simulation.SimulationService
Stop execution.
setImage(byte[]) - Method in class jadex.platform.service.chat.ChatService
Set the image.
setIncludes(String[]) - Method in class jadex.platform.service.awareness.discovery.DiscoveryAgent
Set the includes.
setIncludes(String[]) - Method in class jadex.platform.service.awareness.discovery.local.LocalDiscoveryAgent
Set the includes.
setIncludes(String[]) - Method in class jadex.platform.service.awareness.discovery.relay.RelayDiscoveryAgent
Set the includes.
setIncludes(String[]) - Method in class jadex.platform.service.awareness.management.AwarenessManagementAgent
Set the includes.
setInfo(AwarenessInfo) - Method in class jadex.platform.service.awareness.discovery.DiscoveryEntry
Set the info.
setInfo(Object) - Method in class jadex.platform.service.remote.commands.RemoteFutureBackwardCommand
Set the info.
setInited() - Method in class jadex.platform.service.message.streams.AbstractConnection
Set the inited.
setInitialized(boolean) - Method in class jadex.platform.service.dht.DistributedKVStoreService
Sets the initialized flag.
setInitialized(boolean) - Method in class jadex.platform.service.dht.RingNodeService
Sets the initialized flag.
setInitiator(ITransportComponentIdentifier) - Method in class jadex.platform.service.message.streams.InitInfo
Set the initiator.
setInvalid(IFinger) - Method in class jadex.platform.service.dht.Fingertable
Marks a finger entry as invalid by setting its node entry to the local node.
setKeystoreInfo(String, String, String) - Method in class jadex.platform.service.security.SecurityService
Set the keystore info.
setKilled(boolean) - Method in class jadex.platform.service.awareness.discovery.DiscoveryAgent
Set the killed.
setLastSeenMsg(Email) - Method in class jadex.platform.service.email.SubscriptionInfo
Set the lastseenmsg.
setLastSeenNo(int) - Method in class jadex.platform.service.email.SubscriptionInfo
Set the lastseenno.
setLevel(Level) - Method in class jadex.platform.service.cms.LoggerWrapper
Set the log level specifying which message levels will be logged by this logger.
setLocalPassword(String) - Method in class jadex.platform.service.security.SecurityService
Set the local password.
setMessage(Map<String, Object>) - Method in class jadex.platform.service.message.transport.MessageEnvelope
Set native message.
setMethodName(String) - Method in class jadex.platform.service.remote.commands.RemoteMethodInvocationCommand
Set the methodname.
setMethodName(String) - Method in class jadex.platform.service.remote.commands.RemoteResultCommand
Set the methodname.
setMethodReplacements(Map<MethodInfo, IMethodReplacement>) - Method in class jadex.platform.service.remote.ProxyInfo
Set the replacements.
setMethodTimeouts(Map<MethodInfo, Long>) - Method in class jadex.platform.service.remote.ProxyInfo
Set the timeouts.
setMode(String) - Method in class jadex.platform.service.simulation.SimulationService
Set the execution mode.
setMultiple(boolean) - Method in class jadex.platform.service.remote.commands.RemoteSearchCommand
Set the multiple.
setName(String) - Method in class jadex.platform.service.clock.ClockCreationInfo
Set the name.
setNetworkPassword(String, String) - Method in class jadex.platform.service.security.SecurityService
Set the password for a network.
setNickName(String) - Method in class jadex.platform.service.chat.ChatService
Set the user name.
setNodeId(IID) - Method in class jadex.platform.service.dht.Finger
Set the Node ID of this Finger.
setNonFunctionalProperties(Map<String, Object>) - Method in class jadex.platform.service.message.streams.AbstractConnectionHandler
Set the non-functional properties.
setNonFunctionalProperties(Map<String, Object>) - Method in class jadex.platform.service.message.streams.InitInfo
Set the nonFunctionalProperties.
setNonFunctionalProperties(Map<String, Object>) - Method in class jadex.platform.service.remote.commands.AbstractRemoteCommand
Get the non-functional properties of the call.
setNotificationTime(long) - Method in class jadex.platform.service.clock.TickTimer
Change notification time.
setNotificationTime(long) - Method in class jadex.platform.service.clock.Timer
Change notification time.
setNumber(int) - Method in class jadex.platform.service.remote.TemporaryRemoteReferenceHolder
Set the number.
setOverlayId(String) - Method in class jadex.platform.service.dht.OverlayIdFilter
 
setParameterTypes(Class[]) - Method in class jadex.platform.service.remote.commands.RemoteMethodInvocationCommand
Set the parametertypes.
setParameterValue(String, Object) - Method in class jadex.platform.service.security.AAcquisitionMechanism
Set a mechanism parameter value.
setParameterValue(String, Object) - Method in class jadex.platform.service.security.DecentralizedAcquisitionMechanism
Set a mechanism parameter value.
setParameterValue(String, Object) - Method in class jadex.platform.service.security.TTPAcquisitionMechanism
Set a mechanism parameter value.
setParameterValues(Object[]) - Method in class jadex.platform.service.remote.commands.RemoteMethodInvocationCommand
Set the parametervalues.
setParent(Logger) - Method in class jadex.platform.service.cms.LoggerWrapper
Set the parent for this Logger.
setParticipant(ITransportComponentIdentifier) - Method in class jadex.platform.service.message.streams.InitInfo
Set the participant.
setPlatformPassword(IComponentIdentifier, String) - Method in class jadex.platform.service.security.SecurityService
Set the password for a target component.
setPredecessor(IFinger) - Method in class jadex.platform.service.dht.Fingertable
Sets the predecessor of the local node.
setPredecessor(IFinger) - Method in class jadex.platform.service.dht.RingNodeService
Set the predecessor of this node.
setProperties(Properties) - Method in class jadex.platform.service.awareness.management.AwarenessManagementAgent
Update from given properties.
setProperties(Properties) - Method in class jadex.platform.service.chat.ChatService.PropProvider
Update from given properties.
setProperties(Properties) - Method in class jadex.platform.service.clock.ClockService
Update from given properties.
setProperties(Properties) - Method in class jadex.platform.service.library.LibraryService
Update from given properties.
setProperties(Properties) - Method in class jadex.platform.service.security.AAcquisitionMechanism
Set the properties of the mechanism.
setProperties(Properties) - Method in class jadex.platform.service.security.DecentralizedAcquisitionMechanism
Set the properties of the mechanism.
setProperties(Properties) - Method in class jadex.platform.service.security.TTPAcquisitionMechanism
Set the properties of the mechanism.
setProperties(String, Properties) - Method in class jadex.platform.service.settings.SettingsService
Set the properties for a given id.
setProperties(Properties) - Method in class jadex.platform.service.simulation.SimulationService
Update from given properties.
setProviderId(IComponentIdentifier) - Method in class jadex.platform.service.remote.commands.RemoteSearchCommand
Set the providerid.
setProxyInfo(ProxyInfo) - Method in class jadex.platform.service.remote.ProxyReference
Set the pi.
setPullCallId(String) - Method in class jadex.platform.service.remote.commands.RemoteFuturePullCommand
Set the pullcallid.
setReceivers(IComponentIdentifier[]) - Method in class jadex.platform.service.message.transport.MessageEnvelope
Get the receivers.
setReferenceProperties(Class, boolean, boolean) - Method in class jadex.platform.service.marshal.MarshalService
Register a class with reference values for local and remote.
setRemoteComponentIdentifier(ITransportComponentIdentifier) - Method in class jadex.platform.service.remote.ProxyAgent
Set or update the component identifier of the remote platform, i.e., top reflect new transport addresses.
setRemoteManagementServiceIdentifier(ITransportComponentIdentifier) - Method in class jadex.platform.service.remote.RemoteReference
Set the rms.
setRemoteReference(RemoteReference) - Method in class jadex.platform.service.remote.commands.RemoteDGCAddReferenceCommand
Set the rr.
setRemoteReference(RemoteReference) - Method in class jadex.platform.service.remote.commands.RemoteDGCRemoveReferenceCommand
Set the rr.
setRemoteReference(RemoteReference) - Method in class jadex.platform.service.remote.commands.RemoteMethodInvocationCommand
Set the remote reference.
setRemoteReference(RemoteReference) - Method in class jadex.platform.service.remote.ProxyReference
Set the remote reference.
setResourceIdentifier(IResourceIdentifier) - Method in class jadex.platform.service.library.DelegationURLClassLoader
Set the rid.
setResponses(int) - Method in class jadex.platform.service.security.DecentralizedAcquisitionMechanism
Set the responses.
setResult(Future<Object>) - Method in class jadex.platform.service.message.streams.AbstractConnectionHandler.SendInfo
Set the result.
setResult(Object) - Method in class jadex.platform.service.remote.commands.RemoteResultCommand
Set the result.
setReturnValueReference(boolean) - Method in class jadex.platform.service.remote.commands.RemoteMethodInvocationCommand
Set the returnisref.
setRingService(IRingApplicationService) - Method in class jadex.platform.service.dht.DistributedKVStoreService
Set the local ringNode.
setRoot(IComponentIdentifier) - Method in class jadex.platform.service.awareness.discovery.DiscoveryAgent
Set the root.
setRule(IRule<?>) - Method in class jadex.platform.service.ecarules.RuleAddedEvent
Set the rule.
setRulebaseService(IRulebaseService) - Method in class jadex.platform.service.ecarules.ClientRuleSystemAgent
 
setRuleName(String) - Method in class jadex.platform.service.ecarules.RuleRemovedEvent
Set the rulename.
setSaveOnExit(boolean) - Method in class jadex.platform.service.settings.SettingsService
Set the save on exit policy.
setScope(String) - Method in class jadex.platform.service.remote.commands.RemoteSearchCommand
Set the scope.
setSecureMethods(Set<MethodInfo>) - Method in class jadex.platform.service.remote.ProxyInfo
Set the secure.
setSender(IComponentIdentifier) - Method in class jadex.platform.service.remote.commands.RemoteResultCommand
Set the sender.
setSendId(String) - Method in class jadex.platform.service.awareness.discovery.SendHandler
Set the sendid.
setSettings(AwarenessSettingsData) - Method in class jadex.platform.service.awareness.management.AwarenessManagementAgentHelper
Transfers new Settings to the Agent.
setSid(IServiceIdentifier) - Method in class jadex.platform.service.dht.Finger
Set the SID of this Finger.
setStart(long) - Method in class jadex.platform.service.clock.ClockCreationInfo
Set the start.
setStart(IID) - Method in class jadex.platform.service.dht.Finger
Set the start IID Key of this Finger.
setStarted(boolean) - Method in class jadex.platform.service.awareness.discovery.DiscoveryAgent
Set the started.
setStartSequenceNumber(int) - Method in class jadex.platform.service.message.streams.AckInfo
Set the startSequenceNumber.
setStarttime(long) - Method in class jadex.platform.service.clock.AbstractClock
Set the clocks start time.
setStop(boolean) - Method in class jadex.platform.service.message.streams.AckInfo
Set the stop.
setSuccessor(IFinger) - Method in class jadex.platform.service.dht.Fingertable
Set the successor entry.
setSynchronousMethods(Set<MethodInfo>) - Method in class jadex.platform.service.remote.ProxyInfo
Set the synchronous.
setTargetId(IComponentIdentifier) - Method in class jadex.platform.service.remote.commands.RemoteGetExternalAccessCommand
Set the target id.
setTargetIdentifier(Object) - Method in class jadex.platform.service.remote.RemoteReference
Set the target id.
setTargetInterfaces(Class<?>[]) - Method in class jadex.platform.service.remote.ProxyInfo
Set the target remote interfaces.
setTargetResolverClazz(Class<ITargetResolver>) - Method in class jadex.platform.service.remote.ProxyInfo
Set the target determiner class.
setTask(AbstractSendTask) - Method in class jadex.platform.service.message.streams.AbstractConnectionHandler.SendInfo
Set the task.
setTerminateCallId(String) - Method in class jadex.platform.service.remote.commands.RemoteFutureTerminationCommand
Set the terminate call id.
setTime(long) - Method in class jadex.platform.service.awareness.discovery.DiscoveryEntry
Set the time.
setTime(long) - Method in class jadex.platform.service.clock.ClockService
Set the current time.
setTimer(TimerTask) - Method in class jadex.platform.service.message.streams.AbstractConnectionHandler.SendInfo
Set the timer.
setTimerTask(RemoteServiceManagementService.TimeoutTimerTask) - Method in class jadex.platform.service.remote.RemoteServiceManagementService.WaitingCallInfo
Set the timertask.
SETTINGS_EXTENSION - Static variable in class jadex.platform.service.settings.SettingsService
The filename extension for settings.
SettingsAgent - Class in jadex.platform.service.settings
Agent that provides the settings service.
SettingsAgent() - Constructor for class jadex.platform.service.settings.SettingsAgent
 
SettingsService - Class in jadex.platform.service.settings
Default settings service implementation.
SettingsService() - Constructor for class jadex.platform.service.settings.SettingsService
 
setTotal(int) - Method in class jadex.platform.service.email.SubscriptionInfo
Set the total.
setTrustedLanMode(boolean) - Method in class jadex.platform.service.security.SecurityService
Set the trusted lan mode.
setTryCnt(int) - Method in class jadex.platform.service.message.streams.AbstractConnectionHandler.SendInfo
Set the trycnt.
setTTPCid(IComponentIdentifier) - Method in class jadex.platform.service.security.TTPAcquisitionMechanism
Set the ttpcid.
setType(ClassInfo) - Method in class jadex.platform.service.remote.commands.RemoteSearchCommand
Set the type.
setTypeName(String) - Method in class jadex.platform.service.message.transport.MessageEnvelope
Set the type (e.g.
setUncachedMethods(Set<MethodInfo>) - Method in class jadex.platform.service.remote.ProxyInfo
Set the uncached.
setUseParentHandlers(boolean) - Method in class jadex.platform.service.cms.LoggerWrapper
Specify whether or not this logger should send its output to it's parent Logger.
setUsePassword(boolean) - Method in class jadex.platform.service.security.SecurityService
Enable / disable password protection.
setValidityDuration(long) - Method in class jadex.platform.service.security.SecurityService
Set the validity duration.
setverify(boolean) - Method in class jadex.platform.service.security.TTPAcquisitionMechanism
Set the verify.
severe(String) - Method in class jadex.platform.service.cms.LoggerWrapper
Log a SEVERE message.
shouldRetry() - Method in class jadex.platform.service.message.transport.niotcpmtp.NIOTCPDeadConnection
Test if it should be retried to reestablish the connection.
shouldRetry() - Method in class jadex.platform.service.message.transport.tcpmtp.TCPDeadConnection
Test if it should be retried to reestablish the connection.
shutdown() - Method in class jadex.platform.service.chat.ChatService
Called on shutdown.
shutdown(IResultListener) - Method in class jadex.platform.service.clock.AbstractClock
Shutdown the service.
shutdown() - Method in class jadex.platform.service.cms.PlatformComponent
Perform the shutdown of the component (if any).
shutdown() - Method in class jadex.platform.service.email.EmailAgent
Called when service is shudowned.
shutdown - Variable in class jadex.platform.service.message.transport.httprelaymtp.HttpReceiver
The shutdown flag.
shutdown() - Method in class jadex.platform.service.message.transport.httprelaymtp.HttpRelayTransport
Perform cleanup operations (if any).
shutdown() - Method in interface jadex.platform.service.message.transport.ITransport
Perform cleanup operations (if any).
shutdown() - Method in class jadex.platform.service.message.transport.localmtp.LocalTransport
Perform cleanup operations (if any).
shutdown - Variable in class jadex.platform.service.message.transport.niotcpmtp.NIOTCPTransport
Flag indicating that the transport was shut down.
shutdown() - Method in class jadex.platform.service.message.transport.niotcpmtp.NIOTCPTransport
Perform cleanup operations (if any).
shutdown() - Method in class jadex.platform.service.message.transport.niotcpmtp.SelectorThread
Set the running flag to false to gracefully terminate the thread.
shutdown() - Method in class jadex.platform.service.message.transport.tcpmtp.TCPTransport
Perform cleanup operations (if any).
shutdown() - Method in class jadex.platform.service.monitoring.MonitoringService
Notify subscribers that monitoring service is terminated.
shutdown() - Method in class jadex.platform.service.remote.RemoteReferenceModule
Shutdown the module.
shutdown() - Method in class jadex.platform.service.security.SecurityService
Shutdown the service.
shutdownService() - Method in class jadex.platform.service.clock.ClockService
Shutdown the service.
shutdownService() - Method in class jadex.platform.service.cms.ComponentManagementService
Shutdown the service.
shutdownService() - Method in class jadex.platform.service.context.ContextService
 
shutdownService() - Method in class jadex.platform.service.execution.AsyncExecutionService
Shutdown the executor service.
shutdownService() - Method in class jadex.platform.service.execution.SyncExecutionService
Shutdown the executor service.
shutdownService() - Method in class jadex.platform.service.library.LibraryService
Shutdown the service.
shutdownService() - Method in class jadex.platform.service.marshal.MarshalService
Shutdown the service.
shutdownService() - Method in class jadex.platform.service.message.MessageService
Called when the platform shuts down.
shutdownService() - Method in class jadex.platform.service.remote.RemoteServiceManagementService
Called when the service is shut down.
shutdownService() - Method in class jadex.platform.service.settings.SettingsService
Shutdown the service.
shutdownService() - Method in class jadex.platform.service.simulation.SimulationService
Shutdown the service.
shutdownService() - Method in class jadex.platform.service.threadpool.ThreadPoolService
Shutdown the service.
sid - Variable in class jadex.platform.service.cms.ComponentManagementService
 
sid - Variable in class jadex.platform.service.dht.Finger
ServiceIdentifier of the Node
sid - Variable in class jadex.platform.service.security.SecurityService
The service id.
signCall(byte[]) - Method in class jadex.platform.service.security.SecurityService
Sign a byte[] with the platform key that is stored in the keystore under the platform prefix name.
simulation - Variable in class jadex.platform.service.clock.ClockService
Was simulation set via argument?
SimulationAgent - Class in jadex.platform.service.simulation
Agent that provides the simulation service.
SimulationAgent() - Constructor for class jadex.platform.service.simulation.SimulationAgent
 
SimulationEventClock - Class in jadex.platform.service.clock
An event-driven simulation clock represents a discrete clock that is based on a event-list.
SimulationEventClock(String, long, long) - Constructor for class jadex.platform.service.clock.SimulationEventClock
Create a new clock.
SimulationEventClock(IClock) - Constructor for class jadex.platform.service.clock.SimulationEventClock
Create a new clock.
SimulationService - Class in jadex.platform.service.simulation
The execution control is the access point for controlling the execution of one application.
SimulationService() - Constructor for class jadex.platform.service.simulation.SimulationService
Create a new execution control.
SimulationService.IdleListener - Class in jadex.platform.service.simulation
Listener on the execution service.
SimulationTickClock - Class in jadex.platform.service.clock
A time-driven simulation clock represents a discrete clock that is based on ticks.
SimulationTickClock(String, long, long) - Constructor for class jadex.platform.service.clock.SimulationTickClock
Create a new clock.
SimulationTickClock(IClock) - Constructor for class jadex.platform.service.clock.SimulationTickClock
Create a new clock.
size - Variable in class jadex.platform.service.message.streams.InputConnection
The size.
sock - Variable in class jadex.platform.service.message.transport.tcpmtp.TCPInputConnection
The client socket.
sock - Variable in class jadex.platform.service.message.transport.tcpmtp.TCPOutputConnection
The client socket for sending data.
socket - Variable in class jadex.platform.service.awareness.discovery.ipbroadcast.BroadcastDiscoveryAgent
The socket.
socket - Variable in class jadex.platform.service.awareness.discovery.ipmulticast.MulticastDiscoveryAgent
The socket to send/receive.
socket - Variable in class jadex.platform.service.awareness.discovery.registry.RegistryDiscoveryAgent
The socket to send/receive.
sos - Variable in class jadex.platform.service.message.transport.tcpmtp.TCPOutputConnection
The output stream.
SRelay - Class in jadex.platform.service.message.transport.httprelaymtp
Constants and helper methods for relay server and transport.
SRelay() - Constructor for class jadex.platform.service.message.transport.httprelaymtp.SRelay
 
ssc - Variable in class jadex.platform.service.message.transport.niotcpmtp.NIOTCPTransport
The server socket for receiving messages.
stabilize() - Method in class jadex.platform.service.dht.RingNodeService
Check if my successor is correct.
STABILIZE_DELAY - Static variable in class jadex.platform.service.dht.RingNodeService
Delay in ms between two stabilize runs
start() - Method in class jadex.platform.service.awareness.discovery.local.LocalDiscoveryAgent
Implements the start.
start() - Method in class jadex.platform.service.chat.ChatService
Called on startup.
start() - Method in class jadex.platform.service.clock.AbstractClock
Start the clock.
start - Variable in class jadex.platform.service.clock.ClockCreationInfo
The start time.
start() - Method in class jadex.platform.service.clock.ClockService
Start the clock.
start() - Method in class jadex.platform.service.clock.ContinuousClock
Start the clock.
start - Variable in class jadex.platform.service.dht.Finger
Start key of this finger
start() - Method in class jadex.platform.service.email.EmailAgent
Called on agent start.
start() - Method in class jadex.platform.service.message.transport.httprelaymtp.HttpReceiver
(Re-)Start the receiver.
start() - Method in class jadex.platform.service.message.transport.httprelaymtp.HttpRelayTransport
Start the transport.
start() - Method in interface jadex.platform.service.message.transport.ITransport
Start the transport.
start() - Method in class jadex.platform.service.message.transport.localmtp.LocalTransport
Start the transport.
start() - Method in class jadex.platform.service.message.transport.niotcpmtp.NIOTCPTransport
Start the transport.
start() - Method in class jadex.platform.service.message.transport.tcpmtp.TCPTransport
Start the transport.
start() - Method in class jadex.platform.service.remote.RemoteServiceManagementService.TimeoutTimerTask
Start the timer task.
start() - Method in class jadex.platform.service.security.SecurityService
Start the service.
start() - Method in class jadex.platform.service.simulation.SimulationService
Restart the execution after pause.
started() - Method in class jadex.platform.service.address.TransportAddressService
 
started - Variable in class jadex.platform.service.awareness.discovery.DiscoveryAgent
Flag indicating that the agent is started and the send behavior may be activated.
startoninit - Variable in class jadex.platform.service.simulation.SimulationService
Flag to indicate that simulation should be started after service is inited.
startReceiving() - Method in class jadex.platform.service.awareness.discovery.ReceiveHandler
Start receiving awareness infos.
startRemovalBehaviour() - Method in class jadex.platform.service.remote.RemoteReferenceModule
Start removal behavior for expired holders.
startRemoveBehavior() - Method in class jadex.platform.service.awareness.discovery.LeaseTimeHandler
Start removing discovered proxies.
startRemoveBehaviour() - Method in class jadex.platform.service.awareness.management.AwarenessManagementAgent
Start removing discovered proxies.
startRenewalBehaviour() - Method in class jadex.platform.service.remote.RemoteReferenceModule
Start the removal behavior.
startSendBehavior() - Method in class jadex.platform.service.awareness.discovery.SendHandler
Start sending awareness infos.
startseqno - Variable in class jadex.platform.service.message.streams.AckInfo
The start seqno.
startService() - Method in class jadex.platform.service.clock.ClockService
Start the service.
startService() - Method in class jadex.platform.service.cms.ComponentManagementService
Start the service.
startService() - Method in class jadex.platform.service.df.DirectoryFacilitatorService
Start the service.
startService() - Method in class jadex.platform.service.execution.AsyncExecutionService
Start the execution service.
startService() - Method in class jadex.platform.service.execution.SyncExecutionService
Start the executor service.
startService() - Method in class jadex.platform.service.library.BasicDependencyService
Start the service.
startService() - Method in class jadex.platform.service.library.LibraryService
Start the service.
startService() - Method in class jadex.platform.service.marshal.MarshalService
Start the service.
startService() - Method in class jadex.platform.service.message.MessageService
Start the service.
startService() - Method in class jadex.platform.service.settings.SettingsService
Start the service.
startService() - Method in class jadex.platform.service.simulation.SimulationService
Start (and run) the execution.
startStreamCheckAliveBehavior() - Method in class jadex.platform.service.message.MessageService
 
startStreamSendAliveBehavior() - Method in class jadex.platform.service.message.MessageService
 
starttime - Variable in class jadex.platform.service.clock.AbstractClock
The start time (model time).
starttime - Variable in class jadex.platform.service.message.transport.httprelaymtp.HttpReceiver.TimeoutTask
The time at creation.
startUpload(String, String, long, String) - Method in class jadex.platform.service.chat.ChatService
Send a file.
state - Variable in class jadex.platform.service.clock.AbstractClock
The clock state.
state - Variable in class jadex.platform.service.execution.AsyncExecutionService
The state.
state - Variable in class jadex.platform.service.execution.SyncExecutionService
The state of the service.
status - Variable in class jadex.platform.service.chat.ChatService
The current status (idle, typing, away).
status(String, String, byte[]) - Method in class jadex.platform.service.chat.ChatService
Post a status change.
status(String, byte[], IComponentIdentifier[]) - Method in class jadex.platform.service.chat.ChatService
Post a status change.
statusTo(String, String, byte[], IComponentIdentifier) - Method in class jadex.platform.service.chat.ChatService
Helper method for posting status to cid.
stepComponent(IComponentIdentifier, String) - Method in class jadex.platform.service.cms.ComponentManagementService
Execute a step of a suspended component.
stepEvent() - Method in class jadex.platform.service.simulation.SimulationService
Perform one event.
stepfuture - Variable in class jadex.platform.service.simulation.SimulationService
The future (if any) indicating when a step is finished.
stepTime() - Method in class jadex.platform.service.simulation.SimulationService
Perform all actions belonging to one time point.
stop() - Method in class jadex.platform.service.clock.AbstractClock
Stop the clock.
stop() - Method in class jadex.platform.service.clock.ClockService
Stop the clock.
stop() - Method in class jadex.platform.service.clock.ContinuousClock
Stop the clock.
stop() - Method in class jadex.platform.service.clock.SystemClock
Stop the clock.
stop - Variable in class jadex.platform.service.message.streams.AckInfo
The stop flag.
stop() - Method in class jadex.platform.service.message.transport.httprelaymtp.HttpReceiver
Stop the receiver.
stopflag - Variable in class jadex.platform.service.message.streams.OutputConnectionHandler
Stop flag (is sent in ack from input side) to signal that the rceiver is flooded with data).
stoptime - Variable in class jadex.platform.service.clock.SystemClock
The time when the clock was stopped (used to adjust timers before restarting the clock).
store(String, Object, boolean) - Method in class jadex.platform.service.dht.DistributedKVStoreService
 
store(IID, String, Object, boolean) - Method in class jadex.platform.service.dht.DistributedKVStoreService
 
storeLocal(IID, String, Object, boolean) - Method in class jadex.platform.service.dht.DistributedKVStoreService
Store a key/value pair in the local map.
storeLocal(IID, String, Object, boolean) - Method in class jadex.platform.service.dht.DistributedServiceRegistryService
 
storepass - Variable in class jadex.platform.service.security.SecurityService
The keystore password.
storepath - Variable in class jadex.platform.service.security.SecurityService
The path to the keystore.
streamid - Variable in class jadex.platform.service.message.streams.StreamSendTask
The stream id.
StreamSendTask - Class in jadex.platform.service.message.streams
Task to send data via streams.
StreamSendTask(byte, Object, int, ITransportComponentIdentifier[], ITransport[], ICodec[], Integer, Map<String, Object>) - Constructor for class jadex.platform.service.message.streams.StreamSendTask
Create a new manager send task.
StreamSendTask(StreamSendTask) - Constructor for class jadex.platform.service.message.streams.StreamSendTask
Create a shallow copy.
strictcom - Variable in class jadex.platform.service.message.MessageService
Enable strict communication (i.e.
subscribeForEmail(IFilter<Email>, EmailAccount) - Method in class jadex.platform.service.email.EmailAgent
Subscribe for email.
subscribeForEmail(IFilter<Email>, EmailAccount, boolean) - Method in class jadex.platform.service.email.EmailAgent
Subscribe for email.
subscribeForEvents() - Method in class jadex.platform.service.dht.RingNodeService
Subscribes for RingNodeEvents.
subscribers - Variable in class jadex.platform.service.chat.ChatService
The futures of active subscribers.
subscribers - Variable in class jadex.platform.service.security.SecurityService
The futures of active subscribers.
subscribeToEngine() - Method in class jadex.platform.service.ecarules.ClientRuleSystemAgent
Subscribe to rule executions.
subscribeToEngine() - Method in class jadex.platform.service.ecarules.RuleAgent
Subscribe to rule executions.
subscribeToEvents() - Method in class jadex.platform.service.chat.ChatService
Subscribe to events from the chat service.
subscribeToEvents(IFilter<IMonitoringEvent>) - Method in class jadex.platform.service.monitoring.MonitoringService
Subscribe to monitoring events.
subscribeToEvents() - Method in class jadex.platform.service.security.SecurityService
Subscribe to changes.
subscribeToPlatformList(boolean) - Method in class jadex.platform.service.awareness.management.AwarenessManagementAgent
Retrieve information about platforms as they appear or vanish.
subscribeToRulebase() - Method in class jadex.platform.service.ecarules.RulebaseAgent
Subscribe to rule base changes.
SubscriptionInfo - Class in jadex.platform.service.email
Info struct for email subscriptions.
SubscriptionInfo(IFilter<Email>, EmailAccount, boolean) - Constructor for class jadex.platform.service.email.SubscriptionInfo
Create a new subscription info.
subscriptions - Variable in class jadex.platform.service.dht.RingNodeService
Event subscriptions.
subscriptions - Variable in class jadex.platform.service.email.EmailAgent
The subscriptions (subscription future -> subscription info).
subscriptions - Variable in class jadex.platform.service.monitoring.MonitoringService
The subscriptions (subscription future -> subscription info).
subtractPowerOfTwo(int) - Method in class jadex.platform.service.dht.ID
Subtracts 2^powerOfTwo from the value of this ID and returns the result as new ID.
successorChanged(IFinger, IFinger) - Method in interface jadex.platform.service.dht.Fingertable.FingerTableListener
 
suspendComponent(IComponentIdentifier) - Method in class jadex.platform.service.cms.ComponentManagementService
Suspend the execution of an component.
SyncExecutionService - Class in jadex.platform.service.execution
The synchronous execution service that executes all tasks in zero to one thread.
SyncExecutionService(IInternalAccess) - Constructor for class jadex.platform.service.execution.SyncExecutionService
Create a new synchronous executor service.
SyncExecutionService(IInternalAccess, Map<String, Object>) - Constructor for class jadex.platform.service.execution.SyncExecutionService
Create a new synchronous executor service.
SyncExecutionService.State - Enum in jadex.platform.service.execution
The possible states of the service.
synchronous - Variable in class jadex.platform.service.remote.ProxyInfo
The synchronous methods.
SystemClock - Class in jadex.platform.service.clock
Clock implementation that corresponds to the exact system clock.
SystemClock(IClock, IThreadPool) - Constructor for class jadex.platform.service.clock.SystemClock
Create a new clock.
SystemClock(String, long, IThreadPool) - Constructor for class jadex.platform.service.clock.SystemClock
Create a new clock.
SYSTEMCPRID - Static variable in class jadex.platform.service.library.LibraryService
The pseudo system classpath rid.
SystemSensorAgent - Class in jadex.platform.sensor.system
Agent that installs some top-level non-functional properties including the corresponding sensors.
SystemSensorAgent() - Constructor for class jadex.platform.sensor.system.SystemSensorAgent
 

T

taddresses - Variable in class jadex.platform.service.message.MessageService
 
target - Variable in class jadex.platform.service.remote.commands.RemoteMethodInvocationCommand
The target object (set by postprocessing).
targetcomps - Variable in class jadex.platform.service.remote.RemoteReferenceModule
The map of target components and services (rr -> target comp).
targetid - Variable in class jadex.platform.service.remote.RemoteReference
The target identifier (sid, cid, or tid).
targetinterfaces - Variable in class jadex.platform.service.remote.ProxyInfo
The target class.
targetobjects - Variable in class jadex.platform.service.remote.RemoteReferenceModule
The map of target objects (rr -> target object).
task - Variable in class jadex.platform.service.execution.SyncExecutionService
The current task.
task - Variable in class jadex.platform.service.message.streams.AbstractConnectionHandler.SendInfo
The send task.
task - Variable in class jadex.platform.service.message.streams.OutputConnectionHandler.DataSendInfo
The task.
tasks - Variable in class jadex.platform.service.message.MessageService.SendManager
The list of messages to send.
tasks - Variable in class jadex.platform.service.message.transport.niotcpmtp.SelectorThread
The tasks enqueued from external threads.
TCPDeadConnection - Class in jadex.platform.service.message.transport.tcpmtp
Dead connection identifier.
TCPDeadConnection() - Constructor for class jadex.platform.service.message.transport.tcpmtp.TCPDeadConnection
Create a new dead connection.
TCPInputConnection - Class in jadex.platform.service.message.transport.tcpmtp
Represents the input connection for a tcp stream.
TCPInputConnection(Socket) - Constructor for class jadex.platform.service.message.transport.tcpmtp.TCPInputConnection
Create a new tcp input connection.
TCPOutputConnection - Class in jadex.platform.service.message.transport.tcpmtp
TCP output connection for sending messages to a specific target address.
TCPOutputConnection(TCPTransport.Cleaner, Socket) - Constructor for class jadex.platform.service.message.transport.tcpmtp.TCPOutputConnection
Create a new tcp connection for sending data.
tcpsocket - Variable in class jadex.platform.service.awareness.discovery.ipbroadcast.BroadcastDiscoveryAgent
The tcp socket used for master detection.
TCPTransport - Class in jadex.platform.service.message.transport.tcpmtp
The tcp transport for sending messages over tcp/ip connections.
TCPTransport(IInternalAccess, int) - Constructor for class jadex.platform.service.message.transport.tcpmtp.TCPTransport
Init the transport.
TCPTransport(IInternalAccess, int, boolean) - Constructor for class jadex.platform.service.message.transport.tcpmtp.TCPTransport
Init the transport.
TCPTransport.Cleaner - Class in jadex.platform.service.message.transport.tcpmtp
Class for cleaning output connections after max keep alive time has been reached.
TemporaryRemoteReferenceHolder - Class in jadex.platform.service.remote
A temporary holder is a data struct which keeps track of open protocols.
TemporaryRemoteReferenceHolder(IComponentIdentifier, long) - Constructor for class jadex.platform.service.remote.TemporaryRemoteReferenceHolder
Create a new temporary holder.
terminatecallid - Variable in class jadex.platform.service.remote.commands.RemoteFutureTerminationCommand
The call identifier to terminate.
terminateNetworkRessource() - Method in class jadex.platform.service.awareness.discovery.DiscoveryAgent
Terminate sending/receiving ressource.
terminateNetworkRessource() - Method in class jadex.platform.service.awareness.discovery.ipbroadcast.BroadcastDiscoveryAgent
Terminate receiving.
terminateNetworkRessource() - Method in class jadex.platform.service.awareness.discovery.ipmulticast.MulticastDiscoveryAgent
Terminate receiving.
terminateNetworkRessource() - Method in class jadex.platform.service.awareness.discovery.ipscanner.ScannerDiscoveryAgent
Terminate receiving.
terminateNetworkRessource() - Method in class jadex.platform.service.awareness.discovery.message.MessageDiscoveryAgent
Terminate sending/receiving ressource.
terminateNetworkRessource() - Method in class jadex.platform.service.awareness.discovery.registry.RegistryDiscoveryAgent
Terminate receiving.
terminateNetworkRessource() - Method in class jadex.platform.service.awareness.discovery.relay.RelayDiscoveryAgent
Terminate sending/receiving ressource.
terminationcommands - Variable in class jadex.platform.service.remote.RemoteServiceManagementService
The map of termination commands without futures (callid -> command).
threadpool - Variable in class jadex.platform.service.clock.ClockService
The threadpool.
threadpool - Variable in class jadex.platform.service.clock.ContinuousClock
The threadpool.
threadpool - Variable in class jadex.platform.service.execution.AsyncExecutionService
The threadpool.
threadpool - Variable in class jadex.platform.service.message.transport.httprelaymtp.HttpRelayTransport
The thread pool.
threadpool - Variable in class jadex.platform.service.message.transport.tcpmtp.TCPTransport
The thread pool.
threadpool - Variable in class jadex.platform.service.threadpool.ThreadPoolService
The threadpool.
ThreadPoolService - Class in jadex.platform.service.threadpool
Service wrapper for a threadpool.
ThreadPoolService(IThreadPool, IComponentIdentifier) - Constructor for class jadex.platform.service.threadpool.ThreadPoolService
Create a new threadpool service.
throwing(String, String, Throwable) - Method in class jadex.platform.service.cms.LoggerWrapper
Log throwing an exception.
ticktimer - Variable in class jadex.platform.service.clock.AbstractClock
The tick timer.
TickTimer - Class in jadex.platform.service.clock
A timer for waiting on clock ticks.
TickTimer(IClock, ITimedObject) - Constructor for class jadex.platform.service.clock.TickTimer
Create a new timer.
ticktimers - Variable in class jadex.platform.service.clock.AbstractClock
The tick timers.
time - Variable in class jadex.platform.service.awareness.discovery.DiscoveryEntry
The time.
time - Variable in class jadex.platform.service.clock.Timer
The time delta before the alarm.
time - Variable in class jadex.platform.service.message.transport.httprelaymtp.HttpReceiver.TimeoutTask
The time of the last message (connection alive if different from start time).
TIMEOUT - Static variable in class jadex.platform.service.message.transport.tcpmtp.TCPOutputConnection
5 sec timeout.
timeout - Variable in class jadex.platform.service.remote.RemoteServiceManagementService.TimeoutTimerTask
 
timeouts - Variable in class jadex.platform.service.remote.ProxyInfo
The timeouts for methods (method-info -> long).
TimeoutTask(long[], HttpURLConnection) - Constructor for class jadex.platform.service.message.transport.httprelaymtp.HttpReceiver.TimeoutTask
 
TimeoutTimerTask(long, Future<?>, String, IComponentIdentifier, RemoteServiceManagementService) - Constructor for class jadex.platform.service.remote.RemoteServiceManagementService.TimeoutTimerTask
Create a new timer task.
TimeoutTimerTask(RemoteServiceManagementService.TimeoutTimerTask) - Constructor for class jadex.platform.service.remote.RemoteServiceManagementService.TimeoutTimerTask
Create a new timer task.
timer - Variable in class jadex.platform.service.awareness.discovery.DiscoveryAgent
The timer.
timer - Variable in class jadex.platform.service.awareness.discovery.LeaseTimeHandler
The timer.
timer - Variable in class jadex.platform.service.awareness.discovery.SendHandler
The timer.
timer - Variable in class jadex.platform.service.awareness.management.AwarenessManagementAgent
The timer.
timer - Variable in class jadex.platform.service.clock.ClockService
The realtime timer.
Timer - Class in jadex.platform.service.clock
A timer for being notified at a specified timepoint.
Timer(long, IClock, ITimedObject) - Constructor for class jadex.platform.service.clock.Timer
Create a new timer.
timer - Variable in class jadex.platform.service.message.MessageService
The (real) system clock timer.
timer - Variable in class jadex.platform.service.message.streams.AbstractConnectionHandler.SendInfo
The timer for triggering resends.
timer - Variable in class jadex.platform.service.message.streams.OutputConnectionHandler.DataSendInfo
The timer.
timer - Variable in class jadex.platform.service.message.transport.niotcpmtp.SelectorThread
The cleanup timer.
timer - Variable in class jadex.platform.service.message.transport.tcpmtp.TCPTransport
The cleanup timer.
timer - Variable in class jadex.platform.service.remote.RemoteReferenceModule
The timer.
timer - Variable in class jadex.platform.service.remote.RemoteServiceManagementService
The timer.
timers - Variable in class jadex.platform.service.clock.AbstractClock
The timers (entries ordered by timepoint).
timertask - Variable in class jadex.platform.service.message.transport.niotcpmtp.SelectorThread.Cleaner
The timer task.
timertask - Variable in class jadex.platform.service.message.transport.tcpmtp.TCPTransport.Cleaner
The timer task.
timertask - Variable in class jadex.platform.service.remote.RemoteServiceManagementService.WaitingCallInfo
The timer task.
timesteptime - Variable in class jadex.platform.service.simulation.SimulationService
The time of a time step.
to - Variable in class jadex.platform.service.clock.Timer
The timed object.
toDecimalString(int) - Method in class jadex.platform.service.dht.ID
Returns a string of the decimal representation of the first n bytes of this ID, including leading zeros.
toHexString(int) - Method in class jadex.platform.service.dht.ID
Returns a string of the hexadecimal representation of the first n bytes of this ID, including leading zeros.
tosend - Variable in class jadex.platform.service.message.streams.OutputConnectionHandler
The data to send.
toString() - Method in class jadex.platform.service.awareness.discovery.DiscoveryEntry
Get the string representation.
toString() - Method in class jadex.platform.service.clock.TickTimer
Get the string representation.
toString() - Method in class jadex.platform.service.cms.PlatformComponent
Get a string representation.
toString() - Method in class jadex.platform.service.dht.Finger
 
toString() - Method in class jadex.platform.service.dht.Fingertable
 
toString() - Method in class jadex.platform.service.dht.ID
 
toString() - Method in class jadex.platform.service.dht.RingNodeService
 
toString() - Method in class jadex.platform.service.library.ChangeableURLClassLoader
 
toString() - Method in class jadex.platform.service.library.DelegationURLClassLoader
Get a string representation.
toString() - Method in class jadex.platform.service.message.transport.MessageEnvelope
Get the string representation.
toString() - Method in class jadex.platform.service.message.transport.niotcpmtp.NIOTCPInputConnection
A string representation.
toString() - Method in class jadex.platform.service.remote.commands.RemoteFutureSourceCommand
Get as string.
toString() - Method in class jadex.platform.service.remote.commands.RemoteIntermediateResultCommand
Get as string.
toString() - Method in class jadex.platform.service.remote.commands.RemoteMethodInvocationCommand
Get the string representation.
toString() - Method in class jadex.platform.service.remote.commands.RemoteResultCommand
Get as string.
toString() - Method in class jadex.platform.service.remote.commands.RemoteSearchCommand
Get the string representation.
toString() - Method in class jadex.platform.service.remote.ProxyInfo
Get the string representation.
toString() - Method in class jadex.platform.service.remote.ProxyReference
Get the string representation.
toString() - Method in class jadex.platform.service.remote.RemoteReference
Get the string representation.
toString() - Method in class jadex.platform.service.remote.RemoteReferenceHolder
Get the string representation.
toString() - Method in class jadex.platform.service.remote.TemporaryRemoteReferenceHolder
Get the string representation.
total - Variable in class jadex.platform.service.email.SubscriptionInfo
The number of messages in the folder.
TPCONF - Static variable in class jadex.platform.service.message.MessageAgent
Transport configuration Format:
tr - Variable in class jadex.platform.service.remote.RemoteMethodInvocationHandler
The target resolver.
transfers - Variable in class jadex.platform.service.chat.ChatService
The currently managed file transfers.
transfers2 - Variable in class jadex.platform.service.chat.ChatService
 
transport - Variable in class jadex.platform.service.message.transport.httprelaymtp.HttpReceiver
The transport.
TransportAddressAgent - Class in jadex.platform.service.address
 
TransportAddressAgent() - Constructor for class jadex.platform.service.address.TransportAddressAgent
 
TransportAddressService - Class in jadex.platform.service.address
Service that manages the transport addresses of remote platforms.
TransportAddressService() - Constructor for class jadex.platform.service.address.TransportAddressService
 
transports - Variable in class jadex.platform.service.message.AbstractSendTask
The transports to be tried.
transports - Variable in class jadex.platform.service.message.MessageService
The transports.
trcl - Variable in class jadex.platform.service.remote.ProxyInfo
The target resolver (for intelligent proxies).
tries - Variable in class jadex.platform.service.message.streams.OutputConnectionHandler.DataSendInfo
The try count.
trustedlan - Variable in class jadex.platform.service.security.SecurityService
The trusted lan mode.
trycnt - Variable in class jadex.platform.service.message.streams.AbstractConnectionHandler.SendInfo
The number of timer this task has been executed.
TTPAcquisitionMechanism - Class in jadex.platform.service.security
todo: ensure authentication between ttp and platform.
TTPAcquisitionMechanism() - Constructor for class jadex.platform.service.security.TTPAcquisitionMechanism
Create a new mechanism.
TTPAcquisitionMechanism(String) - Constructor for class jadex.platform.service.security.TTPAcquisitionMechanism
Create a new mechanism.
ttpcid - Variable in class jadex.platform.service.security.TTPAcquisitionMechanism
The component id of the trusted third party.
ttpsecser - Variable in class jadex.platform.service.security.TTPAcquisitionMechanism
The security service of the ttp.
type - Variable in class jadex.platform.service.message.streams.StreamSendTask
The type of message (init, data, close).
type - Variable in class jadex.platform.service.remote.commands.RemoteSearchCommand
The type.

U

unacked - Variable in class jadex.platform.service.message.streams.AbstractConnectionHandler
The unacknowledged messages.
uncached - Variable in class jadex.platform.service.remote.ProxyInfo
The uncached methods.
uniqueids - Variable in class jadex.platform.service.cms.ComponentManagementService
Flag to enable unique id generation.
uploadFile(IInputConnection, String, String) - Method in class jadex.platform.service.filetransfer.FileTransferService
Put a file.
urls - Variable in class jadex.platform.service.library.ChangeableURLClassLoader
The url list.
usepass - Variable in class jadex.platform.service.security.SecurityService
Flag to enable / disable password protection.

V

valdur - Variable in class jadex.platform.service.security.SecurityService
The default message validity duration.
validateRequest(IAuthorizable) - Method in class jadex.platform.service.security.SecurityService
Validate a request.
valueOf(String) - Static method in enum jadex.platform.service.execution.AsyncExecutionService.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum jadex.platform.service.execution.SyncExecutionService.State
Returns the enum constant of this type with the specified name.
values() - Static method in enum jadex.platform.service.execution.AsyncExecutionService.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum jadex.platform.service.execution.SyncExecutionService.State
Returns an array containing the constants of this enum type, in the order they are declared.
verify - Variable in class jadex.platform.service.security.TTPAcquisitionMechanism
Must ttp be verify (i.e.
VERIFY_DELAY - Static variable in class jadex.platform.service.dht.RingNodeService
Delay in ms between two stabilize runs
verifyCall(byte[], byte[], String) - Method in class jadex.platform.service.security.SecurityService
Verify an authenticated service call.
verifyCall(byte[], byte[], Certificate) - Method in class jadex.platform.service.security.SecurityService
Internal verify method that just checks if f-pubkey(content)=signed.
verifyTTP(ISecurityService) - Method in class jadex.platform.service.security.TTPAcquisitionMechanism
 
virtualsmap - Variable in class jadex.platform.service.security.SecurityService
The mappings of virtual names to platform names.

W

WAITFACTOR - Static variable in class jadex.platform.service.remote.RemoteReferenceModule
leasetime*factor is used to determine when an entry should be removed.
waitForReady() - Method in interface jadex.platform.service.message.streams.IOutputConnectionHandler
Wait until the connection is ready for the next write.
waitForReady() - Method in class jadex.platform.service.message.streams.LocalOutputConnectionHandler
Wait until the connection is ready for the next write.
waitForReady() - Method in class jadex.platform.service.message.streams.OutputConnection
Wait until the connection is ready for the next write.
waitForReady() - Method in class jadex.platform.service.message.streams.OutputConnectionHandler
Wait until the connection is ready for the next write.
waitForRealDelay(long, IComponentStep<?>) - Method in class jadex.platform.service.message.MessageService
Wait for a time delay on the (real) system clock.
waiting - Variable in class jadex.platform.service.message.AbstractSendTask
The list of waiting transports.
WaitingCallInfo(Future<Object>, RemoteServiceManagementService.TimeoutTimerTask, Object) - Constructor for class jadex.platform.service.remote.RemoteServiceManagementService.WaitingCallInfo
Create a new info.
waitingcalls - Variable in class jadex.platform.service.remote.RemoteServiceManagementService
The map of waiting calls (callid -> future).
warning(String) - Method in class jadex.platform.service.cms.LoggerWrapper
Log a WARNING message.
watchservice - Variable in class jadex.platform.service.awareness.discovery.local.LocalDiscoveryAgent
The directory watch service.
wb - Variable in class jadex.platform.service.message.transport.niotcpmtp.NIOTCPInputConnection
The write buffer for the channel.
Worker(String) - Constructor for class jadex.platform.service.message.transport.httprelaymtp.HttpRelayTransport.Worker
 
workers - Variable in class jadex.platform.service.message.transport.httprelaymtp.HttpRelayTransport
The worker count (address -> count).
write(byte[]) - Method in class jadex.platform.service.message.streams.OutputConnection
Write the content to the stream.
writeFromInputStream(InputStream, IExternalAccess) - Method in class jadex.platform.service.message.streams.OutputConnection
Do write all data from the input stream.
writePropertiesToStore(Properties) - Method in class jadex.platform.service.settings.SettingsService
Writes the given properties into a Store, usually a file.
writer - Variable in class jadex.platform.service.remote.RemoteServiceManagementService
The rmi object to xml writer.
writetasks - Variable in class jadex.platform.service.message.transport.niotcpmtp.SelectorThread
The write tasks of data waiting to be written to a connection.
writeToOutputStream(OutputStream, IExternalAccess) - Method in class jadex.platform.service.message.streams.InputConnection
Read all data from output stream to the connection.

X

XMLCodec - Class in jadex.platform.service.message.transport.codecs
The XML codec.
XMLCodec() - Constructor for class jadex.platform.service.message.transport.codecs.XMLCodec
 
A B C D E F G H I J K L M N O P Q R S T U V W X 
Skip navigation links