| Modifier and Type | Method and Description | 
|---|---|
ITemplatePacket | 
SpaceEntryPacketIterator.getQueryPacket()  | 
| Modifier and Type | Method and Description | 
|---|---|
ITemplatePacket[] | 
LocalViewConfig.getViewTemplatePackets()  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
LocalViewConfig.setViewTemplatePackets(ITemplatePacket[] viewTemplatePackets)  | 
| Constructor and Description | 
|---|
NotificationLocalViewListener(NotificationLocalView localView,
                             ITemplatePacket queryPacket,
                             DataEventSession eventSession,
                             ContinousQueryConfig config)  | 
| Modifier and Type | Method and Description | 
|---|---|
ReadTakeEntriesUidsResult | 
AbstractSpaceProxy.readEntriesUids(ITemplatePacket template,
               Transaction transaction,
               int entriesLimit,
               int modifiers)  | 
ReadTakeEntriesUidsResult | 
ISpaceProxy.readEntriesUids(ITemplatePacket template,
               Transaction transaction,
               int entriesLimit,
               int modifiers)
Read entries UIDs from space. 
 | 
| Modifier and Type | Field and Description | 
|---|---|
ITemplatePacket | 
QueryProxyActionInfo.queryPacket  | 
| Modifier and Type | Method and Description | 
|---|---|
ReadTakeEntriesUidsResult | 
AbstractSpaceProxyActionManager.readEntriesUids(ITemplatePacket template,
               Transaction transaction,
               int entriesLimit,
               int modifiers)  | 
| Modifier and Type | Method and Description | 
|---|---|
ITemplatePacket | 
SpaceProxyTypeManager.getTemplatePacketFromObject(Object object,
                           ObjectType objectType)  | 
ITemplatePacket | 
ISpaceProxyTypeManager.getTemplatePacketFromObject(Object object,
                           ObjectType objectType)  | 
| Modifier and Type | Method and Description | 
|---|---|
Object | 
SpaceProxyTypeManager.convertQueryResult(IEntryPacket resultPacket,
                  ITemplatePacket queryPacket,
                  boolean returnEntryPacket)  | 
Object | 
ISpaceProxyTypeManager.convertQueryResult(IEntryPacket result,
                  ITemplatePacket query,
                  boolean returnEntryPacket)  | 
Object | 
SpaceProxyTypeManager.convertQueryResult(IEntryPacket resultPacket,
                  ITemplatePacket queryPacket,
                  boolean returnEntryPacket,
                  AbstractProjectionTemplate projectionTemplate)  | 
Object | 
ISpaceProxyTypeManager.convertQueryResult(IEntryPacket result,
                  ITemplatePacket query,
                  boolean returnEntryPacket,
                  AbstractProjectionTemplate projectionTemplate)  | 
Object[] | 
SpaceProxyTypeManager.convertQueryResults(IEntryPacket[] resultPackets,
                   ITemplatePacket query,
                   boolean returnEntryPacket,
                   AbstractProjectionTemplate projectionTemplate)  | 
Object[] | 
ISpaceProxyTypeManager.convertQueryResults(IEntryPacket[] results,
                   ITemplatePacket query,
                   boolean returnEntryPacket,
                   AbstractProjectionTemplate projectionTemplate)  | 
Class<?> | 
SpaceProxyTypeManager.getResultClass(ITemplatePacket templatePacket)  | 
Class<?> | 
ISpaceProxyTypeManager.getResultClass(ITemplatePacket templatePacket)  | 
| Modifier and Type | Method and Description | 
|---|---|
ITemplatePacket | 
AggregateEntriesSpaceOperationRequest.getQueryPacket()  | 
ITemplatePacket | 
ReadTakeEntriesUidsSpaceOperationRequest.getTemplate()  | 
ITemplatePacket | 
ReadTakeEntrySpaceOperationRequest.getTemplatePacket()  | 
ITemplatePacket | 
ChangeEntriesSpaceOperationRequest.getTemplatePacket()  | 
ITemplatePacket | 
ReadTakeEntriesSpaceOperationRequest.getTemplatePacket()  | 
ITemplatePacket | 
RegisterEntriesListenerSpaceOperationRequest.getTemplatePacket()  | 
ITemplatePacket | 
CountClearEntriesSpaceOperationRequest.getTemplatePacket()  | 
| Modifier and Type | Method and Description | 
|---|---|
Collection<ITemplatePacket> | 
RegisterLocalViewSpaceOperationRequest.getQueryPackets()  | 
| Modifier and Type | Method and Description | 
|---|---|
AggregationResult | 
AggregateEntriesSpaceOperationRequest.getFinalResult(IJSpace spaceProxy,
              ITemplatePacket queryPacket,
              boolean returnEntryPacket)  | 
