Modifier and Type | Class and Description |
---|---|
class |
DefaultQuiesceToken |
class |
InstancesQuiesceState
Represents the quiesce state of the all processing unit instances.
|
class |
QuiesceStateChangedEvent
Represents an event which is fired to inform about quiesce state changed
|
Modifier and Type | Class and Description |
---|---|
class |
RocksDBServiceMonitors |
Modifier and Type | Class and Description |
---|---|
class |
ChangeModifiers
Provides modifiers to customize the behavior of change operations.
|
class |
ChangeSet
The set of changes to apply for matches entries of the change operation
|
class |
ClearException
Thrown when a space clear operation fails.
|
class |
ClearModifiers
Provides modifiers to customize the behavior of clear operations.
|
class |
CountModifiers
Provides modifiers to customize the behavior of count operations.
|
class |
EntryLockedException |
class |
IsolationLevelModifiers
Base class for isolation level based space proxy operations modifiers.
|
class |
ReadByIdsException
Thrown when readByIds operation fails.
|
class |
ReadModifiers
Provides modifiers to customize the behavior of read operations.
|
class |
ReadMultipleException
Thrown when a space readMultiple operation fails.
|
class |
ReadTakeByIdResult
Holds a read/takeByIds operation's exception result.
|
class |
ReadTakeByIdsException
A base class for Read/TakeByIdsException
|
class |
SpaceProxyOperationModifiers
Base class for space proxy operations modifiers.
|
class |
TakeByIdsException
Thrown when takeByIds operation fails.
|
class |
TakeModifiers
Provides modifiers to customize the behavior of take operations.
|
class |
TakeMultipleException
Thrown when a space takeMultiple operation fails.
|
class |
WriteModifiers
Provides modifiers to customize the behavior of write operations.
|
class |
WriteMultipleException
Thrown when writeMultiple operation fails.
|
Modifier and Type | Class and Description |
---|---|
class |
InternalReadModifiers |
Modifier and Type | Class and Description |
---|---|
class |
SpaceIteratorAggregator |
class |
SpaceIteratorAggregatorPartitionResult |
Modifier and Type | Class and Description |
---|---|
class |
TieredSpaceIteratorAggregatorPartitionResult |
Modifier and Type | Class and Description |
---|---|
class |
LocalTransactionManagerImpl
Deprecated.
|
Modifier and Type | Class and Description |
---|---|
class |
GSServerTransaction
Title: GSServerTransaction Description: Extends the ServerTransaction to hold Object id
should only be used as a key.
|
class |
GSXid
Local implementation of Xid to be store in Space
|
Modifier and Type | Class and Description |
---|---|
class |
ActiveElectionConfig
This class provides a configuration object of
ActiveElectionManager . |
class |
ActiveElectionState
The election state attribute registered in conjunction with service candidate.
|
Modifier and Type | Class and Description |
---|---|
class |
LoadBalancingPolicy
Copyright (c) 2010 GigaSpaces Technologies Ltd.
|
static class |
LoadBalancingPolicy.LoadBalancingPolicyDescription |
Modifier and Type | Class and Description |
---|---|
class |
MirrorServiceConfig
mirror service configuration
|
class |
ReplicationTargetInfo |
class |
ReplicationTransmissionPolicy
This class describes the transmission policy from source space to a target space.
|
Modifier and Type | Class and Description |
---|---|
class |
MirrorOperationsImpl |
class |
MirrorOperationStatisticsImpl
Statistics for single operation type
|
class |
MirrorStatisticsImpl
Default implementation of the mirror space statistics.
|
Modifier and Type | Class and Description |
---|---|
class |
SyncReplPolicy
This class contains all configuration information about Synchronize Replication.
|
Modifier and Type | Class and Description |
---|---|
class |
NIOConfiguration
This class provides configuration object of NIO communication transport protocol.
|
Modifier and Type | Class and Description |
---|---|
class |
CDCInfo |
class |
DeletedDocumentInfo |
Modifier and Type | Class and Description |
---|---|
class |
SpaceDocument
Represents a document which can be stored and retrieved from the space.
|
Modifier and Type | Class and Description |
---|---|
class |
CompoundSpaceId
This Object was created in order to implement GigaSpaces CompoundId logic
Extending this object will result in inherit all the capabilities of CompoundSpaceId
In order to use this, please implement your CompoundId pojo as explained:
use EmbeddedId hibernate annotation on your getter for the compoundId instance in your POJO that holds the conpoundId
use @Embeddable hibernate annotation on your class in order to use this in hivernate
Implement your empty constructor with call to super with the number of values you have in your compoundID
public MyCompoundSpaceId() {
super(2);
}
|
Modifier and Type | Class and Description |
---|---|
class |
NotifyInfo
Holds a set of space.notify related parameters.
|
class |
SpaceRemoteEvent
Base class for space remote events.
|
Modifier and Type | Class and Description |
---|---|
class |
BatchRemoteEvent
Received on
BatchRemoteEventListener.notifyBatch(BatchRemoteEvent) when a batch of events
that matches the pending templates registration. |
class |
LRMIBatchNotifyDelegatorListener
Notify delegator for batch notifications.
|
Modifier and Type | Class and Description |
---|---|
class |
ApplicationException
An Application Exception abstracts a logical exception rather than an exception in network
infrastructure (which is abstracted by RemoteException).
|
Modifier and Type | Class and Description |
---|---|
class |
ChangeDetailedResultImpl<T> |
class |
ChangeEntryDetailsImpl<T> |
class |
ChangeResultImpl<T> |
class |
CloseIteratorSpaceResponseInfo |
class |
FailedChangedEntryDetailsImpl |
class |
RenewIteratorLeaseSpaceResponseInfo |
class |
SpaceIteratorBatchResult |
Modifier and Type | Class and Description |
---|---|
class |
SpaceUrlCache
Created by tamirt on 12/04/16.
|
Modifier and Type | Class and Description |
---|---|
class |
AddAllToCollectionSpaceEntryMutator |
class |
AddToCollectionSpaceEntryMutator |
class |
CollectionChangeSpaceEntryMutatorResult
A result for changing a collection property
|
class |
IncrementSpaceEntryMutator |
class |
MapChangeSpaceEntryMutatorResult
Result for changing a map property
|
class |
PutInMapSpaceEntryMutator |
class |
RemoveFromCollectionSpaceEntryMutator |
class |
RemoveFromMapSpaceEntryMutator
The set of changes to apply for matches entries of the change operation
|
class |
SetValueSpaceEntryMutator |
class |
SpaceEntryPathMutator |
class |
UnsetValueSpaceEntryMutator |
Modifier and Type | Class and Description |
---|---|
class |
AbstractDirectSpaceProxy
Title: Description:
|
class |
DirectSpaceProxyFactoryImpl |
class |
SpaceProxyImpl
Provides the functionality of clustered proxy.
|
Modifier and Type | Class and Description |
---|---|
class |
AddReplicationGatewayTargetTask |
class |
AddTypeIndexesTask |
class |
BroadcastTableSpaceTask |
class |
CloseIteratorDistributedSpaceTask |
class |
CollocatedJoinSpaceTask |
class |
GetBatchForIteratorDistributedSpaceTask |
class |
GetEntriesTieredMetaDataTask |
class |
GetMVCCEntryMetaDataTask |
class |
GetTypeDescriptorTask |
class |
RegisterReplicationLocalViewTask |
class |
RegisterReplicationNotificationTask |
class |
RegisterTypeDescriptorTask |
class |
RemoveReplicationGatewayTargetTask |
class |
RenewIteratorLeaseDistributedSpaceTask |
class |
SinglePartitionGetBatchForIteratorSpaceTask |
class |
SpaceDataSourceLoadTask |
class |
SystemDistributedTask<T extends Serializable> |
class |
SystemTask<T extends Serializable> |
class |
UnregisterReplicationLocalViewTask |
class |
UnregisterReplicationNotificationTask |
class |
UnregisterTypeDescriptorTask |
Modifier and Type | Class and Description |
---|---|
class |
ClusterTopology |
class |
ClusterTopologyState |
class |
DynamicPartitionInfoImpl |
class |
SpaceClusterInfo |
Modifier and Type | Class and Description |
---|---|
class |
DataTypeAddIndexPacketData |
class |
DataTypeDropPacketData |
class |
DataTypeIntroducePacketData |
class |
NotificationSentSyncOperation |
Modifier and Type | Interface and Description |
---|---|
interface |
IBacklogHandshakeRequest |
interface |
IBacklogMemberState |
interface |
IIdleStateData |
Modifier and Type | Class and Description |
---|---|
class |
BacklogMemberLimitationConfig |
class |
EmptyIdleStateData |
class |
NonExistingBacklogMemberState |
static class |
SingleFileBacklogGroupMarker.SingleFileBacklogGroupMarkerWireForm |
static class |
SingleFileBacklogMarker.SingleFileBacklogMarkerWireForm |
Modifier and Type | Class and Description |
---|---|
class |
GlobalOrderBacklogHandshakeRequest |
class |
GlobalOrderBacklogMemberState |
class |
GlobalOrderDeletedBacklogPacket |
class |
GlobalOrderDiscardedReplicationPacket |
class |
GlobalOrderOperationPacket |
class |
GlobalOrderReliableAsyncBacklogHandshakeRequest |
class |
GlobalOrderReliableAsyncKeptDiscardedOrderedPacket |
class |
GlobalOrderReliableAsyncState |
static class |
GlobalOrderReliableAsyncState.AsyncTargetState |
Modifier and Type | Interface and Description |
---|---|
interface |
IMultiBucketSingleFileReplicationOrderedPacket |
interface |
ISingleBucketReplicationOrderedPacket |
Modifier and Type | Class and Description |
---|---|
class |
AbstractMultiBucketOrderedPacket |
class |
AbstractSingleBucketOrderedPacket |
class |
DeletedMultiBucketOrderedPacket |
class |
DiscardedMultiBucketOrderedPacket |
class |
DiscardedSingleBucketOrderedPacket |
class |
MultiBucketSingleFileBacklogMemberState |
class |
MultiBucketSingleFileHandshakeRequest |
class |
MultiBucketSingleFileReliableAsyncHandshakeRequest |
class |
MultiBucketSingleFileReliableAsyncKeptDiscardedPacket |
class |
MultiBucketSingleFileReliableAsyncState |
static class |
MultiBucketSingleFileReliableAsyncState.AsyncTargetState |
class |
MultipleBucketOrderedPacket |
class |
SingleBucketOrderedPacket |
Modifier and Type | Class and Description |
---|---|
class |
MultiSourceSingleFileBacklogHandshakeRequest |
class |
MultiSourceSingleFileIdleStateData |
class |
MultiSourceSingleFileReliableAsyncBacklogHandshakeRequest |
class |
MultiSourceSingleFileReliableAsyncState |
static class |
MultiSourceSingleFileReliableAsyncState.MultiSourceAsyncTargetState |
Modifier and Type | Interface and Description |
---|---|
interface |
IReliableAsyncState |
Modifier and Type | Class and Description |
---|---|
class |
ReliableAsyncHandshakeIteration |
class |
SynchronizeMissingPacketsHandshakeIteration |
Modifier and Type | Interface and Description |
---|---|
interface |
IMarkerWireForm
A wire form of
IMarker which can be serialized and deserialized |
Modifier and Type | Class and Description |
---|---|
class |
MultiBucketReplicationPolicy |
class |
SourceChannelConfig |
Modifier and Type | Interface and Description |
---|---|
interface |
IDirectPersistencyOpInfo
Created by yechielf on 28/04/2015.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractDirectPersistencyOpInfo
The element of synchronizing a direct-persistency uid
|
class |
DirectPersistencyMultipleUidsOpInfo
The element of synchronizing a direct-persistency multiple uids(transaction result)
|
class |
DirectPersistencyOverflowListSegment
the list segment where the ops list is overflowen to persistency
|
class |
DirectPersistencySingleUidOpInfo
The element of synchronizing a direct-persistency uid
|
class |
DirectPersistencySyncListBatch |
class |
DirectPersistencySyncListFetcher |
Modifier and Type | Class and Description |
---|---|
class |
DirectPersistencySyncAdminInfo
The synchronizing direct-persistency handler
|
Modifier and Type | Class and Description |
---|---|
class |
EmbeddedRelevantGenerationIdsInfo
Embedded Sync- info regarding generation ids from which not all embedded info used surly
transferred to the sync list
|
class |
EmbeddedSyncTransferredInfo
Embedded Sync- info regarding transferred records per segment used in order to avoid updating the
entry each time op was transferred to regular list
|
Modifier and Type | Class and Description |
---|---|
class |
QueryRemoteClusterTopologyPacket |
class |
SinkEstablishConnectionPacket |
Modifier and Type | Interface and Description |
---|---|
interface |
IReplicationUnreliableOperation |
Modifier and Type | Interface and Description |
---|---|
interface |
IHandshakeIteration |
Modifier and Type | Class and Description |
---|---|
class |
ConnectChannelHandshakeRequest |
class |
ConnectChannelHandshakeResponse |
Modifier and Type | Class and Description |
---|---|
class |
AsyncChannelConfig |
class |
FetchReliableAsyncMissingMemberDataPacket |
class |
ReliableAsyncMemberData |
Modifier and Type | Interface and Description |
---|---|
interface |
IReplicationOrderedPacket
A replication packet that has an order that specify a certain order of these packets that needs
to be kept when processed at the target
|
Modifier and Type | Interface and Description |
---|---|
interface |
IDataConsumeFix
A possible fix for a
IReplicationPacketDataConsumer#consume(String,
IReplicationPacketData, com.gigaspaces.internal.cluster.manager.handlers.IReplicationInFacade)
invocation that returned an error result denoted by a IDataConsumeResult that its IDataConsumeResult.isFailed() is true. |
interface |
IDataConsumeResult |
interface |
IExecutableReplicationPacketData<T extends IReplicationPacketEntryData>
An extension of
IReplicationPacketData that can be self executed. |
interface |
IReplicationPacketData<T extends IReplicationPacketEntryData>
The replication packet data that is kept in side an
IReplicationOrderedPacket which
contains the data needed for the processing of the packet |
interface |
IReplicationPacketEntryData |
interface |
IReplicationTransactionalPacketEntryData |
Modifier and Type | Class and Description |
---|---|
class |
AbstractDataConsumeErrorResult |
class |
AbstractDataConsumeFix
A base class for data consume fix generated by
ReplicationPacketDataProducer and consumed
by ReplicationPacketDataConsumer . |
class |
DataConsumeOkResult
Signal a consume ok result
|
class |
DiscardReplicationPacketData |
Modifier and Type | Class and Description |
---|---|
class |
RestoreFullTransactionFix |
class |
ResurrectEntryFix |
class |
ResurrectNotifyTemplateFix
Fix a problem of extend notify template lease that do not exists anymore in the target (long
disconnection ,recovery).
|
class |
TypeDescriptorConsumeFix |
class |
UnhandledErrorFix
A fix that states that the error could not be fixed by the source
|
class |
UnknownConsumeErrorResult |
class |
UnknownEntryLeaseConsumeResult
A consumption error result that is caused when trying to extend entry lease and that lease do no
exists in the space.
|
class |
UnknownLeaseErrorUnfixed
A fix that is returned as a fix of two errors
UnknownEntryLeaseConsumeResult , UnknownNotifyTemplateLeaseConsumeResult . |
class |
UnknownNotifyTemplateLeaseConsumeResult
A consumption error result that is caused when trying to extend notify template lease and that
lease do no exists in the space.
|
class |
UnknownTransactionConsumeResult |
class |
UnknownTypeConsumeResult
A consume error result caused due to
UnknownTypeException thrown during consumption |
Modifier and Type | Interface and Description |
---|---|
interface |
IProcessLogHandshakeResponse |
interface |
IProcessResult |
Modifier and Type | Class and Description |
---|---|
class |
GlobalOrderProcessLogHandshakeResponse |
class |
GlobalOrderProcessResult |
class |
GlobalOrderProcessStatus |
class |
GlobalOrderReliableAsyncKeeperProcessLogHandshakeResponse |
Modifier and Type | Class and Description |
---|---|
class |
MultiBucketSingleFileHandshakeResponse |
class |
MultiBucketSingleFileProcessResult |
Modifier and Type | Interface and Description |
---|---|
interface |
IProcessStatus |
Modifier and Type | Interface and Description |
---|---|
interface |
IExecutableSpaceReplicaData |
interface |
ISpaceReplicaData
A single replica data that is generated by the
ISpaceReplicaDataProducer as part of a
space copy replica request, this replica data is passed to the ISpaceReplicaDataConsumer
as part of the replica process which is consumed in its turn to be translated to a replica
operation |
Modifier and Type | Class and Description |
---|---|
class |
CurrentStageInfo |
class |
SpaceReplicaBatch |
class |
SynchronizationDonePacket |
Modifier and Type | Class and Description |
---|---|
class |
AbstractEntryReplicaData |
class |
AbstractReplicaData |
class |
DirectPersistencyEntryReplicaData |
class |
EntryCopyReplicaData |
class |
EntrySynchronizeReplicaData |
class |
NotifyTemplateReplicaData |
class |
SpaceTypeReplicaData |
Modifier and Type | Class and Description |
---|---|
class |
AbstractGroupNameReplicationPacket<T> |
class |
AbstractReplicationPacket<T> |
class |
ReplicationEndpointDetails
Contains replication endpoint details
|
Modifier and Type | Class and Description |
---|---|
class |
EntryPacketServerEntryAdapter |
Modifier and Type | Interface and Description |
---|---|
interface |
ISpaceCopyReplicaParameters |
Modifier and Type | Class and Description |
---|---|
class |
SpaceCopyReplicaParameters |
Modifier and Type | Class and Description |
---|---|
class |
HeapReport |
Modifier and Type | Class and Description |
---|---|
class |
BatchQueryException
Thrown when one of the following space operations fails: readMultiple,takeMultiple,clear.
|
Modifier and Type | Class and Description |
---|---|
class |
WaitForDataDrainRequest |
class |
WaitForDataDrainTask |
Modifier and Type | Class and Description |
---|---|
class |
CompressedMarshObject
CompressedMarshObject extends MarshObject by keeping the byte array zipped by GZIP.
|
class |
MarshObject
MarshObject is similar to java.rmi.MarshalledObject.
|
Modifier and Type | Method and Description |
---|---|
void |
MarshalOutputStream.writeSmartExternalizable(SmartExternalizable obj) |
Modifier and Type | Class and Description |
---|---|
class |
JVMDetails |
class |
JVMStatistics |
Modifier and Type | Class and Description |
---|---|
class |
LRMIInboundMonitoringDetailsImpl |
class |
LRMIMethodMonitoringDetailsImpl
Tracking details of a specific method
|
class |
LRMIMonitoringDetailsImpl |
class |
LRMIOutboundMonitoringDetailsImpl |
class |
LRMIProxyMonitoringDetailsImpl |
class |
LRMIServiceClientMonitoringDetailsImpl
Tracking details of a single client on a specific service
|
class |
LRMIServiceClientMonitoringIdImpl
Tracking id of a single client on a specific service
|
class |
LRMIServiceMonitoringDetailsImpl
Tracking details of a single hosted service
|
Modifier and Type | Class and Description |
---|---|
class |
LRMINotifyDelegatorListener
NotifyDelegator stub to get notification via LRMI layer.
|
class |
LRMIRemoteEventListener
Super class of all Notify stubs.
|
class |
LRMISpaceImpl
LRMI Stub implementation of
IRemoteJSpaceImpl interface. |
Modifier and Type | Interface and Description |
---|---|
interface |
ITypeIntrospector<T>
Common interface for all the introspectors implementations.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractTypeIntrospector<T>
Common base class for ITypeIntrospector implementations.
|
class |
ConstructorInstantiationDescriptor |
class |
ExternalEntryIntrospector<T extends ExternalEntry> |
class |
PojoIntrospector<T>
Pojo introspector for all the pojo implementations.
|
class |
SpaceCollectionIndex
An index for a path containing a collection ("[*]").
|
class |
SpaceStringProperty |
class |
SpaceTypeInfo |
class |
TypeDescVersionedSerializable |
class |
VirtualEntryIntrospector<T extends VirtualEntry> |
Modifier and Type | Class and Description |
---|---|
class |
OSDetails |
static class |
OSDetails.OSDriveDetails |
static class |
OSDetails.OSNetInterfaceDetails |
static class |
OSDetails.OSVendorDetails |
class |
OSStatistics |
static class |
OSStatistics.OSNetInterfaceStats |
Modifier and Type | Interface and Description |
---|---|
interface |
IQueryIndexScanner
Represents an index that can be provided in a
ICustomQuery and optimize the query run
time. |
Modifier and Type | Class and Description |
---|---|
class |
AbstractCompoundIndexScanner
AbstractCompoundIndexScanner defines an index scanner that scans more than one space index.
|
class |
AbstractCompundCustomQuery
Base class for compound custom queries.
|
class |
AbstractCustomQuery
Base class for all custom query interfaces.
|
class |
AbstractQueryIndex |
class |
AbstractSpaceQuery<T>
Common base class for space query implementations.
|
class |
CompoundAndCustomQuery
Provides a logical AND combination for a list of custom queries.
|
class |
CompoundAndIndexScanner
Scans the indexes and gets index with the least number of entries.
|
class |
CompoundContainsItemsCustomQuery
using a common root query for item in collection-contains.
|
class |
CompoundOrCustomQuery
Provides a logical OR combination for a list of custom queries.
|
class |
CompoundOrIndexScanner
Scans the indexes and gets the union of all indexed entries.
|
class |
CustomSpaceQuery<T> |
class |
ExactValueIndexScanner
Scans the index with the defined index name only for entries that match the exact index value
|
class |
ExacValueCompoundIndexScanner
An exact value index scanner for compound index
|
class |
InValueIndexScanner
Scans the index with the defined index name only for entries that match one of the values in the
index value set.
|
class |
NotRegexIndexScanner
Scans the index with the defined index name only for entries that don't match the given regular
expression.
|
class |
NullValueIndexScanner
Scans only the entries that have a null index value
|
class |
PropertiesQuery
Queries an entry that matches all the given properties.
|
class |
RangeCompoundIndexScanner
Scans only the entries in the defined range via compound index
|
class |
RangeIndexScanner
Scans only the entries in the defined range
|
class |
RegexIndexScanner
Scans the index with the defined index name only for entries that match the given regular
expression.
|
class |
RelationIndexScanner
Scans the index using an external index using one of the relation that the external index is know
to handle.
|
class |
UidsIndexScanner
Scans the entries according to the supplied uids
|
Modifier and Type | Interface and Description |
---|---|
interface |
QueryOperationNode |
Modifier and Type | Class and Description |
---|---|
class |
BetweenRangeNode |
class |
IndexChoiceNode |
class |
QueryJunctionNode |
class |
RangeNode |
class |
ScanningInfo |
class |
SingleExplainPlan |
Modifier and Type | Interface and Description |
---|---|
interface |
ISpacePredicate
Represents a predicate to be executed in the space.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractSpacePredicate
A common basic implementation for space predicate implementations.
|
class |
FalseSpacePredicate
A space predicate that always returns false.
|
class |
TrueSpacePredicate
A space predicate that always returns true.
|
class |
ValueGetterSpacePredicate<T> |
Modifier and Type | Class and Description |
---|---|
class |
BetweenSpacePredicate
Represents a Between predicate.
|
class |
ComparableScalarSpacePredicate
A common basic implementation for comparable scalar comparison predicate implementations.
|
class |
ContainsItemPredicate
a contains predicate cascading from a single item
|
class |
ContainsPredicate
Represents a contains predicate.
|
class |
EqualsSpacePredicate
An implementation of equals to comparison: This predicate returns true if and only if the
predicate's argument is equal to the expected value.
|
class |
GreaterEqualsSpacePredicate
An implementation of greater than or equals to comparison: This predicate returns true if and
only if the predicate's argument is greater than or equals to the expected value.
|
class |
GreaterSpacePredicate
An implementation of greater than comparison: This predicate returns true if and only if the
predicate's argument is greater than the expected value.
|
class |
InSpacePredicate
Represents an In predicate.
|
class |
LessEqualsSpacePredicate
An implementation of less than or equals to comparison: This predicate returns true if and only
if the predicate's argument is less than or equals to the expected value.
|
class |
LessSpacePredicate
An implementation of less than comparison: This predicate returns true if and only if the
predicate's argument is less than the expected value.
|
class |
NotEqualsSpacePredicate
An implementation of not equals condition: This predicate returns true if and only if the
predicate's argument is not equal to the expected value.
|
class |
NotNullSpacePredicate
A predicate to test for non-null values.
|
class |
NotRegexSpacePredicate |
class |
NullSpacePredicate
A predicate to test for null values.
|
class |
RegexSpacePredicate |
class |
RelationPredicate |
class |
ScalarSpacePredicate
A common basic implementation for scalar comparison predicate implementations.
|
Modifier and Type | Class and Description |
---|---|
class |
AllSpacePredicate
An implementation of a logical multiple AND condition: This predicate returns true if and only if
all operands return true.
|
class |
AndSpacePredicate
An implementation of a logical binary AND condition: This predicate returns true if and only if
both left and right operands return true.
|
class |
AnySpacePredicate
An implementation of a logical multiple OR condition: This predicate returns true if and only if
any of the operands return true.
|
class |
BinaryCompositeSpacePredicate
A common basic implementation for binary composite space predicate implementations.
|
class |
CompositeSpacePredicate
A common basic implementation for composite space predicate implementations.
|
class |
MultipleCompositeSpacePredicate |
class |
NotSpacePredicate
An implementation of a logical unary NOT condition: This predicate returns true if and only if
the operand returns false.
|
class |
OrSpacePredicate
An implementation of a logical binary OR condition: This predicate returns true if and only if
either left or right operands return true.
|
class |
UnaryCompositeSpacePredicate
A common basic implementation for unary composite space predicate implementations.
|
class |
XorSpacePredicate
An implementation of a logical binary XOR condition: This predicate returns true if and only if
left or right operands return true, but not both.
|
Modifier and Type | Interface and Description |
---|---|
interface |
ISpaceValueGetter<T>
Represents an abstraction of getting a value from a target object.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractSpaceValueGetter<T>
Common basic implementation for ISpaceValueGetter implementations.
|
class |
SpaceEntryCollectionValuesExtractor
Extracts collection values for the provided collection index path.
|
class |
SpaceEntryCompoundIndexGetter
A space value getter for getting a compound index value from a space entry.
|
class |
SpaceEntryPathGetter
A space value getter for getting a path from a space entry.
|
class |
SpaceEntryPropertyGetter
A space value getter for getting a space entry property value.
|
Modifier and Type | Class and Description |
---|---|
class |
InternalQuiesceDetails |
class |
InternalQuiesceRequest |
Modifier and Type | Class and Description |
---|---|
static class |
AbstractProxy.ProxyReplace |
Modifier and Type | Interface and Description |
---|---|
interface |
RemoteOperationRequest<TResult extends RemoteOperationResult> |
Modifier and Type | Interface and Description |
---|---|
interface |
ScatterGatherRemoteOperationRequest<TResult extends RemoteOperationResult> |
Modifier and Type | Class and Description |
---|---|
class |
AbstractExternalizable
Base class for externalizable classes in gigaspaces, providing forward/backward compatibility
info.
|
Modifier and Type | Class and Description |
---|---|
class |
GSMessageTask |
Modifier and Type | Class and Description |
---|---|
class |
MVCCGenerationsState |
Modifier and Type | Class and Description |
---|---|
class |
WriteEntriesResult |
class |
WriteEntryResult |
Modifier and Type | Class and Description |
---|---|
class |
WaitForDrainCompoundResponse |
class |
WaitForDrainPartitionResponse |
Modifier and Type | Class and Description |
---|---|
class |
CompoundChunksResponse |
class |
CopyChunksPartitionTask |
class |
CopyChunksRequestInfo |
class |
CopyChunksResponseInfo |
class |
CopyChunksTask |
class |
DeleteChunksPartitionTask |
class |
DeleteChunksRequestInfo |
class |
DeleteChunksResponseInfo |
class |
DeleteChunksTask |
class |
DrainRequestInfo |
class |
DrainResponseInfo |
class |
DrainTask |
Modifier and Type | Class and Description |
---|---|
class |
TieredStorageConfig |
class |
TieredStorageTableConfig |
Modifier and Type | Class and Description |
---|---|
class |
ExternalizableServerEntry |
class |
HybridPropertiesHolder |
Modifier and Type | Class and Description |
---|---|
class |
AbstractSpaceActionInfo |
class |
GetTypeDescriptorActionInfo |
Modifier and Type | Interface and Description |
---|---|
interface |
SpaceRequestInfo |
Modifier and Type | Interface and Description |
---|---|
interface |
SpaceResponseInfo |
Modifier and Type | Class and Description |
---|---|
class |
AbstractSpaceResponseInfo |
class |
AddReplicationGatewayTargetResponseInfo |
class |
AddTypeIndexesResponseInfo |
class |
BroadcastTableSpaceResponseInfo |
class |
CollocatedJoinSpaceResponseInfo |
class |
DataSourceLoadSpaceResponseInfo |
class |
GetEntriesTieredMetaDataResponseInfo |
class |
GetMVCCEntryMetaDataResponseInfo |
class |
RegisterReplicationLocalViewResponseInfo |
class |
RegisterReplicationNotificationResponseInfo |
class |
RegisterTypeDescriptorResponseInfo |
class |
RemoveReplicationGatewayTargetResponseInfo |
class |
UnregisterTypeDescriptorResponseInfo |
Modifier and Type | Class and Description |
---|---|
class |
SyncHybridOperationDetails |
Modifier and Type | Class and Description |
---|---|
class |
AbstractTransactionUniqueId |
class |
DefaultTransactionUniqueId |
class |
XATransactionUniqueId |
Modifier and Type | Interface and Description |
---|---|
interface |
IEntryPacket
this is the basic interface defining the proxy-space or space-space transport layer.
|
interface |
ITemplatePacket
Extends IEntryPacket and provides an interface for templates.
|
interface |
ITransportPacket |
Modifier and Type | Class and Description |
---|---|
class |
AbstractEntryPacket |
class |
AbstractProjectionTemplate
Contains projection information and logic
|
class |
AbstractQueryPacket |
class |
CompoundRoutingHashValue |
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 |
MutliProjectionByUids
Holds projection information per uid.
|
class |
PbsEntryPacket |
class |
PbsProjectionTemplate
Holds PBS projection data.
|
class |
PbsTemplatePacket
PbsTemplatePacket defines the template object for Pbs layer.
|
class |
ProjectionTemplate
Holds projection template data
|
class |
TemplatePacket
This class represents a packet of information transmitted between a J-Space client and its
J-Space server .
|
Modifier and Type | Class and Description |
---|---|
class |
MutableBigDecimal |
class |
MutableBigInteger |
class |
MutableByte |
class |
MutableDouble |
class |
MutableFloat |
class |
MutableInteger |
class |
MutableLong |
class |
MutableNumber |
class |
MutableShort |
Modifier and Type | Class and Description |
---|---|
class |
PlatformLogicalVersion
Represents the logical version of the jar
|
Modifier and Type | Class and Description |
---|---|
class |
RemoteStub<T>
The
RemoteStub class is the common superclass to client stubs and provides the
framework to support a wide range of remote reference semantics. |
Modifier and Type | Class and Description |
---|---|
class |
HandshakeRequest
An LRMI handshake object
|
Modifier and Type | Class and Description |
---|---|
class |
NIODetails |
class |
NIOStatistics |
Modifier and Type | Class and Description |
---|---|
class |
JMXConnection
Used as a means for a service to publish information about a JMX Connector.
|
Modifier and Type | Class and Description |
---|---|
class |
LocalCacheDetails
Encapsulates local cache details.
|
class |
LocalViewDetails
Encapsulates local view details.
|
class |
SpaceQueryDetails
Encapsulates space query details.
|
Modifier and Type | Class and Description |
---|---|
class |
ConnectionEndpointDetails
Encapsulates details about a connection end point.
|
Modifier and Type | Interface and Description |
---|---|
interface |
AddTypeIndexesResult
Encapsulates information on the result of an add type indexes operation.
|
interface |
ISpaceCompoundIndexSegment
Encapsulates information about an index segment of a compound index.
|
interface |
ISpaceIndex
Encapsulates information about an index in a space type.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractCompoundIndexSegment
Encapsulates information about an index segment of a compound index.
|
class |
AbstractSpaceIndex |
class |
CompoundIndex
definition of a compound index meta data
|
class |
CustomIndex
Default implementation of the space custom index meta data
|
class |
PathCompoundIndexSegment
information about a path index segment of a compound index.
|
class |
PropertyCompoundIndexSegment
information about a property index segment of a compound index.
|
class |
SpacePathIndex
This type is intended for internal usage and should not be used directly.
|
class |
SpacePropertyIndex
This type is intended for internal usage and should not be used directly.
|
Modifier and Type | Class and Description |
---|---|
class |
CompoundResult |
Modifier and Type | Class and Description |
---|---|
class |
AbstractPathAggregator<T extends Serializable> |
class |
AggregationResult |
class |
AggregationSet
The set of aggregations to run for matches entries of the aggregate operation.
|
class |
AverageAggregator |
static class |
AverageAggregator.AverageTuple |
class |
CountAggregator |
class |
DistinctAggregator<T>
Aggregator for fetching distinct entries - based on some fields.
|
class |
DistinctPropertiesKey |
class |
DistinctResult |
class |
GroupByAggregator |
class |
GroupByKey |
class |
GroupByResult |
class |
GroupByValue |
class |
MaxEntryAggregator |
static class |
MaxEntryAggregator.MaxEntryScannerResult |
class |
MaxValueAggregator<T extends Serializable & Comparable> |
class |
MinEntryAggregator |
static class |
MinEntryAggregator.MinEntryScannerResult |
class |
MinValueAggregator<T extends Serializable & Comparable> |
class |
OrderByAggregator<T>
Aggregator for order by operation.
|
static class |
OrderByAggregator.OrderByScanResult |
class |
OrderByKey |
class |
OrderByPath
Created by anna on 11/10/14.
|
class |
SingleValueAggregator<T extends Serializable & Comparable> |
class |
SingleValueFunctionAggregator<T extends Serializable & Comparable> |
class |
SumAggregator |
class |
SumScalarValueAggregator |
class |
SumZeroAggregator
Sums values of paths of matching entries, when no non null values are applied zero is returned instead of null
returns the same type as the path.
|
class |
SumZeroScalarValueAggregator
Sums scalar value, when no non null values are applied zero is returned instead of null
returns the same type as the value.
|
Modifier and Type | Class and Description |
---|---|
class |
DefaultQueryExtensionPathInfo |
Modifier and Type | Class and Description |
---|---|
class |
TypeQueryExtensionImpl |
class |
TypeQueryExtensionsImpl |
Modifier and Type | Class and Description |
---|---|
class |
AuthenticationToken
An Authentication token which is used to further interact without using sensitive authentication
details (i.e.
|
Modifier and Type | Class and Description |
---|---|
class |
AuditDetails
The
AuditDetails are client side auditing details sent to the server on each
authentication request. |
Modifier and Type | Class and Description |
---|---|
class |
CredentialsProvider |
class |
DefaultCredentialsProvider |
class |
EmptyCredentialsProvider
Represents a CredentialsProvider with null UserDetails.
|
class |
TokenCredentialsProvider |
Modifier and Type | Class and Description |
---|---|
class |
SecurityContext
Security context passed between proxy and server.
|
Modifier and Type | Class and Description |
---|---|
class |
SessionId
Represents a unique identifier for an established session.
|
Modifier and Type | Class and Description |
---|---|
class |
BinaryObject
Contains an object serialized in a binary format.
|
Modifier and Type | Class and Description |
---|---|
class |
BlobStoreStatisticsImpl |
Modifier and Type | Class and Description |
---|---|
class |
SuspendInfo
Represents current suspend state of the space.
|
Modifier and Type | Class and Description |
---|---|
class |
XapManagerClusterInfo |
class |
XapManagerConfig |
Modifier and Type | Class and Description |
---|---|
class |
ExternalizableDataSyncOperation |
Modifier and Type | Class and Description |
---|---|
class |
Pair<T,V> |
Modifier and Type | Class and Description |
---|---|
class |
AbstractIdsQueryPacket
A base template packet for IdsQueryPacket and IdsMultiRoutingQueryPacket The template packet
contains an IDs array.
|
class |
AnswerPacket
This internal class for communication between client/server protocol.
|
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 |
JSpaceAttributes
JSpaceAttributes that contains all information per space.
|
static class |
LeaseInitializer.UIDLease |
static class |
LeaseInitializer.UpdateContextLease |
class |
LeaseProxy
An instance of this class represents an entry/template lease or a lease of an event registration
results from an event registration.
|
class |
LocalCacheResponseEntryPacket |
class |
LRMIJSpaceContainer
LRMI Stub implementation of
IJSpaceContainer, IJSpaceContainerAdmin,
LifeCycle,Service interface. |
class |
OperationID
Global unique identifier of a client operation.
|
class |
SpaceContext
The SpaceContext class defines context info passed from the proxy to the space.
|
class |
SpaceHealthStatus
Represents a space health status
|
class |
UidQueryPacket
Used for querying the space by a uid / uids.
|
Modifier and Type | Class and Description |
---|---|
class |
RuntimeHolder
Space runtime state holds the state of the space instace, for example, primary backup and
replication status.
|
class |
SpaceConfig
This structure contains all information about space configuration.
|
class |
SpaceRuntimeInfo
This class describes the content of the space,
on
com.j_spaces.core.admin.IRemoteJSpaceAdmin.getRuntimeInfo() call. |
class |
TemplateInfo
Used to hold a template info.
|
class |
ZKCollocatedClientConfig |
Modifier and Type | Class and Description |
---|---|
class |
BlobStoreEntryLayout |
Modifier and Type | Class and Description |
---|---|
class |
BlobStoreStorageAdapterClassInfo
class info used & stored in B.S.
|
class |
BlobStoreTypeDescSerializable
BlobStore storage adapter storedTypeDesc
|
Modifier and Type | Class and Description |
---|---|
class |
EntryArrivedRemoteEvent
An EntryArrivedRemoteEvent is sent to a NotifyDelegator object when an entry that matches the
delegator's template enters a GigaSpace.
|
class |
LocalTransactionManager
Deprecated.
Since 8.0 - Use JINI transactions instead.
|
class |
LRMIJSpaceProxyListener
LRMI Stub implementation of
IJSpaceProxyListener interface. |
class |
ProxySettings
Essential proxy settings.
|
class |
SpaceSettings
SpaceSettings is a set of properties passed from the space to its proxy
|
class |
SpaceURL
Deprecated.
|
Modifier and Type | Class and Description |
---|---|
class |
ClusterPolicy
Holds the cluster policy data.
|
static class |
ClusterPolicy.CacheLoaderConfig |
class |
FailOverPolicy
Copyright (c) 2010 GigaSpaces Technologies Ltd.
|
static class |
FailOverPolicy.FailOverPolicyDescription |
class |
ReplicationPolicy |
static class |
ReplicationPolicy.ReplicationPolicyDescription
Replication policy description for every member.
|
class |
SwapBacklogConfig |
Modifier and Type | Class and Description |
---|---|
class |
ReplicationStatistics
Represents the current state of the replication module
|
static class |
ReplicationStatistics.OutgoingChannel
Expose outgoing replication channel statistics
|
static class |
ReplicationStatistics.OutgoingReplication |
class |
RuntimeStatisticsHolder
Holds runtime statistics counters.
|
class |
StatisticsContext
Representation of an operation statistics object.
|
class |
StatisticsHolder |
Modifier and Type | Class and Description |
---|---|
class |
BatchOperationException
Thrown when one of the following space operations fails: readMultiple,takeMultiple,clear.
|
Modifier and Type | Class and Description |
---|---|
class |
ExtendedRequestPacket |
class |
JoinedEntry
This class represents an entry that was constructed from a join between several tables.
|
class |
QueryProcessorStub
Smart stub for the
QueryProcessor |
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 | Class and Description |
---|---|
class |
CompositeRange
CompositeRange indicates a result of a complex intersection that can't be translated to a single
range.
|
class |
ContainsCompositeRange
Collection contains composite range.
|
class |
ContainsItemValueRange
a range for c collection imposede on single item rendered.
|
class |
ContainsValueRange
Represents a value range used by ContainsNode.
|
class |
CriteriaRange |
class |
EmptyRange
Represents an empty range - range that always translates to an empty query
|
class |
EqualValueRange |
class |
FunctionCallDescription
Created by Barak Bar Orion on 2/9/16.
|
class |
InRange
Represents an IN expression range
|
class |
IsNullRange |
class |
NotEqualValueRange |
class |
NotNullRange |
class |
NotRegexRange
Represents a negation of a regular expression range
|
class |
Range |
class |
RegexRange
Represents a regular expression range
|
class |
RelationRange
Created by Barak Bar Orion 8/24/15.
|
class |
SegmentRange
Defines a range of objects.
|
class |
SingleValueRange |
class |
UidsRange
Represents a set of uids to match against the candidates
|
Modifier and Type | Class and Description |
---|---|
static class |
GPreparedStatement.PreparedValuesCollection
An implementation for holding the prepared values & prepared values batch.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractInNode |
class |
AndNode
This is the AndNode, expressing an 'and' between conditions.
|
class |
ColumnNode
This is a column Node.
|
class |
ContainsItemNode
node holding a single item inside contains, or a hole expression pointed by value
|
class |
ContainsItemsRootNode
node holding a root inside contains - points at a subtree of containItemNodes
|
class |
ContainsNode
An expression node for a contains argument.
|
class |
EqualNode
This is the equal operator Node.
|
class |
ExpNode
This is the main expression node.
|
class |
GTENode
This is the greater-than-equal operator Node.
|
class |
GTNode
This is the greater-than operator Node.
|
class |
InnerQueryNode
Represents an inner (sub) query in a WHERE clause condition.
|
class |
InNode
The InNode.
|
class |
IsNullNode
This is the IS NULL operator Node.
|
class |
LikeNode
This is the LIKE operator Node.
|
class |
LiteralNode
This is the Literal node.
|
class |
LTENode
This is the less-than-equal operator Node.
|
class |
LTNode
This is the less-than operator Node.
|
class |
NotEqualNode
This is the not-equal operator Node.
|
class |
NotInNode
The NotInNode.
|
class |
NotLikeNode
This is the NOT LIKE operator Node.
|
class |
OrNode
This is the OR Node that represents an 'OR' between conditions
|
class |
PreparedNode
This is a Prepared node.
|
class |
RelationNode
Created by Barak Bar Orion 8/24/15.
|
class |
RLikeNode
This is the an operator that is used for java regular expression matching
|
class |
RowNumNode
This node represents the rownum command.
|
class |
ValueNode
This is a parent class for the ColumnNode and the LiteralNodes.
|
Modifier and Type | Class and Description |
---|---|
class |
QueryColumnData |
class |
QueryTableData |
Modifier and Type | Class and Description |
---|---|
class |
ClusterGroup
Copyright (c) 2010 GigaSpaces Technologies Ltd.
|
class |
ClusterName
This lookup attributes providing registration space with cluster name class name.
|
class |
ContainerName
Container name attributes for registering to LookupService.
|
class |
HostName
The hostName attributes for registering to LookupService.
|
class |
JoinState |
class |
State
The State entry represents the current service state. |
Modifier and Type | Class and Description |
---|---|
class |
ExtendedPrepareResult
prepare result returned when clusterd proxy is needed
|
class |
TxnMgrProxy
A
TxnMgrProxy is a proxy for the transaction manager service. |
Modifier and Type | Class and Description |
---|---|
class |
DefaultProxyPivot
Default implementation for of
MarshalPivot providing a proxy replacement on the LUS. |
Modifier and Type | Class and Description |
---|---|
class |
ServiceDetails |
Modifier and Type | Class and Description |
---|---|
class |
NestableServerTransaction
Class implementing the
NestableTransaction interface, for use with transaction
participants that implement the default transaction semantics. |
class |
ServerTransaction
Class implementing the
Transaction interface, for use with transaction participants
that implement the default transaction semantics. |
class |
TransactionParticipantDataImpl
Contains ServerTransaction meta data for distributed transactions that have more than 1
participant.
|
Modifier and Type | Class and Description |
---|---|
class |
Name
The name of a service as used by users.
|
class |
ServiceInfo
Generic information about a service.
|
Modifier and Type | Class and Description |
---|---|
class |
RemoteClassLoaderInfo
Created by tamirs
on 11/14/16.
|
class |
SpaceInstanceRemoteClassLoaderInfo
Created by tamirs
on 11/14/16.
|
class |
SupportCodeChangeAnnotationContainer
Created by tamirs
on 11/8/16.
|
Modifier and Type | Class and Description |
---|---|
class |
CR8Impl |
class |
PipelineMetrics |
Modifier and Type | Class and Description |
---|---|
class |
ClusterInfoImpl |
Modifier and Type | Class and Description |
---|---|
class |
InternalDistributedSpaceTaskWrapper<T extends Serializable,R>
An internal implementation of
DistributedSpaceTask that wraps the
actual Task to be executed. |
class |
InternalSpaceTaskWrapper<T extends Serializable>
|
Modifier and Type | Class and Description |
---|---|
class |
CallableDistributedTaskAdapter<T extends Serializable,R>
An adapter allowing to execute a
Callable in a distributed fashion. |
class |
CallableTaskAdapter<T extends Serializable>
An adapter allowing to execute a
Callable using Space task executors. |
class |
RunnableDistributedTaskAdapter<T extends Serializable,R>
An adapter allowing to execute a
Runnable in a distributed fashion. |
class |
RunnableTaskAdapter<T extends Serializable>
An adapter allowing to execute a
Runnable using Space task executors. |
Modifier and Type | Class and Description |
---|---|
class |
AvgTask<T extends Number,R extends Number>
A sum distrubted task that accepts a
Task to delegate the
actual execution to and implements the AvgTask.reduce(java.util.List) operation. |
class |
MaxTask<T extends Number>
A max distrubuted task that accepts a
Task to delegate the
actual execution to and implements the MaxTask.reduce(java.util.List) operation. |
class |
MinTask<T extends Number>
A min distrubuted task that accepts a
Task to delegate the
actual execution to and implements the MinTask.reduce(java.util.List) operation. |
class |
PrivilegedDistributedTask<T extends Serializable,R>
A delegating distrubuted task (with an optional filter) that runs under established access
control settings.
|
class |
PrivilegedTask<T extends Serializable>
A delegating task that runs under established access control settings.
|
class |
SumTask<T extends Number,R extends Number>
A sum distrubuted task that accepts a
Task to delegate the
actual execution to and implements the SumTask.reduce(java.util.List) operation. |
Modifier and Type | Class and Description |
---|---|
class |
GatewayDelegatorServiceDetails
Provide service details of
GatewayDelegatorFactoryBean |
class |
GatewayServiceDetails
Provide service details of a gateway
AbstractGatewayComponentFactoryBean |
class |
GatewaySinkServiceDetails
Provide service details of a
GatewaySinkFactoryBean |
Modifier and Type | Class and Description |
---|---|
class |
SpaceServiceDetails
A Space service defined within a processing unit.
|
Modifier and Type | Class and Description |
---|---|
class |
EventContainerServiceDetails
A generic event container service details.
|
class |
EventContainerServiceMonitors
A generic event container service monitors.
|
Modifier and Type | Class and Description |
---|---|
class |
AggregatedAsyncPollingEventContainerServiceDetails
Async Polling container service details.
|
class |
AsyncPollingEventContainerServiceDetails
Async Polling container service details.
|
class |
AsyncPollingEventContainerServiceMonitors
Async Polling container service monitors.
|
Modifier and Type | Class and Description |
---|---|
class |
AggregatedNotifyEventContainerServiceDetails
Notify container service details.
|
class |
NotifyEventContainerServiceDetails
Notify container service details.
|
class |
NotifyEventContainerServiceMonitors
Notify container service monitors.
|
Modifier and Type | Class and Description |
---|---|
class |
AggregatedPollingEventContainerServiceDetails |
class |
PollingEventContainerServiceDetails
Polling container service details.
|
class |
PollingEventContainerServiceMonitors
Polling container service monitors.
|
Modifier and Type | Class and Description |
---|---|
class |
SpaceTypeDescriptorHolder
A
SpaceTypeDescriptor holder which serializes/deserializes its underlying SpaceTypeDescriptor In a version compatible manner. |
Modifier and Type | Class and Description |
---|---|
class |
SpaceTypeDescriptorContainer |
Modifier and Type | Class and Description |
---|---|
class |
JeeServiceDetails
A service that holds a jee container (such as jetty).
|
Modifier and Type | Class and Description |
---|---|
class |
WebRequestsServiceMonitors
Statistics monitor information for JEE servlet requests.
|
Modifier and Type | Class and Description |
---|---|
class |
PUDetails |
class |
PUMonitors |
Modifier and Type | Class and Description |
---|---|
class |
StandaloneServiceDetails
Standalone details for a Processing Unit instance which is un-managed by the Service Grid.
|
Modifier and Type | Class and Description |
---|---|
class |
CustomServiceDetails
This class should be used by customers in order to implement their ServiceDetails
|
class |
CustomServiceMonitors
This class should be used by customers in order to implement their ServiceMonitors
|
class |
InvocationResult |
class |
PlainAggregatedServiceDetails
A simple and generic implementation of the
AggregatedServiceDetails
interface. |
class |
PlainServiceDetails
A simple implementation of
ServiceDetails . |
class |
PlainServiceMonitors
A simple implementation of
ServiceMonitors . |
Modifier and Type | Class and Description |
---|---|
class |
EventDrivenSpaceRemotingEntry
Default implementation of a remoting entry that acts both as a remote invocation and a remote
result.
|
class |
EventDrivenSpaceRemotingFifoEntry
Default implementation of a remoting entry that acts both as a remote invocation and a remote
result.
|
class |
ExecutorRemotingTask<T extends Serializable>
A
Task that can be used to simulate remote invocation with
SpaceRemotingServiceExporter . |
static class |
ExecutorRemotingTask.InternalExecutorException
A wrapper executor exception that holds more information on the exception, such as the
instance id.
|
static class |
ExecutorRemotingTask.InternalExecutorResult<T extends Serializable>
A wrapper executor result that holds more information on the exception, such as the instance
id.
|
class |
HashedEventDrivenSpaceRemotingEntry |
class |
HashedEventDrivenSpaceRemotingFifoEntry |
class |
RemotingServiceDetails
A generic remoting service details.
|
static class |
RemotingServiceDetails.RemoteService |
class |
RemotingServiceMonitors
A generic event container service monitors.
|
static class |
RemotingServiceMonitors.RemoteServiceStats |
static class |
RemotingUtils.MethodHash |
Modifier and Type | Class and Description |
---|---|
class |
ResourceLazyLoadingScript
A resource lazy loading script is a lazy loading script that uses Spring abstraction on top of
resources on top of a resource.
|
class |
StaticResourceScript
A static script that uses Spring
Resource and ResourceLoader to load a given
script (for example, from the classpath). |
class |
StaticScript
A script that holds the actual script as a String.
|
Copyright © GigaSpaces.