Uses of Package
com.tangosol.net
-
Packages that use com.tangosol.net Package Description com.oracle.coherence.cdi Coherence CDI provides support for CDI (Contexts and Dependency Injection) within Coherence cluster members.com.oracle.coherence.cdi.events Support for adapting Coherence interceptors to standard CDI events.com.oracle.coherence.cdi.server Simple CDI-based Cache Server implementation.com.oracle.coherence.concurrent Coherence Concurrent utilities based on java.util.concurrent.com.oracle.coherence.concurrent.atomic A small toolkit of classes that support lock-free thread-safe programming on single variables.com.oracle.coherence.concurrent.locks Interfaces and classes providing a framework for locking and waiting for conditions that is distinct from built-in synchronization and monitors.com.oracle.coherence.grpc Low-level utilities for Coherence gRPC server and client implementation.com.oracle.coherence.grpc.proxy The Coherence gRPC server implementation.com.oracle.coherence.mp.config Coherence support for Eclipse MicroProfile Config.com.tangosol.coherence.config.builder Defines the typical runtime configuration builders for the Coherence configuration object model.com.tangosol.coherence.config.scheme Defines the Coherence configuration object model classes and interfaces for Caching and Service Schemes.com.tangosol.coherence.config.xml.processor Defines the Xml document Element and Attribute Processors for Coherence Cache Configuration files.com.tangosol.coherence.dslquery Contains packages and classes supporting the Coherence CohQL command line tool.com.tangosol.coherence.jcache Contains classes related to Coherence JCache.com.tangosol.coherence.jcache.common Common utilities used by Coherence JCache.com.tangosol.coherence.jcache.partitionedcache Contains classes related to partitioned cache implementation of Coherence JCache.com.tangosol.coherence.rest Contains classes related to the Coherence REST API.com.tangosol.coherence.rest.events Contains classes related to the Coherence REST APIMapEvent
s.com.tangosol.coherence.rest.query Contains classes related to the Coherence REST pluggable query engine.com.tangosol.internal.net com.tangosol.io Contains classes providing cache persistence of serialized objects.com.tangosol.net Contains basic cluster interfaces and factories.com.tangosol.net.cache Contains classes providing various caching strategies.com.tangosol.net.events Contains classes related to the Coherence Live Event Model.com.tangosol.net.events.application Contains classes related to application events within the Coherence Live Event Model, including ConfigurableCacheFactory events.com.tangosol.net.events.partition Contains classes related to PartitionedService events within the Coherence Live Event Model.com.tangosol.net.events.partition.cache Contains classes related to PartitionedCache events within the Coherence Live Event Model.com.tangosol.net.management Contains classes related to the Coherence Management Framework.com.tangosol.net.partition Contains interfaces and classes related to partitioned services.com.tangosol.net.proxy Contains interfaces and classes related to proxy services.com.tangosol.net.security Contains classes related to the Coherence Security Framework.com.tangosol.net.ssl Contains interfaces and classes related to custom SSL certificate and key store loaders.com.tangosol.net.topic Contains classes that providing topic entities for publish/subscribe messaging.com.tangosol.persistence Contains classes and helpers for implementing various types of persistence.com.tangosol.util Contains various generic utilities.com.tangosol.util.aggregator Contains concreteInvocableMap.EntryAggregator
implementations.com.tangosol.util.extractor ContainsValueExtractor
andValueUpdater
related classes.com.tangosol.util.filter Contains concreteFilter
implementations and related interfaces.com.tangosol.util.fsm Contains Finite state machine interfaces.com.tangosol.util.processor Contains concreteInvocableMap.EntryProcessor
implementations. -
Classes in com.tangosol.net used by com.oracle.coherence.cdi Class Description Coherence CoherenceConfiguration The immutable configuration for aCoherence
instance.Session A thread-safe mechanism to request Coherence-based resources, likeNamedCache
s, from a deployed module.SessionConfiguration A class that can provide the configuration options for aSession
. -
Classes in com.tangosol.net used by com.oracle.coherence.cdi.events Class Description ConfigurableCacheFactory An interface for cache factory.PartitionedService A PartitionedService is aware of a mapping of keys to partitions and of partitions to cluster members. -
Classes in com.tangosol.net used by com.oracle.coherence.cdi.server Class Description Cluster The Cluster interface represents a collection of services that operate in a clustered network environment.Coherence OperationalContext OperationalContext is an interface for providing Oracle Coherence operational configuration. -
Classes in com.tangosol.net used by com.oracle.coherence.concurrent Class Description Member The Member interface represents a cluster member.NamedMap A Map-based data-structure that manages entries across one or more processes.Session A thread-safe mechanism to request Coherence-based resources, likeNamedCache
s, from a deployed module. -
Classes in com.tangosol.net used by com.oracle.coherence.concurrent.atomic Class Description AsyncNamedMap AsynchronousNamedMap
.NamedMap A Map-based data-structure that manages entries across one or more processes. -
Classes in com.tangosol.net used by com.oracle.coherence.concurrent.locks Class Description Member The Member interface represents a cluster member.NamedMap A Map-based data-structure that manages entries across one or more processes.Session A thread-safe mechanism to request Coherence-based resources, likeNamedCache
s, from a deployed module. -
Classes in com.tangosol.net used by com.oracle.coherence.grpc Class Description AsyncNamedCache AsynchronousNamedCache
.NamedCache A Map-based data-structure that manages entries across one or more processes.Service This Service interface represents a controllable service that operates in a clustered network environment. -
Classes in com.tangosol.net used by com.oracle.coherence.grpc.proxy Class Description AsyncNamedCache AsynchronousNamedCache
.ConfigurableCacheFactory An interface for cache factory.NamedCache A Map-based data-structure that manages entries across one or more processes.Service This Service interface represents a controllable service that operates in a clustered network environment. -
Classes in com.tangosol.net used by com.oracle.coherence.mp.config Class Description NamedMap A Map-based data-structure that manages entries across one or more processes. -
Classes in com.tangosol.net used by com.tangosol.coherence.config.builder Class Description ActionPolicy ActionPolicy defines which aspects of a Service's behavior are currently allowed.AddressProvider The AddressProvider is a subclass interface ofSocketAddressProvider
which returnsInetSocketAddress
fromAddressProvider.getNextAddress()
.AddressProviderFactory A factory forAddressProvider
objects.BackingMapManager A callback interface used by CacheService implementations.BackingMapManagerContext The BackingMapManager context is used by the CacheService to pass information to the BackingMapManager during the service initialization.Cluster The Cluster interface represents a collection of services that operate in a clustered network environment.ConfigurableCacheFactory An interface for cache factory.DatagramSocketProvider DatagramSocketProivder defines an interface for creating datagram and multicast sockets.Member The Member interface represents a cluster member.NamedCache A Map-based data-structure that manages entries across one or more processes.NamedCollection NamedCollection defines a common base interface for various named collection types.PartitionedService A PartitionedService is aware of a mapping of keys to partitions and of partitions to cluster members.Service This Service interface represents a controllable service that operates in a clustered network environment.ServiceFailurePolicy ServiceFailurePolicy is used to control how a Guardable associated with a service is managed by its Guardian after the configured timeout.ServiceLoadBalancer A ServiceLoadBalancer is a pluggable strategy for controlling the client load across individual members of a clustered Service.SocketAddressProvider The SocketAddressProvider is an interface that serves as a means to provide addresses to a consumer.SocketProviderFactory.Dependencies Dependencies specifies all dependency requirements of the SocketProviderFactory.ValueTypeAssertion Defines aNamedCollection.Option
for asserting the type of values used with aNamedTopic
. -
Classes in com.tangosol.net used by com.tangosol.coherence.config.scheme Class Description BackingMapManager A callback interface used by CacheService implementations.BackingMapManagerContext The BackingMapManager context is used by the CacheService to pass information to the BackingMapManager during the service initialization.Cluster The Cluster interface represents a collection of services that operate in a clustered network environment.ClusterDependencies.ServiceProvider A provider of nw service instances.ConfigurableCacheFactory An interface for cache factory.NamedCache A Map-based data-structure that manages entries across one or more processes.NamedCollection NamedCollection defines a common base interface for various named collection types.Service This Service interface represents a controllable service that operates in a clustered network environment.ServiceDependencies The ServiceDependencies interface defines externally provided dependencies forclustered services
.TopicService A TopicService is a service providing Topics that can be used for publish/subscribe functionality and message queue processing.ValueTypeAssertion Defines aNamedCollection.Option
for asserting the type of values used with aNamedTopic
. -
Classes in com.tangosol.net used by com.tangosol.coherence.config.xml.processor Class Description MemberListener The listener interface for receiving MemberEvents.NamedCache A Map-based data-structure that manages entries across one or more processes.NamedCollection NamedCollection defines a common base interface for various named collection types.PasswordProvider PasswordProvider allows Coherence users to plug in their own mechanism to determine the appropriate password.SocketOptions SocketOptions provides a means to configure the various aspects of Sockets. -
Classes in com.tangosol.net used by com.tangosol.coherence.dslquery Class Description Cluster The Cluster interface represents a collection of services that operate in a clustered network environment.ConfigurableCacheFactory An interface for cache factory.Session A thread-safe mechanism to request Coherence-based resources, likeNamedCache
s, from a deployed module. -
Classes in com.tangosol.net used by com.tangosol.coherence.jcache Class Description ConfigurableCacheFactory An interface for cache factory.NamedCache A Map-based data-structure that manages entries across one or more processes. -
Classes in com.tangosol.net used by com.tangosol.coherence.jcache.common Class Description ExtensibleConfigurableCacheFactory ExtensibleConfigurableCacheFactory provides a facility to access caches declared in a "coherence-cache-config.xsd" compliant configuration file. -
Classes in com.tangosol.net used by com.tangosol.coherence.jcache.partitionedcache Class Description BackingMapManagerContext The BackingMapManager context is used by the CacheService to pass information to the BackingMapManager during the service initialization.NamedCache A Map-based data-structure that manages entries across one or more processes. -
Classes in com.tangosol.net used by com.tangosol.coherence.rest Class Description NamedCache A Map-based data-structure that manages entries across one or more processes.Session A thread-safe mechanism to request Coherence-based resources, likeNamedCache
s, from a deployed module. -
Classes in com.tangosol.net used by com.tangosol.coherence.rest.events Class Description NamedCache A Map-based data-structure that manages entries across one or more processes. -
Classes in com.tangosol.net used by com.tangosol.coherence.rest.query Class Description NamedCache A Map-based data-structure that manages entries across one or more processes. -
Classes in com.tangosol.net used by com.tangosol.internal.net Class Description SessionProvider CreatesSession
s for use by applications requiring Coherence-based resources, includingNamedCache
s, often for specificClassLoader
s, for deployed modules. -
Classes in com.tangosol.net used by com.tangosol.io Class Description Guardable A Guardable is a logical execution unit whose lifetime may be guarded by a Guardian. -
Classes in com.tangosol.net used by com.tangosol.net Class Description AbstractBackingMapManager Abstract base of the BackingMapManager implementations.AbstractServiceLoadBalancer An abstract base for ServiceLoadBalancer implementations.Action An Action represents a controllable action or behavior that a Service might perform.ActionPolicy ActionPolicy defines which aspects of a Service's behavior are currently allowed.AddressProvider The AddressProvider is a subclass interface ofSocketAddressProvider
which returnsInetSocketAddress
fromAddressProvider.getNextAddress()
.AddressProviderFactory A factory forAddressProvider
objects.AsyncNamedCache AsynchronousNamedCache
.AsyncNamedMap AsynchronousNamedMap
.AsyncNamedMap.Complete AnAsyncNamedMap.Option
to use to specify theExecutor
to use to complete theCompletableFuture
returned from async methods.AsyncNamedMap.Option An immutable option for creating and configuringAsyncNamedMap
s.AsyncNamedMap.OrderBy A configuration option which determines the ordering of async operations.BackingMapContext The BackingMapContext provides an execution context to server side agents such asEntryProcessors
andEntryAggregators
.BackingMapManager A callback interface used by CacheService implementations.BackingMapManagerContext The BackingMapManager context is used by the CacheService to pass information to the BackingMapManager during the service initialization.CacheFactoryBuilder CacheFactoryBuilder provides the means for building and managing configurable cache factories across class loaders in a pluggable fashion.CacheService A CacheService is a clustered service providing a collection of named Maps that hold resources shared among members of a cluster.Cluster The Cluster interface represents a collection of services that operate in a clustered network environment.ClusterDependencies The ClusterDependencies interface defines externally provided dependencies for aCluster
.ClusterDependencies.ServiceProvider A provider of nw service instances.Coherence Coherence.Builder A builder to buildCoherence
instances.Coherence.Mode An enum representing the different modes that aCoherence
instance can run in.CoherenceConfiguration The immutable configuration for aCoherence
instance.CoherenceConfiguration.Builder A builder to build aCoherenceConfiguration
instance.CompositeAddressProvider.AddressIterator An Iterator over the addresses in this AddressProvider.ConfigurableAddressProvider ConfigurableAddressProvider is an implementation of the AddressProvider interface based on a static list of addresses configured in an XML element that contains one or more items in the following format:ConfigurableAddressProvider.AddressHolder A stateful holder for an obtaining an InetSocketAddress object.ConfigurableCacheFactory An interface for cache factory.ConfigurableQuorumPolicy ConfigurableQuorumPolicy provides a Quorum-basedActionPolicy
for services based on the cluster-configuration.ConfigurableQuorumPolicy.ClusterQuorumPolicy ClusterQuorumPolicy defines an action policy that is applicable to the cluster.ConfigurableQuorumPolicy.MembershipQuorumPolicy MembershipQuorumPolicy is a quorum policy that is stateless and based solely on service membership sizes.ConfigurableQuorumPolicy.MembershipQuorumPolicy.QuorumRule A quorum rule defines a set of allowable actions beyond the rule's threshold size.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy PartitionedCacheQuorumPolicy defines a configurable quorum policy that is applicable to a DistributedCacheService.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy.ActionRule Action Rules forConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy
ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy.Notification Notification is a simple struct carrying the notification info.ConfigurableQuorumPolicy.ProxyQuorumPolicy ProxyQuorumPolicy defines a configurable quorum policy that is applicable to a proxy service.DatagramSocketProvider DatagramSocketProivder defines an interface for creating datagram and multicast sockets.DefaultCacheServer DefaultCacheServer is a simple command line facility and convenience API that starts all services that are declared as requiring an "autostart" in the configurable factory XML descriptor.DefaultConfigurableCacheFactory Deprecated.DefaultConfigurableCacheFactory.CacheInfo Deprecated.CacheInfo is a placeholder for cache attributes retrieved during parsing the corresponding cache mapping element.DescribableAddressProvider An AddressProvider that additionally allows to retrieve a human readable description of underlying addresses without doing a DNS lookup.DistributedCacheService A DistributedCacheService is a clustered cache service that partitions its data across cluster members that provide backing storage.ExtensibleConfigurableCacheFactory ExtensibleConfigurableCacheFactory provides a facility to access caches declared in a "coherence-cache-config.xsd" compliant configuration file.ExtensibleConfigurableCacheFactory.Dependencies Guardable A Guardable is a logical execution unit whose lifetime may be guarded by a Guardian.Guardian A Guardian is responsible for monitoring the registeredGuardable
objects.Guardian.GuardContext A GuardContext represents the lifecycle status of a Guardable.GuardSupport.Context Base implementation for GuardContext's used by GuardSupport.InetAddressHelper.RoutableFilter The RoutableFilter evaluates to true for any InetAddress which is externally routable.InputStreamPasswordProvider A base class forPasswordProvider
implementations that read the contents of anInputStream
to obtain a password.Invocable The Invocable object is a cluster-portable object that can be invoked on any set of remote members and each can optionally register a return value for the invocation.InvocableInOrder The InvocableInOrder interface allows to control the ordering in which the results of Invocable tasks are returned back to the caller by the Invocation service with a thread pool.InvocationObserver The InvocationObserver is an object that asynchronously receives notification of results from the execution of Invocable objects.InvocationService The InvocationService is a Service for delivering executable objects to cluster members for distributed invocation.LoadBalancer.AddressPort An AddressPort is an immutable combination of an IP address and a port number.LoadBalancer.Queue A Queue is used to effeciently queue up items for daemon threads to work on.LoadBalancer.RequestHandler A RequestHandler is a daemon thread that processes a request from a queue.LoadBalancer.ResponseHandler A ResponseHandler is a daemon thread that processes an outgoing response from a destination server.LoadBalancer.SocketHandler A SocketHandler is an abstract daemon thread.MapViewBuilder TheViewBuilder
provides a means toMapViewBuilder.build()
amap view
using a fluent pattern / style.Member The Member interface represents a cluster member.MemberEvent An event which indicates that membership has changed: a Member has joined a Member is leaving a Member has left A MemberEvent object is sent as an argument to the MemberListener interface methods.MemberIdentity The MemberIdentity interface represents the identity of a cluster member.MemberIdentityProvider A provider of values for a member's identity.MemberListener The listener interface for receiving MemberEvents.NamedCache A Map-based data-structure that manages entries across one or more processes.NamedCollection NamedCollection defines a common base interface for various named collection types.NamedCollection.Option The Option interface defines the root interface of all NamedCollection Options.NamedMap A Map-based data-structure that manages entries across one or more processes.NamedMap.Option An immutable option for requesting and configuringNamedMap
s.NameService.LookupCallback An object which implementsNameService.LookupCallback
can be registered with aNameService
viaNameService.addLookupCallback(com.tangosol.net.NameService.LookupCallback)
to perform a lookup on names that were not found in the NameService's directory.NameService.RequestContext An object which implementsNameService.RequestContext
stores information about the NameService request.NonBlockingTcpDatagramSocket.Impl A specialization ofTcpDatagramSocket.Impl
which provides non-blocking functionality, seeNonBlockingTcpDatagramSocket.Impl.send(DatagramPacket)
.PartitionedService A PartitionedService is aware of a mapping of keys to partitions and of partitions to cluster members.PartitionedService.PartitionedAction PartitionedAction represents a type of action taken by a PartitionedService.PartitionedService.PartitionRecoveryAction A PartitionedAction representing the recovery of orphaned partitions from the persistent storage, or the assignment of empty partitions if the persistent storage is unavailable or lost.PasswordProvider PasswordProvider allows Coherence users to plug in their own mechanism to determine the appropriate password.PriorityTask The PriorityTask interface allows to control the ordering in which a service schedules tasks for execution using a thread pool and limit their execution times to a specified duration.RefreshableAddressProvider.CircularIterator An Iterator implementation that can be converted intocircular mode
to allow the remaining addresses and previously skipped addresses to be used; typically set once an address has beenaccepted
.Releasable A resource that is activated and then at a later time be released.RequestIncompleteException Signals that a request execution in a distributed environment failed to complete successfully.ScopedCacheFactoryBuilder Implementation ofCacheFactoryBuilder
that manages multiple instances ofConfigurableCacheFactory
.ScopeResolver This interface is used to derive a scope name used to create an instance ofConfigurableCacheFactory
.Service This Service interface represents a controllable service that operates in a clustered network environment.ServiceDependencies The ServiceDependencies interface defines externally provided dependencies forclustered services
.ServiceInfo The ServiceInfo represents information about a Service that operates in a clustered network environment.ServiceLoad A ServiceLoad encapsulates information about the current utilization of a Service.ServiceLoadBalancer A ServiceLoadBalancer is a pluggable strategy for controlling the client load across individual members of a clustered Service.ServiceMonitor TheServiceMonitor
is a facility that keeps registered services alive.Session A thread-safe mechanism to request Coherence-based resources, likeNamedCache
s, from a deployed module.Session.Option Deprecated.since 20.12Session.Option
has been replaced bySessionConfiguration
SessionConfiguration A class that can provide the configuration options for aSession
.SessionConfiguration.Builder A builder to build aSessionConfiguration.ConfigurableCacheFactorySessionConfig
.SessionProvider CreatesSession
s for use by applications requiring Coherence-based resources, includingNamedCache
s, often for specificClassLoader
s, for deployed modules.SessionProvider.Context A context used by providers.SessionProvider.Option Deprecated.SocketAddressProvider The SocketAddressProvider is an interface that serves as a means to provide addresses to a consumer.SocketOptions SocketOptions provides a means to configure the various aspects of Sockets.SocketProviderFactory The SocketProviderFactory produces SocketProviders.SocketProviderFactory.Dependencies Dependencies specifies all dependency requirements of the SocketProviderFactory.SocketProviderFactory.Dependencies.ProviderType Enumeration of Provider types.SystemDatagramSocketProvider SystemDatagramSocketProvider produces JVM default datagram socketsTcpDatagramSocket TCP based datagram socket implementation.TcpDatagramSocket.Impl A specialized version ofDatagramSocketImpl
.TcpDatagramSocketProvider TcpDatagramSocketProvider produces datagram sockets that uses TCP sockets underneath for unicast communication.TcpDatagramSocketProvider.DefaultDependencies DefaultDependenceis is a basic implementation of the Dependencies interface providing "setter" methods for each property.TcpDatagramSocketProvider.Dependencies Dependencies specifies all dependency requirements of the TcpDatagramSocketProvider.ThreadPoolManager A ThreadPoolManager manages the thread pool information for a Coherence service thread pool.TopicService A TopicService is a service providing Topics that can be used for publish/subscribe functionality and message queue processing.ValueTypeAssertion Defines aNamedCollection.Option
for asserting the type of values used with aNamedTopic
.ViewBuilder TheViewBuilder
provides a means toViewBuilder.build()
aview
(ContinuousQueryCache
) using a fluent pattern / style.WrapperService Service implementation that delegates to a wrapped Service instance. -
Classes in com.tangosol.net used by com.tangosol.net.cache Class Description AsyncNamedCache AsynchronousNamedCache
.AsyncNamedMap.Option An immutable option for creating and configuringAsyncNamedMap
s.BackingMapContext The BackingMapContext provides an execution context to server side agents such asEntryProcessors
andEntryAggregators
.BackingMapManagerContext The BackingMapManager context is used by the CacheService to pass information to the BackingMapManager during the service initialization.CacheService A CacheService is a clustered service providing a collection of named Maps that hold resources shared among members of a cluster.FlowControl Communication facilities that provide an asynchronous (non-blocking) way of submitting data exchange requests commonly implement mechanisms of modulating the control flow for underlying data transfer units (e.g. messages or packets).Guardable A Guardable is a logical execution unit whose lifetime may be guarded by a Guardian.Guardian A Guardian is responsible for monitoring the registeredGuardable
objects.MemberEvent An event which indicates that membership has changed: a Member has joined a Member is leaving a Member has left A MemberEvent object is sent as an argument to the MemberListener interface methods.MemberListener The listener interface for receiving MemberEvents.NamedCache A Map-based data-structure that manages entries across one or more processes.NamedCollection NamedCollection defines a common base interface for various named collection types.NamedMap A Map-based data-structure that manages entries across one or more processes.NamedMap.Option An immutable option for requesting and configuringNamedMap
s.Releasable A resource that is activated and then at a later time be released. -
Classes in com.tangosol.net used by com.tangosol.net.events Class Description Coherence Session A thread-safe mechanism to request Coherence-based resources, likeNamedCache
s, from a deployed module. -
Classes in com.tangosol.net used by com.tangosol.net.events.application Class Description ConfigurableCacheFactory An interface for cache factory. -
Classes in com.tangosol.net used by com.tangosol.net.events.partition Class Description Member The Member interface represents a cluster member.PartitionedService A PartitionedService is aware of a mapping of keys to partitions and of partitions to cluster members. -
Classes in com.tangosol.net used by com.tangosol.net.events.partition.cache Class Description BackingMapContext The BackingMapContext provides an execution context to server side agents such asEntryProcessors
andEntryAggregators
.BackingMapManagerContext The BackingMapManager context is used by the CacheService to pass information to the BackingMapManager during the service initialization.CacheService A CacheService is a clustered service providing a collection of named Maps that hold resources shared among members of a cluster. -
Classes in com.tangosol.net used by com.tangosol.net.management Class Description CacheService A CacheService is a clustered service providing a collection of named Maps that hold resources shared among members of a cluster.Cluster The Cluster interface represents a collection of services that operate in a clustered network environment.Member The Member interface represents a cluster member.NamedCache A Map-based data-structure that manages entries across one or more processes.PagedTopicService ATopicService
which provides globally ordered topics.Service This Service interface represents a controllable service that operates in a clustered network environment.TopicService A TopicService is a service providing Topics that can be used for publish/subscribe functionality and message queue processing. -
Classes in com.tangosol.net used by com.tangosol.net.partition Class Description Action An Action represents a controllable action or behavior that a Service might perform.ActionPolicy ActionPolicy defines which aspects of a Service's behavior are currently allowed.BackingMapManager A callback interface used by CacheService implementations.BackingMapManagerContext The BackingMapManager context is used by the CacheService to pass information to the BackingMapManager during the service initialization.Member The Member interface represents a cluster member.MemberEvent An event which indicates that membership has changed: a Member has joined a Member is leaving a Member has left A MemberEvent object is sent as an argument to the MemberListener interface methods.MemberListener The listener interface for receiving MemberEvents.NamedCache A Map-based data-structure that manages entries across one or more processes.PartitionedService A PartitionedService is aware of a mapping of keys to partitions and of partitions to cluster members.Service This Service interface represents a controllable service that operates in a clustered network environment. -
Classes in com.tangosol.net used by com.tangosol.net.proxy Class Description AbstractServiceLoadBalancer An abstract base for ServiceLoadBalancer implementations.Member The Member interface represents a cluster member.MemberIdentity The MemberIdentity interface represents the identity of a cluster member.ServiceLoad A ServiceLoad encapsulates information about the current utilization of a Service.ServiceLoadBalancer A ServiceLoadBalancer is a pluggable strategy for controlling the client load across individual members of a clustered Service.SimpleServiceLoadBalancer A simple ServiceLoadBalancer implementation. -
Classes in com.tangosol.net used by com.tangosol.net.security Class Description BackingMapContext The BackingMapContext provides an execution context to server side agents such asEntryProcessors
andEntryAggregators
.Cluster The Cluster interface represents a collection of services that operate in a clustered network environment.ClusterPermission This class represents access to a clustered resource such as a Service or NamedCache.PasswordProvider PasswordProvider allows Coherence users to plug in their own mechanism to determine the appropriate password.Service This Service interface represents a controllable service that operates in a clustered network environment. -
Classes in com.tangosol.net used by com.tangosol.net.ssl Class Description PasswordProvider PasswordProvider allows Coherence users to plug in their own mechanism to determine the appropriate password. -
Classes in com.tangosol.net used by com.tangosol.net.topic Class Description AbstractBackingMapManager Abstract base of the BackingMapManager implementations.BackingMapManager A callback interface used by CacheService implementations.ExtensibleConfigurableCacheFactory ExtensibleConfigurableCacheFactory provides a facility to access caches declared in a "coherence-cache-config.xsd" compliant configuration file.ExtensibleConfigurableCacheFactory.Manager The Manager class uses builders to create the required backing maps and provides client access to those maps.FlowControl Communication facilities that provide an asynchronous (non-blocking) way of submitting data exchange requests commonly implement mechanisms of modulating the control flow for underlying data transfer units (e.g. messages or packets).NamedCollection NamedCollection defines a common base interface for various named collection types.Releasable A resource that is activated and then at a later time be released.TopicService A TopicService is a service providing Topics that can be used for publish/subscribe functionality and message queue processing. -
Classes in com.tangosol.net used by com.tangosol.persistence Class Description Cluster The Cluster interface represents a collection of services that operate in a clustered network environment.ExtensibleConfigurableCacheFactory ExtensibleConfigurableCacheFactory provides a facility to access caches declared in a "coherence-cache-config.xsd" compliant configuration file.Member The Member interface represents a cluster member.PartitionedService A PartitionedService is aware of a mapping of keys to partitions and of partitions to cluster members. -
Classes in com.tangosol.net used by com.tangosol.util Class Description Action An Action represents a controllable action or behavior that a Service might perform.ActionPolicy ActionPolicy defines which aspects of a Service's behavior are currently allowed.AddressProvider The AddressProvider is a subclass interface ofSocketAddressProvider
which returnsInetSocketAddress
fromAddressProvider.getNextAddress()
.BackingMapContext The BackingMapContext provides an execution context to server side agents such asEntryProcessors
andEntryAggregators
.BackingMapManager A callback interface used by CacheService implementations.BackingMapManagerContext The BackingMapManager context is used by the CacheService to pass information to the BackingMapManager during the service initialization.CacheService A CacheService is a clustered service providing a collection of named Maps that hold resources shared among members of a cluster.ConfigurableCacheFactory An interface for cache factory.FlowControl Communication facilities that provide an asynchronous (non-blocking) way of submitting data exchange requests commonly implement mechanisms of modulating the control flow for underlying data transfer units (e.g. messages or packets).Guardable A Guardable is a logical execution unit whose lifetime may be guarded by a Guardian.Guardian A Guardian is responsible for monitoring the registeredGuardable
objects.Guardian.GuardContext A GuardContext represents the lifecycle status of a Guardable.Member The Member interface represents a cluster member.MemberIdentityProvider A provider of values for a member's identity.NamedCache A Map-based data-structure that manages entries across one or more processes.NamedCollection NamedCollection defines a common base interface for various named collection types.NamedMap A Map-based data-structure that manages entries across one or more processes.Releasable A resource that is activated and then at a later time be released.Service This Service interface represents a controllable service that operates in a clustered network environment.Session A thread-safe mechanism to request Coherence-based resources, likeNamedCache
s, from a deployed module.SocketAddressProvider The SocketAddressProvider is an interface that serves as a means to provide addresses to a consumer. -
Classes in com.tangosol.net used by com.tangosol.util.aggregator Class Description AbstractPriorityTask An abstract base for PriorityTask implementations.FlowControl Communication facilities that provide an asynchronous (non-blocking) way of submitting data exchange requests commonly implement mechanisms of modulating the control flow for underlying data transfer units (e.g. messages or packets).PriorityTask The PriorityTask interface allows to control the ordering in which a service schedules tasks for execution using a thread pool and limit their execution times to a specified duration. -
Classes in com.tangosol.net used by com.tangosol.util.extractor Class Description BackingMapContext The BackingMapContext provides an execution context to server side agents such asEntryProcessors
andEntryAggregators
. -
Classes in com.tangosol.net used by com.tangosol.util.filter Class Description AbstractPriorityTask An abstract base for PriorityTask implementations.PriorityTask The PriorityTask interface allows to control the ordering in which a service schedules tasks for execution using a thread pool and limit their execution times to a specified duration. -
Classes in com.tangosol.net used by com.tangosol.util.fsm Class Description PriorityTask The PriorityTask interface allows to control the ordering in which a service schedules tasks for execution using a thread pool and limit their execution times to a specified duration. -
Classes in com.tangosol.net used by com.tangosol.util.processor Class Description AbstractPriorityTask An abstract base for PriorityTask implementations.FlowControl Communication facilities that provide an asynchronous (non-blocking) way of submitting data exchange requests commonly implement mechanisms of modulating the control flow for underlying data transfer units (e.g. messages or packets).PriorityTask The PriorityTask interface allows to control the ordering in which a service schedules tasks for execution using a thread pool and limit their execution times to a specified duration.