void | 
AggregateEntriesSpaceOperationRequest.setQueryPacket(ITemplatePacket queryPacket)  | 
void | 
ReadTakeEntriesUidsSpaceOperationRequest.setTemplate(ITemplatePacket template)  | 
| Constructor and Description | 
|---|
AggregateEntriesSpaceOperationRequest(ITemplatePacket queryPacket,
                                     Transaction txn,
                                     int modifiers,
                                     List<SpaceEntriesAggregator> aggregators)  | 
ChangeEntriesSpaceOperationRequest(ITemplatePacket templatePacket,
                                  Transaction txn,
                                  long timeout,
                                  long lease,
                                  int modifiers,
                                  Collection<SpaceEntryMutator> mutators,
                                  Object query)  | 
CountClearEntriesSpaceOperationRequest(ITemplatePacket templatePacket,
                                      Transaction txn,
                                      boolean isClear,
                                      int modifiers)  | 
ReadTakeEntriesSpaceOperationRequest(ITemplatePacket templatePacket,
                                    Transaction transaction,
                                    boolean isTake,
                                    int modifiers,
                                    int maxResults,
                                    int minResultsToWaitFor,
                                    long timeout,
                                    boolean ifExist,
                                    Object query)  | 
ReadTakeEntriesUidsSpaceOperationRequest(ITemplatePacket template,
                                        Transaction transaction,
                                        int entriesLimit,
                                        int modifiers)  | 
ReadTakeEntrySpaceOperationRequest(ITemplatePacket templatePacket,
                                  Transaction txn,
                                  boolean isTake,
                                  boolean ifExists,
                                  long timeout,
                                  int modifiers,
                                  boolean returnOnlyUid,
                                  ISpaceProxyTypeManager typeManager,
                                  boolean returnPacket,
                                  Object query)  | 
ReadTakeEntrySpaceOperationRequest(ITemplatePacket templatePacket,
                                  Transaction txn,
                                  boolean isTake,
                                  boolean ifExists,
                                  long timeout,
                                  int modifiers,
                                  boolean returnOnlyUid,
                                  Object query)  | 
RegisterEntriesListenerSpaceOperationRequest(ITemplatePacket templatePacket,
                                            NotifyInfo notifyInfo,
                                            long lease)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
IReplicationInNotifyTemplateCreatedHandler.inInsertNotifyTemplate(IReplicationInContext context,
                      ITemplatePacket entryPacket,
                      String uid,
                      NotifyInfo notifyInfo)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
ReplicationNodeInFacade.inInsertNotifyTemplate(IReplicationInContext context,
                      ITemplatePacket templatePacket,
                      String uidToOperateBy,
                      NotifyInfo notifyInfo)  | 
| Modifier and Type | Method and Description | 
|---|---|
GSEventRegistration | 
LocalCLusterReplicationReplicaConsumeFacade.insertNotifyTemplate(ITemplatePacket templatePacket,
                    String templateUid,
                    NotifyInfo notifyInfo)  | 
void | 
LocalClusterReplicationFixFacade.insertNotifyTemplate(ITemplatePacket notifyTemplate,
                    String uid,
                    NotifyInfo notifyInfo)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
ReplicationInExceptionHandler.handleEntryLockedByTransactionOnChange(Logger logger,
                                      ITemplatePacket entryPacket)  | 
void | 
ReplicationInExceptionHandler.handleEntryNotInSpaceOnChange(Logger logger,
                             ITemplatePacket entryPacket)  | 
void | 
ReplicationInExceptionHandler.handleEntryVersionConflictOnChange(Logger logger,
                                  ITemplatePacket entryPacket,
                                  EntryVersionConflictException ex)  | 
void | 
ReplicationInExceptionHandler.handleEntryVersionConflictOnChange(Logger logger,
                                  ITemplatePacket entryPacket,
                                  EntryVersionConflictException ex,
                                  Level logLevel)  | 
