- abort() - Method in interface com.gigaspaces.cluster.replication.gateway.conflict.DataConflictOperation
-
Determines that the operation will be aborted.
- abort() - Method in interface com.gigaspaces.sync.ConsolidationParticipantData
-
Specifies that this transaction participant should be aborted and not executed.
- abort(long) - Method in class com.sun.jini.mahalo.TxnManagerImpl
-
- abort(long, long) - Method in class com.sun.jini.mahalo.TxnManagerImpl
-
- abort(Object) - Method in class com.sun.jini.mahalo.TxnManagerImpl
-
- abort(Object, long) - Method in class com.sun.jini.mahalo.TxnManagerImpl
-
- abort(long) - Method in class com.sun.jini.mahalo.TxnMgrProxy
-
- abort(long, long) - Method in class com.sun.jini.mahalo.TxnMgrProxy
-
- abort(Object) - Method in class com.sun.jini.mahalo.TxnMgrProxy
-
- abort(Object, long) - Method in class com.sun.jini.mahalo.TxnMgrProxy
-
- abort(Object) - Method in interface net.jini.core.transaction.server.ExtendedTransactionManager
-
- abort(Object, long) - Method in interface net.jini.core.transaction.server.ExtendedTransactionManager
-
- abort() - Method in class net.jini.core.transaction.server.ServerTransaction
-
- abort(long) - Method in class net.jini.core.transaction.server.ServerTransaction
-
- abort(long) - Method in interface net.jini.core.transaction.server.TransactionManager
-
Abort the transaction.
- abort(long, long) - Method in interface net.jini.core.transaction.server.TransactionManager
-
Abort the transaction, waiting for participants to be notified of
the decision.
- abort(TransactionManager, long) - Method in interface net.jini.core.transaction.server.TransactionParticipant
-
Requests that the participant roll back any changes for the specified
transaction and unlock any resources locked by the transaction.
- abort() - Method in interface net.jini.core.transaction.Transaction
-
Abort the transaction.
- abort(long) - Method in interface net.jini.core.transaction.Transaction
-
Abort the transaction, waiting for participants to be notified of
the decision.
- abort_impl(Object, long) - Method in class com.sun.jini.mahalo.TxnManagerImpl
-
- abortAll() - Method in interface com.gigaspaces.cluster.replication.gateway.conflict.DataConflict
-
Indicates that all of the operations associated with the
DataConflict
will be aborted.
- ABORTED - Static variable in interface com.j_spaces.core.ISpaceState
-
Service has been aborted.
- ABORTED - Static variable in interface net.jini.core.transaction.server.TransactionConstants
-
Transaction has been aborted.
- ABORTING - Static variable in interface com.j_spaces.core.ISpaceState
-
Service is during abort process
- AbortJob - Class in com.sun.jini.mahalo
-
An implementation of a com.sun.jini.mahalo.Job
which
interacts with a set of
net.jini.core.transaction.server.TransactionParticipant
s
to inform them to roll back changes associated with a given
net.jini.core.transaction.Transaction
.
- AbortJob(Transaction, TaskManager, WakeupManager, ClientLog, ParticipantHandle[], boolean, Object) - Constructor for class com.sun.jini.mahalo.AbortJob
-
Constructs an AbortJob
- abortPartitionWithEnabledFailover(ParticipantHandle, ExtendedTransactionManager, long, Object) - Static method in class com.sun.jini.mahalo.AbortJob
-
- abs(Value) - Method in class org.openspaces.jpa.openjpa.query.QueryExpressionFactory
-
Return a value representing the absolute value of the given one.
- ABSOLUTE - Static variable in interface net.jini.core.lease.Lease
-
The serialized form of the lease will contain the time of expiration
stored as an absolute time, represented in terms of milliseconds since
the beginning of the epoch.
- absolute(int) - Method in class org.openspaces.jpa.openjpa.query.SpaceProjectionResultObjectProvider
-
- absolute(int) - Method in class org.openspaces.jpa.openjpa.query.SpaceResultObjectProvider
-
- AbstractAlert - Class in org.openspaces.admin.alert.alerts
-
An abstraction over a fired alert, exposing the
Alert
API.
- AbstractAlert() - Constructor for class org.openspaces.admin.alert.alerts.AbstractAlert
-
required by java.io.Externalizable
- AbstractAlert(Alert) - Constructor for class org.openspaces.admin.alert.alerts.AbstractAlert
-
- AbstractApplicationCommand - Class in org.openspaces.admin.application.deploy
-
- AbstractApplicationCommand() - Constructor for class org.openspaces.admin.application.deploy.AbstractApplicationCommand
-
- AbstractBasicWidget - Class in org.openspaces.ui
-
- AbstractBasicWidget(String) - Constructor for class org.openspaces.ui.AbstractBasicWidget
-
- AbstractBasicWidget() - Constructor for class org.openspaces.ui.AbstractBasicWidget
-
- AbstractCapacityRequirement - Class in org.openspaces.grid.gsm.capacity
-
- AbstractCapacityRequirement() - Constructor for class org.openspaces.grid.gsm.capacity.AbstractCapacityRequirement
-
- AbstractCapacityRequirement(long) - Constructor for class org.openspaces.grid.gsm.capacity.AbstractCapacityRequirement
-
- AbstractCapacityScaleStrategyBean - Class in org.openspaces.grid.gsm.strategy
-
- AbstractCapacityScaleStrategyBean() - Constructor for class org.openspaces.grid.gsm.strategy.AbstractCapacityScaleStrategyBean
-
- AbstractChunkDataIterator - Class in org.openspaces.persistency.hibernate.iterator
-
A base class that accepts a batch size and will create several iterators on the given
entity by chunking it into batch size chuncks, each iterator will iterate only on the given
chunk.
- AbstractChunkDataIterator(String, SessionFactory, int, boolean, int) - Constructor for class org.openspaces.persistency.hibernate.iterator.AbstractChunkDataIterator
-
Constructs a scrollable iterator over the given entity name.
- AbstractChunkDataIterator(SQLQuery, SessionFactory, int, boolean, int) - Constructor for class org.openspaces.persistency.hibernate.iterator.AbstractChunkDataIterator
-
Constructs a scrollable iterator over the given GigaSpaces SQLQuery
.
- AbstractChunkDataIterator(String, SessionFactory, int, int) - Constructor for class org.openspaces.persistency.hibernate.iterator.AbstractChunkDataIterator
-
Constructs a scrollable iterator over the given hibernate query string.
- AbstractConfig - Class in org.openspaces.admin.config
-
Base class for configurations
- AbstractConfig(Map<String, String>) - Constructor for class org.openspaces.admin.config.AbstractConfig
-
- AbstractDelegatingDistributedTask<T extends Serializable,R> - Class in org.openspaces.core.executor.support
-
A base class for delegating tasks that are also distributed tasks
- AbstractDelegatingDistributedTask() - Constructor for class org.openspaces.core.executor.support.AbstractDelegatingDistributedTask
-
- AbstractDelegatingDistributedTask(Task<T>) - Constructor for class org.openspaces.core.executor.support.AbstractDelegatingDistributedTask
-
- AbstractDelegatingDistributedTask(Task<T>, AsyncResultFilter<T>) - Constructor for class org.openspaces.core.executor.support.AbstractDelegatingDistributedTask
-
- AbstractEventContainerBeanDefinitionParser - Class in org.openspaces.events.config
-
- AbstractEventContainerBeanDefinitionParser() - Constructor for class org.openspaces.events.config.AbstractEventContainerBeanDefinitionParser
-
- AbstractEventListenerContainer - Class in org.openspaces.events
-
- AbstractEventListenerContainer() - Constructor for class org.openspaces.events.AbstractEventListenerContainer
-
- AbstractFifoGroupingReceiveOperationHandler - Class in org.openspaces.events.polling.receive
-
Support class to perform receive operations with or without Fifo Grouping.
- AbstractFifoGroupingReceiveOperationHandler() - Constructor for class org.openspaces.events.polling.receive.AbstractFifoGroupingReceiveOperationHandler
-
- AbstractFilterBeanDefinitionParser - Class in org.openspaces.core.config
-
- AbstractFilterBeanDefinitionParser() - Constructor for class org.openspaces.core.config.AbstractFilterBeanDefinitionParser
-
- AbstractFilterProviderAdapterFactoryBean - Class in org.openspaces.core.space.filter
-
A base class for filter adapters that delegate the invocation of filter operation and lifecycle
methods to another class.
- AbstractFilterProviderAdapterFactoryBean() - Constructor for class org.openspaces.core.space.filter.AbstractFilterProviderAdapterFactoryBean
-
- AbstractFilterProviderFactoryBean - Class in org.openspaces.core.space.filter
-
A base factory for
FilterProvider
allowing to construct a
filter provider that can be used to provide pre initialized
ISpaceFilter
implementation including its different aspects to an embedded space.
- AbstractFilterProviderFactoryBean() - Constructor for class org.openspaces.core.space.filter.AbstractFilterProviderFactoryBean
-
- AbstractGatewayComponentFactoryBean - Class in org.openspaces.core.gateway
-
Base class for replication gateway components.
- AbstractGatewayComponentFactoryBean() - Constructor for class org.openspaces.core.gateway.AbstractGatewayComponentFactoryBean
-
- AbstractGridServiceAgentProvisioningEvent - Class in org.openspaces.grid.gsm.machines.plugins.events
-
- AbstractGridServiceAgentProvisioningEvent() - Constructor for class org.openspaces.grid.gsm.machines.plugins.events.AbstractGridServiceAgentProvisioningEvent
-
- AbstractHibernateExternalDataSource - Class in org.openspaces.persistency.hibernate
-
- AbstractHibernateExternalDataSource() - Constructor for class org.openspaces.persistency.hibernate.AbstractHibernateExternalDataSource
-
Deprecated.
- AbstractHibernateSpaceDataSource - Class in org.openspaces.persistency.hibernate
-
- AbstractHibernateSpaceDataSource(SessionFactory, Set<String>, int, boolean, String[], int, int, boolean, String[], boolean, ClusterInfo) - Constructor for class org.openspaces.persistency.hibernate.AbstractHibernateSpaceDataSource
-
- AbstractHibernateSpaceSynchronizationEndpoint - Class in org.openspaces.persistency.hibernate
-
- AbstractHibernateSpaceSynchronizationEndpoint(SessionFactory, Set<String>) - Constructor for class org.openspaces.persistency.hibernate.AbstractHibernateSpaceSynchronizationEndpoint
-
- AbstractInstancesStatisticsConfig - Class in org.openspaces.admin.pu.statistics
-
- AbstractInstancesStatisticsConfig(Map<String, String>) - Constructor for class org.openspaces.admin.pu.statistics.AbstractInstancesStatisticsConfig
-
- AbstractJiniTransactionManager - Class in org.openspaces.core.transaction.manager
-
- AbstractJiniTransactionManager() - Constructor for class org.openspaces.core.transaction.manager.AbstractJiniTransactionManager
-
- AbstractJiniTransactionManager.JiniTransactionObject - Class in org.openspaces.core.transaction.manager
-
Jini Transaction object.
- AbstractJiniTransactionManager.UnexpectedTransactionException - Exception in org.openspaces.core.transaction.manager
-
- AbstractJiniTxManagerBeanDefinitionParser - Class in org.openspaces.core.config
-
- AbstractJiniTxManagerBeanDefinitionParser() - Constructor for class org.openspaces.core.config.AbstractJiniTxManagerBeanDefinitionParser
-
- AbstractLease - Class in com.sun.jini.lease
-
A base class for implementing lease objects.
- AbstractLease(long) - Constructor for class com.sun.jini.lease.AbstractLease
-
Construct a relative-format lease.
- AbstractLeaseMap - Class in com.sun.jini.lease
-
A base class for implementing LeaseMaps.
- AbstractLeaseMap(Map) - Constructor for class com.sun.jini.lease.AbstractLeaseMap
-
Provide a map of your choice.
- AbstractLeaseMap(Lease, long) - Constructor for class com.sun.jini.lease.AbstractLeaseMap
-
Default to using a small HashMap.
- AbstractLeaseMap(Map, Lease, long) - Constructor for class com.sun.jini.lease.AbstractLeaseMap
-
Provide a map of your choice.
- AbstractLocalCacheSpaceBeanDefinitionParser - Class in org.openspaces.core.config
-
A base class for local cache based beans.
- AbstractLocalCacheSpaceBeanDefinitionParser() - Constructor for class org.openspaces.core.config.AbstractLocalCacheSpaceBeanDefinitionParser
-
- AbstractLocalCacheSpaceFactoryBean - Class in org.openspaces.core.space.cache
-
Base class for different Local cache space proxies that work with a master
IJSpace
.
- AbstractLocalCacheSpaceFactoryBean() - Constructor for class org.openspaces.core.space.cache.AbstractLocalCacheSpaceFactoryBean
-
- AbstractLocalScriptExecutor<T> - Class in org.openspaces.remoting.scripting
-
- AbstractLocalScriptExecutor() - Constructor for class org.openspaces.remoting.scripting.AbstractLocalScriptExecutor
-
- AbstractMachineProvisioningEvent - Class in org.openspaces.grid.gsm.machines.plugins.events
-
- AbstractMachineProvisioningEvent() - Constructor for class org.openspaces.grid.gsm.machines.plugins.events.AbstractMachineProvisioningEvent
-
- AbstractMachinesSlaPolicy - Class in org.openspaces.grid.gsm.machines
-
- AbstractMachinesSlaPolicy() - Constructor for class org.openspaces.grid.gsm.machines.AbstractMachinesSlaPolicy
-
- AbstractManagedDataSourceDelegator - Class in org.openspaces.persistency.patterns
-
- AbstractManagedDataSourceDelegator(ManagedDataSource) - Constructor for class org.openspaces.persistency.patterns.AbstractManagedDataSourceDelegator
-
Deprecated.
- AbstractManagedDataSourceSplitter - Class in org.openspaces.persistency.patterns
-
- AbstractManagedDataSourceSplitter(ManagedDataSourceEntriesProvider[]) - Constructor for class org.openspaces.persistency.patterns.AbstractManagedDataSourceSplitter
-
Deprecated.
- AbstractMemoryOnlySearchReceiveOperationHandler - Class in org.openspaces.events.polling.receive
-
Support class to perform receive operations with or without memory only search..
- AbstractMemoryOnlySearchReceiveOperationHandler() - Constructor for class org.openspaces.events.polling.receive.AbstractMemoryOnlySearchReceiveOperationHandler
-
- AbstractMonitor - Class in org.openspaces.pu.sla.monitor
-
A base class for monitor classes.
- AbstractMonitor() - Constructor for class org.openspaces.pu.sla.monitor.AbstractMonitor
-
- AbstractNonBlockingReceiveOperationHandler - Class in org.openspaces.events.polling.receive
-
Support class to perform either non blocking or blocking receive operation.
- AbstractNonBlockingReceiveOperationHandler() - Constructor for class org.openspaces.events.polling.receive.AbstractNonBlockingReceiveOperationHandler
-
- AbstractPathAggregator<T extends Serializable> - Class in com.gigaspaces.query.aggregators
-
- AbstractPathAggregator() - Constructor for class com.gigaspaces.query.aggregators.AbstractPathAggregator
-
- AbstractPolicy - Class in org.openspaces.pu.sla
-
Simple base class for different policies.
- AbstractPolicy() - Constructor for class org.openspaces.pu.sla.AbstractPolicy
-
- AbstractReflectionDynamicEventTemplateProviderAdapter - Class in org.openspaces.events.adapter
-
Base class for reflection driven invocation of event template provider method.
- AbstractReflectionDynamicEventTemplateProviderAdapter() - Constructor for class org.openspaces.events.adapter.AbstractReflectionDynamicEventTemplateProviderAdapter
-
- AbstractReflectionEventListenerAdapter - Class in org.openspaces.events.adapter
-
Base class for reflection driven invocation of event listener methods.
- AbstractReflectionEventListenerAdapter() - Constructor for class org.openspaces.events.adapter.AbstractReflectionEventListenerAdapter
-
- AbstractReplicationFilterProviderFactory - Class in org.openspaces.core.space.filter.replication
-
Base class allowing to simplify replicaiton filter provider factories.
- AbstractReplicationFilterProviderFactory() - Constructor for class org.openspaces.core.space.filter.replication.AbstractReplicationFilterProviderFactory
-
- AbstractResultEventAdapterBeanDefinitionParser - Class in org.openspaces.events.config
-
- AbstractResultEventAdapterBeanDefinitionParser() - Constructor for class org.openspaces.events.config.AbstractResultEventAdapterBeanDefinitionParser
-
- AbstractResultEventAdapterFactoryBean - Class in org.openspaces.events.config
-
- AbstractResultEventAdapterFactoryBean() - Constructor for class org.openspaces.events.config.AbstractResultEventAdapterFactoryBean
-
- AbstractResultEventListenerAdapter - Class in org.openspaces.events.adapter
-
A base class event listener allowing for event listeners result handling by writing it back to
the space.
- AbstractResultEventListenerAdapter() - Constructor for class org.openspaces.events.adapter.AbstractResultEventListenerAdapter
-
- AbstractScaleStrategyBean - Class in org.openspaces.grid.gsm.strategy
-
- AbstractScaleStrategyBean() - Constructor for class org.openspaces.grid.gsm.strategy.AbstractScaleStrategyBean
-
- AbstractScrollableDataIterator - Class in org.openspaces.persistency.hibernate.iterator
-
A base class for scrollable result set (ScrollableResults
created based on either an
entity name or a SQLQuery
.
- AbstractScrollableDataIterator(String, SessionFactory, int, boolean) - Constructor for class org.openspaces.persistency.hibernate.iterator.AbstractScrollableDataIterator
-
Constructs a scrollable iterator over the given entity name.
- AbstractScrollableDataIterator(String, SessionFactory, int, boolean, int, int) - Constructor for class org.openspaces.persistency.hibernate.iterator.AbstractScrollableDataIterator
-
Constructs a scrollable iterator over the given entity name.
- AbstractScrollableDataIterator(String, SessionFactory, int) - Constructor for class org.openspaces.persistency.hibernate.iterator.AbstractScrollableDataIterator
-
Constructs a scrollable iterator over the given hibernate query string.
- AbstractScrollableDataIterator(String, SessionFactory, int, int, int) - Constructor for class org.openspaces.persistency.hibernate.iterator.AbstractScrollableDataIterator
-
Constructs a scrollable iterator over the given hibernate query string.
- AbstractScrollableDataIterator(SQLQuery, SessionFactory, int, boolean) - Constructor for class org.openspaces.persistency.hibernate.iterator.AbstractScrollableDataIterator
-
Constructs a scrollable iterator over the given GigaSpaces SQLQuery
.
- AbstractScrollableDataIterator(SQLQuery, SessionFactory, int, boolean, int, int) - Constructor for class org.openspaces.persistency.hibernate.iterator.AbstractScrollableDataIterator
-
Constructs a scrollable iterator over the given GigaSpaces SQLQuery
.
- AbstractSpaceBeanDefinitionParser - Class in org.openspaces.core.config
-
- AbstractSpaceBeanDefinitionParser() - Constructor for class org.openspaces.core.config.AbstractSpaceBeanDefinitionParser
-
- AbstractSpaceConfigurer - Class in org.openspaces.core.space
-
- AbstractSpaceConfigurer() - Constructor for class org.openspaces.core.space.AbstractSpaceConfigurer
-
- AbstractSpaceFactoryBean - Class in org.openspaces.core.space
-
Base class for most space factory beans responsible for creating/finding
IJSpace
implementation.
- AbstractSpaceFactoryBean() - Constructor for class org.openspaces.core.space.AbstractSpaceFactoryBean
-
- AbstractSpaceModeChangeEvent - Class in org.openspaces.core.space.mode
-
Base class for different space mode events.
- AbstractSpaceModeChangeEvent(IJSpace, SpaceMode) - Constructor for class org.openspaces.core.space.mode.AbstractSpaceModeChangeEvent
-
Creates a new Space mode event.
- AbstractSpaceProxyOperationModifierFactoryBean<T extends SpaceProxyOperationModifiers> - Class in org.openspaces.core.config.modifiers
-
Base class for different modifier types beans.
- AbstractSpaceProxyOperationModifierFactoryBean(Class<T>) - Constructor for class org.openspaces.core.config.modifiers.AbstractSpaceProxyOperationModifierFactoryBean
-
- AbstractTemplateEventContainerBeanDefinitionParser - Class in org.openspaces.events.config
-
- AbstractTemplateEventContainerBeanDefinitionParser() - Constructor for class org.openspaces.events.config.AbstractTemplateEventContainerBeanDefinitionParser
-
- AbstractTimeWindowStatisticsConfig - Class in org.openspaces.admin.pu.statistics
-
Base class for statistics configurations that aggregate samples based on a specified time window
- AbstractTimeWindowStatisticsConfig(Map<String, String>) - Constructor for class org.openspaces.admin.pu.statistics.AbstractTimeWindowStatisticsConfig
-
- AbstractTxEventContainerBeanDefinitionParser - Class in org.openspaces.events.config
-
- AbstractTxEventContainerBeanDefinitionParser() - Constructor for class org.openspaces.events.config.AbstractTxEventContainerBeanDefinitionParser
-
- AbstractXmlBeanNamespaceHandler - Class in org.openspaces.core.config.xmlparser
-
- AbstractXmlBeanNamespaceHandler() - Constructor for class org.openspaces.core.config.xmlparser.AbstractXmlBeanNamespaceHandler
-
- AbstractZonesConfig - Class in org.openspaces.admin.zone.config
-
- AbstractZonesConfig(Map<String, String>) - Constructor for class org.openspaces.admin.zone.config.AbstractZonesConfig
-
- accept(T) - Method in interface com.gigaspaces.client.iterator.SpaceIteratorConsumer
-
- accept(String) - Method in class com.gigaspaces.security.authorities.SpaceAuthority.ClassFilter
-
- accept(T) - Method in interface com.gigaspaces.security.authorities.SpaceAuthority.Filter
-
Tests whether or not the object is acceptable.
- accept(String) - Method in class com.gigaspaces.security.authorities.SpaceAuthority.NegateClassFilter
-
- accept(String) - Method in class com.gigaspaces.security.authorities.SpaceAuthority.NegatePackageFilter
-
- accept(String) - Method in class com.gigaspaces.security.authorities.SpaceAuthority.NegateRegexFilter
-
- accept(String) - Method in class com.gigaspaces.security.authorities.SpaceAuthority.PackageFilter
-
- accept(String) - Method in class com.gigaspaces.security.authorities.SpaceAuthority.RegexFilter
-
- acceptJavaVirtualMachine(Map<String, String>, Map<String, String>) - Method in interface org.openspaces.security.AdminFilter
-
Method indicates if java Virtual Machine with passed envVariables
and
sysProperties must be filtered
- acceptJvm(AdminFilter, JVMDetails) - Static method in class org.openspaces.security.AdminFilterHelper
-
- acceptJvm(AdminFilter, Map<String, String>, Map<String, String>) - Static method in class org.openspaces.security.AdminFilterHelper
-
- acceptProcessingUnit(Map<String, String>) - Method in interface org.openspaces.security.AdminFilter
-
Method indicates if processing unit with passed contextProperties
must be filtered
- acceptProcessingUnit(AdminFilter, BeanLevelProperties) - Static method in class org.openspaces.security.AdminFilterHelper
-
- acceptsURL(String) - Method in class com.j_spaces.jdbc.driver.GDriver
-
Only urls that start with jdbc:gigaspaces: are compliant
- acceptVisit(ExpressionVisitor) - Method in class org.openspaces.jpa.openjpa.query.AggregationFunction
-
Accept a visit from a tree visitor.
- acceptVisit(ExpressionVisitor) - Method in class org.openspaces.jpa.openjpa.query.BinaryExpression
-
- acceptVisit(ExpressionVisitor) - Method in class org.openspaces.jpa.openjpa.query.BindVariableExpression
-
- acceptVisit(ExpressionVisitor) - Method in class org.openspaces.jpa.openjpa.query.ContainsExpression
-
- acceptVisit(ExpressionVisitor) - Method in class org.openspaces.jpa.openjpa.query.EmptyExpression
-
- acceptVisit(ExpressionVisitor) - Method in class org.openspaces.jpa.openjpa.query.FieldPathNode
-
- acceptVisit(ExpressionVisitor) - Method in class org.openspaces.jpa.openjpa.query.InnerQuery
-
Accept a visit from a tree visitor.
- acceptVisit(ExpressionVisitor) - Method in class org.openspaces.jpa.openjpa.query.LiteralValueNode
-
- acceptVisit(ExpressionVisitor) - Method in class org.openspaces.jpa.openjpa.query.LogicalExpression
-
- acceptVisit(ExpressionVisitor) - Method in class org.openspaces.jpa.openjpa.query.MatchesExpression
-
- acceptVisit(ExpressionVisitor) - Method in class org.openspaces.jpa.openjpa.query.NullValueNode
-
- acceptVisit(ExpressionVisitor) - Method in class org.openspaces.jpa.openjpa.query.ParameterNode
-
- acceptVisit(ExpressionVisitor) - Method in class org.openspaces.jpa.openjpa.query.Variable
-
- AccessDeniedException - Exception in com.gigaspaces.security
-
Thrown if an operation is performed without a required authority.
- AccessDeniedException(String) - Constructor for exception com.gigaspaces.security.AccessDeniedException
-
Constructs a AccessDeniedException
with the specified detail message.
- AccessDeniedException(String, Throwable) - Constructor for exception com.gigaspaces.security.AccessDeniedException
-
Creates a AccessDeniedException
with the specified detail message and cause.
- action(Transaction) - Method in class com.j_spaces.core.client.XAResourceImpl
-
- ACTIVE - Static variable in interface net.jini.core.transaction.server.TransactionConstants
-
Transaction is currently active.
- ACTIVE - Static variable in class org.openspaces.pu.container.jee.stats.WebRequestsServiceMonitors.Attributes
-
- activeWhenBackup - Variable in class com.j_spaces.core.cluster.ReplicationPolicy.ReplicationPolicyDescription
-
- activeWhenPrimary(boolean) - Method in class org.openspaces.events.asyncpolling.SimpleAsyncPollingContainerConfigurer
-
- activeWhenPrimary(boolean) - Method in class org.openspaces.events.notify.SimpleNotifyContainerConfigurer
-
- activeWhenPrimary(boolean) - Method in class org.openspaces.events.polling.SimplePollingContainerConfigurer
-
- add(ChangeModifiers) - Method in class com.gigaspaces.client.ChangeModifiers
-
Creates a new modifiers instance which is a union of the specified modifiers and this instance.
- add(ClearModifiers) - Method in class com.gigaspaces.client.ClearModifiers
-
Creates a new modifiers instance which is a union of the specified modifiers and this instance.
- add(CountModifiers) - Method in class com.gigaspaces.client.CountModifiers
-
Creates a new modifiers instance which is a union of the specified modifiers and this instance.
- add(ReadModifiers) - Method in class com.gigaspaces.client.ReadModifiers
-
Creates a new modifiers instance which is a union of the specified modifiers and this instance.
- add(SpaceProxyOperationModifiers) - Method in class com.gigaspaces.client.SpaceProxyOperationModifiers
-
- add(TakeModifiers) - Method in class com.gigaspaces.client.TakeModifiers
-
Creates a new modifiers instance which is a union of the specified modifiers and this instance.
- add(WriteModifiers) - Method in class com.gigaspaces.client.WriteModifiers
-
Creates a new modifiers instance which is a union of the specified modifiers and this instance.
- add(SpaceEntriesAggregator) - Method in class com.gigaspaces.query.aggregators.AggregationSet
-
- add(Number, long) - Method in class com.gigaspaces.query.aggregators.AverageAggregator.AverageTuple
-
- add(long) - Method in class com.j_spaces.core.filters.StatisticsContext
-
For internal usage only
- add(AlertTriggeredEventListener) - Method in interface org.openspaces.admin.alert.events.AlertTriggeredEventManager
-
Add the event listener.
- add(AlertTriggeredEventListener, boolean) - Method in interface org.openspaces.admin.alert.events.AlertTriggeredEventManager
-
Add the event listener.
- add(ApplicationAddedEventListener) - Method in interface org.openspaces.admin.application.events.ApplicationAddedEventManager
-
Adds an event listener.
- add(ApplicationRemovedEventListener) - Method in interface org.openspaces.admin.application.events.ApplicationRemovedEventManager
-
Adds an event listener.
- add(DumpResult) - Method in class org.openspaces.admin.dump.CompoundDumpResult
-
- add(ElasticServiceManagerAddedEventListener) - Method in interface org.openspaces.admin.esm.events.ElasticServiceManagerAddedEventManager
-
Add the event listener.
- add(ElasticServiceManagerAddedEventListener, boolean) - Method in interface org.openspaces.admin.esm.events.ElasticServiceManagerAddedEventManager
-
Add the event listener.
- add(ElasticServiceManagerRemovedEventListener) - Method in interface org.openspaces.admin.esm.events.ElasticServiceManagerRemovedEventManager
-
Add the event listener.
- add(GatewayAddedEventListener) - Method in class org.openspaces.admin.gateway.events.DefaultGatewayAddedEventManager
-
- add(GatewayAddedEventListener, boolean) - Method in class org.openspaces.admin.gateway.events.DefaultGatewayAddedEventManager
-
- add(GatewayProcessingUnitAddedEventListener) - Method in class org.openspaces.admin.gateway.events.DefaultGatewayProcessingUnitAddedEventManager
-
- add(GatewayProcessingUnitAddedEventListener, boolean) - Method in class org.openspaces.admin.gateway.events.DefaultGatewayProcessingUnitAddedEventManager
-
- add(GatewayProcessingUnitRemovedEventListener) - Method in class org.openspaces.admin.gateway.events.DefaultGatewayProcessingUnitRemovedEventManager
-
- add(GatewayRemovedEventListener) - Method in class org.openspaces.admin.gateway.events.DefaultGatewayRemovedEventManager
-
- add(GatewayAddedEventListener) - Method in interface org.openspaces.admin.gateway.events.GatewayAddedEventManager
-
Adds an event listener.
- add(GatewayAddedEventListener, boolean) - Method in interface org.openspaces.admin.gateway.events.GatewayAddedEventManager
-
Adds an event listener.
- add(GatewayProcessingUnitAddedEventListener) - Method in interface org.openspaces.admin.gateway.events.GatewayProcessingUnitAddedEventManager
-
Adds an event listener.
- add(GatewayProcessingUnitAddedEventListener, boolean) - Method in interface org.openspaces.admin.gateway.events.GatewayProcessingUnitAddedEventManager
-
Adds an event listener.
- add(GatewayProcessingUnitRemovedEventListener) - Method in interface org.openspaces.admin.gateway.events.GatewayProcessingUnitRemovedEventManager
-
Adds an event listener.
- add(GatewayRemovedEventListener) - Method in interface org.openspaces.admin.gateway.events.GatewayRemovedEventManager
-
Adds an event listener.
- add(ElasticGridServiceAgentProvisioningFailureEventListener) - Method in interface org.openspaces.admin.gsa.events.ElasticGridServiceAgentProvisioningFailureEventManager
-
Adds an event listener, events will be raised if a machine failed to be provisioned for an Elastic PU.
- add(ElasticGridServiceAgentProvisioningProgressChangedEventListener) - Method in interface org.openspaces.admin.gsa.events.ElasticGridServiceAgentProvisioningProgressChangedEventManager
-
Adds the specified event listener and invokes the last progress event
- add(ElasticGridServiceAgentProvisioningProgressChangedEventListener, boolean) - Method in interface org.openspaces.admin.gsa.events.ElasticGridServiceAgentProvisioningProgressChangedEventManager
-
Adds the specified event listener and if specified invokes the last progress event.
- add(GridServiceAgentAddedEventListener) - Method in interface org.openspaces.admin.gsa.events.GridServiceAgentAddedEventManager
-
Add the event listener.
- add(GridServiceAgentAddedEventListener, boolean) - Method in interface org.openspaces.admin.gsa.events.GridServiceAgentAddedEventManager
-
Add the event listener.
- add(GridServiceAgentRemovedEventListener) - Method in interface org.openspaces.admin.gsa.events.GridServiceAgentRemovedEventManager
-
Add the event listener.
- add(ElasticGridServiceContainerProvisioningFailureEventListener) - Method in interface org.openspaces.admin.gsc.events.ElasticGridServiceContainerProvisioningFailureEventManager
-
Adds an event listener, events will be raised if a gsc failed to be provisioned.
- add(ElasticGridServiceContainerProvisioningProgressChangedEventListener) - Method in interface org.openspaces.admin.gsc.events.ElasticGridServiceContainerProvisioningProgressChangedEventManager
-
Adds the specified event listener and invokes the last progress event
- add(ElasticGridServiceContainerProvisioningProgressChangedEventListener, boolean) - Method in interface org.openspaces.admin.gsc.events.ElasticGridServiceContainerProvisioningProgressChangedEventManager
-
Adds the specified event listener and if specified invokes the last progress event.
- add(GridServiceContainerAddedEventListener) - Method in interface org.openspaces.admin.gsc.events.GridServiceContainerAddedEventManager
-
Add the event listener.
- add(GridServiceContainerAddedEventListener, boolean) - Method in interface org.openspaces.admin.gsc.events.GridServiceContainerAddedEventManager
-
Add the event listener.
- add(GridServiceContainerRemovedEventListener) - Method in interface org.openspaces.admin.gsc.events.GridServiceContainerRemovedEventManager
-
Add the event listener.
- add(GridServiceManagerAddedEventListener) - Method in interface org.openspaces.admin.gsm.events.GridServiceManagerAddedEventManager
-
Add the event listener.
- add(GridServiceManagerAddedEventListener, boolean) - Method in interface org.openspaces.admin.gsm.events.GridServiceManagerAddedEventManager
-
Add the event listener.
- add(GridServiceManagerRemovedEventListener) - Method in interface org.openspaces.admin.gsm.events.GridServiceManagerRemovedEventManager
-
Add the event listener.
- add(LookupServiceAddedEventListener) - Method in interface org.openspaces.admin.lus.events.LookupServiceAddedEventManager
-
Add the event listener.
- add(LookupServiceAddedEventListener, boolean) - Method in interface org.openspaces.admin.lus.events.LookupServiceAddedEventManager
-
Add the event listener.
- add(LookupServiceRemovedEventListener) - Method in interface org.openspaces.admin.lus.events.LookupServiceRemovedEventManager
-
Add the event listener.
- add(ElasticMachineProvisioningFailureEventListener) - Method in interface org.openspaces.admin.machine.events.ElasticMachineProvisioningFailureEventManager
-
- add(ElasticMachineProvisioningProgressChangedEventListener, boolean) - Method in interface org.openspaces.admin.machine.events.ElasticMachineProvisioningProgressChangedEventManager
-
Adds the specified event listener.
- add(ElasticMachineProvisioningProgressChangedEventListener) - Method in interface org.openspaces.admin.machine.events.ElasticMachineProvisioningProgressChangedEventManager
-
Adds the specified event listener and invokes with the last progress changed event.
- add(MachineAddedEventListener) - Method in interface org.openspaces.admin.machine.events.MachineAddedEventManager
-
Add the event listener.
- add(MachineAddedEventListener, boolean) - Method in interface org.openspaces.admin.machine.events.MachineAddedEventManager
-
Add the event listener.
- add(MachineRemovedEventListener) - Method in interface org.openspaces.admin.machine.events.MachineRemovedEventManager
-
Add the event listener.
- add(OperatingSystemsStatisticsChangedEventListener) - Method in interface org.openspaces.admin.os.events.OperatingSystemsStatisticsChangedEventManager
-
Adds an event listener.
- add(OperatingSystemsStatisticsChangedEventListener, boolean) - Method in interface org.openspaces.admin.os.events.OperatingSystemsStatisticsChangedEventManager
-
Adds an event listener.
- add(OperatingSystemStatisticsChangedEventListener) - Method in interface org.openspaces.admin.os.events.OperatingSystemStatisticsChangedEventManager
-
Adds an event listener.
- add(OperatingSystemStatisticsChangedEventListener, boolean) - Method in interface org.openspaces.admin.os.events.OperatingSystemStatisticsChangedEventManager
-
Adds an event listener.
- add(ElasticAutoScalingFailureEventListener) - Method in interface org.openspaces.admin.pu.elastic.events.ElasticAutoScalingFailureEventManager
-
- add(ElasticAutoScalingProgressChangedEventListener, boolean) - Method in interface org.openspaces.admin.pu.elastic.events.ElasticAutoScalingProgressChangedEventManager
-
Adds the specified event listener.
- add(ElasticAutoScalingProgressChangedEventListener) - Method in interface org.openspaces.admin.pu.elastic.events.ElasticAutoScalingProgressChangedEventManager
-
Adds the specified event listener and invokes with the last progress changed event.
- add(BackupGridServiceManagerChangedEventListener) - Method in interface org.openspaces.admin.pu.events.BackupGridServiceManagerChangedEventManager
-
Adds an event listener.
- add(BackupGridServiceManagerChangedEventListener, boolean) - Method in interface org.openspaces.admin.pu.events.BackupGridServiceManagerChangedEventManager
-
Adds an event listener.
- add(ManagingGridServiceManagerChangedEventListener) - Method in interface org.openspaces.admin.pu.events.ManagingGridServiceManagerChangedEventManager
-
Adds an event listener.
- add(ManagingGridServiceManagerChangedEventListener, boolean) - Method in interface org.openspaces.admin.pu.events.ManagingGridServiceManagerChangedEventManager
-
Adds an event listener.
- add(ProcessingUnitAddedEventListener) - Method in interface org.openspaces.admin.pu.events.ProcessingUnitAddedEventManager
-
Adds an event listener.
- add(ProcessingUnitAddedEventListener, boolean) - Method in interface org.openspaces.admin.pu.events.ProcessingUnitAddedEventManager
-
Adds an event listener.
- add(ProcessingUnitInstanceAddedEventListener) - Method in interface org.openspaces.admin.pu.events.ProcessingUnitInstanceAddedEventManager
-
Adds an event listener, events will be raised both for existing processing unit instances
and new ones.
- add(ProcessingUnitInstanceAddedEventListener, boolean) - Method in interface org.openspaces.admin.pu.events.ProcessingUnitInstanceAddedEventManager
-
Adds an event listener.
- add(ProcessingUnitInstanceMemberAliveIndicatorStatusChangedEventListener) - Method in interface org.openspaces.admin.pu.events.ProcessingUnitInstanceMemberAliveIndicatorStatusChangedEventManager
-
Adds an event listener.
- add(ProcessingUnitInstanceMemberAliveIndicatorStatusChangedEventListener, boolean) - Method in interface org.openspaces.admin.pu.events.ProcessingUnitInstanceMemberAliveIndicatorStatusChangedEventManager
-
Adds an event listener.
- add(ProcessingUnitInstanceProvisionStatusChangedEventListener) - Method in interface org.openspaces.admin.pu.events.ProcessingUnitInstanceProvisionStatusChangedEventManager
-
Adds an event listener.
- add(ProcessingUnitInstanceProvisionStatusChangedEventListener, boolean) - Method in interface org.openspaces.admin.pu.events.ProcessingUnitInstanceProvisionStatusChangedEventManager
-
Adds an event listener.
- add(ProcessingUnitInstanceRemovedEventListener) - Method in interface org.openspaces.admin.pu.events.ProcessingUnitInstanceRemovedEventManager
-
Adds an event listener.
- add(ProcessingUnitInstanceStatisticsChangedEventListener) - Method in interface org.openspaces.admin.pu.events.ProcessingUnitInstanceStatisticsChangedEventManager
-
Adds an event listener.
- add(ProcessingUnitRemovedEventListener) - Method in interface org.openspaces.admin.pu.events.ProcessingUnitRemovedEventManager
-
Adds an event listener.
- add(ProcessingUnitSpaceCorrelatedEventListener) - Method in interface org.openspaces.admin.pu.events.ProcessingUnitSpaceCorrelatedEventManager
-
Adds an event listener.
- add(ProcessingUnitStatusChangedEventListener) - Method in interface org.openspaces.admin.pu.events.ProcessingUnitStatusChangedEventManager
-
Adds an event listener.
- add(ProcessingUnitStatusChangedEventListener, boolean) - Method in interface org.openspaces.admin.pu.events.ProcessingUnitStatusChangedEventManager
-
Adds an event listener.
- add(ReplicationStatusChangedEventListener) - Method in interface org.openspaces.admin.space.events.ReplicationStatusChangedEventManager
-
Adds an event listener.
- add(SpaceAddedEventListener) - Method in interface org.openspaces.admin.space.events.SpaceAddedEventManager
-
Adds an event listener.
- add(SpaceAddedEventListener, boolean) - Method in interface org.openspaces.admin.space.events.SpaceAddedEventManager
-
Adds an event listener allowing to control using the includeExisting
if events
will be fired for existing spaces as well.
- add(SpaceInstanceAddedEventListener) - Method in interface org.openspaces.admin.space.events.SpaceInstanceAddedEventManager
-
Adds an event listener.
- add(SpaceInstanceAddedEventListener, boolean) - Method in interface org.openspaces.admin.space.events.SpaceInstanceAddedEventManager
-
Adds an event listener allowing to control using the includeExisting
if events
will be fired for existing space instances as well.
- add(SpaceInstanceRemovedEventListener) - Method in interface org.openspaces.admin.space.events.SpaceInstanceRemovedEventManager
-
Adds an event listener.
- add(SpaceInstanceStatisticsChangedEventListener) - Method in interface org.openspaces.admin.space.events.SpaceInstanceStatisticsChangedEventManager
-
Adds an event listener.
- add(SpaceModeChangedEventListener) - Method in interface org.openspaces.admin.space.events.SpaceModeChangedEventManager
-
Adds an event listener.
- add(SpaceRemovedEventListener) - Method in interface org.openspaces.admin.space.events.SpaceRemovedEventManager
-
Adds an event listener.
- add(SpaceStatisticsChangedEventListener) - Method in interface org.openspaces.admin.space.events.SpaceStatisticsChangedEventManager
-
Adds an event listener.
- add(TransportsStatisticsChangedEventListener) - Method in interface org.openspaces.admin.transport.events.TransportsStatisticsChangedEventManager
-
Adds an event listener.
- add(TransportStatisticsChangedEventListener) - Method in interface org.openspaces.admin.transport.events.TransportStatisticsChangedEventManager
-
Adds an event listener.
- add(VirtualMachineAddedEventListener) - Method in interface org.openspaces.admin.vm.events.VirtualMachineAddedEventManager
-
Add the event listener.
- add(VirtualMachineAddedEventListener, boolean) - Method in interface org.openspaces.admin.vm.events.VirtualMachineAddedEventManager
-
Add the event listener.
- add(VirtualMachineRemovedEventListener) - Method in interface org.openspaces.admin.vm.events.VirtualMachineRemovedEventManager
-
Add the event listener.
- add(VirtualMachinesStatisticsChangedEventListener) - Method in interface org.openspaces.admin.vm.events.VirtualMachinesStatisticsChangedEventManager
-
Adds an event listener.
- add(VirtualMachinesStatisticsChangedEventListener, boolean) - Method in interface org.openspaces.admin.vm.events.VirtualMachinesStatisticsChangedEventManager
-
Adds an event listener.
- add(VirtualMachineStatisticsChangedEventListener) - Method in interface org.openspaces.admin.vm.events.VirtualMachineStatisticsChangedEventManager
-
Adds an event listener.
- add(VirtualMachineStatisticsChangedEventListener, boolean) - Method in interface org.openspaces.admin.vm.events.VirtualMachineStatisticsChangedEventManager
-
Adds an event listener, will also fire events for history statistics.
- add(ZoneAddedEventListener) - Method in interface org.openspaces.admin.zone.events.ZoneAddedEventManager
-
Add the event listener.
- add(ZoneRemovedEventListener) - Method in interface org.openspaces.admin.zone.events.ZoneRemovedEventManager
-
Add the event listener.
- add(Task<T>) - Method in class org.openspaces.core.ExecutorBuilder
-
- add(Task<T>, AsyncFutureListener<T>) - Method in class org.openspaces.core.ExecutorBuilder
-
- add(Task<T>, Object) - Method in class org.openspaces.core.ExecutorBuilder
-
- add(DistributedTask<T, R>, Object...) - Method in class org.openspaces.core.ExecutorBuilder
-
- add(DistributedTask<T, R>) - Method in class org.openspaces.core.ExecutorBuilder
-
- add(E) - Method in class org.openspaces.core.util.ConcurrentHashSet
-
Adds the specified element to this set if it is not already
present.
- add(Number, Number) - Method in class org.openspaces.core.util.numbers.BigDecimalHelper
-
- add(Number, Number) - Method in class org.openspaces.core.util.numbers.BigIntegerHelper
-
- add(Number, Number) - Method in class org.openspaces.core.util.numbers.DoubleHelper
-
- add(Number, Number) - Method in class org.openspaces.core.util.numbers.FloatHelper
-
- add(Number, Number) - Method in class org.openspaces.core.util.numbers.IntegerHelper
-
- add(Number, Number) - Method in class org.openspaces.core.util.numbers.LongHelper
-
- add(Number, Number) - Method in interface org.openspaces.core.util.numbers.NumberHelper
-
Adds the two numbers (can be of any Number type) and returns the type result
that the number helper handles.
- add(Number, Number) - Method in class org.openspaces.core.util.numbers.ShortHelper
-
- add(CapacityRequirement) - Method in class org.openspaces.grid.gsm.capacity.AbstractCapacityRequirement
-
- add(CapacityRequirement) - Method in interface org.openspaces.grid.gsm.capacity.CapacityRequirement
-
- add(CapacityRequirements) - Method in class org.openspaces.grid.gsm.capacity.CapacityRequirements
-
- add(CapacityRequirement) - Method in class org.openspaces.grid.gsm.capacity.CapacityRequirements
-
- add(String, CapacityRequirements) - Method in class org.openspaces.grid.gsm.capacity.CapacityRequirementsPerAgent
-
- add(CapacityRequirementsPerAgent) - Method in class org.openspaces.grid.gsm.capacity.CapacityRequirementsPerAgent
-
- add(ZonesConfig, CapacityRequirements) - Method in class org.openspaces.grid.gsm.capacity.CapacityRequirementsPerZones
-
- add(CapacityRequirementsPerZones) - Method in class org.openspaces.grid.gsm.capacity.CapacityRequirementsPerZones
-
- add(CapacityRequirement) - Method in class org.openspaces.grid.gsm.capacity.CpuCapacityRequirement
-
- add(Value, Value) - Method in class org.openspaces.jpa.openjpa.query.QueryExpressionFactory
-
Return a value representing the two values added together.
- add(int) - Method in class org.openspaces.memcached.LocalCacheElement
-
- add(LocalCacheElement) - Method in class org.openspaces.memcached.SpaceCache
-
- addAll(Collection<? extends E>) - Method in class org.openspaces.core.util.ConcurrentHashSet
-
- addAllToCollection(String, Serializable...) - Method in class com.gigaspaces.client.ChangeSet
-
Adds the given items to a collection property
- addAllToCollection(String, Collection<? extends Serializable>) - Method in class com.gigaspaces.client.ChangeSet
-
Adds the given items to a collection property
- AddAllToCollectionOperation - Class in com.gigaspaces.sync.change
-
- addAndGet(GigaSpace, IdQuery<T>, String, D) - Static method in class org.openspaces.extensions.ChangeExtension
-
Atomically adds the given value to the current value of an entry's property.
- addAndGet(GigaSpace, IdQuery<T>, String, D, long, TimeUnit) - Static method in class org.openspaces.extensions.ChangeExtension
-
Atomically adds the given value to the current value of an entry's property.
- addAndGet(GigaSpace, IdQuery<T>, String, D, ChangeModifiers, long, TimeUnit) - Static method in class org.openspaces.extensions.ChangeExtension
-
Atomically adds the given value to the current value of an entry's property.
- addBeanPostProcessor(BeanPostProcessor) - Method in class org.openspaces.pu.container.jee.context.ProcessingUnitWebApplicationContext
-
Adds Spring bean post processor.
- addBeanPostProcessor(BeanPostProcessor) - Method in class org.openspaces.pu.container.support.ResourceApplicationContext
-
Adds Spring bean post processor.
- addCapacity(ZonesConfig, ScaleStrategyCapacityRequirementConfig) - Method in class org.openspaces.admin.pu.elastic.config.CapacityRequirementsPerZonesConfig
-
- addCapacity(ExactZonesConfig, CapacityRequirementsConfig) - Method in class org.openspaces.admin.pu.elastic.config.ManualCapacityPerZonesScaleConfig
-
- addCommandLineArgument(String) - Method in class org.openspaces.admin.pu.elastic.ElasticStatefulProcessingUnitDeployment
-
- addCommandLineArgument(String) - Method in class org.openspaces.admin.pu.elastic.ElasticStatelessProcessingUnitDeployment
-
- addCommandLineArgument(String) - Method in interface org.openspaces.admin.pu.elastic.topology.ElasticDeploymentTopology
-
Will add a JVM level argument when the process is executed using pure JVM.
- addCommandLineArgument(String) - Method in class org.openspaces.admin.space.ElasticSpaceDeployment
-
- addCompoundIndex(String[], SpaceIndexType) - Method in class com.gigaspaces.metadata.SpaceTypeDescriptorBuilder
-
Deprecated.
- addCompoundIndex(String[]) - Method in class com.gigaspaces.metadata.SpaceTypeDescriptorBuilder
-
Adds an index of the specified type for the specified path.
- addCompoundIndex(String[], SpaceIndexType, boolean) - Method in class com.gigaspaces.metadata.SpaceTypeDescriptorBuilder
-
Deprecated.
- addCompoundIndex(String[], boolean) - Method in class com.gigaspaces.metadata.SpaceTypeDescriptorBuilder
-
Adds an index of the specified type for the specified path.
- addConfigLocation(Resource) - Method in class org.openspaces.pu.container.integrated.IntegratedProcessingUnitContainerProvider
-
Adds a config location using Springs
Resource
abstraction.
- addConfigLocation(String) - Method in class org.openspaces.pu.container.integrated.IntegratedProcessingUnitContainerProvider
-
- addConfigLocation(Resource) - Method in class org.openspaces.pu.container.jee.JeeProcessingUnitContainerProvider
-
Adds a config location using Springs
Resource
abstraction.
- addConfigLocation(String) - Method in class org.openspaces.pu.container.jee.JeeProcessingUnitContainerProvider
-
- addConfigLocation(String) - Method in class org.openspaces.pu.container.spi.ApplicationContextProcessingUnitContainerProvider
-
- addConfigLocation(Resource) - Method in class org.openspaces.pu.container.spi.ApplicationContextProcessingUnitContainerProvider
-
- addConfigLocation(String) - Method in class org.openspaces.pu.container.standalone.StandaloneProcessingUnitContainerProvider
-
- addConfigLocation(Resource) - Method in class org.openspaces.pu.container.standalone.StandaloneProcessingUnitContainerProvider
-
- addConnectionProperty(String, String) - Method in class org.openspaces.jdbc.datasource.DbcpBasicDataSource
-
Add a custom connection property to the set that will be passed to our
JDBC driver.
- addContextProperty(String, String) - Method in class org.openspaces.admin.pu.elastic.ElasticStatefulProcessingUnitDeployment
-
- addContextProperty(String, String) - Method in class org.openspaces.admin.pu.elastic.ElasticStatelessProcessingUnitDeployment
-
- addContextProperty(String, String) - Method in interface org.openspaces.admin.pu.elastic.topology.ElasticDeploymentTopology
-
Defines a context deploy time property overriding any ${...}
- addContextProperty(String, String) - Method in class org.openspaces.admin.space.ElasticSpaceDeployment
-
- addDependencies(ProcessingUnitDetailedDependencies<? extends ProcessingUnitDependency>) - Method in class org.openspaces.admin.memcached.MemcachedDeployment
-
Postpones deployment of processing unit instances until the specified dependencies are met.
- addDependencies(ProcessingUnitDetailedDependencies<? extends ProcessingUnitDependency>) - Method in class org.openspaces.admin.pu.elastic.ElasticStatefulProcessingUnitDeployment
-
- addDependencies(ProcessingUnitDetailedDependencies<? extends ProcessingUnitDependency>) - Method in class org.openspaces.admin.pu.elastic.ElasticStatelessProcessingUnitDeployment
-
- addDependencies(ProcessingUnitDetailedDependencies<? extends ProcessingUnitDependency>) - Method in class org.openspaces.admin.pu.ProcessingUnitDeployment
-
Postpones deployment of processing unit instances until the specified dependencies are met.
- addDependencies(ProcessingUnitDetailedDependencies<? extends ProcessingUnitDependency>) - Method in interface org.openspaces.admin.pu.topology.ProcessingUnitDeploymentTopology
-
Postpones deployment of processing unit instances until the specified dependencies are met.
- addDependencies(ProcessingUnitDetailedDependencies<? extends ProcessingUnitDependency>) - Method in class org.openspaces.admin.space.ElasticSpaceDeployment
-
- addDependencies(ProcessingUnitDetailedDependencies<? extends ProcessingUnitDependency>) - Method in class org.openspaces.admin.space.SpaceDeployment
-
Postpones deployment of processing unit instances until the specified dependencies are met.
- addDependency(String) - Method in class org.openspaces.admin.memcached.MemcachedDeployment
-
Postpones deployment of processing unit instances deployment until the specified processing unit deployment is complete.
- addDependency(String) - Method in class org.openspaces.admin.pu.elastic.ElasticStatefulProcessingUnitDeployment
-
- addDependency(String) - Method in class org.openspaces.admin.pu.elastic.ElasticStatelessProcessingUnitDeployment
-
- addDependency(String) - Method in class org.openspaces.admin.pu.ProcessingUnitDeployment
-
Postpones deployment of processing unit instances deployment until the specified processing unit deployment is complete.
- addDependency(String) - Method in interface org.openspaces.admin.pu.topology.ProcessingUnitDeploymentTopology
-
Postpones deployment of processing unit instances deployment until the specified processing unit deployment is complete.
- addDependency(String) - Method in class org.openspaces.admin.space.ElasticSpaceDeployment
-
- addDependency(String) - Method in class org.openspaces.admin.space.SpaceDeployment
-
Postpones deployment of processing unit instances deployment until the specified processing unit deployment is complete.
- addEnvironmentVariable(String, String) - Method in class org.openspaces.admin.pu.elastic.ElasticStatefulProcessingUnitDeployment
-
- addEnvironmentVariable(String, String) - Method in class org.openspaces.admin.pu.elastic.ElasticStatelessProcessingUnitDeployment
-
- addEnvironmentVariable(String, String) - Method in interface org.openspaces.admin.pu.elastic.topology.ElasticDeploymentTopology
-
Defines an environment variable that will be passed to forked process.
- addEnvironmentVariable(String, String) - Method in class org.openspaces.admin.space.ElasticSpaceDeployment
-
- addEventListener(AdminEventListener) - Method in interface org.openspaces.admin.Admin
-
Smart addition of event listeners.
- addEventListener(AdminEventListener, boolean) - Method in interface org.openspaces.admin.Admin
-
Smart addition of event listeners.
- addFifoGroupingIndex(String) - Method in class com.gigaspaces.metadata.SpaceTypeDescriptorBuilder
-
Sets a fifo grouping index
- addFilterProvider(FilterProviderFactory) - Method in class org.openspaces.core.space.EmbeddedSpaceConfigurer
-
- addFilterProvider(FilterProviderFactory) - Method in class org.openspaces.core.space.UrlSpaceConfigurer
-
- addFixedProperty(String, Class<?>) - Method in class com.gigaspaces.metadata.SpaceTypeDescriptorBuilder
-
Adds a property to the fixed properties set.
- addFixedProperty(String, Class<?>, SpaceDocumentSupport) - Method in class com.gigaspaces.metadata.SpaceTypeDescriptorBuilder
-
Adds a property to the fixed properties set.
- addFixedProperty(String, Class<?>, StorageType) - Method in class com.gigaspaces.metadata.SpaceTypeDescriptorBuilder
-
Adds a property to the fixed properties set.
- addFixedProperty(String, Class<?>, SpaceDocumentSupport, StorageType) - Method in class com.gigaspaces.metadata.SpaceTypeDescriptorBuilder
-
Adds a property to the fixed properties set.
- addFixedProperty(String, String) - Method in class com.gigaspaces.metadata.SpaceTypeDescriptorBuilder
-
Adds a property to the fixed properties set.
- addFixedProperty(String, String, SpaceDocumentSupport) - Method in class com.gigaspaces.metadata.SpaceTypeDescriptorBuilder
-
- addFixedProperty(String, String, SpaceDocumentSupport, StorageType) - Method in class com.gigaspaces.metadata.SpaceTypeDescriptorBuilder
-
- addFutureAgents(MachinesSlaEnforcementState.StateKey, FutureGridServiceAgent[], CapacityRequirements) - Method in class org.openspaces.grid.gsm.machines.MachinesSlaEnforcementState
-
- addFutureStoppedMachine(MachinesSlaEnforcementState.StateKey, FutureStoppedMachine) - Method in class org.openspaces.grid.gsm.machines.MachinesSlaEnforcementState
-
- addGateway(Gateway) - Method in interface org.openspaces.admin.gateway.InternalGateways
-
- addGatewayTarget(GatewayTarget) - Method in interface org.openspaces.admin.space.SpaceReplicationManager
-
Adds a new gateway target to the
Space
this manager manages, will wait until the gateway target is added in all
of the
SpaceInstance
s that belong to this space.
- addGridServiceAgentZone(String) - Method in class org.openspaces.admin.pu.elastic.config.DiscoveredMachineProvisioningConfigurer
-
- addGroup(String) - Method in class org.openspaces.admin.AdminFactory
-
Adds a lookup group that will be used to find Lookup Services (using multicast)
that will be used to listen for events.
- addGroups(String) - Method in class org.openspaces.admin.AdminFactory
-
Adds a comma delimited string of groups that will be used to find the Lookup Services
(using multicast).
- addIndex(SpaceIndex) - Method in class com.gigaspaces.metadata.SpaceTypeDescriptorBuilder
-
Adds the specified index to the type's index set.
- AddIndexConflict - Interface in com.gigaspaces.cluster.replication.gateway.conflict
-
- AddIndexData - Interface in com.gigaspaces.sync
-
- AddIndexesConflict - Class in com.gigaspaces.cluster.replication.gateway.conflict
-
A
ConflictCause
implementation for an add indexes operation conflict.
- AddIndexesConflict(String) - Constructor for class com.gigaspaces.cluster.replication.gateway.conflict.AddIndexesConflict
-
- addInvoker(Map<Integer, FilterOperationDelegateInvoker>, Method, int) - Method in class org.openspaces.core.space.filter.AbstractFilterProviderAdapterFactoryBean
-
Helper method for basclasses that add an invoker to the lookup map.
- addKeyToResponse - Variable in class org.openspaces.memcached.protocol.CommandMessage
-
- addLifecycleEventListener(ProcessingUnitInstanceLifecycleEventListener) - Method in interface org.openspaces.admin.machine.Machine
-
- addLifecycleListener(ApplicationLifecycleEventListener) - Method in interface org.openspaces.admin.application.Applications
-
- addLifecycleListener(ElasticServiceManagerLifecycleEventListener) - Method in interface org.openspaces.admin.esm.ElasticServiceManagers
-
- addLifecycleListener(GatewayProcessingUnitLifecycleEventListener) - Method in interface org.openspaces.admin.gateway.GatewayProcessingUnits
-
- addLifecycleListener(GatewayLifecycleEventListener) - Method in interface org.openspaces.admin.gateway.Gateways
-
- addLifecycleListener(GridServiceAgentLifecycleEventListener) - Method in interface org.openspaces.admin.gsa.GridServiceAgents
-
- addLifecycleListener(GridServiceContainerLifecycleEventListener) - Method in interface org.openspaces.admin.gsc.GridServiceContainers
-
- addLifecycleListener(GridServiceManagerLifecycleEventListener) - Method in interface org.openspaces.admin.gsm.GridServiceManagers
-
- addLifecycleListener(LookupServiceLifecycleEventListener) - Method in interface org.openspaces.admin.lus.LookupServices
-
- addLifecycleListener(SpaceInstanceLifecycleEventListener) - Method in interface org.openspaces.admin.machine.Machine
-
- addLifecycleListener(MachineLifecycleEventListener) - Method in interface org.openspaces.admin.machine.Machines
-
- addLifecycleListener(ProcessingUnitInstanceLifecycleEventListener) - Method in interface org.openspaces.admin.pu.ProcessingUnit
-
- addLifecycleListener(ProcessingUnitLifecycleEventListener) - Method in interface org.openspaces.admin.pu.ProcessingUnits
-
- addLifecycleListener(ProcessingUnitInstanceLifecycleEventListener) - Method in interface org.openspaces.admin.pu.ProcessingUnits
-
- addLifecycleListener(SpaceInstanceLifecycleEventListener) - Method in interface org.openspaces.admin.space.Space
-
- addLifecycleListener(SpaceLifecycleEventListener) - Method in interface org.openspaces.admin.space.Spaces
-
- addLifecycleListener(SpaceInstanceLifecycleEventListener) - Method in interface org.openspaces.admin.space.Spaces
-
- addLifecycleListener(SpaceInstanceLifecycleEventListener) - Method in interface org.openspaces.admin.vm.VirtualMachine
-
- addLifecycleListener(VirtualMachineLifecycleEventListener) - Method in interface org.openspaces.admin.vm.VirtualMachines
-
- addLifecycleListener(SpaceInstanceLifecycleEventListener) - Method in interface org.openspaces.admin.zone.Zone
-
- addLifecycleListener(ZoneLifecycleEventListener) - Method in interface org.openspaces.admin.zone.Zones
-
- addListener(Object, RemoteEventListener) - Method in interface com.gigaspaces.events.DataEventSession
-
Registers a listener with a space using a POJO template.
- addListener(Object, RemoteEventListener, NotifyActionType) - Method in interface com.gigaspaces.events.DataEventSession
-
Registers a listener with a space using a POJO template
- addListener(Object, RemoteEventListener, NotifyActionType, MarshalledObject, INotifyDelegatorFilter) - Method in interface com.gigaspaces.events.DataEventSession
-
Registers a listener with a space using a POJO template
- addListener(Object, RemoteEventListener, long, NotifyActionType) - Method in interface com.gigaspaces.events.DataEventSession
-
- addListener(Object, RemoteEventListener, long, MarshalledObject, INotifyDelegatorFilter, NotifyActionType) - Method in interface com.gigaspaces.events.DataEventSession
-
- addListener(CacheListener) - Method in interface com.j_spaces.javax.cache.Cache
-
Deprecated.
Add a listener to the list of cache listeners.
- addListener(CacheListener) - Method in class org.openspaces.core.DefaultGigaMap
-
- addLocator(String) - Method in class org.openspaces.admin.AdminFactory
-
Adds a lookup locator (ip and port) of the lookup service that will be used to listen
for events.
- addLocators(String) - Method in class org.openspaces.admin.AdminFactory
-
Adds a comma delimited lookup locators (ip and port) of the lookup service that will
be used to listen for events.
- addLookupAttributes(Entry[]) - Method in class com.sun.jini.mahalo.TxnManagerImpl
-
- addLookupGroups(String[]) - Method in class com.sun.jini.mahalo.TxnManagerImpl
-
- addLookupLocators(LookupLocator[]) - Method in class com.sun.jini.mahalo.TxnManagerImpl
-
- addNotificationListener(NotificationListener, NotificationFilter, Object) - Method in class org.openspaces.pu.container.servicegrid.jmxs.SecuredPUExtension
-
- addParameter(String, String) - Method in class org.openspaces.core.space.UrlSpaceConfigurer
-
- addPathIndex(String, SpaceIndexType) - Method in class com.gigaspaces.metadata.SpaceTypeDescriptorBuilder
-
Adds an index of the specified type for the specified path.
- addPathIndex(String, SpaceIndexType, boolean) - Method in class com.gigaspaces.metadata.SpaceTypeDescriptorBuilder
-
Adds an index of the specified type for the specified path.
- addProcessingUnit(ProcessingUnitConfigHolder) - Method in class org.openspaces.admin.application.config.ApplicationConfig
-
- addProcessingUnitDeployment(ProcessingUnitDeploymentTopology) - Method in class org.openspaces.admin.application.ApplicationDeployment
-
Adds a processing unit deployment to this application deployment.
- addProcessingUnitDeployment(ProcessingUnitConfigHolder) - Method in class org.openspaces.admin.application.ApplicationDeployment
-
- addProcessingUnitInstanceLifecycleEventListener(ProcessingUnitInstanceLifecycleEventListener) - Method in interface org.openspaces.admin.gsc.GridServiceContainer
-
Adds a processing unit lifecycle listener to the container.
- addProcessingUnitInstanceLifecycleEventListener(ProcessingUnitInstanceLifecycleEventListener) - Method in interface org.openspaces.admin.vm.VirtualMachine
-
- addProcessingUnitInstanceLifecycleEventListener(ProcessingUnitInstanceLifecycleEventListener) - Method in interface org.openspaces.admin.zone.Zone
-
- addProperties(Map<String, Object>) - Method in class com.gigaspaces.document.SpaceDocument
- addProperties(Properties) - Method in class org.openspaces.core.space.EmbeddedSpaceConfigurer
-
- addProperties(Properties) - Method in class org.openspaces.core.space.SpaceProxyConfigurer
-
- addProperties(Properties) - Method in class org.openspaces.core.space.UrlSpaceConfigurer
-
- addProperty(String, String) - Method in class org.openspaces.core.space.cache.AbstractLocalCacheSpaceFactoryBean
-
- addProperty(String, String) - Method in class org.openspaces.core.space.cache.LocalCacheSpaceConfigurer
-
- addProperty(String, String) - Method in class org.openspaces.core.space.cache.LocalViewSpaceConfigurer
-
- addProperty(String, String) - Method in class org.openspaces.core.space.EmbeddedSpaceConfigurer
-
- addProperty(String, String) - Method in class org.openspaces.core.space.SpaceProxyConfigurer
-
- addProperty(String, String) - Method in class org.openspaces.core.space.UrlSpaceConfigurer
-
- addPropertyIndex(String, SpaceIndexType) - Method in class com.gigaspaces.metadata.SpaceTypeDescriptorBuilder
-
Adds an index of the specified type for the specified property.
- addPropertyIndex(String, SpaceIndexType, boolean) - Method in class com.gigaspaces.metadata.SpaceTypeDescriptorBuilder
-
Adds an index of the specified type for the specified property.
- addQueryExtensionInfo(String, Class<? extends Annotation>) - Method in class com.gigaspaces.metadata.SpaceTypeDescriptorBuilder
-
Adds a QueryExtension information for the specified path
- addQueryExtensionProvider(QueryExtensionProvider) - Method in class org.openspaces.core.space.EmbeddedSpaceConfigurer
-
- addReason(ZonesConfig, AutoScalingSlaEnforcementInProgressException) - Method in exception org.openspaces.grid.gsm.autoscaling.exceptions.PerZoneAutoScalingSlaEnforcementInProgressException
-
- addReason(ZonesConfig, GridServiceAgentSlaEnforcementInProgressException) - Method in exception org.openspaces.grid.gsm.machines.exceptions.PerZonesGridServiceAgentSlaEnforcementInProgressException
-
- addReason(ZonesConfig, MachinesSlaEnforcementInProgressException) - Method in exception org.openspaces.grid.gsm.machines.exceptions.PerZonesMachinesSlaEnforcementInProgressException
-
- addRule(AutomaticCapacityScaleRuleConfig) - Method in class org.openspaces.admin.pu.elastic.config.AutomaticCapacityScaleConfigurer
-
- addService(String, Object) - Method in class org.openspaces.remoting.SpaceRemotingServiceExporter
-
- addSpaceType(SpaceTypeDescriptor) - Method in class org.openspaces.core.space.EmbeddedSpaceConfigurer
-
- addSpaceType(SpaceTypeDescriptor) - Method in class org.openspaces.core.space.UrlSpaceConfigurer
-
- addTemplate(Object) - Method in class org.openspaces.core.IteratorBuilder
-
Adds a template that will be used to control the matching entries the iterator
will iterate over.
- addTemplate(ISpaceQuery) - Method in class org.openspaces.core.IteratorBuilder
-
Adds a template that will be used to control the matching entries the iterator
will iterate over.
- addToCollection(String, Serializable) - Method in class com.gigaspaces.client.ChangeSet
-
Adds the given item to a collection property.
- AddToCollectionOperation - Class in com.gigaspaces.sync.change
-
- AddTypeIndexesResult - Interface in com.gigaspaces.metadata.index
-
Encapsulates information on the result of an add type indexes operation.
- addUnknownEvents(Collection) - Method in interface net.jini.event.MailboxPullRegistration
-
Adds the provided collection of unknown events to this registration.
- addUrlProperty(String, String) - Method in class org.openspaces.core.space.UrlSpaceConfigurer
-
- addView(View) - Method in class org.openspaces.core.space.cache.LocalViewSpaceConfigurer
-
- addViewQuery(SQLQuery) - Method in class org.openspaces.core.space.cache.LocalViewSpaceConfigurer
-
Adds a query to the view's criteria.
- addViewQuery(Object) - Method in class org.openspaces.core.space.cache.LocalViewSpaceFactoryBean
-
- addZone(String) - Method in class org.openspaces.admin.memcached.config.MemcachedConfig
-
- addZone(String) - Method in class org.openspaces.admin.memcached.MemcachedDeployment
-
Adds a zone where the processing unit is allowed to be deployed on.
- addZone(String) - Method in class org.openspaces.admin.pu.config.ProcessingUnitConfig
-
- addZone(String, CapacityRequirementsConfig) - Method in class org.openspaces.admin.pu.elastic.config.ManualCapacityPerZonesScaleConfigurer
-
- addZone(String[], CapacityRequirementsConfig) - Method in class org.openspaces.admin.pu.elastic.config.ManualCapacityPerZonesScaleConfigurer
-
- addZone(ExactZonesConfig, CapacityRequirementsConfig) - Method in class org.openspaces.admin.pu.elastic.config.ManualCapacityPerZonesScaleConfigurer
-
- addZone(String) - Method in class org.openspaces.admin.pu.ProcessingUnitDeployment
-
Adds a zone where the processing unit is allowed to be deployed on.
- addZone(String) - Method in class org.openspaces.admin.space.config.SpaceConfig
-
- addZone(String) - Method in class org.openspaces.admin.space.SpaceDeployment
-
Adds a zone where the processing unit is allowed to be deployed on.
- addZone(String) - Method in class org.openspaces.admin.zone.config.AtLeastOneZoneConfigurer
-
- addZone(String) - Method in class org.openspaces.admin.zone.config.ExactZonesConfigurer
-
- addZone(String) - Method in interface org.openspaces.admin.zone.config.ZonesConfigurer
-
- addZones(Collection<String>) - Method in class org.openspaces.admin.zone.config.AtLeastOneZoneConfigurer
-
- addZones(String...) - Method in class org.openspaces.admin.zone.config.AtLeastOneZoneConfigurer
-
- addZones(Collection<String>) - Method in class org.openspaces.admin.zone.config.ExactZonesConfigurer
-
- addZones(String...) - Method in class org.openspaces.admin.zone.config.ExactZonesConfigurer
-
- addZones(Collection<String>) - Method in interface org.openspaces.admin.zone.config.ZonesConfigurer
-
- addZones(String...) - Method in interface org.openspaces.admin.zone.config.ZonesConfigurer
-
- Admin - Interface in org.openspaces.admin
-
The main interface for accessing Admin API.
- AdminAware - Interface in org.openspaces.admin
-
A general interface implements by elements that can provide access to
Admin
.
- adminCreated(Admin, GigaSpace) - Method in interface org.openspaces.grid.esm.ESMImplInitializer.AdminCreatedEventListener
-
- AdminEventListener - Interface in org.openspaces.admin
-
A generics marker interface for all different Admin Events.
- AdminException - Exception in org.openspaces.admin
-
Base for all admin exceptions.
- AdminException(String) - Constructor for exception org.openspaces.admin.AdminException
-
- AdminException(String, Throwable) - Constructor for exception org.openspaces.admin.AdminException
-
- AdminFactory - Class in org.openspaces.admin
-
A factory allowing to create
Admin
instance.
- AdminFactory() - Constructor for class org.openspaces.admin.AdminFactory
-
- adminFilter(AdminFilter) - Method in class org.openspaces.admin.AdminFactory
-
Sets adminFilter, allows to filter services, machines and etc.
- AdminFilter - Interface in org.openspaces.security
-
Interface that defines filtering behavior for Admin services
- AdminFilterHelper - Class in org.openspaces.security
-
Helper class for filter Admin services
- AdminFilterHelper() - Constructor for class org.openspaces.security.AdminFilterHelper
-
- AdminNamespaceHandler - Class in org.openspaces.admin.config
-
A spring namespace handler for the "admin" namespace.
- AdminNamespaceHandler() - Constructor for class org.openspaces.admin.config.AdminNamespaceHandler
-
- AdvancedStatefulDeploymentTopology - Interface in org.openspaces.admin.pu.elastic.topology
-
- advertise() - Method in class org.openspaces.grid.esm.ESMImpl
-
- AFTER_ALL_NOTIFY_TRIGGER - Static variable in class com.j_spaces.core.filters.FilterOperationCodes
-
After all notify trigger operation, indicates that all notify templates that are
matched to the current entry event were triggered and returned or failed.
- AFTER_CHANGE - Static variable in class com.j_spaces.core.filters.FilterOperationCodes
-
After change operation.
- AFTER_EXECUTE - Static variable in class com.j_spaces.core.filters.FilterOperationCodes
-
After execute operation.
- AFTER_NOTIFY_TRIGGER - Static variable in class com.j_spaces.core.filters.FilterOperationCodes
-
After notify trigger operation, indicates that a notify trigger was
successful.
- AFTER_READ - Static variable in class com.j_spaces.core.filters.FilterOperationCodes
-
After read operation.
- AFTER_READ_MULTIPLE - Static variable in class com.j_spaces.core.filters.FilterOperationCodes
-
After readMultiple operation.
- AFTER_REMOVE - Static variable in class com.j_spaces.core.filters.FilterOperationCodes
-
Called after entry remove due to lease expression or lease cancel.
- AFTER_TAKE - Static variable in class com.j_spaces.core.filters.FilterOperationCodes
-
After take operation.
- AFTER_TAKE_MULTIPLE - Static variable in class com.j_spaces.core.filters.FilterOperationCodes
-
After takeMultiple operation.
- AFTER_UPDATE - Static variable in class com.j_spaces.core.filters.FilterOperationCodes
-
After update operation.
- AFTER_WRITE - Static variable in class com.j_spaces.core.filters.FilterOperationCodes
-
After write operation.
- AfterAllNotifyTrigger - Annotation Type in org.openspaces.core.space.filter
-
Filter callback after all notify trigger.
- AfterChange - Annotation Type in org.openspaces.core.space.filter
-
Filter callback before change operation.
- afterEntry(LogEntries, LogEntry) - Static method in class com.gigaspaces.log.LogEntryMatchers
-
- afterEntry(LogEntries, LogEntry, boolean) - Static method in class com.gigaspaces.log.LogEntryMatchers
-
- afterEntry(LogEntries, LogEntry, LogEntryMatcher) - Static method in class com.gigaspaces.log.LogEntryMatchers
-
- afterEntry(LogEntries, LogEntry, boolean, LogEntryMatcher) - Static method in class com.gigaspaces.log.LogEntryMatchers
-
- AfterEntryLogEntryMatcher - Class in com.gigaspaces.log
-
A matcher filter that will return log entries that happened from (after) the provided log entry.
- AfterEntryLogEntryMatcher(LogEntries, LogEntry) - Constructor for class com.gigaspaces.log.AfterEntryLogEntryMatcher
-
- AfterEntryLogEntryMatcher(LogEntries, LogEntry, boolean) - Constructor for class com.gigaspaces.log.AfterEntryLogEntryMatcher
-
- AfterEntryLogEntryMatcher(LogEntries, LogEntry, LogEntryMatcher) - Constructor for class com.gigaspaces.log.AfterEntryLogEntryMatcher
-
- AfterEntryLogEntryMatcher(LogEntries, LogEntry, boolean, LogEntryMatcher) - Constructor for class com.gigaspaces.log.AfterEntryLogEntryMatcher
-
- AfterExecute - Annotation Type in org.openspaces.core.space.filter
-
Filter callback after execute operation
- AfterNotifyTrigger - Annotation Type in org.openspaces.core.space.filter
-
Filter callback after notify trigger.
- afterOperationsBatchSynchronization(OperationsBatchData) - Method in class com.gigaspaces.sync.SpaceSynchronizationEndpoint
-
Triggered after synchronization batch of operations was completed successfully.
- afterOperationsBatchSynchronization(OperationsBatchData) - Method in class org.openspaces.persistency.patterns.SpaceSynchronizationEndpointExceptionHandler
-
- afterOperationsBatchSynchronization(OperationsBatchData) - Method in class org.openspaces.persistency.patterns.SpaceSynchronizationEndpointSplitter
-
- afterPropertiesSet() - Method in class org.openspaces.admin.pu.dependency.config.ProcessingUnitDependencyConfig
-
- afterPropertiesSet() - Method in interface org.openspaces.core.bean.Bean
-
Invoked by a bean factory after it has set all bean properties.
- afterPropertiesSet() - Method in class org.openspaces.core.config.AttributeStoreFactoryBean
-
- afterPropertiesSet() - Method in class org.openspaces.core.config.BlobStoreDataPolicyFactoryBean
-
- afterPropertiesSet() - Method in class org.openspaces.core.config.CustomCachePolicyFactoryBean
-
- afterPropertiesSet() - Method in class org.openspaces.core.config.GigaSpaceDocumentTypeDescriptorFactoryBean
-
- afterPropertiesSet() - Method in class org.openspaces.core.config.SpaceSqlFunctionBean
-
- afterPropertiesSet() - Method in class org.openspaces.core.config.SQLQueryFactoryBean
-
- afterPropertiesSet() - Method in class org.openspaces.core.gateway.AbstractGatewayComponentFactoryBean
-
- afterPropertiesSet() - Method in class org.openspaces.core.gateway.GatewayTargetsFactoryBean
-
- afterPropertiesSet() - Method in class org.openspaces.core.GigaMapFactoryBean
-
- afterPropertiesSet() - Method in class org.openspaces.core.GigaSpaceFactoryBean
-
- afterPropertiesSet() - Method in class org.openspaces.core.map.MapFactoryBean
-
- afterPropertiesSet() - Method in class org.openspaces.core.space.AbstractSpaceFactoryBean
-
- afterPropertiesSet() - Method in class org.openspaces.core.space.cache.AbstractLocalCacheSpaceFactoryBean
-
- afterPropertiesSet() - Method in class org.openspaces.core.space.filter.AbstractFilterProviderFactoryBean
-
Constructs the filter provider and applies its different aspects.
- afterPropertiesSet() - Method in class org.openspaces.core.space.filter.replication.AbstractReplicationFilterProviderFactory
-
- afterPropertiesSet() - Method in class org.openspaces.core.space.LeaderSelectorFactoryBean
-
- afterPropertiesSet() - Method in class org.openspaces.core.space.mode.RefreshSpaceModeContextLoader
-
- afterPropertiesSet() - Method in class org.openspaces.core.space.mode.SpaceModeContextLoader
-
- afterPropertiesSet() - Method in class org.openspaces.core.space.support.WorkerAdapter
-
Deprecated.
- afterPropertiesSet() - Method in class org.openspaces.core.transaction.manager.AbstractJiniTransactionManager
-
- afterPropertiesSet() - Method in class org.openspaces.events.AbstractEventListenerContainer
-
- afterPropertiesSet() - Method in class org.openspaces.events.adapter.AbstractReflectionDynamicEventTemplateProviderAdapter
-
- afterPropertiesSet() - Method in class org.openspaces.events.adapter.AbstractReflectionEventListenerAdapter
-
- afterPropertiesSet() - Method in class org.openspaces.events.adapter.TaskExecutorEventListenerAdapter
-
Initializes the task executor adapter.
- afterPropertiesSet() - Method in class org.openspaces.events.config.AbstractResultEventAdapterFactoryBean
-
- afterPropertiesSet() - Method in class org.openspaces.grid.gsm.ElasticConfigBean
-
- afterPropertiesSet() - Method in class org.openspaces.grid.gsm.machines.plugins.discovered.DiscoveredMachineProvisioningBean
-
- afterPropertiesSet() - Method in class org.openspaces.grid.gsm.strategy.AbstractCapacityScaleStrategyBean
-
- afterPropertiesSet() - Method in class org.openspaces.grid.gsm.strategy.AbstractScaleStrategyBean
-
- afterPropertiesSet() - Method in class org.openspaces.grid.gsm.strategy.AutomaticCapacityScaleStrategyBean
-
- afterPropertiesSet() - Method in class org.openspaces.grid.gsm.strategy.EagerScaleStrategyBean
-
- afterPropertiesSet() - Method in class org.openspaces.grid.gsm.strategy.ManualCapacityPerZonesScaleStrategyBean
-
- afterPropertiesSet() - Method in class org.openspaces.grid.gsm.strategy.ManualCapacityScaleStrategyBean
-
- afterPropertiesSet() - Method in class org.openspaces.grid.gsm.strategy.UndeployScaleStrategyBean
-
- afterPropertiesSet() - Method in class org.openspaces.interop.DotnetProcessingUnitBean
- afterPropertiesSet() - Method in class org.openspaces.jdbc.datasource.DbcpBasicDataSource
-
- afterPropertiesSet() - Method in class org.openspaces.jdbc.datasource.SpaceDriverManagerDataSource
-
- afterPropertiesSet() - Method in class org.openspaces.jms.GigaSpaceConnectionFactory
-
- afterPropertiesSet() - Method in class org.openspaces.jms.GigaSpaceQueue
-
- afterPropertiesSet() - Method in class org.openspaces.jms.GigaSpaceTopic
-
- afterPropertiesSet() - Method in class org.openspaces.jms.GigaSpaceXAConnectionFactory
-
- afterPropertiesSet() - Method in class org.openspaces.leader_selector.zookeeper.config.ZooKeeperLeaderSelectorFactoryBean
-
- afterPropertiesSet() - Method in class org.openspaces.memcached.MemCacheDaemon
-
- afterPropertiesSet() - Method in class org.openspaces.persistency.hibernate.CriteriaHibernateSpaceDataSourceFactoryBean
-
- afterPropertiesSet() - Method in class org.openspaces.persistency.hibernate.DefaultHibernateSpaceDataSourceFactoryBean
-
- afterPropertiesSet() - Method in class org.openspaces.persistency.hibernate.DefaultHibernateSpaceSynchronizationEndpointFactoryBean
-
- afterPropertiesSet() - Method in class org.openspaces.persistency.hibernate.StatelessHibernateSpaceDataSourceFactoryBean
-
- afterPropertiesSet() - Method in class org.openspaces.persistency.hibernate.StatelessHibernateSpaceSynchronizationEndpointFactoryBean
-
- afterPropertiesSet() - Method in class org.openspaces.persistency.utils.HsqlServerBean
-
- afterPropertiesSet() - Method in class org.openspaces.pu.sla.PrimaryZoneController
-
- afterPropertiesSet() - Method in class org.openspaces.pu.sla.SLA
-
- afterPropertiesSet() - Method in class org.openspaces.remoting.EventDrivenSpaceRemotingProxyFactoryBean
-
- afterPropertiesSet() - Method in class org.openspaces.remoting.ExecutorSpaceRemotingProxyFactoryBean
-
- afterPropertiesSet() - Method in class org.openspaces.remoting.scripting.DefaultScriptingExecutor
-
- afterPropertiesSet() - Method in class org.openspaces.remoting.SpaceRemotingServiceExporter
-
- afterPropertiesSetImpl(SecurityConfig) - Method in class org.openspaces.core.gateway.AbstractGatewayComponentFactoryBean
-
- afterPropertiesSetImpl(SecurityConfig) - Method in class org.openspaces.core.gateway.GatewayDelegatorFactoryBean
-
Initializes a ReplicationConnectionDelegatorContainer
using the provided bean's properties.
- afterPropertiesSetImpl(SecurityConfig) - Method in class org.openspaces.core.gateway.GatewaySinkFactoryBean
-
- AfterRead - Annotation Type in org.openspaces.core.space.filter
-
Filter callback after read operation.
- AfterReadMultiple - Annotation Type in org.openspaces.core.space.filter
-
Filter callback after read multiple operation.
- AfterRemoveByLease - Annotation Type in org.openspaces.core.space.filter
-
Filter callback after an entry was removed due to lease expression or lease cancel.
- afterShutdown(GSProcess) - Method in class com.gigaspaces.grid.gsa.GigaSpacesShutdownProcessHandler
-
- afterShutdown(GSProcess) - Method in interface com.gigaspaces.grid.gsa.ShutdownProcessHandler
-
- AfterSpaceModeChangeEvent - Class in org.openspaces.core.space.mode
-
A Space mode event that is raised after the space mode was changed to the space mode reflected in
this event.
- AfterSpaceModeChangeEvent(IJSpace, SpaceMode) - Constructor for class org.openspaces.core.space.mode.AfterSpaceModeChangeEvent
-
Creates a new after space mode event.
- AfterTake - Annotation Type in org.openspaces.core.space.filter
-
Filter callback after take operation.
- AfterTakeMultiple - Annotation Type in org.openspaces.core.space.filter
-
Filter callback after take multiple operation.
- afterTime(long) - Static method in class com.gigaspaces.log.LogEntryMatchers
-
- afterTime(long, boolean) - Static method in class com.gigaspaces.log.LogEntryMatchers
-
- afterTime(long, boolean, LogEntryMatcher) - Static method in class com.gigaspaces.log.LogEntryMatchers
-
- afterTime(long, LogEntryMatcher) - Static method in class com.gigaspaces.log.LogEntryMatchers
-
- afterTime(String) - Static method in class com.gigaspaces.log.LogEntryMatchers
-
- afterTime(String, boolean) - Static method in class com.gigaspaces.log.LogEntryMatchers
-
- afterTime(String, boolean, LogEntryMatcher) - Static method in class com.gigaspaces.log.LogEntryMatchers
-
- afterTime(String, LogEntryMatcher) - Static method in class com.gigaspaces.log.LogEntryMatchers
-
- afterTime(String, String) - Static method in class com.gigaspaces.log.LogEntryMatchers
-
- afterTime(String, String, boolean) - Static method in class com.gigaspaces.log.LogEntryMatchers
-
- afterTime(String, String, boolean, LogEntryMatcher) - Static method in class com.gigaspaces.log.LogEntryMatchers
-
- afterTime(String, String, LogEntryMatcher) - Static method in class com.gigaspaces.log.LogEntryMatchers
-
- AfterTimeLogEntryMatcher - Class in com.gigaspaces.log
-
A matcher filter that will match only on log entries that occurred after the specified time.
- AfterTimeLogEntryMatcher(String) - Constructor for class com.gigaspaces.log.AfterTimeLogEntryMatcher
-
- AfterTimeLogEntryMatcher(String, boolean) - Constructor for class com.gigaspaces.log.AfterTimeLogEntryMatcher
-
- AfterTimeLogEntryMatcher(String, String) - Constructor for class com.gigaspaces.log.AfterTimeLogEntryMatcher
-
- AfterTimeLogEntryMatcher(String, String, boolean) - Constructor for class com.gigaspaces.log.AfterTimeLogEntryMatcher
-
- AfterTimeLogEntryMatcher(String, boolean, LogEntryMatcher) - Constructor for class com.gigaspaces.log.AfterTimeLogEntryMatcher
-
- AfterTimeLogEntryMatcher(String, LogEntryMatcher) - Constructor for class com.gigaspaces.log.AfterTimeLogEntryMatcher
-
- AfterTimeLogEntryMatcher(String, String, LogEntryMatcher) - Constructor for class com.gigaspaces.log.AfterTimeLogEntryMatcher
-
- AfterTimeLogEntryMatcher(String, String, boolean, LogEntryMatcher) - Constructor for class com.gigaspaces.log.AfterTimeLogEntryMatcher
-
- AfterTimeLogEntryMatcher(long) - Constructor for class com.gigaspaces.log.AfterTimeLogEntryMatcher
-
- AfterTimeLogEntryMatcher(long, LogEntryMatcher) - Constructor for class com.gigaspaces.log.AfterTimeLogEntryMatcher
-
- AfterTimeLogEntryMatcher(long, boolean) - Constructor for class com.gigaspaces.log.AfterTimeLogEntryMatcher
-
- AfterTimeLogEntryMatcher(long, boolean, LogEntryMatcher) - Constructor for class com.gigaspaces.log.AfterTimeLogEntryMatcher
-
- afterTransactionSynchronization(TransactionData) - Method in class com.gigaspaces.sync.SpaceSynchronizationEndpoint
-
Triggered after synchronization of a transaction was completed successfully.
- afterTransactionSynchronization(TransactionData) - Method in class org.openspaces.persistency.patterns.SpaceSynchronizationEndpointExceptionHandler
-
- afterTransactionSynchronization(TransactionData) - Method in class org.openspaces.persistency.patterns.SpaceSynchronizationEndpointSplitter
-
- afterUndeployedProcessingUnit(ProcessingUnit) - Method in interface org.openspaces.grid.gsm.machines.MachinesSlaEnforcementEndpoint
-
Erases all Allocated (state) that is related to the specified processing unit.
- afterUndeployProcessingUnit(ProcessingUnit) - Method in class org.openspaces.grid.gsm.machines.MachinesSlaEnforcementState
-
Removes all state related to the specified processing unit
Call this method only if you are not going to call any other state method on this pu
- AfterUpdate - Annotation Type in org.openspaces.core.space.filter
-
Filter callback after update operation.
- AfterWrite - Annotation Type in org.openspaces.core.space.filter
-
Filter callback after write operation.
- AGENT_EXT_JAVA_OPTIONS - Static variable in class org.openspaces.core.gateway.GSCForkHandler
-
- AgentGridComponent - Interface in org.openspaces.admin
-
- agentProvisioningCompletedEvent(ZonesConfig) - Method in class org.openspaces.grid.gsm.strategy.AbstractScaleStrategyBean
-
- agentProvisioningInProgressEvent(GridServiceAgentSlaEnforcementInProgressException, ZonesConfig) - Method in class org.openspaces.grid.gsm.strategy.AbstractScaleStrategyBean
-
- agentsToString(Collection<GridServiceAgent>) - Static method in class org.openspaces.grid.gsm.machines.MachinesSlaUtils
-
- agentToString(Admin, String) - Static method in class org.openspaces.grid.gsm.machines.MachinesSlaUtils
-
- agentToString(GridServiceAgent) - Static method in class org.openspaces.grid.gsm.machines.MachinesSlaUtils
-
- agentZones(ZonesConfig) - Method in class org.openspaces.admin.pu.statistics.ProcessingUnitStatisticsIdConfigurer
-
- aggregate(SpaceEntriesAggregatorContext) - Method in class com.gigaspaces.query.aggregators.AverageAggregator
-
- aggregate(SpaceEntriesAggregatorContext) - Method in class com.gigaspaces.query.aggregators.CountAggregator
-
- aggregate(SpaceEntriesAggregatorContext) - Method in class com.gigaspaces.query.aggregators.DistinctAggregator
-
- aggregate(SpaceEntriesAggregatorContext) - Method in class com.gigaspaces.query.aggregators.GroupByAggregator
-
- aggregate(SpaceEntriesAggregatorContext) - Method in class com.gigaspaces.query.aggregators.ListEntriesAggregator
-
- aggregate(SpaceEntriesAggregatorContext) - Method in class com.gigaspaces.query.aggregators.MaxEntryAggregator
-
- aggregate(SpaceEntriesAggregatorContext) - Method in class com.gigaspaces.query.aggregators.MaxValueAggregator
-
- aggregate(SpaceEntriesAggregatorContext) - Method in class com.gigaspaces.query.aggregators.MinEntryAggregator
-
- aggregate(SpaceEntriesAggregatorContext) - Method in class com.gigaspaces.query.aggregators.MinValueAggregator
-
- aggregate(SpaceEntriesAggregatorContext) - Method in class com.gigaspaces.query.aggregators.OrderByAggregator
-
- aggregate(SpaceEntriesAggregatorContext) - Method in class com.gigaspaces.query.aggregators.SingleValueAggregator
-
- aggregate(SpaceEntriesAggregatorContext) - Method in class com.gigaspaces.query.aggregators.SpaceEntriesAggregator
-
- aggregate() - Method in class com.gigaspaces.query.aggregators.SpaceEntriesAggregatorContext
-
- aggregate(SpaceEntriesAggregatorContext) - Method in class com.gigaspaces.query.aggregators.SumAggregator
-
- aggregate(ISpaceQuery<T>, AggregationSet) - Method in class org.openspaces.core.DefaultGigaSpace
-
- aggregate(ISpaceQuery<T>, AggregationSet) - Method in interface org.openspaces.core.GigaSpace
-
Executes the specified query along with the specified aggregations collocated at the space.
- aggregateById(ServiceDetails[]) - Method in class org.openspaces.events.asyncpolling.AsyncPollingEventContainerServiceDetails
-
- aggregateById(ServiceDetails[]) - Method in class org.openspaces.events.notify.NotifyEventContainerServiceDetails
-
- aggregateById(ServiceDetails[]) - Method in class org.openspaces.events.polling.PollingEventContainerServiceDetails
-
- aggregateById(ServiceDetails[]) - Method in class org.openspaces.pu.service.PlainServiceDetails
-
- aggregateByServiceSubType(ServiceDetails[]) - Method in class org.openspaces.events.asyncpolling.AsyncPollingEventContainerServiceDetails
-
- aggregateByServiceSubType(ServiceDetails[]) - Method in class org.openspaces.events.notify.NotifyEventContainerServiceDetails
-
- aggregateByServiceSubType(ServiceDetails[]) - Method in class org.openspaces.events.polling.PollingEventContainerServiceDetails
-
- aggregateByServiceSubType(ServiceDetails[]) - Method in class org.openspaces.pu.service.PlainServiceDetails
-
- aggregateByServiceType(ServiceDetails[]) - Method in class org.openspaces.pu.service.PlainServiceDetails
-
- AggregatedAsyncPollingEventContainerServiceDetails - Class in org.openspaces.events.asyncpolling
-
Async Polling container service details.
- AggregatedAsyncPollingEventContainerServiceDetails() - Constructor for class org.openspaces.events.asyncpolling.AggregatedAsyncPollingEventContainerServiceDetails
-
- AggregatedAsyncPollingEventContainerServiceDetails(String, ServiceDetails[]) - Constructor for class org.openspaces.events.asyncpolling.AggregatedAsyncPollingEventContainerServiceDetails
-
- AggregatedAsyncPollingEventContainerServiceDetails.Attributes - Class in org.openspaces.events.asyncpolling
-
- AggregatedNotifyEventContainerServiceDetails - Class in org.openspaces.events.notify
-
Notify container service details.
- AggregatedNotifyEventContainerServiceDetails() - Constructor for class org.openspaces.events.notify.AggregatedNotifyEventContainerServiceDetails
-
- AggregatedNotifyEventContainerServiceDetails(String, ServiceDetails[]) - Constructor for class org.openspaces.events.notify.AggregatedNotifyEventContainerServiceDetails
-
- AggregatedNotifyEventContainerServiceDetails.Attributes - Class in org.openspaces.events.notify
-
- AggregatedPollingEventContainerServiceDetails - Class in org.openspaces.events.polling
-
- AggregatedPollingEventContainerServiceDetails() - Constructor for class org.openspaces.events.polling.AggregatedPollingEventContainerServiceDetails
-
- AggregatedPollingEventContainerServiceDetails(String, ServiceDetails[]) - Constructor for class org.openspaces.events.polling.AggregatedPollingEventContainerServiceDetails
-
- AggregatedPollingEventContainerServiceDetails.Attributes - Class in org.openspaces.events.polling
-
- AggregatedServiceDetails - Interface in org.openspaces.pu.service
-
An aggregation of
ServiceDetails
that share at lease the same
service type.
- aggregateIntermediateResult(AverageAggregator.AverageTuple) - Method in class com.gigaspaces.query.aggregators.AverageAggregator
-
- aggregateIntermediateResult(Long) - Method in class com.gigaspaces.query.aggregators.CountAggregator
-
- aggregateIntermediateResult(DistinctResult) - Method in class com.gigaspaces.query.aggregators.DistinctAggregator
-
- aggregateIntermediateResult(GroupByResult) - Method in class com.gigaspaces.query.aggregators.GroupByAggregator
-
- aggregateIntermediateResult(ArrayList<RawEntry>) - Method in class com.gigaspaces.query.aggregators.ListEntriesAggregator
-
- aggregateIntermediateResult(MaxEntryAggregator.MaxEntryScannerResult) - Method in class com.gigaspaces.query.aggregators.MaxEntryAggregator
-
- aggregateIntermediateResult(T) - Method in class com.gigaspaces.query.aggregators.MaxValueAggregator
-
- aggregateIntermediateResult(MinEntryAggregator.MinEntryScannerResult) - Method in class com.gigaspaces.query.aggregators.MinEntryAggregator
-
- aggregateIntermediateResult(T) - Method in class com.gigaspaces.query.aggregators.MinValueAggregator
-
- aggregateIntermediateResult(OrderByAggregator.OrderByScanResult) - Method in class com.gigaspaces.query.aggregators.OrderByAggregator
-
- aggregateIntermediateResult(T) - Method in class com.gigaspaces.query.aggregators.SingleValueAggregator
-
- aggregateIntermediateResult(T) - Method in class com.gigaspaces.query.aggregators.SpaceEntriesAggregator
-
- aggregateIntermediateResult(MutableNumber) - Method in class com.gigaspaces.query.aggregators.SumAggregator
-
- AggregationFunction - Class in org.openspaces.jpa.openjpa.query
-
An aggregation function representation.
- AggregationFunction(Value, AggregationFunction.AggregationType) - Constructor for class org.openspaces.jpa.openjpa.query.AggregationFunction
-
- AggregationFunction.AggregationType - Enum in org.openspaces.jpa.openjpa.query
-
Aggregation function type
- AggregationInternalUtils - Class in com.gigaspaces.query.aggregators
-
This class is intended for internal usage only.
- AggregationInternalUtils() - Constructor for class com.gigaspaces.query.aggregators.AggregationInternalUtils
-
- AggregationResult - Class in com.gigaspaces.query.aggregators
-
- AggregationResult() - Constructor for class com.gigaspaces.query.aggregators.AggregationResult
-
Default constructor required for Externalizable
- AggregationResult(Object[], Map<String, Integer>) - Constructor for class com.gigaspaces.query.aggregators.AggregationResult
-
This constructor is intended for internal usage.
- AggregationSet - Class in com.gigaspaces.query.aggregators
-
The set of aggregations to run for matches entries of the aggregate operation.
- AggregationSet() - Constructor for class com.gigaspaces.query.aggregators.AggregationSet
-
- Alert - Interface in org.openspaces.admin.alert
-
An interface representing an alert issued by an alert bean or an alert provider.
- AlertConfiguration - Interface in org.openspaces.admin.alert.config
-
A configuration of an alert trigger.
- AlertConfigurationException - Exception in org.openspaces.admin.alert
-
- AlertConfigurationException(String) - Constructor for exception org.openspaces.admin.alert.AlertConfigurationException
-
- AlertConfigurationException(String, Throwable) - Constructor for exception org.openspaces.admin.alert.AlertConfigurationException
-
- AlertConfigurationParser - Interface in org.openspaces.admin.alert.config.parser
-
- AlertConfigurationParserException - Exception in org.openspaces.admin.alert.config.parser
-
- AlertConfigurationParserException(String) - Constructor for exception org.openspaces.admin.alert.config.parser.AlertConfigurationParserException
-
- AlertConfigurationParserException(String, Throwable) - Constructor for exception org.openspaces.admin.alert.config.parser.AlertConfigurationParserException
-
- AlertConfigurer - Interface in org.openspaces.admin.alert.config
-
An interface for implementations carrying out the 'builder/chaining' pattern on top of an
AlertConfiguration
.
- AlertFactory - Class in org.openspaces.admin.alert
-
A factory for constructing an alert instance to be fired by an alert bean.
- AlertFactory() - Constructor for class org.openspaces.admin.alert.AlertFactory
-
A factory for creating an
Alert
.
- AlertManager - Interface in org.openspaces.admin.alert
-
The AlertManager is a manager for configuring of alerts, firing of alerts, and
registering for alert events.
- AlertSeverity - Class in org.openspaces.admin.alert
-
The alert severity levels.
- AlertSeverity(String, int) - Constructor for class org.openspaces.admin.alert.AlertSeverity
-
Create a named alert severity with a given integer value.
- AlertStatus - Class in org.openspaces.admin.alert
-
The alert status levels.
- AlertStatus(String, int) - Constructor for class org.openspaces.admin.alert.AlertStatus
-
Create a named alert status with a given integer value.
- alertTriggered(Alert) - Method in interface org.openspaces.admin.alert.events.AlertTriggeredEventListener
-
- AlertTriggeredEventListener - Interface in org.openspaces.admin.alert.events
-
An event listener for all types of alerts.
- AlertTriggeredEventManager - Interface in org.openspaces.admin.alert.events
-
- all() - Static method in class com.gigaspaces.log.LogEntryMatchers
-
- all(Value) - Method in class org.openspaces.jpa.openjpa.query.QueryExpressionFactory
-
Return an expression representing the given condition.
- AllInCachePolicy - Class in org.openspaces.core.space
-
A cache policy that stores all the data in the space.
- AllInCachePolicy() - Constructor for class org.openspaces.core.space.AllInCachePolicy
-
- allLogEntries(LogProcessType, LogEntryMatcher) - Method in interface org.openspaces.admin.gsa.GridServiceAgent
-
Extracts all the log entries for the provided process type including both "live" runtime
components and ones that are no longer running.
- AllLogEntryMatcher - Class in com.gigaspaces.log
-
A matcher that returns all the log entries.
- AllLogEntryMatcher() - Constructor for class com.gigaspaces.log.AllLogEntryMatcher
-
- allocateCapacity(MachinesSlaEnforcementState.StateKey, String, CapacityRequirements) - Method in class org.openspaces.grid.gsm.machines.MachinesSlaEnforcementState
-
- allowAboveAverageMemoryPerMachine(boolean) - Method in class org.openspaces.admin.pu.elastic.config.AutomaticCapacityScaleConfigurer
-
- allowAboveAverageMemoryPerMachine(boolean) - Method in class org.openspaces.admin.pu.elastic.config.EagerScaleConfigurer
-
- allowAboveAverageMemoryPerMachine(boolean) - Method in class org.openspaces.admin.pu.elastic.config.ManualCapacityPerZonesScaleConfigurer
-
- allowAboveAverageMemoryPerMachine(boolean) - Method in class org.openspaces.admin.pu.elastic.config.ManualCapacityScaleConfigurer
-
- allowAboveAverageMemoryPerMachine(boolean) - Method in interface org.openspaces.admin.pu.elastic.config.ScaleStrategyConfigurer
-
- and(Expression, Expression) - Method in class org.openspaces.jpa.openjpa.query.QueryExpressionFactory
-
Return the two expressions AND'd together.
- AnnotationDynamicEventTemplateProviderAdapter - Class in org.openspaces.events.adapter
-
The annotation event template provider adapter uses
DynamicEventTemplate
annotation in order to find the
event template provider to delegate to.
- AnnotationDynamicEventTemplateProviderAdapter() - Constructor for class org.openspaces.events.adapter.AnnotationDynamicEventTemplateProviderAdapter
-
- AnnotationEventAdapterBeanDefinitionParser - Class in org.openspaces.events.config
-
- AnnotationEventAdapterBeanDefinitionParser() - Constructor for class org.openspaces.events.config.AnnotationEventAdapterBeanDefinitionParser
-
- AnnotationEventAdapterFactoryBean - Class in org.openspaces.events.config
-
- AnnotationEventAdapterFactoryBean() - Constructor for class org.openspaces.events.config.AnnotationEventAdapterFactoryBean
-
- AnnotationEventListenerAdapter - Class in org.openspaces.events.adapter
-
An event listener adapter that uses
SpaceDataEvent
annotation in order to find event
listener methods to delegate to.
- AnnotationEventListenerAdapter() - Constructor for class org.openspaces.events.adapter.AnnotationEventListenerAdapter
-
- AnnotationFilterBeanDefinitionParser - Class in org.openspaces.core.config
-
- AnnotationFilterBeanDefinitionParser() - Constructor for class org.openspaces.core.config.AnnotationFilterBeanDefinitionParser
-
- AnnotationFilterFactoryBean - Class in org.openspaces.core.space.filter
-
A FilterProvider
factory that accepts
a Pojo filter with annotation markers as to which filter operation to listen to.
- AnnotationFilterFactoryBean() - Constructor for class org.openspaces.core.space.filter.AnnotationFilterFactoryBean
-
- AnnotationProcessorUtils - Class in org.openspaces.events.support
-
- AnnotationSupportBeanDefinitionParser - Class in org.openspaces.archive.config
-
- AnnotationSupportBeanDefinitionParser() - Constructor for class org.openspaces.archive.config.AnnotationSupportBeanDefinitionParser
-
- AnnotationSupportBeanDefinitionParser - Class in org.openspaces.core.config
-
- AnnotationSupportBeanDefinitionParser() - Constructor for class org.openspaces.core.config.AnnotationSupportBeanDefinitionParser
-
- AnnotationSupportBeanDefinitionParser - Class in org.openspaces.events.config
-
- AnnotationSupportBeanDefinitionParser() - Constructor for class org.openspaces.events.config.AnnotationSupportBeanDefinitionParser
-
- AnnotationUtils - Class in org.openspaces.core.util
-
General utility methods for working with annotations, handling bridge methods
(which the compiler generates for generic declarations) as well as super
methods (for optional "annotation inheritance").
- AnnotationUtils() - Constructor for class org.openspaces.core.util.AnnotationUtils
-
- ANY - Static variable in class com.j_spaces.core.client.SpaceURL
-
Deprecated.
Represents *
symbol.
- ANY - Static variable in interface net.jini.core.lease.Lease
-
Used by the requestor to indicate that there is no particular lease
time desired, and that the grantor of the lease should supply a time
that is most convenient for the grantor.
- any(Value) - Method in class org.openspaces.jpa.openjpa.query.QueryExpressionFactory
-
Return an expression representing the given condition.
- AnyZonesConfig - Class in org.openspaces.admin.zone.config
-
Satisified by any zones
PU[] is statisfied by GSC[]
PU[] is statisfied by GSC[A]
- AnyZonesConfig(Map<String, String>) - Constructor for class org.openspaces.admin.zone.config.AnyZonesConfig
-
- AnyZonesConfig() - Constructor for class org.openspaces.admin.zone.config.AnyZonesConfig
-
- ApacheLoadBalancerAgent - Class in org.openspaces.pu.container.jee.lb.apache
-
Experimental support for automatically refreshing apache load balancer.
- ApacheLoadBalancerAgent() - Constructor for class org.openspaces.pu.container.jee.lb.apache.ApacheLoadBalancerAgent
-
- append(LocalCacheElement) - Method in class org.openspaces.memcached.LocalCacheElement
-
- append(LocalCacheElement) - Method in class org.openspaces.memcached.SpaceCache
-
- APPEND_PROP - Static variable in class com.gigaspaces.logger.RollingFileHandler
-
- appendSelectFromSql() - Method in class org.openspaces.jpa.openjpa.query.executor.JpaJdbcQueryExecutor
-
Append SELECT FROM to SQL string builder.
- appendSpaceRuntimeInfo(SpaceRuntimeInfo) - Method in class com.j_spaces.core.admin.SpaceRuntimeInfo
-
Merge two SpaceRuntimeInfo instances.
- appendSql(StringBuilder) - Method in class org.openspaces.jpa.openjpa.query.AggregationFunction
-
- appendSql(StringBuilder) - Method in class org.openspaces.jpa.openjpa.query.BinaryExpression
-
- appendSql(StringBuilder) - Method in class org.openspaces.jpa.openjpa.query.BindVariableExpression
-
- appendSql(StringBuilder) - Method in class org.openspaces.jpa.openjpa.query.ContainsExpression
-
- appendSql(StringBuilder) - Method in class org.openspaces.jpa.openjpa.query.EmptyExpression
-
- appendSql(StringBuilder) - Method in interface org.openspaces.jpa.openjpa.query.ExpressionNode
-
Appends the node SQL string to the string builder.
- appendSql(StringBuilder) - Method in class org.openspaces.jpa.openjpa.query.FieldPathNode
-
- appendSql(StringBuilder) - Method in class org.openspaces.jpa.openjpa.query.InnerQuery
-
- appendSql(StringBuilder) - Method in class org.openspaces.jpa.openjpa.query.LiteralValueNode
-
- appendSql(StringBuilder) - Method in class org.openspaces.jpa.openjpa.query.LogicalExpression
-
- appendSql(StringBuilder) - Method in class org.openspaces.jpa.openjpa.query.MatchesExpression
-
- appendSql(StringBuilder) - Method in class org.openspaces.jpa.openjpa.query.NotMatchesExpression
-
- appendSql(StringBuilder) - Method in class org.openspaces.jpa.openjpa.query.NullValueNode
-
- appendSql(StringBuilder) - Method in class org.openspaces.jpa.openjpa.query.ParameterNode
-
- appendSql(StringBuilder) - Method in class org.openspaces.jpa.openjpa.query.Variable
-
- appendWhereSql() - Method in class org.openspaces.jpa.openjpa.query.executor.JpaJdbcQueryExecutor
-
- Application - Interface in org.openspaces.admin.application
-
Describes a group of processing units that interact together as an application.
- APPLICATION_CONTEXT_CONTEXT - Static variable in class org.openspaces.pu.container.jee.JeeProcessingUnitContainerProvider
-
The
ServletContext
key under which the
ApplicationContext
(loaded from the
pu.xml
) is stored.
- APPLICATION_CONTEXT_KEY - Static variable in class org.openspaces.remoting.scripting.DefaultScriptingExecutor
-
- applicationAdded(Application) - Method in interface org.openspaces.admin.application.events.ApplicationAddedEventListener
-
A callback indicating that an Application was added (deployed/discovered).
- ApplicationAddedEventListener - Interface in org.openspaces.admin.application.events
-
An event listener allowing to listen for
Application
additions (deployment).
- ApplicationAddedEventManager - Interface in org.openspaces.admin.application.events
-
- ApplicationAlreadyDeployedException - Exception in org.openspaces.admin.application
-
- ApplicationAlreadyDeployedException(String) - Constructor for exception org.openspaces.admin.application.ApplicationAlreadyDeployedException
-
- ApplicationAlreadyDeployedException(String, Throwable) - Constructor for exception org.openspaces.admin.application.ApplicationAlreadyDeployedException
-
- ApplicationConfig - Class in org.openspaces.admin.application.config
-
- ApplicationConfig() - Constructor for class org.openspaces.admin.application.config.ApplicationConfig
-
- applicationContext - Variable in class org.openspaces.core.space.mode.SpaceModeContextLoader
-
- ApplicationContextMonitor - Interface in org.openspaces.pu.sla.monitor
-
- ApplicationContextProcessingUnitContainer - Class in org.openspaces.pu.container.spi
-
- ApplicationContextProcessingUnitContainer() - Constructor for class org.openspaces.pu.container.spi.ApplicationContextProcessingUnitContainer
-
- ApplicationContextProcessingUnitContainerProvider - Class in org.openspaces.pu.container.spi
-
- ApplicationContextProcessingUnitContainerProvider() - Constructor for class org.openspaces.pu.container.spi.ApplicationContextProcessingUnitContainerProvider
-
- ApplicationDeployCommand - Class in org.openspaces.admin.application.deploy
-
- ApplicationDeployCommand() - Constructor for class org.openspaces.admin.application.deploy.ApplicationDeployCommand
-
- ApplicationDeployment - Class in org.openspaces.admin.application
-
Describes an application deployment that consists of one or more processing unit deployments.
- ApplicationDeployment(String) - Constructor for class org.openspaces.admin.application.ApplicationDeployment
-
Creates a new application deployment with the specified name
- ApplicationDeployment(String, ProcessingUnitDeploymentTopology...) - Constructor for class org.openspaces.admin.application.ApplicationDeployment
-
Creates a new application deployment with the specified name, and pu deployments
- ApplicationDeployment(String, ProcessingUnitConfigHolder...) - Constructor for class org.openspaces.admin.application.ApplicationDeployment
-
Creates a new application deployment with the specified name, and pu deployments
- ApplicationDeployment(ApplicationConfig) - Constructor for class org.openspaces.admin.application.ApplicationDeployment
-
- ApplicationFileDeployment - Class in org.openspaces.admin.application
-
- ApplicationFileDeployment(File) - Constructor for class org.openspaces.admin.application.ApplicationFileDeployment
-
Creates a new application deployment based on the specified file
- ApplicationFileDeployment(File, String) - Constructor for class org.openspaces.admin.application.ApplicationFileDeployment
-
Creates a new application deployment based on the specified file
- ApplicationLifecycleEventListener - Interface in org.openspaces.admin.application.events
-
A simple life-cycle event listener that implements both the application added and zone removed event listeners.
- applicationRemoved(Application) - Method in interface org.openspaces.admin.application.events.ApplicationRemovedEventListener
-
A callback indicating that an Application was removed (undeployed).
- ApplicationRemovedEventListener - Interface in org.openspaces.admin.application.events
-
An event listener allowing to listen for
Application
removal (undeployment).
- ApplicationRemovedEventManager - Interface in org.openspaces.admin.application.events
-
- Applications - Interface in org.openspaces.admin.application
-
- ApplicationUndeployCommand - Class in org.openspaces.admin.application.deploy
-
- ApplicationUndeployCommand() - Constructor for class org.openspaces.admin.application.deploy.ApplicationUndeployCommand
-
- applyIsolationLevel(AbstractJiniTransactionManager.JiniTransactionObject, int) - Method in class org.openspaces.core.transaction.manager.AbstractJiniTransactionManager
-
- applyProjectionTemplate(RawEntry) - Method in class com.gigaspaces.query.aggregators.SpaceEntriesAggregatorContext
-
- Archive - Annotation Type in org.openspaces.archive
-
Marks an event listener as archive event listener.
- archive(Object...) - Method in interface org.openspaces.archive.ArchiveOperationHandler
-
Writes the specified objects to the external storage
- archiveHandler(ArchiveOperationHandler) - Method in class org.openspaces.archive.ArchivePollingContainerConfigurer
-
- ArchiveNamespaceHandler - Class in org.openspaces.archive.config
-
- ArchiveNamespaceHandler() - Constructor for class org.openspaces.archive.config.ArchiveNamespaceHandler
-
- ArchiveOperationHandler - Interface in org.openspaces.archive
-
- ArchivePollingAnnotationPostProcessor - Class in org.openspaces.archive
-
A
Archive
annotation post processor.
- ArchivePollingAnnotationPostProcessor() - Constructor for class org.openspaces.archive.ArchivePollingAnnotationPostProcessor
-
- ArchivePollingContainer - Class in org.openspaces.archive
-
- ArchivePollingContainer() - Constructor for class org.openspaces.archive.ArchivePollingContainer
-
- ArchivePollingContainerBeanDefinitionParser - Class in org.openspaces.archive.config
-
- ArchivePollingContainerBeanDefinitionParser() - Constructor for class org.openspaces.archive.config.ArchivePollingContainerBeanDefinitionParser
-
- ArchivePollingContainerConfigurer - Class in org.openspaces.archive
-
- ArchivePollingContainerConfigurer(GigaSpace) - Constructor for class org.openspaces.archive.ArchivePollingContainerConfigurer
-
- argument(String) - Method in class org.openspaces.admin.gsa.GridServiceOptions
-
Will add a process level argument.
- arguments - Variable in class org.openspaces.remoting.EventDrivenSpaceRemotingEntry
-
Deprecated.
- as(String) - Method in class com.gigaspaces.query.aggregators.SpaceEntriesAggregator
-
- asCachePolicy() - Method in class org.openspaces.core.config.BlobStoreDataPolicyFactoryBean
-
- asCachePolicy() - Method in class org.openspaces.core.config.CustomCachePolicyFactoryBean
-
- asExpression(Value) - Method in class org.openspaces.jpa.openjpa.query.QueryExpressionFactory
-
Return the given value as an expression.
- asGatewayPolicy() - Method in class org.openspaces.core.gateway.GatewayTarget
-
- asGatewayPolicy(GatewayPolicy) - Method in class org.openspaces.core.gateway.GatewayTarget
-
- asGatewaysPolicy() - Method in class org.openspaces.core.gateway.GatewayTargetsFactoryBean
-
- asReplicationLookupParameters() - Method in class org.openspaces.core.gateway.GatewayLookupsFactoryBean
-
- ASYNC_REPLICATION_MODE - Static variable in class com.j_spaces.core.cluster.ReplicationPolicy
-
- asyncAddIndex(String, SpaceIndex) - Method in class org.openspaces.core.DefaultGigaSpaceTypeManager
-
- asyncAddIndex(String, SpaceIndex, AsyncFutureListener<AddTypeIndexesResult>) - Method in class org.openspaces.core.DefaultGigaSpaceTypeManager
-
- asyncAddIndex(String, SpaceIndex) - Method in interface org.openspaces.core.GigaSpaceTypeManager
-
Adds the specified index to the specified type.
- asyncAddIndex(String, SpaceIndex, AsyncFutureListener<AddTypeIndexesResult>) - Method in interface org.openspaces.core.GigaSpaceTypeManager
-
Adds the specified index to the specified type.
- asyncAddIndexes(String, SpaceIndex[], AsyncFutureListener<AddTypeIndexesResult>) - Method in class org.openspaces.core.DefaultGigaSpaceTypeManager
-
- asyncAddIndexes(String, SpaceIndex[], AsyncFutureListener<AddTypeIndexesResult>) - Method in interface org.openspaces.core.GigaSpaceTypeManager
-
Adds the specified indexes to the specified type.
- asyncChange(ISpaceQuery<T>, ChangeSet) - Method in class org.openspaces.core.DefaultGigaSpace
-
- asyncChange(ISpaceQuery<T>, ChangeSet, AsyncFutureListener<ChangeResult<T>>) - Method in class org.openspaces.core.DefaultGigaSpace
-
- asyncChange(ISpaceQuery<T>, ChangeSet, long) - Method in class org.openspaces.core.DefaultGigaSpace
-
- asyncChange(ISpaceQuery<T>, ChangeSet, long, AsyncFutureListener<ChangeResult<T>>) - Method in class org.openspaces.core.DefaultGigaSpace
-
- asyncChange(ISpaceQuery<T>, ChangeSet, ChangeModifiers) - Method in class org.openspaces.core.DefaultGigaSpace
-
- asyncChange(ISpaceQuery<T>, ChangeSet, ChangeModifiers, AsyncFutureListener<ChangeResult<T>>) - Method in class org.openspaces.core.DefaultGigaSpace
-
- asyncChange(ISpaceQuery<T>, ChangeSet, ChangeModifiers, long) - Method in class org.openspaces.core.DefaultGigaSpace
-
- asyncChange(ISpaceQuery<T>, ChangeSet, ChangeModifiers, long, AsyncFutureListener<ChangeResult<T>>) - Method in class org.openspaces.core.DefaultGigaSpace
-
- asyncChange(T, ChangeSet) - Method in class org.openspaces.core.DefaultGigaSpace
-
- asyncChange(T, ChangeSet, AsyncFutureListener<ChangeResult<T>>) - Method in class org.openspaces.core.DefaultGigaSpace
-
- asyncChange(T, ChangeSet, long) - Method in class org.openspaces.core.DefaultGigaSpace
-
- asyncChange(T, ChangeSet, long, AsyncFutureListener<ChangeResult<T>>) - Method in class org.openspaces.core.DefaultGigaSpace
-
- asyncChange(T, ChangeSet, ChangeModifiers) - Method in class org.openspaces.core.DefaultGigaSpace
-
- asyncChange(T, ChangeSet, ChangeModifiers, AsyncFutureListener<ChangeResult<T>>) - Method in class org.openspaces.core.DefaultGigaSpace
-
- asyncChange(T, ChangeSet, ChangeModifiers, long) - Method in class org.openspaces.core.DefaultGigaSpace
-
- asyncChange(T, ChangeSet, ChangeModifiers, long, AsyncFutureListener<ChangeResult<T>>) - Method in class org.openspaces.core.DefaultGigaSpace
-
- asyncChange(ISpaceQuery<T>, ChangeSet) - Method in interface org.openspaces.core.GigaSpace
-
Changes existing objects in space in an asynchronous manner, returning immidiately with a future.
- asyncChange(ISpaceQuery<T>, ChangeSet, AsyncFutureListener<ChangeResult<T>>) - Method in interface org.openspaces.core.GigaSpace
-
Changes existing objects in space in an asynchronous manner, returning immidiately with a future.
- asyncChange(ISpaceQuery<T>, ChangeSet, long) - Method in interface org.openspaces.core.GigaSpace
-
Changes existing objects in space in an asynchronous manner, returning immidiately with a future.
- asyncChange(ISpaceQuery<T>, ChangeSet, long, AsyncFutureListener<ChangeResult<T>>) - Method in interface org.openspaces.core.GigaSpace
-
Changes existing objects in space in an asynchronous manner, returning immidiately with a future.
- asyncChange(ISpaceQuery<T>, ChangeSet, ChangeModifiers) - Method in interface org.openspaces.core.GigaSpace
-
Changes an existing objects in space in an asynchronous manner, returning immidiately with a future.
- asyncChange(ISpaceQuery<T>, ChangeSet, ChangeModifiers, AsyncFutureListener<ChangeResult<T>>) - Method in interface org.openspaces.core.GigaSpace
-
Changes existing objects in space in an asynchronous manner, returning immidiately with a future.
- asyncChange(ISpaceQuery<T>, ChangeSet, ChangeModifiers, long) - Method in interface org.openspaces.core.GigaSpace
-
Changes existing objects in space in an asynchronous manner, returning immidiately with a future.
- asyncChange(ISpaceQuery<T>, ChangeSet, ChangeModifiers, long, AsyncFutureListener<ChangeResult<T>>) - Method in interface org.openspaces.core.GigaSpace
-
Changes existing objects in space in an asynchronous manner, returning immidiately with a future.
- asyncChange(T, ChangeSet) - Method in interface org.openspaces.core.GigaSpace
-
Changes existing objects in space in an asynchronous manner, returning immidiately with a future.
- asyncChange(T, ChangeSet, AsyncFutureListener<ChangeResult<T>>) - Method in interface org.openspaces.core.GigaSpace
-
Changes existing objects in space in an asynchronous manner, returning immidiately with a future.
- asyncChange(T, ChangeSet, long) - Method in interface org.openspaces.core.GigaSpace
-
Changes existing objects in space in an asynchronous manner, returning immidiately with a future.
- asyncChange(T, ChangeSet, long, AsyncFutureListener<ChangeResult<T>>) - Method in interface org.openspaces.core.GigaSpace
-
Changes existing objects in space in an asynchronous manner, returning immidiately with a future.
- asyncChange(T, ChangeSet, ChangeModifiers) - Method in interface org.openspaces.core.GigaSpace
-
Changes an existing objects in space in an asynchronous manner, returning immidiately with a future.
- asyncChange(T, ChangeSet, ChangeModifiers, AsyncFutureListener<ChangeResult<T>>) - Method in interface org.openspaces.core.GigaSpace
-
Changes existing objects in space in an asynchronous manner, returning immidiately with a future.
- asyncChange(T, ChangeSet, ChangeModifiers, long) - Method in interface org.openspaces.core.GigaSpace
-
Changes existing objects in space in an asynchronous manner, returning immidiately with a future.
- asyncChange(T, ChangeSet, ChangeModifiers, long, AsyncFutureListener<ChangeResult<T>>) - Method in interface org.openspaces.core.GigaSpace
-
Changes existing objects in space in an asynchronous manner, returning immidiately with a future.
- asyncChange(GigaSpace, ISpaceQuery<T>, ChangeSet) - Static method in class org.openspaces.extensions.AsyncExtension
-
- asyncChange(GigaSpace, ISpaceQuery<T>, ChangeSet, long, TimeUnit) - Static method in class org.openspaces.extensions.AsyncExtension
-
- asyncChange(GigaSpace, ISpaceQuery<T>, ChangeSet, ChangeModifiers) - Static method in class org.openspaces.extensions.AsyncExtension
-
- asyncChange(GigaSpace, ISpaceQuery<T>, ChangeSet, ChangeModifiers, long, TimeUnit) - Static method in class org.openspaces.extensions.AsyncExtension
-
- asyncChange(GigaSpace, T, ChangeSet) - Static method in class org.openspaces.extensions.AsyncExtension
-
- asyncChange(GigaSpace, T, ChangeSet, long, TimeUnit) - Static method in class org.openspaces.extensions.AsyncExtension
-
- asyncChange(GigaSpace, T, ChangeSet, ChangeModifiers) - Static method in class org.openspaces.extensions.AsyncExtension
-
- asyncChange(GigaSpace, T, ChangeSet, ChangeModifiers, long, TimeUnit) - Static method in class org.openspaces.extensions.AsyncExtension
-
- asyncEventPing() - Method in class org.openspaces.memcached.SpaceCache
-
- asyncExecute(Script) - Method in class org.openspaces.remoting.scripting.DefaultScriptingExecutor
-
- asyncExecute(Script) - Method in interface org.openspaces.remoting.scripting.ScriptingExecutor
-
Executes the given script and return a future that can be used to read the response
at a later stage.
- AsyncExtension - Class in org.openspaces.extensions
-
- AsyncExtension() - Constructor for class org.openspaces.extensions.AsyncExtension
-
- AsyncFuture<T> - Interface in com.gigaspaces.async
-
Extends
Future
to provide a listener API.
- AsyncFutureListener<T> - Interface in com.gigaspaces.async
-
Allows to register for a callback on an
AsyncFuture
to be
notified when a result arrives.
- AsyncHandler - Annotation Type in org.openspaces.events.asyncpolling
-
An annotation marking a method as one that is responsilbe to return a
AsyncOperationHandler
to be used
with an async polling container.
- AsyncOperationHandler - Interface in org.openspaces.events.asyncpolling.receive
-
- asyncOperationHandler(AsyncOperationHandler) - Method in class org.openspaces.events.asyncpolling.SimpleAsyncPollingContainerConfigurer
-
- AsyncPolling - Annotation Type in org.openspaces.events.asyncpolling
-
Marks an event listener an asyncronous polled event listener.
- AsyncPollingAnnotationPostProcessor - Class in org.openspaces.events.asyncpolling.config
-
- AsyncPollingAnnotationPostProcessor() - Constructor for class org.openspaces.events.asyncpolling.config.AsyncPollingAnnotationPostProcessor
-
- AsyncPollingContainerBeanDefinitionParser - Class in org.openspaces.events.config
-
- AsyncPollingContainerBeanDefinitionParser() - Constructor for class org.openspaces.events.config.AsyncPollingContainerBeanDefinitionParser
-
- AsyncPollingEventContainerServiceDetails - Class in org.openspaces.events.asyncpolling
-
Async Polling container service details.
- AsyncPollingEventContainerServiceDetails() - Constructor for class org.openspaces.events.asyncpolling.AsyncPollingEventContainerServiceDetails
-
- AsyncPollingEventContainerServiceDetails(String, String, Object, boolean, String, long, int) - Constructor for class org.openspaces.events.asyncpolling.AsyncPollingEventContainerServiceDetails
-
- AsyncPollingEventContainerServiceDetails.Attributes - Class in org.openspaces.events.asyncpolling
-
- AsyncPollingEventContainerServiceMonitors - Class in org.openspaces.events.asyncpolling
-
Async Polling container service monitors.
- AsyncPollingEventContainerServiceMonitors() - Constructor for class org.openspaces.events.asyncpolling.AsyncPollingEventContainerServiceMonitors
-
- AsyncPollingEventContainerServiceMonitors(String, long, long, String) - Constructor for class org.openspaces.events.asyncpolling.AsyncPollingEventContainerServiceMonitors
-
- AsyncPollingEventContainerServiceMonitors.Attributes - Class in org.openspaces.events.asyncpolling
-
- asyncRead(T) - Method in class org.openspaces.core.DefaultGigaSpace
-
- asyncRead(T, AsyncFutureListener<T>) - Method in class org.openspaces.core.DefaultGigaSpace
-
- asyncRead(T, long) - Method in class org.openspaces.core.DefaultGigaSpace
-
- asyncRead(T, long, AsyncFutureListener<T>) - Method in class org.openspaces.core.DefaultGigaSpace
-
- asyncRead(T, long, int) - Method in class org.openspaces.core.DefaultGigaSpace
-
- asyncRead(T, long, ReadModifiers) - Method in class org.openspaces.core.DefaultGigaSpace
-
- asyncRead(T, long, int, AsyncFutureListener<T>) - Method in class org.openspaces.core.DefaultGigaSpace
-
- asyncRead(T, long, ReadModifiers, AsyncFutureListener<T>) - Method in class org.openspaces.core.DefaultGigaSpace
-
- asyncRead(ISpaceQuery<T>) - Method in class org.openspaces.core.DefaultGigaSpace
-
- asyncRead(ISpaceQuery<T>, AsyncFutureListener<T>) - Method in class org.openspaces.core.DefaultGigaSpace
-
- asyncRead(ISpaceQuery<T>, long) - Method in class org.openspaces.core.DefaultGigaSpace
-
- asyncRead(ISpaceQuery<T>, long, AsyncFutureListener<T>) - Method in class org.openspaces.core.DefaultGigaSpace
-
- asyncRead(ISpaceQuery<T>, long, int) - Method in class org.openspaces.core.DefaultGigaSpace
-
- asyncRead(ISpaceQuery<T>, long, ReadModifiers) - Method in class org.openspaces.core.DefaultGigaSpace
-
- asyncRead(ISpaceQuery<T>, long, int, AsyncFutureListener<T>) - Method in class org.openspaces.core.DefaultGigaSpace
-
- asyncRead(ISpaceQuery<T>, long, ReadModifiers, AsyncFutureListener<T>) - Method in class org.openspaces.core.DefaultGigaSpace
-
- asyncRead(T) - Method in interface org.openspaces.core.GigaSpace
-
Reads any matching entry from the space in an asynchronous manner.
- asyncRead(T, AsyncFutureListener<T>) - Method in interface org.openspaces.core.GigaSpace
-
Reads any matching entry from the space in an asynchronous manner.
- asyncRead(T, long) - Method in interface org.openspaces.core.GigaSpace
-
Reads any matching entry from the space in an asynchronous manner.
- asyncRead(T, long, AsyncFutureListener<T>) - Method in interface org.openspaces.core.GigaSpace
-
Reads any matching entry from the space in an asynchronous manner.
- asyncRead(T, long, int) - Method in interface org.openspaces.core.GigaSpace
-
- asyncRead(T, long, ReadModifiers) - Method in interface org.openspaces.core.GigaSpace
-
Reads any matching entry from the space in an asynchronous manner.
- asyncRead(T, long, int, AsyncFutureListener<T>) - Method in interface org.openspaces.core.GigaSpace
-
- asyncRead(T, long, ReadModifiers, AsyncFutureListener<T>) - Method in interface org.openspaces.core.GigaSpace
-
Reads any matching entry from the space in an asynchronous manner.
- asyncRead(ISpaceQuery<T>) - Method in interface org.openspaces.core.GigaSpace
-
Reads any matching entry from the space in an asynchronous manner.
- asyncRead(ISpaceQuery<T>, AsyncFutureListener<T>) - Method in interface org.openspaces.core.GigaSpace
-
Reads any matching entry from the space in an asynchronous manner.
- asyncRead(ISpaceQuery<T>, long) - Method in interface org.openspaces.core.GigaSpace
-
Reads any matching entry from the space in an asynchronous manner.
- asyncRead(ISpaceQuery<T>, long, AsyncFutureListener<T>) - Method in interface org.openspaces.core.GigaSpace
-
Reads any matching entry from the space in an asynchronous manner.
- asyncRead(ISpaceQuery<T>, long, int) - Method in interface org.openspaces.core.GigaSpace
-
- asyncRead(ISpaceQuery<T>, long, ReadModifiers) - Method in interface org.openspaces.core.GigaSpace
-
Reads any matching entry from the space in an asynchronous manner.
- asyncRead(ISpaceQuery<T>, long, int, AsyncFutureListener<T>) - Method in interface org.openspaces.core.GigaSpace
-
- asyncRead(ISpaceQuery<T>, long, ReadModifiers, AsyncFutureListener<T>) - Method in interface org.openspaces.core.GigaSpace
-
Reads any matching entry from the space in an asynchronous manner.
- asyncRead(GigaSpace, T) - Static method in class org.openspaces.extensions.AsyncExtension
-
- asyncRead(GigaSpace, T, long, TimeUnit) - Static method in class org.openspaces.extensions.AsyncExtension
-
- asyncRead(GigaSpace, T, long, TimeUnit, ReadModifiers) - Static method in class org.openspaces.extensions.AsyncExtension
-
- asyncRead(GigaSpace, ISpaceQuery<T>) - Static method in class org.openspaces.extensions.AsyncExtension
-
- asyncRead(GigaSpace, ISpaceQuery<T>, long, TimeUnit) - Static method in class org.openspaces.extensions.AsyncExtension
-
- asyncRead(GigaSpace, ISpaceQuery<T>, long, TimeUnit, ReadModifiers) - Static method in class org.openspaces.extensions.AsyncExtension
-
- asyncReceive(Object, GigaSpace, long, AsyncFutureListener) - Method in interface org.openspaces.events.asyncpolling.receive.AsyncOperationHandler
-
Perform the async receive operation.
- asyncReceive(Object, GigaSpace, long, AsyncFutureListener) - Method in class org.openspaces.events.asyncpolling.receive.ExclusiveReadAsyncOperationHandler
-
- asyncReceive(Object, GigaSpace, long, AsyncFutureListener) - Method in class org.openspaces.events.asyncpolling.receive.SingleReadAsyncOperationHandler
-
- asyncReceive(Object, GigaSpace, long, AsyncFutureListener) - Method in class org.openspaces.events.asyncpolling.receive.SingleTakeAsyncOperationHandler
-
- AsyncResult<T> - Interface in com.gigaspaces.async
-
An async invocation result holding the actual result of the invocation
or an possible exception raised during the invocation.
- AsyncResultFilter<T> - Interface in com.gigaspaces.async
-
An optional filter that can be used with distributed tasks.
- AsyncResultFilter.Decision - Enum in com.gigaspaces.async
-
Controls what should be done with the results.
- AsyncResultFilterEvent<T> - Class in com.gigaspaces.async
-
- AsyncResultFilterEvent(AsyncResult<T>, AsyncResult<T>[], int) - Constructor for class com.gigaspaces.async.AsyncResultFilterEvent
-
Constructs a new async result filter event
- AsyncResultFuture<T> - Class in org.openspaces.core.executor.support
-
- AsyncResultFuture(AsyncResult<T>) - Constructor for class org.openspaces.core.executor.support.AsyncResultFuture
-
- AsyncResultsReducer<T,R> - Interface in com.gigaspaces.async
-
A generic interface that reduces a list of
AsyncResult
.
- asyncTake(T) - Method in class org.openspaces.core.DefaultGigaSpace
-
- asyncTake(T, AsyncFutureListener<T>) - Method in class org.openspaces.core.DefaultGigaSpace
-
- asyncTake(T, long) - Method in class org.openspaces.core.DefaultGigaSpace
-
- asyncTake(T, long, AsyncFutureListener<T>) - Method in class org.openspaces.core.DefaultGigaSpace
-
- asyncTake(T, long, int) - Method in class org.openspaces.core.DefaultGigaSpace
-
- asyncTake(T, long, TakeModifiers) - Method in class org.openspaces.core.DefaultGigaSpace
-
- asyncTake(T, long, int, AsyncFutureListener<T>) - Method in class org.openspaces.core.DefaultGigaSpace
-
- asyncTake(T, long, TakeModifiers, AsyncFutureListener<T>) - Method in class org.openspaces.core.DefaultGigaSpace
-
- asyncTake(ISpaceQuery<T>) - Method in class org.openspaces.core.DefaultGigaSpace
-
- asyncTake(ISpaceQuery<T>, AsyncFutureListener<T>) - Method in class org.openspaces.core.DefaultGigaSpace
-
- asyncTake(ISpaceQuery<T>, long) - Method in class org.openspaces.core.DefaultGigaSpace
-
- asyncTake(ISpaceQuery<T>, long, AsyncFutureListener<T>) - Method in class org.openspaces.core.DefaultGigaSpace
-
- asyncTake(ISpaceQuery<T>, long, int) - Method in class org.openspaces.core.DefaultGigaSpace
-
- asyncTake(ISpaceQuery<T>, long, TakeModifiers) - Method in class org.openspaces.core.DefaultGigaSpace
-
- asyncTake(ISpaceQuery<T>, long, int, AsyncFutureListener<T>) - Method in class org.openspaces.core.DefaultGigaSpace
-
- asyncTake(ISpaceQuery<T>, long, TakeModifiers, AsyncFutureListener<T>) - Method in class org.openspaces.core.DefaultGigaSpace
-
- asyncTake(T) - Method in interface org.openspaces.core.GigaSpace
-
Take (remove) any matching entry from the space in an asynchronous manner.
- asyncTake(T, AsyncFutureListener<T>) - Method in interface org.openspaces.core.GigaSpace
-
Take (remove) any matching entry from the space in an asynchronous manner.
- asyncTake(T, long) - Method in interface org.openspaces.core.GigaSpace
-
Take (remove) any matching entry from the space in an asynchronous manner.
- asyncTake(T, long, AsyncFutureListener<T>) - Method in interface org.openspaces.core.GigaSpace
-
Take (remove) any matching entry from the space in an asynchronous manner.
- asyncTake(T, long, int) - Method in interface org.openspaces.core.GigaSpace
-
- asyncTake(T, long, TakeModifiers) - Method in interface org.openspaces.core.GigaSpace
-
Take (remove) any matching entry from the space in an asynchronous manner.
- asyncTake(T, long, int, AsyncFutureListener<T>) - Method in interface org.openspaces.core.GigaSpace
-
- asyncTake(T, long, TakeModifiers, AsyncFutureListener<T>) - Method in interface org.openspaces.core.GigaSpace
-
Take (remove) any matching entry from the space in an asynchronous manner.
- asyncTake(ISpaceQuery<T>) - Method in interface org.openspaces.core.GigaSpace
-
Take (remove) any matching entry from the space in an asynchronous manner.
- asyncTake(ISpaceQuery<T>, AsyncFutureListener<T>) - Method in interface org.openspaces.core.GigaSpace
-
Take (remove) any matching entry from the space in an asynchronous manner.
- asyncTake(ISpaceQuery<T>, long) - Method in interface org.openspaces.core.GigaSpace
-
Take (remove) any matching entry from the space in an asynchronous manner.
- asyncTake(ISpaceQuery<T>, long, AsyncFutureListener<T>) - Method in interface org.openspaces.core.GigaSpace
-
Take (remove) any matching entry from the space in an asynchronous manner.
- asyncTake(ISpaceQuery<T>, long, int) - Method in interface org.openspaces.core.GigaSpace
-
- asyncTake(ISpaceQuery<T>, long, TakeModifiers) - Method in interface org.openspaces.core.GigaSpace
-
Take (remove) any matching entry from the space in an asynchronous manner.
- asyncTake(ISpaceQuery<T>, long, int, AsyncFutureListener<T>) - Method in interface org.openspaces.core.GigaSpace
-
- asyncTake(ISpaceQuery<T>, long, TakeModifiers, AsyncFutureListener<T>) - Method in interface org.openspaces.core.GigaSpace
-
Take (remove) any matching entry from the space in an asynchronous manner.
- asyncTake(GigaSpace, T) - Static method in class org.openspaces.extensions.AsyncExtension
-
- asyncTake(GigaSpace, T, long, TimeUnit) - Static method in class org.openspaces.extensions.AsyncExtension
-
- asyncTake(GigaSpace, T, long, TimeUnit, TakeModifiers) - Static method in class org.openspaces.extensions.AsyncExtension
-
- asyncTake(GigaSpace, ISpaceQuery<T>) - Static method in class org.openspaces.extensions.AsyncExtension
-
- asyncTake(GigaSpace, ISpaceQuery<T>, long, TimeUnit) - Static method in class org.openspaces.extensions.AsyncExtension
-
- asyncTake(GigaSpace, ISpaceQuery<T>, long, TimeUnit, TakeModifiers) - Static method in class org.openspaces.extensions.AsyncExtension
-
- AtLeastOneZoneConfig - Class in org.openspaces.admin.zone.config
-
Satisfied if at least one of the zones exist
PU[A,B] is statisfied by GSC[A,B]
PU[A,B] is statisfied by GSC[A]
PU[A,B] is statisfied by GSC[B]
PU[A] is statisfied by GSC[A,B]
PU[A] is statisfied by GSC[A]
PU[A] is NOT statisfied by GSC[]
- AtLeastOneZoneConfig(Map<String, String>) - Constructor for class org.openspaces.admin.zone.config.AtLeastOneZoneConfig
-
- AtLeastOneZoneConfig() - Constructor for class org.openspaces.admin.zone.config.AtLeastOneZoneConfig
-
- AtLeastOneZoneConfigurer - Class in org.openspaces.admin.zone.config
-
- AtLeastOneZoneConfigurer() - Constructor for class org.openspaces.admin.zone.config.AtLeastOneZoneConfigurer
-
- atMostOneConcurrentRelocation(boolean) - Method in class org.openspaces.admin.pu.elastic.config.AutomaticCapacityScaleConfigurer
-
- atMostOneConcurrentRelocation(boolean) - Method in class org.openspaces.admin.pu.elastic.config.EagerScaleConfigurer
-
- atMostOneConcurrentRelocation(boolean) - Method in class org.openspaces.admin.pu.elastic.config.ManualCapacityPerZonesScaleConfigurer
-
- atMostOneConcurrentRelocation(boolean) - Method in class org.openspaces.admin.pu.elastic.config.ManualCapacityScaleConfigurer
-
- atMostOneConcurrentRelocation(boolean) - Method in interface org.openspaces.admin.pu.elastic.config.ScaleStrategyConfigurer
-
- atMostOneContainerPerMachine() - Method in class org.openspaces.admin.pu.elastic.config.AutomaticCapacityScaleConfigurer
-
- atMostOneContainerPerMachine() - Method in class org.openspaces.admin.pu.elastic.config.EagerScaleConfigurer
-
- atMostOneContainerPerMachine() - Method in class org.openspaces.admin.pu.elastic.config.ManualCapacityPerZonesScaleConfigurer
-
- atMostOneContainerPerMachine() - Method in class org.openspaces.admin.pu.elastic.config.ManualCapacityScaleConfigurer
-
- atMostOneContainerPerMachine() - Method in interface org.openspaces.admin.pu.elastic.config.ScaleStrategyConfigurer
-
- atoi(byte[]) - Static method in class org.openspaces.memcached.util.BufferUtils
-
- atol(byte[]) - Static method in class org.openspaces.memcached.util.BufferUtils
-
- Attributes() - Constructor for class org.openspaces.core.space.SpaceServiceDetails.Attributes
-
- Attributes() - Constructor for class org.openspaces.events.asyncpolling.AggregatedAsyncPollingEventContainerServiceDetails.Attributes
-
- Attributes() - Constructor for class org.openspaces.events.asyncpolling.AsyncPollingEventContainerServiceDetails.Attributes
-
- Attributes() - Constructor for class org.openspaces.events.asyncpolling.AsyncPollingEventContainerServiceMonitors.Attributes
-
- Attributes() - Constructor for class org.openspaces.events.EventContainerServiceDetails.Attributes
-
- Attributes() - Constructor for class org.openspaces.events.EventContainerServiceMonitors.Attributes
-
- Attributes() - Constructor for class org.openspaces.events.notify.AggregatedNotifyEventContainerServiceDetails.Attributes
-
- Attributes() - Constructor for class org.openspaces.events.notify.NotifyEventContainerServiceDetails.Attributes
-
- Attributes() - Constructor for class org.openspaces.events.notify.NotifyEventContainerServiceMonitors.Attributes
-
- Attributes() - Constructor for class org.openspaces.events.polling.AggregatedPollingEventContainerServiceDetails.Attributes
-
- Attributes() - Constructor for class org.openspaces.events.polling.PollingEventContainerServiceDetails.Attributes
-
- Attributes() - Constructor for class org.openspaces.events.polling.PollingEventContainerServiceMonitors.Attributes
-
- Attributes() - Constructor for class org.openspaces.memcached.MemcachedServiceDetails.Attributes
-
- Attributes() - Constructor for class org.openspaces.memcached.MemcachedServiceMonitors.Attributes
-
- Attributes() - Constructor for class org.openspaces.pu.container.jee.JeeServiceDetails.Attributes
-
- Attributes() - Constructor for class org.openspaces.pu.container.jee.stats.WebRequestsServiceMonitors.Attributes
-
- attributes - Variable in class org.openspaces.pu.service.PlainServiceDetails
-
- Attributes() - Constructor for class org.openspaces.remoting.RemotingServiceDetails.Attributes
-
- Attributes() - Constructor for class org.openspaces.remoting.RemotingServiceMonitors.Attributes
-
- attributeStore(AttributeStore) - Method in class org.openspaces.core.space.EmbeddedSpaceConfigurer
-
Sets an attribute store
- attributeStore(AttributeStore) - Method in class org.openspaces.core.space.EmbeddedSpaceFactoryBean
-
- attributeStore(AttributeStore) - Method in class org.openspaces.core.space.UrlSpaceConfigurer
-
Sets an attribute store
- attributeStore(AttributeStore) - Method in class org.openspaces.core.space.UrlSpaceFactoryBean
-
- AttributeStoreBeanDefinitionParser - Class in org.openspaces.core.config
-
- AttributeStoreBeanDefinitionParser() - Constructor for class org.openspaces.core.config.AttributeStoreBeanDefinitionParser
-
- AttributeStoreFactoryBean - Class in org.openspaces.core.config
-
- AttributeStoreFactoryBean() - Constructor for class org.openspaces.core.config.AttributeStoreFactoryBean
-
- AuditDetails - Class in com.gigaspaces.security.audit
-
The AuditDetails
are client side auditing details sent to the server on each
authentication request.
- AuditDetails() - Constructor for class com.gigaspaces.security.audit.AuditDetails
-
Constructs the session details - done at proxy side.
- AuditHandler - Class in com.gigaspaces.security.audit
-
- AuditHandler() - Constructor for class com.gigaspaces.security.audit.AuditHandler
-
Construct a default FileHandler.
- AuditLogRecord - Class in com.gigaspaces.security.audit
-
The java logging facility formats a
LogRecord
before it is logged.
- AuditLogRecord(Level, String, String) - Constructor for class com.gigaspaces.security.audit.AuditLogRecord
-
- augmentInitialLoadEntries - Variable in class org.openspaces.persistency.ClusterInfoAwareSpaceDataSource
-
- augmentInitialLoadEntries(boolean) - Method in class org.openspaces.persistency.hibernate.CriteriaHibernateSpaceDataSourceConfigurer
-
Feature switch for initial load entries augmentation (creation of partition-specific query for entries).
- augmentInitialLoadEntries(boolean) - Method in class org.openspaces.persistency.hibernate.DefaultHibernateSpaceDataSourceConfigurer
-
Feature switch for initial load entries augmentation (creation of partition-specific query for entries) Defaults to true
.
- augmentInitialLoadEntries(boolean) - Method in class org.openspaces.persistency.hibernate.StatelessHibernateSpaceDataSourceConfigurer
-
Feature switch for initial load entries augmentation (creation of partition-specific query for entries)
- authenticate(UserDetails) - Method in interface com.gigaspaces.security.SecurityManager
-
Attempts to authenticate the passed user represented by
UserDetails
, returning a
fully populated
UserDetails
object (including granted authorities) if
successful.
- authenticate(UserDetails) - Method in class org.openspaces.security.spring.SpringSecurityManager
-
Attempts to authenticate the passed
UserDetails
object, returning a fully populated
Authentication
object (including granted authorities) if successful.
- Authentication - Class in com.gigaspaces.security
-
- Authentication(UserDetails) - Constructor for class com.gigaspaces.security.Authentication
-
Create an authentication for an authenticated
UserDetails
.
- AuthenticationException - Exception in com.gigaspaces.security
-
Thrown if an authentication is invalid.
- AuthenticationException() - Constructor for exception com.gigaspaces.security.AuthenticationException
-
Constructs a AuthenticationException
with no detail message.
- AuthenticationException(String) - Constructor for exception com.gigaspaces.security.AuthenticationException
-
Constructs a AuthenticationException
with the specified detail message.
- AuthenticationException(String, Throwable) - Constructor for exception com.gigaspaces.security.AuthenticationException
-
Creates a AuthenticationException
with the specified detail message and cause.
- AuthenticationException(Throwable) - Constructor for exception com.gigaspaces.security.AuthenticationException
-
Creates a AuthenticationException
with the specified cause and a detail message of
(cause==null ?
- Authority - Interface in com.gigaspaces.security
-
Interface for all authorities that may be granted to a user.
- AuthorityFactory - Class in com.gigaspaces.security
-
- AuthorityFactory() - Constructor for class com.gigaspaces.security.AuthorityFactory
-
- AUTO_RENEW - Static variable in class org.openspaces.events.notify.AggregatedNotifyEventContainerServiceDetails.Attributes
-
- AUTO_RENEW - Static variable in class org.openspaces.events.notify.NotifyEventContainerServiceDetails.Attributes
-
- AutomaticCapacityCooldownValidator - Class in org.openspaces.grid.gsm.autoscaling
-
Validates the cooldown period of auto-scaling rules.
- AutomaticCapacityCooldownValidator() - Constructor for class org.openspaces.grid.gsm.autoscaling.AutomaticCapacityCooldownValidator
-
- AutomaticCapacityScaleConfig - Class in org.openspaces.admin.pu.elastic.config
-
Defines an automatic scaling strategy that increases and decreases capacity.
- AutomaticCapacityScaleConfig() - Constructor for class org.openspaces.admin.pu.elastic.config.AutomaticCapacityScaleConfig
-
Default constructor
- AutomaticCapacityScaleConfig(Map<String, String>) - Constructor for class org.openspaces.admin.pu.elastic.config.AutomaticCapacityScaleConfig
-
- AutomaticCapacityScaleConfigurer - Class in org.openspaces.admin.pu.elastic.config
-
- AutomaticCapacityScaleConfigurer() - Constructor for class org.openspaces.admin.pu.elastic.config.AutomaticCapacityScaleConfigurer
-
- AutomaticCapacityScaleRuleConfig - Class in org.openspaces.admin.pu.elastic.config
-
Configures an automatic scaling rule based on a monitored statistics and thresholds.
- AutomaticCapacityScaleRuleConfig() - Constructor for class org.openspaces.admin.pu.elastic.config.AutomaticCapacityScaleRuleConfig
-
- AutomaticCapacityScaleRuleConfig(Map<String, String>) - Constructor for class org.openspaces.admin.pu.elastic.config.AutomaticCapacityScaleRuleConfig
-
- AutomaticCapacityScaleRuleConfigurer - Class in org.openspaces.admin.pu.elastic.config
-
- AutomaticCapacityScaleRuleConfigurer() - Constructor for class org.openspaces.admin.pu.elastic.config.AutomaticCapacityScaleRuleConfigurer
-
- AutomaticCapacityScaleStrategyBean - Class in org.openspaces.grid.gsm.strategy
-
+ * The business logic that scales an elastic processing unit based on the specified
+ *
AutomaticCapacityScaleConfig
+ *
+ * @author itaif
+ * @since 9.0.0
+
- AutomaticCapacityScaleStrategyBean() - Constructor for class org.openspaces.grid.gsm.strategy.AutomaticCapacityScaleStrategyBean
-
- AutomaticCapacityScaleTopology - Interface in org.openspaces.admin.pu.elastic.topology
-
- autoRenew(boolean) - Method in class org.openspaces.events.notify.SimpleNotifyContainerConfigurer
-
- AutoScalingConfigConflictException - Exception in org.openspaces.grid.gsm.autoscaling.exceptions
-
an exception that is raised if the autoscaling configuration parameters causes an un resolvable conflict
in the Minimum/Maximum Capacity requirements for a specific zone.
- AutoScalingConfigConflictException(ProcessingUnit, CapacityRequirements, CapacityRequirements, Set<String>, CapacityRequirementsPerZones, CapacityRequirementsPerZones) - Constructor for exception org.openspaces.grid.gsm.autoscaling.exceptions.AutoScalingConfigConflictException
-
- AutoScalingHighThresholdBreachedException - Exception in org.openspaces.grid.gsm.autoscaling.exceptions
-
- AutoScalingHighThresholdBreachedException(ProcessingUnit, CapacityRequirements, CapacityRequirements, long, AutomaticCapacityScaleRuleConfig, String) - Constructor for exception org.openspaces.grid.gsm.autoscaling.exceptions.AutoScalingHighThresholdBreachedException
-
- AutoScalingInstanceStatisticsException - Exception in org.openspaces.grid.gsm.autoscaling.exceptions
-
- AutoScalingInstanceStatisticsException(ProcessingUnitInstance, String) - Constructor for exception org.openspaces.grid.gsm.autoscaling.exceptions.AutoScalingInstanceStatisticsException
-
- AutoScalingLowThresholdBreachedException - Exception in org.openspaces.grid.gsm.autoscaling.exceptions
-
- AutoScalingLowThresholdBreachedException(ProcessingUnit, CapacityRequirements, CapacityRequirements, long, AutomaticCapacityScaleRuleConfig, String) - Constructor for exception org.openspaces.grid.gsm.autoscaling.exceptions.AutoScalingLowThresholdBreachedException
-
- AutoScalingSlaEnforcement - Class in org.openspaces.grid.gsm.autoscaling
-
Enforces the AutoScalingSlaPolicy of all processing units by starting an enforcement endpoint for each PU.
- AutoScalingSlaEnforcement(Admin) - Constructor for class org.openspaces.grid.gsm.autoscaling.AutoScalingSlaEnforcement
-
- AutoScalingSlaEnforcementEndpoint - Interface in org.openspaces.grid.gsm.autoscaling
-
A service that on demand enforces auto scaling rules providing the new capacity requirements as a result.
- AutoScalingSlaEnforcementEndpointAware - Interface in org.openspaces.grid.gsm.autoscaling
-
- AutoScalingSlaEnforcementInProgressException - Exception in org.openspaces.grid.gsm.autoscaling.exceptions
-
- AutoScalingSlaEnforcementInProgressException(ProcessingUnit, String) - Constructor for exception org.openspaces.grid.gsm.autoscaling.exceptions.AutoScalingSlaEnforcementInProgressException
-
- AutoScalingSlaEnforcementInProgressException(ProcessingUnit, String, Throwable) - Constructor for exception org.openspaces.grid.gsm.autoscaling.exceptions.AutoScalingSlaEnforcementInProgressException
-
- AutoScalingSlaPolicy - Class in org.openspaces.grid.gsm.autoscaling
-
- AutoScalingSlaPolicy() - Constructor for class org.openspaces.grid.gsm.autoscaling.AutoScalingSlaPolicy
-
- AutoScalingSlaUtils - Class in org.openspaces.grid.gsm.autoscaling
-
- AutoScalingSlaUtils() - Constructor for class org.openspaces.grid.gsm.autoscaling.AutoScalingSlaUtils
-
- AutoScalingStatisticsException - Exception in org.openspaces.grid.gsm.autoscaling.exceptions
-
- AutoScalingStatisticsException(ProcessingUnit, String) - Constructor for exception org.openspaces.grid.gsm.autoscaling.exceptions.AutoScalingStatisticsException
-
- AutoScalingStatisticsException(ProcessingUnit, String, Throwable) - Constructor for exception org.openspaces.grid.gsm.autoscaling.exceptions.AutoScalingStatisticsException
-
- AutoScalingStatisticsException(ProcessingUnit, ProcessingUnitStatisticsId) - Constructor for exception org.openspaces.grid.gsm.autoscaling.exceptions.AutoScalingStatisticsException
-
- AutoScalingStatisticsFormatException - Exception in org.openspaces.grid.gsm.autoscaling.exceptions
-
- AutoScalingStatisticsFormatException(ProcessingUnit, Object, Object, NumberFormatException) - Constructor for exception org.openspaces.grid.gsm.autoscaling.exceptions.AutoScalingStatisticsFormatException
-
- AutoScalingTemporarilyDisabledCooldownException - Exception in org.openspaces.grid.gsm.autoscaling.exceptions
-
Indicates that auto scaling rules are disabled due to cooldown period after instance
added or instance removed.
- AutoScalingTemporarilyDisabledCooldownException(ProcessingUnit, long) - Constructor for exception org.openspaces.grid.gsm.autoscaling.exceptions.AutoScalingTemporarilyDisabledCooldownException
-
- AutoScalingThresholdBreachedException - Exception in org.openspaces.grid.gsm.autoscaling.exceptions
-
Base class for high/low threshold breached exceptions
- AutoScalingThresholdBreachedException(String, ProcessingUnit, CapacityRequirements, CapacityRequirements, long, AutomaticCapacityScaleRuleConfig, boolean, String) - Constructor for exception org.openspaces.grid.gsm.autoscaling.exceptions.AutoScalingThresholdBreachedException
-
- autoStart(boolean) - Method in class org.openspaces.archive.ArchivePollingContainerConfigurer
-
- autoStart(boolean) - Method in class org.openspaces.events.asyncpolling.SimpleAsyncPollingContainerConfigurer
-
- autoStart(boolean) - Method in class org.openspaces.events.notify.SimpleNotifyContainerConfigurer
-
- autoStart(boolean) - Method in class org.openspaces.events.polling.SimplePollingContainerConfigurer
-
- AutowireArguments - Annotation Type in org.openspaces.remoting
-
An annotation enabling autowiring of arguments in a remoting service.
- AutowireArgumentsMarker - Interface in org.openspaces.remoting
-
A marker interface enabling autowiring of arguments in a remoting service.
- AutowireTask - Annotation Type in org.openspaces.core.executor
-
A marker annotation enabling a task to be autowired with resources defined within
the processing unit.
- AutowireTaskMarker - Interface in org.openspaces.core.executor
-
A marker interface enabling a task to be autowired with resources defined within
the processing unit.
- AvailabilityEvent - Class in net.jini.space
-
- AvailabilityEvent(JavaSpace, long, long, MarshalledObject, boolean) - Constructor for class net.jini.space.AvailabilityEvent
-
Create a new AvailabilityEvent
instance.
- AVAILABLE_PROTOCOLS - Static variable in class com.j_spaces.core.client.SpaceURL
-
Deprecated.
Contains a set of actual space protocols.
- average(String) - Method in class com.gigaspaces.query.aggregators.AggregationSet
-
Calculates average of path values of matching entries.
- average(GigaSpace, ISpaceQuery, String) - Static method in class org.openspaces.extensions.QueryExtension
-
- average(String) - Static method in class org.openspaces.extensions.QueryExtension
-
- AVERAGE_REQUESTS_LATENCY - Static variable in class org.openspaces.pu.container.jee.stats.WebRequestsServiceMonitors.Attributes
-
- AverageAggregator - Class in com.gigaspaces.query.aggregators
-
- AverageAggregator() - Constructor for class com.gigaspaces.query.aggregators.AverageAggregator
-
- AverageAggregator.AverageTuple - Class in com.gigaspaces.query.aggregators
-
- AverageInstancesStatisticsConfig - Class in org.openspaces.admin.pu.statistics
-
Calculates the average of all cluster instances values.
- AverageInstancesStatisticsConfig() - Constructor for class org.openspaces.admin.pu.statistics.AverageInstancesStatisticsConfig
-
- AverageInstancesStatisticsConfig(Map<String, String>) - Constructor for class org.openspaces.admin.pu.statistics.AverageInstancesStatisticsConfig
-
- AverageTimeWindowStatisticsConfig - Class in org.openspaces.admin.pu.statistics
-
- AverageTimeWindowStatisticsConfig() - Constructor for class org.openspaces.admin.pu.statistics.AverageTimeWindowStatisticsConfig
-
- AverageTimeWindowStatisticsConfig(Map<String, String>) - Constructor for class org.openspaces.admin.pu.statistics.AverageTimeWindowStatisticsConfig
-
- AverageTimeWindowStatisticsConfigurer - Class in org.openspaces.admin.pu.statistics
-
- AverageTimeWindowStatisticsConfigurer() - Constructor for class org.openspaces.admin.pu.statistics.AverageTimeWindowStatisticsConfigurer
-
- AverageTuple() - Constructor for class com.gigaspaces.query.aggregators.AverageAggregator.AverageTuple
-
- AverageTuple(Number) - Constructor for class com.gigaspaces.query.aggregators.AverageAggregator.AverageTuple
-
- avg(Value) - Method in class org.openspaces.jpa.openjpa.query.QueryExpressionFactory
-
Return the average of the given value for all matches.
- AvgReducer<T extends Number,R extends Number> - Class in org.openspaces.core.executor.support
-
A default implementation of a reducer that averages all types T
into a result R
.
- AvgReducer(Class<R>) - Constructor for class org.openspaces.core.executor.support.AvgReducer
-
- AvgTask<T extends Number,R extends Number> - Class in org.openspaces.core.executor.support
-
- AvgTask() - Constructor for class org.openspaces.core.executor.support.AvgTask
-
Here for externalizable.
- AvgTask(Class<R>, Task<T>) - Constructor for class org.openspaces.core.executor.support.AvgTask
-
Constructs a new sum distributed task that delegates the actual execution to
th provided task.
- AvgTask(Class<R>, Task<T>, AsyncResultFilter<T>) - Constructor for class org.openspaces.core.executor.support.AvgTask
-
Constructs a new sum distributed task that delegates the actual execution to
th provided task.
- awaitTermination(long, TimeUnit) - Method in class org.openspaces.core.executor.juc.DefaultTaskExecutorService
-
- BACKUP_ID_PROP - Static variable in class org.openspaces.core.cluster.ClusterInfoPropertyPlaceholderConfigurer
-
- BACKUP_POLICY_PROP - Static variable in class com.gigaspaces.logger.RollingFileHandler
-
- BackupGridServiceManagerChangedEvent - Class in org.openspaces.admin.pu.events
-
An event indicating that a backup GSM of a processing unit was either added or removed.
- BackupGridServiceManagerChangedEvent(ProcessingUnit, BackupGridServiceManagerChangedEvent.Type, GridServiceManager) - Constructor for class org.openspaces.admin.pu.events.BackupGridServiceManagerChangedEvent
-
- BackupGridServiceManagerChangedEvent.Type - Enum in org.openspaces.admin.pu.events
-
The type of the event.
- BackupGridServiceManagerChangedEventListener - Interface in org.openspaces.admin.pu.events
-
- BackupGridServiceManagerChangedEventManager - Interface in org.openspaces.admin.pu.events
-
- BackupPolicy - Interface in com.gigaspaces.logger
-
An interface for a pluggable backup policy.
- BadSqlQueryException - Exception in org.openspaces.core
-
An exception indicating wrong SQL query usage.
- BadSqlQueryException(SQLQueryException) - Constructor for exception org.openspaces.core.BadSqlQueryException
-
- BalanceGauge - Class in org.openspaces.ui
-
- BalanceGauge() - Constructor for class org.openspaces.ui.BalanceGauge
-
- BalanceGauge(String) - Constructor for class org.openspaces.ui.BalanceGauge
-
- BarLineChart - Class in org.openspaces.ui
-
- BarLineChart() - Constructor for class org.openspaces.ui.BarLineChart
-
- BarLineChart(String) - Constructor for class org.openspaces.ui.BarLineChart
-
- BasicIndex - Class in org.openspaces.core.config
-
- BasicIndex() - Constructor for class org.openspaces.core.config.BasicIndex
-
- BasicIndex(String) - Constructor for class org.openspaces.core.config.BasicIndex
-
- BasicIndex(boolean) - Constructor for class org.openspaces.core.config.BasicIndex
-
- BasicIndex(String, boolean) - Constructor for class org.openspaces.core.config.BasicIndex
-
- BasicRenewalFailureEvent - Class in com.sun.jini.lease
-
Basic implementation of RenewalFailureEvent
that
defers unmarshalling.
- BasicRenewalFailureEvent(LeaseRenewalSet, long, MarshalledObject, MarshalledInstance, MarshalledInstance) - Constructor for class com.sun.jini.lease.BasicRenewalFailureEvent
-
Simple constructor.
- BasicTypeInfo - Class in com.j_spaces.core.client
-
- BasicTypeInfo(ITypeDesc) - Constructor for class com.j_spaces.core.client.BasicTypeInfo
-
Deprecated.
- BATCH_PENDING_THRESHOLD - Static variable in class org.openspaces.events.notify.NotifyEventContainerServiceDetails.Attributes
-
- BATCH_SIZE - Static variable in class org.openspaces.events.notify.AggregatedNotifyEventContainerServiceDetails.Attributes
-
- BATCH_SIZE - Static variable in class org.openspaces.events.notify.NotifyEventContainerServiceDetails.Attributes
-
- BATCH_TIME - Static variable in class org.openspaces.events.notify.AggregatedNotifyEventContainerServiceDetails.Attributes
-
- BATCH_TIME - Static variable in class org.openspaces.events.notify.NotifyEventContainerServiceDetails.Attributes
-
- BatchOperationException - Exception in com.j_spaces.core.multiple
-
Thrown when one of the following space operations fails: readMultiple,takeMultiple,clear.
- BatchOperationException() - Constructor for exception com.j_spaces.core.multiple.BatchOperationException
-
- BatchOperationException(List, List<Throwable>) - Constructor for exception com.j_spaces.core.multiple.BatchOperationException
-
- BatchOperationException(Object[], Throwable[]) - Constructor for exception com.j_spaces.core.multiple.BatchOperationException
-
- batchPendingThreshold(Integer) - Method in class org.openspaces.events.notify.SimpleNotifyContainerConfigurer
-
- BatchRemoteEvent - Class in com.gigaspaces.events.batching
-
- BatchRemoteEvent() - Constructor for class com.gigaspaces.events.batching.BatchRemoteEvent
-
- BatchRemoteEvent(RemoteEvent[]) - Constructor for class com.gigaspaces.events.batching.BatchRemoteEvent
-
- BatchRemoteEventListener - Interface in com.gigaspaces.events.batching
-
Extends the RemoteEventListener to provide batch events.
- batchSize(int) - Method in class org.openspaces.archive.ArchivePollingContainerConfigurer
-
- batchSize(int) - Method in class org.openspaces.core.space.cache.LocalCacheSpaceConfigurer
-
Sets the cache synchronization batch size.
- batchSize(int) - Method in class org.openspaces.core.space.cache.LocalViewSpaceConfigurer
-
Sets the cache synchronization batch size.
- batchSize(Integer) - Method in class org.openspaces.events.notify.SimpleNotifyContainerConfigurer
-
- batchTime(Integer) - Method in class org.openspaces.events.notify.SimpleNotifyContainerConfigurer
-
- batchTimeout(long) - Method in class org.openspaces.core.space.cache.LocalCacheSpaceConfigurer
-
Sets the cache synchronization batch timeout (i.e. maximum time the server will batch entries before updating the client).
- batchTimeout(long) - Method in class org.openspaces.core.space.cache.LocalViewSpaceConfigurer
-
Sets the cache synchronization batch timeout (i.e. maximum time the server will batch entries before updating the client).
- Bean - Interface in org.openspaces.core.bean
-
A simple bean construct with resemblance to a Spring bean (interfaces InitializingBean,
DisposableBean).
- BEAN_LEVEL_PROPERTIES_CONTEXT - Static variable in class org.openspaces.pu.container.jee.JeeProcessingUnitContainerProvider
-
- BeanConfig - Interface in org.openspaces.admin.bean
-
A weakly typed configuration API based on String key-value pairs to configure an admin
Bean.
- BeanConfigException - Exception in org.openspaces.admin.bean
-
Base class for all admin Bean configuration exceptions.
- BeanConfigException(String) - Constructor for exception org.openspaces.admin.bean.BeanConfigException
-
- BeanConfigException(String, Throwable) - Constructor for exception org.openspaces.admin.bean.BeanConfigException
-
- BeanConfigException(RemoteException) - Constructor for exception org.openspaces.admin.bean.BeanConfigException
-
RemoteException sandwich model.
- BeanConfigManager<B extends BeanConfig> - Interface in org.openspaces.admin.bean
-
A strongly typed bean configuration manager using the strongly typed implementation of a
BeanConfig
.
- BeanConfigNotFoundException - Exception in org.openspaces.admin.bean
-
Exception indicating that a configuration for a bean by this name can't be found (has not been
added or has been removed).
- BeanConfigNotFoundException(String) - Constructor for exception org.openspaces.admin.bean.BeanConfigNotFoundException
-
- BeanConfigNotFoundException(String, Throwable) - Constructor for exception org.openspaces.admin.bean.BeanConfigNotFoundException
-
- BeanConfigPropertiesManager - Interface in org.openspaces.admin.bean
-
A weakly typed properties manager for managing admin bean configurations by their name.
- BeanConfigurationClassCastException - Exception in org.openspaces.admin.bean
-
Indicates the bean does not implement the required interfaces.
- BeanConfigurationClassCastException(String) - Constructor for exception org.openspaces.admin.bean.BeanConfigurationClassCastException
-
- BeanConfigurationException - Exception in org.openspaces.admin.bean
-
Exception indicating that a misconfiguration occurred when initializing a bean (such as failure
to set an essential property).
- BeanConfigurationException(String) - Constructor for exception org.openspaces.admin.bean.BeanConfigurationException
-
- BeanConfigurationException(String, Throwable) - Constructor for exception org.openspaces.admin.bean.BeanConfigurationException
-
- BeanConfigurer<T extends BeanConfig> - Interface in org.openspaces.admin.bean
-
A weakly-typed configuration API based on the 'builder' patterns for a more convenient
code-fluent approach to configuring a
BeanConfig
.
- BeanFactory<T extends Bean> - Interface in org.openspaces.core.bean
-
- BeanInitializationException - Exception in org.openspaces.admin.bean
-
Exception indicating that an initialization of a bean failed.
- BeanInitializationException(String) - Constructor for exception org.openspaces.admin.bean.BeanInitializationException
-
- BeanInitializationException(String, Throwable) - Constructor for exception org.openspaces.admin.bean.BeanInitializationException
-
- BeanLevelMergedPropertiesAware - Interface in org.openspaces.core.properties
-
A callback that sets the merged properties using
mergedProperties
and the bean name
that the bean implementing this interface is associated with.
- BeanLevelMergedPropertiesContext - Annotation Type in org.openspaces.core.properties
-
Allows for beans to be injected with
BeanLevelProperties
that contains the bean level
merged properties.
- BeanLevelProperties - Class in org.openspaces.core.properties
-
An extension to Spring support for properties based configuration.
- BeanLevelProperties() - Constructor for class org.openspaces.core.properties.BeanLevelProperties
-
- BeanLevelPropertiesAware - Interface in org.openspaces.core.properties
-
- BeanLevelPropertiesContext - Annotation Type in org.openspaces.core.properties
-
- BeanLevelPropertiesParser - Class in org.openspaces.pu.container.support
-
A
BeanLevelProperties
parser that parses -properties
parameter(s) and transforms it into bean level properties.
- BeanLevelPropertiesParser() - Constructor for class org.openspaces.pu.container.support.BeanLevelPropertiesParser
-
- BeanLevelPropertiesUtils - Class in org.openspaces.pu.container.support
-
- BeanLevelPropertiesUtils() - Constructor for class org.openspaces.pu.container.support.BeanLevelPropertiesUtils
-
- BeanLevelPropertyBeanPostProcessor - Class in org.openspaces.core.properties
-
- BeanLevelPropertyBeanPostProcessor(BeanLevelProperties) - Constructor for class org.openspaces.core.properties.BeanLevelPropertyBeanPostProcessor
-
Constructs a new bean level bean post processor based on the provided bean level properties.
- BeanLevelPropertyPlaceholderConfigurer - Class in org.openspaces.core.properties
-
- BeanLevelPropertyPlaceholderConfigurer(BeanLevelProperties) - Constructor for class org.openspaces.core.properties.BeanLevelPropertyPlaceholderConfigurer
-
- BeanLevelPropertyPlaceholderConfigurer(BeanLevelProperties, ClusterInfo) - Constructor for class org.openspaces.core.properties.BeanLevelPropertyPlaceholderConfigurer
-
- beanName - Variable in class org.openspaces.core.space.mode.SpaceModeContextLoader
-
- beanName - Variable in class org.openspaces.core.transaction.manager.AbstractJiniTransactionManager
-
- beanName - Variable in class org.openspaces.events.AbstractEventListenerContainer
-
- BeanPropertyMonitor - Class in org.openspaces.pu.sla.monitor
-
The bean property monitor allows to register a Spring bean reference and a proeprty name which will
be monitored at a scheduled interval by invoking it.
- BeanPropertyMonitor() - Constructor for class org.openspaces.pu.sla.monitor.BeanPropertyMonitor
-
- BeanPropertyMonitorBeanDefinitionParser - Class in org.openspaces.pu.sla.config
-
- BeanPropertyMonitorBeanDefinitionParser() - Constructor for class org.openspaces.pu.sla.config.BeanPropertyMonitorBeanDefinitionParser
-
- BeanServer<T extends Bean> - Interface in org.openspaces.core.bean
-
- BEFORE_ALL_NOTIFY_TRIGGER - Static variable in class com.j_spaces.core.filters.FilterOperationCodes
-
Before all notify trigger operation, indicates that at least one notify template is
matched to the current entry event.
- BEFORE_AUTHENTICATION - Static variable in class com.j_spaces.core.filters.FilterOperationCodes
-
Before authentication operation on a secured space.
- BEFORE_CHANGE - Static variable in class com.j_spaces.core.filters.FilterOperationCodes
-
Before change operation.
- BEFORE_CLEAN_SPACE - Static variable in class com.j_spaces.core.filters.FilterOperationCodes
-
Before clean operation.
- BEFORE_EXECUTE - Static variable in class com.j_spaces.core.filters.FilterOperationCodes
-
Before execute operation.
- BEFORE_GETADMIN - Static variable in class com.j_spaces.core.filters.FilterOperationCodes
-
Before getAdmin operation.
- BEFORE_NOTIFY - Static variable in class com.j_spaces.core.filters.FilterOperationCodes
-
Before notify register operation.
- BEFORE_NOTIFY_TRIGGER - Static variable in class com.j_spaces.core.filters.FilterOperationCodes
-
Before notify trigger operation, indicates that a matched notify template was
found to the current entry event.
- BEFORE_READ - Static variable in class com.j_spaces.core.filters.FilterOperationCodes
-
Before read operation.
- BEFORE_READ_MULTIPLE - Static variable in class com.j_spaces.core.filters.FilterOperationCodes
-
Before readMultiple operation.
- BEFORE_REMOVE - Static variable in class com.j_spaces.core.filters.FilterOperationCodes
-
Called before entry remove due to lease expression or lease cancel.
- BEFORE_TAKE - Static variable in class com.j_spaces.core.filters.FilterOperationCodes
-
Before take operation.
- BEFORE_TAKE_MULTIPLE - Static variable in class com.j_spaces.core.filters.FilterOperationCodes
-
Before takeMultiple operation.
- BEFORE_UPDATE - Static variable in class com.j_spaces.core.filters.FilterOperationCodes
-
Before update operation.
- BEFORE_WRITE - Static variable in class com.j_spaces.core.filters.FilterOperationCodes
-
Before write operation.
- BeforeAllNotifyTrigger - Annotation Type in org.openspaces.core.space.filter
-
Filter callback before all notify trigger.
- BeforeAuthentication - Annotation Type in org.openspaces.core.space.filter
-
Filter callback before authentication.
- BeforeChange - Annotation Type in org.openspaces.core.space.filter
-
Filter callback before change operation.
- BeforeCleanSpace - Annotation Type in org.openspaces.core.space.filter
-
Filter callback after clean space operation.
- beforeEntry(LogEntries, LogEntry) - Static method in class com.gigaspaces.log.LogEntryMatchers
-
- beforeEntry(LogEntries, LogEntry, boolean) - Static method in class com.gigaspaces.log.LogEntryMatchers
-
- beforeEntry(LogEntries, LogEntry, LogEntryMatcher) - Static method in class com.gigaspaces.log.LogEntryMatchers
-
- beforeEntry(LogEntries, LogEntry, boolean, LogEntryMatcher) - Static method in class com.gigaspaces.log.LogEntryMatchers
-
- BeforeEntryLogEntryMatcher - Class in com.gigaspaces.log
-
A matcher filter that will return log entries that happened till the provided log entry.
- BeforeEntryLogEntryMatcher(LogEntries, LogEntry) - Constructor for class com.gigaspaces.log.BeforeEntryLogEntryMatcher
-
- BeforeEntryLogEntryMatcher(LogEntries, LogEntry, boolean) - Constructor for class com.gigaspaces.log.BeforeEntryLogEntryMatcher
-
- BeforeEntryLogEntryMatcher(LogEntries, LogEntry, LogEntryMatcher) - Constructor for class com.gigaspaces.log.BeforeEntryLogEntryMatcher
-
- BeforeEntryLogEntryMatcher(LogEntries, LogEntry, boolean, LogEntryMatcher) - Constructor for class com.gigaspaces.log.BeforeEntryLogEntryMatcher
-
- BeforeExecute - Annotation Type in org.openspaces.core.space.filter
-
Filter callback before execute operation
- BeforeNotify - Annotation Type in org.openspaces.core.space.filter
-
Filter callback before notify operation.
- BeforeNotifyTrigger - Annotation Type in org.openspaces.core.space.filter
-
Filter callback before notify trigger.
- BeforeRead - Annotation Type in org.openspaces.core.space.filter
-
Filter callback before read operation.
- BeforeReadMultiple - Annotation Type in org.openspaces.core.space.filter
-
Filter callback before read multiple operation.
- BeforeRemoveByLease - Annotation Type in org.openspaces.core.space.filter
-
Filter callback before an entry was removed due to lease expression or lease cancel.
- BeforeSpaceModeChangeEvent - Class in org.openspaces.core.space.mode
-
A Space mode event that is raised before the space mode is changed to the space mode reflected in
this event.
- BeforeSpaceModeChangeEvent(IJSpace, SpaceMode) - Constructor for class org.openspaces.core.space.mode.BeforeSpaceModeChangeEvent
-
Creates a new before space mode event.
- BeforeTake - Annotation Type in org.openspaces.core.space.filter
-
Filter callback before take operation.
- BeforeTakeMultiple - Annotation Type in org.openspaces.core.space.filter
-
Filter callback before take multiple operation.
- beforeTime(long) - Static method in class com.gigaspaces.log.LogEntryMatchers
-
- beforeTime(long, boolean) - Static method in class com.gigaspaces.log.LogEntryMatchers
-
- beforeTime(long, boolean, LogEntryMatcher) - Static method in class com.gigaspaces.log.LogEntryMatchers
-
- beforeTime(long, LogEntryMatcher) - Static method in class com.gigaspaces.log.LogEntryMatchers
-
- beforeTime(String) - Static method in class com.gigaspaces.log.LogEntryMatchers
-
- beforeTime(String, boolean) - Static method in class com.gigaspaces.log.LogEntryMatchers
-
- beforeTime(String, boolean, LogEntryMatcher) - Static method in class com.gigaspaces.log.LogEntryMatchers
-
- beforeTime(String, LogEntryMatcher) - Static method in class com.gigaspaces.log.LogEntryMatchers
-
- beforeTime(String, String) - Static method in class com.gigaspaces.log.LogEntryMatchers
-
- beforeTime(String, String, boolean) - Static method in class com.gigaspaces.log.LogEntryMatchers
-
- beforeTime(String, String, boolean, LogEntryMatcher) - Static method in class com.gigaspaces.log.LogEntryMatchers
-
- beforeTime(String, String, LogEntryMatcher) - Static method in class com.gigaspaces.log.LogEntryMatchers
-
- BeforeTimeLogEntryMatcher - Class in com.gigaspaces.log
-
A matcher filter that will match only on log entries that occurred before the specified time.
- BeforeTimeLogEntryMatcher(String) - Constructor for class com.gigaspaces.log.BeforeTimeLogEntryMatcher
-
- BeforeTimeLogEntryMatcher(String, boolean) - Constructor for class com.gigaspaces.log.BeforeTimeLogEntryMatcher
-
- BeforeTimeLogEntryMatcher(String, String) - Constructor for class com.gigaspaces.log.BeforeTimeLogEntryMatcher
-
- BeforeTimeLogEntryMatcher(String, String, boolean) - Constructor for class com.gigaspaces.log.BeforeTimeLogEntryMatcher
-
- BeforeTimeLogEntryMatcher(String, boolean, LogEntryMatcher) - Constructor for class com.gigaspaces.log.BeforeTimeLogEntryMatcher
-
- BeforeTimeLogEntryMatcher(String, LogEntryMatcher) - Constructor for class com.gigaspaces.log.BeforeTimeLogEntryMatcher
-
- BeforeTimeLogEntryMatcher(String, String, LogEntryMatcher) - Constructor for class com.gigaspaces.log.BeforeTimeLogEntryMatcher
-
- BeforeTimeLogEntryMatcher(String, String, boolean, LogEntryMatcher) - Constructor for class com.gigaspaces.log.BeforeTimeLogEntryMatcher
-
- BeforeTimeLogEntryMatcher(long) - Constructor for class com.gigaspaces.log.BeforeTimeLogEntryMatcher
-
- BeforeTimeLogEntryMatcher(long, LogEntryMatcher) - Constructor for class com.gigaspaces.log.BeforeTimeLogEntryMatcher
-
- BeforeTimeLogEntryMatcher(long, boolean) - Constructor for class com.gigaspaces.log.BeforeTimeLogEntryMatcher
-
- BeforeTimeLogEntryMatcher(long, boolean, LogEntryMatcher) - Constructor for class com.gigaspaces.log.BeforeTimeLogEntryMatcher
-
- beforeUndeployedProcessingUnit(ProcessingUnit) - Method in interface org.openspaces.grid.gsm.machines.MachinesSlaEnforcementEndpoint
-
Marks that the processing unit is being undeployed.
- beforeUndeployProcessingUnit(ProcessingUnit) - Method in class org.openspaces.grid.gsm.machines.MachinesSlaEnforcementState
-
- BeforeUpdate - Annotation Type in org.openspaces.core.space.filter
-
Filter callback before update operation.
- BeforeWrite - Annotation Type in org.openspaces.core.space.filter
-
Filter callback before write operation.
- begin() - Method in class org.openspaces.jpa.StoreManager
-
- beginHandshake() - Method in interface com.gigaspaces.lrmi.nio.filters.IOBlockFilter
-
Initiation of handshake process.
- beginHandshake() - Method in class com.gigaspaces.lrmi.nio.filters.IOSSLFilter
-
- beginOptimistic() - Method in class org.openspaces.jpa.StoreManager
-
- BigDecimalHelper - Class in org.openspaces.core.util.numbers
-
- BigDecimalHelper() - Constructor for class org.openspaces.core.util.numbers.BigDecimalHelper
-
- BigIntegerHelper - Class in org.openspaces.core.util.numbers
-
- BigIntegerHelper() - Constructor for class org.openspaces.core.util.numbers.BigIntegerHelper
-
- BinaryExpression - Class in org.openspaces.jpa.openjpa.query
-
Represents a binary expression.
- BinaryExpression(Value, Value, BinaryExpression.ExpressionType) - Constructor for class org.openspaces.jpa.openjpa.query.BinaryExpression
-
- BinaryExpression.ExpressionType - Enum in org.openspaces.jpa.openjpa.query
-
- bindExistingTransaction(Transaction) - Static method in class org.openspaces.core.transaction.manager.ExistingJiniTransactionManager
-
- bindExistingTransaction(Transaction, boolean, boolean) - Static method in class org.openspaces.core.transaction.manager.ExistingJiniTransactionManager
-
Binds the provided Jini
Transaction
, which means that any operation under
the current thread by
GigaSpace
will be performed under it.
- bindExistingTransaction(ExisitingJiniTransactionHolder) - Static method in class org.openspaces.core.transaction.manager.ExistingJiniTransactionManager
-
Binds the provided jiniHolder which means that any operation under
the current thread by
GigaSpace
will be performed under it.
- bindKeyVariable(Value, Value) - Method in class org.openspaces.jpa.openjpa.query.QueryExpressionFactory
-
Bind the given variable to the key set of the given map value.
- bindValueVariable(Value, Value) - Method in class org.openspaces.jpa.openjpa.query.QueryExpressionFactory
-
Bind the given variable to the value set of the given map value.
- bindVariable(Value, Value) - Method in class org.openspaces.jpa.openjpa.query.QueryExpressionFactory
-
Bind the given variable to the given collection value.
- BindVariableExpression - Class in org.openspaces.jpa.openjpa.query
-
Represents a JPQL bound variable expression node.
- BindVariableExpression() - Constructor for class org.openspaces.jpa.openjpa.query.BindVariableExpression
-
- BinPackingSolver - Class in org.openspaces.grid.gsm.machines
-
A greedy 2D bin packing algorithm.
- BinPackingSolver() - Constructor for class org.openspaces.grid.gsm.machines.BinPackingSolver
-
- BlobStoreDataCachePolicy - Class in org.openspaces.core.space
-
A cache policy that stores data offheap and indexes onheap.
- BlobStoreDataCachePolicy() - Constructor for class org.openspaces.core.space.BlobStoreDataCachePolicy
-
- blobStoreDataPolicy(BlobStoreDataPolicyFactoryBean) - Method in class org.openspaces.core.space.EmbeddedSpaceConfigurer
-
- BlobStoreDataPolicyBeanDefinitionParser - Class in org.openspaces.core.config
-
- BlobStoreDataPolicyBeanDefinitionParser() - Constructor for class org.openspaces.core.config.BlobStoreDataPolicyBeanDefinitionParser
-
- BlobStoreDataPolicyFactoryBean - Class in org.openspaces.core.config
-
- BlobStoreDataPolicyFactoryBean() - Constructor for class org.openspaces.core.config.BlobStoreDataPolicyFactoryBean
-
- BlobStoreException - Exception in com.gigaspaces.server.blobstore
-
Exception class that is thrown when any kind of BlobStore related exception happens.
- BlobStoreException(String) - Constructor for exception com.gigaspaces.server.blobstore.BlobStoreException
-
- BlobStoreException(Throwable) - Constructor for exception com.gigaspaces.server.blobstore.BlobStoreException
-
- BlobStoreException(String, Throwable) - Constructor for exception com.gigaspaces.server.blobstore.BlobStoreException
-
- BlobStoreMemoryMonitorWrapper - Class in com.j_spaces.core.cache.offHeap
-
Wrapper for BlobStoreMemoryMonitor
- BlobStoreMemoryMonitorWrapper(BlobStoreMemoryMonitor, CacheManager, String, Properties) - Constructor for class com.j_spaces.core.cache.offHeap.BlobStoreMemoryMonitorWrapper
-
- BlobStoreObjectType - Enum in com.gigaspaces.server.blobstore
-
- BLOCK_OPERATIONS_MODE - Static variable in class com.j_spaces.core.cluster.ReplicationPolicy
-
- BLOCKING_CLIENT_CONNECT - Static variable in class com.j_spaces.kernel.SystemProperties
-
- BLOCKING_CLIENT_CONNECT_DEFAULT - Static variable in class com.j_spaces.kernel.SystemProperties
-
- blockingAfterPropertiesSet() - Method in interface org.openspaces.grid.gsm.machines.plugins.ElasticMachineProvisioning
-
performs blocking initialization of the external api components.
- BlockingAfterPropertiesSetFailedException - Exception in org.openspaces.grid.gsm.sla.exceptions
-
Exception that indicates the cloud driver failed to initialize.
- BlockingAfterPropertiesSetFailedException(ProcessingUnit, Throwable) - Constructor for exception org.openspaces.grid.gsm.sla.exceptions.BlockingAfterPropertiesSetFailedException
-
- BlockingAfterPropertiesSetInProgressException - Exception in org.openspaces.grid.gsm.sla.exceptions
-
Exception that indicates the cloud driver has not completed initialization yet.
- BlockingAfterPropertiesSetInProgressException(ProcessingUnit) - Constructor for exception org.openspaces.grid.gsm.sla.exceptions.BlockingAfterPropertiesSetInProgressException
-
- BlockingQueueCompiledScriptPool - Class in org.openspaces.remoting.scripting.cache
-
- BlockingQueueCompiledScriptPool(int) - Constructor for class org.openspaces.remoting.scripting.cache.BlockingQueueCompiledScriptPool
-
- BlockingQueueCompiledScriptPoolFactory - Class in org.openspaces.remoting.scripting.cache
-
- BlockingQueueCompiledScriptPoolFactory() - Constructor for class org.openspaces.remoting.scripting.cache.BlockingQueueCompiledScriptPoolFactory
-
Constructs a new blocking queue compiled script pool with default size of 5
.
- BlockingQueueCompiledScriptPoolFactory(int) - Constructor for class org.openspaces.remoting.scripting.cache.BlockingQueueCompiledScriptPoolFactory
-
Constructs a new blocking queue compiled script pool with its size as a parameter.
- bootstrap(Admin, String, String, long, TimeUnit) - Static method in class org.openspaces.core.gateway.BootstrapUtility
-
- bootstrap(String[]) - Method in class org.openspaces.grid.esm.ESMImpl
-
- bootstrapFromGatewayAndWait() - Method in interface org.openspaces.admin.gateway.GatewaySinkSource
-
Bootstrap the local
Space
which is associated to this sink from a remote space.
- bootstrapFromGatewayAndWait(long, TimeUnit) - Method in interface org.openspaces.admin.gateway.GatewaySinkSource
-
Bootstrap the local
Space
which is associated to this sink from a remote space.
- BootstrapResult - Interface in org.openspaces.admin.gateway
-
A result of a bootstrap
- BootstrapUtility - Class in org.openspaces.core.gateway
-
- BootstrapUtility() - Constructor for class org.openspaces.core.gateway.BootstrapUtility
-
Deprecated.
- BootstrapWebApplicationContextListener - Class in org.openspaces.pu.container.jee.context
-
Bootstap servlet context listener allowing to get the
ClusterInfo
,
BeanLevelProperties
, and handle an optional pu.xml file within
META-INF/spring by loading it.
- BootstrapWebApplicationContextListener() - Constructor for class org.openspaces.pu.container.jee.context.BootstrapWebApplicationContextListener
-
- BOUNDED_QUERY_CACHE_SIZE - Static variable in class com.j_spaces.kernel.SystemProperties
-
The bounded query cache size
- BOUNDED_QUERY_CACHE_SIZE_DEFAULT - Static variable in class com.j_spaces.kernel.SystemProperties
-
The default bounded query cache size
- box(boolean) - Static method in class org.openspaces.core.util.Boxer
-
- box(byte) - Static method in class org.openspaces.core.util.Boxer
-
- box(char) - Static method in class org.openspaces.core.util.Boxer
-
- box(short) - Static method in class org.openspaces.core.util.Boxer
-
- box(int) - Static method in class org.openspaces.core.util.Boxer
-
- box(long) - Static method in class org.openspaces.core.util.Boxer
-
- box(float) - Static method in class org.openspaces.core.util.Boxer
-
- box(double) - Static method in class org.openspaces.core.util.Boxer
-
- box(Object) - Static method in class org.openspaces.core.util.Boxer
-
- Boxer - Class in org.openspaces.core.util
-
Boxing methods used by the Scala macro API
- Boxer() - Constructor for class org.openspaces.core.util.Boxer
-
- broadcast(boolean) - Method in class org.openspaces.remoting.ExecutorRemotingProxyConfigurer
-
- broadcast(RemoteResultReducer<X, Y>) - Method in class org.openspaces.remoting.ExecutorRemotingProxyConfigurer
-
- broadcast(RemoteResultReducer<T, Y>) - Method in class org.openspaces.remoting.scripting.ResourceLazyLoadingScript
-
Broadcast the execution of this script over all active partitions.
- broadcast(RemoteResultReducer<T, Y>) - Method in class org.openspaces.remoting.scripting.StaticScript
-
Broadcast the execution of this script over all active partitions.
- BroadcastIndicator - Interface in org.openspaces.remoting
-
An interface optionally implemented by the first parameter in a remote invocation
to indicate if broadcasting is enabled or not.
- Broker - Class in org.openspaces.jpa.openjpa
-
GigaSpaces OpenJPA's Broker implementation.
- Broker() - Constructor for class org.openspaces.jpa.openjpa.Broker
-
- BrokerFactory - Class in org.openspaces.jpa
-
GigaSpaces OpenJPA BrokerFactory implementation.
- BrokerFactory(OpenJPAConfiguration) - Constructor for class org.openspaces.jpa.BrokerFactory
-
- BROWSER_LAF_IS_CROSS_PLATFORM - Static variable in class com.j_spaces.kernel.SystemProperties
-
- bufferSize(int) - Method in class org.openspaces.core.IteratorBuilder
-
- BufferUtils - Class in org.openspaces.memcached.util
-
- BufferUtils() - Constructor for class org.openspaces.memcached.util.BufferUtils
-
- build() - Method in class org.openspaces.jpa.openjpa.query.executor.JpaJdbcQueryExecutor
-
- buildHashToMethodLookupForInterface(Class, boolean) - Static method in class org.openspaces.remoting.RemotingUtils
-
- buildInvocableServices() - Method in class org.openspaces.pu.container.servicegrid.PUServiceBeanImpl
-
- buildInvocation(String, String, Object[]) - Method in class org.openspaces.remoting.EventDrivenSpaceRemotingEntry
-
Deprecated.
- buildInvocation(String, String, RemotingUtils.MethodHash, Object[]) - Method in class org.openspaces.remoting.HashedEventDrivenSpaceRemotingEntry
-
Deprecated.
- buildInvocation(String, String, RemotingUtils.MethodHash, Object[]) - Method in interface org.openspaces.remoting.HashedSpaceRemotingEntry
-
- buildMethodToHashLookupForInterface(Class, String) - Static method in class org.openspaces.remoting.RemotingUtils
-
- buildOperationalString(String[]) - Method in class org.openspaces.pu.container.servicegrid.deploy.Deploy
-
- buildOperationalString(String[]) - Method in class org.openspaces.pu.container.servicegrid.deploy.MemcachedDeploy
-
- buildOperationalString(String[]) - Method in class org.openspaces.pu.container.servicegrid.deploy.SpaceDeploy
-
- buildResult(Throwable) - Method in class org.openspaces.remoting.EventDrivenSpaceRemotingEntry
-
Deprecated.
- buildResult(Object) - Method in class org.openspaces.remoting.EventDrivenSpaceRemotingEntry
-
Deprecated.
- buildResult(Throwable) - Method in class org.openspaces.remoting.HashedEventDrivenSpaceRemotingEntry
-
Deprecated.
- buildResult(Object) - Method in class org.openspaces.remoting.HashedEventDrivenSpaceRemotingEntry
-
Deprecated.
- buildResult(Object) - Method in interface org.openspaces.remoting.SpaceRemotingEntry
-
- buildResult(Throwable) - Method in interface org.openspaces.remoting.SpaceRemotingEntry
-
- buildResultTemplate() - Method in class org.openspaces.remoting.EventDrivenSpaceRemotingEntry
-
Deprecated.
- buildResultTemplate() - Method in class org.openspaces.remoting.HashedEventDrivenSpaceRemotingEntry
-
Deprecated.
- buildResultTemplate() - Method in interface org.openspaces.remoting.SpaceRemotingEntry
-
- BulkDataPersister - Interface in com.gigaspaces.datasource
-
- BulkDataPersisterContext - Class in com.j_spaces.sadapter.datasource
-
- BulkDataPersisterContext(TransactionParticipantDataImpl, String) - Constructor for class com.j_spaces.sadapter.datasource.BulkDataPersisterContext
-
- BulkDataPersisterExceptionHandler - Class in org.openspaces.persistency.patterns
-
- BulkDataPersisterExceptionHandler(ManagedDataSource, ExceptionHandler) - Constructor for class org.openspaces.persistency.patterns.BulkDataPersisterExceptionHandler
-
Deprecated.
- BulkDataPersisterSplitter - Class in org.openspaces.persistency.patterns
-
- BulkDataPersisterSplitter(ManagedDataSourceEntriesProvider[]) - Constructor for class org.openspaces.persistency.patterns.BulkDataPersisterSplitter
-
Deprecated.
- BulkItem - Interface in com.gigaspaces.datasource
-
- bytes - Variable in class org.openspaces.memcached.Key
-
- bytesNeeded - Variable in class org.openspaces.memcached.protocol.SessionStatus
-
- Cache - Interface in com.j_spaces.javax.cache
-
Deprecated.
- cache(boolean) - Method in class org.openspaces.remoting.scripting.ResourceLazyLoadingScript
-
Should this script be cached or not.
- cache(boolean) - Method in class org.openspaces.remoting.scripting.StaticScript
-
Should this script be cached or not.
- CACHE_CONTEXT_CLOSE_MAX_WAIT - Static variable in class com.j_spaces.kernel.SystemProperties
-
- CACHE_CONTEXT_CLOSE_MAX_WAIT_DEFAULT - Static variable in class com.j_spaces.kernel.SystemProperties
-
- CACHE_MANAGER_EMBEDDED_INDEX_PROTECTION - Static variable in class com.j_spaces.kernel.SystemProperties
-
protect embedded indexes by clonning values.
- CACHE_MANAGER_EMBEDDED_INDEX_PROTECTION_DEFAULT - Static variable in class com.j_spaces.kernel.SystemProperties
-
- CACHE_MANAGER_HASHMAP_SEGMENTS - Static variable in class com.j_spaces.kernel.SystemProperties
-
Number of segments used in creating CHM for entries- uids, indices, off-heap internalcache .
- CACHE_MANAGER_HASHMAP_SEGMENTS_DEFAULT - Static variable in class com.j_spaces.kernel.SystemProperties
-
Default Number of segments used in creating CHM for entries- uids, indices, off-heap internalcache.
- CACHE_MANAGER_LOG_RECOVER_PROCESS - Static variable in class com.j_spaces.kernel.SystemProperties
-
Specified whether to disable database recovery logging, default is true.
- CACHE_MANAGER_RECOVER_INTERVAL_DEFAULT - Static variable in class com.j_spaces.kernel.SystemProperties
-
- CACHE_MANAGER_RECOVER_INTERVAL_LOG - Static variable in class com.j_spaces.kernel.SystemProperties
-
Interval in miliseconds to log database recovery process, default is 10 seconds.
- CACHE_STUCK_2PC_BASIC_TIME - Static variable in class com.j_spaces.kernel.SystemProperties
-
- CACHE_STUCK_2PC_BASIC_TIME_DEFAULT - Static variable in class com.j_spaces.kernel.SystemProperties
-
- CACHE_STUCK_2PC_EXTENTION_TIME - Static variable in class com.j_spaces.kernel.SystemProperties
-
- CACHE_STUCK_2PC_EXTENTION_TIME_DEFAULT - Static variable in class com.j_spaces.kernel.SystemProperties
-
- CACHE_URL_PROP - Static variable in class com.j_spaces.core.client.SpaceURL
-
Deprecated.
This system property can be used when space started using ServiceStarter
.
- CacheEntry - Interface in com.j_spaces.javax.cache
-
Deprecated.
- CacheException - Exception in com.j_spaces.core.client
-
Exception class that is thrown when any kind of Cache related
exception happens.
- CacheException(String) - Constructor for exception com.j_spaces.core.client.CacheException
-
Constructs a new cache exception with the specified detail message.
- CacheException(String, Throwable) - Constructor for exception com.j_spaces.core.client.CacheException
-
Constructs a new cache exception with the specified detail message and
cause.
- CacheException - Exception in com.j_spaces.javax.cache
-
Deprecated.
- CacheException() - Constructor for exception com.j_spaces.javax.cache.CacheException
-
Deprecated.
Constructs a new CacheException.
- CacheException(String) - Constructor for exception com.j_spaces.javax.cache.CacheException
-
Deprecated.
Constructs a new CacheException with a message string.
- CacheException(String, Throwable) - Constructor for exception com.j_spaces.javax.cache.CacheException
-
Deprecated.
Constructs a CacheException with a message string, and a cause.
- CacheListener - Interface in com.j_spaces.javax.cache
-
Deprecated.
- CachePolicy - Interface in org.openspaces.core.space
-
A generic interface for cache policies.
- cachePolicy(CachePolicy) - Method in class org.openspaces.core.space.EmbeddedSpaceConfigurer
-
- cachePolicy(CachePolicy) - Method in class org.openspaces.core.space.UrlSpaceConfigurer
-
- CacheTimeoutException - Exception in com.j_spaces.core.client
-
This Exception thrown when the entry is locked
under another transaction and operation timeout expired.
- CacheTimeoutException(Object) - Constructor for exception com.j_spaces.core.client.CacheTimeoutException
-
- calc(StatisticsObjectList) - Method in class org.openspaces.admin.pu.statistics.AverageInstancesStatisticsConfig
-
- calc(StatisticsObjectList) - Method in class org.openspaces.admin.pu.statistics.AverageTimeWindowStatisticsConfig
-
- calc(StatisticsObjectList) - Method in class org.openspaces.admin.pu.statistics.CpuPercentageTimeWindowStatisticsConfig
-
- calc(StatisticsObjectList) - Method in class org.openspaces.admin.pu.statistics.LastSampleTimeWindowStatisticsConfig
-
- calc(StatisticsObjectList) - Method in class org.openspaces.admin.pu.statistics.MaximumInstancesStatisticsConfig
-
- calc(StatisticsObjectList) - Method in class org.openspaces.admin.pu.statistics.MaximumTimeWindowStatisticsConfig
-
- calc(StatisticsObjectList) - Method in class org.openspaces.admin.pu.statistics.MinimumInstancesStatisticsConfig
-
- calc(StatisticsObjectList) - Method in class org.openspaces.admin.pu.statistics.MinimumTimeWindowStatisticsConfig
-
- calc(StatisticsObjectList) - Method in class org.openspaces.admin.pu.statistics.PercentileInstancesStatisticsConfig
-
- calc(StatisticsObjectList) - Method in class org.openspaces.admin.pu.statistics.PercentileTimeWindowStatisticsConfig
-
- calc(StatisticsObjectList) - Method in class org.openspaces.admin.pu.statistics.ThroughputTimeWindowStatisticsConfig
-
- calcNumberOfPartitionsFromCpuRequirements(Admin) - Method in class org.openspaces.admin.pu.elastic.config.ElasticStatefulProcessingUnitConfig
-
- calcNumberOfPartitionsFromMemoryRequirements() - Method in class org.openspaces.admin.pu.elastic.config.ElasticStatefulProcessingUnitConfig
-
- calcRoundedTotalMemoryInMB() - Method in class org.openspaces.grid.gsm.strategy.AbstractCapacityScaleStrategyBean
-
- calculatePercent(long, long) - Method in class com.gigaspaces.metrics.Gauge
-
- CallableDistributedTaskAdapter<T extends Serializable,R> - Class in org.openspaces.core.executor.juc
-
An adapter allowing to execute a
Callable
in a distributed fashion.
- CallableDistributedTaskAdapter() - Constructor for class org.openspaces.core.executor.juc.CallableDistributedTaskAdapter
-
Here just for externalizable.
- CallableDistributedTaskAdapter(Callable<T>) - Constructor for class org.openspaces.core.executor.juc.CallableDistributedTaskAdapter
-
Constructs a new callable distributed task adapter.
- CallableDistributedTaskAdapter(Callable<T>, AsyncResultsReducer<T, R>) - Constructor for class org.openspaces.core.executor.juc.CallableDistributedTaskAdapter
-
Constructs a new callable distributed task adapter with a separate reducer.
- CallableDistributedTaskAdapter(Callable<T>, AsyncResultsReducer<T, R>, AsyncResultFilter<T>) - Constructor for class org.openspaces.core.executor.juc.CallableDistributedTaskAdapter
-
Constructs a new callable distributed task adapter with a separate reducer and filter.
- CallableTaskAdapter<T extends Serializable> - Class in org.openspaces.core.executor.juc
-
An adapter allowing to execute a
Callable
using Space task executors.
- CallableTaskAdapter() - Constructor for class org.openspaces.core.executor.juc.CallableTaskAdapter
-
Here just for externalizable.
- CallableTaskAdapter(Callable<T>) - Constructor for class org.openspaces.core.executor.juc.CallableTaskAdapter
-
Constructs a new callable task adapter with the callable to call
.
- canBatch(Lease) - Method in interface net.jini.core.lease.Lease
-
Returns a boolean indicating whether or not the lease given as a
parameter can be batched (placed in the same LeaseMap) with the
current lease.
- cancel() - Method in class com.j_spaces.core.client.GSIterator
-
Used by the iterator holder to indicate that there is no further interest
in this iterator.
- cancel(Uuid) - Method in interface com.sun.jini.mahalo.LeaseExpirationMgr.Expirer
-
Called by a LeaseExpirationMgr when it needs to expire a
resource.
- cancel(Uuid) - Method in class com.sun.jini.mahalo.TxnManagerImpl
-
Cancels the lease on a Transaction
.
- cancel() - Method in interface net.jini.core.lease.Lease
-
Used by the lease holder to indicate that it is no longer interested
in the resource or information held by the lease.
- cancel(Lease) - Method in class net.jini.lease.LeaseRenewalManager
-
Removes a given lease from the managed set, and cancels it.
- cancel(boolean) - Method in class org.openspaces.core.executor.support.AsyncResultFuture
-
- cancel(boolean) - Method in class org.openspaces.remoting.EventDrivenRemoteFuture
-
Attempts to cancel execution of this task.
- CANCEL_DUPLICATE_PACKET_FILTER - Static variable in class com.j_spaces.kernel.SystemProperties
-
disables the duplication filtering mechanism used to avoid double processing of packets
after recovery.
- CANCEL_DUPLICATE_PACKET_FILTER_DEFAULT - Static variable in class com.j_spaces.kernel.SystemProperties
-
- cancelAll(Uuid[]) - Method in class com.sun.jini.mahalo.TxnManagerImpl
-
Bulk cancel of leases on Transaction
s.
- cancelAll() - Method in interface net.jini.core.lease.LeaseMap
-
Cancels all leases in the LeaseMap.
- canContainKey(Object) - Method in interface net.jini.core.lease.LeaseMap
-
Returns true if the given object is a Lease which can be renewed
and cancelled in a batch with other leases in the map.
- canDecrementInstance() - Method in interface org.openspaces.admin.pu.ProcessingUnit
-
- canIncrementInstance() - Method in interface org.openspaces.admin.pu.ProcessingUnit
-
- CannotAbortException - Exception in net.jini.core.transaction
-
Exception thrown when a transaction cannot abort because it has already
already decided to commit.
- CannotAbortException(String) - Constructor for exception net.jini.core.transaction.CannotAbortException
-
Constructs an instance with a detail message.
- CannotAbortException() - Constructor for exception net.jini.core.transaction.CannotAbortException
-
Constructs an instance with no detail message.
- CannotCloseContainerException - Exception in org.openspaces.pu.container
-
Exception indicating failure to close a container.
- CannotCloseContainerException(String) - Constructor for exception org.openspaces.pu.container.CannotCloseContainerException
-
- CannotCloseContainerException(String, Throwable) - Constructor for exception org.openspaces.pu.container.CannotCloseContainerException
-
- CannotCloseSpaceException - Exception in org.openspaces.core.space
-
Happens when
IJSpace
can not be closed.
- CannotCloseSpaceException(String, Throwable) - Constructor for exception org.openspaces.core.space.CannotCloseSpaceException
-
- CannotCommitException - Exception in net.jini.core.transaction
-
Exception thrown when a transaction cannot commit because it has already
aborted or must now be aborted.
- CannotCommitException(String) - Constructor for exception net.jini.core.transaction.CannotCommitException
-
Constructs an instance with a detail message.
- CannotCommitException(String, Throwable) - Constructor for exception net.jini.core.transaction.CannotCommitException
-
- CannotCommitException() - Constructor for exception net.jini.core.transaction.CannotCommitException
-
Constructs an instance with no detail message.
- CannotCreateContainerException - Exception in org.openspaces.pu.container
-
Exception indicating failure to create a container.
- CannotCreateContainerException(String) - Constructor for exception org.openspaces.pu.container.CannotCreateContainerException
-
- CannotCreateContainerException(String, Throwable) - Constructor for exception org.openspaces.pu.container.CannotCreateContainerException
-
- CannotCreateNotifySessionException - Exception in org.openspaces.events.notify
-
A failure to create a notify session.
- CannotCreateNotifySessionException(String, EventSessionConfig) - Constructor for exception org.openspaces.events.notify.CannotCreateNotifySessionException
-
- CannotCreateNotifySessionException(String, EventSessionConfig, Throwable) - Constructor for exception org.openspaces.events.notify.CannotCreateNotifySessionException
-
- CannotCreateSpaceException - Exception in org.openspaces.core.space
-
Happens when
IJSpace
can not be created.
- CannotCreateSpaceException(String, Throwable) - Constructor for exception org.openspaces.core.space.CannotCreateSpaceException
-
- CannotDetermineIfNeedToStartMoreMachinesException - Exception in org.openspaces.grid.gsm.machines.exceptions
-
- CannotDetermineIfNeedToStartMoreMachinesException(ProcessingUnit, int) - Constructor for exception org.openspaces.grid.gsm.machines.exceptions.CannotDetermineIfNeedToStartMoreMachinesException
-
- CannotDiscoverEsmException - Exception in org.openspaces.grid.gsm.sla.exceptions
-
This exception is monitored by the GSA, and causes the ESM process to restart itself.
- CannotDiscoverEsmException(String) - Constructor for exception org.openspaces.grid.gsm.sla.exceptions.CannotDiscoverEsmException
-
- CannotFindSpaceException - Exception in org.openspaces.core.space
-
Happens when
IJSpace
can not be found (when using jini/rmi protocol).
- CannotFindSpaceException(String, Throwable) - Constructor for exception org.openspaces.core.space.CannotFindSpaceException
-
- CannotJoinException - Exception in net.jini.core.transaction
-
Exception thrown when a transaction cannot be joined because it is no
longer active.
- CannotJoinException(String) - Constructor for exception net.jini.core.transaction.CannotJoinException
-
Constructs an instance with a detail message.
- CannotJoinException() - Constructor for exception net.jini.core.transaction.CannotJoinException
-
Constructs an instance with no detail message.
- CannotNestException - Exception in net.jini.core.transaction
-
Exception thrown when an object does not support nested transactions.
- CannotNestException(String) - Constructor for exception net.jini.core.transaction.CannotNestException
-
Constructs an instance with a detail message.
- CannotNestException() - Constructor for exception net.jini.core.transaction.CannotNestException
-
Constructs an instance with no detail message.
- CapacityMachinesSlaPolicy - Class in org.openspaces.grid.gsm.machines
-
- CapacityMachinesSlaPolicy() - Constructor for class org.openspaces.grid.gsm.machines.CapacityMachinesSlaPolicy
-
- capacityPlanningCompletedEvent() - Method in class org.openspaces.grid.gsm.strategy.AbstractScaleStrategyBean
-
- capacityPlanningCompletedEvent(ZonesConfig) - Method in class org.openspaces.grid.gsm.strategy.AbstractScaleStrategyBean
-
- capacityPlanningInProgressEvent(AutoScalingSlaEnforcementInProgressException, ZonesConfig) - Method in class org.openspaces.grid.gsm.strategy.AbstractScaleStrategyBean
-
- capacityPlanningInProgressEvent(ElasticStatelessProcessingUnitPlannedNumberOfInstancesChangedEvent) - Method in class org.openspaces.grid.gsm.strategy.AbstractScaleStrategyBean
-
- CapacityRequirement - Interface in org.openspaces.grid.gsm.capacity
-
A machine capacity requirement for the
ElasticMachineProvisioning
Each implementation must have a public default constructor that creates a zero capacity requirement object.
- CapacityRequirements - Class in org.openspaces.grid.gsm.capacity
-
- CapacityRequirements(CapacityRequirement...) - Constructor for class org.openspaces.grid.gsm.capacity.CapacityRequirements
-
- CapacityRequirementsConfig - Class in org.openspaces.admin.pu.elastic.config
-
A config object for configuring capacity requirements
- CapacityRequirementsConfig() - Constructor for class org.openspaces.admin.pu.elastic.config.CapacityRequirementsConfig
-
Default constructor
- CapacityRequirementsConfig(Map<String, String>) - Constructor for class org.openspaces.admin.pu.elastic.config.CapacityRequirementsConfig
-
- CapacityRequirementsConfig(CapacityRequirements) - Constructor for class org.openspaces.admin.pu.elastic.config.CapacityRequirementsConfig
-
- CapacityRequirementsConfigurer - Class in org.openspaces.admin.pu.elastic.config
-
- CapacityRequirementsConfigurer() - Constructor for class org.openspaces.admin.pu.elastic.config.CapacityRequirementsConfigurer
-
- CapacityRequirementsPerAgent - Class in org.openspaces.grid.gsm.capacity
-
- CapacityRequirementsPerAgent() - Constructor for class org.openspaces.grid.gsm.capacity.CapacityRequirementsPerAgent
-
- CapacityRequirementsPerZones - Class in org.openspaces.grid.gsm.capacity
-
- CapacityRequirementsPerZones() - Constructor for class org.openspaces.grid.gsm.capacity.CapacityRequirementsPerZones
-
- CapacityRequirementsPerZonesConfig - Class in org.openspaces.admin.pu.elastic.config
-
A key/value alternative to CapacityRequirementsPerZone
- CapacityRequirementsPerZonesConfig() - Constructor for class org.openspaces.admin.pu.elastic.config.CapacityRequirementsPerZonesConfig
-
- CapacityRequirementsPerZonesConfig(CapacityRequirementsPerZones) - Constructor for class org.openspaces.admin.pu.elastic.config.CapacityRequirementsPerZonesConfig
-
- CapacityRequirementsPerZonesConfig(String, CapacityRequirementsPerZones) - Constructor for class org.openspaces.admin.pu.elastic.config.CapacityRequirementsPerZonesConfig
-
- CapacityRequirementsPerZonesConfig(String, Map<String, String>) - Constructor for class org.openspaces.admin.pu.elastic.config.CapacityRequirementsPerZonesConfig
-
- CapacityRequirementType<T extends CapacityRequirement> - Class in org.openspaces.grid.gsm.capacity
-
- cas(Long, LocalCacheElement) - Method in class org.openspaces.memcached.SpaceCache
-
- cas_key - Variable in class org.openspaces.memcached.protocol.CommandMessage
-
- cast(Number) - Method in class org.openspaces.core.util.numbers.BigDecimalHelper
-
- cast(Number) - Method in class org.openspaces.core.util.numbers.BigIntegerHelper
-
- cast(Number) - Method in class org.openspaces.core.util.numbers.DoubleHelper
-
- cast(Number) - Method in class org.openspaces.core.util.numbers.FloatHelper
-
- cast(Number) - Method in class org.openspaces.core.util.numbers.IntegerHelper
-
- cast(Number) - Method in class org.openspaces.core.util.numbers.LongHelper
-
- cast(Number) - Method in interface org.openspaces.core.util.numbers.NumberHelper
-
Casts the give
Number
into the type the number helper handles.
- cast(Number) - Method in class org.openspaces.core.util.numbers.ShortHelper
-
- cast(Value, Class) - Method in class org.openspaces.jpa.openjpa.query.QueryExpressionFactory
-
Cast the value to the given class.
- CHANGE - Static variable in interface com.gigaspaces.datasource.BulkItem
-
Deprecated.
- change(ISpaceQuery<T>, ChangeSet) - Method in class org.openspaces.core.DefaultGigaSpace
-
- change(ISpaceQuery<T>, ChangeSet, ChangeModifiers) - Method in class org.openspaces.core.DefaultGigaSpace
-
- change(ISpaceQuery<T>, ChangeSet, long) - Method in class org.openspaces.core.DefaultGigaSpace
-
- change(ISpaceQuery<T>, ChangeSet, ChangeModifiers, long) - Method in class org.openspaces.core.DefaultGigaSpace
-
- change(T, ChangeSet) - Method in class org.openspaces.core.DefaultGigaSpace
-
- change(T, ChangeSet, ChangeModifiers) - Method in class org.openspaces.core.DefaultGigaSpace
-
- change(T, ChangeSet, long) - Method in class org.openspaces.core.DefaultGigaSpace
-
- change(T, ChangeSet, ChangeModifiers, long) - Method in class org.openspaces.core.DefaultGigaSpace
-
- change(ISpaceQuery<T>, ChangeSet) - Method in interface org.openspaces.core.GigaSpace
-
Changes existing objects in space, returning a change result which provides details of the operation affect.
- change(ISpaceQuery<T>, ChangeSet, long) - Method in interface org.openspaces.core.GigaSpace
-
Changes existing objects in space, returning a change result which provides details of the operation affect.
- change(ISpaceQuery<T>, ChangeSet, ChangeModifiers) - Method in interface org.openspaces.core.GigaSpace
-
Changes existing objects in space, returning a change result which provides details of the operation affect.
- change(ISpaceQuery<T>, ChangeSet, ChangeModifiers, long) - Method in interface org.openspaces.core.GigaSpace
-
Changes existing objects in space, returning a change result which provides details of the operation affect.
- change(T, ChangeSet) - Method in interface org.openspaces.core.GigaSpace
-
Changes existing objects in space, returning a change result which provides details of the operation affect.
- change(T, ChangeSet, long) - Method in interface org.openspaces.core.GigaSpace
-
Changes existing objects in space, returning a change result which provides details of the operation affect.
- change(T, ChangeSet, ChangeModifiers) - Method in interface org.openspaces.core.GigaSpace
-
Changes existing objects in space, returning a change result which provides details of the operation affect.
- change(T, ChangeSet, ChangeModifiers, long) - Method in interface org.openspaces.core.GigaSpace
-
Changes existing objects in space, returning a change result which provides details of the operation affect.
- ChangeDataSyncOperation - Class in com.gigaspaces.sync.change
-
Used to extract the
DataSyncChangeSet
from operations that represent a change operation.
- ChangeDataSyncOperation() - Constructor for class com.gigaspaces.sync.change.ChangeDataSyncOperation
-
- ChangedEntryDetails<T> - Interface in com.gigaspaces.client
-
The result of a change operation executed on an entry
- ChangeException - Exception in com.gigaspaces.client
-
Thrown when any error occurred when trying to perform change of entries
- ChangeException() - Constructor for exception com.gigaspaces.client.ChangeException
-
- ChangeException(String, Collection<ChangedEntryDetails<?>>, Collection<FailedChangedEntryDetails>, Collection<Throwable>) - Constructor for exception com.gigaspaces.client.ChangeException
-
- ChangeException(String, int, Collection<FailedChangedEntryDetails>, Collection<Throwable>) - Constructor for exception com.gigaspaces.client.ChangeException
-
- ChangeException - Exception in org.openspaces.core
-
Thrown when an error occurred while performing a GigaSpace#change(com.gigaspaces.query.IdQuery, com.gigaspaces.client.ChangeSet, com.gigaspaces.client.ChangeModifiers, long)
operation.
- ChangeException(ChangeException, ExceptionTranslator) - Constructor for exception org.openspaces.core.ChangeException
-
- ChangeExtension - Class in org.openspaces.extensions
-
- ChangeExtension() - Constructor for class org.openspaces.extensions.ChangeExtension
-
- ChangeModifierFactoryBean - Class in org.openspaces.core.config.modifiers
-
- ChangeModifierFactoryBean() - Constructor for class org.openspaces.core.config.modifiers.ChangeModifierFactoryBean
-
- ChangeModifiers - Class in com.gigaspaces.client
-
Provides modifiers to customize the behavior of change operations.
- ChangeModifiers() - Constructor for class com.gigaspaces.client.ChangeModifiers
-
- ChangeModifiers(ChangeModifiers, ChangeModifiers) - Constructor for class com.gigaspaces.client.ChangeModifiers
-
Creates a new modifiers from the specified modifiers.
- ChangeModifiers(ChangeModifiers, ChangeModifiers, ChangeModifiers) - Constructor for class com.gigaspaces.client.ChangeModifiers
-
Creates a new modifiers from the specified modifiers.
- ChangeModifiers(ChangeModifiers...) - Constructor for class com.gigaspaces.client.ChangeModifiers
-
Creates a new modifiers from the specified modifiers.
- ChangeOperation - Interface in com.gigaspaces.sync.change
-
A single change applied on a
ChangeSet
when using a change operation on an object.
- ChangeResult<T> - Interface in com.gigaspaces.client
-
Result of a change operation.
- ChangeSet - Class in com.gigaspaces.client
-
The set of changes to apply for matches entries of the change operation
- ChangeSet() - Constructor for class com.gigaspaces.client.ChangeSet
-
Constructs an empty change set
- channelClosed(ChannelHandlerContext, ChannelStateEvent) - Method in class org.openspaces.memcached.protocol.MemcachedCommandHandler
-
On close we manage some statistics, and remove this connection from the channel group.
- channelOpen(ChannelHandlerContext, ChannelStateEvent) - Method in class org.openspaces.memcached.protocol.MemcachedCommandHandler
-
On open we manage some statistics, and add this connection to the channel group.
- checkKey(Object) - Method in class com.sun.jini.lease.AbstractLeaseMap
-
Check that the key is valid for this map
- checkPortAvailable(int) - Static method in class org.openspaces.core.gateway.GatewayUtils
-
Checks is a post is available on the current machine, using new
ServerSocket(port).
- checkValue(Object) - Static method in class com.sun.jini.lease.AbstractLeaseMap
-
Check that the value is a Long
- chunkSize - Variable in class org.openspaces.persistency.hibernate.iterator.AbstractChunkDataIterator
-
- ClassFilter(String) - Constructor for class com.gigaspaces.security.authorities.SpaceAuthority.ClassFilter
-
- cleanupCloud(ProcessingUnit, NonBlockingElasticMachineProvisioning) - Method in interface org.openspaces.grid.gsm.machines.MachinesSlaEnforcementEndpoint
-
Erases all Allocated (state) that is related to the specified processing unit.
- cleanupCloudResources(long, TimeUnit) - Method in class org.openspaces.grid.gsm.machines.plugins.discovered.DiscoveredMachineProvisioningBean
-
- cleanupCloudResources(long, TimeUnit) - Method in interface org.openspaces.grid.gsm.machines.plugins.NonBlockingElasticMachineProvisioning
-
Cleanup all cloud resources.
- cleanupCloudResources(long, TimeUnit) - Method in class org.openspaces.grid.gsm.machines.plugins.NonBlockingElasticMachineProvisioningAdapter
-
- cleanupMachineResources(long, TimeUnit) - Method in interface org.openspaces.grid.gsm.machines.plugins.ElasticMachineProvisioning
-
Cleanup all cloud resources.
- clear(Object, Transaction) - Method in interface com.gigaspaces.client.IPojoSpace
-
- clear(Object, Transaction, int) - Method in interface com.gigaspaces.client.IPojoSpace
-
- clear() - Method in class com.gigaspaces.document.DocumentProperties
- clear() - Method in interface com.j_spaces.javax.cache.Cache
-
Deprecated.
The clear method will remove all objects from
the cache including the key and the associated value.
- clear() - Method in interface com.j_spaces.javax.cache.EvictionStrategy
-
Deprecated.
Clear EvictionStrategy internal structures only and doesn't clear cache.
- clear(boolean) - Method in interface com.j_spaces.map.IMap
-
The clear method will remove all objects from
the cache including the key and the associated value.
- clear() - Method in class com.sun.jini.lease.AbstractLeaseMap
-
- clear() - Method in class net.jini.lease.LeaseRenewalManager
-
Removes all leases from the managed set of leases.
- clear() - Method in class org.openspaces.core.DefaultGigaMap
-
- clear(boolean) - Method in class org.openspaces.core.DefaultGigaMap
-
- clear(Object) - Method in class org.openspaces.core.DefaultGigaSpace
-
- clear(Object, int) - Method in class org.openspaces.core.DefaultGigaSpace
-
- clear(Object, ClearModifiers) - Method in class org.openspaces.core.DefaultGigaSpace
-
- clear(boolean) - Method in interface org.openspaces.core.GigaMap
-
The clear method will remove all objects from
the cache including the key and the associated value.
- clear(Object) - Method in interface org.openspaces.core.GigaSpace
-
Removes the entries that match the specified template and the specified transaction from this space.
- clear(Object, int) - Method in interface org.openspaces.core.GigaSpace
-
- clear(Object, ClearModifiers) - Method in interface org.openspaces.core.GigaSpace
-
Removes the entries that match the specified template and the specified transaction from this space.
- clear() - Method in class org.openspaces.core.util.ConcurrentHashSet
-
Removes all of the elements from this set.
- clear() - Method in class org.openspaces.core.util.StringProperties
-
- clear() - Method in class org.openspaces.persistency.hibernate.iterator.AbstractScrollableDataIterator
-
- clear() - Method in class org.openspaces.persistency.hibernate.iterator.DefaultScrollableDataIterator
-
- clear() - Method in class org.openspaces.persistency.hibernate.iterator.StatelessScrollableDataIterator
-
- ClearException - Exception in com.gigaspaces.client
-
Thrown when a space clear operation fails.
- ClearException() - Constructor for exception com.gigaspaces.client.ClearException
-
- ClearException(List<Throwable>) - Constructor for exception com.gigaspaces.client.ClearException
-
- ClearException(Throwable) - Constructor for exception com.gigaspaces.client.ClearException
-
- ClearException - Exception in org.openspaces.core
-
Thrown when a clear space operations fails.
- ClearException(ClearException, ExceptionTranslator) - Constructor for exception org.openspaces.core.ClearException
-
- clearExpirationWarningListener() - Method in interface net.jini.lease.LeaseRenewalSet
-
Remove the listener currently registered for expiration warning
events.
- ClearModifierFactoryBean - Class in org.openspaces.core.config.modifiers
-
- ClearModifierFactoryBean() - Constructor for class org.openspaces.core.config.modifiers.ClearModifierFactoryBean
-
- ClearModifiers - Class in com.gigaspaces.client
-
Provides modifiers to customize the behavior of clear operations.
- ClearModifiers() - Constructor for class com.gigaspaces.client.ClearModifiers
-
- ClearModifiers(ClearModifiers, ClearModifiers) - Constructor for class com.gigaspaces.client.ClearModifiers
-
Creates a new modifiers from the specified modifiers.
- ClearModifiers(ClearModifiers, ClearModifiers, ClearModifiers) - Constructor for class com.gigaspaces.client.ClearModifiers
-
Creates a new modifiers from the specified modifiers.
- ClearModifiers(ClearModifiers...) - Constructor for class com.gigaspaces.client.ClearModifiers
-
Creates a new modifiers from the specified modifiers.
- clearRenewalFailureListener() - Method in interface net.jini.lease.LeaseRenewalSet
-
Remove the listener currently registered for renewal failure
events.
- clearResults() - Method in exception com.j_spaces.core.multiple.BatchOperationException
-
- clientError(String) - Static method in class org.openspaces.memcached.protocol.CommandMessage
-
- ClientException - Exception in org.openspaces.memcached.protocol.exceptions
-
- ClientException() - Constructor for exception org.openspaces.memcached.protocol.exceptions.ClientException
-
- ClientException(String) - Constructor for exception org.openspaces.memcached.protocol.exceptions.ClientException
-
- ClientException(String, Throwable) - Constructor for exception org.openspaces.memcached.protocol.exceptions.ClientException
-
- ClientException(Throwable) - Constructor for exception org.openspaces.memcached.protocol.exceptions.ClientException
-
- ClientLogEntryMatcherCallback - Interface in com.gigaspaces.log
-
A marker interface for a specific
LogEntryMatcher
marking it as needed to have extra processing step when it is received on the client
side.
- clientSideProcess(LogEntries) - Method in interface com.gigaspaces.log.ClientLogEntryMatcherCallback
-
Process the log entries and use the resulted entries.
- clientSideProcess(LogEntries) - Method in class com.gigaspaces.log.ContinuousLogEntryMatcher
-
- clientSideProcess(LogEntries) - Method in class com.gigaspaces.log.ForwardChunkLogEntryMatcher
-
- clientSideProcess(LogEntries) - Method in class com.gigaspaces.log.ReverseLogEntryMatcher
-
- ClientUIDHandler - Class in com.j_spaces.core.client
-
- clone() - Method in class com.gigaspaces.config.lrmi.nio.NIOConfiguration
-
- clone() - Method in class com.gigaspaces.query.aggregators.SpaceEntriesAggregator
-
- clone() - Method in class com.gigaspaces.query.CompoundResult
-
- clone() - Method in class com.j_spaces.core.admin.SpaceConfig
-
- clone() - Method in class com.j_spaces.core.client.EntryArrivedRemoteEvent
-
Returns a shallow copy of this EntryArrivedRemoteEvent instance.
- clone() - Method in class com.j_spaces.core.client.ExternalEntry
-
Deprecated.
Shallow clone
- clone() - Method in class com.j_spaces.core.client.SpaceURL
-
Deprecated.
deep clones this SpaceURL instance - makes a distinct copy of each of the SpaceURL fields,
and underlying tables.
- clone() - Method in class org.openspaces.remoting.EventDrivenSpaceRemotingEntry
-
Deprecated.
- clone() - Method in interface org.openspaces.remoting.SpaceRemotingEntry
-
- close() - Method in class com.gigaspaces.client.iterator.SpaceIterator
-
- close() - Method in interface com.gigaspaces.datasource.DataIterator
-
Clean up after any resources associated with this iterator
The iterator can be closed even if the iterator wasn't iterated over all of its elements.
- close() - Method in interface com.gigaspaces.events.EventSession
-
closes the session and deregister all listeners.
- close() - Method in class com.gigaspaces.metrics.MetricReporter
-
- close() - Method in interface com.gigaspaces.security.directory.DirectoryManager
-
Close the resource used to store the user and role details.
- close() - Method in interface com.gigaspaces.security.SecurityManager
-
Closes any excess resource kept by the security manager; e.g. connection to a data-source.
- close() - Method in class com.gigaspaces.server.eviction.SpaceEvictionStrategy
-
Called when the space is closed.
- close() - Method in interface com.j_spaces.core.client.INotifyDelegatorFilter
-
Called when notify template unregistered or space was shutdown.
- close() - Method in interface com.j_spaces.core.cluster.IReplicationFilter
-
Closes this filter, enabling the developer to clean open resources.
- close() - Method in interface com.j_spaces.core.filters.ISpaceFilter
-
Closes this filter, enabling the developer to clean open resources.
- close() - Method in interface net.jini.event.RemoteEventIterator
-
Ends all event processing being performed by this iterator
and invalidates the iterator.
- close() - Method in interface org.openspaces.admin.Admin
-
Closes the Admin, releasing any resource and stops listening for events from the lookup service.
- close() - Method in class org.openspaces.core.space.AbstractSpaceFactoryBean
-
Destroys the space and unregisters the internal space mode listener (if registered).
- close() - Method in class org.openspaces.core.space.cache.LocalCacheSpaceConfigurer
-
- close() - Method in class org.openspaces.core.space.cache.LocalViewSpaceConfigurer
-
- close() - Method in class org.openspaces.core.space.EmbeddedSpaceConfigurer
-
- close() - Method in class org.openspaces.core.space.ExecutorSpaceFilter
-
- close() - Method in class org.openspaces.core.space.filter.FilterOperationDelegate
-
- close() - Method in interface org.openspaces.core.space.SpaceConfigurer
-
- close() - Method in class org.openspaces.core.space.SpaceProxyConfigurer
-
- close() - Method in class org.openspaces.core.space.UrlSpaceConfigurer
-
- close() - Method in interface org.openspaces.grid.gsm.machines.backup.MachinesStateBackup
-
- close() - Method in class org.openspaces.grid.gsm.machines.backup.MachinesStateBackupStub
-
- close() - Method in class org.openspaces.grid.gsm.machines.backup.MachinesStateBackupToSpace
-
- close() - Method in class org.openspaces.interop.DotnetProcessingUnitContainer
-
- close() - Method in class org.openspaces.jdbc.datasource.DbcpBasicDataSource
-
Close and release all connections that are currently stored in the
connection pool associated with our data source.
- close() - Method in class org.openspaces.jpa.openjpa.query.SpaceProjectionResultObjectProvider
-
- close() - Method in class org.openspaces.jpa.openjpa.query.SpaceResultObjectProvider
-
- close() - Method in class org.openspaces.memcached.SpaceCache
-
- close() - Method in class org.openspaces.persistency.hibernate.iterator.AbstractChunkDataIterator
-
- close() - Method in class org.openspaces.persistency.hibernate.iterator.AbstractScrollableDataIterator
-
- close() - Method in class org.openspaces.persistency.hibernate.iterator.DefaultCriteriaByExampleDataIterator
-
- close() - Method in class org.openspaces.persistency.hibernate.iterator.DefaultListQueryDataIterator
-
- close() - Method in class org.openspaces.persistency.hibernate.iterator.HibernateProxyRemoverIterator
-
- close() - Method in class org.openspaces.persistency.hibernate.iterator.StatelessListQueryDataIterator
-
- close() - Method in class org.openspaces.persistency.support.ConcurrentMultiDataIterator
-
- close() - Method in class org.openspaces.persistency.support.SerialMultiDataIterator
-
- close() - Method in class org.openspaces.pu.container.integrated.IntegratedProcessingUnitContainer
-
Closes the processing unit container by destroying the Spring application context.
- close() - Method in class org.openspaces.pu.container.ProcessingUnitContainer
-
Closes the given processing unit container.
- close() - Method in class org.openspaces.pu.container.standalone.StandaloneProcessingUnitContainer
-
- close() - Method in class org.openspaces.pu.container.support.CompoundProcessingUnitContainer
-
- close() - Method in class org.openspaces.remoting.scripting.cache.BlockingQueueCompiledScriptPool
-
- close() - Method in interface org.openspaces.remoting.scripting.cache.CompiledScriptPool
-
Closes the pool.
- close(groovy.lang.Script) - Method in class org.openspaces.remoting.scripting.GroovyLocalScriptExecutor
-
- close(JRubyLocalScriptExecutor.JRubyCompiledScript) - Method in class org.openspaces.remoting.scripting.JRubyLocalScriptExecutor
-
- close(Object) - Method in class org.openspaces.remoting.scripting.Jsr223LocalScriptExecutor
-
- close(T) - Method in interface org.openspaces.remoting.scripting.LocalScriptExecutor
-
Closes the compiled script.
- close() - Method in class org.openspaces.security.spring.SpringSecurityManager
-
- closeApplicationContext() - Method in class org.openspaces.core.space.mode.RefreshSpaceModeContextLoader
-
- closeApplicationContext() - Method in class org.openspaces.core.space.mode.SpaceModeContextLoader
-
Closes the application context.
- ClosedResourceException - Exception in com.j_spaces.core.exception
-
ClosedResourceException is thrown when operation is performed
while space is closing its resources.
- ClosedResourceException(String) - Constructor for exception com.j_spaces.core.exception.ClosedResourceException
-
- ClosedResourceException(String, Throwable) - Constructor for exception com.j_spaces.core.exception.ClosedResourceException
-
- closeSession() - Method in class org.openspaces.events.notify.SimpleNotifyEventListenerContainer
-
- ClosureGatewayAddedEventListener - Class in org.openspaces.admin.gateway.events
-
- ClosureGatewayAddedEventListener(Object) - Constructor for class org.openspaces.admin.gateway.events.ClosureGatewayAddedEventListener
-
- ClosureGatewayProcessingUnitAddedEventListener - Class in org.openspaces.admin.gateway.events
-
- ClosureGatewayProcessingUnitAddedEventListener(Object) - Constructor for class org.openspaces.admin.gateway.events.ClosureGatewayProcessingUnitAddedEventListener
-
- ClosureGatewayProcessingUnitRemovedEventListener - Class in org.openspaces.admin.gateway.events
-
- ClosureGatewayProcessingUnitRemovedEventListener(Object) - Constructor for class org.openspaces.admin.gateway.events.ClosureGatewayProcessingUnitRemovedEventListener
-
- ClosureGatewayRemovedEventListener - Class in org.openspaces.admin.gateway.events
-
- ClosureGatewayRemovedEventListener(Object) - Constructor for class org.openspaces.admin.gateway.events.ClosureGatewayRemovedEventListener
-
- CloudCleanupFailedException - Exception in org.openspaces.grid.gsm.machines.exceptions
-
- CloudCleanupFailedException(ProcessingUnit, Exception) - Constructor for exception org.openspaces.grid.gsm.machines.exceptions.CloudCleanupFailedException
-
- CLOUDIFY_MANAGEMENT_SPACE_NAME - Static variable in class org.openspaces.grid.esm.ESMImplInitializer
-
- CLUSTER_BACKUP_ID - Static variable in class com.j_spaces.core.client.SpaceURL
-
Deprecated.
Used in case of Partitioned Cache (when adding backup to each partition)
The backup_id is used to define whether the instance is a backup instance or not.
- CLUSTER_CACHE_LOADER_CENTRAL_DATA_SOURCE - Static variable in class com.j_spaces.kernel.SystemProperties
-
- CLUSTER_CACHE_LOADER_EXTERNAL_DATA_SOURCE - Static variable in class com.j_spaces.kernel.SystemProperties
-
- CLUSTER_CONFIG_URL - Static variable in class com.j_spaces.kernel.SystemProperties
-
- CLUSTER_CONFIG_URL_DEFAULT - Static variable in class com.j_spaces.kernel.SystemProperties
-
- CLUSTER_GROUP - Static variable in class com.j_spaces.core.client.SpaceURL
-
Deprecated.
jini://
multicast support.
- CLUSTER_INFO_CONTEXT - Static variable in class org.openspaces.pu.container.jee.JeeProcessingUnitContainerProvider
-
The
ServletContext
key under which the
ClusterInfo
is stored.
- CLUSTER_INFO_KEY - Static variable in class org.openspaces.remoting.scripting.DefaultScriptingExecutor
-
- CLUSTER_MEMBER_ID - Static variable in class com.j_spaces.core.client.SpaceURL
-
Deprecated.
The id attribute is used to distinguish between cache instances in this cluster.
- CLUSTER_NAME - Static variable in class com.j_spaces.core.client.SpaceURL
-
Deprecated.
jini://
multicast support.
- CLUSTER_PARAMETER_BACKUPID - Static variable in class org.openspaces.pu.container.support.ClusterInfoParser
-
- CLUSTER_PARAMETER_CLUSTERSCHEMA - Static variable in class org.openspaces.pu.container.support.ClusterInfoParser
-
- CLUSTER_PARAMETER_INSTANCEID - Static variable in class org.openspaces.pu.container.support.ClusterInfoParser
-
- CLUSTER_PARAMETER_TOTALMEMBERS - Static variable in class org.openspaces.pu.container.support.ClusterInfoParser
-
- CLUSTER_SCHEMA - Static variable in class com.j_spaces.core.client.SpaceURL
-
Deprecated.
The cluster schema XSL file name to be used to setup a cluster config on the fly in memory.
- CLUSTER_TOTAL_MEMBERS - Static variable in class com.j_spaces.core.client.SpaceURL
-
Deprecated.
The total_members attribute in the space url stands for
the total number of space members within the space cluster.
- CLUSTER_XML_DEBUG - Static variable in class com.j_spaces.kernel.SystemProperties
-
- CLUSTER_XML_SCHEMA_VALIDATION - Static variable in class com.j_spaces.kernel.SystemProperties
-
- CLUSTER_XML_SCHEMA_VALIDATION_DEFAULT - Static variable in class com.j_spaces.kernel.SystemProperties
-
- ClusterConfigurationException - Exception in com.j_spaces.core.exception
-
This exception is thrown in case of cluster configuration issues.
- ClusterConfigurationException() - Constructor for exception com.j_spaces.core.exception.ClusterConfigurationException
-
Constructs a ClusterConfigurationException
.
- ClusterConfigurationException(String) - Constructor for exception com.j_spaces.core.exception.ClusterConfigurationException
-
Constructs a ClusterConfigurationException
with the specified
detail message.
- ClusterConfigurationException(String, Throwable) - Constructor for exception com.j_spaces.core.exception.ClusterConfigurationException
-
Constructs a ClusterConfigurationException
with the specified detail
message and cause.
- CLUSTERED - Static variable in class org.openspaces.core.config.LocalTxManagerBeanDefinitionParser
-
Deprecated.
- clustered(boolean) - Method in class org.openspaces.core.GigaSpaceConfigurer
-
- clustered(boolean) - Method in class org.openspaces.core.map.MapConfigurer
-
- CLUSTERED - Static variable in class org.openspaces.core.space.SpaceServiceDetails.Attributes
-
- clustered(boolean) - Method in class org.openspaces.core.transaction.manager.LocalJiniTxManagerConfigurer
-
Deprecated.
- ClusterInfo - Class in org.openspaces.core.cluster
-
Holds cluster related information.
- ClusterInfo() - Constructor for class org.openspaces.core.cluster.ClusterInfo
-
Constructs a new cluster info with null values on all the fields
- ClusterInfo(String, Integer, Integer, Integer, Integer) - Constructor for class org.openspaces.core.cluster.ClusterInfo
-
Constructs a new Cluster info
- clusterInfo(ClusterInfo) - Method in class org.openspaces.core.space.EmbeddedSpaceConfigurer
-
- clusterInfo(ClusterInfo) - Method in class org.openspaces.core.space.UrlSpaceConfigurer
-
- clusterInfo - Variable in class org.openspaces.persistency.ClusterInfoAwareSpaceDataSource
-
- clusterInfo(ClusterInfo) - Method in class org.openspaces.persistency.hibernate.CriteriaHibernateSpaceDataSourceConfigurer
-
Injects the
ClusterInfo
to be used with the SpaceDataSource
- clusterInfo(ClusterInfo) - Method in class org.openspaces.persistency.hibernate.DefaultHibernateSpaceDataSourceConfigurer
-
Injects the
ClusterInfo
to be used with the SpaceDataSource
- clusterInfo(ClusterInfo) - Method in class org.openspaces.persistency.hibernate.StatelessHibernateSpaceDataSourceConfigurer
-
Injects the
ClusterInfo
to be used with the SpaceDataSource
- ClusterInfoAware - Interface in org.openspaces.core.cluster
-
Allows for beans implementing this interface to be injected with
ClusterInfo
.
- ClusterInfoAwareSpaceDataSource - Class in org.openspaces.persistency
-
Created by yuvalm on 23/04/2014.
- ClusterInfoAwareSpaceDataSource() - Constructor for class org.openspaces.persistency.ClusterInfoAwareSpaceDataSource
-
- ClusterInfoBeanPostProcessor - Class in org.openspaces.core.cluster
-
- ClusterInfoBeanPostProcessor(ClusterInfo) - Constructor for class org.openspaces.core.cluster.ClusterInfoBeanPostProcessor
-
Constructs a new cluster info bean post processor based on the provided cluster info.
- ClusterInfoContext - Annotation Type in org.openspaces.core.cluster
-
- ClusterInfoParser - Class in org.openspaces.pu.container.support
-
ClusterInfo
parser that parses -cluster parameter and
transforms it into a cluster info.
- ClusterInfoParser() - Constructor for class org.openspaces.pu.container.support.ClusterInfoParser
-
- ClusterInfoPropertyPlaceholderConfigurer - Class in org.openspaces.core.cluster
-
Provides the
ClusterInfo
parameters as injected
properties that can be used within Spring application context.
- ClusterInfoPropertyPlaceholderConfigurer() - Constructor for class org.openspaces.core.cluster.ClusterInfoPropertyPlaceholderConfigurer
-
- ClusterInfoPropertyPlaceholderConfigurer(ClusterInfo) - Constructor for class org.openspaces.core.cluster.ClusterInfoPropertyPlaceholderConfigurer
-
- clusterName - Variable in class com.j_spaces.core.cluster.ReplicationPolicy
-
the name of the cluster this replication policy belongs to
- clusterSchema(String) - Method in class org.openspaces.admin.memcached.MemcachedDeployment
-
Sets the cluster schema of the Space.
- clusterSchema(String) - Method in class org.openspaces.admin.pu.ProcessingUnitDeployment
-
Controls the cluster schema of the deployment.
- clusterSchema(String) - Method in class org.openspaces.admin.space.SpaceDeployment
-
Sets the cluster schema of the Space.
- cmd - Variable in class org.openspaces.memcached.protocol.ResponseMessage
-
- cmd - Variable in class org.openspaces.memcached.protocol.SessionStatus
-
- coalesceExpression(Value[]) - Method in class org.openspaces.jpa.openjpa.query.QueryExpressionFactory
-
Return a coalesce expression
- code - Variable in enum org.openspaces.memcached.protocol.binary.MemcachedBinaryResponseEncoder.ResponseCode
-
- COM_TYPE_MULTICAST - Static variable in class org.openspaces.events.notify.SimpleNotifyEventListenerContainer
-
- COM_TYPE_MULTIPLEX - Static variable in class org.openspaces.events.notify.SimpleNotifyEventListenerContainer
-
- COM_TYPE_PREFIX - Static variable in class org.openspaces.events.notify.SimpleNotifyEventListenerContainer
-
- COM_TYPE_UNICAST - Static variable in class org.openspaces.events.notify.SimpleNotifyEventListenerContainer
-
- COMM_TYPE - Static variable in class org.openspaces.events.notify.AggregatedNotifyEventContainerServiceDetails.Attributes
-
- COMM_TYPE - Static variable in class org.openspaces.events.notify.NotifyEventContainerServiceDetails.Attributes
-
- command(Op) - Static method in class org.openspaces.memcached.protocol.CommandMessage
-
- COMMANDLINE_OPTION - Static variable in interface org.openspaces.admin.pu.dependency.ProcessingUnitDeploymentDependencies
-
- commandLineArgument(String) - Method in class org.openspaces.admin.pu.elastic.ElasticStatefulProcessingUnitDeployment
-
- commandLineArgument(String) - Method in class org.openspaces.admin.pu.elastic.ElasticStatelessProcessingUnitDeployment
-
- commandLineArgument(String) - Method in interface org.openspaces.admin.pu.elastic.topology.ElasticDeploymentTopology
-
Will add a JVM level argument when the process is executed using pure JVM.
- commandLineArgument(String) - Method in class org.openspaces.admin.space.ElasticSpaceDeployment
-
- CommandLineParser - Class in org.openspaces.pu.container.support
-
- CommandLineParser() - Constructor for class org.openspaces.pu.container.support.CommandLineParser
-
- CommandLineParser.Parameter - Class in org.openspaces.pu.container.support
-
- CommandMessage - Class in org.openspaces.memcached.protocol
-
The payload object holding the parsed message.
- CommandMessage.ErrorType - Enum in org.openspaces.memcached.protocol
-
- commit() - Method in interface com.gigaspaces.sync.ConsolidationParticipantData
-
Specifies that this transaction participant should be executed as a single separate transaction
- commit(Xid, boolean) - Method in class com.j_spaces.core.client.XAResourceImpl
-
- commit(long) - Method in class com.sun.jini.mahalo.TxnManagerImpl
-
- commit(long, long) - Method in class com.sun.jini.mahalo.TxnManagerImpl
-
- commit(Object) - Method in class com.sun.jini.mahalo.TxnManagerImpl
-
- commit(Object, long) - Method in class com.sun.jini.mahalo.TxnManagerImpl
-
- commit(long) - Method in class com.sun.jini.mahalo.TxnMgrProxy
-
- commit(long, long) - Method in class com.sun.jini.mahalo.TxnMgrProxy
-
- commit(Object) - Method in class com.sun.jini.mahalo.TxnMgrProxy
-
- commit(Object, long) - Method in class com.sun.jini.mahalo.TxnMgrProxy
-
- commit(Object) - Method in interface net.jini.core.transaction.server.ExtendedTransactionManager
-
- commit(Object, long) - Method in interface net.jini.core.transaction.server.ExtendedTransactionManager
-
- commit() - Method in class net.jini.core.transaction.server.ServerTransaction
-
- commit(long) - Method in class net.jini.core.transaction.server.ServerTransaction
-
- commit(long) - Method in interface net.jini.core.transaction.server.TransactionManager
-
Commit the transaction.
- commit(long, long) - Method in interface net.jini.core.transaction.server.TransactionManager
-
Commit the transaction, waiting for participants to be notified of
the decision.
- commit(TransactionManager, long) - Method in interface net.jini.core.transaction.server.TransactionParticipant
-
Requests that the participant make all of its PREPARED
changes for the specified transaction visible outside of the
transaction and unlock any resources locked by the transaction.
- commit(TransactionManager, long, int) - Method in interface net.jini.core.transaction.server.TransactionParticipant
-
Requests that the participant make all of its PREPARED
changes for the specified transaction visible outside of the
transaction and unlock any resources locked by the transaction.
- commit() - Method in interface net.jini.core.transaction.Transaction
-
Commit the transaction.
- commit(long) - Method in interface net.jini.core.transaction.Transaction
-
Commit the transaction, waiting for participants to be notified of
the decision.
- commit() - Method in class org.openspaces.jpa.StoreManager
-
- commitAndPreparePartitionWithEnabledFailover(ParticipantHandle, TransactionManager, long, Object) - Static method in class com.sun.jini.mahalo.PrepareAndCommitJob
-
- CommitJob - Class in com.sun.jini.mahalo
-
An implementation of a Job
which interacts with
a set of TransactionParticipant
s to inform them
to roll forward changes associated with a given Transaction
.
- CommitJob(Transaction, TaskManager, WakeupManager, ClientLog, ParticipantHandle[], Object) - Constructor for class com.sun.jini.mahalo.CommitJob
-
Constructs an CommitJob
- commitPartitionWithEnabledFailover(ParticipantHandle, ExtendedTransactionManager, long, Object, int) - Static method in class com.sun.jini.mahalo.CommitJob
-
- COMMITTED - Static variable in interface net.jini.core.transaction.server.TransactionConstants
-
Transaction has been committed.
- committed - Variable in exception net.jini.core.transaction.TimeoutExpiredException
-
True if the transaction committed before the timeout.
- commitTimeout(long) - Method in class org.openspaces.core.transaction.manager.DistributedJiniTxManagerConfigurer
-
- commitTimeout(long) - Method in class org.openspaces.core.transaction.manager.LocalJiniTxManagerConfigurer
-
Deprecated.
- commitTimeout(long) - Method in class org.openspaces.core.transaction.manager.LookupJiniTxManagerConfigurer
-
- COMMUNICATION_PORT - Static variable in class org.openspaces.core.gateway.config.GatewayLookupBeanDefinitionParser
-
- compare(Number, Number) - Method in class org.openspaces.core.util.numbers.BigDecimalHelper
-
- compare(Number, Number) - Method in class org.openspaces.core.util.numbers.BigIntegerHelper
-
- compare(Number, Number) - Method in class org.openspaces.core.util.numbers.DoubleHelper
-
- compare(Number, Number) - Method in class org.openspaces.core.util.numbers.FloatHelper
-
- compare(Number, Number) - Method in class org.openspaces.core.util.numbers.IntegerHelper
-
- compare(Number, Number) - Method in class org.openspaces.core.util.numbers.LongHelper
-
- compare(Number, Number) - Method in class org.openspaces.core.util.numbers.ShortHelper
-
- compare(Comparable<?>, Object) - Static method in class org.openspaces.grid.gsm.autoscaling.AutoScalingSlaUtils
-
- compareTo(OrderByKey) - Method in class com.gigaspaces.query.aggregators.OrderByKey
-
- compareTo(CapacityRequirement) - Method in class org.openspaces.grid.gsm.capacity.AbstractCapacityRequirement
-
- compareTo(CapacityRequirement) - Method in class org.openspaces.grid.gsm.capacity.CpuCapacityRequirement
-
- compareTo(MachinesSlaEnforcementState.StateKey) - Method in class org.openspaces.grid.gsm.machines.MachinesSlaEnforcementState.StateKey
-
- compile(Script) - Method in class org.openspaces.remoting.scripting.AbstractLocalScriptExecutor
-
- compile(Script) - Method in interface org.openspaces.remoting.scripting.LocalScriptExecutor
-
Compiles the given sctipt.
- CompiledScriptCache - Interface in org.openspaces.remoting.scripting.cache
-
A compiled script cache.
- CompiledScriptPool - Interface in org.openspaces.remoting.scripting.cache
-
Represnts a pool of compiled scripts that should work with a non thread safe
compiled scripts in conjuction with
CompiledScriptCache
.
- CompiledScriptPoolFactory - Interface in org.openspaces.remoting.scripting.cache
-
- completedStateRecovery(MachinesSlaEnforcementState.StateKey) - Method in class org.openspaces.grid.gsm.machines.MachinesSlaEnforcementState
-
- COMPONENT_NAME - Static variable in class org.openspaces.admin.alert.alerts.GarbageCollectionAlert
-
- COMPONENT_NAME - Static variable in class org.openspaces.admin.alert.alerts.HeapMemoryUtilizationAlert
-
- componentDescription(String) - Method in class org.openspaces.admin.alert.AlertFactory
-
- componentUid(String) - Method in class org.openspaces.admin.alert.AlertFactory
-
Component UID - the unique identifier of the component associated with the alert.
- CompoundDumpResult - Class in org.openspaces.admin.dump
-
A dump results that holds one or more Dump results.
- CompoundDumpResult() - Constructor for class org.openspaces.admin.dump.CompoundDumpResult
-
- CompoundIndex - Class in org.openspaces.core.config
-
Describes compound index
- CompoundIndex() - Constructor for class org.openspaces.core.config.CompoundIndex
-
- CompoundIndex(String, String[], CompoundIndex.CompoundIndexTypes) - Constructor for class org.openspaces.core.config.CompoundIndex
-
- CompoundIndex(String, String[], CompoundIndex.CompoundIndexTypes, boolean) - Constructor for class org.openspaces.core.config.CompoundIndex
-
- CompoundIndex.CompoundIndexTypes - Enum in org.openspaces.core.config
-
- CompoundLogEntries - Class in com.gigaspaces.log
-
- CompoundLogEntries(LogEntries[]) - Constructor for class com.gigaspaces.log.CompoundLogEntries
-
Constructs a new instance with an array of
LogEntries
(some
values can be null within the array).
- CompoundProcessingUnitContainer - Class in org.openspaces.pu.container.support
-
Compound processing unit container wraps several processing unit containers and
allows to close them.
- CompoundProcessingUnitContainer(ProcessingUnitContainer[]) - Constructor for class org.openspaces.pu.container.support.CompoundProcessingUnitContainer
-
- CompoundResult - Class in com.gigaspaces.query
-
- CompoundResult() - Constructor for class com.gigaspaces.query.CompoundResult
-
Required for Externalizable
- CompoundResult(Object[], Map<String, Integer>) - Constructor for class com.gigaspaces.query.CompoundResult
-
- CompoundSpaceIndex - Annotation Type in com.gigaspaces.annotation.pojo
-
Defines a compound space index.
- CompoundSpaceIndexes - Annotation Type in com.gigaspaces.annotation.pojo
-
Defines multiple CompoundSpaceIndex annotations for a POJO.
- compression(int) - Method in class org.openspaces.core.map.MapConfigurer
-
- computePerc(int, int) - Static method in class org.openspaces.admin.support.StatisticsUtils
-
- computePerc(long, long) - Static method in class org.openspaces.admin.support.StatisticsUtils
-
- computePerc(double) - Static method in class org.openspaces.admin.support.StatisticsUtils
-
- computePercByTime(long, long, long, long) - Static method in class org.openspaces.admin.support.StatisticsUtils
-
- computePerSecond(long, long, long, long) - Static method in class org.openspaces.admin.support.StatisticsUtils
-
- computeRouting(SpaceRemotingInvocation) - Method in class org.openspaces.remoting.MethodParamRemoteRoutingHandler
-
- computeRouting(SpaceRemotingInvocation) - Method in interface org.openspaces.remoting.RemoteRoutingHandler
-
Returns the routing field value based on the remoting invocation.
- computeRouting(SpaceRemotingInvocation, RemoteRoutingHandler, MethodInvocation) - Static method in class org.openspaces.remoting.RemotingProxyUtils
-
Computes the routing index for a given remote invocation.
- computeRouting(SpaceRemotingInvocation) - Method in class org.openspaces.remoting.scripting.ScriptingRemoteRoutingHandler
-
- computeXapVersion() - Static method in class org.openspaces.maven.support.OutputVersion
-
- comType(int) - Method in class org.openspaces.events.notify.SimpleNotifyContainerConfigurer
-
- concat(Value, Value) - Method in class org.openspaces.jpa.openjpa.query.QueryExpressionFactory
-
Return a value representing the concatenation of
the given target with the given args.
- concatAttrIfNotExist(String, String, String) - Static method in class com.j_spaces.core.client.SpaceURL
-
Deprecated.
Concatenates if not exist the specified attrName and attrValue to the end of the spaceURL
.
- CONCURRENT_CONSUMERS - Static variable in class org.openspaces.events.asyncpolling.AggregatedAsyncPollingEventContainerServiceDetails.Attributes
-
- CONCURRENT_CONSUMERS - Static variable in class org.openspaces.events.asyncpolling.AsyncPollingEventContainerServiceDetails.Attributes
-
- CONCURRENT_CONSUMERS - Static variable in class org.openspaces.events.polling.AggregatedPollingEventContainerServiceDetails.Attributes
-
- CONCURRENT_CONSUMERS - Static variable in class org.openspaces.events.polling.PollingEventContainerServiceDetails.Attributes
-
- concurrentConsumers(int) - Method in class org.openspaces.archive.ArchivePollingContainerConfigurer
-
- concurrentConsumers(int) - Method in class org.openspaces.events.asyncpolling.SimpleAsyncPollingContainerConfigurer
-
- concurrentConsumers(int) - Method in class org.openspaces.events.polling.SimplePollingContainerConfigurer
-
- ConcurrentHashSet<E> - Class in org.openspaces.core.util
-
- ConcurrentHashSet() - Constructor for class org.openspaces.core.util.ConcurrentHashSet
-
Constructs a new, empty set; the backing HashMap instance has
default initial capacity (16) and load factor (0.75).
- ConcurrentMultiDataIterator - Class in org.openspaces.persistency.support
-
A simple implementation wrapping several iterators and exposing them as concurrent iterator using a
fixed size thread pool.
- ConcurrentMultiDataIterator(DataIterator[], int) - Constructor for class org.openspaces.persistency.support.ConcurrentMultiDataIterator
-
- config(Map<String, String>) - Method in class org.openspaces.admin.alert.AlertFactory
-
Set the configuration properties used to configure the alert bean.
- config - Variable in class org.openspaces.core.space.LeaderSelectorFactoryBean
-
- config - Variable in class org.openspaces.leader_selector.zookeeper.config.ZooKeeperLeaderSelectorFactoryBean
-
- CONFIG_PARAMETER - Static variable in class org.openspaces.pu.container.support.ConfigLocationParser
-
- ConfigLocationParser - Class in org.openspaces.pu.container.support
-
- ConfigLocationParser() - Constructor for class org.openspaces.pu.container.support.ConfigLocationParser
-
- configure() - Method in class com.gigaspaces.logger.RollingFileHandler
-
- configure(AlertConfiguration...) - Method in interface org.openspaces.admin.alert.AlertManager
-
Define an alert configuration for a 'bulk' of configurations.
- ConflictCause - Class in com.gigaspaces.cluster.replication.gateway.conflict
-
A base class for gateway conflicts.
- ConflictCause() - Constructor for class com.gigaspaces.cluster.replication.gateway.conflict.ConflictCause
-
- ConflictResolver - Class in com.gigaspaces.cluster.replication.gateway.conflict
-
A base class for a gateway replication Sink component conflict resolver.
- ConflictResolver() - Constructor for class com.gigaspaces.cluster.replication.gateway.conflict.ConflictResolver
-
- connect(String, Properties) - Method in class com.j_spaces.jdbc.driver.GDriver
-
- connectionPool - Variable in class org.openspaces.jdbc.datasource.DbcpBasicDataSource
-
The object pool that internally manages our connections.
- connectionProperties - Variable in class org.openspaces.jdbc.datasource.DbcpBasicDataSource
-
The connection properties that will be sent to our JDBC driver when
establishing new connections.
- connectionTimeout(long, TimeUnit) - Method in class org.openspaces.leader_selector.zookeeper.config.ZooKeeperLeaderSelectorConfigurer
-
- ConsistencyLevelViolationException - Exception in org.openspaces.core
-
Thrown when an operation is rejected since the ConsistencyLevel
for that operation cannot be maintained.
- ConsistencyLevelViolationException(ConsistencyLevelViolationException) - Constructor for exception org.openspaces.core.ConsistencyLevelViolationException
-
- ConsoleReporter - Class in com.gigaspaces.metrics.reporters
-
- ConsoleReporter(ConsoleReporterFactory) - Constructor for class com.gigaspaces.metrics.reporters.ConsoleReporter
-
- ConsoleReporterFactory - Class in com.gigaspaces.metrics.reporters
-
- ConsoleReporterFactory() - Constructor for class com.gigaspaces.metrics.reporters.ConsoleReporterFactory
-
- ConsolidatedDistributedTransactionMetaData - Interface in com.gigaspaces.transaction
-
Consolidated distributed transaction meta data representation.
- ConsolidationParticipantData - Interface in com.gigaspaces.sync
-
Contains the data of a single participant within a consolidated distributed transaction
- constants - Static variable in class org.openspaces.events.notify.SimpleNotifyEventListenerContainer
-
- constructHeader(MemcachedBinaryCommandDecoder.BinaryOp, ChannelBuffer, ChannelBuffer, ChannelBuffer, short, int, long) - Method in class org.openspaces.memcached.protocol.binary.MemcachedBinaryResponseEncoder
-
- constructorFor(Constructor<Object>) - Method in class org.openspaces.persistency.support.ProcedureCache
-
- CONSUMERS - Static variable in class org.openspaces.events.polling.PollingEventContainerServiceMonitors.Attributes
-
- CONTAINER - Static variable in class com.j_spaces.core.client.SpaceURL
-
Deprecated.
Container key which holds the container name taken from the space url string
- CONTAINER_CLASS_PROP - Static variable in class org.openspaces.pu.container.ProcessingUnitContainerProvider
-
- CONTAINER_NAME - Static variable in class com.j_spaces.kernel.SystemProperties
-
- CONTAINER_SHUTDOWN_HOOK - Static variable in class com.j_spaces.kernel.SystemProperties
-
- CONTAINER_SHUTDOWN_HOOK_DEFAULT_VALUE - Static variable in class com.j_spaces.kernel.SystemProperties
-
- ContainerNotDiscoveredException - Exception in org.openspaces.grid.gsm.containers.exceptions
-
- ContainerNotDiscoveredException(ProcessingUnit, GridServiceContainer) - Constructor for exception org.openspaces.grid.gsm.containers.exceptions.ContainerNotDiscoveredException
-
- containerProvisioningCompletedEvent() - Method in class org.openspaces.grid.gsm.strategy.AbstractScaleStrategyBean
-
- containerProvisioningInProgressEvent(ContainersSlaEnforcementInProgressException) - Method in class org.openspaces.grid.gsm.strategy.AbstractScaleStrategyBean
-
- ContainersSlaEnforcement - Class in org.openspaces.grid.gsm.containers
-
- ContainersSlaEnforcement(Admin) - Constructor for class org.openspaces.grid.gsm.containers.ContainersSlaEnforcement
-
- ContainersSlaEnforcementEndpoint - Interface in org.openspaces.grid.gsm.containers
-
A service that on demand enforces the specified number of containers.
- ContainersSlaEnforcementEndpointAware - Interface in org.openspaces.grid.gsm.containers
-
- ContainersSlaEnforcementInProgressException - Exception in org.openspaces.grid.gsm.containers.exceptions
-
- ContainersSlaEnforcementInProgressException(ProcessingUnit, String) - Constructor for exception org.openspaces.grid.gsm.containers.exceptions.ContainersSlaEnforcementInProgressException
-
- ContainersSlaEnforcementInProgressException(ProcessingUnit, String, Exception) - Constructor for exception org.openspaces.grid.gsm.containers.exceptions.ContainersSlaEnforcementInProgressException
-
- ContainersSlaEnforcementPendingProcessingUnitDeallocationException - Exception in org.openspaces.grid.gsm.containers.exceptions
-
- ContainersSlaEnforcementPendingProcessingUnitDeallocationException(ProcessingUnit, Collection<GridServiceContainer>) - Constructor for exception org.openspaces.grid.gsm.containers.exceptions.ContainersSlaEnforcementPendingProcessingUnitDeallocationException
-
- ContainersSlaPolicy - Class in org.openspaces.grid.gsm.containers
-
- ContainersSlaPolicy() - Constructor for class org.openspaces.grid.gsm.containers.ContainersSlaPolicy
-
- ContainersSlaUtils - Class in org.openspaces.grid.gsm.containers
-
- ContainersSlaUtils() - Constructor for class org.openspaces.grid.gsm.containers.ContainersSlaUtils
-
- contains(ChangeModifiers) - Method in class com.gigaspaces.client.ChangeModifiers
-
Checks if the specified modifier is set.
- contains(ClearModifiers) - Method in class com.gigaspaces.client.ClearModifiers
-
Checks if the specified modifier is set.
- contains(CountModifiers) - Method in class com.gigaspaces.client.CountModifiers
-
Checks if the specified modifier is set.
- contains(ReadModifiers) - Method in class com.gigaspaces.client.ReadModifiers
-
Checks if the specified modifier is set.
- contains(SpaceProxyOperationModifiers) - Method in class com.gigaspaces.client.SpaceProxyOperationModifiers
-
Checks if the specified modifier is set.
- contains(TakeModifiers) - Method in class com.gigaspaces.client.TakeModifiers
-
Checks if the specified modifier is set.
- contains(WriteModifiers) - Method in class com.gigaspaces.client.WriteModifiers
-
Checks if the specified modifier is set.
- contains(ProcessingUnitInstance) - Method in interface org.openspaces.admin.gsc.GridServiceContainer
-
Returns true
if the GSC contains the provided processing unit instance.
- contains(ProcessingUnitInstance) - Method in interface org.openspaces.admin.machine.Machine
-
Returns true
if the processing unit instance exists within the machine.
- contains(SpaceInstance) - Method in interface org.openspaces.admin.machine.Machine
-
Returns true
if the machine contains the provided space instance.
- contains(Object) - Method in class org.openspaces.core.util.ConcurrentHashSet
-
Returns true if this set contains the specified element.
- contains(Value, Value) - Method in class org.openspaces.jpa.openjpa.query.QueryExpressionFactory
-
Return an expression representing the given condition.
- CONTAINS_TOKEN - Static variable in class com.j_spaces.core.client.TemplateMatchCodes
-
Deprecated.
collection/array contains matching
- containsAll(Collection<?>) - Method in class org.openspaces.core.util.ConcurrentHashSet
-
- containsCause(Class<? extends Throwable>) - Method in exception com.j_spaces.core.multiple.BatchOperationException
-
- containsCustomAggregators(List<SpaceEntriesAggregator>) - Static method in class com.gigaspaces.query.aggregators.AggregationInternalUtils
-
- ContainsExpression - Class in org.openspaces.jpa.openjpa.query
-
Represents a JPQL contains (MEMBER OF) expression.
- ContainsExpression(Value, Value) - Constructor for class org.openspaces.jpa.openjpa.query.ContainsExpression
-
- containsKey(Object) - Method in class com.gigaspaces.document.DocumentProperties
- containsKey(Object) - Method in class com.j_spaces.core.admin.SpaceConfig
-
- containsKey(Object) - Method in class com.j_spaces.core.client.SpaceURL
-
Deprecated.
- containsKey(Object) - Method in interface com.j_spaces.javax.cache.Cache
-
Deprecated.
Returns true if the cache contains the specified key.
- containsKey(Object) - Method in class com.sun.jini.lease.AbstractLeaseMap
-
- containsKey(Object) - Method in class org.openspaces.core.DefaultGigaMap
-
- containsKey(Value, Value) - Method in class org.openspaces.jpa.openjpa.query.QueryExpressionFactory
-
Return an expression representing the given condition.
- containsProperty(String) - Method in class com.gigaspaces.document.SpaceDocument
- containsSource(String) - Method in interface org.openspaces.admin.gateway.GatewaySink
-
Returns true
if this sink has a source gateway with the specified name; false
otherwise.
- containsString(String) - Static method in class com.gigaspaces.log.LogEntryMatchers
-
- containsString(String, LogEntryMatcher) - Static method in class com.gigaspaces.log.LogEntryMatchers
-
- ContainsStringLogEntryMatcher - Class in com.gigaspaces.log
-
A matcher filter that will filter out all log entries that do not contain the provided
string.
- ContainsStringLogEntryMatcher(String) - Constructor for class com.gigaspaces.log.ContainsStringLogEntryMatcher
-
- ContainsStringLogEntryMatcher(String, LogEntryMatcher) - Constructor for class com.gigaspaces.log.ContainsStringLogEntryMatcher
-
- containsTarget(String) - Method in interface org.openspaces.admin.gateway.GatewayDelegator
-
Returns true
if this delegator has a target gateway with the specified name; false
otherwise.
- containsValue(Object) - Method in class com.gigaspaces.document.DocumentProperties
- containsValue(Object) - Method in interface com.j_spaces.javax.cache.Cache
-
Deprecated.
Returns true if this cache maps one or more keys to the specified value.
- containsValue(Object) - Method in class com.sun.jini.lease.AbstractLeaseMap
-
- containsValue(Object) - Method in class org.openspaces.core.DefaultGigaMap
-
- containsValue(Value, Value) - Method in class org.openspaces.jpa.openjpa.query.QueryExpressionFactory
-
Return an expression representing the given condition.
- ContentEncoder - Interface in com.gigaspaces.security.encoding
-
Interface for performing two-way encryption and decryption on objects.
- contents(Collection, Transaction, long, long) - Method in interface net.jini.space.JavaSpace05
-
Creates a
match set that can be used to
exhaustively read through all of the matching entries in
the space that are visible to the passed
Transaction
and remain visible for the lifetime of the
match set.
- CONTEXT - Static variable in class org.openspaces.core.transaction.manager.ExistingJiniTransactionManager
-
- CONTEXT_PROPERTY_DEPLOY_PATH - Static variable in class org.openspaces.pu.container.ProcessingUnitContainerProvider
-
- contextDestroyed(ServletContextEvent) - Method in class org.openspaces.pu.container.jee.context.BootstrapWebApplicationContextListener
-
- contextInitialized(ServletContextEvent) - Method in class org.openspaces.pu.container.jee.context.BootstrapWebApplicationContextListener
-
- ContextLoaderBeanDefinitionParser - Class in org.openspaces.core.config
-
- ContextLoaderBeanDefinitionParser() - Constructor for class org.openspaces.core.config.ContextLoaderBeanDefinitionParser
-
- CONTEXTPATH - Static variable in class org.openspaces.pu.container.jee.JeeServiceDetails.Attributes
-
- ContextPropertyConfig - Class in org.openspaces.admin.pu.config
-
- ContextPropertyConfig() - Constructor for class org.openspaces.admin.pu.config.ContextPropertyConfig
-
- ContinousQuery<T> - Class in com.j_spaces.core.client
-
- ContinousQuery() - Constructor for class com.j_spaces.core.client.ContinousQuery
-
Deprecated.
Empty constructor.
- ContinousQuery(String, String) - Constructor for class com.j_spaces.core.client.ContinousQuery
-
Deprecated.
Creates a ContinousQuery using the specified type and expression.
- ContinousQuery(String, String, QueryResultType) - Constructor for class com.j_spaces.core.client.ContinousQuery
-
Deprecated.
Creates a ContinousQuery using the specified type, expression and result type.
- ContinousQuery(String, String, Object...) - Constructor for class com.j_spaces.core.client.ContinousQuery
-
Deprecated.
Creates a ContinousQuery using the specified type, expression and parameters.
- ContinousQuery(String, String, QueryResultType, Object...) - Constructor for class com.j_spaces.core.client.ContinousQuery
-
Deprecated.
Creates a ContinousQuery using the specified type, expression, result type and parameters.
- ContinousQuery(Class<T>, String) - Constructor for class com.j_spaces.core.client.ContinousQuery
-
Deprecated.
Creates a ContinousQuery using the specified type and expression.
- ContinousQuery(Class<T>, String, QueryResultType) - Constructor for class com.j_spaces.core.client.ContinousQuery
-
Deprecated.
Creates a ContinousQuery using the specified type, expression and result type.
- ContinousQuery(Class<T>, String, Object...) - Constructor for class com.j_spaces.core.client.ContinousQuery
-
Deprecated.
Creates a ContinousQuery using the specified type, expression and parameters.
- ContinousQuery(Class<T>, String, QueryResultType, Object...) - Constructor for class com.j_spaces.core.client.ContinousQuery
-
Deprecated.
Creates a ContinousQuery using the specified type, expression, result type and parameters.
- continuous(LogEntryMatcher) - Static method in class com.gigaspaces.log.LogEntryMatchers
-
- continuous(LogEntryMatcher, LogEntryMatcher) - Static method in class com.gigaspaces.log.LogEntryMatchers
-
- ContinuousLogEntryMatcher - Class in com.gigaspaces.log
-
A reusable matcher (not thread safe) which accepts a matcher that returns the log entries for the
first call, and for any other call, a
AfterEntryLogEntryMatcher
will be
used with the last log entry returned.
- ContinuousLogEntryMatcher(LogEntryMatcher, LogEntryMatcher) - Constructor for class com.gigaspaces.log.ContinuousLogEntryMatcher
-
- convert(String, boolean) - Static method in class com.gigaspaces.security.authorities.SpaceAuthority.WildcardExpressionToFilterConverter
-
Convert the wildcard expression into a filter.
- convert(long, MemoryUnit) - Method in enum org.openspaces.core.util.MemoryUnit
-
Convert the given memory capacity in the given unit to this
unit.
- convert(String) - Method in enum org.openspaces.core.util.MemoryUnit
-
- convertAgentUidsToAgents(Iterable<String>, Admin) - Static method in class org.openspaces.grid.gsm.machines.MachinesSlaUtils
-
Converts the specified agent UUIDs into GridServiceAgent objects.
- convertAgentUidsToAgentsIfDiscovered(Iterable<String>, Admin) - Static method in class org.openspaces.grid.gsm.machines.MachinesSlaUtils
-
Converts the specified agent UUIDs into GridServiceAgent objects unless these agents are not discovered.
- convertClassLoaderURL(URL) - Method in class org.openspaces.pu.container.support.PUPathMatchingResourcePatternResolver
-
- convertCommandlineParameterToInstanceDeploymentDependencies(CommandLineParser.Parameter) - Static method in class org.openspaces.pu.container.support.RequiredDependenciesCommandLineParser
-
- convertCommandlineParameterToInstanceStartDependencies(CommandLineParser.Parameter) - Static method in class org.openspaces.pu.container.support.RequiredDependenciesCommandLineParser
-
- convertCpuCoresFromDoubleToFraction(double) - Static method in class org.openspaces.grid.gsm.capacity.CpuCapacityRequirement
-
- convertCpuCoresFromDoubleToFraction(double) - Static method in class org.openspaces.grid.gsm.machines.MachinesSlaUtils
-
- convertJiniException(Exception) - Method in class org.openspaces.core.transaction.manager.AbstractJiniTransactionManager
-
- convertPropertiesToMapStringString(Properties) - Static method in class org.openspaces.core.util.StringPropertiesUtils
-
- convertRequiredDependenciesToCommandLineParameter(String, RequiredDependencies) - Static method in class org.openspaces.pu.container.support.RequiredDependenciesCommandLineParser
-
- convertSpringToSpaceIsolationLevel(int, int) - Static method in class org.openspaces.core.IsolationLevelHelpers
-
- convertToGB(long) - Static method in class org.openspaces.admin.support.StatisticsUtils
-
- convertToKilobytes(long) - Static method in class org.openspaces.admin.support.StatisticsUtils
-
- convertToMB(long) - Static method in class org.openspaces.admin.support.StatisticsUtils
-
- convertToRegex(String, boolean) - Static method in class com.gigaspaces.security.authorities.SpaceAuthority.WildcardExpressionToFilterConverter
-
Convert the wildcard expression into a regex expression, since we found that
this is a faster implementation even for fully matched strings.
- cooldownAfterScaleIn(long, TimeUnit) - Method in class org.openspaces.admin.pu.elastic.config.AutomaticCapacityScaleConfigurer
-
- cooldownAfterScaleOut(long, TimeUnit) - Method in class org.openspaces.admin.pu.elastic.config.AutomaticCapacityScaleConfigurer
-
- copy() - Method in class org.openspaces.core.cluster.ClusterInfo
-
- copyParameters(DistributedTransactionProcessingConfiguration) - Method in class org.openspaces.core.gateway.GatewaySinkDistributedTransactionProcessingConfigurationFactoryBean
-
- copyToSinkConfiguration(LocalClusterReplicationSinkConfig) - Method in class org.openspaces.core.gateway.SinkErrorHandlingFactoryBean
-
- CoreNamespaceHandler - Class in org.openspaces.core.config
-
A Spring name space handler for OpenSpaces core package.
- CoreNamespaceHandler() - Constructor for class org.openspaces.core.config.CoreNamespaceHandler
-
- count(Object, Transaction) - Method in interface com.gigaspaces.client.IPojoSpace
-
- count(Object, Transaction, int) - Method in interface com.gigaspaces.client.IPojoSpace
-
- count() - Method in class com.gigaspaces.query.aggregators.AggregationSet
-
Counts matching entries.
- count(String) - Method in class com.gigaspaces.query.aggregators.AggregationSet
-
Counts matching entries whose path is not null.
- count(Object) - Method in class org.openspaces.core.DefaultGigaSpace
-
- count(Object, int) - Method in class org.openspaces.core.DefaultGigaSpace
-
- count(Object, CountModifiers) - Method in class org.openspaces.core.DefaultGigaSpace
-
- count(Object) - Method in interface org.openspaces.core.GigaSpace
-
Count any matching entry from the space.
- count(Object, int) - Method in interface org.openspaces.core.GigaSpace
-
- count(Object, CountModifiers) - Method in interface org.openspaces.core.GigaSpace
-
Count any matching entries from the space.
- count(GigaSpace, ISpaceQuery, String) - Static method in class org.openspaces.extensions.QueryExtension
-
- count() - Static method in class org.openspaces.extensions.QueryExtension
-
- count(String) - Static method in class org.openspaces.extensions.QueryExtension
-
- count(Value) - Method in class org.openspaces.jpa.openjpa.query.QueryExpressionFactory
-
Return the count of the given value for all matches.
- CountAggregator - Class in com.gigaspaces.query.aggregators
-
- CountAggregator() - Constructor for class com.gigaspaces.query.aggregators.CountAggregator
-
- CountModifierFactoryBean - Class in org.openspaces.core.config.modifiers
-
- CountModifierFactoryBean() - Constructor for class org.openspaces.core.config.modifiers.CountModifierFactoryBean
-
- CountModifiers - Class in com.gigaspaces.client
-
Provides modifiers to customize the behavior of count operations.
- CountModifiers() - Constructor for class com.gigaspaces.client.CountModifiers
-
Required for Externalizable
- CountModifiers(CountModifiers, CountModifiers) - Constructor for class com.gigaspaces.client.CountModifiers
-
Creates a new modifiers from the specified modifiers.
- CountModifiers(CountModifiers, CountModifiers, CountModifiers) - Constructor for class com.gigaspaces.client.CountModifiers
-
Creates a new modifiers from the specified modifiers.
- CountModifiers(CountModifiers...) - Constructor for class com.gigaspaces.client.CountModifiers
-
Creates a new modifiers from the specified modifiers.
- CPU_UTILIZATION - Static variable in class org.openspaces.admin.alert.alerts.CpuUtilizationAlert
-
- CPU_UTILIZATION - Static variable in class org.openspaces.admin.alert.alerts.GarbageCollectionAlert
-
- CPU_UTILIZATION - Static variable in class org.openspaces.admin.alert.alerts.HeapMemoryUtilizationAlert
-
- CPU_UTILIZATION - Static variable in class org.openspaces.admin.alert.alerts.PhysicalMemoryUtilizationAlert
-
- CPU_UTILIZATION - Static variable in class org.openspaces.admin.alert.alerts.ProcessingUnitInstanceMemberAliveIndicatorAlert
-
- CPU_UTILIZATION - Static variable in class org.openspaces.admin.alert.alerts.ReplicationRedoLogOverflowToDiskAlert
-
- CPU_UTILIZATION - Static variable in class org.openspaces.admin.alert.alerts.ReplicationRedoLogSizeAlert
-
- CpuCapacityRequirement - Class in org.openspaces.grid.gsm.capacity
-
- CpuCapacityRequirement() - Constructor for class org.openspaces.grid.gsm.capacity.CpuCapacityRequirement
-
- CpuCapacityRequirement(Fraction) - Constructor for class org.openspaces.grid.gsm.capacity.CpuCapacityRequirement
-
- CpuCapacityRequirement(double) - Constructor for class org.openspaces.grid.gsm.capacity.CpuCapacityRequirement
-
- CpuPercentageTimeWindowStatisticsConfig - Class in org.openspaces.admin.pu.statistics
-
Calculates the cpu percentage by dividing the total CPU values by delta time passed in milliseconds.
- CpuPercentageTimeWindowStatisticsConfig() - Constructor for class org.openspaces.admin.pu.statistics.CpuPercentageTimeWindowStatisticsConfig
-
- CpuPercentageTimeWindowStatisticsConfig(Map<String, String>) - Constructor for class org.openspaces.admin.pu.statistics.CpuPercentageTimeWindowStatisticsConfig
-
- CpuPercentageTimeWindowStatisticsConfigurer - Class in org.openspaces.admin.pu.statistics
-
- CpuPercentageTimeWindowStatisticsConfigurer() - Constructor for class org.openspaces.admin.pu.statistics.CpuPercentageTimeWindowStatisticsConfigurer
-
- CpuRequirement - Class in org.openspaces.pu.sla.requirement
-
- CpuRequirement() - Constructor for class org.openspaces.pu.sla.requirement.CpuRequirement
-
- CpuRequirementBeanDefinitionParser - Class in org.openspaces.pu.sla.config
-
- CpuRequirementBeanDefinitionParser() - Constructor for class org.openspaces.pu.sla.config.CpuRequirementBeanDefinitionParser
-
- CpuUtilizationAlert - Class in org.openspaces.admin.alert.alerts
-
A CPU Utilization alert fired upon triggered CPU thresholds.
- CpuUtilizationAlert() - Constructor for class org.openspaces.admin.alert.alerts.CpuUtilizationAlert
-
required by java.io.Externalizable
- CpuUtilizationAlert(Alert) - Constructor for class org.openspaces.admin.alert.alerts.CpuUtilizationAlert
-
- CpuUtilizationAlertConfiguration - Class in org.openspaces.admin.alert.config
-
A CPU utilization alert configuration.
- CpuUtilizationAlertConfiguration() - Constructor for class org.openspaces.admin.alert.config.CpuUtilizationAlertConfiguration
-
Constructs an empty machine CPU utilization alert configuration.
- CpuUtilizationAlertConfigurer - Class in org.openspaces.admin.alert.config
-
A CPU utilization alert configurer.
- CpuUtilizationAlertConfigurer() - Constructor for class org.openspaces.admin.alert.config.CpuUtilizationAlertConfigurer
-
Constructs an empty machine CPU utilization alert configuration.
- CrashCountException - Exception in net.jini.core.transaction.server
-
Exception thrown when a transaction cannot be joined because the
participant's current crash count is different from the crash
count the manager received in a previous join by that participant.
- CrashCountException(String) - Constructor for exception net.jini.core.transaction.server.CrashCountException
-
Constructs an instance with a detail message.
- CrashCountException() - Constructor for exception net.jini.core.transaction.server.CrashCountException
-
Constructs an instance with no detail message.
- create(AsyncFuture<T>[], AsyncResultsReducer<T, R>) - Static method in class com.gigaspaces.async.FutureFactory
-
- create(AsyncFuture<T>[], AsyncResultsReducer<T, R>, AsyncResultFilter<T>) - Static method in class com.gigaspaces.async.FutureFactory
-
- create(int) - Method in class com.gigaspaces.client.ChangeModifiers
-
- create(int) - Method in class com.gigaspaces.client.ClearModifiers
-
- create(int) - Method in class com.gigaspaces.client.CountModifiers
-
- create(int) - Method in class com.gigaspaces.client.ReadModifiers
-
- create(int) - Method in class com.gigaspaces.client.SpaceProxyOperationModifiers
-
- create(int) - Method in class com.gigaspaces.client.TakeModifiers
-
- create(int) - Method in class com.gigaspaces.client.WriteModifiers
-
- create() - Static method in class com.gigaspaces.config.lrmi.nio.NIOConfiguration
-
Creates a new instance of NIO configuration based on system properties.
- create() - Method in class com.gigaspaces.metadata.SpaceTypeDescriptorBuilder
-
Create the space type descriptor using the gathered information.
- create() - Method in class com.gigaspaces.metrics.MetricReporterFactory
-
Create a new metric reporter.
- create() - Method in class com.gigaspaces.metrics.reporters.ConsoleReporterFactory
-
- create(String) - Static method in class com.gigaspaces.security.AuthorityFactory
-
- create(Properties) - Method in class com.gigaspaces.security.directory.DefaultUserDetailsProvider
-
Deprecated.
- create(Properties) - Method in interface com.gigaspaces.security.directory.UserDetailsProvider
-
Deprecated.
Create a
UserDetails
instance using the provided properties.
- CREATE - Static variable in class com.j_spaces.core.client.SpaceURL
-
Deprecated.
java:// protocol support.
- create(long) - Method in class com.sun.jini.mahalo.TxnManagerImpl
-
- create(Object, long) - Method in class com.sun.jini.mahalo.TxnManagerImpl
-
- create(TxnManager, TxnManager, Uuid) - Static method in class com.sun.jini.mahalo.TxnMgrProxy
-
- create(long) - Method in class com.sun.jini.mahalo.TxnMgrProxy
-
- create(Object, long) - Method in class com.sun.jini.mahalo.TxnMgrProxy
-
- create(NestableTransactionManager, long) - Method in interface net.jini.core.transaction.NestableTransaction
-
Create a new nested transaction, with the current transaction as
parent, managed by the given transaction manager.
- create(long) - Method in interface net.jini.core.transaction.NestableTransaction
-
Create a new nested transaction, with the current transaction as
parent, managed by the same transaction manager as the current
transaction.
- create(Object, long) - Method in interface net.jini.core.transaction.server.ExtendedTransactionManager
-
- create(NestableTransactionManager, long) - Method in class net.jini.core.transaction.server.NestableServerTransaction
-
- create(long) - Method in class net.jini.core.transaction.server.NestableServerTransaction
-
- create(NestableTransactionManager, long, long) - Method in interface net.jini.core.transaction.server.NestableTransactionManager
-
Begin a nested transaction, with the specified transaction as parent.
- create(TransactionManager, long, long) - Static method in class net.jini.core.transaction.server.ServerTransaction
-
- create(long) - Method in interface net.jini.core.transaction.server.TransactionManager
-
Begin a new top-level transaction.
- create(TransactionManager, long) - Static method in class net.jini.core.transaction.TransactionFactory
-
Create a new top-level transaction.
- create(NestableTransactionManager, long) - Static method in class net.jini.core.transaction.TransactionFactory
-
Create a new top-level transaction, under which nested transactions
can be created.
- create() - Method in class org.openspaces.admin.AdminFactory
-
Creates the admin and begins its listening for events from the lookup service.
- create() - Method in class org.openspaces.admin.alert.AlertFactory
-
- create() - Method in class org.openspaces.admin.alert.config.CpuUtilizationAlertConfigurer
-
Get a fully configured machine CPU utilization configuration (after all properties have been set).
- create() - Method in class org.openspaces.admin.alert.config.GarbageCollectionAlertConfigurer
-
Get a fully configured garbage collection pause configuration (after all properties have been
set).
- create() - Method in class org.openspaces.admin.alert.config.HeapMemoryUtilizationAlertConfigurer
-
Get a fully configured heap memory utilization configuration (after all properties have been
set).
- create() - Method in class org.openspaces.admin.alert.config.MirrorPersistenceFailureAlertConfigurer
-
Get a fully configured replication channel disconnection configuration (after all properties have been set).
- create() - Method in class org.openspaces.admin.alert.config.PhysicalMemoryUtilizationAlertConfigurer
-
Get a fully configured physical memory utilization configuration (after all properties have been set).
- create() - Method in class org.openspaces.admin.alert.config.ProcessingUnitInstanceMemberAliveIndicatorAlertConfigurer
-
Get a fully configured fault-detection alert configuration (after all properties have been set).
- create() - Method in class org.openspaces.admin.alert.config.ProvisionFailureAlertConfigurer
-
Get a fully configured provision failure alert configuration (after all properties have been set).
- create() - Method in class org.openspaces.admin.alert.config.ReplicationChannelDisconnectedAlertConfigurer
-
Get a fully configured replication channel disconnection configuration (after all properties have been set).
- create() - Method in class org.openspaces.admin.alert.config.ReplicationRedoLogOverflowToDiskAlertConfigurer
-
Get a fully configured configuration (after all properties have been set).
- create() - Method in class org.openspaces.admin.alert.config.ReplicationRedoLogSizeAlertConfigurer
-
Get a fully configured configuration (after all properties have been set).
- create() - Method in class org.openspaces.admin.alert.config.SpacePartitionSplitBrainAlertConfigurer
-
Get a fully configured space partition split-brain alert configuration (after all properties have been set).
- create() - Method in class org.openspaces.admin.application.ApplicationDeployment
-
- create() - Method in class org.openspaces.admin.application.ApplicationFileDeployment
-
- create() - Method in interface org.openspaces.admin.bean.BeanConfigurer
-
Get the fully configured
BeanConfig
object (after all properties have been set).
- create() - Method in class org.openspaces.admin.memcached.MemcachedDeployment
-
- create() - Method in class org.openspaces.admin.pu.elastic.config.AutomaticCapacityScaleConfigurer
-
- create() - Method in class org.openspaces.admin.pu.elastic.config.AutomaticCapacityScaleRuleConfigurer
-
- create() - Method in class org.openspaces.admin.pu.elastic.config.CapacityRequirementsConfigurer
-
- create() - Method in class org.openspaces.admin.pu.elastic.config.DiscoveredMachineProvisioningConfigurer
-
- create() - Method in class org.openspaces.admin.pu.elastic.config.EagerScaleConfigurer
-
- create() - Method in class org.openspaces.admin.pu.elastic.config.ManualCapacityPerZonesScaleConfigurer
-
- create() - Method in class org.openspaces.admin.pu.elastic.config.ManualCapacityScaleConfigurer
-
- create() - Method in class org.openspaces.admin.pu.elastic.ElasticStatefulProcessingUnitDeployment
-
- create() - Method in class org.openspaces.admin.pu.elastic.ElasticStatelessProcessingUnitDeployment
-
- create() - Method in class org.openspaces.admin.pu.ProcessingUnitDeployment
-
- create() - Method in class org.openspaces.admin.pu.statistics.AverageTimeWindowStatisticsConfigurer
-
- create() - Method in class org.openspaces.admin.pu.statistics.CpuPercentageTimeWindowStatisticsConfigurer
-
- create() - Method in class org.openspaces.admin.pu.statistics.MaximumTimeWindowStatisticsConfigurer
-
- create() - Method in class org.openspaces.admin.pu.statistics.MinimumTimeWindowStatisticsConfigurer
-
- create() - Method in class org.openspaces.admin.pu.statistics.PercentileInstancesStatisticsConfigurer
-
- create() - Method in class org.openspaces.admin.pu.statistics.PercentileTimeWindowStatisticsConfigurer
-
- create() - Method in class org.openspaces.admin.pu.statistics.ProcessingUnitStatisticsIdConfigurer
-
- create() - Method in class org.openspaces.admin.pu.statistics.SingleInstanceStatisticsConfigurer
-
- create() - Method in class org.openspaces.admin.pu.statistics.ThroughputTimeWindowStatisticsConfigurer
-
- create() - Method in interface org.openspaces.admin.pu.topology.ProcessingUnitDeploymentTopology
-
Converts this fluent API object to a lazy implementation of ProcessingUnitConfig
- create() - Method in class org.openspaces.admin.space.ElasticSpaceDeployment
-
- create() - Method in class org.openspaces.admin.space.SpaceDeployment
-
- create() - Method in class org.openspaces.admin.zone.config.AtLeastOneZoneConfigurer
-
- create() - Method in class org.openspaces.admin.zone.config.ExactZonesConfigurer
-
- create() - Method in interface org.openspaces.admin.zone.config.ZonesConfigurer
-
- create() - Method in class org.openspaces.archive.ArchivePollingContainerConfigurer
-
- create(String, Map<String, String>, BeanServer<T>) - Method in interface org.openspaces.core.bean.BeanFactory
-
- create(String, Map<String, String>, BeanServer<T>) - Method in class org.openspaces.core.bean.DefaultBeanFactory
-
- create() - Method in class org.openspaces.core.GigaSpaceConfigurer
-
Creates a new
GigaSpace
instance if non already created.
- create() - Method in class org.openspaces.core.IteratorBuilder
-
Returns a new
GSIterator
based on the builder
configuration.
- create() - Method in class org.openspaces.core.space.AbstractSpaceConfigurer
-
- create() - Method in class org.openspaces.core.space.cache.LocalCacheSpaceConfigurer
-
Creates and returns a local cache according to the configured settings.
- create() - Method in class org.openspaces.core.space.cache.LocalViewSpaceConfigurer
-
Creates and returns a local cache according to the configured settings.
- create(AbstractSpaceFactoryBean, String) - Method in class org.openspaces.core.space.InternalSpaceFactory
-
- create(AbstractSpaceFactoryBean, String, boolean) - Method in class org.openspaces.core.space.InternalSpaceFactory
-
- create() - Method in class org.openspaces.core.space.UrlSpaceConfigurer
-
- create() - Method in class org.openspaces.events.asyncpolling.SimpleAsyncPollingContainerConfigurer
-
- create() - Method in class org.openspaces.events.notify.SimpleNotifyContainerConfigurer
-
- create() - Method in class org.openspaces.events.polling.SimplePollingContainerConfigurer
-
- create() - Method in class org.openspaces.grid.gsa.GridServiceAgentConfigurer
-
- create(String, ElasticMachineIsolationConfig) - Method in class org.openspaces.grid.gsm.machines.isolation.ElasticProcessingUnitMachineIsolationFactory
-
- create(ElasticMachineProvisioning) - Method in class org.openspaces.grid.gsm.machines.plugins.NonBlockingElasticMachineProvisioningAdapterFactory
-
- create() - Method in class org.openspaces.leader_selector.zookeeper.config.ZooKeeperLeaderSelectorConfigurer
-
- create() - Method in class org.openspaces.persistency.hibernate.CriteriaHibernateSpaceDataSourceConfigurer
-
- create() - Method in class org.openspaces.persistency.hibernate.DefaultHibernateSpaceDataSourceConfigurer
-
- create() - Method in class org.openspaces.persistency.hibernate.DefaultHibernateSpaceSynchronizationEndpointConfigurer
-
- create() - Method in class org.openspaces.persistency.hibernate.StatelessHibernateSpaceDataSourceConfigurer
-
- create() - Method in class org.openspaces.persistency.hibernate.StatelessHibernateSpaceSynchronizationEndpointConfigurer
-
- create() - Method in class org.openspaces.remoting.scripting.cache.BlockingQueueCompiledScriptPoolFactory
-
- create() - Method in interface org.openspaces.remoting.scripting.cache.CompiledScriptPoolFactory
-
- CREATE_JMX_CONNECTOR_PROP - Static variable in class com.j_spaces.kernel.SystemProperties
-
- createActualFreeMemoryInBytesGauge() - Method in class com.gigaspaces.metrics.factories.SigarMemoryMetricFactory
-
- createActualUsedMemoryInBytesGauge() - Method in class com.gigaspaces.metrics.factories.SigarMemoryMetricFactory
-
- createAdapter() - Method in class org.openspaces.events.config.AbstractResultEventAdapterFactoryBean
-
- createAdapter() - Method in class org.openspaces.events.config.AnnotationEventAdapterFactoryBean
-
- createAdapter() - Method in class org.openspaces.events.config.MethodEventAdapterFactoryBean
-
- createAdmin() - Method in class org.openspaces.admin.AdminFactory
-
Creates the admin and begins its listening for events from the lookup service.
- createAuthenticationRequest(UserDetails) - Method in class org.openspaces.security.spring.SpringSecurityManager
-
- createBeanFactory() - Method in class org.openspaces.pu.container.jee.context.ProcessingUnitWebApplicationContext
-
Creates a new bean factory by delegating to the super bean factory creation and then adding
all the registered
BeanPostProcessor
s.
- createBeanFactory() - Method in class org.openspaces.pu.container.support.ResourceApplicationContext
-
Creates a new bean factory by delegating to the super bean factory creation and then adding
all the registered
BeanPostProcessor
s.
- createBeanMetricManager(String) - Method in class org.openspaces.pu.container.ProcessingUnitContainerContext
-
Creates a bean metric manager using the specified name.
- createByClassOrFindByName(ApplicationContext, String, Class) - Static method in class org.openspaces.remoting.RemotingUtils
-
- createCache(IDirectSpaceProxy) - Method in class org.openspaces.core.space.cache.AbstractLocalCacheSpaceFactoryBean
-
- createCache(IDirectSpaceProxy) - Method in class org.openspaces.core.space.cache.LocalCacheSpaceFactoryBean
-
Creates the local cache.
- createCache(IDirectSpaceProxy) - Method in class org.openspaces.core.space.cache.LocalViewSpaceFactoryBean
-
Creates the local view
- createCGCountGauge() - Method in class com.gigaspaces.metrics.factories.JvmMemoryMetricFactory
-
- createClientFilter(InetSocketAddress) - Method in class com.gigaspaces.lrmi.nio.filters.IOStreamCompressionFilterFactory
-
- createClientFilter(InetSocketAddress) - Method in class com.gigaspaces.lrmi.nio.filters.SSLFilterFactory
-
- createCompoundIndex(String[]) - Static method in class com.gigaspaces.metadata.index.SpaceIndexFactory
-
- createCompoundIndex(String[], SpaceIndexType, String, boolean) - Static method in class com.gigaspaces.metadata.index.SpaceIndexFactory
-
Creates a space compound index from the specified paths with the specified index type.
- createContainer() - Method in class org.openspaces.interop.DotnetProcessingUnitContainerProvider
-
- createContainer(String[]) - Static method in class org.openspaces.pu.container.integrated.IntegratedProcessingUnitContainer
-
- createContainer() - Method in class org.openspaces.pu.container.integrated.IntegratedProcessingUnitContainerProvider
-
- createContainer() - Method in class org.openspaces.pu.container.ProcessingUnitContainerProvider
-
Creates a processing unit container.
- createContainer(String[]) - Static method in class org.openspaces.pu.container.standalone.StandaloneProcessingUnitContainer
-
- createContainer() - Method in class org.openspaces.pu.container.standalone.StandaloneProcessingUnitContainerProvider
-
- createContainerEntityManagerFactory(PersistenceUnitInfo, Map) - Method in class org.openspaces.jpa.OpenSpacesPersistenceProvider
-
- createContextLoader() - Method in class org.openspaces.pu.container.jee.context.ProcessingUnitContextLoaderListener
-
- createCopy(SecurityContext) - Method in class com.j_spaces.core.SpaceContext
-
- createCopy() - Method in class net.jini.core.transaction.server.ServerTransaction
-
- createCursor() - Method in class org.openspaces.persistency.hibernate.iterator.AbstractScrollableDataIterator
-
- createCursor() - Method in class org.openspaces.persistency.hibernate.iterator.DefaultScrollableDataIterator
-
- createCursor() - Method in class org.openspaces.persistency.hibernate.iterator.StatelessScrollableDataIterator
-
- Created(NestableTransaction, Lease) - Constructor for class net.jini.core.transaction.NestableTransaction.Created
-
Simple constructor.
- Created(long, Lease) - Constructor for class net.jini.core.transaction.server.TransactionManager.Created
-
Simple constructor.
- Created(Transaction, Lease) - Constructor for class net.jini.core.transaction.Transaction.Created
-
Simple constructor.
- createDaemonThreadCountGauge() - Method in class com.gigaspaces.metrics.factories.JvmThreadMetricFactory
-
- createDataSource() - Method in class org.openspaces.jdbc.datasource.DbcpBasicDataSource
-
Create (if necessary) and return the internal data source we are
using to manage our connections.
- createDefaultTaskExecutor() - Method in class org.openspaces.events.polling.SimplePollingEventListenerContainer
-
Create a default TaskExecutor.
- createDirectoryManager(UserDetails) - Method in interface com.gigaspaces.security.SecurityManager
-
Attempts to authenticate the passed user represented by
UserDetails
, granting access
only for users that are allowed to manage the directory.
- createDirectoryManager(UserDetails) - Method in class org.openspaces.security.spring.SpringSecurityManager
-
- createEndpoint(ProcessingUnit) - Method in class org.openspaces.grid.gsm.autoscaling.AutoScalingSlaEnforcement
-
- createEndpoint(ProcessingUnit) - Method in class org.openspaces.grid.gsm.containers.ContainersSlaEnforcement
-
- createEndpoint(ProcessingUnit) - Method in class org.openspaces.grid.gsm.machines.MachinesSlaEnforcement
-
- createEndpoint(ProcessingUnit) - Method in class org.openspaces.grid.gsm.rebalancing.RebalancingSlaEnforcement
-
- createEndpoint(ProcessingUnit) - Method in interface org.openspaces.grid.gsm.sla.ServiceLevelAgreementEnforcement
-
Creates a new endpoint for the specified pu, if one does not already exist.
- createEntityManagerFactory(String, IJSpace, Map) - Method in class org.openspaces.jpa.OpenSpacesPersistenceProvider
-
Creates an EntityManagerFactory
instance and injects the provided space instance to it.
- createEntityManagerFactory(String, IJSpace) - Method in class org.openspaces.jpa.OpenSpacesPersistenceProvider
-
Creates an EntityManagerFactory
instance and injects the provided space instance to it.
- createEntityManagerFactory(String, Map) - Method in class org.openspaces.jpa.OpenSpacesPersistenceProvider
-
- createEntry(Object, Object, long, int) - Method in interface com.j_spaces.javax.cache.EvictionStrategy
-
Deprecated.
Creates new CacheEntry for the Cache and probably saves the entry in the
internal structures.
- createEntry() - Method in interface org.openspaces.remoting.SpaceRemotingEntryFactory
-
- createEntry() - Method in class org.openspaces.remoting.SpaceRemotingEntryMetadataFactory
-
Deprecated.
- createEntry() - Method in class org.openspaces.remoting.SpaceRemotingEntryPojoFactory
-
- createEventSessionConfig() - Method in class org.openspaces.events.notify.SimpleNotifyEventListenerContainer
-
Creates a new
EventSessionConfig
based on the different
parameters this container accepts.
- CreateException - Exception in com.j_spaces.core
-
A CreateException is thrown if an attempt to create a new space fails.
- CreateException() - Constructor for exception com.j_spaces.core.CreateException
-
Constructs a CreateException
with
null
as its error detail message.
- CreateException(String) - Constructor for exception com.j_spaces.core.CreateException
-
Constructs a CreateException
with the
specified detail message.
- CreateException(String, Throwable) - Constructor for exception com.j_spaces.core.CreateException
-
- createFileObject(String) - Method in class org.openspaces.pu.container.servicegrid.deploy.HTTPFileSystemView
-
- createFileObject(File, String) - Method in class org.openspaces.pu.container.servicegrid.deploy.HTTPFileSystemView
-
Returns a File object constructed in dir from the given filename.
- createFilter() - Method in class com.gigaspaces.lrmi.nio.filters.IOStreamCompressionFilterFactory
-
- createFreeMemoryInBytesGauge() - Method in class com.gigaspaces.metrics.factories.SigarMemoryMetricFactory
-
- createFreeSwapInBytesGauge() - Method in class com.gigaspaces.metrics.factories.SigarSwapMetricFactory
-
- createGCCollectionTimeGauge() - Method in class com.gigaspaces.metrics.factories.JvmMemoryMetricFactory
-
- createGSXid(Xid) - Method in class com.j_spaces.core.client.XAResourceImpl
-
- createHashEntry() - Method in interface org.openspaces.remoting.SpaceRemotingEntryFactory
-
- createHashEntry() - Method in class org.openspaces.remoting.SpaceRemotingEntryMetadataFactory
-
Deprecated.
- createHashEntry() - Method in class org.openspaces.remoting.SpaceRemotingEntryPojoFactory
-
- createHeapCommittedInBytesGauge() - Method in class com.gigaspaces.metrics.factories.JvmMemoryMetricFactory
-
- createHeapUsedInBytesGauge() - Method in class com.gigaspaces.metrics.factories.JvmMemoryMetricFactory
-
- createIfNeeded(int) - Method in class com.gigaspaces.client.SpaceProxyOperationModifiers
-
- createInitialLoadIterator(DataIterator[]) - Method in class org.openspaces.persistency.hibernate.AbstractHibernateExternalDataSource
-
Deprecated.
- createInitialLoadIterator(DataIterator[]) - Method in class org.openspaces.persistency.hibernate.AbstractHibernateSpaceDataSource
-
A helper method that creates the initial load iterator using the
ConcurrentMultiDataIterator
with the provided
#setInitialLoadThreadPoolSize(int)
thread pool size.
- createInitialLoadQuery(SpaceTypeDescriptor, String) - Method in class org.openspaces.persistency.ClusterInfoAwareSpaceDataSource
-
- createInstance() - Method in class net.jini.core.transaction.server.ServerTransaction
-
- createInstance(String, Map<String, String>, BeanServer<T>) - Method in class org.openspaces.core.bean.DefaultBeanFactory
-
- createInstance() - Method in class org.openspaces.core.jini.JiniServiceFactoryBean
-
Creates an instance of the service.
- createInstance(String, Map<String, String>, BeanServer<Bean>) - Method in class org.openspaces.grid.gsm.ScaleBeanFactory
-
- createIterator() - Method in class org.openspaces.persistency.hibernate.iterator.DefaultCriteriaByExampleDataIterator
-
- createIterator() - Method in class org.openspaces.persistency.hibernate.iterator.DefaultListQueryDataIterator
-
- createIterator(Query) - Method in class org.openspaces.persistency.hibernate.iterator.DefaultListQueryDataIterator
-
- createIterator() - Method in class org.openspaces.persistency.hibernate.iterator.StatelessListQueryDataIterator
-
- createIteratorByEntityName(String, SessionFactory, int, boolean, int, int) - Method in class org.openspaces.persistency.hibernate.iterator.AbstractChunkDataIterator
-
- createIteratorByEntityName(String, SessionFactory, int, boolean, int, int) - Method in class org.openspaces.persistency.hibernate.iterator.DefaultChunkListDataIterator
-
- createIteratorByEntityName(String, SessionFactory, int, boolean, int, int) - Method in class org.openspaces.persistency.hibernate.iterator.DefaultChunkScrollableDataIterator
-
- createIteratorByEntityName(String, SessionFactory, int, boolean, int, int) - Method in class org.openspaces.persistency.hibernate.iterator.StatelessChunkListDataIterator
-
- createIteratorByEntityName(String, SessionFactory, int, boolean, int, int) - Method in class org.openspaces.persistency.hibernate.iterator.StatelessChunkScrollableDataIterator
-
- createIteratorByHibernateQuery(String, SessionFactory, int, int, int) - Method in class org.openspaces.persistency.hibernate.iterator.AbstractChunkDataIterator
-
- createIteratorByHibernateQuery(String, SessionFactory, int, int, int) - Method in class org.openspaces.persistency.hibernate.iterator.DefaultChunkListDataIterator
-
- createIteratorByHibernateQuery(String, SessionFactory, int, int, int) - Method in class org.openspaces.persistency.hibernate.iterator.DefaultChunkScrollableDataIterator
-
- createIteratorByHibernateQuery(String, SessionFactory, int, int, int) - Method in class org.openspaces.persistency.hibernate.iterator.StatelessChunkListDataIterator
-
- createIteratorByHibernateQuery(String, SessionFactory, int, int, int) - Method in class org.openspaces.persistency.hibernate.iterator.StatelessChunkScrollableDataIterator
-
- createIteratorBySQLQuery(SQLQuery, SessionFactory, int, boolean, int, int) - Method in class org.openspaces.persistency.hibernate.iterator.AbstractChunkDataIterator
-
- createIteratorBySQLQuery(SQLQuery, SessionFactory, int, boolean, int, int) - Method in class org.openspaces.persistency.hibernate.iterator.DefaultChunkListDataIterator
-
- createIteratorBySQLQuery(SQLQuery, SessionFactory, int, boolean, int, int) - Method in class org.openspaces.persistency.hibernate.iterator.DefaultChunkScrollableDataIterator
-
- createIteratorBySQLQuery(SQLQuery, SessionFactory, int, boolean, int, int) - Method in class org.openspaces.persistency.hibernate.iterator.StatelessChunkListDataIterator
-
- createIteratorBySQLQuery(SQLQuery, SessionFactory, int, boolean, int, int) - Method in class org.openspaces.persistency.hibernate.iterator.StatelessChunkScrollableDataIterator
-
- createLeaseMap(long) - Method in interface net.jini.core.lease.Lease
-
Creates a Map object that can contain leases whose renewal or
cancellation can be batched, and adds the current lease to that map.