| Package | Description | 
|---|---|
| com.gigaspaces.client | Deprecated: use  org.openspaces.coreinstead. | 
| com.gigaspaces.client.transaction | |
| com.gigaspaces.cluster.replication | |
| com.gigaspaces.events | Provides GigaSpaces events related interfaces. | 
| com.gigaspaces.events.batching | |
| com.gigaspaces.executor | |
| com.gigaspaces.internal.client.cache | |
| com.gigaspaces.internal.client.cache.localcache | |
| com.gigaspaces.internal.client.cache.localview | |
| com.gigaspaces.internal.client.spaceproxy | |
| com.gigaspaces.internal.client.spaceproxy.events | |
| com.gigaspaces.internal.client.spaceproxy.executors | |
| com.gigaspaces.internal.client.spaceproxy.operations | |
| com.gigaspaces.internal.cluster.node.impl.packets.data.filters | |
| com.gigaspaces.internal.events.durable | |
| com.gigaspaces.internal.jms | |
| com.gigaspaces.internal.lrmi.stubs | |
| com.gigaspaces.internal.server.space | |
| com.gigaspaces.internal.server.storage | |
| com.gigaspaces.proxy_pool | |
| com.gigaspaces.security.service | |
| com.gigaspaces.server.filter | |
| com.j_spaces.core | Provides Space properties and security context services | 
| com.j_spaces.core.admin | Provides GigaSpaces administration services | 
| com.j_spaces.core.client | Provides GigaSpaces client interface services | 
| com.j_spaces.core.client.cache.map | |
| com.j_spaces.core.client.lus | |
| com.j_spaces.core.cluster | Provides GigaSpaces cluster plug-in interfaces | 
| com.j_spaces.core.filters | Provides GigaSpaces filter plug-in interfaces. | 
| com.j_spaces.core.filters.entry | Provides GigaSpaces filter plug-in interfaces. | 
| com.j_spaces.jdbc | Provides GigaSpaces JDBC interfaces | 
| com.j_spaces.jdbc.builder | |
| com.j_spaces.jdbc.driver | Provides GigaSpaces JDBC interfaces | 
| com.j_spaces.jms | Provides GigaSpaces J2EE Java Messaging Service Interface | 
| com.j_spaces.jms.utils | Provides GigaSpaces Java Messaging Service. | 
| com.j_spaces.jmx | |
| com.j_spaces.kernel | Provides GigaSpaces low level services | 
| com.j_spaces.map | Provides GigaSpaces MAP API | 
| com.j_spaces.sadapter.cache | |
| com.j_spaces.worker | Deprecated: use   org.openspaces.puinstead. | 
| org.openspaces.admin.internal.space | Internally Used. | 
| org.openspaces.core | Top level core package holding main OpenSpaces API for Space (GigaSpace) and Map (GigaMap) and
the ability to create it. | 
| org.openspaces.core.cluster | Cluster information holder objects and abstraction allowing for custom
beans to be injected with it (if set). | 
| org.openspaces.core.executor.internal | |
| org.openspaces.core.map | A package including factory beans to create GigaSpaces IMap or JCache Cache based on an
IJSpace instance. | 
| org.openspaces.core.space | This package is responsible for simplifying the creation of IJSpace implementation. | 
| org.openspaces.core.space.cache | A package allowing for simpler creation of Local Cache and Local View (expose an IJSpace) based
on an actual IJSpace instance (usually created using the core.space package). | 
| org.openspaces.core.space.filter | A package allowing to simplify the injection of an actual ISpaceFilter instance during
Space creation. | 
| org.openspaces.core.space.mode | A package exposing Space mode (primary/backup) events through Spring application event
support. | 
| org.openspaces.core.space.status | |
| org.openspaces.core.transaction | A package exposing the ability to get a GigaSpaces/Jini current transaction (integrating with
Spring transaction management). | 
| org.openspaces.core.transaction.manager | Jini and Local transaction managers using Spring abstraction for transaction managers
(PlatformTransactionManager). | 
| org.openspaces.core.util | A package including utility classes for OpenSpaces core. | 
| org.openspaces.esb.mule.transaction | |
| org.openspaces.jdbc.datasource | Implementations of Jdbc DataSource interface using GigaSpaces support for Jdbc based on an
actual IJSpace or GigaSpace implementation. | 
| org.openspaces.pu.container.servicegrid | A Service Grid based processing unit container. | 
| Modifier and Type | Method and Description | 
|---|---|
| IJSpace | DirectSpaceProxyFactory. createSpaceProxy() | 
| Modifier and Type | Method and Description | 
|---|---|
| TransactionManager | TransactionManagersMap. get(IJSpace space) | 
| static ITransactionManagerProvider | TransactionManagerProviderFactory. newInstance(IJSpace space,
           TransactionManagerConfiguration transactionManagerConfiguration) | 