void | 
SpaceReplicationTemplateEventHandler.inInsertNotifyTemplate(IReplicationInContext context,
                      ITemplatePacket template,
                      String templateUid,
                      NotifyInfo notifyInfo)  | 
protected void | 
BlobstorePrimaryBackupSpaceReplicationEntryEventHandler.removeEntryFromSpace(IReplicationInContext context,
                    Transaction txn,
                    ITemplatePacket template,
                    boolean twoPhaseCommit)  | 
protected void | 
AbstractSpaceReplicationEntryEventHandler.removeEntryFromSpace(IReplicationInContext context,
                    Transaction txn,
                    ITemplatePacket template,
                    boolean twoPhaseCommit)  | 
protected void | 
PrimaryBackupSpaceReplicationEntryEventHandler.removeEntryFromSpace(IReplicationInContext context,
                    Transaction txn,
                    ITemplatePacket template,
                    boolean twoPhaseCommit)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
NotificationReplicationDataConsumeFixFacade.insertNotifyTemplate(ITemplatePacket notifyTemplate,
                    String uid,
                    NotifyInfo notifyInfo)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
IDataConsumeFixFacade.insertNotifyTemplate(ITemplatePacket notifyTemplate,
                    String uid,
                    NotifyInfo notifyInfo)  | 
void | 
SpaceEngineFixFacade.insertNotifyTemplate(ITemplatePacket notifyTemplate,
                    String uid,
                    NotifyInfo notifyInfo)  | 
| Constructor and Description | 
|---|
ResurrectNotifyTemplateFix(ITemplatePacket notifyTemplate,
                          String uid,
                          NotifyInfo notifyInfo)  | 
| Constructor and Description | 
|---|
InsertNotifyTemplateReplicationPacketData(ITemplatePacket templatePacket,
                                         String templateUid,
                                         NotifyInfo notifyInfo,
                                         long expirationTime)  | 
| Modifier and Type | Method and Description | 
|---|---|
protected ITemplatePacket | 
NotifyTemplateReplicaProducer.buildNotifyTemplatePacket(NotifyTemplateHolder templateHolder,
                         long ttl)  | 
| Modifier and Type | Method and Description | 
|---|---|
GSEventRegistration | 
ISpaceReplicaConsumeFacade.insertNotifyTemplate(ITemplatePacket templatePacket,
                    String templateUid,
                    NotifyInfo notifyInfo)  | 
| Constructor and Description | 
|---|
DirectPersisntecyEntryReplicaProducer(SpaceEngine engine,
                                     SpaceCopyReplicaParameters parameters,
                                     ITemplatePacket templatePacket,
                                     Object requestContext)  | 
EntryReplicaProducer(SpaceEngine engine,
                    SpaceCopyReplicaParameters parameters,
                    ITemplatePacket templatePacket,
                    Object requestContext)  | 
| Constructor and Description | 
|---|
NotifyTemplateReplicaData(ITemplatePacket templatePacket,
                         String templateUid,
                         NotifyInfo notifyInfo,
                         int objectType)  | 
| Constructor and Description | 
|---|
NotifyReplicationFilterReplicaDataWrapper(ITemplatePacket templatePacket,
                                         NotifyInfo notifyInfo,
                                         int objectType,
                                         ITypeDesc typeDesc)  | 
| Constructor and Description | 
|---|
ViewReplicationChannelDataFilter(CacheManager cacheManager,
                                String groupName,
                                ITemplatePacket[] templates,
                                RegexCache regexCache,
                                SpaceTypeManager typeManager)  | 
| Modifier and Type | Method and Description | 
|---|---|
List<ITemplatePacket> | 
SpaceCopyReplicaParameters.getTemplatePackets()  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
SpaceCopyReplicaParameters.addTemplatePacket(ITemplatePacket templatePacket)  | 
| Constructor and Description | 
|---|
AbstractReplicationNotificationInEntryHandler(NotifyInfo notifyInfo,
                                             IDirectSpaceProxy remoteSpace,
                                             long eventID,
                                             ITemplatePacket templatePacket)  | 
NotifyCallHandler(RemoteEventListener listener,
                 NotifyInfo notifyInfo,
                 ITemplatePacket templatePacket,
                 ReplicationNotificationClientEndpoint endpoint)  | 
