public class SpaceEngine extends Object implements ISpaceModeListener, IClusterInfoChangedListener
| Modifier and Type | Class and Description | 
|---|---|
| static class  | SpaceEngine.EntryRemoveReasonCodeswhy is entry removed. | 
| static class  | SpaceEngine.TemplateRemoveReasonCodeswhy is entry removed. | 
| Constructor and Description | 
|---|
| SpaceEngine(SpaceImpl spaceImpl) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | abort(TransactionManager mgr,
     ServerTransaction st,
     boolean supportsTwoPhaseReplication,
     OperationID operationID) | 
| void | abortSA(TransactionManager mgr,
       ServerTransaction st,
       boolean fromLeaseExpiration,
       boolean verifyExpiredXtn,
       boolean supportsTwoPhaseReplication,
       OperationID operationID) | 
| void | afterClusterInfoChange(SpaceClusterInfo clusterInfo)Updates server side components that holds SpaceClusterInfo instances when SpaceClusterInfo changes (i.e horizontal scale event) | 
| void | afterSpaceModeChange(SpaceMode newMode)Called right after the space mode changes. | 
| AnswerHolder | aggregate(ITemplatePacket queryPacket,
         List<SpaceEntriesAggregator> aggregators,
         int readModifiers,
         SpaceContext sc) | 
| protected void | attachFromGatewayStateToTransactionIfNeeded(SpaceContext sc,
                                           XtnEntry txnEntry) | 
| XtnEntry | attachToXtn(ServerTransaction txn,
           boolean fromReplication)Join the specified transaction, if not already joined. | 
| void | beforeAuthentication(SecurityContext securityContext)Invokes the "before-authentication" filter. | 
| void | beforeSpaceModeChange(SpaceMode newMode)Called right before the space mode changes. Implementors usually use it to allow specific service initializations. | 
| ExtendedAnswerHolder | change(ITemplatePacket template,
      Transaction txn,
      long lease,
      long timeout,
      SpaceContext sc,
      boolean fromReplication,
      boolean origin,
      Collection<SpaceEntryMutator> mutators,
      int operationModifiers,
      boolean returnOnlyUid)perform an update in place using mutators | 