| void | TransactionManagersMap. put(IJSpace space,
   TransactionManager transactionManager) | 
| void | TransactionManagersMap. remove(IJSpace space) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | ReplicationFilterWrapper. init(IJSpace space,
    String paramUrl,
    ReplicationPolicy replicationPolicy) | 
| Constructor and Description | 
|---|
| ReplicationFilterManager(ReplicationPolicy replPolicy,
                        SpaceURL spaceURL,
                        IJSpace spaceProxy) | 
| Modifier and Type | Method and Description | 
|---|---|
| IJSpace | EventSession. getSpace() | 
| IJSpace | AbstractDataEventSession. getSpace() | 
| Modifier and Type | Method and Description | 
|---|---|
| static DataEventSession | DataEventSessionFactory. create(IJSpace space,
      EventSessionConfig config) | 
| static EventSessionFactory | EventSessionFactory. getFactory(IJSpace space)Deprecated.  Retrieves the EventSessionFactory according to the space. | 
| static DataEventSession | EventSessionFactory. newDataSession(IJSpace space)Deprecated.  creates a new  DataEventSessionusing the specified space and default configuration. | 
| static DataEventSession | EventSessionFactory. newDataSession(IJSpace space,
              EventSessionConfig config)Deprecated.  creates a new  DataEventSessionusing the specified space and configuration. | 
| Constructor and Description | 
|---|
| AbstractDataEventSession(IJSpace space,
                        EventSessionConfig config) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | BatchRemoteEvent. setSpaceProxy(IJSpace spaceProxy)Used internally to set the proxy for all the events | 
| Modifier and Type | Method and Description | 
|---|---|
| T | SpaceTask. execute(IJSpace space,
       Transaction tx) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractSpaceCacheContainer | 
| Modifier and Type | Method and Description | 
|---|---|
| IJSpace | ISpaceCache. getRemoteSpace()Returns a direct proxy to the remote space. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | LocalCacheContainer | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | LocalViewContainer | 
| Modifier and Type | Interface and Description | 
|---|---|
| interface  | IDirectSpaceProxyA direct space proxy working on an actual space. | 
| interface  | ISpaceProxyA space proxy that extends the  IJSpaceinterface. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractDirectSpaceProxyTitle: Description: | 
| class  | AbstractSpaceProxyA common base class for most space proxies. | 
| class  | SpaceProxyImplProvides the functionality of clustered proxy. | 
| Modifier and Type | Method and Description | 
|---|---|
| IJSpace | IDirectSpaceProxy. getClusteredProxy()Returns a clustered view of this proxy. | 
| IJSpace | SpaceProxyImpl. getClusteredProxy() | 
| IJSpace | IDirectSpaceProxy. getNonClusteredProxy()Returns a proxy of the specified space. | 
| IJSpace | SpaceProxyImpl. getNonClusteredProxy() | 
| Constructor and Description | 
|---|
| SpaceProxyDataEventListener(RemoteEventListener listener,
                           ExecutorService threadPool,
                           IJSpace space,
                           GenericExporter exporter) | 
| Modifier and Type | Method and Description | 
|---|---|
| T | SystemTask. execute(IJSpace spaceProxy,
       Transaction tx) | 
| AddTypeIndexesResult | AddTypeIndexesTask. execute(IJSpace space,
       Transaction tx) | 
| Modifier and Type | Method and Description | 
|---|---|
| AggregationResult | AggregateEntriesSpaceOperationRequest. getFinalResult(IJSpace spaceProxy,
              ITemplatePacket queryPacket,
              boolean returnEntryPacket) | 
| Modifier and Type | Method and Description | 
|---|---|
| Object | ReplicationFilterUidDataWrapper. getObject(IJSpace space) | 
| Object | ReplicationFilterEntryDataWrapper. getObject(IJSpace space) | 
| Constructor and Description | 
|---|
| DurableUnicastDelegatorSession(IJSpace space,
                              EventSessionConfig config) | 
| Modifier and Type | Method and Description | 
|---|---|
| abstract Closeable | JmsFactory. createLookupManager(String containerName,
                   IJSpace spaceProxy,
                   Context internalContext,
                   Context externalContext) | 