ReplicationNotificationBatchInEntryHandler(NotifyInfo notifyInfo,
                                          IDirectSpaceProxy remoteSpace,
                                          long eventID,
                                          ITemplatePacket templatePacket)  | 
ReplicationNotificationInBatchConsumptionHandler(NotifyInfo notifyInfo,
                                                ITemplatePacket templatePacket,
                                                ReplicationNotificationClientEndpoint endpoint)  | 
ReplicationNotificationInEntryHandler(NotifyInfo notifyInfo,
                                     IDirectSpaceProxy remoteSpace,
                                     long eventID,
                                     ITemplatePacket templatePacket,
                                     ReplicationNotificationClientEndpoint endpoint)  | 
| Modifier and Type | Method and Description | 
|---|---|
static ITemplatePacket[] | 
IOUtils.readTemplatePacketArray(ObjectInput in)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
LRMISpaceImpl.snapshot(ITemplatePacket e)  | 
SpaceCopyStatus | 
LRMISpaceImpl.spaceCopy(IRemoteSpace remoteProxy,
         String remoteSpaceUrl,
         String remoteSpaceName,
         ITemplatePacket template,
         boolean includeNotifyTemplates,
         int chunkSize,
         SpaceContext spaceContext,
         SpaceContext remoteSpaceContext)  | 
SpaceCopyStatus | 
LRMISpaceImpl.spaceCopy(String remoteUrl,
         ITemplatePacket template,
         boolean includeNotifyTemplates,
         int chunkSize)  | 
SpaceCopyStatus | 
LRMISpaceImpl.spaceCopy(String remoteUrl,
         ITemplatePacket template,
         boolean includeNotifyTemplates,
         int chunkSize,
         SpaceContext sc)  | 
| Constructor and Description | 
|---|
RawEntryConverter(IDirectSpaceProxy spaceProxy,
                 ITemplatePacket queryPacket,
                 boolean returnRawEntry)  | 
| Constructor and Description | 
|---|
ContinousQuery(ISpaceProxy spaceProxy,
              ITemplatePacket query,
              ContinousQueryListener listener,
              ContinousQueryConfig config,
              DataEventSession eventSession)  | 
| Modifier and Type | Method and Description | 
|---|---|
ITemplatePacket | 
ReadByIdsContext.getTemplate()  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
SpaceEngine.aggregate(ITemplatePacket queryPacket,
         List<SpaceEntriesAggregator> aggregators,
         int readModifiers,
         SpaceContext sc)  | 
Object | 
SpaceImpl.asyncRead(ITemplatePacket template,
         Transaction txn,
         long timeout,
         boolean ifExists,
         boolean take,
         IJSpaceProxyListener listener,
         SpaceContext sc,
         boolean returnOnlyUid,
         int modifiers,
         IFuture result)  | 
ExtendedAnswerHolder | 
SpaceEngine.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 
 | 
Pair<Integer,SingleExplainPlan> | 
SpaceImpl.clear(ITemplatePacket template,
     Transaction txn,
     int modifiers,
     SpaceContext sc)  | 
Pair<Integer,SingleExplainPlan> | 
SpaceEngine.clear(ITemplatePacket template,
     Transaction txn,
     SpaceContext sc,
     int operationModifiers)  | 
Pair<Integer,SingleExplainPlan> | 
SpaceEngine.count(ITemplatePacket template,
     Transaction txn,
     SpaceContext sc,
     int operationModifiers)  | 
Pair<Integer,SingleExplainPlan> | 
SpaceImpl.count(ITemplatePacket template,
     Transaction txn,
     SpaceContext sc,
     int modifiers)  | 
GSEventRegistration | 
SpaceEngineReplicaDirectPersistencySyncConsumerFacade.insertNotifyTemplate(ITemplatePacket templatePacket,
                    String templateUid,
                    NotifyInfo notifyInfo)  | 
GSEventRegistration | 
SpaceEngineReplicaConsumerFacade.insertNotifyTemplate(ITemplatePacket templatePacket,
                    String templateUid,
                    NotifyInfo notifyInfo)  | 
GSEventRegistration | 
SpaceEngine.notify(ITemplatePacket template,
      long lease,
      boolean fromReplication,
      String templateUid,
      SpaceContext sc,
      NotifyInfo info)  | 