| void | checkWFValidityAfterUpdate(Context context,
                          IEntryHolder entry)update performed for an entry under xtn, if there are templates wf this entry, is there any
 use to keep on waiting (i.e. | 
| Pair<Integer,SingleExplainPlan> | clear(ITemplatePacket template,
     Transaction txn,
     SpaceContext sc,
     int operationModifiers) | 
| void | clearDataTypeMetricRegistrarIfExists(String dataTypeName) | 
| void | clearDataTypeMetricRegistrarIfExists(String typeName,
                                    String indexName) | 
| void | close()Closes engine, including all working groups and contexts. | 
| void | closeServerIterator(UUID uuid) | 
| void | commit(TransactionManager mgr,
      ServerTransaction st,
      boolean supportsTwoPhaseReplication,
      OperationID operationID,
      boolean mayBeFromReplication) | 
| Pair<Integer,SingleExplainPlan> | count(ITemplatePacket template,
     Transaction txn,
     SpaceContext sc,
     int operationModifiers) | 
| int | countIncomingConnections() | 
| int | countTransactions(int type,
                 int status) | 
| String | createTransactionDetailsString(ServerTransaction st,
                              OperationID operationID) | 
| String | createUIDFromCounter() | 
| Object | directLocalReadById(Object id,
                   String typeName,
                   QueryResultTypeInternal queryResultType)For local reads without xtn and timeout, used only in local cache, only with object reference
 mode | 
| void | dropClass(String className)Drop all Class entries and all its templates from the space. | 
| void | enableDuplicateExecutionProtection(OperationID operationID) | 
| void | executeOnMatchingEntries(Context context,
                        ITemplateHolder template,
                        boolean makeWaitForInfo)Searches the engine for a matching entry using the BFS tree of the specified template. | 
| MetricRegistrator | extendSpaceMetricRegistrator(String prefix,
                            Map<String,String> extraTags,
                            Map<String,DynamicMetricTag> extraDynamicTags) | 
| String | generateGroupName() | 
| String | generateUid() | 
| void | getAdmin(SpaceContext sc)check authority to get admin. | 
| CacheManager | getCacheManager() | 
| ITypeDesc | getClassTypeInfo(String className)get the basic class info from the space directory. | 
| ITypeDesc | getClassTypeInfo(String className,
                boolean asVirtualType) | 
| SpaceClusterInfo | getClusterInfo() | 
| ClusterPolicy | getClusterPolicy() | 
| List<ISpaceComponentsHandler> | getComponentsHandlers()get the list of component handlers | 
| SpaceConfigReader | getConfigReader() | 
| ConflictingOperationPolicy | getConflictingOperationPolicy() | 
| MetricRegistrator | getDataTypeMetricRegistrar(String dataTypeName) | 
| MetricRegistrator | getDataTypeMetricRegistrar(String typeName,
                          String indexName) | 
| EntryArrivedPacketsFactory | getEntryArrivedPacketsFactory() | 
| EntryDataType | getEntryDataType() | 
| FifoGroupsHandler | getFifoGroupsHandler() | 
| FilterManager | getFilterManager() | 
| String | getFullSpaceName() | 
| List<FilterProvider> | getInternalFilters()Returns a list of internal filters that should be used by the FilterManager | 
| ServerIteratorsManager | getIteratorsManager() | 
| long | getLastEntryTimestamp() | 
| LeaseManager | getLeaseManager() | 
| LocalViewRegistrations | getLocalViewRegistrations() | 
| List<UnderTxnLockedObject> | getLockedObjects(Transaction txn)getLockedObjects returns Info about all the locked Object by the given Transaction. | 
| org.slf4j.Logger | getLogger() | 
| IEntryHolder | getMatchedEntryAndOperateSA(Context context,
                           ITemplateHolder template,
                           boolean makeWaitForInfo,
                           boolean useSCN)Searches the engine for a matching entry using the BFS tree of the specified template. | 
| MemoryManager | getMemoryManager() | 
| MetricManager | getMetricManager() | 
| MetricRegistrator | getMetricRegistrator() | 
| Map<String,Object> | getMetricsSnapshotByPrefix(Collection<String> prefixes) | 
| int | getNotifierQueueSize() | 
| int | getNumberOfPartitions() | 
| org.slf4j.Logger | getOperationLogger() | 
| int | getPartitionIdOneBased()gets the number of this space in the partition. | 
| int | getPartitionIdZeroBased() | 
| PartitionRoutingInfo | getPartitionRoutingInfo() | 
| int | getProcessorQueueSize() | 
| WorkingGroup<BusPacket<Processor>> | getProcessorWG() | 
| SpaceReplicationManager | getReplicationManager() | 
| IReplicationNode | getReplicationNode() | 
| SpaceRuntimeInfo | getRuntimeInfo()Returns the runtime information for all objects in space | 
| SpaceRuntimeInfo | getRuntimeInfo(String typeName)Returns the runtime information for a given class and its subclasses | 
| SpaceImpl | getSpaceImpl() | 
| String | getSpaceName() | 
| TemplateScanner | getTemplateScanner() | 
| List<TemplateInfo> | getTemplatesInfo(String className) | 
| TieredStorageManager | getTieredStorageManager() | 
| XtnEntry | getTransaction(ServerTransaction st) | 
| TransactionHandler | getTransactionHandler() | 
| TransactionInfo[] | getTransactionsInfo(int type,
                   int status)Returns all the transactions that have the type and status. | 
| SpaceTypeManager | getTypeManager() | 
| IServerTypeDesc | getTypeTableEntry(String className) | 
| List<Throwable> | getUnhealthyReasons() | 
| protected void | handleExceptionOnPrepare(TransactionManager mgr,
                        ServerTransaction st,
                        boolean supportsTwoPhaseReplication,
                        XtnEntry xtnEntry) | 
| boolean | hasMirror() | 
| boolean | indicateDirtyRead(ITemplateHolder template)given an entry and a template, return true if dirty-read should be performed | 
| void | init(boolean loadDataFromDB,
    boolean considerMemoryRecovery) | 
| void | invokeFilters(SpaceContext sc,
             int operationCode,
             Object subject) | 
| boolean | isBlobStorePersistent() | 
| boolean | isCleanUnusedEmbeddedGlobalXtns() | 
| boolean | isClusteredExternalDBEnabled(IStorageAdapter storageAdapter) | 
| boolean | isColdStart() | 
| boolean | isEntryFromPartition(IEntryHolder entryHolder)return true if entry belongs to the partition of the space, false if entry is not from space
 partition | 
| boolean | isExpiredEntryStayInSpace(IEntryHolder entry) | 
| boolean | isFailOverDuringRecovery() | 
| boolean | isLocalCache() | 
| boolean | isMemoryRecoveryEnabled() | 
| boolean | isMirrorService() | 
| boolean | isNonBlockingReadForOperation(ITemplateHolder tHolder) | 
| boolean | isNoWriteLease(IEntryPacket entryPacket,
              int modifiers,
              boolean fromReplication) | 
| boolean | isPartitionedSpace()return true if space is part of a partitioned cluster | 
| boolean | isReplicated() | 
| boolean | isReplicatedPersistentBlobstore() | 
| boolean | isSyncReplicationEnabled()is sync-replication enabled for at least one member in a clustered space. | 
| AnswerHolder | newAdaptUpdateMultiple(IEntryPacket[] entries,
                      Transaction txn,
                      long lease,
                      long[] leases,
                      SpaceContext sc,
                      long timeout,
                      int modifiers) | 
| AnswerHolder | newUpdateMultiple(IEntryPacket[] entries,
                 Transaction txn,
                 long[] leases,
                 SpaceContext sc,
                 long timeout,
                 int operationModifiers)perform update of multiple entries. | 
| GSEventRegistration | notify(ITemplatePacket template,
      long lease,
      boolean fromReplication,
      String templateUid,
      SpaceContext sc,
      NotifyInfo info) | 
| WriteEntriesResult | oldAdaptUpdateMultiple(IEntryPacket[] entries,
                      Transaction txn,
                      long lease,
                      long[] leases,
                      SpaceContext sc,
                      int modifiers,
                      boolean newRouter) | 
| int | performReplication(Context context)perform  sync replication from sync-packets list or a single sync-packet contained in the
 context. | 
| void | performTemplateOnEntrySA(Context context,
                        ITemplateHolder template,
                        IEntryHolder entry,
                        boolean makeWaitForInfo)try to process an entry , if the entry has a shadow try it too if the entry don't  suite | 
| int | prepare(TransactionManager mgr,
       ServerTransaction st,
       boolean singleParticipant,
       boolean supportsTwoPhaseReplication,
       OperationID operationID) | 
| int | prepareAndCommit(TransactionManager mgr,
                ServerTransaction st,
                OperationID operationID)Prepare and commit the transaction - called for single participant transaction or transaction
 without changes | 
| AnswerHolder | read(ITemplatePacket template,
    Transaction txn,
    long timeout,
    boolean ifExists,
    boolean take,
    SpaceContext sc,
    boolean returnOnlyUid,
    boolean fromReplication,
    boolean origin,
    int operationModifiers) | 
| AnswerHolder | readMultiple(ITemplatePacket template,
            Transaction txn,
            long timeout,
            boolean ifExists,
            boolean take,
            SpaceContext sc,
            boolean returnOnlyUid,
            int operationModifiers,
            BatchQueryOperationContext batchOperationContext,
            List<SpaceEntriesAggregator> aggregators,
            ServerIteratorRequestInfo serverIteratorRequestInfo) | 
| void | registerLocalView(ITemplatePacket[] queryPackets,
                 Collection<SpaceQueryDetails> queryDescriptions,
                 RouterStubHolder viewStub,
                 int batchSize,
                 long batchTimeout,
                 SpaceContext spaceContext) | 
| void | registerTypeDesc(ITypeDesc typeDesc,
                boolean fromGateway)Attempts to register the provided  ITypeDescinstance and replicate the operation if
 necessary. | 
| void | removeEntrySA(Context context,
             IEntryHolder entry,
             boolean fromReplication,
             boolean origin,
             boolean ofReplicatableClass,
             SpaceEngine.EntryRemoveReasonCodes removeReason,
             boolean disableReplication,
             boolean disableProcessorCall,
             boolean disableSADelete) | 
| void | removeEntrySA(Context context,
             IEntryHolder entry,
             IServerTypeDesc typeDesc,
             boolean fromReplication,
             boolean origin,
             SpaceEngine.EntryRemoveReasonCodes removeReason)Delete an entry (direct delete). | 
| void | removeEntrySA(Context context,
             IEntryHolder entry,
             IServerTypeDesc typeDesc,
             boolean fromReplication,
             boolean origin,
             SpaceEngine.EntryRemoveReasonCodes removeReason,
             boolean disableReplication,
             boolean disableProcessorCall,
             boolean disableSADelete)Delete an entry (direct delete). | 
| void | renewServerIteratorLease(UUID uuid) | 
| void | rollbackCopyReplica(ISpaceCopyResult replicaResult) | 
| void | setLastEntryTimestamp(long timestamp) | 
| void | setReplicationUnhealthyReason(Exception cause) | 
| boolean | shouldReplicate(ReplicationOperationType operType,
               boolean ofReplicatableClass,
               boolean disableReplication,
               boolean fromReplication) | 
| boolean | shouldReplicate(ReplicationOperationType operType,
               IServerTypeDesc serverTypeDesc,
               boolean disableReplication,
               boolean fromReplication) | 
| boolean | skipBroadcastTable(Context context,
                  ITemplateHolder template) | 
| void | snapshot(ITemplatePacket entryPacket)Return a snapshot of the given entry. | 
| ISpaceCopyReplicaState | spaceBroadcastNotifyTemplatesReplica(SpaceURL sourceRemoteUrl,
                                    int chunkSize,
                                    boolean transientOnly) | 
| ISpaceCopyReplicaState | spaceCopyReplica(SpaceURL sourceRemoteUrl,
                String sourceMemberName,
                IRemoteSpace remoteJSpace,
                ITemplatePacket templPacket,
                boolean includeNotifyTemplates,
                int chunkSize,
                SpaceContext sc,
                SpaceContext remoteSpaceContext) | 
| ISpaceSynchronizeReplicaState | spaceSynchronizeReplica(SpaceURL sourceRemoteUrl,
                       int chunkSize,
                       boolean transientOnly,
                       boolean memoryOnly) | 
| boolean | supportsGuaranteedNotifications()Returns true if this cluster topology supports guaranteed notifications. | 
| void | touchLastEntryTimestamp() | 
| void | unregisterLocalView(String viewStubHolderName) | 
| ExtendedAnswerHolder | update(IEntryPacket updated_entry,
      Transaction txn,
      long lease,
      long timeout,
      SpaceContext sc,
      boolean fromReplication,
      boolean origin,
      boolean newRouter,
      int modifiers)perform an update operation- make it atomic NOTE- returnonlyUID is ignored | 
| ExtendedAnswerHolder | update(IEntryPacket updated_entry,
      Transaction txn,
      long lease,
      long timeout,
      SpaceContext sc,
      boolean fromReplication,
      boolean origin,
      boolean newRouter,
      int modifiers,
      MultipleIdsContext multipleIdsContext) | 
| Object[] | updateMultiple(IEntryPacket[] entries,
              Transaction txn,
              long[] leases,
              SpaceContext sc,
              int operationModifiers,
              boolean newRouter)perform update of multiple entries. | 
| void | updateObjectTypeReadCounts(IServerTypeDesc serverTypeDesc) | 
| ExtendedAnswerHolder | updateOrWrite(UpdateOrWriteContext ctx,
             boolean newRouter) | 
| ExtendedAnswerHolder | updateOrWrite(UpdateOrWriteContext ctx,
             boolean fromReplication,
             boolean origin,
             boolean newRouter) | 
| void | updateTieredRAMObjectTypeReadCounts(IServerTypeDesc serverTypeDesc,
                                   TemplateMatchTier templateTieredState) | 
| void | waitForConsistentState()Wait until the engine is a consistent state, which means it has no pending operations that
 will be lost when closing the engine | 
| WriteEntriesResult | write(IEntryPacket[] entryPackets,
     Transaction txn,
     long lease,
     long[] leases,
     int modifiers,
     SpaceContext sc,
     long timeout,
     boolean newRouter)Creates IEntryHolder objects from the specified entry packets and inserts them into all
 relevant engine tables. | 
| WriteEntryResult | write(IEntryPacket entryPacket,
     Transaction txn,
     long lease,
     int modifiers,
     boolean fromReplication,
     boolean origin,
     SpaceContext sc)Creates an IEntryHolder object from the specified entry packet and inserts it into all
 relevant engine tables. | 
public SpaceEngine(SpaceImpl spaceImpl) throws CreateException, RemoteException
CreateExceptionRemoteExceptionpublic TieredStorageManager getTieredStorageManager()
public MetricRegistrator extendSpaceMetricRegistrator(String prefix, Map<String,String> extraTags, Map<String,DynamicMetricTag> extraDynamicTags)
public void init(boolean loadDataFromDB,
                 boolean considerMemoryRecovery)
          throws CreateException
CreateExceptionpublic TemplateScanner getTemplateScanner()
public SpaceImpl getSpaceImpl()
public org.slf4j.Logger getOperationLogger()
public SpaceConfigReader getConfigReader()
public SpaceTypeManager getTypeManager()
public FilterManager getFilterManager()
public LeaseManager getLeaseManager()
public EntryArrivedPacketsFactory getEntryArrivedPacketsFactory()
public EntryDataType getEntryDataType()
public WorkingGroup<BusPacket<Processor>> getProcessorWG()
public void invokeFilters(SpaceContext sc, int operationCode, Object subject)
public WriteEntryResult write(IEntryPacket entryPacket, Transaction txn, long lease, int modifiers, boolean fromReplication, boolean origin, SpaceContext sc) throws TransactionException, UnusableEntryException, UnknownTypeException, RemoteException
public boolean isNoWriteLease(IEntryPacket entryPacket, int modifiers, boolean fromReplication)
public GSEventRegistration notify(ITemplatePacket template, long lease, boolean fromReplication, String templateUid, SpaceContext sc, NotifyInfo info) throws TransactionException, UnusableEntryException, UnknownTypeException, RemoteException
public AnswerHolder read(ITemplatePacket template, Transaction txn, long timeout, boolean ifExists, boolean take, SpaceContext sc, boolean returnOnlyUid, boolean fromReplication, boolean origin, int operationModifiers) throws TransactionException, UnusableEntryException, UnknownTypeException, RemoteException, InterruptedException
public boolean isNonBlockingReadForOperation(ITemplateHolder tHolder)
public void snapshot(ITemplatePacket entryPacket) throws UnusableEntryException
Note: Snapshot doesn't finalize FIFO indicator and thus no InvalidFifoException is thrown.
UnusableEntryExceptionpublic WriteEntriesResult write(IEntryPacket[] entryPackets, Transaction txn, long lease, long[] leases, int modifiers, SpaceContext sc, long timeout, boolean newRouter) throws TransactionException, RemoteException, UnknownTypesException
public WriteEntriesResult oldAdaptUpdateMultiple(IEntryPacket[] entries, Transaction txn, long lease, long[] leases, SpaceContext sc, int modifiers, boolean newRouter) throws RemoteException, TransactionException, UnknownTypesException
public AnswerHolder newAdaptUpdateMultiple(IEntryPacket[] entries, Transaction txn, long lease, long[] leases, SpaceContext sc, long timeout, int modifiers) throws RemoteException, TransactionException, UnknownTypesException
public void updateObjectTypeReadCounts(IServerTypeDesc serverTypeDesc)
public void updateTieredRAMObjectTypeReadCounts(IServerTypeDesc serverTypeDesc, TemplateMatchTier templateTieredState)
public AnswerHolder readMultiple(ITemplatePacket template, Transaction txn, long timeout, boolean ifExists, boolean take, SpaceContext sc, boolean returnOnlyUid, int operationModifiers, BatchQueryOperationContext batchOperationContext, List<SpaceEntriesAggregator> aggregators, ServerIteratorRequestInfo serverIteratorRequestInfo) throws TransactionException, UnusableEntryException, UnknownTypeException, RemoteException, InterruptedException
protected void attachFromGatewayStateToTransactionIfNeeded(SpaceContext sc, XtnEntry txnEntry)
public Pair<Integer,SingleExplainPlan> count(ITemplatePacket template, Transaction txn, SpaceContext sc, int operationModifiers) throws UnusableEntryException, UnknownTypeException, TransactionException, RemoteException
public Pair<Integer,SingleExplainPlan> clear(ITemplatePacket template, Transaction txn, SpaceContext sc, int operationModifiers) throws UnusableEntryException, UnknownTypeException, TransactionException, RemoteException
public ExtendedAnswerHolder update(IEntryPacket updated_entry, Transaction txn, long lease, long timeout, SpaceContext sc, boolean fromReplication, boolean origin, boolean newRouter, int modifiers) throws UnusableEntryException, UnknownTypeException, TransactionException, RemoteException, InterruptedException
public ExtendedAnswerHolder update(IEntryPacket updated_entry, Transaction txn, long lease, long timeout, SpaceContext sc, boolean fromReplication, boolean origin, boolean newRouter, int modifiers, MultipleIdsContext multipleIdsContext) throws UnusableEntryException, UnknownTypeException, TransactionException, RemoteException, InterruptedException
public ExtendedAnswerHolder updateOrWrite(UpdateOrWriteContext ctx, boolean newRouter) throws TransactionException, UnusableEntryException, UnknownTypeException, RemoteException, InterruptedException
public ExtendedAnswerHolder updateOrWrite(UpdateOrWriteContext ctx, boolean fromReplication, boolean origin, boolean newRouter) throws TransactionException, UnusableEntryException, UnknownTypeException, RemoteException, InterruptedException
public ExtendedAnswerHolder change(ITemplatePacket template, Transaction txn, long lease, long timeout, SpaceContext sc, boolean fromReplication, boolean origin, Collection<SpaceEntryMutator> mutators, int operationModifiers, boolean returnOnlyUid) throws UnusableEntryException, UnknownTypeException, TransactionException, RemoteException, InterruptedException
public Object[] updateMultiple(IEntryPacket[] entries, Transaction txn, long[] leases, SpaceContext sc, int operationModifiers, boolean newRouter) throws UnusableEntryException, UnknownTypeException, TransactionException, RemoteException
public AnswerHolder newUpdateMultiple(IEntryPacket[] entries, Transaction txn, long[] leases, SpaceContext sc, long timeout, int operationModifiers) throws UnusableEntryException, UnknownTypeException, TransactionException, RemoteException, InterruptedException
public SpaceRuntimeInfo getRuntimeInfo()
public SpaceRuntimeInfo getRuntimeInfo(String typeName)
typeName - the name of the classpublic String createUIDFromCounter()
public void dropClass(String className) throws DropClassException
className - - name of class to delete.DropClassExceptionpublic int prepare(TransactionManager mgr, ServerTransaction st, boolean singleParticipant, boolean supportsTwoPhaseReplication, OperationID operationID) throws UnknownTransactionException, RemoteException
protected void handleExceptionOnPrepare(TransactionManager mgr, ServerTransaction st, boolean supportsTwoPhaseReplication, XtnEntry xtnEntry) throws RemoteException
RemoteExceptionpublic int prepareAndCommit(TransactionManager mgr, ServerTransaction st, OperationID operationID) throws UnknownTransactionException, RemoteException
public void commit(TransactionManager mgr, ServerTransaction st, boolean supportsTwoPhaseReplication, OperationID operationID, boolean mayBeFromReplication) throws UnknownTransactionException, RemoteException
public String createTransactionDetailsString(ServerTransaction st, OperationID operationID)
public void abort(TransactionManager mgr, ServerTransaction st, boolean supportsTwoPhaseReplication, OperationID operationID) throws UnknownTransactionException
UnknownTransactionExceptionpublic List<TemplateInfo> getTemplatesInfo(String className)
public TransactionInfo[] getTransactionsInfo(int type, int status) throws RemoteException
type - TransactionInfo.LOCAL, TransactionInfo.JINI or TransactionInfo.XAstatus - TransactionConstantsRemoteExceptionpublic int countTransactions(int type,
                             int status)
                      throws RemoteException
RemoteExceptionpublic List<UnderTxnLockedObject> getLockedObjects(Transaction txn) throws RemoteException
txn - - the Transaction that locks the Objects.RemoteExceptionpublic IServerTypeDesc getTypeTableEntry(String className)
public void waitForConsistentState()
public Map<String,Object> getMetricsSnapshotByPrefix(Collection<String> prefixes)
public void close()
public IEntryHolder getMatchedEntryAndOperateSA(Context context, ITemplateHolder template, boolean makeWaitForInfo, boolean useSCN) throws TransactionException, TemplateDeletedException, SAException
null.
 Handles also null templates.public void executeOnMatchingEntries(Context context, ITemplateHolder template, boolean makeWaitForInfo) throws TransactionException, TemplateDeletedException, SAException
public boolean skipBroadcastTable(Context context, ITemplateHolder template)
public boolean hasMirror()
public void performTemplateOnEntrySA(Context context, ITemplateHolder template, IEntryHolder entry, boolean makeWaitForInfo) throws TransactionConflictException, EntryDeletedException, TemplateDeletedException, TransactionNotActiveException, SAException, NoMatchException, FifoException
public boolean indicateDirtyRead(ITemplateHolder template)
public void checkWFValidityAfterUpdate(Context context, IEntryHolder entry) throws SAException
SAExceptionpublic XtnEntry attachToXtn(ServerTransaction txn, boolean fromReplication) throws TransactionException, RemoteException
txn - the transaction to joinTransactionExceptionRemoteExceptionpublic void removeEntrySA(Context context, IEntryHolder entry, IServerTypeDesc typeDesc, boolean fromReplication, boolean origin, SpaceEngine.EntryRemoveReasonCodes removeReason) throws SAException
SAExceptionpublic void removeEntrySA(Context context, IEntryHolder entry, IServerTypeDesc typeDesc, boolean fromReplication, boolean origin, SpaceEngine.EntryRemoveReasonCodes removeReason, boolean disableReplication, boolean disableProcessorCall, boolean disableSADelete) throws SAException
SAExceptionpublic void removeEntrySA(Context context, IEntryHolder entry, boolean fromReplication, boolean origin, boolean ofReplicatableClass, SpaceEngine.EntryRemoveReasonCodes removeReason, boolean disableReplication, boolean disableProcessorCall, boolean disableSADelete) throws SAException
SAExceptionpublic boolean isReplicated()
public boolean isReplicatedPersistentBlobstore()
public void abortSA(TransactionManager mgr, ServerTransaction st, boolean fromLeaseExpiration, boolean verifyExpiredXtn, boolean supportsTwoPhaseReplication, OperationID operationID) throws UnknownTransactionException
UnknownTransactionExceptionpublic XtnEntry getTransaction(ServerTransaction st)
st - public AnswerHolder aggregate(ITemplatePacket queryPacket, List<SpaceEntriesAggregator> aggregators, int readModifiers, SpaceContext sc) throws Exception
Exceptionpublic int countIncomingConnections()
                             throws RemoteException
RemoteExceptionpublic ServerIteratorsManager getIteratorsManager()
public MetricManager getMetricManager()
public void afterClusterInfoChange(SpaceClusterInfo clusterInfo)
IClusterInfoChangedListenerafterClusterInfoChange in interface IClusterInfoChangedListenerpublic void getAdmin(SpaceContext sc) throws RemoteException
RemoteExceptionpublic ClusterPolicy getClusterPolicy()
public void beforeAuthentication(SecurityContext securityContext) throws RemoteException
RemoteExceptionpublic ISpaceCopyReplicaState spaceCopyReplica(SpaceURL sourceRemoteUrl, String sourceMemberName, IRemoteSpace remoteJSpace, ITemplatePacket templPacket, boolean includeNotifyTemplates, int chunkSize, SpaceContext sc, SpaceContext remoteSpaceContext)
public String generateGroupName()
public ISpaceSynchronizeReplicaState spaceSynchronizeReplica(SpaceURL sourceRemoteUrl, int chunkSize, boolean transientOnly, boolean memoryOnly)
public ISpaceCopyReplicaState spaceBroadcastNotifyTemplatesReplica(SpaceURL sourceRemoteUrl, int chunkSize, boolean transientOnly) throws InterruptedException
InterruptedExceptionpublic void rollbackCopyReplica(ISpaceCopyResult replicaResult)
public ITypeDesc getClassTypeInfo(String className)
public final boolean isSyncReplicationEnabled()
public final boolean isMirrorService()
true if this space serves as MirrorService to receive async bulk
 operations to be saved into persistent cache adaptor.public int performReplication(Context context)
public boolean isEntryFromPartition(IEntryHolder entryHolder)
entryHolder- - to checkpublic boolean isPartitionedSpace()
public CacheManager getCacheManager()
public final MemoryManager getMemoryManager()
public List<ISpaceComponentsHandler> getComponentsHandlers()
public int getNumberOfPartitions()
public PartitionRoutingInfo getPartitionRoutingInfo()
public int getPartitionIdOneBased()
public int getPartitionIdZeroBased()
public String getSpaceName()
public String getFullSpaceName()
public long getLastEntryTimestamp()
public void setLastEntryTimestamp(long timestamp)
public void touchLastEntryTimestamp()
public boolean isColdStart()
public boolean isMemoryRecoveryEnabled()
public TransactionHandler getTransactionHandler()
public List<FilterProvider> getInternalFilters()
public boolean supportsGuaranteedNotifications()
public Object directLocalReadById(Object id, String typeName, QueryResultTypeInternal queryResultType)
public boolean shouldReplicate(ReplicationOperationType operType, IServerTypeDesc serverTypeDesc, boolean disableReplication, boolean fromReplication)
public boolean shouldReplicate(ReplicationOperationType operType, boolean ofReplicatableClass, boolean disableReplication, boolean fromReplication)
public IReplicationNode getReplicationNode()
public boolean isCleanUnusedEmbeddedGlobalXtns()
public void afterSpaceModeChange(SpaceMode newMode)
ISpaceModeListenerafterSpaceModeChange in interface ISpaceModeListenernewMode - the new mode change after it was published.public void beforeSpaceModeChange(SpaceMode newMode)
ISpaceModeListenerbeforeSpaceModeChange in interface ISpaceModeListenernewMode - the new mode change before it's published.public boolean isClusteredExternalDBEnabled(IStorageAdapter storageAdapter)
public SpaceReplicationManager getReplicationManager()
public int getProcessorQueueSize()
public int getNotifierQueueSize()
public String generateUid()
public void setReplicationUnhealthyReason(Exception cause)
public ConflictingOperationPolicy getConflictingOperationPolicy()
public FifoGroupsHandler getFifoGroupsHandler()
public void enableDuplicateExecutionProtection(OperationID operationID)
public boolean isExpiredEntryStayInSpace(IEntryHolder entry)
public boolean isFailOverDuringRecovery()
public boolean isLocalCache()
public void registerTypeDesc(ITypeDesc typeDesc, boolean fromGateway) throws DetailedUnusableEntryException
ITypeDesc instance and replicate the operation if
 necessary.DetailedUnusableEntryExceptionpublic LocalViewRegistrations getLocalViewRegistrations()
public MetricRegistrator getMetricRegistrator()
public MetricRegistrator getDataTypeMetricRegistrar(String dataTypeName)
public void clearDataTypeMetricRegistrarIfExists(String dataTypeName)
public MetricRegistrator getDataTypeMetricRegistrar(String typeName, String indexName)
public void clearDataTypeMetricRegistrarIfExists(String typeName, String indexName)
public void registerLocalView(ITemplatePacket[] queryPackets, Collection<SpaceQueryDetails> queryDescriptions, RouterStubHolder viewStub, int batchSize, long batchTimeout, SpaceContext spaceContext) throws UnusableEntryException, UnknownTypeException
public void unregisterLocalView(String viewStubHolderName)
public boolean isBlobStorePersistent()
public SpaceClusterInfo getClusterInfo()
public void closeServerIterator(UUID uuid)
public void renewServerIteratorLease(UUID uuid)
public org.slf4j.Logger getLogger()
Copyright © GigaSpaces.