Package | Description |
---|---|
org.apache.ignite |
Contains entry-point Ignite & HPC APIs.
|
org.apache.ignite.cache.eviction.igfs |
Contains IGFS LRU eviction policy implementations.
|
org.apache.ignite.cache.hibernate |
Contains implementation of Hibernate L2 cache.
|
org.apache.ignite.cache.query |
Contains APIs for creating and executing cache queries.
|
org.apache.ignite.cache.store.hibernate |
Contains reference Hibernate-based cache store implementation.
|
org.apache.ignite.cache.store.jdbc |
Contains reference JDBC-based cache store implementation.
|
org.apache.ignite.compute.gridify |
Contains APIs utilized for AOP-based grid-enabling.
|
org.apache.ignite.compute.gridify.aop |
Contains common classes for different AOP providers.
|
org.apache.ignite.configuration |
Contains configuration-related classes.
|
org.apache.ignite.hadoop |
Contains Hadoop Accelerator APIs.
|
org.apache.ignite.hadoop.fs |
Ignite Hadoop Accelerator file system API.
|
org.apache.ignite.hadoop.mapreduce |
Ignite Hadoop Accelerator map-reduce classes.
|
org.apache.ignite.hadoop.planner |
Ignite Hadoop Accelerator planner classes.
|
org.apache.ignite.logger.java |
Contains Java logging implementation for logging.
|
org.apache.ignite.logger.log4j |
Contains default Log4j implementation for logging.
|
org.apache.ignite.logger.log4j2 |
Contains default Log4j2 implementation for logging.
|
org.apache.ignite.marshaller |
Contains various supported marshallers.
|
org.apache.ignite.marshaller.jdk |
Contains JDK java.io based marshaller.
|
org.apache.ignite.plugin |
Contains plugins management API.
|
org.apache.ignite.plugin.extensions.communication |
Contains extendable components for communication.
|
org.apache.ignite.plugin.security |
Contains APIs for security, authentication, and authorization.
|
org.apache.ignite.plugin.segmentation |
Contains segmentation "split-brain" related classes.
|
org.apache.ignite.spi |
Contains common classes and interfaces for SPI implementations.
|
org.apache.ignite.spi.communication.tcp |
Contains default TCP/IP-based implementation for communication SPI.
|
org.apache.ignite.spi.discovery.tcp |
Contains default TCP/IP implementation for discovery SPI.
|
Modifier and Type | Class and Description |
---|---|
class |
IgniteAuthenticationException
Exception that represents authentication failure.
|
Modifier and Type | Method and Description |
---|---|
static Ignite |
IgniteSpring.start(@Nullable org.springframework.context.ApplicationContext springCtx)
Starts grid with default configuration.
|
static Ignite |
IgniteSpring.start(IgniteConfiguration cfg,
@Nullable org.springframework.context.ApplicationContext springCtx)
Starts grid with given configuration.
|
static Ignite |
IgniteSpring.start(String springCfgPath,
@Nullable org.springframework.context.ApplicationContext springCtx)
Starts all grids specified within given Spring XML configuration file.
|
static Ignite |
IgniteSpring.start(URL springCfgUrl,
@Nullable org.springframework.context.ApplicationContext springCtx)
Starts all grids specified within given Spring XML configuration file URL.
|
Modifier and Type | Method and Description |
---|---|
boolean |
IgfsPerBlockLruEvictionPolicy.exclude(IgfsPath path)
Check whether provided path must be excluded from evictions.
|
Modifier and Type | Method and Description |
---|---|
void |
HibernateCacheProxy.clear()
Clears cache on all nodes that store it's data.
|
void |
HibernateCacheProxy.clear(Object key)
Clears key on all nodes that store it's data.
|
void |
HibernateCacheProxy.clearAll(Set keys)
Clears keys on all nodes that store it's data.
|
static void |
HibernateAccessStrategyAdapter.evictAll(org.apache.ignite.internal.processors.cache.IgniteInternalCache<Object,Object> cache)
Called to remove all data from cache without regard to transaction.
|
@Nullable Object |
HibernateCacheProxy.get(Object key)
Retrieves value mapped to the specified key from cache.
|
Map |
HibernateCacheProxy.getAll(@Nullable Collection keys)
Retrieves values mapped to the specified keys from cache.
|
Map |
HibernateCacheProxy.getAllOutTx(Set keys)
Gets values from cache.
|
@Nullable Object |
HibernateCacheProxy.getAndPut(Object key,
Object val)
Stores given key-value pair in cache.
|
@Nullable Object |
HibernateCacheProxy.getAndPutIfAbsent(Object key,
Object val)
Stores given key-value pair in cache only if cache had no previous mapping for it.
|
@Nullable Object |
HibernateCacheProxy.getAndRemove(Object key)
Removes given key mapping from cache.
|
@Nullable Object |
HibernateCacheProxy.getAndReplace(Object key,
Object val)
Stores given key-value pair in cache only if there is a previous mapping for it.
|
Collection<CacheEntry<Object,Object>> |
HibernateCacheProxy.getEntries(@Nullable Collection keys)
Retrieves values mapped to the specified keys from cache.
|
@Nullable CacheEntry |
HibernateCacheProxy.getEntry(Object key)
Retrieves value mapped to the specified key from cache.
|
@Nullable Object |
HibernateCacheProxy.getForcePrimary(Object key)
Gets value from cache.
|
@Nullable javax.cache.processor.EntryProcessorResult |
HibernateCacheProxy.invoke(@Nullable org.apache.ignite.internal.processors.affinity.AffinityTopologyVersion topVer,
Object key,
javax.cache.processor.EntryProcessor entryProcessor,
Object... args) |
@Nullable javax.cache.processor.EntryProcessorResult |
HibernateCacheProxy.invoke(Object key,
javax.cache.processor.EntryProcessor entryProcessor,
Object... args) |
Map |
HibernateCacheProxy.invokeAll(Map map,
Object... args) |
Map |
HibernateCacheProxy.invokeAll(Set keys,
javax.cache.processor.EntryProcessor entryProcessor,
Object... args) |
Iterable<javax.cache.Cache.Entry<Object,Object>> |
HibernateCacheProxy.localEntries(CachePeekMode[] peekModes) |
void |
HibernateCacheProxy.localLoadCache(@Nullable IgniteBiPredicate p,
Object... args)
Delegates to
CacheStore.loadCache(IgniteBiInClosure, Object...) method
to load state from the underlying persistent storage. |
@Nullable Object |
HibernateCacheProxy.localPeek(Object key,
CachePeekMode[] peekModes) |
boolean |
HibernateCacheProxy.localPreloadPartition(int part)
Preloads cache partition if it exists on local node.
|
int |
HibernateCacheProxy.localSize(CachePeekMode[] peekModes) |
long |
HibernateCacheProxy.localSizeLong(CachePeekMode[] peekModes) |
long |
HibernateCacheProxy.localSizeLong(int partition,
CachePeekMode[] peekModes) |
boolean |
HibernateCacheProxy.lock(Object key,
long timeout)
Synchronously acquires lock on a cached object with given
key only if the passed in filter (if any) passes.
|
boolean |
HibernateCacheProxy.lockAll(@Nullable Collection keys,
long timeout)
All or nothing synchronous lock for passed in keys.
|
void |
HibernateCacheProxy.preloadPartition(int part)
Preload cache partition.
|
org.apache.ignite.internal.IgniteInternalFuture<?> |
HibernateCacheProxy.preloadPartitionAsync(int part)
Preload cache partition.
|
boolean |
HibernateCacheProxy.put(Object key,
Object val)
Stores given key-value pair in cache.
|
void |
HibernateCacheProxy.putAll(@Nullable Map m)
Stores given key-value pairs in cache.
|
void |
HibernateCacheProxy.putAllConflict(Map drMap)
Store DR data.
|
org.apache.ignite.internal.IgniteInternalFuture<?> |
HibernateCacheProxy.putAllConflictAsync(Map drMap)
Store DR data asynchronously.
|
boolean |
HibernateCacheProxy.putIfAbsent(Object key,
Object val)
Stores given key-value pair in cache only if cache had no previous mapping for it.
|
boolean |
HibernateCacheProxy.remove(Object key)
Removes given key mapping from cache.
|
boolean |
HibernateCacheProxy.remove(Object key,
Object val)
Removes given key mapping from cache if one exists and value is equal to the passed in value.
|
void |
HibernateCacheProxy.removeAll()
Removes mappings from cache.
|
void |
HibernateCacheProxy.removeAll(@Nullable Collection keys)
Removes given key mappings from cache.
|
void |
HibernateCacheProxy.removeAllConflict(Map drMap)
Removes DR data.
|
org.apache.ignite.internal.IgniteInternalFuture<?> |
HibernateCacheProxy.removeAllConflictAsync(Map drMap)
Removes DR data asynchronously.
|
boolean |
HibernateCacheProxy.replace(Object key,
Object val)
Stores given key-value pair in cache only if only if there is a previous mapping for it.
|
boolean |
HibernateCacheProxy.replace(Object key,
Object oldVal,
Object newVal)
Stores given key-value pair in cache only if only if the previous value is equal to the
'oldVal' passed in. |
Iterator<javax.cache.Cache.Entry<Object,Object>> |
HibernateCacheProxy.scanIterator(boolean keepBinary,
@Nullable IgniteBiPredicate p) |
int |
HibernateCacheProxy.size(CachePeekMode[] peekModes) |
long |
HibernateCacheProxy.sizeLong(CachePeekMode[] peekModes) |
long |
HibernateCacheProxy.sizeLong(int partition,
CachePeekMode[] peekModes) |
void |
HibernateCacheProxy.unlock(Object key)
Unlocks given key only if current thread owns the lock.
|
void |
HibernateCacheProxy.unlockAll(@Nullable Collection keys)
Unlocks given keys only if current thread owns the locks.
|
Modifier and Type | Class and Description |
---|---|
class |
QueryCancelledException
The exception is thrown if a query was cancelled or timed out while executing.
|
Modifier and Type | Method and Description |
---|---|
protected <X> X |
CacheHibernateBlobStore.fromBytes(byte[] bytes)
Deserialize object from byte array using marshaller.
|
protected byte[] |
CacheHibernateBlobStore.toBytes(Object obj)
Serialize object to byte array using marshaller.
|
Modifier and Type | Method and Description |
---|---|
protected <X> X |
CacheJdbcBlobStore.fromBytes(byte[] bytes)
Deserialize object from byte array using marshaller.
|
protected byte[] |
CacheJdbcBlobStore.toBytes(Object obj)
Serialize object to byte array using marshaller.
|
Modifier and Type | Method and Description |
---|---|
boolean |
GridifyInterceptor.isGridify(Annotation gridify,
GridifyArgument arg)
This method is called before actual grid-enabling happens.
|
Modifier and Type | Method and Description |
---|---|
protected void |
GridifySetToSetAbstractAspect.checkIsSplitToJobsAllowed(org.apache.ignite.internal.util.gridify.GridifyRangeArgument arg,
GridifySetToSet ann)
Check if split allowed for input argument.
|
protected void |
GridifySetToValueAbstractAspect.checkIsSplitToJobsAllowed(org.apache.ignite.internal.util.gridify.GridifyRangeArgument arg,
GridifySetToValue ann)
Check if split allowed for input argument.
|
protected void |
GridifySetToValueAbstractAspect.checkMethodSignature(Method mtd)
Check method signature.
|
protected void |
GridifySetToSetAbstractAspect.checkMethodSignature(Method mtd)
Check method signature.
|
protected Object |
GridifySetToSetAbstractAspect.execute(IgniteCompute compute,
Class<?> cls,
org.apache.ignite.internal.util.gridify.GridifyRangeArgument arg,
GridifyNodeFilter nodeFilter,
int threshold,
int splitSize,
long timeout)
Execute method on grid.
|
protected Object |
GridifySetToValueAbstractAspect.execute(Method mtd,
IgniteCompute compute,
Class<?> cls,
org.apache.ignite.internal.util.gridify.GridifyRangeArgument arg,
GridifyNodeFilter nodeFilter,
int threshold,
int splitSize,
long timeout)
Execute method on grid.
|
Modifier and Type | Method and Description |
---|---|
Collection<InetSocketAddress> |
BasicAddressResolver.getExternalAddresses(InetSocketAddress addr)
Maps internal address to a collection of external addresses.
|
Collection<InetSocketAddress> |
AddressResolver.getExternalAddresses(InetSocketAddress addr)
Maps internal address to a collection of external addresses.
|
Modifier and Type | Method and Description |
---|---|
HadoopMapReducePlan |
HadoopMapReducePlanner.preparePlan(HadoopJob job,
Collection<ClusterNode> top,
@Nullable HadoopMapReducePlan oldPlan)
Prepares map-reduce execution plan for the given job and topology.
|
Modifier and Type | Method and Description |
---|---|
void |
IgniteHadoopFileSystemCounterWriter.write(org.apache.ignite.internal.processors.hadoop.HadoopJobEx job,
org.apache.ignite.internal.processors.hadoop.counter.HadoopCounters cntrs)
Writes counters of given job to some statistics storage.
|
Constructor and Description |
---|
IgniteHadoopIgfsSecondaryFileSystem(String uri)
Deprecated.
|
IgniteHadoopIgfsSecondaryFileSystem(@Nullable String uri,
@Nullable String cfgPath)
Deprecated.
|
IgniteHadoopIgfsSecondaryFileSystem(@Nullable String uri,
@Nullable String cfgPath,
@Nullable String userName)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
HadoopMapReducePlan |
IgniteHadoopWeightedMapReducePlanner.preparePlan(HadoopJob job,
Collection<ClusterNode> nodes,
@Nullable HadoopMapReducePlan oldPlan)
Prepares map-reduce execution plan for the given job and topology.
|
Modifier and Type | Method and Description |
---|---|
HadoopMapReducePlan |
HadoopTestRoundRobinMrPlanner.preparePlan(HadoopJob job,
Collection<ClusterNode> top,
@Nullable HadoopMapReducePlan oldPlan)
Prepares map-reduce execution plan for the given job and topology.
|
Modifier and Type | Method and Description |
---|---|
void |
JavaLoggerFileHandler.nodeId(UUID nodeId,
String workDir)
Sets Node id and instantiates
FileHandler delegate. |
Constructor and Description |
---|
Log4JLogger(File cfgFile)
Creates new logger with given configuration
cfgFile . |
Log4JLogger(File cfgFile,
long watchDelay)
Creates new logger with given configuration
cfgFile . |
Log4JLogger(String path)
Creates new logger with given configuration
path . |
Log4JLogger(String path,
long watchDelay)
Creates new logger with given configuration
path . |
Log4JLogger(URL cfgUrl)
Creates new logger with given configuration
cfgUrl . |
Log4JLogger(URL cfgUrl,
long watchDelay)
Creates new logger with given configuration
cfgUrl . |
Constructor and Description |
---|
Log4J2Logger(File cfgFile)
Creates new logger with given configuration
cfgFile . |
Log4J2Logger(String path)
Creates new logger with given configuration
path . |
Log4J2Logger(URL cfgUrl)
Creates new logger with given configuration
cfgUrl . |
Modifier and Type | Method and Description |
---|---|
static IgnitePredicate<String> |
MarshallerUtils.classNameFilter(ClassLoader clsLdr)
Returns class name filter for marshaller.
|
Class |
MarshallerContext.getClass(int typeId,
ClassLoader ldr)
Gets class for provided type ID.
|
String |
MarshallerContext.getClassName(byte platformId,
int typeId)
Gets class name for provided (platformId, typeId) pair.
|
byte[] |
AbstractNodeNameAwareMarshaller.marshal(@Nullable Object obj)
Marshals object to byte array.
|
byte[] |
Marshaller.marshal(@Nullable Object obj)
Marshals object to byte array.
|
void |
AbstractNodeNameAwareMarshaller.marshal(@Nullable Object obj,
OutputStream out)
Marshals object to the output stream.
|
void |
Marshaller.marshal(@Nullable Object obj,
OutputStream out)
Marshals object to the output stream.
|
protected abstract byte[] |
AbstractNodeNameAwareMarshaller.marshal0(@Nullable Object obj)
Marshals object to byte array.
|
protected abstract void |
AbstractNodeNameAwareMarshaller.marshal0(@Nullable Object obj,
OutputStream out)
Marshals object to the output stream.
|
boolean |
MarshallerContext.registerClassName(byte platformId,
int typeId,
String clsName)
Method to register typeId->class name mapping in marshaller context cluster-wide.
|
boolean |
MarshallerContext.registerClassNameLocally(byte platformId,
int typeId,
String clsName)
Method to register typeId->class name mapping in marshaller context on local node only.
|
<T> T |
AbstractNodeNameAwareMarshaller.unmarshal(byte[] arr,
@Nullable ClassLoader clsLdr)
Unmarshals object from byte array using given class loader.
|
<T> T |
Marshaller.unmarshal(byte[] arr,
@Nullable ClassLoader clsLdr)
Unmarshals object from byte array using given class loader.
|
<T> T |
AbstractNodeNameAwareMarshaller.unmarshal(InputStream in,
@Nullable ClassLoader clsLdr)
Unmarshals object from the input stream using given class loader.
|
<T> T |
Marshaller.unmarshal(InputStream in,
@Nullable ClassLoader clsLdr)
Unmarshals object from the input stream using given class loader.
|
protected abstract <T> T |
AbstractNodeNameAwareMarshaller.unmarshal0(byte[] arr,
@Nullable ClassLoader clsLdr)
Unmarshals object from byte array using given class loader.
|
protected abstract <T> T |
AbstractNodeNameAwareMarshaller.unmarshal0(InputStream in,
@Nullable ClassLoader clsLdr)
Unmarshals object from the input stream using given class loader.
|
Modifier and Type | Method and Description |
---|---|
protected byte[] |
JdkMarshaller.marshal0(@Nullable Object obj)
Marshals object to byte array.
|
protected void |
JdkMarshaller.marshal0(@Nullable Object obj,
OutputStream out)
Marshals object to the output stream.
|
protected <T> T |
JdkMarshaller.unmarshal0(byte[] arr,
@Nullable ClassLoader clsLdr)
Unmarshals object from byte array using given class loader.
|
protected <T> T |
JdkMarshaller.unmarshal0(InputStream in,
@Nullable ClassLoader clsLdr)
Unmarshals object from the input stream using given class loader.
|
Modifier and Type | Method and Description |
---|---|
void |
PluginProvider.initExtensions(PluginContext ctx,
ExtensionRegistry registry)
Registers extensions.
|
void |
PluginProvider.onIgniteStart()
Callback that notifies that Ignite has successfully started,
including all internal components.
|
void |
CachePluginProvider.onIgniteStart()
Callback that notifies that Ignite has successfully started,
including all internal components.
|
void |
CachePluginProvider.start()
Starts grid component.
|
void |
PluginProvider.start(PluginContext ctx)
Starts grid component.
|
void |
PluginProvider.stop(boolean cancel)
Stops grid component.
|
void |
CachePluginProvider.validate()
Validates cache plugin configuration in process of cache creation.
|
void |
CachePluginProvider.validateRemote(CacheConfiguration locCfg,
CacheConfiguration rmtCfg,
ClusterNode rmtNode)
Checks that remote caches has configuration compatible with the local.
|
Modifier and Type | Method and Description |
---|---|
MessageReader |
MessageFormatter.reader(UUID rmtNodeId,
MessageFactory msgFactory)
Creates new message reader instance.
|
MessageWriter |
MessageFormatter.writer(UUID rmtNodeId)
Creates new message writer instance.
|
Modifier and Type | Method and Description |
---|---|
SecurityCredentials |
SecurityCredentialsProvider.credentials()
Gets security credentials.
|
SecurityCredentials |
SecurityCredentialsBasicProvider.credentials()
Gets security credentials.
|
Modifier and Type | Method and Description |
---|---|
boolean |
SegmentationResolver.isValidSegment()
Checks whether segment is valid.
|
Modifier and Type | Class and Description |
---|---|
class |
IgniteSpiOperationTimeoutException
Kind of exception that is used when failure detection timeout is enabled for
TcpDiscoverySpi or
TcpCommunicationSpi . |
Modifier and Type | Method and Description |
---|---|
void |
IgniteSpiCloseableIterator.close()
Closes the iterator and frees all the resources held by the iterator.
|
Modifier and Type | Method and Description |
---|---|
protected void |
TcpCommunicationSpi.processClientCreationError(ClusterNode node,
Collection<InetSocketAddress> addrs,
IgniteCheckedException errs)
Process errors if TCP client to remote node hasn't been created.
|
Modifier and Type | Method and Description |
---|---|
protected org.apache.ignite.internal.util.nio.GridCommunicationClient |
TcpCommunicationSpi.createTcpClient(ClusterNode node,
int connIdx)
Establish TCP connection to remote node and returns client.
|
Collection<InetSocketAddress> |
TcpCommunicationSpi.nodeAddresses(ClusterNode node,
boolean filterReachableAddresses) |
protected void |
TcpCommunicationSpi.processClientCreationError(ClusterNode node,
Collection<InetSocketAddress> addrs,
IgniteCheckedException errs)
Process errors if TCP client to remote node hasn't been created.
|
Modifier and Type | Method and Description |
---|---|
protected <T> T |
TcpDiscoverySpi.readMessage(Socket sock,
@Nullable InputStream in,
long timeout)
Reads message from the socket limiting read time.
|
protected void |
TcpDiscoverySpi.writeToSocket(ClusterNode node,
Socket sock,
OutputStream out,
org.apache.ignite.spi.discovery.tcp.messages.TcpDiscoveryAbstractMessage msg,
long timeout) |
protected void |
TcpDiscoverySpi.writeToSocket(Socket sock,
OutputStream out,
org.apache.ignite.spi.discovery.tcp.messages.TcpDiscoveryAbstractMessage msg,
long timeout)
Writes message to the socket.
|
protected void |
TcpDiscoverySpi.writeToSocket(Socket sock,
org.apache.ignite.spi.discovery.tcp.messages.TcpDiscoveryAbstractMessage msg,
long timeout)
Writes message to the socket.
|
Follow @ApacheIgnite
Ignite Database and Caching Platform : ver. 2.7.2 Release Date : February 6 2019