GSEventRegistration | 
SpaceImpl.notify(ITemplatePacket template,
      Transaction txn,
      long lease,
      SpaceContext sc,
      NotifyInfo info)  | 
AnswerPacket | 
SpaceImpl.read(ITemplatePacket template,
    Transaction txn,
    long timeout,
    boolean ifExists,
    boolean take,
    IJSpaceProxyListener listener,
    SpaceContext sc,
    boolean returnOnlyUid,
    int modifiers)  | 
AnswerHolder | 
SpaceEngine.read(ITemplatePacket template,
    Transaction txn,
    long timeout,
    boolean ifExists,
    boolean take,
    SpaceContext sc,
    boolean returnOnlyUid,
    boolean fromReplication,
    boolean origin,
    int operationModifiers)  | 
IEntryPacket[] | 
SpaceImpl.readByIds(ITemplatePacket template,
         Transaction txn,
         boolean take,
         SpaceContext spaceContext,
         int modifiers)  | 
IEntryPacket[] | 
SpaceImpl.readMultiple(ITemplatePacket template,
            Transaction txn,
            boolean take,
            int maxEntries,
            SpaceContext sc,
            boolean returnOnlyUid,
            int modifiers)  | 
AnswerHolder | 
SpaceImpl.readMultiple(ITemplatePacket template,
            Transaction txn,
            boolean take,
            int maxEntries,
            SpaceContext sc,
            boolean returnOnlyUid,
            int modifiers,
            int minEntries,
            long timeout,
            boolean isIfExist)  | 
AnswerHolder | 
SpaceEngine.readMultiple(ITemplatePacket template,
            Transaction txn,
            long timeout,
            boolean ifExists,
            boolean take,
            SpaceContext sc,
            boolean returnOnlyUid,
            int operationModifiers,
            BatchQueryOperationContext batchOperationContext,
            List<SpaceEntriesAggregator> aggregators)  | 
AnswerHolder | 
SpaceImpl.readNew(ITemplatePacket template,
       Transaction txn,
       long timeout,
       boolean ifExists,
       boolean take,
       IJSpaceProxyListener listener,
       SpaceContext sc,
       boolean returnOnlyUid,
       int modifiers)  | 
void | 
SpaceEngine.registerLocalView(ITemplatePacket[] queryPackets,
                 Collection<SpaceQueryDetails> queryDescriptions,
                 RouterStubHolder viewStub,
                 int batchSize,
                 long batchTimeout,
                 SpaceContext spaceContext)  | 
void | 
IRemoteSpace.snapshot(ITemplatePacket e)  | 
void | 
SpaceEngine.snapshot(ITemplatePacket entryPacket)
Return a snapshot of the given entry. 
 | 
void | 
SpaceImpl.snapshot(ITemplatePacket template)  | 
SpaceCopyStatus | 
SpaceImpl.spaceCopy(IRemoteSpace remoteProxy,
         String remoteSpaceUrl,
         String remoteSpaceName,
         ITemplatePacket template,
         boolean includeNotifyTemplates,
         int chunkSize,
         SpaceContext sc,
         SpaceContext remoteSpaceContext)  | 
SpaceCopyStatus | 
SpaceImpl.spaceCopy(String remoteUrl,
         ITemplatePacket template,
         boolean includeNotifyTemplates,
         int chunkSize)  | 
SpaceCopyStatus | 
SpaceImpl.spaceCopy(String remoteUrl,
         ITemplatePacket template,
         boolean includeNotifyTemplates,
         int chunkSize,
         SpaceContext sc)  | 
ISpaceCopyReplicaState | 
SpaceEngine.spaceCopyReplica(SpaceURL sourceRemoteUrl,
                String sourceMemberName,
                IRemoteSpace remoteJSpace,
                ITemplatePacket templPacket,
                boolean includeNotifyTemplates,
                int chunkSize,
                SpaceContext sc,
                SpaceContext remoteSpaceContext)  | 
| Constructor and Description | 
|---|
AggregateOperationContext(ITemplatePacket template,
                         int maxEntries,
                         int minEntries)  | 
BatchQueryOperationContext(ITemplatePacket template,
                          int maxEntries,
                          int minEntries)  | 
ChangeMultipleContext(ITemplatePacket template,
                     int maxEntries,
                     int minEntries)  | 