| Modifier and Type | Method and Description | 
|---|---|
| SpaceCopyStatus | LRMISpaceImpl. spaceCopy(IJSpace remoteSpace,
         Object template,
         boolean includeNotifyTemplates,
         int chunkSize) | 
| Modifier and Type | Method and Description | 
|---|---|
| IJSpace | SpaceImpl. getSpaceProxy()Return the internal instance of space proxy. | 
| protected IJSpace | SpaceImpl. getTaskProxy() | 
| Modifier and Type | Method and Description | 
|---|---|
| SpaceCopyStatus | SpaceImpl. spaceCopy(IJSpace remoteSpace,
         Object template,
         boolean includeNotifyTemplates,
         int chunkSize) | 
| Modifier and Type | Method and Description | 
|---|---|
| RemoteEvent | NotifyTemplateHolder. createRemoteEvent(IEntryHolder entryHolder,
                 IEntryHolder oldEntryHolder,
                 NotifyActionType notifyType,
                 OperationID operationID,
                 IJSpace spaceProxy,
                 boolean fromReplication) | 
| RemoteEvent | NotifyTemplateHolder. createRemoteEvent(IEntryHolder entryHolder,
                 NotifyActionType notifyType,
                 OperationID operationID,
                 IJSpace spaceProxy,
                 boolean fromReplication) | 
| Modifier and Type | Method and Description | 
|---|---|
| GConnection | SpaceProxyPoolFactory. createClonedProxy(IJSpace space,
                 Properties props) | 
| GConnection | SpaceProxyPool. getOrCreate(IJSpace ijSpace,
           String sessionId,
           Properties props)Get connection for specific sessionId. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | SecurityInterceptor. trustProxy(IJSpace proxy)Internal (VM) trust mechanism; acquires a trusted token and sets the internal proxy. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | NotifyAcknowledgeFilter. init(IJSpace space,
    String filterId,
    String url,
    int priority) | 
| Modifier and Type | Method and Description | 
|---|---|
| IJSpace | JSpaceContainerImpl. createSpace(String spaceName,
           JSpaceAttributes spaceAttr)Creates JSpace with unique space-name in this container and write the created space to
 appropriate Storage Adapter. | 
| IJSpace | IJSpaceContainer. getClusteredSpace(String spaceName)Deprecated.  | 
| IJSpace | LRMIJSpaceContainer. getClusteredSpace(String spaceName) | 
| IJSpace | JSpaceContainerImpl. getClusteredSpace(String spaceName) | 
| IJSpace | JSpaceContainerImpl.ContainerEntry. getClusteredSpaceProxy() | 
| IJSpace | JSpaceContainerImpl.ContainerEntry. getNonClusteredSpaceProxy() | 
| IJSpace | IJSpaceContainer. getSpace(String spaceName)Deprecated.  | 
| IJSpace | LRMIJSpaceContainer. getSpace(String spaceName) | 
| IJSpace | JSpaceContainerImpl. getSpace(String spaceName) | 
| Modifier and Type | Method and Description | 
|---|---|
| Entry | EntryImpl. getEntry(IJSpace space) | 
| Object | IGSEntry. getObject(IJSpace space)Converts to object. | 
| Object | AbstractEntryType. getObject(IJSpace space)Converts to object. | 
| void | LookupManager. register(IJSpace spaceProxy,
        String containerName)Registering forever proxy of JSpace with all Lookup services that exists in the Network. | 
| Modifier and Type | Method and Description | 
|---|---|
| IJSpace | JSpaceAdminProxy. getSpace()return the defined spaceProxy for this spaceAdmin,  nullif setSpace hasn't never
 invoked | 
| Modifier and Type | Method and Description | 
|---|---|
| void | JSpaceAdminProxy. setSpace(IJSpace space)set space proxy for this Admin proxy, useally calls by IJSpace.getAdmin() method | 
| SpaceCopyStatus | IRemoteJSpaceAdmin. spaceCopy(IJSpace remoteSpace,
         Object template,
         boolean includeNotifyTemplates,
         int chunkSize) | 
| SpaceCopyStatus | JSpaceAdminProxy. spaceCopy(IJSpace remoteProxy,
         Object template,
         boolean includeNotifyTemplates,
         int chunkSize) | 
| SpaceCopyStatus | JSpaceAdminImpl. spaceCopy(IJSpace remoteSpace,
         Object template,
         boolean includeNotifyTemplates,
         int chunkSize) | 
