Modifier and Type | Method and Description |
---|---|
IEntryPacket |
CursorEntryPacketIterator.next() |
IEntryPacket |
SpaceEntryPacketIterator.next() |
Modifier and Type | Method and Description |
---|---|
Iterable<IEntryPacket> |
ISpaceIteratorResult.getEntries() |
Modifier and Type | Method and Description |
---|---|
List<IEntryPacket> |
ISpaceIteratorAggregatorPartitionResult.getEntries() |
List<IEntryPacket> |
SpaceIteratorResult.getEntries() |
List<IEntryPacket> |
SpaceIteratorAggregatorPartitionResult.getEntries() |
Modifier and Type | Method and Description |
---|---|
void |
SpaceIteratorAggregatorPartitionResult.setEntries(List<IEntryPacket> entries) |
Modifier and Type | Method and Description |
---|---|
List<IEntryPacket> |
TieredSpaceIteratorResult.getEntries() |
List<IEntryPacket> |
TieredSpaceIteratorAggregatorPartitionResult.getEntries() |
Modifier and Type | Method and Description |
---|---|
void |
TieredSpaceIteratorAggregatorPartitionResult.setEntries(List<IEntryPacket> entries) |
Constructor and Description |
---|
DataSourceIdQueryImpl(ITypeDesc typeDescriptor,
IEntryPacket entryPacket,
SQLQueryBuilder queryBuilder,
Class<?> dataClass,
EntryAdapter entryAdapter) |
Constructor and Description |
---|
DataSourceIdsQueryImpl(ITypeDesc typeDescriptor,
Object[] ids,
IEntryHolder[] templates,
SQLQueryBuilder queryBuilder,
Class<?> dataClass,
IDataConverter<IEntryPacket> converter) |
Modifier and Type | Method and Description |
---|---|
static QueryResultTypeInternal |
QueryResultTypeInternal.getUpdateResultType(IEntryPacket packet) |
Modifier and Type | Method and Description |
---|---|
void |
LocalCache.addToCache(IEntryPacket entry,
int updateModifiers,
long readUpdateTime) |
void |
LocalCache.updateCache(IEntryPacket updatedPacket,
Object objectToUpdateWith,
Transaction txn,
long lease,
int updateModifiers,
long updateTime) |
void |
LocalCache.updateCache(IEntryPacket updatedPacket,
Transaction transaction,
long lease,
int updateModifiers,
long updateTime) |
Modifier and Type | Method and Description |
---|---|
void |
NotificationLocalViewListener.onExisting(IEntryPacket entry) |
Modifier and Type | Method and Description |
---|---|
void |
LocalViewReplicationEntryLeaseEventHandler.inEntryLeaseExpired(IReplicationInContext context,
IEntryPacket entryPacket) |
void |
LocalViewReplicationEntryEventHandler.removeEntry(IReplicationInContext context,
Transaction txn,
boolean twoPhaseCommit,
IEntryPacket entry) |
void |
LocalViewReplicationEntryEventHandler.updateEntry(IReplicationInContext context,
Transaction txn,
boolean twoPhaseCommit,
IEntryPacket entry,
IEntryPacket previousPacket,
boolean partialUpdate,
boolean overrideVersion) |
void |
LocalViewReplicationEntryEventHandler.writeEntry(IReplicationInContext context,
Transaction txn,
boolean twoPhaseCommit,
IEntryPacket entry) |
Modifier and Type | Field and Description |
---|---|
IEntryPacket |
WriteProxyActionInfo.entryPacket |
IEntryPacket[] |
WriteMultipleProxyActionInfo.entryPackets |
Modifier and Type | Method and Description |
---|---|
protected IEntryPacket |
CommonProxyActionInfo.toEntryPacket(ISpaceProxy spaceProxy,
Object entry,
ObjectType objectType) |
Modifier and Type | Method and Description |
---|---|
Object |
ReadTakeProxyActionInfo.convertQueryResult(ISpaceProxy spaceProxy,
IEntryPacket result,
AbstractProjectionTemplate projectionTemplate) |
Object[] |
ReadTakeMultipleProxyActionInfo.convertQueryResults(ISpaceProxy spaceProxy,
IEntryPacket[] results,
AbstractProjectionTemplate projectionTemplate) |
Object[] |
ReadTakeByIdsProxyActionInfo.convertResults(ISpaceProxy spaceProxy,
IEntryPacket[] results,
boolean returnPackets,
AbstractProjectionTemplate projectionTemplate) |
Modifier and Type | Method and Description |
---|---|
IEntryPacket |
SpaceProxyTypeManager.getEntryPacketFromObject(Object object,
ObjectType objectType) |
IEntryPacket |
ISpaceProxyTypeManager.getEntryPacketFromObject(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) |
LeaseContext<?> |
SpaceProxyTypeManager.convertWriteOrUpdateResult(LeaseContext<?> lease,
Object entry,
IEntryPacket entryPacekt,
int modifiers) |
LeaseContext<?> |
ISpaceProxyTypeManager.convertWriteOrUpdateResult(LeaseContext<?> result,
Object entry,
IEntryPacket entryPacket,
int modifiers) |
LeaseContext<?> |
SpaceProxyTypeManager.convertWriteResult(Object entry,
IEntryPacket entryPacket,
LeaseContext<?> lease) |
LeaseContext<?> |
ISpaceProxyTypeManager.convertWriteResult(Object entry,
IEntryPacket entryPacket,
LeaseContext<?> writeResult) |
Object |
SpaceProxyTypeManager.getObjectFromEntryPacket(IEntryPacket entryPacket,
QueryResultTypeInternal resultType,
boolean returnPacket) |
Object |
ISpaceProxyTypeManager.getObjectFromEntryPacket(IEntryPacket entryPacket,
QueryResultTypeInternal resultType,
boolean returnPacket) |
Object |
SpaceProxyTypeManager.getObjectFromEntryPacket(IEntryPacket entryPacket,
QueryResultTypeInternal resultType,
boolean returnPacket,
AbstractProjectionTemplate projectionTemplate) |
Object |
ISpaceProxyTypeManager.getObjectFromEntryPacket(IEntryPacket entryPacket,
QueryResultTypeInternal resultType,
boolean returnPacket,
AbstractProjectionTemplate projectionTemplate) |
Object |
SpaceProxyTypeManager.getObjectFromEntryPacket(IEntryPacket entryPacket,
QueryResultTypeInternal resultType,
boolean returnPacket,
StorageTypeDeserialization storageTypeDeserialization,
AbstractProjectionTemplate projectionTemplate) |
Object |
ISpaceProxyTypeManager.getObjectFromEntryPacket(IEntryPacket entryPacket,
QueryResultTypeInternal resultType,
boolean returnPacket,
StorageTypeDeserialization storageTypeDeserialization,
AbstractProjectionTemplate projectionTemplate) |
LeaseContext<?> |
SpaceProxyTypeManager.processWriteResult(WriteEntryResult writeResult,
Object entry,
IEntryPacket entryPacket) |
LeaseContext<?> |
ISpaceProxyTypeManager.processWriteResult(WriteEntryResult writeResult,
Object entry,
IEntryPacket entryPacket) |
Modifier and Type | Method and Description |
---|---|
IEntryPacket[] |
WriteEntriesSpaceOperationRequest.getEntriesPackets() |
IEntryPacket |
WriteEntrySpaceOperationRequest.getEntryPacket() |
IEntryPacket |
ReadTakeEntrySpaceOperationResult.getEntryPacket() |
IEntryPacket[] |
ReadTakeEntriesSpaceOperationResult.getEntryPackets() |
IEntryPacket[] |
ReadTakeEntriesByIdsSpaceOperationResult.getEntryPackets() |
IEntryPacket |
ReadTakeEntrySpaceOperationRequest.getFinalResult() |
IEntryPacket[] |
ReadTakeEntriesSpaceOperationRequest.getFinalResult() |
Modifier and Type | Method and Description |
---|---|
void |
ReadTakeEntrySpaceOperationResult.setEntryPacket(IEntryPacket entry) |
void |
ReadTakeEntriesSpaceOperationResult.setEntryPackets(IEntryPacket[] entryPackets) |
void |
ReadTakeEntriesByIdsSpaceOperationResult.setEntryPackets(IEntryPacket[] entryPackets) |
Constructor and Description |
---|
ReadTakeEntriesSpaceOperationResult(IEntryPacket[] entries) |
ReadTakeEntriesSpaceOperationResult(IEntryPacket[] entries,
Exception ex) |
WriteEntriesSpaceOperationRequest(ISpaceProxyTypeManager typeManager,
Object[] entries,
IEntryPacket[] entriesPackets,
Transaction txn,
long lease,
long[] leases,
long timeout,
int modifiers,
boolean broadcast) |
WriteEntrySpaceOperationRequest(IEntryPacket entryPacket,
Transaction txn,
long lease,
long timeout,
int modifiers,
boolean isUpdate) |
Modifier and Type | Method and Description |
---|---|
void |
IReplicationInEntryLeaseCancelledHandler.inCancelEntryLease(IReplicationInContext context,
IEntryPacket entryPacket) |
void |
IReplicationInEntryLeaseExpiredHandler.inEntryLeaseExpired(IReplicationInContext context,
IEntryPacket entryPacket) |
void |
AbstractReplicationEntryEventHandler.inRemoveEntry(IReplicationInContext context,
IEntryPacket entry) |
void |
IReplicationInEntryHandler.inRemoveEntry(IReplicationInContext context,
IEntryPacket entryPacket) |
void |
AbstractReplicationEntryEventHandler.inUpdateEntry(IReplicationInContext context,
IEntryPacket entry,
IEntryPacket oldEntryPacket,
boolean partialUpdate,
boolean overrideVersion,
short flags) |
void |
IReplicationInEntryHandler.inUpdateEntry(IReplicationInContext context,
IEntryPacket entryPacket,
IEntryPacket oldEntryPacket,
boolean partialUpdate,
boolean overrideVersion,
short flags) |
void |
AbstractReplicationEntryEventHandler.inWriteEntry(IReplicationInContext context,
IEntryPacket entry) |
void |
IReplicationInEntryHandler.inWriteEntry(IReplicationInContext context,
IEntryPacket entryPacket) |
abstract void |
AbstractReplicationEntryEventHandler.removeEntry(IReplicationInContext context,
Transaction txn,
boolean twoPhaseCommit,
IEntryPacket entry) |
abstract void |
AbstractReplicationEntryEventHandler.updateEntry(IReplicationInContext context,
Transaction txn,
boolean twoPhaseCommit,
IEntryPacket entry,
IEntryPacket previousPacket,
boolean partialUpdate,
boolean overrideVersion) |
abstract void |
AbstractReplicationEntryEventHandler.writeEntry(IReplicationInContext context,
Transaction txn,
boolean twoPhaseCommit,
IEntryPacket entry) |
Modifier and Type | Method and Description |
---|---|
void |
ReplicationNodeInFacade.inCancelEntryLease(IReplicationInContext context,
IEntryPacket entryPacket) |
void |
ReplicationNodeInFacade.inEntryLeaseExpired(IReplicationInContext context,
IEntryPacket entryPacket) |
void |
ReplicationNodeInFacade.inRemoveEntry(IReplicationInContext context,
IEntryPacket entryPacket) |
void |
ReplicationNodeInFacade.inUpdateEntry(IReplicationInContext context,
IEntryPacket entryPacket,
IEntryPacket oldEntryPacket,
boolean partialUpdate,
boolean overrideVersion,
short flags) |
void |
ReplicationNodeInFacade.inWriteEntry(IReplicationInContext context,
IEntryPacket entryPacket) |
Modifier and Type | Method and Description |
---|---|
protected void |
AbstractLocalClusterReplicationInHandler.handleRemoveEntry(IEntryPacket entryPacket,
IReplicationInBatchContext batchContext) |
protected void |
AbstractLocalClusterReplicationInHandler.handleUpdateEntry(IEntryPacket entryPacket,
IEntryPacket oldEntryPacket,
IReplicationInBatchContext batchContext,
boolean partialUpdate) |
protected void |
AbstractLocalClusterReplicationInHandler.handleWriteEntry(IEntryPacket entryPacket,
IReplicationInBatchContext batchContext) |
void |
LocalClusterReplicationEntryLeaseEventHandler.inCancelEntryLease(IReplicationInContext context,
IEntryPacket entryPacket) |
void |
LocalClusterReplicationInEntryHandler.inRemoveEntry(IReplicationInContext context,
IEntryPacket entryPacket) |
void |
LocalClusterReplicationInEntryHandler.inUpdateEntry(IReplicationInContext context,
IEntryPacket entryPacket,
IEntryPacket oldEntryPacket,
boolean partialUpdate,
boolean overrideVersion,
short flags) |
void |
LocalClusterReplicationInEntryHandler.inWriteEntry(IReplicationInContext context,
IEntryPacket entryPacket) |
void |
LocalClusterReplicationInTransactionHandler.removeEntry(IReplicationInBatchContext context,
IEntryPacket entryPacket) |
void |
LocalClusterReplicationInTransactionHandler.updateEntry(IReplicationInBatchContext context,
IEntryPacket entryPacket,
IEntryPacket oldEntryPacket,
boolean partialUpdate,
short flags) |
void |
LocalClusterReplicationFixFacade.write(IEntryPacket entryPacket) |
void |
LocalCLusterReplicationReplicaConsumeFacade.write(IEntryPacket entryPacket,
IMarker evictionMarker,
SpaceCopyReplicaParameters.ReplicaType replicaType) |
void |
LocalClusterReplicationInTransactionHandler.writeEntry(IReplicationInBatchContext context,
IEntryPacket entryPacket) |
Constructor and Description |
---|
AbstractLocalClusterWriteOperationData(ISpaceProxy spaceProxy,
IEntryPacket entryPacket) |
LocalClusterPartialUpdateOperationData(ISpaceProxy spaceProxy,
IEntryPacket entryPacket) |
LocalClusterRemoveOperationData(ISpaceProxy spaceProxy,
IEntryPacket entryPacket) |
LocalClusterUpdateOperationData(ISpaceProxy spaceProxy,
IEntryPacket entryPacket) |
LocalClusterWriteOperationData(ISpaceProxy spaceProxy,
IEntryPacket entryPacket) |
Modifier and Type | Method and Description |
---|---|
protected ExtendedAnswerHolder |
AbstractSpaceReplicationEntryEventHandler.executeUpdateOperation(IReplicationInContext context,
Transaction txn,
IEntryPacket entry,
IEntryPacket previousEntry,
boolean partialUpdate,
boolean overrideVersion,
long lease,
boolean twoPhaseCommit,
int updateModifiers) |
protected ExtendedAnswerHolder |
PrimaryBackupSpaceReplicationEvictionProtectionEntryEventHandler.executeUpdateOperation(IReplicationInContext context,
Transaction txn,
IEntryPacket entry,
IEntryPacket previousEntry,
boolean partialUpdate,
boolean overrideVersion,
long lease,
boolean twoPhaseCommit,
int updateModifiers) |
void |
ReplicationInExceptionHandler.handleEntryAlreadyInSpaceOnWrite(IReplicationInContext context,
IEntryPacket entryPacket) |
void |
ReplicationInExceptionHandler.handleEntryLockedByTransactionOnTake(org.slf4j.Logger logger,
IEntryPacket entryPacket) |
void |
ReplicationInExceptionHandler.handleEntryLockedByTransactionOnUpdate(org.slf4j.Logger logger,
IEntryPacket entryPacket) |
void |
ReplicationInExceptionHandler.handleEntryNotInSpaceOnTake(org.slf4j.Logger logger,
IEntryPacket entryPacket) |
void |
ReplicationInExceptionHandler.handleEntryNotInSpaceOnUpdate(org.slf4j.Logger logger,
IEntryPacket entryPacket,
EntryNotInSpaceException ex) |
void |
ReplicationInExceptionHandler.handleEntryVersionConflictOnTake(org.slf4j.Logger logger,
IEntryPacket entryPacket,
EntryVersionConflictException ex) |
void |
ReplicationInExceptionHandler.handleEntryVersionConflictOnUpdate(org.slf4j.Logger logger,
IEntryPacket entryPacket,
EntryVersionConflictException ex) |
void |
ReplicationInExceptionHandler.handleEntryVersionConflictOnUpdate(org.slf4j.Logger logger,
IEntryPacket entryPacket,
EntryVersionConflictException ex,
LogLevel logLevel) |
void |
SpaceReplicationEntryLeaseEventHandler.inCancelEntryLease(IReplicationInContext context,
IEntryPacket entryPacket) |
void |
SpaceReplicationEntryLeaseEventHandler.inEntryLeaseExpired(IReplicationInContext context,
IEntryPacket entryPacket) |
void |
SpaceReplicationTransactionEventHandler.removeEntry(IReplicationInContext context,
Transaction txn,
boolean twoPhaseCommit,
IEntryPacket entry) |
void |
AbstractSpaceReplicationEntryEventHandler.removeEntry(IReplicationInContext context,
Transaction txn,
boolean twoPhaseCommit,
IEntryPacket entry) |
protected boolean |
ActiveActiveSpaceReplicationEntryEventHandler.shouldUpdateEntryInSpace(IReplicationInContext context,
Transaction txn,
boolean twoPhaseCommit,
IEntryPacket entry) |
protected abstract boolean |
AbstractSpaceReplicationEntryEventHandler.shouldUpdateEntryInSpace(IReplicationInContext context,
Transaction txn,
boolean twoPhaseCommit,
IEntryPacket entry) |
protected boolean |
PrimaryBackupSpaceReplicationEntryEventHandler.shouldUpdateEntryInSpace(IReplicationInContext context,
Transaction txn,
boolean twoPhaseCommit,
IEntryPacket entry) |
void |
AbstractSpaceReplicationEntryEventHandler.updateEntry(IReplicationInContext context,
Transaction txn,
boolean twoPhaseCommit,
IEntryPacket entry,
IEntryPacket previousEntry,
boolean partialUpdate,
boolean overrideVersion) |
void |
SpaceReplicationTransactionEventHandler.updateEntry(IReplicationInContext context,
Transaction txn,
boolean twoPhaseCommit,
IEntryPacket entry,
IEntryPacket previousEntryPacket,
boolean partialUpdate,
boolean overrideVersion,
short flags) |
protected void |
BlobstorePrimaryBackupSpaceReplicationEntryEventHandler.updateEntryInSpace(IReplicationInContext context,
Transaction txn,
IEntryPacket entry,
IEntryPacket previousEntry,
boolean partialUpdate,
boolean overrideVersion,
long lease,
boolean twoPhaseCommit) |
protected void |
AbstractSpaceReplicationEntryEventHandler.updateEntryInSpace(IReplicationInContext context,
Transaction txn,
IEntryPacket entry,
IEntryPacket previousEntry,
boolean partialUpdate,
boolean overrideVersion,
long lease,
boolean twoPhaseCommit) |
protected void |
PrimaryBackupSpaceReplicationEntryEventHandler.updateEntryInSpace(IReplicationInContext context,
Transaction txn,
IEntryPacket entry,
IEntryPacket previousEntry,
boolean partialUpdate,
boolean overrideVersion,
long lease,
boolean twoPhaseCommit) |
protected ExtendedAnswerHolder |
ActiveActiveSpaceReplicationEntryEventHandler.updateOrWrite(IReplicationInContext context,
Transaction transaction,
IEntryPacket entryPacket,
long lease,
int updateModifiers) |
protected abstract ExtendedAnswerHolder |
AbstractSpaceReplicationEntryEventHandler.updateOrWrite(IReplicationInContext context,
Transaction txn,
IEntryPacket entry,
long lease,
int modifiers) |
protected ExtendedAnswerHolder |
PrimaryBackupSpaceReplicationEntryEventHandler.updateOrWrite(IReplicationInContext context,
Transaction transaction,
IEntryPacket entryPacket,
long lease,
int updateModifiers) |
void |
SpaceReplicationTransactionEventHandler.writeEntry(IReplicationInContext context,
Transaction txn,
boolean twoPhaseCommit,
IEntryPacket entry) |
void |
AbstractSpaceReplicationEntryEventHandler.writeEntry(IReplicationInContext context,
Transaction txn,
boolean twoPhaseCommit,
IEntryPacket entry) |
protected void |
BlobstorePrimaryBackupSpaceReplicationEntryEventHandler.writeEntryIntoSpace(IReplicationInContext context,
Transaction txn,
IEntryPacket entry,
long lease,
boolean twoPhaseCommit) |
protected void |
AbstractSpaceReplicationEntryEventHandler.writeEntryIntoSpace(IReplicationInContext context,
Transaction txn,
IEntryPacket entry,
long lease,
boolean twoPhaseCommit) |
protected void |
PrimaryBackupSpaceReplicationEntryEventHandler.writeEntryIntoSpace(IReplicationInContext context,
Transaction txn,
IEntryPacket entry,
long lease,
boolean twoPhaseCommit) |
Modifier and Type | Method and Description |
---|---|
void |
NotificationReplicationDataConsumeFixFacade.write(IEntryPacket entryPacket) |
Modifier and Type | Method and Description |
---|---|
void |
ITransactionalBatchExecutionCallback.removeEntry(IReplicationInBatchContext context,
IEntryPacket entryPacket) |
void |
ITransactionalExecutionCallback.removeEntry(IReplicationInContext context,
Transaction transaction,
boolean twoPhaseCommit,
IEntryPacket entryPacket) |
void |
ITransactionalBatchExecutionCallback.updateEntry(IReplicationInBatchContext context,
IEntryPacket entryPacket,
IEntryPacket oldEntryPacket,
boolean partialUpdate,
short flags) |
void |
ITransactionalExecutionCallback.updateEntry(IReplicationInContext context,
Transaction transaction,
boolean twoPhaseCommit,
IEntryPacket entryPacket,
IEntryPacket previousEntryPacket,
boolean partialUpdate,
boolean overrideVersion,
short flags) |
void |
IDataConsumeFixFacade.write(IEntryPacket entryPacket) |
void |
SpaceEngineFixFacade.write(IEntryPacket entryPacket) |
void |
ITransactionalBatchExecutionCallback.writeEntry(IReplicationInBatchContext context,
IEntryPacket entryPacket) |
void |
ITransactionalExecutionCallback.writeEntry(IReplicationInContext context,
Transaction transaction,
boolean twoPhaseCommit,
IEntryPacket entryPacket) |
Constructor and Description |
---|
ResurrectEntryFix(IEntryPacket entryPacket) |
Constructor and Description |
---|
NotifyReplicationFilterEntryDataWrapper(AbstractReplicationPacketSingleEntryData data,
IEntryPacket entryPacket,
ITypeDesc typeDesc,
int objectType,
NotifyInfo notifyInfo) |
ReplicationFilterEntryDataWrapper(AbstractReplicationPacketSingleEntryData data,
IEntryPacket entryPacket,
ITypeDesc typeDesc,
ReplicationOperationType operationType,
int objectType) |
Modifier and Type | Method and Description |
---|---|
IEntryPacket |
SingleReplicationPacketData.getEntryPacket() |
IEntryPacket |
UpdateReplicationPacketData.getPreviousEntryPacket() |
Modifier and Type | Method and Description |
---|---|
SingleReplicationPacketData |
SingleReplicationPacketData.cloneWithEntryPacket(IEntryPacket entryPacket) |
Constructor and Description |
---|
CancelLeaseFullReplicationPacketData(IEntryPacket entry,
boolean fromGateway) |
EntryLeaseExpiredFullReplicationPacketData(IEntryPacket entry,
boolean fromGateway) |
PartialUpdateReplicationPacketData(IEntryPacket entry,
boolean fromGateway,
boolean overrideVersion,
IEntryData previousEntryData,
long expertaionTime,
IEntryData currentEntryData) |
RemoveReplicationPacketData(IEntryPacket entry,
boolean fromGateway,
IEntryData entryData,
boolean fullEntryPacket) |
RemoveReplicationPacketData(IEntryPacket entry,
boolean fromGateway,
IEntryData entryData,
boolean fullEntryPacket,
boolean backupOnly) |
SingleReplicationPacketData(IEntryPacket entry,
boolean fromGateway) |
UpdateReplicationPacketData(IEntryPacket entry,
boolean fromGateway,
boolean overrideVersion,
IEntryData previousEntryData,
short flags,
long expirationTime,
IEntryData currentEntryData) |
WriteReplicationPacketData(IEntryPacket entry,
boolean fromGateway,
long expirationTime) |
WriteReplicationPacketData(IEntryPacket entry,
boolean fromGateway,
long expirationTime,
boolean backupOnly) |
Modifier and Type | Method and Description |
---|---|
void |
ISpaceReplicaConsumeFacade.write(IEntryPacket entryPacket,
IMarker evictionMarker,
SpaceCopyReplicaParameters.ReplicaType replicaType) |
Modifier and Type | Method and Description |
---|---|
IEntryPacket |
AbstractEntryReplicaData.getEntryPacket() |
Modifier and Type | Method and Description |
---|---|
protected ITypeDesc |
AbstractReplicaData.getTypeDescriptor(SpaceTypeManager spaceTypeManager,
IEntryPacket entryPacket) |
void |
AbstractEntryReplicaData.setEntryPacket(IEntryPacket _entryPacket) |
Constructor and Description |
---|
AbstractEntryReplicaData(IEntryPacket entryPacket) |
DirectPersistencyEntryReplicaData(IEntryPacket entryPacket) |
EntryCopyReplicaData(IEntryPacket entryPacket) |
EntrySynchronizeReplicaData(IEntryPacket entryPacket,
IMarker marker) |
Constructor and Description |
---|
ReplicationFilterEntryReplicaDataWrapper(IEntryPacket entryPacket,
ITypeDesc typeDesc) |
Constructor and Description |
---|
EntryPacketServerEntryAdapter(IEntryPacket entryPacket) |
Modifier and Type | Method and Description |
---|---|
void |
DocumentObjectConverterInternal.convertNonPrimitivePropertiesToDocuments(IEntryPacket entryPacket) |
void |
DocumentObjectConverterInternal.convertNonPrimitivePropertiesToStrings(IEntryPacket entryPacket) |
Modifier and Type | Method and Description |
---|---|
protected EntryArrivedRemoteEvent |
AbstractReplicationNotificationInEntryHandler.createEntryArrivedRemoteEvent(IEntryPacket entryPacket,
IEntryPacket oldEntryPacket,
NotifyActionType notifyActionType) |
void |
AbstractReplicationNotificationInEntryHandler.handleEntryLeaseExpired(IReplicationInContext context,
boolean inTransaction,
IEntryPacket entryPacket) |
void |
AbstractReplicationNotificationInEntryHandler.handleRemoveEntry(IReplicationInContext context,
boolean inTransaction,
IEntryPacket entryPacket) |
void |
AbstractReplicationNotificationInEntryHandler.handleUpdateEntry(IReplicationInContext context,
boolean inTransaction,
IEntryPacket entryPacket,
IEntryPacket oldEntryPacket,
boolean partialUpdate,
boolean overrideVersion,
short flags) |
void |
AbstractReplicationNotificationInEntryHandler.handleWriteEntry(IReplicationInContext context,
boolean inTransaction,
IEntryPacket entryPacket) |
void |
AbstractReplicationNotificationInEntryHandler.inEntryLeaseExpired(IReplicationInContext context,
IEntryPacket entryPacket) |
void |
AbstractReplicationNotificationInEntryHandler.inRemoveEntry(IReplicationInContext context,
IEntryPacket entryPacket) |
void |
AbstractReplicationNotificationInEntryHandler.inUpdateEntry(IReplicationInContext context,
IEntryPacket entryPacket,
IEntryPacket oldEntryPacket,
boolean partialUpdate,
boolean overrideVersion,
short flags) |
void |
AbstractReplicationNotificationInEntryHandler.inWriteEntry(IReplicationInContext context,
IEntryPacket entryPacket) |
void |
ReplicationNotificationInTransactionEntryHandler.removeEntry(IReplicationInBatchContext context,
IEntryPacket entryPacket) |
void |
ReplicationNotificationInTransactionEntryHandler.updateEntry(IReplicationInBatchContext context,
IEntryPacket entryPacket,
IEntryPacket oldEntryPacket,
boolean partialUpdate,
short flags) |
void |
ReplicationNotificationInTransactionEntryHandler.writeEntry(IReplicationInBatchContext context,
IEntryPacket entryPacket) |
Modifier and Type | Method and Description |
---|---|
static IEntryPacket[] |
IOUtils.readEntryPacketArray(ObjectInput in) |
Modifier and Type | Method and Description |
---|---|
Object |
ITypeIntrospector.getPathValue(IEntryPacket entryPacket,
String path) |
Object |
AbstractTypeIntrospector.getPathValue(IEntryPacket entryPacket,
String path) |
T |
ITypeIntrospector.toObject(IEntryPacket packet) |
T |
AbstractTypeIntrospector.toObject(IEntryPacket packet) |
T |
ExternalEntryIntrospector.toObject(IEntryPacket packet,
StorageTypeDeserialization storageTypeDeserialization) |
T |
ITypeIntrospector.toObject(IEntryPacket packet,
StorageTypeDeserialization storageTypeDeserialization) |
T |
AbstractTypeIntrospector.toObject(IEntryPacket packet,
StorageTypeDeserialization storageTypeDeserialization) |
Modifier and Type | Method and Description |
---|---|
void |
ContinousQueryListener.onExisting(IEntryPacket entry) |
Modifier and Type | Method and Description |
---|---|
IEntryPacket[] |
ReadByIdsContext.getResults() |
IEntryPacket[] |
BatchQueryOperationContext.processReturnedValueForBatchOperation(ITemplateHolder template) |
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) |
Modifier and Type | Method and Description |
---|---|
protected List<IEntryPacket> |
BatchQueryOperationContext.createResultList(ITemplatePacket template,
int maxEntries)
Create a list that will accumulate the batch operation results.
|
List<IEntryPacket> |
BatchQueryOperationContext.getResults() |
Modifier and Type | Method and Description |
---|---|
void |
BatchQueryOperationContext.addResult(IEntryPacket result) |
static void |
SpaceImpl.applyEntryPacketOutFilter(IEntryPacket entryPacket,
int modifiers,
AbstractProjectionTemplate projectionTemplate) |
boolean |
SpaceEngine.isNoWriteLease(IEntryPacket entryPacket,
int modifiers,
boolean fromReplication) |
AnswerHolder |
SpaceEngine.newAdaptUpdateMultiple(IEntryPacket[] entries,
Transaction txn,
long lease,
long[] leases,
SpaceContext sc,
long timeout,
int modifiers) |
AnswerHolder |
SpaceEngine.newUpdateMultiple(IEntryPacket[] entries,
Transaction txn,
long[] leases,
SpaceContext sc,
long timeout,
int operationModifiers)
perform update of multiple entries.
|
WriteEntriesResult |
SpaceEngine.oldAdaptUpdateMultiple(IEntryPacket[] entries,
Transaction txn,
long lease,
long[] leases,
SpaceContext sc,
int modifiers,
boolean newRouter) |
ExtendedAnswerHolder |
SpaceEngine.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 |
SpaceEngine.update(IEntryPacket updated_entry,
Transaction txn,
long lease,
long timeout,
SpaceContext sc,
boolean fromReplication,
boolean origin,
boolean newRouter,
int modifiers,
MultipleIdsContext multipleIdsContext) |
AnswerPacket |
SpaceImpl.update(IEntryPacket entry,
Transaction txn,
long lease,
long timeout,
SpaceContext sc,
int modifiers,
boolean newRouter) |
Object[] |
SpaceEngine.updateMultiple(IEntryPacket[] entries,
Transaction txn,
long[] leases,
SpaceContext sc,
int operationModifiers,
boolean newRouter)
perform update of multiple entries.
|
WriteEntriesResult |
SpaceEngine.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.
|
WriteEntriesResult |
SpaceImpl.write(IEntryPacket[] entries,
Transaction txn,
long lease,
long[] leases,
SpaceContext sc,
long timeout,
int modifiers,
boolean newRouter) |
void |
SpaceEngineReplicaDirectPersistencySyncConsumerFacade.write(IEntryPacket entryPacket,
IMarker evictionMarker,
SpaceCopyReplicaParameters.ReplicaType replicaType) |
void |
SpaceEngineReplicaConsumerFacade.write(IEntryPacket entryPacket,
IMarker evictionMarker,
SpaceCopyReplicaParameters.ReplicaType replicaType) |
WriteEntryResult |
SpaceEngine.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.
|
WriteEntryResult |
SpaceImpl.write(IEntryPacket entry,
Transaction txn,
long lease,
int modifiers,
boolean fromReplication,
SpaceContext sc) |
LeaseContext<?>[] |
SpaceImpl.writeOld(IEntryPacket[] entries,
Transaction txn,
long lease,
long[] leases,
SpaceContext sc,
int modifiers) |
Modifier and Type | Method and Description |
---|---|
protected void |
BatchQueryOperationContext.setResults(List<IEntryPacket> _results) |
Constructor and Description |
---|
UpdateMultipleContext(ITemplateHolder concentratingTemplate,
IEntryPacket[] entries,
long[] leases,
int operationModifiers,
long timeout,
SpaceEngine engine,
XtnEntry xtnEntry) |
UpdateOrWriteMultipleContext(ITemplateHolder concentratingTemplate,
IEntryPacket[] entries,
long[] leases,
int operationModifiers,
long timeout,
SpaceEngine engine,
XtnEntry xtnEntry) |
Modifier and Type | Method and Description |
---|---|
void |
BroadcastTableHandler.pushEntries(IEntryPacket[] entryPackets,
long lease,
long[] leases,
long timeout,
int modifiers) |
void |
BroadcastTableHandler.pushEntry(IEntryPacket entryPacket,
long lease,
boolean isUpdate,
long timeout,
int modifiers) |
Modifier and Type | Method and Description |
---|---|
IEntryPacket[] |
ServerIteratorInfo.getStoredEntryPacketsBatch() |
Modifier and Type | Method and Description |
---|---|
ServerIteratorInfo |
ServerIteratorInfo.setStoredEntryPacketsBatch(IEntryPacket[] storedEntryPacketsBatch) |
Modifier and Type | Method and Description |
---|---|
IEntryPacket |
WriteEntryResult.getPrevEntry() |
Modifier and Type | Method and Description |
---|---|
void |
WriteEntryResult.setPrevEntry(IEntryPacket prevEntry) |
Constructor and Description |
---|
WriteEntryResult(IEntryPacket entryPacket) |
Modifier and Type | Method and Description |
---|---|
List<IEntryPacket> |
WriteBatch.getEntries() |
Modifier and Type | Method and Description |
---|---|
IEntryPacket |
TemplateHolder.getUpdateOperationEntry() |
IEntryPacket |
ITemplateHolder.getUpdateOperationEntry() |
Modifier and Type | Method and Description |
---|---|
static IEntryHolder |
EntryHolderFactory.createEntryHolder(IServerTypeDesc typeDesc,
IEntryPacket entryPacket,
EntryDataType entryDataType)
Used by DataAdaptor, the EntryHolder Ctor make sure the version is always bigger than 0.
|
static IEntryHolder |
EntryHolderFactory.createEntryHolder(IServerTypeDesc typeDesc,
IEntryPacket entryPacket,
EntryDataType entryDataType,
String uid,
long expirationTime,
XtnEntry xidOriginated,
long scn,
boolean blobStoreEntryHolder,
boolean isMvcc) |
static IEntryHolder |
EntryHolderFactory.createEntryHolder(IServerTypeDesc typeDesc,
IEntryPacket entryPacket,
EntryDataType entryDataType,
String uid,
long expirationTime,
XtnEntry xidOriginated,
long scn,
int versionID,
boolean keepExpiration,
boolean blobStoreEntryHolder,
boolean isMvcc) |
static ITemplateHolder |
TemplateHolderFactory.createTemplateHolderForReplication(IServerTypeDesc typeDesc,
IEntryPacket template,
String uid,
long expirationTime)
Special builder method for reading object before replicating
|
static ITemplateHolder |
TemplateHolderFactory.createUpdateTemplateHolder(IServerTypeDesc typeDesc,
IEntryPacket template,
String uid,
long expirationTime,
XtnEntry xidOriginated,
long SCN,
IResponseContext respContext,
int operationModifiers)
Special builder method for update that uses TemplateHolder instead EntryHolder
|
void |
TemplateHolder.setForAfterOperationFilter(int afterOpFilterCode,
SpaceContext sc,
FilterManager fm,
IEntryPacket updateOperationEntry) |
void |
ITemplateHolder.setForAfterOperationFilter(int afterOpFilterCode,
SpaceContext sc,
FilterManager fm,
IEntryPacket updateOperationEntry) |
Constructor and Description |
---|
TemplateHolder(IServerTypeDesc typeDesc,
IEntryPacket packet,
String uid,
long expirationTime,
XtnEntry xidOriginated,
long scn,
int templateOperation,
IResponseContext respContext,
int operationModifiers) |
Modifier and Type | Method and Description |
---|---|
IEntryPacket |
PushBroadcastTableEntrySpaceRequestInfo.getEntry() |
IEntryPacket[] |
PushBroadcastTableEntriesSpaceRequestInfo.getEntryPackets() |
Constructor and Description |
---|
PushBroadcastTableEntriesSpaceRequestInfo(IEntryPacket[] entryPackets,
long lease,
long[] leases,
long timeout,
int modifiers) |
PushBroadcastTableEntrySpaceRequestInfo(IEntryPacket entryPacket,
long lease,
boolean isUpdate,
long timeout,
int modifiers) |
Modifier and Type | Method and Description |
---|---|
IEntryPacket[] |
BroadcastTableSpaceResponseInfo.getEntries() |
Modifier and Type | Method and Description |
---|---|
void |
BroadcastTableSpaceResponseInfo.setEntries(IEntryPacket[] newEntries) |
Constructor and Description |
---|
SyncHybridOperationDetails(String spaceName,
DataSyncOperationType dataSyncOperationType,
IEntryPacket entryPacket) |
Modifier and Type | Field and Description |
---|---|
protected IEntryPacket |
MirrorBulkDataItem._dataPacket |
Modifier and Type | Field and Description |
---|---|
protected IDataConverter<IEntryPacket> |
MirrorBulkDataItem._converter |
Modifier and Type | Method and Description |
---|---|
IEntryPacket |
MirrorBulkDataItem.toEntryPacket() |
IEntryPacket |
MirrorChangeBulkDataItem.toEntryPacket() |
Modifier and Type | Method and Description |
---|---|
IDataConverter<IEntryPacket> |
MirrorBulkDataItem.getConverter() |
Modifier and Type | Method and Description |
---|---|
void |
MirrorReplicationInHandler.addRemoveEntry(IReplicationInBatchContext context,
IEntryPacket entryPacket) |
void |
MirrorReplicationInHandler.addUpdateEntry(IReplicationInBatchContext context,
IEntryPacket entryPacket,
IEntryPacket oldEntryPacket,
boolean partialUpdate) |
void |
MirrorReplicationInHandler.addWriteEntry(IReplicationInBatchContext context,
IEntryPacket entryPacket) |
void |
MirrorReplicationInEntryHandler.inRemoveEntry(IReplicationInContext context,
IEntryPacket entryPacket) |
void |
MirrorReplicationInEntryHandler.inUpdateEntry(IReplicationInContext context,
IEntryPacket entryPacket,
IEntryPacket oldEntryPacket,
boolean partialUpdate,
boolean overrideVersion,
short flags) |
void |
MirrorReplicationInEntryHandler.inWriteEntry(IReplicationInContext context,
IEntryPacket entryPacket) |
void |
MirrorReplicationInHandler.removeEntry(IReplicationInBatchContext context,
IEntryPacket entryPacket) |
void |
MirrorReplicationInHandler.updateEntry(IReplicationInBatchContext context,
IEntryPacket entryPacket,
IEntryPacket oldEntryPacket,
boolean partialUpdate,
short flags) |
void |
MirrorFixFacade.write(IEntryPacket entryPacket) |
void |
MirrorReplicationInHandler.writeEntry(IReplicationInBatchContext context,
IEntryPacket entryPacket) |
Modifier and Type | Method and Description |
---|---|
void |
MirrorBulkDataItem.setConverter(IDataConverter<IEntryPacket> converter) |
void |
MirrorChangeBulkDataItem.setConverter(IDataConverter<IEntryPacket> converter) |
Constructor and Description |
---|
MirrorBulkDataItem(IEntryPacket dataPacket,
short operation) |
PartialUpdateMirrorBulkItem(IEntryPacket dataPacket,
short operation) |
Modifier and Type | Interface and Description |
---|---|
interface |
ITemplatePacket
Extends IEntryPacket and provides an interface for templates.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractEntryPacket |
class |
AbstractQueryPacket |
class |
EmptyQueryPacket |
class |
EntryPacket
This class represents a packet of information transmitted between a J-Space client and its
J-Space server (and vice versa).
|
class |
ExternalizableEntryPacket
the entry packet used to move
Externalizable object from the proxy to the server. |
class |
ExternalizableTemplatePacket
Implements
ITemplatePacket for Externalizable classes. |
class |
HybridEntryPacket |
class |
PbsEntryPacket |
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 |
---|---|
IEntryPacket |
HybridEntryPacket.clone()
Returns a shallow copy of this EntryPacket instance.
|
IEntryPacket |
AbstractEntryPacket.clone() |
IEntryPacket |
PbsEntryPacket.clone() |
IEntryPacket |
IEntryPacket.clone() |
IEntryPacket |
EntryPacket.clone()
Returns a shallow copy of this EntryPacket instance.
|
static <T> IEntryPacket |
EntryPacketFactory.createFromObject(T entry,
ITypeDesc typeDesc,
EntryType entryType,
boolean ignoreAutoGenerateUid)
Creates an entry packet from an object.
|
static IEntryPacket |
EntryPacketFactory.createFullPacket(Context context,
IEntryHolder entry,
ITemplateHolder template) |
static IEntryPacket |
EntryPacketFactory.createFullPacket(Context context,
IEntryHolder entry,
ITemplateHolder template,
IEntryData entryData) |
static IEntryPacket |
EntryPacketFactory.createFullPacket(Context context,
IEntryHolder entry,
ITemplateHolder template,
String uid) |
static IEntryPacket |
EntryPacketFactory.createFullPacket(Context context,
ITemplateHolder template,
IEntryData entryData,
String uid,
boolean isTransient) |
static IEntryPacket |
EntryPacketFactory.createFullPacket(IEntryData entryData,
OperationID operationID,
String uid,
boolean isTransient,
QueryResultTypeInternal queryResultType) |
static IEntryPacket |
EntryPacketFactory.createFullPacket(IEntryHolder entryHolder,
ITemplateHolder template,
String uid,
long timeToLive,
IEntryData entryData,
OperationID operationId) |
static IEntryPacket |
EntryPacketFactory.createFullPacketForReplication(IEntryHolder entryHolder,
ITemplateHolder template,
String uid,
long timeToLive) |
static IEntryPacket |
EntryPacketFactory.createFullPacketForReplication(IEntryHolder entryHolder,
OperationID operationID) |
static IEntryPacket |
EntryPacketFactory.createPartialUpdatePacketForReplication(IEntryHolder entryHolder,
OperationID operationID,
boolean[] partialUpdatedValuesIndicators) |
static IEntryPacket |
EntryPacketFactory.createRemovePacketForPersistency(IEntryHolder entryHolder,
OperationID operationID) |
Modifier and Type | Method and Description |
---|---|
void |
PathsProjectionHandler.applyDynamicPathsProjections(IEntryPacket entryPacket,
Map<String,Object> projectedDynamicProperties) |
void |
PathsProjectionHandler.applyFixedPathsProjections(IEntryPacket entryPacket,
Object[] projectedValues) |
static ITemplatePacket |
TemplatePacketFactory.createFullPacket(IEntryPacket entryPacket) |
static ITemplatePacket |
TemplatePacketFactory.createFullPacket(IEntryPacket entryPacket,
ITypeDesc typeDesc,
boolean isTransient) |
void |
AbstractProjectionTemplate.filterOutNonProjectionProperties(IEntryPacket entryPacket)
given a bentry-packet perform projection on it
|
void |
MutliProjectionByUids.filterOutNonProjectionProperties(IEntryPacket entryPacket)
given a entry-packet perform projection on it
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractIdsQueryPacket
A base template packet for IdsQueryPacket and IdsMultiRoutingQueryPacket The template packet
contains an IDs array.
|
class |
ExternalEntryPacket
Represents an ExternalEntry as an IEntryPacket
|
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 |
LocalCacheResponseEntryPacket |
class |
UidQueryPacket
Used for querying the space by a uid / uids.
|
Modifier and Type | Field and Description |
---|---|
IEntryPacket |
AnswerPacket.m_EntryPacket |
IEntryPacket |
UpdateOrWriteContext.packet |
Modifier and Type | Method and Description |
---|---|
IEntryPacket[] |
AnswerHolder.getEntryPackets() |
Modifier and Type | Method and Description |
---|---|
long |
LeaseManager.getExpirationOnUpdateByLeaseOrByTimeRule(long lease,
long startTime,
IEntryPacket entry,
boolean fromReplication) |
long |
LeaseManager.getExpirationOnWriteByLeaseOrByTimeRule(long lease,
long startTime,
IEntryPacket entry,
boolean fromReplication) |
boolean |
LeaseManager.isReRegisterLeaseOnUpdate(long lease,
IEntryPacket entry) |
void |
AnswerHolder.setEntryPackets(IEntryPacket[] entryPackets) |
Constructor and Description |
---|
AnswerPacket(IEntryPacket entryPacket) |
AnswerPacket(IEntryPacket entryPacket,
WriteEntryResult writeResult) |
UpdateOrWriteContext(IEntryPacket packet,
long lease,
long timeout,
Transaction tx,
SpaceContext sc,
int operationModifiers,
boolean fromUpdateMultiple,
boolean updateOperation,
boolean fromWriteMultiple) |
UpdateOrWriteContext(IEntryPacket packet,
long lease,
long timeout,
Transaction tx,
SpaceContext sc,
int operationModifiers,
boolean fromUpdateMultiple,
boolean updateOperation,
boolean fromWriteMultiple,
ITemplateHolder concentratingTemplate,
int ordinalInMultipleIdsContext) |
Modifier and Type | Method and Description |
---|---|
void |
Context.cacheViewEntryDataIfNeeded(IEntryData entryData,
IEntryPacket packet) |
void |
Context.setOperationAnswer(ITemplateHolder template,
IEntryPacket entryPacket,
Exception ex)
fills the template with the answer to be sent to the client.
|
Modifier and Type | Method and Description |
---|---|
IEntryPacket |
EntryArrivedRemoteEvent.getEntryPacket()
Returns an internal GigaSpaces structure to send/receive entries from the space.
|
static IEntryPacket |
RemoteEventAccessor.getEventContextPacket(EntryArrivedRemoteEvent theEvent)
Returns
RemoteEvent entry context. |
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.
|
Modifier and Type | Method and Description |
---|---|
IEntryPacket |
QueryManager.readTake(ReadTakeProxyActionInfo actionInfo) |
IEntryPacket |
IQueryManager.readTake(ReadTakeProxyActionInfo actionInfo) |
IEntryPacket[] |
QueryManager.readTakeMultiple(ReadTakeMultipleProxyActionInfo actionInfo) |
IEntryPacket[] |
IQueryManager.readTakeMultiple(ReadTakeMultipleProxyActionInfo actionInfo) |
Modifier and Type | Field and Description |
---|---|
protected IEntryPacket |
SpaceUpdateFilterEntryImpl._entryPacket |
Constructor and Description |
---|
SpaceAfterChangeFilterEntryImpl(ITemplateHolder templateHolder,
IEntryPacket entryPacket,
ITypeDesc typeDesc,
Collection mutators) |
SpaceUpdateFilterEntryImpl(IEntryPacket entryPacket,
ITypeDesc typeDesc) |
Modifier and Type | Class and Description |
---|---|
class |
JoinedEntry
This class represents an entry that was constructed from a join between several tables.
|
Modifier and Type | Method and Description |
---|---|
IEntryPacket[] |
ResponsePacket.getArray() |
IEntryPacket |
JoinedEntry.getEntry(int index) |
Modifier and Type | Method and Description |
---|---|
static IQueryResultSet<IEntryPacket> |
AggregationsUtil.aggregate(QueryTemplatePacket template,
AggregationSet aggregationSet,
IJSpace space,
Transaction txn,
int modifiers)
Execute aggregation query
|
ArrayList<IEntryPacket> |
DeleteQuery.executeExclusiveReadLock(QueryTemplatePacket template,
IJSpace space,
Transaction txn,
int max,
int modifiers) |
Collection<IEntryPacket> |
ResponsePacket.getResultSet() |
Iterator<IEntryPacket> |
ResponsePacket.iterator() |
Modifier and Type | Method and Description |
---|---|
Object |
SelectColumn.getFieldValue(IEntryPacket entry) |
Object |
FunctionCallColumn.getFieldValue(IEntryPacket entry) |
static Object |
SQLUtil.getFieldValue(IEntryPacket e,
ITypeDesc typeDesc,
String propertyName) |
static Object |
SQLUtil.getFieldValue(IEntryPacket entry,
QueryColumnData columnData) |
void |
ResponsePacket.setResultArray(IEntryPacket[] resultArray) |
Modifier and Type | Method and Description |
---|---|
protected void |
AbstractDMLQuery.filterByRownum(Collection<IEntryPacket> entries) |
void |
ResponsePacket.setResultSet(Collection<IEntryPacket> resultSet) |
Constructor and Description |
---|
JoinedEntry(IEntryPacket... entries) |
Modifier and Type | Class and Description |
---|---|
class |
QueryEntryPacket |
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
|
Modifier and Type | Method and Description |
---|---|
IEntryPacket |
QueryEntryPacket.clone() |
Modifier and Type | Method and Description |
---|---|
IQueryResultSet<IEntryPacket> |
QueryTemplatePacket.read(ISpaceProxy space,
AbstractDMLQuery query,
Transaction txn,
int modifiers,
int maxResults) |
IQueryResultSet<IEntryPacket> |
QueryTemplatePacket.read(ISpaceProxy space,
Transaction txn,
long timeout,
int modifiers,
boolean ifExists,
int maxResults,
int minEntriesToWaitFor) |
IQueryResultSet<IEntryPacket> |
QueryTemplatePacket.readMultiple(ISpaceProxy space,
Transaction txn,
int maxResults,
int modifiers) |
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 |
---|---|
protected boolean |
UnionTemplatePacket.matches(IEntryPacket entryPacket) |
protected boolean |
QueryTemplatePacket.matches(IEntryPacket entryPacket) |
Modifier and Type | Method and Description |
---|---|
IEntryPacket |
AbstractQueryExecutor.aggregate(IQueryResultSet<IEntryPacket> entries)
Execute SQL function that processes the result entries and calculates one value -
sum,average,min,max
|
IEntryPacket |
IQueryExecutor.aggregate(IQueryResultSet<IEntryPacket> entries)
Execute SQL function that processes the result entries and calculates one value -
sum,average,min,max
|
IEntryPacket |
ScanCursor.getCurrentEntry() |
IEntryPacket |
HashedEntriesCursor.getCurrentEntry() |
IEntryPacket |
EntriesCursor.getCurrentEntry() |
Modifier and Type | Method and Description |
---|---|
protected IQueryResultSet<IEntryPacket> |
QueryExecutor.ExecutionTask.execute() |
IQueryResultSet<IEntryPacket> |
QueryExecutor.execute(ISpaceProxy space,
Transaction txn,
int readModifier,
int max) |
IQueryResultSet<IEntryPacket> |
CollocatedJoinedQueryExecutor.execute(ISpaceProxy space,
Transaction txn,
int readModifier,
int max) |
IQueryResultSet<IEntryPacket> |
JoinedQueryExecutor.execute(ISpaceProxy space,
Transaction txn,
int readModifier,
int max) |
IQueryResultSet<IEntryPacket> |
IQueryExecutor.execute(ISpaceProxy space,
Transaction txn,
int modifiers,
int max) |
IQueryResultSet<IEntryPacket> |
AbstractQueryExecutor.executeTemplate(QueryTemplatePacket template,
ISpaceProxy space,
Transaction txn,
int readModifier,
int max) |
IQueryResultSet<IEntryPacket> |
AbstractQueryExecutor.extractResults(ExpNode node) |
IQueryResultSet<IEntryPacket> |
AbstractQueryExecutor.filterDistinctEntries(IQueryResultSet<IEntryPacket> entries)
Removes duplicate entries from the result set.
|
IQueryResultSet<IEntryPacket> |
IQueryExecutor.filterDistinctEntries(IQueryResultSet<IEntryPacket> entries)
Removes duplicate entries from the result set.
|
Comparator<IEntryPacket> |
AbstractQueryExecutor.getGroupByComparator(IQueryResultSet<IEntryPacket> queryResult,
List<SelectColumn> groupColumns) |
Comparator<IEntryPacket> |
JoinedQueryExecutor.getGroupByComparator(List<SelectColumn> groupColumns) |
protected HashMap<ExpNode,IQueryResultSet<IEntryPacket>> |
AbstractQueryExecutor.getIntermediateResults() |
List<IEntryPacket> |
HashedEntriesCursor.getMatch(ColumnNode matchCol,
IEntryPacket expectedMatch) |
Comparator<IEntryPacket> |
AbstractQueryExecutor.getOrderByComparator(IQueryResultSet<IEntryPacket> entries,
List<OrderColumn> orderColumns) |
IQueryResultSet<IEntryPacket> |
AbstractQueryExecutor.groupBy(IQueryResultSet<IEntryPacket> entries,
List<SelectColumn> groupColumns)
Group the results according to the group by clause
|
IQueryResultSet<IEntryPacket> |
IQueryExecutor.groupBy(IQueryResultSet<IEntryPacket> entries,
List<SelectColumn> groupColumns)
Group the results according to the group by clause
|
IQueryResultSet<IEntryPacket> |
IQueryExecutor.readAll(ISpaceProxy space,
Transaction txn) |
protected IQueryResultSet<IEntryPacket> |
AbstractQueryExecutor.traverseExpressionTree(ExpNode root,
ISpaceProxy space,
Transaction txn,
int readModifier,
int max)
Traverse the binary expression tree non-recursively using a custom stack The tree has to be
traversed in postorder - the parent is traversed after its children.
|
Modifier and Type | Method and Description |
---|---|
int |
AbstractQueryExecutor.EntriesOrderByComparator.compare(IEntryPacket o1,
IEntryPacket o2) |
List<IEntryPacket> |
HashedEntriesCursor.getMatch(ColumnNode matchCol,
IEntryPacket expectedMatch) |
Modifier and Type | Method and Description |
---|---|
IEntryPacket |
AbstractQueryExecutor.aggregate(IQueryResultSet<IEntryPacket> entries)
Execute SQL function that processes the result entries and calculates one value -
sum,average,min,max
|
IEntryPacket |
IQueryExecutor.aggregate(IQueryResultSet<IEntryPacket> entries)
Execute SQL function that processes the result entries and calculates one value -
sum,average,min,max
|
Number |
AbstractQueryExecutor.avg(SelectColumn funcColumn,
IQueryResultSet<IEntryPacket> entries)
Calculate the average value of the given column for all entries .
|
ResultEntry |
AbstractQueryExecutor.convertEntriesToResultArrays(IQueryResultSet<IEntryPacket> entries)
Converts the list of ExternaEntries to 2 dimensional array that contains the values of the
entries.
|
ResultEntry |
IQueryExecutor.convertEntriesToResultArrays(IQueryResultSet<IEntryPacket> _entries)
Converts the list of ExternaEntries to 2 dimensional array that contains the values of the
entries.
|
IQueryResultSet<IEntryPacket> |
AbstractQueryExecutor.filterDistinctEntries(IQueryResultSet<IEntryPacket> entries)
Removes duplicate entries from the result set.
|
IQueryResultSet<IEntryPacket> |
IQueryExecutor.filterDistinctEntries(IQueryResultSet<IEntryPacket> entries)
Removes duplicate entries from the result set.
|
Comparator<IEntryPacket> |
AbstractQueryExecutor.getGroupByComparator(IQueryResultSet<IEntryPacket> queryResult,
List<SelectColumn> groupColumns) |
Comparator<IEntryPacket> |
AbstractQueryExecutor.getOrderByComparator(IQueryResultSet<IEntryPacket> entries,
List<OrderColumn> orderColumns) |
IQueryResultSet<IEntryPacket> |
AbstractQueryExecutor.groupBy(IQueryResultSet<IEntryPacket> entries,
List<SelectColumn> groupColumns)
Group the results according to the group by clause
|
IQueryResultSet<IEntryPacket> |
IQueryExecutor.groupBy(IQueryResultSet<IEntryPacket> entries,
List<SelectColumn> groupColumns)
Group the results according to the group by clause
|
Object |
AbstractQueryExecutor.minMax(SelectColumn funcColumn,
IQueryResultSet<IEntryPacket> entries,
boolean isMax)
Finds the minimum/maximum value of given column
|
void |
AbstractQueryExecutor.orderBy(IQueryResultSet<IEntryPacket> entries,
List<OrderColumn> orderColumns)
Order the results according to the order by clause
|
void |
IQueryExecutor.orderBy(IQueryResultSet<IEntryPacket> entries,
List<OrderColumn> orderColumns)
Order the results according to the order by clause
|
void |
AbstractQueryExecutor.setResults(ExpNode node,
IQueryResultSet<IEntryPacket> results) |
Number |
AbstractQueryExecutor.sum(SelectColumn funcColumn,
IQueryResultSet<IEntryPacket> entries)
Calculate the sum value of the given column for all entries
|
Constructor and Description |
---|
EntriesOrderByComparator(IQueryResultSet<IEntryPacket> queryResult,
List<OrderColumn> orderColumns) |
ScanCursor(IQueryResultSet<IEntryPacket> tableEntries) |
Modifier and Type | Method and Description |
---|---|
Object |
ColumnNode.getFieldValue(IEntryPacket entry) |
Modifier and Type | Method and Description |
---|---|
EntriesCursor |
ContainsNode.createIndex(QueryTableData table,
IQueryResultSet<IEntryPacket> entries) |
EntriesCursor |
ExpNode.createIndex(QueryTableData queryTableData,
IQueryResultSet<IEntryPacket> tableEntries) |
EntriesCursor |
EqualNode.createIndex(QueryTableData table,
IQueryResultSet<IEntryPacket> entries) |
Modifier and Type | Interface and Description |
---|---|
interface |
IQueryResultSet<T extends IEntryPacket> |
Modifier and Type | Method and Description |
---|---|
IEntryPacket |
QueryTableData.getCurrentEntry() |
Modifier and Type | Method and Description |
---|---|
IQueryResultSet<IEntryPacket> |
QueryTableData.executeSubQuery(ISpaceProxy space,
Transaction txn) |
IQueryResultSet<IEntryPacket> |
ArrayListResult.intersect(IQueryResultSet<IEntryPacket> set)
Return an intersection of this set and a given one.
|
IQueryResultSet<IEntryPacket> |
ProjectedResultSet.newResultSet() |
IQueryResultSet<IEntryPacket> |
JoinedQueryResult.newResultSet() |
IQueryResultSet<IEntryPacket> |
ArrayListResult.newResultSet() |
IQueryResultSet<IEntryPacket> |
ProjectedResultSet.newResultSet(Collection<IEntryPacket> entries) |
IQueryResultSet<IEntryPacket> |
JoinedQueryResult.newResultSet(Collection<IEntryPacket> entries) |
IQueryResultSet<IEntryPacket> |
ArrayListResult.newResultSet(Collection<IEntryPacket> entries) |
IQueryResultSet<IEntryPacket> |
ArrayListResult.union(IQueryResultSet<IEntryPacket> set)
Return a union of this set and a given one
|
Modifier and Type | Method and Description |
---|---|
Object |
ProjectedResultSet.getFieldValue(SelectColumn column,
IEntryPacket entryPacket) |
Object |
JoinedQueryResult.getFieldValue(SelectColumn column,
IEntryPacket entryPacket) |
Object |
ArrayListResult.getFieldValue(SelectColumn column,
IEntryPacket entry) |
Modifier and Type | Method and Description |
---|---|
IQueryResultSet<IEntryPacket> |
ArrayListResult.intersect(IQueryResultSet<IEntryPacket> set)
Return an intersection of this set and a given one.
|
IQueryResultSet<IEntryPacket> |
ProjectedResultSet.newResultSet(Collection<IEntryPacket> entries) |
IQueryResultSet<IEntryPacket> |
JoinedQueryResult.newResultSet(Collection<IEntryPacket> entries) |
IQueryResultSet<IEntryPacket> |
ArrayListResult.newResultSet(Collection<IEntryPacket> entries) |
IQueryResultSet<T> |
IQueryResultSet.newResultSet(Collection<IEntryPacket> entries) |
IQueryResultSet<IEntryPacket> |
ArrayListResult.union(IQueryResultSet<IEntryPacket> set)
Return a union of this set and a given one
|
Constructor and Description |
---|
ArrayListResult(IEntryPacket entryPacket) |
ArrayListResult(IEntryPacket[] array) |
Constructor and Description |
---|
ArrayListResult(Collection<IEntryPacket> entries) |
JoinedQueryResult(Collection<IEntryPacket> entries) |
ProjectedResultSet(Collection<IEntryPacket> entries) |
Modifier and Type | Field and Description |
---|---|
protected IDataConverter<IEntryPacket> |
EntryAdapter._converter
Converts the external entry to user defined objects
|
Modifier and Type | Method and Description |
---|---|
IEntryPacket |
EntryAdapterIterator.next() |
IEntryPacket |
EntryAdapter.toEntry(Object object)
Converts given object to IGSEntry
|
IEntryPacket |
EntryAdapter.toEntry(Object key,
Object value)
Convert key value to entry
|
IEntryPacket |
EntryAdapter.toEntryPacket() |
IEntryPacket |
InternalBulkItem.toEntryPacket() |
IEntryPacket |
EntryPacketDataConverter.toInternal(Object obj) |
Modifier and Type | Method and Description |
---|---|
IDataConverter<IEntryPacket> |
EntryAdapter.getConverter() |
Modifier and Type | Method and Description |
---|---|
SQLQuery<?> |
SQLQueryBuilder.build(IEntryPacket entryPacket,
ITypeDesc typeDesc)
Builds an
SQLQuery from given entry packet |
SQLQuery<?> |
DefaultSQLQueryBuilder.build(IEntryPacket entry,
ITypeDesc typeDesc) |
SpaceDocument |
EntryPacketDataConverter.toDocument(IEntryPacket entryPacket) |
Object |
EntryPacketDataConverter.toObject(IEntryPacket entryPacket) |
Modifier and Type | Method and Description |
---|---|
void |
DataAdaptorIterator.add(Iterator<IEntryPacket> iterator)
Appends the specified iterator to the end of this list.
|
void |
EntryAdapter.setConverter(IDataConverter<IEntryPacket> converter) |
void |
InternalBulkItem.setConverter(IDataConverter<IEntryPacket> converter) |
Constructor and Description |
---|
BulkDataItem(IEntryHolder entryHolder,
ITypeDesc typeDesc,
short operation,
IDataConverter<IEntryPacket> converter)
Constructs a
BulkDataItem out of IEntryHolder and TypeTableEntry.Given converter is used for internal entry conversion. |
EntryAdapter(IDataConverter<IEntryPacket> converter) |
EntryAdapter(IEntryHolder entryHolder,
ITypeDesc typeDesc,
IDataConverter<IEntryPacket> converter) |
PartialUpdateBulkDataItem(IEntryHolder entryHolder,
boolean[] partialUpdateValuesIndicators,
ITypeDesc typeDesc,
IDataConverter<IEntryPacket> converter) |
Copyright © GigaSpaces.