ClearContext(ITemplatePacket template,
            int maxEntries)  | 
ReadByIdsContext(ITemplatePacket template,
                boolean accumulate)  | 
ReadMultipleContext(ITemplatePacket template,
                   int maxEntries,
                   int minEntries)  | 
TakeMultipleContext(ITemplatePacket template,
                   int maxEntries,
                   int minEntries)  | 
| Modifier and Type | Method and Description | 
|---|---|
ITemplatePacket | 
NotifyTemplateHolder.getGenerationTemplate()  | 
| Modifier and Type | Method and Description | 
|---|---|
static NotifyTemplateHolder | 
TemplateHolderFactory.createNotifyTemplateHolder(IServerTypeDesc typeDesc,
                          ITemplatePacket template,
                          String templateUid,
                          long expirationTime,
                          long eventId,
                          NotifyInfo notifyInfo,
                          boolean isFifo)  | 
static ITemplateHolder | 
TemplateHolderFactory.createTemplateHolder(IServerTypeDesc typeDesc,
                    ITemplatePacket template,
                    String uid,
                    long expirationTime)  | 
static ITemplateHolder | 
TemplateHolderFactory.createTemplateHolder(IServerTypeDesc typeDesc,
                    ITemplatePacket template,
                    String uid,
                    long expirationTime,
                    XtnEntry xidOriginated,
                    long SCN,
                    int templateOperation,
                    IResponseContext respContext,
                    boolean returnOnlyUid,
                    int operationModifiers,
                    boolean isfifo)  | 
static ITemplateHolder | 
TemplateHolderFactory.createTemplateHolder(IServerTypeDesc typeDesc,
                    ITemplatePacket template,
                    String uid,
                    long expirationTime,
                    XtnEntry xidOriginated,
                    long SCN,
                    int templateOperation,
                    IResponseContext respContext,
                    boolean returnOnlyUid,
                    int operationModifiers,
                    boolean isfifo,
                    boolean fromReplication)  | 
static boolean | 
TemplateHolder.isOptimizedForBlobStoreClear(CacheManager cacheManager,
                            ITemplatePacket templatePacket,
                            TemplateEntryData templateEntryData)  | 
| Constructor and Description | 
|---|
NotifyTemplateHolder(IServerTypeDesc typeDesc,
                    ITemplatePacket template,
                    String uid,
                    long expirationTime,
                    long eventId,
                    NotifyInfo info,
                    boolean isFifo)  | 
TemplateHolder(IServerTypeDesc typeDesc,
              ITemplatePacket packet,
              String uid,
              long expirationTime,
              XtnEntry xidOriginated,
              long scn,
              int templateOperation,
              IResponseContext respContext,
              boolean returnOnlyUid,
              int operationModifiers,
              boolean isfifo)  | 
TemplateHolder(IServerTypeDesc typeDesc,
              ITemplatePacket packet,
              String uid,
              long expirationTime,
              XtnEntry xidOriginated,
              long scn,
              int templateOperation,
              IResponseContext respContext,
              boolean returnOnlyUid,
              int operationModifiers,
              boolean isfifo,
              boolean fromReplication)  | 
| Modifier and Type | Field and Description | 
|---|---|
ITemplatePacket | 
RegisterReplicationNotificationRequestInfo.template  | 
ITemplatePacket[] | 
RegisterReplicationLocalViewRequestInfo.templates  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
MirrorFixFacade.insertNotifyTemplate(ITemplatePacket notifyTemplate,
                    String uid,
                    NotifyInfo notifyInfo)  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
AbstractQueryPacket  | 
class  | 
EmptyQueryPacket  | 
class  | 
ExternalizableTemplatePacket
Implements  
ITemplatePacket for Externalizable classes. | 
class  | 
PbsTemplatePacket
PbsTemplatePacket defines the template object for Pbs layer. 
 | 
class  | 
TemplatePacket
This class represents a packet of information transmitted between a J-Space client and its
 J-Space server . 
 | 
| Modifier and Type | Method and Description | 
|---|---|
ITemplatePacket | 
ITemplatePacket.clone()  | 
static ITemplatePacket | 
TemplatePacketFactory.createEmptyPacket(ITypeDesc typeDesc)  | 
static <T> ITemplatePacket | 
TemplatePacketFactory.createFromObject(T entry,
                ITypeDesc typeDesc,
                EntryType entryType)  | 
