Package | Description |
---|---|
org.apache.ignite |
Contains entry-point Ignite & HPC APIs.
|
org.apache.ignite.cache.jta |
Contains JTA (Java Transaction API) related public classes and interfaces.
|
org.apache.ignite.cache.jta.jndi |
Contains JNDI-based transaction manager lookup.
|
org.apache.ignite.cache.jta.reflect |
Contains reflection-based transaction manager lookup.
|
org.apache.ignite.cache.store.jdbc |
Contains reference JDBC-based cache store implementation.
|
org.apache.ignite.cluster | |
org.apache.ignite.compute |
Contains Compute Grid functionality.
|
org.apache.ignite.compute.gridify |
Contains APIs utilized for AOP-based grid-enabling.
|
org.apache.ignite.igfs |
Contains GridGain File System APIs.
|
org.apache.ignite.igfs.mapreduce |
Contains APIs for In-Memory MapReduce over IGFS.
|
org.apache.ignite.igfs.mapreduce.records |
Contains record resolvers for In-Memory MapReduce over IGFS.
|
org.apache.ignite.lang |
Contains general language constructs and functional APIs for distributed computations.
|
org.apache.ignite.lifecycle | |
org.apache.ignite.messaging |
Contains Topic-based Messaging functionality.
|
org.apache.ignite.plugin | |
org.apache.ignite.plugin.security |
Contains APIs for security, authentication, and authorization.
|
org.apache.ignite.scheduler |
Contains Job Scheduling functionality.
|
org.apache.ignite.spi |
Contains common classes and interfaces for SPI implementations.
|
org.apache.ignite.spi.discovery |
Contains APIs for topology manager SPI.
|
org.apache.ignite.spi.failover |
Contains APIs for failover SPI.
|
org.apache.ignite.spi.loadbalancing |
Contains APIs for load balancing SPI.
|
org.apache.ignite.streamer |
Contains main Streaming APIs.
|
org.apache.ignite.streamer.index |
Contains APIs for indexing of streamer windows.
|
org.apache.ignite.streamer.window |
Contains streamer window implementations.
|
org.apache.ignite.transactions |
Modifier and Type | Class and Description |
---|---|
class |
IgniteDeploymentException
Deployment or re-deployment failed.
|
class |
IgniteInterruptedException
This exception is used to wrap standard
InterruptedException into IgniteException . |
Modifier and Type | Method and Description |
---|---|
boolean |
IgniteQueue.add(T item) |
boolean |
IgniteSet.add(T t) |
boolean |
IgniteQueue.addAll(Collection<? extends T> items) |
boolean |
IgniteSet.addAll(Collection<? extends T> c) |
long |
IgniteAtomicLong.addAndGet(long l)
Adds
l and gets current value of atomic long. |
long |
IgniteAtomicSequence.addAndGet(long l)
Adds
l elements to atomic sequence and gets value of atomic sequence. |
IgniteFuture<?> |
IgniteDataLoader.addData(K key,
V val)
Adds data for loading on remote node.
|
IgniteFuture<?> |
IgniteDataLoader.addData(Map.Entry<K,V> entry)
Adds data for loading on remote node.
|
void |
IgniteStreamer.addEvent(Object evt,
Object... evts)
Submits group of events for processing.
|
void |
IgniteStreamer.addEvents(Collection<?> evts)
Submits group of events for processing.
|
void |
IgniteStreamer.addEventsToStage(String stageName,
Collection<?> evts)
Submits events to streamer.
|
void |
IgniteStreamer.addEventToStage(String stageName,
Object evt,
Object... evts)
Submits group of events to streamer.
|
Collection<IgfsBlockLocation> |
IgniteFs.affinity(IgfsPath path,
long start,
long len)
Gets affinity block locations for data blocks of the file, i.e. the nodes, on which the blocks
are stored.
|
Collection<IgfsBlockLocation> |
IgniteFs.affinity(IgfsPath path,
long start,
long len,
long maxLen)
Get affinity block locations for data blocks of the file.
|
<R> R |
IgniteCompute.affinityCall(String cacheName,
Object affKey,
IgniteCallable<R> job)
Executes given job on the node where data for provided affinity key is located
(a.k.a. affinity co-location).
|
void |
IgniteCompute.affinityRun(String cacheName,
Object affKey,
IgniteRunnable job)
Executes given job on the node where data for provided affinity key is located
(a.k.a. affinity co-location).
|
void |
IgniteDataLoader.allowOverwrite(boolean allowOverwrite)
Sets flag indicating that this data loader should assume that there are no other concurrent updates to the cache.
|
IgfsOutputStream |
IgniteFs.append(IgfsPath path,
boolean create)
Opens an output stream to an existing file for appending data.
|
IgfsOutputStream |
IgniteFs.append(IgfsPath path,
int bufSize,
boolean create,
Map<String,String> props)
Opens an output stream to an existing file for appending data.
|
<T,R> Collection<R> |
IgniteCompute.apply(IgniteClosure<T,R> job,
Collection<? extends T> args)
Executes provided closure job on nodes within this grid projection.
|
<R,T> R |
IgniteCompute.apply(IgniteClosure<T,R> job,
T arg)
Executes provided closure job on a node in this grid projection.
|
<R1,R2,T> R2 |
IgniteCompute.apply(IgniteClosure<T,R1> job,
Collection<? extends T> args,
IgniteReducer<R1,R2> rdc)
Executes provided closure job on nodes within this grid projection.
|
IgniteAtomicLong |
Ignite.atomicLong(String name,
long initVal,
boolean create)
Will get a atomic long from cache and create one if it has not been created yet and
create flag
is true . |
<T> IgniteAtomicReference<T> |
Ignite.atomicReference(String name,
T initVal,
boolean create)
Will get a atomic reference from cache and create one if it has not been created yet and
create flag
is true . |
IgniteAtomicSequence |
Ignite.atomicSequence(String name,
long initVal,
boolean create)
Will get an atomic sequence from cache and create one if it has not been created yet and
create flag
is true . |
<T,S> IgniteAtomicStamped<T,S> |
Ignite.atomicStamped(String name,
T initVal,
S initStamp,
boolean create)
Will get a atomic stamped from cache and create one if it has not been created yet and
create flag
is true . |
void |
IgniteCountDownLatch.await()
Causes the current thread to wait until the latch has counted down to
zero, unless current thread is interrupted.
|
boolean |
IgniteCountDownLatch.await(long timeout)
Causes the current thread to wait until the latch has counted down to
zero, unless the thread is interrupted, or the specified waiting time elapses.
|
boolean |
IgniteCountDownLatch.await(long timeout,
TimeUnit unit)
Causes the current thread to wait until the latch has counted down to
zero, unless the thread is interrupted, or the specified waiting time elapses.
|
<R> Collection<R> |
IgniteCompute.broadcast(IgniteCallable<R> job)
Broadcasts given job to all nodes in grid projection.
|
<R,T> Collection<R> |
IgniteCompute.broadcast(IgniteClosure<T,R> job,
T arg)
Broadcasts given closure job with passed in argument to all nodes in grid projection.
|
void |
IgniteCompute.broadcast(IgniteRunnable job)
Broadcasts given job to all nodes in grid projection.
|
<R> Collection<R> |
IgniteCompute.call(Collection<? extends IgniteCallable<R>> jobs)
Executes collection of jobs on nodes within this grid projection.
|
<R1,R2> R2 |
IgniteCompute.call(Collection<? extends IgniteCallable<R1>> jobs,
IgniteReducer<R1,R2> rdc)
Executes collection of jobs on nodes within this grid projection.
|
<R> R |
IgniteCompute.call(IgniteCallable<R> job)
Executes provided job on a node in this grid projection.
|
void |
IgniteServices.cancel(String name)
Cancels service deployment.
|
void |
IgniteServices.cancelAll()
Cancels all deployed services.
|
void |
IgniteQueue.clear() |
void |
IgniteSet.clear() |
void |
IgniteQueue.clear(int batchSize)
Removes all of the elements from this queue.
|
void |
IgniteSpringBean.close()
Closes
this instance of grid. |
void |
IgniteQueue.close()
Removes this queue.
|
void |
IgniteSet.close()
Removes this set.
|
void |
Ignite.close()
Closes
this instance of grid. |
void |
IgniteDataLoader.close()
Closes data loader.
|
void |
IgniteDataLoader.close(boolean cancel)
Loads any remaining data and closes this loader.
|
boolean |
IgniteAtomicLong.compareAndSet(long expVal,
long newVal)
Atomically compares current value to the expected value, and if they are equal, sets current value
to new value.
|
boolean |
IgniteAtomicReference.compareAndSet(T expVal,
T newVal)
Conditionally sets the new value.
|
boolean |
IgniteAtomicStamped.compareAndSet(T expVal,
T newVal,
S expStamp,
S newStamp)
Conditionally sets the new value and new stamp.
|
boolean |
IgniteQueue.contains(Object item) |
boolean |
IgniteSet.contains(Object o) |
boolean |
IgniteQueue.containsAll(Collection<?> items) |
boolean |
IgniteSet.containsAll(Collection<?> c) |
int |
IgniteCountDownLatch.countDown()
Decrements the count of the latch, releasing all waiting threads
on all nodes if the count reaches zero.
|
int |
IgniteCountDownLatch.countDown(int val)
Decreases the count of the latch using passed in value,
releasing all waiting threads on all nodes if the count reaches zero.
|
void |
IgniteCountDownLatch.countDownAll()
Counts down this latch to zero, releasing all waiting threads on all nodes.
|
IgniteCountDownLatch |
Ignite.countDownLatch(String name,
int cnt,
boolean autoDel,
boolean create)
Gets or creates count down latch.
|
IgfsOutputStream |
IgniteFs.create(IgfsPath path,
boolean overwrite)
Creates a file and opens it for writing.
|
IgfsOutputStream |
IgniteFs.create(IgfsPath path,
int bufSize,
boolean overwrite,
IgniteUuid affKey,
int replication,
long blockSize,
Map<String,String> props)
Creates a file and opens it for writing.
|
IgfsOutputStream |
IgniteFs.create(IgfsPath path,
int bufSize,
boolean overwrite,
int replication,
long blockSize,
Map<String,String> props)
Creates a file and opens it for writing.
|
long |
IgniteAtomicLong.decrementAndGet()
Decrements and gets current value of atomic long.
|
void |
IgniteServices.deploy(ServiceConfiguration cfg)
Deploys multiple instances of the service on the grid according to provided
configuration.
|
void |
IgniteServices.deployClusterSingleton(String name,
Service svc)
Deploys a cluster-wide singleton service.
|
void |
IgniteServices.deployKeyAffinitySingleton(String name,
Service svc,
String cacheName,
Object affKey)
Deploys one instance of this service on the primary node for a given affinity key.
|
void |
IgniteServices.deployMultiple(String name,
Service svc,
int totalCnt,
int maxPerNodeCnt)
Deploys multiple instances of the service on the grid.
|
void |
IgniteServices.deployNodeSingleton(String name,
Service svc)
Deploys a per-node singleton service.
|
<T,R> R |
IgniteCompute.execute(Class<? extends ComputeTask<T,R>> taskCls,
T arg)
Executes given task on the grid projection.
|
<T,R> R |
IgniteFs.execute(Class<? extends IgfsTask<T,R>> taskCls,
IgfsRecordResolver rslvr,
Collection<IgfsPath> paths,
boolean skipNonExistentFiles,
long maxRangeLen,
T arg)
Executes IGFS task with overridden maximum range length (see
IgfsConfiguration.getMaximumTaskRangeLength() for more information). |
<T,R> R |
IgniteFs.execute(Class<? extends IgfsTask<T,R>> taskCls,
IgfsRecordResolver rslvr,
Collection<IgfsPath> paths,
T arg)
Executes IGFS task.
|
<T,R> R |
IgniteCompute.execute(ComputeTask<T,R> task,
T arg)
Executes given task on this grid projection.
|
<T,R> R |
IgniteFs.execute(IgfsTask<T,R> task,
IgfsRecordResolver rslvr,
Collection<IgfsPath> paths,
boolean skipNonExistentFiles,
long maxRangeLen,
T arg)
Executes IGFS task with overridden maximum range length (see
IgfsConfiguration.getMaximumTaskRangeLength() for more information). |
<T,R> R |
IgniteFs.execute(IgfsTask<T,R> task,
IgfsRecordResolver rslvr,
Collection<IgfsPath> paths,
T arg)
Executes IGFS task.
|
<T,R> R |
IgniteCompute.execute(String taskName,
T arg)
Executes given task on this grid projection.
|
void |
IgniteDataLoader.flush()
Loads any remaining data, but doesn't close the loader.
|
void |
IgniteFs.format()
Formats the file system removing all existing entries from it.
|
long |
IgniteAtomicLong.get()
Gets current value of atomic long.
|
T |
IgniteAtomicReference.get()
Gets current value of an atomic reference.
|
IgniteBiTuple<T,S> |
IgniteAtomicStamped.get()
Gets both current value and current stamp of atomic stamped.
|
long |
IgniteAtomicSequence.get()
Gets current value of atomic sequence.
|
long |
IgniteAtomicLong.getAndAdd(long l)
Gets current value of atomic long and adds
l . |
long |
IgniteAtomicSequence.getAndAdd(long l)
Gets current value of atomic sequence and adds
l elements. |
long |
IgniteAtomicLong.getAndDecrement()
Gets and decrements current value of atomic long.
|
long |
IgniteAtomicLong.getAndIncrement()
Gets and increments current value of atomic long.
|
long |
IgniteAtomicSequence.getAndIncrement()
Gets and increments current value of atomic sequence.
|
long |
IgniteAtomicLong.getAndSet(long l)
Gets current value of atomic long and sets new value
l of atomic long. |
long |
IgniteAtomicLong.incrementAndGet()
Increments and gets current value of atomic long.
|
long |
IgniteAtomicSequence.incrementAndGet()
Increments and returns the value of atomic sequence.
|
boolean |
IgniteQueue.isEmpty() |
boolean |
IgniteSet.isEmpty() |
Iterator<T> |
IgniteQueue.iterator() |
Iterator<T> |
IgniteSet.iterator() |
void |
IgniteCompute.localDeployTask(Class<? extends ComputeTask> taskCls,
ClassLoader clsLdr)
Explicitly deploys a task with given class loader on the local node.
|
<K> Map<ClusterNode,Collection<K>> |
IgniteCluster.mapKeysToNodes(String cacheName,
Collection<? extends K> keys)
This method provides ability to detect which cache keys are mapped to which nodes
on cache instance with given name.
|
<K> ClusterNode |
IgniteCluster.mapKeyToNode(String cacheName,
K key)
This method provides ability to detect which cache keys are mapped to which nodes
on cache instance with given name.
|
IgfsMetrics |
IgniteFs.metrics()
Gets metrics snapshot for this file system.
|
boolean |
IgniteQueue.offer(T item) |
boolean |
IgniteQueue.offer(T item,
long timeout,
TimeUnit unit) |
IgfsInputStream |
IgniteFs.open(IgfsPath path)
Opens a file for reading.
|
IgfsInputStream |
IgniteFs.open(IgfsPath path,
int bufSize)
Opens a file for reading.
|
IgfsInputStream |
IgniteFs.open(IgfsPath path,
int bufSize,
int seqReadsBeforePrefetch)
Opens a file for reading.
|
T |
IgniteQueue.peek() |
T |
IgniteQueue.poll() |
T |
IgniteQueue.poll(long timeout,
TimeUnit unit) |
void |
IgniteQueue.put(T item) |
<T> IgniteQueue<T> |
Ignite.queue(String name,
int cap,
CollectionConfiguration cfg)
Will get a named queue from cache and create one if it has not been created yet and
cfg is not
null . |
<T extends Event> |
IgniteEvents.remoteListen(IgniteBiPredicate<UUID,T> locLsnr,
IgnitePredicate<T> rmtFilter,
int... types)
Adds event listener for specified events to all nodes in the projection (possibly including
local node if it belongs to the projection as well).
|
<T extends Event> |
IgniteEvents.remoteListen(int bufSize,
long interval,
boolean autoUnsubscribe,
IgniteBiPredicate<UUID,T> locLsnr,
IgnitePredicate<T> rmtFilter,
int... types)
Adds event listener for specified events to all nodes in the projection (possibly including
local node if it belongs to the projection as well).
|
UUID |
IgniteMessaging.remoteListen(Object topic,
IgniteBiPredicate<UUID,?> p)
Adds a message listener for a given topic to all nodes in the projection (possibly including
this node if it belongs to the projection as well).
|
<T extends Event> |
IgniteEvents.remoteQuery(IgnitePredicate<T> p,
long timeout,
int... types)
Queries nodes in this projection for events using passed in predicate filter for event
selection.
|
boolean |
IgniteQueue.remove(Object item) |
boolean |
IgniteSet.remove(Object o) |
boolean |
IgniteQueue.removeAll(Collection<?> items) |
boolean |
IgniteSet.removeAll(Collection<?> c) |
IgniteFuture<?> |
IgniteDataLoader.removeData(K key)
Adds key for removal on remote node.
|
void |
IgniteFs.resetMetrics()
Resets metrics for this file system.
|
void |
IgniteCluster.restartNodes()
Restarts nodes satisfying optional set of predicates.
|
void |
IgniteCluster.restartNodes(Collection<UUID> ids)
Restarts nodes defined by provided IDs.
|
boolean |
IgniteQueue.retainAll(Collection<?> items) |
boolean |
IgniteSet.retainAll(Collection<?> c) |
void |
IgniteCompute.run(Collection<? extends IgniteRunnable> jobs)
Executes collection of jobs on grid nodes within this grid projection.
|
void |
IgniteCompute.run(IgniteRunnable job)
Executes provided job on a node in this grid projection.
|
void |
IgniteMessaging.send(Object topic,
Collection<?> msgs)
Sends given messages with specified topic to the nodes in this projection.
|
void |
IgniteMessaging.send(Object topic,
Object msg)
Sends given message with specified topic to the nodes in this projection.
|
void |
IgniteMessaging.sendOrdered(Object topic,
Object msg,
long timeout)
Sends given message with specified topic to the nodes in this projection.
|
<T> T |
IgniteServices.serviceProxy(String name,
Class<? super T> svcItf,
boolean sticky)
Gets a remote handle on the service.
|
<T> IgniteSet<T> |
Ignite.set(String name,
CollectionConfiguration cfg)
Will get a named set from cache and create one if it has not been created yet and
cfg is not
null . |
void |
IgniteAtomicReference.set(T val)
Unconditionally sets the value.
|
void |
IgniteAtomicStamped.set(T val,
S stamp)
Unconditionally sets the value and the stamp.
|
void |
IgniteFs.setTimes(IgfsPath path,
long accessTime,
long modificationTime)
Sets last access time and last modification time for a given path.
|
int |
IgniteQueue.size() |
int |
IgniteSet.size() |
long |
IgniteFs.size(IgfsPath path)
Determines size of the file denoted by provided path.
|
S |
IgniteAtomicStamped.stamp()
Gets current stamp.
|
static Ignite |
Ignition.start()
Starts grid with default configuration.
|
static Ignite |
Ignition.start(IgniteConfiguration cfg)
Starts grid with given configuration.
|
static Ignite |
Ignition.start(String springCfgPath)
Starts all grids specified within given Spring XML configuration file.
|
static Ignite |
Ignition.start(URL springCfgUrl)
Starts all grids specified within given Spring XML configuration file URL.
|
Collection<org.apache.ignite.internal.util.lang.GridTuple3<String,Boolean,String>> |
IgniteCluster.startNodes(Collection<Map<String,Object>> hosts,
Map<String,Object> dflts,
boolean restart,
int timeout,
int maxConn)
Starts one or more nodes on remote host(s).
|
Collection<org.apache.ignite.internal.util.lang.GridTuple3<String,Boolean,String>> |
IgniteCluster.startNodes(File file,
boolean restart,
int timeout,
int maxConn)
Starts one or more nodes on remote host(s).
|
void |
IgniteCluster.stopNodes()
Stops nodes satisfying optional set of predicates.
|
void |
IgniteCluster.stopNodes(Collection<UUID> ids)
Stops nodes defined by provided IDs.
|
void |
IgniteMessaging.stopRemoteListen(UUID opId)
Unregisters all listeners identified with provided operation ID on all nodes in this projection.
|
void |
IgniteEvents.stopRemoteListen(UUID opId)
Stops listening to remote events.
|
IgfsPathSummary |
IgniteFs.summary(IgfsPath path)
Gets summary (total number of files, total number of directories and total length)
for a given path.
|
T |
IgniteQueue.take() |
Object[] |
IgniteQueue.toArray() |
Object[] |
IgniteSet.toArray() |
<T> T[] |
IgniteQueue.toArray(T[] a) |
<T1> T1[] |
IgniteSet.toArray(T1[] a) |
void |
IgniteDataLoader.tryFlush()
Makes an attempt to load remaining data.
|
void |
IgniteCompute.undeployTask(String taskName)
Makes the best attempt to undeploy a task with given name from this grid projection.
|
void |
IgniteDataLoader.Updater.update(IgniteCache<K,V> cache,
Collection<Map.Entry<K,V>> entries)
Updates cache with batch of entries.
|
T |
IgniteAtomicStamped.value()
Gets current value.
|
<T extends Event> |
IgniteEvents.waitForLocal(IgnitePredicate<T> filter,
int... types)
Waits for the specified events.
|
Modifier and Type | Method and Description |
---|---|
TransactionManager |
CacheTmLookup.getTm()
Gets Transaction Manager (TM).
|
Modifier and Type | Method and Description |
---|---|
TransactionManager |
CacheJndiTmLookup.getTm()
Gets Transaction Manager (TM).
|
Modifier and Type | Method and Description |
---|---|
TransactionManager |
CacheReflectionTmLookup.getTm()
Gets Transaction Manager (TM).
|
Modifier and Type | Method and Description |
---|---|
void |
CacheAbstractJdbcStore.start()
Starts grid component, called on grid start.
|
void |
CacheAbstractJdbcStore.stop()
Stops grid component, called on grid shutdown.
|
Modifier and Type | Class and Description |
---|---|
class |
ClusterGroupEmptyException
This exception defines illegal call on empty cluster group.
|
class |
ClusterTopologyException
This exception is used to indicate error with grid topology (e.g., crashed node, etc.).
|
Modifier and Type | Method and Description |
---|---|
ClusterMetrics |
ClusterGroup.metrics()
Gets a metrics snapshot for this projection.
|
Modifier and Type | Class and Description |
---|---|
class |
ComputeExecutionRejectedException
This exception defines execution rejection.
|
class |
ComputeJobFailoverException
This runtime exception can be thrown from
ComputeJob.execute() method to force
job failover to another node within task topology. |
class |
ComputeTaskCancelledException
This exception indicates that grid task was cancelled.
|
class |
ComputeTaskTimeoutException
This exception indicates that task execution timed out.
|
class |
ComputeUserUndeclaredException
This exception is thrown when user's code throws undeclared runtime exception.
|
Modifier and Type | Method and Description |
---|---|
IgniteException |
ComputeJobResult.getException()
Gets exception produced by execution of remote job, or
null if
remote execution finished normally and did not produce any exceptions. |
Modifier and Type | Method and Description |
---|---|
void |
ComputeJobSibling.cancel()
Sends a request to cancel this sibling.
|
Object |
ComputeJob.execute()
Executes this job.
|
ClusterNode |
ComputeLoadBalancer.getBalancedNode(ComputeJob job,
Collection<ClusterNode> exclNodes)
Gets the next balanced node according to the underlying load balancing policy.
|
ComputeJobSibling |
ComputeTaskSession.getJobSibling(IgniteUuid jobId)
Gets job sibling for a given ID.
|
Collection<ComputeJobSibling> |
ComputeTaskSession.getJobSiblings()
Gets a collection of all grid job siblings.
|
<T> T |
ComputeTaskSession.loadCheckpoint(String key)
Loads job's state previously saved via
ComputeTaskSession.saveCheckpoint(String, Object, ComputeTaskSessionScope, long)
method from an underlying storage for a given key . |
Map<? extends ComputeJob,ClusterNode> |
ComputeTask.map(List<ClusterNode> subgrid,
T arg)
This method is called to map or split grid task into multiple grid jobs.
|
void |
ComputeJobMasterLeaveAware.onMasterNodeLeft(ComputeTaskSession ses)
A method which is executed in case master node has left topology during job execution.
|
R |
ComputeTask.reduce(List<ComputeJobResult> results)
Reduces (or aggregates) results received so far into one compound result to be returned to
caller via
ComputeTaskFuture.get() method. |
Collection<ComputeJobSibling> |
ComputeTaskSession.refreshJobSiblings()
Refreshes collection of job siblings.
|
boolean |
ComputeTaskSession.removeCheckpoint(String key)
Removes previously saved job's state for a given
key from an underlying storage. |
ComputeJobResultPolicy |
ComputeTask.result(ComputeJobResult res,
List<ComputeJobResult> rcvd)
Asynchronous callback invoked every time a result from remote execution is
received.
|
ComputeJobResultPolicy |
ComputeTaskAdapter.result(ComputeJobResult res,
List<ComputeJobResult> rcvd)
Default implementation which will wait for all jobs to complete before
calling
ComputeTask.reduce(List) method. |
void |
ComputeTaskSession.saveCheckpoint(String key,
Object state)
Saves intermediate state of a job or task to a storage.
|
void |
ComputeTaskSession.saveCheckpoint(String key,
Object state,
ComputeTaskSessionScope scope,
long timeout)
Saves intermediate state of a job to a storage.
|
void |
ComputeTaskSession.saveCheckpoint(String key,
Object state,
ComputeTaskSessionScope scope,
long timeout,
boolean overwrite)
Saves intermediate state of a job or task to a storage.
|
void |
ComputeTaskContinuousMapper.send(Collection<? extends ComputeJob> jobs)
Sends collection of jobs to nodes automatically picked by the underlying load balancer.
|
void |
ComputeTaskContinuousMapper.send(ComputeJob job)
Sends job to a node automatically picked by the underlying load balancer.
|
void |
ComputeTaskContinuousMapper.send(ComputeJob job,
ClusterNode node)
Sends given job to a specific grid node.
|
void |
ComputeTaskContinuousMapper.send(Map<? extends ComputeJob,ClusterNode> mappedJobs)
Sends collection of grid jobs to assigned nodes.
|
void |
ComputeTaskSession.setAttribute(Object key,
Object val)
Sets session attributed.
|
void |
ComputeTaskSession.setAttributes(Map<?,?> attrs)
Sets task attributes.
|
protected abstract Collection<? extends ComputeJob> |
ComputeTaskSplitAdapter.split(int gridSize,
T arg)
This is a simplified version of
ComputeTask.map(List, Object) method. |
Modifier and Type | Class and Description |
---|---|
class |
GridifyRuntimeException
This defines gridify exception.
|
Modifier and Type | Class and Description |
---|---|
class |
IgfsConcurrentModificationException
IGFS exception indicating that file system structure was modified concurrently. |
class |
IgfsCorruptedFileException
Exception thrown when target file's block is not found in data cache.
|
class |
IgfsException
IGFS exception thrown by file system components. |
class |
IgfsFileNotFoundException
IGFS exception indicating that target resource is not found. |
class |
IgfsInvalidHdfsVersionException
Exception thrown when Ignite detects that remote HDFS version differs from version of HDFS libraries
in Ignite classpath.
|
class |
IgfsInvalidPathException
IGFS exception indicating that operation target is invalid
(e.g. not a file while expecting to be a file). |
class |
IgfsOutOfSpaceException
IGFS exception that is thrown when it detected out-of-space condition. |
class |
IgfsParentNotDirectoryException
Exception thrown when parent supposed to be a directory is a file.
|
class |
IgfsPathAlreadyExistsException
Exception thrown when target path supposed to be created already exists.
|
Modifier and Type | Method and Description |
---|---|
OutputStream |
Igfs.append(IgfsPath path,
int bufSize,
boolean create,
Map<String,String> props)
Opens an output stream to an existing file for appending data.
|
OutputStream |
Igfs.create(IgfsPath path,
boolean overwrite)
Creates a file and opens it for writing.
|
OutputStream |
Igfs.create(IgfsPath path,
int bufSize,
boolean overwrite,
int replication,
long blockSize,
Map<String,String> props)
Creates a file and opens it for writing.
|
boolean |
Igfs.delete(IgfsPath path,
boolean recursive)
Deletes file.
|
IgfsFile |
Igfs.info(IgfsPath path)
Gets file information for the specified path.
|
Collection<IgfsFile> |
Igfs.listFiles(IgfsPath path)
Lists files under the specified path.
|
Collection<IgfsPath> |
Igfs.listPaths(IgfsPath path)
Lists file paths under the specified path.
|
void |
Igfs.mkdirs(IgfsPath path)
Creates directories under specified path.
|
void |
Igfs.mkdirs(IgfsPath path,
Map<String,String> props)
Creates directories under specified path with the specified properties.
|
IgfsReader |
Igfs.open(IgfsPath path,
int bufSize)
Opens a file for reading.
|
void |
Igfs.rename(IgfsPath src,
IgfsPath dest)
Renames/moves a file.
|
IgfsFile |
Igfs.update(IgfsPath path,
Map<String,String> props)
Updates file information for the specified path.
|
long |
Igfs.usedSpaceSize()
Gets used space in bytes.
|
Modifier and Type | Method and Description |
---|---|
abstract IgfsJob |
IgfsTask.createJob(IgfsPath path,
IgfsFileRange range,
IgfsTaskArgs<T> args)
Callback invoked during task map procedure to create job that will process specified split
for IGFS file.
|
Object |
IgfsJob.execute(IgniteFs igfs,
IgfsFileRange range,
IgfsInputStream in)
Executes this job.
|
Object |
IgfsInputStreamJobAdapter.execute(IgniteFs igfs,
IgfsFileRange range,
IgfsInputStream in)
Executes this job.
|
abstract Object |
IgfsInputStreamJobAdapter.execute(IgniteFs igfs,
IgfsRangeInputStream in)
Executes this job.
|
IgfsFileRange |
IgfsRecordResolver.resolveRecords(IgniteFs fs,
IgfsInputStream stream,
IgfsFileRange suggestedRecord)
Adjusts record start offset and length.
|
Modifier and Type | Method and Description |
---|---|
IgfsFileRange |
IgfsByteDelimiterRecordResolver.resolveRecords(IgniteFs fs,
IgfsInputStream stream,
IgfsFileRange suggestedRecord)
Adjusts record start offset and length.
|
IgfsFileRange |
IgfsFixedLengthRecordResolver.resolveRecords(IgniteFs fs,
IgfsInputStream stream,
IgfsFileRange suggestedRecord)
Adjusts record start offset and length.
|
Modifier and Type | Class and Description |
---|---|
class |
IgniteFutureCancelledException
Future computation cannot be retrieved because it was cancelled.
|
class |
IgniteFutureTimeoutException
Future computation completion is timed out.
|
Modifier and Type | Method and Description |
---|---|
boolean |
IgniteFuture.cancel()
Cancels this future.
|
V |
IgniteFuture.get()
Synchronously waits for completion of the computation and
returns computation result.
|
V |
IgniteFuture.get(long timeout)
Synchronously waits for completion of the computation for
up to the timeout specified and returns computation result.
|
V |
IgniteFuture.get(long timeout,
TimeUnit unit)
Synchronously waits for completion of the computation for
up to the timeout specified and returns computation result.
|
Modifier and Type | Method and Description |
---|---|
void |
LifecycleBean.onLifecycleEvent(LifecycleEventType evt)
This method is called when lifecycle event occurs.
|
void |
LifecycleAware.start()
Starts grid component, called on grid start.
|
void |
LifecycleAware.stop()
Stops grid component, called on grid shutdown.
|
Modifier and Type | Method and Description |
---|---|
protected void |
MessagingListenActor.respond(Object respMsg)
Responds to the original sender node with given message and continues to listen for the new messages.
|
protected void |
MessagingListenActor.respond(UUID id,
Object respMsg)
Responds to the provided node with given message and continues to listen for the new messages.
|
protected void |
MessagingListenActor.stop(Object respMsg)
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.
|
Modifier and Type | Class and Description |
---|---|
class |
PluginNotFoundException
Exception thrown if plugin is not found.
|
class |
PluginValidationException
TODO: Add class description.
|
Modifier and Type | Class and Description |
---|---|
class |
GridSecurityException
Common security exception for the grid.
|
Modifier and Type | Method and Description |
---|---|
R |
SchedulerFuture.last()
Gets result of the last execution of scheduled task, or
null if task has not been executed, or has not
produced a result yet. |
long |
SchedulerFuture.nextExecutionTime()
Gets next execution time of scheduled task.
|
long[] |
SchedulerFuture.nextExecutionTimes(int cnt,
long start)
Gets an array of the next execution times after passed
start timestamp. |
Modifier and Type | Class and Description |
---|---|
class |
IgniteSpiException
Exception thrown by SPI implementations.
|
class |
IgniteSpiMultiException
Grid SPI exception which may contain more than one failure.
|
class |
IgniteSpiVersionCheckException
Grid SPI exception for version check failure.
|
Modifier and Type | Method and Description |
---|---|
GridSecuritySubject |
IgniteSpiContext.authenticatedSubject(UUID subjId)
Gets security subject based on subject ID.
|
Collection<GridSecuritySubject> |
IgniteSpiContext.authenticatedSubjects()
Gets collection of authenticated subjects together with their permissions.
|
<T> T |
IgniteSpiContext.readFromOffheap(String spaceName,
int part,
Object key,
byte[] keyBytes,
ClassLoader ldr)
Reads object from off-heap.
|
<T> T |
IgniteSpiContext.readFromSwap(String spaceName,
SwapKey key,
ClassLoader ldr)
Reads object from swap.
|
<T> T |
IgniteSpiContext.readValueFromOffheapAndSwap(String spaceName,
Object key,
ClassLoader ldr)
Reads swapped cache value from off-heap and swap.
|
boolean |
IgniteSpiContext.removeFromOffheap(String spaceName,
int part,
Object key,
byte[] keyBytes)
Removes data from off-heap memory.
|
void |
IgniteSpiContext.removeFromSwap(String spaceName,
Object key,
ClassLoader ldr)
Removes object from swap.
|
void |
IgniteSpiContext.writeToOffheap(String spaceName,
int part,
Object key,
byte[] keyBytes,
Object val,
byte[] valBytes,
ClassLoader ldr)
Writes data to off-heap memory.
|
void |
IgniteSpiContext.writeToSwap(String spaceName,
Object key,
Object val,
ClassLoader ldr)
Writes object to swap.
|
Modifier and Type | Method and Description |
---|---|
org.apache.ignite.internal.processors.security.GridSecurityContext |
DiscoverySpiNodeAuthenticator.authenticateNode(ClusterNode node,
GridSecurityCredentials cred)
Security credentials.
|
Modifier and Type | Method and Description |
---|---|
ClusterNode |
FailoverContext.getBalancedNode(List<ClusterNode> top)
Gets the next balanced node for failed job.
|
Modifier and Type | Method and Description |
---|---|
ClusterNode |
LoadBalancingSpi.getBalancedNode(ComputeTaskSession ses,
List<ClusterNode> top,
ComputeJob job)
Gets balanced node for specified job within given task session.
|
Modifier and Type | Method and Description |
---|---|
void |
StreamerContext.broadcast(IgniteInClosure<StreamerContext> clo)
Queries all streamer nodes deployed within grid.
|
void |
StreamerContext.broadcast(IgniteInClosure<StreamerContext> clo,
Collection<ClusterNode> nodes)
Queries streamer nodes deployed within grid.
|
void |
StreamerWindow.clearEvicted()
Clears all evicted entries.
|
E |
StreamerWindow.dequeue()
Dequeues last element from windows.
|
Collection<E> |
StreamerWindow.dequeue(int cnt)
Dequeues up to
cnt elements from window. |
Collection<E> |
StreamerWindow.dequeueAll()
Dequeues all elements from window.
|
boolean |
StreamerWindow.enqueue(E... evts)
Adds events to window.
|
boolean |
StreamerWindow.enqueue(E evt)
Adds single event to window.
|
boolean |
StreamerWindow.enqueueAll(Collection<E> evts)
Adds all events to window.
|
E |
StreamerWindow.pollEvicted()
If window supports eviction, this method will return next evicted element.
|
Collection<E> |
StreamerWindow.pollEvicted(int cnt)
If window supports eviction, this method will return up to
cnt evicted elements. |
Collection<E> |
StreamerWindow.pollEvictedAll()
If window supports eviction, this method will return all available evicted elements.
|
Collection<E> |
StreamerWindow.pollEvictedBatch()
If window supports batch eviction, this method will poll next evicted batch from window.
|
<R> Collection<R> |
StreamerContext.query(IgniteClosure<StreamerContext,R> clo)
Queries all streamer nodes deployed within grid.
|
<R> Collection<R> |
StreamerContext.query(IgniteClosure<StreamerContext,R> clo,
Collection<ClusterNode> nodes)
Queries streamer nodes deployed within grid.
|
<R1,R2> R2 |
StreamerContext.reduce(IgniteClosure<StreamerContext,R1> clo,
IgniteReducer<R1,R2> rdc)
Queries all streamer nodes deployed within grid.
|
<R1,R2> R2 |
StreamerContext.reduce(IgniteClosure<StreamerContext,R1> clo,
IgniteReducer<R1,R2> rdc,
Collection<ClusterNode> nodes)
Queries streamer nodes deployed within grid.
|
Map<String,Collection<?>> |
StreamerStage.run(StreamerContext ctx,
Collection<IN> evts)
Stage execution routine.
|
Modifier and Type | Method and Description |
---|---|
protected abstract void |
StreamerIndexProviderAdapter.add(E evt,
K key,
StreamerIndexUpdateSync sync)
Add event to the index.
|
void |
StreamerIndexProvider.add(StreamerIndexUpdateSync sync,
E evt)
Adds an event to index.
|
protected void |
StreamerIndexProviderAdapter.lockIndexKey(StreamerIndexProviderAdapter.IndexKey<V> key,
StreamerIndexUpdateSync sync)
Lock updates on particular key.
|
V |
StreamerIndexUpdater.onAdded(StreamerIndexEntry<E,K,V> entry,
E evt)
Callback invoked whenever an event is being added to the window.
|
protected abstract void |
StreamerIndexProviderAdapter.remove(E evt,
K key,
StreamerIndexUpdateSync sync)
Remove event from the index.
|
void |
StreamerIndexProvider.remove(StreamerIndexUpdateSync sync,
E evt)
Removes an event from index.
|
Modifier and Type | Method and Description |
---|---|
protected abstract void |
StreamerWindowAdapter.checkConfiguration()
Check window configuration.
|
protected void |
StreamerWindowAdapter.updateIndexes(E evt,
boolean rmv)
Update indexes.
|
Modifier and Type | Class and Description |
---|---|
class |
TransactionHeuristicException
Exception thrown whenever grid transaction enters an unknown state.
|
class |
TransactionOptimisticException
Exception thrown whenever grid transactions fail optimistically.
|
class |
TransactionRollbackException
Exception thrown whenever grid transactions has been automatically rolled back.
|
class |
TransactionTimeoutException
Exception thrown whenever grid transactions time out.
|
Modifier and Type | Method and Description |
---|---|
void |
Transaction.close()
Ends the transaction.
|
void |
Transaction.commit()
Commits this transaction by initiating
two-phase-commit process. |
void |
Transaction.rollback()
Rolls back this transaction.
|
Follow @ApacheIgnite
Apache Ignite Fabric : ver. 1.0.0-RC1 Release Date : February 16 2015