- cache - Variable in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyAdapter
-
- cache - Variable in class org.apache.ignite.cache.hibernate.HibernateRegion
-
Cache instance.
- cache(String) - Method in interface org.apache.ignite.Ignite
-
- cache(String) - Method in class org.apache.ignite.IgniteSpringBean
-
- CacheAbstractJdbcStore<K,V> - Class in org.apache.ignite.cache.store.jdbc
-
- CacheAbstractJdbcStore() - Constructor for class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
-
- CacheAbstractJdbcStore.EntryMapping - Class in org.apache.ignite.cache.store.jdbc
-
Entry mapping description.
- CacheAbstractJdbcStore.EntryMapping(String, JdbcDialect, JdbcType, CacheAbstractJdbcStore.TypeKind, CacheAbstractJdbcStore.TypeKind) - Constructor for class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore.EntryMapping
-
- CacheAbstractJdbcStore.TypeKind - Enum in org.apache.ignite.cache.store.jdbc
-
Type kind.
- CacheAtomicityMode - Enum in org.apache.ignite.cache
-
Cache atomicity mode controls whether cache should maintain fully transactional semantics
or more light-weight atomic behavior.
- CacheAtomicUpdateTimeoutException - Exception in org.apache.ignite.cache
-
Exception thrown when atomic operation timeout occurs.
- CacheAtomicUpdateTimeoutException(String) - Constructor for exception org.apache.ignite.cache.CacheAtomicUpdateTimeoutException
-
Creates new timeout exception with given error message.
- CacheAtomicUpdateTimeoutException(String, Throwable) - Constructor for exception org.apache.ignite.cache.CacheAtomicUpdateTimeoutException
-
Creates new timeout exception with given error message and optional nested exception.
- CacheAtomicWriteOrderMode - Enum in org.apache.ignite.cache
-
Cache write ordering mode.
- CacheCheckpointSpi - Class in org.apache.ignite.spi.checkpoint.cache
-
This class defines cache-based implementation for checkpoint SPI.
- CacheCheckpointSpi() - Constructor for class org.apache.ignite.spi.checkpoint.cache.CacheCheckpointSpi
-
- CacheCheckpointSpiMBean - Interface in org.apache.ignite.spi.checkpoint.cache
-
Management bean that provides general administrative and configuration information
about cache checkpoint SPI.
- CacheConfiguration<K,V> - Class in org.apache.ignite.configuration
-
This class defines grid cache configuration.
- CacheConfiguration() - Constructor for class org.apache.ignite.configuration.CacheConfiguration
-
Empty constructor (all values are initialized to their defaults).
- CacheConfiguration(String) - Constructor for class org.apache.ignite.configuration.CacheConfiguration
-
- CacheConfiguration(CompleteConfiguration<K, V>) - Constructor for class org.apache.ignite.configuration.CacheConfiguration
-
Copy constructor.
- cacheConfiguration() - Method in interface org.apache.ignite.plugin.CachePluginContext
-
- CacheConfiguration.IgniteAllNodesPredicate - Class in org.apache.ignite.configuration
-
Filter that accepts all nodes.
- CacheConfiguration.IgniteAllNodesPredicate() - Constructor for class org.apache.ignite.configuration.CacheConfiguration.IgniteAllNodesPredicate
-
- CacheEntry<K,V> - Interface in org.apache.ignite.cache
-
Cache entry that extends Cache.Entry by providing additional entry related information.
- CacheEntryEventSerializableFilter<K,V> - Interface in org.apache.ignite.cache
-
This filter adds
Serializable interface to
CacheEntryEventFilter object.
- CacheEntryProcessor<K,V,T> - Interface in org.apache.ignite.cache
-
This processor adds
Serializable interface to
EntryProcessor object.
- CacheEvent - Class in org.apache.ignite.events
-
In-memory database (cache) event.
- CacheEvent(String, ClusterNode, ClusterNode, String, int, int, boolean, Object, IgniteUuid, Object, Object, boolean, Object, boolean, UUID, String, String) - Constructor for class org.apache.ignite.events.CacheEvent
-
Constructs cache event.
- CacheExistsException - Exception in org.apache.ignite.cache
-
Exception thrown when cache must be created but it already exists.
- CacheExistsException(String) - Constructor for exception org.apache.ignite.cache.CacheExistsException
-
- CacheExistsException(Throwable) - Constructor for exception org.apache.ignite.cache.CacheExistsException
-
- CacheExistsException(String, Throwable) - Constructor for exception org.apache.ignite.cache.CacheExistsException
-
- CacheHibernateBlobStore<K,V> - Class in org.apache.ignite.cache.store.hibernate
-
- CacheHibernateBlobStore() - Constructor for class org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStore
-
- CacheHibernateBlobStoreEntry - Class in org.apache.ignite.cache.store.hibernate
-
- CacheHibernateBlobStoreFactory<K,V> - Class in org.apache.ignite.cache.store.hibernate
-
- CacheHibernateBlobStoreFactory() - Constructor for class org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStoreFactory
-
- CacheHibernateStoreSessionListener - Class in org.apache.ignite.cache.store.hibernate
-
Hibernate-based cache store session listener.
- CacheHibernateStoreSessionListener() - Constructor for class org.apache.ignite.cache.store.hibernate.CacheHibernateStoreSessionListener
-
- CacheInterceptor<K,V> - Interface in org.apache.ignite.cache
-
Cache interceptor.
- CacheInterceptorAdapter<K,V> - Class in org.apache.ignite.cache
-
Cache interceptor convenience adapter.
- CacheInterceptorAdapter() - Constructor for class org.apache.ignite.cache.CacheInterceptorAdapter
-
- CacheJdbcBlobStore<K,V> - Class in org.apache.ignite.cache.store.jdbc
-
- CacheJdbcBlobStore() - Constructor for class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
-
- CacheJdbcBlobStoreFactory<K,V> - Class in org.apache.ignite.cache.store.jdbc
-
- CacheJdbcBlobStoreFactory() - Constructor for class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStoreFactory
-
- CacheJdbcPojoStore<K,V> - Class in org.apache.ignite.cache.store.jdbc
-
Implementation of
CacheStore backed by JDBC and POJO via reflection.
- CacheJdbcPojoStore() - Constructor for class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStore
-
- CacheJdbcPojoStoreFactory<K,V> - Class in org.apache.ignite.cache.store.jdbc
-
- CacheJdbcPojoStoreFactory() - Constructor for class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
-
- CacheJdbcStoreSessionListener - Class in org.apache.ignite.cache.store.jdbc
-
Cache store session listener based on JDBC connection.
- CacheJdbcStoreSessionListener() - Constructor for class org.apache.ignite.cache.store.jdbc.CacheJdbcStoreSessionListener
-
- CacheJndiTmFactory - Class in org.apache.ignite.cache.jta.jndi
-
Implementation of Factory<TransactionManager> interface that is using JNDI names to find TM.
- CacheJndiTmFactory() - Constructor for class org.apache.ignite.cache.jta.jndi.CacheJndiTmFactory
-
Creates uninitialized jndi TM lookup.
- CacheJndiTmFactory(String...) - Constructor for class org.apache.ignite.cache.jta.jndi.CacheJndiTmFactory
-
Creates generic TM lookup with given jndi names.
- CacheJndiTmLookup - Class in org.apache.ignite.cache.jta.jndi
-
Implementation of
CacheTmLookup interface that is using list of JNDI names to find TM.
- CacheJndiTmLookup() - Constructor for class org.apache.ignite.cache.jta.jndi.CacheJndiTmLookup
-
- CacheKeyConfiguration - Class in org.apache.ignite.cache
-
Configuration defining various aspects of cache keys without explicit usage of annotations on user classes.
- CacheKeyConfiguration() - Constructor for class org.apache.ignite.cache.CacheKeyConfiguration
-
Creates an empty cache key configuration that should be populated via setters.
- CacheKeyConfiguration(Class) - Constructor for class org.apache.ignite.cache.CacheKeyConfiguration
-
- CacheKeyConfiguration(String, String) - Constructor for class org.apache.ignite.cache.CacheKeyConfiguration
-
Creates cache key configuration with given type name and affinity field name.
- CacheLoadOnlyStoreAdapter<K,V,I> - Class in org.apache.ignite.cache.store
-
This adapter designed to support stores with bulk loading from stream-like source.
- CacheLoadOnlyStoreAdapter() - Constructor for class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
-
- CacheManager - Class in org.apache.ignite.cache
-
- CacheManager(URI, CachingProvider, ClassLoader, Properties) - Constructor for class org.apache.ignite.cache.CacheManager
-
- cacheMappings - Variable in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
-
Cache with entry mapping description.
- CacheMemoryMode - Enum in org.apache.ignite.cache
-
Defines set of memory modes.
- CacheMetrics - Interface in org.apache.ignite.cache
-
Cache metrics used to obtain statistics on cache itself.
- cacheMetrics() - Method in interface org.apache.ignite.spi.discovery.DiscoveryMetricsProvider
-
Returns metrics data about all caches on local node.
- CacheMetricsMXBean - Interface in org.apache.ignite.mxbean
-
- CacheMode - Enum in org.apache.ignite.cache
-
Enumeration of all supported caching modes.
- cacheName() - Method in interface org.apache.ignite.cache.store.CacheStoreSession
-
Cache name for the current store operation.
- cacheName() - Method in class org.apache.ignite.events.CacheEvent
-
Gets cache name.
- cacheName() - Method in class org.apache.ignite.events.CacheQueryExecutedEvent
-
Gets cache name on which query was executed.
- cacheName() - Method in class org.apache.ignite.events.CacheQueryReadEvent
-
Gets cache name on which query was executed.
- cacheName() - Method in class org.apache.ignite.events.CacheRebalancingEvent
-
Gets cache name.
- cacheName() - Method in interface org.apache.ignite.IgniteDataStreamer
-
Name of cache to stream data to.
- cacheName() - Method in interface org.apache.ignite.services.ServiceContext
-
Gets cache name used for key-to-node affinity calculation.
- cacheName() - Method in interface org.apache.ignite.services.ServiceDescriptor
-
Gets cache name used for key-to-node affinity calculation.
- CacheNameResource - Annotation Type in org.apache.ignite.resources
-
Annotates a field or a setter method for injection of grid cache name.
- cacheNames() - Method in interface org.apache.ignite.Ignite
-
Gets the collection of names of currently available caches.
- cacheNames() - Method in class org.apache.ignite.IgniteSpringBean
-
Gets the collection of names of currently available caches.
- CachePartialUpdateException - Exception in org.apache.ignite.cache
-
Exception thrown from non-transactional cache in case when update succeeded only partially.
- CachePartialUpdateException(CachePartialUpdateCheckedException) - Constructor for exception org.apache.ignite.cache.CachePartialUpdateException
-
- CachePeekMode - Enum in org.apache.ignite.cache
-
Enumeration of all supported cache peek modes.
- cachePermissions() - Method in interface org.apache.ignite.plugin.security.SecurityPermissionSet
-
Map of cache names to cache permissions.
- CachePluginConfiguration<K,V> - Interface in org.apache.ignite.plugin
-
Cache plugin configuration.
- CachePluginContext<C extends CachePluginConfiguration> - Interface in org.apache.ignite.plugin
-
Cache plugin context.
- CachePluginProvider<C extends CachePluginConfiguration> - Interface in org.apache.ignite.plugin
-
- CacheQueryEntryEvent<K,V> - Class in org.apache.ignite.cache.query
-
A Cache continuous query entry event.
- CacheQueryEntryEvent(Cache, EventType) - Constructor for class org.apache.ignite.cache.query.CacheQueryEntryEvent
-
Constructs a cache entry event from a given cache as source.
- CacheQueryExecutedEvent<K,V> - Class in org.apache.ignite.events
-
Cache query execution event.
- CacheQueryExecutedEvent(ClusterNode, String, int, String, String, String, String, IgniteBiPredicate<K, V>, CacheEntryEventSerializableFilter<K, V>, Object[], UUID, String) - Constructor for class org.apache.ignite.events.CacheQueryExecutedEvent
-
- CacheQueryReadEvent<K,V> - Class in org.apache.ignite.events
-
Cache query read event.
- CacheQueryReadEvent(ClusterNode, String, int, String, String, String, String, IgniteBiPredicate<K, V>, CacheEntryEventSerializableFilter<K, V>, Object[], UUID, String, K, V, V, Object) - Constructor for class org.apache.ignite.events.CacheQueryReadEvent
-
- CacheRebalanceMode - Enum in org.apache.ignite.cache
-
Cache rebalance mode.
- CacheRebalancingEvent - Class in org.apache.ignite.events
-
In-memory database (cache) rebalancing event.
- CacheRebalancingEvent(String, ClusterNode, String, int, int, ClusterNode, int, long) - Constructor for class org.apache.ignite.events.CacheRebalancingEvent
-
Constructs cache event.
- CacheReflectionTmLookup - Class in org.apache.ignite.cache.jta.reflect
-
Implementation of
CacheTmLookup interface that attempts to obtain
JTA manager by calling static method on the class.
- CacheReflectionTmLookup() - Constructor for class org.apache.ignite.cache.jta.reflect.CacheReflectionTmLookup
-
Creates uninitialized reflection TM lookup.
- CacheReflectionTmLookup(String, String) - Constructor for class org.apache.ignite.cache.jta.reflect.CacheReflectionTmLookup
-
Creates generic TM lookup with given class and method name.
- CacheServerNotFoundException - Exception in org.apache.ignite.cache
-
Exception thrown when all data nodes left the grid.
- CacheServerNotFoundException(String) - Constructor for exception org.apache.ignite.cache.CacheServerNotFoundException
-
- CacheServerNotFoundException(String, Throwable) - Constructor for exception org.apache.ignite.cache.CacheServerNotFoundException
-
- CacheServerNotFoundException(Throwable) - Constructor for exception org.apache.ignite.cache.CacheServerNotFoundException
-
- CacheSpringStoreSessionListener - Class in org.apache.ignite.cache.store.spring
-
Cache store session listener based on Spring transaction management.
- CacheSpringStoreSessionListener() - Constructor for class org.apache.ignite.cache.store.spring.CacheSpringStoreSessionListener
-
- CacheStore<K,V> - Interface in org.apache.ignite.cache.store
-
API for cache persistent storage for read-through and write-through behavior.
- CacheStoreAdapter<K,V> - Class in org.apache.ignite.cache.store
-
Cache storage convenience adapter.
- CacheStoreAdapter() - Constructor for class org.apache.ignite.cache.store.CacheStoreAdapter
-
- CacheStoreSession - Interface in org.apache.ignite.cache.store
-
Session for the cache store operations.
- CacheStoreSessionListener - Interface in org.apache.ignite.cache.store
-
Cache store session listener that allows to implement callbacks
for session lifecycle.
- CacheStoreSessionResource - Annotation Type in org.apache.ignite.resources
-
Annotates a field or a setter method for injection of current
CacheStoreSession
instance.
- CacheTmLookup - Interface in org.apache.ignite.cache.jta
-
Allows grid to use different transactional systems.
- CacheTypeFieldMetadata - Class in org.apache.ignite.cache
-
Type field metadata.
- CacheTypeFieldMetadata() - Constructor for class org.apache.ignite.cache.CacheTypeFieldMetadata
-
Default constructor.
- CacheTypeFieldMetadata(String, int, String, Class<?>) - Constructor for class org.apache.ignite.cache.CacheTypeFieldMetadata
-
Full constructor.
- CacheTypeMetadata - Class in org.apache.ignite.cache
-
- CacheTypeMetadata() - Constructor for class org.apache.ignite.cache.CacheTypeMetadata
-
Deprecated.
Default constructor.
- CacheTypeMetadata(CacheTypeMetadata) - Constructor for class org.apache.ignite.cache.CacheTypeMetadata
-
Deprecated.
Copy constructor.
- CacheWriteSynchronizationMode - Enum in org.apache.ignite.cache
-
Mode indicating how Ignite should wait for write replies from other nodes.
- CachingHadoopFileSystemFactory - Class in org.apache.ignite.hadoop.fs
-
Caching Hadoop file system factory.
- CachingHadoopFileSystemFactory() - Constructor for class org.apache.ignite.hadoop.fs.CachingHadoopFileSystemFactory
-
Public non-arg constructor.
- CachingProvider - Class in org.apache.ignite.cache
-
Implementation of JSR-107 CachingProvider.
- CachingProvider() - Constructor for class org.apache.ignite.cache.CachingProvider
-
- call() - Method in class org.apache.ignite.compute.ComputeJobAdapter
- call(IgniteCallable<R>) - Method in interface org.apache.ignite.IgniteCompute
-
Executes provided job on a node within the underlying cluster group.
- call(Collection<? extends IgniteCallable<R>>) - Method in interface org.apache.ignite.IgniteCompute
-
Executes collection of jobs on nodes within the underlying cluster group.
- call(Collection<? extends IgniteCallable<R1>>, IgniteReducer<R1, R2>) - Method in interface org.apache.ignite.IgniteCompute
-
Executes collection of jobs on nodes within the underlying cluster group.
- callcc() - Method in interface org.apache.ignite.compute.ComputeJobContinuation
-
- callcc() - Method in class org.apache.ignite.compute.ComputeJobContinuationAdapter
-
- callLocal(Callable<R>) - Method in interface org.apache.ignite.IgniteScheduler
-
Executes given callable on internal system thread pool asynchronously.
- CamelStreamer<K,V> - Class in org.apache.ignite.stream.camel
-
This streamer consumes messages from an Apache Camel consumer endpoint and feeds them into an Ignite data streamer.
- CamelStreamer() - Constructor for class org.apache.ignite.stream.camel.CamelStreamer
-
- cancel() - Method in interface org.apache.ignite.compute.ComputeJob
-
This method is called when system detects that completion of this
job can no longer alter the overall outcome (for example, when parent task
has already reduced the results).
- cancel() - Method in class org.apache.ignite.compute.ComputeJobAdapter
-
This method is called when system detects that completion of this
job can no longer alter the overall outcome (for example, when parent task
has already reduced the results).
- cancel() - Method in interface org.apache.ignite.compute.ComputeJobSibling
-
Sends a request to cancel this sibling.
- cancel() - Method in interface org.apache.ignite.igfs.mapreduce.IgfsJob
-
This method is called when system detects that completion of this
job can no longer alter the overall outcome (for example, when parent task
has already reduced the results).
- cancel() - Method in class org.apache.ignite.igfs.mapreduce.IgfsJobAdapter
-
This method is called when system detects that completion of this
job can no longer alter the overall outcome (for example, when parent task
has already reduced the results).
- cancel(String) - Method in interface org.apache.ignite.IgniteServices
-
Cancels service deployment.
- cancel() - Method in interface org.apache.ignite.lang.IgniteFuture
-
Cancels this future.
- cancel(ServiceContext) - Method in interface org.apache.ignite.services.Service
-
Cancels this service.
- cancel() - Method in interface org.apache.ignite.spi.collision.CollisionJobContext
-
Cancels the job.
- cancelAll() - Method in interface org.apache.ignite.IgniteServices
-
Cancels all deployed services.
- capacity() - Method in interface org.apache.ignite.IgniteQueue
-
Gets maximum number of elements of the queue.
- cast(String, IOException) - Static method in class org.apache.ignite.hadoop.fs.IgniteHadoopIgfsSecondaryFileSystem
-
Cast IO exception to IGFS exception.
- centerShow(String, String, String, Date, String) - Static method in class org.apache.ignite.startup.cmdline.AboutDialog
-
Show about dialog.
- cfg - Variable in class org.apache.ignite.hadoop.fs.BasicHadoopFileSystemFactory
-
Configuration of the secondary filesystem, never null.
- CFG_BATCH_SIZE - Static variable in class org.apache.ignite.stream.flume.IgniteSinkConstants
-
Batch size.
- CFG_CACHE_NAME - Static variable in class org.apache.ignite.stream.flume.IgniteSinkConstants
-
Cache name.
- CFG_EVENT_TRANSFORMER - Static variable in class org.apache.ignite.stream.flume.IgniteSinkConstants
-
Event transformer implementation.
- CFG_PATH - Static variable in class org.apache.ignite.stream.flume.IgniteSinkConstants
-
Ignite configuration file path.
- CFG_URL_PREFIX - Static variable in class org.apache.ignite.IgniteJdbcDriver
-
Config URL prefix.
- cfgNodeId - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
- cfgPaths - Variable in class org.apache.ignite.hadoop.fs.BasicHadoopFileSystemFactory
-
File system config paths.
- chain(IgniteClosure<? super IgniteFuture<V>, T>) - Method in interface org.apache.ignite.lang.IgniteFuture
-
Make a chained future to convert result of this future (when complete) into a new format.
- checkConfigurationConsistency0(IgniteSpiContext, ClusterNode, boolean) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Method which is called in the end of checkConfigurationConsistency() method.
- checkConfigurationConsistency0(IgniteSpiContext, ClusterNode, boolean) - Method in class org.apache.ignite.spi.IgniteSpiAdapter
-
Method which is called in the end of checkConfigurationConsistency() method.
- checkFailedError(TcpDiscoveryCheckFailedMessage) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
- checkFailureTimeoutReached(Exception) - Method in class org.apache.ignite.spi.IgniteSpiOperationTimeoutHelper
-
Checks whether the given
Exception is generated because failure detection timeout has been reached.
- checkIsSplitToJobsAllowed(GridifyRangeArgument, GridifySetToSet) - Method in class org.apache.ignite.compute.gridify.aop.GridifySetToSetAbstractAspect
-
Check if split allowed for input argument.
- checkIsSplitToJobsAllowed(GridifyRangeArgument, GridifySetToValue) - Method in class org.apache.ignite.compute.gridify.aop.GridifySetToValueAbstractAspect
-
Check if split allowed for input argument.
- checkMethodSignature(Method) - Method in class org.apache.ignite.compute.gridify.aop.GridifySetToSetAbstractAspect
-
Check method signature.
- checkMethodSignature(Method) - Method in class org.apache.ignite.compute.gridify.aop.GridifySetToValueAbstractAspect
-
Check method signature.
- checkPath(Path) - Method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
- checkPath(Path) - Method in class org.apache.ignite.hadoop.fs.v2.IgniteHadoopFileSystem
- CheckpointEvent - Class in org.apache.ignite.events
-
Grid checkpoint event.
- CheckpointEvent() - Constructor for class org.apache.ignite.events.CheckpointEvent
-
No-arg constructor.
- CheckpointEvent(ClusterNode, String, int, String) - Constructor for class org.apache.ignite.events.CheckpointEvent
-
Creates new checkpoint event with given parameters.
- CheckpointListener - Interface in org.apache.ignite.spi.checkpoint
-
Listener for notifications of checkpoints removed by
CheckpointSpi.
- CheckpointSpi - Interface in org.apache.ignite.spi.checkpoint
-
Checkpoint SPI provides an ability to save an intermediate job state.
- CHK_QRY - Static variable in class org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc.TcpDiscoveryJdbcIpFinder
-
Query to check database validity.
- classLoader() - Method in class org.apache.ignite.compute.gridify.aop.GridifyDefaultRangeTask
-
Gets class loader for the class.
- classLoader() - Method in class org.apache.ignite.compute.gridify.aop.GridifyDefaultTask
-
Gets class loader for the class.
- classLoader() - Method in class org.apache.ignite.spi.swapspace.SwapContext
-
- classLoader(ClassLoader) - Method in class org.apache.ignite.spi.swapspace.SwapContext
-
- classloaders() - Static method in class org.apache.ignite.osgi.IgniteOsgiUtils
-
Returns a
Map of
Ignite instances and the classloaders of the
Bundles they were
started from.
- classLoadingStrategy() - Method in class org.apache.ignite.osgi.IgniteAbstractOsgiContextActivator
-
Override this method to indicate which classloading strategy to use.
- className() - Method in class org.apache.ignite.events.CacheQueryExecutedEvent
-
Gets queried class name.
- className() - Method in class org.apache.ignite.events.CacheQueryReadEvent
-
Gets queried class name.
- classNotFoundException(String) - Method in class org.apache.ignite.osgi.classloaders.BundleDelegatingClassLoader
-
- clause() - Method in class org.apache.ignite.events.CacheQueryExecutedEvent
-
Gets query clause.
- clause() - Method in class org.apache.ignite.events.CacheQueryReadEvent
-
Gets query clause.
- cleanup() - Method in class org.apache.ignite.spi.IgniteSpiThread
-
Should be overridden by child classes if cleanup logic is required.
- clear() - Method in interface org.apache.ignite.IgniteCache
- clear(K) - Method in interface org.apache.ignite.IgniteCache
-
Clear entry from the cache and swap storage, without notifying listeners or
CacheWriters.
- clear() - Method in interface org.apache.ignite.IgniteQueue
- clear(int) - Method in interface org.apache.ignite.IgniteQueue
-
Removes all of the elements from this queue.
- clear() - Method in interface org.apache.ignite.IgniteSet
- clear() - Method in class org.apache.ignite.lang.IgniteBiTuple
- clear() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
- clear(String) - Method in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
-
Entirely clears data space with given name, if any.
- clear(String) - Method in class org.apache.ignite.spi.swapspace.noop.NoopSwapSpaceSpi
-
Entirely clears data space with given name, if any.
- clear(String) - Method in interface org.apache.ignite.spi.swapspace.SwapSpaceSpi
-
Entirely clears data space with given name, if any.
- clearAll(Set<? extends K>) - Method in interface org.apache.ignite.IgniteCache
-
Clear entries from the cache and swap storage, without notifying listeners or
CacheWriters.
- clearAll() - Method in class org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpi
-
Removes all events from the event queue.
- clearAll() - Method in interface org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpiMBean
-
Removes all events from the event queue.
- clearCache() - Static method in class org.apache.ignite.marshaller.MarshallerExclusions
-
Intended for test purposes only.
- clientReconnectFuture() - Method in interface org.apache.ignite.IgniteCluster
-
If local client node disconnected from cluster returns future
that will be completed when client reconnected.
- clientWorkerCount() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
FOR TEST ONLY!!!
- clone() - Method in interface org.apache.ignite.binary.BinaryObject
-
Copies this binary object.
- clone() - Method in class org.apache.ignite.lang.IgniteBiTuple
- clone() - Method in class org.apache.ignite.lang.IgniteUuid
- close() - Method in class org.apache.ignite.cache.CacheManager
- close() - Method in class org.apache.ignite.cache.CachingProvider
- close(ClassLoader) - Method in class org.apache.ignite.cache.CachingProvider
- close(URI, ClassLoader) - Method in class org.apache.ignite.cache.CachingProvider
- close() - Method in interface org.apache.ignite.cache.query.QueryCursor
-
Closes all resources related to this cursor.
- close() - Method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
- close() - Method in class org.apache.ignite.hadoop.fs.v2.IgniteHadoopFileSystem
- close(ClientProtocol) - Method in class org.apache.ignite.hadoop.mapreduce.IgniteHadoopClientProtocolProvider
- close() - Method in class org.apache.ignite.igfs.mapreduce.IgfsRangeInputStream
- close() - Method in interface org.apache.ignite.Ignite
-
Closes this instance of grid.
- close() - Method in interface org.apache.ignite.IgniteAtomicLong
-
Removes this atomic long.
- close() - Method in interface org.apache.ignite.IgniteAtomicReference
-
Removes this atomic reference.
- close() - Method in interface org.apache.ignite.IgniteAtomicSequence
-
Removes this atomic sequence.
- close() - Method in interface org.apache.ignite.IgniteAtomicStamped
-
Removes this atomic stamped.
- close() - Method in interface org.apache.ignite.IgniteCache
-
Closes this cache instance.
- close() - Method in interface org.apache.ignite.IgniteCountDownLatch
-
Removes this count down latch.
- close(boolean) - Method in interface org.apache.ignite.IgniteDataStreamer
-
Streams any remaining data and closes this streamer.
- close() - Method in interface org.apache.ignite.IgniteDataStreamer
-
Closes data streamer.
- close() - Method in interface org.apache.ignite.IgniteQueue
-
Removes this queue.
- close() - Method in interface org.apache.ignite.IgniteSemaphore
-
Removes this semaphore.
- close() - Method in interface org.apache.ignite.IgniteSet
-
Removes this set.
- close() - Method in class org.apache.ignite.IgniteSpringBean
-
Closes this instance of grid.
- close() - Method in class org.apache.ignite.logger.java.JavaLoggerFileHandler
- close() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
-
Closes this IP finder and releases any system resources associated with it.
- close() - Method in interface org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinder
-
Closes this IP finder and releases any system resources associated with it.
- close() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinderAdapter
-
Closes this IP finder and releases any system resources associated with it.
- close() - Method in interface org.apache.ignite.spi.IgniteSpiCloseableIterator
-
Closes the iterator and frees all the resources held by the iterator.
- close() - Method in interface org.apache.ignite.transactions.Transaction
-
Ends the transaction.
- closeConnection(Connection) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
-
Closes connection.
- closureClassName() - Method in class org.apache.ignite.events.CacheEvent
-
Gets closure class name (applicable only for TRANSFORM operations).
- clsLdr - Variable in class org.apache.ignite.osgi.classloaders.BundleDelegatingClassLoader
-
The fallback classloader, expected to be the ignite-core classloader.
- cluster() - Method in interface org.apache.ignite.Ignite
-
- cluster() - Method in class org.apache.ignite.IgniteSpringBean
-
- ClusterGroup - Interface in org.apache.ignite.cluster
-
Defines a cluster group which contains all or a subset of cluster nodes.
- clusterGroup() - Method in interface org.apache.ignite.IgniteCompute
-
Gets cluster group to which this IgniteCompute instance belongs.
- clusterGroup() - Method in interface org.apache.ignite.IgniteEvents
-
Gets cluster group to which this IgniteEvents instance belongs.
- clusterGroup() - Method in interface org.apache.ignite.IgniteMessaging
-
Gets the cluster group to which this GridMessaging instance belongs.
- clusterGroup() - Method in interface org.apache.ignite.IgniteServices
-
Gets the cluster group to which this GridServices instance belongs.
- ClusterGroupEmptyException - Exception in org.apache.ignite.cluster
-
This exception defines illegal call on empty cluster group.
- ClusterGroupEmptyException() - Constructor for exception org.apache.ignite.cluster.ClusterGroupEmptyException
-
Creates new exception with default error message.
- ClusterGroupEmptyException(String) - Constructor for exception org.apache.ignite.cluster.ClusterGroupEmptyException
-
Creates new exception with given error message.
- ClusterGroupEmptyException(String, Throwable) - Constructor for exception org.apache.ignite.cluster.ClusterGroupEmptyException
-
Creates a new exception with given error message and optional nested cause exception.
- ClusterLocalNodeMetricsMXBean - Interface in org.apache.ignite.mxbean
-
MBean for local node metrics.
- ClusterMetrics - Interface in org.apache.ignite.cluster
-
This class represents runtime information on a cluster.
- clusterName() - Method in class org.apache.ignite.mesos.ClusterProperties
-
- clusterName() - Method in class org.apache.ignite.yarn.ClusterProperties
-
- ClusterNode - Interface in org.apache.ignite.cluster
-
Interface representing a single cluster node.
- ClusterProperties - Class in org.apache.ignite.mesos
-
Cluster settings.
- ClusterProperties() - Constructor for class org.apache.ignite.mesos.ClusterProperties
-
- ClusterProperties - Class in org.apache.ignite.yarn
-
Cluster settings.
- ClusterProperties() - Constructor for class org.apache.ignite.yarn.ClusterProperties
-
- ClusterStartNodeResult - Interface in org.apache.ignite.cluster
-
Cluster start node result information.
- ClusterTopologyException - Exception in org.apache.ignite.cluster
-
This exception is used to indicate error with the cluster topology (e.g., crashed node, etc.).
- ClusterTopologyException(String) - Constructor for exception org.apache.ignite.cluster.ClusterTopologyException
-
Creates new topology exception with given error message.
- ClusterTopologyException(String, Throwable) - Constructor for exception org.apache.ignite.cluster.ClusterTopologyException
-
Creates new topology exception with given error message and optional
nested exception.
- collect(E) - Method in interface org.apache.ignite.lang.IgniteReducer
-
Collects given value.
- collect(UUID) - Method in interface org.apache.ignite.spi.discovery.DiscoverySpiDataExchange
-
Collects data from all components.
- collectExchangeData(UUID) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
- CollectionConfiguration - Class in org.apache.ignite.configuration
-
Configuration for Ignite collections.
- CollectionConfiguration() - Constructor for class org.apache.ignite.configuration.CollectionConfiguration
-
- CollisionContext - Interface in org.apache.ignite.spi.collision
-
Context for resolving collisions.
- CollisionExternalListener - Interface in org.apache.ignite.spi.collision
-
Listener to be set on
CollisionSpi for notification of external
collision events (e.g. job stealing).
- CollisionJobContext - Interface in org.apache.ignite.spi.collision
-
This interface defines set of operations that collision SPI implementation can perform on
jobs that are either waiting or executing.
- CollisionSpi - Interface in org.apache.ignite.spi.collision
-
Collision SPI allows to regulate how grid jobs get executed when they arrive on a
destination node for execution.
- collocated() - Method in interface org.apache.ignite.IgniteQueue
-
Returns true if this queue can be kept on the one node only.
- collocated() - Method in interface org.apache.ignite.IgniteSet
-
Returns true if this set can be kept on the one node only.
- colocateFileWrites(boolean) - Method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
-
Public setter that can be used by direct users of FS or Visor.
- colocateFileWrites(boolean) - Method in class org.apache.ignite.hadoop.fs.v2.IgniteHadoopFileSystem
-
Public setter that can be used by direct users of FS or Visor.
- CommandLineRandomNumberGenerator - Class in org.apache.ignite.startup.cmdline
-
Generates a random number and prints it to the console.
- CommandLineRandomNumberGenerator() - Constructor for class org.apache.ignite.startup.cmdline.CommandLineRandomNumberGenerator
-
- CommandLineStartup - Class in org.apache.ignite.startup.cmdline
-
This class defines command-line Ignite startup.
- CommandLineTransformer - Class in org.apache.ignite.startup.cmdline
-
This class is a workaround for a versatile problems with passing arguments to the Ignite Windows batch launcher
scripts.
- commit() - Method in interface org.apache.ignite.transactions.Transaction
-
Commits this transaction by initiating two-phase-commit process.
- commitTime() - Method in interface org.apache.ignite.transactions.TransactionMetrics
-
Gets last time transaction was committed.
- CommunicationListener<T extends Serializable> - Interface in org.apache.ignite.spi.communication
-
Listener SPI notifies IO manager with.
- CommunicationSpi<T extends Serializable> - Interface in org.apache.ignite.spi.communication
-
Communication SPI is responsible for data exchange between nodes.
- compare(String, String) - Method in class org.apache.ignite.yarn.IgniteProvider.VersionComparator
- compareAndSet(long, long) - Method in interface org.apache.ignite.IgniteAtomicLong
-
Atomically compares current value to the expected value, and if they are equal, sets current value
to new value.
- compareAndSet(T, T) - Method in interface org.apache.ignite.IgniteAtomicReference
-
Conditionally sets the new value.
- compareAndSet(T, T, S, S) - Method in interface org.apache.ignite.IgniteAtomicStamped
-
Conditionally sets the new value and new stamp.
- compareTo(Event) - Method in class org.apache.ignite.events.EventAdapter
- compareTo(IgfsPath) - Method in class org.apache.ignite.igfs.IgfsPath
- compareTo(IgniteProductVersion) - Method in class org.apache.ignite.lang.IgniteProductVersion
- compareTo(IgniteUuid) - Method in class org.apache.ignite.lang.IgniteUuid
- compareToIgnoreTimestamp(IgniteProductVersion) - Method in class org.apache.ignite.lang.IgniteProductVersion
-
- components() - Method in class org.apache.ignite.igfs.IgfsPath
-
Split full path on components.
- componentsArray() - Method in class org.apache.ignite.igfs.IgfsPath
-
Get components in array form.
- compute() - Method in interface org.apache.ignite.Ignite
-
Gets compute facade over all cluster nodes started in server mode.
- compute(ClusterGroup) - Method in interface org.apache.ignite.Ignite
-
Gets compute facade over the specified cluster group.
- compute() - Method in class org.apache.ignite.IgniteSpringBean
-
Gets compute facade over all cluster nodes started in server mode.
- compute(ClusterGroup) - Method in class org.apache.ignite.IgniteSpringBean
-
Gets compute facade over the specified cluster group.
- ComputeExecutionRejectedException - Exception in org.apache.ignite.compute
-
This exception defines execution rejection.
- ComputeExecutionRejectedException(String) - Constructor for exception org.apache.ignite.compute.ComputeExecutionRejectedException
-
Creates new execution rejection exception with given error message.
- ComputeExecutionRejectedException(Throwable) - Constructor for exception org.apache.ignite.compute.ComputeExecutionRejectedException
-
Creates new execution rejection given throwable as a cause and
source of error message.
- ComputeExecutionRejectedException(String, Throwable) - Constructor for exception org.apache.ignite.compute.ComputeExecutionRejectedException
-
Creates new execution rejection exception with given error message
and optional nested exception.
- ComputeJob - Interface in org.apache.ignite.compute
-
- ComputeJobAdapter - Class in org.apache.ignite.compute
-
Convenience adapter for
ComputeJob implementations.
- ComputeJobAdapter() - Constructor for class org.apache.ignite.compute.ComputeJobAdapter
-
No-arg constructor.
- ComputeJobAdapter(Object) - Constructor for class org.apache.ignite.compute.ComputeJobAdapter
-
Creates job with one arguments.
- ComputeJobAdapter(Object...) - Constructor for class org.apache.ignite.compute.ComputeJobAdapter
-
Creates job with specified arguments.
- ComputeJobAfterSend - Annotation Type in org.apache.ignite.compute
-
This annotation allows to call a method right after the job has been
successfully sent for execution.
- ComputeJobBeforeFailover - Annotation Type in org.apache.ignite.compute
-
This annotation allows to call a method right before job is submitted to
FailoverSpi.
- ComputeJobContext - Interface in org.apache.ignite.compute
-
Context attached to every job executed on the grid.
- ComputeJobContinuation - Interface in org.apache.ignite.compute
-
Defines continuation support for grid job context.
- ComputeJobContinuationAdapter - Class in org.apache.ignite.compute
-
Convenience adapter for
ComputeJob implementations.
- ComputeJobContinuationAdapter() - Constructor for class org.apache.ignite.compute.ComputeJobContinuationAdapter
-
No-arg constructor.
- ComputeJobContinuationAdapter(Object) - Constructor for class org.apache.ignite.compute.ComputeJobContinuationAdapter
-
Creates job with one arguments.
- ComputeJobContinuationAdapter(Object...) - Constructor for class org.apache.ignite.compute.ComputeJobContinuationAdapter
-
Creates job with specified arguments.
- ComputeJobFailoverException - Exception in org.apache.ignite.compute
-
This runtime exception can be thrown from
ComputeJob.execute() method to force
job failover to another node within task topology.
- ComputeJobFailoverException(String) - Constructor for exception org.apache.ignite.compute.ComputeJobFailoverException
-
Creates new exception with given error message.
- ComputeJobFailoverException(Throwable) - Constructor for exception org.apache.ignite.compute.ComputeJobFailoverException
-
Creates new given throwable as a cause and
source of error message.
- ComputeJobFailoverException(String, Throwable) - Constructor for exception org.apache.ignite.compute.ComputeJobFailoverException
-
Creates new exception with given error message
and optional nested exception.
- ComputeJobMasterLeaveAware - Interface in org.apache.ignite.compute
-
Annotation for handling master node leave during job execution.
- ComputeJobResult - Interface in org.apache.ignite.compute
-
- ComputeJobResultPolicy - Enum in org.apache.ignite.compute
-
This enumeration provides different types of actions following the last
received job result.
- ComputeJobSibling - Interface in org.apache.ignite.compute
-
Job sibling interface defines a job from the same split.
- ComputeLoadBalancer - Interface in org.apache.ignite.compute
-
Load balancer is used for finding the best balanced node according
to load balancing policy.
- ComputeTask<T,R> - Interface in org.apache.ignite.compute
-
Grid task interface defines a task that can be executed on the grid.
- ComputeTaskAdapter<T,R> - Class in org.apache.ignite.compute
-
- ComputeTaskAdapter() - Constructor for class org.apache.ignite.compute.ComputeTaskAdapter
-
- ComputeTaskCancelledException - Exception in org.apache.ignite.compute
-
This exception indicates that grid task was cancelled.
- ComputeTaskCancelledException(String) - Constructor for exception org.apache.ignite.compute.ComputeTaskCancelledException
-
Creates new task cancellation exception with given error message.
- ComputeTaskCancelledException(Throwable) - Constructor for exception org.apache.ignite.compute.ComputeTaskCancelledException
-
Creates new task cancellation exception given throwable as a cause and
source of error message.
- ComputeTaskCancelledException(String, Throwable) - Constructor for exception org.apache.ignite.compute.ComputeTaskCancelledException
-
Creates new task cancellation exception with given error message and optional nested exception.
- ComputeTaskContinuousMapper - Interface in org.apache.ignite.compute
-
Defines a mapper that can be used for asynchronous job sending.
- ComputeTaskFuture<R> - Interface in org.apache.ignite.compute
-
This class defines a handler for asynchronous task execution.
- ComputeTaskMapAsync - Annotation Type in org.apache.ignite.compute
-
Annotation for asynchronous task mapping.
- ComputeTaskName - Annotation Type in org.apache.ignite.compute
-
This annotation allows to assign optional name to grid task.
- ComputeTaskNoResultCache - Annotation Type in org.apache.ignite.compute
-
This annotation disables caching of task results when attached to
ComputeTask class
being executed.
- ComputeTaskSession - Interface in org.apache.ignite.compute
-
Defines a distributed session for particular task execution.
- ComputeTaskSessionAttributeListener - Interface in org.apache.ignite.compute
-
This interface defines listener for task session attributes.
- ComputeTaskSessionFullSupport - Annotation Type in org.apache.ignite.compute
-
Annotation for enabling task session attributes and checkpoints for tasks.
- ComputeTaskSessionScope - Enum in org.apache.ignite.compute
-
Defines life-time scopes for checkpoint operations.
- ComputeTaskSpis - Annotation Type in org.apache.ignite.compute
-
This annotation allows task to specify what SPIs it wants to use.
- ComputeTaskSplitAdapter<T,R> - Class in org.apache.ignite.compute
-
- ComputeTaskSplitAdapter() - Constructor for class org.apache.ignite.compute.ComputeTaskSplitAdapter
-
- ComputeTaskTimeoutException - Exception in org.apache.ignite.compute
-
This exception indicates that task execution timed out.
- ComputeTaskTimeoutException(String) - Constructor for exception org.apache.ignite.compute.ComputeTaskTimeoutException
-
Creates task timeout exception with given task execution ID and
error message.
- ComputeTaskTimeoutException(Throwable) - Constructor for exception org.apache.ignite.compute.ComputeTaskTimeoutException
-
Creates new task timeout exception given throwable as a cause and
source of error message.
- ComputeTaskTimeoutException(String, Throwable) - Constructor for exception org.apache.ignite.compute.ComputeTaskTimeoutException
-
Creates task timeout exception with given task execution ID,
error message and optional nested exception.
- ComputeUserUndeclaredException - Exception in org.apache.ignite.compute
-
This exception is thrown when user's code throws undeclared runtime exception.
- ComputeUserUndeclaredException(String) - Constructor for exception org.apache.ignite.compute.ComputeUserUndeclaredException
-
Creates user undeclared exception with given task execution ID and
error message.
- ComputeUserUndeclaredException(Throwable) - Constructor for exception org.apache.ignite.compute.ComputeUserUndeclaredException
-
Creates new user undeclared exception given throwable as a cause and
source of error message.
- ComputeUserUndeclaredException(String, Throwable) - Constructor for exception org.apache.ignite.compute.ComputeUserUndeclaredException
-
Creates user undeclared exception with given task execution ID,
error message and optional nested exception.
- concurrency() - Method in interface org.apache.ignite.transactions.Transaction
-
Cache transaction concurrency mode.
- CONFIG_PREFIX - Static variable in class org.apache.ignite.mesos.resource.ResourceHandler
-
- configInfo(String, Object) - Method in class org.apache.ignite.spi.IgniteSpiAdapter
-
Gets uniformed string for configuration parameter.
- configName() - Method in class org.apache.ignite.mesos.resource.ResourceProvider
-
- configuration() - Method in interface org.apache.ignite.Ignite
-
Gets the configuration of this grid instance.
- configuration() - Method in interface org.apache.ignite.IgniteFileSystem
-
Gets IGFS configuration.
- configuration() - Method in class org.apache.ignite.IgniteSpringBean
-
Gets the configuration of this grid instance.
- configure(Context) - Method in class org.apache.ignite.stream.flume.IgniteSink
-
Sink configurations with Ignite-specific settings.
- connect(String, Properties) - Method in class org.apache.ignite.IgniteJdbcDriver
- connectCount() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.HandshakeMessage
-
- connected() - Method in interface org.apache.ignite.visor.plugin.VisorPluginModel
-
Whether Visor connected to the grid.
- connection() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
-
- connectionLost(Throwable) - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
-
Implements the MqttCallback.connectionLost(Throwable) callback method for the MQTT client to inform the
streamer that the connection has been lost.
- ConnectorConfiguration - Class in org.apache.ignite.configuration
-
REST access configuration.
- ConnectorConfiguration() - Constructor for class org.apache.ignite.configuration.ConnectorConfiguration
-
Creates client connection configuration with all default values.
- ConnectorConfiguration(ConnectorConfiguration) - Constructor for class org.apache.ignite.configuration.ConnectorConfiguration
-
Creates client connection configuration by copying all properties from
given configuration.
- ConnectorMessageInterceptor - Interface in org.apache.ignite.configuration
-
Interface for user-defined object interceptors.
- consistentId() - Method in interface org.apache.ignite.cluster.ClusterNode
-
Gets consistent globally unique node ID.
- container() - Method in interface org.apache.ignite.visor.plugin.VisorPluginComponent
-
Get component container.
- ContainerSweepClassLoader - Class in org.apache.ignite.osgi.classloaders
-
A
ClassLoader implementation that first attempts to load the class from the associated
Bundle.
- ContainerSweepClassLoader(Bundle) - Constructor for class org.apache.ignite.osgi.classloaders.ContainerSweepClassLoader
-
Constructor with a Bundle only.
- ContainerSweepClassLoader(Bundle, ClassLoader) - Constructor for class org.apache.ignite.osgi.classloaders.ContainerSweepClassLoader
-
Constructor with a
Bundle and another
ClassLoader to check.
- contains(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateRegion
- contains(Object) - Method in interface org.apache.ignite.IgniteQueue
- contains(Object) - Method in interface org.apache.ignite.IgniteSet
- containsAll(Collection<?>) - Method in interface org.apache.ignite.IgniteQueue
- containsAll(Collection<?>) - Method in interface org.apache.ignite.IgniteSet
- containsKey(K) - Method in interface org.apache.ignite.IgniteCache
- containsKey(Object) - Method in class org.apache.ignite.lang.IgniteBiTuple
- containsKey(String, K) - Method in interface org.apache.ignite.spi.IgniteSpiContext
-
Returns true if this cache contains a mapping for the specified key.
- containsKeys(Set<? extends K>) - Method in interface org.apache.ignite.IgniteCache
-
Determines if the Cache contains entries for the specified keys.
- containsValue(Object) - Method in class org.apache.ignite.lang.IgniteBiTuple
- contextDestroyed(ServletContextEvent) - Method in class org.apache.ignite.startup.servlet.ServletContextListenerStartup
- contextInitialized(ServletContextEvent) - Method in class org.apache.ignite.startup.servlet.ServletContextListenerStartup
- ContinuousQuery<K,V> - Class in org.apache.ignite.cache.query
-
API for configuring continuous cache queries.
- ContinuousQuery() - Constructor for class org.apache.ignite.cache.query.ContinuousQuery
-
Creates new continuous query.
- continuousQueryFilter() - Method in class org.apache.ignite.events.CacheQueryExecutedEvent
-
Gets continuous query filter.
- continuousQueryFilter() - Method in class org.apache.ignite.events.CacheQueryReadEvent
-
Gets continuous query filter.
- convert(byte[]) - Method in interface org.apache.ignite.stream.socket.SocketMessageConverter
-
Converter message represented by array of bytes to object.
- copyLocalToHdfs(FileSystem, String, String) - Static method in class org.apache.ignite.yarn.utils.IgniteYarnUtils
-
- copyright() - Method in interface org.apache.ignite.plugin.PluginProvider
-
- count() - Method in interface org.apache.ignite.IgniteCountDownLatch
-
Gets current count value of the latch.
- count() - Method in interface org.apache.ignite.scheduler.SchedulerFuture
-
Gets total count of executions this task has already completed.
- count(String) - Method in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
-
Gets number of stored entries (keys) in data space with given name.
- count(String, Set<Integer>) - Method in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
-
Gets number of stored entries (keys) in data space with given name.
- count(String) - Method in class org.apache.ignite.spi.swapspace.noop.NoopSwapSpaceSpi
-
Gets number of stored entries (keys) in data space with given name.
- count(String, Set<Integer>) - Method in class org.apache.ignite.spi.swapspace.noop.NoopSwapSpaceSpi
-
Gets number of stored entries (keys) in data space with given name.
- count(String) - Method in interface org.apache.ignite.spi.swapspace.SwapSpaceSpi
-
Gets number of stored entries (keys) in data space with given name.
- count(String, Set<Integer>) - Method in interface org.apache.ignite.spi.swapspace.SwapSpaceSpi
-
Gets number of stored entries (keys) in data space with given name.
- countDown() - Method in interface org.apache.ignite.IgniteCountDownLatch
-
Decrements the count of the latch, releasing all waiting threads
on all nodes if the count reaches zero.
- countDown(int) - Method in interface org.apache.ignite.IgniteCountDownLatch
-
Decreases the count of the latch using passed in value,
releasing all waiting threads on all nodes if the count reaches zero.
- countDownAll() - Method in interface org.apache.ignite.IgniteCountDownLatch
-
Counts down this latch to zero, releasing all waiting threads on all nodes.
- countDownLatch(String, int, boolean, boolean) - Method in interface org.apache.ignite.Ignite
-
Gets or creates count down latch.
- countDownLatch(String, int, boolean, boolean) - Method in class org.apache.ignite.IgniteSpringBean
-
Gets or creates count down latch.
- COUNTER_WRITER_DIR_PROPERTY - Static variable in class org.apache.ignite.hadoop.fs.IgniteHadoopFileSystemCounterWriter
-
- COURTESY_LOGGER_NAME - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
-
Courtesy notice log category.
- CPU - Static variable in class org.apache.ignite.mesos.IgniteScheduler
-
Cpus.
- cpuCores - Variable in class org.apache.ignite.mesos.IgniteTask
-
- cpuCores() - Method in class org.apache.ignite.mesos.IgniteTask
-
- cpuCores - Variable in class org.apache.ignite.yarn.IgniteContainer
-
- cpuCores() - Method in class org.apache.ignite.yarn.IgniteContainer
-
- cpus() - Method in class org.apache.ignite.mesos.ClusterProperties
-
- cpus(double) - Method in class org.apache.ignite.mesos.ClusterProperties
-
Sets CPU count limit.
- cpusPerNode() - Method in class org.apache.ignite.mesos.ClusterProperties
-
- cpusPerNode(double) - Method in class org.apache.ignite.mesos.ClusterProperties
-
Sets CPU count limit.
- cpusPerNode() - Method in class org.apache.ignite.yarn.ClusterProperties
-
- cpusPerNode(double) - Method in class org.apache.ignite.yarn.ClusterProperties
-
Sets CPU count limit.
- create(int) - Method in interface org.apache.ignite.binary.BinaryCollectionFactory
-
Create collection.
- create(int) - Method in interface org.apache.ignite.binary.BinaryMapFactory
-
Create collection.
- create() - Method in class org.apache.ignite.cache.jta.jndi.CacheJndiTmFactory
- create() - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStoreFactory
- create() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStoreFactory
- create() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
- create() - Method in class org.apache.ignite.configuration.IgniteReflectionFactory
- create(String) - Method in class org.apache.ignite.hadoop.fs.BasicHadoopFileSystemFactory
-
Internal file system creation routine, invoked in correct class loader context.
- create(IgfsPath, boolean) - Method in class org.apache.ignite.hadoop.fs.IgniteHadoopIgfsSecondaryFileSystem
-
Creates a file and opens it for writing.
- create(IgfsPath, int, boolean, int, long, Map<String, String>) - Method in class org.apache.ignite.hadoop.fs.IgniteHadoopIgfsSecondaryFileSystem
-
Creates a file and opens it for writing.
- create(String) - Method in class org.apache.ignite.hadoop.fs.KerberosHadoopFileSystemFactory
-
Internal file system creation routine, invoked in correct class loader context.
- create(Path, FsPermission, boolean, int, short, long, Progressable) - Method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
- create(Configuration) - Method in class org.apache.ignite.hadoop.mapreduce.IgniteHadoopClientProtocolProvider
- create(InetSocketAddress, Configuration) - Method in class org.apache.ignite.hadoop.mapreduce.IgniteHadoopClientProtocolProvider
- create(IgfsPath, boolean) - Method in interface org.apache.ignite.igfs.secondary.IgfsSecondaryFileSystem
-
Creates a file and opens it for writing.
- create(IgfsPath, int, boolean, int, long, Map<String, String>) - Method in interface org.apache.ignite.igfs.secondary.IgfsSecondaryFileSystem
-
Creates a file and opens it for writing.
- create(IgfsPath, boolean) - Method in interface org.apache.ignite.IgniteFileSystem
-
Creates a file and opens it for writing.
- create(IgfsPath, int, boolean, int, long, Map<String, String>) - Method in interface org.apache.ignite.IgniteFileSystem
-
Creates a file and opens it for writing.
- create(IgfsPath, int, boolean, IgniteUuid, int, long, Map<String, String>) - Method in interface org.apache.ignite.IgniteFileSystem
-
Creates a file and opens it for writing.
- create() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetCacheStoreFactory
- create(byte) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageFactory
-
Creates new message instance of provided type.
- create() - Method in class org.apache.ignite.ssl.SslContextFactory
- CREATE_ADDRS_TABLE_QRY - Static variable in class org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc.TcpDiscoveryJdbcIpFinder
-
Query to create addresses table.
- createAccessStrategy(AccessType) - Method in class org.apache.ignite.cache.hibernate.HibernateTransactionalDataRegion
-
- createCache(String, C) - Method in class org.apache.ignite.cache.CacheManager
- createCache(CacheConfiguration<K, V>) - Method in interface org.apache.ignite.Ignite
-
Dynamically starts new cache with the given cache configuration.
- createCache(String) - Method in interface org.apache.ignite.Ignite
-
Dynamically starts new cache using template configuration.
- createCache(CacheConfiguration<K, V>, NearCacheConfiguration<K, V>) - Method in interface org.apache.ignite.Ignite
-
Dynamically starts new cache with the given cache configuration.
- createCache(CacheConfiguration<K, V>) - Method in class org.apache.ignite.IgniteSpringBean
-
Dynamically starts new cache with the given cache configuration.
- createCache(CacheConfiguration<K, V>, NearCacheConfiguration<K, V>) - Method in class org.apache.ignite.IgniteSpringBean
-
Dynamically starts new cache with the given cache configuration.
- createCache(String) - Method in class org.apache.ignite.IgniteSpringBean
-
Dynamically starts new cache using template configuration.
- createComponent(Class<T>) - Method in interface org.apache.ignite.plugin.CachePluginProvider
-
- createComponent(PluginContext, Class<T>) - Method in interface org.apache.ignite.plugin.PluginProvider
-
Creates Ignite component.
- createConsoleLogger() - Static method in class org.apache.ignite.logger.log4j2.Log4J2Logger
-
Creates console appender with some reasonable default logging settings.
- createInternal(Path, EnumSet<CreateFlag>, FsPermission, int, short, long, Progressable, Options.ChecksumOpt, boolean) - Method in class org.apache.ignite.hadoop.fs.v2.IgniteHadoopFileSystem
- createJob(IgfsPath, IgfsFileRange, IgfsTaskArgs<T>) - Method in class org.apache.ignite.igfs.mapreduce.IgfsTask
-
Callback invoked during task map procedure to create job that will process specified split
for IGFS file.
- createName(long, String, String) - Static method in class org.apache.ignite.thread.IgniteThread
-
Creates new thread name.
- createNearCache(String, NearCacheConfiguration<K, V>) - Method in interface org.apache.ignite.Ignite
-
- createNearCache(String, NearCacheConfiguration<K, V>) - Method in class org.apache.ignite.IgniteSpringBean
-
- createNioClient(ClusterNode) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
- createPanel(VisorPluginComponentsFactory, JPanel) - Method in class org.apache.ignite.visor.plugin.VisorPluggableTab
-
Construct content of pluggable tab.
- createProvider(CachePluginContext) - Method in interface org.apache.ignite.plugin.CachePluginConfiguration
-
Creates cache plugin provider.
- createShmemClient(ClusterNode, Integer) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
- createSpiAttributeName(String) - Method in class org.apache.ignite.spi.IgniteSpiAdapter
-
Creates new name for the given attribute.
- createTcpClient(ClusterNode) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Establish TCP connection to remote node and returns client.
- createTime() - Method in interface org.apache.ignite.scheduler.SchedulerFuture
-
Gets time in milliseconds at which this future was created.
- credentials() - Method in class org.apache.ignite.plugin.security.AuthenticationContext
-
Gets security credentials.
- credentials(SecurityCredentials) - Method in class org.apache.ignite.plugin.security.AuthenticationContext
-
Sets security credentials.
- credentials() - Method in class org.apache.ignite.plugin.security.SecurityCredentialsBasicProvider
-
Gets security credentials.
- credentials() - Method in interface org.apache.ignite.plugin.security.SecurityCredentialsProvider
-
Gets security credentials.
- ctx - Variable in class org.apache.ignite.marshaller.AbstractMarshaller
-
Context.
- currentTopologySnapshot() - Method in interface org.apache.ignite.cache.affinity.AffinityFunctionContext
-
Gets current topology snapshot.
- currentTopologyVersion() - Method in interface org.apache.ignite.cache.affinity.AffinityFunctionContext
-
Gets current topology version number.
- currentUser() - Static method in class org.apache.ignite.igfs.IgfsUserContext
-
Gets the current context user.
- dataSize() - Method in class org.apache.ignite.events.IgfsEvent
-
Transferred data size for this event.
- dataSrc - Variable in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
-
Data source.
- dataStreamer(String) - Method in interface org.apache.ignite.Ignite
-
Gets a new instance of data streamer associated with given cache name.
- dataStreamer(String) - Method in class org.apache.ignite.IgniteSpringBean
-
Gets a new instance of data streamer associated with given cache name.
- DB2Dialect - Class in org.apache.ignite.cache.store.jdbc.dialect
-
A dialect compatible with the IBM DB2 database.
- DB2Dialect() - Constructor for class org.apache.ignite.cache.store.jdbc.dialect.DB2Dialect
-
- debug(String) - Method in interface org.apache.ignite.IgniteLogger
-
Logs out debug message.
- debug(String) - Method in class org.apache.ignite.logger.java.JavaLogger
-
Logs out debug message.
- debug(String) - Method in class org.apache.ignite.logger.jcl.JclLogger
-
Logs out debug message.
- debug(String) - Method in class org.apache.ignite.logger.log4j.Log4JLogger
-
Logs out debug message.
- debug(String) - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
-
Logs out debug message.
- debug(String) - Method in class org.apache.ignite.logger.NullLogger
-
Logs out debug message.
- debug(String) - Method in class org.apache.ignite.logger.slf4j.Slf4jLogger
-
Logs out debug message.
- decrementAndGet() - Method in interface org.apache.ignite.IgniteAtomicLong
-
Decrements and gets current value of atomic long.
- DEFAULT_CLUSTER_NAME - Static variable in class org.apache.ignite.mesos.ClusterProperties
-
- DEFAULT_CLUSTER_NAME - Static variable in class org.apache.ignite.yarn.ClusterProperties
-
- DEFAULT_CONFIG - Static variable in class org.apache.ignite.mesos.resource.ResourceHandler
-
- DEFAULT_CPU_PER_NODE - Static variable in class org.apache.ignite.yarn.ClusterProperties
-
- DEFAULT_HTTP_SERVER_PORT - Static variable in class org.apache.ignite.mesos.ClusterProperties
-
- DEFAULT_IGNITE_CONFIG - Static variable in class org.apache.ignite.yarn.utils.IgniteYarnUtils
-
- DEFAULT_IGNITE_LOCAL_WORK_DIR - Static variable in class org.apache.ignite.yarn.ClusterProperties
-
- DEFAULT_IGNITE_NODE_COUNT - Static variable in class org.apache.ignite.yarn.ClusterProperties
-
- DEFAULT_IGNITE_RELEASES_DIR - Static variable in class org.apache.ignite.yarn.ClusterProperties
-
- DEFAULT_IGNITE_VERSION - Static variable in class org.apache.ignite.mesos.ClusterProperties
-
- DEFAULT_IGNITE_WORK_DIR - Static variable in class org.apache.ignite.mesos.ClusterProperties
-
- DEFAULT_IGNITE_WORK_DIR - Static variable in class org.apache.ignite.yarn.ClusterProperties
-
- DEFAULT_MEM_PER_NODE - Static variable in class org.apache.ignite.yarn.ClusterProperties
-
- DEFAULT_MESOS_MASTER_URL - Static variable in class org.apache.ignite.mesos.ClusterProperties
-
- DEFAULT_PORT - Static variable in class org.apache.ignite.mesos.IgniteScheduler
-
Default port range.
- DEFAULT_PORT - Static variable in class org.apache.ignite.yarn.ApplicationMaster
-
Default port range.
- DEFAULT_RESOURCE_MIN_CPU - Static variable in class org.apache.ignite.mesos.ClusterProperties
-
- DEFAULT_RESOURCE_MIN_MEM - Static variable in class org.apache.ignite.mesos.ClusterProperties
-
- defaultAllowAll() - Method in interface org.apache.ignite.plugin.security.SecurityPermissionSet
-
Flag indicating whether to allow or deny cache and task operations
if they were not explicitly specified.
- defaultIndexName(QueryIndex) - Static method in class org.apache.ignite.cache.QueryEntity
-
Generates default index name by concatenating all index field names.
- delete(Object) - Method in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
- delete(Object) - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStore
- delete(Object) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
- delete(Object) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
- delete(IgfsPath, boolean) - Method in class org.apache.ignite.hadoop.fs.IgniteHadoopIgfsSecondaryFileSystem
-
Deletes file.
- delete(Path) - Method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
- delete(Path, boolean) - Method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
- delete(Path, boolean) - Method in class org.apache.ignite.hadoop.fs.v2.IgniteHadoopFileSystem
- delete(IgfsPath, boolean) - Method in interface org.apache.ignite.igfs.secondary.IgfsSecondaryFileSystem
-
Deletes file.
- delete(IgfsPath, boolean) - Method in interface org.apache.ignite.IgniteFileSystem
-
Deletes file.
- deleteAll(Collection<?>) - Method in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
- deleteAll(Collection<?>) - Method in class org.apache.ignite.cache.store.CacheStoreAdapter
- deleteAll(Collection<?>) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
- DELIM - Static variable in class org.apache.ignite.mesos.IgniteScheduler
-
Delimiter char.
- DELIM - Static variable in class org.apache.ignite.spi.discovery.tcp.ipfinder.s3.TcpDiscoveryS3IpFinder
-
Delimiter to use in S3 entries name.
- DELIM - Static variable in class org.apache.ignite.spi.discovery.tcp.ipfinder.sharedfs.TcpDiscoverySharedFsIpFinder
-
Delimiter to use between address and port tokens in file names.
- DELIM - Static variable in class org.apache.ignite.yarn.ApplicationMaster
-
Delimiter char.
- deliveryComplete(IMqttDeliveryToken) - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
-
Empty implementation of MqttCallback.deliveryComplete(IMqttDeliveryToken).
- deploy(ServiceConfiguration) - Method in interface org.apache.ignite.IgniteServices
-
Deploys multiple instances of the service on the grid according to provided
configuration.
- DEPLOY_TMP_ROOT_NAME - Static variable in class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
-
- deployClass() - Method in class org.apache.ignite.compute.gridify.aop.GridifyDefaultRangeTask
-
Gets top level user class being deployed.
- deployClass() - Method in class org.apache.ignite.compute.gridify.aop.GridifyDefaultTask
-
Gets top level user class being deployed.
- deployClass(Class<?>) - Method in interface org.apache.ignite.IgniteDataStreamer
-
Optional deploy class for peer deployment.
- deployClusterSingleton(String, Service) - Method in interface org.apache.ignite.IgniteServices
-
Deploys a cluster-wide singleton service.
- deployKeyAffinitySingleton(String, Service, String, Object) - Method in interface org.apache.ignite.IgniteServices
-
Deploys one instance of this service on the primary node for a given affinity key.
- DeploymentEvent - Class in org.apache.ignite.events
-
Grid deployment event.
- DeploymentEvent() - Constructor for class org.apache.ignite.events.DeploymentEvent
-
No-arg constructor.
- DeploymentEvent(ClusterNode, String, int) - Constructor for class org.apache.ignite.events.DeploymentEvent
-
Creates deployment event with given parameters.
- DeploymentListener - Interface in org.apache.ignite.spi.deployment
-
Listener for deployment events.
- DeploymentMode - Enum in org.apache.ignite.configuration
-
Grid deployment mode.
- DeploymentResource - Interface in org.apache.ignite.spi.deployment
-
Generic abstraction over deployed resource containing resource's name, class and corresponding class loader.
- DeploymentResourceAdapter - Class in org.apache.ignite.spi.deployment
-
- DeploymentResourceAdapter(String, Class<?>, ClassLoader) - Constructor for class org.apache.ignite.spi.deployment.DeploymentResourceAdapter
-
Creates resource.
- DeploymentSpi - Interface in org.apache.ignite.spi.deployment
-
Grid deployment SPI is in charge of deploying tasks and classes from different
sources.
- deployMultiple(String, Service, int, int) - Method in interface org.apache.ignite.IgniteServices
-
Deploys multiple instances of the service on the grid.
- deployNodeSingleton(String, Service) - Method in interface org.apache.ignite.IgniteServices
-
Deploys a per-node singleton service.
- depth() - Method in class org.apache.ignite.igfs.IgfsPath
-
Return the number of elements in this path.
- deregisterPort(int, IgnitePortProtocol, Class<?>) - Method in interface org.apache.ignite.plugin.PluginContext
-
Deregisters closed port.
- deregisterPort(int, IgnitePortProtocol) - Method in interface org.apache.ignite.spi.IgniteSpiContext
-
Deregisters closed port.
- deregisterPorts(Class<?>) - Method in interface org.apache.ignite.plugin.PluginContext
-
Deregisters all closed ports.
- deregisterPorts() - Method in interface org.apache.ignite.spi.IgniteSpiContext
-
Deregisters all closed ports.
- deserialize() - Method in interface org.apache.ignite.binary.BinaryObject
-
Gets fully deserialized instance of binary object.
- destroy() - Method in class org.apache.ignite.cache.hibernate.HibernateRegion
- destroy() - Method in class org.apache.ignite.cache.websession.WebSessionFilter
- destroy() - Method in interface org.apache.ignite.IgniteCache
-
Completely deletes the cache with all its data from the system on all cluster nodes.
- destroy() - Method in class org.apache.ignite.IgniteSpringBean
- destroy() - Method in class org.apache.ignite.startup.servlet.ServletStartup
- destroyCache(String) - Method in class org.apache.ignite.cache.CacheManager
- destroyCache(String) - Method in interface org.apache.ignite.Ignite
-
Stops dynamically started cache.
- destroyCache(String) - Method in class org.apache.ignite.IgniteSpringBean
-
Stops dynamically started cache.
- DFLT_ACCESS_TYPE_PROPERTY - Static variable in class org.apache.ignite.cache.hibernate.HibernateRegionFactory
-
- DFLT_ACK_SND_THRESHOLD - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Default received messages threshold for sending ack.
- DFLT_ACK_TIMEOUT - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Default timeout for receiving message acknowledgement in milliseconds (value is 5000ms).
- DFLT_ACK_TIMEOUT_CLIENT - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Default timeout for receiving message acknowledgement in milliseconds (value is 5000ms).
- DFLT_ACTIVE_JOBS_THRESHOLD - Static variable in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
-
Default number of parallel jobs allowed (value is 95 which is
slightly less same as default value of threads in the execution thread pool
to allow some extra threads for system processing).
- DFLT_ADDR_REQ_ATTEMPTS - Static variable in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
-
Default number of attempts to send multicast address request (value is 2).
- DFLT_ALL_SEG_RESOLVERS_PASS_REQ - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
-
Default value for all segmentation resolvers pass required.
- DFLT_ATOMIC_SEQUENCE_RESERVE_SIZE - Static variable in class org.apache.ignite.configuration.AtomicConfiguration
-
Default atomic sequence reservation size.
- DFLT_AUTO_UNSUBSCRIBE - Static variable in class org.apache.ignite.cache.query.ContinuousQuery
-
Default value for automatic unsubscription flag.
- DFLT_BACKUPS - Static variable in class org.apache.ignite.configuration.AtomicConfiguration
-
- DFLT_BACKUPS - Static variable in class org.apache.ignite.configuration.CacheConfiguration
-
Default number of backups.
- DFLT_BASE_DIR - Static variable in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
-
Default base directory.
- DFLT_BATCH_QUEUE_SIZE - Static variable in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
-
Default batch queue size (max batches count to limit memory usage).
- DFLT_BATCH_SIZE - Static variable in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
-
- DFLT_BATCH_SIZE - Static variable in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
-
Default batch size for put and remove operations.
- DFLT_BLOCK_SIZE - Static variable in class org.apache.ignite.configuration.FileSystemConfiguration
-
Default file's data block size (bytes).
- DFLT_BUCKET_NAME_SUFFIX - Static variable in class org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpi
-
Suffix to use in bucket name generation.
- DFLT_BUF_SIZE - Static variable in class org.apache.ignite.configuration.FileSystemConfiguration
-
Default read/write buffers size (bytes).
- DFLT_BUF_SIZE - Static variable in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
-
Default write buffer size in bytes.
- DFLT_BUFFER_SIZE - Static variable in class org.apache.ignite.marshaller.AbstractMarshaller
-
Default initial buffer size for the GridByteArrayOutputStream.
- DFLT_CACHE_ATOMICITY_MODE - Static variable in class org.apache.ignite.configuration.CacheConfiguration
-
Default atomicity mode.
- DFLT_CACHE_MODE - Static variable in class org.apache.ignite.configuration.AtomicConfiguration
-
- DFLT_CACHE_MODE - Static variable in class org.apache.ignite.configuration.CacheConfiguration
-
Default caching mode.
- DFLT_CACHE_NAME - Static variable in class org.apache.ignite.spi.checkpoint.cache.CacheCheckpointSpi
-
Default cache name (value is checkpoints).
- DFLT_CACHE_NAME_PROPERTY - Static variable in class org.apache.ignite.cache.hibernate.HibernateRegionFactory
-
Default cache property name.
- DFLT_CACHE_SANITY_CHECK_ENABLED - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
-
Default value for cache sanity check enabled flag.
- DFLT_CACHE_SIZE - Static variable in class org.apache.ignite.configuration.CacheConfiguration
-
Default cache size to use with eviction policy.
- DFLT_CHECKPOINT_TABLE_NAME - Static variable in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
-
Default checkpoint table name (value is CHECKPOINTS).
- DFLT_CLOCK_SYNC_FREQUENCY - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
-
Default clock synchronization frequency.
- DFLT_CLOCK_SYNC_SAMPLES - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
-
Default number of clock sync samples.
- DFLT_COLOCATE_META - Static variable in class org.apache.ignite.configuration.FileSystemConfiguration
-
Default value of metadata co-location flag.
- DFLT_COMPACT_FOOTER - Static variable in class org.apache.ignite.configuration.BinaryConfiguration
-
Default compact footer flag setting.
- DFLT_CONCUR_LVL - Static variable in class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
-
- DFLT_CONCURRENT_LOAD_ALL_THRESHOLD - Static variable in class org.apache.ignite.configuration.CacheConfiguration
-
Default threshold for concurrent loading of keys from
CacheStore.
- DFLT_CONFIG_PATH - Static variable in class org.apache.ignite.logger.java.JavaLogger
-
- DFLT_CONN_TIMEOUT - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Default connection timeout (value is 5000ms).
- DFLT_CONN_URL - Static variable in class org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStore
-
Default connection URL
(value is jdbc:h2:mem:hibernateCacheStore;DB_CLOSE_DELAY=-1;DEFAULT_LOCK_TIMEOUT=5000).
- DFLT_CONN_URL - Static variable in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
-
Default connection URL (value is jdbc:h2:mem:jdbcCacheStore;DB_CLOSE_DELAY=-1).
- DFLT_COPY_ON_READ - Static variable in class org.apache.ignite.configuration.CacheConfiguration
-
Default value for 'copyOnRead' flag.
- DFLT_CORE_POOL_SIZE - Static variable in class org.apache.ignite.thread.IgniteThreadPoolExecutor
-
Default core pool size (value is 100).
- DFLT_CREATE_TBL_QRY - Static variable in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
-
Default create table query
(value is create table if not exists ENTRIES (key other primary key, val other)).
- DFLT_DEL_QRY - Static variable in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
-
Default delete entry query (value is delete from ENTRIES where key=?
- DFLT_DEPLOY_DIR - Static variable in class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
-
Default deployment directory where SPI will pick up GAR files.
- DFLT_DEPLOYMENT_MODE - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
-
- DFLT_DIR_PATH - Static variable in class org.apache.ignite.spi.checkpoint.sharedfs.SharedFsCheckpointSpi
-
Default checkpoint directory.
- DFLT_DISCOVERY_STARTUP_DELAY - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
-
Default discovery startup delay in milliseconds (value is 60,000ms).
- DFLT_EAGER_TTL - Static variable in class org.apache.ignite.configuration.CacheConfiguration
-
Default value for eager ttl flag.
- DFLT_EVICT_KEY_BUFFER_SIZE - Static variable in class org.apache.ignite.configuration.CacheConfiguration
-
Default eviction key buffer size for batching synchronized evicts.
- DFLT_EVICT_SYNCHRONIZED - Static variable in class org.apache.ignite.configuration.CacheConfiguration
-
Default eviction synchronized flag.
- DFLT_EVICT_SYNCHRONIZED_CONCURRENCY_LEVEL - Static variable in class org.apache.ignite.configuration.CacheConfiguration
-
Default synchronous eviction concurrency level.
- DFLT_EVICT_SYNCHRONIZED_TIMEOUT - Static variable in class org.apache.ignite.configuration.CacheConfiguration
-
Default synchronous eviction timeout in milliseconds.
- DFLT_EXPIRE_AGE_MS - Static variable in class org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpi
-
Default event time to live value in milliseconds (value is
Long.MAX_VALUE).
- DFLT_EXPIRE_COUNT - Static variable in class org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpi
-
Default expire count (value is 10000).
- DFLT_EXPIRE_DATE_FIELD_NAME - Static variable in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
-
Default expiration date field name (value is EXPIRE_DATE).
- DFLT_EXPIRE_DATE_FIELD_TYPE - Static variable in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
-
Default expiration date field type (value is DATETIME).
- DFLT_EXTERNAL_EXECUTION - Static variable in class org.apache.ignite.configuration.HadoopConfiguration
-
Default value for external execution flag.
- DFLT_FAILURE_DETECTION_TIMEOUT - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
-
Default failure detection timeout in millis.
- DFLT_FINISHED_JOB_INFO_TTL - Static variable in class org.apache.ignite.configuration.HadoopConfiguration
-
Default finished job info time-to-live.
- DFLT_FRAGMENTIZER_CONCURRENT_FILES - Static variable in class org.apache.ignite.configuration.FileSystemConfiguration
-
Default fragmentizer concurrent files.
- DFLT_FRAGMENTIZER_ENABLED - Static variable in class org.apache.ignite.configuration.FileSystemConfiguration
-
Fragmentizer enabled property.
- DFLT_FRAGMENTIZER_LOCAL_WRITES_RATIO - Static variable in class org.apache.ignite.configuration.FileSystemConfiguration
-
Default fragmentizer local writes ratio.
- DFLT_FRAGMENTIZER_THROTTLING_BLOCK_LENGTH - Static variable in class org.apache.ignite.configuration.FileSystemConfiguration
-
Default fragmentizer throttling block length.
- DFLT_FRAGMENTIZER_THROTTLING_DELAY - Static variable in class org.apache.ignite.configuration.FileSystemConfiguration
-
Default fragmentizer throttling delay.
- DFLT_GRID_CNT - Static variable in class org.apache.ignite.startup.BasicWarmupClosure
-
Default grid count to warm up.
- DFLT_GRP - Static variable in class org.apache.ignite.spi.IgniteSpiThread
-
Default thread's group.
- DFLT_HBM2DDL_AUTO - Static variable in class org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStore
-
Default hibernate.hbm2ddl.auto property value (value is true).
- DFLT_HEARTBEAT_FREQ - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Default heartbeat messages issuing frequency (value is 2000ms).
- DFLT_HOST - Static variable in class org.apache.ignite.igfs.IgfsIpcEndpointConfiguration
-
Default host.
- DFLT_IDLE_CONN_TIMEOUT - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Default idle connection timeout (value is 30000ms).
- DFLT_IDLE_TIMEOUT - Static variable in class org.apache.ignite.configuration.ConnectorConfiguration
-
Default REST idle timeout.
- DFLT_IGFS_LOG_BATCH_SIZE - Static variable in class org.apache.ignite.configuration.FileSystemConfiguration
-
Default batch size for logging.
- DFLT_IGFS_LOG_DIR - Static variable in class org.apache.ignite.configuration.FileSystemConfiguration
-
Default IGFS log directory.
- DFLT_INIT_DFLT_PATH_MODES - Static variable in class org.apache.ignite.configuration.FileSystemConfiguration
-
Default value of whether to initialize default path modes.
- DFLT_INSERT_QRY - Static variable in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
-
Default insert entry query (value is insert into ENTRIES (key, val) values (?
- DFLT_INVALIDATE - Static variable in class org.apache.ignite.configuration.CacheConfiguration
-
Default value for 'invalidate' flag that indicates if this is invalidation-based cache.
- DFLT_IP_FINDER_CLEAN_FREQ - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Default IP finder clean frequency in milliseconds (value is 60,000ms).
- DFLT_IPC_ENDPOINT_ENABLED - Static variable in class org.apache.ignite.configuration.FileSystemConfiguration
-
Default IPC endpoint enabled flag.
- DFLT_ITERATION_CNT - Static variable in class org.apache.ignite.startup.BasicWarmupClosure
-
Default iteration count per thread.
- DFLT_JOB_PRIORITY - Static variable in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
-
Default start value for job priority (value is 0).
- DFLT_JOB_PRIORITY_ATTRIBUTE_KEY - Static variable in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
-
Default job priority attribute key (value is grid.job.priority).
- DFLT_JOIN_TIMEOUT - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Default timeout for joining topology (value is 0).
- DFLT_KEEP_ALIVE_TIME - Static variable in class org.apache.ignite.configuration.ConnectorConfiguration
-
Default keep alive time for REST thread pool.
- DFLT_KEY_ALGORITHM - Static variable in class org.apache.ignite.ssl.SslContextFactory
-
Default key manager algorithm.
- DFLT_KEY_FIELD_NAME - Static variable in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
-
Default checkpoint key field name (value is NAME).
- DFLT_KEY_FIELD_TYPE - Static variable in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
-
Default checkpoint key field type (value is VARCHAR(256)).
- DFLT_KEY_RANGE - Static variable in class org.apache.ignite.startup.BasicWarmupClosure
-
Default key range.
- DFLT_LOAD_PREV_VAL - Static variable in class org.apache.ignite.configuration.CacheConfiguration
-
Default value for load previous value flag.
- DFLT_LOAD_QRY - Static variable in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
-
Default load entry query (value is select * from ENTRIES where key=?
- DFLT_LOCK_TIMEOUT - Static variable in class org.apache.ignite.configuration.CacheConfiguration
-
Default lock timeout.
- DFLT_LONG_QRY_WARN_TIMEOUT - Static variable in class org.apache.ignite.configuration.CacheConfiguration
-
Default timeout after which long query warning will be printed.
- DFLT_LOWER_CASE - Static variable in class org.apache.ignite.binary.BinaryBasicIdMapper
-
Default lower case flag setting.
- DFLT_MARSHAL_LOCAL_JOBS - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
-
Default marshal local jobs flag.
- DFLT_MAX_ACK_TIMEOUT - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Maximum ack timeout value for receiving message acknowledgement in milliseconds (value is 600,000ms).
- DFLT_MAX_CONCURRENT_ASYNC_OPS - Static variable in class org.apache.ignite.configuration.CacheConfiguration
-
Default value for 'maxConcurrentAsyncOps'.
- DFLT_MAX_CONN_TIMEOUT - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Default Maximum connection timeout (value is 600,000ms).
- DFLT_MAX_EVICTION_OVERFLOW_RATIO - Static variable in class org.apache.ignite.configuration.CacheConfiguration
-
Default maximum eviction queue ratio.
- DFLT_MAX_FAILOVER_ATTEMPTS - Static variable in class org.apache.ignite.spi.failover.always.AlwaysFailoverSpi
-
Maximum number of attempts to execute a failed job on another node (default is 5).
- DFLT_MAX_FAILOVER_ATTEMPTS - Static variable in class org.apache.ignite.spi.failover.jobstealing.JobStealingFailoverSpi
-
Maximum number of attempts to execute a failed job on another node (default is 5).
- DFLT_MAX_MISSED_CLIENT_HEARTBEATS - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Default max heartbeats count node can miss without failing client node (value is 5).
- DFLT_MAX_MISSED_HEARTBEATS - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Default max heartbeats count node can miss without initiating status check (value is 1).
- DFLT_MAX_PARALLEL_OPS - Static variable in interface org.apache.ignite.IgniteDataStreamer
-
Default max concurrent put operations count.
- DFLT_MAX_PARALLEL_TASKS - Static variable in class org.apache.ignite.configuration.HadoopConfiguration
-
Default value for the max parallel tasks.
- DFLT_MAX_PARAMS_CNT - Static variable in class org.apache.ignite.cache.store.jdbc.dialect.BasicJdbcDialect
-
Default max query parameters count.
- DFLT_MAX_RETRIES_ON_FAIL - Static variable in class org.apache.ignite.cache.websession.WebSessionFilter
-
Default retry on fail flag value.
- DFLT_MAX_SPARSITY - Static variable in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
-
Default maximum sparsity.
- DFLT_MAX_STEALING_ATTEMPTS - Static variable in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
-
Maximum number of attempts to steal job by another node (default is 5).
- DFLT_MAX_TASK_QUEUE_SIZE - Static variable in class org.apache.ignite.configuration.HadoopConfiguration
-
Default value for the max task queue size.
- DFLT_MCAST_GROUP - Static variable in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
-
Default multicast IP address (value is 228.1.2.4).
- DFLT_MCAST_PORT - Static variable in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
-
Default multicast port number (value is 47400).
- DFLT_MEM_SIZE - Static variable in class org.apache.ignite.igfs.IgfsIpcEndpointConfiguration
-
Default shared memory space in bytes.
- DFLT_MEMORY_MODE - Static variable in class org.apache.ignite.configuration.CacheConfiguration
-
Default memory mode.
- DFLT_METRICS_EXPIRE_TIME - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
-
Default metrics expire time.
- DFLT_METRICS_HISTORY_SIZE - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
-
Default metrics history size (value is 10000).
- DFLT_METRICS_LOG_FREQ - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
-
Default frequency of metrics log print out.
- DFLT_METRICS_UPDATE_FREQ - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
-
Default metrics update frequency.
- DFLT_MGMT_PORT - Static variable in class org.apache.ignite.configuration.FileSystemConfiguration
-
Default management port.
- DFLT_MGMT_THREAD_CNT - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
-
Default size of management thread pool.
- DFLT_MODE - Static variable in class org.apache.ignite.configuration.FileSystemConfiguration
-
Default IGFS mode.
- DFLT_MSG_EXPIRE_TIME - Static variable in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
-
Default steal message expire time in milliseconds (value is 1000).
- DFLT_MSG_QUEUE_LIMIT - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Default message queue limit per connection (for incoming and outgoing .
- DFLT_NEAR_START_SIZE - Static variable in class org.apache.ignite.configuration.CacheConfiguration
-
Initial default near cache size.
- DFLT_NETWORK_TIMEOUT - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
-
Default maximum timeout to wait for network responses in milliseconds (value is 5,000ms).
- DFLT_NETWORK_TIMEOUT - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Default network timeout in milliseconds (value is 5000ms).
- DFLT_NODE_WEIGHT - Static variable in class org.apache.ignite.spi.loadbalancing.weightedrandom.WeightedRandomLoadBalancingSpi
-
Default weight assigned to every node if explicit one is not provided (value is 10).
- DFLT_NUMBER_OF_RETRIES - Static variable in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
-
Default number of retries in case of errors (value is 2).
- DFLT_OFFHEAP_MEMORY - Static variable in class org.apache.ignite.configuration.CacheConfiguration
-
Default off-heap storage size is -1 which means that off-heap storage is disabled.
- DFLT_P2P_ENABLED - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
-
Default flag for peer class loading.
- DFLT_P2P_MISSED_RESOURCES_CACHE_SIZE - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
-
Default cache size for missed resources.
- DFLT_P2P_THREAD_CNT - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
-
Default size of peer class loading thread pool.
- DFLT_PAGE_SIZE - Static variable in class org.apache.ignite.cache.query.ContinuousQuery
-
Default page size.
- DFLT_PAGE_SIZE - Static variable in class org.apache.ignite.cache.query.Query
-
Default query page size.
- DFLT_PARALLEL_JOBS_NUM - Static variable in class org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpi
-
Default number of parallel jobs allowed (set to number of cores times 2).
- DFLT_PARALLEL_JOBS_NUM - Static variable in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
-
Default number of parallel jobs allowed (set to number of cores times 2).
- DFLT_PARALLEL_LOAD_CACHE_MINIMUM_THRESHOLD - Static variable in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
-
Default batch size for put and remove operations.
- DFLT_PART_CNT - Static variable in class org.apache.ignite.cache.affinity.fair.FairAffinityFunction
-
Default partition count.
- DFLT_PARTITION_COUNT - Static variable in class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
-
Default number of partitions.
- DFLT_PATH - Static variable in class org.apache.ignite.spi.discovery.tcp.ipfinder.sharedfs.TcpDiscoverySharedFsIpFinder
-
Default path for discovering of local nodes (testing only).
- DFLT_PER_NODE_BATCH_SIZE - Static variable in class org.apache.ignite.configuration.FileSystemConfiguration
-
Default per node buffer size.
- DFLT_PER_NODE_BUFFER_SIZE - Static variable in interface org.apache.ignite.IgniteDataStreamer
-
Default per node buffer size.
- DFLT_PER_NODE_PARALLEL_BATCH_CNT - Static variable in class org.apache.ignite.configuration.FileSystemConfiguration
-
Default number of per node parallel operations.
- DFLT_PESSIMISTIC_TX_LOG_LINGER - Static variable in class org.apache.ignite.configuration.TransactionConfiguration
-
Default size of pessimistic transactions log.
- DFLT_PORT - Static variable in class org.apache.ignite.igfs.IgfsIpcEndpointConfiguration
-
Default port.
- DFLT_PORT - Static variable in class org.apache.ignite.IgniteJdbcDriver
-
Default port.
- DFLT_PORT - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Default port which node sets listener to (value is 47100).
- DFLT_PORT - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Default port to listen (value is 47500).
- DFLT_PORT_RANGE - Static variable in class org.apache.ignite.configuration.ConnectorConfiguration
-
Default rest port range.
- DFLT_PORT_RANGE - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Default local port range (value is 100).
- DFLT_PORT_RANGE - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Default local port range (value is 100).
- DFLT_PREVENT_STARVATION_ENABLED - Static variable in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
-
Default flag for preventing starvation of lower priority jobs.
- DFLT_PRIORITY - Static variable in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
-
Default priority that will be assigned if job does not have a
priority attribute set (value is 0).
- DFLT_PRIORITY_ATTRIBUTE_KEY - Static variable in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
-
Default priority attribute key (value is grid.task.priority).
- DFLT_PROPS - Static variable in class org.apache.ignite.cache.CachingProvider
-
- DFLT_PUBLIC_KEEP_ALIVE_TIME - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
-
Default keep alive time for public thread pool.
- DFLT_PUBLIC_THREAD_CNT - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
-
Default core size of public thread pool.
- DFLT_PUBLIC_THREADPOOL_QUEUE_CAP - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
-
Default max queue capacity of public thread pool.
- DFLT_QUE_SIZE - Static variable in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
-
Default write queue size in bytes.
- DFLT_READ_FROM_BACKUP - Static variable in class org.apache.ignite.configuration.CacheConfiguration
-
Default value for 'readFromBackup' flag.
- DFLT_REBALANCE_BATCH_SIZE - Static variable in class org.apache.ignite.configuration.CacheConfiguration
-
Default rebalance batch size in bytes.
- DFLT_REBALANCE_BATCHES_PREFETCH_COUNT - Static variable in class org.apache.ignite.configuration.CacheConfiguration
-
Default rebalance batches prefetch count.
- DFLT_REBALANCE_MODE - Static variable in class org.apache.ignite.configuration.CacheConfiguration
-
Default rebalance mode for distributed cache.
- DFLT_REBALANCE_THREAD_POOL_SIZE - Static variable in class org.apache.ignite.configuration.CacheConfiguration
-
Deprecated.
- DFLT_REBALANCE_THREAD_POOL_SIZE - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
-
Default limit of threads used for rebalance.
- DFLT_REBALANCE_THROTTLE - Static variable in class org.apache.ignite.configuration.CacheConfiguration
-
Time in milliseconds to wait between rebalance messages to avoid overloading CPU.
- DFLT_REBALANCE_TIMEOUT - Static variable in class org.apache.ignite.configuration.CacheConfiguration
-
Default rebalance timeout (ms).
- DFLT_RECONNECT_CNT - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Default reconnect attempts count (value is 10).
- DFLT_RECONNECT_CNT - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Default reconnect attempts count (value is 10).
- DFLT_RELAXED_CONSISTENCY - Static variable in class org.apache.ignite.configuration.FileSystemConfiguration
-
Default value of relaxed consistency flag.
- DFLT_RELOGIN_INTERVAL - Static variable in class org.apache.ignite.hadoop.fs.KerberosHadoopFileSystemFactory
-
The default interval used to re-login from the key tab, in milliseconds.
- DFLT_RES_WAIT_TIME - Static variable in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
-
Default time IP finder waits for reply to multicast address request (value is 500).
- DFLT_REST_CORE_THREAD_CNT - Static variable in class org.apache.ignite.configuration.ConnectorConfiguration
-
Default size of REST thread pool.
- DFLT_REST_MAX_THREAD_CNT - Static variable in class org.apache.ignite.configuration.ConnectorConfiguration
-
Default max size of REST thread pool.
- DFLT_RETRIES_ON_FAIL_TIMEOUT - Static variable in class org.apache.ignite.cache.websession.WebSessionFilter
-
Default retry on fail timeout flag value.
- DFLT_SEG_CHK_FREQ - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
-
Default segment check frequency in discovery manager.
- DFLT_SEG_PLC - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
-
Default segmentation policy.
- DFLT_SEG_POOL_SIZE - Static variable in class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
-
- DFLT_SEG_RESOLVE_ATTEMPTS - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
-
Default value segmentation resolve attempts count.
- DFLT_SELECTORS_CNT - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Default count of selectors for TCP server equals to
"Math.min(4, Runtime.getRuntime().availableProcessors())".
- DFLT_SEND_RETRY_CNT - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
-
Default message send retries count.
- DFLT_SEND_RETRY_DELAY - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
-
Default interval between message send retries.
- DFLT_SHMEM_PORT - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Default port which node sets listener for shared memory connections (value is 48100).
- DFLT_SHOW_SQL - Static variable in class org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStore
-
Default show SQL property value (value is true).
- DFLT_SIMPLE_NAME - Static variable in class org.apache.ignite.binary.BinaryBasicNameMapper
-
Default use simple name flag setting.
- DFLT_SOCK_BUF_SIZE - Static variable in class org.apache.ignite.configuration.ConnectorConfiguration
-
Default socket send and receive buffer size.
- DFLT_SOCK_BUF_SIZE - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Default socket send and receive buffer size.
- DFLT_SOCK_TIMEOUT - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Default socket operations timeout in milliseconds (value is 5000ms).
- DFLT_SOCK_TIMEOUT_CLIENT - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Default socket operations timeout in milliseconds (value is 5000ms).
- DFLT_SOCK_WRITE_TIMEOUT - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Default socket write timeout.
- DFLT_SPACE_NAME - Static variable in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
-
Name for null space.
- DFLT_SQL_ONHEAP_ROW_CACHE_SIZE - Static variable in class org.apache.ignite.configuration.CacheConfiguration
-
Default size for onheap SQL row cache size.
- DFLT_SSL_PROTOCOL - Static variable in class org.apache.ignite.ssl.SslContextFactory
-
Default SSL protocol.
- DFLT_START_SIZE - Static variable in class org.apache.ignite.configuration.CacheConfiguration
-
Initial default cache size.
- DFLT_STARVATION_INCREMENT - Static variable in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
-
Default value on which job priority will be increased every time when job gets bumped down.
- DFLT_STATS_PRINT_FREQ - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Default statistics print frequency in milliseconds (value is 0ms).
- DFLT_STORE_KEEP_BINARY - Static variable in class org.apache.ignite.configuration.CacheConfiguration
-
Default value for keep binary in store behavior .
- DFLT_STORE_TYPE - Static variable in class org.apache.ignite.ssl.SslContextFactory
-
Default key store type.
- DFLT_SWAP_ENABLED - Static variable in class org.apache.ignite.configuration.CacheConfiguration
-
Default value for 'swapEnabled' flag.
- DFLT_SYSTEM_CORE_THREAD_CNT - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
-
Default size of system thread pool.
- DFLT_SYSTEM_KEEP_ALIVE_TIME - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
-
Default keep alive time for system thread pool.
- DFLT_SYSTEM_MAX_THREAD_CNT - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
-
Default max size of system thread pool.
- DFLT_SYSTEM_THREADPOOL_QUEUE_CAP - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
-
Default max queue capacity of system thread pool.
- DFLT_TCP_DIRECT_BUF - Static variable in class org.apache.ignite.configuration.ConnectorConfiguration
-
Default TCP direct buffer flag.
- DFLT_TCP_NODELAY - Static variable in class org.apache.ignite.configuration.ConnectorConfiguration
-
Default TCP_NODELAY flag.
- DFLT_TCP_NODELAY - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Default value for TCP_NODELAY socket option (value is true).
- DFLT_TCP_PORT - Static variable in class org.apache.ignite.configuration.ConnectorConfiguration
-
Default TCP server port.
- DFLT_TCP_PORT - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
-
Default TCP server port.
- DFLT_THREAD_CNT - Static variable in class org.apache.ignite.igfs.IgfsIpcEndpointConfiguration
-
Default threads count.
- DFLT_THREAD_PRI - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Default value for thread priority (value is 10).
- DFLT_THREADPOOL_QUEUE_CAP - Static variable in class org.apache.ignite.configuration.ConnectorConfiguration
-
Default max queue capacity of REST thread pool.
- DFLT_THREADS_COUNT - Static variable in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
-
Default number of working threads (equal to the number of available processors).
- DFLT_TIME_INTERVAL - Static variable in class org.apache.ignite.cache.query.ContinuousQuery
-
Maximum default time interval after which buffer will be flushed (if buffering is enabled).
- DFLT_TIME_SERVER_PORT_BASE - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
-
Default time server port base.
- DFLT_TIME_SERVER_PORT_RANGE - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
-
Default time server port range.
- DFLT_TOKEN_DIR_PATH - Static variable in class org.apache.ignite.igfs.IgfsIpcEndpointConfiguration
-
Default token directory.
- DFLT_TOP_HISTORY_SIZE - Static variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Default size of topology snapshots history.
- DFLT_TRANSACTION_TIMEOUT - Static variable in class org.apache.ignite.configuration.TransactionConfiguration
-
Default transaction timeout.
- DFLT_TRASH_PURGE_TIMEOUT - Static variable in class org.apache.ignite.configuration.FileSystemConfiguration
-
Default trash directory purge await timeout in case data cache oversize is detected.
- DFLT_TX_CONCURRENCY - Static variable in class org.apache.ignite.configuration.TransactionConfiguration
-
Default concurrency mode.
- DFLT_TX_ISOLATION - Static variable in class org.apache.ignite.configuration.TransactionConfiguration
-
Default transaction isolation level.
- DFLT_TX_SERIALIZABLE_ENABLED - Static variable in class org.apache.ignite.configuration.TransactionConfiguration
-
Default value for 'txSerializableEnabled' flag.
- DFLT_TYPE - Static variable in class org.apache.ignite.igfs.IgfsIpcEndpointConfiguration
-
Default endpoint type is TCP.
- DFLT_UPDATE_QRY - Static variable in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
-
Default update entry query (value is select * from ENTRIES where key=?
- DFLT_USER_NAME - Static variable in class org.apache.ignite.configuration.FileSystemConfiguration
-
Default file system user name.
- DFLT_UTILITY_KEEP_ALIVE_TIME - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
-
Default keep alive time for utility thread pool.
- DFLT_VALUE_FIELD_NAME - Static variable in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
-
Default checkpoint value field name (value is VALUE).
- DFLT_VALUE_FIELD_TYPE - Static variable in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
-
Default checkpoint value field type (value is BLOB).
- DFLT_WAIT_FOR_SEG_ON_START - Static variable in class org.apache.ignite.configuration.IgniteConfiguration
-
Default value for wait for segment on startup flag.
- DFLT_WAIT_JOBS_NUM - Static variable in class org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpi
-
Default waiting jobs number.
- DFLT_WAIT_JOBS_NUM - Static variable in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
-
Default waiting jobs number.
- DFLT_WAIT_JOBS_THRESHOLD - Static variable in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
-
Default threshold of waiting jobs.
- DFLT_WRITE_ATTEMPTS - Static variable in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
-
Default value for write attempts.
- DFLT_WRITE_BEHIND_BATCH_SIZE - Static variable in class org.apache.ignite.configuration.CacheConfiguration
-
Default batch size for write-behind cache store.
- DFLT_WRITE_BEHIND_CRITICAL_SIZE - Static variable in class org.apache.ignite.configuration.CacheConfiguration
-
Default critical size used when flush size is not specified.
- DFLT_WRITE_BEHIND_ENABLED - Static variable in class org.apache.ignite.configuration.CacheConfiguration
-
Default value for 'writeBehindEnabled' flag.
- DFLT_WRITE_BEHIND_FLUSH_FREQUENCY - Static variable in class org.apache.ignite.configuration.CacheConfiguration
-
Default flush frequency for write-behind cache store in milliseconds.
- DFLT_WRITE_BEHIND_FLUSH_SIZE - Static variable in class org.apache.ignite.configuration.CacheConfiguration
-
Default flush size for write-behind cache store.
- DFLT_WRITE_FROM_BEHIND_FLUSH_THREAD_CNT - Static variable in class org.apache.ignite.configuration.CacheConfiguration
-
Default count of flush threads for write-behind cache store.
- dialect - Variable in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
-
Database dialect.
- DIRECT_DOWNLOAD_LINK - Static variable in class org.apache.ignite.mesos.resource.IgniteProvider
-
- directoriesCount() - Method in interface org.apache.ignite.igfs.IgfsMetrics
-
Gets number of directories created in file system.
- directoriesCount() - Method in class org.apache.ignite.igfs.IgfsPathSummary
-
- directoriesCount(int) - Method in class org.apache.ignite.igfs.IgfsPathSummary
-
- directType() - Method in interface org.apache.ignite.plugin.extensions.communication.Message
-
Gets message type.
- directType() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingRequest
-
Gets message type.
- directType() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.HandshakeMessage
-
Gets message type.
- directType() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.NodeIdMessage
-
Gets message type.
- directType() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.RecoveryLastReceivedMessage
-
Gets message type.
- disableLocal(int...) - Method in interface org.apache.ignite.IgniteEvents
-
Disables provided events.
- disconnect() - Method in interface org.apache.ignite.spi.discovery.DiscoverySpi
-
Tells discovery SPI to disconnect from topology.
- disconnect() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Tells discovery SPI to disconnect from topology.
- disconnected(SchedulerDriver) - Method in class org.apache.ignite.mesos.IgniteScheduler
- discoveryClientMode() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinderAdapter
-
- discoveryEvent() - Method in interface org.apache.ignite.cache.affinity.AffinityFunctionContext
-
Gets discovery event caused topology change.
- DiscoveryEvent - Class in org.apache.ignite.events
-
Grid discovery event.
- DiscoveryEvent() - Constructor for class org.apache.ignite.events.DiscoveryEvent
-
No-arg constructor.
- DiscoveryEvent(ClusterNode, String, int, ClusterNode) - Constructor for class org.apache.ignite.events.DiscoveryEvent
-
Creates new discovery event with given parameters.
- discoveryEventName() - Method in class org.apache.ignite.events.CacheRebalancingEvent
-
Gets name of discovery event that triggered this rebalancing event.
- discoveryEventType() - Method in class org.apache.ignite.events.CacheRebalancingEvent
-
Gets type of discovery event that triggered this rebalancing event.
- DiscoveryMetricsProvider - Interface in org.apache.ignite.spi.discovery
-
Provides metrics to discovery SPI.
- discoveryNode() - Method in class org.apache.ignite.events.CacheRebalancingEvent
-
Gets shadow of the node that triggered this rebalancing event.
- DiscoverySpi - Interface in org.apache.ignite.spi.discovery
-
Grid discovery SPI allows to discover remote nodes in grid.
- DiscoverySpiCustomMessage - Interface in org.apache.ignite.spi.discovery
-
Message to send across ring.
- DiscoverySpiDataExchange - Interface in org.apache.ignite.spi.discovery
-
Handler for initial data exchange between Ignite nodes.
- DiscoverySpiHistorySupport - Annotation Type in org.apache.ignite.spi.discovery
-
This annotation is for all implementations of
DiscoverySpi that support
topology snapshots history.
- DiscoverySpiListener - Interface in org.apache.ignite.spi.discovery
-
Listener for grid node discovery events.
- DiscoverySpiNodeAuthenticator - Interface in org.apache.ignite.spi.discovery
-
Node authenticator.
- DiscoverySpiOrderSupport - Annotation Type in org.apache.ignite.spi.discovery
-
This annotation is for all implementations of
DiscoverySpi that support
proper node ordering.
- discoveryTimestamp() - Method in class org.apache.ignite.events.CacheRebalancingEvent
-
Gets timestamp of discovery event that caused this rebalancing event.
- disk() - Method in class org.apache.ignite.mesos.ClusterProperties
-
- DISK - Static variable in class org.apache.ignite.mesos.IgniteScheduler
-
Disk.
- disk - Variable in class org.apache.ignite.mesos.IgniteTask
-
- disk() - Method in class org.apache.ignite.mesos.IgniteTask
-
- diskPerNode() - Method in class org.apache.ignite.mesos.ClusterProperties
-
- doAs(String, IgniteOutClosure<T>) - Static method in class org.apache.ignite.igfs.IgfsUserContext
-
Executes given callable in the given user context.
- doAs(String, Callable<T>) - Static method in class org.apache.ignite.igfs.IgfsUserContext
-
- doBegin(Object, TransactionDefinition) - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
- doCleanupAfterCompletion(Object) - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
- doCommit(DefaultTransactionStatus) - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
- doFilter(ServletRequest, ServletResponse, FilterChain) - Method in class org.apache.ignite.cache.websession.WebSessionFilter
- doGetTransaction() - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
- doRollback(DefaultTransactionStatus) - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
- DOWNLOAD_LINK - Static variable in class org.apache.ignite.mesos.resource.IgniteProvider
-
- DOWNLOAD_LINK - Static variable in class org.apache.ignite.yarn.IgniteProvider
-
- downloadIgnite(String) - Method in class org.apache.ignite.mesos.resource.IgniteProvider
-
- drainPermits() - Method in interface org.apache.ignite.IgniteSemaphore
-
Acquires and returns all permits that are immediately available.
- dumpDebugInfo() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
-
Dumps debug information for the current node.
- dumpDebugInfo() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Dumps debug info using configured logger.
- dumpDebugInfo() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
-
Dumps debug info using configured logger.
- dumpStats() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Dumps SPI per-connection stats to logs.
- dumpStats() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
-
Dumps SPI per-connection stats to logs.
- duplicateIdError(TcpDiscoveryDuplicateIdMessage) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
- duration() - Method in interface org.apache.ignite.lang.IgniteFuture
-
Gets duration in milliseconds between start of the future and current time if future
is not finished, or between start and finish of this future.
- get(Object, long) - Method in class org.apache.ignite.cache.hibernate.HibernateAbstractRegionAccessStrategy
- get(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyAdapter
-
Gets value from cache.
- get(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateGeneralDataRegion
- get(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateReadWriteAccessStrategy
-
Gets value from cache.
- get(Object) - Method in class org.apache.ignite.cache.hibernate.HibernateTransactionalAccessStrategy
-
Gets value from cache.
- get() - Method in interface org.apache.ignite.compute.ComputeTaskFuture
-
Synchronously waits for completion of the computation and
returns computation result.
- get(long, TimeUnit) - Method in interface org.apache.ignite.compute.ComputeTaskFuture
-
Synchronously waits for completion of the computation for
up to the timeout specified and returns computation result.
- get(String) - Method in class org.apache.ignite.hadoop.fs.BasicHadoopFileSystemFactory
-
Gets file system for the given user name.
- get(String) - Method in class org.apache.ignite.hadoop.fs.CachingHadoopFileSystemFactory
-
Gets file system for the given user name.
- get(String) - Method in interface org.apache.ignite.hadoop.fs.HadoopFileSystemFactory
-
Gets file system for the given user name.
- get(String) - Method in class org.apache.ignite.hadoop.fs.KerberosHadoopFileSystemFactory
-
Gets file system for the given user name.
- get() - Method in interface org.apache.ignite.IgniteAtomicLong
-
Gets current value of atomic long.
- get() - Method in interface org.apache.ignite.IgniteAtomicReference
-
Gets current value of an atomic reference.
- get() - Method in interface org.apache.ignite.IgniteAtomicSequence
-
Gets current value of atomic sequence.
- get() - Method in interface org.apache.ignite.IgniteAtomicStamped
-
Gets both current value and current stamp of atomic stamped.
- get(K) - Method in interface org.apache.ignite.IgniteCache
- get(Object) - Method in class org.apache.ignite.lang.IgniteBiTuple
- get() - Method in interface org.apache.ignite.lang.IgniteFuture
-
Synchronously waits for completion of the computation and
returns computation result.
- get(long) - Method in interface org.apache.ignite.lang.IgniteFuture
-
Synchronously waits for completion of the computation for
up to the timeout specified and returns computation result.
- get(long, TimeUnit) - Method in interface org.apache.ignite.lang.IgniteFuture
-
Synchronously waits for completion of the computation for
up to the timeout specified and returns computation result.
- get() - Method in interface org.apache.ignite.scheduler.SchedulerFuture
-
Waits for the completion of the next scheduled execution and returns its result.
- get(long, TimeUnit) - Method in interface org.apache.ignite.scheduler.SchedulerFuture
-
Waits for the completion of the next scheduled execution for
specified amount of time and returns its result.
- get(String, K) - Method in interface org.apache.ignite.spi.IgniteSpiContext
-
Gets object from cache.
- get0(String) - Method in class org.apache.ignite.hadoop.fs.BasicHadoopFileSystemFactory
-
Internal file system create routine.
- get1() - Method in class org.apache.ignite.lang.IgniteBiTuple
-
Gets first value.
- get2() - Method in class org.apache.ignite.lang.IgniteBiTuple
-
Gets second value.
- GET_ADDRS_QRY - Static variable in class org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc.TcpDiscoveryJdbcIpFinder
-
Query to get addresses.
- getAccessKey() - Method in class org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpi
-
Gets S3 access key.
- getAccessKey() - Method in interface org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpiMBean
-
- getAccessToken() - Method in class org.apache.ignite.stream.twitter.OAuthSettings
-
- getAccessTokenSecret() - Method in class org.apache.ignite.stream.twitter.OAuthSettings
-
- getAckSendThreshold() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Gets number of received messages per connection to node after which acknowledgment message is sent.
- getAckSendThreshold() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
-
Gets number of received messages per connection to node after which acknowledgment message is sent.
- getAckTimeout() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Gets message acknowledgement timeout.
- getAckTimeout() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
-
Gets message acknowledgement timeout.
- getActiveCount() - Method in interface org.apache.ignite.mxbean.ThreadPoolMXBean
-
Returns the approximate number of threads that are actively executing tasks.
- getActiveJobsThreshold() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
-
Gets number of jobs that can be executed in parallel.
- getActiveJobsThreshold() - Method in interface org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpiMBean
-
Gets number of jobs that can be executed in parallel.
- getAddressRequestAttempts() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
-
Gets number of attempts to send multicast address request.
- getAddressResolver() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Gets address resolver for addresses mapping determination.
- getAddressResolver() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Gets address resolver.
- getAffinity() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Gets key topology resolver to provide mapping from keys to nodes.
- getAffinityKey() - Method in class org.apache.ignite.services.ServiceConfiguration
-
Gets affinity key used for key-to-node affinity calculation.
- getAffinityKeyFieldName() - Method in class org.apache.ignite.cache.CacheKeyConfiguration
-
Gets affinity key field name.
- getAffinityKeyFieldName() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryTypeConfiguration
-
- getAffinityMapper() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Affinity key mapper used to provide custom affinity key for any given key.
- getAliases() - Method in class org.apache.ignite.cache.CacheTypeMetadata
-
Deprecated.
Gets aliases mapping.
- getAliases() - Method in class org.apache.ignite.cache.QueryEntity
-
Gets aliases map.
- getAll() - Method in interface org.apache.ignite.cache.query.QueryCursor
-
Gets all query results and stores them in the collection.
- getAll(Set<? extends K>) - Method in interface org.apache.ignite.IgniteCache
- getAllOutTx(Set<? extends K>) - Method in interface org.apache.ignite.IgniteCache
-
Gets values from cache.
- getAndAdd(long) - Method in interface org.apache.ignite.IgniteAtomicLong
-
Gets current value of atomic long and adds l.
- getAndAdd(long) - Method in interface org.apache.ignite.IgniteAtomicSequence
-
Gets current value of atomic sequence and adds l elements.
- getAndDecrement() - Method in interface org.apache.ignite.IgniteAtomicLong
-
Gets and decrements current value of atomic long.
- getAndIncrement() - Method in interface org.apache.ignite.IgniteAtomicLong
-
Gets and increments current value of atomic long.
- getAndIncrement() - Method in interface org.apache.ignite.IgniteAtomicSequence
-
Gets and increments current value of atomic sequence.
- getAndPut(K, V) - Method in interface org.apache.ignite.IgniteCache
- getAndPutIfAbsent(K, V) - Method in interface org.apache.ignite.IgniteCache
-
Stores given key-value pair in cache only if cache had no previous mapping for it.
- getAndRemove(K) - Method in interface org.apache.ignite.IgniteCache
- getAndReplace(K, V) - Method in interface org.apache.ignite.IgniteCache
- getAndSet(long) - Method in interface org.apache.ignite.IgniteAtomicLong
-
Gets current value of atomic long and sets new value l of atomic long.
- getArgs() - Method in class org.apache.ignite.cache.query.SpiQuery
-
Gets SQL arguments.
- getArgs() - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
-
Gets SQL arguments.
- getArgs() - Method in class org.apache.ignite.cache.query.SqlQuery
-
Gets SQL arguments.
- getAscendingFields() - Method in class org.apache.ignite.cache.CacheTypeMetadata
-
Deprecated.
Gets name-to-type map for ascending-indexed fields.
- getAssemblies() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetConfiguration
-
- getAtomicConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
- getAtomicityMode() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Gets cache atomicity mode.
- getAtomicityMode() - Method in class org.apache.ignite.configuration.CollectionConfiguration
-
- getAtomicSequenceReserveSize() - Method in class org.apache.ignite.configuration.AtomicConfiguration
-
- getAtomicWriteOrderMode() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Gets cache write ordering mode.
- getAttribute(K) - Method in interface org.apache.ignite.compute.ComputeJobContext
-
Gets attribute from this job context.
- getAttribute(K) - Method in interface org.apache.ignite.compute.ComputeTaskSession
-
- getAttributes() - Method in interface org.apache.ignite.compute.ComputeJobContext
-
Gets all attributes present in this job context.
- getAttributes() - Method in interface org.apache.ignite.compute.ComputeTaskSession
-
Gets all attributes.
- getAverageActiveJobs() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Gets average number of active jobs concurrently executing on the node.
- getAverageActiveJobs() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Gets average number of active jobs concurrently executing on the node.
- getAverageCancelledJobs() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Gets average number of cancelled jobs this node ever had running
concurrently.
- getAverageCancelledJobs() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Gets average number of cancelled jobs this node ever had running
concurrently.
- getAverageCpuLoad() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Gets average of CPU load values over all metrics kept in the history.
- getAverageCpuLoad() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Gets average of CPU load values over all metrics kept in the history.
- getAverageGetTime() - Method in interface org.apache.ignite.cache.CacheMetrics
-
The mean time to execute gets.
- getAverageGetTime() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
The mean time to execute gets.
- getAverageJobExecuteTime() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Gets average time a job takes to execute on the node.
- getAverageJobExecuteTime() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Gets average time a job takes to execute on the node.
- getAverageJobWaitTime() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Gets average time jobs spend waiting in the queue to be executed.
- getAverageJobWaitTime() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Gets average time jobs spend waiting in the queue to be executed.
- getAveragePutTime() - Method in interface org.apache.ignite.cache.CacheMetrics
-
The mean time to execute puts.
- getAveragePutTime() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
The mean time to execute puts.
- getAverageRejectedJobs() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Gets average number of jobs this node rejects during collision resolution operations.
- getAverageRejectedJobs() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Gets average number of jobs this node rejects during collision resolution operations.
- getAverageRemoveTime() - Method in interface org.apache.ignite.cache.CacheMetrics
-
The mean time to execute removes.
- getAverageRemoveTime() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
The mean time to execute removes.
- getAverageTxCommitTime() - Method in interface org.apache.ignite.cache.CacheMetrics
-
The mean time to execute tx commit.
- getAverageTxCommitTime() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
The mean time to execute tx commit.
- getAverageTxRollbackTime() - Method in interface org.apache.ignite.cache.CacheMetrics
-
The mean time to execute tx rollbacks.
- getAverageTxRollbackTime() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
The mean time to execute tx rollbacks.
- getAverageWaitingJobs() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Gets average number of waiting jobs this node had queued.
- getAverageWaitingJobs() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Gets average number of waiting jobs this node had queued.
- getAvgMessageProcessingTime() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Gets avg message processing time.
- getAvgMessageProcessingTime() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
-
Gets avg message processing time.
- getBackupFilter() - Method in class org.apache.ignite.cache.affinity.fair.FairAffinityFunction
-
Gets optional backup filter.
- getBackupFilter() - Method in class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
-
Gets optional backup filter.
- getBackups() - Method in class org.apache.ignite.configuration.AtomicConfiguration
-
- getBackups() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
- getBackups() - Method in class org.apache.ignite.configuration.CollectionConfiguration
-
- getBalancedNode(ComputeJob, Collection<ClusterNode>) - Method in interface org.apache.ignite.compute.ComputeLoadBalancer
-
Gets the next balanced node according to the underlying load balancing policy.
- getBalancedNode(List<ClusterNode>) - Method in interface org.apache.ignite.spi.failover.FailoverContext
-
Gets the next balanced node for failed job.
- getBalancedNode(ComputeTaskSession, List<ClusterNode>, ComputeJob) - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveLoadBalancingSpi
-
Gets balanced node for specified job within given task session.
- getBalancedNode(ComputeTaskSession, List<ClusterNode>, ComputeJob) - Method in interface org.apache.ignite.spi.loadbalancing.LoadBalancingSpi
-
Gets balanced node for specified job within given task session.
- getBalancedNode(ComputeTaskSession, List<ClusterNode>, ComputeJob) - Method in class org.apache.ignite.spi.loadbalancing.roundrobin.RoundRobinLoadBalancingSpi
-
Gets balanced node for specified job within given task session.
- getBalancedNode(ComputeTaskSession, List<ClusterNode>, ComputeJob) - Method in class org.apache.ignite.spi.loadbalancing.weightedrandom.WeightedRandomLoadBalancingSpi
-
Gets balanced node for specified job within given task session.
- getBaseDirectory() - Method in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
-
Gets base directory.
- getBaseDirectory() - Method in interface org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpiMBean
-
Gets base directory.
- getBasePath() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.zk.TcpDiscoveryZookeeperIpFinder
-
- getBatchQueueSize() - Method in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
-
Returns batch queue size.
- getBatchSize() - Method in class org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicy
-
Gets batch size.
- getBatchSize() - Method in interface org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicyMBean
-
Gets batch size.
- getBatchSize() - Method in class org.apache.ignite.cache.eviction.lru.LruEvictionPolicy
-
Gets batch size.
- getBatchSize() - Method in interface org.apache.ignite.cache.eviction.lru.LruEvictionPolicyMBean
-
Gets batch size.
- getBatchSize() - Method in class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicy
-
Gets batch size.
- getBatchSize() - Method in interface org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicyMBean
-
Gets batch size.
- getBatchSize() - Method in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
-
Returns batch size.
- getBatchSize() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
-
Get maximum batch size for delete and delete operations.
- getBatchSize() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
-
Get maximum batch size for delete and delete operations.
- getBinaryConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Gets configuration for Ignite Binary objects.
- getBinaryConfiguration() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetConfiguration
-
- getBlockSize() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Get file's data block size.
- getBoolean(String) - Static method in class org.apache.ignite.IgniteSystemProperties
-
Gets either system property or environment variable with given name.
- getBoolean(String, boolean) - Static method in class org.apache.ignite.IgniteSystemProperties
-
Gets either system property or environment variable with given name.
- getBrokerUrl() - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
-
Gets the broker URL.
- getBucketName() - Method in class org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpi
-
Gets S3 bucket name to use.
- getBucketName() - Method in interface org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpiMBean
-
Gets S3 bucket name to use.
- getBundle() - Method in class org.apache.ignite.osgi.classloaders.BundleDelegatingClassLoader
-
Returns the Bundle to which this ClassLoader is associated.
- getBusyTimePercentage() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Gets percentage of time this node is busy executing jobs vs. idling.
- getBusyTimePercentage() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Gets percentage of time this node is busy executing jobs vs. idling.
- getCache(String, Class<K>, Class<V>) - Method in class org.apache.ignite.cache.CacheManager
- getCache(String) - Method in class org.apache.ignite.cache.CacheManager
- getCache(String) - Method in class org.apache.ignite.cache.spring.SpringCacheManager
- getCacheConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Gets configuration (descriptors) for all caches.
- getCacheDataDescription() - Method in class org.apache.ignite.cache.hibernate.HibernateTransactionalDataRegion
- getCacheEntryListenerConfigurations() - Method in class org.apache.ignite.configuration.CacheConfiguration
- getCacheEvictions() - Method in interface org.apache.ignite.cache.CacheMetrics
-
The total number of evictions from the cache.
- getCacheEvictions() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
The total number of evictions from the cache.
- getCacheGets() - Method in interface org.apache.ignite.cache.CacheMetrics
-
The total number of requests to the cache.
- getCacheGets() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
The total number of requests to the cache.
- getCacheHitPercentage() - Method in interface org.apache.ignite.cache.CacheMetrics
-
This is a measure of cache efficiency.
- getCacheHitPercentage() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
This is a measure of cache efficiency.
- getCacheHits() - Method in interface org.apache.ignite.cache.CacheMetrics
-
The number of get requests that were satisfied by the cache.
- getCacheHits() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
The number of get requests that were satisfied by the cache.
- getCacheKeyConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Gets cache key configuration.
- getCacheManager(URI, ClassLoader, Properties) - Method in class org.apache.ignite.cache.CachingProvider
- getCacheManager(URI, ClassLoader) - Method in class org.apache.ignite.cache.CachingProvider
- getCacheManager() - Method in class org.apache.ignite.cache.CachingProvider
- getCacheMisses() - Method in interface org.apache.ignite.cache.CacheMetrics
-
A miss is a get request that is not satisfied.
- getCacheMisses() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
A miss is a get request that is not satisfied.
- getCacheMissPercentage() - Method in interface org.apache.ignite.cache.CacheMetrics
-
Returns the percentage of cache accesses that did not find a requested entry
in the cache.
- getCacheMissPercentage() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
Returns the percentage of cache accesses that did not find a requested entry
in the cache.
- getCacheMode() - Method in class org.apache.ignite.configuration.AtomicConfiguration
-
- getCacheMode() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Gets caching mode to use.
- getCacheMode() - Method in class org.apache.ignite.configuration.CollectionConfiguration
-
- getCacheName() - Method in class org.apache.ignite.cache.store.jdbc.JdbcType
-
Gets associated cache name.
- getCacheName() - Method in class org.apache.ignite.services.ServiceConfiguration
-
Gets cache name used for key-to-node affinity calculation.
- getCacheName() - Method in class org.apache.ignite.spi.checkpoint.cache.CacheCheckpointSpi
-
Gets cache name to be used by this SPI..
- getCacheName() - Method in interface org.apache.ignite.spi.checkpoint.cache.CacheCheckpointSpiMBean
-
Gets cache name to be used by this SPI..
- getCacheNames() - Method in class org.apache.ignite.cache.CacheManager
- getCacheNames() - Method in class org.apache.ignite.cache.spring.SpringCacheManager
- getCachePuts() - Method in interface org.apache.ignite.cache.CacheMetrics
-
The total number of puts to the cache.
- getCachePuts() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
The total number of puts to the cache.
- getCacheRemovals() - Method in interface org.apache.ignite.cache.CacheMetrics
-
The total number of removals from the cache.
- getCacheRemovals() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
The total number of removals from the cache.
- getCacheStoreFactory() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Gets factory for underlying persistent storage for read-through and write-through operations.
- getCacheStoreSessionListenerFactories() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Gets cache store session listener factories.
- getCacheStoreSessionListenerFactories() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Gets cache store session listener factories.
- getCacheTxCommits() - Method in interface org.apache.ignite.cache.CacheMetrics
-
Gets total number of transaction commits.
- getCacheTxCommits() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
Gets total number of transaction commits.
- getCacheTxRollbacks() - Method in interface org.apache.ignite.cache.CacheMetrics
-
Gets total number of transaction rollbacks.
- getCacheTxRollbacks() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
Gets total number of transaction rollbacks.
- getCachingProvider() - Method in class org.apache.ignite.cache.CacheManager
- getCamelContext() - Method in class org.apache.ignite.stream.camel.CamelStreamer
-
Gets the underlying CamelContext, whether created automatically by Ignite or the context specified by the
user.
- getCause(Class<T>) - Method in exception org.apache.ignite.IgniteCheckedException
-
Gets first exception of given class from 'cause' hierarchy if any.
- getCause(Class<T>) - Method in exception org.apache.ignite.IgniteException
-
Gets first exception of given class from 'cause' hierarchy if any.
- getCause(Class<T>) - Method in exception org.apache.ignite.IgniteIllegalStateException
-
Gets first exception of given class from 'cause' hierarchy if any.
- getCheckpointSpi() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Should return fully configured checkpoint SPI implementation.
- getCheckpointSpiFormatted() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
-
Gets a formatted instance of configured checkpoint SPI implementation.
- getCheckpointTableName() - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
-
Gets checkpoint table name.
- getCheckpointTableName() - Method in interface org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpiMBean
-
Gets checkpoint table name.
- getClass(int, ClassLoader) - Method in interface org.apache.ignite.marshaller.MarshallerContext
-
Gets class for provided type ID.
- getClassFilter() - Method in class org.apache.ignite.compute.gridify.aop.spring.GridifySpringPointcut
- getClassLoader() - Method in class org.apache.ignite.cache.CacheManager
- getClassLoader() - Method in interface org.apache.ignite.compute.ComputeTaskSession
-
Gets class loader responsible for loading all classes within task.
- getClassLoader() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
- getClassLoader() - Method in interface org.apache.ignite.spi.deployment.DeploymentResource
-
Gets resource class loader.
- getClassLoader() - Method in class org.apache.ignite.spi.deployment.DeploymentResourceAdapter
-
Gets resource class loader.
- getClassName() - Method in class org.apache.ignite.cache.jta.reflect.CacheReflectionTmLookup
-
Gets class name to use.
- getClient(BlockingQueue<String>) - Method in class org.apache.ignite.stream.twitter.TwitterStreamer
-
- getClientId() - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
-
Gets the client ID, either the one set by the user or the automatically generated one.
- getClockSyncFrequency() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Gets frequency at which clock is synchronized between nodes, in milliseconds.
- getClockSyncSamples() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Gets number of samples used to synchronize clocks between different nodes.
- getCollisionSpi() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Should return fully configured collision SPI implementation.
- getCollisionSpiFormatted() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
-
Gets a formatted instance of configured collision SPI implementations.
- getColumnValue(ResultSet, int, Class<?>) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
-
Retrieves the value of the designated column in the current row of this ResultSet object and
will convert to the requested Java data type.
- getCommunicationSpi() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Should return fully configured SPI communication implementation.
- getCommunicationSpiFormatted() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
-
Gets a formatted instance of fully configured SPI communication implementation.
- getCompletedTaskCount() - Method in interface org.apache.ignite.mxbean.ThreadPoolMXBean
-
Returns the approximate total number of tasks that have completed execution.
- getComponentClass() - Method in class org.apache.ignite.configuration.IgniteReflectionFactory
-
- getConfigPaths() - Method in class org.apache.ignite.hadoop.fs.BasicHadoopFileSystemFactory
-
Gets paths to additional file system configuration files (e.g. core-site.xml).
- getConfiguration() - Method in class org.apache.ignite.cache.spring.SpringCacheManager
-
Gets configuration bean.
- getConfiguration(Class<C>) - Method in interface org.apache.ignite.IgniteCache
- getConfiguration() - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
-
Gets configuration bean.
- getConfigurationPath() - Method in class org.apache.ignite.cache.spring.SpringCacheManager
-
Gets configuration file path.
- getConfigurationPath() - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
-
Gets configuration file path.
- getConnectionBufferFlushFrequency() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Deprecated.
- getConnectionBufferFlushFrequency() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
-
Deprecated.
Not used anymore.
- getConnectionBufferSize() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Deprecated.
- getConnectionBufferSize() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
-
Deprecated.
Not used anymore.
- getConnectOptions() - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
-
Gets the currently used MQTT client connect options.
- getConnectorConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
- getConnectTimeout() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Gets connect timeout used when establishing connection
with remote nodes.
- getConnectTimeout() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
-
Gets connect timeout used when establishing connection
with remote nodes.
- getConsistentAttributeNames() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
-
Returns back a list of attributes that should be consistent
for this SPI.
- getConsistentAttributeNames() - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
-
Returns back a list of attributes that should be consistent
for this SPI.
- getConsistentAttributeNames() - Method in class org.apache.ignite.spi.failover.always.AlwaysFailoverSpi
-
Returns back a list of attributes that should be consistent
for this SPI.
- getConsistentAttributeNames() - Method in class org.apache.ignite.spi.failover.jobstealing.JobStealingFailoverSpi
-
Returns back a list of attributes that should be consistent
for this SPI.
- getConsistentAttributeNames() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
-
Returns back a list of attributes that should be consistent
for this SPI.
- getConsistentAttributeNames() - Method in class org.apache.ignite.spi.loadbalancing.weightedrandom.WeightedRandomLoadBalancingSpi
-
Returns back a list of attributes that should be consistent
for this SPI.
- getConsistentId() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Gets consistent globally unique node ID which survives node restarts.
- getConsumerKey() - Method in class org.apache.ignite.stream.twitter.OAuthSettings
-
- getConsumerSecret() - Method in class org.apache.ignite.stream.twitter.OAuthSettings
-
- getContainers() - Method in class org.apache.ignite.yarn.ApplicationMaster
-
Deprecated.
- getContentSummary(Path) - Method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
- getCoordinator() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Gets current coordinator.
- getCoordinator() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
-
Gets current coordinator.
- getCoordinatorSinceTimestamp() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Gets time local node has been coordinator since.
- getCoordinatorSinceTimestamp() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
-
Gets time local node has been coordinator since.
- getCopyright() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
-
Gets copyright statement for Ignite product.
- getCorePoolSize() - Method in interface org.apache.ignite.mxbean.ThreadPoolMXBean
-
Returns the core number of threads.
- getCurrentActiveJobs() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Gets number of currently active jobs concurrently executing on the node.
- getCurrentActiveJobs() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Gets number of currently active jobs concurrently executing on the node.
- getCurrentActiveJobsNumber() - Method in class org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpi
-
Gets current number of jobs that are active, i.e.
- getCurrentActiveJobsNumber() - Method in interface org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpiMBean
-
Gets current number of jobs that are active, i.e.
- getCurrentActiveJobsNumber() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
-
Gets current number of jobs that are being executed.
- getCurrentActiveJobsNumber() - Method in interface org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpiMBean
-
Gets current number of jobs that are being executed.
- getCurrentActiveJobsNumber() - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
-
Gets current number of jobs that are active, i.e.
- getCurrentActiveJobsNumber() - Method in interface org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpiMBean
-
Gets current number of jobs that are active, i.e.
- getCurrentBlocks() - Method in class org.apache.ignite.cache.eviction.igfs.IgfsPerBlockLruEvictionPolicy
-
Gets current amount of blocks.
- getCurrentBlocks() - Method in interface org.apache.ignite.cache.eviction.igfs.IgfsPerBlockLruEvictionPolicyMXBean
-
Gets current amount of blocks.
- getCurrentCancelledJobs() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Gets number of cancelled jobs that are still running.
- getCurrentCancelledJobs() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Gets number of cancelled jobs that are still running.
- getCurrentCpuLoad() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Returns the CPU usage usage in [0, 1] range.
- getCurrentCpuLoad() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Returns the CPU usage usage in [0, 1] range.
- getCurrentDaemonThreadCount() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Returns the current number of live daemon threads.
- getCurrentDaemonThreadCount() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Returns the current number of live daemon threads.
- getCurrentDirectoryPath() - Method in class org.apache.ignite.spi.checkpoint.sharedfs.SharedFsCheckpointSpi
-
Gets path to the directory where all checkpoints are saved.
- getCurrentDirectoryPath() - Method in interface org.apache.ignite.spi.checkpoint.sharedfs.SharedFsCheckpointSpiMBean
-
Gets path to the directory where all checkpoints are saved.
- getCurrentGcCpuLoad() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Returns average time spent in CG since the last update.
- getCurrentGcCpuLoad() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Returns average time spent in CG since the last update.
- getCurrentHeldJobsNumber() - Method in class org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpi
-
Gets number of currently 'held' jobs.
- getCurrentHeldJobsNumber() - Method in interface org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpiMBean
-
Gets number of currently 'held' jobs.
- getCurrentHeldJobsNumber() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
-
Gets number of currently 'held' jobs.
- getCurrentHeldJobsNumber() - Method in interface org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpiMBean
-
Gets number of currently 'held' jobs.
- getCurrentHeldJobsNumber() - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
-
Gets number of currently 'held' jobs.
- getCurrentHeldJobsNumber() - Method in interface org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpiMBean
-
Gets number of currently 'held' jobs.
- getCurrentIdleTime() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Gets time this node spend idling since executing last job.
- getCurrentIdleTime() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Gets time this node spend idling since executing last job.
- getCurrentJobExecuteTime() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Gets longest time a current job has been executing for.
- getCurrentJobExecuteTime() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Gets longest time a current job has been executing for.
- getCurrentJobsToStealNumber() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
-
Gets current number of jobs to be stolen.
- getCurrentJobsToStealNumber() - Method in interface org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpiMBean
-
Gets current number of jobs to be stolen.
- getCurrentJobWaitTime() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Gets current time an oldest jobs has spent waiting to be executed.
- getCurrentJobWaitTime() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Gets current time an oldest jobs has spent waiting to be executed.
- getCurrentMemorySize() - Method in class org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicy
-
Gets current queue size in bytes.
- getCurrentMemorySize() - Method in interface org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicyMBean
-
Gets current queue size in bytes.
- getCurrentMemorySize() - Method in class org.apache.ignite.cache.eviction.lru.LruEvictionPolicy
-
Gets current queue size in bytes.
- getCurrentMemorySize() - Method in interface org.apache.ignite.cache.eviction.lru.LruEvictionPolicyMBean
-
Gets current queue size in bytes.
- getCurrentMemorySize() - Method in class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicy
-
Gets current sorted entries queue size in bytes.
- getCurrentMemorySize() - Method in interface org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicyMBean
-
Gets current sorted entries queue size in bytes.
- getCurrentRejectedJobs() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Gets number of jobs rejected after more recent collision resolution operation.
- getCurrentRejectedJobs() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Gets number of jobs rejected after more recent collision resolution operation.
- getCurrentRunningJobsNumber() - Method in class org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpi
- getCurrentRunningJobsNumber() - Method in interface org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpiMBean
-
- getCurrentRunningJobsNumber() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
- getCurrentRunningJobsNumber() - Method in interface org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpiMBean
-
- getCurrentRunningJobsNumber() - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
- getCurrentRunningJobsNumber() - Method in interface org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpiMBean
-
- getCurrentSize() - Method in class org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicy
-
Gets current queue size.
- getCurrentSize() - Method in interface org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicyMBean
-
Gets current queue size.
- getCurrentSize() - Method in class org.apache.ignite.cache.eviction.igfs.IgfsPerBlockLruEvictionPolicy
-
Gets current size of data in all blocks.
- getCurrentSize() - Method in interface org.apache.ignite.cache.eviction.igfs.IgfsPerBlockLruEvictionPolicyMXBean
-
Gets current size of data in all blocks.
- getCurrentSize() - Method in class org.apache.ignite.cache.eviction.lru.LruEvictionPolicy
-
Gets current queue size.
- getCurrentSize() - Method in interface org.apache.ignite.cache.eviction.lru.LruEvictionPolicyMBean
-
Gets current queue size.
- getCurrentSize() - Method in class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicy
-
Gets current size.
- getCurrentSize() - Method in interface org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicyMBean
-
Gets current size.
- getCurrentThreadCount() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Returns the current number of live threads including both
daemon and non-daemon threads.
- getCurrentThreadCount() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Returns the current number of live threads including both
daemon and non-daemon threads.
- getCurrentWaitingJobs() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Gets number of queued jobs currently waiting to be executed.
- getCurrentWaitingJobs() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Gets number of queued jobs currently waiting to be executed.
- getCurrentWaitJobsNumber() - Method in class org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpi
-
Gets current number of jobs that wait for the execution.
- getCurrentWaitJobsNumber() - Method in interface org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpiMBean
-
Gets current number of jobs that wait for the execution.
- getCurrentWaitJobsNumber() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
-
Gets current number of jobs that wait for the execution.
- getCurrentWaitJobsNumber() - Method in interface org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpiMBean
-
Gets current number of jobs that wait for the execution.
- getCurrentWaitJobsNumber() - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
-
Gets current number of jobs that wait for the execution.
- getCurrentWaitJobsNumber() - Method in interface org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpiMBean
-
Gets current number of jobs that wait for the execution.
- getData() - Method in interface org.apache.ignite.compute.ComputeJobResult
-
Gets data returned by remote job if it didn't fail.
- getDatabaseFieldName() - Method in class org.apache.ignite.cache.store.jdbc.JdbcTypeField
-
- getDatabaseFieldType() - Method in class org.apache.ignite.cache.store.jdbc.JdbcTypeField
-
- getDatabaseName() - Method in class org.apache.ignite.cache.CacheTypeFieldMetadata
-
- getDatabaseSchema() - Method in class org.apache.ignite.cache.CacheTypeMetadata
-
Deprecated.
Gets database schema name.
- getDatabaseSchema() - Method in class org.apache.ignite.cache.store.jdbc.JdbcType
-
Gets database schema name.
- getDatabaseTable() - Method in class org.apache.ignite.cache.CacheTypeMetadata
-
Deprecated.
Gets table name in database.
- getDatabaseTable() - Method in class org.apache.ignite.cache.store.jdbc.JdbcType
-
Gets table name in database.
- getDatabaseType() - Method in class org.apache.ignite.cache.CacheTypeFieldMetadata
-
- getDataCacheName() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Cache name to store IGFS data.
- getDataSource() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
-
- getDataSource() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcStoreSessionListener
-
Gets data source.
- getDataSource() - Method in class org.apache.ignite.cache.store.spring.CacheSpringStoreSessionListener
-
Gets data source.
- getDataSourceBean() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
-
Gets name of the data source bean.
- getDataSourceInfo() - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
-
Gets data source description.
- getDataSourceInfo() - Method in interface org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpiMBean
-
Gets data source description.
- getDefaultAccessType() - Method in class org.apache.ignite.cache.hibernate.HibernateRegionFactory
- getDefaultBlockSize() - Method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
- getDefaultClassLoader() - Method in class org.apache.ignite.cache.CachingProvider
- getDefaultIdMapper() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryConfiguration
-
- getDefaultLockTimeout() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Gets default lock acquisition timeout.
- getDefaultMode() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Gets mode to specify how IGFS interacts with Hadoop file system, like HDFS.
- getDefaultNameMapper() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryConfiguration
-
- getDefaultPriority() - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
-
Gets default priority to use if a job does not have priority attribute
set.
- getDefaultPriority() - Method in interface org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpiMBean
-
Gets default priority to use if a job does not have priority attribute
set.
- getDefaultProperties() - Method in class org.apache.ignite.cache.CachingProvider
- getDefaultReplication() - Method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
- getDefaultSerializer() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryConfiguration
-
- getDefaultTxConcurrency() - Method in class org.apache.ignite.configuration.TransactionConfiguration
-
Default cache transaction concurrency to use when one is not explicitly
specified.
- getDefaultTxIsolation() - Method in class org.apache.ignite.configuration.TransactionConfiguration
-
Default cache transaction isolation to use when one is not explicitly
specified.
- getDefaultTxTimeout() - Method in class org.apache.ignite.configuration.TransactionConfiguration
-
Gets default transaction timeout.
- getDefaultURI() - Method in class org.apache.ignite.cache.CachingProvider
- getDefaultUserName() - Method in class org.apache.ignite.hadoop.fs.IgniteHadoopIgfsSecondaryFileSystem
-
Gets default user name.
- getDeploymentMode() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Gets deployment mode for deploying tasks and other classes on this node.
- getDeploymentSpi() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Should return fully configured deployment SPI implementation.
- getDeploymentSpiFormatted() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
-
Gets a formatted instance of fully configured deployment SPI implementation.
- getDescendingFields() - Method in class org.apache.ignite.cache.CacheTypeMetadata
-
Deprecated.
Gets name-to-type map for descending-indexed fields.
- getDhtEvictQueueCurrentSize() - Method in interface org.apache.ignite.cache.CacheMetrics
-
Gets current size of evict queue used to batch up evictions.
- getDhtEvictQueueCurrentSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
Gets current size of evict queue used to batch up evictions.
- getDialect() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
-
Get database dialect.
- getDialect() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
-
Get database dialect.
- getDirectoryPaths() - Method in class org.apache.ignite.spi.checkpoint.sharedfs.SharedFsCheckpointSpi
-
Gets collection of all configured paths where checkpoints can be saved.
- getDirectoryPaths() - Method in interface org.apache.ignite.spi.checkpoint.sharedfs.SharedFsCheckpointSpiMBean
-
Gets collection of all configured paths where checkpoints can be saved.
- getDisabledTrustManager() - Static method in class org.apache.ignite.ssl.SslContextFactory
-
Returns an instance of trust manager that will always succeed regardless of certificate provided.
- getDisconnectForciblyTimeout() - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
-
Gets the timeout if disconnecting forcibly.
- getDisconnectQuiesceTimeout() - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
-
Gets the disconnect quiesce timeout.
- getDiscoveryPort() - Method in class org.apache.ignite.startup.BasicWarmupClosure
-
Gets discovery port for warmup.
- getDiscoverySpi() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Should return fully configured discovery SPI implementation.
- getDiscoverySpiFormatted() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
-
Gets a formatted instance of configured discovery SPI implementation.
- getDiscoveryStartupDelay() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
This value is used to expire messages from waiting list whenever node
discovery discrepancies happen.
- getDouble(String, double) - Static method in class org.apache.ignite.IgniteSystemProperties
-
Gets either system property or environment variable with given name.
- getDualModeMaxPendingPutsSize() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Get maximum amount of pending data read from the secondary file system and waiting to be written to data
cache.
- getDualModePutExecutorService() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Get DUAL mode put operation executor service.
- getDualModePutExecutorServiceShutdown() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Get DUAL mode put operation executor service shutdown flag.
- getDynamicCacheConfiguration() - Method in class org.apache.ignite.cache.spring.SpringCacheManager
-
Gets dynamic cache configuration template.
- getDynamicNearCacheConfiguration() - Method in class org.apache.ignite.cache.spring.SpringCacheManager
-
Gets dynamic near cache configuration template.
- getElementCountInMemory() - Method in class org.apache.ignite.cache.hibernate.HibernateRegion
- getElementCountOnDisk() - Method in class org.apache.ignite.cache.hibernate.HibernateRegion
- getEndpointUri() - Method in class org.apache.ignite.stream.camel.CamelStreamer
-
Gets the endpoint URI from which to consume.
- getEndTime() - Method in interface org.apache.ignite.compute.ComputeTaskSession
-
Gets end of computation time for the task.
- getEntries(Set<? extends K>) - Method in interface org.apache.ignite.IgniteCache
-
Gets a collection of entries from the Cache.
- getEntry(K) - Method in interface org.apache.ignite.IgniteCache
-
Gets an entry from the cache.
- getError() - Method in interface org.apache.ignite.cluster.ClusterStartNodeResult
-
Gets error message if any.
- getEventStorageSpi() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Should return fully configured event SPI implementation.
- getEventStorageSpiFormatted() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
-
Gets a formatted instance of fully configured event SPI implementation.
- getEvictionFilter() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
- getEvictionPolicy() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Gets cache eviction policy.
- getEvictMaxOverflowRatio() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
This value denotes the maximum size of eviction queue in percents of cache
size in case of distributed cache (replicated and partitioned) and using
synchronized eviction (that is if
CacheConfiguration.isEvictSynchronized() returns
true).
- getEvictSynchronizedConcurrencyLevel() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Gets concurrency level for synchronized evictions.
- getEvictSynchronizedKeyBufferSize() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Gets size of the key buffer for synchronized evictions.
- getEvictSynchronizedTimeout() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Gets timeout for synchronized evictions.
- getException() - Method in interface org.apache.ignite.compute.ComputeJobResult
-
Gets exception produced by execution of remote job, or null if
remote execution finished normally and did not produce any exceptions.
- getExceptionRegistry() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
-
Gets Exception registry.
- getExcludePaths() - Method in class org.apache.ignite.cache.eviction.igfs.IgfsPerBlockLruEvictionPolicy
-
Gets collection of regex for paths whose blocks must not be evicted.
- getExcludePaths() - Method in interface org.apache.ignite.cache.eviction.igfs.IgfsPerBlockLruEvictionPolicyMXBean
-
Gets collection of regex for paths whose blocks must not be evicted.
- getExecutorServiceFormatted() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
-
Gets a formatted instance of fully configured thread pool that is used in grid.
- getExpireAgeMs() - Method in class org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpi
-
Gets event time-to-live value.
- getExpireAgeMs() - Method in interface org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpiMBean
-
Gets event time-to-live value.
- getExpireCount() - Method in class org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpi
-
Gets maximum event queue size.
- getExpireCount() - Method in interface org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpiMBean
-
Gets maximum event queue size.
- getExpireDateFieldName() - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
-
Gets expiration date field name for checkpoint table.
- getExpireDateFieldName() - Method in interface org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpiMBean
-
Gets expiration date field name for checkpoint table.
- getExpireDateFieldType() - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
-
Gets expiration date field type for checkpoint table.
- getExpireDateFieldType() - Method in interface org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpiMBean
-
Gets expiration date field type for checkpoint table.
- getExternalAddresses(InetSocketAddress) - Method in interface org.apache.ignite.configuration.AddressResolver
-
Maps internal address to a collection of external addresses.
- getFailoverSpi() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Should return fully configured failover SPI implementation.
- getFailoverSpiFormatted() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
-
Gets a formatted instance of fully configured failover SPI implementations.
- getFailureDetectionTimeout() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
- getField(String) - Method in interface org.apache.ignite.binary.BinaryObjectBuilder
-
Returns value assigned to the specified field.
- getFieldNames() - Method in class org.apache.ignite.cache.QueryIndex
-
- getFields() - Method in class org.apache.ignite.cache.QueryEntity
-
Gets query fields for this query pair.
- getFields() - Method in class org.apache.ignite.cache.QueryIndex
-
Gets fields included in the index.
- getFileBlockLocations(FileStatus, long, long) - Method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
- getFileBlockLocations(Path, long, long) - Method in class org.apache.ignite.hadoop.fs.v2.IgniteHadoopFileSystem
- getFileChecksum(Path) - Method in class org.apache.ignite.hadoop.fs.v2.IgniteHadoopFileSystem
- getFileStatus(Path) - Method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
- getFileStatus(Path) - Method in class org.apache.ignite.hadoop.fs.v2.IgniteHadoopFileSystem
- getFileSystemConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Gets IGFS (Ignite In-Memory File System) configurations.
- getFileSystemFactory() - Method in class org.apache.ignite.hadoop.fs.IgniteHadoopIgfsSecondaryFileSystem
-
Gets secondary file system factory.
- getFilter() - Method in class org.apache.ignite.cache.query.ScanQuery
-
Gets filter.
- getFilter() - Method in class org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpi
-
Gets filter for events to be recorded.
- getFinishedJobInfoTtl() - Method in class org.apache.ignite.configuration.HadoopConfiguration
-
Gets finished job info time-to-live in milliseconds.
- getFragmentizerConcurrentFiles() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Gets number of files that can be processed by fragmentizer concurrently.
- getFragmentizerLocalWritesRatio() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Deprecated.
Parameter is no longer used.
- getFragmentizerThrottlingBlockLength() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Gets the length of file chunk to send before delaying the fragmentizer.
- getFragmentizerThrottlingDelay() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Gets throttle delay for fragmentizer.
- getFsHadoopUser() - Static method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
-
Gets non-null user name as per the Hadoop file system viewpoint.
- getFsStatus() - Method in class org.apache.ignite.hadoop.fs.v2.IgniteHadoopFileSystem
- getFullVersion() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
-
Gets string presentation of the version.
- getGridCount() - Method in class org.apache.ignite.startup.BasicWarmupClosure
-
Gets number of grids to start and run warmup.
- getGridLogger() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Should return an instance of logger to use in grid.
- getGridLoggerFormatted() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
-
Gets a formatted instance of logger that is in grid.
- getGridName() - Method in class org.apache.ignite.cache.spring.SpringCacheManager
-
Gets grid name.
- getGridName() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Gets optional grid name.
- getGridName() - Method in class org.apache.ignite.thread.IgniteThread
-
Gets name of the grid this thread belongs to.
- getGridName() - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
-
Gets grid name.
- getGridStartTime() - Method in interface org.apache.ignite.spi.discovery.DiscoverySpi
-
Gets start time of the very first node in the grid.
- getGridStartTime() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Gets start time of the very first node in the grid.
- getGroups() - Method in class org.apache.ignite.cache.CacheTypeMetadata
-
Deprecated.
Gets group-indexed fields.
- getHadoopConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Gets hadoop configuration.
- getHasher() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
-
Gets hash code calculator.
- getHasher() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
-
Gets hash code calculator.
- getHashIdResolver() - Method in class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
-
Deprecated.
- getHeapMemoryCommitted() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Returns the amount of heap memory in bytes that is committed for
the JVM to use.
- getHeapMemoryCommitted() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Returns the amount of heap memory in bytes that is committed for
the JVM to use.
- getHeapMemoryInitialized() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Returns the amount of heap memory in bytes that the JVM
initially requests from the operating system for memory management.
- getHeapMemoryInitialized() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Returns the amount of heap memory in bytes that the JVM
initially requests from the operating system for memory management.
- getHeapMemoryMaximum() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Returns the maximum amount of heap memory in bytes that can be
used for memory management.
- getHeapMemoryMaximum() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Returns the maximum amount of heap memory in bytes that can be
used for memory management.
- getHeapMemoryTotal() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Returns the total amount of heap memory in bytes.
- getHeapMemoryTotal() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Returns the total amount of heap memory in bytes.
- getHeapMemoryUsed() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Returns the current heap size that is used for object allocation.
- getHeapMemoryUsed() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Returns the current heap size that is used for object allocation.
- getHeartbeatFrequency() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Gets delay between heartbeat messages sent by coordinator.
- getHeartbeatFrequency() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
-
Gets delay between heartbeat messages sent by coordinator.
- getHibernateConfigurationPath() - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateStoreSessionListener
-
Gets hibernate configuration path.
- getHomeDirectory() - Method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
- getHost() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
-
Gets host for TCP binary protocol server.
- getHost() - Method in class org.apache.ignite.igfs.IgfsIpcEndpointConfiguration
-
Gets the host endpoint is bound to.
- getHostName() - Method in interface org.apache.ignite.cluster.ClusterStartNodeResult
-
Gets host name.
- getId() - Method in interface org.apache.ignite.compute.ComputeTaskSession
-
Gets session ID of the task being executed.
- getIdleConnectionTimeout() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Gets maximum idle connection time upon which idle connections
will be closed.
- getIdleConnectionTimeout() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
-
Gets maximum idle connection time upon which idle connections
will be closed.
- getIdleQueryCursorCheckFrequency() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
-
Gets idle query cursors check frequency.
- getIdleQueryCursorTimeout() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
-
Gets idle query cursors timeout in milliseconds.
- getIdleTimeout() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
-
Gets idle timeout for REST server.
- getIdleTimePercentage() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Gets percentage of time this node is idling vs. executing jobs.
- getIdleTimePercentage() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Gets percentage of time this node is idling vs. executing jobs.
- getIdMapper() - Method in class org.apache.ignite.binary.BinaryTypeConfiguration
-
Gets ID mapper.
- getIdMapper() - Method in class org.apache.ignite.configuration.BinaryConfiguration
-
Gets ID mapper.
- getIdMapper() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryTypeConfiguration
-
- getIgfsThreadPoolSize() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Size of thread pool that is in charge of processing outgoing IGFS messages.
- getIgnite() - Method in class org.apache.ignite.mesos.resource.IgniteProvider
-
- getIgnite(String) - Method in class org.apache.ignite.mesos.resource.IgniteProvider
-
- getIgnite() - Method in class org.apache.ignite.stream.StreamAdapter
-
- getIgnite() - Method in class org.apache.ignite.yarn.IgniteProvider
-
- getIgnite(String) - Method in class org.apache.ignite.yarn.IgniteProvider
-
- getIgniteHome() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Should return Ignite installation home folder.
- getIgniteHome() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
-
Gets Ignite installation home folder.
- getIgniteHome() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
-
Gets Ignite installation home folder (i.e.
- getIgniteHome() - Method in interface org.apache.ignite.spi.IgniteSpiManagementMBean
-
Gets Ignite installation home folder (i.e.
- getIncludeEventTypes() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Gets array of event types, which will be recorded.
- getIncludeProperties() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Gets array of system or environment properties to include into node attributes.
- getIndexedTypes() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Array of key and value type pairs to be indexed (thus array length must be always even).
- getIndexes() - Method in class org.apache.ignite.cache.QueryEntity
-
Gets a collection of index entities.
- getIndexingSpi() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Should return fully configured indexing SPI implementations.
- getIndexType() - Method in class org.apache.ignite.cache.QueryIndex
-
Gets index type.
- getInitialContextEnvironment() - Method in class org.apache.ignite.cache.jta.jndi.CacheJndiTmFactory
-
Gets initial context environment map.
- getInitialQuery() - Method in class org.apache.ignite.cache.query.ContinuousQuery
-
Gets initial query.
- getInstanceName() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
-
Gets optional kernal instance name.
- getInteger(String, int) - Static method in class org.apache.ignite.IgniteSystemProperties
-
Gets either system property or environment variable with given name.
- getInterceptor() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Gets cache interceptor.
- getIpcEndpointConfiguration() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Gets IPC endpoint configuration.
- getIpFinder() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Gets IP finder for IP addresses sharing and storing.
- getIpFinderCleanFrequency() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Gets IP finder clean frequency.
- getIpFinderCleanFrequency() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
-
Gets IP finder clean frequency.
- getIpFinderFormatted() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
- getIpFinderFormatted() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
-
- getIterationCount() - Method in class org.apache.ignite.startup.BasicWarmupClosure
-
Gets iteration count for warmup.
- getJavaFieldName() - Method in class org.apache.ignite.cache.store.jdbc.JdbcTypeField
-
- getJavaFieldType() - Method in class org.apache.ignite.cache.store.jdbc.JdbcTypeField
-
- getJavaName() - Method in class org.apache.ignite.cache.CacheTypeFieldMetadata
-
- getJavaType() - Method in class org.apache.ignite.cache.CacheTypeFieldMetadata
-
- getJdkInformation() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
-
Gets JDK information.
- getJettyPath() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
-
Gets path, either absolute or relative to IGNITE_HOME, to Jetty
XML configuration file.
- getJndiNames() - Method in class org.apache.ignite.cache.jta.jndi.CacheJndiTmFactory
-
Gets a list of JNDI names.
- getJndiNames() - Method in class org.apache.ignite.cache.jta.jndi.CacheJndiTmLookup
-
Gets a list of JNDI names.
- getJob() - Method in interface org.apache.ignite.compute.ComputeJobResult
-
- getJob() - Method in interface org.apache.ignite.spi.collision.CollisionJobContext
-
Job for this context.
- getJobContext() - Method in interface org.apache.ignite.compute.ComputeJobResult
-
Gets job context.
- getJobContext() - Method in interface org.apache.ignite.spi.collision.CollisionJobContext
-
Gets job context.
- getJobId() - Method in interface org.apache.ignite.compute.ComputeJobContext
-
Gets ID of the job this context belongs to.
- getJobId() - Method in interface org.apache.ignite.compute.ComputeJobSibling
-
Gets ID of this grid job sibling.
- getJobPriorityAttributeKey() - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
-
Gets key name of job priority attribute.
- getJobPriorityAttributeKey() - Method in interface org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpiMBean
-
Gets key name of job priority attribute.
- getJobResult() - Method in interface org.apache.ignite.spi.failover.FailoverContext
-
Gets failed result of job execution.
- getJobSibling(IgniteUuid) - Method in interface org.apache.ignite.compute.ComputeTaskSession
-
Gets job sibling for a given ID.
- getJobSiblings() - Method in interface org.apache.ignite.compute.ComputeTaskSession
-
Gets a collection of all grid job siblings.
- getJoinTimeout() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Gets join timeout.
- getJoinTimeout() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
-
Gets join timeout.
- getKeepAliveTime() - Method in interface org.apache.ignite.mxbean.ThreadPoolMXBean
-
Returns the thread keep-alive time, which is the amount of time which threads
in excess of the core pool size may remain idle before being terminated.
- getKeepDeserialized() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryTypeConfiguration
-
Gets keep deserialized flag.
- getKey() - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStoreEntry
-
- getKey() - Method in class org.apache.ignite.lang.IgniteBiTuple
- getKeyAlgorithm() - Method in class org.apache.ignite.ssl.SslContextFactory
-
Gets algorithm that will be used to create a key manager.
- getKeyFieldName() - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
-
Gets key field name for checkpoint table.
- getKeyFieldName() - Method in interface org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpiMBean
-
Gets key field name for checkpoint table.
- getKeyFields() - Method in class org.apache.ignite.cache.CacheTypeMetadata
-
Deprecated.
- getKeyFields() - Method in class org.apache.ignite.cache.store.jdbc.JdbcType
-
- getKeyFieldType() - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
-
Gets key field type for checkpoint table.
- getKeyFieldType() - Method in interface org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpiMBean
-
Gets key field type for checkpoint table.
- getKeyRange() - Method in class org.apache.ignite.startup.BasicWarmupClosure
-
Gets key range.
- getKeySize() - Method in interface org.apache.ignite.cache.CacheMetrics
-
Gets number of keys in the cache, possibly with null values.
- getKeySize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
Gets number of keys in the cache, possibly with null values.
- getKeyStoreFilePath() - Method in class org.apache.ignite.ssl.SslContextFactory
-
Gets path to the key store file.
- getKeyStorePassword() - Method in class org.apache.ignite.ssl.SslContextFactory
-
Gets key store password.
- getKeyStoreType() - Method in class org.apache.ignite.ssl.SslContextFactory
-
Gets key store type used for context creation.
- getKeyTab() - Method in class org.apache.ignite.hadoop.fs.KerberosHadoopFileSystemFactory
-
Gets the key tab full file name (e.g.
- getKeyTabPrincipal() - Method in class org.apache.ignite.hadoop.fs.KerberosHadoopFileSystemFactory
-
Gets the key tab principal short name (e.g.
- getKeyType() - Method in interface org.apache.ignite.cache.CacheMetrics
-
Determines the required type of keys for this Cache, if any.
- getKeyType() - Method in class org.apache.ignite.cache.CacheTypeMetadata
-
Deprecated.
Gets key type.
- getKeyType() - Method in class org.apache.ignite.cache.QueryEntity
-
Gets key type for this query pair.
- getKeyType() - Method in class org.apache.ignite.cache.store.jdbc.JdbcType
-
Gets key type.
- getKeyType() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
Determines the required type of keys for this Cache, if any.
- getLargestPoolSize() - Method in interface org.apache.ignite.mxbean.ThreadPoolMXBean
-
Returns the largest number of threads that have ever
simultaneously been in the pool.
- getLastDataVersion() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
In-Memory Data Grid assigns incremental versions to all cache operations.
- getLastDataVersion() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
In-Memory Data Grid assigns incremental versions to all cache operations.
- getLastUpdateTime() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Gets last update time of this node metrics.
- getLastUpdateTime() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Gets last update time of this node metrics.
- getLifecycleBeans() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Returns a collection of life-cycle beans.
- getLifecycleBeansFormatted() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
-
Gets toString() representation of of lifecycle beans configured
with Ignite.
- getListener() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
- getLoad(ClusterNode, int) - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveCpuLoadProbe
-
Calculates load value for a given node.
- getLoad(ClusterNode, int) - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveJobCountLoadProbe
-
Calculates load value for a given node.
- getLoad(ClusterNode, int) - Method in interface org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveLoadProbe
-
Calculates load value for a given node.
- getLoad(ClusterNode, int) - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveProcessingTimeLoadProbe
-
Calculates load value for a given node.
- getLoadBalancingSpi() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Should return fully configured load balancing SPI implementation.
- getLoadBalancingSpiFormatted() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
-
Gets a formatted instance of fully configured load balancing SPI implementations.
- getLoadProbeFormatted() - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveLoadBalancingSpi
-
Gets text description of current load probing implementation used.
- getLoadProbeFormatted() - Method in interface org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveLoadBalancingSpiMBean
-
Gets text description of current load probing implementation used.
- getLocalAddress() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Gets local host address for socket binding.
- getLocalAddress() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
-
Gets local host address for socket binding.
- getLocalAddress() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
-
Gets local address that multicast IP finder uses.
- getLocalAddress() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
- getLocalEventListeners() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Gets map of pre-configured local event listeners.
- getLocalHost() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Gets system-wide local address or host for all Ignite components to bind to.
- getLocalListener() - Method in class org.apache.ignite.cache.query.ContinuousQuery
-
Gets local listener.
- getLocalNode() - Method in interface org.apache.ignite.spi.discovery.DiscoverySpi
-
Gets local node.
- getLocalNode() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Gets local node.
- getLocalNode() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
-
- getLocalNodeId() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
-
Unique identifier for this node within grid.
- getLocalNodeId() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
-
Gets ID of the local node.
- getLocalNodeId() - Method in interface org.apache.ignite.spi.IgniteSpiManagementMBean
-
Gets ID of the local node.
- getLocalPort() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Gets local port for socket binding.
- getLocalPort() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
-
Gets local port for socket binding.
- getLocalPort() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Gets local TCP port SPI listens to.
- getLocalPort() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
-
Gets local TCP port SPI listens to.
- getLocalPortRange() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Gets maximum number of local ports tried if all previously
tried ports are occupied.
- getLocalPortRange() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
-
Gets maximum number of local ports tried if all previously
tried ports are occupied.
- getLocalPortRange() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Gets local TCP port range.
- getLocalPortRange() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
-
Gets local TCP port range.
- getLogger(Object) - Method in interface org.apache.ignite.IgniteLogger
-
Creates new logger with given category based off the current instance.
- getLogger(Object) - Method in class org.apache.ignite.logger.java.JavaLogger
-
Creates new logger with given category based off the current instance.
- getLogger(Object) - Method in class org.apache.ignite.logger.jcl.JclLogger
-
Creates new logger with given category based off the current instance.
- getLogger(Object) - Method in class org.apache.ignite.logger.log4j.Log4JLogger
-
Gets
IgniteLogger wrapper around log4j logger for the given
category.
- getLogger(Object) - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
-
Gets
IgniteLogger wrapper around log4j logger for the given
category.
- getLogger(Object) - Method in class org.apache.ignite.logger.NullLogger
-
Creates new logger with given category based off the current instance.
- getLogger(Object) - Method in class org.apache.ignite.logger.slf4j.Slf4jLogger
-
Creates new logger with given category based off the current instance.
- getLogin() - Method in class org.apache.ignite.plugin.security.SecurityCredentials
-
Gets login.
- getLong(String, long) - Static method in class org.apache.ignite.IgniteSystemProperties
-
Gets either system property or environment variable with given name.
- getLongQueryWarningTimeout() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Gets timeout in milliseconds after which long query warning will be printed.
- getMajorVersion() - Method in class org.apache.ignite.IgniteJdbcDriver
- getManagementPort() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Gets port number for management endpoint.
- getManagementThreadPoolSize() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Size of thread pool that is in charge of processing internal and Visor
GridJobs.
- getMapReducePlanner() - Method in class org.apache.ignite.configuration.HadoopConfiguration
-
Gets Hadoop map-reduce planner, a component which defines job execution plan based on job
configuration and current grid topology.
- getMarshaller() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Should return an instance of marshaller to use in grid.
- getMarshallerCacheKeepAliveTime() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Keep alive time of thread pool that is in charge of processing marshaller messages.
- getMarshallerCacheThreadPoolSize() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Default size of thread pool that is in charge of processing marshaller messages.
- getMaxAckTimeout() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Gets maximum message acknowledgement timeout.
- getMaxAckTimeout() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
-
Gets maximum message acknowledgement timeout.
- getMaxBlocks() - Method in class org.apache.ignite.cache.eviction.igfs.IgfsPerBlockLruEvictionPolicy
-
Gets maximum allowed amount of blocks.
- getMaxBlocks() - Method in interface org.apache.ignite.cache.eviction.igfs.IgfsPerBlockLruEvictionPolicyMXBean
-
Gets maximum allowed amount of blocks.
- getMaxConcurrentAsyncOperations() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Gets maximum number of allowed concurrent asynchronous operations.
- getMaxConnectTimeout() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Gets maximum connect timeout.
- getMaxConnectTimeout() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
-
Gets maximum connect timeout.
- getMaximumActiveJobs() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Gets maximum number of jobs that ever ran concurrently on this node.
- getMaximumActiveJobs() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Gets maximum number of jobs that ever ran concurrently on this node.
- getMaximumCancelledJobs() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Gets maximum number of cancelled jobs this node ever had running
concurrently.
- getMaximumCancelledJobs() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Gets maximum number of cancelled jobs this node ever had running
concurrently.
- getMaximumFailoverAttempts() - Method in class org.apache.ignite.spi.failover.always.AlwaysFailoverSpi
-
Gets maximum number of attempts to execute a failed job on another node.
- getMaximumFailoverAttempts() - Method in interface org.apache.ignite.spi.failover.always.AlwaysFailoverSpiMBean
-
Gets maximum number of attempts to execute a failed job on another node.
- getMaximumFailoverAttempts() - Method in class org.apache.ignite.spi.failover.jobstealing.JobStealingFailoverSpi
-
Gets maximum number of attempts to execute a failed job on another node.
- getMaximumFailoverAttempts() - Method in interface org.apache.ignite.spi.failover.jobstealing.JobStealingFailoverSpiMBean
-
Gets maximum number of attempts to execute a failed job on another node.
- getMaximumJobExecuteTime() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Gets time it took to execute the longest job on the node.
- getMaximumJobExecuteTime() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Gets time it took to execute the longest job on the node.
- getMaximumJobWaitTime() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Gets maximum time a job ever spent waiting in a queue to be executed.
- getMaximumJobWaitTime() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Gets maximum time a job ever spent waiting in a queue to be executed.
- getMaximumPoolSize() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
-
Get Max workers thread count.
- getMaximumPoolSize() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
-
Get maximum workers thread count.
- getMaximumPoolSize() - Method in interface org.apache.ignite.mxbean.ThreadPoolMXBean
-
Returns the maximum allowed number of threads.
- getMaximumRejectedJobs() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Gets maximum number of jobs rejected at once during a single collision resolution
operation.
- getMaximumRejectedJobs() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Gets maximum number of jobs rejected at once during a single collision resolution
operation.
- getMaximumSparsity() - Method in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
-
Gets maximum sparsity.
- getMaximumSparsity() - Method in interface org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpiMBean
-
Gets maximum sparsity.
- getMaximumStealingAttempts() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
-
Gets maximum number of attempts to steal job by another node.
- getMaximumStealingAttempts() - Method in interface org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpiMBean
-
Gets maximum number of attempts to steal job by another node.
- getMaximumTaskRangeLength() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Get maximum default range size of a file being split during IGFS task execution.
- getMaximumThreadCount() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Returns the maximum live thread count since the JVM
started or peak was reset.
- getMaximumThreadCount() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Returns the maximum live thread count since the JVM
started or peak was reset.
- getMaximumWaitingJobs() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Gets maximum number of waiting jobs this node had.
- getMaximumWaitingJobs() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Gets maximum number of waiting jobs this node had.
- getMaximumWriteAttempts() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
-
Gets maximum number of write attempts in case of database error.
- getMaximumWriteAttempts() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
-
Gets maximum number of write attempts in case of database error.
- getMaxMemorySize() - Method in class org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicy
-
Gets maximum allowed cache size in bytes.
- getMaxMemorySize() - Method in interface org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicyMBean
-
Gets maximum allowed cache size in bytes.
- getMaxMemorySize() - Method in class org.apache.ignite.cache.eviction.lru.LruEvictionPolicy
-
Gets maximum allowed cache size in bytes.
- getMaxMemorySize() - Method in interface org.apache.ignite.cache.eviction.lru.LruEvictionPolicyMBean
-
Gets maximum allowed cache size in bytes.
- getMaxMemorySize() - Method in class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicy
-
Gets maximum allowed cache size in bytes.
- getMaxMemorySize() - Method in interface org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicyMBean
-
Gets maximum allowed cache size in bytes.
- getMaxMessageProcessingTime() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Gets max message processing time.
- getMaxMessageProcessingTime() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
-
Gets max message processing time.
- getMaxMissedClientHeartbeats() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Gets max heartbeats count node can miss without failing client node.
- getMaxMissedClientHeartbeats() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
-
Gets max heartbeats count node can miss without failing client node.
- getMaxMissedHeartbeats() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Gets max heartbeats count node can miss without initiating status check.
- getMaxMissedHeartbeats() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
-
Gets max heartbeats count node can miss without initiating status check.
- getMaxParallelTasks() - Method in class org.apache.ignite.configuration.HadoopConfiguration
-
Gets max number of local tasks that may be executed in parallel.
- getMaxParameterCount() - Method in class org.apache.ignite.cache.store.jdbc.dialect.BasicJdbcDialect
-
Get max query parameters count.
- getMaxParameterCount() - Method in interface org.apache.ignite.cache.store.jdbc.dialect.JdbcDialect
-
Get max query parameters count.
- getMaxPerNodeCount() - Method in class org.apache.ignite.services.ServiceConfiguration
-
Gets maximum number of deployed service instances on each node, 0 for unlimited.
- getMaxSize() - Method in class org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicy
-
Gets maximum allowed size of cache before entry will start getting evicted.
- getMaxSize() - Method in interface org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicyMBean
-
Gets maximum allowed cache size.
- getMaxSize() - Method in class org.apache.ignite.cache.eviction.igfs.IgfsPerBlockLruEvictionPolicy
-
Gets maximum allowed size of all blocks in bytes.
- getMaxSize() - Method in interface org.apache.ignite.cache.eviction.igfs.IgfsPerBlockLruEvictionPolicyMXBean
-
Gets maximum allowed size of all blocks in bytes.
- getMaxSize() - Method in class org.apache.ignite.cache.eviction.lru.LruEvictionPolicy
-
Gets maximum allowed size of cache before entry will start getting evicted.
- getMaxSize() - Method in interface org.apache.ignite.cache.eviction.lru.LruEvictionPolicyMBean
-
Gets maximum allowed cache size.
- getMaxSize() - Method in class org.apache.ignite.cache.eviction.random.RandomEvictionPolicy
-
Deprecated.
Gets maximum allowed size of cache before entry will start getting evicted.
- getMaxSize() - Method in interface org.apache.ignite.cache.eviction.random.RandomEvictionPolicyMBean
-
Gets maximum allowed cache size.
- getMaxSize() - Method in class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicy
-
Gets maximum allowed size of cache before entry will start getting evicted.
- getMaxSize() - Method in interface org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicyMBean
-
Gets maximum allowed cache size.
- getMaxSpaceSize() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Get maximum space available for data cache to store file system entries.
- getMaxTaskQueueSize() - Method in class org.apache.ignite.configuration.HadoopConfiguration
-
Gets max task queue size.
- getMaxWriteQueueSize() - Method in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
-
Gets max write queue size in bytes.
- getMaxWriteQueueSize() - Method in interface org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpiMBean
-
Gets max write queue size in bytes.
- getMBeanServer() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Should return MBean server instance.
- getMBeanServerFormatted() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
-
Gets a formatted instance of MBean server instance.
- getMemoryMode() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Gets memory mode for cache.
- getMemoryMode() - Method in class org.apache.ignite.configuration.CollectionConfiguration
-
- getMemorySize() - Method in class org.apache.ignite.igfs.IgfsIpcEndpointConfiguration
-
Gets shared memory size in bytes allocated for endpoint communication.
- getMessageExpireTime() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
-
Message expire time configuration parameter.
- getMessageExpireTime() - Method in interface org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpiMBean
-
Message expire time configuration parameter.
- getMessageInterceptor() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
-
Gets interceptor for objects, moving to and from remote clients.
- getMessageQueueLimit() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Gets message queue limit for incoming and outgoing messages.
- getMessageQueueLimit() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
-
Gets message queue limit for incoming and outgoing messages.
- getMessageWorkerQueueSize() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Gets message worker queue current size.
- getMessageWorkerQueueSize() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
-
Gets message worker queue current size.
- getMetaCacheName() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Cache name to store IGFS meta information.
- getMethodClass() - Method in class org.apache.ignite.compute.gridify.aop.GridifyArgumentAdapter
-
Gets class to which the executed method belongs.
- getMethodClass() - Method in interface org.apache.ignite.compute.gridify.GridifyArgument
-
Gets class to which the executed method belongs.
- getMethodMatcher() - Method in class org.apache.ignite.compute.gridify.aop.spring.GridifySpringPointcut
- getMethodName() - Method in class org.apache.ignite.cache.jta.reflect.CacheReflectionTmLookup
-
Gets method name.
- getMethodName() - Method in class org.apache.ignite.compute.gridify.aop.GridifyArgumentAdapter
-
Gets method name.
- getMethodName() - Method in interface org.apache.ignite.compute.gridify.GridifyArgument
-
Gets method name.
- getMethodParameters() - Method in class org.apache.ignite.compute.gridify.aop.GridifyArgumentAdapter
-
Gets method parameters in the same order they appear in method
signature.
- getMethodParameters() - Method in interface org.apache.ignite.compute.gridify.GridifyArgument
-
Gets method parameters in the same order they appear in method
signature.
- getMethodParameterTypes() - Method in class org.apache.ignite.compute.gridify.aop.GridifyArgumentAdapter
-
Gets method parameter types in the same order they appear in method
signature.
- getMethodParameterTypes() - Method in interface org.apache.ignite.compute.gridify.GridifyArgument
-
Gets method parameter types in the same order they appear in method
signature.
- getMetricsExpireTime() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Elapsed time in milliseconds after which node metrics are considered expired.
- getMetricsHistorySize() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Number of node metrics to keep in memory to calculate totals and averages.
- getMetricsLogFrequency() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Gets frequency of metrics log print out.
- getMetricsUpdateFrequency() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Gets job metrics update frequency in milliseconds.
- getMinimumBufferedMessageCount() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Deprecated.
- getMinimumBufferedMessageCount() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
-
Deprecated.
Not used anymore.
- getMinorVersion() - Method in class org.apache.ignite.IgniteJdbcDriver
- getMulticastGroup() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
-
Gets IP address of multicast group.
- getMulticastPort() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
-
Gets port number which multicast messages are sent to.
- getMultipleTupleExtractor() - Method in class org.apache.ignite.stream.StreamAdapter
-
- getName() - Method in class org.apache.ignite.cache.hibernate.HibernateRegion
- getName() - Method in class org.apache.ignite.cache.QueryIndex
-
Gets index name.
- getName() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Cache name or
null if not provided, then this will be considered a default
cache which can be accessed via
Ignite.cache(String) method.
- getName() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Gets IGFS instance name.
- getName() - Method in class org.apache.ignite.services.ServiceConfiguration
-
Gets service name.
- getName() - Method in interface org.apache.ignite.spi.deployment.DeploymentResource
-
Gets resource name, either class name or alias name, such as alias
specified by
ComputeTaskName annotation.
- getName() - Method in class org.apache.ignite.spi.deployment.DeploymentResourceAdapter
-
Gets resource name, either class name or alias name, such as alias
specified by
ComputeTaskName annotation.
- getName() - Method in interface org.apache.ignite.spi.IgniteSpi
-
Gets SPI name.
- getName() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
-
Gets SPI name.
- getName() - Method in interface org.apache.ignite.spi.IgniteSpiManagementMBean
-
Gets name of the SPI.
- getNameMapper() - Method in class org.apache.ignite.binary.BinaryTypeConfiguration
-
Gets name mapper.
- getNameMapper() - Method in class org.apache.ignite.configuration.BinaryConfiguration
-
Gets name mapper.
- getNameMapper() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryTypeConfiguration
-
- getNearConfiguration() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
- getNearEvictionPolicy() - Method in class org.apache.ignite.configuration.NearCacheConfiguration
-
Gets near eviction policy.
- getNearStartSize() - Method in class org.apache.ignite.configuration.NearCacheConfiguration
-
Gets initial cache size for near cache which will be used to pre-create internal
hash table after start.
- getNetworkSendRetryCount() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Message send retries count.
- getNetworkSendRetryDelay() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Interval in milliseconds between message send retries.
- getNetworkTimeout() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Maximum timeout in milliseconds for network requests.
- getNetworkTimeout() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Gets network timeout.
- getNetworkTimeout() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
-
Gets network timeout.
- getNode() - Method in interface org.apache.ignite.compute.ComputeJobResult
-
Gets node this job executed on.
- getNode(UUID) - Method in interface org.apache.ignite.spi.discovery.DiscoverySpi
-
Gets node by ID.
- getNode(UUID) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Gets node by ID.
- getNodeAttributes() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
-
- getNodeAttributes() - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
-
- getNodeAttributes() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
- getNodeAttributes() - Method in class org.apache.ignite.spi.failover.always.AlwaysFailoverSpi
-
- getNodeAttributes() - Method in class org.apache.ignite.spi.failover.jobstealing.JobStealingFailoverSpi
-
- getNodeAttributes() - Method in interface org.apache.ignite.spi.IgniteSpi
-
- getNodeAttributes() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
-
- getNodeAttributes() - Method in class org.apache.ignite.spi.loadbalancing.weightedrandom.WeightedRandomLoadBalancingSpi
-
- getNodeFilter() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Gets filter which determines on what nodes the cache should be started.
- getNodeFilter() - Method in class org.apache.ignite.configuration.CollectionConfiguration
-
- getNodeFilter() - Method in class org.apache.ignite.services.ServiceConfiguration
-
Gets node filter used to filter nodes on which the service will be deployed.
- getNodeId() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Deprecated.
- getNodeId() - Method in class org.apache.ignite.logger.java.JavaLogger
-
Gets node ID.
- getNodeId() - Method in class org.apache.ignite.logger.log4j.Log4JLogger
-
Gets node ID.
- getNodeId() - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
-
Gets node ID.
- getNodeId() - Method in interface org.apache.ignite.logger.LoggerNodeIdAware
-
Gets node ID.
- getNodesFailed() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Gets failed nodes count.
- getNodesFailed() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
-
Gets failed nodes count.
- getNodesJoined() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Gets joined nodes count.
- getNodesJoined() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
-
Gets joined nodes count.
- getNodesLeft() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Gets left nodes count.
- getNodesLeft() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
-
Gets left nodes count.
- getNodeStartTime() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Returns the start time of grid node in milliseconds.
- getNodeStartTime() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Returns the start time of grid node in milliseconds.
- getNodeWeight() - Method in class org.apache.ignite.spi.loadbalancing.weightedrandom.WeightedRandomLoadBalancingSpi
-
Gets weight of this node.
- getNodeWeight() - Method in interface org.apache.ignite.spi.loadbalancing.weightedrandom.WeightedRandomLoadBalancingSpiMBean
-
Gets weight of this node.
- getNonHeapMemoryCommitted() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Returns the amount of non-heap memory in bytes that is committed for
the JVM to use.
- getNonHeapMemoryCommitted() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Returns the amount of non-heap memory in bytes that is committed for
the JVM to use.
- getNonHeapMemoryInitialized() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Returns the amount of non-heap memory in bytes that the JVM
initially requests from the operating system for memory management.
- getNonHeapMemoryInitialized() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Returns the amount of non-heap memory in bytes that the JVM
initially requests from the operating system for memory management.
- getNonHeapMemoryMaximum() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Returns the maximum amount of non-heap memory in bytes that can be
used for memory management.
- getNonHeapMemoryMaximum() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Returns the maximum amount of non-heap memory in bytes that can be
used for memory management.
- getNonHeapMemoryTotal() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Returns the total amount of non-heap memory in bytes that can be
used for memory management.
- getNonHeapMemoryTotal() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Returns the total amount of non-heap memory in bytes that can be
used for memory management.
- getNonHeapMemoryUsed() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Returns the current non-heap memory size that is used by Java VM.
- getNonHeapMemoryUsed() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Returns the current non-heap memory size that is used by Java VM.
- getNonLoopbackAddress() - Static method in class org.apache.ignite.mesos.ClusterProperties
-
Finds a local, non-loopback, IPv4 address
- getNumberOfRetries() - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
-
Gets number of retries in case of DB failure.
- getNumberOfRetries() - Method in interface org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpiMBean
-
Gets number of retries in case of DB failure.
- getOffHeapAllocatedSize() - Method in interface org.apache.ignite.cache.CacheMetrics
-
Gets memory size allocated in off-heap.
- getOffHeapAllocatedSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
Gets memory size allocated in off-heap.
- getOffHeapBackupEntriesCount() - Method in interface org.apache.ignite.cache.CacheMetrics
-
Gets number of backup entries stored in off-heap memory.
- getOffHeapBackupEntriesCount() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
Gets number of backup entries stored in off-heap memory.
- getOffHeapEntriesCount() - Method in interface org.apache.ignite.cache.CacheMetrics
-
Gets number of entries stored in off-heap memory.
- getOffHeapEntriesCount() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
Gets number of entries stored in off-heap memory.
- getOffHeapEvictions() - Method in interface org.apache.ignite.cache.CacheMetrics
-
The total number of evictions from the off-heap memory.
- getOffHeapEvictions() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
The total number of evictions from the off-heap memory.
- getOffHeapGets() - Method in interface org.apache.ignite.cache.CacheMetrics
-
The total number of get requests to the off-heap memory.
- getOffHeapGets() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
The total number of get requests to the off-heap memory.
- getOffHeapHitPercentage() - Method in interface org.apache.ignite.cache.CacheMetrics
-
Gets the percentage of hits on off-heap memory.
- getOffHeapHitPercentage() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
Gets the percentage of hits on off-heap memory.
- getOffHeapHits() - Method in interface org.apache.ignite.cache.CacheMetrics
-
The number of get requests that were satisfied by the off-heap memory.
- getOffHeapHits() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
The number of get requests that were satisfied by the off-heap memory.
- getOffHeapMaxMemory() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Gets maximum amount of memory available to off-heap storage.
- getOffHeapMaxMemory() - Method in class org.apache.ignite.configuration.CollectionConfiguration
-
- getOffHeapMaxSize() - Method in interface org.apache.ignite.cache.CacheMetrics
-
Gets off-heap memory maximum size.
- getOffHeapMaxSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
Gets off-heap memory maximum size.
- getOffHeapMisses() - Method in interface org.apache.ignite.cache.CacheMetrics
-
A miss is a get request that is not satisfied by off-heap memory.
- getOffHeapMisses() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
A miss is a get request that is not satisfied by off-heap memory.
- getOffHeapMissPercentage() - Method in interface org.apache.ignite.cache.CacheMetrics
-
Gets the percentage of misses on off-heap memory.
- getOffHeapMissPercentage() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
Gets the percentage of misses on off-heap memory.
- getOffHeapPrimaryEntriesCount() - Method in interface org.apache.ignite.cache.CacheMetrics
-
Gets number of primary entries stored in off-heap memory.
- getOffHeapPrimaryEntriesCount() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
Gets number of primary entries stored in off-heap memory.
- getOffHeapPuts() - Method in interface org.apache.ignite.cache.CacheMetrics
-
The total number of put requests to the off-heap memory.
- getOffHeapPuts() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
The total number of put requests to the off-heap memory.
- getOffHeapRemovals() - Method in interface org.apache.ignite.cache.CacheMetrics
-
The total number of removals from the off-heap memory.
- getOffHeapRemovals() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
The total number of removals from the off-heap memory.
- getOrCreateCache(CacheConfiguration<K, V>) - Method in interface org.apache.ignite.Ignite
-
Gets existing cache with the given name or creates new one with the given configuration.
- getOrCreateCache(String) - Method in interface org.apache.ignite.Ignite
-
Gets existing cache with the given name or creates new one using template configuration.
- getOrCreateCache(CacheConfiguration<K, V>, NearCacheConfiguration<K, V>) - Method in interface org.apache.ignite.Ignite
-
Gets existing cache with the given cache configuration or creates one if it does not exist.
- getOrCreateCache(CacheConfiguration<K, V>) - Method in class org.apache.ignite.IgniteSpringBean
-
Gets existing cache with the given name or creates new one with the given configuration.
- getOrCreateCache(CacheConfiguration<K, V>, NearCacheConfiguration<K, V>) - Method in class org.apache.ignite.IgniteSpringBean
-
Gets existing cache with the given cache configuration or creates one if it does not exist.
- getOrCreateCache(String) - Method in class org.apache.ignite.IgniteSpringBean
-
Gets existing cache with the given name or creates new one using template configuration.
- getOrCreateNearCache(String, NearCacheConfiguration<K, V>) - Method in interface org.apache.ignite.Ignite
-
Gets existing near cache with the given name or creates a new one.
- getOrCreateNearCache(String, NearCacheConfiguration<K, V>) - Method in class org.apache.ignite.IgniteSpringBean
-
Gets existing near cache with the given name or creates a new one.
- getOsInformation() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
-
Gets OS information.
- getOsUser() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
-
Gets OS user.
- getOutboundMessagesQueueSize() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Gets outbound messages queue size.
- getOutboundMessagesQueueSize() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Gets outbound messages queue size.
- getOutboundMessagesQueueSize() - Method in interface org.apache.ignite.spi.communication.CommunicationSpi
-
Gets outbound messages queue size.
- getOutboundMessagesQueueSize() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Gets outbound messages queue size.
- getOutboundMessagesQueueSize() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
-
Gets outbound messages queue size.
- getOverflowSize() - Method in interface org.apache.ignite.cache.CacheMetrics
-
Gets number of entries that was swapped to disk.
- getOverflowSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
Gets number of entries that was swapped to disk.
- getPageSize() - Method in class org.apache.ignite.cache.query.Query
-
Gets optional page size, if 0, then default is used.
- getParallelJobsNumber() - Method in class org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpi
-
Gets number of jobs that can be executed in parallel.
- getParallelJobsNumber() - Method in interface org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpiMBean
-
Gets number of jobs that can be executed in parallel.
- getParallelJobsNumber() - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
-
Gets number of jobs that can be executed in parallel.
- getParallelJobsNumber() - Method in interface org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpiMBean
-
Gets number of jobs that can be executed in parallel.
- getParallelLoadCacheMinimumThreshold() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
-
Parallel load cache minimum row count threshold.
- getParallelLoadCacheMinimumThreshold() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
-
Parallel load cache minimum row count threshold.
- getParentLogger() - Method in class org.apache.ignite.IgniteJdbcDriver
- getPartition() - Method in class org.apache.ignite.cache.query.ScanQuery
-
Gets partition number over which this query should iterate.
- getPartitions() - Method in class org.apache.ignite.cache.affinity.fair.FairAffinityFunction
-
Gets total number of key partitions.
- getPartitions() - Method in class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
-
Gets total number of key partitions.
- getPartitionUpdateCounter() - Method in class org.apache.ignite.cache.query.CacheQueryEntryEvent
-
Each cache update increases partition counter.
- getPassword() - Method in class org.apache.ignite.plugin.security.SecurityCredentials
-
Gets password.
- getPath() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.sharedfs.TcpDiscoverySharedFsIpFinder
-
Gets path.
- getPathModes() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Gets map of path prefixes to IGFS modes used for them.
- getPayload() - Method in class org.apache.ignite.hadoop.fs.IgniteHadoopIgfsSecondaryFileSystem
- getPeerClassLoadingLocalClassPathExclude() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Should return list of packages from the system classpath that need to
be peer-to-peer loaded from task originating node.
'*' is supported at the end of the package name which means
that all sub-packages and their classes are included like in Java
package import clause.
- getPeerClassLoadingMissedResourcesCacheSize() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Returns missed resources cache size.
- getPeerClassLoadingThreadPoolSize() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Size of thread pool which is in charge of peer class loading requests/responses.
- getPendingMessagesDiscarded() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Gets pending messages discarded count.
- getPendingMessagesDiscarded() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
-
Gets pending messages discarded count.
- getPendingMessagesRegistered() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Gets pending messages registered count.
- getPendingMessagesRegistered() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
-
Gets pending messages registered count.
- getPerNodeBatchSize() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Gets number of file blocks buffered on local node before sending batch to remote node.
- getPerNodeParallelBatchCount() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Gets number of batches that can be concurrently sent to remote node.
- getPersistence() - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
-
Gets the currently set persistence mechanism.
- getPessimisticTxLogLinger() - Method in class org.apache.ignite.configuration.TransactionConfiguration
-
Gets delay, in milliseconds, after which pessimistic recovery entries will be cleaned up for failed node.
- getPessimisticTxLogSize() - Method in class org.apache.ignite.configuration.TransactionConfiguration
-
Gets size of pessimistic transactions log stored on node in order to recover transaction commit if originating
node has left grid before it has sent all messages to transaction nodes.
- getPlatformConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Gets platform configuration.
- getPluginConfigurations() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Gets array of cache plugin configurations.
- getPluginConfigurations() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Gets plugin configurations.
- getPoolSize() - Method in interface org.apache.ignite.mxbean.ThreadPoolMXBean
-
Returns the current number of threads in the pool.
- getPort() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
-
Gets port for TCP binary protocol server.
- getPort() - Method in class org.apache.ignite.igfs.IgfsIpcEndpointConfiguration
-
Gets the port endpoint is bound to.
- getPortRange() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
-
Gets number of ports to try if configured port is already in use.
- getPrefetchBlocks() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Get number of pre-fetched blocks if specific file's chunk is requested.
- getPriorityAttributeKey() - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
-
Gets key name of task priority attribute.
- getPriorityAttributeKey() - Method in interface org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpiMBean
-
Gets key name of task priority attribute.
- getProcessedMessages() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Gets processed messages counts (grouped by type).
- getProcessedMessages() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
-
Gets processed messages counts (grouped by type).
- getProcessorCoefficient() - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveCpuLoadProbe
-
Gets coefficient of every CPU processor.
- getProgress() - Method in class org.apache.ignite.yarn.ApplicationMaster
- getProperties() - Method in class org.apache.ignite.cache.CacheManager
- getProperties() - Method in class org.apache.ignite.configuration.IgniteReflectionFactory
-
Gets a map of properties.
- getProperties() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetCacheStoreFactory
-
Get properties.
- getProperties() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetLifecycleBean
-
Get properties.
- getPropertyInfo(String, Properties) - Method in class org.apache.ignite.IgniteJdbcDriver
- getProtocol() - Method in class org.apache.ignite.ssl.SslContextFactory
-
Gets protocol for secure transport.
- getProxyHost() - Method in class org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpi
-
Gets HTTP proxy host.
- getProxyHost() - Method in interface org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpiMBean
-
- getProxyPassword() - Method in class org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpi
-
Gets HTTP proxy password.
- getProxyPort() - Method in class org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpi
-
Gets HTTP proxy port.
- getProxyPort() - Method in interface org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpiMBean
-
- getProxyUsername() - Method in class org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpi
-
Gets HTTP proxy user name.
- getProxyUsername() - Method in interface org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpiMBean
-
- getPublicThreadPoolSize() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Should return a thread pool size to be used in grid.
- getPwd() - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
-
Gets checkpoint jdbc password.
- getPwd() - Method in interface org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpiMBean
-
Gets checkpoint jdbc password.
- getQualitiesOfService() - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
-
Gets the qualities of service for multiple topics.
- getQualityOfService() - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
-
Gets the quality of service set by the user for a single topic consumption.
- getQueryEntities() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Gets a collection of configured query entities.
- getQueryFields() - Method in class org.apache.ignite.cache.CacheTypeMetadata
-
Deprecated.
Gets name-to-type map for query-enabled fields.
- getQueueLength() - Method in interface org.apache.ignite.IgniteSemaphore
-
Returns an estimate of the number of nodes waiting to acquire.
- getQueueSize() - Method in interface org.apache.ignite.mxbean.ThreadPoolMXBean
-
Gets current size of the execution queue.
- getQueueSize() - Method in class org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpi
-
Gets current queue size of the event queue.
- getQueueSize() - Method in interface org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpiMBean
-
Gets current queue size of the event queue.
- getReadStripesNumber() - Method in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
-
Gets read pool size.
- getReadStripesNumber() - Method in interface org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpiMBean
-
Gets read pool size.
- getRebalanceBatchesPrefetchCount() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
To gain better rebalancing performance supplier node can provide more than one batch at rebalancing start and
provide one new to each next demand request.
- getRebalanceBatchSize() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Gets size (in number bytes) to be loaded within a single rebalance message.
- getRebalanceDelay() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Gets delay in milliseconds upon a node joining or leaving topology (or crash) after which rebalancing
should be started automatically.
- getRebalanceMode() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Gets rebalance mode for distributed cache.
- getRebalanceOrder() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Gets cache rebalance order.
- getRebalanceThreadPoolSize() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Deprecated.
- getRebalanceThreadPoolSize() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Gets Max count of threads can be used at rebalancing.
- getRebalanceThrottle() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Time in milliseconds to wait between rebalance messages to avoid overloading of CPU or network.
- getRebalanceTimeout() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Gets rebalance timeout (ms).
- getReceiveBufferSize() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
-
Gets REST TCP server receive buffer size.
- getReceivedBytesCount() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Gets received bytes count.
- getReceivedBytesCount() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Gets received bytes count.
- getReceivedBytesCount() - Method in interface org.apache.ignite.spi.communication.CommunicationSpi
-
Gets received bytes count.
- getReceivedBytesCount() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Gets received bytes count.
- getReceivedBytesCount() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
-
Gets received bytes count.
- getReceivedMessages() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Gets received messages counts (grouped by type).
- getReceivedMessages() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
-
Gets received messages counts (grouped by type).
- getReceivedMessagesCount() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Gets received messages count.
- getReceivedMessagesCount() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Gets received messages count.
- getReceivedMessagesCount() - Method in interface org.apache.ignite.spi.communication.CommunicationSpi
-
Gets received messages count.
- getReceivedMessagesCount() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Gets received messages count.
- getReceivedMessagesCount() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
-
Gets received messages count.
- getReconnectCount() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Gets maximum number of reconnect attempts used when establishing connection
with remote nodes.
- getReconnectCount() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
-
Gets maximum number of reconnect attempts used when establishing connection
with remote nodes.
- getReconnectCount() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Gets number of connection attempts.
- getReconnectCount() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
-
Gets number of connection attempts.
- getRegisteredAddresses() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.cloud.TcpDiscoveryCloudIpFinder
-
Gets all addresses registered in this finder.
- getRegisteredAddresses() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.gce.TcpDiscoveryGoogleStorageIpFinder
-
Gets all addresses registered in this finder.
- getRegisteredAddresses() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc.TcpDiscoveryJdbcIpFinder
-
Gets all addresses registered in this finder.
- getRegisteredAddresses() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
-
Gets all addresses registered in this finder.
- getRegisteredAddresses() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.s3.TcpDiscoveryS3IpFinder
-
Gets all addresses registered in this finder.
- getRegisteredAddresses() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.sharedfs.TcpDiscoverySharedFsIpFinder
-
Gets all addresses registered in this finder.
- getRegisteredAddresses() - Method in interface org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinder
-
Gets all addresses registered in this finder.
- getRegisteredAddresses() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.vm.TcpDiscoveryVmIpFinder
-
Gets all addresses registered in this finder.
- getRegisteredAddresses() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.zk.TcpDiscoveryZookeeperIpFinder
-
Gets all addresses registered in this finder.
- getRejectedExecutionHandlerClass() - Method in interface org.apache.ignite.mxbean.ThreadPoolMXBean
-
Returns the class name of current rejection handler.
- getReloginInterval() - Method in class org.apache.ignite.hadoop.fs.KerberosHadoopFileSystemFactory
-
The interval used to re-login from the key tab, in milliseconds.
- getRemoteFilter() - Method in class org.apache.ignite.cache.query.ContinuousQuery
-
Gets remote filter.
- getRemoteFilterFactory() - Method in class org.apache.ignite.cache.query.ContinuousQuery
-
Gets remote filter.
- getRemoteNodes() - Method in interface org.apache.ignite.spi.discovery.DiscoverySpi
-
Gets collection of remote nodes in grid or empty collection if no remote nodes found.
- getRemoteNodes() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Gets collection of remote nodes in grid or empty collection if no remote nodes found.
- getResourceClass() - Method in interface org.apache.ignite.spi.deployment.DeploymentResource
-
Gets resource class.
- getResourceClass() - Method in class org.apache.ignite.spi.deployment.DeploymentResourceAdapter
-
Gets resource class.
- getResourceFactory() - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
- getResponseProcessor() - Method in class org.apache.ignite.stream.camel.CamelStreamer
-
Gets the Processor used to generate the response.
- getResponseWaitTime() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
-
Gets time in milliseconds IP finder waits for reply to
multicast address request.
- getRetryPolicy() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.zk.TcpDiscoveryZookeeperIpFinder
-
- getRetryStopStrategy() - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
-
Gets the retry stop strategy.
- getRetryWaitStrategy() - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
-
Gets the retry wait strategy.
- getScanners() - Method in class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
-
Gets scanners.
- getSecondaryFileSystem() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Gets the secondary file system.
- getSecretAccessKey() - Method in class org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpi
-
Gets S3 secret key.
- getSecretKey() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
-
Gets secret key to authenticate REST requests.
- getSegmentationPolicy() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Returns segmentation policy.
- getSegmentationResolveAttempts() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Gets segmentation resolve attempts.
- getSegmentationResolvers() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Returns a collection of segmentation resolvers.
- getSegmentCheckFrequency() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Returns frequency of network segment check by discovery manager.
- getSelectorCount() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
-
Gets number of selector threads in REST TCP server.
- getSelectorsCount() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Gets count of selectors used in TCP server.
- getSelectorsCount() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
-
Gets count of selectors used in TCP server.
- getSendBufferSize() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
-
Gets REST TCP server send buffer size.
- getSendQueueLimit() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
-
Gets REST TCP server send queue limit.
- getSentBytesCount() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Gets sent bytes count.
- getSentBytesCount() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Gets sent bytes count.
- getSentBytesCount() - Method in interface org.apache.ignite.spi.communication.CommunicationSpi
-
Gets sent bytes count.
- getSentBytesCount() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Gets sent bytes count.
- getSentBytesCount() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
-
Gets sent bytes count.
- getSentMessagesCount() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Gets sent messages count.
- getSentMessagesCount() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Gets sent messages count.
- getSentMessagesCount() - Method in interface org.apache.ignite.spi.communication.CommunicationSpi
-
Gets sent messages count.
- getSentMessagesCount() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Gets sent messages count.
- getSentMessagesCount() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
-
Gets sent messages count.
- getSequentialReadsBeforePrefetch() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Get amount of sequential block reads before prefetch is triggered.
- getSerializer() - Method in class org.apache.ignite.binary.BinaryTypeConfiguration
-
Gets serializer.
- getSerializer() - Method in class org.apache.ignite.configuration.BinaryConfiguration
-
Gets serializer.
- getSerializer() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryTypeConfiguration
-
- getServerDefaults() - Method in class org.apache.ignite.hadoop.fs.v2.IgniteHadoopFileSystem
- getService() - Method in class org.apache.ignite.services.ServiceConfiguration
-
Gets service instance.
- getServiceConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Gets configurations for services to be deployed on the grid.
- getServiceName() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.zk.TcpDiscoveryZookeeperIpFinder
-
- getSessionFactory() - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateStoreSessionListener
-
Gets Hibernate session factory.
- getSharedMemoryPort() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Gets local port for shared memory communication.
- getSharedMemoryPort() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
-
Gets local port for shared memory communication.
- getSimpleValueType() - Method in class org.apache.ignite.cache.CacheTypeMetadata
-
Deprecated.
Gets simple value type.
- getSingleTupleExtractor() - Method in class org.apache.ignite.stream.StreamAdapter
-
- getSize() - Method in interface org.apache.ignite.cache.CacheMetrics
-
Gets number of non-null values in the cache.
- getSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
Gets number of non-null values in the cache.
- getSizeInMemory() - Method in class org.apache.ignite.cache.hibernate.HibernateRegion
- getSlowClientQueueLimit() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Gets slow client queue limit.
- getSlowClientQueueLimit() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
-
Gets slow client queue limit.
- getSocketReceiveBuffer() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Gets receive buffer size for sockets created or accepted by this SPI.
- getSocketReceiveBuffer() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
-
Gets receive buffer size for sockets created or accepted by this SPI.
- getSocketSendBuffer() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Gets send buffer size for sockets created or accepted by this SPI.
- getSocketSendBuffer() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
-
Gets send buffer size for sockets created or accepted by this SPI.
- getSocketTimeout() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Gets socket timeout.
- getSocketTimeout() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
-
Gets socket timeout.
- getSocketWriteTimeout() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Gets socket write timeout for TCP connections.
- getSocketWriteTimeout() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
-
Gets socket write timeout for TCP connections.
- getSpiContext() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Gets SPI context.
- getSpiContext() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Gets SPI context.
- getSpiContext() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
-
Gets SPI context.
- getSpiState() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Gets current SPI state.
- getSpiState() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
-
Gets current SPI state.
- getSql() - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
-
Gets SQL clause.
- getSql() - Method in class org.apache.ignite.cache.query.SqlQuery
-
Gets SQL clause.
- getSqlFunctionClasses() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Gets classes with methods annotated by
QuerySqlFunction
to be used as user-defined functions from SQL queries.
- getSqlOnheapRowCacheSize() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Number of SQL rows which will be cached onheap to avoid deserialization on each SQL index access.
- getSqlSchema() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Gets custom name of the sql schema.
- getSslContextFactory() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
-
- getSslContextFactory() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Returns SSL context factory that will be used for creating a secure socket layer.
- getSslFactory() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
-
Gets context factory that will be used for creating a secure socket layer of rest binary server.
- getStartSize() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Gets initial cache size which will be used to pre-create internal
hash table after start.
- getStartTime() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Returns the start time of the JVM in milliseconds.
- getStartTime() - Method in interface org.apache.ignite.compute.ComputeTaskSession
-
Gets start of computation time for the task.
- getStartTime() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Returns the start time of the JVM in milliseconds.
- getStartTimestamp() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
-
Get start timestamp of the kernal.
- getStartTimestamp() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
-
Get start timestamp of this SPI.
- getStartTimestamp() - Method in interface org.apache.ignite.spi.IgniteSpiManagementMBean
-
Get start timestamp of this SPI.
- getStartTimestampFormatted() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
-
Gets string presentation of the kernal start timestamp.
- getStartTimestampFormatted() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
-
Gets string presentation of the start timestamp.
- getStartTimestampFormatted() - Method in interface org.apache.ignite.spi.IgniteSpiManagementMBean
-
Gets string presentation of the start timestamp.
- getStarvationIncrement() - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
-
Gets value to increment job priority by every time a lower priority job gets
behind a higher priority job.
- getStarvationIncrement() - Method in interface org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpiMBean
-
Gets value to increment job priority by every time a lower priority job gets
behind a higher priority job.
- getState() - Method in interface org.apache.ignite.mxbean.IgnitionMXBean
-
Gets state of default grid instance.
- getState(String) - Method in interface org.apache.ignite.mxbean.IgnitionMXBean
-
Gets state for a given grid instance.
- getStatisticsPrintFrequency() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Gets statistics print frequency.
- getStatisticsPrintFrequency() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
-
Gets statistics print frequency.
- getStealingAttributes() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
-
- getStealingAttributes() - Method in interface org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpiMBean
-
- getStoreConcurrentLoadAllThreshold() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Gets the threshold used in cases when values for multiple keys are being loaded from an underlying
CacheStore in parallel.
- getStreamBufferSize() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Get read/write buffer size for IGFS stream operations in bytes.
- getStreamer() - Method in class org.apache.ignite.stream.StreamAdapter
-
- getString(String) - Static method in class org.apache.ignite.IgniteSystemProperties
-
Gets either system property or environment variable with given name.
- getString(String, String) - Static method in class org.apache.ignite.IgniteSystemProperties
-
Gets either system property or environment variable with given name.
- getSwapEntriesCount() - Method in interface org.apache.ignite.cache.CacheMetrics
-
Gets number of entries stored in swap.
- getSwapEntriesCount() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
Gets number of entries stored in swap.
- getSwapGets() - Method in interface org.apache.ignite.cache.CacheMetrics
-
The total number of get requests to the swap.
- getSwapGets() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
The total number of get requests to the swap.
- getSwapHitPercentage() - Method in interface org.apache.ignite.cache.CacheMetrics
-
Gets the percentage of hits on swap.
- getSwapHitPercentage() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
Gets the percentage of hits on swap.
- getSwapHits() - Method in interface org.apache.ignite.cache.CacheMetrics
-
The number of get requests that were satisfied by the swap.
- getSwapHits() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
The number of get requests that were satisfied by the swap.
- getSwapMisses() - Method in interface org.apache.ignite.cache.CacheMetrics
-
A miss is a get request that is not satisfied by swap.
- getSwapMisses() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
A miss is a get request that is not satisfied by swap.
- getSwapMissPercentage() - Method in interface org.apache.ignite.cache.CacheMetrics
-
Gets the percentage of misses on swap.
- getSwapMissPercentage() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
Gets the percentage of misses on swap.
- getSwapPuts() - Method in interface org.apache.ignite.cache.CacheMetrics
-
The total number of put requests to the swap.
- getSwapPuts() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
The total number of put requests to the swap.
- getSwapRemovals() - Method in interface org.apache.ignite.cache.CacheMetrics
-
The total number of removals from the swap.
- getSwapRemovals() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
The total number of removals from the swap.
- getSwapSize() - Method in interface org.apache.ignite.cache.CacheMetrics
-
Gets size of swap.
- getSwapSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
Gets size of swap.
- getSwapSpaceSpi() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Should return fully configured swap space SPI implementation.
- getSwapSpaceSpiFormatted() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
-
Gets a formatted instance of configured swapspace SPI implementations.
- getSystemThreadPoolSize() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Size of thread pool that is in charge of processing internal system messages.
- getTarget() - Method in class org.apache.ignite.compute.gridify.aop.GridifyArgumentAdapter
-
Gets target object for method execution.
- getTarget() - Method in interface org.apache.ignite.compute.gridify.GridifyArgument
-
Gets target object to execute method on.
- getTaskCount() - Method in interface org.apache.ignite.mxbean.ThreadPoolMXBean
-
Returns the approximate total number of tasks that have been scheduled
for execution.
- getTaskName() - Method in interface org.apache.ignite.compute.ComputeTaskSession
-
Gets task name of the task this session belongs to.
- getTaskNodeId() - Method in interface org.apache.ignite.compute.ComputeTaskSession
-
Gets ID of the node on which task execution originated.
- getTaskSession() - Method in interface org.apache.ignite.compute.ComputeTaskFuture
-
Gets task session of execution grid task.
- getTaskSession() - Method in interface org.apache.ignite.spi.collision.CollisionJobContext
-
Gets current task session associated with this job.
- getTaskSession() - Method in interface org.apache.ignite.spi.failover.FailoverContext
-
Gets current task session.
- getTemporaryDirectoryPath() - Method in class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
-
Gets temporary directory path.
- getTemporaryDirectoryPath() - Method in interface org.apache.ignite.spi.deployment.uri.UriDeploymentSpiMBean
-
Gets temporary directory path.
- getText() - Method in class org.apache.ignite.cache.query.TextQuery
-
Gets text search string.
- getTextFields() - Method in class org.apache.ignite.cache.CacheTypeMetadata
-
Deprecated.
Gets text-indexed fields.
- getThreadCount() - Method in class org.apache.ignite.igfs.IgfsIpcEndpointConfiguration
-
Get number of threads used by this endpoint to process incoming requests.
- getThreadCount() - Method in class org.apache.ignite.startup.BasicWarmupClosure
-
Gets thread count for warmup.
- getThreadFactoryClass() - Method in interface org.apache.ignite.mxbean.ThreadPoolMXBean
-
Returns the class name of thread factory used to create new threads.
- getThreadPoolSize() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
-
Should return a thread pool size to be used for
processing of client messages (REST requests).
- getThreadPriority() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Gets thread priority.
- getThreadPriority() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
-
Gets thread priority.
- getThreadsCount() - Method in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
-
Returns number of worker threads.
- getTimeInterval() - Method in class org.apache.ignite.cache.query.ContinuousQuery
-
Gets time interval.
- getTimeout() - Method in class org.apache.ignite.cache.hibernate.HibernateRegion
- getTimeServerPortBase() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Gets base UPD port number for grid time server.
- getTimeServerPortRange() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Defines port range to try for time server start.
- getTimeToLive() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
-
Set the default time-to-live for multicast packets sent out on this
IP finder.
- getTm() - Method in interface org.apache.ignite.cache.jta.CacheTmLookup
-
Gets Transaction Manager (TM).
- getTm() - Method in class org.apache.ignite.cache.jta.jndi.CacheJndiTmLookup
-
Gets Transaction Manager (TM).
- getTm() - Method in class org.apache.ignite.cache.jta.reflect.CacheReflectionTmLookup
-
Gets Transaction Manager (TM).
- getTokenDirectoryPath() - Method in class org.apache.ignite.igfs.IgfsIpcEndpointConfiguration
-
Gets directory where shared memory tokens are stored.
- getTopHistorySize() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
- getTopic() - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
-
Gets the subscribed topic.
- getTopics() - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
-
Gets the topics subscribed to.
- getTopology() - Method in interface org.apache.ignite.compute.ComputeTaskSession
-
Gets a collection of grid nodes IDs.
- getTopologyValidator() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Gets topology validator.
- getTotalBusyTime() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Gets total time this node spent executing jobs.
- getTotalBusyTime() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Gets total time this node spent executing jobs.
- getTotalCancelledJobs() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Gets number of cancelled jobs since node startup.
- getTotalCancelledJobs() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Gets number of cancelled jobs since node startup.
- getTotalCount() - Method in class org.apache.ignite.services.ServiceConfiguration
-
Gets total number of deployed service instances in the cluster, 0 for unlimited.
- getTotalCpus() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Returns the number of CPUs available to the Java Virtual Machine.
- getTotalCpus() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Returns the number of CPUs available to the Java Virtual Machine.
- getTotalExecutedJobs() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Gets total number of jobs handled by the node since node startup.
- getTotalExecutedJobs() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Gets total number of jobs handled by the node since node startup.
- getTotalExecutedTasks() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Gets total number of tasks handled by the node.
- getTotalExecutedTasks() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Gets total number of tasks handled by the node.
- getTotalFailedOverJobsCount() - Method in class org.apache.ignite.spi.failover.jobstealing.JobStealingFailoverSpi
-
Get total number of jobs that were failed over including stolen ones.
- getTotalFailedOverJobsCount() - Method in interface org.apache.ignite.spi.failover.jobstealing.JobStealingFailoverSpiMBean
-
Get total number of jobs that were failed over including stolen ones.
- getTotalFailoverJobsCount() - Method in class org.apache.ignite.spi.failover.always.AlwaysFailoverSpi
-
Get total number of jobs that were failed over.
- getTotalFailoverJobsCount() - Method in interface org.apache.ignite.spi.failover.always.AlwaysFailoverSpiMBean
-
Get total number of jobs that were failed over.
- getTotalIdleTime() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Gets total time this node spent idling (not executing any jobs).
- getTotalIdleTime() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Gets total time this node spent idling (not executing any jobs).
- getTotalNodes() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Gets total number of nodes.
- getTotalNodes() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Gets total number of nodes.
- getTotalProcessedMessages() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Gets total processed messages count.
- getTotalProcessedMessages() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
-
Gets total processed messages count.
- getTotalReceivedMessages() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Gets total received messages count.
- getTotalReceivedMessages() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
-
Gets total received messages count.
- getTotalRejectedJobs() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Gets total number of jobs this node rejects during collision resolution operations since node startup.
- getTotalRejectedJobs() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Gets total number of jobs this node rejects during collision resolution operations since node startup.
- getTotalStartedThreadCount() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Returns the total number of threads created and also started
since the JVM started.
- getTotalStartedThreadCount() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Returns the total number of threads created and also started
since the JVM started.
- getTotalStolenJobsCount() - Method in class org.apache.ignite.spi.failover.jobstealing.JobStealingFailoverSpi
-
Get total number of jobs that were stolen.
- getTotalStolenJobsCount() - Method in interface org.apache.ignite.spi.failover.jobstealing.JobStealingFailoverSpiMBean
-
Get total number of jobs that were stolen.
- getTotalStolenJobsNumber() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
-
Gets total number of stolen jobs.
- getTotalStolenJobsNumber() - Method in interface org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpiMBean
-
Gets total number of stolen jobs.
- getTransactionConcurrency() - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
-
Gets transaction concurrency level.
- getTransactionConfiguration() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Gets transactions configuration.
- getTransactionManager() - Method in class org.apache.ignite.cache.store.spring.CacheSpringStoreSessionListener
-
Gets transaction manager.
- getTransactionManagerLookupClassName() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
- getTrashPurgeTimeout() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Gets maximum timeout awaiting for trash purging in case data cache oversize is detected.
- getTrustManagers() - Method in class org.apache.ignite.ssl.SslContextFactory
-
Gets pre-configured trust managers.
- getTrustStoreFilePath() - Method in class org.apache.ignite.ssl.SslContextFactory
-
Gets path to the trust store file.
- getTrustStorePassword() - Method in class org.apache.ignite.ssl.SslContextFactory
-
Gets trust store password.
- getTrustStoreType() - Method in class org.apache.ignite.ssl.SslContextFactory
-
Gets trust store type used for context creation.
- getTupleExtractor() - Method in class org.apache.ignite.stream.StreamAdapter
-
Deprecated.
- getTxCommitQueueSize() - Method in interface org.apache.ignite.cache.CacheMetrics
-
Gets committed transaction queue size.
- getTxCommitQueueSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
Gets committed transaction queue size.
- getTxCommittedVersionsSize() - Method in interface org.apache.ignite.cache.CacheMetrics
-
Gets number of cached committed transaction IDs.
- getTxCommittedVersionsSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
Gets number of cached committed transaction IDs.
- getTxDhtCommitQueueSize() - Method in interface org.apache.ignite.cache.CacheMetrics
-
Gets committed DHT transaction queue size.
- getTxDhtCommitQueueSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
Gets committed DHT transaction queue size.
- getTxDhtCommittedVersionsSize() - Method in interface org.apache.ignite.cache.CacheMetrics
-
Gets number of cached committed DHT transaction IDs.
- getTxDhtCommittedVersionsSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
Gets number of cached committed DHT transaction IDs.
- getTxDhtPrepareQueueSize() - Method in interface org.apache.ignite.cache.CacheMetrics
-
Gets prepared DHT transaction queue size.
- getTxDhtPrepareQueueSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
Gets prepared DHT transaction queue size.
- getTxDhtRolledbackVersionsSize() - Method in interface org.apache.ignite.cache.CacheMetrics
-
Gets number of cached rolled back DHT transaction IDs.
- getTxDhtRolledbackVersionsSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
Gets number of cached rolled back DHT transaction IDs.
- getTxDhtStartVersionCountsSize() - Method in interface org.apache.ignite.cache.CacheMetrics
-
Gets DHT start version counts map size.
- getTxDhtStartVersionCountsSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
Gets DHT start version counts map size.
- getTxDhtThreadMapSize() - Method in interface org.apache.ignite.cache.CacheMetrics
-
Gets transaction DHT per-thread map size.
- getTxDhtThreadMapSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
Gets transaction DHT per-thread map size.
- getTxDhtXidMapSize() - Method in interface org.apache.ignite.cache.CacheMetrics
-
Gets transaction DHT per-Xid map size.
- getTxDhtXidMapSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
Gets transaction DHT per-Xid map size.
- getTxManagerFactory() - Method in class org.apache.ignite.configuration.TransactionConfiguration
-
Gets transaction manager factory for integration with JEE app servers.
- getTxManagerLookupClassName() - Method in class org.apache.ignite.configuration.TransactionConfiguration
-
- getTxPrepareQueueSize() - Method in interface org.apache.ignite.cache.CacheMetrics
-
Gets prepared transaction queue size.
- getTxPrepareQueueSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
Gets prepared transaction queue size.
- getTxRolledbackVersionsSize() - Method in interface org.apache.ignite.cache.CacheMetrics
-
Gets number of cached rolled back transaction IDs.
- getTxRolledbackVersionsSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
Gets number of cached rolled back transaction IDs.
- getTxStartVersionCountsSize() - Method in interface org.apache.ignite.cache.CacheMetrics
-
Gets start version counts map size.
- getTxStartVersionCountsSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
Gets start version counts map size.
- getTxThreadMapSize() - Method in interface org.apache.ignite.cache.CacheMetrics
-
Gets transaction per-thread map size.
- getTxThreadMapSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
Gets transaction per-thread map size.
- getTxXidMapSize() - Method in interface org.apache.ignite.cache.CacheMetrics
-
Gets transaction per-Xid map size.
- getTxXidMapSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
Gets transaction per-Xid map size.
- getType() - Method in class org.apache.ignite.cache.query.SqlQuery
-
Gets type for query.
- getType() - Method in class org.apache.ignite.cache.query.TextQuery
-
Gets type for query.
- getType() - Method in class org.apache.ignite.igfs.IgfsIpcEndpointConfiguration
-
Gets endpoint type.
- getTypeConfigurations() - Method in class org.apache.ignite.configuration.BinaryConfiguration
-
Gets types configuration.
- getTypeMetadata() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Gets collection of type metadata objects.
- getTypeName() - Method in class org.apache.ignite.binary.BinaryTypeConfiguration
-
Gets type name.
- getTypeName() - Method in class org.apache.ignite.cache.CacheKeyConfiguration
-
Sets type name for which affinity field name is being defined.
- getTypeName() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryTypeConfiguration
-
- getTypeName() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetCacheStoreFactory
-
Gets .NET type name.
- getTypeName() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetLifecycleBean
-
Get type name.
- getTypes() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
-
Gets types known by store.
- getTypes() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
-
Gets types known by store.
- getTypes() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryConfiguration
-
- getTypesConfiguration() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryConfiguration
-
- getUnacknowledgedMessagesBufferSize() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Gets maximum number of stored unacknowledged messages per connection to node.
- getUnacknowledgedMessagesBufferSize() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
-
Gets maximum number of stored unacknowledged messages per connection to node.
- getUpTime() - Method in interface org.apache.ignite.cluster.ClusterMetrics
-
Returns the uptime of the JVM in milliseconds.
- getUpTime() - Method in interface org.apache.ignite.mxbean.ClusterLocalNodeMetricsMXBean
-
Returns the uptime of the JVM in milliseconds.
- getUpTime() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
-
Gets up-time of the kernal.
- getUpTime() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
-
Gets up-time of this SPI in ms.
- getUpTime() - Method in interface org.apache.ignite.spi.IgniteSpiManagementMBean
-
Gets up-time of this SPI in ms.
- getUpTimeFormatted() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
-
Gets string presentation of up-time for the kernal.
- getUpTimeFormatted() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
-
Gets string presentation of up-time for this SPI.
- getUpTimeFormatted() - Method in interface org.apache.ignite.spi.IgniteSpiManagementMBean
-
Gets string presentation of up-time for this SPI.
- getURI() - Method in class org.apache.ignite.cache.CacheManager
- getUri() - Method in class org.apache.ignite.hadoop.fs.BasicHadoopFileSystemFactory
-
Gets file system URI.
- getUri() - Method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
- getUri() - Method in class org.apache.ignite.hadoop.fs.v2.IgniteHadoopFileSystem
- getUriDefaultPort() - Method in class org.apache.ignite.hadoop.fs.v2.IgniteHadoopFileSystem
- getUriList() - Method in class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
-
Gets list of URIs that are processed by SPI.
- getUriList() - Method in interface org.apache.ignite.spi.deployment.uri.UriDeploymentSpiMBean
-
Gets list of URIs that are processed by SPI.
- getUser() - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
-
Gets checkpoint jdbc user name.
- getUser() - Method in interface org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpiMBean
-
Gets checkpoint jdbc user name.
- getUserAttributes() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Should return any user-defined attributes to be added to this node.
- getUserAttributesFormatted() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
-
Gets a list of formatted user-defined attributes added to this node.
- getUserObject() - Method in class org.apache.ignite.plugin.security.SecurityCredentials
-
Gets user-specific object.
- getUtilityCacheKeepAliveTime() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Keep alive time of thread pool that is in charge of processing utility cache messages.
- getUtilityCacheThreadPoolSize() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Default size of thread pool that is in charge of processing utility cache messages.
- getValue() - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStoreEntry
-
- getValue() - Method in class org.apache.ignite.lang.IgniteBiTuple
- getValueFieldName() - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
-
Gets value field name for checkpoint table.
- getValueFieldName() - Method in interface org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpiMBean
-
Gets value field name for checkpoint table.
- getValueFields() - Method in class org.apache.ignite.cache.CacheTypeMetadata
-
Deprecated.
- getValueFields() - Method in class org.apache.ignite.cache.store.jdbc.JdbcType
-
- getValueFieldType() - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
-
Gets value field type for checkpoint table.
- getValueFieldType() - Method in interface org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpiMBean
-
Gets value field type for checkpoint table.
- getValueType() - Method in interface org.apache.ignite.cache.CacheMetrics
-
Determines the required type of values for this Cache, if any.
- getValueType() - Method in class org.apache.ignite.cache.CacheTypeMetadata
-
Deprecated.
Gets value type.
- getValueType() - Method in class org.apache.ignite.cache.QueryEntity
-
Gets value type for this query pair.
- getValueType() - Method in class org.apache.ignite.cache.store.jdbc.JdbcType
-
Gets value type.
- getValueType() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
Determines the required type of values for this Cache, if any.
- getVmName() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
-
Gets VM name.
- getWaitingJobsNumber() - Method in class org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpi
-
Maximum number of jobs that are allowed to wait in waiting queue.
- getWaitingJobsNumber() - Method in interface org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpiMBean
-
Maximum number of jobs that are allowed to wait in waiting queue.
- getWaitingJobsNumber() - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
-
Maximum number of jobs that are allowed to wait in waiting queue.
- getWaitingJobsNumber() - Method in interface org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpiMBean
-
Maximum number of jobs that are allowed to wait in waiting queue.
- getWaitJobsThreshold() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
-
Gets job count threshold at which this node will
start stealing jobs from other nodes.
- getWaitJobsThreshold() - Method in interface org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpiMBean
-
Gets job count threshold at which this node will
start stealing jobs from other nodes.
- getWarmupClosure() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Gets grid warmup closure.
- getWarmupMethods() - Method in class org.apache.ignite.startup.BasicWarmupClosure
-
Gets warmup methods to use for cache warmup.
- getWorkDirectory() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Gets Ignite work folder.
- getWorkingDirectory() - Method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
- getWriteBehindBatchSize() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Maximum batch size for write-behind cache store operations.
- getWriteBehindBufferSize() - Method in interface org.apache.ignite.cache.CacheMetrics
-
Gets count of entries that were processed by the write-behind store and have not been
flushed to the underlying store yet.
- getWriteBehindBufferSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
Gets count of entries that were processed by the write-behind store and have not been
flushed to the underlying store yet.
- getWriteBehindCriticalOverflowCount() - Method in interface org.apache.ignite.cache.CacheMetrics
-
Gets count of write buffer overflow events in progress at the moment.
- getWriteBehindCriticalOverflowCount() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
Gets count of write buffer overflow events in progress at the moment.
- getWriteBehindErrorRetryCount() - Method in interface org.apache.ignite.cache.CacheMetrics
-
Gets count of cache entries that are in a store-retry state.
- getWriteBehindErrorRetryCount() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
Gets count of cache entries that are in a store-retry state.
- getWriteBehindFlushFrequency() - Method in interface org.apache.ignite.cache.CacheMetrics
-
Gets the cache flush frequency.
- getWriteBehindFlushFrequency() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Frequency with which write-behind cache is flushed to the cache store in milliseconds.
- getWriteBehindFlushFrequency() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
Gets the cache flush frequency.
- getWriteBehindFlushSize() - Method in interface org.apache.ignite.cache.CacheMetrics
-
Gets the maximum size of the write-behind buffer.
- getWriteBehindFlushSize() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Maximum size of the write-behind cache.
- getWriteBehindFlushSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
Gets the maximum size of the write-behind buffer.
- getWriteBehindFlushThreadCount() - Method in interface org.apache.ignite.cache.CacheMetrics
-
Gets the number of flush threads that will perform store update operations.
- getWriteBehindFlushThreadCount() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Number of threads that will perform cache flushing.
- getWriteBehindFlushThreadCount() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
Gets the number of flush threads that will perform store update operations.
- getWriteBehindStoreBatchSize() - Method in interface org.apache.ignite.cache.CacheMetrics
-
Gets the maximum count of similar (put or remove) operations that can be grouped to a single batch.
- getWriteBehindStoreBatchSize() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
Gets the maximum count of similar (put or remove) operations that can be grouped to a single batch.
- getWriteBehindTotalCriticalOverflowCount() - Method in interface org.apache.ignite.cache.CacheMetrics
-
Gets count of write buffer overflow events since initialization.
- getWriteBehindTotalCriticalOverflowCount() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
Gets count of write buffer overflow events since initialization.
- getWriteBufferSize() - Method in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
-
Gets write buffer size in bytes.
- getWriteBufferSize() - Method in interface org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpiMBean
-
Gets write buffer size in bytes.
- getWriteSynchronizationMode() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Gets write synchronization mode.
- getZkConnectionString() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.zk.TcpDiscoveryZookeeperIpFinder
-
- globalId() - Method in class org.apache.ignite.lang.IgniteUuid
-
Gets global ID portion of this GridUuid.
- greaterThanEqual(int, int, int) - Method in class org.apache.ignite.lang.IgniteProductVersion
-
- grid() - Method in interface org.apache.ignite.plugin.CachePluginContext
-
- grid() - Method in interface org.apache.ignite.plugin.PluginContext
-
- GRID_CONFIG_PROPERTY - Static variable in class org.apache.ignite.cache.hibernate.HibernateRegionFactory
-
- GRID_NAME_PROPERTY - Static variable in class org.apache.ignite.cache.hibernate.HibernateRegionFactory
-
Hibernate L2 cache grid name property name.
- gridCount() - Static method in class org.apache.ignite.osgi.IgniteOsgiUtils
-
Returns the number of grids currently running in this OSGi container.
- gridify(ProceedingJoinPoint) - Method in class org.apache.ignite.compute.gridify.aop.aspectj.GridifyAspectJAspect
-
Aspect implementation which executes grid-enabled methods on remote
nodes.
- gridify(ProceedingJoinPoint) - Method in class org.apache.ignite.compute.gridify.aop.aspectj.GridifySetToSetAspectJAspect
-
Aspect implementation which executes grid-enabled methods on remote
nodes.
- gridify(ProceedingJoinPoint) - Method in class org.apache.ignite.compute.gridify.aop.aspectj.GridifySetToValueAspectJAspect
-
Aspect implementation which executes grid-enabled methods on remote
nodes.
- Gridify - Annotation Type in org.apache.ignite.compute.gridify
-
Gridify annotation is the main way to grid-enable existing code.
- GridifyArgument - Interface in org.apache.ignite.compute.gridify
-
Gridify task argument created by the system for task execution.
- GridifyArgumentAdapter - Class in org.apache.ignite.compute.gridify.aop
-
- GridifyArgumentAdapter() - Constructor for class org.apache.ignite.compute.gridify.aop.GridifyArgumentAdapter
-
Empty constructor.
- GridifyArgumentAdapter(GridifyArgument, Object...) - Constructor for class org.apache.ignite.compute.gridify.aop.GridifyArgumentAdapter
-
Copy constructor.
- GridifyArgumentAdapter(Class<?>, String, Class<?>[], Object[], Object) - Constructor for class org.apache.ignite.compute.gridify.aop.GridifyArgumentAdapter
-
Creates a fully initialized gridify argument.
- GridifyAspectJAspect - Class in org.apache.ignite.compute.gridify.aop.aspectj
-
AspectJ aspect that cross-cuts on all methods grid-enabled with
Gridify annotation and potentially executes them on
remote node.
- GridifyAspectJAspect() - Constructor for class org.apache.ignite.compute.gridify.aop.aspectj.GridifyAspectJAspect
-
- GridifyDefaultRangeTask - Class in org.apache.ignite.compute.gridify.aop
-
Default gridify task which simply executes a method on remote node.
- GridifyDefaultRangeTask(Class<?>, GridifyNodeFilter, int, int, boolean) - Constructor for class org.apache.ignite.compute.gridify.aop.GridifyDefaultRangeTask
-
- GridifyDefaultTask - Class in org.apache.ignite.compute.gridify.aop
-
Default gridify task which simply executes a method on remote node.
- GridifyDefaultTask(Class<?>) - Constructor for class org.apache.ignite.compute.gridify.aop.GridifyDefaultTask
-
Creates gridify default task with given deployment class.
- GridifyInput - Annotation Type in org.apache.ignite.compute.gridify
-
This annotation can be applied to method parameter for grid-enabled method.
- GridifyInterceptor - Interface in org.apache.ignite.compute.gridify
-
This interface defines an interceptor apply for
Gridify annotation.
- GridifyNodeFilter - Interface in org.apache.ignite.compute.gridify
-
Predicate node filter.
- GridifyRuntimeException - Exception in org.apache.ignite.compute.gridify
-
This defines gridify exception.
- GridifyRuntimeException(String) - Constructor for exception org.apache.ignite.compute.gridify.GridifyRuntimeException
-
Creates new gridify runtime exception with specified message.
- GridifyRuntimeException(Throwable) - Constructor for exception org.apache.ignite.compute.gridify.GridifyRuntimeException
-
Creates new gridify runtime exception given throwable as a cause and
source of error message.
- GridifyRuntimeException(String, Throwable) - Constructor for exception org.apache.ignite.compute.gridify.GridifyRuntimeException
-
Creates new gridify runtime exception with specified message and cause.
- GridifySetToSet - Annotation Type in org.apache.ignite.compute.gridify
-
GridifySetToSet annotation allows to grid-enable existing code with specific semantics.
- GridifySetToSetAbstractAspect - Class in org.apache.ignite.compute.gridify.aop
-
Convenience adapter with common methods for different aspect implementations
(AspectJ, JBoss AOP, Spring AOP).
- GridifySetToSetAbstractAspect() - Constructor for class org.apache.ignite.compute.gridify.aop.GridifySetToSetAbstractAspect
-
- GridifySetToSetAspectJAspect - Class in org.apache.ignite.compute.gridify.aop.aspectj
-
AspectJ aspect that cross-cuts on all methods grid-enabled with
GridifySetToSet annotation and potentially executes them on
remote node.
- GridifySetToSetAspectJAspect() - Constructor for class org.apache.ignite.compute.gridify.aop.aspectj.GridifySetToSetAspectJAspect
-
- GridifySetToSetSpringAspect - Class in org.apache.ignite.compute.gridify.aop.spring
-
Spring aspect that cross-cuts on all methods grid-enabled with
GridifySetToSet annotation and potentially executes them on
remote node.
- GridifySetToSetSpringAspect() - Constructor for class org.apache.ignite.compute.gridify.aop.spring.GridifySetToSetSpringAspect
-
- GridifySetToValue - Annotation Type in org.apache.ignite.compute.gridify
-
GridifySetToValue annotation is the way to grid-enable existing code with specific semantics.
- GridifySetToValueAbstractAspect - Class in org.apache.ignite.compute.gridify.aop
-
Convenience adapter with common methods for different aspect implementations
(AspectJ, JBoss AOP, Spring AOP).
- GridifySetToValueAbstractAspect() - Constructor for class org.apache.ignite.compute.gridify.aop.GridifySetToValueAbstractAspect
-
- GridifySetToValueAspectJAspect - Class in org.apache.ignite.compute.gridify.aop.aspectj
-
AspectJ aspect that cross-cuts on all methods grid-enabled with
GridifySetToValue annotation and potentially executes them on
remote node.
- GridifySetToValueAspectJAspect() - Constructor for class org.apache.ignite.compute.gridify.aop.aspectj.GridifySetToValueAspectJAspect
-
- GridifySetToValueSpringAspect - Class in org.apache.ignite.compute.gridify.aop.spring
-
Spring aspect that cross-cuts on all methods grid-enabled with
GridifySetToValue annotation and potentially executes them on
remote node.
- GridifySetToValueSpringAspect() - Constructor for class org.apache.ignite.compute.gridify.aop.spring.GridifySetToValueSpringAspect
-
- GridifySpringAspect - Class in org.apache.ignite.compute.gridify.aop.spring
-
Spring aspect that cross-cuts on all methods grid-enabled with
Gridify annotation and potentially executes them on
remote node.
- GridifySpringAspect() - Constructor for class org.apache.ignite.compute.gridify.aop.spring.GridifySpringAspect
-
- GridifySpringEnhancer - Class in org.apache.ignite.compute.gridify.aop.spring
-
Spring AOP enhancer.
- GridifySpringPointcut - Class in org.apache.ignite.compute.gridify.aop.spring
-
- GridifySpringPointcut(GridifySpringPointcut.GridifySpringPointcutType) - Constructor for class org.apache.ignite.compute.gridify.aop.spring.GridifySpringPointcut
-
Creates pointcut associated with specific aspect.
- GridifySpringPointcut.GridifySpringPointcutType - Enum in org.apache.ignite.compute.gridify.aop.spring
-
Pointcut type.
- GridifyTaskAdapter<R> - Class in org.apache.ignite.compute.gridify
-
Convenience adapter for tasks that work with
Gridify annotation
for grid-enabling methods.
- GridifyTaskAdapter() - Constructor for class org.apache.ignite.compute.gridify.GridifyTaskAdapter
-
- GridifyTaskSplitAdapter<R> - Class in org.apache.ignite.compute.gridify
-
Convenience adapter for tasks that work with
Gridify annotation
for grid-enabling methods.
- GridifyTaskSplitAdapter() - Constructor for class org.apache.ignite.compute.gridify.GridifyTaskSplitAdapter
-
- gridName - Variable in class org.apache.ignite.spi.IgniteSpiAdapter
-
Grid instance name.
- gridName - Variable in class org.apache.ignite.thread.IgniteThread
-
The name of the grid this thread belongs to.
- gridStartTime - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Start time of the very first grid node.
- groupBlockSize() - Method in interface org.apache.ignite.igfs.IgfsFile
-
Gets file group block size (i.e. block size * group size).
- groupSize() - Method in class org.apache.ignite.igfs.IgfsGroupDataBlocksKeyMapper
-
- icon() - Method in class org.apache.ignite.visor.plugin.VisorPluggableTab
-
Tab and menu icon 16x16 px.
- id() - Method in interface org.apache.ignite.cluster.ClusterNode
-
Gets globally unique node ID.
- id() - Method in interface org.apache.ignite.events.Event
-
Gets globally unique ID of this event.
- id() - Method in class org.apache.ignite.events.EventAdapter
-
Gets globally unique ID of this event.
- id() - Method in interface org.apache.ignite.plugin.extensions.communication.IoPool
-
Gets the numeric identifier of the pool.
- id() - Method in interface org.apache.ignite.plugin.security.SecuritySubject
-
Gets subject ID.
- id() - Method in interface org.apache.ignite.scheduler.SchedulerFuture
-
Gets scheduled task ID.
- id() - Method in interface org.apache.ignite.spi.IgniteSpiTimeoutObject
-
- id - Variable in class org.apache.ignite.yarn.IgniteContainer
-
- id() - Method in class org.apache.ignite.yarn.IgniteContainer
-
- IGFS_MANAGEMENT - Static variable in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
-
Internal property to indicate management connection.
- IGFS_SCHEME - Static variable in interface org.apache.ignite.IgniteFileSystem
-
IGFS scheme name.
- IgfsBlockLocation - Interface in org.apache.ignite.igfs
-
IGFS file's data block location in the grid.
- IgfsByteDelimiterRecordResolver - Class in org.apache.ignite.igfs.mapreduce.records
-
Record resolver which adjusts records based on provided delimiters.
- IgfsByteDelimiterRecordResolver() - Constructor for class org.apache.ignite.igfs.mapreduce.records.IgfsByteDelimiterRecordResolver
-
- IgfsByteDelimiterRecordResolver(byte[]...) - Constructor for class org.apache.ignite.igfs.mapreduce.records.IgfsByteDelimiterRecordResolver
-
Creates delimiter-based record resolver.
- IgfsConcurrentModificationException - Exception in org.apache.ignite.igfs
-
IGFS exception indicating that file system structure was modified concurrently.
- IgfsConcurrentModificationException(String) - Constructor for exception org.apache.ignite.igfs.IgfsConcurrentModificationException
-
Constructor.
- IgfsConcurrentModificationException(Throwable) - Constructor for exception org.apache.ignite.igfs.IgfsConcurrentModificationException
-
Constructor.
- IgfsConcurrentModificationException(String, Throwable) - Constructor for exception org.apache.ignite.igfs.IgfsConcurrentModificationException
-
Constructor.
- IgfsCorruptedFileException - Exception in org.apache.ignite.igfs
-
Exception thrown when target file's block is not found in data cache.
- IgfsCorruptedFileException(String) - Constructor for exception org.apache.ignite.igfs.IgfsCorruptedFileException
-
Constructor.
- IgfsCorruptedFileException(Throwable) - Constructor for exception org.apache.ignite.igfs.IgfsCorruptedFileException
-
Constructor.
- IgfsCorruptedFileException(String, Throwable) - Constructor for exception org.apache.ignite.igfs.IgfsCorruptedFileException
-
Constructor.
- IgfsDirectoryNotEmptyException - Exception in org.apache.ignite.igfs
-
Exception indicating that directory can not be deleted because it is not empty.
- IgfsDirectoryNotEmptyException(String) - Constructor for exception org.apache.ignite.igfs.IgfsDirectoryNotEmptyException
-
Constructor.
- IgfsDirectoryNotEmptyException(Throwable) - Constructor for exception org.apache.ignite.igfs.IgfsDirectoryNotEmptyException
-
Constructor.
- IgfsDirectoryNotEmptyException(String, Throwable) - Constructor for exception org.apache.ignite.igfs.IgfsDirectoryNotEmptyException
-
Constructor.
- IgfsEvent - Class in org.apache.ignite.events
-
IGFS event.
- IgfsEvent(IgfsPath, ClusterNode, int) - Constructor for class org.apache.ignite.events.IgfsEvent
-
Constructs an event instance.
- IgfsEvent(IgfsPath, IgfsPath, ClusterNode, int) - Constructor for class org.apache.ignite.events.IgfsEvent
-
- IgfsEvent(IgfsPath, ClusterNode, int, long) - Constructor for class org.apache.ignite.events.IgfsEvent
-
- IgfsEvent(IgfsPath, ClusterNode, int, Map<String, String>) - Constructor for class org.apache.ignite.events.IgfsEvent
-
- IgfsEvictionFilter - Class in org.apache.ignite.cache.eviction.igfs
-
IGFS eviction filter which will not evict blocks of particular files.
- IgfsEvictionFilter() - Constructor for class org.apache.ignite.cache.eviction.igfs.IgfsEvictionFilter
-
- IgfsException - Exception in org.apache.ignite.igfs
-
IGFS exception thrown by file system components.
- IgfsException(String) - Constructor for exception org.apache.ignite.igfs.IgfsException
-
Constructor.
- IgfsException(Throwable) - Constructor for exception org.apache.ignite.igfs.IgfsException
-
Constructor.
- IgfsException(String, Throwable) - Constructor for exception org.apache.ignite.igfs.IgfsException
-
Constructor.
- IgfsFile - Interface in org.apache.ignite.igfs
-
IGFS file or directory descriptor.
- IgfsFileRange - Class in org.apache.ignite.igfs.mapreduce
-
Entity representing part of IGFS file identified by file path, start position, and length.
- IgfsFileRange(IgfsPath, long, long) - Constructor for class org.apache.ignite.igfs.mapreduce.IgfsFileRange
-
Creates file range.
- IgfsFixedLengthRecordResolver - Class in org.apache.ignite.igfs.mapreduce.records
-
Record resolver which adjusts records to fixed length.
- IgfsFixedLengthRecordResolver() - Constructor for class org.apache.ignite.igfs.mapreduce.records.IgfsFixedLengthRecordResolver
-
- IgfsFixedLengthRecordResolver(long) - Constructor for class org.apache.ignite.igfs.mapreduce.records.IgfsFixedLengthRecordResolver
-
Creates fixed-length record resolver.
- IgfsGroupDataBlocksKeyMapper - Class in org.apache.ignite.igfs
-
IGFS class providing ability to group file's data blocks together on one node.
- IgfsGroupDataBlocksKeyMapper(int) - Constructor for class org.apache.ignite.igfs.IgfsGroupDataBlocksKeyMapper
-
Constructs affinity mapper to group several data blocks with the same key.
- IgfsInputStream - Class in org.apache.ignite.igfs
-
IGFS input stream to read data from the file system.
- IgfsInputStream() - Constructor for class org.apache.ignite.igfs.IgfsInputStream
-
- IgfsInputStreamJobAdapter - Class in org.apache.ignite.igfs.mapreduce
-
- IgfsInputStreamJobAdapter() - Constructor for class org.apache.ignite.igfs.mapreduce.IgfsInputStreamJobAdapter
-
- IgfsInvalidHdfsVersionException - Exception in org.apache.ignite.igfs
-
Exception thrown when Ignite detects that remote HDFS version differs from version of HDFS libraries
in Ignite classpath.
- IgfsInvalidHdfsVersionException(String) - Constructor for exception org.apache.ignite.igfs.IgfsInvalidHdfsVersionException
-
Constructor.
- IgfsInvalidHdfsVersionException(Throwable) - Constructor for exception org.apache.ignite.igfs.IgfsInvalidHdfsVersionException
-
Constructor.
- IgfsInvalidHdfsVersionException(String, Throwable) - Constructor for exception org.apache.ignite.igfs.IgfsInvalidHdfsVersionException
-
Constructor.
- IgfsInvalidPathException - Exception in org.apache.ignite.igfs
-
IGFS exception indicating that operation target is invalid
(e.g. not a file while expecting to be a file).
- IgfsInvalidPathException(String) - Constructor for exception org.apache.ignite.igfs.IgfsInvalidPathException
-
Constructor.
- IgfsInvalidPathException(Throwable) - Constructor for exception org.apache.ignite.igfs.IgfsInvalidPathException
-
Constructor.
- IgfsInvalidPathException(String, Throwable) - Constructor for exception org.apache.ignite.igfs.IgfsInvalidPathException
-
Constructor.
- IgfsIpcEndpointConfiguration - Class in org.apache.ignite.igfs
-
IGFS IPC endpoint configuration.
- IgfsIpcEndpointConfiguration() - Constructor for class org.apache.ignite.igfs.IgfsIpcEndpointConfiguration
-
Default constructor.
- IgfsIpcEndpointConfiguration(IgfsIpcEndpointConfiguration) - Constructor for class org.apache.ignite.igfs.IgfsIpcEndpointConfiguration
-
Copying constructor.
- IgfsIpcEndpointType - Enum in org.apache.ignite.igfs
-
IGFS endpoint type.
- IgfsJob - Interface in org.apache.ignite.igfs.mapreduce
-
- IgfsJobAdapter - Class in org.apache.ignite.igfs.mapreduce
-
- IgfsJobAdapter() - Constructor for class org.apache.ignite.igfs.mapreduce.IgfsJobAdapter
-
- IgfsMetrics - Interface in org.apache.ignite.igfs
-
IGFS metrics snapshot for the file system.
- IgfsMode - Enum in org.apache.ignite.igfs
-
IGFS mode defining interactions with underlying secondary Hadoop file system.
- igfsName() - Method in interface org.apache.ignite.igfs.mapreduce.IgfsTaskArgs
-
Gets IGFS name.
- IgfsNewLineRecordResolver - Class in org.apache.ignite.igfs.mapreduce.records
-
Record resolver based on new line detection.
- IgfsNewLineRecordResolver() - Constructor for class org.apache.ignite.igfs.mapreduce.records.IgfsNewLineRecordResolver
-
- IgfsOutOfSpaceException - Exception in org.apache.ignite.igfs
-
IGFS exception that is thrown when it detected out-of-space condition.
- IgfsOutOfSpaceException(String) - Constructor for exception org.apache.ignite.igfs.IgfsOutOfSpaceException
-
Constructor.
- IgfsOutOfSpaceException(Throwable) - Constructor for exception org.apache.ignite.igfs.IgfsOutOfSpaceException
-
Constructor.
- IgfsOutOfSpaceException(String, Throwable) - Constructor for exception org.apache.ignite.igfs.IgfsOutOfSpaceException
-
Constructor.
- IgfsOutputStream - Class in org.apache.ignite.igfs
-
IGFS output stream to write data into the file system.
- IgfsOutputStream() - Constructor for class org.apache.ignite.igfs.IgfsOutputStream
-
- IgfsParentNotDirectoryException - Exception in org.apache.ignite.igfs
-
Exception thrown when parent supposed to be a directory is a file.
- IgfsParentNotDirectoryException(String) - Constructor for exception org.apache.ignite.igfs.IgfsParentNotDirectoryException
-
Constructor.
- IgfsParentNotDirectoryException(Throwable) - Constructor for exception org.apache.ignite.igfs.IgfsParentNotDirectoryException
-
Constructor.
- IgfsParentNotDirectoryException(String, Throwable) - Constructor for exception org.apache.ignite.igfs.IgfsParentNotDirectoryException
-
Constructor.
- IgfsPath - Class in org.apache.ignite.igfs
-
IGFS path to file in the file system.
- IgfsPath() - Constructor for class org.apache.ignite.igfs.IgfsPath
-
Constructs default root path.
- IgfsPath(URI) - Constructor for class org.apache.ignite.igfs.IgfsPath
-
Constructs a path from an URI
- IgfsPath(String) - Constructor for class org.apache.ignite.igfs.IgfsPath
-
Constructs a path from the URI string.
- IgfsPath(IgfsPath, String) - Constructor for class org.apache.ignite.igfs.IgfsPath
-
Resolve a child path against a parent path.
- IgfsPathAlreadyExistsException - Exception in org.apache.ignite.igfs
-
Exception thrown when target path supposed to be created already exists.
- IgfsPathAlreadyExistsException(String) - Constructor for exception org.apache.ignite.igfs.IgfsPathAlreadyExistsException
-
Constructor.
- IgfsPathAlreadyExistsException(Throwable) - Constructor for exception org.apache.ignite.igfs.IgfsPathAlreadyExistsException
-
Constructor.
- IgfsPathAlreadyExistsException(String, Throwable) - Constructor for exception org.apache.ignite.igfs.IgfsPathAlreadyExistsException
-
Constructor.
- IgfsPathIsDirectoryException - Exception in org.apache.ignite.igfs
-
Exception indicating that path is directory, while it is expected to be a file.
- IgfsPathIsDirectoryException(String) - Constructor for exception org.apache.ignite.igfs.IgfsPathIsDirectoryException
-
Constructor.
- IgfsPathIsDirectoryException(Throwable) - Constructor for exception org.apache.ignite.igfs.IgfsPathIsDirectoryException
-
Constructor.
- IgfsPathIsDirectoryException(String, Throwable) - Constructor for exception org.apache.ignite.igfs.IgfsPathIsDirectoryException
-
Constructor.
- IgfsPathIsNotDirectoryException - Exception in org.apache.ignite.igfs
-
Exception indicating that path is not directory.
- IgfsPathIsNotDirectoryException(String) - Constructor for exception org.apache.ignite.igfs.IgfsPathIsNotDirectoryException
-
Constructor.
- IgfsPathIsNotDirectoryException(Throwable) - Constructor for exception org.apache.ignite.igfs.IgfsPathIsNotDirectoryException
-
Constructor.
- IgfsPathIsNotDirectoryException(String, Throwable) - Constructor for exception org.apache.ignite.igfs.IgfsPathIsNotDirectoryException
-
Constructor.
- IgfsPathNotFoundException - Exception in org.apache.ignite.igfs
-
IGFS exception indicating that target resource is not found.
- IgfsPathNotFoundException(String) - Constructor for exception org.apache.ignite.igfs.IgfsPathNotFoundException
-
Constructor.
- IgfsPathNotFoundException(Throwable) - Constructor for exception org.apache.ignite.igfs.IgfsPathNotFoundException
-
Constructor.
- IgfsPathNotFoundException(String, Throwable) - Constructor for exception org.apache.ignite.igfs.IgfsPathNotFoundException
-
Constructor.
- IgfsPathSummary - Class in org.apache.ignite.igfs
-
Path summary: total files count, total directories count, total length.
- IgfsPathSummary() - Constructor for class org.apache.ignite.igfs.IgfsPathSummary
-
- IgfsPathSummary(IgfsPath) - Constructor for class org.apache.ignite.igfs.IgfsPathSummary
-
Construct empty path summary.
- IgfsPerBlockLruEvictionPolicy - Class in org.apache.ignite.cache.eviction.igfs
-
IGFS eviction policy which evicts particular blocks.
- IgfsPerBlockLruEvictionPolicy() - Constructor for class org.apache.ignite.cache.eviction.igfs.IgfsPerBlockLruEvictionPolicy
-
Default constructor.
- IgfsPerBlockLruEvictionPolicy(long, int) - Constructor for class org.apache.ignite.cache.eviction.igfs.IgfsPerBlockLruEvictionPolicy
-
Constructor.
- IgfsPerBlockLruEvictionPolicy(long, int, Collection<String>) - Constructor for class org.apache.ignite.cache.eviction.igfs.IgfsPerBlockLruEvictionPolicy
-
Constructor.
- IgfsPerBlockLruEvictionPolicyMXBean - Interface in org.apache.ignite.cache.eviction.igfs
-
MBean for IGFS per-block LRU eviction policy.
- IgfsRangeInputStream - Class in org.apache.ignite.igfs.mapreduce
-
Decorator for regular
IgfsInputStream which streams only data within the given range.
- IgfsRangeInputStream(IgfsInputStream, long, long) - Constructor for class org.apache.ignite.igfs.mapreduce.IgfsRangeInputStream
-
Constructor.
- IgfsRangeInputStream(IgfsInputStream, IgfsFileRange) - Constructor for class org.apache.ignite.igfs.mapreduce.IgfsRangeInputStream
-
Constructor.
- IgfsRecordResolver - Interface in org.apache.ignite.igfs.mapreduce
-
IGFS record resolver.
- IgfsSecondaryFileSystem - Interface in org.apache.ignite.igfs.secondary
-
Secondary file system interface.
- IgfsSecondaryFileSystemPositionedReadable - Interface in org.apache.ignite.igfs.secondary
-
The simplest data input interface to read from secondary file system.
- IgfsStringDelimiterRecordResolver - Class in org.apache.ignite.igfs.mapreduce.records
-
Record resolver based on delimiters represented as strings.
- IgfsStringDelimiterRecordResolver() - Constructor for class org.apache.ignite.igfs.mapreduce.records.IgfsStringDelimiterRecordResolver
-
- IgfsStringDelimiterRecordResolver(Charset, String...) - Constructor for class org.apache.ignite.igfs.mapreduce.records.IgfsStringDelimiterRecordResolver
-
Creates record resolver from given string and given charset.
- IgfsStringDelimiterRecordResolver(String...) - Constructor for class org.apache.ignite.igfs.mapreduce.records.IgfsStringDelimiterRecordResolver
-
Creates record resolver based on given string with default charset.
- IgfsTask<T,R> - Class in org.apache.ignite.igfs.mapreduce
-
IGFS task which can be executed on the grid using one of IgniteFs.execute() methods.
- IgfsTask() - Constructor for class org.apache.ignite.igfs.mapreduce.IgfsTask
-
- IgfsTaskArgs<T> - Interface in org.apache.ignite.igfs.mapreduce
-
IGFS task arguments.
- IgfsTaskNoReduceAdapter<T,R> - Class in org.apache.ignite.igfs.mapreduce
-
Convenient
IgfsTask adapter with empty reduce step.
- IgfsTaskNoReduceAdapter() - Constructor for class org.apache.ignite.igfs.mapreduce.IgfsTaskNoReduceAdapter
-
- IgfsUserContext - Class in org.apache.ignite.igfs
-
Provides ability to execute IGFS code in a context of a specific user.
- IgfsUserContext() - Constructor for class org.apache.ignite.igfs.IgfsUserContext
-
- ignite - Variable in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyAdapter
-
Grid.
- ignite - Variable in class org.apache.ignite.cache.hibernate.HibernateRegion
-
Grid instance.
- ignite - Variable in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
-
Auto injected ignite instance.
- ignite() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
-
- ignite() - Method in interface org.apache.ignite.cluster.ClusterGroup
-
Gets instance of grid.
- Ignite - Interface in org.apache.ignite
-
Main entry-point for all Ignite APIs.
- ignite() - Static method in class org.apache.ignite.Ignition
-
Gets an instance of default no-name grid.
- ignite(UUID) - Static method in class org.apache.ignite.Ignition
-
Gets a grid instance for given local node ID.
- ignite(String) - Static method in class org.apache.ignite.Ignition
-
Gets an named grid instance.
- ignite() - Method in class org.apache.ignite.messaging.MessagingListenActor
-
Gets grid instance associated with this actor.
- ignite - Variable in class org.apache.ignite.osgi.IgniteAbstractOsgiContextActivator
-
The instance of Ignite started by this Activator.
- ignite - Variable in class org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinderAdapter
-
Ignite instance .
- ignite - Variable in class org.apache.ignite.spi.IgniteSpiAdapter
-
Ignite instance.
- IGNITE_AFFINITY_HISTORY_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
-
Maximum size for affinity assignment history.
- IGNITE_ATOMIC_CACHE_DELETE_HISTORY_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
-
Maximum size for atomic cache queue delete history (default is 200 000 entries per partition).
- IGNITE_ATOMIC_DEFERRED_ACK_BUFFER_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
-
Atomic cache deferred update response buffer size.
- IGNITE_ATOMIC_DEFERRED_ACK_TIMEOUT - Static variable in class org.apache.ignite.IgniteSystemProperties
-
Atomic cache deferred update timeout.
- IGNITE_CACHE_CLIENT - Static variable in class org.apache.ignite.IgniteSystemProperties
-
Property controlling default behavior of cache client flag.
- IGNITE_CACHE_KEY_VALIDATION_DISABLED - Static variable in class org.apache.ignite.IgniteSystemProperties
-
Flag indicating whether validation of keys put to cache should be disabled.
- IGNITE_CACHE_RETRIES_COUNT - Static variable in class org.apache.ignite.IgniteSystemProperties
-
Number of cache operation retries in case of topology exceptions.
- IGNITE_CFG_FILE_PATH_PARAM - Static variable in class org.apache.ignite.startup.servlet.ServletContextListenerStartup
-
Configuration file path parameter name.
- IGNITE_CLUSTER_NAME - Static variable in class org.apache.ignite.mesos.ClusterProperties
-
- IGNITE_CLUSTER_NAME - Static variable in class org.apache.ignite.yarn.ClusterProperties
-
- IGNITE_CONFIG_URL - Static variable in class org.apache.ignite.IgniteSystemProperties
-
System property to hold optional configuration URL.
- IGNITE_CONFIG_XML - Static variable in class org.apache.ignite.mesos.ClusterProperties
-
- IGNITE_CONFIG_XML - Static variable in class org.apache.ignite.yarn.ClusterProperties
-
- IGNITE_CONFIG_XML_URL - Static variable in class org.apache.ignite.mesos.ClusterProperties
-
- IGNITE_CONSOLE_APPENDER - Static variable in class org.apache.ignite.IgniteSystemProperties
-
If this property is set to
true (default) and Ignite is launched
in verbose mode (see
IgniteSystemProperties.IGNITE_QUIET) and no console appenders can be found
in configuration, then default console appender will be added.
- IGNITE_DAEMON - Static variable in class org.apache.ignite.IgniteSystemProperties
-
Presence of this system property with value true will make the grid
node start as a daemon node.
- IGNITE_DEP_MODE_OVERRIDE - Static variable in class org.apache.ignite.IgniteSystemProperties
-
System property to override deployment mode configuration parameter.
- IGNITE_DISABLE_HOSTNAME_VERIFIER - Static variable in class org.apache.ignite.IgniteSystemProperties
-
- IGNITE_DISCOVERY_HISTORY_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
-
Maximum size for discovery messages history.
- IGNITE_DISK_SPACE_PER_NODE - Static variable in class org.apache.ignite.mesos.ClusterProperties
-
- IGNITE_DUMP_PENDING_OBJECTS_THRESHOLD - Static variable in class org.apache.ignite.IgniteSystemProperties
-
Number of times pending cache objects will be dumped to the log in case of partition exchange timeout.
- IGNITE_EXCEPTION_REGISTRY_MAX_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
-
Property controlling size of buffer holding last exception.
- IGNITE_FRAMEWORK_NAME - Static variable in class org.apache.ignite.mesos.IgniteFramework
-
Framework name.
- IGNITE_H2_DEBUG_CONSOLE - Static variable in class org.apache.ignite.IgniteSystemProperties
-
If this property set then debug console will be opened for H2 indexing SPI.
- IGNITE_HOME - Static variable in class org.apache.ignite.IgniteSystemProperties
-
Defines Ignite installation folder.
- IGNITE_HOSTNAME_CONSTRAINT - Static variable in class org.apache.ignite.mesos.ClusterProperties
-
- IGNITE_HOSTNAME_CONSTRAINT - Static variable in class org.apache.ignite.yarn.ClusterProperties
-
- IGNITE_HTTP_SERVER_HOST - Static variable in class org.apache.ignite.mesos.ClusterProperties
-
- IGNITE_HTTP_SERVER_PORT - Static variable in class org.apache.ignite.mesos.ClusterProperties
-
- IGNITE_IPC_SHMEM_SPACE_DEBUG - Static variable in class org.apache.ignite.IgniteSystemProperties
-
If this property is set to true then shared memory space native debug will be enabled.
- IGNITE_JCACHE_DEFAULT_ISOLATED - Static variable in class org.apache.ignite.IgniteSystemProperties
-
Property controlling whether CacheManager will start grid with isolated IP finder when default URL
is passed in.
- IGNITE_JDBC_DRIVER_CURSOR_REMOVE_DELAY - Static variable in class org.apache.ignite.IgniteSystemProperties
-
JDBC driver cursor remove delay.
- IGNITE_JETTY_HOST - Static variable in class org.apache.ignite.IgniteSystemProperties
-
This property allows to override Jetty host for REST processor.
- IGNITE_JETTY_LOG_NO_OVERRIDE - Static variable in class org.apache.ignite.IgniteSystemProperties
-
This property does not allow Ignite to override Jetty log configuration for REST processor.
- IGNITE_JETTY_PORT - Static variable in class org.apache.ignite.IgniteSystemProperties
-
This property allows to override Jetty local port for REST processor.
- IGNITE_JOBS_HISTORY_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
-
System property to override default job processor maps sizes for finished jobs and
cancellation requests.
- IGNITE_JOBS_METRICS_CONCURRENCY_LEVEL - Static variable in class org.apache.ignite.IgniteSystemProperties
-
System property to override default job metrics processor property defining
concurrency level for structure holding job metrics snapshots.
- IGNITE_JVM_OPTS - Static variable in class org.apache.ignite.mesos.ClusterProperties
-
- IGNITE_JVM_OPTS - Static variable in class org.apache.ignite.yarn.ClusterProperties
-
- IGNITE_LOCAL_HOST - Static variable in class org.apache.ignite.IgniteSystemProperties
-
Name of system property to set system-wide local IP address or host.
- IGNITE_LOCAL_WORK_DIR - Static variable in class org.apache.ignite.yarn.ClusterProperties
-
- IGNITE_LOG_DIR - Static variable in class org.apache.ignite.IgniteSystemProperties
-
Environment variable to override logging directory that has been set in logger configuration.
- IGNITE_LOG_GRID_NAME - Static variable in class org.apache.ignite.IgniteSystemProperties
-
If this system property is present the Ignite will include grid name into verbose log.
- IGNITE_MAP_CONCURRENCY_LEVEL - Static variable in class org.apache.ignite.IgniteSystemProperties
-
Concurrency level for all concurrent hash maps created by Ignite.
- IGNITE_MARSHAL_BUFFERS_RECHECK - Static variable in class org.apache.ignite.IgniteSystemProperties
-
System property to specify how often in milliseconds marshal buffers
should be rechecked and potentially trimmed.
- IGNITE_MAX_COMPLETED_TX_COUNT - Static variable in class org.apache.ignite.IgniteSystemProperties
-
Property controlling size of buffer holding completed transaction versions.
- IGNITE_MAX_NESTED_LISTENER_CALLS - Static variable in class org.apache.ignite.IgniteSystemProperties
-
Maximum number of nested listener calls before listener notification becomes asynchronous.
- IGNITE_MBEAN_APPEND_CLASS_LOADER_ID - Static variable in class org.apache.ignite.IgniteSystemProperties
-
If this property is set to true then Ignite will append
hash code of class loader to MXBean name.
- IGNITE_MBEAN_APPEND_JVM_ID - Static variable in class org.apache.ignite.IgniteSystemProperties
-
If this property is set to
true then Ignite will append
hash code of
Ignite class as hex string and append
JVM name returned by
RuntimeMXBean.getName().
- IGNITE_MEMORY_PER_NODE - Static variable in class org.apache.ignite.mesos.ClusterProperties
-
- IGNITE_MEMORY_PER_NODE - Static variable in class org.apache.ignite.yarn.ClusterProperties
-
- IGNITE_MIN_BUFFERED_COMMUNICATION_MSG_CNT - Static variable in class org.apache.ignite.IgniteSystemProperties
-
Deprecated.
Not used anymore.
- IGNITE_MIN_CPU_PER_NODE - Static variable in class org.apache.ignite.mesos.ClusterProperties
-
- IGNITE_MIN_MEMORY_PER_NODE - Static variable in class org.apache.ignite.mesos.ClusterProperties
-
- IGNITE_NEAR_GET_MAX_REMAPS - Static variable in class org.apache.ignite.IgniteSystemProperties
-
This property defines the maximum number of attempts to remap near get to the same
primary node.
- IGNITE_NO_ASCII - Static variable in class org.apache.ignite.IgniteSystemProperties
-
If this system property is present (any value) - no ASCII logo will
be printed.
- IGNITE_NO_DISCO_ORDER - Static variable in class org.apache.ignite.IgniteSystemProperties
-
Name of the system property to disable requirement for proper node ordering
by discovery SPI.
- IGNITE_NO_SHUTDOWN_HOOK - Static variable in class org.apache.ignite.IgniteSystemProperties
-
If this system property is set to false - no shutdown hook will be set.
- IGNITE_NODE_COUNT - Static variable in class org.apache.ignite.mesos.ClusterProperties
-
- IGNITE_NODE_COUNT - Static variable in class org.apache.ignite.yarn.ClusterProperties
-
- IGNITE_OFFHEAP_SAFE_RELEASE - Static variable in class org.apache.ignite.IgniteSystemProperties
-
Flag that will force Ignite to fill memory block with some recognisable pattern right before
this memory block is released.
- IGNITE_OPTIMIZED_MARSHALLER_USE_DEFAULT_SUID - Static variable in class org.apache.ignite.IgniteSystemProperties
-
- IGNITE_OVERRIDE_MCAST_GRP - Static variable in class org.apache.ignite.IgniteSystemProperties
-
System property to override multicast group taken from configuration.
- IGNITE_PACKAGE_URL - Static variable in class org.apache.ignite.mesos.ClusterProperties
-
- IGNITE_PATH - Static variable in class org.apache.ignite.yarn.ClusterProperties
-
- IGNITE_PERFORMANCE_SUGGESTIONS_DISABLED - Static variable in class org.apache.ignite.IgniteSystemProperties
-
Flag indicating whether performance suggestions output on start should be disabled.
- IGNITE_PREFIX - Static variable in class org.apache.ignite.mesos.resource.ResourceHandler
-
- IGNITE_PRELOAD_RESEND_TIMEOUT - Static variable in class org.apache.ignite.IgniteSystemProperties
-
System property to hold preload resend timeout for evicted partitions.
- IGNITE_PROG_NAME - Static variable in class org.apache.ignite.IgniteSystemProperties
-
Name of the system property defining name of command line program.
- IGNITE_QUIET - Static variable in class org.apache.ignite.IgniteSystemProperties
-
Set to either true or false to enable or disable quiet mode
of Ignite.
- IGNITE_REFLECTION_CACHE_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
-
System property to override default reflection cache size.
- IGNITE_RELEASES_DIR - Static variable in class org.apache.ignite.yarn.ClusterProperties
-
- IGNITE_REST_MAX_TASK_RESULTS - Static variable in class org.apache.ignite.IgniteSystemProperties
-
This property allows to override maximum count of task results stored on one node
in REST processor.
- IGNITE_REST_SESSION_TIMEOUT - Static variable in class org.apache.ignite.IgniteSystemProperties
-
This property allow rewriting default (30) rest session expire time (in seconds).
- IGNITE_RESTART_CODE - Static variable in class org.apache.ignite.IgniteSystemProperties
-
This property is used internally to pass an exit code to loader when
Ignite instance is being restarted.
- IGNITE_RUN_CPU_PER_NODE - Static variable in class org.apache.ignite.mesos.ClusterProperties
-
- IGNITE_RUN_CPU_PER_NODE - Static variable in class org.apache.ignite.yarn.ClusterProperties
-
- IGNITE_SKIP_CONFIGURATION_CONSISTENCY_CHECK - Static variable in class org.apache.ignite.IgniteSystemProperties
-
Property allowing to skip configuration consistency checks.
- IGNITE_SLOW_TX_WARN_TIMEOUT - Static variable in class org.apache.ignite.IgniteSystemProperties
-
Transactions that take more time, than value of this property, will be output to log
with warning level.
- IGNITE_SQL_MERGE_TABLE_MAX_SIZE - Static variable in class org.apache.ignite.IgniteSystemProperties
-
Property controlling maximum number of SQL result rows which can be fetched into a merge table.
- IGNITE_SSH_HOST - Static variable in class org.apache.ignite.IgniteSystemProperties
-
System property to hold SSH host for visor-started nodes.
- IGNITE_SSH_USER_NAME - Static variable in class org.apache.ignite.IgniteSystemProperties
-
System property to hold SSH user name for visor-started nodes.
- IGNITE_STARVATION_CHECK_INTERVAL - Static variable in class org.apache.ignite.IgniteSystemProperties
-
This system property defines interval in milliseconds in which Ignite will check
thread pool state for starvation.
- IGNITE_SUCCESS_FILE - Static variable in class org.apache.ignite.IgniteSystemProperties
-
Name of the system property defining success file name.
- IGNITE_TCP_DISCOVERY_ADDRESSES - Static variable in class org.apache.ignite.IgniteSystemProperties
-
Comma separated list of addresses in format "10.100.22.100:45000,10.100.22.101:45000".
- IGNITE_TOTAL_CPU - Static variable in class org.apache.ignite.mesos.ClusterProperties
-
- IGNITE_TOTAL_DISK_SPACE - Static variable in class org.apache.ignite.mesos.ClusterProperties
-
- IGNITE_TOTAL_MEMORY - Static variable in class org.apache.ignite.mesos.ClusterProperties
-
- IGNITE_TX_SALVAGE_TIMEOUT - Static variable in class org.apache.ignite.IgniteSystemProperties
-
Timeout after which all uncompleted transactions originated by left node will be
salvaged (i.e. invalidated and committed).
- IGNITE_UPDATE_NOTIFIER - Static variable in class org.apache.ignite.IgniteSystemProperties
-
If this system property is set to false - no checks for new versions will
be performed by Ignite.
- IGNITE_URL - Static variable in class org.apache.ignite.yarn.ClusterProperties
-
- IGNITE_USERS_LIBS - Static variable in class org.apache.ignite.mesos.ClusterProperties
-
- IGNITE_USERS_LIBS - Static variable in class org.apache.ignite.yarn.ClusterProperties
-
- IGNITE_USERS_LIBS_URL - Static variable in class org.apache.ignite.mesos.ClusterProperties
-
- IGNITE_VERSION - Static variable in class org.apache.ignite.mesos.ClusterProperties
-
- IGNITE_WORK_DIR - Static variable in class org.apache.ignite.IgniteSystemProperties
-
Environment variable to set work directory.
- IGNITE_WORK_DIR - Static variable in class org.apache.ignite.mesos.ClusterProperties
-
- IGNITE_WORKING_DIR - Static variable in class org.apache.ignite.yarn.ClusterProperties
-
- IgniteAbstractOsgiContextActivator - Class in org.apache.ignite.osgi
-
This BundleActivator starts Apache Ignite inside the OSGi container when the bundle is started.
- IgniteAbstractOsgiContextActivator() - Constructor for class org.apache.ignite.osgi.IgniteAbstractOsgiContextActivator
-
- IgniteAsyncSupport - Interface in org.apache.ignite.lang
-
Allows to enable asynchronous mode on Ignite APIs.
- IgniteAsyncSupported - Annotation Type in org.apache.ignite.lang
-
Annotation to indicate that method can be executed asynchronously if async mode is enabled.
- IgniteAtomicLong - Interface in org.apache.ignite
-
This interface provides a rich API for working with distributedly cached atomic long value.
- IgniteAtomicReference<T> - Interface in org.apache.ignite
-
This interface provides a rich API for working with distributed atomic reference.
- IgniteAtomicSequence - Interface in org.apache.ignite
-
This interface provides a rich API for working with distributed atomic sequence.
- IgniteAtomicStamped<T,S> - Interface in org.apache.ignite
-
This interface provides a rich API for working with distributed atomic stamped value.
- IgniteAuthenticationException - Exception in org.apache.ignite
-
Exception that represents authentication failure.
- IgniteAuthenticationException(String) - Constructor for exception org.apache.ignite.IgniteAuthenticationException
-
Creates authentication exception with given error message.
- IgniteBiClosure<E1,E2,R> - Interface in org.apache.ignite.lang
-
Defines generic closure with two parameters.
- IgniteBiInClosure<E1,E2> - Interface in org.apache.ignite.lang
-
Closure with two in-parameters and void return type.
- IgniteBinary - Interface in org.apache.ignite
-
Defines binary objects functionality.
- IgniteBiPredicate<E1,E2> - Interface in org.apache.ignite.lang
-
Defines a predicate which accepts two parameters and returns true or false.
- IgniteBiTuple<V1,V2> - Class in org.apache.ignite.lang
-
Convenience class representing mutable tuple of two values.
- IgniteBiTuple() - Constructor for class org.apache.ignite.lang.IgniteBiTuple
-
- IgniteBiTuple(V1, V2) - Constructor for class org.apache.ignite.lang.IgniteBiTuple
-
Fully initializes this tuple.
- IgniteCache<K,V> - Interface in org.apache.ignite
-
Main entry point for all Data Grid APIs.
- igniteCacheConfiguration() - Method in interface org.apache.ignite.plugin.CachePluginContext
-
- IgniteCallable<V> - Interface in org.apache.ignite.lang
-
Grid-aware adapter for
Callable implementations.
- igniteCfg() - Method in class org.apache.ignite.mesos.ClusterProperties
-
- igniteCfg() - Method in class org.apache.ignite.yarn.ClusterProperties
-
- IgniteCheckedException - Exception in org.apache.ignite
-
General grid exception.
- IgniteCheckedException() - Constructor for exception org.apache.ignite.IgniteCheckedException
-
Create empty exception.
- IgniteCheckedException(String) - Constructor for exception org.apache.ignite.IgniteCheckedException
-
Creates new exception with given error message.
- IgniteCheckedException(Throwable) - Constructor for exception org.apache.ignite.IgniteCheckedException
-
Creates new grid exception with given throwable as a cause and
source of error message.
- IgniteCheckedException(String, Throwable) - Constructor for exception org.apache.ignite.IgniteCheckedException
-
Creates new exception with given error message and optional nested exception.
- IgniteClientDisconnectedException - Exception in org.apache.ignite
-
Exception thrown from Ignite API when client node disconnected from cluster.
- IgniteClientDisconnectedException(IgniteFuture<?>, String) - Constructor for exception org.apache.ignite.IgniteClientDisconnectedException
-
- IgniteClientDisconnectedException(IgniteFuture<?>, String, Throwable) - Constructor for exception org.apache.ignite.IgniteClientDisconnectedException
-
- IgniteClosure<E,R> - Interface in org.apache.ignite.lang
-
Defines generic closure with one parameter.
- IgniteCluster - Interface in org.apache.ignite
-
Represents whole cluster (all available nodes) and also provides a handle on
IgniteCluster.nodeLocalMap() which
provides map-like functionality linked to current grid node.
- IgniteCompute - Interface in org.apache.ignite
-
Defines compute grid functionality for executing tasks and closures over nodes
in the
ClusterGroup.
- IgniteConfiguration - Class in org.apache.ignite.configuration
-
This class defines grid runtime configuration.
- IgniteConfiguration() - Constructor for class org.apache.ignite.configuration.IgniteConfiguration
-
Creates valid grid configuration with all default values.
- IgniteConfiguration(IgniteConfiguration) - Constructor for class org.apache.ignite.configuration.IgniteConfiguration
-
Creates grid configuration by coping all configuration properties from
given configuration.
- igniteConfiguration() - Method in class org.apache.ignite.osgi.IgniteAbstractOsgiContextActivator
-
Override this method to provide the Ignite configuration this bundle will start.
- igniteConfiguration() - Method in interface org.apache.ignite.plugin.CachePluginContext
-
- igniteConfiguration() - Method in interface org.apache.ignite.plugin.PluginContext
-
- igniteConfigUrl() - Method in class org.apache.ignite.mesos.ClusterProperties
-
- igniteConfigUrl() - Method in class org.apache.ignite.mesos.resource.ResourceProvider
-
- IgniteContainer - Class in org.apache.ignite.yarn
-
Information about launched task.
- IgniteContainer(ContainerId, NodeId, double, double) - Constructor for class org.apache.ignite.yarn.IgniteContainer
-
Ignite launched task.
- IgniteCountDownLatch - Interface in org.apache.ignite
-
This interface provides a rich API for working with distributed count down latch.
- IgniteDataStreamer<K,V> - Interface in org.apache.ignite
-
Data streamer is responsible for streaming external data into cache.
- IgniteDeploymentException - Exception in org.apache.ignite
-
Deployment or re-deployment failed.
- IgniteDeploymentException(String) - Constructor for exception org.apache.ignite.IgniteDeploymentException
-
Creates new exception with given error message.
- IgniteDeploymentException(Throwable) - Constructor for exception org.apache.ignite.IgniteDeploymentException
-
Creates new exception with given throwable as a nested cause and
source of error message.
- IgniteDeploymentException(String, Throwable) - Constructor for exception org.apache.ignite.IgniteDeploymentException
-
Creates a new exception with given error message and optional nested cause exception.
- IgniteEvents - Interface in org.apache.ignite
-
- IgniteException - Exception in org.apache.ignite
-
General grid exception.
- IgniteException() - Constructor for exception org.apache.ignite.IgniteException
-
Create empty exception.
- IgniteException(String) - Constructor for exception org.apache.ignite.IgniteException
-
Creates new exception with given error message.
- IgniteException(Throwable) - Constructor for exception org.apache.ignite.IgniteException
-
Creates new grid exception with given throwable as a cause and
source of error message.
- IgniteException(String, Throwable) - Constructor for exception org.apache.ignite.IgniteException
-
Creates new exception with given error message and optional nested exception.
- IgniteFileSystem - Interface in org.apache.ignite
-
IGnite File System API.
- IgniteFramework - Class in org.apache.ignite.mesos
-
Ignite mesos framework.
- IgniteFramework() - Constructor for class org.apache.ignite.mesos.IgniteFramework
-
- IgniteFuture<V> - Interface in org.apache.ignite.lang
-
Future with simplified exception handling, functional programming support
and ability to listen for future completion via functional callback.
- IgniteFutureCancelledException - Exception in org.apache.ignite.lang
-
Future computation cannot be retrieved because it was cancelled.
- IgniteFutureCancelledException(String) - Constructor for exception org.apache.ignite.lang.IgniteFutureCancelledException
-
Creates new exception with given error message.
- IgniteFutureCancelledException(Throwable) - Constructor for exception org.apache.ignite.lang.IgniteFutureCancelledException
-
Creates new exception with given throwable as a nested cause and
source of error message.
- IgniteFutureCancelledException(String, Throwable) - Constructor for exception org.apache.ignite.lang.IgniteFutureCancelledException
-
Creates a new exception with given error message and optional nested cause exception.
- IgniteFutureTimeoutException - Exception in org.apache.ignite.lang
-
Future computation completion is timed out.
- IgniteFutureTimeoutException(String) - Constructor for exception org.apache.ignite.lang.IgniteFutureTimeoutException
-
Creates new exception with given error message.
- IgniteFutureTimeoutException(Throwable) - Constructor for exception org.apache.ignite.lang.IgniteFutureTimeoutException
-
Creates new exception with given throwable as a nested cause and
source of error message.
- IgniteFutureTimeoutException(String, Throwable) - Constructor for exception org.apache.ignite.lang.IgniteFutureTimeoutException
-
Creates a new exception with given error message and optional nested cause exception.
- IgniteHadoopClientProtocolProvider - Class in org.apache.ignite.hadoop.mapreduce
-
Ignite Hadoop client protocol provider.
- IgniteHadoopClientProtocolProvider() - Constructor for class org.apache.ignite.hadoop.mapreduce.IgniteHadoopClientProtocolProvider
-
- IgniteHadoopFileSystem - Class in org.apache.ignite.hadoop.fs.v1
-
IGFS Hadoop 1.x file system driver over file system API.
- IgniteHadoopFileSystem() - Constructor for class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
-
- IgniteHadoopFileSystem - Class in org.apache.ignite.hadoop.fs.v2
-
IGFS Hadoop 2.x file system driver over file system API.
- IgniteHadoopFileSystem(URI, Configuration) - Constructor for class org.apache.ignite.hadoop.fs.v2.IgniteHadoopFileSystem
-
- IgniteHadoopFileSystemCounterWriter - Class in org.apache.ignite.hadoop.fs
-
Statistic writer implementation that writes info into any Hadoop file system.
- IgniteHadoopFileSystemCounterWriter() - Constructor for class org.apache.ignite.hadoop.fs.IgniteHadoopFileSystemCounterWriter
-
- IgniteHadoopIgfsSecondaryFileSystem - Class in org.apache.ignite.hadoop.fs
-
Secondary file system which delegates calls to an instance of Hadoop
FileSystem.
- IgniteHadoopIgfsSecondaryFileSystem() - Constructor for class org.apache.ignite.hadoop.fs.IgniteHadoopIgfsSecondaryFileSystem
-
Default constructor for Spring.
- IgniteHadoopIgfsSecondaryFileSystem(String) - Constructor for class org.apache.ignite.hadoop.fs.IgniteHadoopIgfsSecondaryFileSystem
-
- IgniteHadoopIgfsSecondaryFileSystem(String, String) - Constructor for class org.apache.ignite.hadoop.fs.IgniteHadoopIgfsSecondaryFileSystem
-
- IgniteHadoopIgfsSecondaryFileSystem(String, String, String) - Constructor for class org.apache.ignite.hadoop.fs.IgniteHadoopIgfsSecondaryFileSystem
-
- IgniteHadoopMapReducePlanner - Class in org.apache.ignite.hadoop.mapreduce
-
Default map-reduce planner implementation.
- IgniteHadoopMapReducePlanner() - Constructor for class org.apache.ignite.hadoop.mapreduce.IgniteHadoopMapReducePlanner
-
- IgniteIllegalStateException - Exception in org.apache.ignite
-
This exception indicates the ignite access in invalid state.
- IgniteIllegalStateException(String, Throwable) - Constructor for exception org.apache.ignite.IgniteIllegalStateException
-
Constructs exception with given message and cause.
- IgniteIllegalStateException(Throwable) - Constructor for exception org.apache.ignite.IgniteIllegalStateException
-
Creates exception given throwable as a cause and
source of error message.
- IgniteIllegalStateException(String) - Constructor for exception org.apache.ignite.IgniteIllegalStateException
-
Constructs exception with given message.
- IgniteInClosure<E> - Interface in org.apache.ignite.lang
-
Closure with one in-parameter and void return type.
- IgniteInstanceResource - Annotation Type in org.apache.ignite.resources
-
Annotates a field or a setter method for injection of current
Ignite instance.
- IgniteInterruptedException - Exception in org.apache.ignite
-
- IgniteInterruptedException(InterruptedException) - Constructor for exception org.apache.ignite.IgniteInterruptedException
-
Creates new exception with given throwable as a nested cause and
source of error message.
- IgniteInterruptedException(String) - Constructor for exception org.apache.ignite.IgniteInterruptedException
-
Creates a new exception with given error message and optional nested cause exception.
- IgniteInterruptedException(String, InterruptedException) - Constructor for exception org.apache.ignite.IgniteInterruptedException
-
Creates a new exception with given error message and optional nested cause exception.
- IgniteJdbcDriver - Class in org.apache.ignite
-
JDBC driver implementation for In-Memory Data Grid.
- IgniteJdbcDriver() - Constructor for class org.apache.ignite.IgniteJdbcDriver
-
- igniteLocalWorkDir() - Method in class org.apache.ignite.yarn.ClusterProperties
-
- IgniteLogger - Interface in org.apache.ignite
-
This interface defines basic logging functionality used throughout the system.
- IgniteMessaging - Interface in org.apache.ignite
-
- IgniteMXBean - Interface in org.apache.ignite.mxbean
-
This interface defines JMX view on kernal.
- IgniteNodeValidationResult - Class in org.apache.ignite.spi
-
Result of joining node validation.
- IgniteNodeValidationResult(UUID, String, String) - Constructor for class org.apache.ignite.spi.IgniteNodeValidationResult
-
- IgniteNotPeerDeployable - Annotation Type in org.apache.ignite.lang
-
This annotations should be used to mark any type that should not be
peer deployable.
- IgniteOsgiUtils - Class in org.apache.ignite.osgi
-
Helper class for OSGi.
- IgniteOutClosure<T> - Interface in org.apache.ignite.lang
-
Closure that does not take any parameters and returns a value.
- ignitePackageUrl() - Method in class org.apache.ignite.mesos.ClusterProperties
-
- ignitePath() - Method in class org.apache.ignite.yarn.ClusterProperties
-
- IgnitePlugin - Interface in org.apache.ignite.plugin
-
Marker interface for all Ignite plugins.
- IgnitePortProtocol - Enum in org.apache.ignite.spi
-
Protocols supported by port processor.
- IgnitePredicate<E> - Interface in org.apache.ignite.lang
-
Defines a predicate which accepts a parameter and returns true or false.
- IgniteProductVersion - Class in org.apache.ignite.lang
-
Represents node version.
- IgniteProductVersion() - Constructor for class org.apache.ignite.lang.IgniteProductVersion
-
- IgniteProductVersion(byte, byte, byte, long, byte[]) - Constructor for class org.apache.ignite.lang.IgniteProductVersion
-
- IgniteProductVersion(byte, byte, byte, String, long, byte[]) - Constructor for class org.apache.ignite.lang.IgniteProductVersion
-
- IgniteProvider - Class in org.apache.ignite.mesos.resource
-
Class downloads and stores Ignite.
- IgniteProvider(String) - Constructor for class org.apache.ignite.mesos.resource.IgniteProvider
-
- IgniteProvider - Class in org.apache.ignite.yarn
-
Downloads and stores Ignite.
- IgniteProvider(ClusterProperties, FileSystem) - Constructor for class org.apache.ignite.yarn.IgniteProvider
-
- IgniteProvider.VersionComparator - Class in org.apache.ignite.yarn
-
Ignite version comparator.
- IgniteQueue<T> - Interface in org.apache.ignite
-
This interface provides a rich API for working with distributed queues based on In-Memory Data Grid.
- IgniteReducer<E,R> - Interface in org.apache.ignite.lang
-
Defines generic reducer that collects multiple values and reduces them into one.
- IgniteReflectionFactory<T> - Class in org.apache.ignite.configuration
-
Factory implementation that use reflection to create instance of given class.
- IgniteReflectionFactory() - Constructor for class org.apache.ignite.configuration.IgniteReflectionFactory
-
Default constructor.
- IgniteReflectionFactory(Class<? extends T>, boolean) - Constructor for class org.apache.ignite.configuration.IgniteReflectionFactory
-
- IgniteReflectionFactory(Class<? extends T>) - Constructor for class org.apache.ignite.configuration.IgniteReflectionFactory
-
Creates non-singleton component factory.
- igniteReleasesDir() - Method in class org.apache.ignite.yarn.ClusterProperties
-
- IgniteRunnable - Interface in org.apache.ignite.lang
-
Grid-aware adapter for
Runnable implementations.
- IgniteScheduler - Interface in org.apache.ignite
-
Provides functionality for scheduling jobs locally using UNIX cron-based syntax.
- IgniteScheduler - Class in org.apache.ignite.mesos
-
Ignite scheduler receives offers from Mesos and decides how many resources will be occupied.
- IgniteScheduler(ClusterProperties, ResourceProvider) - Constructor for class org.apache.ignite.mesos.IgniteScheduler
-
- IgniteSemaphore - Interface in org.apache.ignite
-
This interface provides a rich API for working with distributed semaphore.
- IgniteServices - Interface in org.apache.ignite
-
Defines functionality necessary to deploy distributed services on the grid.
- IgniteSet<T> - Interface in org.apache.ignite
-
Set implementation based on on In-Memory Data Grid.
- IgniteSink - Class in org.apache.ignite.stream.flume
-
Flume sink for Apache Ignite.
- IgniteSink() - Constructor for class org.apache.ignite.stream.flume.IgniteSink
-
Empty constructor.
- IgniteSinkConstants - Class in org.apache.ignite.stream.flume
-
Configuration strings for sending data to cache.
- IgniteSinkConstants() - Constructor for class org.apache.ignite.stream.flume.IgniteSinkConstants
-
- IgniteSpi - Interface in org.apache.ignite.spi
-
This interface defines life-cycle of SPI implementation.
- IgniteSpiAdapter - Class in org.apache.ignite.spi
-
This class provides convenient adapter for SPI implementations.
- IgniteSpiAdapter() - Constructor for class org.apache.ignite.spi.IgniteSpiAdapter
-
Creates new adapter and initializes it from the current (this) class.
- IgniteSpiCloseableIterator<T> - Interface in org.apache.ignite.spi
-
Closeable iterator.
- IgniteSpiConfiguration - Annotation Type in org.apache.ignite.spi
-
Annotates SPI configuration setters on whether or not it is optional.
- IgniteSpiConsistencyChecked - Annotation Type in org.apache.ignite.spi
-
SPIs that have this annotation present will be checked for consistency within grid.
- IgniteSpiContext - Interface in org.apache.ignite.spi
-
SPI context provides common functionality for all SPI implementations.
- IgniteSpiException - Exception in org.apache.ignite.spi
-
Exception thrown by SPI implementations.
- IgniteSpiException(String) - Constructor for exception org.apache.ignite.spi.IgniteSpiException
-
Creates new SPI exception with given error message.
- IgniteSpiException(Throwable) - Constructor for exception org.apache.ignite.spi.IgniteSpiException
-
Creates new SPI exception given throwable as a cause and
source of error message.
- IgniteSpiException(String, Throwable) - Constructor for exception org.apache.ignite.spi.IgniteSpiException
-
Creates new SPI exception with given error message and optional nested exception.
- IgniteSpiManagementMBean - Interface in org.apache.ignite.spi
-
This interface defines basic MBean for all SPI implementations.
- IgniteSpiMultiException - Exception in org.apache.ignite.spi
-
Grid SPI exception which may contain more than one failure.
- IgniteSpiMultiException(String) - Constructor for exception org.apache.ignite.spi.IgniteSpiMultiException
-
Creates new exception with given error message.
- IgniteSpiMultiException(Throwable) - Constructor for exception org.apache.ignite.spi.IgniteSpiMultiException
-
Creates new grid exception with given throwable as a cause and
source of error message.
- IgniteSpiMultiException(String, Throwable) - Constructor for exception org.apache.ignite.spi.IgniteSpiMultiException
-
Creates new exception with given error message and optional nested exception.
- IgniteSpiMultiException(String, Throwable, Collection<Throwable>) - Constructor for exception org.apache.ignite.spi.IgniteSpiMultiException
-
Creates new exception with given error message and optional nested exception.
- IgniteSpiMultipleInstancesSupport - Annotation Type in org.apache.ignite.spi
-
Annotates whether or not multiple instances of this SPI can be
started in the same VM.
- IgniteSpiNoop - Annotation Type in org.apache.ignite.spi
-
Annotates NO-OP SPI implementations.
- IgniteSpiOperationTimeoutException - Exception in org.apache.ignite.spi
-
- IgniteSpiOperationTimeoutException(String) - Constructor for exception org.apache.ignite.spi.IgniteSpiOperationTimeoutException
-
Constructor.
- IgniteSpiOperationTimeoutHelper - Class in org.apache.ignite.spi
-
Object that incorporates logic that determines a timeout value for the next network related operation and checks
whether a failure detection timeout is reached or not.
- IgniteSpiOperationTimeoutHelper(IgniteSpiAdapter) - Constructor for class org.apache.ignite.spi.IgniteSpiOperationTimeoutHelper
-
Constructor.
- IgniteSpiThread - Class in org.apache.ignite.spi
-
This class provides convenient adapter for threads used by SPIs.
- IgniteSpiThread(String, String, IgniteLogger) - Constructor for class org.apache.ignite.spi.IgniteSpiThread
-
Creates thread with given name.
- IgniteSpiThreadFactory - Class in org.apache.ignite.spi
-
This class provides implementation of
ThreadFactory factory
for creating grid SPI threads.
- IgniteSpiThreadFactory(String, String, IgniteLogger) - Constructor for class org.apache.ignite.spi.IgniteSpiThreadFactory
-
- IgniteSpiTimeoutObject - Interface in org.apache.ignite.spi
-
- IgniteSpiVersionCheckException - Exception in org.apache.ignite.spi
-
Grid SPI exception for version check failure.
- IgniteSpiVersionCheckException(String) - Constructor for exception org.apache.ignite.spi.IgniteSpiVersionCheckException
-
Creates new SPI exception with given error message.
- IgniteSpiVersionCheckException(Throwable) - Constructor for exception org.apache.ignite.spi.IgniteSpiVersionCheckException
-
Creates new SPI exception given throwable as a cause and
source of error message.
- IgniteSpiVersionCheckException(String, Throwable) - Constructor for exception org.apache.ignite.spi.IgniteSpiVersionCheckException
-
Creates new SPI exception with given error message and optional nested exception.
- IgniteSpring - Class in org.apache.ignite
-
Factory methods to start Ignite with optional Spring application context, this context can be injected into
grid tasks and grid jobs using
@SpringApplicationContextResource
annotation.
- IgniteSpring() - Constructor for class org.apache.ignite.IgniteSpring
-
- IgniteSpringBean - Class in org.apache.ignite
-
Grid Spring bean allows to bypass
Ignition methods.
- IgniteSpringBean() - Constructor for class org.apache.ignite.IgniteSpringBean
-
- IgniteState - Enum in org.apache.ignite
-
- IgniteStripedThreadPoolExecutor - Class in org.apache.ignite.thread
-
An
ExecutorService that executes submitted tasks using pooled grid threads.
- IgniteStripedThreadPoolExecutor() - Constructor for class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
-
- IgniteSystemProperties - Class in org.apache.ignite
-
Contains constants for all system properties and environmental variables in Ignite.
- IgniteTask - Class in org.apache.ignite.mesos
-
Information about launched task.
- IgniteTask(String, double, double, double) - Constructor for class org.apache.ignite.mesos.IgniteTask
-
Ignite launched task.
- IgniteThread - Class in org.apache.ignite.thread
-
This class adds some necessary plumbing on top of the
Thread class.
- IgniteThread(GridWorker) - Constructor for class org.apache.ignite.thread.IgniteThread
-
Creates thread with given worker.
- IgniteThread(String, String, Runnable) - Constructor for class org.apache.ignite.thread.IgniteThread
-
Creates grid thread with given name for a given grid.
- IgniteThread(ThreadGroup, String, String, Runnable) - Constructor for class org.apache.ignite.thread.IgniteThread
-
Creates grid thread with given name for a given grid with specified
thread group.
- IgniteThread(String, ThreadGroup, String) - Constructor for class org.apache.ignite.thread.IgniteThread
-
- IgniteThreadFactory - Class in org.apache.ignite.thread
-
This class provides implementation of
ThreadFactory factory
for creating grid threads.
- IgniteThreadFactory(String) - Constructor for class org.apache.ignite.thread.IgniteThreadFactory
-
Constructs new thread factory for given grid.
- IgniteThreadFactory(String, String) - Constructor for class org.apache.ignite.thread.IgniteThreadFactory
-
Constructs new thread factory for given grid.
- IgniteThreadPoolExecutor - Class in org.apache.ignite.thread
-
An
ExecutorService that executes submitted tasks using pooled grid threads.
- IgniteThreadPoolExecutor() - Constructor for class org.apache.ignite.thread.IgniteThreadPoolExecutor
-
Creates a new service with default initial parameters.
- IgniteThreadPoolExecutor(int, int, long, BlockingQueue<Runnable>) - Constructor for class org.apache.ignite.thread.IgniteThreadPoolExecutor
-
Creates a new service with the given initial parameters.
- IgniteThreadPoolExecutor(int, int, long, BlockingQueue<Runnable>, RejectedExecutionHandler) - Constructor for class org.apache.ignite.thread.IgniteThreadPoolExecutor
-
Creates a new service with the given initial parameters.
- IgniteThreadPoolExecutor(String) - Constructor for class org.apache.ignite.thread.IgniteThreadPoolExecutor
-
Creates a new service with default initial parameters.
- IgniteThreadPoolExecutor(String, String, int, int, long, BlockingQueue<Runnable>) - Constructor for class org.apache.ignite.thread.IgniteThreadPoolExecutor
-
Creates a new service with the given initial parameters.
- IgniteThreadPoolExecutor(int, int, long, BlockingQueue<Runnable>, ThreadFactory, RejectedExecutionHandler) - Constructor for class org.apache.ignite.thread.IgniteThreadPoolExecutor
-
Creates a new service with the given initial parameters.
- IgniteTransactions - Interface in org.apache.ignite
-
Transactions facade provides ACID-compliant semantic when working with caches.
- igniteUrl() - Method in class org.apache.ignite.mesos.resource.ResourceProvider
-
- igniteUrl() - Method in class org.apache.ignite.yarn.ClusterProperties
-
- IgniteUuid - Class in org.apache.ignite.lang
-
This is a faster performing version of
UUID.
- IgniteUuid() - Constructor for class org.apache.ignite.lang.IgniteUuid
-
- IgniteUuid(UUID, long) - Constructor for class org.apache.ignite.lang.IgniteUuid
-
Constructs GridUuid from a global and local identifiers.
- igniteVer() - Method in class org.apache.ignite.mesos.ClusterProperties
-
- igniteWorkDir() - Method in class org.apache.ignite.mesos.ClusterProperties
-
- igniteWorkDir() - Method in class org.apache.ignite.yarn.ClusterProperties
-
- IgniteYarnClient - Class in org.apache.ignite.yarn
-
Ignite yarn client.
- IgniteYarnClient() - Constructor for class org.apache.ignite.yarn.IgniteYarnClient
-
- IgniteYarnUtils - Class in org.apache.ignite.yarn.utils
-
Utils.
- IgniteYarnUtils() - Constructor for class org.apache.ignite.yarn.utils.IgniteYarnUtils
-
- Ignition - Class in org.apache.ignite
-
This class defines a factory for the main Ignite API.
- Ignition() - Constructor for class org.apache.ignite.Ignition
-
Enforces singleton.
- IgnitionListener - Interface in org.apache.ignite
-
Listener for gird state change notifications.
- IgnitionMXBean - Interface in org.apache.ignite.mxbean
-
This interface defines JMX view on
Ignition.
- IgnoreIfPeerClassLoadingDisabled - Annotation Type in org.apache.ignite.spi.deployment
-
This annotation is for all implementations of
DeploymentSpi that may be
ignored if peer class loading is disabled.
- impl - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
- implicit() - Method in interface org.apache.ignite.transactions.Transaction
-
Flag indicating whether transaction was started automatically by the
system or not.
- incomeConnLsnrs - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
- incrementAndGet() - Method in interface org.apache.ignite.IgniteAtomicLong
-
Increments and gets current value of atomic long.
- incrementAndGet() - Method in interface org.apache.ignite.IgniteAtomicSequence
-
Increments and returns the value of atomic sequence.
- incrementState() - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
-
Increments read state.
- incrementState() - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
-
Increments state.
- IndexingQueryFilter - Interface in org.apache.ignite.spi.indexing
-
Cache entry filter.
- IndexingSpi - Interface in org.apache.ignite.spi.indexing
-
Indexing SPI allows user to index cache content.
- info(IgfsPath) - Method in class org.apache.ignite.hadoop.fs.IgniteHadoopIgfsSecondaryFileSystem
-
Gets file information for the specified path.
- info(IgfsPath) - Method in interface org.apache.ignite.igfs.secondary.IgfsSecondaryFileSystem
-
Gets file information for the specified path.
- info(IgfsPath) - Method in interface org.apache.ignite.IgniteFileSystem
-
Gets file information for the specified path.
- info(String) - Method in interface org.apache.ignite.IgniteLogger
-
Logs out information message.
- info(String) - Method in class org.apache.ignite.logger.java.JavaLogger
-
Logs out information message.
- info(String) - Method in class org.apache.ignite.logger.jcl.JclLogger
-
Logs out information message.
- info(String) - Method in class org.apache.ignite.logger.log4j.Log4JLogger
-
Logs out information message.
- info(String) - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
-
Logs out information message.
- info(String) - Method in class org.apache.ignite.logger.NullLogger
-
Logs out information message.
- info(String) - Method in class org.apache.ignite.logger.slf4j.Slf4jLogger
-
Logs out information message.
- init(FilterConfig) - Method in class org.apache.ignite.cache.websession.WebSessionFilter
- init(ClusterProperties, IgniteProvider, String) - Method in class org.apache.ignite.mesos.resource.ResourceProvider
-
- init(ServiceContext) - Method in interface org.apache.ignite.services.Service
-
Pre-initializes service before execution.
- init() - Method in class org.apache.ignite.startup.servlet.ServletStartup
- init() - Method in class org.apache.ignite.yarn.ApplicationMaster
-
- initExtensions(PluginContext, ExtensionRegistry) - Method in interface org.apache.ignite.plugin.PluginProvider
-
Registers extensions.
- initFailureDetectionTimeout() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
-
Initiates and checks failure detection timeout value.
- initialCount() - Method in interface org.apache.ignite.IgniteCountDownLatch
-
Gets initial count value of the latch.
- initialize(URI, Configuration) - Method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
- initializeLocalAddresses(Collection<InetSocketAddress>) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
-
Initializes addresses discovery SPI binds to.
- initializeLocalAddresses(Collection<InetSocketAddress>) - Method in interface org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinder
-
Initializes addresses discovery SPI binds to.
- initializeLocalAddresses(Collection<InetSocketAddress>) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinderAdapter
-
Initializes addresses discovery SPI binds to.
- initLocalNode(int, boolean) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
- injectables() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
This method returns SPI internal instances that need to be injected as well.
- injectables() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
-
This method returns SPI internal instances that need to be injected as well.
- injectResources(Ignite) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Injects resources.
- injectResources(Ignite) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Inject resources
- injectResources(Ignite) - Method in class org.apache.ignite.spi.IgniteSpiAdapter
-
Inject ignite instance.
- inputIterator(Object...) - Method in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
-
Returns iterator of input records.
- insert(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateAccessStrategyAdapter
-
Called after Hibernate inserted object in the database but before transaction completed.
- insert(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateNonStrictAccessStrategy
-
Called after Hibernate inserted object in the database but before transaction completed.
- insert(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateReadOnlyAccessStrategy
-
Called after Hibernate inserted object in the database but before transaction completed.
- insert(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateReadWriteAccessStrategy
-
Called after Hibernate inserted object in the database but before transaction completed.
- insert(Object, Object) - Method in class org.apache.ignite.cache.hibernate.HibernateTransactionalAccessStrategy
-
Called after Hibernate inserted object in the database but before transaction completed.
- insertQuery(String, Collection<String>, Collection<String>) - Method in class org.apache.ignite.cache.store.jdbc.dialect.BasicJdbcDialect
-
Construct insert query.
- insertQuery(String, Collection<String>, Collection<String>) - Method in interface org.apache.ignite.cache.store.jdbc.dialect.JdbcDialect
-
Construct insert query.
- INSTANCE - Static variable in class org.apache.ignite.cache.store.jdbc.JdbcTypeDefaultHasher
-
Singleton instance to use.
- INSTANCE - Static variable in class org.apache.ignite.yarn.IgniteProvider.VersionComparator
-
- instances() - Method in class org.apache.ignite.mesos.ClusterProperties
-
- instances() - Method in class org.apache.ignite.yarn.ClusterProperties
-
- instances(int) - Method in class org.apache.ignite.yarn.ClusterProperties
-
Sets instance count limit.
- internal() - Method in class org.apache.ignite.events.TaskEvent
-
Returns true if task is created by Ignite and is used for system needs.
- invoke(MethodInvocation) - Method in class org.apache.ignite.compute.gridify.aop.spring.GridifySetToSetSpringAspect
-
Aspect implementation which executes grid-enabled methods on remote
nodes.
- invoke(MethodInvocation) - Method in class org.apache.ignite.compute.gridify.aop.spring.GridifySetToValueSpringAspect
-
Aspect implementation which executes grid-enabled methods on remote
nodes.
- invoke(MethodInvocation) - Method in class org.apache.ignite.compute.gridify.aop.spring.GridifySpringAspect
-
Aspect implementation which executes grid-enabled methods on remote
nodes.
- invoke(K, EntryProcessor<K, V, T>, Object...) - Method in interface org.apache.ignite.IgniteCache
- invoke(K, CacheEntryProcessor<K, V, T>, Object...) - Method in interface org.apache.ignite.IgniteCache
-
- invokeAll(Map<? extends K, ? extends EntryProcessor<K, V, T>>, Object...) - Method in interface org.apache.ignite.IgniteCache
-
- invokeAll(Set<? extends K>, EntryProcessor<K, V, T>, Object...) - Method in interface org.apache.ignite.IgniteCache
- invokeAll(Set<? extends K>, CacheEntryProcessor<K, V, T>, Object...) - Method in interface org.apache.ignite.IgniteCache
-
- invokeAll(Collection<? extends Callable<T>>) - Method in class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
- invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
- invokeAny(Collection<? extends Callable<T>>) - Method in class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
- invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
- IoPool - Interface in org.apache.ignite.plugin.extensions.communication
-
The interface of IO Messaging Pool Extension.
- ipFinder - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
IP finder.
- ipFinderCleanFreq - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
IP finder clean frequency.
- isAllowDuplicateRegistrations() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.zk.TcpDiscoveryZookeeperIpFinder
-
* @return The value of this flag.
- isAllSegmentationResolversPassRequired() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Gets all segmentation resolvers pass required flag.
- isAsync() - Method in interface org.apache.ignite.lang.IgniteAsyncSupport
-
- isAutoUnsubscribe() - Method in class org.apache.ignite.cache.query.ContinuousQuery
-
Gets automatic unsubscription flag value.
- isBackup(ClusterNode, K) - Method in interface org.apache.ignite.cache.affinity.Affinity
-
Returns true if local node is one of the backup nodes for given key.
- isBlockUntilConnected() - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
-
Gets whether to block the start() method until connected for the first time.
- isBroken() - Method in interface org.apache.ignite.IgniteSemaphore
-
Gets broken status of the semaphore.
- isCached() - Method in interface org.apache.ignite.cache.eviction.EvictableEntry
-
Checks whether entry is currently present in cache or not.
- isCacheSanityCheckEnabled() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Gets flag indicating whether cache sanity check is enabled.
- isCancelled() - Method in class org.apache.ignite.compute.ComputeJobAdapter
-
This method tests whether or not this job was cancelled.
- isCancelled() - Method in interface org.apache.ignite.compute.ComputeJobResult
-
Gets job cancellation status.
- isCancelled() - Method in interface org.apache.ignite.lang.IgniteFuture
-
Returns true if this task was cancelled before it completed
normally.
- isCancelled() - Method in interface org.apache.ignite.services.ServiceContext
-
Get flag indicating whether service has been cancelled or not.
- isCheckMd5() - Method in class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
-
Gets checkMd5 property.
- isCheckMd5() - Method in interface org.apache.ignite.spi.deployment.uri.UriDeploymentSpiMBean
-
Indicates if this SPI should check new deployment units md5 for redundancy.
- isClient() - Method in interface org.apache.ignite.cluster.ClusterNode
-
Tests whether or not this node is connected to cluster as a client.
- isClientMode() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Gets client mode flag.
- isClientMode() - Static method in class org.apache.ignite.Ignition
-
Gets client mode static flag.
- isClientMode() - Method in interface org.apache.ignite.spi.discovery.DiscoverySpi
-
Whether or not discovery is started in client mode.
- isClientMode() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Whether or not discovery is started in client mode.
- isClientMode() - Method in interface org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpiMBean
-
Whether or not discovery is started in client mode.
- isClientReconnectDisabled() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
If true client does not try to reconnect after
server detected client node failure.
- isClosed() - Method in class org.apache.ignite.cache.CacheManager
- isCollocated() - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
-
Checks if this query is collocated.
- isCollocated() - Method in class org.apache.ignite.configuration.CollectionConfiguration
-
- isColocateMetadata() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Get whether to co-locate metadata on a single node.
- isCompactFooter() - Method in class org.apache.ignite.configuration.BinaryConfiguration
-
Get whether to write footers in compact form.
- isConfigured() - Static method in class org.apache.ignite.logger.java.JavaLogger
-
Checks if logger is already configured within this VM or not.
- isConfigured() - Static method in class org.apache.ignite.logger.log4j.Log4JLogger
-
Checks if Log4j is already configured within this VM or not.
- isConnected() - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
-
Returns whether this streamer is connected by delegating to the underlying MqttClient.isConnected()
- isCopyOnRead() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Gets flag indicating whether copy of of the value stored in cache should be created
for cache operation implying return value.
- isDaemon() - Method in interface org.apache.ignite.cluster.ClusterNode
-
Tests whether or not this node is a daemon.
- isDaemon() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Whether or not this node should be a daemon node.
- isDaemon() - Static method in class org.apache.ignite.Ignition
-
Gets daemon flag.
- isDebugEnabled() - Method in interface org.apache.ignite.IgniteLogger
-
Tests whether debug level is enabled.
- isDebugEnabled() - Method in class org.apache.ignite.logger.java.JavaLogger
-
Tests whether debug level is enabled.
- isDebugEnabled() - Method in class org.apache.ignite.logger.jcl.JclLogger
-
Tests whether debug level is enabled.
- isDebugEnabled() - Method in class org.apache.ignite.logger.log4j.Log4JLogger
-
Tests whether debug level is enabled.
- isDebugEnabled() - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
-
Tests whether debug level is enabled.
- isDebugEnabled() - Method in class org.apache.ignite.logger.NullLogger
-
Tests whether debug level is enabled.
- isDebugEnabled() - Method in class org.apache.ignite.logger.slf4j.Slf4jLogger
-
Tests whether debug level is enabled.
- isDefaultKeepDeserialized() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryConfiguration
-
Gets default keep deserialized flag.
- isDirectBuffer() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
-
Gets flag indicating whether REST TCP server should use direct buffers.
- isDirectBuffer() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Gets flag that indicates whether direct or heap allocated buffer is used.
- isDirectBuffer() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
-
Gets flag that indicates whether direct or heap allocated buffer is used.
- isDirectory() - Method in class org.apache.ignite.events.IgfsEvent
-
Checks if this is a directory-related event.
- isDirectory() - Method in interface org.apache.ignite.igfs.IgfsFile
-
Check this file is a directory.
- isDirectSendBuffer() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Gets flag defining whether direct send buffer should be used.
- isDirectSendBuffer() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
-
Gets flag defining whether direct send buffer should be used.
- isDisconnectForcibly() - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
-
Gets whether this MQTT client will disconnect forcibly when shutting down.
- isDone() - Method in interface org.apache.ignite.lang.IgniteFuture
-
Returns true if this task completed.
- isEagerTtl() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Gets flag indicating whether expired cache entries will be eagerly removed from cache.
- isEmpty() - Method in interface org.apache.ignite.cache.CacheMetrics
-
Returns true if this cache is empty.
- isEmpty() - Method in interface org.apache.ignite.IgniteQueue
- isEmpty() - Method in interface org.apache.ignite.IgniteSet
- isEmpty() - Method in class org.apache.ignite.lang.IgniteBiTuple
- isEmpty() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
Returns true if this cache is empty.
- isEnabled(int) - Method in interface org.apache.ignite.IgniteEvents
-
Check if event is enabled.
- isEnum() - Method in interface org.apache.ignite.binary.BinaryType
-
Check whether type represents enum or not.
- isEnum() - Method in class org.apache.ignite.binary.BinaryTypeConfiguration
-
Gets whether this is enum type.
- isEnum() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryTypeConfiguration
-
Gets whether this is enum type.
- isEventRecordable(int...) - Method in interface org.apache.ignite.spi.IgniteSpiContext
-
Checks whether all provided event types are recordable.
- isEvictSynchronized() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Gets flag indicating whether eviction is synchronized between primary, backup and near nodes.
- isExcluded(Class<?>) - Static method in class org.apache.ignite.marshaller.MarshallerExclusions
-
Checks whether or not given class should be excluded from marshalling.
- isExcludeNeighbors() - Method in class org.apache.ignite.cache.affinity.fair.FairAffinityFunction
-
Checks flag to exclude same-host-neighbors from being backups of each other (default is false).
- isExcludeNeighbors() - Method in class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
-
Checks flag to exclude same-host-neighbors from being backups of each other (default is false).
- isExistingTransaction(Object) - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
- isFailoverSafe() - Method in interface org.apache.ignite.IgniteSemaphore
-
Returns true if this semaphore is safe to use after node failure.
- isFile() - Method in interface org.apache.ignite.igfs.IgfsFile
-
Check this file is a data file.
- isForceServerMode() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
- isFragmentizerEnabled() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Gets flag indicating whether IGFS fragmentizer is enabled.
- isGlobalNodeAuthentication() - Method in interface org.apache.ignite.spi.discovery.DiscoverySpiNodeAuthenticator
-
Gets global node authentication flag.
- isGridify(Annotation, GridifyArgument) - Method in interface org.apache.ignite.compute.gridify.GridifyInterceptor
-
This method is called before actual grid-enabling happens.
- isHeaderWritten() - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
-
- isInfoEnabled() - Method in interface org.apache.ignite.IgniteLogger
-
Tests whether info level is enabled.
- isInfoEnabled() - Method in class org.apache.ignite.logger.java.JavaLogger
-
Tests whether info level is enabled.
- isInfoEnabled() - Method in class org.apache.ignite.logger.jcl.JclLogger
-
Tests whether info level is enabled.
- isInfoEnabled() - Method in class org.apache.ignite.logger.log4j.Log4JLogger
-
Tests whether info level is enabled.
- isInfoEnabled() - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
-
Tests whether info level is enabled.
- isInfoEnabled() - Method in class org.apache.ignite.logger.NullLogger
-
Tests whether info level is enabled.
- isInfoEnabled() - Method in class org.apache.ignite.logger.slf4j.Slf4jLogger
-
Tests whether info level is enabled.
- isInitializeDefaultPathModes() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Get whether to initialize default path modes.
- isInvalidate() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Invalidation flag.
- isInvalidate() - Method in interface org.apache.ignite.transactions.Transaction
-
Get invalidation flag for this transaction.
- isIpcEndpointEnabled() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Get IPC endpoint enabled flag.
- isKeepDeserialized() - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryTypeConfiguration
-
- isLastRead() - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
-
Tells whether last invocation of any of readXXX(...)
- isLoadPreviousValue() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
- isLocal() - Method in class org.apache.ignite.cache.query.Query
-
Returns true if this query should be executed on local node only.
- isLocal() - Method in interface org.apache.ignite.cluster.ClusterNode
-
Tests whether or not this node is a local node.
- isLocalLocked(K, boolean) - Method in interface org.apache.ignite.IgniteCache
-
Checks if specified key is locked.
- isLoggable(LogRecord) - Method in class org.apache.ignite.logger.java.JavaLoggerFileHandler
- isLowerCase() - Method in class org.apache.ignite.binary.BinaryBasicIdMapper
-
Gets whether to use strings in lower case or not.
- isManagementEnabled() - Method in interface org.apache.ignite.cache.CacheMetrics
-
Checks whether management is enabled on this cache.
- isManagementEnabled() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
Checks whether management is enabled on this cache.
- isMarshalLocalJobs() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
If this flag is set to true, jobs mapped to local node will be
marshalled as if it was remote node.
- isMinimalPutsEnabledByDefault() - Method in class org.apache.ignite.cache.hibernate.HibernateRegionFactory
- isMutable() - Method in interface org.apache.ignite.spi.discovery.DiscoverySpiCustomMessage
-
- isNear() - Method in class org.apache.ignite.events.CacheEvent
-
Gets flag indicating whether event happened on near or partitioned cache.
- isNoDelay() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
-
Gets flag indicating whether TCP_NODELAY option should be set for accepted client connections.
- isNodeStopping() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
-
- isolation() - Method in interface org.apache.ignite.transactions.Transaction
-
Cache transaction isolation level.
- isOsgi() - Static method in class org.apache.ignite.osgi.IgniteOsgiUtils
-
Returns whether we are running in an OSGi environment.
- isPeerClassLoadingEnabled() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Returns true if peer class loading is enabled, false
otherwise.
- isPeerClassLoadingEnabled() - Method in interface org.apache.ignite.mxbean.IgniteMXBean
-
Returns true if peer class loading is enabled, false
otherwise.
- isPerTask() - Method in class org.apache.ignite.spi.loadbalancing.roundrobin.RoundRobinLoadBalancingSpi
-
Configuration parameter indicating whether a new round robin order should be
created for every task.
- isPerTask() - Method in interface org.apache.ignite.spi.loadbalancing.roundrobin.RoundRobinLoadBalancingSpiMBean
-
Configuration parameter indicating whether a new round robin order should be
created for every task.
- isPrimary(ClusterNode, K) - Method in interface org.apache.ignite.cache.affinity.Affinity
-
Returns true if given node is the primary node for given key.
- isPrimaryOrBackup(ClusterNode, K) - Method in interface org.apache.ignite.cache.affinity.Affinity
-
- isQuiet() - Method in interface org.apache.ignite.IgniteLogger
-
Tests whether info and debug levels are turned off.
- isQuiet() - Method in class org.apache.ignite.logger.java.JavaLogger
-
Tests whether info and debug levels are turned off.
- isQuiet() - Method in class org.apache.ignite.logger.jcl.JclLogger
-
Tests whether info and debug levels are turned off.
- isQuiet() - Method in class org.apache.ignite.logger.log4j.Log4JLogger
-
Tests whether info and debug levels are turned off.
- isQuiet() - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
-
Tests whether info and debug levels are turned off.
- isQuiet() - Method in class org.apache.ignite.logger.NullLogger
-
Tests whether info and debug levels are turned off.
- isQuiet() - Method in class org.apache.ignite.logger.slf4j.Slf4jLogger
-
Tests whether info and debug levels are turned off.
- isReadFromBackup() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Gets flag indicating whether data can be read from backup.
- isReadThrough() - Method in interface org.apache.ignite.cache.CacheMetrics
-
Determines if a Cache should operate in read-through mode.
- isReadThrough() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
Determines if a Cache should operate in read-through mode.
- isRelaxedConsistency() - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Get relaxed consistency flag.
- isRollbackOnly() - Method in interface org.apache.ignite.transactions.Transaction
-
If transaction was marked as rollback-only.
- isRunning() - Method in interface org.apache.ignite.scheduler.SchedulerFuture
-
Returns true if scheduled task is currently running.
- isSame(IgfsPath) - Method in class org.apache.ignite.igfs.IgfsPath
-
Checks if paths are identical.
- isShared() - Method in interface org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinder
-
Checks whether IP finder is shared or not.
- isShared() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinderAdapter
-
Checks whether IP finder is shared or not.
- isShutdown() - Method in interface org.apache.ignite.mxbean.ThreadPoolMXBean
-
Returns true if this executor has been shut down.
- isShutdown() - Method in class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
- isSimpleName() - Method in class org.apache.ignite.binary.BinaryBasicNameMapper
-
Gets whether to use simple name of class or not.
- isSingleton() - Method in class org.apache.ignite.configuration.IgniteReflectionFactory
-
- isSnapshotableIndex() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Gets flag indicating whether SQL indexes should support snapshots.
- isSqlEscapeAll() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
If true all the SQL table and field names will be escaped with double quotes like
({@code "tableName"."
- isSslClientAuth() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
-
Gets a flag indicating whether or not remote clients will be required to have a valid SSL certificate which
validity will be verified with trust manager.
- isSslEnabled() - Method in class org.apache.ignite.configuration.ConnectorConfiguration
-
Whether secure socket layer should be enabled on binary rest server.
- isStarvationPreventionEnabled() - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
-
Gets flag indicating whether job starvation prevention is enabled.
- isStarvationPreventionEnabled() - Method in interface org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpiMBean
-
Gets flag indicating whether job starvation prevention is enabled.
- isStatisticsEnabled() - Method in interface org.apache.ignite.cache.CacheMetrics
-
Checks whether statistics collection is enabled in this cache.
- isStatisticsEnabled() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
Checks whether statistics collection is enabled in this cache.
- isStealingEnabled() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
-
Gets flag indicating whether this node should attempt to steal jobs
from other nodes.
- isStealingEnabled() - Method in interface org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpiMBean
-
Gets flag indicating whether this node should attempt to steal jobs
from other nodes.
- isStopped() - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
-
Returns whether this streamer is stopped.
- isStopping() - Method in interface org.apache.ignite.spi.IgniteSpiContext
-
- isStoreByValue() - Method in interface org.apache.ignite.cache.CacheMetrics
-
Whether storeByValue true or storeByReference false.
- isStoreByValue() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
Whether storeByValue true or storeByReference false.
- isStoreKeepBinary() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Flag indicating that
CacheStore implementation
is working with binary objects instead of Java objects.
- isSubDirectoryOf(IgfsPath) - Method in class org.apache.ignite.igfs.IgfsPath
-
Checks whether this path is a sub-directory of argument.
- isSuccess() - Method in interface org.apache.ignite.cluster.ClusterStartNodeResult
-
Gets result of success or failure.
- isSupported(OptionalFeature) - Method in class org.apache.ignite.cache.CachingProvider
- isSwapEnabled() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Flag indicating whether Ignite should use swap storage by default.
- isSystemType(String) - Method in interface org.apache.ignite.marshaller.MarshallerContext
-
Checks whether the given type is a system one - JDK class or Ignite class.
- isTcpNoDelay() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Gets value for TCP_NODELAY socket option.
- isTcpNoDelay() - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
-
Gets value for TCP_NODELAY socket option.
- isTerminated() - Method in interface org.apache.ignite.mxbean.ThreadPoolMXBean
-
Returns true if all tasks have completed following shut down.
- isTerminated() - Method in class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
- isTerminating() - Method in interface org.apache.ignite.mxbean.ThreadPoolMXBean
-
Returns true if this executor is in the process of terminating after
shutdown() or shutdownNow() but has not completely terminated.
- isTraceEnabled() - Method in interface org.apache.ignite.IgniteLogger
-
Tests whether trace level is enabled.
- isTraceEnabled() - Method in class org.apache.ignite.logger.java.JavaLogger
-
Tests whether trace level is enabled.
- isTraceEnabled() - Method in class org.apache.ignite.logger.jcl.JclLogger
-
Tests whether trace level is enabled.
- isTraceEnabled() - Method in class org.apache.ignite.logger.log4j.Log4JLogger
-
Tests whether trace level is enabled.
- isTraceEnabled() - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
-
Tests whether trace level is enabled.
- isTraceEnabled() - Method in class org.apache.ignite.logger.NullLogger
-
Tests whether trace level is enabled.
- isTraceEnabled() - Method in class org.apache.ignite.logger.slf4j.Slf4jLogger
-
Tests whether trace level is enabled.
- isTransactionAware() - Method in class org.apache.ignite.cache.hibernate.HibernateTransactionalDataRegion
- isTxSerializableEnabled() - Method in class org.apache.ignite.configuration.TransactionConfiguration
-
Deprecated.
- isUseAverage() - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveCpuLoadProbe
-
Gets flag indicating whether to use average CPU load vs. current.
- isUseAverage() - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveJobCountLoadProbe
-
Gets flag indicating whether to use average job counts vs. current.
- isUseAverage() - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveProcessingTimeLoadProbe
-
Gets flag indicating whether to use average execution time vs. current.
- isUseJtaSynchronization() - Method in class org.apache.ignite.configuration.TransactionConfiguration
-
- isUseProcessors() - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveCpuLoadProbe
-
Gets flag indicating whether to use average CPU load vs. current
(default is true).
- isUseWeights() - Method in class org.apache.ignite.spi.loadbalancing.weightedrandom.WeightedRandomLoadBalancingSpi
-
Checks whether node weights are considered when doing
random load balancing.
- isUseWeights() - Method in interface org.apache.ignite.spi.loadbalancing.weightedrandom.WeightedRandomLoadBalancingSpiMBean
-
Checks whether node weights are considered when doing
random load balancing.
- isValidSegment() - Method in interface org.apache.ignite.plugin.segmentation.SegmentationResolver
-
Checks whether segment is valid.
- isWaitForSegmentOnStart() - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Gets wait for segment on startup flag.
- isWithinTransaction() - Method in interface org.apache.ignite.cache.store.CacheStoreSession
-
Returns true if performing store operation within a transaction,
false otherwise.
- isWriteBehindEnabled() - Method in interface org.apache.ignite.cache.CacheMetrics
-
Returns true if write-behind is enabled.
- isWriteBehindEnabled() - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Flag indicating whether Ignite should use write-behind behaviour for the cache store.
- isWriteBehindEnabled() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
Returns true if write-behind is enabled.
- isWriteThrough() - Method in interface org.apache.ignite.cache.CacheMetrics
-
Determines if a Cache should operate in "write-through"
mode.
- isWriteThrough() - Method in interface org.apache.ignite.mxbean.CacheMetricsMXBean
-
Determines if a Cache should operate in "write-through"
mode.
- iterator() - Method in interface org.apache.ignite.IgniteQueue
- iterator() - Method in interface org.apache.ignite.IgniteSet
- iterator() - Method in class org.apache.ignite.lang.IgniteBiTuple
- iterator() - Method in class org.apache.ignite.lang.IgniteUuid
- OAuthSettings - Class in org.apache.ignite.stream.twitter
-
OAuth keys holder.
- OAuthSettings(String, String, String, String) - Constructor for class org.apache.ignite.stream.twitter.OAuthSettings
-
- offer(T) - Method in interface org.apache.ignite.IgniteQueue
- offer(T, long, TimeUnit) - Method in interface org.apache.ignite.IgniteQueue
- offerRescinded(SchedulerDriver, Protos.OfferID) - Method in class org.apache.ignite.mesos.IgniteScheduler
- oldValue() - Method in class org.apache.ignite.events.CacheEvent
-
Gets old value associated with this event.
- oldValue() - Method in class org.apache.ignite.events.CacheQueryReadEvent
-
Gets read entry old value (applicable for continuous queries).
- onAckReceived() - Method in interface org.apache.ignite.plugin.extensions.communication.Message
-
Method called when ack message received.
- onAckReceived() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingRequest
-
Method called when ack message received.
- onAckReceived() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.HandshakeMessage
-
Method called when ack message received.
- onAckReceived() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.NodeIdMessage
-
Method called when ack message received.
- onAckReceived() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi.RecoveryLastReceivedMessage
-
Method called when ack message received.
- onAfterPut(Cache.Entry<K, V>) - Method in interface org.apache.ignite.cache.CacheInterceptor
-
This method is called after new value has been stored.
- onAfterPut(Cache.Entry<K, V>) - Method in class org.apache.ignite.cache.CacheInterceptorAdapter
-
This method is called after new value has been stored.
- onAfterRemove(Cache.Entry<K, V>) - Method in interface org.apache.ignite.cache.CacheInterceptor
-
This method is called after value has been removed.
- onAfterRemove(Cache.Entry<K, V>) - Method in class org.apache.ignite.cache.CacheInterceptorAdapter
-
This method is called after value has been removed.
- onAfterStart(BundleContext, Throwable) - Method in class org.apache.ignite.osgi.IgniteAbstractOsgiContextActivator
-
This method is called after Ignite initialises, only if initialization succeeded.
- onAfterStop(BundleContext, Throwable) - Method in class org.apache.ignite.osgi.IgniteAbstractOsgiContextActivator
-
This method is called after Ignite stops, only if the operation succeeded.
- onAttributeSet(Object, Object) - Method in interface org.apache.ignite.compute.ComputeTaskSessionAttributeListener
-
Called on attribute change (set or update).
- onBeforePut(Cache.Entry<K, V>, V) - Method in interface org.apache.ignite.cache.CacheInterceptor
-
- onBeforePut(Cache.Entry<K, V>, V) - Method in class org.apache.ignite.cache.CacheInterceptorAdapter
-
- onBeforeRemove(Cache.Entry<K, V>) - Method in interface org.apache.ignite.cache.CacheInterceptor
-
- onBeforeRemove(Cache.Entry<K, V>) - Method in class org.apache.ignite.cache.CacheInterceptorAdapter
-
- onBeforeStart(BundleContext) - Method in class org.apache.ignite.osgi.IgniteAbstractOsgiContextActivator
-
This method is called before Ignite initialises.
- onBeforeStop(BundleContext) - Method in class org.apache.ignite.osgi.IgniteAbstractOsgiContextActivator
-
This method is called before Ignite stops.
- onChange(Collection<T>) - Method in interface org.apache.ignite.visor.plugin.VisorSelectionListener
-
On selection changed.
- onCheckpointRemoved(String) - Method in interface org.apache.ignite.spi.checkpoint.CheckpointListener
-
Notification for removed checkpoint.
- onClientDisconnected(IgniteFuture<?>) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Client node disconnected callback.
- onClientDisconnected(IgniteFuture<?>) - Method in interface org.apache.ignite.spi.IgniteSpi
-
Client node disconnected callback.
- onClientDisconnected(IgniteFuture<?>) - Method in class org.apache.ignite.spi.IgniteSpiAdapter
-
Client node disconnected callback.
- onClientReconnected(boolean) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Client node reconnected callback.
- onClientReconnected(boolean) - Method in interface org.apache.ignite.spi.IgniteSpi
-
Client node reconnected callback.
- onClientReconnected(boolean) - Method in class org.apache.ignite.spi.IgniteSpiAdapter
-
Client node reconnected callback.
- onClosed() - Method in class org.apache.ignite.visor.plugin.VisorPluggableTab
-
Will be executed on tab close.
- onCollision(CollisionContext) - Method in interface org.apache.ignite.spi.collision.CollisionSpi
-
This is a callback called when either new grid job arrived or executing job finished its
execution.
- onCollision(CollisionContext) - Method in class org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpi
-
This is a callback called when either new grid job arrived or executing job finished its
execution.
- onCollision(CollisionContext) - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
-
This is a callback called when either new grid job arrived or executing job finished its
execution.
- onCollision(CollisionContext) - Method in class org.apache.ignite.spi.collision.noop.NoopCollisionSpi
-
This is a callback called when either new grid job arrived or executing job finished its
execution.
- onCollision(CollisionContext) - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
-
This is a callback called when either new grid job arrived or executing job finished its
execution.
- onConnected() - Method in class org.apache.ignite.visor.plugin.VisorExtensionPoint
-
Will be executed on Visor connect to grid.
- onContainersAllocated(List<Container>) - Method in class org.apache.ignite.yarn.ApplicationMaster
- onContainersCompleted(List<ContainerStatus>) - Method in class org.apache.ignite.yarn.ApplicationMaster
- onContextDestroyed() - Method in interface org.apache.ignite.spi.IgniteSpi
-
Callback invoked prior to stopping grid before SPI context is destroyed.
- onContextDestroyed() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
-
Callback invoked prior to stopping grid before SPI context is destroyed.
- onContextDestroyed0() - Method in class org.apache.ignite.spi.checkpoint.cache.CacheCheckpointSpi
-
Method to be called in the beginning of onContextDestroyed() method.
- onContextDestroyed0() - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
-
Method to be called in the beginning of onContextDestroyed() method.
- onContextDestroyed0() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
-
Method to be called in the beginning of onContextDestroyed() method.
- onContextDestroyed0() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Method to be called in the beginning of onContextDestroyed() method.
- onContextDestroyed0() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Method to be called in the beginning of onContextDestroyed() method.
- onContextDestroyed0() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
-
Method to be called in the beginning of onContextDestroyed() method.
- onContextDestroyed0() - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveLoadBalancingSpi
-
Method to be called in the beginning of onContextDestroyed() method.
- onContextDestroyed0() - Method in class org.apache.ignite.spi.loadbalancing.roundrobin.RoundRobinLoadBalancingSpi
-
Method to be called in the beginning of onContextDestroyed() method.
- onContextDestroyed0() - Method in class org.apache.ignite.spi.loadbalancing.weightedrandom.WeightedRandomLoadBalancingSpi
-
Method to be called in the beginning of onContextDestroyed() method.
- onContextInitialized(IgniteSpiContext) - Method in interface org.apache.ignite.spi.IgniteSpi
-
Callback invoked when SPI context is initialized.
- onContextInitialized(IgniteSpiContext) - Method in class org.apache.ignite.spi.IgniteSpiAdapter
-
Callback invoked when SPI context is initialized.
- onContextInitialized0(IgniteSpiContext) - Method in class org.apache.ignite.spi.checkpoint.cache.CacheCheckpointSpi
-
Method to be called in the end of onContextInitialized method.
- onContextInitialized0(IgniteSpiContext) - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
-
Method to be called in the end of onContextInitialized method.
- onContextInitialized0(IgniteSpiContext) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Method to be called in the end of onContextInitialized method.
- onContextInitialized0(IgniteSpiContext) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Method to be called in the end of onContextInitialized method.
- onContextInitialized0(IgniteSpiContext) - Method in class org.apache.ignite.spi.IgniteSpiAdapter
-
Method to be called in the end of onContextInitialized method.
- onContextInitialized0(IgniteSpiContext) - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveLoadBalancingSpi
-
Method to be called in the end of onContextInitialized method.
- onContextInitialized0(IgniteSpiContext) - Method in class org.apache.ignite.spi.loadbalancing.roundrobin.RoundRobinLoadBalancingSpi
-
Method to be called in the end of onContextInitialized method.
- onContextInitialized0(IgniteSpiContext) - Method in class org.apache.ignite.spi.loadbalancing.weightedrandom.WeightedRandomLoadBalancingSpi
-
Method to be called in the end of onContextInitialized method.
- onDisconnected(UUID) - Method in interface org.apache.ignite.spi.communication.CommunicationListener
-
Callback invoked when connection with remote node is lost.
- onDisconnected() - Method in class org.apache.ignite.visor.plugin.VisorExtensionPoint
-
Will be executed on Visor disconnect from grid.
- onDiscovery(int, long, ClusterNode, Collection<ClusterNode>, Map<Long, Collection<ClusterNode>>, DiscoverySpiCustomMessage) - Method in interface org.apache.ignite.spi.discovery.DiscoverySpiListener
-
Notification for grid node discovery events.
- onEntryAccessed(boolean, EvictableEntry<K, V>) - Method in interface org.apache.ignite.cache.eviction.EvictionPolicy
-
Callback for whenever entry is accessed.
- onEntryAccessed(boolean, EvictableEntry<K, V>) - Method in class org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicy
-
Callback for whenever entry is accessed.
- onEntryAccessed(boolean, EvictableEntry<IgfsBlockKey, byte[]>) - Method in class org.apache.ignite.cache.eviction.igfs.IgfsPerBlockLruEvictionPolicy
-
Callback for whenever entry is accessed.
- onEntryAccessed(boolean, EvictableEntry<K, V>) - Method in class org.apache.ignite.cache.eviction.lru.LruEvictionPolicy
-
Callback for whenever entry is accessed.
- onEntryAccessed(boolean, EvictableEntry<K, V>) - Method in class org.apache.ignite.cache.eviction.random.RandomEvictionPolicy
-
Deprecated.
Callback for whenever entry is accessed.
- onEntryAccessed(boolean, EvictableEntry<K, V>) - Method in class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicy
-
Callback for whenever entry is accessed.
- onError(Throwable) - Method in class org.apache.ignite.messaging.MessagingListenActor
-
- onError(Throwable) - Method in class org.apache.ignite.yarn.ApplicationMaster
- onEventsChanged() - Method in class org.apache.ignite.visor.plugin.VisorExtensionPoint
-
Will be executed on Visor events changed.
- onExchange(UUID, UUID, Map<Integer, Serializable>) - Method in interface org.apache.ignite.spi.discovery.DiscoverySpiDataExchange
-
Notifies discovery manager about data received from remote node.
- onExchange(UUID, UUID, Map<Integer, byte[]>, ClassLoader) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
- onExternalCollision() - Method in interface org.apache.ignite.spi.collision.CollisionExternalListener
-
Callback invoked by Collision SPI whenever an external collision
event occurs.
- onGet(K, V) - Method in interface org.apache.ignite.cache.CacheInterceptor
-
This method is called within
IgniteCache.get(Object)
and similar operations to provide control over returned value.
- onGet(K, V) - Method in class org.apache.ignite.cache.CacheInterceptorAdapter
-
This method is called within
IgniteCache.get(Object)
and similar operations to provide control over returned value.
- onHeaderWritten() - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
-
Callback called when header of the message is written.
- onIgniteStart() - Method in interface org.apache.ignite.plugin.CachePluginProvider
-
Callback that notifies that Ignite has successfully started,
including all internal components.
- onIgniteStart() - Method in interface org.apache.ignite.plugin.PluginProvider
-
Callback that notifies that Ignite has successfully started,
including all internal components.
- onIgniteStop(boolean) - Method in interface org.apache.ignite.plugin.CachePluginProvider
-
Callback to notify that Ignite is about to stop.
- onIgniteStop(boolean) - Method in interface org.apache.ignite.plugin.PluginProvider
-
Callback to notify that Ignite is about to stop.
- onLifecycleEvent(LifecycleEventType) - Method in interface org.apache.ignite.lifecycle.LifecycleBean
-
This method is called when lifecycle event occurs.
- onMasterNodeLeft(ComputeTaskSession) - Method in interface org.apache.ignite.compute.ComputeJobMasterLeaveAware
-
A method which is executed in case master node has left topology during job execution.
- onMessage(UUID, T, IgniteRunnable) - Method in interface org.apache.ignite.spi.communication.CommunicationListener
-
NOTE: CommunicationSpi should ignore very first 4 bytes received from
sender node and pass the rest of the received message to the listener.
- onModelChanged() - Method in class org.apache.ignite.visor.plugin.VisorExtensionPoint
-
Will be executed on Visor model changed.
- onNodeFailed(UUID) - Method in interface org.apache.ignite.visor.plugin.VisorTopologyListener
-
Action that should be done on node failed.
- onNodeJoin(UUID) - Method in interface org.apache.ignite.visor.plugin.VisorTopologyListener
-
Action that should be done on node join.
- onNodeLeft(UUID) - Method in interface org.apache.ignite.visor.plugin.VisorTopologyListener
-
Action that should be done on node left.
- onNodeSegmented(UUID) - Method in interface org.apache.ignite.visor.plugin.VisorTopologyListener
-
Action that should be done on node segmented.
- onNodesUpdated(List<NodeReport>) - Method in class org.apache.ignite.yarn.ApplicationMaster
- onReceive(Object) - Method in interface org.apache.ignite.configuration.ConnectorMessageInterceptor
-
Intercepts received objects.
- onSend(Object) - Method in interface org.apache.ignite.configuration.ConnectorMessageInterceptor
-
Intercepts received objects.
- onSessionEnd(CacheStoreSession, boolean) - Method in interface org.apache.ignite.cache.store.CacheStoreSessionListener
-
On session end callback.
- onSessionEnd(CacheStoreSession, boolean) - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateStoreSessionListener
-
On session end callback.
- onSessionEnd(CacheStoreSession, boolean) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcStoreSessionListener
-
On session end callback.
- onSessionEnd(CacheStoreSession, boolean) - Method in class org.apache.ignite.cache.store.spring.CacheSpringStoreSessionListener
-
On session end callback.
- onSessionStart(CacheStoreSession) - Method in interface org.apache.ignite.cache.store.CacheStoreSessionListener
-
On session start callback.
- onSessionStart(CacheStoreSession) - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateStoreSessionListener
-
On session start callback.
- onSessionStart(CacheStoreSession) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcStoreSessionListener
-
On session start callback.
- onSessionStart(CacheStoreSession) - Method in class org.apache.ignite.cache.store.spring.CacheSpringStoreSessionListener
-
On session start callback.
- onShutdownRequest() - Method in class org.apache.ignite.yarn.ApplicationMaster
- onSpiContextDestroyed() - Method in interface org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinder
-
Callback invoked prior to stopping grid before SPI context is destroyed.
- onSpiContextDestroyed() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinderAdapter
-
Callback invoked prior to stopping grid before SPI context is destroyed.
- onSpiContextDestroyed() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.zk.TcpDiscoveryZookeeperIpFinder
-
Callback invoked prior to stopping grid before SPI context is destroyed.
- onSpiContextInitialized(IgniteSpiContext) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
-
- onSpiContextInitialized(IgniteSpiContext) - Method in interface org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinder
-
- onSpiContextInitialized(IgniteSpiContext) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinderAdapter
-
- onStateChange(String, IgniteState) - Method in interface org.apache.ignite.IgnitionListener
-
Listener for grid factory state change notifications.
- onSwap(String, Object) - Method in interface org.apache.ignite.spi.indexing.IndexingSpi
-
Will be called when entry with given key is swapped.
- onSwap(String, Object) - Method in class org.apache.ignite.spi.indexing.noop.NoopIndexingSpi
-
Will be called when entry with given key is swapped.
- onSwapEvent(int, String, byte[], byte[]) - Method in interface org.apache.ignite.spi.swapspace.SwapSpaceSpiListener
-
Notification for swap space events.
- onTimeout() - Method in interface org.apache.ignite.spi.IgniteSpiTimeoutObject
-
Timeout callback.
- onUndeploy(ClassLoader) - Method in class org.apache.ignite.marshaller.AbstractMarshaller
-
Undeployment callback invoked when class loader is being undeployed.
- onUndeploy(ClassLoader) - Method in class org.apache.ignite.marshaller.jdk.JdkMarshaller
-
Undeployment callback invoked when class loader is being undeployed.
- onUndeploy(ClassLoader) - Method in class org.apache.ignite.marshaller.optimized.OptimizedMarshaller
-
Undeployment callback invoked when class loader is being undeployed.
- onUnregistered(ClassLoader) - Method in interface org.apache.ignite.spi.deployment.DeploymentListener
-
Called when a deployment has been unregistered..
- onUnswap(String, Object, Object) - Method in interface org.apache.ignite.spi.indexing.IndexingSpi
-
Will be called when entry with given key is unswapped.
- onUnswap(String, Object, Object) - Method in class org.apache.ignite.spi.indexing.noop.NoopIndexingSpi
-
Will be called when entry with given key is unswapped.
- open(IgfsPath, int) - Method in class org.apache.ignite.hadoop.fs.IgniteHadoopIgfsSecondaryFileSystem
-
Opens a file for reading.
- open(Path, int) - Method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
- open(Path, int) - Method in class org.apache.ignite.hadoop.fs.v2.IgniteHadoopFileSystem
- open(IgfsPath, int) - Method in interface org.apache.ignite.igfs.secondary.IgfsSecondaryFileSystem
-
Opens a file for reading.
- open(IgfsPath) - Method in interface org.apache.ignite.IgniteFileSystem
-
Opens a file for reading.
- open(IgfsPath, int) - Method in interface org.apache.ignite.IgniteFileSystem
-
Opens a file for reading.
- open(IgfsPath, int, int) - Method in interface org.apache.ignite.IgniteFileSystem
-
Opens a file for reading.
- openConnection(boolean) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
-
Gets connection from a pool.
- openFileInputStream(String) - Method in class org.apache.ignite.ssl.SslContextFactory
-
By default, this method simply opens a raw file input stream.
- openSocket(InetSocketAddress, IgniteSpiOperationTimeoutHelper) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
- openSocket(Socket, InetSocketAddress, IgniteSpiOperationTimeoutHelper) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Connects to remote address sending U.IGNITE_HEADER when connection is established.
- OptimizedMarshaller - Class in org.apache.ignite.marshaller.optimized
-
- OptimizedMarshaller() - Constructor for class org.apache.ignite.marshaller.optimized.OptimizedMarshaller
-
Creates new marshaller will all defaults.
- OptimizedMarshaller(boolean) - Constructor for class org.apache.ignite.marshaller.optimized.OptimizedMarshaller
-
Creates new marshaller providing whether it should
require
Serializable interface or not.
- OptimizedMarshallerIdMapper - Interface in org.apache.ignite.marshaller.optimized
-
ID mapper.
- OracleDialect - Class in org.apache.ignite.cache.store.jdbc.dialect
-
A dialect compatible with the Oracle database.
- OracleDialect() - Constructor for class org.apache.ignite.cache.store.jdbc.dialect.OracleDialect
-
- order() - Method in interface org.apache.ignite.cluster.ClusterNode
-
Node order within grid topology.
- org.apache.ignite - package org.apache.ignite
-
Contains entry-point Ignite & HPC APIs.
- org.apache.ignite.binary - package org.apache.ignite.binary
-
Contains Ignite Binary Objects API classes.
- org.apache.ignite.cache - package org.apache.ignite.cache
-
Contains main Data Grid APIs.
- org.apache.ignite.cache.affinity - package org.apache.ignite.cache.affinity
-
Contains cache node affinity implementations.
- org.apache.ignite.cache.affinity.fair - package org.apache.ignite.cache.affinity.fair
-
Contains fair cache affinity for partitioned cache.
- org.apache.ignite.cache.affinity.rendezvous - package org.apache.ignite.cache.affinity.rendezvous
-
Contains HRW-based cache affinity for partitioned cache.
- org.apache.ignite.cache.eviction - package org.apache.ignite.cache.eviction
-
Contains cache eviction policy implementations.
- org.apache.ignite.cache.eviction.fifo - package org.apache.ignite.cache.eviction.fifo
-
Contains cache FIFO eviction policy implementations.
- org.apache.ignite.cache.eviction.igfs - package org.apache.ignite.cache.eviction.igfs
-
Contains IGFS LRU eviction policy implementations.
- org.apache.ignite.cache.eviction.lru - package org.apache.ignite.cache.eviction.lru
-
Contains cache LRU eviction policy implementations.
- org.apache.ignite.cache.eviction.random - package org.apache.ignite.cache.eviction.random
-
Contains cache randomized eviction policy implementations.
- org.apache.ignite.cache.eviction.sorted - package org.apache.ignite.cache.eviction.sorted
-
Contains cache sorted eviction policy implementation.
- org.apache.ignite.cache.hibernate - package org.apache.ignite.cache.hibernate
-
Contains implementation of Hibernate L2 cache.
- org.apache.ignite.cache.jta - package org.apache.ignite.cache.jta
-
Contains JTA (Java Transaction API) related public classes and interfaces.
- org.apache.ignite.cache.jta.jndi - package org.apache.ignite.cache.jta.jndi
-
Contains JNDI-based transaction manager lookup.
- org.apache.ignite.cache.jta.reflect - package org.apache.ignite.cache.jta.reflect
-
Contains reflection-based transaction manager lookup.
- org.apache.ignite.cache.query - package org.apache.ignite.cache.query
-
Contains APIs for creating and executing cache queries.
- org.apache.ignite.cache.query.annotations - package org.apache.ignite.cache.query.annotations
-
Contains query-related annotations.
- org.apache.ignite.cache.spring - package org.apache.ignite.cache.spring
-
Contains implementation of Spring cache abstraction and @Cacheable annotation.
- org.apache.ignite.cache.store - package org.apache.ignite.cache.store
-
Contains cache store interfaces.
- org.apache.ignite.cache.store.hibernate - package org.apache.ignite.cache.store.hibernate
-
Contains reference Hibernate-based cache store implementation.
- org.apache.ignite.cache.store.jdbc - package org.apache.ignite.cache.store.jdbc
-
Contains reference JDBC-based cache store implementation.
- org.apache.ignite.cache.store.jdbc.dialect - package org.apache.ignite.cache.store.jdbc.dialect
-
Contains SQL dialects for different RDBMS.
- org.apache.ignite.cache.store.spring - package org.apache.ignite.cache.store.spring
-
Contains cache store session listener based on Spring transaction management.
- org.apache.ignite.cache.websession - package org.apache.ignite.cache.websession
-
Contains classes for Web Sessions Caching.
- org.apache.ignite.cluster - package org.apache.ignite.cluster
-
Contains cluster-related classes.
- org.apache.ignite.compute - package org.apache.ignite.compute
-
Contains Compute Grid functionality.
- org.apache.ignite.compute.gridify - package org.apache.ignite.compute.gridify
-
Contains APIs utilized for AOP-based grid-enabling.
- org.apache.ignite.compute.gridify.aop - package org.apache.ignite.compute.gridify.aop
-
Contains common classes for different AOP providers.
- org.apache.ignite.compute.gridify.aop.aspectj - package org.apache.ignite.compute.gridify.aop.aspectj
-
Contains all classes used by AspectJ AOP implementation.
- org.apache.ignite.compute.gridify.aop.spring - package org.apache.ignite.compute.gridify.aop.spring
-
Contains all classes used by Spring AOP implementation.
- org.apache.ignite.configuration - package org.apache.ignite.configuration
-
Contains configuration-related classes.
- org.apache.ignite.events - package org.apache.ignite.events
-
Contains Event Subscription functionality together with various events emitted by Ignite.
- org.apache.ignite.hadoop - package org.apache.ignite.hadoop
-
Ignite Hadoop Accelerator API.
- org.apache.ignite.hadoop.fs - package org.apache.ignite.hadoop.fs
-
Ignite Hadoop Accelerator file system API.
- org.apache.ignite.hadoop.fs.v1 - package org.apache.ignite.hadoop.fs.v1
-
Contains Ignite Hadoop 1.x FileSystem implementation.
- org.apache.ignite.hadoop.fs.v2 - package org.apache.ignite.hadoop.fs.v2
-
Contains Ignite Hadoop 2.x FileSystem implementation.
- org.apache.ignite.hadoop.mapreduce - package org.apache.ignite.hadoop.mapreduce
-
Ignite Hadoop Accelerator map-reduce classes.
- org.apache.ignite.igfs - package org.apache.ignite.igfs
-
Contains IGnite File System APIs.
- org.apache.ignite.igfs.mapreduce - package org.apache.ignite.igfs.mapreduce
-
Contains APIs for In-Memory MapReduce over IGFS.
- org.apache.ignite.igfs.mapreduce.records - package org.apache.ignite.igfs.mapreduce.records
-
Contains record resolvers for In-Memory MapReduce over IGFS.
- org.apache.ignite.igfs.secondary - package org.apache.ignite.igfs.secondary
-
Contains APIs for IGFS secondary file system.
- org.apache.ignite.lang - package org.apache.ignite.lang
-
Contains general language constructs and functional APIs for distributed computations.
- org.apache.ignite.lifecycle - package org.apache.ignite.lifecycle
-
Contains lifecycle-related classes.
- org.apache.ignite.logger - package org.apache.ignite.logger
-
Contains logging functionality used throughout the system.
- org.apache.ignite.logger.java - package org.apache.ignite.logger.java
-
Contains Java logging implementation for logging.
- org.apache.ignite.logger.jcl - package org.apache.ignite.logger.jcl
-
Contains Jakarta commons logging implementation for logging.
- org.apache.ignite.logger.log4j - package org.apache.ignite.logger.log4j
-
Contains default Log4j implementation for logging.
- org.apache.ignite.logger.log4j2 - package org.apache.ignite.logger.log4j2
-
Contains default Log4j2 implementation for logging.
- org.apache.ignite.logger.slf4j - package org.apache.ignite.logger.slf4j
-
Contains SLF4J implementation for logging.
- org.apache.ignite.marshaller - package org.apache.ignite.marshaller
-
Contains various supported marshallers.
- org.apache.ignite.marshaller.jdk - package org.apache.ignite.marshaller.jdk
-
Contains JDK java.io based marshaller.
- org.apache.ignite.marshaller.optimized - package org.apache.ignite.marshaller.optimized
-
Contains Optimized marshaller.
- org.apache.ignite.mesos - package org.apache.ignite.mesos
-
Contains classes to support integration with Apache Mesos.
- org.apache.ignite.mesos.resource - package org.apache.ignite.mesos.resource
-
Contains classes provide access to resources.
- org.apache.ignite.messaging - package org.apache.ignite.messaging
-
Contains Topic-based Messaging functionality.
- org.apache.ignite.mxbean - package org.apache.ignite.mxbean
-
Contains annotations for Dynamic MBeans.
- org.apache.ignite.osgi - package org.apache.ignite.osgi
-
Contains OSGi related classes.
- org.apache.ignite.osgi.classloaders - package org.apache.ignite.osgi.classloaders
-
Contains implementation of OSGi class loaders.
- org.apache.ignite.platform - package org.apache.ignite.platform
-
Contains platform-related classes.
- org.apache.ignite.platform.cpp - package org.apache.ignite.platform.cpp
-
Contains C++ platform-related classes.
- org.apache.ignite.platform.dotnet - package org.apache.ignite.platform.dotnet
-
Contains .Net platform-related classes.
- org.apache.ignite.plugin - package org.apache.ignite.plugin
-
Contains plugins management API.
- org.apache.ignite.plugin.extensions.communication - package org.apache.ignite.plugin.extensions.communication
-
Contains extendable components for communication.
- org.apache.ignite.plugin.security - package org.apache.ignite.plugin.security
-
Contains APIs for security, authentication, and authorization.
- org.apache.ignite.plugin.segmentation - package org.apache.ignite.plugin.segmentation
-
Contains segmentation "split-brain" related classes.
- org.apache.ignite.resources - package org.apache.ignite.resources
-
Contains resource injection annotations.
- org.apache.ignite.scheduler - package org.apache.ignite.scheduler
-
Contains Job Scheduling functionality.
- org.apache.ignite.services - package org.apache.ignite.services
-
Contains main Managed Services APIs.
- org.apache.ignite.spi - package org.apache.ignite.spi
-
Contains common classes and interfaces for SPI implementations.
- org.apache.ignite.spi.checkpoint - package org.apache.ignite.spi.checkpoint
-
Contains APIs for checkpoint SPI.
- org.apache.ignite.spi.checkpoint.cache - package org.apache.ignite.spi.checkpoint.cache
-
Contains cache-based implementation for checkpoint SPI.
- org.apache.ignite.spi.checkpoint.jdbc - package org.apache.ignite.spi.checkpoint.jdbc
-
Contains JDBC implementation for checkpoint SPI.
- org.apache.ignite.spi.checkpoint.noop - package org.apache.ignite.spi.checkpoint.noop
-
Contains default no-op checkpoint SPI implementation.
- org.apache.ignite.spi.checkpoint.s3 - package org.apache.ignite.spi.checkpoint.s3
-
Contains S3-based implementation for checkpoint SPI.
- org.apache.ignite.spi.checkpoint.sharedfs - package org.apache.ignite.spi.checkpoint.sharedfs
-
Contains shared file system implementation for checkpoint SPI.
- org.apache.ignite.spi.collision - package org.apache.ignite.spi.collision
-
Contains APIs for collision SPI.
- org.apache.ignite.spi.collision.fifoqueue - package org.apache.ignite.spi.collision.fifoqueue
-
Contains FIFO based collision SPI implementation.
- org.apache.ignite.spi.collision.jobstealing - package org.apache.ignite.spi.collision.jobstealing
-
Contains job stealing collision SPI implementation.
- org.apache.ignite.spi.collision.noop - package org.apache.ignite.spi.collision.noop
-
Contains default no-op collision SPI implementation.
- org.apache.ignite.spi.collision.priorityqueue - package org.apache.ignite.spi.collision.priorityqueue
-
Contains priority based collision SPI implementation.
- org.apache.ignite.spi.communication - package org.apache.ignite.spi.communication
-
Contains APIs for grid communication SPI.
- org.apache.ignite.spi.communication.tcp - package org.apache.ignite.spi.communication.tcp
-
Contains default TCP/IP-based implementation for communication SPI.
- org.apache.ignite.spi.deployment - package org.apache.ignite.spi.deployment
-
Contains APIs for deployment SPI.
- org.apache.ignite.spi.deployment.local - package org.apache.ignite.spi.deployment.local
-
Contains default local deployment SPI implementation.
- org.apache.ignite.spi.deployment.uri - package org.apache.ignite.spi.deployment.uri
-
Contains URI-based deployment SPI implementation.
- org.apache.ignite.spi.discovery - package org.apache.ignite.spi.discovery
-
Contains APIs for topology manager SPI.
- org.apache.ignite.spi.discovery.tcp - package org.apache.ignite.spi.discovery.tcp
-
Contains default TCP/IP implementation for discovery SPI.
- org.apache.ignite.spi.discovery.tcp.ipfinder - package org.apache.ignite.spi.discovery.tcp.ipfinder
-
Contains IP finder interface and adapter.
- org.apache.ignite.spi.discovery.tcp.ipfinder.cloud - package org.apache.ignite.spi.discovery.tcp.ipfinder.cloud
-
Contains Apache jclouds based IP finder.
- org.apache.ignite.spi.discovery.tcp.ipfinder.gce - package org.apache.ignite.spi.discovery.tcp.ipfinder.gce
-
Contains Google Cloud Storage IP finder.
- org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc - package org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc
-
Contains JDBC IP finder implementation.
- org.apache.ignite.spi.discovery.tcp.ipfinder.multicast - package org.apache.ignite.spi.discovery.tcp.ipfinder.multicast
-
Contains multicast-based IP finder.
- org.apache.ignite.spi.discovery.tcp.ipfinder.s3 - package org.apache.ignite.spi.discovery.tcp.ipfinder.s3
-
Contains AWS S3-based IP finder.
- org.apache.ignite.spi.discovery.tcp.ipfinder.sharedfs - package org.apache.ignite.spi.discovery.tcp.ipfinder.sharedfs
-
Contains shared filesystem-based IP finder.
- org.apache.ignite.spi.discovery.tcp.ipfinder.vm - package org.apache.ignite.spi.discovery.tcp.ipfinder.vm
-
Contains local JVM-based IP finder.
- org.apache.ignite.spi.discovery.tcp.ipfinder.zk - package org.apache.ignite.spi.discovery.tcp.ipfinder.zk
-
Contains TCP Discovery IP Finder uses Apache ZooKeeper (ZK) to locate peer nodes.
- org.apache.ignite.spi.eventstorage - package org.apache.ignite.spi.eventstorage
-
Contains APIs for event storage SPI.
- org.apache.ignite.spi.eventstorage.memory - package org.apache.ignite.spi.eventstorage.memory
-
Contains default in-memory implementation for event storage SPI.
- org.apache.ignite.spi.failover - package org.apache.ignite.spi.failover
-
Contains APIs for failover SPI.
- org.apache.ignite.spi.failover.always - package org.apache.ignite.spi.failover.always
-
Contains default "always" failover SPI.
- org.apache.ignite.spi.failover.jobstealing - package org.apache.ignite.spi.failover.jobstealing
-
Contains job stealing failover SPI.
- org.apache.ignite.spi.failover.never - package org.apache.ignite.spi.failover.never
-
Contains "never" failover SPI.
- org.apache.ignite.spi.indexing - package org.apache.ignite.spi.indexing
-
Contains APIs for indexing SPI.
- org.apache.ignite.spi.indexing.noop - package org.apache.ignite.spi.indexing.noop
-
Contains default no-op indexing SPI implementation.
- org.apache.ignite.spi.loadbalancing - package org.apache.ignite.spi.loadbalancing
-
Contains APIs for load balancing SPI.
- org.apache.ignite.spi.loadbalancing.adaptive - package org.apache.ignite.spi.loadbalancing.adaptive
-
Contains adaptive load balancing SPI.
- org.apache.ignite.spi.loadbalancing.roundrobin - package org.apache.ignite.spi.loadbalancing.roundrobin
-
Contains default round-robin implementation for load balancing SPI.
- org.apache.ignite.spi.loadbalancing.weightedrandom - package org.apache.ignite.spi.loadbalancing.weightedrandom
-
Contains weighted random-base implementation for load balancing SPI.
- org.apache.ignite.spi.swapspace - package org.apache.ignite.spi.swapspace
-
Contains APIs for swap space SPI.
- org.apache.ignite.spi.swapspace.file - package org.apache.ignite.spi.swapspace.file
-
Contains file-based swap space SPI.
- org.apache.ignite.spi.swapspace.noop - package org.apache.ignite.spi.swapspace.noop
-
Contains default no-op swap space SPI implementation.
- org.apache.ignite.ssl - package org.apache.ignite.ssl
-
Contains classes for working with SSL.
- org.apache.ignite.startup - package org.apache.ignite.startup
-
Contains Ignite runtime startup classes.
- org.apache.ignite.startup.cmdline - package org.apache.ignite.startup.cmdline
-
Contains default command line startup.
- org.apache.ignite.startup.servlet - package org.apache.ignite.startup.servlet
-
Contains servlet-based startup.
- org.apache.ignite.stream - package org.apache.ignite.stream
-
Contains Ignite Streamer classes.
- org.apache.ignite.stream.camel - package org.apache.ignite.stream.camel
-
Contains implementation of Camel Streamer.
- org.apache.ignite.stream.flume - package org.apache.ignite.stream.flume
-
Contains implementation of Flume Sink.
- org.apache.ignite.stream.jms11 - package org.apache.ignite.stream.jms11
-
Contains implementation of JMS queue and topic messages consumer.
- org.apache.ignite.stream.kafka - package org.apache.ignite.stream.kafka
-
Contains implementation of Kafka Streamer.
- org.apache.ignite.stream.mqtt - package org.apache.ignite.stream.mqtt
-
Contains implementation of MQTT topic messages consumer.
- org.apache.ignite.stream.socket - package org.apache.ignite.stream.socket
-
Contains socket streamer implementation.
- org.apache.ignite.stream.twitter - package org.apache.ignite.stream.twitter
-
Contains implementation of Twitter Streamer.
- org.apache.ignite.thread - package org.apache.ignite.thread
-
Contains threads-related utility classes.
- org.apache.ignite.transactions - package org.apache.ignite.transactions
-
Contains transaction-related classes.
- org.apache.ignite.transactions.spring - package org.apache.ignite.transactions.spring
-
Contains implementation of Spring transaction manager.
- org.apache.ignite.visor.plugin - package org.apache.ignite.visor.plugin
-
Contains Visor Plugin extension functionality.
- org.apache.ignite.yarn - package org.apache.ignite.yarn
-
Contains classes to support integration with Apache Hadoop Yarn.
- org.apache.ignite.yarn.utils - package org.apache.ignite.yarn.utils
-
Utility and helper classes.
- originNodeId() - Method in interface org.apache.ignite.services.ServiceDescriptor
-
Gets ID of grid node that initiated the service deployment.
- OSGI_SERVICE_PROP_IGNITE_NAME - Static variable in class org.apache.ignite.osgi.IgniteAbstractOsgiContextActivator
-
OSGI service property name.
- OsgiClassLoadingStrategyType - Enum in org.apache.ignite.osgi.classloaders
-
Enum for the user to indicate which type of
ClassLoader Ignite should use.
- OUT_OF_RESOURCES_TCP_MSG - Static variable in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
IPC error message.
- S3CheckpointSpi - Class in org.apache.ignite.spi.checkpoint.s3
-
This class defines Amazon S3-based implementation for checkpoint SPI.
- S3CheckpointSpi() - Constructor for class org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpi
-
- S3CheckpointSpiMBean - Interface in org.apache.ignite.spi.checkpoint.s3
-
- saveCheckpoint(String, Object) - Method in interface org.apache.ignite.compute.ComputeTaskSession
-
Saves intermediate state of a job or task to a storage.
- saveCheckpoint(String, Object, ComputeTaskSessionScope, long) - Method in interface org.apache.ignite.compute.ComputeTaskSession
-
Saves intermediate state of a job to a storage.
- saveCheckpoint(String, Object, ComputeTaskSessionScope, long, boolean) - Method in interface org.apache.ignite.compute.ComputeTaskSession
-
Saves intermediate state of a job or task to a storage.
- saveCheckpoint(String, byte[], long, boolean) - Method in class org.apache.ignite.spi.checkpoint.cache.CacheCheckpointSpi
-
Saves checkpoint to the storage.
- saveCheckpoint(String, byte[], long, boolean) - Method in interface org.apache.ignite.spi.checkpoint.CheckpointSpi
-
Saves checkpoint to the storage.
- saveCheckpoint(String, byte[], long, boolean) - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
-
Saves checkpoint to the storage.
- saveCheckpoint(String, byte[], long, boolean) - Method in class org.apache.ignite.spi.checkpoint.noop.NoopCheckpointSpi
-
Saves checkpoint to the storage.
- saveCheckpoint(String, byte[], long, boolean) - Method in class org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpi
-
Saves checkpoint to the storage.
- saveCheckpoint(String, byte[], long, boolean) - Method in class org.apache.ignite.spi.checkpoint.sharedfs.SharedFsCheckpointSpi
-
Saves checkpoint to the storage.
- ScanQuery<K,V> - Class in org.apache.ignite.cache.query
-
Scan query over cache entries.
- ScanQuery() - Constructor for class org.apache.ignite.cache.query.ScanQuery
-
Create scan query returning all entries.
- ScanQuery(int) - Constructor for class org.apache.ignite.cache.query.ScanQuery
-
Creates partition scan query returning all entries for given partition.
- ScanQuery(IgniteBiPredicate<K, V>) - Constructor for class org.apache.ignite.cache.query.ScanQuery
-
Create scan query with filter.
- ScanQuery(Integer, IgniteBiPredicate<K, V>) - Constructor for class org.apache.ignite.cache.query.ScanQuery
-
Create scan query with filter.
- scanQueryFilter() - Method in class org.apache.ignite.events.CacheQueryExecutedEvent
-
Gets scan query filter.
- scanQueryFilter() - Method in class org.apache.ignite.events.CacheQueryReadEvent
-
Gets scan query filter.
- scheduleLocal(Runnable, String) - Method in interface org.apache.ignite.IgniteScheduler
-
Schedules job for execution using local cron-based scheduling.
- scheduleLocal(Callable<R>, String) - Method in interface org.apache.ignite.IgniteScheduler
-
Schedules job for execution using local cron-based scheduling.
- scheduler() - Method in interface org.apache.ignite.Ignite
-
Gets an instance of cron-based scheduler.
- scheduler() - Method in class org.apache.ignite.IgniteSpringBean
-
Gets an instance of cron-based scheduler.
- SchedulerFuture<R> - Interface in org.apache.ignite.scheduler
-
Future for cron-based scheduled execution.
- secondarySpaceSize() - Method in interface org.apache.ignite.igfs.IgfsMetrics
-
Get used space in bytes used in the secondary file system.
- SecurityCredentials - Class in org.apache.ignite.plugin.security
-
Security credentials used for node authentication.
- SecurityCredentials() - Constructor for class org.apache.ignite.plugin.security.SecurityCredentials
-
- SecurityCredentials(String, String) - Constructor for class org.apache.ignite.plugin.security.SecurityCredentials
-
Constructs security credentials based on login and password.
- SecurityCredentials(String, String, Object) - Constructor for class org.apache.ignite.plugin.security.SecurityCredentials
-
Constructs security credentials based on login, password,
and custom user object.
- SecurityCredentialsBasicProvider - Class in org.apache.ignite.plugin.security
-
- SecurityCredentialsBasicProvider(SecurityCredentials) - Constructor for class org.apache.ignite.plugin.security.SecurityCredentialsBasicProvider
-
Constructs security credentials provider based on security credentials passed in.
- SecurityCredentialsProvider - Interface in org.apache.ignite.plugin.security
-
Security credentials provider for specifying security credentials.
- SecurityException - Exception in org.apache.ignite.plugin.security
-
Common security exception for the grid.
- SecurityException(String, Throwable) - Constructor for exception org.apache.ignite.plugin.security.SecurityException
-
Constructs security grid exception with given message and cause.
- SecurityException(Throwable) - Constructor for exception org.apache.ignite.plugin.security.SecurityException
-
Creates new security grid exception given throwable as a cause and
source of error message.
- SecurityException(String) - Constructor for exception org.apache.ignite.plugin.security.SecurityException
-
Constructs security grid exception with given message.
- SecurityPermission - Enum in org.apache.ignite.plugin.security
-
Supported security permissions within grid.
- SecurityPermissionSet - Interface in org.apache.ignite.plugin.security
-
Security permission set for authorized security subjects.
- SecuritySubject - Interface in org.apache.ignite.plugin.security
-
Security subject representing authenticated node with a set of permissions.
- SecuritySubjectType - Enum in org.apache.ignite.plugin.security
-
Supported security subject types.
- seek(long) - Method in class org.apache.ignite.igfs.IgfsInputStream
-
Seek to the specified position.
- seek(long) - Method in class org.apache.ignite.igfs.mapreduce.IgfsRangeInputStream
-
Seek to the specified position.
- SegmentationPolicy - Enum in org.apache.ignite.plugin.segmentation
-
Policy that defines how node will react on topology segmentation.
- SegmentationResolver - Interface in org.apache.ignite.plugin.segmentation
-
This is interface for segmentation (a.k.a "split-brain" problem) resolvers.
- selected() - Method in interface org.apache.ignite.visor.plugin.VisorPluginNodesPanel
-
Get selected elements.
- semaphore(String, int, boolean, boolean) - Method in interface org.apache.ignite.Ignite
-
Gets or creates semaphore.
- semaphore(String, int, boolean, boolean) - Method in class org.apache.ignite.IgniteSpringBean
-
Gets or creates semaphore.
- send(ComputeJob, ClusterNode) - Method in interface org.apache.ignite.compute.ComputeTaskContinuousMapper
-
Sends given job to a specific grid node.
- send(Map<? extends ComputeJob, ClusterNode>) - Method in interface org.apache.ignite.compute.ComputeTaskContinuousMapper
-
Sends collection of grid jobs to assigned nodes.
- send(ComputeJob) - Method in interface org.apache.ignite.compute.ComputeTaskContinuousMapper
-
Sends job to a node automatically picked by the underlying load balancer.
- send(Collection<? extends ComputeJob>) - Method in interface org.apache.ignite.compute.ComputeTaskContinuousMapper
-
Sends collection of jobs to nodes automatically picked by the underlying load balancer.
- send(Object, Object) - Method in interface org.apache.ignite.IgniteMessaging
-
Sends given message with specified topic to the nodes in the underlying cluster group.
- send(Object, Collection<?>) - Method in interface org.apache.ignite.IgniteMessaging
-
Sends given messages with the specified topic to the nodes in the underlying cluster group.
- send(ClusterNode, Serializable, String) - Method in interface org.apache.ignite.spi.IgniteSpiContext
-
Sends a message to a remote node.
- sendCustomEvent(DiscoverySpiCustomMessage) - Method in interface org.apache.ignite.spi.discovery.DiscoverySpi
-
Sends custom message across the ring.
- sendCustomEvent(DiscoverySpiCustomMessage) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Sends custom message across the ring.
- sendMessage(ClusterNode, T) - Method in interface org.apache.ignite.spi.communication.CommunicationSpi
-
Sends given message to destination node.
- sendMessage(ClusterNode, Message) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Sends given message to destination node.
- sendMessage(ClusterNode, Message, IgniteInClosure<IgniteException>) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Sends given message to destination node.
- sendMessage() - Method in class org.apache.ignite.spi.IgniteNodeValidationResult
-
- sendOrdered(Object, Object, long) - Method in interface org.apache.ignite.IgniteMessaging
-
Sends given message with specified topic to the nodes in the underlying cluster group.
- service(String) - Method in interface org.apache.ignite.IgniteServices
-
Gets deployed service with specified name.
- Service - Interface in org.apache.ignite.services
-
An instance of grid-managed service.
- serviceClass() - Method in interface org.apache.ignite.services.ServiceDescriptor
-
Gets service class.
- ServiceConfiguration - Class in org.apache.ignite.services
-
Managed service configuration.
- ServiceConfiguration() - Constructor for class org.apache.ignite.services.ServiceConfiguration
-
- ServiceContext - Interface in org.apache.ignite.services
-
Service execution context.
- ServiceDescriptor - Interface in org.apache.ignite.services
-
Service deployment descriptor.
- serviceDescriptors() - Method in interface org.apache.ignite.IgniteServices
-
Gets metadata about all deployed services.
- serviceProxy(String, Class<? super T>, boolean) - Method in interface org.apache.ignite.IgniteServices
-
Gets a remote handle on the service.
- ServiceResource - Annotation Type in org.apache.ignite.resources
-
Annotates a field or a setter method for injection of Ignite service(s) by specified service name.
- services() - Method in interface org.apache.ignite.Ignite
-
Gets services facade over all cluster nodes started in server mode.
- services(ClusterGroup) - Method in interface org.apache.ignite.Ignite
-
Gets services facade over nodes within the cluster group.
- services(String) - Method in interface org.apache.ignite.IgniteServices
-
Gets all deployed services with specified name.
- services() - Method in class org.apache.ignite.IgniteSpringBean
-
Gets services facade over all cluster nodes started in server mode.
- services(ClusterGroup) - Method in class org.apache.ignite.IgniteSpringBean
-
Gets services facade over nodes within the cluster group.
- ServletContextListenerStartup - Class in org.apache.ignite.startup.servlet
-
This class defines Ignite startup based on servlet context listener.
- ServletContextListenerStartup() - Constructor for class org.apache.ignite.startup.servlet.ServletContextListenerStartup
-
- ServletStartup - Class in org.apache.ignite.startup.servlet
-
This class defines servlet-based Ignite startup.
- ServletStartup() - Constructor for class org.apache.ignite.startup.servlet.ServletStartup
-
- session() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
-
- session() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
-
- sessionEnd(boolean) - Method in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
-
Tells store to commit or rollback a transaction depending on the value of the 'commit'
parameter.
- sessionEnd(boolean) - Method in interface org.apache.ignite.cache.store.CacheStore
-
- sessionEnd(boolean) - Method in class org.apache.ignite.cache.store.CacheStoreAdapter
-
Default empty implementation for ending transactions.
- sessionEnd(boolean) - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStore
-
Default empty implementation for ending transactions.
- sessionEnd(boolean) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
-
Tells store to commit or rollback a transaction depending on the value of the 'commit'
parameter.
- sessionEnd(boolean) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
-
Default empty implementation for ending transactions.
- set(String, CollectionConfiguration) - Method in interface org.apache.ignite.Ignite
-
Will get a named set from cache and create one if it has not been created yet and cfg is not
null.
- set(T) - Method in interface org.apache.ignite.IgniteAtomicReference
-
Unconditionally sets the value.
- set(T, S) - Method in interface org.apache.ignite.IgniteAtomicStamped
-
Unconditionally sets the value and the stamp.
- set(String, CollectionConfiguration) - Method in class org.apache.ignite.IgniteSpringBean
-
Will get a named set from cache and create one if it has not been created yet and cfg is not
null.
- set(V1, V2) - Method in class org.apache.ignite.lang.IgniteBiTuple
-
Sets both values in the tuple.
- set1(V1) - Method in class org.apache.ignite.lang.IgniteBiTuple
-
Sets first value.
- set2(V2) - Method in class org.apache.ignite.lang.IgniteBiTuple
-
Sets second value.
- setAckSendThreshold(int) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Sets number of received messages per connection to node after which acknowledgment message is sent.
- setAckTimeout(long) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Sets timeout for receiving acknowledgement for sent message.
- setActiveJobsThreshold(int) - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
-
Sets number of jobs that can be executed in parallel.
- setActiveJobsThreshold(int) - Method in interface org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpiMBean
-
Sets number of jobs that can be executed in parallel.
- setAddr(InetAddress) - Method in class org.apache.ignite.stream.socket.SocketStreamer
-
Sets server address.
- setAddresses(Collection<String>) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.vm.TcpDiscoveryVmIpFinder
-
Parses provided values and initializes the internal collection of addresses.
- setAddressRequestAttempts(int) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
-
Sets number of attempts to send multicast address request.
- setAddressResolver(AddressResolver) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets address resolver for addresses mapping determination.
- setAddressResolver(AddressResolver) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Sets address resolver.
- setAddressResolver(AddressResolver) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Sets address resolver.
- setAffinity(AffinityFunction) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Sets affinity for cache keys.
- setAffinityKey(Object) - Method in class org.apache.ignite.services.ServiceConfiguration
-
Sets affinity key used for key-to-node affinity calculation.
- setAffinityKeyFieldName(String) - Method in class org.apache.ignite.cache.CacheKeyConfiguration
-
Sets affinity key field name.
- setAffinityKeyFieldName(String) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryTypeConfiguration
-
- setAffinityMapper(AffinityKeyMapper) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Sets custom affinity mapper.
- setAliases(Map<String, String>) - Method in class org.apache.ignite.cache.CacheTypeMetadata
-
Deprecated.
Sets mapping from full property name in dot notation to an alias that will be used as SQL column name.
- setAliases(Map<String, String>) - Method in class org.apache.ignite.cache.QueryEntity
-
Sets mapping from full property name in dot notation to an alias that will be used as SQL column name.
- setAllowDuplicateRegistrations(boolean) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.zk.TcpDiscoveryZookeeperIpFinder
-
- setAllSegmentationResolversPassRequired(boolean) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets all segmentation resolvers pass required flag.
- setApiParams(Map<String, String>) - Method in class org.apache.ignite.stream.twitter.TwitterStreamer
-
Sets API Params.
- setApplicationContext(ApplicationContext) - Method in class org.apache.ignite.IgniteSpringBean
- setArgs(Object...) - Method in class org.apache.ignite.cache.query.SpiQuery
-
Sets SQL arguments.
- setArgs(Object...) - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
-
Sets SQL arguments.
- setArgs(Object...) - Method in class org.apache.ignite.cache.query.SqlQuery
-
Sets SQL arguments.
- setArguments(Object...) - Method in class org.apache.ignite.compute.ComputeJobAdapter
-
Sets given arguments.
- setAscendingFields(Map<String, Class<?>>) - Method in class org.apache.ignite.cache.CacheTypeMetadata
-
Deprecated.
Sets name-to-type map for ascending-indexed fields.
- setAssemblies(List<String>) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetConfiguration
-
- setAtomicConfiguration(AtomicConfiguration) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
- setAtomicityMode(CacheAtomicityMode) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Sets cache atomicity mode.
- setAtomicityMode(CacheAtomicityMode) - Method in class org.apache.ignite.configuration.CollectionConfiguration
-
- setAtomicSequenceReserveSize(int) - Method in class org.apache.ignite.configuration.AtomicConfiguration
-
- setAtomicWriteOrderMode(CacheAtomicWriteOrderMode) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Sets cache write ordering mode.
- setAttribute(Object, Object) - Method in interface org.apache.ignite.compute.ComputeJobContext
-
Sets an attribute into this job context.
- setAttribute(Object, Object) - Method in interface org.apache.ignite.compute.ComputeTaskSession
-
Sets session attributed.
- setAttributes(Map<?, ?>) - Method in interface org.apache.ignite.compute.ComputeJobContext
-
Sets map of attributes into this job context.
- setAttributes(Map<?, ?>) - Method in interface org.apache.ignite.compute.ComputeTaskSession
-
Sets task attributes.
- setAuthenticator(DiscoverySpiNodeAuthenticator) - Method in interface org.apache.ignite.spi.discovery.DiscoverySpi
-
Sets discovery SPI node authenticator.
- setAuthenticator(DiscoverySpiNodeAuthenticator) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Sets discovery SPI node authenticator.
- setAutoUnsubscribe(boolean) - Method in class org.apache.ignite.cache.query.ContinuousQuery
-
Sets automatic unsubscribe flag.
- setAwsCredentials(AWSCredentials) - Method in class org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpi
-
Sets AWS credentials.
- setAwsCredentials(AWSCredentials) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.s3.TcpDiscoveryS3IpFinder
-
Sets AWS credentials.
- setBackupFilter(IgniteBiPredicate<ClusterNode, ClusterNode>) - Method in class org.apache.ignite.cache.affinity.fair.FairAffinityFunction
-
Sets optional backup filter.
- setBackupFilter(IgniteBiPredicate<ClusterNode, ClusterNode>) - Method in class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
-
Sets optional backup filter.
- setBackups(int) - Method in class org.apache.ignite.configuration.AtomicConfiguration
-
- setBackups(int) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
- setBackups(int) - Method in class org.apache.ignite.configuration.CollectionConfiguration
-
- setBaseDirectory(String) - Method in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
-
Sets base directory.
- setBasePath(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.zk.TcpDiscoveryZookeeperIpFinder
-
- setBatchClosureMillis(long) - Method in class org.apache.ignite.stream.jms11.JmsStreamer
-
When using batched consumption, sets the time in milliseconds that will elapse before a batch is committed.
- setBatchClosureSize(int) - Method in class org.apache.ignite.stream.jms11.JmsStreamer
-
When using batched consumption, sets the amount of messages that will be received before a batch is committed.
- setBatched(boolean) - Method in class org.apache.ignite.stream.jms11.JmsStreamer
-
Batch consumption leverages JMS Transactions to minimise round trips to the broker.
- setBatchQueueSize(int) - Method in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
-
Sets batch queue size.
- setBatchSize(int) - Method in class org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicy
-
Sets batch size.
- setBatchSize(int) - Method in interface org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicyMBean
-
Sets batch size.
- setBatchSize(int) - Method in class org.apache.ignite.cache.eviction.lru.LruEvictionPolicy
-
Sets batch size.
- setBatchSize(int) - Method in interface org.apache.ignite.cache.eviction.lru.LruEvictionPolicyMBean
-
Sets batch size.
- setBatchSize(int) - Method in class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicy
-
Sets batch size.
- setBatchSize(int) - Method in interface org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicyMBean
-
Sets batch size.
- setBatchSize(int) - Method in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
-
Sets batch size.
- setBatchSize(int) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
-
Set maximum batch size for write and delete operations.
- setBatchSize(int) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
-
Set maximum batch size for write and delete operations.
- setBinaryConfiguration(BinaryConfiguration) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets configuration for Ignite Binary objects.
- setBinaryConfiguration(PlatformDotNetBinaryConfiguration) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetConfiguration
-
- setBlockSize(int) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Sets file's data block size.
- setBlockUntilConnected(boolean) - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
-
Sets whether to block the start() method until connected for the first time.
- setBrokerUrl(String) - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
-
Sets the broker URL (compulsory).
- setBucketName(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.gce.TcpDiscoveryGoogleStorageIpFinder
-
Sets Google Cloud Storage bucket name.
- setBucketName(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.s3.TcpDiscoveryS3IpFinder
-
Sets bucket name for IP finder.
- setBucketNameSuffix(String) - Method in class org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpi
-
Sets bucket name suffix.
- setBuffer(ByteBuffer) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
-
Sets but buffer to read from.
- setBuffer(ByteBuffer) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
-
Sets but buffer to write to.
- setBufferCapacity(Integer) - Method in class org.apache.ignite.stream.twitter.TwitterStreamer
-
Sets Buffer capacity.
- setCacheConfiguration(CacheConfiguration...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets cache configurations.
- setCacheKeyConfiguration(CacheKeyConfiguration...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets cache key configuration.
- setCacheMode(CacheMode) - Method in class org.apache.ignite.configuration.AtomicConfiguration
-
- setCacheMode(CacheMode) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Sets caching mode.
- setCacheMode(CacheMode) - Method in class org.apache.ignite.configuration.CollectionConfiguration
-
- setCacheName(String) - Method in class org.apache.ignite.cache.store.jdbc.JdbcType
-
Sets associated cache name.
- setCacheName(String) - Method in class org.apache.ignite.services.ServiceConfiguration
-
Sets cache name used for key-to-node affinity calculation.
- setCacheName(String) - Method in class org.apache.ignite.spi.checkpoint.cache.CacheCheckpointSpi
-
Sets cache name to be used by this SPI.
- setCacheSanityCheckEnabled(boolean) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets cache sanity check flag.
- setCacheStoreFactory(Factory<? extends CacheStore<? super K, ? super V>>) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Sets factory for persistent storage for cache data.
- setCacheStoreSessionListenerFactories(Factory<? extends CacheStoreSessionListener>...) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Cache store session listener factories.
- setCacheStoreSessionListenerFactories(Factory<CacheStoreSessionListener>...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Cache store session listener factories.
- setCamelContext(CamelContext) - Method in class org.apache.ignite.stream.camel.CamelStreamer
-
Explicitly sets the CamelContext to use.
- setCheckMd5(boolean) - Method in class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
-
If set to true then SPI should exclude files with same md5s from deployment.
- setCheckpointListener(CheckpointListener) - Method in class org.apache.ignite.spi.checkpoint.cache.CacheCheckpointSpi
-
Sets the checkpoint listener.
- setCheckpointListener(CheckpointListener) - Method in interface org.apache.ignite.spi.checkpoint.CheckpointSpi
-
Sets the checkpoint listener.
- setCheckpointListener(CheckpointListener) - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
-
Sets the checkpoint listener.
- setCheckpointListener(CheckpointListener) - Method in class org.apache.ignite.spi.checkpoint.noop.NoopCheckpointSpi
-
Sets the checkpoint listener.
- setCheckpointListener(CheckpointListener) - Method in class org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpi
-
Sets the checkpoint listener.
- setCheckpointListener(CheckpointListener) - Method in class org.apache.ignite.spi.checkpoint.sharedfs.SharedFsCheckpointSpi
-
Sets the checkpoint listener.
- setCheckpointSpi(CheckpointSpi...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
- setCheckpointTableName(String) - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
-
Sets checkpoint table name.
- setClassLoader(ClassLoader) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets loader which will be used for instantiating execution context (EntryProcessors,
CacheEntryListeners, CacheLoaders and
ExpiryPolicys).
- setClassName(String) - Method in class org.apache.ignite.cache.jta.reflect.CacheReflectionTmLookup
-
Sets class name to use.
- setClassNames(Collection<String>) - Method in class org.apache.ignite.configuration.BinaryConfiguration
-
Sets class names of binary objects explicitly.
- setClientConfiguration(ClientConfiguration) - Method in class org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpi
-
Sets Amazon client configuration.
- setClientConfiguration(ClientConfiguration) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.s3.TcpDiscoveryS3IpFinder
-
Sets Amazon client configuration.
- setClientId(String) - Method in class org.apache.ignite.stream.jms11.JmsStreamer
-
Sets the client ID of the JMS Connection.
- setClientId(String) - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
-
Sets the MQTT client ID (optional).
- setClientMode(boolean) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets client mode flag.
- setClientMode(boolean) - Static method in class org.apache.ignite.Ignition
-
Sets client mode static flag.
- setClientReconnectDisabled(boolean) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Sets client reconnect disabled flag.
- setClockSyncFrequency(long) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets clock synchronization frequency in milliseconds.
- setClockSyncSamples(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets number of samples used for clock synchronization.
- setClusterProps(ClusterProperties) - Method in class org.apache.ignite.mesos.IgniteScheduler
-
- setCollisionSpi(CollisionSpi) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
- setCollocated(boolean) - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
-
Sets flag defining if this query is collocated.
- setCollocated(boolean) - Method in class org.apache.ignite.configuration.CollectionConfiguration
-
- setColocateMetadata(boolean) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Set metadata co-location flag.
- setCommunicationSpi(CommunicationSpi) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
- setCompactFooter(boolean) - Method in class org.apache.ignite.configuration.BinaryConfiguration
-
Set whether to write footers in compact form.
- setComponentClass(Class<T>) - Method in class org.apache.ignite.configuration.IgniteReflectionFactory
-
- setConfigPaths(String...) - Method in class org.apache.ignite.hadoop.fs.BasicHadoopFileSystemFactory
-
Set paths to additional file system configuration files (e.g. core-site.xml).
- setConfiguration(IgniteConfiguration) - Method in class org.apache.ignite.cache.spring.SpringCacheManager
-
Sets configuration bean.
- setConfiguration(IgniteConfiguration) - Method in class org.apache.ignite.IgniteSpringBean
-
Sets grid configuration.
- setConfiguration(IgniteConfiguration) - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
-
Sets configuration bean.
- setConfigurationPath(String) - Method in class org.apache.ignite.cache.spring.SpringCacheManager
-
Sets configuration file path.
- setConfigurationPath(String) - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
-
Sets configuration file path.
- setConnectionBufferFlushFrequency(long) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Deprecated.
- setConnectionBufferFlushFrequency(long) - Method in interface org.apache.ignite.spi.communication.tcp.TcpCommunicationSpiMBean
-
Deprecated.
Not used anymore.
- setConnectionBufferSize(int) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Deprecated.
Not used any more.
- setConnectionFactory(ConnectionFactory) - Method in class org.apache.ignite.stream.jms11.JmsStreamer
-
Sets the JMS ConnectionFactory.
- setConnectionUrl(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
-
Sets connection URL.
- setConnectionUrl(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStoreFactory
-
Sets connection URL.
- setConnectOptions(MqttConnectOptions) - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
-
Sets the MQTT client connect options, where users can configured the last will and testament, durability, etc.
- setConnectorConfiguration(ConnectorConfiguration) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
- setConnectTimeout(long) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Sets connect timeout used when establishing connection
with remote nodes.
- setConsistentId(Serializable) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets consistent globally unique node ID which survives node restarts.
- setConsumerConfig(ConsumerConfig) - Method in class org.apache.ignite.stream.kafka.KafkaStreamer
-
Sets the consumer config.
- setContext(MarshallerContext) - Method in class org.apache.ignite.marshaller.AbstractMarshaller
-
Sets marshaller context.
- setContext(MarshallerContext) - Method in interface org.apache.ignite.marshaller.Marshaller
-
Sets marshaller context.
- setConverter(SocketMessageConverter<T>) - Method in class org.apache.ignite.stream.socket.SocketStreamer
-
Sets message converter.
- setCopyOnRead(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Sets copy on read flag.
- setCreateTableQuery(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
-
Sets create table query.
- setCreateTableQuery(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStoreFactory
-
Sets create table query.
- setCredential(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.cloud.TcpDiscoveryCloudIpFinder
-
Sets credential that is used during authentication on the cloud.
- setCredentialPath(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.cloud.TcpDiscoveryCloudIpFinder
-
Sets the path to a credential that is used during authentication on the cloud.
- setCurator(CuratorFramework) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.zk.TcpDiscoveryZookeeperIpFinder
-
- setCurrentReadClass(Class<? extends Message>) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
-
Sets type of message currently read.
- setCurrentWriteClass(Class<? extends Message>) - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
-
Sets type of message currently written.
- setDaemon(boolean) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets daemon flag.
- setDaemon(boolean) - Static method in class org.apache.ignite.Ignition
-
Sets daemon flag.
- setDatabaseFieldName(String) - Method in class org.apache.ignite.cache.store.jdbc.JdbcTypeField
-
- setDatabaseFieldType(int) - Method in class org.apache.ignite.cache.store.jdbc.JdbcTypeField
-
- setDatabaseName(String) - Method in class org.apache.ignite.cache.CacheTypeFieldMetadata
-
- setDatabaseSchema(String) - Method in class org.apache.ignite.cache.CacheTypeMetadata
-
Deprecated.
Sets database schema name.
- setDatabaseSchema(String) - Method in class org.apache.ignite.cache.store.jdbc.JdbcType
-
Sets database schema name.
- setDatabaseTable(String) - Method in class org.apache.ignite.cache.CacheTypeMetadata
-
Deprecated.
Table name in database.
- setDatabaseTable(String) - Method in class org.apache.ignite.cache.store.jdbc.JdbcType
-
Table name in database.
- setDatabaseType(int) - Method in class org.apache.ignite.cache.CacheTypeFieldMetadata
-
- setDataCacheName(String) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Sets cache name to store IGFS data.
- setDataExchange(DiscoverySpiDataExchange) - Method in interface org.apache.ignite.spi.discovery.DiscoverySpi
-
Sets a handler for initial data exchange between Ignite nodes.
- setDataExchange(DiscoverySpiDataExchange) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Sets a handler for initial data exchange between Ignite nodes.
- setDataSource(DataSource) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
-
- setDataSource(DataSource) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
-
Sets data source.
- setDataSource(DataSource) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStoreFactory
-
Sets data source.
- setDataSource(DataSource) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
-
Sets data source.
- setDataSource(DataSource) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcStoreSessionListener
-
Sets data source.
- setDataSource(DataSource) - Method in class org.apache.ignite.cache.store.spring.CacheSpringStoreSessionListener
-
Sets data source.
- setDataSource(DataSource) - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
-
Sets DataSource to use for database access.
- setDataSource(DataSource) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc.TcpDiscoveryJdbcIpFinder
-
Sets data source.
- setDataSourceBean(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStoreFactory
-
Sets name of the data source bean.
- setDataSourceBean(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
-
Sets name of the data source bean.
- setDefaultIdMapper(String) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryConfiguration
-
- setDefaultKeepDeserialized(boolean) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryConfiguration
-
Sets default keep deserialized flag.
- setDefaultLockTimeout(long) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Sets default lock timeout in milliseconds.
- setDefaultMode(IgfsMode) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Sets IGFS mode to specify how it should interact with secondary
Hadoop file system, like HDFS.
- setDefaultNameMapper(String) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryConfiguration
-
- setDefaultPriority(int) - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
-
Sets default priority to use if a job does not have priority attribute set.
- setDefaultPriority(int) - Method in interface org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpiMBean
-
Sets default priority to use if a job does not have priority attribute set.
- setDefaultSerializer(String) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryConfiguration
-
- setDefaultTxConcurrency(TransactionConcurrency) - Method in class org.apache.ignite.configuration.TransactionConfiguration
-
Sets default transaction concurrency.
- setDefaultTxIsolation(TransactionIsolation) - Method in class org.apache.ignite.configuration.TransactionConfiguration
-
Sets default transaction isolation.
- setDefaultTxTimeout(long) - Method in class org.apache.ignite.configuration.TransactionConfiguration
-
Sets default transaction timeout in milliseconds.
- setDefaultUserName(String) - Method in class org.apache.ignite.hadoop.fs.IgniteHadoopIgfsSecondaryFileSystem
-
Sets default user name.
- setDeleteQuery(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
-
Sets delete entry query.
- setDeleteQuery(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStoreFactory
-
Sets delete entry query.
- setDelimiter(byte[]) - Method in class org.apache.ignite.stream.socket.SocketStreamer
-
Sets message delimiter.
- setDeploymentMode(DeploymentMode) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets task classes and resources sharing mode.
- setDeploymentSpi(DeploymentSpi) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
- setDescendingFields(Map<String, Class<?>>) - Method in class org.apache.ignite.cache.CacheTypeMetadata
-
Deprecated.
Sets name-to-type map for descending-indexed fields.
- setDestination(Destination) - Method in class org.apache.ignite.stream.jms11.JmsStreamer
-
Sets the JMS Destination explicitly.
- setDestinationName(String) - Method in class org.apache.ignite.stream.jms11.JmsStreamer
-
Sets the name of the JMS destination to consume from.
- setDestinationType(Class<? extends Destination>) - Method in class org.apache.ignite.stream.jms11.JmsStreamer
-
- setDialect(JdbcDialect) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
-
Set database dialect.
- setDialect(JdbcDialect) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
-
Set database dialect.
- setDirectBuffer(boolean) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
-
Sets whether to use direct buffer for REST TCP server.
- setDirectBuffer(boolean) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Sets flag to allocate direct or heap buffer in SPI.
- setDirectMode(boolean) - Method in class org.apache.ignite.stream.socket.SocketStreamer
-
Sets direct mode flag.
- setDirectoryPaths(Collection<String>) - Method in class org.apache.ignite.spi.checkpoint.sharedfs.SharedFsCheckpointSpi
-
Sets path to a shared directory where checkpoints will be stored.
- setDirectSendBuffer(boolean) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Sets whether to use direct buffer for sending.
- setDisconnectForcibly(boolean) - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
-
Sets whether to disconnect forcibly or not when shutting down.
- setDisconnectForciblyTimeout(Integer) - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
-
Sets the timeout if disconnecting forcibly.
- setDisconnectQuiesceTimeout(Integer) - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
-
Sets the quiesce timeout on disconnection.
- setDiscoveryPort(int) - Method in class org.apache.ignite.startup.BasicWarmupClosure
-
Sets discovery port for warmup.
- setDiscoverySpi(DiscoverySpi) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
- setDiscoveryStartupDelay(long) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets time in milliseconds after which a certain metric value is considered expired.
- setDualModeMaxPendingPutsSize(long) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Set maximum amount of data in pending put operations.
- setDualModePutExecutorService(ExecutorService) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Set DUAL mode put operations executor service.
- setDualModePutExecutorServiceShutdown(boolean) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Set DUAL mode put operations executor service shutdown flag.
- setDurableSubscription(boolean) - Method in class org.apache.ignite.stream.jms11.JmsStreamer
-
A true value is only accepted in combination with topic consumption.
- setDurableSubscriptionName(String) - Method in class org.apache.ignite.stream.jms11.JmsStreamer
-
When using Durable Subscribers, sets the name of the durable subscriber.
- setDynamicCacheConfiguration(CacheConfiguration<Object, Object>) - Method in class org.apache.ignite.cache.spring.SpringCacheManager
-
Sets dynamic cache configuration template.
- setDynamicNearCacheConfiguration(NearCacheConfiguration<Object, Object>) - Method in class org.apache.ignite.cache.spring.SpringCacheManager
-
Sets dynamic cache configuration template.
- setEagerTtl(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Sets eager ttl flag.
- setEncodeUri(boolean) - Method in class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
-
Indicates that URI must be encoded before usage.
- setEndpointUri(String) - Method in class org.apache.ignite.stream.camel.CamelStreamer
-
Sets the endpoint URI from which to consume.
- setEndpointUrl(String) - Method in class org.apache.ignite.stream.twitter.TwitterStreamer
-
Sets Endpoint URL.
- setEnum(boolean) - Method in class org.apache.ignite.binary.BinaryTypeConfiguration
-
Sets whether this is enum type.
- setEnum(boolean) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryTypeConfiguration
-
Sets whether this is enum type.
- setEventStorageSpi(EventStorageSpi) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
- setEvictionFilter(EvictionFilter<K, V>) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Sets eviction filter.
- setEvictionPolicy(EvictionPolicy) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Sets cache eviction policy.
- setEvictMaxOverflowRatio(float) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Sets maximum eviction overflow ratio.
- setEvictSynchronized(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Sets flag indicating whether eviction is synchronized with backup nodes or near caches
(or the rest of the nodes for replicated cache).
- setEvictSynchronizedConcurrencyLevel(int) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Sets concurrency level for synchronized evictions.
- setEvictSynchronizedKeyBufferSize(int) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Sets eviction key buffer size.
- setEvictSynchronizedTimeout(long) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Sets timeout for synchronized evictions.
- setExcludeNeighbors(boolean) - Method in class org.apache.ignite.cache.affinity.fair.FairAffinityFunction
-
Sets flag to exclude same-host-neighbors from being backups of each other (default is false).
- setExcludeNeighbors(boolean) - Method in class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
-
Sets flag to exclude same-host-neighbors from being backups of each other (default is false).
- setExcludePaths(Collection<String>) - Method in class org.apache.ignite.cache.eviction.igfs.IgfsPerBlockLruEvictionPolicy
-
Sets collection of regex for paths whose blocks must not be evicted.
- setExcludePaths(Collection<String>) - Method in interface org.apache.ignite.cache.eviction.igfs.IgfsPerBlockLruEvictionPolicyMXBean
-
Sets collection of regex for paths whose blocks must not be evicted.
- setExpireAgeMs(long) - Method in class org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpi
-
Sets events expiration time.
- setExpireCount(long) - Method in class org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpi
-
Sets events queue size.
- setExpireDateFieldName(String) - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
-
Sets checkpoint expiration date field name.
- setExpireDateFieldType(String) - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
-
Sets checkpoint expiration date field type.
- setExternalCollisionListener(CollisionExternalListener) - Method in interface org.apache.ignite.spi.collision.CollisionSpi
-
Listener to be set for notification of external collision events (e.g. job stealing).
- setExternalCollisionListener(CollisionExternalListener) - Method in class org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpi
-
Listener to be set for notification of external collision events (e.g. job stealing).
- setExternalCollisionListener(CollisionExternalListener) - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
-
Listener to be set for notification of external collision events (e.g. job stealing).
- setExternalCollisionListener(CollisionExternalListener) - Method in class org.apache.ignite.spi.collision.noop.NoopCollisionSpi
-
Listener to be set for notification of external collision events (e.g. job stealing).
- setExternalCollisionListener(CollisionExternalListener) - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
-
Listener to be set for notification of external collision events (e.g. job stealing).
- setFailoverSpi(FailoverSpi...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
- setFailureDetectionTimeout(long) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
- setField(String, Object) - Method in interface org.apache.ignite.binary.BinaryObjectBuilder
-
Sets field value.
- setField(String, T, Class<? super T>) - Method in interface org.apache.ignite.binary.BinaryObjectBuilder
-
Sets field value with value type specification.
- setField(String, BinaryObjectBuilder) - Method in interface org.apache.ignite.binary.BinaryObjectBuilder
-
Sets field value.
- setFieldNames(Collection<String>, boolean) - Method in class org.apache.ignite.cache.QueryIndex
-
Sets a collection of field names altogether with the field sorting direction.
- setFields(LinkedHashMap<String, String>) - Method in class org.apache.ignite.cache.QueryEntity
-
Sets query fields for this query pair.
- setFields(LinkedHashMap<String, Boolean>) - Method in class org.apache.ignite.cache.QueryIndex
-
Sets fields included in the index.
- setFile(String, boolean, boolean, int) - Method in class org.apache.ignite.logger.log4j.Log4JDailyRollingFileAppender
- setFile(String, boolean, boolean, int) - Method in class org.apache.ignite.logger.log4j.Log4JExternallyRolledFileAppender
- setFile(String, boolean, boolean, int) - Method in class org.apache.ignite.logger.log4j.Log4JFileAppender
- setFile(String, boolean, boolean, int) - Method in class org.apache.ignite.logger.log4j.Log4jRollingFileAppender
- setFileSystemConfiguration(FileSystemConfiguration...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets IGFS (Ignite In-Memory File System) configurations.
- setFileSystemFactory(HadoopFileSystemFactory) - Method in class org.apache.ignite.hadoop.fs.IgniteHadoopIgfsSecondaryFileSystem
-
Sets secondary file system factory.
- setFilter(IgniteBiPredicate<K, V>) - Method in class org.apache.ignite.cache.query.ScanQuery
-
Sets filter.
- setFilter(IgnitePredicate<Event>) - Method in class org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpi
-
Sets filter for events to be recorded.
- setFinishedJobInfoTtl(long) - Method in class org.apache.ignite.configuration.HadoopConfiguration
-
Sets finished job info time-to-live.
- setForceServerMode(boolean) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Sets force server mode flag.
- setFragmentizerConcurrentFiles(int) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Sets number of files to process concurrently by fragmentizer.
- setFragmentizerEnabled(boolean) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Sets property indicating whether fragmentizer is enabled.
- setFragmentizerLocalWritesRatio(float) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Deprecated.
Parameter is no longer used.
- setFragmentizerThrottlingBlockLength(long) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Sets length of file chunk to transmit before throttling is delayed.
- setFragmentizerThrottlingDelay(long) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Sets delay in milliseconds for which fragmentizer is paused.
- setFs(FileSystem) - Method in class org.apache.ignite.yarn.ApplicationMaster
-
Sets file system.
- setGridCount(int) - Method in class org.apache.ignite.startup.BasicWarmupClosure
-
Sets number of grids to start and run the warmup.
- setGridLogger(IgniteLogger) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets logger to use within grid.
- setGridName(String) - Method in class org.apache.ignite.cache.spring.SpringCacheManager
-
Sets grid name.
- setGridName(String) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets grid name.
- setGridName(String) - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
-
Sets grid name.
- setGroups(Map<String, LinkedHashMap<String, IgniteBiTuple<Class<?>, Boolean>>>) - Method in class org.apache.ignite.cache.CacheTypeMetadata
-
Deprecated.
Sets group-indexed fields.
- setHadoopConfiguration(HadoopConfiguration) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets hadoop configuration.
- setHasher(JdbcTypeHasher) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
-
Sets hash code calculator.
- setHasher(JdbcTypeHasher) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
-
Sets hash code calculator.
- setHashIdResolver(AffinityNodeHashResolver) - Method in class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
-
- setHeartbeatFrequency(long) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Sets delay between issuing of heartbeat messages.
- setHibernateConfigurationPath(String) - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStore
-
Sets hibernate configuration path.
- setHibernateConfigurationPath(String) - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStoreFactory
-
Sets hibernate configuration path.
- setHibernateConfigurationPath(String) - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateStoreSessionListener
-
Sets hibernate configuration path.
- setHibernateProperties(Properties) - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStore
-
Sets Hibernate properties.
- setHibernateProperties(Properties) - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStoreFactory
-
Sets Hibernate properties.
- setHost(String) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
-
Sets host for TCP binary protocol server.
- setHost(String) - Method in class org.apache.ignite.igfs.IgfsIpcEndpointConfiguration
-
Sets the host endpoint is bound to.
- setIdentity(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.cloud.TcpDiscoveryCloudIpFinder
-
Sets the identity that is used as a user name during a connection to the cloud.
- setIdleConnectionTimeout(long) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Sets maximum idle connection timeout upon which a connection
to client will be closed.
- setIdleQueryCursorCheckFrequency(long) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
-
Sets idle query cursor check frequency.
- setIdleQueryCursorTimeout(long) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
-
Sets idle query cursors timeout.
- setIdleTimeout(long) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
-
Sets idle timeout for REST server.
- setIdMapper(BinaryIdMapper) - Method in class org.apache.ignite.binary.BinaryTypeConfiguration
-
Sets ID mapper.
- setIdMapper(BinaryIdMapper) - Method in class org.apache.ignite.configuration.BinaryConfiguration
-
Sets ID mapper.
- setIdMapper(OptimizedMarshallerIdMapper) - Method in class org.apache.ignite.marshaller.optimized.OptimizedMarshaller
-
Sets ID mapper.
- setIdMapper(String) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryTypeConfiguration
-
- setIgfsThreadPoolSize(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Set thread pool size that will be used to process outgoing IGFS messages.
- setIgnite(Ignite) - Method in class org.apache.ignite.stream.StreamAdapter
-
- setIgniteHome(String) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets Ignite installation folder.
- setIncludeEventTypes(int...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets array of event types, which will be recorded by GridEventStorageManager.record(Event).
- setIncludeProperties(String...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets array of system or environment property names to include into node attributes.
- setIndexedTypes(Class<?>...) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Array of key and value type pairs to be indexed (thus array length must be always even).
- setIndexes(Collection<QueryIndex>) - Method in class org.apache.ignite.cache.QueryEntity
-
Sets a collection of index entities.
- setIndexingSpi(IndexingSpi) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
- setIndexType(QueryIndexType) - Method in class org.apache.ignite.cache.QueryIndex
-
Sets index type.
- setInitialContextEnvironment(Map<?, ?>) - Method in class org.apache.ignite.cache.jta.jndi.CacheJndiTmFactory
-
- setInitializeDefaultPathModes(boolean) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Set whether to initialize default path modes.
- setInitialQuery(Query<Cache.Entry<K, V>>) - Method in class org.apache.ignite.cache.query.ContinuousQuery
-
Sets initial query.
- setInitSchema(boolean) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
-
Flag indicating whether DB schema should be initialized by Ignite (default behaviour) or
was explicitly created by user.
- setInitSchema(boolean) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStoreFactory
-
Flag indicating whether DB schema should be initialized by Ignite (default behaviour) or
was explicitly created by user.
- setInitSchema(boolean) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.jdbc.TcpDiscoveryJdbcIpFinder
-
Flag indicating whether DB schema should be initialized by Ignite (default behaviour) or
was explicitly created by user.
- setInsertQuery(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
-
Sets insert entry query.
- setInsertQuery(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStoreFactory
-
Sets insert entry query.
- setInterceptor(CacheInterceptor<K, V>) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Sets cache interceptor.
- setInvalidate(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Sets invalidation flag for near cache entries in this transaction.
- setIpcEndpointConfiguration(IgfsIpcEndpointConfiguration) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Sets IPC endpoint configuration.
- setIpcEndpointEnabled(boolean) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Set IPC endpoint enabled flag.
- setIpFinder(TcpDiscoveryIpFinder) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Sets IP finder for IP addresses sharing and storing.
- setIpFinderCleanFrequency(long) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Sets IP finder clean frequency in milliseconds.
- setIterationCount(int) - Method in class org.apache.ignite.startup.BasicWarmupClosure
-
Sets iteration count for warmup.
- setJavaFieldName(String) - Method in class org.apache.ignite.cache.store.jdbc.JdbcTypeField
-
- setJavaFieldType(Class<?>) - Method in class org.apache.ignite.cache.store.jdbc.JdbcTypeField
-
- setJavaName(String) - Method in class org.apache.ignite.cache.CacheTypeFieldMetadata
-
- setJavaType(Class<?>) - Method in class org.apache.ignite.cache.CacheTypeFieldMetadata
-
- setJettyPath(String) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
-
Sets path, either absolute or relative to IGNITE_HOME, to JETTY
XML configuration file.
- setJndiNames(String...) - Method in class org.apache.ignite.cache.jta.jndi.CacheJndiTmFactory
-
Sets JNDI names used by this TM factory.
- setJndiNames(List<String>) - Method in class org.apache.ignite.cache.jta.jndi.CacheJndiTmLookup
-
Sets a list of JNDI names used by this TM.
- setJobPriorityAttributeKey(String) - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
-
Sets job priority attribute key.
- setJoinTimeout(long) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Sets join timeout.
- setKeepDeserialized(Boolean) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryTypeConfiguration
-
Sets keep deserialized flag.
- setKey(byte[]) - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStoreEntry
-
- setKeyAlgorithm(String) - Method in class org.apache.ignite.ssl.SslContextFactory
-
Sets key manager algorithm that will be used to create a key manager.
- setKeyDecoder(Decoder<K>) - Method in class org.apache.ignite.stream.kafka.KafkaStreamer
-
Sets the key decoder.
- setKeyFieldName(String) - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
-
Sets checkpoint key field name.
- setKeyFields(Collection<CacheTypeFieldMetadata>) - Method in class org.apache.ignite.cache.CacheTypeMetadata
-
Deprecated.
- setKeyFields(JdbcTypeField...) - Method in class org.apache.ignite.cache.store.jdbc.JdbcType
-
- setKeyFieldType(String) - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
-
Sets checkpoint key field type.
- setKeyRange(int) - Method in class org.apache.ignite.startup.BasicWarmupClosure
-
Sets key range.
- setKeyStoreFilePath(String) - Method in class org.apache.ignite.ssl.SslContextFactory
-
Sets path to the key store file.
- setKeyStorePassword(char[]) - Method in class org.apache.ignite.ssl.SslContextFactory
-
Sets key store password.
- setKeyStoreType(String) - Method in class org.apache.ignite.ssl.SslContextFactory
-
Sets key store type used in context initialization.
- setKeyTab(String) - Method in class org.apache.ignite.hadoop.fs.KerberosHadoopFileSystemFactory
-
Sets the key tab file name.
- setKeyTabPrincipal(String) - Method in class org.apache.ignite.hadoop.fs.KerberosHadoopFileSystemFactory
-
Set the key tab principal name.
- setKeyType(String) - Method in class org.apache.ignite.cache.CacheTypeMetadata
-
Deprecated.
Sets key type.
- setKeyType(Class<?>) - Method in class org.apache.ignite.cache.CacheTypeMetadata
-
Deprecated.
Sets key type.
- setKeyType(String) - Method in class org.apache.ignite.cache.QueryEntity
-
Sets key type for this query pair.
- setKeyType(String) - Method in class org.apache.ignite.cache.store.jdbc.JdbcType
-
Sets key type.
- setKeyType(Class<?>) - Method in class org.apache.ignite.cache.store.jdbc.JdbcType
-
Sets key type.
- setLevel(Level) - Method in class org.apache.ignite.logger.log4j.Log4JLogger
-
Sets level for internal log4j implementation.
- setLevel(Level) - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
-
Sets level for internal log4j implementation.
- setLifecycleBeans(LifecycleBean...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets a collection of lifecycle beans.
- setListener(CommunicationListener<T>) - Method in interface org.apache.ignite.spi.communication.CommunicationSpi
-
Set communication listener.
- setListener(CommunicationListener<Message>) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Set communication listener.
- setListener(DeploymentListener) - Method in interface org.apache.ignite.spi.deployment.DeploymentSpi
-
Sets or unsets deployment event listener.
- setListener(DeploymentListener) - Method in class org.apache.ignite.spi.deployment.local.LocalDeploymentSpi
-
Sets or unsets deployment event listener.
- setListener(DeploymentListener) - Method in class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
-
Sets or unsets deployment event listener.
- setListener(DiscoverySpiListener) - Method in interface org.apache.ignite.spi.discovery.DiscoverySpi
-
Sets a listener for discovery events.
- setListener(DiscoverySpiListener) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Sets a listener for discovery events.
- setListener(SwapSpaceSpiListener) - Method in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
-
Sets eviction listener to receive notifications on evicted swap entries.
- setListener(SwapSpaceSpiListener) - Method in class org.apache.ignite.spi.swapspace.noop.NoopSwapSpaceSpi
-
Sets eviction listener to receive notifications on evicted swap entries.
- setListener(SwapSpaceSpiListener) - Method in interface org.apache.ignite.spi.swapspace.SwapSpaceSpi
-
Sets eviction listener to receive notifications on evicted swap entries.
- setLoadBalancingSpi(LoadBalancingSpi...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
- setLoadPreviousValue(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
- setLoadProbe(AdaptiveLoadProbe) - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveLoadBalancingSpi
-
Sets implementation of node load probe.
- setLoadQuery(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
-
Sets load query.
- setLoadQuery(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStoreFactory
-
Sets load query.
- setLocal(boolean) - Method in class org.apache.ignite.cache.query.ContinuousQuery
-
Sets whether this query should be executed on local node only.
- setLocal(boolean) - Method in class org.apache.ignite.cache.query.Query
-
Sets whether this query should be executed on local node only.
- setLocal(boolean) - Method in class org.apache.ignite.cache.query.ScanQuery
-
Sets whether this query should be executed on local node only.
- setLocal(boolean) - Method in class org.apache.ignite.cache.query.SpiQuery
-
Sets whether this query should be executed on local node only.
- setLocal(boolean) - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
-
Sets whether this query should be executed on local node only.
- setLocal(boolean) - Method in class org.apache.ignite.cache.query.SqlQuery
-
Sets whether this query should be executed on local node only.
- setLocal(boolean) - Method in class org.apache.ignite.cache.query.TextQuery
-
Sets whether this query should be executed on local node only.
- setLocalAddress(String) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Sets local host address for socket binding.
- setLocalAddress(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
-
Sets local host address used by this IP finder.
- setLocalAddress(String) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Sets local host IP address that discovery SPI uses.
- setLocalEventListeners(Map<IgnitePredicate<? extends Event>, int[]>) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets map of pre-configured local event listeners.
- setLocalHost(String) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets system-wide local address or host for all Ignite components to bind to.
- setLocalListener(CacheEntryUpdatedListener<K, V>) - Method in class org.apache.ignite.cache.query.ContinuousQuery
-
Sets local callback.
- setLocalPort(int) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Sets local port for socket binding.
- setLocalPort(int) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Sets local port to listen to.
- setLocalPortRange(int) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Sets local port range for local host ports (value must greater than or equal to 0).
- setLocalPortRange(int) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Range for local ports.
- setLogin(Object) - Method in class org.apache.ignite.plugin.security.SecurityCredentials
-
Sets login.
- setLongQueryWarningTimeout(long) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Sets timeout in milliseconds after which long query warning will be printed.
- setLowerCase(boolean) - Method in class org.apache.ignite.binary.BinaryBasicIdMapper
-
Sets whether to use strings in lower case or not.
- setManagementPort(int) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Sets management endpoint port.
- setManagementThreadPoolSize(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets management thread pool size to use within grid.
- setMapReducePlanner(HadoopMapReducePlanner) - Method in class org.apache.ignite.configuration.HadoopConfiguration
-
Sets Hadoop map-reduce planner, a component which defines job execution plan based on job
configuration and current grid topology.
- setMarshaller(Marshaller) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets marshaller to use within grid.
- setMarshallerCacheKeepAliveTime(long) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets maximum thread pool size that will be used to process marshaller messages.
- setMarshallerCachePoolSize(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets default thread pool size that will be used to process marshaller messages.
- setMarshalLocalJobs(boolean) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets marshal local jobs flag.
- setMaxAckTimeout(long) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Sets maximum timeout for receiving acknowledgement for sent message.
- setMaxBlocks(int) - Method in class org.apache.ignite.cache.eviction.igfs.IgfsPerBlockLruEvictionPolicy
-
Sets maximum allowed amount of blocks.
- setMaxBlocks(int) - Method in interface org.apache.ignite.cache.eviction.igfs.IgfsPerBlockLruEvictionPolicyMXBean
-
Sets maximum allowed amount of blocks.
- setMaxConcurrentAsyncOperations(int) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Sets maximum number of concurrent asynchronous operations.
- setMaxConnectTimeout(long) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Sets maximum connect timeout.
- setMaximumFailoverAttempts(int) - Method in class org.apache.ignite.spi.failover.always.AlwaysFailoverSpi
-
Sets maximum number of attempts to execute a failed job on another node.
- setMaximumFailoverAttempts(int) - Method in class org.apache.ignite.spi.failover.jobstealing.JobStealingFailoverSpi
-
Sets maximum number of attempts to execute a failed job on another node.
- setMaximumPoolSize(int) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
-
Set Max workers thread count.
- setMaximumPoolSize(int) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
-
Set Maximum workers thread count.
- setMaximumSparsity(float) - Method in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
-
Sets maximum sparsity.
- setMaximumStealingAttempts(int) - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
-
Gets maximum number of attempts to steal job by another node.
- setMaximumStealingAttempts(int) - Method in interface org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpiMBean
-
Gets maximum number of attempts to steal job by another node.
- setMaximumTaskRangeLength(long) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Set maximum default range size of a file being split during IGFS task execution.
- setMaximumWriteAttempts(int) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
-
Sets maximum number of write attempts in case of database error.
- setMaximumWriteAttempts(int) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
-
Sets maximum number of write attempts in case of database error.
- setMaxMemorySize(long) - Method in class org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicy
-
Sets maximum allowed cache size in bytes.
- setMaxMemorySize(long) - Method in interface org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicyMBean
-
Sets maximum allowed cache size in bytes.
- setMaxMemorySize(long) - Method in class org.apache.ignite.cache.eviction.lru.LruEvictionPolicy
-
Sets maximum allowed cache size in bytes.
- setMaxMemorySize(long) - Method in interface org.apache.ignite.cache.eviction.lru.LruEvictionPolicyMBean
-
Sets maximum allowed cache size in bytes.
- setMaxMemorySize(long) - Method in class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicy
-
Sets maximum allowed cache size in bytes.
- setMaxMemorySize(long) - Method in interface org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicyMBean
-
Sets maximum allowed cache size in bytes.
- setMaxMissedClientHeartbeats(int) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Sets max heartbeats count node can miss without failing client node.
- setMaxMissedHeartbeats(int) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Sets max heartbeats count node can miss without initiating status check.
- setMaxParallelTasks(int) - Method in class org.apache.ignite.configuration.HadoopConfiguration
-
Sets max number of local tasks that may be executed in parallel.
- setMaxParameterCount(int) - Method in class org.apache.ignite.cache.store.jdbc.dialect.BasicJdbcDialect
-
Set max query parameters count.
- setMaxPerNodeCount(int) - Method in class org.apache.ignite.services.ServiceConfiguration
-
Sets maximum number of deployed service instances on each node, 0 for unlimited.
- setMaxSize(int) - Method in class org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicy
-
Sets maximum allowed size of cache before entry will start getting evicted.
- setMaxSize(int) - Method in interface org.apache.ignite.cache.eviction.fifo.FifoEvictionPolicyMBean
-
Sets maximum allowed cache size.
- setMaxSize(long) - Method in class org.apache.ignite.cache.eviction.igfs.IgfsPerBlockLruEvictionPolicy
-
Sets maximum allowed size of data in all blocks in bytes.
- setMaxSize(long) - Method in interface org.apache.ignite.cache.eviction.igfs.IgfsPerBlockLruEvictionPolicyMXBean
-
Sets maximum allowed size of data in all blocks in bytes.
- setMaxSize(int) - Method in class org.apache.ignite.cache.eviction.lru.LruEvictionPolicy
-
Sets maximum allowed size of cache before entry will start getting evicted.
- setMaxSize(int) - Method in interface org.apache.ignite.cache.eviction.lru.LruEvictionPolicyMBean
-
Sets maximum allowed cache size.
- setMaxSize(int) - Method in class org.apache.ignite.cache.eviction.random.RandomEvictionPolicy
-
Deprecated.
Sets maximum allowed size of cache before entry will start getting evicted.
- setMaxSize(int) - Method in interface org.apache.ignite.cache.eviction.random.RandomEvictionPolicyMBean
-
Sets maximum allowed cache size.
- setMaxSize(int) - Method in class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicy
-
Sets maximum allowed size of cache before entry will start getting evicted.
- setMaxSize(int) - Method in interface org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicyMBean
-
Sets maximum allowed cache size.
- setMaxSpaceSize(long) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Set maximum space in bytes available in data cache.
- setMaxTaskQueueSize(int) - Method in class org.apache.ignite.configuration.HadoopConfiguration
-
Sets max task queue size.
- setMaxWriteQueueSize(int) - Method in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
-
Sets max write queue size in bytes.
- setMBeanServer(MBeanServer) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets initialized and started MBean server.
- setMemoryMode(CacheMemoryMode) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Sets memory mode for cache.
- setMemoryMode(CacheMemoryMode) - Method in class org.apache.ignite.configuration.CollectionConfiguration
-
- setMemorySize(int) - Method in class org.apache.ignite.igfs.IgfsIpcEndpointConfiguration
-
Sets shared memory size in bytes allocated for endpoint communication.
- setMessageExpireTime(long) - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
-
Message expire time configuration parameter.
- setMessageExpireTime(long) - Method in interface org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpiMBean
-
Message expire time configuration parameter.
- setMessageInterceptor(ConnectorMessageInterceptor) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
-
Sets client message interceptor.
- setMessageQueueLimit(int) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Sets message queue limit for incoming and outgoing messages.
- setMetaCacheName(String) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Sets cache name to store IGFS meta information.
- setMethodClass(Class<?>) - Method in class org.apache.ignite.compute.gridify.aop.GridifyArgumentAdapter
-
Sets method class.
- setMethodName(String) - Method in class org.apache.ignite.cache.jta.reflect.CacheReflectionTmLookup
-
Sets method name.
- setMethodName(String) - Method in class org.apache.ignite.compute.gridify.aop.GridifyArgumentAdapter
-
Sets method name.
- setMethodParameters(Object...) - Method in class org.apache.ignite.compute.gridify.aop.GridifyArgumentAdapter
-
Sets method parameters.
- setMethodParameterTypes(Class<?>...) - Method in class org.apache.ignite.compute.gridify.aop.GridifyArgumentAdapter
-
Sets method parameter types.
- setMetricsExpireTime(long) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets time in milliseconds after which a certain metric value is considered expired.
- setMetricsHistorySize(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets number of metrics kept in history to compute totals and averages.
- setMetricsLogFrequency(long) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets frequency of metrics log print out.
- setMetricsProvider(DiscoveryMetricsProvider) - Method in interface org.apache.ignite.spi.discovery.DiscoverySpi
-
Sets discovery metrics provider.
- setMetricsProvider(DiscoveryMetricsProvider) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Sets discovery metrics provider.
- setMetricsUpdateFrequency(long) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets job metrics update frequency in milliseconds.
- setMinimumBufferedMessageCount(int) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Deprecated.
Not used any more.
- setMulticastGroup(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
-
Sets IP address of multicast group.
- setMulticastPort(int) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
-
Sets port number which multicast messages are sent to.
- setMultipleTupleExtractor(StreamMultipleTupleExtractor<T, K, V>) - Method in class org.apache.ignite.stream.StreamAdapter
-
- setName(String) - Method in class org.apache.ignite.cache.QueryIndex
-
Sets index name.
- setName(String) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Sets cache name.
- setName(String) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Sets IGFS instance name.
- setName(String) - Method in class org.apache.ignite.services.ServiceConfiguration
-
Sets service name.
- setName(String) - Method in class org.apache.ignite.spi.IgniteSpiAdapter
-
Sets SPI name.
- setNameMapper(BinaryNameMapper) - Method in class org.apache.ignite.binary.BinaryTypeConfiguration
-
Sets name mapper.
- setNameMapper(BinaryNameMapper) - Method in class org.apache.ignite.configuration.BinaryConfiguration
-
Sets name mapper.
- setNameMapper(String) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryTypeConfiguration
-
- setNearConfiguration(NearCacheConfiguration<K, V>) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
- setNearEvictionPolicy(EvictionPolicy<K, V>) - Method in class org.apache.ignite.configuration.NearCacheConfiguration
-
Sets near eviction policy.
- setNearStartSize(int) - Method in class org.apache.ignite.configuration.NearCacheConfiguration
-
Start size for near cache.
- setNetworkSendRetryCount(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets message send retries count.
- setNetworkSendRetryDelay(long) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets interval in milliseconds between message send retries.
- setNetworkTimeout(long) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Maximum timeout in milliseconds for network requests.
- setNetworkTimeout(long) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Sets maximum network timeout to use for network operations.
- setNmClient(NMClient) - Method in class org.apache.ignite.yarn.ApplicationMaster
-
Sets NMClient.
- setNodeAttributes(Map<String, Object>, IgniteProductVersion) - Method in interface org.apache.ignite.spi.discovery.DiscoverySpi
-
Sets node attributes and node version which will be distributed in grid during
join process.
- setNodeAttributes(Map<String, Object>, IgniteProductVersion) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Sets node attributes and node version which will be distributed in grid during
join process.
- setNodeFilter(IgnitePredicate<ClusterNode>) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Sets filter which determines on what nodes the cache should be started.
- setNodeFilter(IgnitePredicate<ClusterNode>) - Method in class org.apache.ignite.configuration.CollectionConfiguration
-
- setNodeFilter(IgnitePredicate<ClusterNode>) - Method in class org.apache.ignite.services.ServiceConfiguration
-
Sets node filter used to filter nodes on which the service will be deployed.
- setNodeId(UUID) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
- setNodeId(UUID) - Method in class org.apache.ignite.logger.java.JavaLogger
-
Sets node ID.
- setNodeId(UUID) - Method in class org.apache.ignite.logger.log4j.Log4JLogger
-
Sets node ID.
- setNodeId(UUID) - Method in class org.apache.ignite.logger.log4j2.Log4J2Logger
-
Sets node ID.
- setNodeId(UUID) - Method in interface org.apache.ignite.logger.LoggerNodeIdAware
-
Sets node ID.
- setNoDelay(boolean) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
-
Sets whether TCP_NODELAY option should be set for all accepted client connections.
- setNodeWeight(int) - Method in class org.apache.ignite.spi.loadbalancing.weightedrandom.WeightedRandomLoadBalancingSpi
-
Sets weight of this node.
- setNumberOfRetries(int) - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
-
Sets number of retries in case of any database errors.
- setOffHeapMaxMemory(long) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Sets maximum amount of memory available to off-heap storage.
- setOffHeapMaxMemory(long) - Method in class org.apache.ignite.configuration.CollectionConfiguration
-
- setOwner(Path, String, String) - Method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
- setOwner(Path, String, String) - Method in class org.apache.ignite.hadoop.fs.v2.IgniteHadoopFileSystem
- setPageSize(int) - Method in class org.apache.ignite.cache.query.ContinuousQuery
-
Sets optional page size, if 0, then default is used.
- setPageSize(int) - Method in class org.apache.ignite.cache.query.Query
-
Sets optional page size, if 0, then default is used.
- setPageSize(int) - Method in class org.apache.ignite.cache.query.ScanQuery
-
Sets optional page size, if 0, then default is used.
- setPageSize(int) - Method in class org.apache.ignite.cache.query.SpiQuery
-
Sets optional page size, if 0, then default is used.
- setPageSize(int) - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
-
Sets optional page size, if 0, then default is used.
- setPageSize(int) - Method in class org.apache.ignite.cache.query.SqlQuery
-
Sets optional page size, if 0, then default is used.
- setPageSize(int) - Method in class org.apache.ignite.cache.query.TextQuery
-
Sets optional page size, if 0, then default is used.
- setParallelJobsNumber(int) - Method in class org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpi
-
Sets number of jobs that can be executed in parallel.
- setParallelJobsNumber(int) - Method in interface org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpiMBean
-
Sets number of jobs that can be executed in parallel.
- setParallelJobsNumber(int) - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
-
Sets number of jobs that can be executed in parallel.
- setParallelJobsNumber(int) - Method in interface org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpiMBean
-
Sets number of jobs that can be executed in parallel.
- setParallelLoadCacheMinimumThreshold(int) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
-
Parallel load cache minimum row count threshold.
- setParallelLoadCacheMinimumThreshold(int) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
-
Parallel load cache minimum row count threshold.
- setPartition(Integer) - Method in class org.apache.ignite.cache.query.ScanQuery
-
Sets partition number over which this query should iterate.
- setPartitions(int) - Method in class org.apache.ignite.cache.affinity.fair.FairAffinityFunction
-
Sets total number of partitions.
- setPartitions(int) - Method in class org.apache.ignite.cache.affinity.rendezvous.RendezvousAffinityFunction
-
Sets total number of partitions.
- setPassword(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
-
Sets password for database access.
- setPassword(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStoreFactory
-
Sets password for database access.
- setPassword(Object) - Method in class org.apache.ignite.plugin.security.SecurityCredentials
-
Sets password.
- setPath(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.sharedfs.TcpDiscoverySharedFsIpFinder
-
Sets path.
- setPathModes(Map<String, IgfsMode>) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Sets map of path prefixes to IGFS modes used for them.
- setPeerClassLoadingEnabled(boolean) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Enables/disables peer class loading.
- setPeerClassLoadingLocalClassPathExclude(String...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets list of packages in a system class path that should be P2P
loaded even if they exist locally.
- setPeerClassLoadingMissedResourcesCacheSize(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets size of missed resources cache.
- setPeerClassLoadingThreadPoolSize(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets thread pool size to use for peer class loading.
- setPermission(Path, FsPermission) - Method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
- setPermission(Path, FsPermission) - Method in class org.apache.ignite.hadoop.fs.v2.IgniteHadoopFileSystem
- setPerNodeBatchSize(int) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Sets number of file blocks collected on local node before sending batch to remote node.
- setPerNodeParallelBatchCount(int) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Sets number of file block batches that can be concurrently sent to remote node.
- setPersistence(MqttClientPersistence) - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
-
Sets the persistence mechanism.
- setPerTask(boolean) - Method in class org.apache.ignite.spi.loadbalancing.roundrobin.RoundRobinLoadBalancingSpi
-
Configuration parameter indicating whether a new round robin order should be
created for every task.
- setPessimisticTxLogLinger(int) - Method in class org.apache.ignite.configuration.TransactionConfiguration
-
Sets cleanup delay for pessimistic transaction recovery log for failed node, in milliseconds.
- setPessimisticTxLogSize(int) - Method in class org.apache.ignite.configuration.TransactionConfiguration
-
Sets pessimistic transactions log size.
- setPlatformConfiguration(PlatformConfiguration) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets platform configuration.
- setPluginConfigurations(CachePluginConfiguration...) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Sets cache plugin configurations.
- setPluginConfigurations(PluginConfiguration...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets plugin configurations.
- setPoolSize(int) - Method in class org.apache.ignite.marshaller.optimized.OptimizedMarshaller
-
Specifies size of cached object streams used by marshaller.
- setPort(int) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
-
Sets port for TCP binary protocol server.
- setPort(int) - Method in class org.apache.ignite.igfs.IgfsIpcEndpointConfiguration
-
Sets the port endpoint is bound to.
- setPort(int) - Method in class org.apache.ignite.stream.socket.SocketStreamer
-
Sets port number.
- setPortRange(int) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
-
Sets number of ports to try if configured one is in use.
- setPrefetchBlocks(int) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Sets the number of pre-fetched blocks if specific file's chunk is requested.
- setPriorityAttributeKey(String) - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
-
Sets task priority attribute key.
- setProcessorCoefficient(double) - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveCpuLoadProbe
-
Sets coefficient of every CPU processor.
- setProjectName(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.gce.TcpDiscoveryGoogleStorageIpFinder
-
Sets Google Cloud Platforms project name.
- setProperties(Map<String, Serializable>) - Method in class org.apache.ignite.configuration.IgniteReflectionFactory
-
Sets a map of properties.
- setProperties(Map<String, ?>) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetCacheStoreFactory
-
Set properties.
- setProperties(Map<String, ?>) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetLifecycleBean
-
Set properties.
- setProtocol(String) - Method in class org.apache.ignite.ssl.SslContextFactory
-
Sets protocol for secure transport.
- setProvider(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.cloud.TcpDiscoveryCloudIpFinder
-
Sets the cloud provider to use.
- setPublicThreadPoolSize(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets thread pool size to use within grid.
- setPwd(String) - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
-
Sets checkpoint database password.
- setQualitiesOfService(List<Integer>) - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
-
Sets the qualities of service to use for multiple topic subscriptions.
- setQualityOfService(Integer) - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
-
Sets the quality of service to use for a single topic subscription (optional).
- setQueryEntities(Collection<QueryEntity>) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Sets query entities configuration.
- setQueryFields(Map<String, Class<?>>) - Method in class org.apache.ignite.cache.CacheTypeMetadata
-
Deprecated.
Sets name-to-type map for query-enabled fields.
- setReadFromBackup(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Sets read from backup flag.
- setReadStripesNumber(int) - Method in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
-
Sets read stripe size.
- setRebalanceBatchesPrefetchCount(long) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
To gain better rebalancing performance supplier node can provide more than one batch at rebalancing start and
provide one new to each next demand request.
- setRebalanceBatchSize(int) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Sets rebalance batch size.
- setRebalanceDelay(long) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
- setRebalanceMode(CacheRebalanceMode) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Sets cache rebalance mode.
- setRebalanceOrder(int) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Sets cache rebalance order.
- setRebalanceThreadPoolSize(int) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Deprecated.
- setRebalanceThreadPoolSize(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets Max count of threads can be used at rebalancing.
- setRebalanceThrottle(long) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Time in milliseconds to wait between rebalance messages to avoid overloading of CPU or network.
- setRebalanceTimeout(long) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Sets rebalance timeout (ms).
- setReceiveBufferSize(int) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
-
Sets REST TCP server receive buffer size.
- setReconnectCount(int) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Sets maximum number of reconnect attempts used when establishing connection
with remote nodes.
- setReconnectCount(int) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Number of times node tries to (re)establish connection to another node.
- setRegions(Collection<String>) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.cloud.TcpDiscoveryCloudIpFinder
-
Sets list of regions where VMs are located.
- setRelaxedConsistency(boolean) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Set relaxed consistency flag.
- setReloginInterval(long) - Method in class org.apache.ignite.hadoop.fs.KerberosHadoopFileSystemFactory
-
Sets the relogin interval in milliseconds.
- setRemoteFilter(CacheEntryEventSerializableFilter<K, V>) - Method in class org.apache.ignite.cache.query.ContinuousQuery
-
- setRemoteFilterFactory(Factory<? extends CacheEntryEventFilter<K, V>>) - Method in class org.apache.ignite.cache.query.ContinuousQuery
-
Sets optional key-value filter factory.
- setReplication(Path, short) - Method in class org.apache.ignite.hadoop.fs.v2.IgniteHadoopFileSystem
- setRequireSerializable(boolean) - Method in class org.apache.ignite.marshaller.optimized.OptimizedMarshaller
-
Sets whether marshaller should require
Serializable interface or not.
- setResponseProcessor(Processor) - Method in class org.apache.ignite.stream.camel.CamelStreamer
-
Sets the Processor used to generate the response.
- setResponseWaitTime(int) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
-
Sets time in milliseconds IP finder waits for reply to
multicast address request.
- setRetryPolicy(RetryPolicy) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.zk.TcpDiscoveryZookeeperIpFinder
-
- setRetryStopStrategy(StopStrategy) - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
-
Sets the strategy to determine when to stop retrying to (re-)connect.
- setRetryTimeout(long) - Method in class org.apache.ignite.stream.kafka.KafkaStreamer
-
Sets the retry timeout.
- setRetryWaitStrategy(WaitStrategy) - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
-
Sets the strategy to determine how long to wait between retry attempts.
- setRmClient(AMRMClientAsync<AMRMClient.ContainerRequest>) - Method in class org.apache.ignite.yarn.ApplicationMaster
-
Sets RMClient
- setRollbackOnly() - Method in interface org.apache.ignite.transactions.Transaction
-
Modify the transaction associated with the current thread such that the
only possible outcome of the transaction is to roll back the
transaction.
- setScanners(UriDeploymentScanner...) - Method in class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
-
Sets scanners.
- setSchedulerTimeout(long) - Method in class org.apache.ignite.yarn.ApplicationMaster
-
Sets scheduler timeout.
- setSecondaryFileSystem(IgfsSecondaryFileSystem) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Sets the secondary file system.
- setSecretKey(String) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
-
Sets secret key to authenticate REST requests.
- setSegmentationPolicy(SegmentationPolicy) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets segmentation policy.
- setSegmentationResolveAttempts(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets segmentation resolve attempts count.
- setSegmentationResolvers(SegmentationResolver...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets segmentation resolvers.
- setSegmentCheckFrequency(long) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets network segment check frequency.
- setSelectorCount(int) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
-
Sets number of selector threads for REST TCP server.
- setSelectorsCount(int) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Sets the count of selectors te be used in TCP server.
- setSendBufferSize(int) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
-
Sets REST TCP server send buffer size.
- setSendQueueLimit(int) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
-
Sets REST TCP server send queue limit.
- setSequentialReadsBeforePrefetch(int) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Sets amount of sequential block reads before prefetch is triggered.
- setSerializer(BinarySerializer) - Method in class org.apache.ignite.binary.BinaryTypeConfiguration
-
Sets serializer.
- setSerializer(BinarySerializer) - Method in class org.apache.ignite.configuration.BinaryConfiguration
-
Sets serializer.
- setSerializer(String) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryTypeConfiguration
-
- setService(Service) - Method in class org.apache.ignite.services.ServiceConfiguration
-
Sets service instance.
- setServiceAccountId(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.gce.TcpDiscoveryGoogleStorageIpFinder
-
Sets the service account ID (typically an e-mail address).
- setServiceAccountP12FilePath(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.gce.TcpDiscoveryGoogleStorageIpFinder
-
Sets a full path to the private key in PKCS12 format of the Service Account.
- setServiceConfiguration(ServiceConfiguration...) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets configurations for services to be deployed on the grid.
- setServiceName(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.zk.TcpDiscoveryZookeeperIpFinder
-
- setSessionFactory(SessionFactory) - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStore
-
Sets session factory.
- setSessionFactory(SessionFactory) - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStoreFactory
-
Sets session factory.
- setSessionFactory(SessionFactory) - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateStoreSessionListener
-
Sets Hibernate session factory.
- setSessionFactoryBean(String) - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStoreFactory
-
Sets name of the data source bean.
- setShared(boolean) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinderAdapter
-
Sets shared flag.
- setSharedMemoryPort(int) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Sets local port to accept shared memory connections.
- setSimpleName(boolean) - Method in class org.apache.ignite.binary.BinaryBasicNameMapper
-
Sets whether to use simple name of class or not.
- setSingleton(boolean) - Method in class org.apache.ignite.configuration.IgniteReflectionFactory
-
- setSingleTupleExtractor(StreamSingleTupleExtractor<T, K, V>) - Method in class org.apache.ignite.stream.StreamAdapter
-
- setSlowClientQueueLimit(int) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Sets slow client queue limit.
- setSnapshotableIndex(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Sets flag indicating whether SQL indexes should support snapshots.
- setSocketReceiveBuffer(int) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Sets receive buffer size for sockets created or accepted by this SPI.
- setSocketSendBuffer(int) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Sets send buffer size for sockets created or accepted by this SPI.
- setSocketTimeout(long) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Sets socket operations timeout.
- setSocketWriteTimeout(long) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Sets socket write timeout for TCP connection.
- setSql(String) - Method in class org.apache.ignite.cache.query.SqlFieldsQuery
-
Sets SQL clause.
- setSql(String) - Method in class org.apache.ignite.cache.query.SqlQuery
-
Sets SQL clause.
- setSqlEscapeAll(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
If true all the SQL table and field names will be escaped with double quotes like
({@code "tableName"."
- setSqlFunctionClasses(Class<?>...) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Sets classes with methods annotated by
QuerySqlFunction
to be used as user-defined functions from SQL queries.
- setSqlOnheapRowCacheSize(int) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Number of SQL rows which will be cached onheap to avoid deserialization on each SQL index access.
- setSqlSchema(String) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Sets sql schema to be used for current cache.
- setSslClientAuth(boolean) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
-
Sets flag indicating whether or not SSL client authentication is required.
- setSslContextFactory(GridSslContextFactory) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
-
- setSslContextFactory(Factory<SSLContext>) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets SSL context factory that will be used for creating a secure socket layer.
- setSslEnabled(boolean) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
-
Sets whether Secure Socket Layer should be enabled for REST TCP binary protocol.
- setSslFactory(Factory<SSLContext>) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
-
Sets instance of Factory that will be used to create an instance of SSLContext
for Secure Socket Layer on TCP binary protocol.
- setStartSize(int) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Initial size for internal hash map.
- setStarvationIncrement(int) - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
-
Sets value to increment job priority by every time a lower priority job gets
behind a higher priority job.
- setStarvationIncrement(int) - Method in interface org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpiMBean
-
Sets value to increment job priority by every time a lower priority job gets
behind a higher priority job.
- setStarvationPreventionEnabled(boolean) - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
-
Sets flag indicating whether job starvation prevention is enabled.
- setStarvationPreventionEnabled(boolean) - Method in interface org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpiMBean
-
Sets flag indicating whether job starvation prevention is enabled.
- setStatisticsPrintFrequency(long) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Sets statistics print frequency.
- setStealingAttributes(Map<String, ? extends Serializable>) - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
-
- setStealingEnabled(boolean) - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
-
Gets flag indicating whether this node should attempt to steal jobs
from other nodes.
- setStealingEnabled(boolean) - Method in interface org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpiMBean
-
Gets flag indicating whether this node should attempt to steal jobs
from other nodes.
- setStoreConcurrentLoadAllThreshold(int) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Sets the concurrent load-all threshold used for cases when keys' values are being loaded from
CacheStore
in parallel.
- setStoreKeepBinary(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Sets keep binary in store flag.
- setStreamBufferSize(int) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Sets read/write buffers size for IGFS stream operations (bytes).
- setStreamer(IgniteDataStreamer<K, V>) - Method in class org.apache.ignite.stream.StreamAdapter
-
- setSwapEnabled(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Flag indicating whether swap storage is enabled or not.
- setSwapSpaceSpi(SwapSpaceSpi) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
- setSystemThreadPoolSize(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets system thread pool size to use within grid.
- setTarget(Object) - Method in class org.apache.ignite.compute.gridify.aop.GridifyArgumentAdapter
-
Sets target object for method execution.
- setTcpNoDelay(boolean) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Sets value for TCP_NODELAY socket option.
- setTemporaryDirectoryPath(String) - Method in class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
-
Sets absolute path to temporary directory which will be used by
deployment SPI to keep all deployed classes in.
- setText(String) - Method in class org.apache.ignite.cache.query.TextQuery
-
Sets text search string.
- setTextFields(Collection<String>) - Method in class org.apache.ignite.cache.CacheTypeMetadata
-
Deprecated.
Sets text-indexed fields.
- setThreadCount(int) - Method in class org.apache.ignite.igfs.IgfsIpcEndpointConfiguration
-
Set number of threads used by this endpoint to process incoming requests.
- setThreadCount(int) - Method in class org.apache.ignite.startup.BasicWarmupClosure
-
Sets thread count for warmup.
- setThreadPoolSize(int) - Method in class org.apache.ignite.configuration.ConnectorConfiguration
-
Sets thread pool size to use for processing of client messages (REST requests).
- setThreadPriority(int) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Sets thread priority.
- setThreads(int) - Method in class org.apache.ignite.stream.jms11.JmsStreamer
-
Sets the number of threads to concurrently consume JMS messages.
- setThreads(int) - Method in class org.apache.ignite.stream.kafka.KafkaStreamer
-
Sets the threads.
- setThreads(int) - Method in class org.apache.ignite.stream.socket.SocketStreamer
-
Sets threadds amount.
- setThreadsCount(int) - Method in class org.apache.ignite.cache.store.CacheLoadOnlyStoreAdapter
-
Sets number of worker threads.
- setThreadsCount(int) - Method in class org.apache.ignite.stream.twitter.TwitterStreamer
-
Sets Threads count.
- setTimeInterval(long) - Method in class org.apache.ignite.cache.query.ContinuousQuery
-
Sets time interval.
- setTimes(Path, long, long) - Method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
- setTimes(Path, long, long) - Method in class org.apache.ignite.hadoop.fs.v2.IgniteHadoopFileSystem
- setTimes(IgfsPath, long, long) - Method in interface org.apache.ignite.IgniteFileSystem
-
Sets last access time and last modification time for a given path.
- setTimeServerPortBase(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets time server port base.
- setTimeServerPortRange(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets time server port range.
- setTimeToLive(int) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.multicast.TcpDiscoveryMulticastIpFinder
-
Set the default time-to-live for multicast packets sent out on this
IP finder in order to control the scope of the multicast.
- setTokenDirectoryPath(String) - Method in class org.apache.ignite.igfs.IgfsIpcEndpointConfiguration
-
Sets directory where shared memory tokens are stored.
- setTopHistorySize(int) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Sets size of topology snapshots history.
- setTopic(String) - Method in class org.apache.ignite.stream.kafka.KafkaStreamer
-
Sets the topic name.
- setTopic(String) - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
-
Sets the topic to subscribe to, if a single topic.
- setTopics(List<String>) - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
-
Sets the topics to subscribe to, if many.
- setTopologyValidator(TopologyValidator) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Sets topology validator.
- setTotalCount(int) - Method in class org.apache.ignite.services.ServiceConfiguration
-
Sets total number of deployed service instances in the cluster, 0 for unlimited.
- setTransacted(boolean) - Method in class org.apache.ignite.stream.jms11.JmsStreamer
-
Instructs the streamer whether to use local JMS transactions or not.
- setTransactionConcurrency(TransactionConcurrency) - Method in class org.apache.ignite.transactions.spring.SpringTransactionManager
-
Sets transaction concurrency level.
- setTransactionConfiguration(TransactionConfiguration) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets transactions configuration.
- setTransactionManager(PlatformTransactionManager) - Method in class org.apache.ignite.cache.store.spring.CacheSpringStoreSessionListener
-
Sets transaction manager.
- setTransactionManagerLookupClassName(String) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
- setTransformer(MessageTransformer<T, K, V>) - Method in class org.apache.ignite.stream.jms11.JmsStreamer
-
Compulsory.
- setTrashPurgeTimeout(long) - Method in class org.apache.ignite.configuration.FileSystemConfiguration
-
Sets maximum timeout awaiting for trash purging in case data cache oversize is detected.
- setTrustManagers(TrustManager...) - Method in class org.apache.ignite.ssl.SslContextFactory
-
Sets pre-configured trust managers.
- setTrustStoreFilePath(String) - Method in class org.apache.ignite.ssl.SslContextFactory
-
Sets path to the trust store file.
- setTrustStorePassword(char[]) - Method in class org.apache.ignite.ssl.SslContextFactory
-
Sets trust store password.
- setTrustStoreType(String) - Method in class org.apache.ignite.ssl.SslContextFactory
-
Sets trust store type used in context initialization.
- setTupleExtractor(StreamTupleExtractor<T, K, V>) - Method in class org.apache.ignite.stream.StreamAdapter
-
Deprecated.
- setTxManagerFactory(Factory<T>) - Method in class org.apache.ignite.configuration.TransactionConfiguration
-
Sets transaction manager factory for available javax.transaction.TransactionManager implementation,
if any.
- setTxManagerLookupClassName(String) - Method in class org.apache.ignite.configuration.TransactionConfiguration
-
- setTxSerializableEnabled(boolean) - Method in class org.apache.ignite.configuration.TransactionConfiguration
-
- setType(String) - Method in class org.apache.ignite.cache.query.SqlQuery
-
Sets type for query.
- setType(Class<?>) - Method in class org.apache.ignite.cache.query.SqlQuery
-
- setType(Class<?>) - Method in class org.apache.ignite.cache.query.TextQuery
-
Sets type for query.
- setType(String) - Method in class org.apache.ignite.cache.query.TextQuery
-
Sets type for query.
- setType(IgfsIpcEndpointType) - Method in class org.apache.ignite.igfs.IgfsIpcEndpointConfiguration
-
Sets endpoint type.
- setTypeConfigurations(Collection<BinaryTypeConfiguration>) - Method in class org.apache.ignite.configuration.BinaryConfiguration
-
Sets type configurations.
- setTypeMetadata(Collection<CacheTypeMetadata>) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
- setTypeName(String) - Method in class org.apache.ignite.binary.BinaryTypeConfiguration
-
Sets type name.
- setTypeName(String) - Method in class org.apache.ignite.cache.CacheKeyConfiguration
-
- setTypeName(String) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryTypeConfiguration
-
- setTypeName(String) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetCacheStoreFactory
-
Sets .NET type name.
- setTypeName(String) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetLifecycleBean
-
Set type name.
- setTypes(JdbcType...) - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
-
Sets store configurations.
- setTypes(JdbcType...) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcPojoStoreFactory
-
Sets store configurations.
- setTypes(Collection<String>) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryConfiguration
-
- setTypesConfiguration(Collection<PlatformDotNetBinaryTypeConfiguration>) - Method in class org.apache.ignite.platform.dotnet.PlatformDotNetBinaryConfiguration
-
- setUnacknowledgedMessagesBufferSize(int) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Sets maximum number of stored unacknowledged messages per connection to node.
- setUpdateQuery(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
-
Sets update entry query.
- setUpdateQuery(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStoreFactory
-
Sets update entry query.
- setupFile(Path, FileSystem, LocalResourceType) - Static method in class org.apache.ignite.yarn.utils.IgniteYarnUtils
-
- setUri(String) - Method in class org.apache.ignite.hadoop.fs.BasicHadoopFileSystemFactory
-
Sets file system URI.
- setUriList(List<String>) - Method in class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
-
Sets list of URI which point to GAR file and which should be
scanned by SPI for the new tasks.
- setUseAverage(boolean) - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveCpuLoadProbe
-
Sets flag indicating whether to use average CPU load vs. current.
- setUseAverage(boolean) - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveJobCountLoadProbe
-
Sets flag indicating whether to use average job counts vs. current.
- setUseAverage(boolean) - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveProcessingTimeLoadProbe
-
Sets flag indicating whether to use average execution time vs. current.
- setUseJtaSynchronization(boolean) - Method in class org.apache.ignite.configuration.TransactionConfiguration
-
Sets the flag that defines whether to use lightweight JTA synchronization callback to enlist
into JTA transaction instead of creating a separate XA resource.
- setUseProcessors(boolean) - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveCpuLoadProbe
-
Sets flag indicating whether to use average CPU load vs. current
(default is true).
- setUser(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStore
-
Sets user name for database access.
- setUser(String) - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcBlobStoreFactory
-
Sets user name for database access.
- setUser(String) - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
-
Sets checkpoint database user name.
- setUserAttributes(Map<String, ?>) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets user attributes for this node.
- setUserObject(Object) - Method in class org.apache.ignite.plugin.security.SecurityCredentials
-
Sets user-specific object.
- setUseWeights(boolean) - Method in class org.apache.ignite.spi.loadbalancing.weightedrandom.WeightedRandomLoadBalancingSpi
-
Sets a flag to indicate whether node weights should be checked when
doing random load balancing.
- setUtilityCacheKeepAliveTime(long) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets keep alive time of thread pool size that will be used to process utility cache messages.
- setUtilityCachePoolSize(int) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets default thread pool size that will be used to process utility cache messages.
- setValue(byte[]) - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateBlobStoreEntry
-
- setValue(V2) - Method in class org.apache.ignite.lang.IgniteBiTuple
- setValueDecoder(Decoder<V>) - Method in class org.apache.ignite.stream.kafka.KafkaStreamer
-
Sets the value decoder.
- setValueFieldName(String) - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
-
Sets checkpoint value field name.
- setValueFields(Collection<CacheTypeFieldMetadata>) - Method in class org.apache.ignite.cache.CacheTypeMetadata
-
Deprecated.
- setValueFields(JdbcTypeField...) - Method in class org.apache.ignite.cache.store.jdbc.JdbcType
-
- setValueFieldType(String) - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
-
Sets checkpoint value field type.
- setValueType(String) - Method in class org.apache.ignite.cache.CacheTypeMetadata
-
Deprecated.
Sets value type.
- setValueType(Class<?>) - Method in class org.apache.ignite.cache.CacheTypeMetadata
-
Deprecated.
Sets value type.
- setValueType(String) - Method in class org.apache.ignite.cache.QueryEntity
-
Sets value type for this query pair.
- setValueType(String) - Method in class org.apache.ignite.cache.store.jdbc.JdbcType
-
Sets value type.
- setValueType(Class<?>) - Method in class org.apache.ignite.cache.store.jdbc.JdbcType
-
Sets value type.
- setVerifyChecksum(boolean) - Method in class org.apache.ignite.hadoop.fs.v2.IgniteHadoopFileSystem
- setWaitForSegmentOnStart(boolean) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets wait for segment on start flag.
- setWaitingJobsNumber(int) - Method in class org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpi
-
Sets maximum number of jobs that are allowed to wait in waiting queue.
- setWaitingJobsNumber(int) - Method in interface org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpiMBean
-
Sets maximum number of jobs that are allowed to wait in waiting queue.
- setWaitingJobsNumber(int) - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
-
Maximum number of jobs that are allowed to wait in waiting queue.
- setWaitingJobsNumber(int) - Method in interface org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpiMBean
-
Maximum number of jobs that are allowed to wait in waiting queue.
- setWaitJobsThreshold(int) - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
-
Sets job count threshold at which this node will
start stealing jobs from other nodes.
- setWaitJobsThreshold(int) - Method in interface org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpiMBean
-
Sets job count threshold at which this node will
start stealing jobs from other nodes.
- setWarmupClosure(IgniteInClosure<IgniteConfiguration>) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets warmup closure to execute before grid startup.
- setWarmupMethods(String...) - Method in class org.apache.ignite.startup.BasicWarmupClosure
-
Sets warmup methods to use for cache warmup.
- setWorkDirectory(String) - Method in class org.apache.ignite.configuration.IgniteConfiguration
-
Sets Ignite work folder.
- setWorkingDirectory(Path) - Method in class org.apache.ignite.hadoop.fs.v1.IgniteHadoopFileSystem
- setWriteBehindBatchSize(int) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Sets maximum batch size for write-behind cache.
- setWriteBehindEnabled(boolean) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Sets flag indicating whether write-behind is enabled.
- setWriteBehindFlushFrequency(long) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Sets write-behind flush frequency.
- setWriteBehindFlushSize(int) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Sets write-behind flush size.
- setWriteBehindFlushThreadCount(int) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Sets flush thread count for write-behind cache.
- setWriteBufferSize(int) - Method in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
-
Sets write buffer size in bytes.
- setWriteSynchronizationMode(CacheWriteSynchronizationMode) - Method in class org.apache.ignite.configuration.CacheConfiguration
-
Sets write synchronization mode.
- setZkConnectionString(String) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.zk.TcpDiscoveryZookeeperIpFinder
-
- setZones(Collection<String>) - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.cloud.TcpDiscoveryCloudIpFinder
-
Sets list of zones where VMs are located.
- SharedFsCheckpointSpi - Class in org.apache.ignite.spi.checkpoint.sharedfs
-
This class defines shared file system
CheckpointSpi implementation for
checkpoint SPI.
- SharedFsCheckpointSpi() - Constructor for class org.apache.ignite.spi.checkpoint.sharedfs.SharedFsCheckpointSpi
-
Initializes default directory paths.
- SharedFsCheckpointSpiMBean - Interface in org.apache.ignite.spi.checkpoint.sharedfs
-
Management bean that provides general administrative and configuration information
about shared file system checkpoints.
- shortDisplay() - Method in class org.apache.ignite.events.CacheEvent
-
Gets a shortened version of toString() result.
- shortDisplay() - Method in class org.apache.ignite.events.CacheRebalancingEvent
-
Gets a shortened version of toString() result.
- shortDisplay() - Method in class org.apache.ignite.events.CheckpointEvent
-
Gets a shortened version of toString() result.
- shortDisplay() - Method in class org.apache.ignite.events.DeploymentEvent
-
Gets a shortened version of toString() result.
- shortDisplay() - Method in class org.apache.ignite.events.DiscoveryEvent
-
Gets a shortened version of toString() result.
- shortDisplay() - Method in interface org.apache.ignite.events.Event
-
Gets a shortened version of toString() result.
- shortDisplay() - Method in class org.apache.ignite.events.EventAdapter
-
Gets a shortened version of toString() result.
- shortDisplay() - Method in class org.apache.ignite.events.JobEvent
-
Gets a shortened version of toString() result.
- shortDisplay() - Method in class org.apache.ignite.events.SwapSpaceEvent
-
Gets a shortened version of toString() result.
- shortDisplay() - Method in class org.apache.ignite.events.TaskEvent
-
Gets a shortened version of toString() result.
- shortString() - Method in class org.apache.ignite.lang.IgniteUuid
-
Gets a short string version of this ID.
- shutdown() - Method in class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
- shutdownNow() - Method in class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
- simulateNodeFailure() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
Stops service threads to simulate node failure.
- simulateNodeFailure() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
FOR TEST ONLY!!!
- size() - Method in interface org.apache.ignite.cache.eviction.EvictableEntry
-
Returns entry size in bytes.
- size(CachePeekMode...) - Method in interface org.apache.ignite.IgniteCache
-
Gets the number of all entries cached across all nodes.
- size(IgfsPath) - Method in interface org.apache.ignite.IgniteFileSystem
-
Determines size of the file denoted by provided path.
- size() - Method in interface org.apache.ignite.IgniteQueue
- size() - Method in interface org.apache.ignite.IgniteSet
- size() - Method in class org.apache.ignite.lang.IgniteBiTuple
- size(String) - Method in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
-
Gets size in bytes for data space with given name.
- size(String) - Method in class org.apache.ignite.spi.swapspace.noop.NoopSwapSpaceSpi
-
Gets size in bytes for data space with given name.
- size(String) - Method in interface org.apache.ignite.spi.swapspace.SwapSpaceSpi
-
Gets size in bytes for data space with given name.
- sizeLong(CachePeekMode...) - Method in interface org.apache.ignite.IgniteCache
-
Gets the number of all entries cached across all nodes as a long value.
- skip() - Method in class org.apache.ignite.messaging.MessagingListenActor
-
Skips current message and continues to listen for new message.
- skipNonExistentFiles() - Method in interface org.apache.ignite.igfs.mapreduce.IgfsTaskArgs
-
Flag indicating whether to fail or simply skip non-existent files.
- skipStore() - Method in interface org.apache.ignite.IgniteDataStreamer
-
Gets flag indicating that write-through behavior should be disabled for data streaming.
- skipStore(boolean) - Method in interface org.apache.ignite.IgniteDataStreamer
-
Sets flag indicating that write-through behavior should be disabled for data streaming.
- SLASH - Static variable in class org.apache.ignite.igfs.IgfsPath
-
The directory separator.
- slaveLost(SchedulerDriver, Protos.SlaveID) - Method in class org.apache.ignite.mesos.IgniteScheduler
- Slf4jLogger - Class in org.apache.ignite.logger.slf4j
-
SLF4J-based implementation for logging.
- Slf4jLogger() - Constructor for class org.apache.ignite.logger.slf4j.Slf4jLogger
-
Creates new logger.
- Slf4jLogger(Logger) - Constructor for class org.apache.ignite.logger.slf4j.Slf4jLogger
-
Creates new logger with given implementation.
- snapshot() - Static method in class org.apache.ignite.IgniteSystemProperties
-
Gets snapshot of system properties.
- sndMsgLsnrs - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
- SocketMessageConverter<T> - Interface in org.apache.ignite.stream.socket
-
Socket message converter.
- SocketStreamer<T,K,V> - Class in org.apache.ignite.stream.socket
-
- SocketStreamer() - Constructor for class org.apache.ignite.stream.socket.SocketStreamer
-
- SortedEvictionPolicy<K,V> - Class in org.apache.ignite.cache.eviction.sorted
-
Cache eviction policy which will select the minimum cache entry for eviction.
- SortedEvictionPolicy() - Constructor for class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicy
-
Constructs sorted eviction policy with all defaults.
- SortedEvictionPolicy(int) - Constructor for class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicy
-
Constructs sorted eviction policy with maximum size.
- SortedEvictionPolicy(int, Comparator<EvictableEntry<K, V>>) - Constructor for class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicy
-
Constructs sorted eviction policy with given maximum size and given entry comparator.
- SortedEvictionPolicy(int, int, Comparator<EvictableEntry<K, V>>) - Constructor for class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicy
-
Constructs sorted eviction policy with given maximum size, eviction batch size and entries comparator.
- SortedEvictionPolicy(Comparator<EvictableEntry<K, V>>) - Constructor for class org.apache.ignite.cache.eviction.sorted.SortedEvictionPolicy
-
Constructs sorted eviction policy with given maximum size and given entry comparator.
- SortedEvictionPolicyMBean - Interface in org.apache.ignite.cache.eviction.sorted
-
MBean for sorted eviction policy.
- space() - Method in class org.apache.ignite.events.SwapSpaceEvent
-
Gets swap space name.
- SPACE - Static variable in class org.apache.ignite.yarn.utils.IgniteYarnUtils
-
- spiContext() - Method in class org.apache.ignite.spi.discovery.tcp.ipfinder.TcpDiscoveryIpFinderAdapter
-
- SpiQuery<K,V> - Class in org.apache.ignite.cache.query
-
- SpiQuery() - Constructor for class org.apache.ignite.cache.query.SpiQuery
-
- spiStart(String) - Method in class org.apache.ignite.spi.checkpoint.cache.CacheCheckpointSpi
-
This method is called to start SPI.
- spiStart(String) - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
-
This method is called to start SPI.
- spiStart(String) - Method in class org.apache.ignite.spi.checkpoint.noop.NoopCheckpointSpi
-
This method is called to start SPI.
- spiStart(String) - Method in class org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpi
-
This method is called to start SPI.
- spiStart(String) - Method in class org.apache.ignite.spi.checkpoint.sharedfs.SharedFsCheckpointSpi
-
This method is called to start SPI.
- spiStart(String) - Method in class org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpi
-
This method is called to start SPI.
- spiStart(String) - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
-
This method is called to start SPI.
- spiStart(String) - Method in class org.apache.ignite.spi.collision.noop.NoopCollisionSpi
-
This method is called to start SPI.
- spiStart(String) - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
-
This method is called to start SPI.
- spiStart(String) - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
This method is called to start SPI.
- spiStart(String) - Method in class org.apache.ignite.spi.deployment.local.LocalDeploymentSpi
-
This method is called to start SPI.
- spiStart(String) - Method in class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
-
This method is called to start SPI.
- spiStart(String) - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
This method is called to start SPI.
- spiStart(String) - Method in class org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpi
-
This method is called to start SPI.
- spiStart(String) - Method in class org.apache.ignite.spi.failover.always.AlwaysFailoverSpi
-
This method is called to start SPI.
- spiStart(String) - Method in class org.apache.ignite.spi.failover.jobstealing.JobStealingFailoverSpi
-
This method is called to start SPI.
- spiStart(String) - Method in class org.apache.ignite.spi.failover.never.NeverFailoverSpi
-
This method is called to start SPI.
- spiStart(String) - Method in interface org.apache.ignite.spi.IgniteSpi
-
This method is called to start SPI.
- spiStart(String) - Method in class org.apache.ignite.spi.indexing.noop.NoopIndexingSpi
-
This method is called to start SPI.
- spiStart(String) - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveLoadBalancingSpi
-
This method is called to start SPI.
- spiStart(String) - Method in class org.apache.ignite.spi.loadbalancing.roundrobin.RoundRobinLoadBalancingSpi
-
This method is called to start SPI.
- spiStart(String) - Method in class org.apache.ignite.spi.loadbalancing.weightedrandom.WeightedRandomLoadBalancingSpi
-
This method is called to start SPI.
- spiStart(String) - Method in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
-
This method is called to start SPI.
- spiStart(String) - Method in class org.apache.ignite.spi.swapspace.noop.NoopSwapSpaceSpi
-
This method is called to start SPI.
- spiStop() - Method in class org.apache.ignite.spi.checkpoint.cache.CacheCheckpointSpi
-
This method is called to stop SPI.
- spiStop() - Method in class org.apache.ignite.spi.checkpoint.jdbc.JdbcCheckpointSpi
-
This method is called to stop SPI.
- spiStop() - Method in class org.apache.ignite.spi.checkpoint.noop.NoopCheckpointSpi
-
This method is called to stop SPI.
- spiStop() - Method in class org.apache.ignite.spi.checkpoint.s3.S3CheckpointSpi
-
This method is called to stop SPI.
- spiStop() - Method in class org.apache.ignite.spi.checkpoint.sharedfs.SharedFsCheckpointSpi
-
This method is called to stop SPI.
- spiStop() - Method in class org.apache.ignite.spi.collision.fifoqueue.FifoQueueCollisionSpi
-
This method is called to stop SPI.
- spiStop() - Method in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
-
This method is called to stop SPI.
- spiStop() - Method in class org.apache.ignite.spi.collision.noop.NoopCollisionSpi
-
This method is called to stop SPI.
- spiStop() - Method in class org.apache.ignite.spi.collision.priorityqueue.PriorityQueueCollisionSpi
-
This method is called to stop SPI.
- spiStop() - Method in class org.apache.ignite.spi.communication.tcp.TcpCommunicationSpi
-
This method is called to stop SPI.
- spiStop() - Method in class org.apache.ignite.spi.deployment.local.LocalDeploymentSpi
-
This method is called to stop SPI.
- spiStop() - Method in class org.apache.ignite.spi.deployment.uri.UriDeploymentSpi
-
This method is called to stop SPI.
- spiStop() - Method in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
This method is called to stop SPI.
- spiStop() - Method in class org.apache.ignite.spi.eventstorage.memory.MemoryEventStorageSpi
-
This method is called to stop SPI.
- spiStop() - Method in class org.apache.ignite.spi.failover.always.AlwaysFailoverSpi
-
This method is called to stop SPI.
- spiStop() - Method in class org.apache.ignite.spi.failover.jobstealing.JobStealingFailoverSpi
-
This method is called to stop SPI.
- spiStop() - Method in class org.apache.ignite.spi.failover.never.NeverFailoverSpi
-
This method is called to stop SPI.
- spiStop() - Method in interface org.apache.ignite.spi.IgniteSpi
-
This method is called to stop SPI.
- spiStop() - Method in class org.apache.ignite.spi.indexing.noop.NoopIndexingSpi
-
This method is called to stop SPI.
- spiStop() - Method in class org.apache.ignite.spi.loadbalancing.adaptive.AdaptiveLoadBalancingSpi
-
This method is called to stop SPI.
- spiStop() - Method in class org.apache.ignite.spi.loadbalancing.roundrobin.RoundRobinLoadBalancingSpi
-
This method is called to stop SPI.
- spiStop() - Method in class org.apache.ignite.spi.loadbalancing.weightedrandom.WeightedRandomLoadBalancingSpi
-
This method is called to stop SPI.
- spiStop() - Method in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
-
This method is called to stop SPI.
- spiStop() - Method in class org.apache.ignite.spi.swapspace.noop.NoopSwapSpaceSpi
-
This method is called to stop SPI.
- split(int, T) - Method in class org.apache.ignite.compute.ComputeTaskSplitAdapter
-
- SpringApplicationContextResource - Annotation Type in org.apache.ignite.resources
-
Annotates a field or a setter method for injection of Spring ApplicationContext resource.
- SpringCacheManager - Class in org.apache.ignite.cache.spring
-
Implementation of Spring cache abstraction based on Ignite cache.
- SpringCacheManager() - Constructor for class org.apache.ignite.cache.spring.SpringCacheManager
-
- SpringResource - Annotation Type in org.apache.ignite.resources
-
Annotates a field or a setter method for injection of resource
from Spring ApplicationContext.
- SpringTransactionManager - Class in org.apache.ignite.transactions.spring
-
Implementation of Spring transaction abstraction based on Ignite transaction.
- SpringTransactionManager() - Constructor for class org.apache.ignite.transactions.spring.SpringTransactionManager
-
Constructs the transaction manager with no target Ignite instance.
- SqlFieldsQuery - Class in org.apache.ignite.cache.query
-
SQL Fields query.
- SqlFieldsQuery(String) - Constructor for class org.apache.ignite.cache.query.SqlFieldsQuery
-
Constructs SQL fields query.
- SqlFieldsQuery(String, boolean) - Constructor for class org.apache.ignite.cache.query.SqlFieldsQuery
-
Constructs SQL fields query.
- SqlQuery<K,V> - Class in org.apache.ignite.cache.query
-
SQL Query.
- SqlQuery(String, String) - Constructor for class org.apache.ignite.cache.query.SqlQuery
-
Constructs query for the given type name and SQL query.
- SqlQuery(Class<?>, String) - Constructor for class org.apache.ignite.cache.query.SqlQuery
-
Constructs query for the given type and SQL query.
- SQLServerDialect - Class in org.apache.ignite.cache.store.jdbc.dialect
-
A dialect compatible with the Microsoft SQL Server database.
- SQLServerDialect() - Constructor for class org.apache.ignite.cache.store.jdbc.dialect.SQLServerDialect
-
- SslContextFactory - Class in org.apache.ignite.ssl
-
This SSL context factory that provides ssl context configuration with specified key
and trust stores.
- SslContextFactory() - Constructor for class org.apache.ignite.ssl.SslContextFactory
-
- sslSockFactory - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
SSL socket factory.
- sslSrvSockFactory - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
SSL server socket factory.
- stage() - Method in class org.apache.ignite.lang.IgniteProductVersion
-
- stamp() - Method in interface org.apache.ignite.IgniteAtomicStamped
-
Gets current stamp.
- start(Settings, Properties) - Method in class org.apache.ignite.cache.hibernate.HibernateRegionFactory
- start() - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateStoreSessionListener
-
Starts grid component, called on grid start.
- start() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
-
Starts grid component, called on grid start.
- start() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcStoreSessionListener
-
Starts grid component, called on grid start.
- start() - Method in class org.apache.ignite.cache.store.spring.CacheSpringStoreSessionListener
-
Starts grid component, called on grid start.
- start() - Method in class org.apache.ignite.hadoop.fs.BasicHadoopFileSystemFactory
-
Starts grid component, called on grid start.
- start() - Method in class org.apache.ignite.hadoop.fs.CachingHadoopFileSystemFactory
-
Starts grid component, called on grid start.
- start() - Method in class org.apache.ignite.hadoop.fs.IgniteHadoopIgfsSecondaryFileSystem
-
Starts grid component, called on grid start.
- start() - Method in class org.apache.ignite.hadoop.fs.KerberosHadoopFileSystemFactory
-
Starts grid component, called on grid start.
- start() - Method in interface org.apache.ignite.igfs.IgfsBlockLocation
-
Start position in the file this block relates to.
- start() - Method in class org.apache.ignite.igfs.mapreduce.IgfsFileRange
-
Gets range start position.
- start(ApplicationContext) - Static method in class org.apache.ignite.IgniteSpring
-
Starts grid with default configuration.
- start(IgniteConfiguration, ApplicationContext) - Static method in class org.apache.ignite.IgniteSpring
-
Starts grid with given configuration.
- start(String, ApplicationContext) - Static method in class org.apache.ignite.IgniteSpring
-
Starts all grids specified within given Spring XML configuration file.
- start(URL, ApplicationContext) - Static method in class org.apache.ignite.IgniteSpring
-
Starts all grids specified within given Spring XML configuration file URL.
- start() - Static method in class org.apache.ignite.Ignition
-
Starts grid with default configuration.
- start(IgniteConfiguration) - Static method in class org.apache.ignite.Ignition
-
Starts grid with given configuration.
- start(String) - Static method in class org.apache.ignite.Ignition
-
Starts all grids specified within given Spring XML configuration file.
- start(URL) - Static method in class org.apache.ignite.Ignition
-
Starts all grids specified within given Spring XML configuration file URL.
- start(InputStream) - Static method in class org.apache.ignite.Ignition
-
Starts all grids specified within given Spring XML configuration input stream.
- start() - Method in interface org.apache.ignite.lifecycle.LifecycleAware
-
Starts grid component, called on grid start.
- start(InetSocketAddress, Handler) - Method in class org.apache.ignite.mesos.resource.JettyServer
-
Starts jetty server.
- start(BundleContext) - Method in class org.apache.ignite.osgi.IgniteAbstractOsgiContextActivator
-
Method invoked by OSGi to start the bundle.
- start() - Method in interface org.apache.ignite.plugin.CachePluginProvider
-
Starts grid component.
- start(PluginContext) - Method in interface org.apache.ignite.plugin.PluginProvider
-
Starts grid component.
- start() - Method in class org.apache.ignite.stream.camel.CamelStreamer
-
Starts the streamer.
- start() - Method in class org.apache.ignite.stream.flume.IgniteSink
-
Starts a grid and initializes na event transformer.
- start() - Method in class org.apache.ignite.stream.jms11.JmsStreamer
-
Starts streamer.
- start() - Method in class org.apache.ignite.stream.kafka.KafkaStreamer
-
Starts streamer.
- start() - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
-
Starts streamer.
- start() - Method in class org.apache.ignite.stream.socket.SocketStreamer
-
Starts streamer.
- start() - Method in class org.apache.ignite.stream.twitter.TwitterStreamer
-
Starts streamer.
- start() - Method in class org.apache.ignite.visor.plugin.VisorPlugin
- startInfo() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
-
Gets uniformly formatted message for SPI start.
- startNodes(File, boolean, int, int) - Method in interface org.apache.ignite.IgniteCluster
-
Starts one or more nodes on remote host(s).
- startNodes(Collection<Map<String, Object>>, Map<String, Object>, boolean, int, int) - Method in interface org.apache.ignite.IgniteCluster
-
Starts one or more nodes on remote host(s).
- startOffset() - Method in class org.apache.ignite.igfs.mapreduce.IgfsRangeInputStream
-
Since range input stream represents a part of larger file stream, there is an offset at which this
range input stream starts in original input stream.
- startStopwatch() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
-
Starts startup stopwatch.
- startTime() - Method in interface org.apache.ignite.lang.IgniteFuture
-
Gets start time for this future.
- startTime() - Method in interface org.apache.ignite.transactions.Transaction
-
Start time of this transaction.
- state() - Static method in class org.apache.ignite.Ignition
-
Gets state of grid default grid.
- state(String) - Static method in class org.apache.ignite.Ignition
-
Gets states of named grid.
- state() - Method in interface org.apache.ignite.plugin.extensions.communication.MessageReader
-
Gets current read state.
- state() - Method in interface org.apache.ignite.plugin.extensions.communication.MessageWriter
-
Gets current message state.
- state() - Method in interface org.apache.ignite.transactions.Transaction
-
Gets current transaction state value.
- stats - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Statistics.
- statsPrintFreq - Variable in class org.apache.ignite.spi.discovery.tcp.TcpDiscoverySpi
-
Statistics print frequency.
- statusUpdate(SchedulerDriver, Protos.TaskStatus) - Method in class org.apache.ignite.mesos.IgniteScheduler
- STEALING_ATTEMPT_COUNT_ATTR - Static variable in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
-
Name of job context attribute containing current stealing attempt count.
- STEALING_PRIORITY_ATTR - Static variable in class org.apache.ignite.spi.collision.jobstealing.JobStealingCollisionSpi
-
Stealing priority attribute name.
- stgy - Variable in class org.apache.ignite.cache.hibernate.HibernateAbstractRegionAccessStrategy
-
- stop() - Method in class org.apache.ignite.cache.hibernate.HibernateRegionFactory
- stop() - Method in class org.apache.ignite.cache.store.hibernate.CacheHibernateStoreSessionListener
-
Stops grid component, called on grid shutdown.
- stop() - Method in class org.apache.ignite.cache.store.jdbc.CacheAbstractJdbcStore
-
Stops grid component, called on grid shutdown.
- stop() - Method in class org.apache.ignite.cache.store.jdbc.CacheJdbcStoreSessionListener
-
Stops grid component, called on grid shutdown.
- stop() - Method in class org.apache.ignite.cache.store.spring.CacheSpringStoreSessionListener
-
Stops grid component, called on grid shutdown.
- stop() - Method in class org.apache.ignite.hadoop.fs.BasicHadoopFileSystemFactory
-
Stops grid component, called on grid shutdown.
- stop() - Method in class org.apache.ignite.hadoop.fs.CachingHadoopFileSystemFactory
-
Stops grid component, called on grid shutdown.
- stop() - Method in class org.apache.ignite.hadoop.fs.IgniteHadoopIgfsSecondaryFileSystem
-
Stops grid component, called on grid shutdown.
- stop(boolean) - Static method in class org.apache.ignite.Ignition
-
Stops default grid.
- stop(String, boolean) - Static method in class org.apache.ignite.Ignition
-
Stops named grid.
- stop() - Method in interface org.apache.ignite.lifecycle.LifecycleAware
-
Stops grid component, called on grid shutdown.
- stop() - Method in class org.apache.ignite.mesos.resource.JettyServer
-
Stops server.
- stop() - Method in class org.apache.ignite.messaging.MessagingListenActor
-
This method instructs underlying implementation to stop receiving new messages and unregister
the message listener.
- stop(Object) - Method in class org.apache.ignite.messaging.MessagingListenActor
-
This method sends the response message to the original sender node and instructs underlying
implementation to stop receiving new messages and unregister the message listener.
- stop(boolean) - Method in interface org.apache.ignite.mxbean.IgnitionMXBean
-
Stops default grid instance.
- stop(String, boolean) - Method in interface org.apache.ignite.mxbean.IgnitionMXBean
-
Stops named grid.
- stop(BundleContext) - Method in class org.apache.ignite.osgi.IgniteAbstractOsgiContextActivator
-
Stops Ignite when the bundle is stopping.
- stop(boolean) - Method in interface org.apache.ignite.plugin.CachePluginProvider
-
Stops grid component.
- stop(boolean) - Method in interface org.apache.ignite.plugin.PluginProvider
-
Stops grid component.
- stop() - Method in class org.apache.ignite.stream.camel.CamelStreamer
-
Stops the streamer.
- stop() - Method in class org.apache.ignite.stream.flume.IgniteSink
-
Stops the grid.
- stop() - Method in class org.apache.ignite.stream.jms11.JmsStreamer
-
Stops streamer.
- stop() - Method in class org.apache.ignite.stream.kafka.KafkaStreamer
-
Stops streamer.
- stop() - Method in class org.apache.ignite.stream.mqtt.MqttStreamer
-
Stops streamer.
- stop() - Method in class org.apache.ignite.stream.socket.SocketStreamer
-
Stops streamer.
- stop() - Method in class org.apache.ignite.stream.twitter.TwitterStreamer
-
Stops streamer.
- stop() - Method in class org.apache.ignite.visor.plugin.VisorPlugin
- stopAll(boolean) - Static method in class org.apache.ignite.Ignition
-
Stops all started grids in current JVM.
- stopAll(boolean) - Method in interface org.apache.ignite.mxbean.IgnitionMXBean
-
Stops all started grids.
- stopInfo() - Method in class org.apache.ignite.spi.IgniteSpiAdapter
-
Gets uniformly format message for SPI stop.
- stopLocalListen(IgnitePredicate<? extends Event>, int...) - Method in interface org.apache.ignite.IgniteEvents
-
Removes local event listener.
- stopLocalListen(Object, IgniteBiPredicate<UUID, ?>) - Method in interface org.apache.ignite.IgniteMessaging
-
Unregisters local listener for given topic on local node only.
- stopNodes() - Method in interface org.apache.ignite.IgniteCluster
-
Stops nodes satisfying optional set of predicates.
- stopNodes(Collection<UUID>) - Method in interface org.apache.ignite.IgniteCluster
-
Stops nodes defined by provided IDs.
- stopRemoteListen(UUID) - Method in interface org.apache.ignite.IgniteEvents
-
Stops listening to remote events.
- stopRemoteListen(UUID) - Method in interface org.apache.ignite.IgniteMessaging
-
Unregisters all listeners identified with provided operation ID on all nodes in the cluster group.
- store(String, Object, Object, long) - Method in interface org.apache.ignite.spi.indexing.IndexingSpi
-
Updates index.
- store(String, Object, Object, long) - Method in class org.apache.ignite.spi.indexing.noop.NoopIndexingSpi
-
Updates index.
- store(String, SwapKey, byte[], SwapContext) - Method in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
-
Stores value as array of bytes with given key into data space with given name.
- store(String, SwapKey, byte[], SwapContext) - Method in class org.apache.ignite.spi.swapspace.noop.NoopSwapSpaceSpi
-
Stores value as array of bytes with given key into data space with given name.
- store(String, SwapKey, byte[], SwapContext) - Method in interface org.apache.ignite.spi.swapspace.SwapSpaceSpi
-
Stores value as array of bytes with given key into data space with given name.
- storeAll(String, Map<SwapKey, byte[]>, SwapContext) - Method in class org.apache.ignite.spi.swapspace.file.FileSwapSpaceSpi
-
Stores key-value pairs (both keys and values are arrays of bytes) into data
space with given name.
- storeAll(String, Map<SwapKey, byte[]>, SwapContext) - Method in class org.apache.ignite.spi.swapspace.noop.NoopSwapSpaceSpi
-
Stores key-value pairs (both keys and values are arrays of bytes) into data
space with given name.
- storeAll(String, Map<SwapKey, byte[]>, SwapContext) - Method in interface org.apache.ignite.spi.swapspace.SwapSpaceSpi
-
Stores key-value pairs (both keys and values are arrays of bytes) into data
space with given name.
- StreamAdapter<T,K,V> - Class in org.apache.ignite.stream
-
Convenience adapter for streamers.
- StreamAdapter() - Constructor for class org.apache.ignite.stream.StreamAdapter
-
Empty constructor.
- StreamAdapter(IgniteDataStreamer<K, V>, StreamSingleTupleExtractor<T, K, V>) - Constructor for class org.apache.ignite.stream.StreamAdapter
-
Stream adapter.
- StreamAdapter(IgniteDataStreamer<K, V>, StreamMultipleTupleExtractor<T, K, V>) - Constructor for class org.apache.ignite.stream.StreamAdapter
-
Stream adapter.
- StreamMultipleTupleExtractor<T,K,V> - Interface in org.apache.ignite.stream
-
Stream tuple extractor to convert a single message to zero, one or many tuples.
- StreamReceiver<K,V> - Interface in org.apache.ignite.stream
-
Updates cache with batch of entries.
- StreamSingleTupleExtractor<T,K,V> - Interface in org.apache.ignite.stream
-
Stream tuple extractor to convert a message to a single Ignite key-value tuple.
- StreamTransformer<K,V> - Class in org.apache.ignite.stream
-
Convenience adapter to transform update existing values in streaming cache
based on the previously cached value.
- StreamTransformer() - Constructor for class org.apache.ignite.stream.StreamTransformer
-
- StreamTupleExtractor<T,K,V> - Interface in org.apache.ignite.stream
-
Deprecated.
Will be removed in 2.0.0.
- StreamVisitor<K,V> - Class in org.apache.ignite.stream
-
Convenience adapter to visit every key-value tuple in the stream.
- StreamVisitor() - Constructor for class org.apache.ignite.stream.StreamVisitor
-
- subjectId() - Method in class org.apache.ignite.events.CacheEvent
-
Gets security subject ID initiated this cache event, if available.
- subjectId() - Method in class org.apache.ignite.events.CacheQueryExecutedEvent
-
Gets security subject ID.
- subjectId() - Method in class org.apache.ignite.events.CacheQueryReadEvent
-
Gets security subject ID.
- subjectId() - Method in class org.apache.ignite.events.TaskEvent
-
Gets security subject ID initiated this task event, if available.
- subjectId() - Method in class org.apache.ignite.plugin.security.AuthenticationContext
-
Gets subject ID.
- subjectId(UUID) - Method in class org.apache.ignite.plugin.security.AuthenticationContext
-
Sets subject ID.
- subjectType() - Method in class org.apache.ignite.plugin.security.AuthenticationContext
-
Gets subject type.
- subjectType(SecuritySubjectType) - Method in class org.apache.ignite.plugin.security.AuthenticationContext
-
Sets subject type.
- submit(Callable<T>) - Method in class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
- submit(Runnable, T) - Method in class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
- submit(Runnable) - Method in class org.apache.ignite.thread.IgniteStripedThreadPoolExecutor
- suffix(String) - Method in class org.apache.ignite.igfs.IgfsPath
-
Adds a suffix to the final name in the path.
- summary(IgfsPath) - Method in interface org.apache.ignite.IgniteFileSystem
-
Gets summary (total number of files, total number of directories and total length)
for a given path.
- supportsSymlinks() - Method in class org.apache.ignite.hadoop.fs.v2.IgniteHadoopFileSystem
- swap() - Method in class org.apache.ignite.lang.IgniteBiTuple
-
Swaps values.
- SwapContext - Class in org.apache.ignite.spi.swapspace
-
Context for swap operations.
- SwapContext() - Constructor for class org.apache.ignite.spi.swapspace.SwapContext
-
- SwapKey - Class in org.apache.ignite.spi.swapspace
-
Utility wrapper class that represents swap key.
- SwapKey(Object) - Constructor for class org.apache.ignite.spi.swapspace.SwapKey
-
- SwapKey(Object, int) - Constructor for class org.apache.ignite.spi.swapspace.SwapKey
-
- SwapKey(KeyCacheObject, int, byte[]) - Constructor for class org.apache.ignite.spi.swapspace.SwapKey
-
- SwapSpaceEvent - Class in org.apache.ignite.events
-
Grid swap space event.
- SwapSpaceEvent(ClusterNode, String, int, String) - Constructor for class org.apache.ignite.events.SwapSpaceEvent
-
Creates swap space event.
- SwapSpaceSpi - Interface in org.apache.ignite.spi.swapspace
-
Provides a mechanism in grid for storing data on disk.
- SwapSpaceSpiListener - Interface in org.apache.ignite.spi.swapspace
-
Swap space SPI eviction listener.
- sweepContainer(String) - Method in class org.apache.ignite.osgi.classloaders.ContainerSweepClassLoader
-
Sweeps the OSGi container to find the first Bundle that can load the class.
- SYM_CR - Static variable in class org.apache.ignite.igfs.mapreduce.records.IgfsNewLineRecordResolver
-
CR symbol.
- SYM_LF - Static variable in class org.apache.ignite.igfs.mapreduce.records.IgfsNewLineRecordResolver
-
LF symbol.
- systemPermissions() - Method in interface org.apache.ignite.plugin.security.SecurityPermissionSet
-
Collection of system-wide permissions (events enable/disable, Visor task execution).