static ITemplatePacket | 
TemplatePacketFactory.createFullPacket(IEntryData entryData,
                String uid,
                OperationID operationId,
                boolean isTransient)  | 
static ITemplatePacket | 
TemplatePacketFactory.createFullPacket(IEntryHolder entryHolder,
                ITemplateHolder template,
                String uid,
                long timeToLive,
                IEntryData entryData,
                OperationID operationID)  | 
static ITemplatePacket | 
TemplatePacketFactory.createFullPacket(IEntryHolder entryHolder,
                ITemplateHolder template,
                String uid,
                long timeToLive,
                OperationID operationId)  | 
static ITemplatePacket | 
TemplatePacketFactory.createFullPacket(IEntryHolder entryHolder,
                OperationID operationID)  | 
static ITemplatePacket | 
TemplatePacketFactory.createFullPacket(IEntryPacket entryPacket)  | 
static ITemplatePacket | 
TemplatePacketFactory.createFullPacket(IEntryPacket entryPacket,
                ITypeDesc typeDesc,
                boolean isTransient)  | 
static ITemplatePacket | 
TemplatePacketFactory.createFullPacket(ITemplateHolder template,
                String uid,
                long timeToLive,
                OperationID operationId)  | 
static ITemplatePacket | 
TemplatePacketFactory.createFullPacketForReplication(NotifyTemplateHolder template,
                              OperationID operationID)  | 
static ITemplatePacket | 
TemplatePacketFactory.createIdOrUidPacket(ITypeDesc typeDesc,
                   QueryResultTypeInternal resultType,
                   Object routing,
                   Object id,
                   int version,
                   AbstractProjectionTemplate projectionTemplate)  | 
static ITemplatePacket | 
TemplatePacketFactory.createIdPacket(Object id,
              Object routing,
              int version,
              ITypeDesc typeDesc,
              QueryResultTypeInternal resultType,
              AbstractProjectionTemplate projectionTemplate)  | 
static ITemplatePacket | 
TemplatePacketFactory.createUidPacket(ITypeDesc typeDesc,
               String uid,
               Object routing,
               int version,
               QueryResultTypeInternal resultType,
               AbstractProjectionTemplate projectionTemplate)  | 
static ITemplatePacket | 
TemplatePacketFactory.createUidPacket(String uid,
               int version)  | 
static ITemplatePacket | 
TemplatePacketFactory.createUidPacket(String uid,
               int version,
               boolean returnOnlyUids)  | 
static ITemplatePacket | 
TemplatePacketFactory.createUidPacket(String uid,
               Object routing,
               int version,
               QueryResultTypeInternal resultType)  | 
static ITemplatePacket | 
TemplatePacketFactory.createUidResponsePacket(String uid,
                       int version)  | 
static ITemplatePacket | 
TemplatePacketFactory.createUidsPacket(String[] uids,
                QueryResultTypeInternal resultType,
                boolean returnOnlyUids)  | 
static ITemplatePacket | 
TemplatePacketFactory.createUidsResponsePacket(String[] uids)  | 
| Modifier and Type | Method and Description | 
|---|---|
static ITemplatePacket | 
PbsEntryFormatter.getCppTemplatePacketFromSqlQuery(SQLQuery<?> sqlQuery,
                                ISpaceProxy spaceProxy)  | 
static ITemplatePacket | 
PbsEntryFormatter.getTemplatePacketFromSqlQuery(SQLQuery<?> sqlQuery,
                             ISpaceProxy spaceProxy,
                             PbsProjectionTemplate projectionTemplate,
                             QueryResultTypeInternal resultType)  | 
static ITemplatePacket | 
PbsEntryFormatter.readPbsTemplate(PbsInputStream input,
               ISpaceProxy spaceProxy)  | 
static ITemplatePacket | 
PbsEntryFormatter.readPbsTemplate(PbsInputStream input,
               ISpaceProxy spaceProxy,
               ITypeDesc typeDescriptor)  | 
static ITemplatePacket | 
PbsEntryFormatter.readSqlQuery(PbsInputStream input,
            ISpaceProxy spaceProxy,
            ITypeDesc typeDescriptor)  | 
