Search Java Classes and Packages

Search Java Frameworks and Libraries

255581 classes and counting ...
Search Tips Index Status



# Classes and Interfaces in #Ignite - 469 results found.
NameDescriptionTypePackageFramework
PacketCollectorProvides a mechanism to collect packets into a result queue that pass a specified filter.Classorg.jivesoftware.smackSmack Ignite
PacketListenerInterfaceorg.jivesoftware.smackSmack Ignite
AboutDialogClassorg.apache.ignite.startup.cmdlineIgnite
AbstractMarshallerBase class for marshallers.Classorg.apache.ignite.marshallerIgnite
AdaptiveCpuLoadProbe Based on setUseAverage(boolean) parameter, this implementation will either use average CPU loadClassorg.apache.ignite.spi.loadbalancing.adaptiveIgnite
AdaptiveJobCountLoadProbe Based on setUseAverage(boolean) parameter, this implementation will either use average job count values or current (default is to use averages).Classorg.apache.ignite.spi.loadbalancing.adaptiveIgnite
AdaptiveLoadBalancingSpiLoad balancing SPI that adapts to overall node performance.Classorg.apache.ignite.spi.loadbalancing.adaptiveIgnite
AdaptiveLoadBalancingSpiMBeanManagement MBean for AdaptiveLoadBalancingSpi SPI.Interfaceorg.apache.ignite.spi.loadbalancing.adaptiveIgnite
AdaptiveLoadProbePluggable implementation of node load probing.Interfaceorg.apache.ignite.spi.loadbalancing.adaptiveIgnite
AdaptiveProcessingTimeLoadProbe Based on setUseAverage(boolean) parameter, this implementation will either use average job executionClassorg.apache.ignite.spi.loadbalancing.adaptiveIgnite
AddressResolverProvides resolution between external and internal addresses.Interfaceorg.apache.ignite.configurationIgnite
AffinityProvides affinity information to detect which node is primary and which nodes are backups for a partitioned cache.Interfaceorg.apache.ignite.cache.affinityIgnite
AffinityCentralizedFunctionAnnotation marker which identifies affinity function that must be calculated on one centralized node instead of independently on each node.Classorg.apache.ignite.cache.affinityIgnite
AffinityFunctionCache key affinity which maps keys to nodes.Interfaceorg.apache.ignite.cache.affinityIgnite
AffinityFunctionContextAffinity function context.Interfaceorg.apache.ignite.cache.affinityIgnite
AffinityKeyOptional wrapper for cache keys to provide support for custom affinity mapping.Classorg.apache.ignite.cache.affinityIgnite
AffinityKeyMappedOptional annotation to specify custom key-to-node affinity.Classorg.apache.ignite.cache.affinityIgnite
AffinityKeyMapperAffinity mapper which maps cache key to an affinity key.Interfaceorg.apache.ignite.cache.affinityIgnite
AffinityNodeAddressHashResolverNode hash resolver which uses ClusterNode.Classorg.apache.ignite.cache.affinityIgnite
AffinityNodeHashResolverResolver which is used to provide node hash value for affinity function.Interfaceorg.apache.ignite.cache.affinityIgnite
AffinityNodeIdHashResolverNode hash resolver which uses generated node ID as node hash value.Classorg.apache.ignite.cache.affinityIgnite
AlwaysFailoverSpiFailover SPI that always reroutes a failed job to another node.Classorg.apache.ignite.spi.failover.alwaysIgnite
AlwaysFailoverSpiMBeanManagement bean for AlwaysFailoverSpi.Interfaceorg.apache.ignite.spi.failover.alwaysIgnite
AtomicConfigurationConfiguration for atomic data structures.Classorg.apache.ignite.configurationIgnite
AuthenticationContextAuthentication context.Classorg.apache.ignite.plugin.securityIgnite
BasicJdbcDialectBasic implementation of dialect based on JDBC specification.Classorg.apache.ignite.cache.store.jdbc.dialectIgnite
BasicWarmupClosureBasic warm-up closure which warm-ups cache operations.Classorg.apache.ignite.startupIgnite
CacheAbstractJdbcStore Store works with database via SQL dialect.Classorg.apache.ignite.cache.store.jdbcIgnite
CacheAtomicityModeenum CacheAtomicityModeCache atomicity mode controls whether cache should maintain fully transactional semanticsClassorg.apache.ignite.cacheIgnite
CacheAtomicUpdateTimeoutExceptionException thrown when atomic operation timeout occurs.Classorg.apache.ignite.cacheIgnite
CacheAtomicWriteOrderModeenum CacheAtomicWriteOrderModeCache write ordering mode.Classorg.apache.ignite.cacheIgnite
CacheCheckpointSpiThis class defines cache-based implementation for checkpoint SPI.Classorg.apache.ignite.spi.checkpoint.cacheIgnite
CacheCheckpointSpiMBeanManagement bean that provides general administrative and configuration information about cache checkpoint SPI.Interfaceorg.apache.ignite.spi.checkpoint.cacheIgnite
CacheConfigurationThis class defines grid cache configuration.Classorg.apache.ignite.configurationIgnite
CacheEntryEventSerializableFilterThis filter adds Serializable interface to CacheEntryEventFilter object.Interfaceorg.apache.ignite.cacheIgnite
CacheEntryProcessorThis processor adds Serializable interface to EntryProcessor object.Interfaceorg.apache.ignite.cacheIgnite
CacheEventIn-memory database (cache) event.Classorg.apache.ignite.eventsIgnite
CacheExistsExceptionException thrown when cache must be created but it already exists.Classorg.apache.ignite.cacheIgnite
CacheInterceptorCache interceptor.Interfaceorg.apache.ignite.cacheIgnite
CacheInterceptorAdapterCache interceptor convenience adapter.Classorg.apache.ignite.cacheIgnite
CacheJdbcBlobStoreCacheStore implementation backed by JDBC.Classorg.apache.ignite.cache.store.jdbcIgnite
CacheJdbcPojoStore This implementation stores objects in underlying database using java beans mapping description via reflection.Classorg.apache.ignite.cache.store.jdbcIgnite
CacheJndiTmLookupClassorg.apache.ignite.cache.jta.jndiIgnite
CacheLoadOnlyStoreAdapterThis adapter designed to support stores with bulk loading from stream-like source.Classorg.apache.ignite.cache.storeIgnite
CacheManagerClassorg.apache.ignite.cacheIgnite
CacheMemoryModeenum CacheMemoryModeDefines set of memory modes.Classorg.apache.ignite.cacheIgnite
CacheMetricsCache metrics used to obtain statistics on cache itself.Interfaceorg.apache.ignite.cacheIgnite
CacheMetricsMXBeanThis interface defines JMX view on IgniteCache.Interfaceorg.apache.ignite.mxbeanIgnite
CacheModeEnumeration of all supported caching modes.Classorg.apache.ignite.cacheIgnite
CacheNameResourceAnnotates a field or a setter method for injection of grid cache name.Classorg.apache.ignite.resourcesIgnite
CachePartialUpdateExceptionException thrown from non-transactional cache in case when update succeeded only partially.Classorg.apache.ignite.cacheIgnite
CachePeekModeEnumeration of all supported cache peek modes.Classorg.apache.ignite.cacheIgnite
CacheQueryExecutedEventCache query execution event.Classorg.apache.ignite.eventsIgnite
CacheQueryReadEventCache query read event.Classorg.apache.ignite.eventsIgnite
CacheRebalanceModeenum CacheRebalanceModeCache rebalance mode.Classorg.apache.ignite.cacheIgnite
CacheRebalancingEventIn-memory database (cache) rebalancing event.Classorg.apache.ignite.eventsIgnite
CacheReflectionTmLookup JTA manager by calling static method on the class.Classorg.apache.ignite.cache.jta.reflectIgnite
CacheServerNotFoundExceptionException thrown when all data nodes left the grid.Classorg.apache.ignite.cacheIgnite
CacheStoreAPI for cache persistent storage for read-through and write-through behavior.Interfaceorg.apache.ignite.cache.storeIgnite
CacheStoreAdapterCache storage convenience adapter.Classorg.apache.ignite.cache.storeIgnite
CacheStoreSessionSession for the cache store operations.Interfaceorg.apache.ignite.cache.storeIgnite
CacheStoreSessionResourceAnnotates a field or a setter method for injection of current CacheStoreSession instance.Classorg.apache.ignite.resourcesIgnite
CacheTmLookupAllows grid to use different transactional systems.Interfaceorg.apache.ignite.cache.jtaIgnite
CacheTypeFieldMetadataType field metadata.Classorg.apache.ignite.cacheIgnite
CacheTypeMetadataClassorg.apache.ignite.cacheIgnite
CacheWriteSynchronizationModeenum CacheWriteSynchronizationModeMode indicating how Ignite should wait for write replies from other nodes.Classorg.apache.ignite.cacheIgnite
CachingProviderClassorg.apache.ignite.cacheIgnite
CheckpointEventGrid checkpoint event.Classorg.apache.ignite.eventsIgnite
CheckpointListenerListener for notifications of checkpoints removed by CheckpointSpi.Interfaceorg.apache.ignite.spi.checkpointIgnite
CheckpointSpiCheckpoint SPI provides an ability to save an intermediate job state.Interfaceorg.apache.ignite.spi.checkpointIgnite
ClusterGroupDefines a cluster group which contains all or a subset of cluster nodes.Interfaceorg.apache.ignite.clusterIgnite
ClusterGroupEmptyExceptionThis exception defines illegal call on empty cluster group.Classorg.apache.ignite.clusterIgnite
ClusterLocalNodeMetricsMXBeanMBean for local node metrics.Interfaceorg.apache.ignite.mxbeanIgnite
ClusterMetricsThis class represents runtime information on a cluster.Interfaceorg.apache.ignite.clusterIgnite
ClusterNodeInterface representing a single cluster node.Interfaceorg.apache.ignite.clusterIgnite
ClusterTopologyExceptionThis exception is used to indicate error with the cluster topology (e.Classorg.apache.ignite.clusterIgnite
CollectionConfigurationConfiguration for Ignite collections.Classorg.apache.ignite.configurationIgnite
CollisionContextContext for resolving collisions.Interfaceorg.apache.ignite.spi.collisionIgnite
CollisionExternalListenerListener to be set on CollisionSpi for notification of external collision events (e.Interfaceorg.apache.ignite.spi.collisionIgnite
CollisionJobContextThis interface defines set of operations that collision SPI implementation can perform on jobs that are either waiting or executing.Interfaceorg.apache.ignite.spi.collisionIgnite
CollisionSpiCollision SPI allows to regulate how grid jobs get executed when they arrive on a destination node for execution.Interfaceorg.apache.ignite.spi.collisionIgnite
CommandLineRandomNumberGeneratorGenerates a random number and prints it to the console.Classorg.apache.ignite.startup.cmdlineIgnite
CommandLineStartupThis class defines command-line Ignite startup.Classorg.apache.ignite.startup.cmdlineIgnite
CommandLineTransformerThis class is a workaround for a versatile problems with passing arguments to the Ignite Windows batch launcher scripts.Classorg.apache.ignite.startup.cmdlineIgnite
CommunicationListenerListener SPI notifies IO manager with.Interfaceorg.apache.ignite.spi.communicationIgnite
CommunicationSpiCommunication SPI is responsible for data exchange between nodes.Interfaceorg.apache.ignite.spi.communicationIgnite
ComputeExecutionRejectedExceptionThis exception defines execution rejection.Classorg.apache.ignite.computeIgnite
ComputeJobDefines executable unit for ComputeTask.Interfaceorg.apache.ignite.computeIgnite
ComputeJobAdapterConvenience adapter for ComputeJob implementations.Classorg.apache.ignite.computeIgnite
ComputeJobAfterSendThis annotation allows to call a method right after the job has been successfully sent for execution.Classorg.apache.ignite.computeIgnite
ComputeJobBeforeFailoverThis annotation allows to call a method right before job is submitted to FailoverSpi.Classorg.apache.ignite.computeIgnite
ComputeJobContextContext attached to every job executed on the grid.Interfaceorg.apache.ignite.computeIgnite
ComputeJobContinuationDefines continuation support for grid job context.Interfaceorg.apache.ignite.computeIgnite
ComputeJobContinuationAdapterConvenience adapter for ComputeJob implementations.Classorg.apache.ignite.computeIgnite
ComputeJobFailoverExceptionThis runtime exception can be thrown from ComputeJob.Classorg.apache.ignite.computeIgnite
ComputeJobMasterLeaveAwareAnnotation for handling master node leave during job execution.Interfaceorg.apache.ignite.computeIgnite
ComputeJobResultResult of remote job which gets passed into ComputeTask.Interfaceorg.apache.ignite.computeIgnite
ComputeJobResultPolicyenum ComputeJobResultPolicyThis enumeration provides different types of actions following the lastClassorg.apache.ignite.computeIgnite
ComputeJobSiblingJob sibling interface defines a job from the same split.Interfaceorg.apache.ignite.computeIgnite
ComputeLoadBalancerLoad balancer is used for finding the best balanced node according to load balancing policy.Interfaceorg.apache.ignite.computeIgnite
ComputeTaskGrid task interface defines a task that can be executed on the grid.Interfaceorg.apache.ignite.computeIgnite
ComputeTaskAdapterConvenience adapter for ComputeTask interface.Classorg.apache.ignite.computeIgnite
ComputeTaskCancelledExceptionThis exception indicates that grid task was cancelled.Classorg.apache.ignite.computeIgnite
ComputeTaskContinuousMapperDefines a mapper that can be used for asynchronous job sending.Interfaceorg.apache.ignite.computeIgnite
ComputeTaskFutureThis class defines a handler for asynchronous task execution.Interfaceorg.apache.ignite.computeIgnite
ComputeTaskMapAsyncAnnotation for asynchronous task mapping.Classorg.apache.ignite.computeIgnite
ComputeTaskNameThis annotation allows to assign optional name to grid task.Classorg.apache.ignite.computeIgnite
ComputeTaskNoResultCacheThis annotation disables caching of task results when attached to ComputeTask class being executed.Classorg.apache.ignite.computeIgnite
ComputeTaskSessionDefines a distributed session for particular task execution.Interfaceorg.apache.ignite.computeIgnite
ComputeTaskSessionAttributeListenerThis interface defines listener for task session attributes.Interfaceorg.apache.ignite.computeIgnite
ComputeTaskSessionFullSupportAnnotation for enabling task session attributes and checkpoints for tasks.Classorg.apache.ignite.computeIgnite
ComputeTaskSessionScopeenum ComputeTaskSessionScopeDefines life-time scopes for checkpoint operations.Classorg.apache.ignite.computeIgnite
ComputeTaskSpisThis annotation allows task to specify what SPIs it wants to use.Classorg.apache.ignite.computeIgnite
ComputeTaskSplitAdapterThis class defines simplified adapter for ComputeTask.Classorg.apache.ignite.computeIgnite
ComputeTaskTimeoutExceptionThis exception indicates that task execution timed out.Classorg.apache.ignite.computeIgnite
ComputeUserUndeclaredExceptionThis exception is thrown when user's code throws undeclared runtime exception.Classorg.apache.ignite.computeIgnite
ConnectorConfigurationREST access configuration.Classorg.apache.ignite.configurationIgnite
ConnectorMessageInterceptorInterface for user-defined object interceptors.Interfaceorg.apache.ignite.configurationIgnite
ContinuousQueryAPI for configuring continuous cache queries.Classorg.apache.ignite.cache.queryIgnite
DB2DialectA dialect compatible with the IBM DB2 database.Classorg.apache.ignite.cache.store.jdbc.dialectIgnite
DeploymentEventGrid deployment event.Classorg.apache.ignite.eventsIgnite
DeploymentListenerListener for deployment events.Interfaceorg.apache.ignite.spi.deploymentIgnite
DeploymentModeGrid deployment mode.Classorg.apache.ignite.configurationIgnite
DeploymentResourceGeneric abstraction over deployed resource containing resource's name, class and corresponding class loader.Interfaceorg.apache.ignite.spi.deploymentIgnite
DeploymentResourceAdapterSimple adapter for DeploymentResource interface.Classorg.apache.ignite.spi.deploymentIgnite
DeploymentSpiGrid deployment SPI is in charge of deploying tasks and classes from different Class loaders that are in charge of loading task classes (and other classes)Interfaceorg.apache.ignite.spi.deploymentIgnite
DiscoveryEventGrid discovery event.Classorg.apache.ignite.eventsIgnite
DiscoveryMetricsProviderProvides metrics to discovery SPI.Interfaceorg.apache.ignite.spi.discoveryIgnite
DiscoverySpiGrid discovery SPI allows to discover remote nodes in grid.Interfaceorg.apache.ignite.spi.discoveryIgnite
DiscoverySpiDataExchangeHandler for initial data exchange between Ignite nodes.Interfaceorg.apache.ignite.spi.discoveryIgnite
DiscoverySpiHistorySupportThis annotation is for all implementations of DiscoverySpi that support topology snapshots history.Classorg.apache.ignite.spi.discoveryIgnite
DiscoverySpiListenerListener for grid node discovery events.Interfaceorg.apache.ignite.spi.discoveryIgnite
DiscoverySpiNodeAuthenticatorInterfaceorg.apache.ignite.spi.discoveryIgnite
DiscoverySpiOrderSupportThis annotation is for all implementations of DiscoverySpi that support proper node ordering.Classorg.apache.ignite.spi.discoveryIgnite
EventGrid events are used for notification about what happens within the grid.Interfaceorg.apache.ignite.eventsIgnite
EventAdapterBase adapter for the events.Classorg.apache.ignite.eventsIgnite
EventStorageSpiThis SPI provides local node events storage.Interfaceorg.apache.ignite.spi.eventstorageIgnite
EventTypeContains event type constants.Interfaceorg.apache.ignite.eventsIgnite
EvictableEntryEvictable cache entry passed into EvictionPolicy.Interfaceorg.apache.ignite.cache.evictionIgnite
EvictionFilterEviction filter to specify which entries should not be evicted.Interfaceorg.apache.ignite.cache.evictionIgnite
EvictionPolicyPluggable cache eviction policy.Interfaceorg.apache.ignite.cache.evictionIgnite
ExtensionMarker interface for extensions.Interfaceorg.apache.ignite.pluginIgnite
ExtensionRegistryContext that allows to register extensions.Interfaceorg.apache.ignite.pluginIgnite
FailoverContextThis interface defines a set of operations available to failover SPI one a given failed job.Interfaceorg.apache.ignite.spi.failoverIgnite
FailoverSpiFailover SPI provides developer with ability to supply custom logic for handling failed execution of a grid job.Interfaceorg.apache.ignite.spi.failoverIgnite
FairAffinityFunctionFair affinity function which tries to ensure that all nodes get equal number of partitions with minimum amount of reassignments between existing nodes.Classorg.apache.ignite.cache.affinity.fairIgnite
FifoEvictionPolicyEviction policy based on First In First Out (FIFO) algorithm.Classorg.apache.ignite.cache.eviction.fifoIgnite
FifoEvictionPolicyMBeanMBean for FIFO eviction policy.Interfaceorg.apache.ignite.cache.eviction.fifoIgnite
FifoQueueCollisionSpiThis class provides implementation for Collision SPI based on FIFO queue.Classorg.apache.ignite.spi.collision.fifoqueueIgnite
FifoQueueCollisionSpiMBeanManagement bean that provides access to the FIFO queue collision SPI configuration.Interfaceorg.apache.ignite.spi.collision.fifoqueueIgnite
FileSwapSpaceSpiFile-based swap space SPI implementation which holds keys in memory.Classorg.apache.ignite.spi.swapspace.fileIgnite
FileSwapSpaceSpiMBeanManagement bean for FileSwapSpaceSpi.Interfaceorg.apache.ignite.spi.swapspace.fileIgnite
FileSystemConfigurationIGFS configuration.Classorg.apache.ignite.configurationIgnite
Gridify @Gridify(taskClass = GridifyHelloWorldTask.Classorg.apache.ignite.compute.gridifyIgnite
GridifyArgumentGridify task argument created by the system for task execution.Interfaceorg.apache.ignite.compute.gridifyIgnite
GridifyArgumentAdapterConvenience adapter for GridifyArgument interface.Classorg.apache.ignite.compute.gridify.aopIgnite
GridifyAspectJAspectAspectJ aspect that cross-cuts on all methods grid-enabled with Gridify annotation and potentially executes them onClassorg.apache.ignite.compute.gridify.aop.aspectjIgnite
GridifyDefaultRangeTaskDefault gridify task which simply executes a method on remote node.Classorg.apache.ignite.compute.gridify.aopIgnite
GridifyDefaultTaskDefault gridify task which simply executes a method on remote node.Classorg.apache.ignite.compute.gridify.aopIgnite
GridifyInputThis annotation can be applied to method parameter for grid-enabled method.Classorg.apache.ignite.compute.gridifyIgnite
GridifyInterceptorThis interface defines an interceptor apply for Gridify annotation.Interfaceorg.apache.ignite.compute.gridifyIgnite
GridifyNodeFilterPredicate node filter.Interfaceorg.apache.ignite.compute.gridifyIgnite
GridifyRuntimeExceptionThis defines gridify exception.Classorg.apache.ignite.compute.gridifyIgnite
GridifySetToSetGridifySetToSet annotation allows to grid-enable existing code with specific semantics.Classorg.apache.ignite.compute.gridifyIgnite
GridifySetToSetAbstractAspectConvenience adapter with common methods for different aspect implementations (AspectJ, JBoss AOP, Spring AOP).Classorg.apache.ignite.compute.gridify.aopIgnite
GridifySetToSetAspectJAspectAspectJ aspect that cross-cuts on all methods grid-enabled with GridifySetToSet annotation and potentially executes them onClassorg.apache.ignite.compute.gridify.aop.aspectjIgnite
GridifySetToSetSpringAspectSpring aspect that cross-cuts on all methods grid-enabled with GridifySetToSet annotation and potentially executes them onClassorg.apache.ignite.compute.gridify.aop.springIgnite
GridifySetToValueGridifySetToValue annotation is the way to grid-enable existing code with specific semantics.Classorg.apache.ignite.compute.gridifyIgnite
GridifySetToValueAbstractAspectConvenience adapter with common methods for different aspect implementations (AspectJ, JBoss AOP, Spring AOP).Classorg.apache.ignite.compute.gridify.aopIgnite
GridifySetToValueAspectJAspectAspectJ aspect that cross-cuts on all methods grid-enabled with GridifySetToValue annotation and potentially executes them onClassorg.apache.ignite.compute.gridify.aop.aspectjIgnite
GridifySetToValueSpringAspectSpring aspect that cross-cuts on all methods grid-enabled with GridifySetToValue annotation and potentially executes them onClassorg.apache.ignite.compute.gridify.aop.springIgnite
GridifySpringAspectSpring aspect that cross-cuts on all methods grid-enabled with Gridify annotation and potentially executes them onClassorg.apache.ignite.compute.gridify.aop.springIgnite
GridifySpringEnhancerSpring AOP enhancer.Classorg.apache.ignite.compute.gridify.aop.springIgnite
GridifySpringPointcutPointcut used by gridified aspects to find methods annotated with Gridify, GridifySetToValue andClassorg.apache.ignite.compute.gridify.aop.springIgnite
GridifyTaskAdapterConvenience adapter for tasks that work with Gridify annotation for grid-enabling methods.Classorg.apache.ignite.compute.gridifyIgnite
GridifyTaskSplitAdapterConvenience adapter for tasks that work with Gridify annotation for grid-enabling methods.Classorg.apache.ignite.compute.gridifyIgnite
GridSecurityCredentialsSecurity credentials used for client or node authentication.Classorg.apache.ignite.plugin.securityIgnite
GridSecurityCredentialsBasicProviderBasic implementation for GridSecurityCredentialsProvider.Classorg.apache.ignite.plugin.securityIgnite
GridSecurityCredentialsProviderSecurity credentials provider for specifying security credentials.Interfaceorg.apache.ignite.plugin.securityIgnite
GridSecurityExceptionCommon security exception for the grid.Classorg.apache.ignite.plugin.securityIgnite
GridSecurityPermissionenum GridSecurityPermissionSupported security permissions within grid.Classorg.apache.ignite.plugin.securityIgnite
GridSecurityPermissionSetSecurity permission set for authorized security subjects.Interfaceorg.apache.ignite.plugin.securityIgnite
GridSecuritySubjectSecurity subject representing authenticated node or client with a set of permissions.Interfaceorg.apache.ignite.plugin.securityIgnite
GridSecuritySubjectTypeenum GridSecuritySubjectTypeSupported security subject types.Classorg.apache.ignite.plugin.securityIgnite
GridSegmentationPolicyenum GridSegmentationPolicyPolicy that defines how node will react on topology segmentation.Classorg.apache.ignite.plugin.segmentationIgnite
GridSegmentationResolverThis is interface for segmentation (a.Interfaceorg.apache.ignite.plugin.segmentationIgnite
GridSlf4jLoggerSLF4J-based implementation for logging.Classorg.apache.ignite.logger.slf4jIgnite
H2DialectA dialect compatible with the H2 database.Classorg.apache.ignite.cache.store.jdbc.dialectIgnite
HadoopConfigurationIgnite Hadoop Accelerator configuration.Classorg.apache.ignite.configurationIgnite
IgfsBlockLocationIGFS file's data block location in the grid.Interfaceorg.apache.ignite.igfsIgnite
IgfsByteDelimiterRecordResolverRecord resolver which adjusts records based on provided delimiters.Classorg.apache.ignite.igfs.mapreduce.recordsIgnite
IgfsConcurrentModificationExceptionIGFS exception indicating that file system structure was modified concurrently.Classorg.apache.ignite.igfsIgnite
IgfsCorruptedFileExceptionException thrown when target file's block is not found in data cache.Classorg.apache.ignite.igfsIgnite
IgfsDirectoryNotEmptyExceptionException indicating that directory can not be deleted because it is not empty.Classorg.apache.ignite.igfsIgnite
IgfsEvent Grid events are used for notification about what happens within the grid.Classorg.apache.ignite.eventsIgnite
IgfsEvictionFilterIGFS eviction filter which will not evict blocks of particular files.Classorg.apache.ignite.cache.eviction.igfsIgnite
IgfsExceptionIGFS exception thrown by file system components.Classorg.apache.ignite.igfsIgnite
IgfsFileIGFS file or directory descriptor.Interfaceorg.apache.ignite.igfsIgnite
IgfsFileRangeEntity representing part of IGFS file identified by file path, start position, and length.Classorg.apache.ignite.igfs.mapreduceIgnite
IgfsFixedLengthRecordResolverRecord resolver which adjusts records to fixed length.Classorg.apache.ignite.igfs.mapreduce.recordsIgnite
IgfsGroupDataBlocksKeyMapperIGFS class providing ability to group file's data blocks together on one node.Classorg.apache.ignite.igfsIgnite
IgfsInputStreamIGFS input stream to read data from the file system.Classorg.apache.ignite.igfsIgnite
IgfsInputStreamJobAdapterConvenient IgfsJob adapter.Classorg.apache.ignite.igfs.mapreduceIgnite
IgfsInvalidHdfsVersionExceptionException thrown when Ignite detects that remote HDFS version differs from version of HDFS libraries in Ignite classpath.Classorg.apache.ignite.igfsIgnite
IgfsInvalidPathExceptionIGFS exception indicating that operation target is invalid (e.Classorg.apache.ignite.igfsIgnite
IgfsIpcEndpointConfigurationIGFS IPC endpoint configuration.Classorg.apache.ignite.igfsIgnite
IgfsIpcEndpointTypeenum IgfsIpcEndpointTypeEnum Constant SummaryClassorg.apache.ignite.igfsIgnite
IgfsJobDefines executable unit for IgfsTask.Interfaceorg.apache.ignite.igfs.mapreduceIgnite
IgfsJobAdapterAdapter for IgfsJob with no-op implementation of cancel() method.Classorg.apache.ignite.igfs.mapreduceIgnite
IgfsMetricsIGFS metrics snapshot for the file system.Interfaceorg.apache.ignite.igfsIgnite
IgfsModeIGFS mode defining interactions with underlying secondary Hadoop file system.Classorg.apache.ignite.igfsIgnite
IgfsNewLineRecordResolverRecord resolver based on new line detection.Classorg.apache.ignite.igfs.mapreduce.recordsIgnite
IgfsOutOfSpaceExceptionIGFS exception that is thrown when it detected out-of-space condition.Classorg.apache.ignite.igfsIgnite
IgfsOutputStreamIGFS output stream to write data into the file system.Classorg.apache.ignite.igfsIgnite
IgfsParentNotDirectoryExceptionException thrown when parent supposed to be a directory is a file.Classorg.apache.ignite.igfsIgnite
IgfsPathIGFS path to file in the file system.Classorg.apache.ignite.igfsIgnite
IgfsPathAlreadyExistsExceptionException thrown when target path supposed to be created already exists.Classorg.apache.ignite.igfsIgnite
IgfsPathIsDirectoryExceptionException indicating that path is directory, while it is expected to be a file.Classorg.apache.ignite.igfsIgnite
IgfsPathIsNotDirectoryExceptionException indicating that path is not directory.Classorg.apache.ignite.igfsIgnite
IgfsPathNotFoundExceptionIGFS exception indicating that target resource is not found.Classorg.apache.ignite.igfsIgnite
IgfsPathSummaryPath summary: total files count, total directories count, total length.Classorg.apache.ignite.igfsIgnite
IgfsPerBlockLruEvictionPolicyIGFS eviction policy which evicts particular blocks.Classorg.apache.ignite.cache.eviction.igfsIgnite
IgfsPerBlockLruEvictionPolicyMXBeanMBean for IGFS per-block LRU eviction policy.Interfaceorg.apache.ignite.cache.eviction.igfsIgnite
IgfsRangeInputStreamDecorator for regular IgfsInputStream which streams only data within the given range.Classorg.apache.ignite.igfs.mapreduceIgnite
IgfsRecordResolverIGFS record resolver.Interfaceorg.apache.ignite.igfs.mapreduceIgnite
IgfsSecondaryFileSystemSecondary file system interface.Interfaceorg.apache.ignite.igfs.secondaryIgnite
IgfsSecondaryFileSystemPositionedReadableThe simplest data input interface to read from secondary file system.Interfaceorg.apache.ignite.igfs.secondaryIgnite
IgfsStringDelimiterRecordResolverRecord resolver based on delimiters represented as strings.Classorg.apache.ignite.igfs.mapreduce.recordsIgnite
IgfsTaskIGFS task which can be executed on the grid using one of IgniteFs.Classorg.apache.ignite.igfs.mapreduceIgnite
IgfsTaskArgsIGFS task arguments.Interfaceorg.apache.ignite.igfs.mapreduceIgnite
IgfsTaskNoReduceAdapterConvenient IgfsTask adapter with empty reduce step.Classorg.apache.ignite.igfs.mapreduceIgnite
IgniteMain entry-point for all Ignite APIs.Classorg.apache.igniteIgnite
IgniteAsyncSupportAllows to enable asynchronous mode on Ignite APIs.Interfaceorg.apache.ignite.langIgnite
IgniteAsyncSupportedAnnotation to indicate that method can be executed asynchronously if async mode is enabled.Classorg.apache.ignite.langIgnite
IgniteAtomicLongThis interface provides a rich API for working with distributedly cached atomic long value.Interfaceorg.apache.igniteIgnite
IgniteAtomicReferenceThis interface provides a rich API for working with distributed atomic reference.Interfaceorg.apache.igniteIgnite
IgniteAtomicSequenceThis interface provides a rich API for working with distributed atomic sequence.Interfaceorg.apache.igniteIgnite
IgniteAtomicStampedThis interface provides a rich API for working with distributed atomic stamped value.Interfaceorg.apache.igniteIgnite
IgniteAuthenticationExceptionException that represents authentication failure.Classorg.apache.igniteIgnite
IgniteBiClosureDefines generic closure with two parameters.Interfaceorg.apache.ignite.langIgnite
IgniteBiInClosureClosure with two in-parameters and void return type.Interfaceorg.apache.ignite.langIgnite
IgniteBiPredicateDefines a predicate which accepts two parameters and returns true or false.Interfaceorg.apache.ignite.langIgnite
IgniteBiTupleConvenience class representing mutable tuple of two values.Classorg.apache.ignite.langIgnite
IgniteCacheMain entry point for all Data Grid APIs.Interfaceorg.apache.igniteIgnite
IgniteCallableGrid-aware adapter for Callable implementations.Interfaceorg.apache.ignite.langIgnite
IgniteCheckedExceptionGeneral grid exception.Classorg.apache.igniteIgnite
IgniteClosureDefines generic closure with one parameter.Interfaceorg.apache.ignite.langIgnite
IgniteClusterRepresents whole cluster (all available nodes) and also provides a handle on nodeLocalMap() which provides map-like functionality linked to current grid node.Interfaceorg.apache.igniteIgnite
IgniteComputeDefines compute grid functionality for executing tasks and closures over nodes in the ClusterGroup.Interfaceorg.apache.igniteIgnite
IgniteConfigurationThis class defines grid runtime configuration.Classorg.apache.ignite.configurationIgnite
IgniteCountDownLatchThis interface provides a rich API for working with distributed count down latch.Interfaceorg.apache.igniteIgnite
IgniteDataStreamerData streamer is responsible for streaming external data into cache.Interfaceorg.apache.igniteIgnite
IgniteDeploymentExceptionDeployment or re-deployment failed.Classorg.apache.igniteIgnite
IgniteEventsProvides functionality for local and remote event notifications on nodes defined by clusterGroup().Interfaceorg.apache.igniteIgnite
IgniteExceptionGeneral grid exception.Classorg.apache.igniteIgnite
IgniteFileSystemIGnite File System API.Interfaceorg.apache.igniteIgnite
IgniteFutureFuture with simplified exception handling, functional programming support and ability to listen for future completion via functional callback.Interfaceorg.apache.ignite.langIgnite
IgniteFutureCancelledExceptionFuture computation cannot be retrieved because it was cancelled.Classorg.apache.ignite.langIgnite
IgniteFutureTimeoutExceptionFuture computation completion is timed out.Classorg.apache.ignite.langIgnite
IgniteHadoopClientProtocolProviderIgnite Hadoop client protocol provider.Classorg.apache.ignite.hadoop.mapreduceIgnite
IgniteHadoopFileSystemIGFS Hadoop 1.Classorg.apache.ignite.hadoop.fs.v1Ignite
IgniteHadoopFileSystemIGFS Hadoop 2.Classorg.apache.ignite.hadoop.fs.v2Ignite
IgniteHadoopFileSystemCounterWriterStatistic writer implementation that writes info into any Hadoop file system.Classorg.apache.ignite.hadoop.fsIgnite
IgniteHadoopIgfsSecondaryFileSystemAdapter to use any Hadoop file system FileSystem as IgfsSecondaryFileSystem.Classorg.apache.ignite.hadoop.fsIgnite
IgniteHadoopMapReducePlannerDefault map-reduce planner implementation.Classorg.apache.ignite.hadoop.mapreduceIgnite
IgniteIllegalStateExceptionThis exception indicates the ignite access in invalid state.Classorg.apache.igniteIgnite
IgniteImmutableImmutable types should be annotated with this annotation to avoid unnecessary copying (e.Classorg.apache.ignite.langIgnite
IgniteInClosureClosure with one in-parameter and void return type.Interfaceorg.apache.ignite.langIgnite
IgniteInstanceResourceAnnotates a field or a setter method for injection of current Ignite instance.Classorg.apache.ignite.resourcesIgnite
IgniteInterruptedExceptionThis exception is used to wrap standard InterruptedException into IgniteException.Classorg.apache.igniteIgnite
IgniteJclLoggerThis logger wraps any JCL (Jakarta Commons Logging) loggers.Classorg.apache.ignite.logger.jclIgnite
IgniteJdbcDriverJDBC driver implementation for In-Memory Data Grid.Classorg.apache.igniteIgnite
IgniteLoggerThis interface defines basic logging functionality used throughout the system.Interfaceorg.apache.igniteIgnite
IgniteMessagingProvides functionality for topic-based message exchange among nodes defined by clusterGroup().Interfaceorg.apache.igniteIgnite
IgniteMXBeanThis interface defines JMX view on kernal.Interfaceorg.apache.ignite.mxbeanIgnite
IgniteNotPeerDeployableThis annotations should be used to mark any type that should not be peer deployable.Classorg.apache.ignite.langIgnite
IgniteOutClosureClosure that does not take any parameters and returns a value.Interfaceorg.apache.ignite.langIgnite
IgnitePluginMarker interface for all Ignite plugins.Interfaceorg.apache.ignite.pluginIgnite
IgnitePortProtocolenum IgnitePortProtocolProtocols supported by port processor.Classorg.apache.ignite.spiIgnite
IgnitePredicateDefines a predicate which accepts a parameter and returns true or false.Interfaceorg.apache.ignite.langIgnite
IgniteProductVersionRepresents node version.Classorg.apache.ignite.langIgnite
IgniteQueueThis interface provides a rich API for working with distributed queues based on In-Memory Data Grid.Interfaceorg.apache.igniteIgnite
IgniteReducerDefines generic reducer that collects multiple values and reduces them into one.Interfaceorg.apache.ignite.langIgnite
IgniteReflectionFactoryConvenience class for reflection-based object creation.Classorg.apache.ignite.configurationIgnite
IgniteRunnableGrid-aware adapter for Runnable implementations.Interfaceorg.apache.ignite.langIgnite
IgniteSchedulerProvides functionality for scheduling jobs locally using UNIX cron-based syntax.Interfaceorg.apache.igniteIgnite
IgniteServicesDefines functionality necessary to deploy distributed services on the grid.Interfaceorg.apache.igniteIgnite
IgniteSetSet implementation based on on In-Memory Data Grid.Interfaceorg.apache.igniteIgnite
IgniteSpiThis interface defines life-cycle of SPI implementation.Interfaceorg.apache.ignite.spiIgnite
IgniteSpiAdapterThis class provides convenient adapter for SPI implementations.Classorg.apache.ignite.spiIgnite
IgniteSpiCloseableIteratorInterfaceorg.apache.ignite.spiIgnite
IgniteSpiConfigurationAnnotates SPI configuration setters on whether or not it is optional.Classorg.apache.ignite.spiIgnite
IgniteSpiConsistencyCheckedSPIs that have this annotation present will be checked for consistency within grid.Classorg.apache.ignite.spiIgnite
IgniteSpiContextSPI context provides common functionality for all SPI implementations.Interfaceorg.apache.ignite.spiIgnite
IgniteSpiExceptionException thrown by SPI implementations.Classorg.apache.ignite.spiIgnite
IgniteSpiManagementMBeanThis interface defines basic MBean for all SPI implementations.Interfaceorg.apache.ignite.spiIgnite
IgniteSpiMultiExceptionGrid SPI exception which may contain more than one failure.Classorg.apache.ignite.spiIgnite
IgniteSpiMultipleInstancesSupportAnnotates whether or not multiple instances of this SPI can be started in the same VM.Classorg.apache.ignite.spiIgnite
IgniteSpiNodeValidationResultResult of joining node validation.Classorg.apache.ignite.spiIgnite
IgniteSpiNoopAnnotates NO-OP SPI implementations.Classorg.apache.ignite.spiIgnite
IgniteSpiThreadThis class provides convenient adapter for threads used by SPIs.Classorg.apache.ignite.spiIgnite
IgniteSpiThreadFactoryThis class provides implementation of ThreadFactory factory for creating grid SPI threads.Classorg.apache.ignite.spiIgnite
IgniteSpiVersionCheckExceptionGrid SPI exception for version check failure.Classorg.apache.ignite.spiIgnite
IgniteSpringFactory methods to start Ignite with optional Spring application context, this context can be injected into grid tasks and grid jobs using @IgniteSpringApplicationContextResourceClassorg.apache.igniteIgnite
IgniteSpringBeanGrid Spring bean allows to bypass Ignition methods.Classorg.apache.igniteIgnite
IgniteStatePossible states of Ignition.Classorg.apache.igniteIgnite
IgniteStripedThreadPoolExecutorAn ExecutorService that executes submitted tasks using pooled grid threads.Classorg.apache.ignite.threadIgnite
IgniteSystemPropertiesContains constants for all system properties and environmental variables in Ignite.Classorg.apache.igniteIgnite
IgniteThreadThis class adds some necessary plumbing on top of the Thread class.Classorg.apache.ignite.threadIgnite
IgniteThreadFactoryThis class provides implementation of ThreadFactory factory for creating grid threads.Classorg.apache.ignite.threadIgnite
IgniteThreadPoolExecutorAn ExecutorService that executes submitted tasks using pooled grid threads.Classorg.apache.ignite.threadIgnite
IgniteTransactionsTransactions facade provides ACID-compliant semantic when working with caches.Interfaceorg.apache.igniteIgnite
IgniteUuidThis is a faster performing version of UUID.Classorg.apache.ignite.langIgnite
IgnitionThis class defines a factory for the main Ignite API.Classorg.apache.igniteIgnite
IgnitionListenerListener for gird state change notifications.Interfaceorg.apache.igniteIgnite
IgnitionMXBeanThis interface defines JMX view on Ignition.Interfaceorg.apache.ignite.mxbeanIgnite
IgnoreIfPeerClassLoadingDisabledThis annotation is for all implementations of DeploymentSpi that may be ignored if peer class loading is disabled.Classorg.apache.ignite.spi.deploymentIgnite
IndexingQueryFilterInterfaceorg.apache.ignite.spi.indexingIgnite
IndexingSpiIndexing SPI allows user to index cache content.Interfaceorg.apache.ignite.spi.indexingIgnite
JavaLoggerLogger to use with Java logging.Classorg.apache.ignite.logger.javaIgnite
JavaLoggerFileHandlerFile logging handler which skips all the messages until node ID is set.Classorg.apache.ignite.logger.javaIgnite
JavaLoggerFormatterFormatter for JUL logger.Classorg.apache.ignite.logger.javaIgnite
JdbcCheckpointSpiThis class defines JDBC checkpoint SPI implementation.Classorg.apache.ignite.spi.checkpoint.jdbcIgnite
JdbcCheckpointSpiMBeanManagement bean that provides general administrative and configuration information about jdbc checkpoint SPI.Interfaceorg.apache.ignite.spi.checkpoint.jdbcIgnite
JdbcDialectRepresents a dialect of SQL implemented by a particular RDBMS.Interfaceorg.apache.ignite.cache.store.jdbc.dialectIgnite
JdkMarshaller This marshaller has no mandatory configuration parameters.Classorg.apache.ignite.marshaller.jdkIgnite
JobContextResourceAnnotates a field or a setter method for injection of ComputeJobContext instance.Classorg.apache.ignite.resourcesIgnite
JobEvent Grid events are used for notification about what happens within the grid.Classorg.apache.ignite.eventsIgnite
JobStealingCollisionSpiCollision SPI that supports job stealing from over-utilized nodes to under-utilized nodes.Classorg.apache.ignite.spi.collision.jobstealingIgnite
JobStealingCollisionSpiMBeanManagement MBean for job stealing based collision SPI.Interfaceorg.apache.ignite.spi.collision.jobstealingIgnite
JobStealingDisabledThis annotation disables job stealing if corresponding feature is configured.Classorg.apache.ignite.spi.collision.jobstealingIgnite
JobStealingFailoverSpiJob stealing failover SPI needs to always be used in conjunction with JobStealingCollisionSpi SPI.Classorg.apache.ignite.spi.failover.jobstealingIgnite
JobStealingFailoverSpiMBeanManagement bean for JobStealingFailoverSpi.Interfaceorg.apache.ignite.spi.failover.jobstealingIgnite
JobStealingRequestJob stealing request.Classorg.apache.ignite.spi.collision.jobstealingIgnite
LifecycleAwareAll components provided in Ignite configuration can implement this interface.Interfaceorg.apache.ignite.lifecycleIgnite
LifecycleBeanA bean that reacts to node lifecycle events defined in LifecycleEventType.Interfaceorg.apache.ignite.lifecycleIgnite
LifecycleEventTypeenum LifecycleEventTypeNode lifecycle event types.Classorg.apache.ignite.lifecycleIgnite
LoadBalancerResourceAnnotates a field or a setter method for injection of ComputeLoadBalancer.Classorg.apache.ignite.resourcesIgnite
LoadBalancingSpiLoad balancing SPI provides the next best balanced node for job execution.Interfaceorg.apache.ignite.spi.loadbalancingIgnite
LocalDeploymentSpiLocal deployment SPI that implements only within VM deployment on local node via register(ClassLoader, Class) method.Classorg.apache.ignite.spi.deployment.localIgnite
LocalDeploymentSpiMBeanManagement MBean for LocalDeploymentSpi SPI.Interfaceorg.apache.ignite.spi.deployment.localIgnite
Log4JDailyRollingFileAppenderLog4J DailyRollingFileAppender with added support for grid node IDs.Classorg.apache.ignite.logger.log4jIgnite
Log4JExternallyRolledFileAppenderLog4J ExternallyRolledFileAppender with added support for grid node IDs.Classorg.apache.ignite.logger.log4jIgnite
Log4JFileAppenderLog4J FileAppender with added support for grid node IDs.Classorg.apache.ignite.logger.log4jIgnite
Log4JLoggerLog4j-based implementation for logging.Classorg.apache.ignite.logger.log4jIgnite
Log4jRollingFileAppenderLog4J RollingFileAppender with added support for grid node IDs.Classorg.apache.ignite.logger.log4jIgnite
LoggerNodeIdAwareInterface for Ignite file appenders to attach node ID to log file names.Interfaceorg.apache.ignite.loggerIgnite
LoggerResourceAnnotates a field or a setter method for injection of IgniteLogger.Classorg.apache.ignite.resourcesIgnite
LruEvictionPolicyEviction policy based on Least Recently Used (LRU) algorithm.Classorg.apache.ignite.cache.eviction.lruIgnite
LruEvictionPolicyMBeanMBean for LRU eviction policy.Interfaceorg.apache.ignite.cache.eviction.lruIgnite
MarshallerGridMarshaller allows to marshal or unmarshal objects in grid.Interfaceorg.apache.ignite.marshallerIgnite
MarshallerContextInterfaceorg.apache.ignite.marshallerIgnite
MarshallerExclusionsControls what classes should be excluded from marshalling by default.Classorg.apache.ignite.marshallerIgnite
MBeanServerResourceAnnotates a field or a setter method for injection of MBeanServer resource.Classorg.apache.ignite.resourcesIgnite
MemoryEventStorageSpiIn-memory EventStorageSpi implementation.Classorg.apache.ignite.spi.eventstorage.memoryIgnite
MemoryEventStorageSpiMBeanManagement bean for MemoryEventStorageSpi.Interfaceorg.apache.ignite.spi.eventstorage.memoryIgnite
MessageBase class for all communication messages.Interfaceorg.apache.ignite.plugin.extensions.communicationIgnite
MessageCollectionItemTypeenum MessageCollectionItemTypeEnum representing possible types of collection items.Classorg.apache.ignite.plugin.extensions.communicationIgnite
MessageFactoryFactory for communication messages.Interfaceorg.apache.ignite.plugin.extensions.communicationIgnite
MessageFormatterProvides a custom format for communication messages.Interfaceorg.apache.ignite.plugin.extensions.communicationIgnite
MessageReaderCommunication message reader.Interfaceorg.apache.ignite.plugin.extensions.communicationIgnite
MessageWriterCommunication message writer.Interfaceorg.apache.ignite.plugin.extensions.communicationIgnite
MessagingListenActorConvenience actor-base adapter for IgniteMessaging.Classorg.apache.ignite.messagingIgnite
MXBeanDescriptionProvides description for MBean classes and methods.Classorg.apache.ignite.mxbeanIgnite
MXBeanParametersDescriptionsProvides MBean method parameters description.Classorg.apache.ignite.mxbeanIgnite
MXBeanParametersNamesProvides MBean method parameters names.Classorg.apache.ignite.mxbeanIgnite
MySQLDialectA dialect compatible with the MySQL database.Classorg.apache.ignite.cache.store.jdbc.dialectIgnite
NearCacheConfigurationClient cache configuration.Classorg.apache.ignite.configurationIgnite
NeverFailoverSpiThis class provides failover SPI implementation that never fails over.Classorg.apache.ignite.spi.failover.neverIgnite
NeverFailoverSpiMBeanManagement bean for NeverFailoverSpi.Interfaceorg.apache.ignite.spi.failover.neverIgnite
NoopCheckpointSpiNo-op implementation of CheckpointSpi.Classorg.apache.ignite.spi.checkpoint.noopIgnite
NoopCollisionSpiNo-op implementation of CollisionSpi.Classorg.apache.ignite.spi.collision.noopIgnite
NoopIndexingSpiDefault implementation of IndexingSpi which does not index cache.Classorg.apache.ignite.spi.indexing.noopIgnite
NoopSwapSpaceSpiNo-op implementation of SwapSpaceSpi.Classorg.apache.ignite.spi.swapspace.noopIgnite
NullLoggerLogger which does not output anything.Classorg.apache.ignite.loggerIgnite
OptimizedMarshallerOptimized implementation of Marshaller.Classorg.apache.ignite.marshaller.optimizedIgnite
OptimizedMarshallerIdMapperInterfaceorg.apache.ignite.marshaller.optimizedIgnite
OracleDialectA dialect compatible with the Oracle database.Classorg.apache.ignite.cache.store.jdbc.dialectIgnite
PluginConfigurationTODO: Add class description.Interfaceorg.apache.ignite.pluginIgnite
PluginContextTODO: Add class description.Interfaceorg.apache.ignite.pluginIgnite
PluginNotFoundExceptionException thrown if plugin is not found.Classorg.apache.ignite.pluginIgnite
PluginProviderPluggable ignite component.Interfaceorg.apache.ignite.pluginIgnite
PluginValidationExceptionTODO: Add class description.Classorg.apache.ignite.pluginIgnite
PriorityQueueCollisionSpiThis class provides implementation for Collision SPI based on priority queue.Classorg.apache.ignite.spi.collision.priorityqueueIgnite
PriorityQueueCollisionSpiMBeanManagement bean that provides access to the priority queue collision SPI configuration.Interfaceorg.apache.ignite.spi.collision.priorityqueueIgnite
QueryBase class for all Ignite cache queries.Classorg.apache.ignite.cache.queryIgnite
QueryCursorQuery result cursor.Interfaceorg.apache.ignite.cache.queryIgnite
QueryGroupIndexDescribes group index.Classorg.apache.ignite.cache.query.annotationsIgnite
QueryMetricsCache query metrics used to obtain statistics on query.Interfaceorg.apache.ignite.cache.queryIgnite
QuerySqlFieldAnnotates fields for SQL queries.Classorg.apache.ignite.cache.query.annotationsIgnite
QuerySqlFunctionAnnotates public static methods in classes to be used in SQL queries as custom functions.Classorg.apache.ignite.cache.query.annotationsIgnite
QueryTextFieldAnnotation for fields or getters to be indexed for full text search using Lucene.Classorg.apache.ignite.cache.query.annotationsIgnite
RandomEvictionPolicyCache eviction policy which will select random cache entry for eviction if cache size exceeds the getMaxSize() parameter.Classorg.apache.ignite.cache.eviction.randomIgnite
RandomEvictionPolicyMBeanMBean for random eviction policy.Interfaceorg.apache.ignite.cache.eviction.randomIgnite
RendezvousAffinityFunctionAffinity function for partitioned cache based on Highest Random Weight algorithm.Classorg.apache.ignite.cache.affinity.rendezvousIgnite
RoundRobinLoadBalancingSpiThis SPI iterates through nodes in round-robin fashion and pick the next sequential node.Classorg.apache.ignite.spi.loadbalancing.roundrobinIgnite
RoundRobinLoadBalancingSpiMBeanManagement bean for RoundRobinLoadBalancingSpi SPI.Interfaceorg.apache.ignite.spi.loadbalancing.roundrobinIgnite
S3CheckpointSpiThis class defines Amazon S3-based implementation for checkpoint SPI.Classorg.apache.ignite.spi.checkpoint.s3Ignite
S3CheckpointSpiMBeanManagement bean for S3CheckpointSpi.Interfaceorg.apache.ignite.spi.checkpoint.s3Ignite
ScanQueryScan query over cache entries.Classorg.apache.ignite.cache.queryIgnite
SchedulerFutureFuture for cron-based scheduled execution.Interfaceorg.apache.ignite.schedulerIgnite
ServiceAn instance of grid-managed service.Interfaceorg.apache.ignite.servicesIgnite
ServiceConfigurationManaged service configuration.Classorg.apache.ignite.servicesIgnite
ServiceContextService execution context.Interfaceorg.apache.ignite.servicesIgnite
ServiceDescriptorService deployment descriptor.Interfaceorg.apache.ignite.servicesIgnite
ServiceResourceAnnotates a field or a setter method for injection of Ignite service(s) by specified service name.Classorg.apache.ignite.resourcesIgnite
ServletContextListenerStartupThis class defines Ignite startup based on servlet context listener.Classorg.apache.ignite.startup.servletIgnite
ServletStartupThis class defines servlet-based Ignite startup.Classorg.apache.ignite.startup.servletIgnite
SharedFsCheckpointSpiThis class defines shared file system CheckpointSpi implementation for checkpoint SPI.Classorg.apache.ignite.spi.checkpoint.sharedfsIgnite
SharedFsCheckpointSpiMBeanManagement bean that provides general administrative and configuration information about shared file system checkpoints.Interfaceorg.apache.ignite.spi.checkpoint.sharedfsIgnite
SpiQueryQuery to be used by IndexingSpi implementations.Classorg.apache.ignite.cache.queryIgnite
SpringApplicationContextResourceAnnotates a field or a setter method for injection of Spring ApplicationContext resource.Classorg.apache.ignite.resourcesIgnite
SpringCacheManager Spring cache abstraction allows to enable caching for Java methods so that the result of a method execution is stored in some storage.Classorg.apache.ignite.cache.springIgnite
SpringResourceAnnotates a field or a setter method for injection of resource from Spring ApplicationContext.Classorg.apache.ignite.resourcesIgnite
SqlFieldsQuerySee Also:IgniteCache.Classorg.apache.ignite.cache.queryIgnite
SqlQuerySee Also:IgniteCache.Classorg.apache.ignite.cache.queryIgnite
SQLServerDialectA dialect compatible with the Microsoft SQL Server database.Classorg.apache.ignite.cache.store.jdbc.dialectIgnite
StreamReceiverUpdates cache with batch of entries.Interfaceorg.apache.ignite.streamIgnite
StreamTransformerConvenience adapter to transform update existing values in streaming cache based on the previously cached value.Classorg.apache.ignite.streamIgnite
StreamVisitorConvenience adapter to visit every key-value tuple in the stream.Classorg.apache.ignite.streamIgnite
SwapContextContext for swap operations.Classorg.apache.ignite.spi.swapspaceIgnite
SwapKeyUtility wrapper class that represents swap key.Classorg.apache.ignite.spi.swapspaceIgnite
SwapSpaceEventGrid swap space event.Classorg.apache.ignite.eventsIgnite
SwapSpaceSpiProvides a mechanism in grid for storing data on disk.Interfaceorg.apache.ignite.spi.swapspaceIgnite
SwapSpaceSpiListenerSwap space SPI eviction listener.Interfaceorg.apache.ignite.spi.swapspaceIgnite
TaskContinuousMapperResourceAnnotates a field or a setter method for injection of ComputeTaskContinuousMapper resource.Classorg.apache.ignite.resourcesIgnite
TaskEvent Grid events are used for notification about what happens within the grid.Classorg.apache.ignite.eventsIgnite
TaskSessionResourceAnnotates a field or a setter method for injection of ComputeTaskSession resource.Classorg.apache.ignite.resourcesIgnite
TcpClientDiscoverySpiClient discovery SPI implementation that uses TCP/IP for node discovery.Classorg.apache.ignite.spi.discovery.tcpIgnite
TcpClientDiscoverySpiMBeanManagement bean for TcpClientDiscoverySpi.Interfaceorg.apache.ignite.spi.discovery.tcpIgnite
TcpCommunicationSpiGridTcpCommunicationSpi is default communication SPI which uses TCP/IP protocol and Java NIO to communicate with other nodes.Classorg.apache.ignite.spi.communication.tcpIgnite
TcpCommunicationSpiMBeanMBean provide access to TCP-based communication SPI.Interfaceorg.apache.ignite.spi.communication.tcpIgnite
TcpDiscoveryIpFinderIP finder interface for TcpDiscoverySpi.Interfaceorg.apache.ignite.spi.discovery.tcp.ipfinderIgnite
TcpDiscoveryIpFinderAdapterIP finder interface implementation adapter.Classorg.apache.ignite.spi.discovery.tcp.ipfinderIgnite
TcpDiscoveryJdbcIpFinderJDBC-based IP finder.Classorg.apache.ignite.spi.discovery.tcp.ipfinder.jdbcIgnite
TcpDiscoveryMulticastIpFinderMulticast-based IP finder.Classorg.apache.ignite.spi.discovery.tcp.ipfinder.multicastIgnite
TcpDiscoveryS3IpFinderAWS S3-based IP finder.Classorg.apache.ignite.spi.discovery.tcp.ipfinder.s3Ignite
TcpDiscoverySharedFsIpFinderShared filesystem-based IP finder.Classorg.apache.ignite.spi.discovery.tcp.ipfinder.sharedfsIgnite
TcpDiscoverySpiDiscovery SPI implementation that uses TCP/IP for node discovery.Classorg.apache.ignite.spi.discovery.tcpIgnite
TcpDiscoverySpiMBeanManagement bean for TcpDiscoverySpi.Interfaceorg.apache.ignite.spi.discovery.tcpIgnite
TcpDiscoveryVmIpFinderIP Finder which works only with pre-configured list of IP addresses specified via setAddresses(Collection) method.Classorg.apache.ignite.spi.discovery.tcp.ipfinder.vmIgnite
TextQueryQuery for Lucene based fulltext search.Classorg.apache.ignite.cache.queryIgnite
ThreadPoolMXBeanMBean that provides access to information about executor service.Interfaceorg.apache.ignite.mxbeanIgnite
TransactionGrid cache transaction.Interfaceorg.apache.ignite.transactionsIgnite
TransactionConcurrencyenum TransactionConcurrencyTransaction concurrency control.Classorg.apache.ignite.transactionsIgnite
TransactionConfigurationTransactions configuration.Classorg.apache.ignite.configurationIgnite
TransactionHeuristicExceptionException thrown whenever grid transaction enters an unknown state.Classorg.apache.ignite.transactionsIgnite
TransactionIsolationenum TransactionIsolationDefines different cache transaction isolation levels.Classorg.apache.ignite.transactionsIgnite
TransactionMetricsTransaction metrics, shared across all caches.Interfaceorg.apache.ignite.transactionsIgnite
TransactionOptimisticExceptionException thrown whenever grid transactions fail optimistically.Classorg.apache.ignite.transactionsIgnite
TransactionRollbackExceptionException thrown whenever grid transactions has been automatically rolled back.Classorg.apache.ignite.transactionsIgnite
TransactionStateenum TransactionStateCache transaction state.Classorg.apache.ignite.transactionsIgnite
TransactionSynchronizationSynchronization callback for transaction.Interfaceorg.apache.ignite.transactionsIgnite
TransactionTimeoutExceptionException thrown whenever grid transactions time out.Classorg.apache.ignite.transactionsIgnite
UriDeploymentSpi different sources like file system folders, FTP, email and HTTP.Classorg.apache.ignite.spi.deployment.uriIgnite
UriDeploymentSpiMBeanManagement bean for UriDeploymentSpi.Interfaceorg.apache.ignite.spi.deployment.uriIgnite
VisorExtensionPointAbstract base class for Visor plugin extension point.Classorg.apache.ignite.visor.pluginIgnite
VisorPluggableTabAbstract base class for Visor pluggable tabs.Classorg.apache.ignite.visor.pluginIgnite
VisorPluginBase class for Visor plugins.Classorg.apache.ignite.visor.pluginIgnite
VisorPluginComponentBase interface for Visor components.Interfaceorg.apache.ignite.visor.pluginIgnite
VisorPluginComponentsFactoryFactory for creating ready Visor UI blocks like nodes panel, log panel, etc.Interfaceorg.apache.ignite.visor.pluginIgnite
VisorPluginLogPanelStandard Visor panel with log entries.Interfaceorg.apache.ignite.visor.pluginIgnite
VisorPluginModelGateway to Visor functionality from plugins.Interfaceorg.apache.ignite.visor.pluginIgnite
VisorPluginNodesPanelStandart Visor panel with nodes.Interfaceorg.apache.ignite.visor.pluginIgnite
VisorSelectionListenerThe listener interface for receiving "selection" events from standard Visor panels.Interfaceorg.apache.ignite.visor.pluginIgnite
VisorTopologyListenerListener for grid node topology changes.Interfaceorg.apache.ignite.visor.pluginIgnite
WebSessionFilterFilter for web sessions caching.Classorg.apache.ignite.cache.websessionIgnite
WeightedRandomLoadBalancingSpiLoad balancing SPI that picks a random node for job execution.Classorg.apache.ignite.spi.loadbalancing.weightedrandomIgnite
WeightedRandomLoadBalancingSpiMBeanManagement MBean for WeightedRandomLoadBalancingSpi SPI.Interfaceorg.apache.ignite.spi.loadbalancing.weightedrandomIgnite