| Modifier and Type | Field and Description | 
|---|---|
| protected IJSpace | EntryArrivedRemoteEvent. _spaceProxy | 
| Modifier and Type | Method and Description | 
|---|---|
| Entry | ExternalEntry. getEntry(IJSpace space)Deprecated.  | 
| Object | ExternalEntry. getObject(IJSpace space)Deprecated.  Converts to object. | 
| void | INotifyDelegatorFilter. init(IJSpace space,
    Object notifyTemplate)Called inside of server on Notify Filter init. | 
| void | SpaceURL. setPropertiesForSpaceProxy(IJSpace spaceProxy)Deprecated.  Set SpaceURL properties for desired space proxy. | 
| void | EntryArrivedRemoteEvent. setSpaceProxy(IJSpace spaceProxy) | 
| Constructor and Description | 
|---|
| EntryArrivedRemoteEvent(IJSpace source,
                       long eventID,
                       long seqNum,
                       MarshalledObject handback,
                       IEntryPacket entryPacket,
                       IEntryPacket oldEntryPacket,
                       NotifyActionType notifyType,
                       boolean fromReplication,
                       String templateUID,
                       QueryResultTypeInternal resultType)/** This constructor is reserved for internal usage only. | 
| GSIterator(IJSpace spaceProxy,
          Collection<?> templates)Deprecated.  Equivalent to calling  GSIterator.GSIterator(IJSpace, Collection, com.gigaspaces.client.iterator.GSIteratorConfig). | 
| GSIterator(IJSpace spaceProxy,
          Collection<?> templates,
          GSIteratorConfig config)Deprecated.  Constructs an iterator over a space using a collection of entity instances to be
 incrementally returned. | 
| GSIterator(IJSpace spaceProxy,
          Collection<?> templates,
          int bufferSize,
          boolean withHistory,
          long leaseDuration)Deprecated. 
 | 
| JSpaceProxyWrapper(IJSpace spaceProxy) | 
| NotifyDelegator(IJSpace space,
               Object template,
               long lease,
               NotifyInfo info)Deprecated.  | 
| XAResourceImpl(TransactionManager txnManger,
              IJSpace proxy) | 
| XAResourceImpl(TransactionManager txnManger,
              IJSpace proxy,
              boolean delegatedXa,
              boolean resourcePerSingleTxn)Ctor | 
| Constructor and Description | 
|---|
| MapCache(IJSpace space,
        boolean isVersioned,
        int updateMode,
        EvictionStrategy evictionStrategy,
        boolean putFirst,
        int sizeLimit,
        int compression)Constructor. | 
| Modifier and Type | Method and Description | 
|---|---|
| abstract void | AbstractServiceDiscoveryListener. serviceAdded(String fullName,
            IJSpace space,
            ServiceID id)This method is called if the event is relevant according to the parameters provided in the
 constructor. | 
| abstract void | AbstractServiceDiscoveryListener. serviceChanged(String fullName,
              IJSpace space,
              ServiceID id)This method is called if the event is relevant according to the parameters provided in the
 constructor. | 
| abstract void | AbstractServiceDiscoveryListener. serviceRemoved(String fullName,
              IJSpace space,
              ServiceID id)This method is called if the event is relevant according to the parameters provided in the
 constructor. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | IReplicationFilter. init(IJSpace space,
    String paramUrl,
    ReplicationPolicy replicationPolicy)Initializes this filter. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | PhantomObjectsFilter. init(IJSpace space,
    String paramUrl,
    ReplicationPolicy replicationPolicy) | 
| void | ISpaceFilter. init(IJSpace space,
    String filterId,
    String url,
    int priority)Initializes this filter. | 
| void | JSpaceStatistics. init(IJSpace space,
    String filterId,
    String url,
    int priority) | 
| Constructor and Description | 
|---|
| FilterManager(SpaceTypeManager typeManager,
             IJSpace space,
             SpaceEngine engine) | 
| Modifier and Type | Method and Description | 
|---|---|
| Entry | SpaceUpdateFilterEntryImpl. getEntry(IJSpace space) | 
| Entry | ExecutionFilterEntry. getEntry(IJSpace space)Deprecated.  | 
| Object | ExecutionFilterEntry. getObject(IJSpace space) | 
| Modifier and Type | Method and Description | 
|---|---|
| static IQueryResultSet<IEntryPacket> | AggregationsUtil. aggregate(QueryTemplatePacket template,
         AggregationSet aggregationSet,
         IJSpace space,
         Transaction txn,
         int modifiers)Execute aggregation query | 
| static ITypeDesc | SQLUtil. checkTableExistence(String tableName,
                   IJSpace space)Checks if given table (class name) exists in space | 
| ResultEntry | IProcedure. execute(Connection connection,
       IJSpace space,
       ArrayList paramList)Deprecated.  The execute method should include the business logic to be invoked at the server side | 
| ArrayList<IEntryPacket> | DeleteQuery. executeExclusiveReadLock(QueryTemplatePacket template,
                        IJSpace space,
                        Transaction txn,
                        int max,
                        int modifiers) | 
| static IRemoteJSpaceAdmin | SQLUtil. getAdmin(IJSpace space)Get this space admin | 
| static IQueryProcessor | QueryProcessorFactory. newInstance(IJSpace proxy,
           IRemoteSpace remoteSpace,
           Properties config)Creates local or remote QP according to configuration | 
| static IQueryProcessor | QueryProcessorFactory. newLocalInstance(IJSpace clusterProxy,
                IJSpace spaceProxy,
                Properties connectionProperties,
                SecurityInterceptor securityInterceptor)Create new QueryProcessor instance using the connection properties and the qp.properties | 
| Constructor and Description | 
|---|
| QueryHandler(IJSpace spaceCluster,
            IJSpace spaceRegular,
            QueryProcessorConfiguration config,
            SecurityInterceptor securityInterceptor) | 
| QueryProcessor(IJSpace clusterProxy,
              IJSpace spaceProxy,
              Properties overrideProperties,
              SecurityInterceptor securityInterceptor) | 
| Modifier and Type | Method and Description | 
|---|---|
| ArrayList<IEntryPacket> | QueryTemplatePacket. take(IJSpace space,
    Object routing,
    AbstractProjectionTemplate projectionTemplate,
    Transaction txn,
    long timeout,
    int modifiers,
    boolean ifExists,
    int maxResults,
    int minEntriesToWaitFor,
    QueryResultTypeInternal resultType) | 
| Modifier and Type | Method and Description | 
|---|---|
| static GConnection | GConnection. getInstance(IJSpace space) | 
| static GConnection | GConnection. getInstance(IJSpace space,
           Properties properties) | 
| static Connection | GConnection. getInstance(IJSpace space,
           String username,
           String password) | 
| Constructor and Description | 
|---|
| GConnection(IJSpace space,
           Properties properties) | 
| Modifier and Type | Method and Description | 
|---|---|
| protected IJSpace | GSConnectionFactoryImpl. getSpace() | 
| Modifier and Type | Method and Description | 
|---|---|
| Object | GSJmsFactory. createConnectionFactory(IJSpace spaceProxy) | 
| Closeable | GSJmsFactory. createLookupManager(String containerName,
                   IJSpace spaceProxy,
                   Context internalContext,
                   Context externalContext) | 
| Object | GSJmsFactory. createQueueConnectionFactory(IJSpace spaceProxy) | 
| Object | GSJmsFactory. createTopicConnectionFactory(IJSpace spaceProxy) | 
| Object | GSJmsFactory. createXAQueueConnectionFactory(IJSpace spaceProxy) | 
| Object | GSJmsFactory. createXATopicConnectionFactory(IJSpace spaceProxy) | 
| void | DurableServiceWorkerImpl. init(IJSpace proxy,
    String workerName,
    String arg) | 
| Constructor and Description | 
|---|
| GSConnectionFactoryImpl(IJSpace space,
                       IMessageConverter messageConverter) | 
| GsJmsLookupManager(String containerName,
                  IJSpace spaceProxy,
                  GSJmsFactory jmsFactory,
                  Context internalJndiContext,
                  Context externalJndiContext) | 
| GSQueueConnectionFactoryImpl(IJSpace space,
                            IMessageConverter messageConverter)Constructs a  GSQueueConnectionFactoryImpl. | 
| GSTopicConnectionFactoryImpl(IJSpace space,
                            IMessageConverter messageConverter)Constructs an  GSTopicConnectionFactoryImpl. | 
| GSXAConnectionFactoryImpl(IJSpace space,
                         IMessageConverter messageConverter) | 
| GSXAQueueConnectionFactoryImpl(IJSpace space,
                              IMessageConverter messageConverter) | 
| GSXATopicConnectionFactoryImpl(IJSpace space,
                              IMessageConverter messageConverter) | 
| JMSDurableSubService(IJSpace space) | 
| Modifier and Type | Method and Description | 
|---|---|
| javax.jms.ConnectionFactory | GSJMSAdmin. getConnectionFactory(IJSpace space) | 
| javax.jms.ConnectionFactory | GSJMSAdmin. getConnectionFactory(IJSpace space,
                    IMessageConverter messageConverter)Returns a  ConnectionFactorythat works with the specified space proxy. | 
| javax.jms.QueueConnectionFactory | GSJMSAdmin. getQueueConnectionFactory(IJSpace space) | 
| javax.jms.QueueConnectionFactory | GSJMSAdmin. getQueueConnectionFactory(IJSpace space,
                         IMessageConverter messageConverter)Returns a  QueueConnectionFactorythat works with the specified space proxy. | 
| javax.jms.TopicConnectionFactory | GSJMSAdmin. getTopicConnectionFactory(IJSpace space) | 
| javax.jms.TopicConnectionFactory | GSJMSAdmin. getTopicConnectionFactory(IJSpace space,
                         IMessageConverter messageConverter)Returns a  TopicConnectionFactorythat works with the specified space proxy. | 
| javax.jms.XAConnectionFactory | GSJMSAdmin. getXAConnectionFactory(IJSpace space) | 
| javax.jms.XAConnectionFactory | GSJMSAdmin. getXAConnectionFactory(IJSpace space,
                      IMessageConverter messageConverter)Returns a  XAConnectionFactorythat works with the specified space proxy. | 
| javax.jms.XAQueueConnectionFactory | GSJMSAdmin. getXAQueueConnectionFactory(IJSpace space) | 
| javax.jms.XAQueueConnectionFactory | GSJMSAdmin. getXAQueueConnectionFactory(IJSpace space,
                           IMessageConverter messageConverter)Returns a  XAQueueConnectionFactorythat works with the specified space proxy. | 
| javax.jms.XATopicConnectionFactory | GSJMSAdmin. getXATopicConnectionFactory(IJSpace space) | 
| javax.jms.XATopicConnectionFactory | GSJMSAdmin. getXATopicConnectionFactory(IJSpace space,
                           IMessageConverter messageConverter)Returns a  XATopicConnectionFactorythat works with the specified space proxy. | 
| Modifier and Type | Method and Description | 
|---|---|
| IJSpace | JMXSpace. getSpace()Return the JavaSpace object | 
| Modifier and Type | Method and Description | 
|---|---|
| Entry | TemplateImpl. getEntry(IJSpace space)Deprecated.  | 
| Object | TemplateImpl. getObject(IJSpace space) | 
| Constructor and Description | 
|---|
| JMXSpace(IJSpace remoteSpaceProxy,
        String xmlDescriptorsFileURL) | 
| JMXSpaceExt(IJSpace spaceProxy,
           SpaceConfig spaceConfig,
           String xmlDescriptorsFileURL) | 
| Modifier and Type | Method and Description | 
|---|---|
| static Object | JSpaceUtilities. getObjectFromSpaceByUid(IJSpace spaceProxy,
                       String uid) | 
| static ServiceID | JSpaceUtilities. getSpaceServiceID(IJSpace space) | 
| Modifier and Type | Method and Description | 
|---|---|
| IJSpace | AbstractMap. getLocalSpace()Returns the Local Space proxy if exists. | 
| IJSpace | IMap. getLocalSpace()Returns the Local Space proxy if exists. | 
| IJSpace | AbstractMap. getMasterSpace()Returns the Master Space proxy. | 
| IJSpace | IMap. getMasterSpace()Returns the Master Space proxy. | 
| Modifier and Type | Method and Description | 
|---|---|
| static IMap | MapFactory. createMap(IJSpace space) | 
| static IMap | MapFactory. createMapWithCache(IJSpace space,
                  Integer updateMode) | 
| static void | MapEntryFactory. initialize(IJSpace space) | 
| Constructor and Description | 
|---|
| AbstractMap(IJSpace space,
           long timeToLive,
           Transaction txn,
           int compression,
           boolean isVersioned)AbstractMap constructor. | 
| GSMapImpl(IJSpace space)GSMap constructor. | 
| GSMapImpl(IJSpace space,
         int compress)GSMap constructor. | 
| GSMapImpl(IJSpace space,
         long timeToLive)GSMap constructor. | 
| GSMapImpl(IJSpace space,
         long timeToLive,
         Transaction txn,
         int compress)GSMapImpl constructor. | 
| GSMapImpl(IJSpace space,
         Transaction txn)GSMap constructor. | 
| Modifier and Type | Method and Description | 
|---|---|
| Entry | CacheEntry. getEntry(IJSpace space) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | IWorker. init(IJSpace proxy,
    String workerName,
    String arg)Deprecated.  This method will be called on space initialization. | 
| void | IPrivilegeWorker. init(IJSpace proxy,
    String workerName,
    String arg)Deprecated.  This method will be called on space initialization. | 
| Constructor and Description | 
|---|
| WorkerManager(IJSpace workerProxy,
             String fullSpaceName)Deprecated.  | 
| Modifier and Type | Method and Description | 
|---|---|
| IJSpace | DefaultSpaceInstance. getIJSpace() | 
| IJSpace | DefaultSpace. getIJSpace() | 
| IJSpace | InternalSpaceInstance. getIJSpace() | 
| Constructor and Description | 
|---|
| DefaultSpaceInstance(ServiceID serviceID,
                    IJSpace directSpace,
                    IInternalRemoteJSpaceAdmin spaceAdmin,
                    InternalAdmin admin,
                    JVMDetails jvmDetails) | 
| Modifier and Type | Method and Description | 
|---|---|
| IJSpace | GigaSpaceConfigurer. getSpace() | 
| IJSpace | DefaultGigaSpace. getSpace() | 
| IJSpace | GigaSpace. getSpace()Returns the  IJSpaceused by this GigaSpace implementation to delegate different
 space operations. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | GigaSpaceFactoryBean. setSpace(IJSpace space)Sets the space that will be used by the created  GigaSpace. | 
| protected void | GigaSpaceConfigurer. space(IJSpace space)For internal usage only | 
| Constructor and Description | 
|---|
| GigaSpaceConfigurer(IJSpace space)Constructs a new configurer based on the Space. | 
| Constructor and Description | 
|---|
| SpaceMemberAliveIndicator(IJSpace spaceProxy,
                         Boolean enabled) | 
| Modifier and Type | Method and Description | 
|---|---|
| T | InternalSpaceTaskWrapper. execute(IJSpace space,
       Transaction tx) | 
| Modifier and Type | Method and Description | 
|---|---|
| protected IJSpace | MapFactoryBean. getSpace() | 
| Modifier and Type | Method and Description | 
|---|---|
| void | MapFactoryBean. setSpace(IJSpace space)Sets the Space the Map will be built on top. | 
| Constructor and Description | 
|---|
| MapConfigurer(IJSpace space) | 
| Modifier and Type | Method and Description | 
|---|---|
| IJSpace | AbstractSpaceConfigurer. create() | 
| IJSpace | UrlSpaceConfigurer. create()Creates or finds (if not already created) a new Space by calling  AbstractSpaceFactoryBean.afterPropertiesSet(). | 
| IJSpace | InternalSpaceFactory. create(AbstractSpaceFactoryBean spaceFactoryBean,
      String url) | 
| IJSpace | InternalSpaceFactory. create(AbstractSpaceFactoryBean spaceFactoryBean,
      String name,
      boolean isRemote) | 
| protected IJSpace | EmbeddedSpaceConfigurer. createSpace() | 
| protected IJSpace | SpaceProxyConfigurer. createSpace() | 
| protected abstract IJSpace | AbstractSpaceConfigurer. createSpace() | 
| protected IJSpace | SpaceProxyFactoryBean. doCreateSpace() | 
| protected IJSpace | EmbeddedSpaceFactoryBean. doCreateSpace() | 
| protected IJSpace | DirectSpaceFactoryBean. doCreateSpace()Returns the space provided in the constructor. | 
| protected abstract IJSpace | AbstractSpaceFactoryBean. doCreateSpace()Responsible for creating/finding the actual  IJSpaceimplementation. | 
| protected IJSpace | UrlSpaceFactoryBean. doCreateSpace()Creates the space. | 
| IJSpace | AbstractSpaceConfigurer. space() | 
| IJSpace | SpaceConfigurer. space() | 
| IJSpace | UrlSpaceConfigurer. space()Creates or finds (if not already created) a new Space by calling  AbstractSpaceFactoryBean.afterPropertiesSet(). | 
| Modifier and Type | Method and Description | 
|---|---|
| Class<? extends IJSpace> | AbstractSpaceFactoryBean. getObjectType()Returns the object type of the factory bean. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | ExecutorSpaceFilter. init(IJSpace space,
    String filterId,
    String url,
    int priority) | 
| Constructor and Description | 
|---|
| DirectSpaceFactoryBean(IJSpace space)Constucts a new direct space factory using the provided space. | 
| SpaceServiceDetails(IJSpace space) | 
| SpaceServiceDetails(String id,
                   IJSpace space) | 
| Modifier and Type | Method and Description | 
|---|---|
| IJSpace | LocalViewSpaceConfigurer. create()Creates and returns a local cache according to the configured settings. | 
| IJSpace | LocalCacheSpaceConfigurer. create()Creates and returns a local cache according to the configured settings. | 
| IJSpace | LocalCacheSpaceConfigurer. localCache() | 
| IJSpace | LocalViewSpaceConfigurer. localView() | 
| IJSpace | LocalViewSpaceConfigurer. space() | 
| IJSpace | LocalCacheSpaceConfigurer. space() | 
| Modifier and Type | Method and Description | 
|---|---|
| Class<? extends IJSpace> | LocalViewSpaceFactoryBean. getObjectType()Returns the type of the factory object. | 
| Class<? extends IJSpace> | LocalCacheSpaceFactoryBean. getObjectType()Returns the type of the factory object. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | LocalViewSpaceFactoryBean. setSpace(IJSpace space)Sets the master space that a local cache will be built on top. | 
| void | LocalCacheSpaceFactoryBean. setSpace(IJSpace space)Sets the master space that a local cache will be built on top. | 
| Constructor and Description | 
|---|
| LocalCacheSpaceConfigurer(IJSpace space) | 
| LocalViewSpaceConfigurer(IJSpace space) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | FilterOperationDelegate. init(IJSpace space,
    String filterId,
    String url,
    int priority)If  initMethodis supplied, will invoke it. | 
| Modifier and Type | Method and Description | 
|---|---|
| IJSpace | AbstractSpaceModeChangeEvent. getSpace()Returns the space that initiated this event. | 
| Constructor and Description | 
|---|
| AbstractSpaceModeChangeEvent(IJSpace space,
                            SpaceMode spaceMode)Creates a new Space mode event. | 
| AfterSpaceModeChangeEvent(IJSpace space,
                         SpaceMode spaceMode)Creates a new after space mode event. | 
| BeforeSpaceModeChangeEvent(IJSpace space,
                          SpaceMode spaceMode)Creates a new before space mode event. | 
| Constructor and Description | 
|---|
| SpaceStatusChangedEvent(IJSpace space,
                       SuspendType suspendType,
                       SpaceMode spaceMode)Creates a new Space status changed event that occurred when a space change his  SuspendTypeorSpaceMode | 
| Modifier and Type | Method and Description | 
|---|---|
| Transaction.Created | TransactionProvider. getCurrentTransaction(Object transactionalContext,
                     IJSpace space)Returns the currently running transaction (usually managed externally/declarative). | 
| Transaction.Created | DefaultTransactionProvider. getCurrentTransaction(Object transactionalContext,
                     IJSpace space)Returns the current running transaction based on the constructor provided transactional
 context (Note that the passed transactional context is not used). | 
| Constructor and Description | 
|---|
| DefaultTransactionProvider(IJSpace space,
                          Object actualTransactionalContext,
                          org.springframework.transaction.PlatformTransactionManager transactionManager)Creates a new transaction provider. | 
| DefaultTransactionProvider(IJSpace space,
                          org.springframework.transaction.PlatformTransactionManager transactionManager) | 
| Constructor and Description | 
|---|
| LocalJiniTxManagerConfigurer(IJSpace space)Deprecated.  | 
| Modifier and Type | Method and Description | 
|---|---|
| static IJSpace | SpaceUtils. getClusterMemberSpace(IJSpace space)Returns a proxy space to the specified space name. | 
| Modifier and Type | Method and Description | 
|---|---|
| static IJSpace | SpaceUtils. getClusterMemberSpace(IJSpace space)Returns a proxy space to the specified space name. | 
| static boolean | SpaceUtils. isRemoteProtocol(IJSpace space)Returns  trueif the Space uses a remote protocol. | 
| static boolean | SpaceUtils. isSameSpace(IJSpace space1,
           IJSpace space2) | 
| Modifier and Type | Method and Description | 
|---|---|
| Transaction.Created | MuleXATransactionProvider. getCurrentTransaction(Object transactionalContext,
                     IJSpace space) | 
| Constructor and Description | 
|---|
| MuleXATransactionProvider(IJSpace space) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | SpaceDriverManagerDataSource. setSpace(IJSpace space) | 
| Constructor and Description | 
|---|
| SpaceDriverManagerDataSource(IJSpace space) | 
| Modifier and Type | Method and Description | 
|---|---|
| IJSpace | PUServiceBeanProxy. getSpaceDirect(ServiceID serviceID) | 
| IJSpace | PUServiceBeanImpl. getSpaceDirect(ServiceID serviceID) | 
| IJSpace | PUServiceBean. getSpaceDirect(ServiceID serviceID) | 
Copyright © GigaSpaces.