| Modifier and Type | Method and Description | 
|---|---|
static Map<Long,ITemplatePacket> | 
PbsPreparedTemplateCache.getCache()  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
AbstractIdsQueryPacket
A base template packet for IdsQueryPacket and IdsMultiRoutingQueryPacket The template packet
 contains an IDs array. 
 | 
class  | 
ExternalTemplatePacket
Created by IntelliJ IDEA. 
 | 
class  | 
IdQueryPacket
Used for querying the space by a class + id. 
 | 
class  | 
IdsMultiRoutingQueryPacket
A template packet used by readByIds operation. 
 | 
class  | 
IdsQueryPacket
A template packet used by readByIds operation. 
 | 
class  | 
UidQueryPacket
Used for querying the space by a uid / uids. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
SpaceCopyStatus | 
JSpaceAdminProxy.spaceCopy(IRemoteSpace remoteProxy,
         String remoteSpaceUrl,
         String remoteSpaceName,
         ITemplatePacket template,
         boolean includeNotifyTemplates,
         int chunkSize,
         SpaceContext spaceContext,
         SpaceContext remoteSpaceContext)  | 
SpaceCopyStatus | 
IInternalRemoteJSpaceAdmin.spaceCopy(IRemoteSpace remoteProxy,
         String remoteSpaceUrl,
         String remoteSpaceName,
         ITemplatePacket template,
         boolean includeNotifyTemplates,
         int chunkSize,
         SpaceContext spaceContext,
         SpaceContext remoteSpaceContext)
Given ISpaceInternal of a remote space, Copy all entries/notify templates from the space. 
 | 
SpaceCopyStatus | 
JSpaceAdminImpl.spaceCopy(IRemoteSpace remoteProxy,
         String remoteSpaceUrl,
         String remoteSpaceName,
         ITemplatePacket template,
         boolean includeNotifyTemplates,
         int chunkSize,
         SpaceContext sc,
         SpaceContext remoteSpaceContext)  | 
SpaceCopyStatus | 
JSpaceAdminProxy.spaceCopy(String remoteUrl,
         ITemplatePacket templPacket,
         boolean includeNotifyTemplates,
         int chunkSize)  | 
SpaceCopyStatus | 
IInternalRemoteJSpaceAdmin.spaceCopy(String remoteUrl,
         ITemplatePacket template,
         boolean includeNotifyTemplates,
         int chunkSize)
Given Url of a remote space, Copy all entries/notify templates from the space. 
 | 
SpaceCopyStatus | 
JSpaceAdminImpl.spaceCopy(String remoteUrl,
         ITemplatePacket template,
         boolean includeNotifyTemplates,
         int chunkSize)  | 
SpaceCopyStatus | 
JSpaceAdminProxy.spaceCopy(String remoteUrl,
         ITemplatePacket template,
         boolean includeNotifyTemplates,
         int chunkSize,
         SpaceContext sc)  | 
SpaceCopyStatus | 
IInternalRemoteJSpaceAdmin.spaceCopy(String remoteUrl,
         ITemplatePacket template,
         boolean includeNotifyTemplates,
         int chunkSize,
         SpaceContext sc)
Given Url of a remote space, Copy all entries/notify templates from the space. 
 | 
SpaceCopyStatus | 
JSpaceAdminImpl.spaceCopy(String remoteUrl,
         ITemplatePacket template,
         boolean includeNotifyTemplates,
         int chunkSize,
         SpaceContext sc)  | 
| Modifier and Type | Method and Description | 
|---|---|
ITemplatePacket | 
EntrySnapshot.getTemplatePacket()  | 
| Constructor and Description | 
|---|
EntrySnapshot(ITemplatePacket packet)  | 
| Modifier and Type | Method and Description | 
|---|---|
ITemplatePacket | 
QueryManager.getSQLTemplate(SQLQueryTemplatePacket template,
              Transaction txn)  | 
ITemplatePacket | 
IQueryManager.getSQLTemplate(SQLQueryTemplatePacket template,
              Transaction txn)  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
QueryTemplatePacket  | 
class  | 
SQLQueryTemplatePacket
A wrapper for the SQLQuery - gives it a facade of ITemplatePacket 
 | 
class  | 
UnionTemplatePacket
Represents query that is translated to several template packets The result is the union of all
 results 
 | 
Copyright © GigaSpaces.