You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ignite.apache.org by vk...@apache.org on 2015/03/04 02:31:31 UTC

[01/50] [abbrv] incubator-ignite git commit: # sprint-1 minor

Repository: incubator-ignite
Updated Branches:
  refs/heads/master afd26f21b -> 8e37cef42


# sprint-1 minor


Project: http://git-wip-us.apache.org/repos/asf/incubator-ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-ignite/commit/4ffb6dba
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/4ffb6dba
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/4ffb6dba

Branch: refs/heads/master
Commit: 4ffb6dba0f2ddfab75a57500c61dc39ef4351d6f
Parents: bbf5163
Author: sboikov <sb...@gridgain.com>
Authored: Mon Feb 16 13:42:50 2015 +0300
Committer: sboikov <sb...@gridgain.com>
Committed: Mon Feb 16 13:42:50 2015 +0300

----------------------------------------------------------------------
 .../cache/distributed/dht/atomic/GridDhtAtomicCache.java           | 2 +-
 .../processors/cache/transactions/IgniteTxLocalAdapter.java        | 2 +-
 2 files changed, 2 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/4ffb6dba/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/atomic/GridDhtAtomicCache.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/atomic/GridDhtAtomicCache.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/atomic/GridDhtAtomicCache.java
index 2a8a2c7..b90d78e 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/atomic/GridDhtAtomicCache.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/atomic/GridDhtAtomicCache.java
@@ -1978,7 +1978,7 @@ public class GridDhtAtomicCache<K, V> extends GridDhtCacheAdapter<K, V> {
                             assert op == DELETE : op;
 
                             // Old value should be already loaded for 'CacheInterceptor.onBeforeRemove'.
-                            ctx.config().<K, V>getInterceptor().onAfterRemove(entry.key(), updRes.oldValue());
+                            ctx.config().getInterceptor().onAfterRemove(entry.key(), updRes.oldValue());
                         }
                     }
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/4ffb6dba/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/transactions/IgniteTxLocalAdapter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/transactions/IgniteTxLocalAdapter.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/transactions/IgniteTxLocalAdapter.java
index 0856f67..8ffe224 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/transactions/IgniteTxLocalAdapter.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/transactions/IgniteTxLocalAdapter.java
@@ -577,7 +577,7 @@ public abstract class IgniteTxLocalAdapter<K, V> extends IgniteTxAdapter<K, V>
                             if (intercept) {
                                 V old = e.cached().rawGetOrUnmarshal(true);
 
-                                IgniteBiTuple<Boolean, V> t = cacheCtx.config().<K, V>getInterceptor()
+                                IgniteBiTuple<Boolean, V> t = cacheCtx.config().getInterceptor()
                                     .onBeforeRemove(key, old);
 
                                 if (cacheCtx.cancelRemove(t))


[33/50] [abbrv] incubator-ignite git commit: sprint-1: moved cache projection to internal

Posted by vk...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f27a989c/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/CacheProjection.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/CacheProjection.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/CacheProjection.java
new file mode 100644
index 0000000..9a57d8e
--- /dev/null
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/CacheProjection.java
@@ -0,0 +1,1925 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+package org.apache.ignite.internal.processors.cache;
+
+import org.apache.ignite.*;
+import org.apache.ignite.cache.*;
+import org.apache.ignite.cache.store.*;
+import org.apache.ignite.cluster.*;
+import org.apache.ignite.internal.*;
+import org.apache.ignite.internal.processors.cache.query.*;
+import org.apache.ignite.internal.processors.cache.transactions.*;
+import org.apache.ignite.lang.*;
+import org.apache.ignite.transactions.*;
+import org.jetbrains.annotations.*;
+
+import javax.cache.*;
+import java.sql.*;
+import java.util.*;
+import java.util.Date;
+import java.util.concurrent.*;
+
+/**
+ * This interface provides a rich API for working with distributed caches. It includes the following
+ * main functionality:
+ * <ul>
+ * <li>
+ *  Various {@code 'get(..)'} methods to synchronously or asynchronously get values from cache.
+ *  All {@code 'get(..)'} methods are transactional and will participate in an ongoing transaction
+ *  if there is one.
+ * </li>
+ * <li>
+ *  Various {@code 'put(..)'}, {@code 'putIfAbsent(..)'}, and {@code 'replace(..)'} methods to
+ *  synchronously or asynchronously put single or multiple entries into cache.
+ *  All these methods are transactional and will participate in an ongoing transaction
+ *  if there is one.
+ * </li>
+ * <li>
+ *  Various {@code 'remove(..)'} methods to synchronously or asynchronously remove single or multiple keys
+ *  from cache. All {@code 'remove(..)'} methods are transactional and will participate in an ongoing transaction
+ *  if there is one.
+ * </li>
+ * <li>
+ *  Various {@code 'contains(..)'} method to check if cache contains certain keys or values locally.
+ * </li>
+ * <li>
+ *  Various {@code 'forEach(..)'}, {@code 'forAny(..)'}, and {@code 'reduce(..)'} methods to visit
+ *  every local cache entry within this projection.
+ * </li>
+ * <li>
+ *  Various {@code flagsOn(..)'}, {@code 'flagsOff(..)'}, and {@code 'projection(..)'} methods to
+ *  set specific flags and filters on a cache projection.
+ * </li>
+ * <li>
+ *  Methods like {@code 'keySet(..)'}, {@code 'values(..)'}, and {@code 'entrySet(..)'} to provide
+ *  views on cache keys, values, and entries.
+ * </li>
+ * <li>
+ *  Various {@code 'peek(..)'} methods to peek at values in global or transactional memory, swap
+ *  storage, or persistent storage.
+ * </li>
+ * <li>
+ *  Various {@code 'reload(..)'} methods to reload latest values from persistent storage.
+ * </li>
+ * <li>
+ *  Various {@code 'promote(..)'} methods to load specified keys from swap storage into
+ *  global cache memory.
+ * </li>
+ * <li>
+ *  Various {@code 'lock(..)'}, {@code 'unlock(..)'}, and {@code 'isLocked(..)'} methods to acquire, release,
+ *  and check on distributed locks on a single or multiple keys in cache. All locking methods
+ *  are not transactional and will not enlist keys into ongoing transaction, if any.
+ * </li>
+ * <li>
+ *  Various {@code 'clear(..)'} methods to clear elements from cache, and optionally from
+ *  swap storage. All {@code 'clear(..)'} methods are not transactional and will not enlist cleared
+ *  keys into ongoing transaction, if any.
+ * </li>
+ * <li>
+ *  Various {@code 'evict(..)'} methods to evict elements from cache, and optionally store
+ *  them in underlying swap storage for later access. All {@code 'evict(..)'} methods are not
+ *  transactional and will not enlist evicted keys into ongoing transaction, if any.
+ * </li>
+ * <li>
+ *  Various {@code 'txStart(..)'} methods to perform various cache
+ *  operations within a transaction (see {@link Transaction} for more information).
+ * </li>
+ * <li>
+ *  {@link #queries()} method to get an instance of {@link CacheQueries} service for working
+ *  with distributed cache queries.
+ * </li>
+ * <li>
+ *  Various {@code 'gridProjection(..)'} methods which provide {@link org.apache.ignite.cluster.ClusterGroup} only
+ *  for nodes on which given keys reside. All {@code 'gridProjection(..)'} methods are not
+ *  transactional and will not enlist keys into ongoing transaction.
+ * </li>
+ * <li>Method {@link GridCache#toMap()} to convert this interface into standard Java {@link ConcurrentMap} interface.
+ * </ul>
+ * <h1 class="header">Extended Put And Remove Methods</h1>
+ * All methods that end with {@code 'x'} provide the same functionality as their sibling
+ * methods that don't end with {@code 'x'}, however instead of returning a previous value they
+ * return a {@code boolean} flag indicating whether operation succeeded or not. Returning
+ * a previous value may involve a network trip or a persistent store lookup and should be
+ * avoided whenever not needed.
+ * <h1 class="header">Predicate Filters</h1>
+ * All filters passed into methods on this API are checked <b>atomically</b>. In other words the
+ * value returned by the methods is guaranteed to be consistent with the filters passed in. Note
+ * that filters are optional, and if not passed in, then methods will still work as is without
+ * filter validation.
+ * <h1 class="header">Transactions</h1>
+ * Cache API supports distributed transactions. All {@code 'get(..)'}, {@code 'put(..)'}, {@code 'replace(..)'},
+ * and {@code 'remove(..)'} operations are transactional and will participate in an ongoing transaction,
+ * if any. Other methods like {@code 'peek(..)'} or various {@code 'contains(..)'} methods may
+ * be transaction-aware, i.e. check in-transaction entries first, but will not affect the current
+ * state of transaction. See {@link Transaction} documentation for more information
+ * about transactions.
+ * <h1 class="header">Group Locking</h1>
+ * <i>Group Locking</i> is a feature where instead of acquiring individual locks, Ignite will lock
+ * multiple keys with one lock to save on locking overhead. There are 2 types of <i>Group Locking</i>:
+ * <i>affinity-based</i>, and <i>partitioned-based</i>.
+ * <p>
+ * With {@code affinity-based-group-locking} the keys are grouped by <i>affinity-key</i>. This means that
+ * only keys with identical affinity-key (see {@link org.apache.ignite.cache.affinity.CacheAffinityKeyMapped}) can participate in the
+ * transaction, and only one lock on the <i>affinity-key</i> will be acquired for the whole transaction.
+ * {@code Affinity-group-locked} transactions are started via
+ * {@link #txStartAffinity(Object, TransactionConcurrency, TransactionIsolation, long, int)} method.
+ * <p>
+ * With {@code partition-based-group-locking} the keys are grouped by partition ID. This means that
+ * only keys belonging to identical partition (see {@link org.apache.ignite.cache.affinity.CacheAffinity#partition(Object)}) can participate in the
+ * transaction, and only one lock on the whole partition will be acquired for the whole transaction.
+ * {@code Partition-group-locked} transactions are started via
+ * {@link #txStartPartition(int, TransactionConcurrency, TransactionIsolation, long, int)} method.
+ * <p>
+ * <i>Group locking</i> should always be used for transactions whenever possible. If your requirements fit either
+ * <i>affinity-based</i> or <i>partition-based</i> scenarios outlined above then <i>group-locking</i>
+ * can significantly improve performance of your application, often by an order of magnitude.
+ * <h1 class="header">Null Keys or Values</h1>
+ * Neither {@code null} keys or values are allowed to be stored in cache. If a {@code null} value
+ * happens to be in cache (e.g. after invalidation or remove), then cache will treat this case
+ * as there is no value at all.
+ * <h1 class="header">Peer Class Loading</h1>
+ * If peer-class-loading is enabled, all classes passed into cache API will be automatically deployed
+ * to any participating grid nodes. However, in case of redeployment, caches will be cleared and
+ * all entries will be removed. This behavior is useful during development, but should not be
+ * used in production.
+ * <h1 class="header">Portable Objects</h1>
+ * If an object is defined as portable Ignite cache will automatically store it in portable (i.e. binary)
+ * format. User can choose to work either with the portable format or with the deserialized form (assuming
+ * that class definitions are present in the classpath). By default, cache works with deserialized form
+ * (example shows the case when {@link Integer} is used as a key for a portable object):
+ * <pre>
+ * CacheProjection<Integer, Value> prj = Ignition.grid().cache(null);
+ *
+ * // Value will be serialized and stored in cache in portable format.
+ * prj.put(1, new Value());
+ *
+ * // Value will be deserialized since it's stored in portable format.
+ * Value val = prj.get(1);
+ * </pre>
+ * You won't be able to work with deserialized form if class definition for the {@code Value} is not on
+ * classpath. Even if you have the class definition, you should always avoid full deserialization if it's not
+ * needed for performance reasons. To work with portable format directly you should create special projection
+ * using {@link #keepPortable()} method:
+ * <pre>
+ * CacheProjection<Integer, GridPortableObject> prj = Ignition.grid().cache(null).keepPortable();
+ *
+ * // Value is not deserialized and returned in portable format.
+ * GridPortableObject po = prj.get(1);
+ * </pre>
+ * See {@link #keepPortable()} method JavaDoc for more details.
+ */
+public interface CacheProjection<K, V> extends Iterable<Cache.Entry<K, V>> {
+    /**
+     * Gets name of this cache ({@code null} for default cache).
+     *
+     * @return Cache name.
+     */
+    public String name();
+
+    /**
+     * Gets grid projection for this cache. This projection includes all nodes which have this cache configured.
+     *
+     * @return Projection instance.
+     */
+    public ClusterGroup gridProjection();
+
+    /**
+     * Gets base cache for this projection.
+     *
+     * @param <K1> Cache key type.
+     * @param <V1> Cache value type.
+     * @return Base cache for this projection.
+     */
+    @SuppressWarnings({"ClassReferencesSubclass"})
+    public <K1, V1> GridCache<K1, V1> cache();
+
+    /**
+     * Gets cache flags enabled on this projection.
+     *
+     * @return Flags for this projection (empty set if no flags have been set).
+     */
+    public Set<CacheFlag> flags();
+
+    /**
+     * Returns queries facade responsible for creating various SQL, TEXT, or SCAN queries.
+
+     * @return Queries facade responsible for creating various SQL, TEXT, or SCAN queries.
+     */
+    public CacheQueries<K, V> queries();
+
+    /**
+     * Gets cache projection only for given key and value type. Only {@code non-null} key-value
+     * pairs that have matching key and value pairs will be used in this projection.
+     *
+     * @param keyType Key type.
+     * @param valType Value type.
+     * @param <K1> Key type.
+     * @param <V1> Value type.
+     * @return Cache projection for given key and value types.
+     */
+    public <K1, V1> CacheProjection<K1, V1> projection(Class<? super K1> keyType, Class<? super V1> valType);
+
+    /**
+     * Gets cache projection based on given key-value predicate. Whenever makes sense,
+     * this predicate will be used to pre-filter cache operations. If
+     * operation passed pre-filtering, this filter will be passed through
+     * to cache operations as well.
+     * <p>
+     * For example, for {@link #putAll(Map, org.apache.ignite.lang.IgnitePredicate[])} method only
+     * elements that pass the filter will be given to {@code Cache.putAll(m, filter)}
+     * where it will be checked once again prior to put.
+     *
+     * @param p Key-value predicate for this projection. If {@code null}, then the
+     *      same projection is returned.
+     * @return Projection for given key-value predicate.
+     */
+    public CacheProjection<K, V> projection(@Nullable IgniteBiPredicate<K, V> p);
+
+    /**
+     * Gets cache projection based on given entry filter. This filter will be simply passed through
+     * to all cache operations on this projection. Unlike {@link #projection(org.apache.ignite.lang.IgniteBiPredicate)}
+     * method, this filter will <b>not</b> be used for pre-filtering.
+     *
+     * @param filter Filter to be passed through to all cache operations. If {@code null}, then the
+     *      same projection is returned.  If cache operation receives its own filter, then filters
+     *      will be {@code 'anded'}.
+     * @return Projection based on given filter.
+     */
+    public CacheProjection<K, V> projection(@Nullable IgnitePredicate<Cache.Entry<K, V>> filter);
+
+    /**
+     * Gets cache projection base on this one, but with the specified flags turned on.
+     * <h1 class="header">Cache Flags</h1>
+     * The resulting projection will inherit all the flags from this projection.
+     *
+     * @param flags Flags to turn on (if empty, then no-op).
+     * @return New projection based on this one, but with the specified flags turned on.
+     */
+    public CacheProjection<K, V> flagsOn(@Nullable CacheFlag... flags);
+
+    /**
+     * Gets cache projection base on this but with the specified flags turned off.
+     * <h1 class="header">Cache Flags</h1>
+     * The resulting projection will inherit all the flags from this projection except for
+     * the ones that were turned off.
+     *
+     * @param flags Flags to turn off (if empty, then all flags will be turned off).
+     * @return New projection based on this one, but with the specified flags turned off.
+     */
+    public CacheProjection<K, V> flagsOff(@Nullable CacheFlag... flags);
+
+    /**
+     * Creates projection that will operate with portable objects.
+     * <p>
+     * Projection returned by this method will force cache not to deserialize portable objects,
+     * so keys and values will be returned from cache API methods without changes. Therefore,
+     * signature of the projection can contain only following types:
+     * <ul>
+     *     <li>{@link org.gridgain.grid.portables.PortableObject} for portable classes</li>
+     *     <li>All primitives (byte, int, ...) and there boxed versions (Byte, Integer, ...)</li>
+     *     <li>Arrays of primitives (byte[], int[], ...)</li>
+     *     <li>{@link String} and array of {@link String}s</li>
+     *     <li>{@link UUID} and array of {@link UUID}s</li>
+     *     <li>{@link Date} and array of {@link Date}s</li>
+     *     <li>{@link Timestamp} and array of {@link Timestamp}s</li>
+     *     <li>Enums and array of enums</li>
+     *     <li>
+     *         Maps, collections and array of objects (but objects inside
+     *         them will still be converted if they are portable)
+     *     </li>
+     * </ul>
+     * <p>
+     * For example, if you use {@link Integer} as a key and {@code Value} class as a value
+     * (which will be stored in portable format), you should acquire following projection
+     * to avoid deserialization:
+     * <pre>
+     * CacheProjection<Integer, GridPortableObject> prj = cache.keepPortable();
+     *
+     * // Value is not deserialized and returned in portable format.
+     * GridPortableObject po = prj.get(1);
+     * </pre>
+     * <p>
+     * Note that this method makes sense only if cache is working in portable mode
+     * ({@link org.apache.ignite.configuration.CacheConfiguration#isPortableEnabled()} returns {@code true}. If not,
+     * this method is no-op and will return current projection.
+     *
+     * @return Projection for portable objects.
+     */
+    public <K1, V1> CacheProjection<K1, V1> keepPortable();
+
+    /**
+     * Returns {@code true} if this map contains no key-value mappings.
+     *
+     * @return {@code true} if this map contains no key-value mappings.
+     */
+    public boolean isEmpty();
+
+    /**
+     * Converts this API into standard Java {@link ConcurrentMap} interface.
+     *
+     * @return {@link ConcurrentMap} representation of given cache projection.
+     */
+    public ConcurrentMap<K, V> toMap();
+
+    /**
+     * @param key Key.
+     * @return {@code True} if cache contains mapping for a given key.
+     */
+    public boolean containsKey(K key);
+
+    /**
+     * @param key Key.
+     * @return Future.
+     */
+    public IgniteInternalFuture<Boolean> containsKeyAsync(K key);
+
+    /**
+     * @param keys Keys,
+     * @return {@code True} if cache contains all keys.
+     */
+    public boolean containsKeys(Collection<? extends K> keys);
+
+    /**
+     * @param keys Keys to check.
+     * @return Future.
+     */
+    public IgniteInternalFuture<Boolean> containsKeysAsync(Collection<? extends K> keys);
+
+    /**
+     * Returns {@code true} if this cache contains given value.
+     *
+     * @param val Value to check.
+     * @return {@code True} if given value is present in cache.
+     * @throws NullPointerException if the value is {@code null}.
+     */
+    public boolean containsValue(V val);
+
+    /**
+     * Executes visitor closure on each cache element.
+     * <h2 class="header">Transactions</h2>
+     * This method is not transactional and will not enlist keys into transaction simply
+     * because they were visited. However, if you perform transactional operations on the
+     * visited entries, those operations will enlist the entry into transaction.
+     *
+     * @param vis Closure which will be invoked for each cache entry.
+     */
+    public void forEach(IgniteInClosure<Cache.Entry<K, V>> vis);
+
+    /**
+     * Tests whether the predicate holds for all entries. If cache is empty,
+     * then {@code true} is returned.
+     * <h2 class="header">Transactions</h2>
+     * This method is not transactional and will not enlist keys into transaction simply
+     * because they were visited. However, if you perform transactional operations on the
+     * visited entries, those operations will enlist the entry into transaction.
+     *
+     * @param vis Predicate to test for each cache entry.
+     * @return {@code True} if the given predicate holds for all visited entries, {@code false} otherwise.
+     */
+    public boolean forAll(IgnitePredicate<Cache.Entry<K, V>> vis);
+
+    /**
+     * Reloads a single key from persistent storage. This method
+     * delegates to {@link CacheStore#load(Transaction, Object)}
+     * method.
+     * <h2 class="header">Transactions</h2>
+     * This method does not participate in transactions, however it does not violate
+     * cache integrity and can be used safely with or without transactions.
+     *
+     * @param key Key to reload.
+     * @return Reloaded value or current value if entry was updated while reloading.
+     * @throws IgniteCheckedException If reloading failed.
+     */
+    @Nullable public V reload(K key) throws IgniteCheckedException;
+
+    /**
+     * Asynchronously reloads a single key from persistent storage. This method
+     * delegates to {@link CacheStore#load(Transaction, Object)}
+     * method.
+     * <h2 class="header">Transactions</h2>
+     * This method does not participate in transactions, however it does not violate
+     * cache integrity and can be used safely with or without transactions.
+     *
+     * @param key Key to reload.
+     * @return Future to be completed whenever the entry is reloaded.
+     */
+    public IgniteInternalFuture<V> reloadAsync(K key);
+
+    /**
+     * Reloads all currently cached keys form persistent storage.
+     * <h2 class="header">Transactions</h2>
+     * This method does not participate in transactions, however it does not violate
+     * cache integrity and can be used safely with or without transactions.
+     *
+     * @throws IgniteCheckedException If reloading failed.
+     */
+    public void reloadAll() throws IgniteCheckedException;
+
+    /**
+     * Asynchronously reloads all specified entries from underlying
+     * persistent storage.
+     * <h2 class="header">Transactions</h2>
+     * This method does not participate in transactions, however it does not violate
+     * cache integrity and can be used safely with or without transactions.
+     *
+     * @return Future which will complete whenever {@code reload} completes.
+     */
+    public IgniteInternalFuture<?> reloadAllAsync();
+
+    /**
+     * Reloads specified entries from underlying persistent storage.
+     * <h2 class="header">Transactions</h2>
+     * This method does not participate in transactions, however it does not violate
+     * cache integrity and can be used safely with or without transactions.
+     *
+     * @param keys Keys to reload.
+     * @throws IgniteCheckedException if reloading failed.
+     */
+    public void reloadAll(@Nullable Collection<? extends K> keys) throws IgniteCheckedException;
+
+    /**
+     * Asynchronously reloads all specified entries from underlying
+     * persistent storage.
+     * <h2 class="header">Transactions</h2>
+     * This method does not participate in transactions, however it does not violate
+     * cache integrity and can be used safely with or without transactions.
+     *
+     * @param keys Keys to reload.
+     * @return Future which will complete whenever {@code reload} completes.
+     */
+    public IgniteInternalFuture<?> reloadAllAsync(@Nullable Collection<? extends K> keys);
+
+    /**
+     * Peeks at in-memory cached value using default {@link GridCachePeekMode#SMART}
+     * peek mode.
+     * <p>
+     * This method will not load value from any persistent store or from a remote node.
+     * <h2 class="header">Transactions</h2>
+     * This method does not participate in any transactions, however, it will
+     * peek at transactional value according to the {@link GridCachePeekMode#SMART} mode
+     * semantics. If you need to look at global cached value even from within transaction,
+     * you can use {@link GridCache#peek(Object, Collection)} method.
+     *
+     * @param key Entry key.
+     * @return Peeked value.
+     * @throws NullPointerException If key is {@code null}.
+     */
+    @Nullable public V peek(K key);
+
+    /**
+     * @param key Key.
+     * @param peekModes Peek modes.
+     * @param plc Expiry policy if TTL should be updated.
+     * @return Value.
+     * @throws IgniteCheckedException If failed.
+     */
+    @Nullable public V localPeek(K key, CachePeekMode[] peekModes, @Nullable IgniteCacheExpiryPolicy plc)
+        throws IgniteCheckedException;
+
+    /**
+     * @param peekModes Peek modes.
+     * @return Entries iterable.
+     * @throws IgniteCheckedException If failed.
+     */
+    public Iterable<Cache.Entry<K, V>> localEntries(CachePeekMode[] peekModes) throws IgniteCheckedException;
+
+    /**
+     * Peeks at cached value using optional set of peek modes. This method will sequentially
+     * iterate over given peek modes in the order passed in, and try to peek at value using
+     * each peek mode. Once a {@code non-null} value is found, it will be immediately returned.
+     * <p>
+     * Note that if modes are not provided this method works exactly the same way as
+     * {@link #peek(Object)}, implicitly using {@link GridCachePeekMode#SMART} mode.
+     * <h2 class="header">Transactions</h2>
+     * This method does not participate in any transactions, however, it may
+     * peek at transactional value depending on the peek modes used.
+     *
+     * @param key Entry key.
+     * @param modes Optional set of peek modes.
+     * @return Peeked value.
+     * @throws IgniteCheckedException If peek operation failed.
+     * @throws NullPointerException If key is {@code null}.
+     */
+    @Nullable public V peek(K key, @Nullable Collection<GridCachePeekMode> modes) throws IgniteCheckedException;
+
+    /**
+     * Retrieves value mapped to the specified key from cache. Value will only be returned if
+     * its entry passed the optional filter provided. Filter check is atomic, and therefore the
+     * returned value is guaranteed to be consistent with the filter. The return value of {@code null}
+     * means entry did not pass the provided filter or cache has no mapping for the
+     * key.
+     * <p>
+     * If the value is not present in cache, then it will be looked up from swap storage. If
+     * it's not present in swap, or if swap is disable, and if read-through is allowed, value
+     * will be loaded from {@link CacheStore} persistent storage via
+     * {@link CacheStore#load(Transaction, Object)} method.
+     * <h2 class="header">Transactions</h2>
+     * This method is transactional and will enlist the entry into ongoing transaction
+     * if there is one.
+     * <h2 class="header">Cache Flags</h2>
+     * This method is not available if {@link CacheFlag#LOCAL} flag is set on projection.
+     *
+     * @param key Key to retrieve the value for.
+     * @return Value for the given key.
+     * @throws IgniteCheckedException If get operation failed.
+     * @throws CacheFlagException If failed projection flags validation.
+     * @throws NullPointerException if the key is {@code null}.
+     */
+    @Nullable public V get(K key) throws IgniteCheckedException;
+
+    /**
+     * Asynchronously retrieves value mapped to the specified key from cache. Value will only be returned if
+     * its entry passed the optional filter provided. Filter check is atomic, and therefore the
+     * returned value is guaranteed to be consistent with the filter. The return value of {@code null}
+     * means entry did not pass the provided filter or cache has no mapping for the
+     * key.
+     * <p>
+     * If the value is not present in cache, then it will be looked up from swap storage. If
+     * it's not present in swap, or if swap is disabled, and if read-through is allowed, value
+     * will be loaded from {@link CacheStore} persistent storage via
+     * {@link CacheStore#load(Transaction, Object)} method.
+     * <h2 class="header">Transactions</h2>
+     * This method is transactional and will enlist the entry into ongoing transaction
+     * if there is one.
+     * <h2 class="header">Cache Flags</h2>
+     * This method is not available if {@link CacheFlag#LOCAL} flag is set on projection.
+     *
+     * @param key Key for the value to get.
+     * @return Future for the get operation.
+     * @throws NullPointerException if the key is {@code null}.
+     * @throws CacheFlagException If projection flags validation failed.
+     */
+    public IgniteInternalFuture<V> getAsync(K key);
+
+    /**
+     * Retrieves values mapped to the specified keys from cache. Value will only be returned if
+     * its entry passed the optional filter provided. Filter check is atomic, and therefore the
+     * returned value is guaranteed to be consistent with the filter. If requested key-value pair
+     * is not present in the returned map, then it means that its entry did not pass the provided
+     * filter or cache has no mapping for the key.
+     * <p>
+     * If some value is not present in cache, then it will be looked up from swap storage. If
+     * it's not present in swap, or if swap is disabled, and if read-through is allowed, value
+     * will be loaded from {@link CacheStore} persistent storage via
+     * {@link CacheStore#loadAll(Transaction, Collection, org.apache.ignite.lang.IgniteBiInClosure)} method.
+     * <h2 class="header">Transactions</h2>
+     * This method is transactional and will enlist the entry into ongoing transaction
+     * if there is one.
+     * <h2 class="header">Cache Flags</h2>
+     * This method is not available if {@link CacheFlag#LOCAL} flag is set on projection.
+     *
+     * @param keys Keys to get.
+     * @return Map of key-value pairs.
+     * @throws IgniteCheckedException If get operation failed.
+     * @throws CacheFlagException If failed projection flags validation.
+     */
+    public Map<K, V> getAll(@Nullable Collection<? extends K> keys) throws IgniteCheckedException;
+
+    /**
+     * Asynchronously retrieves values mapped to the specified keys from cache. Value will only be returned if
+     * its entry passed the optional filter provided. Filter check is atomic, and therefore the
+     * returned value is guaranteed to be consistent with the filter. If requested key-value pair
+     * is not present in the returned map, then it means that its entry did not pass the provided
+     * filter or cache has no mapping for the key.
+     * <p>
+     * If some value is not present in cache, then it will be looked up from swap storage. If
+     * it's not present in swap, or if swap is disabled, and if read-through is allowed, value
+     * will be loaded from {@link CacheStore} persistent storage via
+     * {@link CacheStore#loadAll(Transaction, Collection, org.apache.ignite.lang.IgniteBiInClosure)} method.
+     * <h2 class="header">Transactions</h2>
+     * This method is transactional and will enlist the entry into ongoing transaction
+     * if there is one.
+     * <h2 class="header">Cache Flags</h2>
+     * This method is not available if {@link CacheFlag#LOCAL} flag is set on projection.
+     *
+     * @param keys Key for the value to get.
+     * @return Future for the get operation.
+     * @throws CacheFlagException If projection flags validation failed.
+     */
+    public IgniteInternalFuture<Map<K, V>> getAllAsync(@Nullable Collection<? extends K> keys);
+
+    /**
+     * Stores given key-value pair in cache. If filters are provided, then entries will
+     * be stored in cache only if they pass the filter. Note that filter check is atomic,
+     * so value stored in cache is guaranteed to be consistent with the filters. If cache
+     * previously contained value for the given key, then this value is returned.
+     * In case of {@link CacheMode#PARTITIONED} or {@link CacheMode#REPLICATED} caches,
+     * the value will be loaded from the primary node, which in its turn may load the value
+     * from the swap storage, and consecutively, if it's not in swap,
+     * from the underlying persistent storage. If value has to be loaded from persistent
+     * storage,  {@link CacheStore#load(Transaction, Object)} method will be used.
+     * <p>
+     * If the returned value is not needed, method {@link #putx(Object, Object, org.apache.ignite.lang.IgnitePredicate[])} should
+     * always be used instead of this one to avoid the overhead associated with returning of the previous value.
+     * <p>
+     * If write-through is enabled, the stored value will be persisted to {@link CacheStore}
+     * via {@link CacheStore#put(Transaction, Object, Object)} method.
+     * <h2 class="header">Transactions</h2>
+     * This method is transactional and will enlist the entry into ongoing transaction
+     * if there is one.
+     * <h2 class="header">Cache Flags</h2>
+     * This method is not available if any of the following flags are set on projection:
+     * {@link CacheFlag#LOCAL}, {@link CacheFlag#READ}.
+     *
+     * @param key Key to store in cache.
+     * @param val Value to be associated with the given key.
+     * @param filter Optional filter to check prior to putting value in cache. Note
+     *      that filter check is atomic with put operation.
+     * @return Previous value associated with specified key, or {@code null}
+     *  if entry did not pass the filter, or if there was no mapping for the key in swap
+     *  or in persistent storage.
+     * @throws NullPointerException If either key or value are {@code null}.
+     * @throws IgniteCheckedException If put operation failed.
+     * @throws CacheFlagException If projection flags validation failed.
+     */
+    @Nullable public V put(K key, V val, @Nullable IgnitePredicate<Cache.Entry<K, V>>... filter)
+        throws IgniteCheckedException;
+
+    /**
+     * Asynchronously stores given key-value pair in cache. If filters are provided, then entries will
+     * be stored in cache only if they pass the filter. Note that filter check is atomic,
+     * so value stored in cache is guaranteed to be consistent with the filters. If cache
+     * previously contained value for the given key, then this value is returned. Otherwise,
+     * in case of {@link CacheMode#REPLICATED} caches, the value will be loaded from swap
+     * and, if it's not there, and read-through is allowed, from the underlying
+     * {@link CacheStore} storage. In case of {@link CacheMode#PARTITIONED} caches,
+     * the value will be loaded from the primary node, which in its turn may load the value
+     * from the swap storage, and consecutively, if it's not in swap and read-through is allowed,
+     * from the underlying persistent storage. If value has to be loaded from persistent
+     * storage,  {@link CacheStore#load(Transaction, Object)} method will be used.
+     * <p>
+     * If the returned value is not needed, method {@link #putx(Object, Object, org.apache.ignite.lang.IgnitePredicate[])} should
+     * always be used instead of this one to avoid the overhead associated with returning of the previous value.
+     * <p>
+     * If write-through is enabled, the stored value will be persisted to {@link CacheStore}
+     * via {@link CacheStore#put(Transaction, Object, Object)} method.
+     * <h2 class="header">Transactions</h2>
+     * This method is transactional and will enlist the entry into ongoing transaction
+     * if there is one.
+     * <h2 class="header">Cache Flags</h2>
+     * This method is not available if any of the following flags are set on projection:
+     * {@link CacheFlag#LOCAL}, {@link CacheFlag#READ}.
+     *
+     * @param key Key to store in cache.
+     * @param val Value to be associated with the given key.
+     * @param filter Optional filter to check prior to putting value in cache. Note
+     *      that filter check is atomic with put operation.
+     * @return Future for the put operation.
+     * @throws NullPointerException If either key or value are {@code null}.
+     * @throws CacheFlagException If projection flags validation failed.
+     */
+    public IgniteInternalFuture<V> putAsync(K key, V val, @Nullable IgnitePredicate<Cache.Entry<K, V>>... filter);
+
+    /**
+     * Stores given key-value pair in cache. If filters are provided, then entries will
+     * be stored in cache only if they pass the filter. Note that filter check is atomic,
+     * so value stored in cache is guaranteed to be consistent with the filters.
+     * <p>
+     * This method will return {@code true} if value is stored in cache and {@code false} otherwise.
+     * Unlike {@link #put(Object, Object, org.apache.ignite.lang.IgnitePredicate[])} method, it does not return previous
+     * value and, therefore, does not have any overhead associated with returning a value. It
+     * should be used whenever return value is not required.
+     * <p>
+     * If write-through is enabled, the stored value will be persisted to {@link CacheStore}
+     * via {@link CacheStore#put(Transaction, Object, Object)} method.
+     * <h2 class="header">Transactions</h2>
+     * This method is transactional and will enlist the entry into ongoing transaction
+     * if there is one.
+     * <h2 class="header">Cache Flags</h2>
+     * This method is not available if any of the following flags are set on projection:
+     * {@link CacheFlag#LOCAL}, {@link CacheFlag#READ}.
+     *
+     * @param key Key to store in cache.
+     * @param val Value to be associated with the given key.
+     * @param filter Optional filter to check prior to putting value in cache. Note
+     *      that filter check is atomic with put operation.
+     * @return {@code True} if optional filter passed and value was stored in cache,
+     *      {@code false} otherwise. Note that this method will return {@code true} if filter is not
+     *      specified.
+     * @throws NullPointerException If either key or value are {@code null}.
+     * @throws IgniteCheckedException If put operation failed.
+     * @throws CacheFlagException If projection flags validation failed.
+     */
+    public boolean putx(K key, V val, @Nullable IgnitePredicate<Cache.Entry<K, V>>... filter)
+        throws IgniteCheckedException;
+
+    /**
+     * Stores given key-value pair in cache. If filters are provided, then entries will
+     * be stored in cache only if they pass the filter. Note that filter check is atomic,
+     * so value stored in cache is guaranteed to be consistent with the filters.
+     * <p>
+     * This method will return {@code true} if value is stored in cache and {@code false} otherwise.
+     * Unlike {@link #put(Object, Object, org.apache.ignite.lang.IgnitePredicate[])} method, it does not return previous
+     * value and, therefore, does not have any overhead associated with returning of a value. It
+     * should always be used whenever return value is not required.
+     * <p>
+     * If write-through is enabled, the stored value will be persisted to {@link CacheStore}
+     * via {@link CacheStore#put(Transaction, Object, Object)} method.
+     * <h2 class="header">Transactions</h2>
+     * This method is transactional and will enlist the entry into ongoing transaction
+     * if there is one.
+     * <h2 class="header">Cache Flags</h2>
+     * This method is not available if any of the following flags are set on projection:
+     * {@link CacheFlag#LOCAL}, {@link CacheFlag#READ}.
+     *
+     * @param key Key to store in cache.
+     * @param val Value to be associated with the given key.
+     * @param filter Optional filter to check prior to putting value in cache. Note
+     *      that filter check is atomic with put operation.
+     * @return Future for the put operation. Future will return {@code true} if optional filter
+     *      passed and value was stored in cache, {@code false} otherwise. Note that future will
+     *      return {@code true} if filter is not specified.
+     * @throws NullPointerException If either key or value are {@code null}.
+     * @throws CacheFlagException If projection flags validation failed.
+     */
+    public IgniteInternalFuture<Boolean> putxAsync(K key, V val, @Nullable IgnitePredicate<Cache.Entry<K, V>>... filter);
+
+    /**
+     * Stores given key-value pair in cache only if cache had no previous mapping for it. If cache
+     * previously contained value for the given key, then this value is returned.
+     * In case of {@link CacheMode#PARTITIONED} or {@link CacheMode#REPLICATED} caches,
+     * the value will be loaded from the primary node, which in its turn may load the value
+     * from the swap storage, and consecutively, if it's not in swap,
+     * from the underlying persistent storage. If value has to be loaded from persistent
+     * storage, {@link CacheStore#load(Transaction, Object)} method will be used.
+     * <p>
+     * If the returned value is not needed, method {@link #putxIfAbsent(Object, Object)} should
+     * always be used instead of this one to avoid the overhead associated with returning of the
+     * previous value.
+     * <p>
+     * If write-through is enabled, the stored value will be persisted to {@link CacheStore}
+     * via {@link CacheStore#put(Transaction, Object, Object)} method.
+     * <h2 class="header">Transactions</h2>
+     * This method is transactional and will enlist the entry into ongoing transaction
+     * if there is one.
+     * <h2 class="header">Cache Flags</h2>
+     * This method is not available if any of the following flags are set on projection:
+     * {@link CacheFlag#LOCAL}, {@link CacheFlag#READ}.
+     *
+     * @param key Key to store in cache.
+     * @param val Value to be associated with the given key.
+     * @return Previously contained value regardless of whether put happened or not.
+     * @throws NullPointerException If either key or value are {@code null}.
+     * @throws IgniteCheckedException If put operation failed.
+     * @throws CacheFlagException If projection flags validation failed.
+     */
+    @Nullable public V putIfAbsent(K key, V val) throws IgniteCheckedException;
+
+    /**
+     * Asynchronously stores given key-value pair in cache only if cache had no previous mapping for it. If cache
+     * previously contained value for the given key, then this value is returned. In case of
+     * {@link CacheMode#PARTITIONED} or {@link CacheMode#REPLICATED} caches,
+     * the value will be loaded from the primary node, which in its turn may load the value
+     * from the swap storage, and consecutively, if it's not in swap,
+     * from the underlying persistent storage. If value has to be loaded from persistent
+     * storage, {@link CacheStore#load(Transaction, Object)} method will be used.
+     * <p>
+     * If the returned value is not needed, method {@link #putxIfAbsentAsync(Object, Object)} should
+     * always be used instead of this one to avoid the overhead associated with returning of the
+     * previous value.
+     * <p>
+     * If write-through is enabled, the stored value will be persisted to {@link CacheStore}
+     * via {@link CacheStore#put(Transaction, Object, Object)} method.
+     * <h2 class="header">Transactions</h2>
+     * This method is transactional and will enlist the entry into ongoing transaction
+     * if there is one.
+     * <h2 class="header">Cache Flags</h2>
+     * This method is not available if any of the following flags are set on projection:
+     * {@link CacheFlag#LOCAL}, {@link CacheFlag#READ}.
+     *
+     * @param key Key to store in cache.
+     * @param val Value to be associated with the given key.
+     * @return Future of put operation which will provide previously contained value
+     *   regardless of whether put happened or not.
+     * @throws NullPointerException If either key or value are {@code null}.
+     * @throws CacheFlagException If projection flags validation failed.
+     */
+    public IgniteInternalFuture<V> putIfAbsentAsync(K key, V val);
+
+    /**
+     * Stores given key-value pair in cache only if cache had no previous mapping for it.
+     * <p>
+     * This method will return {@code true} if value is stored in cache and {@code false} otherwise.
+     * Unlike {@link #putIfAbsent(Object, Object)} method, it does not return previous
+     * value and, therefore, does not have any overhead associated with returning of a value. It
+     * should always be used whenever return value is not required.
+     * <p>
+     * If write-through is enabled, the stored value will be persisted to {@link CacheStore}
+     * via {@link CacheStore#put(Transaction, Object, Object)} method.
+     * <h2 class="header">Transactions</h2>
+     * This method is transactional and will enlist the entry into ongoing transaction
+     * if there is one.
+     * <h2 class="header">Cache Flags</h2>
+     * This method is not available if any of the following flags are set on projection:
+     * {@link CacheFlag#LOCAL}, {@link CacheFlag#READ}.
+     *
+     * @param key Key to store in cache.
+     * @param val Value to be associated with the given key.
+     * @return {@code true} if value is stored in cache and {@code false} otherwise.
+     * @throws NullPointerException If either key or value are {@code null}.
+     * @throws IgniteCheckedException If put operation failed.
+     * @throws CacheFlagException If projection flags validation failed.
+     */
+    public boolean putxIfAbsent(K key, V val) throws IgniteCheckedException;
+
+    /**
+     * Asynchronously stores given key-value pair in cache only if cache had no previous mapping for it.
+     * <p>
+     * This method will return {@code true} if value is stored in cache and {@code false} otherwise.
+     * Unlike {@link #putIfAbsent(Object, Object)} method, it does not return previous
+     * value and, therefore, does not have any overhead associated with returning of a value. It
+     * should always be used whenever return value is not required.
+     * <p>
+     * If write-through is enabled, the stored value will be persisted to {@link CacheStore}
+     * via {@link CacheStore#put(Transaction, Object, Object)} method.
+     * <h2 class="header">Transactions</h2>
+     * This method is transactional and will enlist the entry into ongoing transaction
+     * if there is one.
+     * <h2 class="header">Cache Flags</h2>
+     * This method is not available if any of the following flags are set on projection:
+     * {@link CacheFlag#LOCAL}, {@link CacheFlag#READ}.
+     *
+     * @param key Key to store in cache.
+     * @param val Value to be associated with the given key.
+     * @return Future for this put operation.
+     * @throws NullPointerException If either key or value are {@code null}.
+     * @throws CacheFlagException If projection flags validation failed.
+     */
+    public IgniteInternalFuture<Boolean> putxIfAbsentAsync(K key, V val);
+
+    /**
+     * Stores given key-value pair in cache only if there is a previous mapping for it.
+     * In case of {@link CacheMode#PARTITIONED} or {@link CacheMode#REPLICATED} caches,
+     * the value will be loaded from the primary node, which in its turn may load the value
+     * from the swap storage, and consecutively, if it's not in swap,
+     * from the underlying persistent storage. If value has to be loaded from persistent
+     * storage, {@link CacheStore#load(Transaction, Object)} method will be used.
+     * <p>
+     * If the returned value is not needed, method {@link #replacex(Object, Object)} should
+     * always be used instead of this one to avoid the overhead associated with returning of the
+     * previous value.
+     * <p>
+     * If write-through is enabled, the stored value will be persisted to {@link CacheStore}
+     * via {@link CacheStore#put(Transaction, Object, Object)} method.
+     * <h2 class="header">Transactions</h2>
+     * This method is transactional and will enlist the entry into ongoing transaction
+     * if there is one.
+     * <h2 class="header">Cache Flags</h2>
+     * This method is not available if any of the following flags are set on projection:
+     * {@link CacheFlag#LOCAL}, {@link CacheFlag#READ}.
+     *
+     * @param key Key to store in cache.
+     * @param val Value to be associated with the given key.
+     * @return Previously contained value regardless of whether replace happened or not.
+     * @throws NullPointerException If either key or value are {@code null}.
+     * @throws IgniteCheckedException If replace operation failed.
+     * @throws CacheFlagException If projection flags validation failed.
+     */
+    @Nullable public V replace(K key, V val) throws IgniteCheckedException;
+
+    /**
+     * Asynchronously stores given key-value pair in cache only if there is a previous mapping for it. If cache
+     * previously contained value for the given key, then this value is returned.In case of
+     * {@link CacheMode#PARTITIONED} caches, the value will be loaded from the primary node,
+     * which in its turn may load the value from the swap storage, and consecutively, if it's not in swap,
+     * from the underlying persistent storage. If value has to be loaded from persistent
+     * storage, {@link CacheStore#load(Transaction, Object)} method will be used.
+     * <p>
+     * If the returned value is not needed, method {@link #replacex(Object, Object)} should
+     * always be used instead of this one to avoid the overhead associated with returning of the
+     * previous value.
+     * <p>
+     * If write-through is enabled, the stored value will be persisted to {@link CacheStore}
+     * via {@link CacheStore#put(Transaction, Object, Object)} method.
+     * <h2 class="header">Transactions</h2>
+     * This method is transactional and will enlist the entry into ongoing transaction
+     * if there is one.
+     * <h2 class="header">Cache Flags</h2>
+     * This method is not available if any of the following flags are set on projection:
+     * {@link CacheFlag#LOCAL}, {@link CacheFlag#READ}.
+     *
+     * @param key Key to store in cache.
+     * @param val Value to be associated with the given key.
+     * @return Future for replace operation.
+     * @throws NullPointerException If either key or value are {@code null}.
+     * @throws CacheFlagException If projection flags validation failed.
+     */
+    public IgniteInternalFuture<V> replaceAsync(K key, V val);
+
+    /**
+     * Stores given key-value pair in cache only if only if there is a previous mapping for it.
+     * <p>
+     * This method will return {@code true} if value is stored in cache and {@code false} otherwise.
+     * Unlike {@link #replace(Object, Object)} method, it does not return previous
+     * value and, therefore, does not have any overhead associated with returning of a value. It
+     * should always be used whenever return value is not required.
+     * <p>
+     * If write-through is enabled, the stored value will be persisted to {@link CacheStore}
+     * via {@link CacheStore#put(Transaction, Object, Object)} method.
+     * <h2 class="header">Transactions</h2>
+     * This method is transactional and will enlist the entry into ongoing transaction
+     * if there is one.
+     * <h2 class="header">Cache Flags</h2>
+     * This method is not available if any of the following flags are set on projection:
+     * {@link CacheFlag#LOCAL}, {@link CacheFlag#READ}.
+     *
+     * @param key Key to store in cache.
+     * @param val Value to be associated with the given key.
+     * @return {@code True} if replace happened, {@code false} otherwise.
+     * @throws NullPointerException If either key or value are {@code null}.
+     * @throws IgniteCheckedException If replace operation failed.
+     * @throws CacheFlagException If projection flags validation failed.
+     */
+    public boolean replacex(K key, V val) throws IgniteCheckedException;
+
+    /**
+     * Asynchronously stores given key-value pair in cache only if only if there is a previous mapping for it.
+     * <p>
+     * This method will return {@code true} if value is stored in cache and {@code false} otherwise.
+     * Unlike {@link #replaceAsync(Object, Object)} method, it does not return previous
+     * value and, therefore, does not have any overhead associated with returning of a value. It
+     * should always be used whenever return value is not required.
+     * <p>
+     * If write-through is enabled, the stored value will be persisted to {@link CacheStore}
+     * via {@link CacheStore#put(Transaction, Object, Object)} method.
+     * <h2 class="header">Transactions</h2>
+     * This method is transactional and will enlist the entry into ongoing transaction
+     * if there is one.
+     * <h2 class="header">Cache Flags</h2>
+     * This method is not available if any of the following flags are set on projection:
+     * {@link CacheFlag#LOCAL}, {@link CacheFlag#READ}.
+     *
+     * @param key Key to store in cache.
+     * @param val Value to be associated with the given key.
+     * @return Future for the replace operation.
+     * @throws NullPointerException If either key or value are {@code null}.
+     * @throws CacheFlagException If projection flags validation failed.
+     */
+    public IgniteInternalFuture<Boolean> replacexAsync(K key, V val);
+
+    /**
+     * Stores given key-value pair in cache only if only if the previous value is equal to the
+     * {@code 'oldVal'} passed in.
+     * <p>
+     * This method will return {@code true} if value is stored in cache and {@code false} otherwise.
+     * <p>
+     * If write-through is enabled, the stored value will be persisted to {@link CacheStore}
+     * via {@link CacheStore#put(Transaction, Object, Object)} method.
+     * <h2 class="header">Transactions</h2>
+     * This method is transactional and will enlist the entry into ongoing transaction
+     * if there is one.
+     * <h2 class="header">Cache Flags</h2>
+     * This method is not available if any of the following flags are set on projection:
+     * {@link CacheFlag#LOCAL}, {@link CacheFlag#READ}.
+     *
+     * @param key Key to store in cache.
+     * @param oldVal Old value to match.
+     * @param newVal Value to be associated with the given key.
+     * @return {@code True} if replace happened, {@code false} otherwise.
+     * @throws NullPointerException If either key or value are {@code null}.
+     * @throws IgniteCheckedException If replace operation failed.
+     * @throws CacheFlagException If projection flags validation failed.
+     */
+    public boolean replace(K key, V oldVal, V newVal) throws IgniteCheckedException;
+
+    /**
+     * Asynchronously stores given key-value pair in cache only if only if the previous value is equal to the
+     * {@code 'oldVal'} passed in.
+     * <p>
+     * This method will return {@code true} if value is stored in cache and {@code false} otherwise.
+     * <p>
+     * If write-through is enabled, the stored value will be persisted to {@link CacheStore}
+     * via {@link CacheStore#put(Transaction, Object, Object)} method.
+     * <h2 class="header">Transactions</h2>
+     * This method is transactional and will enlist the entry into ongoing transaction
+     * if there is one.
+     * <h2 class="header">Cache Flags</h2>
+     * This method is not available if any of the following flags are set on projection:
+     * {@link CacheFlag#LOCAL}, {@link CacheFlag#READ}.
+     *
+     * @param key Key to store in cache.
+     * @param oldVal Old value to match.
+     * @param newVal Value to be associated with the given key.
+     * @return Future for the replace operation.
+     * @throws NullPointerException If either key or value are {@code null}.
+     * @throws CacheFlagException If projection flags validation failed.
+     */
+    public IgniteInternalFuture<Boolean> replaceAsync(K key, V oldVal, V newVal);
+
+    /**
+     * Stores given key-value pairs in cache. If filters are provided, then entries will
+     * be stored in cache only if they pass the filter. Note that filter check is atomic,
+     * so value stored in cache is guaranteed to be consistent with the filters.
+     * <p>
+     * If write-through is enabled, the stored values will be persisted to {@link CacheStore}
+     * via {@link CacheStore#putAll(Transaction, Map)} method.
+     * <h2 class="header">Transactions</h2>
+     * This method is transactional and will enlist the entry into ongoing transaction
+     * if there is one.
+     * <h2 class="header">Cache Flags</h2>
+     * This method is not available if any of the following flags are set on projection:
+     * {@link CacheFlag#LOCAL}, {@link CacheFlag#READ}.
+     *
+     * @param m Key-value pairs to store in cache.
+     * @param filter Optional entry filter. If provided, then entry will
+     *      be stored only if the filter returned {@code true}.
+     * @throws IgniteCheckedException If put operation failed.
+     * @throws CacheFlagException If projection flags validation failed.
+     */
+    public void putAll(@Nullable Map<? extends K, ? extends V> m,
+        @Nullable IgnitePredicate<Cache.Entry<K, V>>... filter) throws IgniteCheckedException;
+
+    /**
+     * Asynchronously stores given key-value pairs in cache. If filters are provided, then entries will
+     * be stored in cache only if they pass the filter. Note that filter check is atomic,
+     * so value stored in cache is guaranteed to be consistent with the filters.
+     * <p>
+     * If write-through is enabled, the stored values will be persisted to {@link CacheStore}
+     * via {@link CacheStore#putAll(Transaction, Map)} method.
+     * <h2 class="header">Transactions</h2>
+     * This method is transactional and will enlist the entry into ongoing transaction
+     * if there is one.
+     * <h2 class="header">Cache Flags</h2>
+     * This method is not available if any of the following flags are set on projection:
+     * {@link CacheFlag#LOCAL}, {@link CacheFlag#READ}.
+     *
+     * @param m Key-value pairs to store in cache.
+     * @param filter Optional entry filter. If provided, then entry will
+     *      be stored only if the filter returned {@code true}.
+     * @return Future for putAll operation.
+     * @throws CacheFlagException If projection flags validation failed.
+     */
+    public IgniteInternalFuture<?> putAllAsync(@Nullable Map<? extends K, ? extends V> m,
+        @Nullable IgnitePredicate<Cache.Entry<K, V>>... filter);
+
+    /**
+     * Set of keys cached on this node. You can remove elements from this set, but you cannot add elements
+     * to this set. All removal operation will be reflected on the cache itself.
+     * <p>
+     * Iterator over this set will not fail if set was concurrently updated
+     * by another thread. This means that iterator may or may not return latest
+     * keys depending on whether they were added before or after current
+     * iterator position.
+     * <p>
+     * NOTE: this operation is not distributed and returns only the keys cached on this node.
+     *
+     * @return Key set for this cache projection.
+     */
+    public Set<K> keySet();
+
+    /**
+     * Set of keys cached on this node. You can remove elements from this set, but you cannot add elements
+     * to this set. All removal operation will be reflected on the cache itself.
+     * <p>
+     * Iterator over this set will not fail if set was concurrently updated
+     * by another thread. This means that iterator may or may not return latest
+     * keys depending on whether they were added before or after current
+     * iterator position.
+     * <p>
+     * NOTE: this operation is not distributed and returns only the keys cached on this node.
+     *
+     * @param filter Optional filter to check prior to getting key form cache. Note
+     * that filter is checked atomically together with get operation.
+     * @return Key set for this cache projection.
+     */
+    public Set<K> keySet(@Nullable IgnitePredicate<Cache.Entry<K, V>>... filter);
+
+    /**
+     * Set of keys for which this node is primary.
+     * This set is dynamic and may change with grid topology changes.
+     * Note that this set will contain mappings for all keys, even if their values are
+     * {@code null} because they were invalidated. You can remove elements from
+     * this set, but you cannot add elements to this set. All removal operation will be
+     * reflected on the cache itself.
+     * <p>
+     * Iterator over this set will not fail if set was concurrently updated
+     * by another thread. This means that iterator may or may not return latest
+     * keys depending on whether they were added before or after current
+     * iterator position.
+     * <p>
+     * NOTE: this operation is not distributed and returns only the keys cached on this node.
+     *
+     * @return Primary key set for the current node.
+     */
+    public Set<K> primaryKeySet();
+
+    /**
+     * Collection of values cached on this node. You can remove
+     * elements from this collection, but you cannot add elements to this collection.
+     * All removal operation will be reflected on the cache itself.
+     * <p>
+     * Iterator over this collection will not fail if collection was
+     * concurrently updated by another thread. This means that iterator may or
+     * may not return latest values depending on whether they were added before
+     * or after current iterator position.
+     * <p>
+     * NOTE: this operation is not distributed and returns only the values cached on this node.
+     *
+     * @return Collection of cached values.
+     */
+    public Collection<V> values();
+
+    /**
+     * Collection of cached values for which this node is primary.
+     * This collection is dynamic and may change with grid topology changes.
+     * Note that this collection will not contain values that are {@code null}
+     * because they were invalided. You can remove elements from this collection,
+     * but you cannot add elements to this collection. All removal operation will be
+     * reflected on the cache itself.
+     * <p>
+     * Iterator over this collection will not fail if collection was
+     * concurrently updated by another thread. This means that iterator may or
+     * may not return latest values depending on whether they were added before
+     * or after current iterator position.
+     * <p>
+     * NOTE: this operation is not distributed and returns only the values cached on this node.
+     *
+     * @return Collection of primary cached values for the current node.
+     */
+    public Collection<V> primaryValues();
+
+    /**
+     * Gets set of all entries cached on this node. You can remove
+     * elements from this set, but you cannot add elements to this set.
+     * All removal operation will be reflected on the cache itself.
+     * <p>
+     * NOTE: this operation is not distributed and returns only the entries cached on this node.
+     *
+     * @return Entries that pass through key filter.
+     */
+    public Set<Cache.Entry<K, V>> entrySet();
+
+    /**
+     * Gets set containing cache entries that belong to provided partition or {@code null}
+     * if partition is not found locally.
+     * <p>
+     * NOTE: this operation is not distributed and returns only the entries cached on this node.
+     *
+     * @param part Partition.
+     * @return Set containing partition's entries or {@code null} if partition is
+     *      not found locally.
+     */
+    @Nullable public Set<Cache.Entry<K, V>> entrySet(int part);
+
+    /**
+     * Gets set of cache entries for which this node is primary.
+     * This set is dynamic and may change with grid topology changes. You can remove
+     * elements from this set, but you cannot add elements to this set.
+     * All removal operation will be reflected on the cache itself.
+     * <p>
+     * NOTE: this operation is not distributed and returns only the entries cached on this node.
+     *
+     * @return Primary cache entries that pass through key filter.
+     */
+    public Set<Cache.Entry<K, V>> primaryEntrySet();
+
+    /**
+     * Starts transaction with default isolation, concurrency, timeout, and invalidation policy.
+     * All defaults are set in {@link org.apache.ignite.configuration.CacheConfiguration} at startup.
+     *
+     * @return New transaction
+     * @throws IllegalStateException If transaction is already started by this thread.
+     * @throws UnsupportedOperationException If cache is {@link CacheAtomicityMode#ATOMIC}.
+     */
+    public Transaction txStart() throws IllegalStateException;
+
+    /**
+     * Starts new transaction with the specified concurrency and isolation.
+     *
+     * @param concurrency Concurrency.
+     * @param isolation Isolation.
+     * @return New transaction.
+     * @throws IllegalStateException If transaction is already started by this thread.
+     * @throws UnsupportedOperationException If cache is {@link CacheAtomicityMode#ATOMIC}.
+     */
+    public Transaction txStart(TransactionConcurrency concurrency, TransactionIsolation isolation);
+
+    /**
+     * @param concurrency Concurrency.
+     * @param isolation Isolation.
+     * @return New transaction.
+     */
+    public IgniteInternalTx txStartEx(TransactionConcurrency concurrency, TransactionIsolation isolation);
+
+    /**
+     * Starts transaction with specified isolation, concurrency, timeout, invalidation flag,
+     * and number of participating entries.
+     *
+     * @param concurrency Concurrency.
+     * @param isolation Isolation.
+     * @param timeout Timeout.
+     * @param txSize Number of entries participating in transaction (may be approximate).
+     * @return New transaction.
+     * @throws IllegalStateException If transaction is already started by this thread.
+     * @throws UnsupportedOperationException If cache is {@link CacheAtomicityMode#ATOMIC}.
+     */
+    public Transaction txStart(TransactionConcurrency concurrency, TransactionIsolation isolation, long timeout,
+        int txSize);
+
+    /**
+     * Gets transaction started by this thread or {@code null} if this thread does
+     * not have a transaction.
+     *
+     * @return Transaction started by this thread or {@code null} if this thread
+     *      does not have a transaction.
+     */
+    @Nullable public Transaction tx();
+
+    /**
+     * Gets entry from cache with the specified key. The returned entry can
+     * be used even after entry key has been removed from cache. In that
+     * case, every operation on returned entry will result in creation of a
+     * new entry.
+     * <p>
+     * Note that this method can return {@code null} if projection is configured as
+     * pre-filtered and entry key and value don't pass key-value filter of the projection.
+     *
+     * @param key Entry key.
+     * @return Cache entry or {@code null} if projection pre-filtering was not passed.
+     */
+    @Nullable public Cache.Entry<K, V> entry(K key);
+
+    /**
+     * Evicts entry associated with given key from cache. Note, that entry will be evicted
+     * only if it's not used (not participating in any locks or transactions).
+     * <p>
+     * If {@link org.apache.ignite.configuration.CacheConfiguration#isSwapEnabled()} is set to {@code true} and
+     * {@link CacheFlag#SKIP_SWAP} is not enabled, the evicted entry will
+     * be swapped to offheap, and then to disk.
+     * <h2 class="header">Cache Flags</h2>
+     * This method is not available if any of the following flags are set on projection:
+     * {@link CacheFlag#READ}.
+     *
+     * @param key Key to evict from cache.
+     * @return {@code True} if entry could be evicted, {@code false} otherwise.
+     */
+    public boolean evict(K key);
+
+    /**
+     * Attempts to evict all cache entries. Note, that entry will be
+     * evicted only if it's not used (not participating in any locks or
+     * transactions).
+     * <p>
+     * If {@link org.apache.ignite.configuration.CacheConfiguration#isSwapEnabled()} is set to {@code true} and
+     * {@link CacheFlag#SKIP_SWAP} is not enabled, the evicted entry will
+     * be swapped to offheap, and then to disk.
+     * <h2 class="header">Cache Flags</h2>
+     * This method is not available if any of the following flags are set on projection:
+     * {@link CacheFlag#READ}.
+     */
+    public void evictAll();
+
+    /**
+     * Attempts to evict all entries associated with keys. Note,
+     * that entry will be evicted only if it's not used (not
+     * participating in any locks or transactions).
+     * <p>
+     * If {@link org.apache.ignite.configuration.CacheConfiguration#isSwapEnabled()} is set to {@code true} and
+     * {@link CacheFlag#SKIP_SWAP} is not enabled, the evicted entry will
+     * be swapped to offheap, and then to disk.
+     * <h2 class="header">Cache Flags</h2>
+     * This method is not available if any of the following flags are set on projection:
+     * {@link CacheFlag#READ}.
+     *
+     * @param keys Keys to evict.
+     */
+    public void evictAll(@Nullable Collection<? extends K> keys);
+
+    /**
+     * Clears all entries from this cache only if the entry is not
+     * currently locked or participating in a transaction.
+     * <p>
+     * If {@link org.apache.ignite.configuration.CacheConfiguration#isSwapEnabled()} is set to {@code true} and
+     * {@link CacheFlag#SKIP_SWAP} is not enabled, the evicted entries will
+     * also be cleared from swap.
+     * <p>
+     * Note that this operation is local as it merely clears
+     * entries from local cache. It does not remove entries from
+     * remote caches or from underlying persistent storage.
+     * <h2 class="header">Cache Flags</h2>
+     * This method is not available if any of the following flags are set on projection:
+     * {@link CacheFlag#READ}.
+     */
+    public void clearLocally();
+
+    /**
+     * Clears an entry from this cache and swap storage only if the entry
+     * is not currently locked, and is not participating in a transaction.
+     * <p>
+     * If {@link org.apache.ignite.configuration.CacheConfiguration#isSwapEnabled()} is set to {@code true} and
+     * {@link CacheFlag#SKIP_SWAP} is not enabled, the evicted entries will
+     * also be cleared from swap.
+     * <p>
+     * Note that this operation is local as it merely clears
+     * an entry from local cache. It does not remove entries from
+     * remote caches or from underlying persistent storage.
+     * <h2 class="header">Cache Flags</h2>
+     * This method is not available if any of the following flags are set on projection:
+     * {@link CacheFlag#READ}.
+     *
+     * @param key Key to clearLocally.
+     * @return {@code True} if entry was successfully cleared from cache, {@code false}
+     *      if entry was in use at the time of this method invocation and could not be
+     *      cleared.
+     */
+    public boolean clearLocally(K key);
+
+    /**
+     * Clears cache on all nodes that store it's data. That is, caches are cleared on remote
+     * nodes and local node, as opposed to {@link CacheProjection#clearLocally()} method which only
+     * clears local node's cache.
+     * <p>
+     * Ignite will make the best attempt to clear caches on all nodes. If some caches
+     * could not be cleared, then exception will be thrown.
+     * <p>
+     * This method is identical to calling {@link #clear(long) clear(0)}.
+     *
+     * @throws IgniteCheckedException In case of cache could not be cleared on any of the nodes.
+     * @deprecated Deprecated in favor of {@link #clear(long)} method.
+     */
+    public void clear() throws IgniteCheckedException;
+
+    /**
+     * @return Clear future.
+     */
+    public IgniteInternalFuture<?> clearAsync();
+
+    /**
+     * Clears cache on all nodes that store it's data. That is, caches are cleared on remote
+     * nodes and local node, as opposed to {@link CacheProjection#clearLocally()} method which only
+     * clears local node's cache.
+     * <p>
+     * Ignite will make the best attempt to clearLocally caches on all nodes. If some caches
+     * could not be cleared, then exception will be thrown.
+     *
+     * @param timeout Timeout for clearLocally all task in milliseconds (0 for never).
+     *      Set it to larger value for large caches.
+     * @throws IgniteCheckedException In case of cache could not be cleared on any of the nodes.
+     */
+    public void clear(long timeout) throws IgniteCheckedException;
+
+    /**
+     * Clears serialized value bytes from entry (if any) leaving only object representation.
+     *
+     * @param key Key to compact.
+     * @throws IgniteCheckedException If failed to compact.
+     * @return {@code true} if entry was deleted from cache (i.e. was expired).
+     */
+    public boolean compact(K key) throws IgniteCheckedException;
+
+    /**
+     * Clears serialized value bytes from cache entries (if any) leaving only object representation.
+     * @throws IgniteCheckedException If failed to compact.
+     */
+    public void compactAll() throws IgniteCheckedException;
+
+    /**
+     * Removes given key mapping from cache. If cache previously contained value for the given key,
+     * then this value is returned. In case of {@link CacheMode#PARTITIONED} or {@link CacheMode#REPLICATED}
+     * caches, the value will be loaded from the primary node, which in its turn may load the value
+     * from the disk-based swap storage, and consecutively, if it's not in swap,
+     * from the underlying persistent storage. If value has to be loaded from persistent
+     * storage, {@link CacheStore#load(Transaction, Object)} method will be used.
+     * <p>
+     * If the returned value is not needed, method {@link #removex(Object, org.apache.ignite.lang.IgnitePredicate[])} should
+     * always be used instead of this one to avoid the overhead associated with returning of the
+     * previous value.
+     * <p>
+     * If write-through is enabled, the value will be removed from {@link CacheStore}
+     * via {@link CacheStore#remove(Transaction, Object)} method.
+     * <h2 class="header">Transactions</h2>
+     * This method is transactional and will enlist the entry into ongoing transaction
+     * if there is one.
+     * <h2 class="header">Cache Flags</h2>
+     * This method is not available if any of the following flags are set on projection:
+     * {@link CacheFlag#LOCAL}, {@link CacheFlag#READ}.
+     *
+     * @param key Key whose mapping is to be removed from cache.
+     * @param filter Optional filter to check prior to removing value form cache. Note
+     *      that filter is checked atomically together with remove operation.
+     * @return Previous value associated with specified key, or {@code null}
+     *      if there was no value for this key.
+     * @throws NullPointerException If key is {@code null}.
+     * @throws IgniteCheckedException If remove operation failed.
+     * @throws CacheFlagException If projection flags validation failed.
+     */
+    @Nullable public V remove(K key, @Nullable IgnitePredicate<Cache.Entry<K, V>>... filter)
+        throws IgniteCheckedException;
+
+    /**
+     * Asynchronously removes given key mapping from cache. If cache previously contained value for the given key,
+     * then this value is returned. In case of {@link CacheMode#PARTITIONED} or {@link CacheMode#REPLICATED}
+     * caches, the value will be loaded from the primary node, which in its turn may load the value
+     * from the swap storage, and consecutively, if it's not in swap,
+     * from the underlying persistent storage. If value has to be loaded from persistent
+     * storage, {@link CacheStore#load(Transaction, Object)} method will be used.
+     * <p>
+     * If the returned value is not needed, method {@link #removex(Object, org.apache.ignite.lang.IgnitePredicate[])} should
+     * always be used instead of this one to avoid the overhead associated with returning of the
+     * previous value.
+     * <p>
+     * If write-through is enabled, the value will be removed from {@link CacheStore}
+     * via {@link CacheStore#remove(Transaction, Object)} method.
+     * <h2 class="header">Transactions</h2>
+     * This method is transactional and will enlist the entry into ongoing transaction
+     * if there is one.
+     * <h2 class="header">Cache Flags</h2>
+     * This method is not available if any of the following flags are set on projection:
+     * {@link CacheFlag#LOCAL}, {@link CacheFlag#READ}.
+     *
+     * @param key Key whose mapping is to be removed from cache.
+     * @param filter Optional filter to check prior to removing value form cache. Note
+     *      that filter is checked atomically together with remove operation.
+     * @return Future for the remove operation.
+     * @throws NullPointerException if the key is {@code null}.
+     * @throws CacheFlagException If projection flags validation failed.
+     */
+    public IgniteInternalFuture<V> removeAsync(K key, IgnitePredicate<Cache.Entry<K, V>>... filter);
+
+    /**
+     * Removes given key mapping from cache.
+     * <p>
+     * This method will return {@code true} if remove did occur, which means that all optionally
+     * provided filters have passed and there was something to remove, {@code false} otherwise.
+     * <p>
+     * If write-through is enabled, the value will be removed from {@link CacheStore}
+     * via {@link CacheStore#remove(Transaction, Object)} method.
+     * <h2 class="header">Transactions</h2>
+     * This method is transactional and will enlist the entry into ongoing transaction
+     * if there is one.
+     * <h2 class="header">Cache Flags</h2>
+     * This method is not available if any of the following flags are set on projection:
+     * {@link CacheFlag#LOCAL}, {@link CacheFlag#READ}.
+     *
+     * @param key Key whose mapping is to be removed from cache.
+     * @param filter Optional filter to check prior to removing value form cache. Note
+     *      that filter is checked atomically together with remove operation.
+     * @return {@code True} if filter passed validation and entry was removed, {@code false} otherwise.
+     *      Note that if filter is not specified, this method will return {@code true}.
+     * @throws NullPointerException if the key is {@code null}.
+     * @throws IgniteCheckedException If remove failed.
+     * @throws CacheFlagException If projection flags validation failed.
+     */
+    public boolean removex(K key, @Nullable IgnitePredicate<Cache.Entry<K, V>>... filter)
+        throws IgniteCheckedException;
+
+    /**
+     * Asynchronously removes given key mapping from cache.
+     * <p>
+     * This method will return {@code true} if remove did occur, which means that all optionally
+     * provided filters have passed and there was something to remove, {@code false} otherwise.
+     * <p>
+     * If write-through is enabled, the value will be removed from {@link CacheStore}
+     * via {@link CacheStore#remove(Transaction, Object)} method.
+     * <h2 class="header">Transactions</h2>
+     * This method is transactional and will enlist the entry into ongoing transaction
+     * if there is one.
+     * <h2 class="header">Cache Flags</h2>
+     * This method is not available if any of the following flags are set on projection:
+     * {@link CacheFlag#LOCAL}, {@link CacheFlag#READ}.
+     *
+     * @param key Key whose mapping is to be removed from cache.
+     * @param filter Optional filter to check prior to removing value form cache. Note
+     *      that filter is checked atomically together with remove operation.
+     * @return Future for the remove operation. The future will return {@code true}
+     *      if optional filters passed validation and remove did occur, {@code false} otherwise.
+     *      Note that if filter is not specified, this method will return {@code true}.
+     * @throws NullPointerException if the key is {@code null}.
+     * @throws CacheFlagException If projection flags validation failed.
+     */
+    public IgniteInternalFuture<Boolean> removexAsync(K key,
+        @Nullable IgnitePredicate<Cache.Entry<K, V>>... filter);
+
+    /**
+     * Removes given key mapping from cache if one exists and value is equal to the passed in value.
+     * <p>
+     * If write-through is enabled, the value will be removed from {@link CacheStore}
+     * via {@link CacheStore#remove(Transaction, Object)} method.
+     * <h2 class="header">Transactions</h2>
+     * This method is transactional and will enlist the entry into ongoing transaction
+     * if there is one.
+     * <h2 class="header">Cache Flags</h2>
+     * This method is not available if any of the following flags are set on projection:
+     * {@link CacheFlag#LOCAL}, {@link CacheFlag#READ}.
+     *
+     * @param key Key whose mapping is to be removed from cache.
+     * @param val Value to match against currently cached value.
+     * @return {@code True} if entry was removed and passed in value matched the cached one,
+     *      {@code false} otherwise.
+     * @throws NullPointerException if the key or value is {@code null}.
+     * @throws IgniteCheckedException If remove failed.
+     * @throws CacheFlagException If projection flags validation failed.
+     */
+    public boolean remove(K key, V val) throws IgniteCheckedException;
+
+    /**
+     * Asynchronously removes given key mapping from cache if one exists and value is equal to the passed in value.
+     * <p>
+     * This method will return {@code true} if remove did occur, which means that all optionally
+     * provided filters have passed and there was something to remove, {@code false} otherwise.
+     * <p>
+     * If write-through is enabled, the value will be removed from {@link CacheStore}
+     * via {@link CacheStore#remove(Transaction, Object)} method.
+     * <h2 class="header">Transactions</h2>
+     * This method is transactional and will enlist the entry into ongoing transaction
+     * if there is one.
+     * <h2 class="header">Cache Flags</h2>
+     * This method is not available if any of the following flags are set on projection:
+     * {@link CacheFlag#LOCAL}, {@link CacheFlag#READ}.
+     *
+     * @param key Key whose mapping is to be removed from cache.
+     * @param val Value to match against currently cached value.
+     * @return Future for the remove operation. The future will return {@code true}
+     *      if currently cached value will match the passed in one.
+     * @throws NullPointerException if the key or value is {@code null}.
+     * @throws CacheFlagException If projection flags validation failed.
+     */
+    public IgniteInternalFuture<Boolean> removeAsync(K key, V val);
+
+    /**
+     * Removes given key mappings from cache for entries for which the optionally passed in filters do
+     * pass.
+     * <p>
+     * If write-through is enabled, the values will be removed from {@link CacheStore}
+     * via {@link CacheStore#removeAll(Transaction, Collection)} method.
+     * <h2 class="header">Transactions</h2>
+     * This method is transactional and will enlist the entry into ongoing transaction
+     * if there is one.
+     * <h2 class="header">Cache Flags</h2>
+     * This method is not available if any of the following flags are set on projection:
+     * {@link CacheFlag#LOCAL}, {@link CacheFlag#READ}.
+     *
+     * @param keys Keys whose mappings are to be removed from cache.
+     * @param filter Optional filter to check prior to removing value form cache. Note
+     *      that filter is checked atomically together with remove operation.
+     * @throws IgniteCheckedException If remove failed.
+     * @throws CacheFlagException If flags validation failed.
+     */
+    public void removeAll(@Nullable Collection<? extends K> keys,
+        @Nullable IgnitePredicate<Cache.Entry<K, V>>... filter) throws IgniteCheckedException;
+
+    /**
+     * Asynchronously removes given key mappings from cache for entries for which the optionally
+     * passed in filters do pass.
+     * <p>
+     * If write-through is enabled, the values will be removed from {@link CacheStore}
+     * via {@link CacheStore#removeAll(Transaction, Collection)} method.
+     * <h2 class="header">Transactions</h2>
+     * This method is transactional and will enlist the entry into ongoing transaction
+     * if there is one.
+     * <h2 class="header">Cache Flags</h2>
+     * This method is not available if any of the following flags are set on projection:
+     * {@link CacheFlag#LOCAL}, {@link CacheFlag#READ}.
+     *
+     * @param keys Keys whose mappings are to be removed from cache.
+     * @param filter Optional filter to check prior to removing value form cache. Note
+     *      that filter is checked atomically together with remove operation.
+     * @return Future for the remove operation. The future will complete whenever
+     *      remove operation completes.
+     * @throws CacheFlagException If flags validation failed.
+     */
+    public IgniteInternalFuture<?> removeAllAsync(@Nullable Collection<? extends K> keys,
+        @Nullable IgnitePredicate<Cache.Entry<K, V>>... filter);
+
+    /**
+     * Removes mappings from cache for entries for which the optionally passed in filters do
+     * pass. If passed in filters are {@code null}, then all entries in cache will be enrolled
+     * into transaction.
+     * <p>
+     * <b>USE WITH CARE</b> - if your cache has many entries that pass through the filter or if filter
+     * is empty, then transaction will quickly become very heavy and slow. Also, locks
+     * are acquired in undefined order, so it may cause a deadlock when used with
+     * other concurrent transactional updates.
+     * <p>
+     * If write-through is enabled, the values will be removed from {@link CacheStore}
+     * via {@link CacheStore#removeAll(Transaction, Collection)} method.
+     * <h2 class="header">Transactions</h2>
+     * This method is transactional and will enlist the entry into ongoing transaction
+     * if there is one.
+     * <h2 class="header">Cache Flags</h2>
+     * This method is not available if any of the following flags are set on projection:
+     * {@link CacheFlag#LOCAL}, {@link CacheFlag#READ}.
+     *
+     * @throws IgniteCheckedException If remove failed.
+     * @throws CacheFlagException If flags validation failed.
+     */
+    public void removeAll() throws IgniteCheckedException;
+
+    /**
+     * @return Remove future.
+     */
+    public IgniteInternalFuture<?> removeAllAsync();
+
+    /**
+     * Asynchronously removes mappings from cache for entries for which the optionally passed in filters do
+     * pass. If passed in filters are {@code null}, then all entries in cache will be enrolled
+     * into transaction.
+     * <p>
+     * <b>USE WITH CARE</b> - if your cache has many entries that pass through the filter or if filter
+     * is empty, then transaction will quickly become very heavy and slow.
+     * <p>
+     * If write-through is enabled, the values will be removed from {@link CacheStore}
+     * via {@link CacheStore#removeAll(Transaction, Collection)} method.
+     * <h2 class="header">Transactions</h2>
+     * This method is transactional and will enlist the entry into ongoing transaction
+     * if there is one.
+     * <h2 class="header">Cache Flags</h2>
+     * This method is not available if any of the following flags are set on projection:
+     * {@link CacheFlag#LOCAL}, {@link CacheFlag#READ}.
+     *
+     * @param filter Filter used to supply keys for remove operation (if {@code null},
+     *      then nothing will be removed).
+     * @return Future for the remove operation. The future will complete whenever
+     *      remove operation completes.
+     * @throws CacheFlagException If flags validation failed.
+     */
+    public IgniteInternalFuture<?> removeAllAsync(@Nullable IgnitePredicate<Cache.Entry<K, V>>... filter);
+
+    /**
+     * Synchronously acquires lock on a cached object with given
+     * key only if the passed in filter (if any) passes. This method
+     * together with filter check will be executed as one atomic operation.
+     * <h2 class="header">Transactions</h2>
+     * Locks are not transactional and should not be used from within transactions. If you do
+     * need explicit locking within transaction, then you should use
+     * {@link TransactionConcurrency#PESSIMISTIC} concurrency control for transaction
+     * which will acquire explicit locks for relevant cache operations.
+     * <h2 class="header">Cache Flags</h2>
+     * This method is not available if any of the following flags are set on projection:
+     * {@link CacheFlag#LOCAL}, {@link CacheFlag#READ}.
+     *
+     * @param key Key to lock.
+     * @param timeout Timeout in milliseconds to wait for lock to be acquired
+     *      ({@code '0'} for no expiration), {@code -1} for immediate failure if
+     *      lock cannot be acquired immediately).
+     * @param filter Optional filter to validate prior to acquiring the lock.
+     * @return {@code True} if all filters passed and lock was acquired,
+     *      {@code false} otherwise.
+     * @throws IgniteCheckedException If lock acquisition resulted in error.
+     * @throws CacheFlagException If flags validation failed.
+     */
+    public boolean lock(K key, long timeout, @Nullable IgnitePredicate<Cache.Entry<K, V>>... filter)
+        throws IgniteCheckedException;
+
+    /**
+     * Asynchronously acquires lock on a cached object with given
+     * key only if the passed in filter (if any) passes. This method
+     * together with filter check will be executed as one atomic operation.
+     * <h2 class="header">Transactions</h2>
+     * Locks are not transactional and should not be used from within transactions. If you do
+     * need explicit locking within transaction, then you should use
+     * {@link TransactionConcurrency#PESSIMISTIC} concurrency control for transaction
+     * which will acquire explicit locks for 

<TRUNCATED>

[11/50] [abbrv] incubator-ignite git commit: Merge remote-tracking branch 'origin/sprint-1' into sprint-1

Posted by vk...@apache.org.
Merge remote-tracking branch 'origin/sprint-1' into sprint-1


Project: http://git-wip-us.apache.org/repos/asf/incubator-ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-ignite/commit/3ba4f3cb
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/3ba4f3cb
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/3ba4f3cb

Branch: refs/heads/master
Commit: 3ba4f3cb129b49b4d76d4644c9aeb601a3617c0d
Parents: 2c1ba55 bd28d7d
Author: Yakov Zhdanov <yz...@gridgain.com>
Authored: Mon Feb 16 14:51:36 2015 +0300
Committer: Yakov Zhdanov <yz...@gridgain.com>
Committed: Mon Feb 16 14:51:36 2015 +0300

----------------------------------------------------------------------
 .../dht/atomic/GridDhtAtomicCache.java          |   2 +-
 .../transactions/IgniteTxLocalAdapter.java      |   2 +-
 .../GridTransactionalCacheQueueImpl.java        |   4 +-
 .../near/GridCacheNearMetricsSelfTest.java      |   4 +-
 ...idCachePartitionedHitsAndMissesSelfTest.java | 177 +++++++++++++++++++
 .../IgniteCacheMetricsSelfTestSuite.java        |  21 +--
 ...idCachePartitionedHitsAndMissesSelfTest.java | 176 ------------------
 .../IgniteH2IndexingSpiTestSuite.java           |   2 -
 .../commands/cache/VisorCacheCommand.scala      |   2 +-
 .../commands/top/VisorTopologyCommand.scala     |   3 +-
 .../scala/org/apache/ignite/visor/visor.scala   |   2 +-
 pom.xml                                         |   2 +-
 12 files changed, 198 insertions(+), 199 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/3ba4f3cb/pom.xml
----------------------------------------------------------------------


[32/50] [abbrv] incubator-ignite git commit: sprint-1: moved cache projection to internal

Posted by vk...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f27a989c/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheAdapter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheAdapter.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheAdapter.java
index 0082375..229cecf 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheAdapter.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheAdapter.java
@@ -5603,7 +5603,7 @@ public abstract class GridCacheAdapter<K, V> implements GridCache<K, V>,
     }
 
     /**
-     * Internal callable which performs {@link org.apache.ignite.cache.CacheProjection#clearLocally()}
+     * Internal callable which performs {@link CacheProjection#clearLocally()}
      * operation on a cache with the given name.
      */
     @GridInternal

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f27a989c/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheMapAdapter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheMapAdapter.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheMapAdapter.java
index de43ca5..3d47852 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheMapAdapter.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheMapAdapter.java
@@ -18,7 +18,6 @@
 package org.apache.ignite.internal.processors.cache;
 
 import org.apache.ignite.*;
-import org.apache.ignite.cache.*;
 import org.apache.ignite.internal.util.typedef.internal.*;
 import org.jetbrains.annotations.*;
 

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f27a989c/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCachePeekMode.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCachePeekMode.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCachePeekMode.java
index a4aa453..ff5676d 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCachePeekMode.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCachePeekMode.java
@@ -24,7 +24,7 @@ import java.util.*;
 /**
  * Enumeration of all supported cache peek modes. Peek modes can be passed into various
  * {@code 'CacheProjection.peek(..)'} and {@code Entry.peek(..)} methods,
- * such as {@link org.apache.ignite.cache.CacheProjection#peek(Object, Collection)},
+ * such as {@link CacheProjection#peek(Object, Collection)},
  * {@link org.apache.ignite.cache.Entry#peek()}, and others.
  * <p>
  * The following modes are supported:

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f27a989c/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheProjectionEx.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheProjectionEx.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheProjectionEx.java
index cf7dc99..4e93122 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheProjectionEx.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheProjectionEx.java
@@ -18,7 +18,6 @@
 package org.apache.ignite.internal.processors.cache;
 
 import org.apache.ignite.*;
-import org.apache.ignite.cache.*;
 import org.apache.ignite.cache.store.*;
 import org.apache.ignite.internal.*;
 import org.apache.ignite.internal.processors.cache.dr.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f27a989c/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/query/GridCacheQueriesProxy.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/query/GridCacheQueriesProxy.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/query/GridCacheQueriesProxy.java
index 79eb978..4e185c7 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/query/GridCacheQueriesProxy.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/query/GridCacheQueriesProxy.java
@@ -18,7 +18,6 @@
 package org.apache.ignite.internal.processors.cache.query;
 
 import org.apache.ignite.*;
-import org.apache.ignite.cache.*;
 import org.apache.ignite.cache.query.*;
 import org.apache.ignite.internal.*;
 import org.apache.ignite.internal.processors.cache.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f27a989c/modules/core/src/main/java/org/apache/ignite/internal/processors/datastructures/GridCacheAtomicLongImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/datastructures/GridCacheAtomicLongImpl.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/datastructures/GridCacheAtomicLongImpl.java
index f32ff0b..e53fed3 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/datastructures/GridCacheAtomicLongImpl.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/datastructures/GridCacheAtomicLongImpl.java
@@ -18,7 +18,6 @@
 package org.apache.ignite.internal.processors.datastructures;
 
 import org.apache.ignite.*;
-import org.apache.ignite.cache.*;
 import org.apache.ignite.internal.*;
 import org.apache.ignite.internal.processors.cache.*;
 import org.apache.ignite.internal.processors.cache.transactions.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f27a989c/modules/core/src/main/java/org/apache/ignite/internal/processors/datastructures/GridCacheAtomicReferenceImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/datastructures/GridCacheAtomicReferenceImpl.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/datastructures/GridCacheAtomicReferenceImpl.java
index 8d976fe..1031cc4 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/datastructures/GridCacheAtomicReferenceImpl.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/datastructures/GridCacheAtomicReferenceImpl.java
@@ -18,7 +18,6 @@
 package org.apache.ignite.internal.processors.datastructures;
 
 import org.apache.ignite.*;
-import org.apache.ignite.cache.*;
 import org.apache.ignite.internal.*;
 import org.apache.ignite.internal.processors.cache.*;
 import org.apache.ignite.internal.processors.cache.transactions.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f27a989c/modules/core/src/main/java/org/apache/ignite/internal/processors/datastructures/GridCacheAtomicSequenceImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/datastructures/GridCacheAtomicSequenceImpl.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/datastructures/GridCacheAtomicSequenceImpl.java
index e6b9c19..e61deee 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/datastructures/GridCacheAtomicSequenceImpl.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/datastructures/GridCacheAtomicSequenceImpl.java
@@ -18,7 +18,6 @@
 package org.apache.ignite.internal.processors.datastructures;
 
 import org.apache.ignite.*;
-import org.apache.ignite.cache.*;
 import org.apache.ignite.internal.*;
 import org.apache.ignite.internal.processors.cache.*;
 import org.apache.ignite.internal.processors.cache.transactions.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f27a989c/modules/core/src/main/java/org/apache/ignite/internal/processors/datastructures/GridCacheAtomicStampedImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/datastructures/GridCacheAtomicStampedImpl.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/datastructures/GridCacheAtomicStampedImpl.java
index 0717914..3596724 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/datastructures/GridCacheAtomicStampedImpl.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/datastructures/GridCacheAtomicStampedImpl.java
@@ -18,7 +18,6 @@
 package org.apache.ignite.internal.processors.datastructures;
 
 import org.apache.ignite.*;
-import org.apache.ignite.cache.*;
 import org.apache.ignite.internal.*;
 import org.apache.ignite.internal.processors.cache.*;
 import org.apache.ignite.internal.processors.cache.transactions.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f27a989c/modules/core/src/main/java/org/apache/ignite/internal/processors/datastructures/GridCacheCountDownLatchImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/datastructures/GridCacheCountDownLatchImpl.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/datastructures/GridCacheCountDownLatchImpl.java
index 40811b7..cb85136 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/datastructures/GridCacheCountDownLatchImpl.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/datastructures/GridCacheCountDownLatchImpl.java
@@ -18,7 +18,6 @@
 package org.apache.ignite.internal.processors.datastructures;
 
 import org.apache.ignite.*;
-import org.apache.ignite.cache.*;
 import org.apache.ignite.internal.*;
 import org.apache.ignite.internal.processors.cache.*;
 import org.apache.ignite.internal.processors.cache.transactions.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f27a989c/modules/core/src/main/java/org/apache/ignite/internal/visor/query/VisorQueryTask.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/visor/query/VisorQueryTask.java b/modules/core/src/main/java/org/apache/ignite/internal/visor/query/VisorQueryTask.java
index d975021..f062ee1 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/visor/query/VisorQueryTask.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/visor/query/VisorQueryTask.java
@@ -21,6 +21,7 @@ import org.apache.ignite.*;
 import org.apache.ignite.cache.*;
 import org.apache.ignite.cluster.*;
 import org.apache.ignite.internal.*;
+import org.apache.ignite.internal.processors.cache.*;
 import org.apache.ignite.internal.processors.cache.query.*;
 import org.apache.ignite.internal.processors.query.*;
 import org.apache.ignite.internal.processors.task.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f27a989c/modules/core/src/main/java/org/apache/ignite/transactions/Transaction.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/transactions/Transaction.java b/modules/core/src/main/java/org/apache/ignite/transactions/Transaction.java
index da2d1bd..e2fc42d 100644
--- a/modules/core/src/main/java/org/apache/ignite/transactions/Transaction.java
+++ b/modules/core/src/main/java/org/apache/ignite/transactions/Transaction.java
@@ -18,6 +18,7 @@
 package org.apache.ignite.transactions;
 
 import org.apache.ignite.*;
+import org.apache.ignite.internal.processors.cache.*;
 import org.apache.ignite.lang.*;
 import org.jetbrains.annotations.*;
 
@@ -27,7 +28,7 @@ import java.util.*;
  * Grid cache transaction. Cache transactions have a default 2PC (two-phase-commit) behavior and
  * can be plugged into ongoing {@code JTA} transaction by properly implementing
  * {@ignitelink org.apache.ignite.cache.jta.CacheTmLookup}
- * interface. Cache transactions can also be started explicitly directly from {@link org.apache.ignite.cache.CacheProjection} API
+ * interface. Cache transactions can also be started explicitly directly from {@link CacheProjection} API
  * via any of the {@code 'CacheProjection.txStart(..)'} methods.
  * <p>
  * Cache transactions support the following isolation levels:

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f27a989c/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/query/reducefields/GridCacheAbstractReduceFieldsQuerySelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/query/reducefields/GridCacheAbstractReduceFieldsQuerySelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/query/reducefields/GridCacheAbstractReduceFieldsQuerySelfTest.java
index 35546ae..0c48643 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/query/reducefields/GridCacheAbstractReduceFieldsQuerySelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/query/reducefields/GridCacheAbstractReduceFieldsQuerySelfTest.java
@@ -21,6 +21,7 @@ import org.apache.ignite.cache.*;
 import org.apache.ignite.cache.affinity.*;
 import org.apache.ignite.cache.query.annotations.*;
 import org.apache.ignite.configuration.*;
+import org.apache.ignite.internal.processors.cache.*;
 import org.apache.ignite.internal.processors.cache.query.*;
 import org.apache.ignite.internal.*;
 import org.apache.ignite.internal.util.typedef.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f27a989c/modules/hadoop/src/main/java/org/apache/ignite/internal/processors/hadoop/jobtracker/GridHadoopJobTracker.java
----------------------------------------------------------------------
diff --git a/modules/hadoop/src/main/java/org/apache/ignite/internal/processors/hadoop/jobtracker/GridHadoopJobTracker.java b/modules/hadoop/src/main/java/org/apache/ignite/internal/processors/hadoop/jobtracker/GridHadoopJobTracker.java
index a7e3b8f..0beaf32 100644
--- a/modules/hadoop/src/main/java/org/apache/ignite/internal/processors/hadoop/jobtracker/GridHadoopJobTracker.java
+++ b/modules/hadoop/src/main/java/org/apache/ignite/internal/processors/hadoop/jobtracker/GridHadoopJobTracker.java
@@ -18,7 +18,6 @@
 package org.apache.ignite.internal.processors.hadoop.jobtracker;
 
 import org.apache.ignite.*;
-import org.apache.ignite.cache.*;
 import org.apache.ignite.events.*;
 import org.apache.ignite.events.EventType;
 import org.apache.ignite.internal.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f27a989c/modules/hibernate/src/main/java/org/apache/ignite/cache/hibernate/GridHibernateAccessStrategyAdapter.java
----------------------------------------------------------------------
diff --git a/modules/hibernate/src/main/java/org/apache/ignite/cache/hibernate/GridHibernateAccessStrategyAdapter.java b/modules/hibernate/src/main/java/org/apache/ignite/cache/hibernate/GridHibernateAccessStrategyAdapter.java
index eaea273..bc01095 100644
--- a/modules/hibernate/src/main/java/org/apache/ignite/cache/hibernate/GridHibernateAccessStrategyAdapter.java
+++ b/modules/hibernate/src/main/java/org/apache/ignite/cache/hibernate/GridHibernateAccessStrategyAdapter.java
@@ -20,6 +20,7 @@ package org.apache.ignite.cache.hibernate;
 import org.apache.ignite.*;
 import org.apache.ignite.cache.*;
 import org.apache.ignite.internal.*;
+import org.apache.ignite.internal.processors.cache.*;
 import org.apache.ignite.internal.util.typedef.internal.*;
 import org.apache.ignite.lang.*;
 import org.apache.ignite.resources.*;
@@ -28,7 +29,6 @@ import org.hibernate.cache.spi.access.*;
 import org.jetbrains.annotations.*;
 
 import java.io.*;
-import java.util.concurrent.*;
 
 /**
  * Common interface used to implement Hibernate L2 cache access strategies ({@link RegionAccessStrategy},

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f27a989c/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheOffHeapAndSwapSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheOffHeapAndSwapSelfTest.java b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheOffHeapAndSwapSelfTest.java
index 6ad56b3..160bdd6 100644
--- a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheOffHeapAndSwapSelfTest.java
+++ b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheOffHeapAndSwapSelfTest.java
@@ -19,7 +19,6 @@ package org.apache.ignite.internal.processors.cache;
 
 import org.apache.ignite.*;
 import org.apache.ignite.cache.*;
-import org.apache.ignite.cache.query.*;
 import org.apache.ignite.configuration.*;
 import org.apache.ignite.events.*;
 import org.apache.ignite.internal.*;
@@ -409,7 +408,7 @@ public class GridCacheOffHeapAndSwapSelfTest extends GridCommonAbstractTest {
     }
 
     /**
-     * Tests {@link org.apache.ignite.cache.CacheProjection#promote(Object)} behavior on offheaped entries.
+     * Tests {@link CacheProjection#promote(Object)} behavior on offheaped entries.
      *
      * @throws Exception If failed.
      */

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f27a989c/modules/spring/src/main/java/org/apache/ignite/cache/spring/SpringCache.java
----------------------------------------------------------------------
diff --git a/modules/spring/src/main/java/org/apache/ignite/cache/spring/SpringCache.java b/modules/spring/src/main/java/org/apache/ignite/cache/spring/SpringCache.java
index 1d1fd8c..6719069 100644
--- a/modules/spring/src/main/java/org/apache/ignite/cache/spring/SpringCache.java
+++ b/modules/spring/src/main/java/org/apache/ignite/cache/spring/SpringCache.java
@@ -18,7 +18,7 @@
 package org.apache.ignite.cache.spring;
 
 import org.apache.ignite.*;
-import org.apache.ignite.cache.*;
+import org.apache.ignite.internal.processors.cache.*;
 import org.apache.ignite.internal.util.typedef.*;
 import org.apache.ignite.lang.*;
 import org.springframework.cache.*;


[07/50] [abbrv] incubator-ignite git commit: Merge branch 'sprint-1' into ignite-204

Posted by vk...@apache.org.
Merge branch 'sprint-1' into ignite-204


Project: http://git-wip-us.apache.org/repos/asf/incubator-ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-ignite/commit/56818bd9
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/56818bd9
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/56818bd9

Branch: refs/heads/master
Commit: 56818bd9f7e7e29914d596b2ebed94579f75334c
Parents: 9edc6ca f459714
Author: Artem Shutak <as...@gridgain.com>
Authored: Mon Feb 16 14:36:13 2015 +0300
Committer: Artem Shutak <as...@gridgain.com>
Committed: Mon Feb 16 14:36:13 2015 +0300

----------------------------------------------------------------------
 .../cache/distributed/dht/atomic/GridDhtAtomicCache.java         | 2 +-
 .../processors/cache/transactions/IgniteTxLocalAdapter.java      | 2 +-
 .../datastructures/GridTransactionalCacheQueueImpl.java          | 4 ++--
 .../apache/ignite/visor/commands/cache/VisorCacheCommand.scala   | 2 +-
 .../apache/ignite/visor/commands/top/VisorTopologyCommand.scala  | 3 +--
 .../src/main/scala/org/apache/ignite/visor/visor.scala           | 2 +-
 6 files changed, 7 insertions(+), 8 deletions(-)
----------------------------------------------------------------------



[08/50] [abbrv] incubator-ignite git commit: # ignite-204 : fix GridGain occurrences - delete unused functions from assembly/docfiles/tools.js

Posted by vk...@apache.org.
# ignite-204 : fix GridGain occurrences - delete unused functions from assembly/docfiles/tools.js


Project: http://git-wip-us.apache.org/repos/asf/incubator-ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-ignite/commit/0cf20b30
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/0cf20b30
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/0cf20b30

Branch: refs/heads/master
Commit: 0cf20b3013eb12d30fc2827ba300b1eb8cf2acb4
Parents: 56818bd
Author: Artem Shutak <as...@gridgain.com>
Authored: Mon Feb 16 14:40:19 2015 +0300
Committer: Artem Shutak <as...@gridgain.com>
Committed: Mon Feb 16 14:40:19 2015 +0300

----------------------------------------------------------------------
 assembly/docfiles/tools.js | 30 ------------------------------
 1 file changed, 30 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/0cf20b30/assembly/docfiles/tools.js
----------------------------------------------------------------------
diff --git a/assembly/docfiles/tools.js b/assembly/docfiles/tools.js
index b37eda4..3bd8323 100644
--- a/assembly/docfiles/tools.js
+++ b/assembly/docfiles/tools.js
@@ -27,33 +27,3 @@ function toggleDisplay(id) {
         e.style.visibility = 'visible';
     }
 }
-
-/*
- * Produces forum search form.
- */
-function forumSearchForm(root) {
-    document.write(
-        "<form  method='POST' action='http://www.gridgainsystems.com/jiveforums/search.jspa' target='forum' style='margin: 1px; padding: 1px'>" +
-            "" +
-            "<input class='search_text' type='text' style='color: #ccc' onClick='this.value=\"\"; this.style.color=\"#333\"' name='q' value=' find...' size='20' maxlength='100'>" +
-            "&nbsp;" +
-            "<input title='Search Forum' class='search_button' name='button' type='submit' value='f o r u m'>" +
-        "</form>"
-    );
-}
-
-/*
- * Produces Wiki search form.
- */
-function wikiSearchForm(root) {
-    document.write(
-        "<form method='POST' action='http://www.gridgainsystems.com:8080/wiki/dosearchsite.action' target='wiki' style='margin: 1px; padding: 1px' name='search_form'>" +
-            "" +
-            "<input type='hidden' name='quickSearch' value='true'>" +
-            "<input type='hidden' name='searchQuery.spaceKey' value='conf_global'>" +
-            "<input class='search_text' type='text' style='color: #ccc' onClick='this.value=\"\"; this.style.color=\"#333\"' accessKey='s' value=' find...' name='searchQuery.queryString' size='20'>" +
-            "&nbsp;" +
-            "<input title='Search Wiki' class='search_button' name='button' type='submit' value='w i k i'>" +
-        "</form>"
-    );
-}


[39/50] [abbrv] incubator-ignite git commit: Merge remote-tracking branch 'remotes/origin/sprint-1' into sprint-1-release

Posted by vk...@apache.org.
Merge remote-tracking branch 'remotes/origin/sprint-1' into sprint-1-release


Project: http://git-wip-us.apache.org/repos/asf/incubator-ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-ignite/commit/bd820cef
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/bd820cef
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/bd820cef

Branch: refs/heads/master
Commit: bd820cef2be8123d5c906091e57e57f835e0a50e
Parents: 397b730 5926470
Author: sboikov <sb...@gridgain.com>
Authored: Mon Feb 16 17:18:45 2015 +0300
Committer: sboikov <sb...@gridgain.com>
Committed: Mon Feb 16 17:18:45 2015 +0300

----------------------------------------------------------------------
 .../datastructures/IgniteQueueExample.java      |  2 +-
 .../datastructures/DataStructuresProcessor.java | 15 ++++++-
 .../IgniteDataStructureUniqueNameTest.java      | 41 ++++++++++++++++++++
 3 files changed, 56 insertions(+), 2 deletions(-)
----------------------------------------------------------------------



[34/50] [abbrv] incubator-ignite git commit: sprint-1: moved cache projection to internal

Posted by vk...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f27a989c/modules/core/src/main/java/org/apache/ignite/cache/GridCache.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/cache/GridCache.java b/modules/core/src/main/java/org/apache/ignite/cache/GridCache.java
index d57e5e5..bb48ee4 100644
--- a/modules/core/src/main/java/org/apache/ignite/cache/GridCache.java
+++ b/modules/core/src/main/java/org/apache/ignite/cache/GridCache.java
@@ -22,6 +22,7 @@ import org.apache.ignite.cache.affinity.*;
 import org.apache.ignite.cache.store.*;
 import org.apache.ignite.configuration.*;
 import org.apache.ignite.internal.*;
+import org.apache.ignite.internal.processors.cache.*;
 import org.apache.ignite.lang.*;
 import org.apache.ignite.mxbean.*;
 import org.apache.ignite.transactions.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f27a989c/modules/core/src/main/java/org/apache/ignite/configuration/CacheConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/configuration/CacheConfiguration.java b/modules/core/src/main/java/org/apache/ignite/configuration/CacheConfiguration.java
index 858dc3c..57583d4 100644
--- a/modules/core/src/main/java/org/apache/ignite/configuration/CacheConfiguration.java
+++ b/modules/core/src/main/java/org/apache/ignite/configuration/CacheConfiguration.java
@@ -22,6 +22,7 @@ import org.apache.ignite.cache.*;
 import org.apache.ignite.cache.affinity.*;
 import org.apache.ignite.cache.eviction.*;
 import org.apache.ignite.cache.store.*;
+import org.apache.ignite.internal.processors.cache.*;
 import org.apache.ignite.internal.util.typedef.internal.*;
 import org.apache.ignite.spi.indexing.*;
 import org.jetbrains.annotations.*;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f27a989c/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/CacheFlag.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/CacheFlag.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/CacheFlag.java
index 947d5df..50fb4d3 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/CacheFlag.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/CacheFlag.java
@@ -25,10 +25,10 @@ import javax.cache.processor.*;
 
 /**
  * Cache projection flags that specify projection behaviour. This flags can be explicitly passed into
- * the following methods on {@link org.apache.ignite.cache.CacheProjection}:
+ * the following methods on {@link CacheProjection}:
  * <ul>
- * <li>{@link org.apache.ignite.cache.CacheProjection#flagsOn(CacheFlag...)}</li>
- * <li>{@link org.apache.ignite.cache.CacheProjection#flagsOff(CacheFlag...)}</li>
+ * <li>{@link CacheProjection#flagsOn(CacheFlag...)}</li>
+ * <li>{@link CacheProjection#flagsOff(CacheFlag...)}</li>
  * </ul>
  * Also, some flags, like {@link #LOCAL}, or {@link #READ} may be implicitly set whenever
  * creating new projections and passing entries to predicate filters.


[05/50] [abbrv] incubator-ignite git commit: # sprint-1 Fixed Visor Plugins package group in javadoc.

Posted by vk...@apache.org.
# sprint-1 Fixed Visor Plugins package group in javadoc.


Project: http://git-wip-us.apache.org/repos/asf/incubator-ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-ignite/commit/f4597140
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/f4597140
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/f4597140

Branch: refs/heads/master
Commit: f4597140f82abb8c25686f3df7396e8fb59d23f8
Parents: b1a7ab4
Author: anovikov <an...@gridgain.com>
Authored: Mon Feb 16 18:00:38 2015 +0700
Committer: anovikov <an...@gridgain.com>
Committed: Mon Feb 16 18:00:38 2015 +0700

----------------------------------------------------------------------
 pom.xml | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f4597140/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
index 9e1d29f..51c3365 100644
--- a/pom.xml
+++ b/pom.xml
@@ -1012,7 +1012,7 @@
                                         </group>
                                         <group>
                                             <title>Visor Plugins</title>
-                                            <packages>org.gridgain.visor.plugin</packages>
+                                            <packages>org.apache.ignite.visor.plugin</packages>
                                         </group>
                                         <group>
                                             <title>Spring Caching</title>


[28/50] [abbrv] incubator-ignite git commit: Merge branches 'ignite-public-api-cleanup' and 'sprint-1' of https://git-wip-us.apache.org/repos/asf/incubator-ignite into ignite-public-api-cleanup

Posted by vk...@apache.org.
Merge branches 'ignite-public-api-cleanup' and 'sprint-1' of https://git-wip-us.apache.org/repos/asf/incubator-ignite into ignite-public-api-cleanup


Project: http://git-wip-us.apache.org/repos/asf/incubator-ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-ignite/commit/1441a7f5
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/1441a7f5
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/1441a7f5

Branch: refs/heads/master
Commit: 1441a7f5877caedea1ea77d2a6afea8dccded6e6
Parents: 887a807 761882b
Author: AKuznetsov <ak...@gridgain.com>
Authored: Mon Feb 16 20:23:40 2015 +0700
Committer: AKuznetsov <ak...@gridgain.com>
Committed: Mon Feb 16 20:23:40 2015 +0700

----------------------------------------------------------------------
 .../continuous/CacheContinuousQueryManager.java | 49 ++++++++++++--------
 1 file changed, 30 insertions(+), 19 deletions(-)
----------------------------------------------------------------------



[14/50] [abbrv] incubator-ignite git commit: TC package fix

Posted by vk...@apache.org.
TC package fix


Project: http://git-wip-us.apache.org/repos/asf/incubator-ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-ignite/commit/19c1b5c2
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/19c1b5c2
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/19c1b5c2

Branch: refs/heads/master
Commit: 19c1b5c28a463f18282d50fb8ff5d879b0c3217b
Parents: 3ba4f3c
Author: avinogradov <av...@gridgain.com>
Authored: Mon Feb 16 15:30:59 2015 +0300
Committer: avinogradov <av...@gridgain.com>
Committed: Mon Feb 16 15:30:59 2015 +0300

----------------------------------------------------------------------
 pom.xml | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/19c1b5c2/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
index 04fb0c5..8071ee3 100644
--- a/pom.xml
+++ b/pom.xml
@@ -989,7 +989,7 @@
                                         </group>
                                         <group>
                                             <title>Ignite plugin API</title>
-                                            <packages>org.apache.ignite.plugin:org.apache.ignite.plugin.extensions:org.apache.ignite.plugin.extensions.communication:org.apache.ignite.visor.plugin</packages>
+                                            <packages>org.apache.ignite.plugin:org.apache.ignite.plugin.extensions:org.apache.ignite.plugin.extensions.communication</packages>
                                         </group>
                                         <group>
                                             <title>Logging</title>


[06/50] [abbrv] incubator-ignite git commit: # ignite-204 : fix GridGain occurrences (portables from clients/test at spring-configs)

Posted by vk...@apache.org.
# ignite-204 : fix GridGain occurrences (portables from clients/test at spring-configs)


Project: http://git-wip-us.apache.org/repos/asf/incubator-ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-ignite/commit/9edc6ca2
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/9edc6ca2
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/9edc6ca2

Branch: refs/heads/master
Commit: 9edc6ca2afd61176407deb33eb6da686b2b83441
Parents: d220443
Author: Artem Shutak <as...@gridgain.com>
Authored: Mon Feb 16 14:35:00 2015 +0300
Committer: Artem Shutak <as...@gridgain.com>
Committed: Mon Feb 16 14:35:00 2015 +0300

----------------------------------------------------------------------
 .../clients/src/test/resources/spring-cache.xml | 12 -----------
 .../src/test/resources/spring-server-node.xml   | 21 --------------------
 .../test/resources/spring-server-ssl-node.xml   | 20 ++-----------------
 3 files changed, 2 insertions(+), 51 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/9edc6ca2/modules/clients/src/test/resources/spring-cache.xml
----------------------------------------------------------------------
diff --git a/modules/clients/src/test/resources/spring-cache.xml b/modules/clients/src/test/resources/spring-cache.xml
index 6e93f4e..d34e3cc 100644
--- a/modules/clients/src/test/resources/spring-cache.xml
+++ b/modules/clients/src/test/resources/spring-cache.xml
@@ -222,17 +222,5 @@
                 </property>
             </bean>
         </property>
-
-        <property name="portableConfiguration">
-            <bean class="org.gridgain.grid.portables.PortableConfiguration">
-                <property name="typeConfigurations">
-                    <list>
-                        <bean class="org.gridgain.grid.portables.PortableTypeConfiguration">
-                            <property name="className" value="org.gridgain.client.ClientTestPortable"/>
-                        </bean>
-                    </list>
-                </property>
-            </bean>
-        </property>
     </bean>
 </beans>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/9edc6ca2/modules/clients/src/test/resources/spring-server-node.xml
----------------------------------------------------------------------
diff --git a/modules/clients/src/test/resources/spring-server-node.xml b/modules/clients/src/test/resources/spring-server-node.xml
index 3aff4a2..3b19f3d 100644
--- a/modules/clients/src/test/resources/spring-server-node.xml
+++ b/modules/clients/src/test/resources/spring-server-node.xml
@@ -72,27 +72,6 @@
             </list>
         </property>
 
-        <property name="portableConfiguration">
-            <bean class="org.gridgain.grid.portables.PortableConfiguration">
-                <property name="typeConfigurations">
-                    <list>
-                        <bean class="org.gridgain.grid.portables.PortableTypeConfiguration">
-                            <property name="className" value="org.gridgain.client.ClientTestPortable"/>
-                        </bean>
-                        <bean class="org.gridgain.grid.portables.PortableTypeConfiguration">
-                            <property name="className" value="org.apache.ignite.client.model.GridPortablePerson"/>
-                        </bean>
-                        <bean class="org.gridgain.grid.portables.PortableTypeConfiguration">
-                            <property name="className" value="org.apache.ignite.client.model.GridImplicitPortablePerson"/>
-                        </bean>
-                        <bean class="org.gridgain.grid.portables.PortableTypeConfiguration">
-                            <property name="className" value="GridNoDefPortablePerson"/>
-                        </bean>
-                    </list>
-                </property>
-            </bean>
-        </property>
-
         <!-- Client configuration. -->
         <property name="connectorConfiguration">
             <bean class="org.apache.ignite.configuration.ConnectorConfiguration">

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/9edc6ca2/modules/clients/src/test/resources/spring-server-ssl-node.xml
----------------------------------------------------------------------
diff --git a/modules/clients/src/test/resources/spring-server-ssl-node.xml b/modules/clients/src/test/resources/spring-server-ssl-node.xml
index bffc965..3989ac6 100644
--- a/modules/clients/src/test/resources/spring-server-ssl-node.xml
+++ b/modules/clients/src/test/resources/spring-server-ssl-node.xml
@@ -28,12 +28,8 @@
 -->
 <beans xmlns="http://www.springframework.org/schema/beans"
        xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-       xmlns:util="http://www.springframework.org/schema/util"
-       xsi:schemaLocation="
-       http://www.springframework.org/schema/beans
-       http://www.springframework.org/schema/beans/spring-beans.xsd
-       http://www.springframework.org/schema/util
-       http://www.springframework.org/schema/util/spring-util.xsd">
+       xsi:schemaLocation="http://www.springframework.org/schema/beans
+       http://www.springframework.org/schema/beans/spring-beans.xsd">
 
     <!--
         Optional description.
@@ -263,17 +259,5 @@
         <property name="publicThreadPoolSize" value="15"/>
 
         <property name="systemThreadPoolSize" value="15"/>
-
-        <property name="portableConfiguration">
-            <bean class="org.gridgain.grid.portables.PortableConfiguration">
-                <property name="typeConfigurations">
-                    <list>
-                        <bean class="org.gridgain.grid.portables.PortableTypeConfiguration">
-                            <property name="className" value="org.gridgain.client.ClientTestPortable"/>
-                        </bean>
-                    </list>
-                </property>
-            </bean>
-        </property>
     </bean>
 </beans>


[02/50] [abbrv] incubator-ignite git commit: Merge remote-tracking branch 'origin/sprint-1' into sprint-1

Posted by vk...@apache.org.
Merge remote-tracking branch 'origin/sprint-1' into sprint-1


Project: http://git-wip-us.apache.org/repos/asf/incubator-ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-ignite/commit/6e536271
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/6e536271
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/6e536271

Branch: refs/heads/master
Commit: 6e536271f5f24f500ce13f46d6f5bce3bdc1c8de
Parents: 4ffb6db c0e1b52
Author: sboikov <sb...@gridgain.com>
Authored: Mon Feb 16 13:46:47 2015 +0300
Committer: sboikov <sb...@gridgain.com>
Committed: Mon Feb 16 13:46:47 2015 +0300

----------------------------------------------------------------------
 .../org/apache/ignite/compute/ComputeTask.java  |  3 +--
 .../apache/ignite/resources/package-info.java   | 22 +++++++++++++++++
 .../org/apache/ignite/resources/package.html    | 25 --------------------
 .../commands/cache/VisorCacheCommand.scala      |  2 +-
 .../commands/top/VisorTopologyCommand.scala     |  3 +--
 .../scala/org/apache/ignite/visor/visor.scala   |  2 +-
 6 files changed, 26 insertions(+), 31 deletions(-)
----------------------------------------------------------------------



[42/50] [abbrv] incubator-ignite git commit: # sprint-1 - Fixed build

Posted by vk...@apache.org.
# sprint-1 - Fixed build


Project: http://git-wip-us.apache.org/repos/asf/incubator-ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-ignite/commit/66ca1161
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/66ca1161
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/66ca1161

Branch: refs/heads/master
Commit: 66ca11612077871bb05caf77aae8c5d5f5087d66
Parents: 82924b6
Author: Valentin Kulichenko <vk...@gridgain.com>
Authored: Mon Feb 16 09:54:19 2015 -0800
Committer: Valentin Kulichenko <vk...@gridgain.com>
Committed: Mon Feb 16 09:54:19 2015 -0800

----------------------------------------------------------------------
 pom.xml | 16 +---------------
 1 file changed, 1 insertion(+), 15 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/66ca1161/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
index b6bee00..033f9dc 100644
--- a/pom.xml
+++ b/pom.xml
@@ -868,7 +868,7 @@
                                 <goals>
                                     <goal>aggregate</goal>
                                 </goals>
-                                <phase>prepare-package</phase>
+                                <phase>process-test-classes</phase>
                                 <configuration>
                                     <taglets>
                                         <taglet>
@@ -1096,13 +1096,6 @@
                                             </fileset>
                                         </copy>
 
-                                        <copy todir="${basedir}/target/javadoc/client">
-                                            <fileset dir="assembly/docfiles">
-                                                <include name="img/**"/>
-                                                <include name="*.js"/>
-                                            </fileset>
-                                        </copy>
-
                                         <taskdef name="doctask"
                                                  classname="org.apache.ignite.tools.ant.beautifier.GridJavadocAntTask"/>
 
@@ -1112,13 +1105,6 @@
                                             <exclude name="allclasses-frame.html"/>
                                             <exclude name="**/class-use/*"/>
                                         </doctask>
-
-                                        <doctask css="dotted" dir="target/javadoc/client">
-                                            <include name="**/*.html"/>
-                                            <exclude name="overview-frame.html"/>
-                                            <exclude name="allclasses-frame.html"/>
-                                            <exclude name="**/class-use/*"/>
-                                        </doctask>
                                     </target>
                                 </configuration>
                             </execution>


[49/50] [abbrv] incubator-ignite git commit: Merge branch 'sprint-1' of https://git-wip-us.apache.org/repos/asf/incubator-ignite into sprint-1-release

Posted by vk...@apache.org.
Merge branch 'sprint-1' of https://git-wip-us.apache.org/repos/asf/incubator-ignite into sprint-1-release


Project: http://git-wip-us.apache.org/repos/asf/incubator-ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-ignite/commit/16ef8eac
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/16ef8eac
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/16ef8eac

Branch: refs/heads/master
Commit: 16ef8eac5492b362d03481b4419be87c75849212
Parents: a245325 a4101a5
Author: Valentin Kulichenko <vk...@gridgain.com>
Authored: Mon Feb 16 22:38:13 2015 -0800
Committer: Valentin Kulichenko <vk...@gridgain.com>
Committed: Mon Feb 16 22:38:13 2015 -0800

----------------------------------------------------------------------
 .../internal/visor/node/VisorExecutorServiceConfiguration.java      | 1 +
 1 file changed, 1 insertion(+)
----------------------------------------------------------------------



[16/50] [abbrv] incubator-ignite git commit: IGNITE-261 Scalar: fixed examples and tests.

Posted by vk...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f0209856/modules/scalar/src/test/scala/org/apache/ignite/scalar/tests/ScalarCacheQueriesSpec.scala
----------------------------------------------------------------------
diff --git a/modules/scalar/src/test/scala/org/apache/ignite/scalar/tests/ScalarCacheQueriesSpec.scala b/modules/scalar/src/test/scala/org/apache/ignite/scalar/tests/ScalarCacheQueriesSpec.scala
index f4e7fb8..8d91fdc 100644
--- a/modules/scalar/src/test/scala/org/apache/ignite/scalar/tests/ScalarCacheQueriesSpec.scala
+++ b/modules/scalar/src/test/scala/org/apache/ignite/scalar/tests/ScalarCacheQueriesSpec.scala
@@ -25,6 +25,8 @@ import org.junit.runner.RunWith
 import org.scalatest._
 import org.scalatest.junit.JUnitRunner
 
+import scala.collection.JavaConversions._
+
 /**
  * Tests for Scalar cache queries API.
  */
@@ -53,9 +55,7 @@ class ScalarCacheQueriesSpec extends FlatSpec with ShouldMatchers with BeforeAnd
 
         (1 to ENTRY_CNT).foreach(i => c.put(i, ObjectValue(i, "str " + WORDS(i))))
 
-        val peekModes = Array.empty[CachePeekMode]
-
-        assert(c.size(peekModes:_*) == ENTRY_CNT)
+        assert(c.size(Array.empty[CachePeekMode]:_*) == ENTRY_CNT)
 
         c.foreach(e => println(e.getKey + " -> " + e.getValue))
     }
@@ -70,504 +70,129 @@ class ScalarCacheQueriesSpec extends FlatSpec with ShouldMatchers with BeforeAnd
     behavior of "Scalar cache queries API"
 
     it should "correctly execute SCAN queries" in {
-        var res = c.scan(classOf[ObjectValue], (k: Int, v: ObjectValue) => k > 5 && v.intVal < 8)
+        var res = c.scan(classOf[ObjectValue], (k: Int, v: ObjectValue) => k > 5 && v.intVal < 8).getAll
 
         assert(res.size == 2)
 
-        res.foreach(t => assert(t._1 > 5 && t._1 < 8 && t._1 == t._2.intVal))
+        res.foreach(t => assert(t.getKey > 5 && t.getKey < 8 && t.getKey == t.getValue.intVal))
 
-        res = c.scan((k: Int, v: ObjectValue) => k > 5 && v.intVal < 8)
+        res = c.scan((k: Int, v: ObjectValue) => k > 5 && v.intVal < 8).getAll
 
         assert(res.size == 2)
 
-        res.foreach(t => assert(t._1 > 5 && t._1 < 8 && t._1 == t._2.intVal))
+        res.foreach(t => assert(t.getKey > 5 && t.getKey < 8 && t.getKey == t.getValue.intVal))
 
-        res = c.scan(classOf[ObjectValue], (k: Int, v: ObjectValue) => k > 5 && v.intVal < 8)
+        res = c.scan(classOf[ObjectValue], (k: Int, v: ObjectValue) => k > 5 && v.intVal < 8).getAll
 
         assert(res.size == 2)
 
-        res.foreach(t => assert(t._1 > 5 && t._1 < 8 && t._1 == t._2.intVal))
+        res.foreach(t => assert(t.getKey > 5 && t.getKey < 8 && t.getKey == t.getValue.intVal))
 
-        res = c.scan((k: Int, v: ObjectValue) => k > 5 && v.intVal < 8)
+        res = c.scan((k: Int, v: ObjectValue) => k > 5 && v.intVal < 8).getAll
 
         assert(res.size == 2)
 
-        res.foreach(t => assert(t._1 > 5 && t._1 < 8 && t._1 == t._2.intVal))
+        res.foreach(t => assert(t.getKey > 5 && t.getKey < 8 && t.getKey == t.getValue.intVal))
     }
 
     it should "correctly execute SQL queries" in {
-        var res = c.sql(classOf[ObjectValue], "intVal > 5")
+        var res = c.sql(classOf[ObjectValue], "intVal > 5").getAll
 
         assert(res.size == ENTRY_CNT - 5)
 
-        res.foreach(t => assert(t._1 > 5 && t._1 == t._2.intVal))
+        res.foreach(t => assert(t.getKey > 5 && t.getKey == t.getValue.intVal))
 
-        res = c.sql(classOf[ObjectValue], "intVal > ?", 5)
+        res = c.sql(classOf[ObjectValue], "intVal > ?", 5).getAll
 
         assert(res.size == ENTRY_CNT - 5)
 
-        res.foreach(t => assert(t._1 > 5 && t._1 == t._2.intVal))
+        res.foreach(t => assert(t.getKey > 5 && t.getKey == t.getValue.intVal))
 
-        res = c.sql("intVal > 5")
+        res = c.sql("intVal > 5").getAll
 
         assert(res.size == ENTRY_CNT - 5)
 
-        res.foreach(t => assert(t._1 > 5 && t._1 == t._2.intVal))
+        res.foreach(t => assert(t.getKey > 5 && t.getKey == t.getValue.intVal))
 
-        res = c.sql("intVal > ?", 5)
+        res = c.sql("intVal > ?", 5).getAll
 
         assert(res.size == ENTRY_CNT - 5)
 
-        res.foreach(t => assert(t._1 > 5 && t._1 == t._2.intVal))
+        res.foreach(t => assert(t.getKey > 5 && t.getKey == t.getValue.intVal))
 
-        res = c.sql(classOf[ObjectValue], "intVal > 5")
+        res = c.sql(classOf[ObjectValue], "intVal > 5").getAll
 
         assert(res.size == ENTRY_CNT - 5)
 
-        res.foreach(t => assert(t._1 > 5 && t._1 == t._2.intVal))
+        res.foreach(t => assert(t.getKey > 5 && t.getKey == t.getValue.intVal))
 
-        res = c.sql(classOf[ObjectValue], "intVal > ?", 5)
+        res = c.sql(classOf[ObjectValue], "intVal > ?", 5).getAll
 
         assert(res.size == ENTRY_CNT - 5)
 
-        res.foreach(t => assert(t._1 > 5 && t._1 == t._2.intVal))
+        res.foreach(t => assert(t.getKey > 5 && t.getKey == t.getValue.intVal))
 
-        res.foreach(t => assert(t._1 > 5 && t._1 == t._2.intVal))
+        res.foreach(t => assert(t.getKey > 5 && t.getKey == t.getValue.intVal))
 
-        res = c.sql("intVal > 5")
+        res = c.sql("intVal > 5").getAll
 
         assert(res.size == ENTRY_CNT - 5)
 
-        res.foreach(t => assert(t._1 > 5 && t._1 == t._2.intVal))
+        res.foreach(t => assert(t.getKey > 5 && t.getKey == t.getValue.intVal))
 
-        res = c.sql("intVal > ?", 5)
+        res = c.sql("intVal > ?", 5).getAll
 
         assert(res.size == ENTRY_CNT - 5)
 
-        res.foreach(t => assert(t._1 > 5 && t._1 == t._2.intVal))
+        res.foreach(t => assert(t.getKey > 5 && t.getKey == t.getValue.intVal))
     }
 
     it should "correctly execute TEXT queries" in {
-        var res = c.text(classOf[ObjectValue], "str")
-
-        assert(res.size == ENTRY_CNT)
-
-        res = c.text(classOf[ObjectValue], "five")
-
-        assert(res.size == 1)
-        assert(res.head._1 == 5)
-
-        res = c.text("str")
-
-        assert(res.size == ENTRY_CNT)
-
-        res = c.text("five")
-
-        assert(res.size == 1)
-        assert(res.head._1 == 5)
-
-        res = c.text(classOf[ObjectValue], "str")
-
-        assert(res.size == ENTRY_CNT)
-
-        res = c.text(classOf[ObjectValue], "five")
-
-        assert(res.size == 1)
-        assert(res.head._1 == 5)
-
-        res = c.text("str")
-
-        assert(res.size == ENTRY_CNT)
-
-        res = c.text("five")
-
-        assert(res.size == 1)
-        assert(res.head._1 == 5)
-    }
-
-    it should "correctly execute SCAN transform queries" in {
-        var res = c.scanTransform(classOf[ObjectValue], (k: Int, v: ObjectValue) => k > 5 && v.intVal < 8,
-            (v: ObjectValue) => v.intVal + 1)
-
-        assert(res.size == 2)
-
-        res.foreach(t => assert(t._1 > 5 && t._1 < 8 && t._1 + 1 == t._2))
-
-        res = c.scanTransform((k: Int, v: ObjectValue) => k > 5 && v.intVal < 8, (v: ObjectValue) => v.intVal + 1)
-
-        assert(res.size == 2)
-
-        res.foreach(t => assert(t._1 > 5 && t._1 < 8 && t._1 + 1 == t._2))
-
-        res = c.scanTransform(classOf[ObjectValue], (k: Int, v: ObjectValue) => k > 5 && v.intVal < 8, (v: ObjectValue) => v.intVal + 1)
-
-        assert(res.size == 2)
-
-        res.foreach(t => assert(t._1 > 5 && t._1 < 8 && t._1 + 1 == t._2))
-
-        res = c.scanTransform((k: Int, v: ObjectValue) => k > 5 && v.intVal < 8, (v: ObjectValue) => v.intVal + 1)
-
-        assert(res.size == 2)
-
-        res.foreach(t => assert(t._1 > 5 && t._1 < 8 && t._1 + 1 == t._2))
-    }
-
-    it should "correctly execute SQL transform queries" in {
-        var res = c.sqlTransform(classOf[ObjectValue], "intVal > 5", (v: ObjectValue) => v.intVal + 1)
-
-        assert(res.size == ENTRY_CNT - 5)
-
-        res.foreach(t => assert(t._1 > 5 && t._1 + 1 == t._2))
-
-        res = c.sqlTransform(classOf[ObjectValue], "intVal > ?", (v: ObjectValue) => v.intVal + 1, 5)
-
-        assert(res.size == ENTRY_CNT - 5)
-
-        res.foreach(t => assert(t._1 > 5 && t._1 + 1 == t._2))
-
-        res = c.sqlTransform("intVal > 5", (v: ObjectValue) => v.intVal + 1)
-
-        assert(res.size == ENTRY_CNT - 5)
-
-        res.foreach(t => assert(t._1 > 5 && t._1 + 1 == t._2))
-
-        res = c.sqlTransform("intVal > ?", (v: ObjectValue) => v.intVal + 1, 5)
-
-        assert(res.size == ENTRY_CNT - 5)
-
-        res.foreach(t => assert(t._1 > 5 && t._1 + 1 == t._2))
-
-        res = c.sqlTransform(classOf[ObjectValue], "intVal > 5", (v: ObjectValue) => v.intVal + 1)
-
-        assert(res.size == ENTRY_CNT - 5)
-
-        res.foreach(t => assert(t._1 > 5 && t._1 + 1 == t._2))
-
-        res = c.sqlTransform(classOf[ObjectValue], "intVal > ?", (v: ObjectValue) => v.intVal + 1, 5)
-
-        assert(res.size == ENTRY_CNT - 5)
-
-        res.foreach(t => assert(t._1 > 5 && t._1 + 1 == t._2))
-
-        res = c.sqlTransform("intVal > 5", (v: ObjectValue) => v.intVal + 1)
-
-        assert(res.size == ENTRY_CNT - 5)
-
-        res.foreach(t => assert(t._1 > 5 && t._1 + 1 == t._2))
-
-        res = c.sqlTransform("intVal > ?", (v: ObjectValue) => v.intVal + 1, 5)
-
-        assert(res.size == ENTRY_CNT - 5)
-
-        res.foreach(t => assert(t._1 > 5 && t._1 + 1 == t._2))
-    }
-
-    it should "correctly execute TEXT transform queries" in {
-        var res = c.textTransform(classOf[ObjectValue], "str", (v: ObjectValue) => v.intVal + 1)
+        var res = c.text(classOf[ObjectValue], "str").getAll
 
         assert(res.size == ENTRY_CNT)
 
-        res.foreach(t => assert(t._1 + 1 == t._2))
-
-        res = c.textTransform(classOf[ObjectValue], "five", (v: ObjectValue) => v.intVal + 1)
+        res = c.text(classOf[ObjectValue], "five").getAll
 
         assert(res.size == 1)
-        assert(res.head._1 == 5 && res.head._2 == 6)
+        assert(res.head.getKey == 5)
 
-        res = c.textTransform("str", (v: ObjectValue) => v.intVal + 1)
+        res = c.text("str").getAll
 
         assert(res.size == ENTRY_CNT)
 
-        res.foreach(t => assert(t._1 + 1 == t._2))
-
-        res = c.textTransform("five", (v: ObjectValue) => v.intVal + 1)
+        res = c.text("five").getAll
 
         assert(res.size == 1)
-        assert(res.head._1 == 5 && res.head._2 == 6)
+        assert(res.head.getKey == 5)
 
-        res = c.textTransform(classOf[ObjectValue], "str", (v: ObjectValue) => v.intVal + 1)
+        res = c.text(classOf[ObjectValue], "str").getAll
 
         assert(res.size == ENTRY_CNT)
 
-        res.foreach(t => assert(t._1 + 1 == t._2))
-
-        res = c.textTransform(classOf[ObjectValue], "five", (v: ObjectValue) => v.intVal + 1)
+        res = c.text(classOf[ObjectValue], "five").getAll
 
         assert(res.size == 1)
-        assert(res.head._1 == 5 && res.head._2 == 6)
+        assert(res.head.getKey == 5)
 
-        res = c.textTransform("str", (v: ObjectValue) => v.intVal + 1)
+        res = c.text("str").getAll
 
         assert(res.size == ENTRY_CNT)
 
-        res.foreach(t => assert(t._1 + 1 == t._2))
-
-        res = c.textTransform("five", (v: ObjectValue) => v.intVal + 1)
+        res = c.text("five").getAll
 
         assert(res.size == 1)
-        assert(res.head._1 == 5 && res.head._2 == 6)
-    }
-
-    it should "correctly execute SCAN reduce queries with two reducers" in {
-        var res = c.scanReduce(classOf[ObjectValue], (k: Int, v: ObjectValue) => k > 5 && v.intVal < 8,
-            (i: Iterable[(Int, ObjectValue)]) => i.map(_._2.intVal).sum, (i: Iterable[Int]) => i.sum)
-
-        assert(res == 13)
-
-        res = c.scanReduce((k: Int, v: ObjectValue) => k > 5 && v.intVal < 8,
-            (i: Iterable[(Int, ObjectValue)]) => i.map(_._2.intVal).sum, (i: Iterable[Int]) => i.sum)
-
-        assert(res == 13)
-
-        res = c.scanReduce(classOf[ObjectValue], (k: Int, v: ObjectValue) => k > 5 && v.intVal < 8,
-            (i: Iterable[(Int, ObjectValue)]) => i.map(_._2.intVal).sum, (i: Iterable[Int]) => i.sum)
-
-        assert(res == 13)
-
-        res = c.scanReduce((k: Int, v: ObjectValue) => k > 5 && v.intVal < 8,
-            (i: Iterable[(Int, ObjectValue)]) => i.map(_._2.intVal).sum, (i: Iterable[Int]) => i.sum)
-
-        assert(res == 13)
-    }
-
-    it should "correctly execute SQL reduce queries with two reducers" in {
-        var res = c.sqlReduce(classOf[ObjectValue], "intVal > 5",
-            (i: Iterable[(Int, ObjectValue)]) => i.map(_._2.intVal).sum, (i: Iterable[Int]) => i.sum)
-
-        assert(res == 40)
-
-        res = c.sqlReduce(classOf[ObjectValue], "intVal > ?",
-            (i: Iterable[(Int, ObjectValue)]) => i.map(_._2.intVal).sum, (i: Iterable[Int]) => i.sum, 3)
-
-        assert(res == 49)
-
-        res = c.sqlReduce("intVal > 5",
-            (i: Iterable[(Int, ObjectValue)]) => i.map(_._2.intVal).sum, (i: Iterable[Int]) => i.sum)
-
-        assert(res == 40)
-
-        res = c.sqlReduce("intVal > ?",
-            (i: Iterable[(Int, ObjectValue)]) => i.map(_._2.intVal).sum, (i: Iterable[Int]) => i.sum, 3)
-
-        assert(res == 49)
-
-        res = c.sqlReduce(classOf[ObjectValue], "intVal > 5",
-            (i: Iterable[(Int, ObjectValue)]) => i.map(_._2.intVal).sum, (i: Iterable[Int]) => i.sum)
-
-        assert(res == 40)
-
-        res = c.sqlReduce(classOf[ObjectValue], "intVal > ?",
-            (i: Iterable[(Int, ObjectValue)]) => i.map(_._2.intVal).sum, (i: Iterable[Int]) => i.sum, 3)
-
-        assert(res == 49)
-
-        res = c.sqlReduce("intVal > 5", (i: Iterable[(Int, ObjectValue)]) => i.map(_._2.intVal).sum,
-            (i: Iterable[Int]) => i.sum)
-
-        assert(res == 40)
-
-        res = c.sqlReduce("intVal > ?", (i: Iterable[(Int, ObjectValue)]) => i.map(_._2.intVal).sum,
-            (i: Iterable[Int]) => i.sum, 3)
-
-        assert(res == 49)
-    }
-
-    it should "correctly execute TEXT reduce queries with two reducers" in {
-        var res = c.textReduce(classOf[ObjectValue], "str",
-            (i: Iterable[(Int, ObjectValue)]) => i.map(_._2.intVal).sum, (i: Iterable[Int]) => i.sum)
-
-        assert(res == 55)
-
-        res = c.textReduce(classOf[ObjectValue], "three five seven",
-            (i: Iterable[(Int, ObjectValue)]) => i.map(_._2.intVal).sum, (i: Iterable[Int]) => i.sum)
-
-        assert(res == 15)
-
-        res = c.textReduce("str", (i: Iterable[(Int, ObjectValue)]) => i.map(_._2.intVal).sum,
-            (i: Iterable[Int]) => i.sum)
-
-        assert(res == 55)
-
-        res = c.textReduce("three five seven", (i: Iterable[(Int, ObjectValue)]) => i.map(_._2.intVal).sum,
-            (i: Iterable[Int]) => i.sum)
-
-        assert(res == 15)
-
-        res = c.textReduce(classOf[ObjectValue], "str",
-            (i: Iterable[(Int, ObjectValue)]) => i.map(_._2.intVal).sum, (i: Iterable[Int]) => i.sum)
-
-        assert(res == 55)
-
-        res = c.textReduce(classOf[ObjectValue], "three five seven",
-            (i: Iterable[(Int, ObjectValue)]) => i.map(_._2.intVal).sum, (i: Iterable[Int]) => i.sum)
-
-        assert(res == 15)
-
-        res = c.textReduce("str", (i: Iterable[(Int, ObjectValue)]) => i.map(_._2.intVal).sum,
-            (i: Iterable[Int]) => i.sum)
-
-        assert(res == 55)
-
-        res = c.textReduce("three five seven", (i: Iterable[(Int, ObjectValue)]) => i.map(_._2.intVal).sum,
-            (i: Iterable[Int]) => i.sum)
-
-        assert(res == 15)
-
-        res = c.textReduce(classOf[ObjectValue], "str",
-            (i: Iterable[(Int, ObjectValue)]) => i.map(_._2.intVal).sum, (i: Iterable[Int]) => i.sum)
-
-        assert(res == 55)
-
-        res = c.textReduce(classOf[ObjectValue], "seven",
-            (i: Iterable[(Int, ObjectValue)]) => i.map(_._2.intVal).sum, (i: Iterable[Int]) => i.sum)
-
-        assert(res == 7)
-
-        res = c.textReduce("str",
-            (i: Iterable[(Int, ObjectValue)]) => i.map(_._2.intVal).sum, (i: Iterable[Int]) => i.sum)
-
-        assert(res == 55)
-
-        res = c.textReduce("seven",
-            (i: Iterable[(Int, ObjectValue)]) => i.map(_._2.intVal).sum, (i: Iterable[Int]) => i.sum)
-
-        assert(res == 7)
-
-        res = c.textReduce(classOf[ObjectValue], "str",
-            (i: Iterable[(Int, ObjectValue)]) => i.map(_._2.intVal).sum, (i: Iterable[Int]) => i.sum)
-
-        assert(res == 55)
-
-        res = c.textReduce(classOf[ObjectValue], "seven",
-            (i: Iterable[(Int, ObjectValue)]) => i.map(_._2.intVal).sum, (i: Iterable[Int]) => i.sum)
-
-        assert(res == 7)
-
-        res = c.textReduce("str",
-            (i: Iterable[(Int, ObjectValue)]) => i.map(_._2.intVal).sum, (i: Iterable[Int]) => i.sum)
-
-        assert(res == 55)
-
-        res = c.textReduce("seven",
-            (i: Iterable[(Int, ObjectValue)]) => i.map(_._2.intVal).sum, (i: Iterable[Int]) => i.sum)
-
-        assert(res == 7)
-    }
-
-    it should "correctly execute SCAN reduce queries with one reducer" in {
-        var res = c.scanReduceRemote(classOf[ObjectValue], (k: Int, v: ObjectValue) => k > 5 && v.intVal < 8,
-            (i: Iterable[(Int, ObjectValue)]) => i.map(_._2.intVal).sum)
-
-        assert(res.sum == 13)
-
-        res = c.scanReduceRemote((k: Int, v: ObjectValue) => k > 5 && v.intVal < 8,
-            (i: Iterable[(Int, ObjectValue)]) => i.map(_._2.intVal).sum)
-
-        assert(res.sum == 13)
-
-        res = c.scanReduceRemote(classOf[ObjectValue], (k: Int, v: ObjectValue) => k > 5 && v.intVal < 8,
-            (i: Iterable[(Int, ObjectValue)]) => i.map(_._2.intVal).sum)
-
-        assert(res.sum == 13)
-
-        res = c.scanReduceRemote((k: Int, v: ObjectValue) => k > 5 && v.intVal < 8,
-            (i: Iterable[(Int, ObjectValue)]) => i.map(_._2.intVal).sum)
-
-        assert(res.sum == 13)
-    }
-
-    it should "correctly execute SQL reduce queries with one reducer" in {
-        var res = c.sqlReduceRemote(classOf[ObjectValue], "intVal > 5",
-            (i: Iterable[(Int, ObjectValue)]) => i.map(_._2.intVal).sum)
-
-        assert(res.sum == 40)
-
-        res = c.sqlReduceRemote(classOf[ObjectValue], "intVal > ?",
-            (i: Iterable[(Int, ObjectValue)]) => i.map(_._2.intVal).sum, 3)
-
-        assert(res.sum == 49)
-
-        res = c.sqlReduceRemote("intVal > 5",
-            (i: Iterable[(Int, ObjectValue)]) => i.map(_._2.intVal).sum)
-
-        assert(res.sum == 40)
-
-        res = c.sqlReduceRemote("intVal > ?",
-            (i: Iterable[(Int, ObjectValue)]) => i.map(_._2.intVal).sum, 3)
-
-        assert(res.sum == 49)
-
-        res = c.sqlReduceRemote(classOf[ObjectValue], "intVal > 5",
-            (i: Iterable[(Int, ObjectValue)]) => i.map(_._2.intVal).sum)
-
-        assert(res.sum == 40)
-
-        res = c.sqlReduceRemote(classOf[ObjectValue], "intVal > ?",
-            (i: Iterable[(Int, ObjectValue)]) => i.map(_._2.intVal).sum, 3)
-
-        assert(res.sum == 49)
-
-        res = c.sqlReduceRemote("intVal > 5",
-            (i: Iterable[(Int, ObjectValue)]) => i.map(_._2.intVal).sum)
-
-        assert(res.sum == 40)
-
-        res = c.sqlReduceRemote("intVal > ?",
-            (i: Iterable[(Int, ObjectValue)]) => i.map(_._2.intVal).sum, 3)
-
-        assert(res.sum == 49)
-    }
-
-    it should "correctly execute TEXT reduce queries with one reducer" in {
-        var res = c.textReduceRemote(classOf[ObjectValue], "str",
-            (i: Iterable[(Int, ObjectValue)]) => i.map(_._2.intVal).sum)
-
-        assert(res.sum == 55)
-
-        res = c.textReduceRemote(classOf[ObjectValue], "seven",
-            (i: Iterable[(Int, ObjectValue)]) => i.map(_._2.intVal).sum)
-
-        assert(res.sum == 7)
-
-        res = c.textReduceRemote("str",
-            (i: Iterable[(Int, ObjectValue)]) => i.map(_._2.intVal).sum)
-
-        assert(res.sum == 55)
-
-        res = c.textReduceRemote("seven",
-            (i: Iterable[(Int, ObjectValue)]) => i.map(_._2.intVal).sum)
-
-        assert(res.sum == 7)
-
-        res = c.textReduceRemote(classOf[ObjectValue], "str",
-            (i: Iterable[(Int, ObjectValue)]) => i.map(_._2.intVal).sum)
-
-        assert(res.sum == 55)
-
-        res = c.textReduceRemote(classOf[ObjectValue], "seven",
-            (i: Iterable[(Int, ObjectValue)]) => i.map(_._2.intVal).sum)
-
-        assert(res.sum == 7)
-
-        res = c.textReduceRemote("str",
-            (i: Iterable[(Int, ObjectValue)]) => i.map(_._2.intVal).sum)
-
-        assert(res.sum == 55)
-
-        res = c.textReduceRemote("seven",
-            (i: Iterable[(Int, ObjectValue)]) => i.map(_._2.intVal).sum)
-
-        assert(res.sum == 7)
+        assert(res.head.getKey == 5)
     }
 
     it should "correctly execute fields queries" in {
-        var res = c.sqlFields(null, "select intVal from ObjectValue where intVal > 5")
+        var res = c.sqlFields("select intVal from ObjectValue where intVal > 5").getAll
 
         assert(res.size == ENTRY_CNT - 5)
 
         res.foreach(t => assert(t.size == 1 && t.head.asInstanceOf[Int] > 5))
 
-        res = c.sqlFields(null, "select intVal from ObjectValue where intVal > ?", 5)
+        res = c.sqlFields("select intVal from ObjectValue where intVal > ?", 5).getAll
 
         assert(res.size == ENTRY_CNT - 5)
 
@@ -575,7 +200,7 @@ class ScalarCacheQueriesSpec extends FlatSpec with ShouldMatchers with BeforeAnd
     }
 
     it should "correctly execute queries with multiple arguments" in {
-        val res = c.sql("from ObjectValue where intVal in (?, ?, ?)", 1, 2, 3)
+        val res = c.sql("from ObjectValue where intVal in (?, ?, ?)", 1, 2, 3).getAll
 
         assert(res.size == 3)
     }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f0209856/modules/scalar/src/test/scala/org/apache/ignite/scalar/tests/ScalarCacheSpec.scala
----------------------------------------------------------------------
diff --git a/modules/scalar/src/test/scala/org/apache/ignite/scalar/tests/ScalarCacheSpec.scala b/modules/scalar/src/test/scala/org/apache/ignite/scalar/tests/ScalarCacheSpec.scala
index 8ac523d..565b68f 100644
--- a/modules/scalar/src/test/scala/org/apache/ignite/scalar/tests/ScalarCacheSpec.scala
+++ b/modules/scalar/src/test/scala/org/apache/ignite/scalar/tests/ScalarCacheSpec.scala
@@ -38,16 +38,14 @@ class ScalarCacheSpec extends FlatSpec with ShouldMatchers {
         scalar("examples/config/example-cache.xml") {
             registerListener()
 
-            throw new RuntimeException("Test is disabled.")
+            val c = cache$[Int, Int]("partitioned").get
 
-//            val c = cache$("partitioned").get.viewByType(classOf[Int], classOf[Int])
-//
-//            c.putx(1, 1)
-//            c.putx(2, 2)
-//
-//            c.values foreach println
-//
-//            println("Size is: " + c.size)
+            c.put(1, 1)
+            c.put(2, 2)
+
+            c.iterator() foreach println
+
+            println("Size is: " + c.size())
         }
     }
 


[31/50] [abbrv] incubator-ignite git commit: Merge remote-tracking branch 'origin/sprint-1' into sprint-1

Posted by vk...@apache.org.
Merge remote-tracking branch 'origin/sprint-1' into sprint-1


Project: http://git-wip-us.apache.org/repos/asf/incubator-ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-ignite/commit/56da893e
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/56da893e
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/56da893e

Branch: refs/heads/master
Commit: 56da893e7d9470197d451bc51bacaf5bae672e03
Parents: 9b555ff a2b5123
Author: Artem Shutak <as...@gridgain.com>
Authored: Mon Feb 16 16:30:41 2015 +0300
Committer: Artem Shutak <as...@gridgain.com>
Committed: Mon Feb 16 16:30:41 2015 +0300

----------------------------------------------------------------------
 .../examples/datagrid/CacheQueryExample.java    |   25 +-
 .../starschema/CacheStarSchemaExample.java      |   11 +-
 .../datastructures/IgniteQueueExample.java      |    2 +-
 .../examples/ScalarCacheAffinityExample1.scala  |    6 +-
 .../examples/ScalarCacheAffinityExample2.scala  |    4 +-
 .../ScalarCacheAffinitySimpleExample.scala      |   10 +-
 .../scalar/examples/ScalarCacheExample.scala    |   49 +-
 .../ScalarCachePopularNumbersExample.scala      |   13 +-
 .../examples/ScalarCacheQueryExample.scala      |   48 +-
 .../examples/ScalarSnowflakeSchemaExample.scala |   37 +-
 .../src/main/java/org/apache/ignite/Ignite.java |   27 -
 .../apache/ignite/IgniteSystemProperties.java   |  120 --
 .../configuration/IgniteConfiguration.java      |  353 ---
 .../ignite/internal/GridKernalContext.java      |    8 -
 .../ignite/internal/GridKernalContextImpl.java  |   12 -
 .../ignite/internal/IgniteComponentType.java    |    7 -
 .../org/apache/ignite/internal/IgniteEx.java    |   12 -
 .../apache/ignite/internal/IgniteKernal.java    |  217 +-
 .../org/apache/ignite/internal/IgnitionEx.java  |   49 -
 .../processors/cache/GridCacheAdapter.java      |    2 +-
 .../cache/GridCacheDeploymentManager.java       |   33 +-
 .../continuous/CacheContinuousQueryManager.java |   49 +-
 .../processors/email/GridEmailHolder.java       |  111 -
 .../email/IgniteEmailProcessorAdapter.java      |   84 -
 .../email/IgniteNoopEmailProcessor.java         |   55 -
 .../internal/processors/email/package.html      |   24 -
 .../visor/node/VisorEmailConfiguration.java     |  177 --
 .../visor/node/VisorGridConfiguration.java      |   18 -
 .../visor/node/VisorLifecycleConfiguration.java |   19 -
 .../ignite/startup/BasicWarmupClosure.java      |    6 +-
 .../GridCacheFieldsQueryNoDataSelfTest.java     |    4 +-
 .../cache/GridCacheOffHeapSelfTest.java         |    4 +-
 .../cache/GridCacheSwapPreloadSelfTest.java     |    3 +-
 .../IgniteClientAffinityAssignmentSelfTest.java |    5 +-
 .../cache/IgnitePutAllLargeBatchSelfTest.java   |    8 +-
 ...tAllUpdateNonPreloadedPartitionSelfTest.java |    4 +-
 .../cache/IgniteTxMultiNodeAbstractTest.java    |    3 +-
 ...dCacheMultithreadedFailoverAbstractTest.java |    3 +-
 .../GridCacheNodeFailureAbstractTest.java       |    3 +-
 ...chePartitionedReloadAllAbstractSelfTest.java |    8 +-
 ...ridCacheContinuousQueryAbstractSelfTest.java |    4 +-
 ...dCacheAbstractReduceFieldsQuerySelfTest.java |    4 +-
 .../GridDataLoaderProcessorSelfTest.java        |    2 +-
 .../processors/igfs/IgfsCacheSelfTest.java      |    5 +-
 .../ignite/testframework/junits/IgniteMock.java |   10 -
 modules/email/licenses/apache-2.0.txt           |  202 --
 modules/email/pom.xml                           |   51 -
 modules/email/readme.txt                        |   34 -
 .../processors/email/IgniteEmailProcessor.java  |  296 ---
 ...idHadoopDefaultMapReducePlannerSelfTest.java |   10 -
 ...idHibernateL2CacheConfigurationSelfTest.java |    3 +-
 .../hibernate/GridHibernateL2CacheSelfTest.java |    3 +-
 .../GridCacheAbstractFieldsQuerySelfTest.java   |    3 +-
 .../cache/GridCacheAbstractQuerySelfTest.java   |    5 +-
 .../cache/GridCacheCrossCacheQuerySelfTest.java |   12 +-
 .../GridCacheCrossCacheQuerySelfTestNewApi.java |    7 +-
 .../processors/cache/GridCacheSwapSelfTest.java |    4 +-
 .../near/GridCachePartitionedQuerySelfTest.java |    2 +-
 .../GridCacheReplicatedQuerySelfTest.java       |    6 +-
 .../ignite/scalar/ScalarConversions.scala       |   47 +-
 .../ignite/scalar/pimps/ScalarCachePimp.scala   |  662 +++++-
 .../pimps/ScalarCacheProjectionPimp.scala       | 2004 ------------------
 .../scala/org/apache/ignite/scalar/scalar.scala |   25 +-
 .../tests/ScalarAffinityRoutingSpec.scala       |   12 +-
 .../scalar/tests/ScalarCacheQueriesSpec.scala   |  466 +---
 .../ignite/scalar/tests/ScalarCacheSpec.scala   |   10 +-
 .../org/apache/ignite/IgniteSpringBean.java     |   20 +-
 .../ignite/cache/spring/SpringCacheManager.java |    2 +-
 .../commands/alert/VisorAlertCommand.scala      |   83 +-
 .../config/VisorConfigurationCommand.scala      |   15 -
 .../commands/alert/VisorAlertCommandSpec.scala  |    1 -
 .../config/VisorConfigurationCommandSpec.scala  |    1 -
 .../disco/VisorDiscoveryCommandSpec.scala       |    1 -
 .../events/VisorEventsCommandSpec.scala         |    1 -
 .../visor/commands/gc/VisorGcCommandSpec.scala  |    1 -
 .../commands/tasks/VisorTasksCommandSpec.scala  |    2 -
 pom.xml                                         |    3 +-
 77 files changed, 923 insertions(+), 4729 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/56da893e/examples/src/main/java/org/apache/ignite/examples/datagrid/CacheQueryExample.java
----------------------------------------------------------------------


[50/50] [abbrv] incubator-ignite git commit: Merge branch 'release-1.0.0-RC1-branch'

Posted by vk...@apache.org.
Merge branch 'release-1.0.0-RC1-branch'


Project: http://git-wip-us.apache.org/repos/asf/incubator-ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-ignite/commit/8e37cef4
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/8e37cef4
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/8e37cef4

Branch: refs/heads/master
Commit: 8e37cef42c71be5a3d5caeb666162e628822792c
Parents: afd26f2 16ef8ea
Author: Valentin Kulichenko <vk...@gridgain.com>
Authored: Tue Mar 3 17:29:49 2015 -0800
Committer: Valentin Kulichenko <vk...@gridgain.com>
Committed: Tue Mar 3 17:29:49 2015 -0800

----------------------------------------------------------------------
 .gitignore                                      |     2 +-
 LICENSE.txt                                     |   229 +
 NOTICE.txt                                      |    21 +
 apache-2.0.txt                                  |   202 -
 assembly/core-jar.xml                           |    49 -
 assembly/dependencies-fabric.xml                |    51 +-
 assembly/dependencies-hadoop.xml                |    44 +-
 assembly/dependencies-optional-fabric.xml       |     4 +-
 assembly/dependencies-optional-hadoop.xml       |     5 +-
 assembly/dependencies-schema-load.xml           |    56 +
 assembly/dependencies-visor-console.xml         |     2 +-
 assembly/dependencies-visor-trial.xml           |    80 -
 assembly/docfiles/tools.js                      |    30 -
 assembly/libs/readme.txt                        |   125 +-
 assembly/release-base-fabric.xml                |    83 -
 assembly/release-base.xml                       |    19 +-
 assembly/release-fabric.xml                     |    61 +-
 assembly/release-hadoop.xml                     |     8 +-
 assembly/release-scala.xml                      |    50 +
 assembly/test.xml                               |     2 +-
 bin/ggrouter.bat                                |    33 -
 bin/ggrouter.sh                                 |    50 -
 bin/ggstart.bat                                 |   228 -
 bin/ggstart.sh                                  |   176 -
 bin/ggvisorcmd.bat                              |   144 -
 bin/ggvisorcmd.sh                               |   124 -
 bin/ignite-schema-load.bat                      |   116 +
 bin/ignite-schema-load.sh                       |    78 +
 bin/ignite.bat                                  |   230 +
 bin/ignite.sh                                   |   178 +
 bin/igniterouter.bat                            |    35 +
 bin/igniterouter.sh                             |    52 +
 bin/ignitevisorcmd.bat                          |   146 +
 bin/ignitevisorcmd.sh                           |   126 +
 bin/include/functions.sh                        |    72 +-
 bin/include/ggservice.exe                       |   Bin 5632 -> 0 bytes
 bin/include/hadoop-classpath.bat                |    28 +-
 bin/include/hadoop-classpath.sh                 |    30 +-
 bin/include/igniteservice.exe                   |   Bin 0 -> 6144 bytes
 bin/include/parseargs.bat                       |    34 +-
 bin/include/parseargs.sh                        |    38 +-
 bin/include/service.sh                          |    46 +-
 bin/include/setenv.bat                          |    60 +-
 bin/include/setenv.sh                           |    64 +-
 bin/include/target-classpath.bat                |    34 +-
 bin/include/target-classpath.sh                 |    40 +-
 bin/setup-hadoop.bat                            |    32 +-
 bin/setup-hadoop.sh                             |    44 +-
 config/default-config.xml                       |     2 +-
 config/fabric/default-config.xml                |    16 +-
 config/gridgain-log4j.xml                       |   152 -
 config/hadoop/default-config.xml                |    74 +-
 config/ignite-log4j.xml                         |   133 +
 config/java.util.logging.properties             |    28 +-
 config/router/default-router.xml                |    12 +-
 docs/core-site.gridgain.xml                     |    68 -
 docs/core-site.ignite.xml                       |    90 +
 docs/gridgain_readme.md                         |   149 -
 docs/gridgain_readme.pdf                        |   Bin 407698 -> 0 bytes
 docs/hadoop_readme.md                           |    86 +-
 docs/hadoop_readme.pdf                          |   Bin 411788 -> 82297 bytes
 docs/hive-site.gridgain.xml                     |    36 -
 docs/hive-site.ignite.xml                       |    37 +
 docs/ignite_readme.md                           |   100 +
 docs/ignite_readme.pdf                          |   Bin 0 -> 77136 bytes
 docs/mapred-site.gridgain.xml                   |    79 -
 docs/mapred-site.ignite.xml                     |    66 +
 docs/release_notes.md                           |    16 +
 docs/release_notes.pdf                          |   Bin 59911 -> 33174 bytes
 examples/config/example-cache.xml               |    45 +-
 examples/config/example-compute.xml             |    23 +-
 examples/config/example-streamer.xml            |    67 +-
 examples/config/filesystem/core-site.xml        |    18 +-
 examples/config/filesystem/example-ggfs.xml     |   168 -
 examples/config/filesystem/example-igfs.xml     |   165 +
 examples/config/filesystem/readme.txt           |     8 +-
 .../hibernate/example-hibernate-L2-cache.xml    |    28 +-
 examples/config/hibernate/readme.txt            |     4 +-
 examples/config/servlet/WEB-INF/web.xml         |     8 +-
 examples/config/servlet/readme.txt              |     2 +-
 examples/pom-standalone.xml                     |   155 +-
 examples/pom.xml                                |    85 +-
 examples/rest/http-rest-example.php             |    10 +-
 examples/rest/memcache-rest-example.php         |     6 +-
 .../ignite/examples/ComputeNodeStartup.java     |    35 +
 .../apache/ignite/examples/ExamplesUtils.java   |    99 +
 .../computegrid/ComputeBroadcastExample.java    |   114 +
 .../computegrid/ComputeCallableExample.java     |    79 +
 .../computegrid/ComputeClosureExample.java      |    77 +
 .../ComputeClusterGroupsExample.java            |    93 +
 .../ComputeContinuousMapperExample.java         |   158 +
 .../ComputeExecutorServiceExample.java          |    71 +
 .../ComputeFibonacciContinuationExample.java    |   183 +
 .../computegrid/ComputeReducerExample.java      |    89 +
 .../computegrid/ComputeRunnableExample.java     |    74 +
 .../computegrid/ComputeScheduleExample.java     |    81 +
 .../computegrid/ComputeTaskMapExample.java      |   113 +
 .../computegrid/ComputeTaskSplitExample.java    |   102 +
 .../failover/ComputeFailoverExample.java        |   137 +
 .../failover/ComputeFailoverNodeStartup.java    |    77 +
 .../examples/computegrid/failover/package.html  |    24 +
 .../examples/computegrid/montecarlo/Credit.java |   110 +
 .../montecarlo/CreditRiskExample.java           |   153 +
 .../montecarlo/CreditRiskManager.java           |   143 +
 .../computegrid/montecarlo/package.html         |    24 +
 .../ignite/examples/computegrid/package.html    |    24 +
 .../examples/datagrid/CacheAffinityExample.java |   133 +
 .../examples/datagrid/CacheApiExample.java      |   124 +
 .../datagrid/CacheContinuousQueryExample.java   |   102 +
 .../datagrid/CacheDataLoaderExample.java        |    85 +
 .../examples/datagrid/CacheEventsExample.java   |    94 +
 .../examples/datagrid/CacheNodeStartup.java     |    35 +
 .../datagrid/CachePopularNumbersExample.java    |   161 +
 .../examples/datagrid/CachePutGetExample.java   |   113 +
 .../examples/datagrid/CacheQueryExample.java    |   372 +
 .../datagrid/CacheTransactionExample.java       |   143 +
 .../hibernate/HibernateL2CacheExample.java      |   204 +
 .../HibernateL2CacheExampleNodeStartup.java     |    97 +
 .../examples/datagrid/hibernate/Post.java       |   126 +
 .../examples/datagrid/hibernate/User.java       |   151 +
 .../examples/datagrid/hibernate/package.html    |    24 +
 .../ignite/examples/datagrid/package.html       |    24 +
 .../starschema/CacheStarSchemaExample.java      |   232 +
 .../datagrid/starschema/DimProduct.java         |   101 +
 .../examples/datagrid/starschema/DimStore.java  |   101 +
 .../datagrid/starschema/FactPurchase.java       |   103 +
 .../examples/datagrid/starschema/package.html   |    24 +
 .../store/CacheNodeWithStoreStartup.java        |    88 +
 .../datagrid/store/CacheStoreExample.java       |    87 +
 .../store/CacheStoreLoadDataExample.java        |    75 +
 .../ignite/examples/datagrid/store/Person.java  |   103 +
 .../store/dummy/CacheDummyPersonStore.java      |   120 +
 .../examples/datagrid/store/dummy/package.html  |    24 +
 .../hibernate/CacheHibernatePersonStore.java    |   290 +
 .../datagrid/store/hibernate/Person.hbm.xml     |    34 +
 .../datagrid/store/hibernate/hibernate.cfg.xml  |    44 +
 .../datagrid/store/hibernate/package.html       |    24 +
 .../store/jdbc/CacheJdbcPersonStore.java        |   308 +
 .../examples/datagrid/store/jdbc/package.html   |    24 +
 .../ignite/examples/datagrid/store/package.html |    24 +
 .../datastructures/IgniteAtomicLongExample.java |    74 +
 .../IgniteAtomicReferenceExample.java           |   110 +
 .../IgniteAtomicSequenceExample.java            |    96 +
 .../IgniteAtomicStampedExample.java             |   117 +
 .../IgniteCountDownLatchExample.java            |    96 +
 .../datastructures/IgniteQueueExample.java      |   206 +
 .../datastructures/IgniteSetExample.java        |   186 +
 .../ignite/examples/datastructures/package.html |    24 +
 .../ignite/examples/events/EventsExample.java   |   144 +
 .../apache/ignite/examples/events/package.html  |    24 +
 .../ignite/examples/igfs/IgfsExample.java       |   278 +
 .../examples/igfs/IgfsMapReduceExample.java     |   249 +
 .../ignite/examples/igfs/IgfsNodeStartup.java   |    41 +
 .../apache/ignite/examples/igfs/package.html    |    24 +
 .../examples/messaging/MessagingExample.java    |   173 +
 .../messaging/MessagingPingPongExample.java     |   133 +
 .../MessagingPingPongListenActorExample.java    |   107 +
 .../ignite/examples/messaging/package.html      |    24 +
 .../client/memcache/MemcacheRestExample.java    |   125 +
 .../MemcacheRestExampleNodeStartup.java         |   100 +
 .../examples/misc/client/memcache/package.html  |    24 +
 .../ignite/examples/misc/client/package.html    |    24 +
 .../misc/deployment/DeploymentExample.java      |   129 +
 .../examples/misc/deployment/package.html       |    24 +
 .../misc/lifecycle/LifecycleExample.java        |    92 +
 .../ignite/examples/misc/lifecycle/package.html |    24 +
 .../apache/ignite/examples/misc/package.html    |    24 +
 .../misc/springbean/SpringBeanExample.java      |    88 +
 .../examples/misc/springbean/package.html       |    24 +
 .../examples/misc/springbean/spring-bean.xml    |    70 +
 .../org/apache/ignite/examples/package.html     |    24 +
 .../examples/servicegrid/ServicesExample.java   |   167 +
 .../examples/servicegrid/SimpleMapService.java  |    49 +
 .../servicegrid/SimpleMapServiceImpl.java       |    71 +
 .../streaming/StreamingCheckInExample.java      |   580 +
 .../streaming/StreamingNodeStartup.java         |    35 +
 .../StreamingPopularNumbersExample.java         |   250 +
 .../streaming/StreamingPriceBarsExample.java    |   451 +
 .../StreamingRunningAverageExample.java         |   247 +
 .../ignite/examples/streaming/package.html      |    24 +
 .../gridgain/examples/ComputeNodeStartup.java   |    36 -
 .../org/gridgain/examples/ExamplesUtils.java    |    99 -
 .../compute/ComputeBroadcastExample.java        |   115 -
 .../compute/ComputeCallableExample.java         |    80 -
 .../examples/compute/ComputeClosureExample.java |    78 -
 .../compute/ComputeContinuousMapperExample.java |   163 -
 .../compute/ComputeExecutorServiceExample.java  |    72 -
 .../ComputeFibonacciContinuationExample.java    |   189 -
 .../compute/ComputeProjectionExample.java       |    95 -
 .../examples/compute/ComputeReducerExample.java |    90 -
 .../compute/ComputeRunnableExample.java         |    75 -
 .../compute/ComputeScheduleExample.java         |    87 -
 .../examples/compute/ComputeTaskMapExample.java |   114 -
 .../compute/ComputeTaskSplitExample.java        |   103 -
 .../failover/ComputeFailoverExample.java        |   144 -
 .../failover/ComputeFailoverNodeStartup.java    |    78 -
 .../examples/compute/failover/package.html      |    23 -
 .../examples/compute/montecarlo/Credit.java     |   110 -
 .../compute/montecarlo/CreditRiskExample.java   |   154 -
 .../compute/montecarlo/CreditRiskManager.java   |   153 -
 .../examples/compute/montecarlo/package.html    |    24 -
 .../org/gridgain/examples/compute/package.html  |    23 -
 .../examples/datagrid/CacheAffinityExample.java |   139 -
 .../examples/datagrid/CacheApiExample.java      |   173 -
 .../datagrid/CacheContinuousQueryExample.java   |    98 -
 .../datagrid/CacheDataLoaderExample.java        |    82 -
 .../examples/datagrid/CacheEventsExample.java   |    96 -
 .../examples/datagrid/CacheNodeStartup.java     |    36 -
 .../datagrid/CachePopularNumbersExample.java    |   176 -
 .../examples/datagrid/CachePutGetExample.java   |   115 -
 .../examples/datagrid/CacheQueryExample.java    |   477 -
 .../datagrid/CacheTransactionExample.java       |   148 -
 .../datastructures/CacheAtomicLongExample.java  |    79 -
 .../CacheAtomicReferenceExample.java            |   127 -
 .../CacheAtomicSequenceExample.java             |   113 -
 .../CacheAtomicStampedExample.java              |   133 -
 .../CacheCountDownLatchExample.java             |   113 -
 .../datastructures/CacheQueueExample.java       |   215 -
 .../datastructures/CacheSetExample.java         |   194 -
 .../datagrid/datastructures/package.html        |    23 -
 .../hibernate/HibernateL2CacheExample.java      |   205 -
 .../HibernateL2CacheExampleNodeStartup.java     |    98 -
 .../examples/datagrid/hibernate/Post.java       |   126 -
 .../examples/datagrid/hibernate/User.java       |   151 -
 .../examples/datagrid/hibernate/package.html    |    23 -
 .../org/gridgain/examples/datagrid/package.html |    23 -
 .../starschema/CacheStarSchemaExample.java      |   228 -
 .../datagrid/starschema/DimProduct.java         |   101 -
 .../examples/datagrid/starschema/DimStore.java  |   101 -
 .../datagrid/starschema/FactPurchase.java       |   103 -
 .../examples/datagrid/starschema/package.html   |    24 -
 .../store/CacheNodeWithStoreStartup.java        |    82 -
 .../datagrid/store/CacheStoreExample.java       |    88 -
 .../store/CacheStoreLoadDataExample.java        |    77 -
 .../examples/datagrid/store/Person.java         |   103 -
 .../store/dummy/CacheDummyPersonStore.java      |    94 -
 .../examples/datagrid/store/dummy/package.html  |    24 -
 .../hibernate/CacheHibernatePersonStore.java    |   252 -
 .../datagrid/store/hibernate/Person.hbm.xml     |    32 -
 .../datagrid/store/hibernate/hibernate.cfg.xml  |    44 -
 .../datagrid/store/hibernate/package.html       |    24 -
 .../store/jdbc/CacheJdbcPersonStore.java        |   279 -
 .../examples/datagrid/store/jdbc/package.html   |    24 -
 .../examples/datagrid/store/package.html        |    24 -
 .../gridgain/examples/events/EventsExample.java |   145 -
 .../org/gridgain/examples/events/package.html   |    24 -
 .../org/gridgain/examples/ggfs/GgfsExample.java |   279 -
 .../examples/ggfs/GgfsMapReduceExample.java     |   250 -
 .../gridgain/examples/ggfs/GgfsNodeStartup.java |    42 -
 .../org/gridgain/examples/ggfs/package.html     |    23 -
 .../examples/messaging/MessagingExample.java    |   175 -
 .../messaging/MessagingPingPongExample.java     |   134 -
 .../MessagingPingPongListenActorExample.java    |   108 -
 .../gridgain/examples/messaging/package.html    |    24 -
 .../client/memcache/MemcacheRestExample.java    |   127 -
 .../MemcacheRestExampleNodeStartup.java         |   100 -
 .../examples/misc/client/memcache/package.html  |    23 -
 .../gridgain/examples/misc/client/package.html  |    24 -
 .../misc/deployment/DeploymentExample.java      |   130 -
 .../examples/misc/deployment/package.html       |    24 -
 .../misc/lifecycle/LifecycleExample.java        |    93 -
 .../examples/misc/lifecycle/package.html        |    24 -
 .../org/gridgain/examples/misc/package.html     |    24 -
 .../misc/springbean/SpringBeanExample.java      |    89 -
 .../examples/misc/springbean/package.html       |    24 -
 .../examples/misc/springbean/spring-bean.xml    |    73 -
 .../java/org/gridgain/examples/package.html     |    24 -
 .../examples/services/ServicesExample.java      |   161 -
 .../examples/services/SimpleMapService.java     |    49 -
 .../examples/services/SimpleMapServiceImpl.java |    71 -
 .../streaming/StreamingCheckInExample.java      |   583 -
 .../streaming/StreamingNodeStartup.java         |    36 -
 .../StreamingPopularNumbersExample.java         |   252 -
 .../streaming/StreamingPriceBarsExample.java    |   454 -
 .../StreamingRunningAverageExample.java         |   249 -
 .../gridgain/examples/streaming/package.html    |    24 -
 .../apache/ignite/examples/ComputeExample.java  |    57 +
 .../ignite/examples/MessagingExample.java       |   162 +
 .../org/gridgain/examples/ComputeExample.java   |    59 -
 .../org/gridgain/examples/MessagingExample.java |   166 -
 .../examples/ScalarCacheAffinityExample1.scala  |   121 +
 .../examples/ScalarCacheAffinityExample2.scala  |   116 +
 .../ScalarCacheAffinitySimpleExample.scala      |    83 +
 .../scalar/examples/ScalarCacheExample.scala    |   108 +
 .../ScalarCachePopularNumbersExample.scala      |   118 +
 .../examples/ScalarCacheQueryExample.scala      |   183 +
 .../scalar/examples/ScalarClosureExample.scala  |    97 +
 .../examples/ScalarContinuationExample.scala    |   160 +
 .../examples/ScalarCreditRiskExample.scala      |   246 +
 .../scalar/examples/ScalarJvmCloudExample.scala |    95 +
 .../examples/ScalarPiCalculationExample.scala   |    55 +
 .../scalar/examples/ScalarPingPongExample.scala |   157 +
 .../scalar/examples/ScalarPrimeExample.scala    |   134 +
 .../scalar/examples/ScalarScheduleExample.scala |    63 +
 .../examples/ScalarSnowflakeSchemaExample.scala |   300 +
 .../scalar/examples/ScalarTaskExample.scala     |    52 +
 .../examples/ScalarWorldShortestMapReduce.scala |    39 +
 .../examples/ScalarCacheAffinityExample1.scala  |   123 -
 .../examples/ScalarCacheAffinityExample2.scala  |   117 -
 .../ScalarCacheAffinitySimpleExample.scala      |    83 -
 .../scalar/examples/ScalarCacheExample.scala    |   149 -
 .../ScalarCachePopularNumbersExample.scala      |   129 -
 .../examples/ScalarCacheQueryExample.scala      |   203 -
 .../scalar/examples/ScalarClosureExample.scala  |    99 -
 .../examples/ScalarContinuationExample.scala    |   159 -
 .../examples/ScalarCreditRiskExample.scala      |   245 -
 .../scalar/examples/ScalarJvmCloudExample.scala |    94 -
 .../examples/ScalarPiCalculationExample.scala   |    54 -
 .../scalar/examples/ScalarPingPongExample.scala |   156 -
 .../scalar/examples/ScalarPrimeExample.scala    |   132 -
 .../scalar/examples/ScalarScheduleExample.scala |    63 -
 .../examples/ScalarSnowflakeSchemaExample.scala |   292 -
 .../examples/ScalarStartStopExample.scala       |    73 -
 .../scalar/examples/ScalarTaskExample.scala     |    50 -
 .../examples/ScalarWorldShortestMapReduce.scala |    39 -
 .../BasicExamplesMultiNodeSelfTest.java         |    28 +
 .../ignite/examples/BasicExamplesSelfTest.java  |    82 +
 .../CacheExamplesMultiNodeSelfTest.java         |    48 +
 .../ignite/examples/CacheExamplesSelfTest.java  |   155 +
 ...heStoreLoadDataExampleMultiNodeSelfTest.java |    39 +
 .../examples/CheckpointExamplesSelfTest.java    |    45 +
 .../ComputeClusterGroupsExampleSelfTest.java    |    39 +
 .../ContinuationExamplesMultiNodeSelfTest.java  |    28 +
 .../examples/ContinuationExamplesSelfTest.java  |    33 +
 ...ntinuousMapperExamplesMultiNodeSelfTest.java |    28 +
 .../ContinuousMapperExamplesSelfTest.java       |    33 +
 .../DeploymentExamplesMultiNodeSelfTest.java    |    30 +
 .../examples/DeploymentExamplesSelfTest.java    |    33 +
 .../EventsExamplesMultiNodeSelfTest.java        |    28 +
 .../ignite/examples/EventsExamplesSelfTest.java |    33 +
 ...ibernateL2CacheExampleMultiNodeSelfTest.java |    31 +
 .../HibernateL2CacheExampleSelfTest.java        |    33 +
 .../ignite/examples/IgfsExamplesSelfTest.java   |    51 +
 .../examples/LifecycleExamplesSelfTest.java     |    33 +
 .../MemcacheRestExamplesMultiNodeSelfTest.java  |    31 +
 .../examples/MemcacheRestExamplesSelfTest.java  |    41 +
 .../examples/MessagingExamplesSelfTest.java     |    52 +
 .../MonteCarloExamplesMultiNodeSelfTest.java    |    28 +
 .../examples/MonteCarloExamplesSelfTest.java    |    74 +
 .../examples/SpringBeanExamplesSelfTest.java    |    33 +
 .../examples/TaskExamplesMultiNodeSelfTest.java |    28 +
 .../ignite/examples/TaskExamplesSelfTest.java   |    40 +
 .../testsuites/IgniteExamplesSelfTestSuite.java |    74 +
 .../GridBasicExamplesMultiNodeSelfTest.java     |    28 -
 .../examples/GridBasicExamplesSelfTest.java     |    82 -
 .../GridCacheExamplesMultiNodeSelfTest.java     |    48 -
 .../examples/GridCacheExamplesSelfTest.java     |   155 -
 ...heStoreLoadDataExampleMultiNodeSelfTest.java |    39 -
 .../GridCheckpointExamplesSelfTest.java         |    45 -
 ...idContinuationExamplesMultiNodeSelfTest.java |    28 -
 .../GridContinuationExamplesSelfTest.java       |    33 -
 ...ntinuousMapperExamplesMultiNodeSelfTest.java |    28 -
 .../GridContinuousMapperExamplesSelfTest.java   |    33 -
 ...GridDeploymentExamplesMultiNodeSelfTest.java |    30 -
 .../GridDeploymentExamplesSelfTest.java         |    33 -
 .../GridEventsExamplesMultiNodeSelfTest.java    |    28 -
 .../examples/GridEventsExamplesSelfTest.java    |    33 -
 .../examples/GridGgfsExamplesSelfTest.java      |    67 -
 ...ibernateL2CacheExampleMultiNodeSelfTest.java |    31 -
 .../GridHibernateL2CacheExampleSelfTest.java    |    33 -
 .../examples/GridLifecycleExamplesSelfTest.java |    33 -
 ...idMemcacheRestExamplesMultiNodeSelfTest.java |    31 -
 .../GridMemcacheRestExamplesSelfTest.java       |    41 -
 .../examples/GridMessagingExamplesSelfTest.java |    52 -
 ...GridMonteCarloExamplesMultiNodeSelfTest.java |    28 -
 .../GridMonteCarloExamplesSelfTest.java         |    74 -
 .../examples/GridProjectionExampleSelfTest.java |    39 -
 .../GridSpringBeanExamplesSelfTest.java         |    33 -
 .../GridTaskExamplesMultiNodeSelfTest.java      |    28 -
 .../examples/GridTaskExamplesSelfTest.java      |    40 -
 .../testsuites/GridExamplesSelfTestSuite.java   |    74 -
 .../ScalarExamplesMultiNodeSelfTest.scala       |    33 +
 .../tests/examples/ScalarExamplesSelfTest.scala |   113 +
 .../ScalarExamplesSelfTestSuite.scala           |    37 +
 .../ScalarExamplesMultiNodeSelfTest.scala       |    33 -
 .../tests/examples/ScalarExamplesSelfTest.scala |   118 -
 .../ScalarExamplesSelfTestSuite.scala           |    39 -
 ipc/readme.txt                                  |     4 +-
 ipc/shmem/Makefile.am                           |     2 +-
 ipc/shmem/Makefile.in                           |     2 +-
 ipc/shmem/configure                             |    28 +-
 ipc/shmem/configure.ac                          |     4 +-
 ipc/shmem/ggshmem/Makefile.am                   |    23 -
 ipc/shmem/ggshmem/Makefile.in                   |   589 -
 ..._util_ipc_shmem_GridIpcSharedMemoryUtils.cpp |   882 --
 ipc/shmem/igniteshmem/Makefile.am               |    23 +
 ipc/shmem/igniteshmem/Makefile.in               |   589 +
 ...rnal_util_ipc_shmem_IpcSharedMemoryUtils.cpp |   882 ++
 ipc/shmem/include/Makefile.am                   |     2 +-
 ipc/shmem/include/Makefile.in                   |     2 +-
 ...ternal_util_ipc_shmem_IpcSharedMemoryUtils.h |   117 +
 ...id_util_ipc_shmem_GridIpcSharedMemoryUtils.h |   117 -
 ipc/shmem/readme.txt                            |    19 +-
 license/header-customisation.xml                |    51 +
 license/header.txt                              |    14 +
 modules/aop/pom.xml                             |     2 +-
 modules/aop/readme.txt                          |    18 +-
 .../aop/aspectj/GridifyAspectJAspect.java       |   124 +
 .../aspectj/GridifySetToSetAspectJAspect.java   |   135 +
 .../aspectj/GridifySetToValueAspectJAspect.java |   135 +
 .../compute/gridify/aop/aspectj/package.html    |    24 +
 .../aop/spring/GridifySetToSetSpringAspect.java |   130 +
 .../spring/GridifySetToValueSpringAspect.java   |   130 +
 .../gridify/aop/spring/GridifySpringAspect.java |   118 +
 .../aop/spring/GridifySpringEnhancer.java       |    81 +
 .../aop/spring/GridifySpringPointcut.java       |   137 +
 .../compute/gridify/aop/spring/package.html     |    25 +
 .../aop/aspectj/GridifyAspectJAspect.java       |   124 -
 .../aspectj/GridifySetToSetAspectJAspect.java   |   135 -
 .../aspectj/GridifySetToValueAspectJAspect.java |   135 -
 .../compute/gridify/aop/aspectj/package.html    |    24 -
 .../aop/spring/GridifySetToSetSpringAspect.java |   130 -
 .../spring/GridifySetToValueSpringAspect.java   |   130 -
 .../gridify/aop/spring/GridifySpringAspect.java |   119 -
 .../aop/spring/GridifySpringEnhancer.java       |    82 -
 .../aop/spring/GridifySpringPointcut.java       |   136 -
 .../compute/gridify/aop/spring/package.html     |    23 -
 .../test/config/aop/aspectj/META-INF/aop.xml    |    18 +-
 .../config/aop/jboss/jboss-gridgain-aop.xml     |    38 -
 .../apache/ignite/gridify/AbstractAopTest.java  |   734 +
 .../apache/ignite/gridify/BasicAopSelfTest.java |    77 +
 .../ignite/gridify/GridifySetToSetTarget.java   |   372 +
 .../gridify/GridifySetToSetTargetInterface.java |   109 +
 .../ignite/gridify/GridifySetToValueTarget.java |   199 +
 .../GridifySetToValueTargetInterface.java       |   100 +
 .../GridifySetToXXXNonSpringAopSelfTest.java    |   204 +
 .../GridifySetToXXXSpringAopSelfTest.java       |   205 +
 .../ignite/gridify/NonSpringAopSelfTest.java    |    57 +
 .../ignite/gridify/SpringAopSelfTest.java       |    52 +
 .../apache/ignite/gridify/TestAopTarget.java    |   138 +
 .../ignite/gridify/TestAopTargetInterface.java  |    87 +
 .../ignite/gridify/TestGridifyException.java    |    38 +
 .../apache/ignite/gridify/TestGridifyJob.java   |    67 +
 .../apache/ignite/gridify/TestGridifyTask.java  |    46 +
 .../gridify/hierarchy/GridifyHierarchyTest.java |    51 +
 .../ignite/gridify/hierarchy/SuperTarget.java   |    53 +
 .../apache/ignite/gridify/hierarchy/Target.java |    45 +
 .../ignite/gridify/hierarchy/package.html       |    25 +
 .../java/org/apache/ignite/gridify/package.html |    25 +
 .../ignite/gridify/test_resource.properties     |    18 +
 .../optimized/OptimizedMarshallerAopTest.java   |   104 +
 .../apache/ignite/p2p/P2PGridifySelfTest.java   |   241 +
 .../testsuites/IgniteAopSelfTestSuite.java      |    52 +
 .../singlesplit/SingleSplitTestJobTarget.java   |    44 +
 .../direct/singlesplit/SingleSplitTestTask.java |    93 +
 .../singlesplit/SingleSplitsLoadTest.java       |   131 +
 .../loadtests/direct/singlesplit/package.html   |    24 +
 .../gridify/GridifyLoadTestJobTarget.java       |    37 +
 .../loadtests/gridify/GridifyLoadTestTask.java  |    70 +
 .../gridify/GridifySingleSplitLoadTest.java     |   156 +
 .../grid/gridify/GridAbstractAopTest.java       |   734 -
 .../grid/gridify/GridBasicAopSelfTest.java      |    77 -
 .../grid/gridify/GridNonSpringAopSelfTest.java  |    57 -
 .../grid/gridify/GridSpringAopSelfTest.java     |    52 -
 .../grid/gridify/GridTestAopTarget.java         |   138 -
 .../gridify/GridTestAopTargetInterface.java     |    87 -
 .../grid/gridify/GridTestGridifyException.java  |    38 -
 .../grid/gridify/GridTestGridifyJob.java        |    68 -
 .../grid/gridify/GridTestGridifyTask.java       |    47 -
 .../grid/gridify/GridifySetToSetTarget.java     |   372 -
 .../gridify/GridifySetToSetTargetInterface.java |   109 -
 .../grid/gridify/GridifySetToValueTarget.java   |   199 -
 .../GridifySetToValueTargetInterface.java       |   100 -
 .../GridifySetToXXXNonSpringAopSelfTest.java    |   203 -
 .../GridifySetToXXXSpringAopSelfTest.java       |   204 -
 .../grid/gridify/hierarchy/GridSuperTarget.java |    53 -
 .../grid/gridify/hierarchy/GridTarget.java      |    45 -
 .../gridify/hierarchy/GridifyHierarchyTest.java |    51 -
 .../grid/gridify/hierarchy/package.html         |    23 -
 .../java/org/gridgain/grid/gridify/package.html |    23 -
 .../grid/gridify/test_resource.properties       |    18 -
 .../GridOptimizedMarshallerAopTest.java         |   105 -
 .../grid/p2p/GridP2PGridifySelfTest.java        |   241 -
 .../GridSingleSplitTestJobTarget.java           |    46 -
 .../singlesplit/GridSingleSplitTestTask.java    |    94 -
 .../singlesplit/GridSingleSplitsLoadTest.java   |   136 -
 .../loadtests/direct/singlesplit/package.html   |    24 -
 .../gridify/GridifyLoadTestJobTarget.java       |    37 -
 .../loadtests/gridify/GridifyLoadTestTask.java  |    70 -
 .../gridify/GridifySingleSplitLoadTest.java     |   157 -
 .../testsuites/GridAopSelfTestSuite.java        |    52 -
 .../org/test/gridify/ExternalAopTarget.java     |   134 +
 .../test/gridify/ExternalGridifyException.java  |    38 +
 .../org/test/gridify/ExternalGridifyTask.java   |    79 +
 .../gridify/ExternalNonSpringAopSelfTest.java   |   539 +
 .../org/test/gridify/GridExternalAopTarget.java |   134 -
 .../gridify/GridExternalGridifyException.java   |    38 -
 .../test/gridify/GridExternalGridifyTask.java   |    80 -
 .../GridExternalNonSpringAopSelfTest.java       |   539 -
 .../src/test/java/org/test/gridify/package.html |     3 +-
 modules/aws/pom.xml                             |     3 +-
 modules/aws/readme.txt                          |    18 +-
 .../spi/checkpoint/s3/GridS3CheckpointData.java |    90 -
 .../spi/checkpoint/s3/GridS3CheckpointSpi.java  |   684 -
 .../checkpoint/s3/GridS3CheckpointSpiMBean.java |    59 -
 .../spi/checkpoint/s3/GridS3TimeData.java       |    79 -
 .../spi/checkpoint/s3/S3CheckpointData.java     |    91 +
 .../spi/checkpoint/s3/S3CheckpointSpi.java      |   679 +
 .../spi/checkpoint/s3/S3CheckpointSpiMBean.java |    59 +
 .../ignite/spi/checkpoint/s3/S3TimeData.java    |    79 +
 .../ignite/spi/checkpoint/s3/package.html       |     2 +-
 .../ipfinder/s3/GridTcpDiscoveryS3IpFinder.java |   320 -
 .../tcp/ipfinder/s3/TcpDiscoveryS3IpFinder.java |   320 +
 .../spi/discovery/tcp/ipfinder/s3/package.html  |     3 +-
 .../s3/GridS3CheckpointManagerSelfTest.java     |    66 -
 .../s3/GridS3CheckpointSpiConfigSelfTest.java   |    33 -
 .../s3/GridS3CheckpointSpiSelfTest.java         |   215 -
 .../GridS3CheckpointSpiStartStopSelfTest.java   |    41 -
 .../s3/GridS3SessionCheckpointSelfTest.java     |    50 -
 .../s3/S3CheckpointManagerSelfTest.java         |    66 +
 .../s3/S3CheckpointSpiConfigSelfTest.java       |    33 +
 .../checkpoint/s3/S3CheckpointSpiSelfTest.java  |   215 +
 .../s3/S3CheckpointSpiStartStopSelfTest.java    |    41 +
 .../s3/S3SessionCheckpointSelfTest.java         |    50 +
 .../ignite/spi/checkpoint/s3/package.html       |     2 +-
 .../s3/GridTcpDiscoveryS3IpFinderSelfTest.java  |    72 -
 .../s3/TcpDiscoveryS3IpFinderSelfTest.java      |    72 +
 .../spi/discovery/tcp/ipfinder/s3/package.html  |     3 +-
 .../ignite/testsuites/IgniteS3TestSuite.java    |    69 +
 .../testsuites/bamboo/GridS3TestSuite.java      |    69 -
 .../config/grid-client-config.properties        |     4 +-
 .../config/grid-client-spring-config.xml        |    12 +-
 modules/clients/pom.xml                         |     2 +-
 modules/clients/readme.md                       |     8 +-
 modules/clients/src/test/bin/start-nodes-ssh.sh |    28 +-
 modules/clients/src/test/bin/start-nodes.cmd    |    41 +-
 modules/clients/src/test/bin/start-nodes.sh     |    60 +-
 modules/clients/src/test/bin/stop-nodes.cmd     |    17 +
 modules/clients/src/test/bin/stop-nodes.sh      |    26 +-
 .../internal/TaskEventSubjectIdSelfTest.java    |   392 +
 .../ClientAbstractMultiThreadedSelfTest.java    |   598 +
 .../client/ClientDefaultCacheSelfTest.java      |   220 +
 .../internal/client/ClientGetAffinityTask.java  |    64 +
 .../ignite/internal/client/ClientHttpTask.java  |    58 +
 .../internal/client/ClientNodeStartup.java      |    57 +
 .../client/ClientReconnectionSelfTest.java      |   233 +
 .../internal/client/ClientSslNodeStartup.java   |    59 +
 .../internal/client/ClientStartNodeTask.java    |   179 +
 .../internal/client/ClientStopNodeTask.java     |   127 +
 .../internal/client/ClientStringLengthTask.java |    71 +
 .../client/ClientTcpMultiThreadedSelfTest.java  |    45 +
 .../ClientTcpSslAuthenticationSelfTest.java     |   265 +
 .../ClientTcpSslMultiThreadedSelfTest.java      |    46 +
 .../ignite/internal/client/ClientTcpTask.java   |    71 +
 ...skExecutionAfterTopologyRestartSelfTest.java |    75 +
 .../internal/client/ClientTestRestServer.java   |   281 +
 .../client/ClientTopologyCacheSelfTest.java     |   288 +
 .../ignite/internal/client/HashMapStore.java    |    53 +
 .../ignite/internal/client/SleepTestTask.java   |    66 +
 .../client/TaskSingleJobSplitAdapter.java       |    70 +
 .../client/impl/ClientCacheFlagsCodecTest.java  |    83 +
 .../client/impl/ClientComputeImplSelfTest.java  |   167 +
 .../client/impl/ClientDataImplSelfTest.java     |   268 +
 .../impl/ClientFutureAdapterSelfTest.java       |   115 +
 .../impl/ClientPartitionAffinitySelfTest.java   |   406 +
 .../ClientPropertiesConfigurationSelfTest.java  |   232 +
 .../ClientAbstractConnectivitySelfTest.java     |   303 +
 .../ClientAbstractMultiNodeSelfTest.java        |   828 +
 .../integration/ClientAbstractSelfTest.java     |  1483 ++
 .../integration/ClientPreferDirectSelfTest.java |   192 +
 .../ClientTcpConnectivitySelfTest.java          |    75 +
 .../ClientTcpDirectMultiNodeSelfTest.java       |    55 +
 .../integration/ClientTcpDirectSelfTest.java    |    58 +
 .../integration/ClientTcpMultiNodeSelfTest.java |    35 +
 .../client/integration/ClientTcpSelfTest.java   |    46 +
 .../ClientTcpSslDirectMultiNodeSelfTest.java    |    62 +
 .../integration/ClientTcpSslDirectSelfTest.java |    59 +
 .../ClientTcpSslMultiNodeSelfTest.java          |    42 +
 .../integration/ClientTcpSslSelfTest.java       |    47 +
 .../ClientTcpUnreachableMultiNodeSelfTest.java  |   134 +
 .../client/router/ClientFailedInitSelfTest.java |   275 +
 .../client/router/RouterFactorySelfTest.java    |   107 +
 .../router/TcpRouterAbstractSelfTest.java       |   125 +
 .../router/TcpRouterMultiNodeSelfTest.java      |   110 +
 .../client/router/TcpRouterSelfTest.java        |    35 +
 .../client/router/TcpSslRouterSelfTest.java     |    48 +
 .../client/suite/IgniteClientTestSuite.java     |   118 +
 .../client/util/ClientByteUtilsTest.java        |   172 +
 .../util/ClientConsistentHashSelfTest.java      |   281 +
 .../client/util/ClientJavaHasherSelfTest.java   |    84 +
 .../rest/AbstractRestProcessorSelfTest.java     |   106 +
 .../rest/ClientMemcachedProtocolSelfTest.java   |   443 +
 .../JettyRestProcessorAbstractSelfTest.java     |   724 +
 .../rest/JettyRestProcessorSignedSelfTest.java  |   103 +
 .../JettyRestProcessorUnsignedSelfTest.java     |    36 +
 .../rest/MemcacheRestProcessorTest.java         |    76 +
 .../rest/RestBinaryProtocolSelfTest.java        |   609 +
 .../rest/RestMemcacheProtocolSelfTest.java      |   339 +
 .../rest/RestProcessorMultiStartSelfTest.java   |    55 +
 .../rest/RestProcessorStartSelfTest.java        |   164 +
 .../processors/rest/RestProcessorTest.java      |   346 +
 .../rest/TaskCommandHandlerSelfTest.java        |   210 +
 .../processors/rest/TestBinaryClient.java       |   638 +
 .../processors/rest/TestMemcacheClient.java     |   897 ++
 .../internal/processors/rest/TestTask1.java     |    50 +
 .../internal/processors/rest/TestTask2.java     |    53 +
 .../rest/protocols/tcp/MockNioSession.java      |   155 +
 .../protocols/tcp/TcpRestParserSelfTest.java    |   451 +
 .../ignite/jdbc/JdbcComplexQuerySelfTest.java   |   316 +
 .../ignite/jdbc/JdbcConnectionSelfTest.java     |   218 +
 .../ignite/jdbc/JdbcEmptyCacheSelfTest.java     |   135 +
 .../ignite/jdbc/JdbcLocalCachesSelfTest.java    |   160 +
 .../ignite/jdbc/JdbcMetadataSelfTest.java       |   336 +
 .../jdbc/JdbcPreparedStatementSelfTest.java     |   726 +
 .../ignite/jdbc/JdbcResultSetSelfTest.java      |   715 +
 .../ignite/jdbc/JdbcStatementSelfTest.java      |   286 +
 .../jdbc/suite/IgniteJdbcDriverTestSuite.java   |    45 +
 .../loadtests/client/ClientCacheBenchmark.java  |   259 +
 .../client/ClientMarshallerBenchmarkTest.java   |   156 +
 .../loadtests/client/ClientTcpSslLoadTest.java  |    88 +
 ...GridClientAbstractMultiThreadedSelfTest.java |   618 -
 .../client/GridClientDefaultCacheSelfTest.java  |   157 -
 .../client/GridClientGetAffinityTask.java       |    65 -
 .../org/gridgain/client/GridClientHttpTask.java |    59 -
 .../gridgain/client/GridClientNodeStartup.java  |    58 -
 .../client/GridClientPortableArgumentTask.java  |    53 -
 .../client/GridClientPutPortableTask.java       |    45 -
 .../client/GridClientReconnectionSelfTest.java  |   235 -
 .../client/GridClientSslNodeStartup.java        |    60 -
 .../client/GridClientStartNodeTask.java         |   181 -
 .../gridgain/client/GridClientStopNodeTask.java |   128 -
 .../client/GridClientStringLengthTask.java      |    73 -
 .../GridClientTcpMultiThreadedSelfTest.java     |    45 -
 .../GridClientTcpSslAuthenticationSelfTest.java |   265 -
 .../GridClientTcpSslMultiThreadedSelfTest.java  |    46 -
 .../org/gridgain/client/GridClientTcpTask.java  |    73 -
 ...skExecutionAfterTopologyRestartSelfTest.java |    75 -
 .../gridgain/client/GridClientTestPortable.java |   490 -
 .../GridClientTestPortableAffinityKeyTask.java  |    86 -
 .../client/GridClientTestRestServer.java        |   276 -
 .../client/GridClientTopologyCacheSelfTest.java |   289 -
 .../org/gridgain/client/GridHashMapStore.java   |    59 -
 .../org/gridgain/client/GridSleepTestTask.java  |    68 -
 .../client/GridTaskSingleJobSplitAdapter.java   |    75 -
 .../impl/GridClientCacheFlagsCodecTest.java     |    83 -
 .../impl/GridClientComputeImplSelfTest.java     |   167 -
 .../client/impl/GridClientDataImplSelfTest.java |   268 -
 .../impl/GridClientFutureAdapterSelfTest.java   |   115 -
 .../GridClientPartitionAffinitySelfTest.java    |   406 -
 ...idClientPropertiesConfigurationSelfTest.java |   232 -
 .../GridClientAbstractConnectivitySelfTest.java |   303 -
 .../GridClientAbstractMultiNodeSelfTest.java    |   860 --
 .../integration/GridClientAbstractSelfTest.java |  1597 --
 .../GridClientPreferDirectSelfTest.java         |   194 -
 .../GridClientTcpConnectivitySelfTest.java      |    75 -
 .../GridClientTcpDirectMultiNodeSelfTest.java   |    55 -
 .../GridClientTcpDirectSelfTest.java            |    58 -
 .../GridClientTcpMultiNodeSelfTest.java         |    35 -
 .../integration/GridClientTcpSelfTest.java      |    46 -
 ...GridClientTcpSslDirectMultiNodeSelfTest.java |    62 -
 .../GridClientTcpSslDirectSelfTest.java         |    59 -
 .../GridClientTcpSslMultiNodeSelfTest.java      |    42 -
 .../integration/GridClientTcpSslSelfTest.java   |    47 -
 ...idClientTcpUnreachableMultiNodeSelfTest.java |   146 -
 .../gridgain/client/integration/package.html    |    24 -
 .../router/GridClientFailedInitSelfTest.java    |   276 -
 .../router/GridRouterFactorySelfTest.java       |   107 -
 .../router/GridTcpRouterAbstractSelfTest.java   |   125 -
 .../router/GridTcpRouterMultiNodeSelfTest.java  |   110 -
 .../client/router/GridTcpRouterSelfTest.java    |    35 -
 .../client/router/GridTcpSslRouterSelfTest.java |    49 -
 .../org/gridgain/client/router/package.html     |    24 -
 .../router/testsuites/GridRouterTestSuite.java  |    41 -
 .../client/suite/GridClientTestSuite.java       |   118 -
 .../client/util/GridClientByteUtilsTest.java    |   172 -
 .../util/GridClientConsistentHashSelfTest.java  |   281 -
 .../util/GridClientJavaHasherSelfTest.java      |    84 -
 .../kernal/GridTaskEventSubjectIdSelfTest.java  |   393 -
 .../rest/GridAbstractRestProcessorSelfTest.java |    95 -
 .../GridClientMemcachedProtocolSelfTest.java    |   443 -
 .../GridJettyRestProcessorAbstractSelfTest.java |   724 -
 .../GridJettyRestProcessorSignedSelfTest.java   |   103 -
 .../GridJettyRestProcessorUnsignedSelfTest.java |    36 -
 .../rest/GridMemcacheRestProcessorTest.java     |    76 -
 .../rest/GridRestBinaryProtocolSelfTest.java    |   633 -
 .../rest/GridRestMemcacheProtocolSelfTest.java  |   332 -
 .../GridRestProcessorMultiStartSelfTest.java    |    55 -
 .../rest/GridRestProcessorStartSelfTest.java    |   163 -
 .../processors/rest/GridRestProcessorTest.java  |   346 -
 .../rest/GridTaskCommandHandlerSelfTest.java    |   212 -
 .../processors/rest/GridTestBinaryClient.java   |   652 -
 .../processors/rest/GridTestMemcacheClient.java |   899 --
 .../grid/kernal/processors/rest/TestTask1.java  |    52 -
 .../grid/kernal/processors/rest/TestTask2.java  |    54 -
 .../rest/protocols/tcp/GridMockNioSession.java  |   155 -
 .../tcp/GridTcpRestParserSelfTest.java          |   451 -
 .../jdbc/GridJdbcComplexQuerySelfTest.java      |   316 -
 .../jdbc/GridJdbcConnectionSelfTest.java        |   219 -
 .../jdbc/GridJdbcEmptyCacheSelfTest.java        |   136 -
 .../jdbc/GridJdbcLocalCachesSelfTest.java       |   158 -
 .../gridgain/jdbc/GridJdbcMetadataSelfTest.java |   336 -
 .../jdbc/GridJdbcPreparedStatementSelfTest.java |   726 -
 .../jdbc/GridJdbcResultSetSelfTest.java         |   715 -
 .../jdbc/GridJdbcStatementSelfTest.java         |   286 -
 .../jdbc/suite/GridJdbcDriverTestSuite.java     |    45 -
 .../client/GridClientCacheBenchmark.java        |   259 -
 .../GridClientMarshallerBenchmarkTest.java      |   156 -
 .../client/GridClientTcpSslLoadTest.java        |    83 -
 modules/clients/src/test/keystore/generate.sh   |    25 +-
 .../src/test/resources/jetty/rest-jetty-ssl.xml |    12 +-
 .../src/test/resources/jetty/rest-jetty.xml     |    10 +-
 .../test/resources/jetty/router-jetty-ssl.xml   |    10 +-
 .../src/test/resources/jetty/router-jetty.xml   |    10 +-
 modules/clients/src/test/resources/log4j.xml    |    18 +-
 .../clients/src/test/resources/spring-cache.xml |    47 +-
 .../src/test/resources/spring-router-ssl.xml    |    18 +-
 .../src/test/resources/spring-router.xml        |    16 +-
 .../src/test/resources/spring-server-node.xml   |   221 +-
 .../test/resources/spring-server-ssl-node.xml   |   219 +-
 modules/codegen/pom.xml                         |    50 +
 .../CommunicationMessageCodeGenerator.java      |   788 +
 modules/core/licenses/sun-bcl-license.txt       |    50 +
 modules/core/pom.xml                            |    89 +-
 .../java/META-INF/native/linux64/libggshmem.so  |   Bin 138023 -> 0 bytes
 .../META-INF/native/linux64/libigniteshmem.so   |   Bin 0 -> 138345 bytes
 .../java/META-INF/native/osx/libggshmem.dylib   |   Bin 32940 -> 0 bytes
 .../META-INF/native/osx/libigniteshmem.dylib    |   Bin 0 -> 33116 bytes
 .../services/javax.cache.spi.CachingProvider    |     1 +
 .../src/main/java/org/apache/ignite/Ignite.java |   223 +-
 .../org/apache/ignite/IgniteAtomicLong.java     |   163 +
 .../apache/ignite/IgniteAtomicReference.java    |    99 +
 .../org/apache/ignite/IgniteAtomicSequence.java |   136 +
 .../org/apache/ignite/IgniteAtomicStamped.java  |   128 +
 .../ignite/IgniteAuthenticationException.java   |    35 +
 .../java/org/apache/ignite/IgniteCache.java     |   315 +-
 .../apache/ignite/IgniteCheckedException.java   |    29 +-
 .../java/org/apache/ignite/IgniteCluster.java   |    73 +-
 .../java/org/apache/ignite/IgniteCompute.java   |   116 +-
 .../org/apache/ignite/IgniteCountDownLatch.java |   230 +
 .../org/apache/ignite/IgniteDataLoader.java     |   109 +-
 .../ignite/IgniteDeploymentException.java       |    57 +
 .../java/org/apache/ignite/IgniteEvents.java    |    71 +-
 .../java/org/apache/ignite/IgniteException.java |    31 +-
 .../main/java/org/apache/ignite/IgniteFs.java   |   179 +-
 .../ignite/IgniteIllegalStateException.java     |    84 +
 .../ignite/IgniteInterruptedException.java      |    55 +
 .../org/apache/ignite/IgniteJdbcDriver.java     |   484 +
 .../java/org/apache/ignite/IgniteLogger.java    |    22 +-
 .../java/org/apache/ignite/IgniteManaged.java   |   351 -
 .../java/org/apache/ignite/IgniteMessaging.java |    45 +-
 .../java/org/apache/ignite/IgnitePortables.java |   366 -
 .../java/org/apache/ignite/IgniteQueue.java     |   182 +
 .../java/org/apache/ignite/IgniteScheduler.java |    12 +-
 .../java/org/apache/ignite/IgniteServices.java  |   354 +
 .../main/java/org/apache/ignite/IgniteSet.java  |   104 +
 .../java/org/apache/ignite/IgniteState.java     |     4 +-
 .../java/org/apache/ignite/IgniteStreamer.java  |    26 +-
 .../apache/ignite/IgniteSystemProperties.java   |   286 +-
 .../org/apache/ignite/IgniteTransactions.java   |    93 +-
 .../main/java/org/apache/ignite/Ignition.java   |   137 +-
 .../org/apache/ignite/IgnitionListener.java     |    37 +
 .../CacheAtomicUpdateTimeoutException.java      |    47 +
 .../ignite/cache/CacheAtomicWriteOrderMode.java |    64 +
 .../apache/ignite/cache/CacheAtomicityMode.java |    79 +
 .../apache/ignite/cache/CacheConfiguration.java |    31 -
 .../ignite/cache/CacheDistributionMode.java     |    69 +
 .../apache/ignite/cache/CacheEntryEvent.java    |    44 -
 .../java/org/apache/ignite/cache/CacheFlag.java |    77 -
 .../apache/ignite/cache/CacheInterceptor.java   |   121 +
 .../ignite/cache/CacheInterceptorAdapter.java   |    52 +
 .../org/apache/ignite/cache/CacheManager.java   |   441 +
 .../apache/ignite/cache/CacheMemoryMode.java    |    59 +
 .../org/apache/ignite/cache/CacheMetrics.java   |   455 +
 .../java/org/apache/ignite/cache/CacheMode.java |    73 +
 .../cache/CachePartialUpdateException.java      |    44 +
 .../org/apache/ignite/cache/CachePeekMode.java  |    14 +-
 .../apache/ignite/cache/CachePreloadMode.java   |    67 +
 .../ignite/cache/CacheTypeFieldMetadata.java    |   145 +
 .../apache/ignite/cache/CacheTypeMetadata.java  |   330 +
 .../cache/CacheWriteSynchronizationMode.java    |    69 +
 .../apache/ignite/cache/CachingProvider.java    |   189 +
 .../java/org/apache/ignite/cache/GridCache.java |   271 +
 .../ignite/cache/affinity/CacheAffinity.java    |   256 +
 .../cache/affinity/CacheAffinityFunction.java   |   110 +
 .../affinity/CacheAffinityFunctionContext.java  |    71 +
 .../ignite/cache/affinity/CacheAffinityKey.java |   189 +
 .../cache/affinity/CacheAffinityKeyMapped.java  |   156 +
 .../cache/affinity/CacheAffinityKeyMapper.java  |    62 +
 .../CacheAffinityNodeAddressHashResolver.java   |    39 +
 .../affinity/CacheAffinityNodeHashResolver.java |    43 +
 .../CacheAffinityNodeIdHashResolver.java        |    40 +
 .../CacheCentralizedAffinityFunction.java       |    31 +
 .../CacheConsistentHashAffinityFunction.java    |   702 +
 .../cache/affinity/consistenthash/package.html  |    24 +
 .../fair/CachePartitionFairAffinity.java        |   804 +
 .../ignite/cache/affinity/fair/package.html     |    24 +
 .../apache/ignite/cache/affinity/package.html   |    24 +
 .../CacheRendezvousAffinityFunction.java        |   501 +
 .../cache/affinity/rendezvous/package.html      |    24 +
 .../cache/eviction/CacheEvictionFilter.java     |    40 +
 .../cache/eviction/CacheEvictionPolicy.java     |    51 +
 .../ignite/cache/eviction/EvictableEntry.java   |    71 +-
 .../eviction/fifo/CacheFifoEvictionPolicy.java  |   181 +
 .../fifo/CacheFifoEvictionPolicyMBean.java      |    50 +
 .../ignite/cache/eviction/fifo/package.html     |    24 +
 .../eviction/igfs/CacheIgfsEvictionFilter.java  |    35 +
 .../CacheIgfsPerBlockLruEvictionPolicy.java     |   358 +
 ...acheIgfsPerBlockLruEvictionPolicyMXBean.java |    93 +
 .../ignite/cache/eviction/igfs/package.html     |    24 +
 .../eviction/lru/CacheLruEvictionPolicy.java    |   186 +
 .../lru/CacheLruEvictionPolicyMBean.java        |    50 +
 .../ignite/cache/eviction/lru/package.html      |    24 +
 .../apache/ignite/cache/eviction/package.html   |    24 +
 .../random/CacheRandomEvictionPolicy.java       |   101 +
 .../random/CacheRandomEvictionPolicyMBean.java  |    42 +
 .../ignite/cache/eviction/random/package.html   |    24 +
 .../java/org/apache/ignite/cache/package.html   |    24 +
 .../ignite/cache/query/ContinuousQuery.java     |   314 +
 .../org/apache/ignite/cache/query/Query.java    |   143 +
 .../cache/query/QueryAffinityPredicate.java     |   132 -
 .../cache/query/QueryContinuousPredicate.java   |   212 -
 .../apache/ignite/cache/query/QueryCursor.java  |    22 +-
 .../apache/ignite/cache/query/QueryMetrics.java |    62 +
 .../ignite/cache/query/QueryPredicate.java      |    76 -
 .../apache/ignite/cache/query/QueryReducer.java |    30 -
 .../ignite/cache/query/QuerySqlPredicate.java   |   115 -
 .../ignite/cache/query/QueryTextPredicate.java  |    87 -
 .../ignite/cache/query/QueryTypeResolver.java   |    32 +
 .../apache/ignite/cache/query/ScanQuery.java    |    76 +
 .../org/apache/ignite/cache/query/SpiQuery.java |    64 +
 .../ignite/cache/query/SqlFieldsQuery.java      |    98 +
 .../org/apache/ignite/cache/query/SqlQuery.java |   142 +
 .../apache/ignite/cache/query/TextQuery.java    |   119 +
 .../query/annotations/QueryGroupIndex.java      |     9 -
 .../cache/query/annotations/QuerySqlField.java  |    20 +-
 .../query/annotations/QuerySqlFunction.java     |     4 +-
 .../cache/query/annotations/QueryTextField.java |     8 +-
 .../org/apache/ignite/cache/query/package.html  |    24 +
 .../cache/store/CacheLoadOnlyStoreAdapter.java  |   323 +
 .../apache/ignite/cache/store/CacheStore.java   |   150 +
 .../ignite/cache/store/CacheStoreAdapter.java   |    94 +
 .../ignite/cache/store/CacheStoreSession.java   |    55 +
 .../store/jdbc/CacheAbstractJdbcStore.java      |  1606 ++
 .../cache/store/jdbc/CacheJdbcBlobStore.java    |   596 +
 .../cache/store/jdbc/CacheJdbcPojoStore.java    |   205 +
 .../store/jdbc/dialect/BasicJdbcDialect.java    |   274 +
 .../cache/store/jdbc/dialect/DB2Dialect.java    |    68 +
 .../cache/store/jdbc/dialect/H2Dialect.java     |    41 +
 .../cache/store/jdbc/dialect/JdbcDialect.java   |   117 +
 .../cache/store/jdbc/dialect/MySQLDialect.java  |    48 +
 .../cache/store/jdbc/dialect/OracleDialect.java |    72 +
 .../store/jdbc/dialect/SQLServerDialect.java    |    67 +
 .../cache/store/jdbc/dialect/package.html       |    24 +
 .../apache/ignite/cache/store/jdbc/package.html |    24 +
 .../org/apache/ignite/cache/store/package.html  |    24 +
 .../org/apache/ignite/cluster/ClusterGroup.java |    35 +-
 .../cluster/ClusterGroupEmptyException.java     |     4 +-
 .../apache/ignite/cluster/ClusterMetrics.java   |   728 +-
 .../org/apache/ignite/cluster/ClusterNode.java  |    40 +-
 .../ignite/cluster/ClusterNodeLocalMap.java     |     4 +-
 .../ignite/cluster/ClusterNodeMetrics.java      |   695 -
 .../cluster/ClusterTopologyException.java       |     2 +-
 .../ComputeExecutionRejectedException.java      |     4 +-
 .../org/apache/ignite/compute/ComputeJob.java   |    29 +-
 .../ignite/compute/ComputeJobAdapter.java       |     6 +-
 .../ignite/compute/ComputeJobContext.java       |    26 +-
 .../compute/ComputeJobContinuationAdapter.java  |     4 +-
 .../compute/ComputeJobFailoverException.java    |     5 +-
 .../compute/ComputeJobMasterLeaveAware.java     |     4 +-
 .../apache/ignite/compute/ComputeJobResult.java |     6 +-
 .../ignite/compute/ComputeJobSibling.java       |     7 +-
 .../ignite/compute/ComputeLoadBalancer.java     |    11 +-
 .../org/apache/ignite/compute/ComputeTask.java  |    42 +-
 .../ignite/compute/ComputeTaskAdapter.java      |    17 +-
 .../compute/ComputeTaskCancelledException.java  |     2 +-
 .../compute/ComputeTaskContinuousMapper.java    |    26 +-
 .../ignite/compute/ComputeTaskFuture.java       |    12 +-
 .../ignite/compute/ComputeTaskMapAsync.java     |     2 +-
 .../apache/ignite/compute/ComputeTaskName.java  |     2 +-
 .../ignite/compute/ComputeTaskSession.java      |    49 +-
 .../apache/ignite/compute/ComputeTaskSpis.java  |     2 +-
 .../ignite/compute/ComputeTaskSplitAdapter.java |    17 +-
 .../compute/ComputeTaskTimeoutException.java    |     2 +-
 .../compute/ComputeUserUndeclaredException.java |     4 +-
 .../apache/ignite/compute/gridify/Gridify.java  |    12 +-
 .../ignite/compute/gridify/GridifyInput.java    |     2 +-
 .../ignite/compute/gridify/GridifySetToSet.java |    20 +-
 .../compute/gridify/GridifySetToValue.java      |    20 +-
 .../gridify/aop/GridifyArgumentAdapter.java     |     2 +-
 .../gridify/aop/GridifyDefaultRangeTask.java    |    26 +-
 .../compute/gridify/aop/GridifyDefaultTask.java |    14 +-
 .../aop/GridifySetToSetAbstractAspect.java      |    12 +-
 .../aop/GridifySetToValueAbstractAspect.java    |    12 +-
 .../ignite/compute/gridify/aop/package.html     |     3 +-
 .../apache/ignite/compute/gridify/package.html  |     3 +-
 .../java/org/apache/ignite/compute/package.html |     2 +-
 .../ignite/configuration/AddressResolver.java   |    43 +
 .../configuration/AtomicConfiguration.java      |   105 +
 .../configuration/CacheConfiguration.java       |  1627 ++
 .../configuration/CacheQueryConfiguration.java  |   182 +
 .../ClientConnectionConfiguration.java          |   577 -
 .../configuration/ClientMessageInterceptor.java |    45 -
 .../configuration/CollectionConfiguration.java  |    67 +
 .../configuration/ConnectorConfiguration.java   |   518 +
 .../ConnectorMessageInterceptor.java            |    45 +
 .../ignite/configuration/DeploymentMode.java    |   181 +
 .../configuration/GridQueryConfiguration.java   |   202 -
 .../ignite/configuration/IgfsConfiguration.java |   807 +
 .../configuration/IgniteAddressResolver.java    |    43 -
 .../configuration/IgniteConfiguration.java      |  1676 +-
 .../configuration/IgniteDeploymentMode.java     |   196 -
 .../configuration/QueryConfiguration.java       |   202 +
 .../configuration/TransactionConfiguration.java |   205 +
 .../TransactionsConfiguration.java              |   202 -
 .../dataload/IgniteDataLoadCacheUpdater.java    |    43 -
 .../org/apache/ignite/dataload/package.html     |    23 -
 .../org/apache/ignite/events/CacheEvent.java    |   331 +
 .../ignite/events/CachePreloadingEvent.java     |   172 +
 .../ignite/events/CacheQueryExecutedEvent.java  |   238 +
 .../ignite/events/CacheQueryReadEvent.java      |   300 +
 .../apache/ignite/events/CheckpointEvent.java   |   122 +
 .../apache/ignite/events/DeploymentEvent.java   |   118 +
 .../apache/ignite/events/DiscoveryEvent.java    |   165 +
 .../java/org/apache/ignite/events/Event.java    |   154 +
 .../org/apache/ignite/events/EventAdapter.java  |   168 +
 .../apache/ignite/events/EventLocalOrder.java   |    44 +
 .../org/apache/ignite/events/EventType.java     |   983 ++
 .../org/apache/ignite/events/IgfsEvent.java     |   197 +
 .../events/IgniteAuthenticationEvent.java       |   172 -
 .../ignite/events/IgniteAuthorizationEvent.java |   146 -
 .../apache/ignite/events/IgniteCacheEvent.java  |   331 -
 .../events/IgniteCachePreloadingEvent.java      |   172 -
 .../events/IgniteCacheQueryExecutedEvent.java   |   237 -
 .../events/IgniteCacheQueryReadEvent.java       |   299 -
 .../ignite/events/IgniteCheckpointEvent.java    |   122 -
 .../ignite/events/IgniteDeploymentEvent.java    |   118 -
 .../ignite/events/IgniteDiscoveryEvent.java     |   165 -
 .../org/apache/ignite/events/IgniteEvent.java   |   154 -
 .../ignite/events/IgniteEventAdapter.java       |   168 -
 .../ignite/events/IgniteEventLocalOrder.java    |    44 -
 .../apache/ignite/events/IgniteEventType.java   |  1266 --
 .../org/apache/ignite/events/IgniteFsEvent.java |   197 -
 .../apache/ignite/events/IgniteJobEvent.java    |   236 -
 .../ignite/events/IgniteLicenseEvent.java       |   116 -
 .../ignite/events/IgniteSecureSessionEvent.java |   154 -
 .../ignite/events/IgniteSwapSpaceEvent.java     |   104 -
 .../apache/ignite/events/IgniteTaskEvent.java   |   168 -
 .../java/org/apache/ignite/events/JobEvent.java |   236 +
 .../apache/ignite/events/SwapSpaceEvent.java    |   104 +
 .../org/apache/ignite/events/TaskEvent.java     |   168 +
 .../java/org/apache/ignite/events/package.html  |     5 +-
 .../apache/ignite/fs/IgniteFsBlockLocation.java |    63 -
 ...IgniteFsConcurrentModificationException.java |    36 -
 .../apache/ignite/fs/IgniteFsConfiguration.java |   806 -
 .../fs/IgniteFsCorruptedFileException.java      |    50 -
 .../org/apache/ignite/fs/IgniteFsException.java |    57 -
 .../java/org/apache/ignite/fs/IgniteFsFile.java |   120 -
 .../fs/IgniteFsFileNotFoundException.java       |    44 -
 .../apache/ignite/fs/IgniteFsFileSystem.java    |   216 -
 .../fs/IgniteFsGroupDataBlocksKeyMapper.java    |   101 -
 .../apache/ignite/fs/IgniteFsInputStream.java   |    80 -
 .../fs/IgniteFsInvalidHdfsVersionException.java |    42 -
 .../ignite/fs/IgniteFsInvalidPathException.java |    57 -
 .../org/apache/ignite/fs/IgniteFsMetrics.java   |   159 -
 .../java/org/apache/ignite/fs/IgniteFsMode.java |    80 -
 .../ignite/fs/IgniteFsOutOfSpaceException.java  |    58 -
 .../apache/ignite/fs/IgniteFsOutputStream.java  |    35 -
 .../fs/IgniteFsParentNotDirectoryException.java |    50 -
 .../java/org/apache/ignite/fs/IgniteFsPath.java |   262 -
 .../fs/IgniteFsPathAlreadyExistsException.java  |    50 -
 .../apache/ignite/fs/IgniteFsPathSummary.java   |   138 -
 .../org/apache/ignite/fs/IgniteFsReader.java    |    38 -
 .../ignite/fs/mapreduce/IgniteFsFileRange.java  |    80 -
 .../IgniteFsInputStreamJobAdapter.java          |    53 -
 .../apache/ignite/fs/mapreduce/IgniteFsJob.java |    70 -
 .../ignite/fs/mapreduce/IgniteFsJobAdapter.java |    28 -
 .../fs/mapreduce/IgniteFsRangeInputStream.java  |   197 -
 .../fs/mapreduce/IgniteFsRecordResolver.java    |    57 -
 .../ignite/fs/mapreduce/IgniteFsTask.java       |   173 -
 .../ignite/fs/mapreduce/IgniteFsTaskArgs.java   |    82 -
 .../mapreduce/IgniteFsTaskNoReduceAdapter.java  |    42 -
 .../org/apache/ignite/fs/mapreduce/package.html |    23 -
 .../IgniteFsByteDelimiterRecordResolver.java    |   348 -
 .../IgniteFsFixedLengthRecordResolver.java      |    87 -
 .../records/IgniteFsNewLineRecordResolver.java  |    66 -
 .../IgniteFsStringDelimiterRecordResolver.java  |    84 -
 .../ignite/fs/mapreduce/records/package.html    |    24 -
 .../main/java/org/apache/ignite/fs/package.html |    24 -
 .../main/java/org/apache/ignite/igfs/Igfs.java  |   216 +
 .../apache/ignite/igfs/IgfsBlockLocation.java   |    63 +
 .../IgfsConcurrentModificationException.java    |    36 +
 .../ignite/igfs/IgfsCorruptedFileException.java |    50 +
 .../org/apache/ignite/igfs/IgfsException.java   |    57 +
 .../java/org/apache/ignite/igfs/IgfsFile.java   |   120 +
 .../ignite/igfs/IgfsFileNotFoundException.java  |    44 +
 .../igfs/IgfsGroupDataBlocksKeyMapper.java      |   101 +
 .../org/apache/ignite/igfs/IgfsInputStream.java |    80 +
 .../igfs/IgfsInvalidHdfsVersionException.java   |    42 +
 .../ignite/igfs/IgfsInvalidPathException.java   |    57 +
 .../org/apache/ignite/igfs/IgfsMetrics.java     |   159 +
 .../java/org/apache/ignite/igfs/IgfsMode.java   |    80 +
 .../ignite/igfs/IgfsOutOfSpaceException.java    |    58 +
 .../apache/ignite/igfs/IgfsOutputStream.java    |    35 +
 .../igfs/IgfsParentNotDirectoryException.java   |    50 +
 .../java/org/apache/ignite/igfs/IgfsPath.java   |   262 +
 .../igfs/IgfsPathAlreadyExistsException.java    |    50 +
 .../org/apache/ignite/igfs/IgfsPathSummary.java |   138 +
 .../java/org/apache/ignite/igfs/IgfsReader.java |    38 +
 .../ignite/igfs/mapreduce/IgfsFileRange.java    |    80 +
 .../mapreduce/IgfsInputStreamJobAdapter.java    |    52 +
 .../apache/ignite/igfs/mapreduce/IgfsJob.java   |    69 +
 .../ignite/igfs/mapreduce/IgfsJobAdapter.java   |    28 +
 .../igfs/mapreduce/IgfsRangeInputStream.java    |   197 +
 .../igfs/mapreduce/IgfsRecordResolver.java      |    56 +
 .../apache/ignite/igfs/mapreduce/IgfsTask.java  |   172 +
 .../ignite/igfs/mapreduce/IgfsTaskArgs.java     |    82 +
 .../igfs/mapreduce/IgfsTaskNoReduceAdapter.java |    42 +
 .../apache/ignite/igfs/mapreduce/package.html   |    24 +
 .../IgfsByteDelimiterRecordResolver.java        |   347 +
 .../records/IgfsFixedLengthRecordResolver.java  |    86 +
 .../records/IgfsNewLineRecordResolver.java      |    66 +
 .../IgfsStringDelimiterRecordResolver.java      |    84 +
 .../ignite/igfs/mapreduce/records/package.html  |    24 +
 .../java/org/apache/ignite/igfs/package.html    |    24 +
 .../ignite/internal/AsyncSupportAdapter.java    |   109 +
 .../ignite/internal/ClusterGroupAdapter.java    |   889 ++
 .../apache/ignite/internal/ClusterGroupEx.java  |    44 +
 .../ClusterLocalNodeMetricsMXBeanImpl.java      |   319 +
 .../ignite/internal/ClusterMetricsSnapshot.java |  1524 ++
 .../internal/ClusterNodeLocalMapImpl.java       |   103 +
 .../internal/ComputeTaskInternalFuture.java     |   292 +
 .../ignite/internal/GridClosureCallMode.java    |    61 +
 .../apache/ignite/internal/GridComponent.java   |   115 +
 .../apache/ignite/internal/GridDiagnostic.java  |   172 +
 .../ignite/internal/GridDirectCollection.java   |    32 +
 .../apache/ignite/internal/GridDirectMap.java   |    37 +
 .../ignite/internal/GridDirectTransient.java    |    29 +
 .../internal/GridEventConsumeHandler.java       |   415 +
 .../ignite/internal/GridInternalException.java  |    69 +
 .../ignite/internal/GridInternalWrapper.java    |    30 +
 .../ignite/internal/GridJobCancelRequest.java   |   190 +
 .../ignite/internal/GridJobContextImpl.java     |   259 +
 .../ignite/internal/GridJobExecuteRequest.java  |   748 +
 .../ignite/internal/GridJobExecuteResponse.java |   341 +
 .../ignite/internal/GridJobResultImpl.java      |   184 +
 .../ignite/internal/GridJobSessionImpl.java     |   302 +
 .../ignite/internal/GridJobSiblingImpl.java     |   196 +
 .../ignite/internal/GridJobSiblingsRequest.java |   150 +
 .../internal/GridJobSiblingsResponse.java       |   129 +
 .../ignite/internal/GridKernalContext.java      |   511 +
 .../ignite/internal/GridKernalContextImpl.java  |   861 ++
 .../ignite/internal/GridKernalGateway.java      |   138 +
 .../ignite/internal/GridKernalGatewayImpl.java  |   243 +
 .../apache/ignite/internal/GridKernalState.java |    51 +
 .../apache/ignite/internal/GridKillTask.java    |   103 +
 .../apache/ignite/internal/GridLoggerProxy.java |   218 +
 .../internal/GridMessageListenHandler.java      |   200 +
 .../internal/GridNodeOrderComparator.java       |    36 +
 .../internal/GridPerformanceSuggestions.java    |    90 +
 .../ignite/internal/GridPluginComponent.java    |   101 +
 .../ignite/internal/GridPluginContext.java      |    95 +
 .../apache/ignite/internal/GridProperties.java  |    78 +
 .../ignite/internal/GridProxyListener.java      |    51 +
 .../ignite/internal/GridTaskCancelRequest.java  |   113 +
 .../apache/ignite/internal/GridTaskMessage.java |    30 +
 .../ignite/internal/GridTaskNameHashKey.java    |    75 +
 .../ignite/internal/GridTaskSessionImpl.java    |   854 +
 .../internal/GridTaskSessionInternal.java       |    69 +
 .../ignite/internal/GridTaskSessionRequest.java |   178 +
 .../org/apache/ignite/internal/GridTopic.java   |   832 +
 .../ignite/internal/GridUpdateNotifier.java     |   361 +
 .../ignite/internal/IgniteClusterAsyncImpl.java |   261 +
 .../ignite/internal/IgniteComponentType.java    |   276 +
 .../ignite/internal/IgniteComputeImpl.java      |   563 +
 .../IgniteDeploymentCheckedException.java       |    58 +
 .../ignite/internal/IgniteEventsImpl.java       |   308 +
 .../org/apache/ignite/internal/IgniteEx.java    |   133 +
 .../IgniteFutureCancelledCheckedException.java  |    58 +
 .../IgniteFutureTimeoutCheckedException.java    |    58 +
 .../ignite/internal/IgniteInternalFuture.java   |   190 +
 .../IgniteInterruptedCheckedException.java      |    58 +
 .../apache/ignite/internal/IgniteKernal.java    |  3070 ++++
 .../ignite/internal/IgniteMessagingImpl.java    |   244 +
 .../ignite/internal/IgniteNodeAttributes.java   |   141 +
 .../ignite/internal/IgniteSchedulerImpl.java    |   142 +
 .../ignite/internal/IgniteServicesImpl.java     |   283 +
 .../ignite/internal/IgniteTransactionsEx.java   |    66 +
 .../ignite/internal/IgniteVersionUtils.java     |    78 +
 .../org/apache/ignite/internal/IgnitionEx.java  |  2271 +++
 .../ignite/internal/IgnitionMXBeanAdapter.java  |    59 +
 .../internal/ThreadPoolMXBeanAdapter.java       |   129 +
 .../ignite/internal/client/GridClient.java      |   146 +
 .../GridClientAuthenticationException.java      |    35 +
 .../internal/client/GridClientCacheFlag.java    |    65 +
 .../internal/client/GridClientCacheMode.java    |    32 +
 .../client/GridClientClosedException.java       |    35 +
 .../internal/client/GridClientCompute.java      |   419 +
 .../client/GridClientConfiguration.java         |   844 +
 .../ignite/internal/client/GridClientData.java  |   443 +
 .../internal/client/GridClientDataAffinity.java |    39 +
 .../client/GridClientDataConfiguration.java     |   118 +
 .../internal/client/GridClientDataMetrics.java  |    77 +
 .../client/GridClientDisconnectedException.java |    36 +
 .../internal/client/GridClientException.java    |   111 +
 .../internal/client/GridClientFactory.java      |   138 +
 .../internal/client/GridClientFuture.java       |    68 +
 .../client/GridClientFutureListener.java        |    30 +
 .../GridClientFutureTimeoutException.java       |    45 +
 .../client/GridClientHandshakeException.java    |    48 +
 .../ignite/internal/client/GridClientNode.java  |   128 +
 .../internal/client/GridClientNodeMetrics.java  |   524 +
 .../client/GridClientPartitionAffinity.java     |   369 +
 .../internal/client/GridClientPredicate.java    |    38 +
 .../internal/client/GridClientProtocol.java     |    26 +
 .../client/GridClientTopologyListener.java      |    41 +
 .../client/GridServerUnreachableException.java  |    45 +
 .../balancer/GridClientBalancerAdapter.java     |    76 +
 .../client/balancer/GridClientLoadBalancer.java |    44 +
 .../balancer/GridClientRandomBalancer.java      |    75 +
 .../balancer/GridClientRoundRobinBalancer.java  |   111 +
 .../impl/GridClientAbstractProjection.java      |   458 +
 .../client/impl/GridClientAndPredicate.java     |    52 +
 .../client/impl/GridClientComputeImpl.java      |   263 +
 .../client/impl/GridClientDataImpl.java         |   389 +
 .../impl/GridClientDataMetricsAdapter.java      |   160 +
 .../client/impl/GridClientFutureAdapter.java    |   349 +
 .../client/impl/GridClientFutureCallback.java   |    35 +
 .../internal/client/impl/GridClientImpl.java    |   527 +
 .../client/impl/GridClientNodeImpl.java         |   396 +
 .../impl/GridClientNodeMetricsAdapter.java      |   990 ++
 .../client/impl/GridClientThreadFactory.java    |    62 +
 .../impl/connection/GridClientConnection.java   |   515 +
 .../GridClientConnectionCloseReason.java        |    32 +
 .../connection/GridClientConnectionManager.java |    71 +
 .../GridClientConnectionManagerAdapter.java     |   644 +
 .../GridClientConnectionManagerOsImpl.java      |    48 +
 .../GridClientConnectionResetException.java     |    48 +
 .../connection/GridClientNioTcpConnection.java  |  1063 ++
 .../impl/connection/GridClientTopology.java     |   450 +
 .../GridConnectionIdleClosedException.java      |    36 +
 .../client/marshaller/GridClientMarshaller.java |    45 +
 .../marshaller/jdk/GridClientJdkMarshaller.java |    68 +
 .../GridClientOptimizedMarshaller.java          |   103 +
 .../client/router/GridRouterFactory.java        |   126 +
 .../internal/client/router/GridTcpRouter.java   |    74 +
 .../router/GridTcpRouterConfiguration.java      |   306 +
 .../client/router/GridTcpRouterMBean.java       |    88 +
 .../router/impl/GridRouterClientImpl.java       |   200 +
 .../impl/GridRouterCommandLineStartup.java      |   169 +
 .../client/router/impl/GridTcpRouterImpl.java   |   348 +
 .../impl/GridTcpRouterNioListenerAdapter.java   |   203 +
 .../impl/GridTcpRouterNioListenerOsImpl.java    |    38 +
 .../router/impl/GridTcpRouterNioParser.java     |   115 +
 .../client/ssl/GridSslBasicContextFactory.java  |   438 +
 .../client/ssl/GridSslContextFactory.java       |    36 +
 .../client/util/GridClientConsistentHash.java   |   440 +
 .../client/util/GridClientStripedLock.java      |   135 +
 .../internal/client/util/GridClientUtils.java   |   171 +
 .../client/util/GridConcurrentHashSet.java      |   113 +
 .../ClusterGroupEmptyCheckedException.java      |    55 +
 .../ClusterTopologyCheckedException.java        |    49 +
 .../ComputeTaskCancelledCheckedException.java   |    58 +
 .../ComputeTaskTimeoutCheckedException.java     |    61 +
 .../internal/direct/DirectByteBufferStream.java |  1453 ++
 .../internal/direct/DirectMessageReader.java    |   270 +
 .../internal/direct/DirectMessageWriter.java    |   245 +
 .../direct/DirectMessageWriterState.java        |   113 +
 .../internal/executor/GridExecutorService.java  |   716 +
 .../ignite/internal/executor/package.html       |    24 +
 .../igfs/common/IgfsControlResponse.java        |   633 +
 .../igfs/common/IgfsDataInputStream.java        |    40 +
 .../igfs/common/IgfsDataOutputStream.java       |    43 +
 .../igfs/common/IgfsHandshakeRequest.java       |    93 +
 .../internal/igfs/common/IgfsIpcCommand.java    |    98 +
 .../ignite/internal/igfs/common/IgfsLogger.java |   767 +
 .../internal/igfs/common/IgfsMarshaller.java    |   374 +
 .../internal/igfs/common/IgfsMessage.java       |    41 +
 .../igfs/common/IgfsPathControlRequest.java     |   238 +
 .../internal/igfs/common/IgfsStatusRequest.java |    35 +
 .../igfs/common/IgfsStreamControlRequest.java   |   101 +
 .../ignite/internal/igfs/common/package.html    |    24 +
 .../ignite/internal/jdbc/JdbcConnection.java    |   547 +
 .../internal/jdbc/JdbcConnectionInfo.java       |    91 +
 .../internal/jdbc/JdbcDatabaseMetadata.java     |  1313 ++
 .../internal/jdbc/JdbcPreparedStatement.java    |   411 +
 .../ignite/internal/jdbc/JdbcResultSet.java     |  1519 ++
 .../internal/jdbc/JdbcResultSetMetadata.java    |   170 +
 .../ignite/internal/jdbc/JdbcStatement.java     |   448 +
 .../apache/ignite/internal/jdbc/JdbcUtils.java  |   232 +
 .../ignite/internal/managers/GridManager.java   |    46 +
 .../internal/managers/GridManagerAdapter.java   |   642 +
 .../checkpoint/GridCheckpointManager.java       |   447 +
 .../checkpoint/GridCheckpointRequest.java       |   164 +
 .../internal/managers/checkpoint/package.html   |    24 +
 .../GridCollisionJobContextAdapter.java         |    62 +
 .../collision/GridCollisionManager.java         |   133 +
 .../internal/managers/collision/package.html    |    24 +
 .../communication/GridDisconnectListener.java   |    34 +
 .../managers/communication/GridIoManager.java   |  2084 +++
 .../managers/communication/GridIoMessage.java   |   319 +
 .../communication/GridIoMessageFactory.java     |   533 +
 .../managers/communication/GridIoPolicy.java    |    57 +
 .../communication/GridIoUserMessage.java        |   343 +
 .../communication/GridMessageListener.java      |    34 +
 .../managers/communication/package.html         |    24 +
 .../managers/deployment/GridDeployment.java     |   771 +
 .../deployment/GridDeploymentClassLoader.java   |   801 +
 .../deployment/GridDeploymentCommunication.java |   485 +
 .../managers/deployment/GridDeploymentInfo.java |    58 +
 .../deployment/GridDeploymentInfoBean.java      |   268 +
 .../deployment/GridDeploymentLocalStore.java    |   557 +
 .../deployment/GridDeploymentManager.java       |   611 +
 .../deployment/GridDeploymentMetadata.java      |   291 +
 .../GridDeploymentPerLoaderStore.java           |   515 +
 .../GridDeploymentPerVersionStore.java          |  1278 ++
 .../deployment/GridDeploymentRequest.java       |   264 +
 .../deployment/GridDeploymentResponse.java      |   186 +
 .../deployment/GridDeploymentStore.java         |    98 +
 .../deployment/GridDeploymentStoreAdapter.java  |   158 +
 .../internal/managers/deployment/package.html   |    24 +
 .../protocol/gg/GridProtocolHandler.java        |    54 +
 .../protocol/gg/GridUrlConnection.java          |    74 +
 .../deployment/protocol/gg/package.html         |    24 +
 .../discovery/GridDiscoveryManager.java         |  2130 +++
 .../GridDiscoveryTopologySnapshot.java          |    62 +
 .../managers/discovery/GridLocalMetrics.java    |   216 +
 .../internal/managers/discovery/package.html    |    24 +
 .../eventstorage/GridEventStorageManager.java   |  1152 ++
 .../eventstorage/GridEventStorageMessage.java   |   429 +
 .../eventstorage/GridLocalEventListener.java    |    39 +
 .../internal/managers/eventstorage/package.html |    24 +
 .../failover/GridFailoverContextImpl.java       |    81 +
 .../managers/failover/GridFailoverManager.java  |    66 +
 .../internal/managers/failover/package.html     |    24 +
 .../managers/indexing/GridIndexingManager.java  |   232 +
 .../internal/managers/indexing/package.html     |    24 +
 .../loadbalancer/GridLoadBalancerAdapter.java   |    50 +
 .../loadbalancer/GridLoadBalancerManager.java   |   105 +
 .../internal/managers/loadbalancer/package.html |    24 +
 .../ignite/internal/managers/package.html       |    24 +
 .../swapspace/GridSwapSpaceManager.java         |   443 +
 .../internal/managers/swapspace/package.html    |    24 +
 .../internal/mxbean/IgniteStandardMXBean.java   |   277 +
 .../apache/ignite/internal/mxbean/package.html  |    24 +
 .../org/apache/ignite/internal/package.html     |    24 +
 .../internal/processors/GridProcessor.java      |    38 +
 .../processors/GridProcessorAdapter.java        |   130 +
 .../affinity/GridAffinityAssignment.java        |   174 +
 .../affinity/GridAffinityAssignmentCache.java   |   455 +
 .../affinity/GridAffinityMessage.java           |   164 +
 .../affinity/GridAffinityProcessor.java         |   866 ++
 .../processors/affinity/GridAffinityUtils.java  |   187 +
 .../GridCacheAffinityFunctionContextImpl.java   |    83 +
 .../internal/processors/affinity/package.html   |    24 +
 ...acheAtomicUpdateTimeoutCheckedException.java |    47 +
 .../processors/cache/CacheEntryImpl.java        |    64 +
 .../processors/cache/CacheEntryImpl0.java       |    60 +
 .../internal/processors/cache/CacheFlag.java    |   110 +
 .../processors/cache/CacheFlagException.java    |    67 +
 .../processors/cache/CacheInvokeEntry.java      |   138 +
 .../processors/cache/CacheInvokeResult.java     |   102 +
 .../cache/CacheIteratorConverter.java           |    39 +
 .../processors/cache/CacheLockImpl.java         |   204 +
 .../processors/cache/CacheMetricsImpl.java      |   586 +
 .../cache/CacheMetricsMXBeanImpl.java           |   310 +
 .../processors/cache/CacheMetricsSnapshot.java  |   518 +
 .../CachePartialUpdateCheckedException.java     |    64 +
 .../processors/cache/CacheProjection.java       |  1925 +++
 .../cache/CacheStoreBalancingWrapper.java       |   297 +
 .../cache/CacheStorePartialUpdateException.java |    51 +
 .../cache/CacheVersionedEntryImpl.java          |    53 +
 .../cache/CacheWeakQueryIteratorsHolder.java    |   233 +
 .../processors/cache/EvictableEntryImpl.java    |   188 +
 .../processors/cache/GridCacheAdapter.java      |  6326 ++++++++
 .../cache/GridCacheAffinityManager.java         |   383 +
 .../processors/cache/GridCacheAtomicFuture.java |    47 +
 .../cache/GridCacheAtomicVersionComparator.java |    60 +
 .../processors/cache/GridCacheAttributes.java   |   609 +
 .../cache/GridCacheBatchSwapEntry.java          |    90 +
 .../cache/GridCacheClearAllRunnable.java        |   174 +
 .../cache/GridCacheConcurrentMap.java           |  2398 +++
 .../processors/cache/GridCacheContext.java      |  1835 +++
 .../GridCacheDefaultAffinityKeyMapper.java      |   127 +
 .../processors/cache/GridCacheDeployable.java   |    37 +
 .../cache/GridCacheDeploymentManager.java       |   977 ++
 .../processors/cache/GridCacheEntryEx.java      |  1029 ++
 .../processors/cache/GridCacheEntryInfo.java    |   344 +
 .../GridCacheEntryInfoCollectSwapListener.java  |    88 +
 .../cache/GridCacheEntryRedeployException.java  |    35 +
 .../cache/GridCacheEntryRemovedException.java   |    28 +
 .../processors/cache/GridCacheEntrySet.java     |   109 +
 .../processors/cache/GridCacheEventManager.java |   256 +
 .../cache/GridCacheEvictionManager.java         |  2050 +++
 .../cache/GridCacheEvictionRequest.java         |   226 +
 .../cache/GridCacheEvictionResponse.java        |   215 +
 .../cache/GridCacheExplicitLockSpan.java        |   279 +
 .../cache/GridCacheFilterFailedException.java   |    58 +
 .../processors/cache/GridCacheFuture.java       |    63 +
 .../processors/cache/GridCacheGateway.java      |   155 +
 .../cache/GridCacheIndexUpdateException.java    |    45 +
 .../processors/cache/GridCacheInternal.java     |    27 +
 .../processors/cache/GridCacheIoManager.java    |   780 +
 .../processors/cache/GridCacheIterator.java     |    87 +
 .../processors/cache/GridCacheKeySet.java       |   104 +
 .../cache/GridCacheLoaderWriterStore.java       |   139 +
 .../cache/GridCacheLockTimeoutException.java    |    35 +
 .../processors/cache/GridCacheLogger.java       |   188 +
 .../processors/cache/GridCacheManager.java      |    57 +
 .../cache/GridCacheManagerAdapter.java          |   166 +
 .../processors/cache/GridCacheMapAdapter.java   |   238 +
 .../processors/cache/GridCacheMapEntry.java     |  4396 ++++++
 .../cache/GridCacheMapEntryFactory.java         |    39 +
 .../processors/cache/GridCacheMessage.java      |   721 +
 .../cache/GridCacheMultiTxFuture.java           |   145 +
 .../processors/cache/GridCacheMvcc.java         |  1263 ++
 .../processors/cache/GridCacheMvccCallback.java |    53 +
 .../cache/GridCacheMvccCandidate.java           |   690 +
 .../processors/cache/GridCacheMvccFuture.java   |    30 +
 .../processors/cache/GridCacheMvccManager.java  |  1196 ++
 .../cache/GridCacheOffheapSwapEntry.java        |   194 +
 .../processors/cache/GridCacheOperation.java    |    60 +
 .../GridCachePartitionExchangeManager.java      |  1039 ++
 .../processors/cache/GridCachePeekMode.java     |    85 +
 .../processors/cache/GridCachePreloader.java    |   129 +
 .../cache/GridCachePreloaderAdapter.java        |   141 +
 .../processors/cache/GridCacheProcessor.java    |  1890 +++
 .../processors/cache/GridCacheProjectionEx.java |   461 +
 .../cache/GridCacheProjectionImpl.java          |  1476 ++
 .../processors/cache/GridCacheProxy.java        |    27 +
 .../processors/cache/GridCacheProxyImpl.java    |  2018 +++
 .../processors/cache/GridCacheReturn.java       |   227 +
 .../cache/GridCacheSharedContext.java           |   508 +
 .../cache/GridCacheSharedManager.java           |    57 +
 .../cache/GridCacheSharedManagerAdapter.java    |   166 +
 .../processors/cache/GridCacheStoreManager.java |  1175 ++
 .../processors/cache/GridCacheSwapEntry.java    |    82 +
 .../cache/GridCacheSwapEntryImpl.java           |   345 +
 .../processors/cache/GridCacheSwapListener.java |    31 +
 .../processors/cache/GridCacheSwapManager.java  |  1846 +++
 .../processors/cache/GridCacheTtlManager.java   |   219 +
 .../cache/GridCacheUpdateAtomicResult.java      |   162 +
 .../cache/GridCacheUpdateTxResult.java          |    64 +
 .../processors/cache/GridCacheUtilityKey.java   |    45 +
 .../processors/cache/GridCacheUtils.java        |  1742 +++
 .../processors/cache/GridCacheValueBytes.java   |   186 +
 .../cache/GridCacheValueCollection.java         |   162 +
 .../cache/GridCacheWriteBehindStore.java        |   987 ++
 .../processors/cache/GridPartitionLockKey.java  |   104 +
 .../cache/IgniteCacheExpiryPolicy.java          |    80 +
 .../IgniteCacheOsSerializationManager.java      |    48 +
 .../processors/cache/IgniteCacheProxy.java      |  1161 +-
 .../cache/affinity/GridCacheAffinityImpl.java   |   221 +
 .../cache/affinity/GridCacheAffinityProxy.java  |   262 +
 .../CacheDataStructuresManager.java             |   705 +
 .../distributed/GridCacheCommittedTxInfo.java   |   110 +
 .../distributed/GridCacheMappedVersion.java     |    33 +
 ...ridCacheOptimisticCheckPreparedTxFuture.java |   391 +
 ...idCacheOptimisticCheckPreparedTxRequest.java |   224 +
 ...dCacheOptimisticCheckPreparedTxResponse.java |   171 +
 .../distributed/GridCacheTtlUpdateRequest.java  |   310 +
 .../distributed/GridCacheTxFinishSync.java      |   292 +
 .../distributed/GridDistributedBaseMessage.java |   349 +
 .../GridDistributedCacheAdapter.java            |   321 +
 .../distributed/GridDistributedCacheEntry.java  |   848 +
 .../GridDistributedLockCancelledException.java  |    40 +
 .../distributed/GridDistributedLockRequest.java |   591 +
 .../GridDistributedLockResponse.java            |   365 +
 .../GridDistributedTxFinishRequest.java         |   445 +
 .../GridDistributedTxFinishResponse.java        |   146 +
 .../distributed/GridDistributedTxMapping.java   |   303 +
 .../GridDistributedTxPrepareRequest.java        |   678 +
 .../GridDistributedTxPrepareResponse.java       |   222 +
 .../GridDistributedTxRemoteAdapter.java         |   791 +
 .../GridDistributedUnlockRequest.java           |   174 +
 .../IgniteExternalizableExpiryPolicy.java       |   178 +
 .../dht/GridClientPartitionTopology.java        |   816 +
 .../dht/GridDhtAffinityAssignmentRequest.java   |   120 +
 .../dht/GridDhtAffinityAssignmentResponse.java  |   174 +
 .../dht/GridDhtAssignmentFetchFuture.java       |   184 +
 .../cache/distributed/dht/GridDhtCache.java     |    99 +
 .../distributed/dht/GridDhtCacheAdapter.java    |  1111 ++
 .../distributed/dht/GridDhtCacheEntry.java      |   740 +
 .../distributed/dht/GridDhtEmbeddedFuture.java  |    92 +
 .../distributed/dht/GridDhtFinishedFuture.java  |    66 +
 .../cache/distributed/dht/GridDhtFuture.java    |    36 +
 .../cache/distributed/dht/GridDhtGetFuture.java |   454 +
 .../dht/GridDhtInvalidPartitionException.java   |    51 +
 .../distributed/dht/GridDhtLocalPartition.java  |   596 +
 .../distributed/dht/GridDhtLockFuture.java      |  1147 ++
 .../distributed/dht/GridDhtLockRequest.java     |   508 +
 .../distributed/dht/GridDhtLockResponse.java    |   299 +
 .../distributed/dht/GridDhtPartitionState.java  |    55 +
 .../dht/GridDhtPartitionTopology.java           |   207 +
 .../dht/GridDhtPartitionTopologyImpl.java       |  1195 ++
 .../distributed/dht/GridDhtTopologyFuture.java  |    44 +
 .../dht/GridDhtTransactionalCacheAdapter.java   |  1484 ++
 .../distributed/dht/GridDhtTxFinishFuture.java  |   503 +
 .../distributed/dht/GridDhtTxFinishRequest.java |   393 +
 .../dht/GridDhtTxFinishResponse.java            |   122 +
 .../cache/distributed/dht/GridDhtTxLocal.java   |   680 +
 .../distributed/dht/GridDhtTxLocalAdapter.java  |   842 +
 .../cache/distributed/dht/GridDhtTxMapping.java |   169 +
 .../distributed/dht/GridDhtTxPrepareFuture.java |  1302 ++
 .../dht/GridDhtTxPrepareRequest.java            |   521 +
 .../dht/GridDhtTxPrepareResponse.java           |   316 +
 .../cache/distributed/dht/GridDhtTxRemote.java  |   323 +
 .../distributed/dht/GridDhtUnlockRequest.java   |   157 +
 .../distributed/dht/GridNoStorageCacheMap.java  |   109 +
 .../dht/GridPartitionedGetFuture.java           |   723 +
 .../dht/atomic/GridDhtAtomicCache.java          |  2937 ++++
 .../dht/atomic/GridDhtAtomicCacheEntry.java     |    52 +
 .../GridDhtAtomicDeferredUpdateResponse.java    |   126 +
 .../dht/atomic/GridDhtAtomicUpdateFuture.java   |   444 +
 .../dht/atomic/GridDhtAtomicUpdateRequest.java  |  1009 ++
 .../dht/atomic/GridDhtAtomicUpdateResponse.java |   278 +
 .../dht/atomic/GridNearAtomicUpdateFuture.java  |   909 ++
 .../dht/atomic/GridNearAtomicUpdateRequest.java |   862 ++
 .../atomic/GridNearAtomicUpdateResponse.java    |   616 +
 .../dht/colocated/GridDhtColocatedCache.java    |   814 +
 .../colocated/GridDhtColocatedCacheEntry.java   |    52 +
 .../colocated/GridDhtColocatedLockFuture.java   |  1294 ++
 .../colocated/GridDhtDetachedCacheEntry.java    |   106 +
 .../dht/preloader/GridDhtForceKeysFuture.java   |   567 +
 .../dht/preloader/GridDhtForceKeysRequest.java  |   262 +
 .../dht/preloader/GridDhtForceKeysResponse.java |   265 +
 .../GridDhtPartitionDemandMessage.java          |   319 +
 .../preloader/GridDhtPartitionDemandPool.java   |  1133 ++
 .../preloader/GridDhtPartitionExchangeId.java   |   228 +
 .../dht/preloader/GridDhtPartitionFullMap.java  |   238 +
 .../dht/preloader/GridDhtPartitionMap.java      |   247 +
 .../GridDhtPartitionSupplyMessage.java          |   404 +
 .../preloader/GridDhtPartitionSupplyPool.java   |   557 +
 .../GridDhtPartitionsAbstractMessage.java       |   142 +
 .../GridDhtPartitionsExchangeFuture.java        |  1110 ++
 .../preloader/GridDhtPartitionsFullMessage.java |   189 +
 .../GridDhtPartitionsSingleMessage.java         |   153 +
 .../GridDhtPartitionsSingleRequest.java         |    83 +
 .../dht/preloader/GridDhtPreloader.java         |   582 +
 .../preloader/GridDhtPreloaderAssignments.java  |    73 +
 .../distributed/near/GridNearAtomicCache.java   |   693 +
 .../distributed/near/GridNearCacheAdapter.java  |   793 +
 .../near/GridNearCacheClearAllRunnable.java     |    63 +
 .../distributed/near/GridNearCacheEntry.java    |   615 +
 .../distributed/near/GridNearGetFuture.java     |   875 ++
 .../distributed/near/GridNearGetRequest.java    |   437 +
 .../distributed/near/GridNearGetResponse.java   |   342 +
 .../distributed/near/GridNearLockFuture.java    |  1464 ++
 .../distributed/near/GridNearLockMapping.java   |   116 +
 .../distributed/near/GridNearLockRequest.java   |   535 +
 .../distributed/near/GridNearLockResponse.java  |   295 +
 .../near/GridNearTransactionalCache.java        |   702 +
 .../near/GridNearTxFinishFuture.java            |   500 +
 .../near/GridNearTxFinishRequest.java           |   281 +
 .../near/GridNearTxFinishResponse.java          |   200 +
 .../cache/distributed/near/GridNearTxLocal.java |  1291 ++
 .../near/GridNearTxPrepareFuture.java           |  1020 ++
 .../near/GridNearTxPrepareRequest.java          |   427 +
 .../near/GridNearTxPrepareResponse.java         |   439 +
 .../distributed/near/GridNearTxRemote.java      |   393 +
 .../distributed/near/GridNearUnlockRequest.java |    85 +
 .../cache/dr/GridCacheDrExpirationInfo.java     |    90 +
 .../processors/cache/dr/GridCacheDrInfo.java    |   103 +
 .../processors/cache/dr/GridCacheDrManager.java |   108 +
 .../cache/dr/os/GridOsCacheDrManager.java       |   112 +
 .../extras/GridCacheAttributesEntryExtras.java  |    84 +
 .../GridCacheAttributesMvccEntryExtras.java     |   102 +
 ...dCacheAttributesMvccObsoleteEntryExtras.java |   120 +
 ...cheAttributesMvccObsoleteTtlEntryExtras.java |   147 +
 .../GridCacheAttributesMvccTtlEntryExtras.java  |   131 +
 .../GridCacheAttributesObsoleteEntryExtras.java |   102 +
 ...idCacheAttributesObsoleteTtlEntryExtras.java |   131 +
 .../GridCacheAttributesTtlEntryExtras.java      |   113 +
 .../cache/extras/GridCacheEntryExtras.java      |    83 +
 .../extras/GridCacheEntryExtrasAdapter.java     |    52 +
 .../cache/extras/GridCacheMvccEntryExtras.java  |    83 +
 .../GridCacheMvccObsoleteEntryExtras.java       |   100 +
 .../GridCacheMvccObsoleteTtlEntryExtras.java    |   130 +
 .../extras/GridCacheMvccTtlEntryExtras.java     |   113 +
 .../extras/GridCacheObsoleteEntryExtras.java    |    83 +
 .../extras/GridCacheObsoleteTtlEntryExtras.java |   112 +
 .../cache/extras/GridCacheTtlEntryExtras.java   |    94 +
 .../cache/jta/CacheJtaManagerAdapter.java       |    50 +
 .../cache/jta/CacheNoopJtaManager.java          |    42 +
 .../processors/cache/local/GridLocalCache.java  |   225 +
 .../cache/local/GridLocalCacheEntry.java        |   384 +
 .../cache/local/GridLocalLockCallback.java      |    38 +
 .../cache/local/GridLocalLockFuture.java        |   452 +
 .../processors/cache/local/GridLocalTx.java     |   206 +
 .../cache/local/GridLocalTxFuture.java          |   351 +
 .../local/atomic/GridLocalAtomicCache.java      |  1579 ++
 .../processors/cache/query/CacheQueries.java    |   143 +
 .../processors/cache/query/CacheQuery.java      |   296 +
 .../cache/query/CacheQueryFuture.java           |    66 +
 .../processors/cache/query/CacheQueryType.java  |    47 +
 .../GridCacheDistributedFieldsQueryFuture.java  |   105 +
 .../query/GridCacheDistributedQueryFuture.java  |   259 +
 .../query/GridCacheDistributedQueryManager.java |   771 +
 .../query/GridCacheFieldsQueryErrorFuture.java  |    53 +
 .../query/GridCacheLocalFieldsQueryFuture.java  |    85 +
 .../cache/query/GridCacheLocalQueryFuture.java  |   141 +
 .../cache/query/GridCacheLocalQueryManager.java |   144 +
 .../cache/query/GridCacheQueriesEx.java         |    67 +
 .../cache/query/GridCacheQueriesImpl.java       |   260 +
 .../cache/query/GridCacheQueriesProxy.java      |   285 +
 .../cache/query/GridCacheQueryAdapter.java      |   506 +
 .../cache/query/GridCacheQueryBean.java         |    90 +
 .../cache/query/GridCacheQueryErrorFuture.java  |    51 +
 .../query/GridCacheQueryFutureAdapter.java      |   561 +
 .../cache/query/GridCacheQueryInfo.java         |   184 +
 .../cache/query/GridCacheQueryManager.java      |  2962 ++++
 .../query/GridCacheQueryMetadataAware.java      |    33 +
 .../query/GridCacheQueryMetricsAdapter.java     |   150 +
 .../cache/query/GridCacheQueryMetricsKey.java   |   117 +
 .../cache/query/GridCacheQueryRequest.java      |   755 +
 .../cache/query/GridCacheQueryResponse.java     |   330 +
 .../query/GridCacheQueryResponseEntry.java      |   114 +
 .../cache/query/GridCacheQueryType.java         |    70 +
 .../cache/query/GridCacheSqlIndexMetadata.java  |    59 +
 .../cache/query/GridCacheSqlMetadata.java       |    89 +
 .../cache/query/GridCacheSqlQuery.java          |   110 +
 .../cache/query/GridCacheSqlResult.java         |    29 +
 .../cache/query/GridCacheTwoStepQuery.java      |    85 +
 .../processors/cache/query/QueryCursorImpl.java |    87 +
 .../continuous/CacheContinuousQueryEntry.java   |   234 +
 .../continuous/CacheContinuousQueryEvent.java   |    87 +
 .../CacheContinuousQueryFilterEx.java           |    31 +
 .../continuous/CacheContinuousQueryHandler.java |   502 +
 .../CacheContinuousQueryListener.java           |    49 +
 .../continuous/CacheContinuousQueryManager.java |   745 +
 .../jdbc/GridCacheQueryJdbcMetadataTask.java    |   171 +
 .../query/jdbc/GridCacheQueryJdbcTask.java      |   356 +
 .../jdbc/GridCacheQueryJdbcValidationTask.java  |    59 +
 .../IgniteCacheSerializationManager.java        |    51 +
 .../processors/cache/store/CacheLocalStore.java |    31 +
 .../cache/transactions/IgniteInternalTx.java    |   705 +
 .../transactions/IgniteTransactionsImpl.java    |   201 +
 .../cache/transactions/IgniteTxAdapter.java     |  2074 +++
 .../cache/transactions/IgniteTxEntry.java       |  1125 ++
 .../cache/transactions/IgniteTxHandler.java     |  1128 ++
 .../cache/transactions/IgniteTxKey.java         |   108 +
 .../transactions/IgniteTxLocalAdapter.java      |  3643 +++++
 .../cache/transactions/IgniteTxLocalEx.java     |   188 +
 .../cache/transactions/IgniteTxManager.java     |  2104 +++
 .../cache/transactions/IgniteTxMap.java         |   187 +
 .../cache/transactions/IgniteTxRemoteEx.java    |    47 +
 .../transactions/TransactionMetricsAdapter.java |   119 +
 .../cache/transactions/TransactionProxy.java    |    27 +
 .../transactions/TransactionProxyImpl.java      |   345 +
 .../version/GridCachePlainVersionedEntry.java   |   131 +
 .../version/GridCacheRawVersionedEntry.java     |   237 +
 .../cache/version/GridCacheVersion.java         |   347 +
 ...ridCacheVersionAbstractConflictResolver.java |    56 +
 .../GridCacheVersionConflictContext.java        |   219 +
 .../GridCacheVersionConflictResolver.java       |    59 +
 .../cache/version/GridCacheVersionEx.java       |   104 +
 .../cache/version/GridCacheVersionManager.java  |   282 +
 .../cache/version/GridCacheVersionable.java     |    28 +
 .../cache/version/GridCacheVersionedEntry.java  |    81 +
 .../version/GridCacheVersionedEntryEx.java      |    29 +
 .../clock/GridClockDeltaSnapshot.java           |   231 +
 .../clock/GridClockDeltaSnapshotMessage.java    |   138 +
 .../processors/clock/GridClockDeltaVersion.java |   179 +
 .../processors/clock/GridClockMessage.java      |   171 +
 .../processors/clock/GridClockServer.java       |   206 +
 .../processors/clock/GridClockSource.java       |    30 +
 .../clock/GridClockSyncProcessor.java           |   458 +
 .../processors/clock/GridJvmClockSource.java    |    28 +
 .../processors/closure/GridClosurePolicy.java   |    51 +
 .../closure/GridClosureProcessor.java           |  1831 +++
 .../closure/GridPeerDeployAwareTaskAdapter.java |    60 +
 .../internal/processors/closure/package.html    |    24 +
 .../continuous/GridContinuousHandler.java       |   105 +
 .../continuous/GridContinuousMessage.java       |   229 +
 .../continuous/GridContinuousMessageType.java   |    56 +
 .../continuous/GridContinuousProcessor.java     |  1854 +++
 .../dataload/GridDataLoadCacheUpdaters.java     |   199 +
 .../dataload/GridDataLoadRequest.java           |   442 +
 .../dataload/GridDataLoadResponse.java          |   158 +
 .../dataload/GridDataLoadUpdateJob.java         |   119 +
 .../dataload/GridDataLoaderFuture.java          |    75 +
 .../dataload/GridDataLoaderProcessor.java       |   316 +
 .../dataload/IgniteDataLoaderImpl.java          |  1427 ++
 .../internal/processors/dataload/package.html   |    24 +
 .../CacheDataStructuresConfigurationKey.java    |    62 +
 .../datastructures/DataStructuresProcessor.java |  1675 ++
 .../GridAtomicCacheQueueImpl.java               |   255 +
 .../GridCacheAnnotationHelper.java              |   240 +
 .../datastructures/GridCacheAtomicLongEx.java   |    32 +
 .../datastructures/GridCacheAtomicLongImpl.java |   552 +
 .../GridCacheAtomicLongValue.java               |    84 +
 .../GridCacheAtomicReferenceEx.java             |    32 +
 .../GridCacheAtomicReferenceImpl.java           |   338 +
 .../GridCacheAtomicReferenceValue.java          |   106 +
 .../GridCacheAtomicSequenceEx.java              |    32 +
 .../GridCacheAtomicSequenceImpl.java            |   554 +
 .../GridCacheAtomicSequenceValue.java           |    84 +
 .../GridCacheAtomicStampedEx.java               |    32 +
 .../GridCacheAtomicStampedImpl.java             |   378 +
 .../GridCacheAtomicStampedValue.java            |   135 +
 .../GridCacheCountDownLatchEx.java              |    39 +
 .../GridCacheCountDownLatchImpl.java            |   393 +
 .../GridCacheCountDownLatchValue.java           |   115 +
 .../datastructures/GridCacheInternalKey.java    |    31 +
 .../GridCacheInternalKeyImpl.java               |    89 +
 .../datastructures/GridCacheQueueAdapter.java   |  1037 ++
 .../datastructures/GridCacheQueueHeader.java    |   199 +
 .../datastructures/GridCacheQueueHeaderKey.java |    88 +
 .../datastructures/GridCacheQueueItemKey.java   |   121 +
 .../datastructures/GridCacheQueueProxy.java     |   771 +
 .../datastructures/GridCacheRemovable.java      |    37 +
 .../datastructures/GridCacheSetHeader.java      |    85 +
 .../datastructures/GridCacheSetHeaderKey.java   |    88 +
 .../datastructures/GridCacheSetImpl.java        |   593 +
 .../datastructures/GridCacheSetItemKey.java     |   109 +
 .../datastructures/GridCacheSetProxy.java       |   562 +
 .../datastructures/GridSetQueryPredicate.java   |   116 +
 .../GridTransactionalCacheQueueImpl.java        |   240 +
 .../dr/GridDrDataLoadCacheUpdater.java          |    81 +
 .../internal/processors/dr/GridDrType.java      |    38 +
 .../ignite/internal/processors/dr/package.html  |    26 +
 .../internal/processors/hadoop/GridHadoop.java  |    86 +
 .../hadoop/GridHadoopConfiguration.java         |   172 +
 .../processors/hadoop/GridHadoopCounter.java    |    44 +
 .../hadoop/GridHadoopCounterWriter.java         |    36 +
 .../processors/hadoop/GridHadoopCounters.java   |    49 +
 .../processors/hadoop/GridHadoopFileBlock.java  |   162 +
 .../processors/hadoop/GridHadoopInputSplit.java |    54 +
 .../processors/hadoop/GridHadoopJob.java        |   102 +
 .../processors/hadoop/GridHadoopJobId.java      |   103 +
 .../processors/hadoop/GridHadoopJobInfo.java    |    83 +
 .../processors/hadoop/GridHadoopJobPhase.java   |    38 +
 .../hadoop/GridHadoopJobProperty.java           |   138 +
 .../processors/hadoop/GridHadoopJobStatus.java  |   207 +
 .../hadoop/GridHadoopMapReducePlan.java         |    80 +
 .../hadoop/GridHadoopMapReducePlanner.java      |    40 +
 .../hadoop/GridHadoopPartitioner.java           |    33 +
 .../hadoop/GridHadoopSerialization.java         |    54 +
 .../processors/hadoop/GridHadoopTask.java       |    72 +
 .../hadoop/GridHadoopTaskContext.java           |   189 +
 .../processors/hadoop/GridHadoopTaskInfo.java   |   153 +
 .../processors/hadoop/GridHadoopTaskInput.java  |    55 +
 .../processors/hadoop/GridHadoopTaskOutput.java |    40 +
 .../processors/hadoop/GridHadoopTaskType.java   |    56 +
 .../hadoop/IgniteHadoopNoopProcessor.java       |    74 +
 .../hadoop/IgniteHadoopProcessorAdapter.java    |    94 +
 .../internal/processors/hadoop/package.html     |    24 +
 .../processors/igfs/IgfsAckMessage.java         |   184 +
 .../internal/processors/igfs/IgfsAsyncImpl.java |   316 +
 .../processors/igfs/IgfsAttributes.java         |   186 +
 .../internal/processors/igfs/IgfsBlockKey.java  |   252 +
 .../processors/igfs/IgfsBlockLocationImpl.java  |   258 +
 .../processors/igfs/IgfsBlocksMessage.java      |   165 +
 .../processors/igfs/IgfsClientSession.java      |    75 +
 .../igfs/IgfsCommunicationMessage.java          |    71 +
 .../internal/processors/igfs/IgfsContext.java   |   205 +
 .../processors/igfs/IgfsDataManager.java        |  1907 +++
 .../processors/igfs/IgfsDeleteMessage.java      |   179 +
 .../processors/igfs/IgfsDeleteWorker.java       |   345 +
 .../igfs/IgfsDirectoryNotEmptyException.java    |    44 +
 .../ignite/internal/processors/igfs/IgfsEx.java |   143 +
 .../processors/igfs/IgfsFileAffinityRange.java  |   371 +
 .../internal/processors/igfs/IgfsFileImpl.java  |   245 +
 .../internal/processors/igfs/IgfsFileInfo.java  |   569 +
 .../internal/processors/igfs/IgfsFileMap.java   |   361 +
 .../processors/igfs/IgfsFileWorker.java         |   182 +
 .../processors/igfs/IgfsFileWorkerBatch.java    |   236 +
 .../processors/igfs/IgfsFileWorkerTask.java     |    32 +
 .../igfs/IgfsFragmentizerManager.java           |   831 +
 .../igfs/IgfsFragmentizerRequest.java           |   146 +
 .../igfs/IgfsFragmentizerResponse.java          |   108 +
 .../processors/igfs/IgfsHandshakeResponse.java  |   122 +
 .../internal/processors/igfs/IgfsHelper.java    |    49 +
 .../processors/igfs/IgfsHelperImpl.java         |    54 +
 .../internal/processors/igfs/IgfsImpl.java      |  2224 +++
 .../processors/igfs/IgfsInputStreamAdapter.java |    49 +
 .../igfs/IgfsInputStreamDescriptor.java         |    78 +
 .../processors/igfs/IgfsInputStreamImpl.java    |   533 +
 .../igfs/IgfsInvalidRangeException.java         |    43 +
 .../processors/igfs/IgfsIpcHandler.java         |   562 +
 .../internal/processors/igfs/IgfsJobImpl.java   |   117 +
 .../processors/igfs/IgfsListingEntry.java       |   197 +
 .../processors/igfs/IgfsLocalMetrics.java       |   212 +
 .../internal/processors/igfs/IgfsManager.java   |   155 +
 .../processors/igfs/IgfsMetaManager.java        |  3027 ++++
 .../processors/igfs/IgfsMetricsAdapter.java     |   239 +
 .../processors/igfs/IgfsModeResolver.java       |   177 +
 .../processors/igfs/IgfsNoopHelper.java         |    41 +
 .../processors/igfs/IgfsNoopProcessor.java      |    71 +
 .../igfs/IgfsOutputStreamAdapter.java           |   263 +
 .../processors/igfs/IgfsOutputStreamImpl.java   |   505 +
 .../internal/processors/igfs/IgfsPaths.java     |   124 +
 .../internal/processors/igfs/IgfsProcessor.java |   420 +
 .../processors/igfs/IgfsProcessorAdapter.java   |    80 +
 .../processors/igfs/IgfsSamplingKey.java        |    83 +
 .../IgfsSecondaryInputStreamDescriptor.java     |    59 +
 .../IgfsSecondaryOutputStreamDescriptor.java    |    74 +
 .../internal/processors/igfs/IgfsServer.java    |   427 +
 .../processors/igfs/IgfsServerHandler.java      |    57 +
 .../processors/igfs/IgfsServerManager.java      |   211 +
 .../internal/processors/igfs/IgfsStatus.java    |    76 +
 .../processors/igfs/IgfsSyncMessage.java        |   139 +
 .../processors/igfs/IgfsTaskArgsImpl.java       |   135 +
 .../internal/processors/igfs/IgfsThread.java    |    82 +
 .../internal/processors/igfs/package.html       |    24 +
 .../processors/job/GridJobEventListener.java    |    40 +
 .../processors/job/GridJobHoldListener.java     |    36 +
 .../processors/job/GridJobProcessor.java        |  1859 +++
 .../internal/processors/job/GridJobWorker.java  |   891 ++
 .../ignite/internal/processors/job/package.html |    24 +
 .../processors/jobmetrics/GridJobMetrics.java   |   448 +
 .../jobmetrics/GridJobMetricsProcessor.java     |   404 +
 .../jobmetrics/GridJobMetricsSnapshot.java      |   227 +
 .../internal/processors/jobmetrics/package.html |    24 +
 .../offheap/GridOffHeapProcessor.java           |   341 +
 .../ignite/internal/processors/package.html     |    24 +
 .../plugin/IgnitePluginProcessor.java           |   255 +
 .../processors/port/GridPortListener.java       |    28 +
 .../processors/port/GridPortProcessor.java      |   195 +
 .../processors/port/GridPortRecord.java         |    72 +
 .../internal/processors/port/package.html       |    24 +
 .../portable/GridPortableInputStream.java       |   184 +
 .../portable/GridPortableOutputStream.java      |   165 +
 .../portable/GridPortableProcessor.java         |   142 +
 .../processors/portable/GridPortableStream.java |    53 +
 .../portable/os/GridOsPortableProcessor.java    |   120 +
 .../processors/portable/os/package.html         |    24 +
 .../internal/processors/portable/package.html   |    24 +
 .../query/GridQueryFieldMetadata.java           |    54 +
 .../processors/query/GridQueryFieldsResult.java |    42 +
 .../query/GridQueryFieldsResultAdapter.java     |    57 +
 .../query/GridQueryIndexDescriptor.java         |    50 +
 .../processors/query/GridQueryIndexType.java    |    32 +
 .../processors/query/GridQueryIndexing.java     |   196 +
 .../processors/query/GridQueryProcessor.java    |  1831 +++
 .../query/GridQueryTypeDescriptor.java          |    86 +
 .../resource/GridResourceBasicInjector.java     |    71 +
 .../processors/resource/GridResourceField.java  |    72 +
 .../resource/GridResourceInjector.java          |    56 +
 .../processors/resource/GridResourceIoc.java    |   465 +
 .../GridResourceJobContextInjector.java         |    54 +
 .../resource/GridResourceLoggerInjector.java    |    68 +
 .../processors/resource/GridResourceMethod.java |    72 +
 .../resource/GridResourceProcessor.java         |   628 +
 .../resource/GridResourceServiceInjector.java   |    84 +
 .../processors/resource/GridResourceUtils.java  |   106 +
 .../resource/GridSpringResourceContext.java     |    48 +
 .../internal/processors/resource/package.html   |    24 +
 .../processors/rest/GridRestCommand.java        |   160 +
 .../processors/rest/GridRestProcessor.java      |   694 +
 .../processors/rest/GridRestProtocol.java       |    59 +
 .../rest/GridRestProtocolHandler.java           |    40 +
 .../processors/rest/GridRestResponse.java       |   177 +
 .../message/GridClientAbstractMessage.java      |   102 +
 .../GridClientAuthenticationRequest.java        |    66 +
 .../message/GridClientCacheQueryRequest.java    |   366 +
 .../client/message/GridClientCacheRequest.java  |   271 +
 .../message/GridClientHandshakeRequest.java     |   108 +
 .../message/GridClientHandshakeResponse.java    |    66 +
 .../rest/client/message/GridClientMessage.java  |    82 +
 .../rest/client/message/GridClientNodeBean.java |   304 +
 .../message/GridClientNodeMetricsBean.java      |  1460 ++
 .../client/message/GridClientPingPacket.java    |    39 +
 .../message/GridClientPortableMetaData.java     |    72 +
 .../rest/client/message/GridClientResponse.java |   122 +
 .../client/message/GridClientTaskRequest.java   |   124 +
 .../message/GridClientTaskResultBean.java       |   121 +
 .../message/GridClientTopologyRequest.java      |   149 +
 .../rest/client/message/GridRouterRequest.java  |    58 +
 .../rest/client/message/GridRouterResponse.java |    84 +
 .../processors/rest/client/message/package.html |    24 +
 .../rest/handlers/GridRestCommandHandler.java   |    40 +
 .../handlers/GridRestCommandHandlerAdapter.java |    51 +
 .../cache/GridCacheClientQueryResult.java       |    97 +
 .../handlers/cache/GridCacheCommandHandler.java |  1054 ++
 .../cache/GridCacheQueryCommandHandler.java     |   483 +
 .../handlers/cache/GridCacheRestMetrics.java    |   142 +
 .../handlers/cache/GridCacheRestResponse.java   |    67 +
 .../processors/rest/handlers/cache/package.html |    24 +
 .../DataStructuresCommandHandler.java           |   110 +
 .../processors/rest/handlers/package.html       |    24 +
 .../handlers/task/GridTaskCommandHandler.java   |   636 +
 .../handlers/task/GridTaskResultRequest.java    |   160 +
 .../handlers/task/GridTaskResultResponse.java   |   206 +
 .../top/GridTopologyCommandHandler.java         |   334 +
 .../processors/rest/handlers/top/package.html   |    24 +
 .../version/GridVersionCommandHandler.java      |    59 +
 .../rest/handlers/version/package.html          |    24 +
 .../internal/processors/rest/package.html       |    24 +
 .../rest/protocols/GridRestProtocolAdapter.java |   196 +
 .../processors/rest/protocols/package.html      |    24 +
 .../protocols/tcp/GridClientPacketType.java     |    35 +
 .../protocols/tcp/GridMemcachedMessage.java     |   488 +
 .../tcp/GridTcpMemcachedNioListener.java        |   440 +
 .../protocols/tcp/GridTcpRestNioListener.java   |   345 +
 .../rest/protocols/tcp/GridTcpRestParser.java   |   941 ++
 .../rest/protocols/tcp/GridTcpRestProtocol.java |   280 +
 .../processors/rest/protocols/tcp/package.html  |    24 +
 .../rest/request/DataStructuresRequest.java     |    74 +
 .../rest/request/GridRestCacheQueryRequest.java |   143 +
 .../rest/request/GridRestCacheRequest.java      |   151 +
 .../rest/request/GridRestLogRequest.java        |    81 +
 .../rest/request/GridRestRequest.java           |   167 +
 .../rest/request/GridRestTaskRequest.java       |   134 +
 .../rest/request/GridRestTopologyRequest.java   |   100 +
 .../processors/rest/request/package.html        |    24 +
 .../schedule/GridScheduleStatistics.java        |   182 +
 .../schedule/IgniteNoopScheduleProcessor.java   |    54 +
 .../IgniteScheduleProcessorAdapter.java         |    53 +
 .../internal/processors/schedule/package.html   |    24 +
 .../securesession/GridSecureSession.java        |    60 +
 .../GridSecureSessionProcessor.java             |    59 +
 .../os/GridOsSecureSessionProcessor.java        |    61 +
 .../security/GridSecurityContext.java           |   248 +
 .../security/GridSecurityProcessor.java         |    97 +
 .../security/os/GridOsSecurityProcessor.java    |   218 +
 .../segmentation/GridSegmentationProcessor.java |    51 +
 .../os/GridOsSegmentationProcessor.java         |    39 +
 .../processors/segmentation/package.html        |    24 +
 .../service/GridServiceAssignments.java         |   135 +
 .../service/GridServiceAssignmentsKey.java      |    63 +
 .../service/GridServiceDeployment.java          |    95 +
 .../service/GridServiceDeploymentFuture.java    |    56 +
 .../service/GridServiceDeploymentKey.java       |    63 +
 .../GridServiceMethodNotFoundException.java     |    43 +
 .../service/GridServiceMethodReflectKey.java    |    77 +
 .../service/GridServiceNotFoundException.java   |    40 +
 .../service/GridServiceProcessor.java           |  1256 ++
 .../processors/service/GridServiceProxy.java    |   381 +
 .../processors/service/ServiceContextImpl.java  |   156 +
 .../service/ServiceDescriptorImpl.java          |   101 +
 .../session/GridTaskSessionProcessor.java       |   178 +
 .../internal/processors/session/package.html    |    25 +
 .../spring/IgniteSpringProcessor.java           |    73 +
 .../streamer/GridStreamProcessor.java           |   354 +
 .../streamer/GridStreamerAttributes.java        |   127 +
 .../streamer/GridStreamerCancelRequest.java     |   102 +
 .../streamer/GridStreamerContextDelegate.java   |   102 +
 .../streamer/GridStreamerContextImpl.java       |   201 +
 .../streamer/GridStreamerExecutionBatch.java    |   185 +
 .../streamer/GridStreamerExecutionRequest.java  |   285 +
 .../streamer/GridStreamerResponse.java          |   136 +
 .../GridStreamerRouteFailedException.java       |    36 +
 .../GridStreamerStageExecutionFuture.java       |   363 +
 .../streamer/GridStreamerWindowIterator.java    |    40 +
 .../processors/streamer/IgniteStreamerEx.java   |    94 +
 .../processors/streamer/IgniteStreamerImpl.java |  1394 ++
 .../streamer/StreamerMBeanAdapter.java          |   116 +
 .../streamer/StreamerMetricsAdapter.java        |   272 +
 .../streamer/StreamerMetricsHolder.java         |   424 +
 .../streamer/StreamerStageMBeanAdapter.java     |   101 +
 .../streamer/StreamerStageMetricsAdapter.java   |   135 +
 .../streamer/StreamerStageMetricsHolder.java    |   167 +
 .../streamer/StreamerStageWrapper.java          |    90 +
 .../streamer/StreamerWindowMetricsAdapter.java  |    65 +
 .../streamer/StreamerWindowMetricsHolder.java   |    50 +
 .../internal/processors/streamer/package.html   |    24 +
 .../task/GridStreamerBroadcastTask.java         |   137 +
 .../streamer/task/GridStreamerQueryTask.java    |   140 +
 .../streamer/task/GridStreamerReduceTask.java   |   144 +
 .../internal/processors/task/GridInternal.java  |    35 +
 .../processors/task/GridTaskEventListener.java  |    56 +
 .../processors/task/GridTaskProcessor.java      |  1289 ++
 .../task/GridTaskThreadContextKey.java          |    38 +
 .../processors/task/GridTaskWorker.java         |  1364 ++
 .../internal/processors/task/package.html       |    24 +
 .../processors/timeout/GridTimeoutObject.java   |    40 +
 .../timeout/GridTimeoutObjectAdapter.java       |    61 +
 .../timeout/GridTimeoutProcessor.java           |   173 +
 .../internal/processors/timeout/package.html    |    24 +
 .../internal/tck/TCKMBeanServerBuilder.java     |   118 +
 .../IgniteTxHeuristicCheckedException.java      |    51 +
 .../IgniteTxOptimisticCheckedException.java     |    47 +
 .../IgniteTxRollbackCheckedException.java       |    47 +
 .../IgniteTxTimeoutCheckedException.java        |    47 +
 .../org/apache/ignite/internal/util/F0.java     |   368 +
 .../internal/util/GridAnnotationsCache.java     |    84 +
 .../ignite/internal/util/GridArgumentCheck.java |   149 +
 .../internal/util/GridAtomicInitializer.java    |   113 +
 .../ignite/internal/util/GridAtomicInteger.java |   249 +
 .../ignite/internal/util/GridAtomicLong.java    |   249 +
 .../GridBoundedConcurrentLinkedHashMap.java     |   124 +
 .../GridBoundedConcurrentLinkedHashSet.java     |   162 +
 .../util/GridBoundedConcurrentOrderedMap.java   |   252 +
 .../util/GridBoundedConcurrentOrderedSet.java   |   179 +
 .../internal/util/GridBoundedLinkedHashMap.java |   129 +
 .../internal/util/GridBoundedLinkedHashSet.java |   207 +
 .../ignite/internal/util/GridBusyLock.java      |    83 +
 .../ignite/internal/util/GridByteArrayList.java |   473 +
 .../internal/util/GridCircularBuffer.java       |   230 +
 .../internal/util/GridClassLoaderCache.java     |   131 +
 .../internal/util/GridClientByteUtils.java      |   237 +
 .../util/GridCloseableIteratorAdapter.java      |   110 +
 .../util/GridCloseableIteratorAdapterEx.java    |   127 +
 .../ignite/internal/util/GridCollections.java   |   644 +
 .../internal/util/GridConcurrentFactory.java    |   109 +
 .../internal/util/GridConcurrentHashSet.java    |   119 +
 .../util/GridConcurrentLinkedHashSet.java       |   131 +
 .../util/GridConcurrentPhantomHashSet.java      |   403 +
 .../util/GridConcurrentSkipListSet.java         |   302 +
 .../util/GridConcurrentWeakHashSet.java         |   403 +
 .../internal/util/GridConfigurationFinder.java  |   151 +
 .../internal/util/GridConsistentHash.java       |   672 +
 .../apache/ignite/internal/util/GridDebug.java  |   303 +
 .../util/GridEmptyCloseableIterator.java        |    42 +
 .../ignite/internal/util/GridEmptyIterator.java |    51 +
 .../ignite/internal/util/GridEnumCache.java     |    57 +
 .../internal/util/GridExecutionStatistics.java  |   105 +
 .../internal/util/GridFixedSizeInputStream.java |    85 +
 .../ignite/internal/util/GridHandleTable.java   |   198 +
 .../internal/util/GridIdentityHashSet.java      |    63 +
 .../ignite/internal/util/GridJavaProcess.java   |   259 +
 .../ignite/internal/util/GridKeyLock.java       |   154 +
 .../ignite/internal/util/GridLeanMap.java       |  1266 ++
 .../ignite/internal/util/GridLeanSet.java       |    83 +
 .../ignite/internal/util/GridListSet.java       |   529 +
 .../ignite/internal/util/GridLogThrottle.java   |   221 +
 .../ignite/internal/util/GridLongList.java      |   566 +
 .../apache/ignite/internal/util/GridMutex.java  |    56 +
 .../apache/ignite/internal/util/GridQueue.java  |   348 +
 .../apache/ignite/internal/util/GridRandom.java |    57 +
 .../internal/util/GridReflectionCache.java      |   250 +
 .../util/GridSerializableCollection.java        |    33 +
 .../internal/util/GridSerializableFuture.java   |    28 +
 .../internal/util/GridSerializableIterable.java |    28 +
 .../internal/util/GridSerializableIterator.java |    29 +
 .../internal/util/GridSerializableList.java     |    33 +
 .../internal/util/GridSerializableMap.java      |    37 +
 .../internal/util/GridSerializableSet.java      |    37 +
 .../ignite/internal/util/GridSetWrapper.java    |   136 +
 .../ignite/internal/util/GridSnapshotLock.java  |   219 +
 .../util/GridSpiCloseableIteratorWrapper.java   |    57 +
 .../ignite/internal/util/GridSpinBusyLock.java  |    84 +
 .../internal/util/GridSpinReadWriteLock.java    |   413 +
 .../ignite/internal/util/GridStringBuilder.java |   447 +
 .../internal/util/GridStringBuilderFactory.java |    98 +
 .../ignite/internal/util/GridStripedLock.java   |   143 +
 .../internal/util/GridStripedReadWriteLock.java |   100 +
 .../internal/util/GridSynchronizedMap.java      |   100 +
 .../ignite/internal/util/GridThreadLocal.java   |   175 +
 .../ignite/internal/util/GridThreadLocalEx.java |   210 +
 .../apache/ignite/internal/util/GridTimer.java  |   154 +
 .../ignite/internal/util/GridTimerTask.java     |    40 +
 .../apache/ignite/internal/util/GridUnsafe.java |    61 +
 .../ignite/internal/util/GridWeakIterator.java  |    55 +
 .../ignite/internal/util/IgniteUtils.java       |  9184 +++++++++++
 .../ignite/internal/util/IgniteUuidCache.java   |    59 +
 .../util/future/GridCompoundFuture.java         |   385 +
 .../util/future/GridCompoundIdentityFuture.java |    58 +
 .../util/future/GridEmbeddedFuture.java         |   321 +
 .../util/future/GridFinishedFuture.java         |   224 +
 .../util/future/GridFinishedFutureEx.java       |   197 +
 .../internal/util/future/GridFutureAdapter.java |   626 +
 .../util/future/GridFutureAdapterEx.java        |   516 +
 .../util/future/GridFutureChainListener.java    |    72 +
 .../util/future/IgniteFinishedFutureImpl.java   |    40 +
 .../util/future/IgniteFinishedFutureImplEx.java |    30 +
 .../internal/util/future/IgniteFutureImpl.java  |   221 +
 .../ignite/internal/util/future/package.html    |    24 +
 .../util/gridify/GridifyArgumentBuilder.java    |   186 +
 .../util/gridify/GridifyJobAdapter.java         |   106 +
 .../util/gridify/GridifyRangeArgument.java      |   104 +
 .../internal/util/gridify/GridifyUtils.java     |   522 +
 .../ignite/internal/util/gridify/package.html   |    24 +
 .../util/io/GridByteArrayInputStream.java       |   209 +
 .../util/io/GridByteArrayOutputStream.java      |   167 +
 .../ignite/internal/util/io/GridDataInput.java  |   132 +
 .../ignite/internal/util/io/GridDataOutput.java |   119 +
 .../internal/util/io/GridFilenameUtils.java     |  1560 ++
 .../util/io/GridReversedLinesFileReader.java    |   333 +
 .../internal/util/io/GridUnsafeDataInput.java   |   603 +
 .../internal/util/io/GridUnsafeDataOutput.java  |   500 +
 .../ignite/internal/util/ipc/IpcEndpoint.java   |    49 +
 .../util/ipc/IpcEndpointBindException.java      |    47 +
 .../internal/util/ipc/IpcEndpointFactory.java   |    84 +
 .../internal/util/ipc/IpcEndpointType.java      |    29 +
 .../internal/util/ipc/IpcServerEndpoint.java    |    73 +
 .../util/ipc/IpcServerEndpointDeserializer.java |    66 +
 .../internal/util/ipc/IpcToNioAdapter.java      |   247 +
 .../util/ipc/loopback/IpcClientTcpEndpoint.java |    87 +
 .../util/ipc/loopback/IpcServerTcpEndpoint.java |   179 +
 .../internal/util/ipc/loopback/package.html     |    24 +
 .../ignite/internal/util/ipc/package.html       |    24 +
 .../shmem/IpcOutOfSystemResourcesException.java |    59 +
 .../shmem/IpcSharedMemoryClientEndpoint.java    |   336 +
 .../ipc/shmem/IpcSharedMemoryInitRequest.java   |    67 +
 .../ipc/shmem/IpcSharedMemoryInitResponse.java  |   171 +
 .../ipc/shmem/IpcSharedMemoryInputStream.java   |    99 +
 .../ipc/shmem/IpcSharedMemoryNativeLoader.java  |   262 +
 ...cSharedMemoryOperationTimedoutException.java |    59 +
 .../ipc/shmem/IpcSharedMemoryOutputStream.java  |    80 +
 .../shmem/IpcSharedMemoryServerEndpoint.java    |   705 +
 .../util/ipc/shmem/IpcSharedMemorySpace.java    |   374 +
 .../util/ipc/shmem/IpcSharedMemoryUtils.java    |   242 +
 .../ignite/internal/util/ipc/shmem/package.html |    24 +
 .../internal/util/lang/GridAbsClosure.java      |    54 +
 .../internal/util/lang/GridAbsClosureX.java     |    48 +
 .../internal/util/lang/GridAbsPredicate.java    |    44 +
 .../internal/util/lang/GridAbsPredicateX.java   |    46 +
 .../util/lang/GridCloseableIterator.java        |    62 +
 .../ignite/internal/util/lang/GridClosure3.java |    52 +
 .../internal/util/lang/GridClosure3X.java       |    51 +
 .../util/lang/GridClosureException.java         |    50 +
 .../util/lang/GridComputeJobWrapper.java        |    96 +
 .../util/lang/GridFilteredIterator.java         |    87 +
 .../ignite/internal/util/lang/GridFunc.java     |  8628 +++++++++++
 .../internal/util/lang/GridInClosure3.java      |    49 +
 .../internal/util/lang/GridInClosure3X.java     |    50 +
 .../ignite/internal/util/lang/GridIterable.java |    35 +
 .../internal/util/lang/GridIterableAdapter.java |   120 +
 .../ignite/internal/util/lang/GridIterator.java |    67 +
 .../internal/util/lang/GridIteratorAdapter.java |    66 +
 .../ignite/internal/util/lang/GridMapEntry.java |    92 +
 .../util/lang/GridMetadataAwareAdapter.java     |   435 +
 .../internal/util/lang/GridNodePredicate.java   |   157 +
 .../internal/util/lang/GridPeerDeployAware.java |    52 +
 .../util/lang/GridPeerDeployAwareAdapter.java   |    69 +
 .../internal/util/lang/GridPlainAbsClosure.java |    33 +
 .../internal/util/lang/GridPlainCallable.java   |    27 +
 .../internal/util/lang/GridPlainClosure.java    |    32 +
 .../internal/util/lang/GridPlainClosure2.java   |    33 +
 .../internal/util/lang/GridPlainFuture.java     |    79 +
 .../util/lang/GridPlainFutureAdapter.java       |   299 +
 .../internal/util/lang/GridPlainInClosure.java  |    31 +
 .../internal/util/lang/GridPlainOutClosure.java |    31 +
 .../internal/util/lang/GridPlainRunnable.java   |    25 +
 .../internal/util/lang/GridPredicate3.java      |    57 +
 .../internal/util/lang/GridPredicate3X.java     |    51 +
 .../ignite/internal/util/lang/GridTriple.java   |    54 +
 .../ignite/internal/util/lang/GridTuple.java    |   147 +
 .../ignite/internal/util/lang/GridTuple3.java   |   226 +
 .../ignite/internal/util/lang/GridTuple4.java   |   257 +
 .../ignite/internal/util/lang/GridTuple5.java   |   288 +
 .../ignite/internal/util/lang/GridTuple6.java   |   322 +
 .../ignite/internal/util/lang/GridTupleV.java   |   188 +
 .../internal/util/lang/IgniteClosure2X.java     |    53 +
 .../internal/util/lang/IgniteClosureX.java      |    52 +
 .../internal/util/lang/IgniteInClosure2X.java   |    52 +
 .../internal/util/lang/IgniteInClosureX.java    |    51 +
 .../internal/util/lang/IgniteOutClosureX.java   |    50 +
 .../ignite/internal/util/lang/IgnitePair.java   |    54 +
 .../internal/util/lang/IgnitePredicate2X.java   |    53 +
 .../internal/util/lang/IgnitePredicateX.java    |    52 +
 .../internal/util/lang/IgniteReducer2.java      |    53 +
 .../internal/util/lang/IgniteReducer2X.java     |    50 +
 .../internal/util/lang/IgniteReducer3.java      |    55 +
 .../internal/util/lang/IgniteReducer3X.java     |    50 +
 .../internal/util/lang/IgniteReducerX.java      |    51 +
 .../nio/GridAbstractCommunicationClient.java    |   112 +
 .../internal/util/nio/GridBufferedParser.java   |    96 +
 .../util/nio/GridCommunicationClient.java       |   112 +
 .../nio/GridConnectionBytesVerifyFilter.java    |   139 +
 .../internal/util/nio/GridDirectParser.java     |    72 +
 .../util/nio/GridNioAsyncNotifyFilter.java      |   141 +
 .../util/nio/GridNioBackPressureControl.java    |    56 +
 .../internal/util/nio/GridNioCodecFilter.java   |   139 +
 .../util/nio/GridNioEmbeddedFuture.java         |    72 +
 .../internal/util/nio/GridNioException.java     |    58 +
 .../ignite/internal/util/nio/GridNioFilter.java |   244 +
 .../internal/util/nio/GridNioFilterAdapter.java |   183 +
 .../internal/util/nio/GridNioFilterChain.java   |   292 +
 .../util/nio/GridNioFinishedFuture.java         |   116 +
 .../ignite/internal/util/nio/GridNioFuture.java |   120 +
 .../internal/util/nio/GridNioFutureImpl.java    |   327 +
 .../internal/util/nio/GridNioMessageReader.java |    42 +
 .../util/nio/GridNioMessageTracker.java         |   121 +
 .../internal/util/nio/GridNioMessageWriter.java |    49 +
 .../util/nio/GridNioMetricsListener.java        |    33 +
 .../ignite/internal/util/nio/GridNioParser.java |    62 +
 .../util/nio/GridNioRecoveryDescriptor.java     |   364 +
 .../ignite/internal/util/nio/GridNioServer.java |  2320 +++
 .../internal/util/nio/GridNioServerBuffer.java  |   117 +
 .../util/nio/GridNioServerListener.java         |    64 +
 .../util/nio/GridNioServerListenerAdapter.java  |    33 +
 .../internal/util/nio/GridNioSession.java       |   168 +
 .../internal/util/nio/GridNioSessionImpl.java   |   312 +
 .../util/nio/GridNioSessionMetaKey.java         |    69 +
 .../util/nio/GridSelectorNioSessionImpl.java    |   297 +
 .../util/nio/GridShmemCommunicationClient.java  |   146 +
 .../util/nio/GridTcpCommunicationClient.java    |   554 +
 .../util/nio/GridTcpNioCommunicationClient.java |   163 +
 .../ignite/internal/util/nio/package.html       |    24 +
 .../internal/util/nio/ssl/GridNioSslFilter.java |   418 +
 .../util/nio/ssl/GridNioSslHandler.java         |   615 +
 .../ignite/internal/util/nio/ssl/package.html   |    24 +
 .../util/nodestart/IgniteNodeCallable.java      |    30 +
 .../util/nodestart/IgniteNodeStartUtils.java    |   391 +
 .../IgniteRemoteStartSpecification.java         |   279 +
 .../util/nodestart/IgniteSshProcessor.java      |    34 +
 .../internal/util/offheap/GridOffHeapEvent.java |    47 +
 .../util/offheap/GridOffHeapEventListener.java  |    26 +
 .../util/offheap/GridOffHeapEvictListener.java  |    33 +
 .../internal/util/offheap/GridOffHeapMap.java   |   207 +
 .../util/offheap/GridOffHeapMapFactory.java     |   225 +
 .../GridOffHeapOutOfMemoryException.java        |    50 +
 .../util/offheap/GridOffHeapPartitionedMap.java |   229 +
 .../offheap/unsafe/GridOffHeapSmartPointer.java |    38 +
 .../unsafe/GridOffHeapSmartPointerFactory.java  |    29 +
 .../offheap/unsafe/GridOffHeapSnapTreeMap.java  |  4457 ++++++
 .../unsafe/GridUnsafeCompoundMemory.java        |    35 +
 .../util/offheap/unsafe/GridUnsafeGuard.java    |   374 +
 .../util/offheap/unsafe/GridUnsafeLru.java      |   627 +
 .../offheap/unsafe/GridUnsafeLruPoller.java     |    30 +
 .../util/offheap/unsafe/GridUnsafeMap.java      |  1753 +++
 .../util/offheap/unsafe/GridUnsafeMemory.java   |   721 +
 .../unsafe/GridUnsafePartitionedMap.java        |   433 +
 .../apache/ignite/internal/util/package.html    |    24 +
 .../util/portscanner/GridJmxPortFinder.java     |   176 +
 .../internal/util/portscanner/package.html      |    24 +
 .../apache/ignite/internal/util/scala/impl.java |    35 +
 .../ignite/internal/util/scala/package.html     |    24 +
 .../util/snaptree/CopyOnWriteManager.java       |   390 +
 .../ignite/internal/util/snaptree/Epoch.java    |   131 +
 .../internal/util/snaptree/EpochNode.java       |   432 +
 .../internal/util/snaptree/SnapTreeMap.java     |  2897 ++++
 .../ignite/internal/util/snaptree/package.html  |    24 +
 .../internal/util/test/GridTestPrintStream.java |   293 +
 .../util/test/GridTestPrintStreamFactory.java   |   128 +
 .../ignite/internal/util/test/package.html      |    24 +
 .../util/tostring/GridToStringBuilder.java      |   588 +
 .../tostring/GridToStringClassDescriptor.java   |    85 +
 .../util/tostring/GridToStringExclude.java      |    32 +
 .../tostring/GridToStringFieldDescriptor.java   |    53 +
 .../util/tostring/GridToStringInclude.java      |    32 +
 .../util/tostring/GridToStringOrder.java        |    37 +
 .../util/tostring/GridToStringThreadLocal.java  |    55 +
 .../ignite/internal/util/tostring/package.html  |    24 +
 .../apache/ignite/internal/util/typedef/C1.java |    32 +
 .../apache/ignite/internal/util/typedef/C2.java |    33 +
 .../apache/ignite/internal/util/typedef/C3.java |    35 +
 .../apache/ignite/internal/util/typedef/CA.java |    33 +
 .../ignite/internal/util/typedef/CAX.java       |    32 +
 .../ignite/internal/util/typedef/CI1.java       |    31 +
 .../ignite/internal/util/typedef/CI2.java       |    32 +
 .../ignite/internal/util/typedef/CI3.java       |    32 +
 .../ignite/internal/util/typedef/CIX1.java      |    33 +
 .../ignite/internal/util/typedef/CIX2.java      |    32 +
 .../ignite/internal/util/typedef/CIX3.java      |    29 +
 .../apache/ignite/internal/util/typedef/CO.java |    31 +
 .../ignite/internal/util/typedef/COX.java       |    33 +
 .../ignite/internal/util/typedef/CX1.java       |    34 +
 .../ignite/internal/util/typedef/CX2.java       |    35 +
 .../ignite/internal/util/typedef/CX3.java       |    33 +
 .../apache/ignite/internal/util/typedef/F.java  |    29 +
 .../apache/ignite/internal/util/typedef/G.java  |    29 +
 .../apache/ignite/internal/util/typedef/P1.java |    31 +
 .../apache/ignite/internal/util/typedef/P2.java |    32 +
 .../apache/ignite/internal/util/typedef/P3.java |    32 +
 .../apache/ignite/internal/util/typedef/PA.java |    29 +
 .../ignite/internal/util/typedef/PAX.java       |    29 +
 .../ignite/internal/util/typedef/PCE.java       |    34 +
 .../apache/ignite/internal/util/typedef/PE.java |    33 +
 .../ignite/internal/util/typedef/PKV.java       |    31 +
 .../apache/ignite/internal/util/typedef/PN.java |    33 +
 .../ignite/internal/util/typedef/PX1.java       |    33 +
 .../ignite/internal/util/typedef/PX2.java       |    34 +
 .../ignite/internal/util/typedef/PX3.java       |    32 +
 .../apache/ignite/internal/util/typedef/R1.java |    32 +
 .../apache/ignite/internal/util/typedef/R2.java |    31 +
 .../apache/ignite/internal/util/typedef/R3.java |    31 +
 .../ignite/internal/util/typedef/RX1.java       |    34 +
 .../ignite/internal/util/typedef/RX2.java       |    34 +
 .../ignite/internal/util/typedef/RX3.java       |    34 +
 .../apache/ignite/internal/util/typedef/T1.java |    51 +
 .../apache/ignite/internal/util/typedef/T2.java |    52 +
 .../apache/ignite/internal/util/typedef/T3.java |    52 +
 .../apache/ignite/internal/util/typedef/T4.java |    53 +
 .../apache/ignite/internal/util/typedef/T5.java |    54 +
 .../apache/ignite/internal/util/typedef/T6.java |    55 +
 .../apache/ignite/internal/util/typedef/X.java  |   881 ++
 .../internal/util/typedef/internal/A.java       |    28 +
 .../internal/util/typedef/internal/CU.java      |    30 +
 .../internal/util/typedef/internal/D.java       |    28 +
 .../internal/util/typedef/internal/GPC.java     |    27 +
 .../internal/util/typedef/internal/GPR.java     |    27 +
 .../internal/util/typedef/internal/LT.java      |    28 +
 .../internal/util/typedef/internal/S.java       |    28 +
 .../internal/util/typedef/internal/SB.java      |    63 +
 .../internal/util/typedef/internal/U.java       |    28 +
 .../internal/util/typedef/internal/package.html |    24 +
 .../ignite/internal/util/typedef/package.html   |    24 +
 .../ignite/internal/util/worker/GridWorker.java |   305 +
 .../internal/util/worker/GridWorkerFuture.java  |    70 +
 .../util/worker/GridWorkerListener.java         |    35 +
 .../util/worker/GridWorkerListenerAdapter.java  |    33 +
 .../internal/util/worker/GridWorkerPool.java    |   116 +
 .../ignite/internal/util/worker/package.html    |    24 +
 .../apache/ignite/internal/visor/VisorJob.java  |    79 +
 .../internal/visor/VisorMultiNodeTask.java      |   125 +
 .../ignite/internal/visor/VisorOneNodeTask.java |    41 +
 .../internal/visor/VisorTaskArgument.java       |   106 +
 .../ignite/internal/visor/cache/VisorCache.java |   485 +
 .../cache/VisorCacheAffinityConfiguration.java  |   171 +
 .../cache/VisorCacheAggregatedMetrics.java      |   437 +
 .../visor/cache/VisorCacheClearTask.java        |   175 +
 .../visor/cache/VisorCacheCompactTask.java      |    91 +
 .../visor/cache/VisorCacheConfiguration.java    |   737 +
 .../cache/VisorCacheDefaultConfiguration.java   |   158 +
 .../cache/VisorCacheEvictionConfiguration.java  |   215 +
 .../visor/cache/VisorCacheLoadTask.java         |    93 +
 .../visor/cache/VisorCacheMetadataTask.java     |    81 +
 .../internal/visor/cache/VisorCacheMetrics.java |   484 +
 .../cache/VisorCacheMetricsCollectorTask.java   |   112 +
 .../cache/VisorCacheNearConfiguration.java      |   123 +
 .../cache/VisorCachePreloadConfiguration.java   |   156 +
 .../visor/cache/VisorCachePreloadTask.java      |    82 +
 .../visor/cache/VisorCacheQueryMetrics.java     |   102 +
 .../visor/cache/VisorCacheResetMetricsTask.java |    68 +
 .../cache/VisorCacheStoreConfiguration.java     |    93 +
 .../visor/cache/VisorCacheSwapBackupsTask.java  |   100 +
 .../cache/VisorCacheTypeFieldMetadata.java      |   115 +
 .../visor/cache/VisorCacheTypeMetadata.java     |   320 +
 .../VisorCacheWriteBehindConfiguration.java     |   137 +
 .../compute/VisorComputeCancelSessionsTask.java |    89 +
 .../compute/VisorComputeMonitoringHolder.java   |   121 +
 .../compute/VisorComputeResetMetricsTask.java   |    64 +
 .../VisorComputeToggleMonitoringTask.java       |   111 +
 .../visor/debug/VisorThreadDumpTask.java        |    74 +
 .../internal/visor/debug/VisorThreadInfo.java   |   329 +
 .../visor/debug/VisorThreadLockInfo.java        |    73 +
 .../visor/debug/VisorThreadMonitorInfo.java     |    72 +
 .../event/VisorGridAuthenticationEvent.java     |   106 +
 .../event/VisorGridAuthorizationEvent.java      |    89 +
 .../visor/event/VisorGridDeploymentEvent.java   |    74 +
 .../visor/event/VisorGridDiscoveryEvent.java    |   100 +
 .../internal/visor/event/VisorGridEvent.java    |   130 +
 .../visor/event/VisorGridEventsLost.java        |    45 +
 .../internal/visor/event/VisorGridJobEvent.java |   113 +
 .../event/VisorGridSecuritySessionEvent.java    |    91 +
 .../visor/event/VisorGridTaskEvent.java         |   113 +
 .../internal/visor/file/VisorFileBlock.java     |   114 +
 .../internal/visor/file/VisorFileBlockTask.java |   125 +
 .../visor/file/VisorLatestTextFilesTask.java    |    97 +
 .../ignite/internal/visor/igfs/VisorIgfs.java   |   112 +
 .../internal/visor/igfs/VisorIgfsEndpoint.java  |   106 +
 .../visor/igfs/VisorIgfsFormatTask.java         |    70 +
 .../internal/visor/igfs/VisorIgfsMetrics.java   |   350 +
 .../internal/visor/igfs/VisorIgfsProfiler.java  |    88 +
 .../visor/igfs/VisorIgfsProfilerClearTask.java  |   114 +
 .../visor/igfs/VisorIgfsProfilerEntry.java      |   238 +
 .../visor/igfs/VisorIgfsProfilerTask.java       |   519 +
 .../VisorIgfsProfilerUniformityCounters.java    |   204 +
 .../visor/igfs/VisorIgfsResetMetricsTask.java   |    73 +
 .../visor/igfs/VisorIgfsSamplingStateTask.java  |    77 +
 .../ignite/internal/visor/log/VisorLogFile.java |    87 +
 .../visor/log/VisorLogSearchResult.java         |   156 +
 .../internal/visor/log/VisorLogSearchTask.java  |   271 +
 .../internal/visor/misc/VisorAckTask.java       |    75 +
 .../visor/misc/VisorLatestVersionTask.java      |    62 +
 .../internal/visor/misc/VisorNopTask.java       |    92 +
 .../visor/misc/VisorResolveHostNameTask.java    |   104 +
 .../visor/node/VisorAtomicConfiguration.java    |   104 +
 .../visor/node/VisorBasicConfiguration.java     |   432 +
 .../node/VisorExecutorServiceConfiguration.java |   160 +
 .../visor/node/VisorGridConfiguration.java      |   380 +
 .../visor/node/VisorIgfsConfiguration.java      |   574 +
 .../visor/node/VisorLifecycleConfiguration.java |    68 +
 .../visor/node/VisorMetricsConfiguration.java   |    95 +
 .../VisorNodeConfigurationCollectorJob.java     |    47 +
 .../VisorNodeConfigurationCollectorTask.java    |    35 +
 .../visor/node/VisorNodeDataCollectorJob.java   |   225 +
 .../node/VisorNodeDataCollectorJobResult.java   |   203 +
 .../visor/node/VisorNodeDataCollectorTask.java  |   139 +
 .../node/VisorNodeDataCollectorTaskArg.java     |   143 +
 .../node/VisorNodeDataCollectorTaskResult.java  |   184 +
 .../node/VisorNodeEventsCollectorTask.java      |   339 +
 .../internal/visor/node/VisorNodeGcTask.java    |    98 +
 .../internal/visor/node/VisorNodePingTask.java  |    80 +
 .../visor/node/VisorNodeRestartTask.java        |    78 +
 .../internal/visor/node/VisorNodeStopTask.java  |    78 +
 .../node/VisorPeerToPeerConfiguration.java      |   105 +
 .../visor/node/VisorRestConfiguration.java      |   220 +
 .../node/VisorSegmentationConfiguration.java    |   141 +
 .../visor/node/VisorSpisConfiguration.java      |   337 +
 .../node/VisorTransactionConfiguration.java     |   158 +
 .../visor/query/VisorQueryCleanupTask.java      |   101 +
 .../internal/visor/query/VisorQueryField.java   |    66 +
 .../visor/query/VisorQueryNextPageTask.java     |   122 +
 .../internal/visor/query/VisorQueryResult.java  |    79 +
 .../visor/query/VisorQueryResultEx.java         |    88 +
 .../internal/visor/query/VisorQueryTask.java    |   308 +
 .../internal/visor/query/VisorQueryUtils.java   |   204 +
 .../internal/visor/streamer/VisorStreamer.java  |   104 +
 .../streamer/VisorStreamerConfiguration.java    |   177 +
 .../visor/streamer/VisorStreamerMetrics.java    |   350 +
 .../streamer/VisorStreamerMetricsResetTask.java |    75 +
 .../visor/streamer/VisorStreamerResetTask.java  |    75 +
 .../streamer/VisorStreamerStageMetrics.java     |   277 +
 .../internal/visor/util/VisorMimeTypes.java     |  1019 ++
 .../internal/visor/util/VisorTaskUtils.java     |   808 +
 .../apache/ignite/lang/IgniteAsyncSupport.java  |     4 +-
 .../ignite/lang/IgniteAsyncSupportAdapter.java  |    84 -
 .../ignite/lang/IgniteAsyncSupported.java       |     2 +-
 .../org/apache/ignite/lang/IgniteBiTuple.java   |    10 +-
 .../org/apache/ignite/lang/IgniteClosure.java   |     2 +-
 .../org/apache/ignite/lang/IgniteFuture.java    |    71 +-
 .../lang/IgniteFutureCancelledException.java    |     2 +-
 .../lang/IgniteFutureTimeoutException.java      |     2 +-
 .../ignite/lang/IgniteNotPeerDeployable.java    |    41 +
 .../org/apache/ignite/lang/IgnitePredicate.java |     6 +-
 .../ignite/lang/IgniteProductVersion.java       |   291 +
 .../org/apache/ignite/lang/IgniteRunnable.java  |     2 +-
 .../java/org/apache/ignite/lang/IgniteUuid.java |     8 +-
 .../java/org/apache/ignite/lang/package.html    |     3 +-
 .../apache/ignite/lifecycle/IgniteListener.java |    37 -
 .../apache/ignite/lifecycle/LifecycleAware.java |    10 +-
 .../apache/ignite/lifecycle/LifecycleBean.java  |    31 +-
 .../ignite/logger/IgniteLoggerNodeIdAware.java  |    39 -
 .../apache/ignite/logger/IgniteNullLogger.java  |    91 -
 .../apache/ignite/logger/LoggerNodeIdAware.java |    39 +
 .../org/apache/ignite/logger/NullLogger.java    |    91 +
 .../ignite/logger/java/IgniteJavaLogger.java    |   390 -
 .../java/IgniteJavaLoggerFileHandler.java       |   190 -
 .../logger/java/IgniteJavaLoggerFormatter.java  |    79 -
 .../apache/ignite/logger/java/JavaLogger.java   |   385 +
 .../logger/java/JavaLoggerFileHandler.java      |   190 +
 .../ignite/logger/java/JavaLoggerFormatter.java |    79 +
 .../org/apache/ignite/logger/java/package.html  |     3 +-
 .../java/org/apache/ignite/logger/package.html  |     3 +-
 .../apache/ignite/managed/ManagedService.java   |   123 -
 .../managed/ManagedServiceConfiguration.java    |   305 -
 .../ignite/managed/ManagedServiceContext.java   |    68 -
 .../managed/ManagedServiceDescriptor.java       |    90 -
 .../java/org/apache/ignite/managed/package.html |    23 -
 .../ignite/marshaller/AbstractMarshaller.java   |    65 +
 .../marshaller/IgniteAbstractMarshaller.java    |    65 -
 .../ignite/marshaller/IgniteMarshaller.java     |   136 -
 .../marshaller/IgniteMarshallerExclusions.java  |   153 -
 .../apache/ignite/marshaller/Marshaller.java    |   109 +
 .../ignite/marshaller/MarshallerExclusions.java |   153 +
 .../marshaller/jdk/IgniteJdkMarshaller.java     |   142 -
 .../IgniteJdkMarshallerDummySerializable.java   |    30 -
 .../IgniteJdkMarshallerInputStreamWrapper.java  |    81 -
 .../IgniteJdkMarshallerObjectInputStream.java   |    61 -
 .../IgniteJdkMarshallerObjectOutputStream.java  |    45 -
 .../IgniteJdkMarshallerOutputStreamWrapper.java |    59 -
 .../ignite/marshaller/jdk/JdkMarshaller.java    |   117 +
 .../jdk/JdkMarshallerDummySerializable.java     |    30 +
 .../jdk/JdkMarshallerInputStreamWrapper.java    |    81 +
 .../jdk/JdkMarshallerObjectInputStream.java     |    61 +
 .../jdk/JdkMarshallerObjectOutputStream.java    |    45 +
 .../jdk/JdkMarshallerOutputStreamWrapper.java   |    59 +
 .../apache/ignite/marshaller/jdk/package.html   |     2 +-
 .../IgniteOptimizedClassDescriptor.java         |  1040 --
 .../optimized/IgniteOptimizedClassResolver.java |   477 -
 .../optimized/IgniteOptimizedFieldType.java     |    50 -
 .../optimized/IgniteOptimizedMarshallable.java  |    65 -
 .../optimized/IgniteOptimizedMarshaller.java    |   416 -
 .../IgniteOptimizedMarshallerUtils.java         |   458 -
 .../IgniteOptimizedObjectInputStream.java       |  1016 --
 .../IgniteOptimizedObjectOutputStream.java      |   839 -
 .../IgniteOptimizedObjectStreamRegistry.java    |   224 -
 .../optimized/OptimizedClassDescriptor.java     |  1040 ++
 .../optimized/OptimizedClassResolver.java       |   477 +
 .../optimized/OptimizedFieldType.java           |    50 +
 .../optimized/OptimizedMarshallable.java        |    65 +
 .../optimized/OptimizedMarshaller.java          |   393 +
 .../optimized/OptimizedMarshallerUtils.java     |   458 +
 .../optimized/OptimizedObjectInputStream.java   |  1018 ++
 .../optimized/OptimizedObjectOutputStream.java  |   839 +
 .../OptimizedObjectStreamRegistry.java          |   224 +
 .../optimized-classnames.previous.properties    |    17 -
 .../optimized/optimized-classnames.properties   |  1669 +-
 .../ignite/marshaller/optimized/package.html    |     2 +-
 .../org/apache/ignite/marshaller/package.html   |     3 +-
 .../org/apache/ignite/mbean/IgniteMBean.java    |   386 -
 .../ignite/mbean/IgniteMBeanDescription.java    |    34 -
 .../IgniteMBeanParametersDescriptions.java      |    34 -
 .../mbean/IgniteMBeanParametersNames.java       |    34 -
 .../ignite/mbean/IgniteStandardMBean.java       |   275 -
 .../ignite/mbean/IgniteThreadPoolMBean.java     |   152 -
 .../org/apache/ignite/mbean/IgnitionMBean.java  |   151 -
 .../java/org/apache/ignite/mbean/package.html   |    23 -
 .../ignite/messaging/MessagingListenActor.java  |    25 +-
 .../org/apache/ignite/messaging/package.html    |     2 +-
 .../ignite/mxbean/CacheMetricsMXBean.java       |   245 +
 .../mxbean/ClusterLocalNodeMetricsMXBean.java   |   249 +
 .../org/apache/ignite/mxbean/IgniteMXBean.java  |   362 +
 .../apache/ignite/mxbean/IgnitionMXBean.java    |   151 +
 .../apache/ignite/mxbean/MXBeanDescription.java |    34 +
 .../mxbean/MXBeanParametersDescriptions.java    |    34 +
 .../ignite/mxbean/MXBeanParametersNames.java    |    34 +
 .../apache/ignite/mxbean/ThreadPoolMXBean.java  |   152 +
 .../java/org/apache/ignite/mxbean/package.html  |    24 +
 .../main/java/org/apache/ignite/package.html    |    24 +
 .../org/apache/ignite/plugin/Extension.java     |    25 +
 .../apache/ignite/plugin/ExtensionRegistry.java |    32 +
 .../apache/ignite/plugin/IgniteExtension.java   |    25 -
 .../ignite/plugin/IgniteExtensionRegistry.java  |    32 -
 .../org/apache/ignite/plugin/PluginContext.java |     7 -
 .../apache/ignite/plugin/PluginProvider.java    |     6 +-
 .../plugin/PluginValidationException.java       |     1 -
 .../communication/MessageAdapter.java           |   143 +
 .../communication/MessageCallback.java          |    48 -
 .../communication/MessageFactory.java           |    41 +
 .../communication/MessageFormatter.java         |    46 +
 .../extensions/communication/MessageReader.java |   245 +
 .../extensions/communication/MessageWriter.java |   297 +
 .../extensions/communication/package.html       |    24 +
 .../extensions/discovery/DiscoveryCallback.java |    51 -
 .../plugin/security/AuthenticationContext.java  |   110 +
 .../ignite/plugin/security/GridSecurity.java    |    97 -
 .../security/GridSecurityCredentials.java       |    31 +-
 .../GridSecurityCredentialsProvider.java        |     7 +-
 .../plugin/security/GridSecuritySubject.java    |     1 -
 .../apache/ignite/plugin/security/package.html  |     3 +-
 .../segmentation/GridSegmentationPolicy.java    |    11 +-
 .../segmentation/GridSegmentationResolver.java  |     2 +-
 .../ignite/plugin/segmentation/package.html     |     2 +-
 .../ignite/portables/PortableBuilder.java       |   137 -
 .../ignite/portables/PortableConfiguration.java |   189 -
 .../ignite/portables/PortableException.java     |    57 -
 .../ignite/portables/PortableIdMapper.java      |    55 -
 .../PortableInvalidClassException.java          |    58 -
 .../ignite/portables/PortableMarshalAware.java  |    48 -
 .../ignite/portables/PortableMetadata.java      |    61 -
 .../apache/ignite/portables/PortableObject.java |   174 -
 .../ignite/portables/PortableRawReader.java     |   235 -
 .../ignite/portables/PortableRawWriter.java     |   218 -
 .../apache/ignite/portables/PortableReader.java |   286 -
 .../ignite/portables/PortableSerializer.java    |    47 -
 .../portables/PortableTypeConfiguration.java    |   195 -
 .../apache/ignite/portables/PortableWriter.java |   265 -
 .../org/apache/ignite/portables/package.html    |    23 -
 .../apache/ignite/product/IgniteProduct.java    |    66 -
 .../ignite/product/IgniteProductLicense.java    |   183 -
 .../product/IgniteProductLicenseException.java  |    70 -
 .../ignite/product/IgniteProductVersion.java    |   291 -
 .../java/org/apache/ignite/product/package.html |    23 -
 .../ignite/resources/CacheNameResource.java     |    59 +
 .../resources/CacheStoreSessionResource.java    |    41 +
 .../IgniteAddressResolverResource.java          |    58 -
 .../resources/IgniteCacheNameResource.java      |    60 -
 .../IgniteExecutorServiceResource.java          |    66 -
 .../ignite/resources/IgniteHomeResource.java    |    65 -
 .../resources/IgniteInstanceResource.java       |    17 +-
 .../resources/IgniteJobContextResource.java     |    59 -
 .../resources/IgniteLoadBalancerResource.java   |    61 -
 .../resources/IgniteLocalHostResource.java      |    66 -
 .../resources/IgniteLocalNodeIdResource.java    |    66 -
 .../ignite/resources/IgniteLoggerResource.java  |    86 -
 .../resources/IgniteMBeanServerResource.java    |    66 -
 .../resources/IgniteMarshallerResource.java     |    65 -
 .../ignite/resources/IgniteNameResource.java    |    65 -
 .../ignite/resources/IgniteServiceResource.java |    87 -
 .../IgniteSpringApplicationContextResource.java |    69 -
 .../ignite/resources/IgniteSpringResource.java  |   116 -
 .../IgniteTaskContinuousMapperResource.java     |    57 -
 .../resources/IgniteTaskSessionResource.java    |    60 -
 .../ignite/resources/IgniteUserResource.java    |   132 -
 .../resources/IgniteUserResourceOnDeployed.java |    54 -
 .../IgniteUserResourceOnUndeployed.java         |    53 -
 .../ignite/resources/JobContextResource.java    |    59 +
 .../ignite/resources/LoadBalancerResource.java  |    61 +
 .../apache/ignite/resources/LoggerResource.java |    85 +
 .../ignite/resources/MBeanServerResource.java   |    65 +
 .../ignite/resources/ServiceResource.java       |    87 +
 .../SpringApplicationContextResource.java       |    68 +
 .../apache/ignite/resources/SpringResource.java |   112 +
 .../resources/TaskContinuousMapperResource.java |    57 +
 .../ignite/resources/TaskSessionResource.java   |    60 +
 .../apache/ignite/resources/package-info.java   |    22 +
 .../org/apache/ignite/resources/package.html    |    24 -
 .../ignite/scheduler/SchedulerFuture.java       |    45 +-
 .../org/apache/ignite/scheduler/package.html    |     3 +-
 .../org/apache/ignite/services/Service.java     |   123 +
 .../ignite/services/ServiceConfiguration.java   |   305 +
 .../apache/ignite/services/ServiceContext.java  |    68 +
 .../ignite/services/ServiceDescriptor.java      |    90 +
 .../org/apache/ignite/services/package.html     |    23 +
 .../java/org/apache/ignite/spi/IgniteSpi.java   |    17 +-
 .../org/apache/ignite/spi/IgniteSpiAdapter.java |   118 +-
 .../ignite/spi/IgniteSpiConfiguration.java      |     2 +-
 .../org/apache/ignite/spi/IgniteSpiContext.java |    95 +-
 .../apache/ignite/spi/IgniteSpiException.java   |     2 +-
 .../ignite/spi/IgniteSpiManagementMBean.java    |    22 +-
 .../org/apache/ignite/spi/IgniteSpiThread.java  |     5 +-
 .../AuthenticationAclProvider.java              |    41 -
 .../authentication/AuthenticationContext.java   |    56 -
 .../AuthenticationContextAdapter.java           |   112 -
 .../spi/authentication/AuthenticationSpi.java   |    90 -
 .../noop/NoopAuthenticationSpi.java             |   127 -
 .../noop/NoopAuthenticationSpiMBean.java        |    29 -
 .../ignite/spi/authentication/noop/package.html |    23 -
 .../ignite/spi/authentication/package.html      |    23 -
 .../ignite/spi/checkpoint/CheckpointSpi.java    |     6 +-
 .../checkpoint/cache/CacheCheckpointSpi.java    |    29 +-
 .../cache/CacheCheckpointSpiMBean.java          |     6 +-
 .../ignite/spi/checkpoint/cache/package.html    |     3 +-
 .../spi/checkpoint/jdbc/JdbcCheckpointSpi.java  |    11 +-
 .../checkpoint/jdbc/JdbcCheckpointSpiMBean.java |    26 +-
 .../ignite/spi/checkpoint/jdbc/package.html     |     3 +-
 .../spi/checkpoint/noop/NoopCheckpointSpi.java  |     4 +-
 .../ignite/spi/checkpoint/noop/package.html     |     3 +-
 .../apache/ignite/spi/checkpoint/package.html   |     2 +-
 .../sharedfs/SharedFsCheckpointData.java        |     3 +-
 .../sharedfs/SharedFsCheckpointSpi.java         |    31 +-
 .../sharedfs/SharedFsCheckpointSpiMBean.java    |     8 +-
 .../checkpoint/sharedfs/SharedFsTimeData.java   |     2 +-
 .../sharedfs/SharedFsTimeoutTask.java           |     8 +-
 .../spi/checkpoint/sharedfs/SharedFsUtils.java  |     8 +-
 .../ignite/spi/checkpoint/sharedfs/package.html |     3 +-
 .../ignite/spi/collision/CollisionSpi.java      |     6 +-
 .../fifoqueue/FifoQueueCollisionSpi.java        |    14 +-
 .../fifoqueue/FifoQueueCollisionSpiMBean.java   |    20 +-
 .../ignite/spi/collision/fifoqueue/package.html |     3 +-
 .../jobstealing/JobStealingCollisionSpi.java    |    38 +-
 .../JobStealingCollisionSpiMBean.java           |    38 +-
 .../jobstealing/JobStealingRequest.java         |    55 +-
 .../spi/collision/jobstealing/package.html      |     3 +-
 .../spi/collision/noop/NoopCollisionSpi.java    |     4 +-
 .../ignite/spi/collision/noop/package.html      |     3 +-
 .../apache/ignite/spi/collision/package.html    |     3 +-
 .../PriorityQueueCollisionSpi.java              |    30 +-
 .../PriorityQueueCollisionSpiMBean.java         |    36 +-
 .../spi/collision/priorityqueue/package.html    |     3 +-
 .../spi/communication/CommunicationSpi.java     |     6 +-
 .../ignite/spi/communication/package.html       |     3 +-
 .../communication/tcp/TcpCommunicationSpi.java  |   348 +-
 .../tcp/TcpCommunicationSpiMBean.java           |    60 +-
 .../ignite/spi/communication/tcp/package.html   |     3 +-
 .../deployment/DeploymentResourceAdapter.java   |     2 +-
 .../ignite/spi/deployment/DeploymentSpi.java    |     6 +-
 .../deployment/local/LocalDeploymentSpi.java    |     8 +-
 .../local/LocalDeploymentSpiMBean.java          |     4 +-
 .../ignite/spi/deployment/local/package.html    |     3 +-
 .../apache/ignite/spi/deployment/package.html   |     3 +-
 .../spi/discovery/DiscoveryMetricsHelper.java   |   368 -
 .../spi/discovery/DiscoveryMetricsProvider.java |     6 +-
 .../discovery/DiscoveryNodeMetricsAdapter.java  |  1068 --
 .../ignite/spi/discovery/DiscoverySpi.java      |    16 +-
 .../spi/discovery/DiscoverySpiDataExchange.java |     6 +-
 .../spi/discovery/DiscoverySpiListener.java     |     2 +-
 .../DiscoverySpiNodeAuthenticator.java          |     6 +-
 .../spi/discovery/DiscoverySpiOrderSupport.java |     2 +-
 .../apache/ignite/spi/discovery/package.html    |     3 +-
 .../discovery/tcp/TcpClientDiscoverySpi.java    |    86 +-
 .../tcp/TcpClientDiscoverySpiMBean.java         |    36 +-
 .../spi/discovery/tcp/TcpDiscoverySpi.java      |   297 +-
 .../discovery/tcp/TcpDiscoverySpiAdapter.java   |    53 +-
 .../spi/discovery/tcp/TcpDiscoverySpiMBean.java |    64 +-
 .../tcp/internal/TcpDiscoveryNode.java          |    33 +-
 .../tcp/internal/TcpDiscoveryNodesRing.java     |     8 +-
 .../tcp/internal/TcpDiscoveryStatistics.java    |     8 +-
 .../spi/discovery/tcp/internal/package.html     |     3 +-
 .../ipfinder/TcpDiscoveryIpFinderAdapter.java   |     4 +-
 .../ipfinder/jdbc/TcpDiscoveryJdbcIpFinder.java |    18 +-
 .../discovery/tcp/ipfinder/jdbc/package.html    |     3 +-
 .../TcpDiscoveryMulticastIpFinder.java          |    42 +-
 .../tcp/ipfinder/multicast/package.html         |     3 +-
 .../spi/discovery/tcp/ipfinder/package.html     |     3 +-
 .../sharedfs/TcpDiscoverySharedFsIpFinder.java  |    14 +-
 .../tcp/ipfinder/sharedfs/package.html          |     3 +-
 .../tcp/ipfinder/vm/TcpDiscoveryVmIpFinder.java |    10 +-
 .../spi/discovery/tcp/ipfinder/vm/package.html  |     3 +-
 .../messages/TcpDiscoveryAbstractMessage.java   |     4 +-
 .../messages/TcpDiscoveryAuthFailedMessage.java |     2 +-
 .../TcpDiscoveryCheckFailedMessage.java         |     2 +-
 .../TcpDiscoveryClientReconnectMessage.java     |     4 +-
 .../messages/TcpDiscoveryDiscardMessage.java    |     2 +-
 .../TcpDiscoveryDuplicateIdMessage.java         |     2 +-
 .../messages/TcpDiscoveryHandshakeRequest.java  |     2 +-
 .../messages/TcpDiscoveryHandshakeResponse.java |     2 +-
 .../messages/TcpDiscoveryHeartbeatMessage.java  |    42 +-
 .../TcpDiscoveryJoinRequestMessage.java         |    12 +-
 .../TcpDiscoveryLoopbackProblemMessage.java     |     2 +-
 .../TcpDiscoveryNodeAddFinishedMessage.java     |     2 +-
 .../messages/TcpDiscoveryNodeAddedMessage.java  |    28 +-
 .../messages/TcpDiscoveryNodeFailedMessage.java |     2 +-
 .../messages/TcpDiscoveryNodeLeftMessage.java   |     2 +-
 .../tcp/messages/TcpDiscoveryPingRequest.java   |     2 +-
 .../TcpDiscoveryStatusCheckMessage.java         |     2 +-
 .../spi/discovery/tcp/messages/package.html     |     3 +-
 .../ignite/spi/discovery/tcp/package.html       |     3 +-
 .../spi/eventstorage/EventStorageSpi.java       |    10 +-
 .../memory/MemoryEventStorageSpi.java           |    30 +-
 .../memory/MemoryEventStorageSpiMBean.java      |    12 +-
 .../ignite/spi/eventstorage/memory/package.html |     2 +-
 .../apache/ignite/spi/eventstorage/package.html |     2 +-
 .../ignite/spi/failover/FailoverContext.java    |     4 +-
 .../apache/ignite/spi/failover/FailoverSpi.java |     4 +-
 .../spi/failover/always/AlwaysFailoverSpi.java  |    11 +-
 .../failover/always/AlwaysFailoverSpiMBean.java |     8 +-
 .../ignite/spi/failover/always/package.html     |     3 +-
 .../jobstealing/JobStealingFailoverSpi.java     |    23 +-
 .../JobStealingFailoverSpiMBean.java            |    10 +-
 .../spi/failover/jobstealing/package.html       |     2 +-
 .../spi/failover/never/NeverFailoverSpi.java    |     7 +-
 .../failover/never/NeverFailoverSpiMBean.java   |     4 +-
 .../ignite/spi/failover/never/package.html      |     3 +-
 .../org/apache/ignite/spi/failover/package.html |     2 +-
 .../spi/indexing/GridIndexingQueryFilter.java   |    35 -
 .../ignite/spi/indexing/GridIndexingSpi.java    |   112 -
 .../spi/indexing/GridNoopIndexingSpi.java       |    66 -
 .../spi/indexing/IndexingQueryFilter.java       |    34 +
 .../apache/ignite/spi/indexing/IndexingSpi.java |   113 +
 .../spi/indexing/noop/NoopIndexingSpi.java      |    68 +
 .../org/apache/ignite/spi/indexing/package.html |     3 +-
 .../spi/loadbalancing/LoadBalancingSpi.java     |    16 +-
 .../adaptive/AdaptiveCpuLoadProbe.java          |    10 +-
 .../adaptive/AdaptiveJobCountLoadProbe.java     |    10 +-
 .../adaptive/AdaptiveLoadBalancingSpi.java      |    38 +-
 .../adaptive/AdaptiveLoadBalancingSpiMBean.java |     6 +-
 .../adaptive/AdaptiveLoadProbe.java             |     2 +-
 .../AdaptiveProcessingTimeLoadProbe.java        |    10 +-
 .../spi/loadbalancing/adaptive/package.html     |     2 +-
 .../ignite/spi/loadbalancing/package.html       |     3 +-
 .../RoundRobinGlobalLoadBalancer.java           |    35 +-
 .../roundrobin/RoundRobinLoadBalancingSpi.java  |    30 +-
 .../RoundRobinLoadBalancingSpiMBean.java        |     6 +-
 .../spi/loadbalancing/roundrobin/package.html   |     3 +-
 .../WeightedRandomLoadBalancingSpi.java         |    32 +-
 .../WeightedRandomLoadBalancingSpiMBean.java    |     8 +-
 .../loadbalancing/weightedrandom/package.html   |     2 +-
 .../java/org/apache/ignite/spi/package.html     |     2 +-
 .../spi/securesession/SecureSessionSpi.java     |    92 -
 .../noop/NoopSecureSessionSpi.java              |   123 -
 .../noop/NoopSecureSessionSpiMBean.java         |    29 -
 .../ignite/spi/securesession/noop/package.html  |    23 -
 .../ignite/spi/securesession/package.html       |    24 -
 .../ignite/spi/swapspace/SwapContext.java       |     2 +-
 .../apache/ignite/spi/swapspace/SwapKey.java    |     4 +-
 .../ignite/spi/swapspace/SwapSpaceSpi.java      |    17 +-
 .../spi/swapspace/SwapSpaceSpiListener.java     |     2 +-
 .../spi/swapspace/file/FileSwapSpaceSpi.java    |    72 +-
 .../swapspace/file/FileSwapSpaceSpiMBean.java   |    14 +-
 .../ignite/spi/swapspace/file/package.html      |     3 +-
 .../spi/swapspace/noop/NoopSwapSpaceSpi.java    |    13 +-
 .../ignite/spi/swapspace/noop/package.html      |     3 +-
 .../apache/ignite/spi/swapspace/package.html    |     3 +-
 .../ignite/startup/BasicWarmupClosure.java      |   562 +
 .../ignite/startup/cmdline/AboutDialog.java     |     2 +-
 .../startup/cmdline/CommandLineStartup.java     |    41 +-
 .../startup/cmdline/CommandLineTransformer.java |    12 +-
 .../apache/ignite/startup/cmdline/package.html  |     3 +-
 .../org/apache/ignite/startup/package-info.java |     2 +-
 .../ignite/streamer/StreamerConfiguration.java  |    54 +-
 .../apache/ignite/streamer/StreamerContext.java |    24 +-
 .../streamer/StreamerEventRouterAdapter.java    |     4 +-
 .../apache/ignite/streamer/StreamerMBean.java   |    36 +-
 .../apache/ignite/streamer/StreamerStage.java   |     4 +-
 .../ignite/streamer/StreamerStageMBean.java     |    26 +-
 .../apache/ignite/streamer/StreamerWindow.java  |    46 +-
 .../ignite/streamer/StreamerWindowMBean.java    |    12 +-
 .../streamer/index/StreamerIndexProvider.java   |     8 +-
 .../index/StreamerIndexProviderAdapter.java     |    30 +-
 .../index/StreamerIndexProviderMBean.java       |    14 +-
 .../streamer/index/StreamerIndexUpdateSync.java |     2 +-
 .../streamer/index/StreamerIndexUpdater.java    |     4 +-
 .../index/hash/StreamerHashIndexProvider.java   |    10 +-
 .../ignite/streamer/index/hash/package.html     |     3 +-
 .../apache/ignite/streamer/index/package.html   |     3 +-
 .../index/tree/StreamerTreeIndexProvider.java   |    20 +-
 .../ignite/streamer/index/tree/package.html     |     2 +-
 .../org/apache/ignite/streamer/package.html     |     3 +-
 .../router/StreamerAffinityEventRouter.java     |     6 +-
 .../StreamerCacheAffinityEventRouter.java       |     6 +-
 .../router/StreamerLocalEventRouter.java        |     2 +-
 .../router/StreamerRandomEventRouter.java       |     2 +-
 .../apache/ignite/streamer/router/package.html  |     3 +-
 .../window/StreamerBoundedSizeBatchWindow.java  |    26 +-
 .../window/StreamerBoundedSizeSortedWindow.java |     6 +-
 .../window/StreamerBoundedSizeWindow.java       |     2 +-
 .../StreamerBoundedSizeWindowAdapter.java       |    10 +-
 .../window/StreamerBoundedTimeBatchWindow.java  |    28 +-
 .../window/StreamerBoundedTimeWindow.java       |    14 +-
 .../window/StreamerUnboundedWindow.java         |     2 +-
 .../streamer/window/StreamerWindowAdapter.java  |    44 +-
 .../apache/ignite/streamer/window/package.html  |     3 +-
 .../thread/IgniteStripedThreadPoolExecutor.java |     2 +-
 .../org/apache/ignite/thread/IgniteThread.java  |     6 +-
 .../ignite/thread/IgniteThreadFactory.java      |     2 +-
 .../java/org/apache/ignite/thread/package.html  |     3 +-
 .../apache/ignite/transactions/IgniteTx.java    |   247 -
 .../transactions/IgniteTxConcurrency.java       |    45 -
 .../IgniteTxHeuristicException.java             |    51 -
 .../ignite/transactions/IgniteTxIsolation.java  |    49 -
 .../ignite/transactions/IgniteTxMetrics.java    |    53 -
 .../IgniteTxOptimisticException.java            |    47 -
 .../transactions/IgniteTxRollbackException.java |    47 -
 .../ignite/transactions/IgniteTxState.java      |    65 -
 .../transactions/IgniteTxSynchronization.java   |    46 -
 .../transactions/IgniteTxTimeoutException.java  |    47 -
 .../apache/ignite/transactions/Transaction.java |   276 +
 .../transactions/TransactionConcurrency.java    |    45 +
 .../TransactionHeuristicException.java          |    51 +
 .../transactions/TransactionIsolation.java      |    49 +
 .../ignite/transactions/TransactionMetrics.java |    53 +
 .../TransactionOptimisticException.java         |    47 +
 .../TransactionRollbackException.java           |    47 +
 .../ignite/transactions/TransactionState.java   |    65 +
 .../TransactionSynchronization.java             |    45 +
 .../TransactionTimeoutException.java            |    47 +
 .../java/org/gridgain/client/GridClient.java    |   148 -
 .../GridClientAuthenticationException.java      |    35 -
 .../gridgain/client/GridClientCacheFlag.java    |    65 -
 .../gridgain/client/GridClientCacheMode.java    |    32 -
 .../client/GridClientClosedException.java       |    35 -
 .../org/gridgain/client/GridClientCompute.java  |   476 -
 .../client/GridClientConfiguration.java         |   868 --
 .../org/gridgain/client/GridClientData.java     |   443 -
 .../gridgain/client/GridClientDataAffinity.java |    39 -
 .../client/GridClientDataConfiguration.java     |   118 -
 .../gridgain/client/GridClientDataMetrics.java  |    77 -
 .../client/GridClientDisconnectedException.java |    36 -
 .../gridgain/client/GridClientException.java    |   111 -
 .../org/gridgain/client/GridClientFactory.java  |   138 -
 .../org/gridgain/client/GridClientFuture.java   |    68 -
 .../client/GridClientFutureListener.java        |    30 -
 .../GridClientFutureTimeoutException.java       |    45 -
 .../client/GridClientHandshakeException.java    |    48 -
 .../org/gridgain/client/GridClientNode.java     |   152 -
 .../gridgain/client/GridClientNodeMetrics.java  |   524 -
 .../client/GridClientPartitionAffinity.java     |   369 -
 .../gridgain/client/GridClientPredicate.java    |    38 -
 .../org/gridgain/client/GridClientProtocol.java |    30 -
 .../client/GridClientTopologyListener.java      |    41 -
 .../client/GridServerUnreachableException.java  |    45 -
 .../balancer/GridClientBalancerAdapter.java     |    76 -
 .../client/balancer/GridClientLoadBalancer.java |    44 -
 .../balancer/GridClientRandomBalancer.java      |    75 -
 .../balancer/GridClientRoundRobinBalancer.java  |   111 -
 .../org/gridgain/client/balancer/package.html   |    24 -
 .../impl/GridClientAbstractProjection.java      |   458 -
 .../client/impl/GridClientAndPredicate.java     |    52 -
 .../client/impl/GridClientComputeImpl.java      |   293 -
 .../client/impl/GridClientDataImpl.java         |   389 -
 .../impl/GridClientDataMetricsAdapter.java      |   160 -
 .../client/impl/GridClientFutureAdapter.java    |   349 -
 .../client/impl/GridClientFutureCallback.java   |    35 -
 .../gridgain/client/impl/GridClientImpl.java    |   524 -
 .../client/impl/GridClientNodeImpl.java         |   411 -
 .../impl/GridClientNodeMetricsAdapter.java      |   990 --
 .../client/impl/GridClientThreadFactory.java    |    62 -
 .../impl/connection/GridClientConnection.java   |   531 -
 .../GridClientConnectionCloseReason.java        |    32 -
 .../connection/GridClientConnectionManager.java |    71 -
 .../GridClientConnectionManagerAdapter.java     |   764 -
 .../GridClientConnectionManagerOsImpl.java      |    47 -
 .../GridClientConnectionResetException.java     |    48 -
 .../connection/GridClientNioTcpConnection.java  |  1160 --
 .../impl/connection/GridClientTopology.java     |   450 -
 .../GridConnectionIdleClosedException.java      |    36 -
 .../java/org/gridgain/client/impl/package.html  |    23 -
 .../client/marshaller/GridClientMarshaller.java |    45 -
 .../marshaller/jdk/GridClientJdkMarshaller.java |    68 -
 .../gridgain/client/marshaller/jdk/package.html |    24 -
 .../GridClientOptimizedMarshaller.java          |   104 -
 .../client/marshaller/optimized/package.html    |    24 -
 .../org/gridgain/client/marshaller/package.html |    23 -
 .../main/java/org/gridgain/client/package.html  |    23 -
 .../client/router/GridRouterFactory.java        |   121 -
 .../gridgain/client/router/GridTcpRouter.java   |    76 -
 .../router/GridTcpRouterConfiguration.java      |   306 -
 .../client/router/GridTcpRouterMBean.java       |    88 -
 .../router/impl/GridRouterClientImpl.java       |   200 -
 .../impl/GridRouterCommandLineStartup.java      |   165 -
 .../client/router/impl/GridTcpRouterImpl.java   |   349 -
 .../impl/GridTcpRouterNioListenerAdapter.java   |   203 -
 .../impl/GridTcpRouterNioListenerOsImpl.java    |    38 -
 .../router/impl/GridTcpRouterNioParser.java     |   109 -
 .../gridgain/client/router/impl/package.html    |    23 -
 .../org/gridgain/client/router/package.html     |    23 -
 .../client/ssl/GridSslBasicContextFactory.java  |   438 -
 .../client/ssl/GridSslContextFactory.java       |    36 -
 .../java/org/gridgain/client/ssl/package.html   |    24 -
 .../client/util/GridClientConsistentHash.java   |   440 -
 .../client/util/GridClientStripedLock.java      |   135 -
 .../gridgain/client/util/GridClientUtils.java   |   172 -
 .../client/util/GridConcurrentHashSet.java      |   113 -
 .../java/org/gridgain/client/util/package.html  |    24 -
 .../grid/GridAuthenticationException.java       |    37 -
 .../gridgain/grid/GridBasicWarmupClosure.java   |   559 -
 .../gridgain/grid/GridDeploymentException.java  |    58 -
 .../grid/GridIllegalStateException.java         |    84 -
 .../gridgain/grid/GridInterruptedException.java |    58 -
 .../org/gridgain/grid/GridMetadataAware.java    |   187 -
 .../gridgain/grid/GridNotPeerDeployable.java    |    41 -
 .../java/org/gridgain/grid/cache/GridCache.java |   279 -
 .../GridCacheAtomicUpdateTimeoutException.java  |    47 -
 .../cache/GridCacheAtomicWriteOrderMode.java    |    64 -
 .../grid/cache/GridCacheAtomicityMode.java      |    79 -
 .../grid/cache/GridCacheConfiguration.java      |  1740 ---
 .../grid/cache/GridCacheDistributionMode.java   |    69 -
 .../org/gridgain/grid/cache/GridCacheEntry.java |   569 -
 .../org/gridgain/grid/cache/GridCacheFlag.java  |   110 -
 .../grid/cache/GridCacheFlagException.java      |    67 -
 .../grid/cache/GridCacheInterceptor.java        |   120 -
 .../grid/cache/GridCacheInterceptorAdapter.java |    52 -
 .../org/gridgain/grid/cache/GridCacheMBean.java |   295 -
 .../grid/cache/GridCacheMemoryMode.java         |    61 -
 .../gridgain/grid/cache/GridCacheMetrics.java   |   103 -
 .../org/gridgain/grid/cache/GridCacheMode.java  |    74 -
 .../org/gridgain/grid/cache/GridCacheName.java  |    43 -
 .../cache/GridCachePartialUpdateException.java  |    63 -
 .../gridgain/grid/cache/GridCachePeekMode.java  |    85 -
 .../grid/cache/GridCachePreloadMode.java        |    68 -
 .../grid/cache/GridCacheProjection.java         |  2099 ---
 .../GridCacheWriteSynchronizationMode.java      |    69 -
 .../grid/cache/affinity/GridCacheAffinity.java  |   262 -
 .../affinity/GridCacheAffinityFunction.java     |   111 -
 .../GridCacheAffinityFunctionContext.java       |    71 -
 .../cache/affinity/GridCacheAffinityKey.java    |   189 -
 .../affinity/GridCacheAffinityKeyMapped.java    |   158 -
 .../affinity/GridCacheAffinityKeyMapper.java    |    64 -
 ...ridCacheAffinityNodeAddressHashResolver.java |    39 -
 .../GridCacheAffinityNodeHashResolver.java      |    43 -
 .../GridCacheAffinityNodeIdHashResolver.java    |    40 -
 .../GridCacheCentralizedAffinityFunction.java   |    31 -
 ...GridCacheConsistentHashAffinityFunction.java |   703 -
 .../cache/affinity/consistenthash/package.html  |    24 -
 .../fair/GridCachePartitionFairAffinity.java    |   805 -
 .../grid/cache/affinity/fair/package.html       |    24 -
 .../gridgain/grid/cache/affinity/package.html   |    24 -
 .../GridCacheRendezvousAffinityFunction.java    |   503 -
 .../grid/cache/affinity/rendezvous/package.html |    23 -
 .../grid/cache/cloner/GridCacheBasicCloner.java |    34 -
 .../grid/cache/cloner/GridCacheCloner.java      |    58 -
 .../grid/cache/cloner/GridCacheDeepCloner.java  |    87 -
 .../org/gridgain/grid/cache/cloner/package.html |    24 -
 .../datastructures/GridCacheAtomicLong.java     |   157 -
 .../GridCacheAtomicReference.java               |    93 -
 .../datastructures/GridCacheAtomicSequence.java |   130 -
 .../datastructures/GridCacheAtomicStamped.java  |   121 -
 .../datastructures/GridCacheCountDownLatch.java |   227 -
 .../GridCacheDataStructureInvalidException.java |    66 -
 ...cheDataStructureInvalidRuntimeException.java |    66 -
 .../GridCacheDataStructureRemovedException.java |    61 -
 ...cheDataStructureRemovedRuntimeException.java |    61 -
 .../datastructures/GridCacheDataStructures.java |   221 -
 .../cache/datastructures/GridCacheQueue.java    |   182 -
 .../grid/cache/datastructures/GridCacheSet.java |    61 -
 .../grid/cache/datastructures/package.html      |    24 -
 .../cache/eviction/GridCacheEvictionFilter.java |    40 -
 .../cache/eviction/GridCacheEvictionPolicy.java |    56 -
 .../fifo/GridCacheFifoEvictionPolicy.java       |   210 -
 .../fifo/GridCacheFifoEvictionPolicyMBean.java  |    58 -
 .../grid/cache/eviction/fifo/package.html       |    23 -
 .../ggfs/GridCacheGgfsEvictionFilter.java       |    34 -
 .../GridCacheGgfsPerBlockLruEvictionPolicy.java |   353 -
 ...CacheGgfsPerBlockLruEvictionPolicyMBean.java |    93 -
 .../grid/cache/eviction/ggfs/package.html       |    23 -
 .../lru/GridCacheLruEvictionPolicy.java         |   193 -
 .../lru/GridCacheLruEvictionPolicyMBean.java    |    58 -
 .../grid/cache/eviction/lru/package.html        |    23 -
 .../gridgain/grid/cache/eviction/package.html   |    23 -
 .../random/GridCacheRandomEvictionPolicy.java   |   121 -
 .../GridCacheRandomEvictionPolicyMBean.java     |    42 -
 .../grid/cache/eviction/random/package.html     |    23 -
 .../java/org/gridgain/grid/cache/package.html   |    24 -
 .../cache/query/GridCacheContinuousQuery.java   |   342 -
 .../query/GridCacheContinuousQueryEntry.java    |    49 -
 .../grid/cache/query/GridCacheQueries.java      |   151 -
 .../grid/cache/query/GridCacheQuery.java        |   297 -
 .../query/GridCacheQueryConfiguration.java      |   203 -
 .../grid/cache/query/GridCacheQueryFuture.java  |    66 -
 .../cache/query/GridCacheQueryGroupIndex.java   |    58 -
 .../grid/cache/query/GridCacheQueryMetrics.java |    60 -
 .../cache/query/GridCacheQuerySqlField.java     |   133 -
 .../cache/query/GridCacheQuerySqlFunction.java  |    69 -
 .../cache/query/GridCacheQueryTextField.java    |    33 -
 .../grid/cache/query/GridCacheQueryType.java    |    47 -
 .../cache/query/GridCacheQueryTypeMetadata.java |   196 -
 .../cache/query/GridCacheQueryTypeResolver.java |    32 -
 .../org/gridgain/grid/cache/query/package.html  |    23 -
 .../store/GridCacheLoadOnlyStoreAdapter.java    |   328 -
 .../grid/cache/store/GridCacheLocalStore.java   |    31 -
 .../grid/cache/store/GridCacheStore.java        |   220 -
 .../grid/cache/store/GridCacheStoreAdapter.java |   100 -
 .../store/GridCacheStoreBalancingWrapper.java   |   278 -
 .../store/jdbc/GridCacheJdbcBlobStore.java      |   552 -
 .../gridgain/grid/cache/store/jdbc/package.html |    24 -
 .../org/gridgain/grid/cache/store/package.html  |    23 -
 .../grid/dotnet/GridDotNetConfiguration.java    |   113 -
 .../dotnet/GridDotNetPortableConfiguration.java |   207 -
 .../GridDotNetPortableTypeConfiguration.java    |   219 -
 .../java/org/gridgain/grid/dotnet/package.html  |    23 -
 .../org/gridgain/grid/hadoop/GridHadoop.java    |    86 -
 .../grid/hadoop/GridHadoopConfiguration.java    |   172 -
 .../gridgain/grid/hadoop/GridHadoopCounter.java |    44 -
 .../grid/hadoop/GridHadoopCounterWriter.java    |    36 -
 .../grid/hadoop/GridHadoopCounters.java         |    49 -
 .../grid/hadoop/GridHadoopFileBlock.java        |   162 -
 .../grid/hadoop/GridHadoopInputSplit.java       |    54 -
 .../org/gridgain/grid/hadoop/GridHadoopJob.java |   102 -
 .../gridgain/grid/hadoop/GridHadoopJobId.java   |   102 -
 .../gridgain/grid/hadoop/GridHadoopJobInfo.java |    84 -
 .../grid/hadoop/GridHadoopJobPhase.java         |    38 -
 .../grid/hadoop/GridHadoopJobProperty.java      |   138 -
 .../grid/hadoop/GridHadoopJobStatus.java        |   207 -
 .../grid/hadoop/GridHadoopMapReducePlan.java    |    80 -
 .../grid/hadoop/GridHadoopMapReducePlanner.java |    40 -
 .../grid/hadoop/GridHadoopPartitioner.java      |    33 -
 .../grid/hadoop/GridHadoopSerialization.java    |    54 -
 .../gridgain/grid/hadoop/GridHadoopTask.java    |    73 -
 .../grid/hadoop/GridHadoopTaskContext.java      |   189 -
 .../grid/hadoop/GridHadoopTaskInfo.java         |   153 -
 .../grid/hadoop/GridHadoopTaskInput.java        |    55 -
 .../grid/hadoop/GridHadoopTaskOutput.java       |    40 -
 .../grid/hadoop/GridHadoopTaskType.java         |    56 -
 .../java/org/gridgain/grid/hadoop/package.html  |    24 -
 .../grid/kernal/ClusterGroupAdapter.java        |   852 -
 .../gridgain/grid/kernal/ClusterGroupEx.java    |    35 -
 .../grid/kernal/ClusterLocalNodeMetrics.java    |   311 -
 .../grid/kernal/ClusterMetricsImpl.java         |   813 -
 .../grid/kernal/ClusterNodeLocalMapImpl.java    |   183 -
 .../grid/kernal/ClusterNodeMetricsMBean.java    |    29 -
 .../grid/kernal/GridClosureCallMode.java        |    61 -
 .../org/gridgain/grid/kernal/GridComponent.java |    96 -
 .../gridgain/grid/kernal/GridComponentType.java |   283 -
 .../gridgain/grid/kernal/GridDiagnostic.java    |   172 -
 .../grid/kernal/GridDirectCollection.java       |    32 -
 .../org/gridgain/grid/kernal/GridDirectMap.java |    37 -
 .../grid/kernal/GridDirectTransient.java        |    29 -
 .../gridgain/grid/kernal/GridDirectVersion.java |    32 -
 .../grid/kernal/GridEventConsumeHandler.java    |   416 -
 .../java/org/gridgain/grid/kernal/GridEx.java   |   143 -
 .../org/gridgain/grid/kernal/GridGainEx.java    |  2400 ---
 .../grid/kernal/GridInternalException.java      |    69 -
 .../grid/kernal/GridInternalWrapper.java        |    30 -
 .../grid/kernal/GridJobCancelRequest.java       |   215 -
 .../grid/kernal/GridJobContextImpl.java         |   284 -
 .../grid/kernal/GridJobExecuteRequest.java      |   918 --
 .../grid/kernal/GridJobExecuteRequestV2.java    |   185 -
 .../grid/kernal/GridJobExecuteResponse.java     |   374 -
 .../gridgain/grid/kernal/GridJobResultImpl.java |   182 -
 .../grid/kernal/GridJobSessionImpl.java         |   288 -
 .../grid/kernal/GridJobSiblingImpl.java         |   191 -
 .../grid/kernal/GridJobSiblingsRequest.java     |   175 -
 .../grid/kernal/GridJobSiblingsResponse.java    |   151 -
 .../org/gridgain/grid/kernal/GridKernal.java    |  3316 ----
 .../gridgain/grid/kernal/GridKernalContext.java |   516 -
 .../grid/kernal/GridKernalContextImpl.java      |   908 --
 .../gridgain/grid/kernal/GridKernalGateway.java |   131 -
 .../grid/kernal/GridKernalGatewayImpl.java      |   229 -
 .../gridgain/grid/kernal/GridKernalState.java   |    51 -
 .../org/gridgain/grid/kernal/GridKillTask.java  |   105 -
 .../gridgain/grid/kernal/GridLoggerProxy.java   |   220 -
 .../grid/kernal/GridMessageListenHandler.java   |   201 -
 .../grid/kernal/GridNodeAttributes.java         |   145 -
 .../grid/kernal/GridNodeOrderComparator.java    |    36 -
 .../grid/kernal/GridPerformanceSuggestions.java |    90 -
 .../grid/kernal/GridPluginComponent.java        |    96 -
 .../gridgain/grid/kernal/GridPluginContext.java |   101 -
 .../gridgain/grid/kernal/GridPortablesImpl.java |   174 -
 .../gridgain/grid/kernal/GridProductImpl.java   |   190 -
 .../gridgain/grid/kernal/GridProperties.java    |    82 -
 .../gridgain/grid/kernal/GridProxyListener.java |    51 -
 .../grid/kernal/GridTaskCancelRequest.java      |   134 -
 .../grid/kernal/GridTaskFutureImpl.java         |   122 -
 .../gridgain/grid/kernal/GridTaskMessage.java   |    30 -
 .../grid/kernal/GridTaskNameHashKey.java        |    75 -
 .../grid/kernal/GridTaskSessionImpl.java        |   839 -
 .../grid/kernal/GridTaskSessionInternal.java    |    69 -
 .../grid/kernal/GridTaskSessionRequest.java     |   206 -
 .../org/gridgain/grid/kernal/GridTopic.java     |   829 -
 .../grid/kernal/GridUpdateNotifier.java         |   377 -
 .../grid/kernal/IgniteClusterAsyncImpl.java     |   239 -
 .../gridgain/grid/kernal/IgniteComputeImpl.java |   477 -
 .../gridgain/grid/kernal/IgniteEventsImpl.java  |   300 -
 .../gridgain/grid/kernal/IgniteManagedImpl.java |   265 -
 .../grid/kernal/IgniteMessagingImpl.java        |   222 -
 .../grid/kernal/IgniteSchedulerImpl.java        |   141 -
 .../kernal/IgniteThreadPoolMBeanAdapter.java    |   149 -
 .../grid/kernal/IgniteTransactionsEx.java       |    42 -
 .../grid/kernal/IgnitionMBeanAdapter.java       |    59 -
 .../kernal/executor/GridExecutorService.java    |   737 -
 .../gridgain/grid/kernal/executor/package.html  |    23 -
 .../ggfs/common/GridGgfsControlResponse.java    |   633 -
 .../ggfs/common/GridGgfsDataInputStream.java    |    40 -
 .../ggfs/common/GridGgfsDataOutputStream.java   |    43 -
 .../ggfs/common/GridGgfsHandshakeRequest.java   |    93 -
 .../kernal/ggfs/common/GridGgfsIpcCommand.java  |    98 -
 .../grid/kernal/ggfs/common/GridGgfsLogger.java |   767 -
 .../kernal/ggfs/common/GridGgfsMarshaller.java  |   374 -
 .../kernal/ggfs/common/GridGgfsMessage.java     |    41 -
 .../ggfs/common/GridGgfsPathControlRequest.java |   238 -
 .../ggfs/common/GridGgfsStatusRequest.java      |    35 -
 .../common/GridGgfsStreamControlRequest.java    |   101 -
 .../grid/kernal/ggfs/common/package.html        |    23 -
 .../grid/kernal/managers/GridManager.java       |    46 -
 .../kernal/managers/GridManagerAdapter.java     |   607 -
 .../kernal/managers/GridNoopManagerAdapter.java |    88 -
 .../checkpoint/GridCheckpointManager.java       |   447 -
 .../checkpoint/GridCheckpointRequest.java       |   191 -
 .../kernal/managers/checkpoint/package.html     |    23 -
 .../GridCollisionJobContextAdapter.java         |    62 -
 .../collision/GridCollisionManager.java         |   133 -
 .../grid/kernal/managers/collision/package.html |    23 -
 .../communication/GridDisconnectListener.java   |    34 -
 .../managers/communication/GridIoManager.java   |  2206 ---
 .../managers/communication/GridIoMessage.java   |   361 -
 .../managers/communication/GridIoPolicy.java    |    57 -
 .../communication/GridIoUserMessage.java        |   445 -
 .../communication/GridMessageListener.java      |    34 -
 .../kernal/managers/communication/package.html  |    23 -
 .../managers/deployment/GridDeployment.java     |   775 -
 .../deployment/GridDeploymentClassLoader.java   |   802 -
 .../deployment/GridDeploymentCommunication.java |   486 -
 .../managers/deployment/GridDeploymentInfo.java |    58 -
 .../deployment/GridDeploymentInfoBean.java      |   359 -
 .../deployment/GridDeploymentLocalStore.java    |   558 -
 .../deployment/GridDeploymentManager.java       |   614 -
 .../deployment/GridDeploymentMetadata.java      |   290 -
 .../GridDeploymentPerLoaderStore.java           |   521 -
 .../GridDeploymentPerVersionStore.java          |  1281 --
 .../deployment/GridDeploymentRequest.java       |   336 -
 .../deployment/GridDeploymentResponse.java      |   212 -
 .../deployment/GridDeploymentStore.java         |    98 -
 .../deployment/GridDeploymentStoreAdapter.java  |   159 -
 .../kernal/managers/deployment/package.html     |    23 -
 .../protocol/gg/GridProtocolHandler.java        |    53 -
 .../protocol/gg/GridUrlConnection.java          |    74 -
 .../deployment/protocol/gg/package.html         |    23 -
 .../discovery/GridDiscoveryManager.java         |  2180 ---
 .../GridDiscoveryTopologySnapshot.java          |    62 -
 .../managers/discovery/GridLocalMetrics.java    |   216 -
 .../grid/kernal/managers/discovery/package.html |    23 -
 .../eventstorage/GridEventStorageManager.java   |  1153 --
 .../eventstorage/GridEventStorageMessage.java   |   537 -
 .../eventstorage/GridLocalEventListener.java    |    39 -
 .../kernal/managers/eventstorage/package.html   |    23 -
 .../failover/GridFailoverContextImpl.java       |    82 -
 .../managers/failover/GridFailoverManager.java  |    66 -
 .../grid/kernal/managers/failover/package.html  |    24 -
 .../managers/indexing/GridIndexingManager.java  |   232 -
 .../grid/kernal/managers/indexing/package.html  |    24 -
 .../loadbalancer/GridLoadBalancerAdapter.java   |    52 -
 .../loadbalancer/GridLoadBalancerManager.java   |   163 -
 .../kernal/managers/loadbalancer/package.html   |    23 -
 .../gridgain/grid/kernal/managers/package.html  |    23 -
 .../securesession/GridSecureSession.java        |    54 -
 .../securesession/GridSecureSessionManager.java |    54 -
 .../os/GridOsSecureSessionManager.java          |    56 -
 .../managers/securesession/os/package.html      |    23 -
 .../kernal/managers/securesession/package.html  |    23 -
 .../security/GridAllowAllPermissionSet.java     |    55 -
 .../managers/security/GridSecurityContext.java  |   248 -
 .../managers/security/GridSecurityImpl.java     |    84 -
 .../managers/security/GridSecurityManager.java  |    93 -
 .../security/GridSecuritySubjectAdapter.java    |   131 -
 .../security/os/GridOsSecurityManager.java      |    97 -
 .../kernal/managers/security/os/package.html    |    23 -
 .../grid/kernal/managers/security/package.html  |    23 -
 .../swapspace/GridSwapSpaceManager.java         |   426 -
 .../grid/kernal/managers/swapspace/package.html |    23 -
 .../java/org/gridgain/grid/kernal/package.html  |    24 -
 .../grid/kernal/processors/GridProcessor.java   |    38 -
 .../kernal/processors/GridProcessorAdapter.java |   126 -
 .../affinity/GridAffinityAssignment.java        |   168 -
 .../affinity/GridAffinityAssignmentCache.java   |   409 -
 .../affinity/GridAffinityMessage.java           |   164 -
 .../affinity/GridAffinityProcessor.java         |   528 -
 .../processors/affinity/GridAffinityUtils.java  |   189 -
 .../GridCacheAffinityFunctionContextImpl.java   |    83 -
 .../kernal/processors/affinity/package.html     |    23 -
 .../processors/cache/GridCacheAdapter.java      |  4795 ------
 .../cache/GridCacheAffinityManager.java         |   378 -
 .../processors/cache/GridCacheAtomicFuture.java |    47 -
 .../cache/GridCacheAtomicVersionComparator.java |    58 -
 .../processors/cache/GridCacheAttributes.java   |   606 -
 .../cache/GridCacheBatchSwapEntry.java          |    89 -
 .../cache/GridCacheClearAllRunnable.java        |   174 -
 .../cache/GridCacheConcurrentMap.java           |  2419 ---
 .../processors/cache/GridCacheContext.java      |  1815 ---
 .../GridCacheDefaultAffinityKeyMapper.java      |   137 -
 .../processors/cache/GridCacheDeployable.java   |    37 -
 .../cache/GridCacheDeploymentManager.java       |   951 --
 .../processors/cache/GridCacheEntryEx.java      |   896 --
 .../processors/cache/GridCacheEntryImpl.java    |   780 -
 .../processors/cache/GridCacheEntryInfo.java    |   334 -
 .../GridCacheEntryInfoCollectSwapListener.java  |    89 -
 .../cache/GridCacheEntryRedeployException.java  |    35 -
 .../cache/GridCacheEntryRemovedException.java   |    28 -
 .../processors/cache/GridCacheEntrySet.java     |   112 -
 .../processors/cache/GridCacheEventManager.java |   254 -
 .../cache/GridCacheEvictionEntry.java           |   531 -
 .../cache/GridCacheEvictionManager.java         |  2038 ---
 .../cache/GridCacheEvictionRequest.java         |   251 -
 .../cache/GridCacheEvictionResponse.java        |   281 -
 .../cache/GridCacheExplicitLockSpan.java        |   278 -
 .../cache/GridCacheFilterEvaluationEntry.java   |   437 -
 .../cache/GridCacheFilterFailedException.java   |    58 -
 .../processors/cache/GridCacheFuture.java       |    61 -
 .../processors/cache/GridCacheGateway.java      |   153 -
 .../cache/GridCacheIndexUpdateException.java    |    45 -
 .../processors/cache/GridCacheInternal.java     |    27 -
 .../processors/cache/GridCacheIoManager.java    |   866 --
 .../processors/cache/GridCacheIterator.java     |    86 -
 .../processors/cache/GridCacheKeySet.java       |   111 -
 .../cache/GridCacheLockTimeoutException.java    |    33 -
 .../processors/cache/GridCacheLogger.java       |   189 -
 .../processors/cache/GridCacheMBeanAdapter.java |   217 -
 .../processors/cache/GridCacheManager.java      |    57 -
 .../cache/GridCacheManagerAdapter.java          |   167 -
 .../processors/cache/GridCacheMapAdapter.java   |   174 -
 .../processors/cache/GridCacheMapEntry.java     |  4157 -----
 .../cache/GridCacheMapEntryFactory.java         |    39 -
 .../processors/cache/GridCacheMessage.java      |   669 -
 .../cache/GridCacheMetricsAdapter.java          |   260 -
 .../cache/GridCacheMultiTxFuture.java           |   146 -
 .../kernal/processors/cache/GridCacheMvcc.java  |  1258 --
 .../processors/cache/GridCacheMvccCallback.java |    53 -
 .../cache/GridCacheMvccCandidate.java           |   707 -
 .../processors/cache/GridCacheMvccFuture.java   |    30 -
 .../processors/cache/GridCacheMvccManager.java  |  1179 --
 .../cache/GridCacheOffheapSwapEntry.java        |   195 -
 .../processors/cache/GridCacheOperation.java    |    60 -
 .../GridCachePartitionExchangeManager.java      |  1023 --
 .../processors/cache/GridCachePreloader.java    |   128 -
 .../cache/GridCachePreloaderAdapter.java        |   141 -
 .../processors/cache/GridCacheProcessor.java    |  1860 ---
 .../processors/cache/GridCacheProjectionEx.java |   392 -
 .../cache/GridCacheProjectionImpl.java          |  1394 --
 .../kernal/processors/cache/GridCacheProxy.java |    27 -
 .../processors/cache/GridCacheProxyImpl.java    |  1894 ---
 .../processors/cache/GridCacheReturn.java       |   175 -
 .../cache/GridCacheSharedContext.java           |   508 -
 .../cache/GridCacheSharedManager.java           |    57 -
 .../cache/GridCacheSharedManagerAdapter.java    |   167 -
 .../processors/cache/GridCacheStoreManager.java |   515 -
 .../processors/cache/GridCacheSwapEntry.java    |    81 -
 .../cache/GridCacheSwapEntryImpl.java           |   344 -
 .../processors/cache/GridCacheSwapListener.java |    31 -
 .../processors/cache/GridCacheSwapManager.java  |  1615 --
 .../cache/GridCacheTransformComputeClosure.java |    76 -
 .../processors/cache/GridCacheTtlManager.java   |   216 -
 .../cache/GridCacheUpdateAtomicResult.java      |   147 -
 .../cache/GridCacheUpdateTxResult.java          |    64 -
 .../processors/cache/GridCacheUtilityKey.java   |    45 -
 .../kernal/processors/cache/GridCacheUtils.java |  1659 --
 .../processors/cache/GridCacheValueBytes.java   |   120 -
 .../cache/GridCacheValueCollection.java         |   167 -
 .../processors/cache/GridCacheVersion.java      |   256 -
 .../processors/cache/GridCacheVersionEx.java    |    95 -
 .../cache/GridCacheVersionManager.java          |   281 -
 .../processors/cache/GridCacheVersionable.java  |    28 -
 .../cache/GridCacheWriteBehindStore.java        |  1010 --
 .../processors/cache/GridDrResolveResult.java   |    63 -
 .../processors/cache/GridPartitionLockKey.java  |   104 -
 .../cache/affinity/GridCacheAffinityImpl.java   |   222 -
 .../cache/affinity/GridCacheAffinityProxy.java  |   262 -
 .../GridAtomicCacheQueueImpl.java               |   259 -
 .../GridCacheAnnotationHelper.java              |   240 -
 .../datastructures/GridCacheAtomicLongEx.java   |    32 -
 .../datastructures/GridCacheAtomicLongImpl.java |   527 -
 .../GridCacheAtomicLongValue.java               |    84 -
 .../GridCacheAtomicReferenceEx.java             |    33 -
 .../GridCacheAtomicReferenceImpl.java           |   320 -
 .../GridCacheAtomicReferenceValue.java          |   106 -
 .../GridCacheAtomicSequenceEx.java              |    32 -
 .../GridCacheAtomicSequenceImpl.java            |   516 -
 .../GridCacheAtomicSequenceValue.java           |    84 -
 .../GridCacheAtomicStampedEx.java               |    32 -
 .../GridCacheAtomicStampedImpl.java             |   350 -
 .../GridCacheAtomicStampedValue.java            |   135 -
 .../GridCacheCountDownLatchEx.java              |    39 -
 .../GridCacheCountDownLatchImpl.java            |   359 -
 .../GridCacheCountDownLatchValue.java           |   115 -
 .../GridCacheDataStructuresImpl.java            |   119 -
 .../GridCacheDataStructuresManager.java         |  1583 --
 .../GridCacheDataStructuresProxy.java           |   267 -
 .../datastructures/GridCacheInternalKey.java    |    31 -
 .../GridCacheInternalKeyImpl.java               |    89 -
 .../datastructures/GridCacheQueueAdapter.java   |   960 --
 .../datastructures/GridCacheQueueHeader.java    |   199 -
 .../datastructures/GridCacheQueueHeaderKey.java |    88 -
 .../datastructures/GridCacheQueueItemKey.java   |   121 -
 .../datastructures/GridCacheQueueProxy.java     |   746 -
 .../datastructures/GridCacheRemovable.java      |    37 -
 .../datastructures/GridCacheSetHeader.java      |    85 -
 .../datastructures/GridCacheSetHeaderKey.java   |    88 -
 .../cache/datastructures/GridCacheSetImpl.java  |   724 -
 .../datastructures/GridCacheSetItemKey.java     |   109 -
 .../cache/datastructures/GridCacheSetProxy.java |   538 -
 .../datastructures/GridSetQueryPredicate.java   |   116 -
 .../GridTransactionalCacheQueueImpl.java        |   243 -
 .../distributed/GridCacheCommittedTxInfo.java   |   112 -
 .../distributed/GridCacheMappedVersion.java     |    33 -
 ...ridCacheOptimisticCheckPreparedTxFuture.java |   388 -
 ...idCacheOptimisticCheckPreparedTxRequest.java |   227 -
 ...dCacheOptimisticCheckPreparedTxResponse.java |   198 -
 .../GridCachePerThreadTxCommitBuffer.java       |   185 -
 ...dCachePessimisticCheckCommittedTxFuture.java |   380 -
 ...CachePessimisticCheckCommittedTxRequest.java |   292 -
 ...achePessimisticCheckCommittedTxResponse.java |   231 -
 .../distributed/GridCacheTxCommitBuffer.java    |    60 -
 .../distributed/GridCacheTxFinishSync.java      |   293 -
 .../distributed/GridDistributedBaseMessage.java |   456 -
 .../GridDistributedCacheAdapter.java            |   119 -
 .../distributed/GridDistributedCacheEntry.java  |   850 -
 .../GridDistributedLockCancelledException.java  |    40 -
 .../distributed/GridDistributedLockRequest.java |   833 -
 .../GridDistributedLockResponse.java            |   423 -
 .../GridDistributedTxFinishRequest.java         |   695 -
 .../GridDistributedTxFinishResponse.java        |   172 -
 .../distributed/GridDistributedTxMapping.java   |   302 -
 .../GridDistributedTxPrepareRequest.java        |   776 -
 .../GridDistributedTxPrepareResponse.java       |   250 -
 .../GridDistributedTxRemoteAdapter.java         |   809 -
 .../GridDistributedUnlockRequest.java           |   239 -
 .../GridPartitionedCacheEntryImpl.java          |   570 -
 .../dht/GridClientPartitionTopology.java        |   817 -
 .../dht/GridDhtAffinityAssignmentRequest.java   |   139 -
 .../dht/GridDhtAffinityAssignmentResponse.java  |   196 -
 .../dht/GridDhtAssignmentFetchFuture.java       |   184 -
 .../cache/distributed/dht/GridDhtCache.java     |   103 -
 .../distributed/dht/GridDhtCacheAdapter.java    |   762 -
 .../distributed/dht/GridDhtCacheEntry.java      |   760 -
 .../distributed/dht/GridDhtCacheEntryImpl.java  |   172 -
 .../distributed/dht/GridDhtEmbeddedFuture.java  |    92 -
 .../distributed/dht/GridDhtFinishedFuture.java  |    66 -
 .../cache/distributed/dht/GridDhtFuture.java    |    36 -
 .../cache/distributed/dht/GridDhtGetFuture.java |   397 -
 .../dht/GridDhtInvalidPartitionException.java   |    51 -
 .../distributed/dht/GridDhtLocalPartition.java  |   595 -
 .../distributed/dht/GridDhtLockFuture.java      |  1225 --
 .../distributed/dht/GridDhtLockRequest.java     |   552 -
 .../distributed/dht/GridDhtLockResponse.java    |   453 -
 .../distributed/dht/GridDhtPartitionState.java  |    55 -
 .../dht/GridDhtPartitionTopology.java           |   207 -
 .../dht/GridDhtPartitionTopologyImpl.java       |  1196 --
 .../distributed/dht/GridDhtTopologyFuture.java  |    44 -
 .../dht/GridDhtTransactionalCacheAdapter.java   |  1459 --
 .../distributed/dht/GridDhtTxFinishFuture.java  |   510 -
 .../distributed/dht/GridDhtTxFinishRequest.java |   607 -
 .../dht/GridDhtTxFinishResponse.java            |   145 -
 .../cache/distributed/dht/GridDhtTxLocal.java   |   651 -
 .../distributed/dht/GridDhtTxLocalAdapter.java  |   793 -
 .../cache/distributed/dht/GridDhtTxMapping.java |   169 -
 .../distributed/dht/GridDhtTxPrepareFuture.java |  1075 --
 .../dht/GridDhtTxPrepareRequest.java            |   613 -
 .../dht/GridDhtTxPrepareResponse.java           |   471 -
 .../cache/distributed/dht/GridDhtTxRemote.java  |   315 -
 .../distributed/dht/GridDhtUnlockRequest.java   |   221 -
 .../distributed/dht/GridNoStorageCacheMap.java  |   109 -
 .../dht/GridPartitionedGetFuture.java           |   688 -
 .../dht/atomic/GridDhtAtomicCache.java          |  2565 ---
 .../dht/atomic/GridDhtAtomicCacheEntry.java     |    75 -
 .../GridDhtAtomicDeferredUpdateResponse.java    |   188 -
 .../dht/atomic/GridDhtAtomicUpdateFuture.java   |   418 -
 .../dht/atomic/GridDhtAtomicUpdateRequest.java  |  1250 --
 .../dht/atomic/GridDhtAtomicUpdateResponse.java |   353 -
 .../dht/atomic/GridNearAtomicUpdateFuture.java  |   847 -
 .../dht/atomic/GridNearAtomicUpdateRequest.java |  1026 --
 .../atomic/GridNearAtomicUpdateResponse.java    |   720 -
 .../dht/colocated/GridDhtColocatedCache.java    |   721 -
 .../colocated/GridDhtColocatedCacheEntry.java   |    67 -
 .../colocated/GridDhtColocatedLockFuture.java   |  1290 --
 .../colocated/GridDhtDetachedCacheEntry.java    |   108 -
 .../dht/preloader/GridDhtForceKeysFuture.java   |   566 -
 .../dht/preloader/GridDhtForceKeysRequest.java  |   333 -
 .../dht/preloader/GridDhtForceKeysResponse.java |   339 -
 .../GridDhtPartitionDemandMessage.java          |   390 -
 .../preloader/GridDhtPartitionDemandPool.java   |  1141 --
 .../preloader/GridDhtPartitionExchangeId.java   |   151 -
 .../dht/preloader/GridDhtPartitionFullMap.java  |   238 -
 .../dht/preloader/GridDhtPartitionMap.java      |   159 -
 .../GridDhtPartitionSupplyMessage.java          |   519 -
 .../preloader/GridDhtPartitionSupplyPool.java   |   576 -
 .../GridDhtPartitionsAbstractMessage.java       |   157 -
 .../GridDhtPartitionsExchangeFuture.java        |  1107 --
 .../preloader/GridDhtPartitionsFullMessage.java |   258 -
 .../GridDhtPartitionsSingleMessage.java         |   176 -
 .../GridDhtPartitionsSingleRequest.java         |   101 -
 .../dht/preloader/GridDhtPreloader.java         |   572 -
 .../preloader/GridDhtPreloaderAssignments.java  |    73 -
 .../distributed/near/GridNearAtomicCache.java   |   636 -
 .../distributed/near/GridNearCacheAdapter.java  |   757 -
 .../near/GridNearCacheClearAllRunnable.java     |    62 -
 .../distributed/near/GridNearCacheEntry.java    |   625 -
 .../distributed/near/GridNearGetFuture.java     |   831 -
 .../distributed/near/GridNearGetRequest.java    |   538 -
 .../distributed/near/GridNearGetResponse.java   |   422 -
 .../distributed/near/GridNearLockFuture.java    |  1461 --
 .../distributed/near/GridNearLockMapping.java   |   116 -
 .../distributed/near/GridNearLockRequest.java   |   629 -
 .../distributed/near/GridNearLockResponse.java  |   448 -
 .../near/GridNearTransactionalCache.java        |   661 -
 .../near/GridNearTxFinishFuture.java            |   500 -
 .../near/GridNearTxFinishRequest.java           |   317 -
 .../near/GridNearTxFinishResponse.java          |   227 -
 .../cache/distributed/near/GridNearTxLocal.java |  1203 --
 .../near/GridNearTxPrepareFuture.java           |   898 --
 .../near/GridNearTxPrepareRequest.java          |   442 -
 .../near/GridNearTxPrepareResponse.java         |   510 -
 .../distributed/near/GridNearTxRemote.java      |   386 -
 .../distributed/near/GridNearUnlockRequest.java |   103 -
 .../cache/dr/GridCacheDrExpirationInfo.java     |    90 -
 .../processors/cache/dr/GridCacheDrInfo.java    |   103 -
 .../processors/cache/dr/GridCacheDrManager.java |   143 -
 .../cache/dr/os/GridOsCacheDrManager.java       |   126 -
 .../extras/GridCacheAttributesEntryExtras.java  |    83 -
 .../GridCacheAttributesMvccEntryExtras.java     |   101 -
 ...dCacheAttributesMvccObsoleteEntryExtras.java |   119 -
 ...cheAttributesMvccObsoleteTtlEntryExtras.java |   146 -
 .../GridCacheAttributesMvccTtlEntryExtras.java  |   130 -
 .../GridCacheAttributesObsoleteEntryExtras.java |   101 -
 ...idCacheAttributesObsoleteTtlEntryExtras.java |   130 -
 .../GridCacheAttributesTtlEntryExtras.java      |   112 -
 .../cache/extras/GridCacheEntryExtras.java      |    82 -
 .../extras/GridCacheEntryExtrasAdapter.java     |    51 -
 .../cache/extras/GridCacheMvccEntryExtras.java  |    82 -
 .../GridCacheMvccObsoleteEntryExtras.java       |    99 -
 .../GridCacheMvccObsoleteTtlEntryExtras.java    |   129 -
 .../extras/GridCacheMvccTtlEntryExtras.java     |   112 -
 .../extras/GridCacheObsoleteEntryExtras.java    |    82 -
 .../extras/GridCacheObsoleteTtlEntryExtras.java |   111 -
 .../cache/extras/GridCacheTtlEntryExtras.java   |    93 -
 .../cache/jta/GridCacheJtaManagerAdapter.java   |    50 -
 .../cache/jta/GridCacheNoopJtaManager.java      |    42 -
 .../processors/cache/local/GridLocalCache.java  |   200 -
 .../cache/local/GridLocalCacheEntry.java        |   386 -
 .../cache/local/GridLocalLockCallback.java      |    38 -
 .../cache/local/GridLocalLockFuture.java        |   451 -
 .../processors/cache/local/GridLocalTx.java     |   205 -
 .../cache/local/GridLocalTxFuture.java          |   350 -
 .../local/atomic/GridLocalAtomicCache.java      |  1333 --
 .../GridCacheDistributedFieldsQueryFuture.java  |   105 -
 .../query/GridCacheDistributedQueryFuture.java  |   259 -
 .../query/GridCacheDistributedQueryManager.java |   794 -
 .../query/GridCacheFieldsQueryErrorFuture.java  |    54 -
 .../query/GridCacheLocalFieldsQueryFuture.java  |    85 -
 .../cache/query/GridCacheLocalQueryFuture.java  |   140 -
 .../cache/query/GridCacheLocalQueryManager.java |   145 -
 .../cache/query/GridCacheQueriesEx.java         |    52 -
 .../cache/query/GridCacheQueriesImpl.java       |   249 -
 .../cache/query/GridCacheQueriesProxy.java      |   273 -
 .../cache/query/GridCacheQueryAdapter.java      |   508 -
 .../cache/query/GridCacheQueryBean.java         |    90 -
 .../cache/query/GridCacheQueryErrorFuture.java  |    52 -
 .../query/GridCacheQueryFutureAdapter.java      |   559 -
 .../cache/query/GridCacheQueryInfo.java         |   184 -
 .../cache/query/GridCacheQueryManager.java      |  3199 ----
 .../query/GridCacheQueryMetadataAware.java      |    33 -
 .../query/GridCacheQueryMetricsAdapter.java     |   150 -
 .../cache/query/GridCacheQueryMetricsKey.java   |   117 -
 .../cache/query/GridCacheQueryRequest.java      |   818 -
 .../cache/query/GridCacheQueryResponse.java     |   445 -
 .../query/GridCacheQueryResponseEntry.java      |   114 -
 .../cache/query/GridCacheQueryType.java         |    71 -
 .../cache/query/GridCacheSqlIndexMetadata.java  |    59 -
 .../cache/query/GridCacheSqlMetadata.java       |    89 -
 .../GridCacheContinuousQueryAdapter.java        |   367 -
 .../GridCacheContinuousQueryEntry.java          |   763 -
 .../GridCacheContinuousQueryFilterEx.java       |    32 -
 .../GridCacheContinuousQueryHandler.java        |   510 -
 .../GridCacheContinuousQueryHandlerV2.java      |    83 -
 .../GridCacheContinuousQueryHandlerV3.java      |    61 -
 .../GridCacheContinuousQueryHandlerV4.java      |    61 -
 .../GridCacheContinuousQueryListener.java       |    41 -
 .../GridCacheContinuousQueryManager.java        |   304 -
 .../jdbc/GridCacheQueryJdbcMetadataTask.java    |   167 -
 .../query/jdbc/GridCacheQueryJdbcTask.java      |   343 -
 .../jdbc/GridCacheQueryJdbcValidationTask.java  |    65 -
 .../transactions/IgniteTransactionsImpl.java    |   253 -
 .../cache/transactions/IgniteTxAdapter.java     |  1556 --
 .../cache/transactions/IgniteTxEntry.java       |  1068 --
 .../cache/transactions/IgniteTxEx.java          |   534 -
 .../cache/transactions/IgniteTxHandler.java     |  1501 --
 .../cache/transactions/IgniteTxKey.java         |   105 -
 .../transactions/IgniteTxLocalAdapter.java      |  3187 ----
 .../cache/transactions/IgniteTxLocalEx.java     |   170 -
 .../cache/transactions/IgniteTxManager.java     |  2221 ---
 .../cache/transactions/IgniteTxMap.java         |   187 -
 .../transactions/IgniteTxMetricsAdapter.java    |   116 -
 .../cache/transactions/IgniteTxProxy.java       |    27 -
 .../cache/transactions/IgniteTxProxyImpl.java   |   372 -
 .../cache/transactions/IgniteTxRemoteEx.java    |    47 -
 .../clock/GridClockDeltaSnapshot.java           |   231 -
 .../clock/GridClockDeltaSnapshotMessage.java    |   226 -
 .../processors/clock/GridClockDeltaVersion.java |   117 -
 .../processors/clock/GridClockMessage.java      |   171 -
 .../processors/clock/GridClockServer.java       |   207 -
 .../processors/clock/GridClockSource.java       |    30 -
 .../clock/GridClockSyncProcessor.java           |   459 -
 .../processors/clock/GridJvmClockSource.java    |    28 -
 .../processors/closure/GridClosurePolicy.java   |    51 -
 .../closure/GridClosureProcessor.java           |  1744 ---
 .../GridMasterLeaveAwareComputeJobAdapter.java  |    36 -
 .../closure/GridPeerDeployAwareTaskAdapter.java |    60 -
 .../grid/kernal/processors/closure/package.html |    23 -
 .../continuous/GridContinuousHandler.java       |   105 -
 .../continuous/GridContinuousMessage.java       |   220 -
 .../continuous/GridContinuousMessageType.java   |    53 -
 .../continuous/GridContinuousProcessor.java     |  1718 ---
 .../dataload/GridDataLoadCacheUpdaters.java     |   289 -
 .../dataload/GridDataLoadRequest.java           |   520 -
 .../dataload/GridDataLoadResponse.java          |   181 -
 .../dataload/GridDataLoadUpdateJob.java         |   105 -
 .../dataload/GridDataLoaderFuture.java          |    76 -
 .../dataload/GridDataLoaderProcessor.java       |   314 -
 .../dataload/IgniteDataLoaderImpl.java          |  1334 --
 .../kernal/processors/dataload/package.html     |    23 -
 .../dr/GridDrDataLoadCacheUpdater.java          |    78 -
 .../grid/kernal/processors/dr/GridDrType.java   |    38 -
 .../processors/dr/GridRawVersionedEntry.java    |   210 -
 .../processors/dr/GridVersionedEntry.java       |    80 -
 .../grid/kernal/processors/dr/package.html      |    25 -
 .../processors/email/GridEmailHolder.java       |   111 -
 .../email/GridEmailProcessorAdapter.java        |    86 -
 .../email/GridNoopEmailProcessor.java           |    56 -
 .../grid/kernal/processors/email/package.html   |    24 -
 .../processors/ggfs/GridGgfsAckMessage.java     |   212 -
 .../processors/ggfs/GridGgfsAsyncImpl.java      |   298 -
 .../processors/ggfs/GridGgfsAttributes.java     |   186 -
 .../processors/ggfs/GridGgfsBlockKey.java       |   279 -
 .../ggfs/GridGgfsBlockLocationImpl.java         |   258 -
 .../processors/ggfs/GridGgfsBlocksMessage.java  |   257 -
 .../processors/ggfs/GridGgfsClientSession.java  |    75 -
 .../ggfs/GridGgfsCommunicationMessage.java      |    75 -
 .../kernal/processors/ggfs/GridGgfsContext.java |   205 -
 .../processors/ggfs/GridGgfsDataManager.java    |  1918 ---
 .../processors/ggfs/GridGgfsDeleteMessage.java  |   206 -
 .../processors/ggfs/GridGgfsDeleteWorker.java   |   351 -
 .../GridGgfsDirectoryNotEmptyException.java     |    44 -
 .../grid/kernal/processors/ggfs/GridGgfsEx.java |   143 -
 .../ggfs/GridGgfsFileAffinityRange.java         |   396 -
 .../processors/ggfs/GridGgfsFileInfo.java       |   568 -
 .../kernal/processors/ggfs/GridGgfsFileMap.java |   361 -
 .../processors/ggfs/GridGgfsFileWorker.java     |   182 -
 .../ggfs/GridGgfsFileWorkerBatch.java           |   236 -
 .../processors/ggfs/GridGgfsFileWorkerTask.java |    32 -
 .../ggfs/GridGgfsFragmentizerManager.java       |   830 -
 .../ggfs/GridGgfsFragmentizerRequest.java       |   212 -
 .../ggfs/GridGgfsFragmentizerResponse.java      |   131 -
 .../ggfs/GridGgfsHandshakeResponse.java         |   122 -
 .../kernal/processors/ggfs/GridGgfsHelper.java  |    49 -
 .../processors/ggfs/GridGgfsHelperImpl.java     |    54 -
 .../kernal/processors/ggfs/GridGgfsImpl.java    |  2153 ---
 .../ggfs/GridGgfsInputStreamAdapter.java        |    49 -
 .../ggfs/GridGgfsInputStreamDescriptor.java     |    78 -
 .../ggfs/GridGgfsInputStreamImpl.java           |   533 -
 .../ggfs/GridGgfsInvalidRangeException.java     |    43 -
 .../processors/ggfs/GridGgfsIpcHandler.java     |   565 -
 .../kernal/processors/ggfs/GridGgfsJobImpl.java |   118 -
 .../processors/ggfs/GridGgfsListingEntry.java   |   197 -
 .../processors/ggfs/GridGgfsLocalMetrics.java   |   212 -
 .../kernal/processors/ggfs/GridGgfsManager.java |   156 -
 .../processors/ggfs/GridGgfsMetaManager.java    |  2976 ----
 .../processors/ggfs/GridGgfsModeResolver.java   |   177 -
 .../kernal/processors/ggfs/GridGgfsPaths.java   |   124 -
 .../processors/ggfs/GridGgfsProcessor.java      |   464 -
 .../ggfs/GridGgfsProcessorAdapter.java          |    80 -
 .../processors/ggfs/GridGgfsSamplingKey.java    |    83 -
 .../GridGgfsSecondaryInputStreamDescriptor.java |    59 -
 ...GridGgfsSecondaryOutputStreamDescriptor.java |    74 -
 .../kernal/processors/ggfs/GridGgfsServer.java  |   428 -
 .../processors/ggfs/GridGgfsServerHandler.java  |    57 -
 .../processors/ggfs/GridGgfsServerManager.java  |   211 -
 .../kernal/processors/ggfs/GridGgfsStatus.java  |    76 -
 .../processors/ggfs/GridGgfsSyncMessage.java    |   161 -
 .../kernal/processors/ggfs/GridGgfsThread.java  |    82 -
 .../processors/ggfs/GridNoopGgfsHelper.java     |    42 -
 .../processors/ggfs/GridNoopGgfsProcessor.java  |    71 -
 .../processors/ggfs/IgniteFsFileImpl.java       |   245 -
 .../processors/ggfs/IgniteFsMetricsAdapter.java |   239 -
 .../ggfs/IgniteFsOutputStreamAdapter.java       |   263 -
 .../ggfs/IgniteFsOutputStreamImpl.java          |   505 -
 .../processors/ggfs/IgniteFsTaskArgsImpl.java   |   135 -
 .../grid/kernal/processors/ggfs/package.html    |    23 -
 .../hadoop/GridHadoopNoopProcessor.java         |    76 -
 .../hadoop/GridHadoopProcessorAdapter.java      |    96 -
 .../processors/interop/GridInteropAware.java    |    49 -
 .../interop/GridInteropProcessor.java           |    82 -
 .../interop/GridInteropProcessorAdapter.java    |    31 -
 .../processors/interop/GridInteropTarget.java   |   109 -
 .../interop/os/GridOsInteropProcessor.java      |    81 -
 .../kernal/processors/interop/os/package.html   |    23 -
 .../grid/kernal/processors/interop/package.html |    23 -
 .../processors/job/GridJobEventListener.java    |    40 -
 .../processors/job/GridJobHoldListener.java     |    36 -
 .../kernal/processors/job/GridJobProcessor.java |  1873 ---
 .../kernal/processors/job/GridJobWorker.java    |   895 --
 .../grid/kernal/processors/job/package.html     |    23 -
 .../processors/jobmetrics/GridJobMetrics.java   |   448 -
 .../jobmetrics/GridJobMetricsProcessor.java     |   404 -
 .../jobmetrics/GridJobMetricsSnapshot.java      |   227 -
 .../kernal/processors/jobmetrics/package.html   |    24 -
 .../license/GridLicenseProcessor.java           |    69 -
 .../license/GridLicenseSubsystem.java           |    53 -
 .../license/GridLicenseUseRegistry.java         |    90 -
 .../license/os/GridOsLicenseProcessor.java      |    66 -
 .../kernal/processors/license/os/package.html   |    23 -
 .../grid/kernal/processors/license/package.html |    24 -
 .../offheap/GridOffHeapProcessor.java           |   326 -
 .../grid/kernal/processors/package.html         |    23 -
 .../plugin/IgnitePluginProcessor.java           |   211 -
 .../processors/port/GridPortListener.java       |    28 -
 .../processors/port/GridPortProcessor.java      |   196 -
 .../kernal/processors/port/GridPortRecord.java  |    72 -
 .../grid/kernal/processors/port/package.html    |    24 -
 .../portable/GridPortableInputStream.java       |   177 -
 .../portable/GridPortableOutputStream.java      |   172 -
 .../portable/GridPortableProcessor.java         |   150 -
 .../processors/portable/GridPortableStream.java |    53 -
 .../portable/os/GridOsPortableProcessor.java    |   126 -
 .../kernal/processors/portable/os/package.html  |    23 -
 .../kernal/processors/portable/package.html     |    23 -
 .../query/GridQueryFieldMetadata.java           |    54 -
 .../processors/query/GridQueryFieldsResult.java |    42 -
 .../query/GridQueryFieldsResultAdapter.java     |    57 -
 .../query/GridQueryIndexDescriptor.java         |    50 -
 .../processors/query/GridQueryIndexType.java    |    32 -
 .../processors/query/GridQueryIndexing.java     |   170 -
 .../processors/query/GridQueryProcessor.java    |  1681 --
 .../query/GridQueryTypeDescriptor.java          |    86 -
 .../resource/GridResourceBasicInjector.java     |    71 -
 .../resource/GridResourceCustomInjector.java    |   555 -
 .../processors/resource/GridResourceField.java  |    71 -
 .../resource/GridResourceInjector.java          |    56 -
 .../processors/resource/GridResourceIoc.java    |   437 -
 .../GridResourceJobContextInjector.java         |    54 -
 .../resource/GridResourceLoggerInjector.java    |    69 -
 .../processors/resource/GridResourceMethod.java |    71 -
 .../resource/GridResourceProcessor.java         |   786 -
 .../resource/GridResourceServiceInjector.java   |    85 -
 .../processors/resource/GridResourceUtils.java  |   104 -
 .../resource/GridSpringResourceContext.java     |    48 -
 .../kernal/processors/resource/package.html     |    23 -
 .../kernal/processors/rest/GridRestCommand.java |   160 -
 .../processors/rest/GridRestProcessor.java      |   697 -
 .../processors/rest/GridRestProtocol.java       |    59 -
 .../rest/GridRestProtocolHandler.java           |    40 -
 .../processors/rest/GridRestResponse.java       |   177 -
 .../message/GridClientAbstractMessage.java      |   117 -
 .../GridClientAuthenticationRequest.java        |    85 -
 .../message/GridClientCacheQueryRequest.java    |   414 -
 .../client/message/GridClientCacheRequest.java  |   319 -
 .../message/GridClientGetMetaDataRequest.java   |    64 -
 .../message/GridClientHandshakeRequest.java     |   108 -
 .../GridClientHandshakeRequestWrapper.java      |   129 -
 .../message/GridClientHandshakeResponse.java    |    66 -
 .../GridClientHandshakeResponseWrapper.java     |    96 -
 .../client/message/GridClientLogRequest.java    |   141 -
 .../rest/client/message/GridClientMessage.java  |    82 -
 .../message/GridClientMessageWrapper.java       |   266 -
 .../message/GridClientMetaDataResponse.java     |    57 -
 .../rest/client/message/GridClientNodeBean.java |   342 -
 .../message/GridClientNodeMetricsBean.java      |  1578 --
 .../client/message/GridClientPingPacket.java    |    37 -
 .../message/GridClientPingPacketWrapper.java    |    89 -
 .../message/GridClientPortableMetaData.java     |    93 -
 .../message/GridClientPutMetaDataRequest.java   |    64 -
 .../rest/client/message/GridClientResponse.java |   145 -
 .../client/message/GridClientTaskRequest.java   |   152 -
 .../message/GridClientTaskResultBean.java       |   147 -
 .../message/GridClientTopologyRequest.java      |   174 -
 .../rest/client/message/GridRouterRequest.java  |    57 -
 .../rest/client/message/GridRouterResponse.java |    84 -
 .../processors/rest/client/message/package.html |    23 -
 .../rest/handlers/GridRestCommandHandler.java   |    40 -
 .../handlers/GridRestCommandHandlerAdapter.java |    51 -
 .../cache/GridCacheClientQueryResult.java       |   119 -
 .../handlers/cache/GridCacheCommandHandler.java |  1159 --
 .../cache/GridCacheQueryCommandHandler.java     |   494 -
 .../handlers/cache/GridCacheRestMetrics.java    |   215 -
 .../handlers/cache/GridCacheRestResponse.java   |    67 -
 .../processors/rest/handlers/cache/package.html |    23 -
 .../handlers/log/GridLogCommandHandler.java     |   307 -
 .../processors/rest/handlers/log/package.html   |    23 -
 .../metadata/GridPortableMetadataHandler.java   |   105 -
 .../processors/rest/handlers/package.html       |    23 -
 .../handlers/task/GridTaskCommandHandler.java   |   639 -
 .../handlers/task/GridTaskResultRequest.java    |   185 -
 .../handlers/task/GridTaskResultResponse.java   |   233 -
 .../top/GridTopologyCommandHandler.java         |   334 -
 .../processors/rest/handlers/top/package.html   |    23 -
 .../version/GridVersionCommandHandler.java      |    60 -
 .../rest/handlers/version/package.html          |    23 -
 .../grid/kernal/processors/rest/package.html    |    23 -
 .../rest/protocols/GridRestProtocolAdapter.java |   197 -
 .../processors/rest/protocols/package.html      |    23 -
 .../protocols/tcp/GridClientPacketType.java     |    32 -
 .../protocols/tcp/GridMemcachedMessage.java     |   485 -
 .../tcp/GridMemcachedMessageWrapper.java        |   269 -
 .../tcp/GridTcpMemcachedNioListener.java        |   443 -
 .../protocols/tcp/GridTcpRestDirectParser.java  |   519 -
 .../protocols/tcp/GridTcpRestNioListener.java   |   387 -
 .../rest/protocols/tcp/GridTcpRestParser.java   |   878 --
 .../rest/protocols/tcp/GridTcpRestProtocol.java |   335 -
 .../processors/rest/protocols/tcp/package.html  |    23 -
 .../rest/request/GridRestCacheQueryRequest.java |   143 -
 .../rest/request/GridRestCacheRequest.java      |   182 -
 .../rest/request/GridRestLogRequest.java        |    81 -
 .../GridRestPortableGetMetaDataRequest.java     |    44 -
 .../GridRestPortablePutMetaDataRequest.java     |    44 -
 .../rest/request/GridRestRequest.java           |   167 -
 .../rest/request/GridRestTaskRequest.java       |   134 -
 .../rest/request/GridRestTopologyRequest.java   |   100 -
 .../kernal/processors/rest/request/package.html |    23 -
 .../schedule/GridNoopScheduleProcessor.java     |    54 -
 .../schedule/GridScheduleProcessorAdapter.java  |    53 -
 .../schedule/GridScheduleStatistics.java        |   182 -
 .../kernal/processors/schedule/package.html     |    24 -
 .../segmentation/GridSegmentationProcessor.java |    51 -
 .../os/GridOsSegmentationProcessor.java         |    39 -
 .../kernal/processors/segmentation/package.html |    23 -
 .../service/GridServiceAssignments.java         |   135 -
 .../service/GridServiceAssignmentsKey.java      |    63 -
 .../service/GridServiceDeployment.java          |    95 -
 .../service/GridServiceDeploymentFuture.java    |    56 -
 .../service/GridServiceDeploymentKey.java       |    63 -
 .../GridServiceMethodNotFoundException.java     |    43 -
 .../service/GridServiceMethodReflectKey.java    |    77 -
 .../service/GridServiceNotFoundException.java   |    40 -
 .../service/GridServiceProcessor.java           |  1290 --
 .../processors/service/GridServiceProxy.java    |   381 -
 .../service/ManagedServiceContextImpl.java      |   156 -
 .../service/ManagedServiceDescriptorImpl.java   |   101 -
 .../session/GridTaskSessionProcessor.java       |   178 -
 .../grid/kernal/processors/session/package.html |    24 -
 .../processors/spring/GridSpringProcessor.java  |    74 -
 .../streamer/GridStreamProcessor.java           |   361 -
 .../streamer/GridStreamerAttributes.java        |   127 -
 .../streamer/GridStreamerCancelRequest.java     |   123 -
 .../streamer/GridStreamerContextDelegate.java   |   106 -
 .../streamer/GridStreamerContextImpl.java       |   205 -
 .../streamer/GridStreamerExecutionBatch.java    |   185 -
 .../streamer/GridStreamerExecutionRequest.java  |   382 -
 .../streamer/GridStreamerResponse.java          |   160 -
 .../GridStreamerRouteFailedException.java       |    36 -
 .../GridStreamerStageExecutionFuture.java       |   363 -
 .../streamer/GridStreamerWindowIterator.java    |    40 -
 .../processors/streamer/IgniteStreamerEx.java   |    96 -
 .../processors/streamer/IgniteStreamerImpl.java |  1416 --
 .../streamer/StreamerMBeanAdapter.java          |   116 -
 .../streamer/StreamerMetricsAdapter.java        |   272 -
 .../streamer/StreamerMetricsHolder.java         |   424 -
 .../streamer/StreamerStageMBeanAdapter.java     |   101 -
 .../streamer/StreamerStageMetricsAdapter.java   |   135 -
 .../streamer/StreamerStageMetricsHolder.java    |   167 -
 .../streamer/StreamerStageWrapper.java          |    92 -
 .../streamer/StreamerWindowMetricsAdapter.java  |    65 -
 .../streamer/StreamerWindowMetricsHolder.java   |    50 -
 .../kernal/processors/streamer/package.html     |    23 -
 .../task/GridStreamerBroadcastTask.java         |   139 -
 .../streamer/task/GridStreamerQueryTask.java    |   142 -
 .../streamer/task/GridStreamerReduceTask.java   |   146 -
 .../kernal/processors/task/GridInternal.java    |    35 -
 .../processors/task/GridTaskEventListener.java  |    55 -
 .../processors/task/GridTaskProcessor.java      |  1296 --
 .../task/GridTaskThreadContextKey.java          |    38 -
 .../kernal/processors/task/GridTaskWorker.java  |  1398 --
 .../grid/kernal/processors/task/package.html    |    23 -
 .../processors/timeout/GridTimeoutObject.java   |    40 -
 .../timeout/GridTimeoutObjectAdapter.java       |    61 -
 .../timeout/GridTimeoutProcessor.java           |   173 -
 .../grid/kernal/processors/timeout/package.html |    23 -
 .../version/GridVersionConverter.java           |    46 -
 .../gridgain/grid/kernal/visor/VisorJob.java    |    77 -
 .../grid/kernal/visor/VisorMultiNodeTask.java   |   127 -
 .../grid/kernal/visor/VisorOneNodeTask.java     |    42 -
 .../grid/kernal/visor/VisorTaskArgument.java    |   106 -
 .../grid/kernal/visor/cache/VisorCache.java     |   485 -
 .../cache/VisorCacheAffinityConfiguration.java  |   171 -
 .../cache/VisorCacheAggregatedMetrics.java      |   471 -
 .../kernal/visor/cache/VisorCacheClearTask.java |    88 -
 .../visor/cache/VisorCacheCompactTask.java      |    86 -
 .../visor/cache/VisorCacheConfiguration.java    |   682 -
 .../cache/VisorCacheDefaultConfiguration.java   |   158 -
 .../visor/cache/VisorCacheDgcConfiguration.java |    97 -
 .../cache/VisorCacheEvictionConfiguration.java  |   215 -
 .../kernal/visor/cache/VisorCacheLoadTask.java  |    88 -
 .../visor/cache/VisorCacheMetadataTask.java     |    76 -
 .../kernal/visor/cache/VisorCacheMetrics.java   |   270 -
 .../cache/VisorCacheMetricsCollectorTask.java   |   112 -
 .../cache/VisorCacheNearConfiguration.java      |   123 -
 .../cache/VisorCachePreloadConfiguration.java   |   155 -
 .../visor/cache/VisorCachePreloadTask.java      |    77 -
 .../visor/cache/VisorCacheQueryMetrics.java     |   102 -
 .../visor/cache/VisorCacheResetMetricsTask.java |    69 -
 .../cache/VisorCacheStoreConfiguration.java     |    90 -
 .../visor/cache/VisorCacheSwapBackupsTask.java  |    90 -
 .../VisorCacheWriteBehindConfiguration.java     |   137 -
 .../compute/VisorComputeCancelSessionsTask.java |    90 -
 .../compute/VisorComputeMonitoringHolder.java   |   118 -
 .../compute/VisorComputeResetMetricsTask.java   |    65 -
 .../VisorComputeToggleMonitoringTask.java       |   112 -
 .../kernal/visor/debug/VisorThreadDumpTask.java |    75 -
 .../kernal/visor/debug/VisorThreadInfo.java     |   328 -
 .../kernal/visor/debug/VisorThreadLockInfo.java |    73 -
 .../visor/debug/VisorThreadMonitorInfo.java     |    72 -
 .../event/VisorGridAuthenticationEvent.java     |   106 -
 .../event/VisorGridAuthorizationEvent.java      |    89 -
 .../visor/event/VisorGridDeploymentEvent.java   |    74 -
 .../visor/event/VisorGridDiscoveryEvent.java    |   100 -
 .../grid/kernal/visor/event/VisorGridEvent.java |   130 -
 .../kernal/visor/event/VisorGridEventsLost.java |    45 -
 .../kernal/visor/event/VisorGridJobEvent.java   |   113 -
 .../visor/event/VisorGridLicenseEvent.java      |    74 -
 .../event/VisorGridSecuritySessionEvent.java    |    91 -
 .../kernal/visor/event/VisorGridTaskEvent.java  |   113 -
 .../grid/kernal/visor/file/VisorFileBlock.java  |   114 -
 .../kernal/visor/file/VisorFileBlockTask.java   |   126 -
 .../visor/file/VisorLatestTextFilesTask.java    |    98 -
 .../grid/kernal/visor/ggfs/VisorGgfs.java       |   114 -
 .../kernal/visor/ggfs/VisorGgfsEndpoint.java    |   106 -
 .../kernal/visor/ggfs/VisorGgfsFormatTask.java  |    70 -
 .../kernal/visor/ggfs/VisorGgfsMetrics.java     |   350 -
 .../kernal/visor/ggfs/VisorGgfsProfiler.java    |    88 -
 .../visor/ggfs/VisorGgfsProfilerClearTask.java  |   112 -
 .../visor/ggfs/VisorGgfsProfilerEntry.java      |   238 -
 .../visor/ggfs/VisorGgfsProfilerTask.java       |   504 -
 .../VisorGgfsProfilerUniformityCounters.java    |   197 -
 .../visor/ggfs/VisorGgfsResetMetricsTask.java   |    73 -
 .../visor/ggfs/VisorGgfsSamplingStateTask.java  |    74 -
 .../grid/kernal/visor/log/VisorLogFile.java     |    87 -
 .../kernal/visor/log/VisorLogSearchResult.java  |   156 -
 .../kernal/visor/log/VisorLogSearchTask.java    |   270 -
 .../grid/kernal/visor/misc/VisorAckTask.java    |    76 -
 .../visor/misc/VisorLatestVersionTask.java      |    63 -
 .../grid/kernal/visor/misc/VisorNopTask.java    |    90 -
 .../visor/misc/VisorResolveHostNameTask.java    |   104 -
 .../visor/node/VisorBasicConfiguration.java     |   451 -
 .../visor/node/VisorEmailConfiguration.java     |   177 -
 .../node/VisorExecutorServiceConfiguration.java |   200 -
 .../visor/node/VisorGgfsConfiguration.java      |   573 -
 .../visor/node/VisorGridConfiguration.java      |   361 -
 .../visor/node/VisorLifecycleConfiguration.java |    87 -
 .../visor/node/VisorMetricsConfiguration.java   |    95 -
 .../VisorNodeConfigurationCollectorJob.java     |    47 -
 .../VisorNodeConfigurationCollectorTask.java    |    35 -
 .../visor/node/VisorNodeDataCollectorJob.java   |   219 -
 .../node/VisorNodeDataCollectorJobResult.java   |   158 -
 .../visor/node/VisorNodeDataCollectorTask.java  |   127 -
 .../node/VisorNodeDataCollectorTaskArg.java     |   140 -
 .../node/VisorNodeDataCollectorTaskResult.java  |   184 -
 .../node/VisorNodeEventsCollectorTask.java      |   365 -
 .../grid/kernal/visor/node/VisorNodeGcTask.java |   100 -
 .../kernal/visor/node/VisorNodePingTask.java    |    81 -
 .../kernal/visor/node/VisorNodeRestartTask.java |    79 -
 .../kernal/visor/node/VisorNodeStopTask.java    |    79 -
 .../node/VisorPeerToPeerConfiguration.java      |   105 -
 .../visor/node/VisorRestConfiguration.java      |   221 -
 .../node/VisorSegmentationConfiguration.java    |   141 -
 .../visor/node/VisorSpisConfiguration.java      |   334 -
 .../visor/portable/VisorPortableMetadata.java   |    72 -
 .../VisorPortableMetadataCollectorTask.java     |    95 -
 .../portable/VisorPortableMetadataField.java    |    71 -
 .../visor/query/VisorQueryCleanupTask.java      |   102 -
 .../kernal/visor/query/VisorQueryField.java     |    66 -
 .../visor/query/VisorQueryNextPageTask.java     |   117 -
 .../kernal/visor/query/VisorQueryResult.java    |    79 -
 .../kernal/visor/query/VisorQueryResultEx.java  |    88 -
 .../grid/kernal/visor/query/VisorQueryTask.java |   310 -
 .../kernal/visor/query/VisorQueryUtils.java     |   204 -
 .../kernal/visor/streamer/VisorStreamer.java    |   104 -
 .../streamer/VisorStreamerConfiguration.java    |   178 -
 .../visor/streamer/VisorStreamerMetrics.java    |   350 -
 .../streamer/VisorStreamerMetricsResetTask.java |    76 -
 .../visor/streamer/VisorStreamerResetTask.java  |    76 -
 .../streamer/VisorStreamerStageMetrics.java     |   277 -
 .../grid/kernal/visor/util/VisorMimeTypes.java  |  1004 --
 .../grid/kernal/visor/util/VisorTaskUtils.java  |   831 -
 .../main/java/org/gridgain/grid/package.html    |    23 -
 .../main/java/org/gridgain/grid/util/F0.java    |   368 -
 .../grid/util/GridAnnotationsCache.java         |    84 -
 .../gridgain/grid/util/GridArgumentCheck.java   |   149 -
 .../grid/util/GridAtomicInitializer.java        |   113 -
 .../gridgain/grid/util/GridAtomicInteger.java   |   249 -
 .../org/gridgain/grid/util/GridAtomicLong.java  |   249 -
 .../GridBoundedConcurrentLinkedHashMap.java     |   124 -
 .../GridBoundedConcurrentLinkedHashSet.java     |   162 -
 .../util/GridBoundedConcurrentOrderedMap.java   |   242 -
 .../util/GridBoundedConcurrentOrderedSet.java   |   179 -
 .../grid/util/GridBoundedLinkedHashMap.java     |   129 -
 .../grid/util/GridBoundedLinkedHashSet.java     |   207 -
 .../org/gridgain/grid/util/GridBusyLock.java    |    83 -
 .../gridgain/grid/util/GridByteArrayList.java   |   412 -
 .../gridgain/grid/util/GridCircularBuffer.java  |   230 -
 .../grid/util/GridClassLoaderCache.java         |   131 -
 .../gridgain/grid/util/GridClientByteUtils.java |   238 -
 .../grid/util/GridCloseableIteratorAdapter.java |   110 -
 .../util/GridCloseableIteratorAdapterEx.java    |   127 -
 .../org/gridgain/grid/util/GridCollections.java |   644 -
 .../grid/util/GridConcurrentFactory.java        |   109 -
 .../grid/util/GridConcurrentHashSet.java        |   119 -
 .../grid/util/GridConcurrentLinkedHashSet.java  |   131 -
 .../grid/util/GridConcurrentPhantomHashSet.java |   402 -
 .../grid/util/GridConcurrentSkipListSet.java    |   302 -
 .../grid/util/GridConcurrentWeakHashSet.java    |   402 -
 .../grid/util/GridConfigurationFinder.java      |   151 -
 .../gridgain/grid/util/GridConsistentHash.java  |   672 -
 .../java/org/gridgain/grid/util/GridDebug.java  |   303 -
 .../grid/util/GridEmptyCloseableIterator.java   |    42 -
 .../gridgain/grid/util/GridEmptyIterator.java   |    51 -
 .../org/gridgain/grid/util/GridEnumCache.java   |    57 -
 .../grid/util/GridExecutionStatistics.java      |   105 -
 .../grid/util/GridFixedSizeInputStream.java     |    85 -
 .../org/gridgain/grid/util/GridHandleTable.java |   198 -
 .../gridgain/grid/util/GridIdentityHashSet.java |    63 -
 .../org/gridgain/grid/util/GridJavaProcess.java |   259 -
 .../org/gridgain/grid/util/GridKeyLock.java     |   154 -
 .../org/gridgain/grid/util/GridLeanMap.java     |  1266 --
 .../org/gridgain/grid/util/GridLeanSet.java     |    83 -
 .../org/gridgain/grid/util/GridListSet.java     |   529 -
 .../org/gridgain/grid/util/GridLogThrottle.java |   221 -
 .../org/gridgain/grid/util/GridLongList.java    |   500 -
 .../java/org/gridgain/grid/util/GridMutex.java  |    55 -
 .../java/org/gridgain/grid/util/GridQueue.java  |   348 -
 .../java/org/gridgain/grid/util/GridRandom.java |    57 -
 .../gridgain/grid/util/GridReflectionCache.java |   250 -
 .../grid/util/GridSerializableCollection.java   |    33 -
 .../grid/util/GridSerializableFuture.java       |    28 -
 .../grid/util/GridSerializableIterable.java     |    28 -
 .../grid/util/GridSerializableIterator.java     |    29 -
 .../grid/util/GridSerializableList.java         |    33 -
 .../gridgain/grid/util/GridSerializableMap.java |    37 -
 .../gridgain/grid/util/GridSerializableSet.java |    37 -
 .../org/gridgain/grid/util/GridSetWrapper.java  |   136 -
 .../gridgain/grid/util/GridSnapshotLock.java    |   219 -
 .../util/GridSpiCloseableIteratorWrapper.java   |    57 -
 .../gridgain/grid/util/GridSpinBusyLock.java    |    84 -
 .../grid/util/GridSpinReadWriteLock.java        |   413 -
 .../gridgain/grid/util/GridStringBuilder.java   |   447 -
 .../grid/util/GridStringBuilderFactory.java     |    98 -
 .../org/gridgain/grid/util/GridStripedLock.java |   143 -
 .../grid/util/GridStripedReadWriteLock.java     |   100 -
 .../gridgain/grid/util/GridSynchronizedMap.java |   100 -
 .../org/gridgain/grid/util/GridThreadLocal.java |   175 -
 .../gridgain/grid/util/GridThreadLocalEx.java   |   210 -
 .../java/org/gridgain/grid/util/GridTimer.java  |   154 -
 .../org/gridgain/grid/util/GridTimerTask.java   |    40 -
 .../java/org/gridgain/grid/util/GridUnsafe.java |    61 -
 .../java/org/gridgain/grid/util/GridUtils.java  |  9120 -----------
 .../org/gridgain/grid/util/GridUuidCache.java   |    59 -
 .../gridgain/grid/util/GridWeakIterator.java    |    55 -
 .../GridTcpCommunicationMessageAdapter.java     |   217 -
 .../GridTcpCommunicationMessageFactory.java     |   359 -
 .../GridTcpCommunicationMessageProducer.java    |    31 -
 .../GridTcpCommunicationMessageState.java       |  1598 --
 .../grid/util/direct/GridTcpMessageFactory.java |    29 -
 .../grid/util/future/GridCompoundFuture.java    |   383 -
 .../util/future/GridCompoundIdentityFuture.java |    68 -
 .../grid/util/future/GridEmbeddedFuture.java    |   322 -
 .../grid/util/future/GridFinishedFuture.java    |   225 -
 .../grid/util/future/GridFinishedFutureEx.java  |   196 -
 .../grid/util/future/GridFutureAdapter.java     |   627 -
 .../grid/util/future/GridFutureAdapterEx.java   |   516 -
 .../util/future/GridFutureChainListener.java    |    72 -
 .../org/gridgain/grid/util/future/package.html  |    23 -
 .../util/gridify/GridifyArgumentBuilder.java    |   186 -
 .../grid/util/gridify/GridifyJobAdapter.java    |   107 -
 .../grid/util/gridify/GridifyRangeArgument.java |   103 -
 .../grid/util/gridify/GridifyUtils.java         |   521 -
 .../org/gridgain/grid/util/gridify/package.html |    23 -
 .../grid/util/io/GridByteArrayInputStream.java  |   209 -
 .../grid/util/io/GridByteArrayOutputStream.java |   167 -
 .../gridgain/grid/util/io/GridDataInput.java    |   132 -
 .../gridgain/grid/util/io/GridDataOutput.java   |   119 -
 .../grid/util/io/GridFilenameUtils.java         |  1560 --
 .../util/io/GridReversedLinesFileReader.java    |   333 -
 .../grid/util/io/GridUnsafeDataInput.java       |   603 -
 .../grid/util/io/GridUnsafeDataOutput.java      |   500 -
 .../gridgain/grid/util/ipc/GridIpcEndpoint.java |    49 -
 .../util/ipc/GridIpcEndpointBindException.java  |    47 -
 .../grid/util/ipc/GridIpcEndpointFactory.java   |    85 -
 .../grid/util/ipc/GridIpcEndpointType.java      |    29 -
 .../grid/util/ipc/GridIpcServerEndpoint.java    |    73 -
 .../ipc/GridIpcServerEndpointDeserializer.java  |    66 -
 .../grid/util/ipc/GridIpcToNioAdapter.java      |   251 -
 .../ipc/loopback/GridIpcClientTcpEndpoint.java  |    87 -
 .../ipc/loopback/GridIpcServerTcpEndpoint.java  |   180 -
 .../grid/util/ipc/loopback/package.html         |    23 -
 .../org/gridgain/grid/util/ipc/package.html     |    23 -
 .../GridIpcOutOfSystemResourcesException.java   |    59 -
 .../GridIpcSharedMemoryClientEndpoint.java      |   337 -
 .../shmem/GridIpcSharedMemoryInitRequest.java   |    67 -
 .../shmem/GridIpcSharedMemoryInitResponse.java  |   171 -
 .../shmem/GridIpcSharedMemoryInputStream.java   |    99 -
 .../shmem/GridIpcSharedMemoryNativeLoader.java  |   243 -
 ...cSharedMemoryOperationTimedoutException.java |    59 -
 .../shmem/GridIpcSharedMemoryOutputStream.java  |    80 -
 .../GridIpcSharedMemoryServerEndpoint.java      |   691 -
 .../ipc/shmem/GridIpcSharedMemorySpace.java     |   374 -
 .../ipc/shmem/GridIpcSharedMemoryUtils.java     |   242 -
 .../gridgain/grid/util/ipc/shmem/package.html   |    23 -
 .../gridgain/grid/util/lang/GridAbsClosure.java |    52 -
 .../grid/util/lang/GridAbsClosureX.java         |    48 -
 .../grid/util/lang/GridAbsPredicate.java        |    44 -
 .../grid/util/lang/GridAbsPredicateX.java       |    46 -
 .../grid/util/lang/GridCloseableIterator.java   |    62 -
 .../gridgain/grid/util/lang/GridClosure3.java   |    52 -
 .../gridgain/grid/util/lang/GridClosure3X.java  |    51 -
 .../grid/util/lang/GridClosureException.java    |    50 -
 .../grid/util/lang/GridComputeJobWrapper.java   |   106 -
 .../grid/util/lang/GridFilteredIterator.java    |    87 -
 .../org/gridgain/grid/util/lang/GridFunc.java   |  8755 -----------
 .../gridgain/grid/util/lang/GridInClosure3.java |    49 -
 .../grid/util/lang/GridInClosure3X.java         |    50 -
 .../gridgain/grid/util/lang/GridIterable.java   |    35 -
 .../grid/util/lang/GridIterableAdapter.java     |   120 -
 .../gridgain/grid/util/lang/GridIterator.java   |    67 -
 .../grid/util/lang/GridIteratorAdapter.java     |    66 -
 .../gridgain/grid/util/lang/GridMapEntry.java   |    92 -
 .../util/lang/GridMetadataAwareAdapter.java     |   344 -
 .../grid/util/lang/GridNodePredicate.java       |   156 -
 .../grid/util/lang/GridPeerDeployAware.java     |    52 -
 .../util/lang/GridPeerDeployAwareAdapter.java   |    69 -
 .../grid/util/lang/GridPlainAbsClosure.java     |    33 -
 .../grid/util/lang/GridPlainCallable.java       |    27 -
 .../grid/util/lang/GridPlainClosure.java        |    32 -
 .../grid/util/lang/GridPlainClosure2.java       |    33 -
 .../grid/util/lang/GridPlainFuture.java         |    79 -
 .../grid/util/lang/GridPlainFutureAdapter.java  |   299 -
 .../grid/util/lang/GridPlainInClosure.java      |    31 -
 .../grid/util/lang/GridPlainOutClosure.java     |    31 -
 .../grid/util/lang/GridPlainRunnable.java       |    25 -
 .../gridgain/grid/util/lang/GridPredicate3.java |    57 -
 .../grid/util/lang/GridPredicate3X.java         |    51 -
 .../org/gridgain/grid/util/lang/GridTriple.java |    54 -
 .../org/gridgain/grid/util/lang/GridTuple.java  |   147 -
 .../org/gridgain/grid/util/lang/GridTuple3.java |   226 -
 .../org/gridgain/grid/util/lang/GridTuple4.java |   257 -
 .../org/gridgain/grid/util/lang/GridTuple5.java |   288 -
 .../org/gridgain/grid/util/lang/GridTuple6.java |   322 -
 .../org/gridgain/grid/util/lang/GridTupleV.java |   189 -
 .../grid/util/lang/IgniteClosure2X.java         |    53 -
 .../gridgain/grid/util/lang/IgniteClosureX.java |    52 -
 .../grid/util/lang/IgniteInClosure2X.java       |    52 -
 .../grid/util/lang/IgniteInClosureX.java        |    51 -
 .../grid/util/lang/IgniteOutClosureX.java       |    50 -
 .../org/gridgain/grid/util/lang/IgnitePair.java |    53 -
 .../grid/util/lang/IgnitePredicate2X.java       |    53 -
 .../grid/util/lang/IgnitePredicateX.java        |    52 -
 .../gridgain/grid/util/lang/IgniteReducer2.java |    53 -
 .../grid/util/lang/IgniteReducer2X.java         |    50 -
 .../gridgain/grid/util/lang/IgniteReducer3.java |    55 -
 .../grid/util/lang/IgniteReducer3X.java         |    50 -
 .../gridgain/grid/util/lang/IgniteReducerX.java |    51 -
 .../nio/GridAbstractCommunicationClient.java    |   112 -
 .../grid/util/nio/GridBufferedParser.java       |    96 -
 .../grid/util/nio/GridCommunicationClient.java  |   112 -
 .../nio/GridConnectionBytesVerifyFilter.java    |   140 -
 .../grid/util/nio/GridDirectParser.java         |    84 -
 .../grid/util/nio/GridNioAsyncNotifyFilter.java |   142 -
 .../util/nio/GridNioBackPressureControl.java    |    56 -
 .../grid/util/nio/GridNioCodecFilter.java       |   140 -
 .../grid/util/nio/GridNioEmbeddedFuture.java    |    72 -
 .../grid/util/nio/GridNioException.java         |    58 -
 .../gridgain/grid/util/nio/GridNioFilter.java   |   244 -
 .../grid/util/nio/GridNioFilterAdapter.java     |   183 -
 .../grid/util/nio/GridNioFilterChain.java       |   293 -
 .../grid/util/nio/GridNioFinishedFuture.java    |   116 -
 .../gridgain/grid/util/nio/GridNioFuture.java   |   121 -
 .../grid/util/nio/GridNioFutureImpl.java        |   327 -
 .../grid/util/nio/GridNioMessageReader.java     |    42 -
 .../grid/util/nio/GridNioMessageTracker.java    |   121 -
 .../grid/util/nio/GridNioMessageWriter.java     |    49 -
 .../grid/util/nio/GridNioMetricsListener.java   |    33 -
 .../gridgain/grid/util/nio/GridNioParser.java   |    62 -
 .../util/nio/GridNioRecoveryDescriptor.java     |   364 -
 .../gridgain/grid/util/nio/GridNioServer.java   |  2306 ---
 .../grid/util/nio/GridNioServerBuffer.java      |   117 -
 .../grid/util/nio/GridNioServerListener.java    |    64 -
 .../util/nio/GridNioServerListenerAdapter.java  |    33 -
 .../gridgain/grid/util/nio/GridNioSession.java  |   168 -
 .../grid/util/nio/GridNioSessionImpl.java       |   312 -
 .../grid/util/nio/GridNioSessionMetaKey.java    |    66 -
 .../util/nio/GridSelectorNioSessionImpl.java    |   297 -
 .../util/nio/GridShmemCommunicationClient.java  |   149 -
 .../util/nio/GridTcpCommunicationClient.java    |   555 -
 .../util/nio/GridTcpNioCommunicationClient.java |   163 -
 .../org/gridgain/grid/util/nio/package.html     |    23 -
 .../grid/util/nio/ssl/GridNioSslFilter.java     |   419 -
 .../grid/util/nio/ssl/GridNioSslHandler.java    |   616 -
 .../org/gridgain/grid/util/nio/ssl/package.html |    23 -
 .../grid/util/nodestart/GridNodeCallable.java   |    29 -
 .../grid/util/nodestart/GridNodeStartUtils.java |   391 -
 .../nodestart/GridRemoteStartSpecification.java |   279 -
 .../grid/util/nodestart/GridSshProcessor.java   |    34 -
 .../grid/util/offheap/GridOffHeapEvent.java     |    47 -
 .../util/offheap/GridOffHeapEventListener.java  |    26 -
 .../util/offheap/GridOffHeapEvictListener.java  |    33 -
 .../grid/util/offheap/GridOffHeapMap.java       |   200 -
 .../util/offheap/GridOffHeapMapFactory.java     |   225 -
 .../GridOffHeapOutOfMemoryException.java        |    50 -
 .../util/offheap/GridOffHeapPartitionedMap.java |   218 -
 .../offheap/unsafe/GridOffHeapSmartPointer.java |    38 -
 .../unsafe/GridOffHeapSmartPointerFactory.java  |    29 -
 .../offheap/unsafe/GridOffHeapSnapTreeMap.java  |  4457 ------
 .../unsafe/GridUnsafeCompoundMemory.java        |    35 -
 .../util/offheap/unsafe/GridUnsafeGuard.java    |   374 -
 .../grid/util/offheap/unsafe/GridUnsafeLru.java |   627 -
 .../offheap/unsafe/GridUnsafeLruPoller.java     |    30 -
 .../grid/util/offheap/unsafe/GridUnsafeMap.java |  1743 ---
 .../util/offheap/unsafe/GridUnsafeMemory.java   |   721 -
 .../unsafe/GridUnsafePartitionedMap.java        |   424 -
 .../java/org/gridgain/grid/util/package.html    |    24 -
 .../grid/util/portable/PortableRawReaderEx.java |    32 -
 .../grid/util/portable/PortableRawWriterEx.java |    43 -
 .../util/portscanner/GridJmxPortFinder.java     |   176 -
 .../gridgain/grid/util/portscanner/package.html |    23 -
 .../java/org/gridgain/grid/util/scala/impl.java |    35 -
 .../org/gridgain/grid/util/scala/package.html   |    24 -
 .../grid/util/snaptree/CopyOnWriteManager.java  |   390 -
 .../org/gridgain/grid/util/snaptree/Epoch.java  |   131 -
 .../gridgain/grid/util/snaptree/EpochNode.java  |   432 -
 .../grid/util/snaptree/SnapTreeMap.java         |  2897 ----
 .../gridgain/grid/util/snaptree/package.html    |    24 -
 .../grid/util/test/GridTestPrintStream.java     |   293 -
 .../util/test/GridTestPrintStreamFactory.java   |   128 -
 .../org/gridgain/grid/util/test/package.html    |    24 -
 .../grid/util/tostring/GridToStringBuilder.java |   588 -
 .../tostring/GridToStringClassDescriptor.java   |    85 -
 .../grid/util/tostring/GridToStringExclude.java |    32 -
 .../tostring/GridToStringFieldDescriptor.java   |    53 -
 .../grid/util/tostring/GridToStringInclude.java |    32 -
 .../grid/util/tostring/GridToStringOrder.java   |    37 -
 .../util/tostring/GridToStringThreadLocal.java  |    55 -
 .../gridgain/grid/util/tostring/package.html    |    23 -
 .../java/org/gridgain/grid/util/typedef/C1.java |    32 -
 .../java/org/gridgain/grid/util/typedef/C2.java |    33 -
 .../java/org/gridgain/grid/util/typedef/C3.java |    35 -
 .../java/org/gridgain/grid/util/typedef/CA.java |    32 -
 .../org/gridgain/grid/util/typedef/CAX.java     |    32 -
 .../org/gridgain/grid/util/typedef/CI1.java     |    31 -
 .../org/gridgain/grid/util/typedef/CI2.java     |    32 -
 .../org/gridgain/grid/util/typedef/CI3.java     |    32 -
 .../org/gridgain/grid/util/typedef/CIX1.java    |    33 -
 .../org/gridgain/grid/util/typedef/CIX2.java    |    32 -
 .../org/gridgain/grid/util/typedef/CIX3.java    |    29 -
 .../java/org/gridgain/grid/util/typedef/CO.java |    31 -
 .../org/gridgain/grid/util/typedef/COX.java     |    33 -
 .../org/gridgain/grid/util/typedef/CX1.java     |    34 -
 .../org/gridgain/grid/util/typedef/CX2.java     |    35 -
 .../org/gridgain/grid/util/typedef/CX3.java     |    33 -
 .../java/org/gridgain/grid/util/typedef/F.java  |    29 -
 .../java/org/gridgain/grid/util/typedef/G.java  |    29 -
 .../java/org/gridgain/grid/util/typedef/P1.java |    31 -
 .../java/org/gridgain/grid/util/typedef/P2.java |    32 -
 .../java/org/gridgain/grid/util/typedef/P3.java |    32 -
 .../java/org/gridgain/grid/util/typedef/PA.java |    29 -
 .../org/gridgain/grid/util/typedef/PAX.java     |    29 -
 .../org/gridgain/grid/util/typedef/PCE.java     |    33 -
 .../java/org/gridgain/grid/util/typedef/PE.java |    33 -
 .../org/gridgain/grid/util/typedef/PKV.java     |    31 -
 .../java/org/gridgain/grid/util/typedef/PN.java |    33 -
 .../org/gridgain/grid/util/typedef/PX1.java     |    33 -
 .../org/gridgain/grid/util/typedef/PX2.java     |    34 -
 .../org/gridgain/grid/util/typedef/PX3.java     |    32 -
 .../java/org/gridgain/grid/util/typedef/R1.java |    32 -
 .../java/org/gridgain/grid/util/typedef/R2.java |    31 -
 .../java/org/gridgain/grid/util/typedef/R3.java |    31 -
 .../org/gridgain/grid/util/typedef/RX1.java     |    34 -
 .../org/gridgain/grid/util/typedef/RX2.java     |    34 -
 .../org/gridgain/grid/util/typedef/RX3.java     |    34 -
 .../java/org/gridgain/grid/util/typedef/T1.java |    51 -
 .../java/org/gridgain/grid/util/typedef/T2.java |    52 -
 .../java/org/gridgain/grid/util/typedef/T3.java |    52 -
 .../java/org/gridgain/grid/util/typedef/T4.java |    53 -
 .../java/org/gridgain/grid/util/typedef/T5.java |    54 -
 .../java/org/gridgain/grid/util/typedef/T6.java |    55 -
 .../java/org/gridgain/grid/util/typedef/X.java  |   937 --
 .../gridgain/grid/util/typedef/internal/A.java  |    28 -
 .../gridgain/grid/util/typedef/internal/CU.java |    30 -
 .../gridgain/grid/util/typedef/internal/D.java  |    28 -
 .../grid/util/typedef/internal/GPC.java         |    27 -
 .../grid/util/typedef/internal/GPR.java         |    27 -
 .../gridgain/grid/util/typedef/internal/LT.java |    28 -
 .../gridgain/grid/util/typedef/internal/S.java  |    28 -
 .../gridgain/grid/util/typedef/internal/SB.java |    63 -
 .../gridgain/grid/util/typedef/internal/U.java  |    28 -
 .../grid/util/typedef/internal/package.html     |    23 -
 .../org/gridgain/grid/util/typedef/package.html |    23 -
 .../gridgain/grid/util/worker/GridWorker.java   |   305 -
 .../grid/util/worker/GridWorkerFuture.java      |    70 -
 .../grid/util/worker/GridWorkerListener.java    |    35 -
 .../util/worker/GridWorkerListenerAdapter.java  |    33 -
 .../grid/util/worker/GridWorkerPool.java        |   117 -
 .../org/gridgain/grid/util/worker/package.html  |    24 -
 .../org/gridgain/jdbc/GridJdbcConnection.java   |   547 -
 .../gridgain/jdbc/GridJdbcConnectionInfo.java   |    91 -
 .../gridgain/jdbc/GridJdbcDatabaseMetadata.java |  1314 --
 .../java/org/gridgain/jdbc/GridJdbcDriver.java  |   483 -
 .../jdbc/GridJdbcPreparedStatement.java         |   411 -
 .../org/gridgain/jdbc/GridJdbcResultSet.java    |  1520 --
 .../jdbc/GridJdbcResultSetMetadata.java         |   172 -
 .../org/gridgain/jdbc/GridJdbcStatement.java    |   449 -
 .../main/java/org/gridgain/jdbc/package.html    |    23 -
 .../main/java/org/gridgain/jdbc/typedef/JU.java |    28 -
 .../java/org/gridgain/jdbc/typedef/package.html |    23 -
 .../org/gridgain/jdbc/util/GridJdbcUtils.java   |   233 -
 .../java/org/gridgain/jdbc/util/package.html    |    23 -
 .../org/jdk8/backport/ConcurrentHashMap8.java   |  3825 +++++
 .../jdk8/backport/ConcurrentLinkedDeque8.java   |  1983 +++
 .../jdk8/backport/ConcurrentLinkedHashMap.java  |  2170 +++
 .../main/java/org/jdk8/backport/LongAdder.java  |   235 +
 .../main/java/org/jdk8/backport/Striped64.java  |   370 +
 .../org/jdk8/backport/ThreadLocalRandom8.java   |   231 +
 .../META-INF/licenses/gnu-gplv2ce-license.txt   |   349 +
 .../core/src/main/resources/gridgain.properties |    22 -
 .../core/src/main/resources/ignite.properties   |    22 +
 .../core/src/test/bin/start-nodes-custom.bat    |    30 +-
 modules/core/src/test/bin/start-nodes-custom.sh |    28 +-
 .../spring-cache-client-benchmark-1.xml         |    28 +-
 .../spring-cache-client-benchmark-2.xml         |    22 +-
 .../spring-cache-client-benchmark-3.xml         |    22 +-
 .../test/config/default-spring-url-testing.xml  |     6 +-
 .../core/src/test/config/discovery-stress.xml   |     6 +-
 modules/core/src/test/config/example-cache.xml  |    22 +-
 modules/core/src/test/config/ggfs-loopback.xml  |   198 -
 .../core/src/test/config/ggfs-no-endpoint.xml   |   199 -
 modules/core/src/test/config/ggfs-shmem.xml     |   198 -
 .../hadoop/core-site-loopback-secondary.xml     |    18 +-
 .../test/config/hadoop/core-site-loopback.xml   |    14 +-
 .../test/config/hadoop/core-site-secondary.xml  |    14 +-
 .../core/src/test/config/hadoop/core-site.xml   |    12 +-
 modules/core/src/test/config/igfs-loopback.xml  |   167 +
 modules/core/src/test/config/igfs-shmem.xml     |   167 +
 .../src/test/config/io-manager-benchmark.xml    |     8 +-
 .../src/test/config/job-loadtest/client.xml     |    44 +-
 .../src/test/config/job-loadtest/server.xml     |    18 +-
 modules/core/src/test/config/jobs-load-base.xml |    36 +-
 .../core/src/test/config/jobs-load-client.xml   |     4 +-
 .../core/src/test/config/jobs-load-server.xml   |     4 +-
 .../src/test/config/load/cache-benchmark.xml    |    16 +-
 .../test/config/load/cache-client-benchmark.xml |    16 +-
 .../config/load/dsi-49-server-production.xml    |    13 +-
 .../core/src/test/config/load/dsi-load-base.xml |    46 +-
 .../src/test/config/load/dsi-load-client.xml    |     6 +-
 .../src/test/config/load/dsi-load-server.xml    |    10 +-
 .../src/test/config/load/merge-sort-base.xml    |    51 +-
 .../test/config/load/mongo-multinode-foster.xml |   170 -
 .../test/config/loaders/grid-cfg-2-grids.xml    |     8 +-
 .../core/src/test/config/loaders/grid-cfg.xml   |     8 +-
 modules/core/src/test/config/log4j-test.xml     |    12 +-
 .../core/src/test/config/spring-cache-load.xml  |    14 +-
 .../config/spring-cache-put-remove-load.xml     |     8 +-
 .../core/src/test/config/spring-cache-swap.xml  |     8 +-
 .../src/test/config/spring-cache-teststore.xml  |    10 +-
 .../core/src/test/config/spring-multicache.xml  |    85 +-
 .../src/test/config/spring-start-nodes-attr.xml |     8 +-
 .../core/src/test/config/spring-start-nodes.xml |     8 +-
 modules/core/src/test/config/start-nodes.ini    |     6 +-
 .../core/src/test/config/store/jdbc/Ignite.xml  |   153 +
 .../average/spring-streamer-average-base.xml    |    22 +-
 .../average/spring-streamer-average-local.xml   |    12 +-
 .../average/spring-streamer-average-random.xml  |    12 +-
 .../config/streamer/spring-streamer-base.xml    |    14 +-
 modules/core/src/test/config/tests.properties   |    18 +-
 .../test/config/websession/spring-cache-1.xml   |    10 +-
 .../test/config/websession/spring-cache-2.xml   |    10 +-
 .../test/config/websession/spring-cache-3.xml   |    10 +-
 .../GridCacheAffinityBackupsSelfTest.java       |   112 +
 .../ignite/GridSuppressedExceptionSelfTest.java |   140 +
 .../java/org/apache/ignite/GridTestIoUtils.java |   198 +
 .../java/org/apache/ignite/GridTestJob.java     |    50 +
 .../org/apache/ignite/GridTestJobContext.java   |    93 +
 .../org/apache/ignite/GridTestJobResult.java    |    95 +
 .../org/apache/ignite/GridTestNodeStartup.java  |    49 +
 .../apache/ignite/GridTestStoreNodeStartup.java |    57 +
 .../java/org/apache/ignite/GridTestTask.java    |    53 +
 .../org/apache/ignite/GridTestTaskSession.java  |   233 +
 .../ignite/IgniteCacheAffinitySelfTest.java     |   283 +
 .../IgniteExternalizableAbstractTest.java       |    42 +
 ...CachePartitionFairAffinityNodesSelfTest.java |   242 +
 .../GridCachePartitionFairAffinitySelfTest.java |   261 +
 .../store/GridCacheBalancingStoreSelfTest.java  |   201 +
 .../GridCacheLoadOnlyStoreAdapterSelfTest.java  |   114 +
 .../cache/store/GridGeneratingTestStore.java    |   101 +
 .../CacheJdbcPojoStoreMultitreadedSelfTest.java |    35 +
 .../store/jdbc/CacheJdbcPojoStoreTest.java      |   763 +
 ...eJdbcStoreAbstractMultithreadedSelfTest.java |   280 +
 ...CacheJdbcBlobStoreMultithreadedSelfTest.java |   250 +
 .../jdbc/GridCacheJdbcBlobStoreSelfTest.java    |    51 +
 .../cache/store/jdbc/model/Organization.java    |   155 +
 .../cache/store/jdbc/model/OrganizationKey.java |    97 +
 .../ignite/cache/store/jdbc/model/Person.java   |   155 +
 .../store/jdbc/model/PersonComplexKey.java      |   146 +
 .../cache/store/jdbc/model/PersonKey.java       |    97 +
 .../ignite/cache/store/jdbc/model/package.html  |    24 +
 .../apache/ignite/cache/store/jdbc/package.html |    24 +
 .../org/apache/ignite/cache/store/package.html  |    24 +
 .../ignite/igfs/IgfsEventsAbstractSelfTest.java |   848 +
 .../igfs/IgfsFragmentizerAbstractSelfTest.java  |   168 +
 .../ignite/igfs/IgfsFragmentizerSelfTest.java   |   268 +
 .../igfs/IgfsFragmentizerTopologySelfTest.java  |    49 +
 .../apache/ignite/igfs/IgfsPathSelfTest.java    |   162 +
 .../ignite/igfs/IgfsTestInputGenerator.java     |    51 +
 .../ignite/internal/ClusterMetricsSelfTest.java |   233 +
 .../internal/ClusterNodeMetricsSelfTest.java    |   261 +
 .../ignite/internal/GridAffinityMappedTest.java |   163 +
 .../internal/GridAffinityP2PSelfTest.java       |   204 +
 .../ignite/internal/GridAffinitySelfTest.java   |   117 +
 .../GridAlwaysFailoverSpiFailSelfTest.java      |   159 +
 .../internal/GridCacheProjectionRemoveTest.java |    41 +
 .../internal/GridCancelOnGridStopSelfTest.java  |   106 +
 .../internal/GridCancelUnusedJobSelfTest.java   |   213 +
 .../GridCancelledJobsMetricsSelfTest.java       |   214 +
 .../GridCollisionJobsContextSelfTest.java       |   113 +
 .../internal/GridCommunicationSelfTest.java     |   121 +
 .../GridContinuousJobAnnotationSelfTest.java    |   215 +
 .../GridContinuousJobSiblingsSelfTest.java      |   144 +
 .../internal/GridContinuousTaskSelfTest.java    |   348 +
 .../GridDeploymentMultiThreadedSelfTest.java    |   121 +
 .../ignite/internal/GridDeploymentSelfTest.java |   534 +
 .../internal/GridDiscoveryEventSelfTest.java    |   420 +
 .../ignite/internal/GridDiscoverySelfTest.java  |   417 +
 .../GridEventStorageCheckAllEventsSelfTest.java |   433 +
 ...ventStorageRuntimeConfigurationSelfTest.java |   347 +
 .../internal/GridEventStorageSelfTest.java      |   268 +
 .../internal/GridFactoryVmShutdownTest.java     |    97 +
 .../GridFailedInputParametersSelfTest.java      |   154 +
 .../GridFailoverCustomTopologySelfTest.java     |   188 +
 .../ignite/internal/GridFailoverSelfTest.java   |   151 +
 .../GridFailoverTaskWithPredicateSelfTest.java  |   248 +
 .../internal/GridFailoverTopologySelfTest.java  |   160 +
 .../ignite/internal/GridHomePathSelfTest.java   |    75 +
 .../GridJobCheckpointCleanupSelfTest.java       |   163 +
 .../GridJobCollisionCancelSelfTest.java         |   276 +
 .../ignite/internal/GridJobContextSelfTest.java |   121 +
 .../GridJobMasterLeaveAwareSelfTest.java        |   800 +
 .../internal/GridJobStealingSelfTest.java       |   438 +
 .../GridJobStealingZeroActiveJobsSelfTest.java  |   169 +
 .../internal/GridJobSubjectIdSelfTest.java      |   152 +
 .../GridKernalConcurrentAccessStopSelfTest.java |    63 +
 .../ignite/internal/GridKernalTestUtils.java    |    44 +
 .../internal/GridLifecycleAwareSelfTest.java    |   196 +
 .../internal/GridLifecycleBeanSelfTest.java     |   312 +
 .../internal/GridListenActorSelfTest.java       |   229 +
 .../GridLocalEventListenerSelfTest.java         |    73 +
 .../internal/GridMultipleJobsSelfTest.java      |   231 +
 .../internal/GridMultipleSpisSelfTest.java      |   302 +
 .../GridMultipleVersionsDeploymentSelfTest.java |   306 +
 .../GridMultithreadedJobStealingSelfTest.java   |   239 +
 .../ignite/internal/GridNodeFilterSelfTest.java |    78 +
 .../ignite/internal/GridNodeLocalSelfTest.java  |    65 +
 .../GridNodeVisorAttributesSelfTest.java        |   114 +
 .../internal/GridNonHistoryMetricsSelfTest.java |   124 +
 .../internal/GridProjectionAbstractTest.java    |   768 +
 .../GridProjectionForCachesSelfTest.java        |   267 +
 ...ectionLocalJobMultipleArgumentsSelfTest.java |   155 +
 .../ignite/internal/GridProjectionSelfTest.java |   145 +
 .../ignite/internal/GridReduceSelfTest.java     |   193 +
 .../internal/GridReleaseTypeSelfTest.java       |   103 +
 .../internal/GridRuntimeExceptionSelfTest.java  |   301 +
 .../internal/GridSameVmStartupSelfTest.java     |   107 +
 .../apache/ignite/internal/GridSelfTest.java    |   166 +
 .../internal/GridSpiExceptionSelfTest.java      |   178 +
 .../ignite/internal/GridStartStopSelfTest.java  |   181 +
 .../apache/ignite/internal/GridStartupMain.java |    57 +
 .../apache/ignite/internal/GridStartupTest.java |    69 +
 .../internal/GridStopWithCancelSelfTest.java    |   122 +
 .../internal/GridStopWithWaitSelfTest.java      |   263 +
 .../GridTaskCancelSingleNodeSelfTest.java       |   183 +
 .../GridTaskContinuousMapperSelfTest.java       |   331 +
 .../GridTaskExecutionContextSelfTest.java       |   178 +
 .../internal/GridTaskExecutionSelfTest.java     |    68 +
 .../internal/GridTaskFailoverSelfTest.java      |   116 +
 .../GridTaskFutureImplStopGridSelfTest.java     |   213 +
 .../GridTaskInstanceExecutionSelfTest.java      |   121 +
 .../internal/GridTaskInstantiationSelfTest.java |   117 +
 .../internal/GridTaskJobRejectSelfTest.java     |   160 +
 .../internal/GridTaskListenerSelfTest.java      |   106 +
 .../internal/GridTaskMapAsyncSelfTest.java      |   141 +
 .../GridTaskNameAnnotationSelfTest.java         |   122 +
 .../internal/GridTaskResultCacheSelfTest.java   |   128 +
 .../internal/GridTaskTimeoutSelfTest.java       |   223 +
 .../GridTopicExternalizableSelfTest.java        |   165 +
 .../internal/GridUpdateNotifierSelfTest.java    |    95 +
 .../ignite/internal/GridVersionSelfTest.java    |    68 +
 .../IgniteComputeEmptyClusterGroupTest.java     |   197 +
 .../IgniteComputeTopologyExceptionTest.java     |   112 +
 .../internal/IgniteExecutorServiceTest.java     |   313 +
 ...gniteExplicitImplicitDeploymentSelfTest.java |   476 +
 .../managers/GridManagerStopSelfTest.java       |   225 +
 .../managers/GridNoopManagerSelfTest.java       |    96 +
 .../GridCheckpointManagerAbstractSelfTest.java  |   758 +
 .../GridCheckpointManagerSelfTest.java          |    68 +
 .../checkpoint/GridCheckpointTaskSelfTest.java  |   232 +
 .../internal/managers/checkpoint/package.html   |    24 +
 ...idCommunicationManagerListenersSelfTest.java |   158 +
 .../GridCommunicationSendMessageSelfTest.java   |   163 +
 .../communication/GridIoManagerSelfTest.java    |   237 +
 .../managers/communication/package.html         |    24 +
 .../GridDeploymentManagerStopSelfTest.java      |    99 +
 .../GridDeploymentMessageCountSelfTest.java     |   211 +
 .../managers/deployment/GridTestDeployment.java |    39 +
 .../internal/managers/deployment/package.html   |    24 +
 .../GridDiscoveryManagerAliveCacheSelfTest.java |   236 +
 .../GridDiscoveryManagerAttributesSelfTest.java |   171 +
 .../discovery/GridDiscoveryManagerSelfTest.java |   185 +
 .../events/GridEventStorageManagerSelfTest.java |   125 +
 .../ignite/internal/managers/package.html       |    24 +
 .../GridSwapSpaceCustomLocalValue.java          |    86 +
 .../swapspace/GridSwapSpaceManagerSelfTest.java |   164 +
 .../internal/managers/swapspace/package.html    |    24 +
 .../org/apache/ignite/internal/package.html     |    24 +
 .../GridAffinityProcessorAbstractSelfTest.java  |   194 +
 ...AffinityProcessorConsistentHashSelfTest.java |    31 +
 ...GridAffinityProcessorRendezvousSelfTest.java |    31 +
 ...ridCacheAbstractByteArrayValuesSelfTest.java |    83 +
 .../GridCacheAbstractFailoverSelfTest.java      |   408 +
 .../cache/GridCacheAbstractFlagsTest.java       |   100 +
 ...cheAbstractFullApiMultithreadedSelfTest.java |   351 +
 .../cache/GridCacheAbstractFullApiSelfTest.java |  3987 +++++
 .../GridCacheAbstractIteratorsSelfTest.java     |   144 +
 .../cache/GridCacheAbstractMetricsSelfTest.java |   906 ++
 .../GridCacheAbstractRemoveFailureTest.java     |   323 +
 .../cache/GridCacheAbstractSelfTest.java        |   599 +
 .../cache/GridCacheAbstractTxReadTest.java      |   136 +
 .../cache/GridCacheAffinityApiSelfTest.java     |   330 +
 .../cache/GridCacheAffinityMapperSelfTest.java  |   149 +
 .../cache/GridCacheAffinityRoutingSelfTest.java |   269 +
 .../cache/GridCacheAlwaysEvictionPolicy.java    |    33 +
 .../GridCacheAsyncOperationsLimitSelfTest.java  |    82 +
 .../GridCacheAtomicMessageCountSelfTest.java    |   236 +
 .../cache/GridCacheBasicApiAbstractTest.java    |   695 +
 .../cache/GridCacheBasicStoreAbstractTest.java  |   595 +
 ...acheBasicStoreMultithreadedAbstractTest.java |   132 +
 .../cache/GridCacheClearAllSelfTest.java        |   168 +
 .../cache/GridCacheClearLocalySelfTest.java     |   336 +
 ...dCacheColocatedTxStoreExceptionSelfTest.java |    38 +
 .../cache/GridCacheConcurrentMapSelfTest.java   |   362 +
 .../cache/GridCacheConcurrentMapTest.java       |   140 +
 .../GridCacheConcurrentTxMultiNodeTest.java     |   862 ++
 ...idCacheConfigurationConsistencySelfTest.java |  1060 ++
 ...ridCacheConfigurationValidationSelfTest.java |   195 +
 .../GridCacheDaemonNodeAbstractSelfTest.java    |   189 +
 .../GridCacheDeploymentOffHeapSelfTest.java     |    42 +
 .../cache/GridCacheDeploymentSelfTest.java      |   439 +
 .../cache/GridCacheEntryMemorySizeSelfTest.java |   320 +
 .../cache/GridCacheEntryVersionSelfTest.java    |   159 +
 .../GridCacheEvictionEventAbstractTest.java     |   122 +
 .../GridCacheExAbstractFullApiSelfTest.java     |   103 +
 .../GridCacheFieldsQueryNoDataSelfTest.java     |    83 +
 .../GridCacheFinishPartitionsSelfTest.java      |   319 +
 ...CacheFullTextQueryMultithreadedSelfTest.java |   158 +
 .../cache/GridCacheGenericTestStore.java        |   275 +
 ...idCacheGetAndTransformStoreAbstractTest.java |   176 +
 .../cache/GridCacheIncrementTransformTest.java  |   233 +
 .../GridCacheInterceptorAbstractSelfTest.java   |  1666 ++
 ...cheInterceptorAtomicNearEnabledSelfTest.java |    32 +
 ...erceptorAtomicPrimaryWriteOrderSelfTest.java |    45 +
 ...omicReplicatedPrimaryWriteOrderSelfTest.java |    46 +
 ...acheInterceptorAtomicReplicatedSelfTest.java |    45 +
 .../GridCacheInterceptorAtomicSelfTest.java     |    45 +
 ...ceptorAtomicWithStoreReplicatedSelfTest.java |    29 +
 ...CacheInterceptorAtomicWithStoreSelfTest.java |    28 +
 ...GridCacheInterceptorLocalAtomicSelfTest.java |    50 +
 ...InterceptorLocalAtomicWithStoreSelfTest.java |    28 +
 .../GridCacheInterceptorLocalSelfTest.java      |    44 +
 ...dCacheInterceptorLocalWithStoreSelfTest.java |    28 +
 ...GridCacheInterceptorNearEnabledSelfTest.java |    30 +
 .../GridCacheInterceptorReplicatedSelfTest.java |    39 +
 ...eInterceptorReplicatedWithStoreSelfTest.java |    28 +
 .../cache/GridCacheInterceptorSelfTest.java     |    39 +
 .../GridCacheInterceptorWithStoreSelfTest.java  |    28 +
 .../cache/GridCacheIteratorPerformanceTest.java |   245 +
 .../GridCacheKeyCheckNearEnabledSelfTest.java   |    30 +
 .../cache/GridCacheKeyCheckSelfTest.java        |   206 +
 .../processors/cache/GridCacheLeakTest.java     |   151 +
 .../cache/GridCacheLifecycleAwareSelfTest.java  |   344 +
 .../GridCacheLocalTxStoreExceptionSelfTest.java |    37 +
 .../cache/GridCacheLuceneQueryIndexTest.java    |   465 +
 .../GridCacheMarshallerTxAbstractTest.java      |   132 +
 .../cache/GridCacheMemoryModeSelfTest.java      |   260 +
 .../GridCacheMissingCommitVersionSelfTest.java  |   133 +
 ...GridCacheMixedPartitionExchangeSelfTest.java |   152 +
 .../cache/GridCacheMultiUpdateLockSelfTest.java |   201 +
 ...ridCacheMultinodeUpdateAbstractSelfTest.java |   134 +
 ...ultinodeUpdateAtomicNearEnabledSelfTest.java |    39 +
 .../GridCacheMultinodeUpdateAtomicSelfTest.java |    38 +
 ...inodeUpdateNearEnabledNoBackupsSelfTest.java |    39 +
 ...CacheMultinodeUpdateNearEnabledSelfTest.java |    40 +
 .../cache/GridCacheMultinodeUpdateSelfTest.java |    39 +
 .../cache/GridCacheMvccFlagsTest.java           |   141 +
 .../cache/GridCacheMvccManagerSelfTest.java     |   115 +
 .../cache/GridCacheMvccPartitionedSelfTest.java |   687 +
 .../processors/cache/GridCacheMvccSelfTest.java |  1850 +++
 .../GridCacheNearTxStoreExceptionSelfTest.java  |    32 +
 .../cache/GridCacheNestedTxAbstractTest.java    |   283 +
 .../cache/GridCacheObjectToStringSelfTest.java  |   186 +
 ...ffHeapAtomicMultiThreadedUpdateSelfTest.java |    33 +
 ...HeapMultiThreadedUpdateAbstractSelfTest.java |   354 +
 ...CacheOffHeapMultiThreadedUpdateSelfTest.java |   213 +
 .../cache/GridCacheOffHeapSelfTest.java         |   652 +
 .../processors/cache/GridCacheOffHeapTest.java  |   258 +
 .../GridCacheOffHeapTieredAbstractSelfTest.java |   667 +
 .../GridCacheOffHeapTieredAtomicSelfTest.java   |    32 +
 ...heOffHeapTieredEvictionAbstractSelfTest.java |   357 +
 ...acheOffHeapTieredEvictionAtomicSelfTest.java |    32 +
 .../GridCacheOffHeapTieredEvictionSelfTest.java |    33 +
 .../cache/GridCacheOffHeapTieredSelfTest.java   |    33 +
 .../cache/GridCacheOffheapUpdateSelfTest.java   |   139 +
 .../GridCacheOrderedPreloadingSelfTest.java     |   157 +
 .../cache/GridCacheP2PUndeploySelfTest.java     |   304 +
 .../GridCachePartitionedAffinitySpreadTest.java |   167 +
 .../cache/GridCachePartitionedGetSelfTest.java  |   244 +
 ...hePartitionedProjectionAffinitySelfTest.java |   118 +
 .../cache/GridCachePartitionedWritesTest.java   |   148 +
 .../GridCachePreloadingEvictionsSelfTest.java   |   262 +
 .../cache/GridCachePutAllFailoverSelfTest.java  |   708 +
 .../processors/cache/GridCachePutAllTask.java   |   131 +
 .../cache/GridCacheQueryEmbeddedValue.java      |    49 +
 .../cache/GridCacheQueryIndexSelfTest.java      |   126 +
 .../GridCacheQueryIndexingDisabledSelfTest.java |    99 +
 .../GridCacheQueryInternalKeysSelfTest.java     |   113 +
 .../GridCacheReferenceCleanupSelfTest.java      |   511 +
 .../cache/GridCacheReloadSelfTest.java          |   177 +
 ...ridCacheReplicatedSynchronousCommitTest.java |   202 +
 ...CacheReplicatedTxStoreExceptionSelfTest.java |    38 +
 .../GridCacheReturnValueTransferSelfTest.java   |   206 +
 .../cache/GridCacheSlowTxWarnTest.java          |   146 +
 .../processors/cache/GridCacheStopSelfTest.java |   200 +
 .../cache/GridCacheStorePutxSelfTest.java       |   158 +
 .../cache/GridCacheStoreValueBytesSelfTest.java |   111 +
 .../cache/GridCacheSwapPreloadSelfTest.java     |   231 +
 .../cache/GridCacheSwapReloadSelfTest.java      |   248 +
 .../processors/cache/GridCacheTestEntryEx.java  |   846 +
 .../processors/cache/GridCacheTestKey.java      |    65 +
 .../processors/cache/GridCacheTestStore.java    |   353 +
 .../processors/cache/GridCacheTestValue.java    |    78 +
 .../processors/cache/GridCacheTestValue2.java   |    68 +
 ...cheTransactionalAbstractMetricsSelfTest.java |   285 +
 .../cache/GridCacheTtlManagerLoadTest.java      |    84 +
 .../cache/GridCacheTtlManagerSelfTest.java      |   120 +
 .../cache/GridCacheUtilsSelfTest.java           |   261 +
 .../GridCacheValueBytesPreloadingSelfTest.java  |   151 +
 ...idCacheValueConsistencyAbstractSelfTest.java |   324 +
 ...istencyTransactionalNearEnabledSelfTest.java |    31 +
 ...heValueConsistencyTransactionalSelfTest.java |    37 +
 .../GridCacheVariableTopologySelfTest.java      |   191 +
 .../cache/GridCacheVersionMultinodeTest.java    |   208 +
 .../cache/GridCacheVersionSelfTest.java         |   103 +
 ...idCacheWriteBehindStoreAbstractSelfTest.java |   189 +
 .../GridCacheWriteBehindStoreAbstractTest.java  |   351 +
 .../GridCacheWriteBehindStoreLocalTest.java     |    30 +
 ...heWriteBehindStoreMultithreadedSelfTest.java |   163 +
 ...BehindStorePartitionedMultiNodeSelfTest.java |   217 +
 ...ridCacheWriteBehindStorePartitionedTest.java |    30 +
 ...GridCacheWriteBehindStoreReplicatedTest.java |    30 +
 .../GridCacheWriteBehindStoreSelfTest.java      |   267 +
 .../IgniteCacheAbstractStopBusySelfTest.java    |   381 +
 .../cache/IgniteCacheAbstractTest.java          |   247 +
 .../cache/IgniteCacheAtomicInvokeTest.java      |    55 +
 .../cache/IgniteCacheAtomicLocalInvokeTest.java |    49 +
 .../IgniteCacheAtomicLocalPeekModesTest.java    |    43 +
 ...niteCacheAtomicLocalWithStoreInvokeTest.java |    30 +
 .../IgniteCacheAtomicNearEnabledInvokeTest.java |    32 +
 .../cache/IgniteCacheAtomicPeekModesTest.java   |    49 +
 ...eCacheAtomicPrimaryWriteOrderInvokeTest.java |    55 +
 ...micPrimaryWriteOrderWithStoreInvokeTest.java |    31 +
 ...gniteCacheAtomicReplicatedPeekModesTest.java |    32 +
 .../IgniteCacheAtomicStopBusySelfTest.java      |    59 +
 .../IgniteCacheContainsKeyAbstractSelfTest.java |   136 +
 .../IgniteCacheEntryListenerAbstractTest.java   |  1004 ++
 ...IgniteCacheEntryListenerAtomicLocalTest.java |    49 +
 ...eCacheEntryListenerAtomicReplicatedTest.java |    32 +
 .../IgniteCacheEntryListenerAtomicTest.java     |    55 +
 ...eCacheEntryListenerEagerTtlDisabledTest.java |    29 +
 .../IgniteCacheEntryListenerTxLocalTest.java    |    49 +
 ...gniteCacheEntryListenerTxReplicatedTest.java |    32 +
 .../cache/IgniteCacheEntryListenerTxTest.java   |    49 +
 .../IgniteCacheInterceptorSelfTestSuite.java    |    56 +
 .../cache/IgniteCacheInvokeAbstractTest.java    |   659 +
 .../cache/IgniteCacheInvokeReadThroughTest.java |   121 +
 .../cache/IgniteCachePeekModesAbstractTest.java |  1131 ++
 .../processors/cache/IgniteCacheTest.java       |   121 -
 ...gniteCacheTransactionalStopBusySelfTest.java |    53 +
 .../cache/IgniteCacheTxInvokeTest.java          |    49 +
 .../cache/IgniteCacheTxLocalInvokeTest.java     |    49 +
 .../cache/IgniteCacheTxLocalPeekModesTest.java  |    43 +
 .../IgniteCacheTxNearEnabledInvokeTest.java     |    32 +
 .../cache/IgniteCacheTxPeekModesTest.java       |    49 +
 .../IgniteCacheTxReplicatedPeekModesTest.java   |    32 +
 .../cache/IgniteCachingProviderSelfTest.java    |   130 +
 .../IgniteClientAffinityAssignmentSelfTest.java |   165 +
 .../cache/IgnitePutAllLargeBatchSelfTest.java   |   301 +
 ...tAllUpdateNonPreloadedPartitionSelfTest.java |   129 +
 .../processors/cache/IgniteTxAbstractTest.java  |   475 +
 .../IgniteTxConcurrentGetAbstractTest.java      |   142 +
 .../IgniteTxExceptionAbstractSelfTest.java      |   653 +
 .../cache/IgniteTxMultiNodeAbstractTest.java    |   927 ++
 .../IgniteTxMultiThreadedAbstractTest.java      |   283 +
 .../cache/IgniteTxReentryAbstractSelfTest.java  |   178 +
 .../IgniteTxSingleThreadedAbstractTest.java     |   137 +
 .../IgniteTxStoreExceptionAbstractSelfTest.java |   656 +
 ...IgniteCacheAbstractExecutionContextTest.java |    96 +
 .../IgniteCacheAtomicExecutionContextTest.java  |    49 +
 ...niteCacheContinuousExecutionContextTest.java |    34 +
 ...IgniteCacheIsolatedExecutionContextTest.java |    34 +
 ...niteCacheP2PDisableExecutionContextTest.java |    34 +
 ...iteCachePartitionedExecutionContextTest.java |    49 +
 .../IgniteCachePrivateExecutionContextTest.java |    34 +
 ...niteCacheReplicatedExecutionContextTest.java |    49 +
 .../IgniteCacheSharedExecutionContextTest.java  |    34 +
 .../IgniteCacheTxExecutionContextTest.java      |    49 +
 ...eAbstractDataStructuresFailoverSelfTest.java |   920 ++
 ...actQueueFailoverDataConsistencySelfTest.java |   369 +
 ...CacheAtomicReferenceApiSelfAbstractTest.java |   112 +
 ...cheAtomicReferenceMultiNodeAbstractTest.java |   166 +
 ...idCacheAtomicStampedApiSelfAbstractTest.java |   123 +
 .../GridCacheMultiNodeDataStructureTest.java    |    75 +
 .../GridCacheQueueApiSelfAbstractTest.java      |   552 +
 .../GridCacheQueueCleanupSelfTest.java          |   236 +
 ...ridCacheQueueJoinedNodeSelfAbstractTest.java |   286 +
 ...GridCacheQueueMultiNodeAbstractSelfTest.java |   772 +
 ...dCacheQueueMultiNodeConsistencySelfTest.java |   186 +
 ...CacheQueueRotativeMultiNodeAbstractTest.java |   387 +
 .../GridCacheSequenceApiSelfAbstractTest.java   |   609 +
 ...dCacheSequenceMultiNodeAbstractSelfTest.java |   260 +
 .../GridCacheSetAbstractSelfTest.java           |   882 ++
 .../GridCacheSetFailoverAbstractSelfTest.java   |   225 +
 .../IgniteAtomicLongApiAbstractSelfTest.java    |   265 +
 .../IgniteAtomicsAbstractTest.java              |    83 +
 .../IgniteCollectionAbstractTest.java           |   255 +
 .../IgniteCountDownLatchAbstractSelfTest.java   |   270 +
 .../IgniteDataStructureUniqueNameTest.java      |   397 +
 .../GridCacheLocalAtomicQueueApiSelfTest.java   |    32 +
 .../local/GridCacheLocalAtomicSetSelfTest.java  |    44 +
 .../local/GridCacheLocalQueueApiSelfTest.java   |    39 +
 .../GridCacheLocalSequenceApiSelfTest.java      |    33 +
 .../local/GridCacheLocalSetSelfTest.java        |    44 +
 .../local/IgniteLocalAtomicLongApiSelfTest.java |    33 +
 .../IgniteLocalCountDownLatchSelfTest.java      |    95 +
 ...dCachePartitionedAtomicQueueApiSelfTest.java |    32 +
 ...ionedAtomicQueueCreateMultiNodeSelfTest.java |    33 +
 ...micQueueFailoverDataConsistencySelfTest.java |    34 +
 ...PartitionedAtomicQueueMultiNodeSelfTest.java |    32 +
 ...itionedAtomicQueueRotativeMultiNodeTest.java |    33 +
 ...hePartitionedAtomicReferenceApiSelfTest.java |    43 +
 ...PartitionedAtomicReferenceMultiNodeTest.java |    43 +
 ...titionedAtomicSequenceMultiThreadedTest.java |   339 +
 ...chePartitionedAtomicSetFailoverSelfTest.java |    33 +
 .../GridCachePartitionedAtomicSetSelfTest.java  |    32 +
 ...achePartitionedAtomicStampedApiSelfTest.java |    43 +
 ...rtitionedDataStructuresFailoverSelfTest.java |    40 +
 ...GridCachePartitionedNodeRestartSelfTest.java |    67 +
 ...idCachePartitionedNodeRestartTxSelfTest.java |   300 +
 .../GridCachePartitionedQueueApiSelfTest.java   |    39 +
 ...PartitionedQueueCreateMultiNodeSelfTest.java |   208 +
 ...dCachePartitionedQueueEntryMoveSelfTest.java |   257 +
 ...nedQueueFailoverDataConsistencySelfTest.java |    34 +
 ...CachePartitionedQueueJoinedNodeSelfTest.java |    39 +
 ...dCachePartitionedQueueMultiNodeSelfTest.java |    39 +
 ...hePartitionedQueueRotativeMultiNodeTest.java |    39 +
 ...GridCachePartitionedSequenceApiSelfTest.java |    43 +
 ...chePartitionedSequenceMultiNodeSelfTest.java |    44 +
 ...GridCachePartitionedSetFailoverSelfTest.java |    33 +
 .../GridCachePartitionedSetSelfTest.java        |    39 +
 .../IgnitePartitionedAtomicLongApiSelfTest.java |    33 +
 ...IgnitePartitionedCountDownLatchSelfTest.java |    33 +
 .../IgnitePartitionedSetNoBackupsSelfTest.java  |    68 +
 ...cheReplicatedAtomicReferenceApiSelfTest.java |    33 +
 ...eReplicatedAtomicReferenceMultiNodeTest.java |    33 +
 ...CacheReplicatedAtomicStampedApiSelfTest.java |    33 +
 ...eplicatedDataStructuresFailoverSelfTest.java |    40 +
 .../GridCacheReplicatedQueueApiSelfTest.java    |    39 +
 ...idCacheReplicatedQueueMultiNodeSelfTest.java |    39 +
 ...cheReplicatedQueueRotativeMultiNodeTest.java |    39 +
 .../GridCacheReplicatedSequenceApiSelfTest.java |    33 +
 ...acheReplicatedSequenceMultiNodeSelfTest.java |    43 +
 .../GridCacheReplicatedSetSelfTest.java         |    39 +
 .../IgniteReplicatedAtomicLongApiSelfTest.java  |    33 +
 .../IgniteReplicatedCountDownLatchSelfTest.java |    33 +
 ...tractDistributedByteArrayValuesSelfTest.java |   385 +
 .../GridCacheAbstractJobExecutionTest.java      |   194 +
 .../GridCacheAbstractNodeRestartSelfTest.java   |   895 ++
 ...tractPartitionedByteArrayValuesSelfTest.java |    97 +
 .../GridCacheAbstractPrimarySyncSelfTest.java   |   109 +
 .../GridCacheAtomicTimeoutSelfTest.java         |   315 +
 .../GridCacheBasicOpAbstractTest.java           |   410 +
 .../GridCacheClientModesAbstractSelfTest.java   |   211 +
 .../GridCacheEntrySetAbstractSelfTest.java      |   116 +
 ...acheEntrySetIterationPreloadingSelfTest.java |    93 +
 .../distributed/GridCacheEventAbstractTest.java |   944 ++
 ...heExpiredEntriesPreloadAbstractSelfTest.java |   118 +
 .../distributed/GridCacheLockAbstractTest.java  |   497 +
 .../distributed/GridCacheMixedModeSelfTest.java |    82 +
 .../GridCacheModuloAffinityFunction.java        |   200 +
 .../GridCacheMultiNodeAbstractTest.java         |   425 +
 .../GridCacheMultiNodeLockAbstractTest.java     |   576 +
 ...dCacheMultithreadedFailoverAbstractTest.java |   607 +
 .../GridCacheNodeFailureAbstractTest.java       |   298 +
 ...dCachePartitionedAffinityFilterSelfTest.java |   145 +
 ...chePartitionedReloadAllAbstractSelfTest.java |   248 +
 .../GridCachePreloadEventsAbstractSelfTest.java |   131 +
 .../GridCachePreloadLifecycleAbstractTest.java  |   229 +
 ...GridCachePreloadRestartAbstractSelfTest.java |   322 +
 .../GridCacheTransformEventSelfTest.java        |   609 +
 .../IgniteCrossCacheTxStoreSelfTest.java        |   311 +
 ...iteTxConsistencyRestartAbstractSelfTest.java |   202 +
 ...xOriginatingNodeFailureAbstractSelfTest.java |   305 +
 ...cOriginatingNodeFailureAbstractSelfTest.java |   516 +
 .../IgniteTxPreloadAbstractTest.java            |   220 +
 .../IgniteTxTimeoutAbstractTest.java            |   167 +
 ...tPartitionedOnlyByteArrayValuesSelfTest.java |   169 +
 ...heAbstractTransformWriteThroughSelfTest.java |   338 +
 ...acheAtomicExpiredEntriesPreloadSelfTest.java |    45 +
 .../dht/GridCacheAtomicFullApiSelfTest.java     |   128 +
 .../dht/GridCacheAtomicNearCacheSelfTest.java   |   818 +
 ...idCacheAtomicNearEnabledFullApiSelfTest.java |    32 +
 ...EnabledPrimaryWriteOrderFullApiSelfTest.java |    33 +
 ...eAtomicPrimaryWriteOrderFullApiSelfTest.java |    32 +
 ...tomicPrimaryWriteOrderReloadAllSelfTest.java |    32 +
 .../dht/GridCacheAtomicReloadAllSelfTest.java   |    38 +
 .../dht/GridCacheClientOnlySelfTest.java        |    38 +
 .../dht/GridCacheColocatedDebugTest.java        |   979 ++
 .../dht/GridCacheColocatedFailoverSelfTest.java |    39 +
 ...eColocatedOptimisticTransactionSelfTest.java |   155 +
 ...ridCacheColocatedPreloadRestartSelfTest.java |    30 +
 .../GridCacheColocatedPrimarySyncSelfTest.java  |    33 +
 .../GridCacheColocatedReloadAllSelfTest.java    |    30 +
 .../GridCacheColocatedTxExceptionSelfTest.java  |    39 +
 ...ssimisticOriginatingNodeFailureSelfTest.java |    49 +
 ...dCacheColocatedTxSingleThreadedSelfTest.java |   107 +
 .../GridCacheDaemonNodePartitionedSelfTest.java |    31 +
 ...cheDhtAtomicEvictionNearReadersSelfTest.java |    32 +
 .../GridCacheDhtAtomicRemoveFailureTest.java    |    51 +
 .../dht/GridCacheDhtEntrySelfTest.java          |   314 +
 .../dht/GridCacheDhtEntrySetSelfTest.java       |    46 +
 ...GridCacheDhtEvictionNearReadersSelfTest.java |   297 +
 .../dht/GridCacheDhtEvictionSelfTest.java       |   360 +
 .../GridCacheDhtEvictionsDisabledSelfTest.java  |   125 +
 ...idCacheDhtExpiredEntriesPreloadSelfTest.java |    39 +
 .../dht/GridCacheDhtInternalEntrySelfTest.java  |   208 +
 .../dht/GridCacheDhtMappingSelfTest.java        |   105 +
 .../dht/GridCacheDhtMultiBackupTest.java        |   134 +
 .../dht/GridCacheDhtPreloadBigDataSelfTest.java |   228 +
 .../dht/GridCacheDhtPreloadDelayedSelfTest.java |   456 +
 .../GridCacheDhtPreloadDisabledSelfTest.java    |   278 +
 .../GridCacheDhtPreloadMessageCountTest.java    |   171 +
 ...ridCacheDhtPreloadMultiThreadedSelfTest.java |   175 +
 .../dht/GridCacheDhtPreloadOffHeapSelfTest.java |    39 +
 .../dht/GridCacheDhtPreloadPutGetSelfTest.java  |   271 +
 .../dht/GridCacheDhtPreloadSelfTest.java        |   667 +
 .../GridCacheDhtPreloadStartStopSelfTest.java   |   258 +
 .../dht/GridCacheDhtPreloadUnloadSelfTest.java  |   321 +
 .../dht/GridCacheDhtRemoveFailureTest.java      |    45 +
 .../distributed/dht/GridCacheDhtTestUtils.java  |   222 +
 .../dht/GridCacheDhtTxPreloadSelfTest.java      |    45 +
 .../GridCacheExColocatedFullApiSelfTest.java    |    33 +
 .../dht/GridCacheGlobalLoadTest.java            |   229 +
 ...ePartitionedNearDisabledFullApiSelfTest.java |    33 +
 ...ePartitionedNearDisabledMetricsSelfTest.java |   120 +
 ...nedNearDisabledMultiNodeFullApiSelfTest.java |    34 +
 ...bledMultiNodeP2PDisabledFullApiSelfTest.java |    34 +
 ...ionedNearDisabledOffHeapFullApiSelfTest.java |    29 +
 ...DisabledOffHeapMultiNodeFullApiSelfTest.java |    29 +
 ...isabledTxOriginatingNodeFailureSelfTest.java |    31 +
 ...dOnlyP2PDisabledByteArrayValuesSelfTest.java |    29 +
 ...edOnlyP2PEnabledByteArrayValuesSelfTest.java |    29 +
 ...idCachePartitionedPreloadEventsSelfTest.java |   125 +
 ...dCachePartitionedTopologyChangeSelfTest.java |   606 +
 ...ransformWriteThroughBatchUpdateSelfTest.java |    29 +
 ...itionedTxOriginatingNodeFailureSelfTest.java |   162 +
 ...ridCachePartitionedUnloadEventsSelfTest.java |   151 +
 ...IgniteCacheContainsKeyColocatedSelfTest.java |    36 +
 ...teTxConsistencyColocatedRestartSelfTest.java |    36 +
 .../dht/IgniteTxReentryColocatedSelfTest.java   |    80 +
 ...eAtomicInvalidPartitionHandlingSelfTest.java |   326 +
 .../atomic/GridCacheAtomicPreloadSelfTest.java  |   214 +
 ...lueConsistencyAtomicNearEnabledSelfTest.java |    38 +
 ...micPrimaryWriteOrderNearEnabledSelfTest.java |    39 +
 ...GridCacheValueConsistencyAtomicSelfTest.java |   139 +
 ...CacheContainsKeyColocatedAtomicSelfTest.java |    41 +
 ...gniteCacheContainsKeyNearAtomicSelfTest.java |    36 +
 ...tNearPartitionedByteArrayValuesSelfTest.java |    34 +
 ...unctionExcludeNeighborsAbstractSelfTest.java |   175 +
 ...tomicClientOnlyMultiNodeFullApiSelfTest.java |   378 +
 ...OnlyMultiNodeP2PDisabledFullApiSelfTest.java |    35 +
 ...GridCacheAtomicMultiNodeFullApiSelfTest.java |    69 +
 ...omicMultiNodeP2PDisabledFullApiSelfTest.java |    67 +
 ...omicNearEnabledMultiNodeFullApiSelfTest.java |    32 +
 ...imaryWriteOrderMultiNodeFullApiSelfTest.java |    33 +
 ...ridCacheAtomicNearEvictionEventSelfTest.java |    39 +
 .../GridCacheAtomicNearEvictionSelfTest.java    |    32 +
 .../GridCacheAtomicNearMultiNodeSelfTest.java   |    32 +
 ...eAtomicNearOnlyMultiNodeFullApiSelfTest.java |   154 +
 ...OnlyMultiNodeP2PDisabledFullApiSelfTest.java |    35 +
 .../near/GridCacheAtomicNearOnlySelfTest.java   |    32 +
 .../GridCacheAtomicNearReadersSelfTest.java     |    32 +
 .../GridCacheAtomicNearRemoveFailureTest.java   |    52 +
 .../GridCacheAtomicOffHeapFullApiSelfTest.java  |    66 +
 ...heAtomicOffHeapMultiNodeFullApiSelfTest.java |    67 +
 ...idCacheAtomicPartitionedMetricsSelfTest.java |    64 +
 ...AtomicPartitionedTckMetricsSelfTestImpl.java |   185 +
 ...imaryWriteOrderMultiNodeFullApiSelfTest.java |    32 +
 ...rderMultiNodeP2PDisabledFullApiSelfTest.java |    33 +
 ...cPrimaryWriteOrderNearRemoveFailureTest.java |    52 +
 ...PrimaryWriteOrderOffHeapFullApiSelfTest.java |    32 +
 ...ityOrderOffHeapMultiNodeFullApiSelfTest.java |    33 +
 ...ffinityFunctionExcludeNeighborsSelfTest.java |    32 +
 .../near/GridCacheExNearFullApiSelfTest.java    |    39 +
 .../near/GridCacheGetStoreErrorSelfTest.java    |   150 +
 .../GridCacheNearEvictionEventSelfTest.java     |    48 +
 .../near/GridCacheNearEvictionSelfTest.java     |   187 +
 ...dCacheNearExpiredEntriesPreloadSelfTest.java |    39 +
 .../near/GridCacheNearJobExecutionSelfTest.java |    48 +
 .../near/GridCacheNearMetricsSelfTest.java      |   418 +
 .../near/GridCacheNearMultiGetSelfTest.java     |   310 +
 .../near/GridCacheNearMultiNodeSelfTest.java    |   966 ++
 .../near/GridCacheNearOneNodeSelfTest.java      |   393 +
 ...idCacheNearOnlyMultiNodeFullApiSelfTest.java |   591 +
 ...OnlyMultiNodeP2PDisabledFullApiSelfTest.java |    34 +
 .../near/GridCacheNearOnlySelfTest.java         |    69 +
 .../near/GridCacheNearOnlyTopologySelfTest.java |   235 +
 .../GridCacheNearPartitionedClearSelfTest.java  |   154 +
 ...ionedP2PDisabledByteArrayValuesSelfTest.java |    29 +
 ...tionedP2PEnabledByteArrayValuesSelfTest.java |    29 +
 .../GridCacheNearPreloadRestartSelfTest.java    |    30 +
 .../near/GridCacheNearPrimarySyncSelfTest.java  |    33 +
 .../GridCacheNearReaderPreloadSelfTest.java     |   200 +
 .../near/GridCacheNearReadersSelfTest.java      |   587 +
 .../near/GridCacheNearReloadAllSelfTest.java    |    30 +
 .../near/GridCacheNearRemoveFailureTest.java    |    45 +
 .../near/GridCacheNearTxExceptionSelfTest.java  |    33 +
 .../near/GridCacheNearTxMultiNodeSelfTest.java  |   245 +
 ...ssimisticOriginatingNodeFailureSelfTest.java |    49 +
 .../near/GridCacheNearTxPreloadSelfTest.java    |    45 +
 ...AffinityExcludeNeighborsPerformanceTest.java |   253 +
 ...rtitionedAffinityHashIdResolverSelfTest.java |    96 +
 .../GridCachePartitionedAffinitySelfTest.java   |   514 +
 ...ionedAtomicGetAndTransformStoreSelfTest.java |    33 +
 .../near/GridCachePartitionedBasicApiTest.java  |    46 +
 .../GridCachePartitionedBasicOpSelfTest.java    |    67 +
 ...ePartitionedBasicStoreMultiNodeSelfTest.java |   359 +
 .../GridCachePartitionedBasicStoreSelfTest.java |    33 +
 ...ionedClientOnlyNoPrimaryFullApiSelfTest.java |    67 +
 .../GridCachePartitionedEntryLockSelfTest.java  |    39 +
 .../near/GridCachePartitionedEventSelfTest.java |    60 +
 .../GridCachePartitionedEvictionSelfTest.java   |   215 +
 ...titionedExplicitLockNodeFailureSelfTest.java |   160 +
 .../GridCachePartitionedFailoverSelfTest.java   |    33 +
 ...GridCachePartitionedFilteredPutSelfTest.java |   125 +
 .../near/GridCachePartitionedFlagsTest.java     |    41 +
 ...PartitionedFullApiMultithreadedSelfTest.java |    38 +
 .../GridCachePartitionedFullApiSelfTest.java    |    81 +
 ...PartitionedGetAndTransformStoreSelfTest.java |    34 +
 ...idCachePartitionedHitsAndMissesSelfTest.java |   177 +
 .../GridCachePartitionedIteratorsSelfTest.java  |    43 +
 .../GridCachePartitionedLoadCacheSelfTest.java  |   179 +
 .../near/GridCachePartitionedLockSelfTest.java  |    52 +
 .../GridCachePartitionedMetricsSelfTest.java    |    59 +
 ...achePartitionedMultiNodeCounterSelfTest.java |   779 +
 ...achePartitionedMultiNodeFullApiSelfTest.java |   425 +
 ...idCachePartitionedMultiNodeLockSelfTest.java |    77 +
 ...onedMultiNodeP2PDisabledFullApiSelfTest.java |    35 +
 .../GridCachePartitionedMultiNodeSelfTest.java  |    48 +
 ...ePartitionedMultiThreadedPutGetSelfTest.java |   207 +
 ...NearDisabledBasicStoreMultiNodeSelfTest.java |    33 +
 ...itionedNearOnlyNoPrimaryFullApiSelfTest.java |    31 +
 .../near/GridCachePartitionedNestedTxTest.java  |    48 +
 ...GridCachePartitionedNodeFailureSelfTest.java |    50 +
 .../GridCachePartitionedNodeRestartTest.java    |   130 +
 ...dCachePartitionedOffHeapFullApiSelfTest.java |    28 +
 ...titionedOffHeapMultiNodeFullApiSelfTest.java |    28 +
 ...ePartitionedOptimisticTxNodeRestartTest.java |   126 +
 ...achePartitionedPreloadLifecycleSelfTest.java |   278 +
 ...hePartitionedQueryMultiThreadedSelfTest.java |   305 +
 .../GridCachePartitionedStorePutSelfTest.java   |   147 +
 ...GridCachePartitionedTxConcurrentGetTest.java |    45 +
 ...GridCachePartitionedTxMultiNodeSelfTest.java |    80 +
 ...CachePartitionedTxMultiThreadedSelfTest.java |   104 +
 .../near/GridCachePartitionedTxReadTest.java    |    33 +
 .../GridCachePartitionedTxSalvageSelfTest.java  |   283 +
 ...achePartitionedTxSingleThreadedSelfTest.java |   106 +
 .../GridCachePartitionedTxTimeoutSelfTest.java  |    66 +
 .../near/GridCachePutArrayValueSelfTest.java    |   117 +
 ...idCacheRendezvousAffinityClientSelfTest.java |   106 +
 ...ffinityFunctionExcludeNeighborsSelfTest.java |    32 +
 .../near/GridPartitionedBackupLoadSelfTest.java |   163 +
 .../IgniteCacheContainsKeyNearSelfTest.java     |    31 +
 .../near/IgniteTxReentryNearSelfTest.java       |    80 +
 ...stractReplicatedByteArrayValuesSelfTest.java |    83 +
 ...ridCacheAtomicReplicatedMetricsSelfTest.java |    59 +
 .../GridCacheDaemonNodeReplicatedSelfTest.java  |    31 +
 .../GridCacheExReplicatedFullApiSelfTest.java   |    33 +
 ...ridCacheReplicatedAtomicFullApiSelfTest.java |    42 +
 ...catedAtomicGetAndTransformStoreSelfTest.java |    33 +
 ...eplicatedAtomicMultiNodeFullApiSelfTest.java |    60 +
 ...imaryWriteOrderMultiNodeFullApiSelfTest.java |    33 +
 .../GridCacheReplicatedBasicApiTest.java        |    41 +
 .../GridCacheReplicatedBasicOpSelfTest.java     |    41 +
 .../GridCacheReplicatedBasicStoreSelfTest.java  |    33 +
 .../GridCacheReplicatedClientOnlySelfTest.java  |    43 +
 .../GridCacheReplicatedEntrySetSelfTest.java    |    33 +
 .../GridCacheReplicatedEventSelfTest.java       |    38 +
 ...ridCacheReplicatedEvictionEventSelfTest.java |    38 +
 .../GridCacheReplicatedEvictionSelfTest.java    |   131 +
 .../GridCacheReplicatedFailoverSelfTest.java    |    33 +
 .../GridCacheReplicatedFlagsTest.java           |    28 +
 ...eReplicatedFullApiMultithreadedSelfTest.java |    38 +
 ...ReplicatedFullApiMultithreadedSelfTest1.java |  1980 +++
 .../GridCacheReplicatedFullApiSelfTest.java     |    57 +
 ...eReplicatedGetAndTransformStoreSelfTest.java |    33 +
 .../GridCacheReplicatedInvalidateSelfTest.java  |   245 +
 .../GridCacheReplicatedIteratorsSelfTest.java   |    43 +
 .../GridCacheReplicatedJobExecutionTest.java    |    45 +
 .../GridCacheReplicatedLockSelfTest.java        |    33 +
 .../GridCacheReplicatedMarshallerTxTest.java    |    46 +
 .../GridCacheReplicatedMetricsSelfTest.java     |    53 +
 ...CacheReplicatedMultiNodeFullApiSelfTest.java |    28 +
 ...ridCacheReplicatedMultiNodeLockSelfTest.java |    41 +
 ...atedMultiNodeP2PDisabledFullApiSelfTest.java |    35 +
 .../GridCacheReplicatedMultiNodeSelfTest.java   |    41 +
 ...licatedNearOnlyMultiNodeFullApiSelfTest.java |    39 +
 .../GridCacheReplicatedNearOnlySelfTest.java    |    43 +
 .../GridCacheReplicatedNodeFailureSelfTest.java |    45 +
 .../GridCacheReplicatedNodeRestartSelfTest.java |    53 +
 ...idCacheReplicatedOffHeapFullApiSelfTest.java |    28 +
 ...plicatedOffHeapMultiNodeFullApiSelfTest.java |    28 +
 ...catedP2PDisabledByteArrayValuesSelfTest.java |    29 +
 ...icatedP2PEnabledByteArrayValuesSelfTest.java |    29 +
 ...ridCacheReplicatedPreloadEventsSelfTest.java |    32 +
 ...dezvousAffinityMultiNodeFullApiSelfTest.java |    35 +
 .../GridCacheReplicatedTxConcurrentGetTest.java |    44 +
 .../GridCacheReplicatedTxExceptionSelfTest.java |    39 +
 ...GridCacheReplicatedTxMultiNodeBasicTest.java |    80 +
 ...dCacheReplicatedTxMultiThreadedSelfTest.java |   110 +
 ...licatedTxOriginatingNodeFailureSelfTest.java |    37 +
 ...ssimisticOriginatingNodeFailureSelfTest.java |    50 +
 .../GridCacheReplicatedTxReadTest.java          |    33 +
 ...CacheReplicatedTxSingleThreadedSelfTest.java |   101 +
 .../GridCacheReplicatedTxTimeoutSelfTest.java   |    59 +
 ...idCacheReplicatedUnswapAdvancedSelfTest.java |   174 +
 .../GridCacheSyncReplicatedPreloadSelfTest.java |   165 +
 .../replicated/GridReplicatedTxPreloadTest.java |    33 +
 ...CacheReplicatedPreloadLifecycleSelfTest.java |   291 +
 ...idCacheReplicatedPreloadOffHeapSelfTest.java |    39 +
 .../GridCacheReplicatedPreloadSelfTest.java     |   585 +
 ...eplicatedPreloadStartStopEventsSelfTest.java |    94 +
 ...GridCacheReplicatedPreloadUndeploysTest.java |    87 +
 .../GridCacheBatchEvictUnswapSelfTest.java      |   196 +
 ...heConcurrentEvictionConsistencySelfTest.java |   267 +
 .../GridCacheConcurrentEvictionsSelfTest.java   |   183 +
 .../GridCacheDistributedEvictionsSelfTest.java  |   261 +
 .../GridCacheEmptyEntriesAbstractSelfTest.java  |   319 +
 .../GridCacheEmptyEntriesLocalSelfTest.java     |    41 +
 ...ridCacheEmptyEntriesPartitionedSelfTest.java |    41 +
 .../eviction/GridCacheEvictionAbstractTest.java |   471 +
 .../GridCacheEvictionFilterSelfTest.java        |   248 +
 .../GridCacheEvictionLockUnlockSelfTest.java    |   178 +
 .../GridCacheEvictionTouchSelfTest.java         |   254 +
 .../cache/eviction/GridCacheMockEntry.java      |   136 +
 ...cheSynchronousEvictionsFailoverSelfTest.java |   160 +
 .../GridCacheFifoEvictionPolicySelfTest.java    |   372 +
 .../lru/GridCacheLruEvictionPolicySelfTest.java |   417 +
 .../GridCacheLruNearEvictionPolicySelfTest.java |   136 +
 ...heNearOnlyLruNearEvictionPolicySelfTest.java |   167 +
 .../GridCacheRandomEvictionPolicySelfTest.java  |   258 +
 .../IgniteCacheAtomicExpiryPolicyTest.java      |    55 +
 ...iteCacheAtomicExpiryPolicyWithStoreTest.java |    49 +
 .../IgniteCacheAtomicLocalExpiryPolicyTest.java |    49 +
 ...AtomicPrimaryWriteOrderExpiryPolicyTest.java |    32 +
 ...maryWriteOrderWithStoreExpiryPolicyTest.java |    31 +
 ...teCacheAtomicReplicatedExpiryPolicyTest.java |    32 +
 ...iteCacheAtomicWithStoreExpiryPolicyTest.java |    30 +
 .../IgniteCacheExpiryPolicyAbstractTest.java    |  1133 ++
 .../IgniteCacheExpiryPolicyTestSuite.java       |    50 +
 ...eCacheExpiryPolicyWithStoreAbstractTest.java |   236 +
 .../expiry/IgniteCacheTxExpiryPolicyTest.java   |    49 +
 .../IgniteCacheTxExpiryPolicyWithStoreTest.java |    43 +
 .../IgniteCacheTxLocalExpiryPolicyTest.java     |    49 +
 ...IgniteCacheTxReplicatedExpiryPolicyTest.java |    32 +
 .../IgniteCacheTxWithStoreExpiryPolicyTest.java |    30 +
 .../IgniteCacheAtomicLoadAllTest.java           |    55 +
 .../IgniteCacheAtomicLoaderWriterTest.java      |    55 +
 .../IgniteCacheAtomicLocalLoadAllTest.java      |    49 +
 ...CacheAtomicLocalNoLoadPreviousValueTest.java |    49 +
 ...IgniteCacheAtomicLocalNoReadThroughTest.java |    49 +
 ...gniteCacheAtomicLocalNoWriteThroughTest.java |    49 +
 ...tomicNearEnabledNoLoadPreviousValueTest.java |    32 +
 ...CacheAtomicNearEnabledNoReadThroughTest.java |    32 +
 ...acheAtomicNearEnabledNoWriteThroughTest.java |    32 +
 ...gniteCacheAtomicNoLoadPreviousValueTest.java |    55 +
 .../IgniteCacheAtomicNoReadThroughTest.java     |    55 +
 .../IgniteCacheAtomicNoWriteThroughTest.java    |    55 +
 .../IgniteCacheAtomicStoreSessionTest.java      |    55 +
 .../IgniteCacheLoadAllAbstractTest.java         |   237 +
 .../IgniteCacheLoaderWriterAbstractTest.java    |   377 +
 ...iteCacheNoLoadPreviousValueAbstractTest.java |   211 +
 .../IgniteCacheNoReadThroughAbstractTest.java   |   320 +
 .../IgniteCacheNoWriteThroughAbstractTest.java  |   343 +
 .../IgniteCacheStoreSessionAbstractTest.java    |   343 +
 .../integration/IgniteCacheTxLoadAllTest.java   |    49 +
 .../IgniteCacheTxLoaderWriterTest.java          |    49 +
 .../IgniteCacheTxLocalLoadAllTest.java          |    49 +
 ...niteCacheTxLocalNoLoadPreviousValueTest.java |    49 +
 .../IgniteCacheTxLocalNoReadThroughTest.java    |    49 +
 .../IgniteCacheTxLocalNoWriteThroughTest.java   |    49 +
 ...cheTxNearEnabledNoLoadPreviousValueTest.java |    32 +
 ...niteCacheTxNearEnabledNoReadThroughTest.java |    32 +
 ...iteCacheTxNearEnabledNoWriteThroughTest.java |    32 +
 .../IgniteCacheTxNoLoadPreviousValueTest.java   |    49 +
 .../IgniteCacheTxNoReadThroughTest.java         |    49 +
 .../IgniteCacheTxNoWriteThroughTest.java        |    49 +
 .../IgniteCacheTxStoreSessionTest.java          |   287 +
 ...dCacheAtomicLocalMetricsNoStoreSelfTest.java |    29 +
 .../GridCacheAtomicLocalMetricsSelfTest.java    |    59 +
 ...dCacheAtomicLocalTckMetricsSelfTestImpl.java |   178 +
 .../local/GridCacheDaemonNodeLocalSelfTest.java |    64 +
 .../local/GridCacheExLocalFullApiSelfTest.java  |    30 +
 .../GridCacheLocalAtomicBasicStoreSelfTest.java |    32 +
 .../GridCacheLocalAtomicFullApiSelfTest.java    |    42 +
 ...LocalAtomicGetAndTransformStoreSelfTest.java |    33 +
 ...dCacheLocalAtomicOffHeapFullApiSelfTest.java |    42 +
 .../local/GridCacheLocalBasicApiSelfTest.java   |    41 +
 ...cheLocalBasicStoreMultithreadedSelfTest.java |    30 +
 .../local/GridCacheLocalBasicStoreSelfTest.java |    33 +
 .../GridCacheLocalByteArrayValuesSelfTest.java  |   255 +
 .../local/GridCacheLocalEventSelfTest.java      |    38 +
 .../GridCacheLocalEvictionEventSelfTest.java    |    38 +
 ...dCacheLocalFullApiMultithreadedSelfTest.java |    38 +
 .../local/GridCacheLocalFullApiSelfTest.java    |    93 +
 ...dCacheLocalGetAndTransformStoreSelfTest.java |    33 +
 .../local/GridCacheLocalIteratorsSelfTest.java  |    43 +
 .../local/GridCacheLocalLoadAllSelfTest.java    |   110 +
 .../cache/local/GridCacheLocalLockSelfTest.java |   321 +
 .../local/GridCacheLocalMetricsSelfTest.java    |    54 +
 .../GridCacheLocalMultithreadedSelfTest.java    |   347 +
 .../GridCacheLocalOffHeapFullApiSelfTest.java   |    28 +
 .../GridCacheLocalTxExceptionSelfTest.java      |    38 +
 .../GridCacheLocalTxMultiThreadedSelfTest.java  |    90 +
 .../cache/local/GridCacheLocalTxReadTest.java   |    33 +
 .../GridCacheLocalTxSingleThreadedSelfTest.java |    85 +
 .../local/GridCacheLocalTxTimeoutSelfTest.java  |   161 +
 .../GridCacheSwapScanQueryAbstractSelfTest.java |   374 +
 .../query/GridCacheSwapScanQuerySelfTest.java   |    24 +
 .../cache/query/GridCircularQueueTest.java      |   119 +
 ...ridCacheContinuousQueryAbstractSelfTest.java |   956 ++
 ...ontinuousQueryAtomicNearEnabledSelfTest.java |    32 +
 ...ontinuousQueryAtomicP2PDisabledSelfTest.java |    29 +
 .../GridCacheContinuousQueryAtomicSelfTest.java |    43 +
 ...CacheContinuousQueryLocalAtomicSelfTest.java |    32 +
 .../GridCacheContinuousQueryLocalSelfTest.java  |    37 +
 ...eContinuousQueryPartitionedOnlySelfTest.java |    48 +
 ...uousQueryPartitionedP2PDisabledSelfTest.java |    29 +
 ...CacheContinuousQueryPartitionedSelfTest.java |    37 +
 ...ContinuousQueryReplicatedAtomicSelfTest.java |    37 +
 ...nuousQueryReplicatedP2PDisabledSelfTest.java |    28 +
 ...dCacheContinuousQueryReplicatedSelfTest.java |   134 +
 ...dCacheAbstractReduceFieldsQuerySelfTest.java |   429 +
 ...ridCacheReduceFieldsQueryAtomicSelfTest.java |    38 +
 ...GridCacheReduceFieldsQueryLocalSelfTest.java |    37 +
 ...cheReduceFieldsQueryPartitionedSelfTest.java |    59 +
 ...acheReduceFieldsQueryReplicatedSelfTest.java |    37 +
 .../clock/GridTimeSyncProcessorSelfTest.java    |   223 +
 .../closure/GridClosureProcessorRemoteTest.java |   120 +
 .../closure/GridClosureProcessorSelfTest.java   |   542 +
 .../internal/processors/closure/package.html    |    24 +
 .../continuous/GridEventConsumeSelfTest.java    |  1079 ++
 .../continuous/GridMessageListenSelfTest.java   |   489 +
 .../dataload/GridDataLoaderImplSelfTest.java    |   215 +
 .../dataload/GridDataLoaderPerformanceTest.java |   199 +
 .../GridDataLoaderProcessorSelfTest.java        |   925 ++
 ...heIgfsPerBlockLruEvictionPolicySelfTest.java |   485 +
 .../processors/igfs/IgfsAbstractSelfTest.java   |  2453 +++
 .../processors/igfs/IgfsAttributesSelfTest.java |    75 +
 .../processors/igfs/IgfsCacheSelfTest.java      |   134 +
 .../processors/igfs/IgfsCommonAbstractTest.java |    67 +
 .../igfs/IgfsDataManagerSelfTest.java           |   600 +
 .../igfs/IgfsDualAbstractSelfTest.java          |  1601 ++
 .../processors/igfs/IgfsDualAsyncSelfTest.java  |    32 +
 .../processors/igfs/IgfsDualSyncSelfTest.java   |    32 +
 .../processors/igfs/IgfsFileInfoSelfTest.java   |    88 +
 .../processors/igfs/IgfsFileMapSelfTest.java    |   337 +
 ...IgfsGroupDataBlockKeyMapperHashSelfTest.java |   136 +
 .../igfs/IgfsMetaManagerSelfTest.java           |   475 +
 .../processors/igfs/IgfsMetricsSelfTest.java    |   536 +
 .../igfs/IgfsModeResolverSelfTest.java          |    77 +
 .../processors/igfs/IgfsModesSelfTest.java      |   604 +
 .../igfs/IgfsPrimaryOffheapTieredSelfTest.java  |    33 +
 .../igfs/IgfsPrimaryOffheapValuesSelfTest.java  |    33 +
 .../processors/igfs/IgfsPrimarySelfTest.java    |    32 +
 .../processors/igfs/IgfsProcessorSelfTest.java  |   978 ++
 .../igfs/IgfsProcessorValidationSelfTest.java   |   535 +
 ...IpcEndpointRegistrationAbstractSelfTest.java |   185 +
 ...dpointRegistrationOnLinuxAndMacSelfTest.java |    50 +
 ...pcEndpointRegistrationOnWindowsSelfTest.java |    53 +
 .../processors/igfs/IgfsSizeSelfTest.java       |   875 ++
 .../processors/igfs/IgfsStreamsSelfTest.java    |   472 +
 .../processors/igfs/IgfsTaskSelfTest.java       |   311 +
 .../processors/igfs/IgfsTestInputStream.java    |    66 +
 .../internal/processors/igfs/package.html       |    24 +
 .../IgfsAbstractRecordResolverSelfTest.java     |   186 +
 ...IgfsByteDelimiterRecordResolverSelfTest.java |   335 +
 .../IgfsFixedLengthRecordResolverSelfTest.java  |   147 +
 ...sNewLineDelimiterRecordResolverSelfTest.java |   129 +
 ...fsStringDelimiterRecordResolverSelfTest.java |   137 +
 .../GridJobMetricsProcessorLoadTest.java        |    89 +
 .../port/GridPortProcessorSelfTest.java         |   129 +
 .../cache/GridCacheCommandHandlerSelfTest.java  |   266 +
 .../processors/service/DummyService.java        |   148 +
 .../GridServiceProcessorAbstractSelfTest.java   |   676 +
 ...ServiceProcessorMultiNodeConfigSelfTest.java |   200 +
 .../GridServiceProcessorMultiNodeSelfTest.java  |   170 +
 .../GridServiceProcessorProxySelfTest.java      |   376 +
 .../GridServiceProcessorSingleNodeSelfTest.java |    57 +
 .../GridServiceReassignmentSelfTest.java        |   222 +
 .../streamer/GridStreamerEvictionSelfTest.java  |   164 +
 .../streamer/GridStreamerFailoverSelfTest.java  |   267 +
 .../GridStreamerLifecycleAwareSelfTest.java     |   212 +
 .../streamer/GridStreamerSelfTest.java          |   796 +
 .../processors/streamer/GridTestStage.java      |    52 +
 .../streamer/GridTestStreamerEventRouter.java   |    49 +
 .../ignite/internal/processors/streamer/SC.java |    31 +
 .../timeout/GridTimeoutProcessorSelfTest.java   |   610 +
 .../product/GridProductVersionSelfTest.java     |   129 +
 .../apache/ignite/internal/updatestatus.html    |    29 +
 ...artupWithSpecifiedWorkDirectorySelfTest.java |   163 +
 .../internal/util/GridTestClockTimer.java       |    37 +
 .../internal/util/IgniteUtilsSelfTest.java      |   724 +
 .../util/future/GridCompoundFutureSelfTest.java |   204 +
 .../util/future/GridEmbeddedFutureSelfTest.java |   138 +
 .../util/future/GridFinishedFutureSelfTest.java |   103 +
 .../util/future/GridFutureAdapterSelfTest.java  |   441 +
 .../future/GridFutureListenPerformanceTest.java |   108 +
 .../util/future/GridFutureQueueTest.java        |   183 +
 .../util/future/IgniteFutureImplTest.java       |   526 +
 .../nio/GridNioEmbeddedFutureSelfTest.java      |    59 +
 .../util/future/nio/GridNioFutureSelfTest.java  |   210 +
 ...GridUnsafeDataOutputArraySizingSelfTest.java |   161 +
 .../IpcServerEndpointDeserializerSelfTest.java  |   160 +
 .../ipc/shmem/IgfsSharedMemoryTestClient.java   |    76 +
 .../ipc/shmem/IgfsSharedMemoryTestServer.java   |    71 +
 .../IpcSharedMemoryCrashDetectionSelfTest.java  |   500 +
 .../ipc/shmem/IpcSharedMemoryFakeClient.java    |    36 +
 .../IpcSharedMemoryNativeLoaderSelfTest.java    |    78 +
 .../ipc/shmem/IpcSharedMemoryNodeStartup.java   |    85 +
 .../ipc/shmem/IpcSharedMemorySpaceSelfTest.java |   267 +
 .../ipc/shmem/IpcSharedMemoryUtilsSelfTest.java |    84 +
 .../LoadWithCorruptedLibFileTestRunner.java     |    63 +
 .../IpcSharedMemoryBenchmarkParty.java          |    35 +
 .../IpcSharedMemoryBenchmarkReader.java         |   133 +
 .../IpcSharedMemoryBenchmarkWriter.java         |   125 +
 .../internal/util/nio/GridNioSelfTest.java      |  1441 ++
 .../util/nio/GridNioSessionMetaKeySelfTest.java |    58 +
 .../internal/util/nio/GridNioSslSelfTest.java   |    88 +
 .../internal/util/nio/GridRoundTripTest.java    |   226 +
 .../nio/impl/GridNioFilterChainSelfTest.java    |   390 +
 .../ignite/internal/util/nio/package.html       |    24 +
 .../util/offheap/GridByteArrayWrapper.java      |    63 +
 .../offheap/GridOffHeapMapAbstractSelfTest.java |   813 +
 .../GridOffHeapMapPerformanceAbstractTest.java  |   289 +
 ...idOffHeapPartitionedMapAbstractSelfTest.java |  1134 ++
 ...apPartitionedMapPerformanceAbstractTest.java |   429 +
 .../unsafe/GridOffheapSnapTreeSelfTest.java     |   321 +
 .../unsafe/GridUnsafeMapPerformanceTest.java    |    30 +
 .../offheap/unsafe/GridUnsafeMapSelfTest.java   |    30 +
 .../unsafe/GridUnsafeMemorySelfTest.java        |   542 +
 ...GridUnsafePartitionedMapPerformanceTest.java |    32 +
 .../GridUnsafePartitionedMapSelfTest.java       |    30 +
 .../unsafe/GridUnsafeStripedLruSefTest.java     |   229 +
 .../tostring/GridToStringBuilderSelfTest.java   |   205 +
 .../ignite/internal/util/tostring/package.html  |    24 +
 .../ignite/jvmtest/BlockingQueueTest.java       |   144 +
 .../ignite/jvmtest/ConcurrentMapTest.java       |   193 +
 .../org/apache/ignite/jvmtest/FileIOTest.java   |   138 +
 .../apache/ignite/jvmtest/FileLocksTest.java    |   121 +
 .../ignite/jvmtest/LinkedHashMapTest.java       |    87 +
 .../ignite/jvmtest/MultipleFileIOTest.java      |   134 +
 .../ignite/jvmtest/NetworkFailureTest.java      |   370 +
 .../QueueSizeCounterMultiThreadedTest.java      |   102 +
 .../jvmtest/ReadWriteLockMultiThreadedTest.java |   207 +
 .../org/apache/ignite/jvmtest/RegExpTest.java   |    56 +
 .../jvmtest/ServerSocketMultiThreadedTest.java  |   100 +
 .../ignite/lang/GridBasicPerformanceTest.java   |  1077 ++
 .../ignite/lang/GridByteArrayListSelfTest.java  |   214 +
 .../ignite/lang/GridFuncPerformanceTest.java    |   101 +
 .../lang/GridFutureListenPerformanceTest.java   |   112 +
 .../GridImmutableCollectionsPerfomanceTest.java |   120 +
 .../lang/GridMetadataAwareAdapterSelfTest.java  |   118 +
 .../ignite/lang/GridSetWrapperSelfTest.java     |   224 +
 .../lang/GridSystemCurrentTimeMillisTest.java   |   107 +
 .../ignite/lang/GridThreadPriorityTest.java     |    72 +
 .../apache/ignite/lang/GridTupleSelfTest.java   |   164 +
 .../org/apache/ignite/lang/GridXSelfTest.java   |   262 +
 .../apache/ignite/lang/IgniteUuidSelfTest.java  |   325 +
 .../java/org/apache/ignite/lang/package.html    |    24 +
 ...dBoundedConcurrentLinkedHashMapSelfTest.java |    55 +
 ...GridBoundedConcurrentOrderedMapSelfTest.java |    81 +
 .../GridCircularBufferPerformanceTest.java      |   226 +
 .../lang/utils/GridCircularBufferSelfTest.java  |   176 +
 .../utils/GridConcurrentHashMapSelfTest.java    |   109 +
 .../GridConcurrentLinkedHashMapSelfTest.java    |   246 +
 .../GridConcurrentWeakHashSetSelfTest.java      |   395 +
 .../lang/utils/GridConsistentHashSelfTest.java  |   332 +
 .../lang/utils/GridLeanMapPerformanceTest.java  |    84 +
 .../ignite/lang/utils/GridLeanMapSelfTest.java  |   658 +
 .../ignite/lang/utils/GridListSetSelfTest.java  |   286 +
 .../ignite/lang/utils/GridPCollectionsTest.java |    54 +
 .../lang/utils/GridStripedLockSelfTest.java     |   200 +
 .../ignite/lang/utils/GridTrieMapSelfTest.java  |   242 +
 .../org/apache/ignite/lang/utils/package.html   |    24 +
 .../ignite/loadtest/GridLoadTestStatistics.java |   210 +
 .../loadtest/GridSingleExecutionTest.java       |   324 +
 .../org/apache/ignite/loadtest/package.html     |    24 +
 ...idFileSwapSpaceSpiMultithreadedLoadTest.java |   247 +
 .../loadtests/GridCacheLoadPopulationTask.java  |   152 +
 .../loadtests/GridCacheMultiNodeLoadTest.java   |   103 +
 .../cache/GridCacheAbstractLoadTest.java        |   375 +
 .../loadtests/cache/GridCacheBenchmark.java     |   202 +
 .../cache/GridCacheDataStructuresLoadTest.java  |   452 +
 .../loadtests/cache/GridCacheLoadTest.java      |   163 +
 .../cache/GridCachePutRemoveLoadTest.java       |   373 +
 .../cache/GridCacheSingleNodeLoadTest.java      |   182 +
 .../loadtests/cache/GridCacheSwapLoadTest.java  |   311 +
 .../GridCacheWriteBehindStoreLoadTest.java      |   202 +
 .../capacity/GridCapacityLoadTest.java          |    95 +
 .../capacity/spring-capacity-cache.xml          |   124 +
 .../colocation/GridTestCacheStore.java          |   130 +
 .../loadtests/colocation/GridTestConstants.java |    35 +
 .../loadtests/colocation/GridTestKey.java       |    92 +
 .../colocation/GridTestLifecycleBean.java       |    42 +
 .../loadtests/colocation/GridTestMain.java      |   207 +
 .../loadtests/colocation/spring-colocation.xml  |   160 +
 .../communication/GridIoManagerBenchmark.java   |   337 +
 .../communication/GridIoManagerBenchmark0.java  |   469 +
 .../GridTcpCommunicationBenchmark.java          |   586 +
 .../communication/GridTestMessage.java          |   124 +
 .../GridContinuousOperationsLoadTest.java       |   218 +
 .../GridCachePartitionedAtomicLongLoadTest.java |   136 +
 .../direct/multisplit/GridLoadTestJob.java      |    58 +
 .../multisplit/GridLoadTestJobTarget.java       |    33 +
 .../direct/multisplit/GridLoadTestTask.java     |    83 +
 .../multisplit/GridMultiSplitsLoadTest.java     |   158 +
 .../GridMultiSplitsRedeployLoadTest.java        |   160 +
 .../loadtests/direct/multisplit/package.html    |    24 +
 .../GridSingleSplitNewNodesTestJobTarget.java   |    49 +
 .../GridSingleSplitNewNodesTestTask.java        |    94 +
 ...ridSingleSplitsNewNodesAbstractLoadTest.java |   181 +
 ...idSingleSplitsNewNodesMulticastLoadTest.java |    45 +
 .../loadtests/direct/newnodes/package.html      |    24 +
 .../GridSingleSplitsRedeployLoadTest.java       |   172 +
 .../loadtests/direct/redeploy/package.html      |    24 +
 .../direct/session/GridSessionLoadTest.java     |   112 +
 .../direct/session/GridSessionLoadTestJob.java  |    76 +
 .../direct/session/GridSessionLoadTestTask.java |   136 +
 .../loadtests/direct/session/package.html       |    24 +
 .../direct/stealing/GridStealingLoadTest.java   |   154 +
 .../stealing/GridStealingLoadTestJob.java       |    61 +
 .../stealing/GridStealingLoadTestTask.java      |    95 +
 .../loadtests/direct/stealing/package.html      |    24 +
 .../loadtests/discovery/GridGcTimeoutTest.java  |    63 +
 .../ignite/loadtests/dsi/GridDsiClient.java     |   419 +
 .../loadtests/dsi/GridDsiLifecycleBean.java     |    65 +
 .../ignite/loadtests/dsi/GridDsiMessage.java    |    74 +
 .../ignite/loadtests/dsi/GridDsiPerfJob.java    |   341 +
 .../ignite/loadtests/dsi/GridDsiRequest.java    |    93 +
 .../loadtests/dsi/GridDsiRequestTask.java       |    40 +
 .../ignite/loadtests/dsi/GridDsiResponse.java   |    87 +
 .../loadtests/dsi/GridDsiResponseTask.java      |    40 +
 .../ignite/loadtests/dsi/GridDsiSession.java    |    84 +
 .../cacheget/GridBenchmarkCacheGetLoadTest.java |   109 +
 .../apache/ignite/loadtests/dsi/package.html    |    24 +
 ...dBoundedConcurrentLinkedHashSetLoadTest.java |   118 +
 .../loadtests/hashmap/GridCacheTestContext.java |    74 +
 .../loadtests/hashmap/GridHashMapLoadTest.java  |   101 +
 .../job/GridJobExecutionLoadTestClient.java     |   219 +
 ...GridJobExecutionLoadTestClientSemaphore.java |   239 +
 .../job/GridJobExecutionLoadTestJob.java        |    47 +
 .../job/GridJobExecutionLoadTestServer.java     |    40 +
 .../job/GridJobExecutionLoadTestTask.java       |    48 +
 .../job/GridJobExecutionSingleNodeLoadTest.java |   236 +
 ...JobExecutionSingleNodeSemaphoreLoadTest.java |   226 +
 .../ignite/loadtests/job/GridJobLoadTest.java   |   201 +
 .../loadtests/job/GridJobLoadTestJob.java       |   162 +
 .../loadtests/job/GridJobLoadTestParams.java    |    84 +
 .../loadtests/job/GridJobLoadTestSubmitter.java |   143 +
 .../loadtests/job/GridJobLoadTestTask.java      |    71 +
 .../apache/ignite/loadtests/job/package.html    |    24 +
 .../GridConcurrentLinkedHashMapBenchmark.java   |   238 +
 .../mapper/GridContinuousMapperLoadTest1.java   |    50 +
 .../mapper/GridContinuousMapperLoadTest2.java   |    91 +
 .../mapper/GridContinuousMapperTask1.java       |   149 +
 .../mapper/GridContinuousMapperTask2.java       |    87 +
 .../loadtests/mapper/GridNodeStartup.java       |    55 +
 .../ignite/loadtests/mapper/TestObject.java     |    58 +
 .../mergesort/GridMergeSortLoadTask.java        |   188 +
 .../mergesort/GridMergeSortLoadTest.java        |   143 +
 .../loadtests/nio/GridNioBenchmarkClient.java   |   167 +
 .../loadtests/nio/GridNioBenchmarkTest.java     |   119 +
 .../GridOffHeapMapPerformanceAbstractTest.java  |   290 +
 ...apPartitionedMapPerformanceAbstractTest.java |   430 +
 .../unsafe/GridUnsafeMapPerformanceTest.java    |    30 +
 ...GridUnsafePartitionedMapPerformanceTest.java |    32 +
 .../ignite/loadtests/streamer/EventClosure.java |    60 +
 .../streamer/GridStreamerBenchmark.java         |   140 +
 .../streamer/GridStreamerIndexLoadTest.java     |   179 +
 .../loadtests/streamer/GridStreamerLoad.java    |    62 +
 .../ignite/loadtests/streamer/IndexUpdater.java |    46 +
 .../ignite/loadtests/streamer/QueryClosure.java |   107 +
 .../loadtests/streamer/average/TestAverage.java |    70 +
 .../loadtests/streamer/average/TestStage.java   |    63 +
 .../swap/GridSwapEvictAllBenchmark.java         |   300 +
 .../loadtests/util/GridCumulativeAverage.java   |    63 +
 .../ignite/loadtests/util/GridLoadTestArgs.java |   283 +
 .../logger/java/IgniteJavaLoggerTest.java       |    65 +
 .../org/apache/ignite/logger/java/package.html  |    24 +
 .../marshaller/GridMarshallerAbstractTest.java  |   958 ++
 .../GridMarshallerExternalizableBean.java       |    64 +
 .../GridMarshallerPerformanceTest.java          |   514 +
 .../marshaller/GridMarshallerResourceBean.java  |   103 +
 .../GridMarshallerTestAbstractBean.java         |    40 +
 .../marshaller/GridMarshallerTestBean.java      |   148 +
 .../GridMarshallerTestInheritedBean.java        |    25 +
 .../jdk/GridJdkMarshallerSelfTest.java          |    33 +
 .../apache/ignite/marshaller/jdk/package.html   |    24 +
 .../GridOptimizedMarshallerEnumSelfTest.java    |    62 -
 .../GridOptimizedMarshallerSelfTest.java        |   453 -
 .../optimized/GridOptimizedMarshallerTest.java  |   832 -
 .../GridOptimizedObjectStreamSelfTest.java      |  2093 ---
 .../GridTestTcpDiscoveryIpFinderAdapter.java    |    44 -
 .../OptimizedMarshallerEnumSelfTest.java        |    62 +
 .../optimized/OptimizedMarshallerSelfTest.java  |   452 +
 .../optimized/OptimizedMarshallerTest.java      |   830 +
 .../OptimizedObjectStreamSelfTest.java          |  2093 +++
 .../TestTcpDiscoveryIpFinderAdapter.java        |    44 +
 .../ignite/marshaller/optimized/package.html    |     3 +-
 .../org/apache/ignite/marshaller/package.html   |    24 +
 ...GridMessagingNoPeerClassLoadingSelfTest.java |    90 +
 .../ignite/messaging/GridMessagingSelfTest.java |  1088 ++
 .../p2p/GridAbstractMultinodeRedeployTest.java  |   106 +
 ...MultinodeRedeployContinuousModeSelfTest.java |    37 +
 ...idMultinodeRedeployIsolatedModeSelfTest.java |    37 +
 ...ridMultinodeRedeployPrivateModeSelfTest.java |    37 +
 ...GridMultinodeRedeploySharedModeSelfTest.java |    37 +
 .../ignite/p2p/GridP2PClassLoadingSelfTest.java |   157 +
 .../GridP2PContinuousDeploymentSelfTest.java    |   117 +
 .../GridP2PDifferentClassLoaderSelfTest.java    |   221 +
 .../p2p/GridP2PDoubleDeploymentSelfTest.java    |   140 +
 .../p2p/GridP2PHotRedeploymentSelfTest.java     |   232 +
 .../p2p/GridP2PJobClassLoaderSelfTest.java      |   141 +
 .../p2p/GridP2PLocalDeploymentSelfTest.java     |   253 +
 .../GridP2PMissedResourceCacheSizeSelfTest.java |   292 +
 .../ignite/p2p/GridP2PNodeLeftSelfTest.java     |   121 +
 .../p2p/GridP2PRecursionTaskSelfTest.java       |   192 +
 .../p2p/GridP2PRemoteClassLoadersSelfTest.java  |   281 +
 .../p2p/GridP2PSameClassLoaderSelfTest.java     |   163 +
 .../org/apache/ignite/p2p/GridP2PTestJob.java   |   128 +
 .../org/apache/ignite/p2p/GridP2PTestTask.java  |    82 +
 .../p2p/GridP2PTestTaskExecutionTest.java       |    50 +
 .../ignite/p2p/GridP2PTimeoutSelfTest.java      |   205 +
 .../ignite/p2p/GridP2PUndeploySelfTest.java     |   237 +
 .../ignite/p2p/GridSwapSpaceCustomKey.java      |    59 +
 .../ignite/p2p/GridSwapSpaceCustomValue.java    |    65 +
 .../java/org/apache/ignite/p2p/p2p.properties   |     1 +
 .../java/org/apache/ignite/p2p/package.html     |    24 +
 .../test/java/org/apache/ignite/package.html    |    24 +
 ...SessionCancelSiblingsFromFutureSelfTest.java |   273 +
 ...ridSessionCancelSiblingsFromJobSelfTest.java |   283 +
 ...idSessionCancelSiblingsFromTaskSelfTest.java |   290 +
 .../GridSessionCheckpointAbstractSelfTest.java  |   231 +
 .../session/GridSessionCheckpointSelfTest.java  |    95 +
 .../GridSessionCollisionSpiSelfTest.java        |   143 +
 ...idSessionFutureWaitJobAttributeSelfTest.java |   250 +
 ...dSessionFutureWaitTaskAttributeSelfTest.java |   249 +
 .../session/GridSessionJobFailoverSelfTest.java |   161 +
 ...GridSessionJobWaitTaskAttributeSelfTest.java |   211 +
 .../ignite/session/GridSessionLoadSelfTest.java |   273 +
 .../GridSessionSetFutureAttributeSelfTest.java  |   246 +
 ...nSetFutureAttributeWaitListenerSelfTest.java |   234 +
 .../GridSessionSetJobAttribute2SelfTest.java    |   134 +
 ...GridSessionSetJobAttributeOrderSelfTest.java |   153 +
 .../GridSessionSetJobAttributeSelfTest.java     |   200 +
 ...sionSetJobAttributeWaitListenerSelfTest.java |   237 +
 .../GridSessionSetTaskAttributeSelfTest.java    |   196 +
 ...GridSessionTaskWaitJobAttributeSelfTest.java |   189 +
 .../GridSessionWaitAttributeSelfTest.java       |   471 +
 .../ignite/session/GridThreadSerialNumber.java  |    40 +
 .../java/org/apache/ignite/session/package.html |    24 +
 .../spi/GridSpiLocalHostInjectionTest.java      |   156 +
 .../spi/GridSpiStartStopAbstractTest.java       |    79 +
 .../org/apache/ignite/spi/GridTcpForwarder.java |   169 +
 .../spi/GridTcpSpiForwardingSelfTest.java       |   164 +
 .../GridCheckpointSpiAbstractTest.java          |     4 +-
 .../cache/CacheCheckpointSpiConfigSelfTest.java |    34 +
 .../CacheCheckpointSpiSecondCacheSelfTest.java  |   106 +
 .../cache/CacheCheckpointSpiSelfTest.java       |    29 +
 .../CacheCheckpointSpiStartStopSelfTest.java    |    34 +
 .../GridCacheCheckpointSpiConfigSelfTest.java   |    34 -
 ...idCacheCheckpointSpiSecondCacheSelfTest.java |   106 -
 .../cache/GridCacheCheckpointSpiSelfTest.java   |    29 -
 ...GridCacheCheckpointSpiStartStopSelfTest.java |    34 -
 .../ignite/spi/checkpoint/cache/package.html    |     2 +-
 .../GridJdbcCheckpointSpiConfigSelfTest.java    |    76 -
 ...idJdbcCheckpointSpiCustomConfigSelfTest.java |    47 -
 ...dJdbcCheckpointSpiDefaultConfigSelfTest.java |    45 -
 .../GridJdbcCheckpointSpiStartStopSelfTest.java |    47 -
 .../jdbc/JdbcCheckpointSpiConfigSelfTest.java   |    77 +
 .../JdbcCheckpointSpiCustomConfigSelfTest.java  |    47 +
 .../JdbcCheckpointSpiDefaultConfigSelfTest.java |    45 +
 .../JdbcCheckpointSpiStartStopSelfTest.java     |    47 +
 .../ignite/spi/checkpoint/jdbc/package.html     |     2 +-
 .../apache/ignite/spi/checkpoint/package.html   |     2 +-
 ...GridSharedFsCheckpointSpiConfigSelfTest.java |     3 +-
 ...redFsCheckpointSpiMultiThreadedSelfTest.java |    16 +-
 ...heckpointSpiMultipleDirectoriesSelfTest.java |     7 +-
 .../GridSharedFsCheckpointSpiSelfTest.java      |     7 +-
 ...dSharedFsCheckpointSpiStartStopSelfTest.java |     4 +-
 .../ignite/spi/checkpoint/sharedfs/package.html |     3 +-
 .../collision/GridTestCollisionJobContext.java  |     2 +-
 .../collision/GridTestCollisionTaskSession.java |    16 +-
 ...GridFifoQueueCollisionSpiConfigSelfTest.java |     2 +-
 .../GridFifoQueueCollisionSpiSelfTest.java      |    16 +-
 ...dFifoQueueCollisionSpiStartStopSelfTest.java |     4 +-
 .../ignite/spi/collision/fifoqueue/package.html |     3 +-
 ...bStealingCollisionSpiAttributesSelfTest.java |    14 +-
 ...idJobStealingCollisionSpiConfigSelfTest.java |     2 +-
 ...alingCollisionSpiCustomTopologySelfTest.java |    14 +-
 .../GridJobStealingCollisionSpiSelfTest.java    |    16 +-
 ...obStealingCollisionSpiStartStopSelfTest.java |    11 +-
 .../spi/collision/jobstealing/package.html      |     3 +-
 .../apache/ignite/spi/collision/package.html    |     3 +-
 ...PriorityQueueCollisionSpiConfigSelfTest.java |     2 +-
 .../GridPriorityQueueCollisionSpiSelfTest.java  |     6 +-
 ...orityQueueCollisionSpiStartStopSelfTest.java |     4 +-
 .../spi/collision/priorityqueue/package.html    |     3 +-
 .../GridAbstractCommunicationSelfTest.java      |    47 +-
 .../spi/communication/GridTestMessage.java      |    88 +-
 .../ignite/spi/communication/package.html       |     2 +-
 .../tcp/GridCacheDhtLockBackupSelfTest.java     |    63 +-
 .../GridTcpCommunicationSpiAbstractTest.java    |     8 +-
 ...mmunicationSpiConcurrentConnectSelfTest.java |    44 +-
 .../GridTcpCommunicationSpiConfigSelfTest.java  |     2 +-
 .../tcp/GridTcpCommunicationSpiLanTest.java     |    27 +-
 ...cpCommunicationSpiMultithreadedSelfTest.java |    69 +-
 ...dTcpCommunicationSpiRecoveryAckSelfTest.java |    35 +-
 ...GridTcpCommunicationSpiRecoverySelfTest.java |    41 +-
 .../GridTcpCommunicationSpiShmemSelfTest.java   |     2 +-
 ...ridTcpCommunicationSpiStartStopSelfTest.java |     6 +-
 .../tcp/GridTcpCommunicationSpiTcpSelfTest.java |     2 +-
 .../ignite/spi/communication/tcp/package.html   |     3 +-
 .../local/GridLocalDeploymentSpiSelfTest.java   |    11 +-
 ...GridLocalDeploymentSpiStartStopSelfTest.java |     4 +-
 .../ignite/spi/deployment/local/package.html    |     3 +-
 .../AbstractDiscoveryRandomStartStopTest.java   |   213 +
 .../discovery/AbstractDiscoverySelfTest.java    |   493 +
 .../spi/discovery/AbstractDiscoveryTest.java    |   153 +
 ...ClusterMetricsSnapshotSerializeSelfTest.java |   174 +
 ...ridAbstractDiscoveryRandomStartStopTest.java |   213 -
 .../GridAbstractDiscoverySelfTest.java          |   496 -
 .../discovery/GridAbstractDiscoveryTest.java    |   153 -
 .../GridDiscoveryMetricsHelperSelfTest.java     |   149 -
 .../apache/ignite/spi/discovery/package.html    |     3 +-
 .../tcp/GridTcpClientDiscoverySelfTest.java     |   691 -
 .../GridTcpDiscoveryConcurrentStartTest.java    |   118 -
 ...GridTcpDiscoveryMarshallerCheckSelfTest.java |   102 -
 .../tcp/GridTcpDiscoveryMultiThreadedTest.java  |   207 -
 .../discovery/tcp/GridTcpDiscoverySelfTest.java |   991 --
 .../GridTcpDiscoverySnapshotHistoryTest.java    |   174 -
 .../tcp/GridTcpDiscoverySpiConfigSelfTest.java  |    45 -
 .../GridTcpDiscoverySpiRandomStartStopTest.java |    45 -
 .../tcp/GridTcpDiscoverySpiSelfTest.java        |    43 -
 .../GridTcpDiscoverySpiStartStopSelfTest.java   |    82 -
 .../GridTcpDiscoverySpiWildcardSelfTest.java    |    63 -
 .../tcp/TcpClientDiscoverySelfTest.java         |   691 +
 .../tcp/TcpDiscoveryConcurrentStartTest.java    |   118 +
 .../TcpDiscoveryMarshallerCheckSelfTest.java    |   102 +
 .../tcp/TcpDiscoveryMultiThreadedTest.java      |   206 +
 .../spi/discovery/tcp/TcpDiscoverySelfTest.java |   990 ++
 .../tcp/TcpDiscoverySnapshotHistoryTest.java    |   174 +
 .../tcp/TcpDiscoverySpiConfigSelfTest.java      |    45 +
 .../tcp/TcpDiscoverySpiRandomStartStopTest.java |    45 +
 .../discovery/tcp/TcpDiscoverySpiSelfTest.java  |    43 +
 .../tcp/TcpDiscoverySpiStartStopSelfTest.java   |    79 +
 .../tcp/TcpDiscoverySpiWildcardSelfTest.java    |    63 +
 ...ridTcpDiscoveryIpFinderAbstractSelfTest.java |   125 -
 .../TcpDiscoveryIpFinderAbstractSelfTest.java   |   125 +
 .../GridTcpDiscoveryJdbcIpFinderSelfTest.java   |    90 -
 .../jdbc/TcpDiscoveryJdbcIpFinderSelfTest.java  |    90 +
 .../discovery/tcp/ipfinder/jdbc/package.html    |     3 +-
 ...idTcpDiscoveryMulticastIpFinderSelfTest.java |   115 -
 .../TcpDiscoveryMulticastIpFinderSelfTest.java  |   115 +
 .../spi/discovery/tcp/ipfinder/package.html     |     2 +-
 ...ridTcpDiscoverySharedFsIpFinderSelfTest.java |    56 -
 .../TcpDiscoverySharedFsIpFinderSelfTest.java   |    56 +
 .../tcp/ipfinder/sharedfs/package.html          |     3 +-
 .../vm/GridTcpDiscoveryVmIpFinderSelfTest.java  |   193 -
 .../vm/TcpDiscoveryVmIpFinderSelfTest.java      |   193 +
 .../spi/discovery/tcp/ipfinder/vm/package.html  |     3 +-
 .../ignite/spi/discovery/tcp/package.html       |     3 +-
 ...MemoryEventStorageMultiThreadedSelfTest.java |    11 +-
 ...GridMemoryEventStorageSpiConfigSelfTest.java |     2 +-
 .../GridMemoryEventStorageSpiSelfTest.java      |    18 +-
 ...dMemoryEventStorageSpiStartStopSelfTest.java |     4 +-
 .../ignite/spi/eventstorage/memory/package.html |     3 +-
 .../spi/failover/GridFailoverTestContext.java   |     3 +-
 .../GridAlwaysFailoverSpiConfigSelfTest.java    |     2 +-
 .../always/GridAlwaysFailoverSpiSelfTest.java   |     6 +-
 .../GridAlwaysFailoverSpiStartStopSelfTest.java |     4 +-
 .../ignite/spi/failover/always/package.html     |     3 +-
 ...ridJobStealingFailoverSpiConfigSelfTest.java |     2 +-
 ...idJobStealingFailoverSpiOneNodeSelfTest.java |    14 +-
 .../GridJobStealingFailoverSpiSelfTest.java     |    10 +-
 ...JobStealingFailoverSpiStartStopSelfTest.java |    11 +-
 .../spi/failover/jobstealing/package.html       |     3 +-
 .../never/GridNeverFailoverSpiSelfTest.java     |     7 +-
 .../GridNeverFailoverSpiStartStopSelfTest.java  |     4 +-
 .../ignite/spi/failover/never/package.html      |     3 +-
 .../org/apache/ignite/spi/failover/package.html |     2 +-
 ...dAdaptiveLoadBalancingSpiConfigSelfTest.java |     2 +-
 ...iveLoadBalancingSpiMultipleNodeSelfTest.java |     7 +-
 .../GridAdaptiveLoadBalancingSpiSelfTest.java   |     6 +-
 ...aptiveLoadBalancingSpiStartStopSelfTest.java |     4 +-
 .../spi/loadbalancing/adaptive/package.html     |     3 +-
 .../ignite/spi/loadbalancing/package.html       |     3 +-
 ...alancingNotPerTaskMultithreadedSelfTest.java |     6 +-
 ...dRobinLoadBalancingSpiLocalNodeSelfTest.java |     5 +-
 ...inLoadBalancingSpiMultipleNodesSelfTest.java |    12 +-
 ...RobinLoadBalancingSpiNotPerTaskSelfTest.java |    13 +-
 ...dRobinLoadBalancingSpiStartStopSelfTest.java |     4 +-
 ...nLoadBalancingSpiTopologyChangeSelfTest.java |     6 +-
 .../roundrobin/GridRoundRobinTestUtils.java     |     1 -
 .../spi/loadbalancing/roundrobin/package.html   |     3 +-
 ...tedRandomLoadBalancingSpiConfigSelfTest.java |     2 +-
 ...dWeightedRandomLoadBalancingSpiSelfTest.java |     7 +-
 ...RandomLoadBalancingSpiStartStopSelfTest.java |     4 +-
 ...dRandomLoadBalancingSpiWeightedSelfTest.java |     9 +-
 .../loadbalancing/weightedrandom/package.html   |     3 +-
 .../java/org/apache/ignite/spi/package.html     |    24 +
 .../GridSwapSpaceSpiAbstractSelfTest.java       |    10 +-
 .../file/GridFileSwapCompactionSelfTest.java    |     8 +-
 .../file/GridFileSwapSpaceSpiSelfTest.java      |    11 +-
 .../inmemory/GridTestSwapSpaceSpi.java          |    45 +-
 .../noop/GridNoopSwapSpaceSpiSelfTest.java      |     2 +-
 .../apache/ignite/spi/swapspace/package.html    |     3 +-
 .../startup/GridRandomCommandLineLoader.java    |   399 +
 .../ignite/startup/GridVmNodesStarter.java      |   271 +
 .../cmdline/GridCommandLineLoaderTest.java      |    12 +-
 .../GridCommandLineTransformerSelfTest.java     |    14 +-
 .../apache/ignite/startup/cmdline/package.html  |     3 +-
 .../java/org/apache/ignite/startup/package.html |    24 +
 .../startup/servlet/GridServletLoaderTest.java  |   172 +
 .../apache/ignite/startup/servlet/package.html  |    24 +
 .../GridCacheStoreValueBytesNode.java           |   139 +
 .../GridCacheStoreValueBytesTest.java           |   345 +
 .../index/GridStreamerIndexSelfTest.java        |    30 +-
 .../window/GridStreamerWindowSelfTest.java      |    40 +-
 .../ignite/testframework/GridFileLock.java      |   110 +
 .../testframework/GridJarClassLoader.java       |   178 +
 .../ignite/testframework/GridLoadTestUtils.java |   152 +
 .../testframework/GridSpiTestContext.java       |   574 +
 .../ignite/testframework/GridStringLogger.java  |   167 +
 .../testframework/GridTestClassLoader.java      |   110 +
 .../GridTestExternalClassLoader.java            |   194 +
 .../ignite/testframework/GridTestNode.java      |   254 +
 .../GridTestSafeThreadFactory.java              |   214 +
 .../ignite/testframework/GridTestThread.java    |   147 +
 .../ignite/testframework/GridTestUtils.java     |  1451 ++
 .../config/GridTestProperties.java              |   304 +
 .../ignite/testframework/config/package.html    |    24 +
 .../http/GridEmbeddedHttpServer.java            |   189 +
 .../ignite/testframework/http/package.html      |    24 +
 .../testframework/junits/GridAbstractTest.java  |  1428 ++
 .../junits/GridTestKernalContext.java           |   110 +
 .../ignite/testframework/junits/IgniteMock.java |   261 +
 .../junits/IgniteTestResources.java             |   255 +
 .../cache/GridAbstractCacheStoreSelfTest.java   |   563 +
 .../junits/cache/TestCacheSession.java          |    65 +
 .../cache/TestThreadLocalCacheSession.java      |    65 +
 .../junits/common/GridAbstractExamplesTest.java |    79 +
 .../GridAbstractLifecycleAwareSelfTest.java     |   127 +
 .../junits/common/GridCommonAbstractTest.java   |   731 +
 .../junits/common/GridCommonTest.java           |    36 +
 .../testframework/junits/common/package.html    |    24 +
 .../logger/GridLog4jRollingFileAppender.java    |   114 +
 .../junits/logger/GridTestLog4jLogger.java      |   511 +
 .../ignite/testframework/junits/package.html    |    24 +
 .../junits/spi/GridSpiAbstractConfigTest.java   |   110 +
 .../junits/spi/GridSpiAbstractTest.java         |   775 +
 .../testframework/junits/spi/GridSpiTest.java   |    62 +
 .../junits/spi/GridSpiTestConfig.java           |    48 +
 .../testframework/junits/spi/package.html       |    24 +
 .../apache/ignite/testframework/package.html    |    24 +
 .../ignite/testsuites/IgniteBasicTestSuite.java |    79 +
 .../IgniteCacheDataStructuresSelfTestSuite.java |   107 +
 .../IgniteCacheEvictionSelfTestSuite.java       |    62 +
 .../IgniteCacheFailoverTestSuite.java           |    56 +
 .../IgniteCacheFullApiSelfTestSuite.java        |   119 +
 .../IgniteCacheIteratorsSelfTestSuite.java      |    42 +
 .../IgniteCacheMetricsSelfTestSuite.java        |    52 +
 .../IgniteCacheNearOnlySelfTestSuite.java       |    45 +
 .../testsuites/IgniteCacheRestartTestSuite.java |    49 +
 .../ignite/testsuites/IgniteCacheTestSuite.java |   398 +
 .../IgniteCacheTxRecoverySelfTestSuite.java     |    46 +
 .../IgniteCacheWriteBehindTestSuite.java        |    45 +
 .../testsuites/IgniteComputeGridTestSuite.java  |    99 +
 .../IgniteContinuousTaskSelfTestSuite.java      |    42 +
 .../IgniteExternalizableSelfTestSuite.java      |    37 +
 .../ignite/testsuites/IgniteIgfsTestSuite.java  |    79 +
 .../IgniteIpcSharedMemorySelfTestSuite.java     |    41 +
 .../IgniteJobMetricsSelfTestSuite.java          |    38 +
 .../testsuites/IgniteKernalSelfTestSuite.java   |    79 +
 .../testsuites/IgniteLangSelfTestSuite.java     |    70 +
 .../testsuites/IgniteLoggingSelfTestSuite.java  |    38 +
 .../IgniteMarshallerSelfTestSuite.java          |    45 +
 .../testsuites/IgniteP2PSelfTestSuite.java      |    54 +
 .../testsuites/IgniteRestHandlerTestSuite.java  |    38 +
 .../IgniteSpiCheckpointSelfTestSuite.java       |    56 +
 .../IgniteSpiCollisionSelfTestSuite.java        |    55 +
 .../IgniteSpiCommunicationSelfTestSuite.java    |    52 +
 .../IgniteSpiDeploymentSelfTestSuite.java       |    40 +
 .../IgniteSpiDiscoverySelfTestSuite.java        |    56 +
 .../IgniteSpiEventStorageSelfTestSuite.java     |    41 +
 .../IgniteSpiFailoverSelfTestSuite.java         |    53 +
 .../IgniteSpiIndexingSelfTestSuite.java         |    38 +
 .../IgniteSpiLoadBalancingSelfTestSuite.java    |    64 +
 .../IgniteSpiSwapSpaceSelfTestSuite.java        |    41 +
 .../ignite/testsuites/IgniteSpiTestSuite.java   |    69 +
 .../testsuites/IgniteStartUpTestSuite.java      |    38 +
 .../testsuites/IgniteStreamerSelfTestSuite.java |    46 +
 .../IgniteTaskSessionSelfTestSuite.java         |    56 +
 .../IgniteTimeoutProcessorSelfTestSuite.java    |    38 +
 .../testsuites/IgniteUtilSelfTestSuite.java     |    72 +
 .../org/apache/ignite/testsuites/package.html   |    24 +
 .../GridThreadPoolExecutorServiceSelfTest.java  |   187 +
 .../apache/ignite/thread/GridThreadTest.java    |    52 +
 ...dConcurrentLinkedDequeMultiThreadedTest.java |   101 +
 .../util/GridConcurrentLinkedDequeSelfTest.java |   234 +
 ...rrentLinkedHashMapMultiThreadedSelfTest.java |   551 +
 .../apache/ignite/util/GridIndexFillTest.java   |   256 +
 .../apache/ignite/util/GridLogThrottleTest.java |   123 +
 .../ignite/util/GridLongListSelfTest.java       |   153 +
 .../apache/ignite/util/GridQueueSelfTest.java   |    71 +
 .../apache/ignite/util/GridRandomSelfTest.java  |    69 +
 .../ignite/util/GridSnapshotLockSelfTest.java   |   113 +
 .../util/GridSpinReadWriteLockSelfTest.java     |   144 +
 .../util/GridStringBuilderFactorySelfTest.java  |    72 +
 .../util/GridTopologyHeapSizeSelfTest.java      |   120 +
 .../apache/ignite/util/GridTransientTest.java   |    69 +
 .../ignite/util/mbeans/GridMBeanSelfTest.java   |   346 +
 .../java/org/apache/ignite/util/package.html    |    24 +
 .../GridCacheStoreValueBytesNode.java           |   140 -
 .../GridCacheStoreValueBytesTest.java           |   340 -
 .../grid/GridCacheAffinityBackupsSelfTest.java  |   111 -
 .../grid/GridExceptionHelpLinksSelfTest.java    |   106 -
 .../grid/GridExternalizableAbstractTest.java    |    41 -
 .../grid/GridSuppressedExceptionSelfTest.java   |   141 -
 .../java/org/gridgain/grid/GridTestIoUtils.java |   198 -
 .../java/org/gridgain/grid/GridTestJob.java     |    51 -
 .../org/gridgain/grid/GridTestJobContext.java   |   104 -
 .../org/gridgain/grid/GridTestJobResult.java    |    92 -
 .../org/gridgain/grid/GridTestNodeStartup.java  |    49 -
 .../gridgain/grid/GridTestStoreNodeStartup.java |    58 -
 .../java/org/gridgain/grid/GridTestTask.java    |    54 -
 .../org/gridgain/grid/GridTestTaskSession.java  |   235 -
 ...CachePartitionFairAffinityNodesSelfTest.java |   242 -
 .../GridCachePartitionFairAffinitySelfTest.java |   261 -
 .../store/GridCacheBalancingStoreSelfTest.java  |   200 -
 .../GridCacheLoadOnlyStoreAdapterSelfTest.java  |   108 -
 .../cache/store/GridGeneratingTestStore.java    |   104 -
 ...CacheJdbcBlobStoreMultithreadedSelfTest.java |   243 -
 .../jdbc/GridCacheJdbcBlobStoreSelfTest.java    |    51 -
 .../gridgain/grid/cache/store/jdbc/package.html |    23 -
 .../org/gridgain/grid/cache/store/package.html  |    23 -
 .../ggfs/GridGgfsEventsAbstractSelfTest.java    |   851 -
 .../GridGgfsFragmentizerAbstractSelfTest.java   |   169 -
 .../grid/ggfs/GridGgfsFragmentizerSelfTest.java |   269 -
 .../GridGgfsFragmentizerTopologySelfTest.java   |    50 -
 .../grid/ggfs/GridGgfsPathSelfTest.java         |   163 -
 .../grid/ggfs/GridGgfsTestInputGenerator.java   |    51 -
 .../grid/kernal/ClusterMetricsSelfTest.java     |   354 -
 .../grid/kernal/ClusterNodeMetricsSelfTest.java |   247 -
 .../grid/kernal/GridAffinityMappedTest.java     |   165 -
 .../grid/kernal/GridAffinityP2PSelfTest.java    |   205 -
 .../grid/kernal/GridAffinitySelfTest.java       |   119 -
 .../GridAlwaysFailoverSpiFailSelfTest.java      |   160 -
 .../kernal/GridCacheProjectionRemoveTest.java   |    41 -
 .../kernal/GridCancelOnGridStopSelfTest.java    |   108 -
 .../kernal/GridCancelUnusedJobSelfTest.java     |   221 -
 .../GridCancelledJobsMetricsSelfTest.java       |   215 -
 .../GridCollisionJobsContextSelfTest.java       |   113 -
 .../grid/kernal/GridCommunicationSelfTest.java  |   122 -
 .../GridContinuousJobAnnotationSelfTest.java    |   216 -
 .../GridContinuousJobSiblingsSelfTest.java      |   146 -
 .../grid/kernal/GridContinuousTaskSelfTest.java |   349 -
 .../GridDeploymentMultiThreadedSelfTest.java    |   122 -
 .../grid/kernal/GridDeploymentSelfTest.java     |   536 -
 .../grid/kernal/GridDiscoveryEventSelfTest.java |   421 -
 .../grid/kernal/GridDiscoverySelfTest.java      |   418 -
 .../GridEventStorageCheckAllEventsSelfTest.java |   434 -
 ...ventStorageRuntimeConfigurationSelfTest.java |   348 -
 .../grid/kernal/GridEventStorageSelfTest.java   |   269 -
 .../grid/kernal/GridExecutorServiceTest.java    |   314 -
 .../GridExplicitImplicitDeploymentSelfTest.java |   475 -
 .../grid/kernal/GridFactoryVmShutdownTest.java  |   102 -
 .../GridFailedInputParametersSelfTest.java      |   155 -
 .../GridFailoverCustomTopologySelfTest.java     |   181 -
 .../grid/kernal/GridFailoverSelfTest.java       |   150 -
 .../GridFailoverTaskWithPredicateSelfTest.java  |   256 -
 .../kernal/GridFailoverTopologySelfTest.java    |   155 -
 .../grid/kernal/GridHomePathSelfTest.java       |    75 -
 .../GridJobCheckpointCleanupSelfTest.java       |   165 -
 .../kernal/GridJobCollisionCancelSelfTest.java  |   277 -
 .../grid/kernal/GridJobContextSelfTest.java     |   120 -
 .../kernal/GridJobMasterLeaveAwareSelfTest.java |   807 -
 .../grid/kernal/GridJobStealingSelfTest.java    |   440 -
 .../GridJobStealingZeroActiveJobsSelfTest.java  |   170 -
 .../grid/kernal/GridJobSubjectIdSelfTest.java   |   153 -
 .../GridKernalConcurrentAccessStopSelfTest.java |    63 -
 .../grid/kernal/GridKernalTestUtils.java        |    44 -
 .../grid/kernal/GridLifecycleAwareSelfTest.java |   196 -
 .../grid/kernal/GridLifecycleBeanSelfTest.java  |   313 -
 .../grid/kernal/GridListenActorSelfTest.java    |   232 -
 .../kernal/GridLocalEventListenerSelfTest.java  |    73 -
 .../grid/kernal/GridManagementJobSelfTest.java  |   167 -
 .../grid/kernal/GridMultipleJobsSelfTest.java   |   232 -
 .../grid/kernal/GridMultipleSpisSelfTest.java   |   303 -
 .../GridMultipleVersionsDeploymentSelfTest.java |   301 -
 .../GridMultithreadedJobStealingSelfTest.java   |   241 -
 .../grid/kernal/GridNodeFilterSelfTest.java     |    78 -
 .../grid/kernal/GridNodeLocalSelfTest.java      |    65 -
 .../kernal/GridNodeVisorAttributesSelfTest.java |   114 -
 .../kernal/GridNonHistoryMetricsSelfTest.java   |   125 -
 .../grid/kernal/GridProjectionAbstractTest.java |   769 -
 .../kernal/GridProjectionForCachesSelfTest.java |   256 -
 ...ectionLocalJobMultipleArgumentsSelfTest.java |   156 -
 .../grid/kernal/GridProjectionSelfTest.java     |   145 -
 .../grid/kernal/GridReduceSelfTest.java         |   194 -
 .../grid/kernal/GridReleaseTypeSelfTest.java    |   134 -
 .../kernal/GridRuntimeExceptionSelfTest.java    |   303 -
 .../grid/kernal/GridSameVmStartupSelfTest.java  |   107 -
 .../org/gridgain/grid/kernal/GridSelfTest.java  |   166 -
 .../grid/kernal/GridSpiExceptionSelfTest.java   |   175 -
 .../grid/kernal/GridStartStopSelfTest.java      |   182 -
 .../gridgain/grid/kernal/GridStartupMain.java   |    57 -
 .../gridgain/grid/kernal/GridStartupTest.java   |    69 -
 .../grid/kernal/GridStopWithCancelSelfTest.java |   123 -
 .../grid/kernal/GridStopWithWaitSelfTest.java   |   258 -
 .../GridTaskCancelSingleNodeSelfTest.java       |   186 -
 .../GridTaskContinuousMapperSelfTest.java       |   332 -
 .../GridTaskExecutionContextSelfTest.java       |   179 -
 .../grid/kernal/GridTaskExecutionSelfTest.java  |    69 -
 .../grid/kernal/GridTaskFailoverSelfTest.java   |   118 -
 .../GridTaskFutureImplStopGridSelfTest.java     |   214 -
 .../GridTaskInstanceExecutionSelfTest.java      |   122 -
 .../kernal/GridTaskInstantiationSelfTest.java   |   117 -
 .../grid/kernal/GridTaskJobRejectSelfTest.java  |   161 -
 .../grid/kernal/GridTaskListenerSelfTest.java   |   107 -
 .../grid/kernal/GridTaskMapAsyncSelfTest.java   |   142 -
 .../kernal/GridTaskNameAnnotationSelfTest.java  |   124 -
 .../kernal/GridTaskResultCacheSelfTest.java     |   130 -
 .../grid/kernal/GridTaskTimeoutSelfTest.java    |   224 -
 .../kernal/GridTopicExternalizableSelfTest.java |   165 -
 .../GridTopologyBuildVersionSelfTest.java       |   101 -
 .../grid/kernal/GridUpdateNotifierSelfTest.java |    91 -
 .../grid/kernal/GridVersionSelfTest.java        |    69 -
 .../managers/GridManagerStopSelfTest.java       |   225 -
 .../managers/GridNoopManagerSelfTest.java       |    96 -
 .../GridCheckpointManagerAbstractSelfTest.java  |   756 -
 .../GridCheckpointManagerSelfTest.java          |    68 -
 .../checkpoint/GridCheckpointTaskSelfTest.java  |   232 -
 .../kernal/managers/checkpoint/package.html     |    23 -
 ...idCommunicationManagerListenersSelfTest.java |   159 -
 .../GridCommunicationSendMessageSelfTest.java   |   173 -
 .../communication/GridIoManagerSelfTest.java    |   249 -
 .../kernal/managers/communication/package.html  |    23 -
 .../GridDeploymentManagerStopSelfTest.java      |    99 -
 .../GridDeploymentMessageCountSelfTest.java     |   210 -
 .../managers/deployment/GridTestDeployment.java |    39 -
 .../kernal/managers/deployment/package.html     |    23 -
 .../GridDiscoveryManagerAliveCacheSelfTest.java |   237 -
 .../GridDiscoveryManagerAttributesSelfTest.java |   172 -
 .../discovery/GridDiscoveryManagerSelfTest.java |   154 -
 .../events/GridEventStorageManagerSelfTest.java |   125 -
 .../gridgain/grid/kernal/managers/package.html  |    23 -
 .../GridSwapSpaceCustomLocalValue.java          |    85 -
 .../swapspace/GridSwapSpaceManagerSelfTest.java |   164 -
 .../grid/kernal/managers/swapspace/package.html |    23 -
 .../java/org/gridgain/grid/kernal/package.html  |    24 -
 .../GridAffinityProcessorAbstractSelfTest.java  |   194 -
 ...AffinityProcessorConsistentHashSelfTest.java |    31 -
 ...GridAffinityProcessorRendezvousSelfTest.java |    31 -
 ...ridCacheAbstractByteArrayValuesSelfTest.java |    83 -
 .../GridCacheAbstractFailoverSelfTest.java      |   430 -
 .../cache/GridCacheAbstractFlagsTest.java       |    98 -
 ...cheAbstractFullApiMultithreadedSelfTest.java |   402 -
 .../cache/GridCacheAbstractFullApiSelfTest.java |  5196 -------
 .../GridCacheAbstractIteratorsSelfTest.java     |   349 -
 .../cache/GridCacheAbstractMetricsSelfTest.java |   218 -
 .../GridCacheAbstractProjectionSelfTest.java    |   834 -
 .../GridCacheAbstractRemoveFailureTest.java     |   322 -
 .../cache/GridCacheAbstractSelfTest.java        |   575 -
 .../cache/GridCacheAbstractTtlSelfTest.java     |   104 -
 .../cache/GridCacheAbstractTxReadTest.java      |   137 -
 .../cache/GridCacheAffinityApiSelfTest.java     |   361 -
 .../cache/GridCacheAffinityMapperSelfTest.java  |   132 -
 .../cache/GridCacheAffinityRoutingSelfTest.java |   690 -
 .../cache/GridCacheAlwaysEvictionPolicy.java    |    34 -
 .../GridCacheAsyncOperationsLimitSelfTest.java  |    76 -
 .../GridCacheAtomicMessageCountSelfTest.java    |   233 -
 .../cache/GridCacheBasicApiAbstractTest.java    |   581 -
 .../cache/GridCacheBasicStoreAbstractTest.java  |   584 -
 ...acheBasicStoreMultithreadedAbstractTest.java |   128 -
 .../cache/GridCacheClearAllSelfTest.java        |   335 -
 ...dCacheColocatedTxStoreExceptionSelfTest.java |    38 -
 .../cache/GridCacheConcurrentMapSelfTest.java   |   384 -
 .../cache/GridCacheConcurrentMapTest.java       |   137 -
 .../GridCacheConcurrentTxMultiNodeTest.java     |   856 -
 ...idCacheConfigurationConsistencySelfTest.java |  1042 --
 ...ridCacheConfigurationValidationSelfTest.java |   196 -
 .../GridCacheDaemonNodeAbstractSelfTest.java    |   189 -
 .../GridCacheDeploymentOffHeapSelfTest.java     |    42 -
 .../cache/GridCacheDeploymentSelfTest.java      |   485 -
 .../cache/GridCacheEntryMemorySizeSelfTest.java |   314 -
 .../cache/GridCacheEntryVersionSelfTest.java    |   158 -
 .../GridCacheEvictionEventAbstractTest.java     |   121 -
 .../GridCacheExAbstractFullApiSelfTest.java     |   103 -
 .../GridCacheFieldsQueryNoDataSelfTest.java     |    82 -
 .../GridCacheFinishPartitionsSelfTest.java      |   311 -
 ...CacheFullTextQueryMultithreadedSelfTest.java |   156 -
 .../cache/GridCacheGenericTestStore.java        |   269 -
 ...idCacheGetAndTransformStoreAbstractTest.java |   164 -
 .../cache/GridCacheGlobalClearAllSelfTest.java  |   167 -
 .../GridCacheGroupLockAbstractSelfTest.java     |  1295 --
 ...heGroupLockFailoverOptimisticTxSelfTest.java |    28 -
 .../GridCacheGroupLockFailoverSelfTest.java     |   532 -
 ...CacheGroupLockMultiNodeAbstractSelfTest.java |    28 -
 .../cache/GridCacheGroupLockPutTask.java        |   157 -
 .../cache/GridCacheIncrementTransformTest.java  |   229 -
 .../GridCacheInterceptorAbstractSelfTest.java   |  1675 --
 ...cheInterceptorAtomicNearEnabledSelfTest.java |    31 -
 ...erceptorAtomicPrimaryWriteOrderSelfTest.java |    45 -
 ...omicReplicatedPrimaryWriteOrderSelfTest.java |    46 -
 ...acheInterceptorAtomicReplicatedSelfTest.java |    45 -
 .../GridCacheInterceptorAtomicSelfTest.java     |    45 -
 ...ceptorAtomicWithStoreReplicatedSelfTest.java |    31 -
 ...CacheInterceptorAtomicWithStoreSelfTest.java |    30 -
 ...GridCacheInterceptorLocalAtomicSelfTest.java |    50 -
 ...InterceptorLocalAtomicWithStoreSelfTest.java |    30 -
 .../GridCacheInterceptorLocalSelfTest.java      |    44 -
 ...dCacheInterceptorLocalWithStoreSelfTest.java |    30 -
 ...GridCacheInterceptorNearEnabledSelfTest.java |    30 -
 .../GridCacheInterceptorReplicatedSelfTest.java |    39 -
 ...eInterceptorReplicatedWithStoreSelfTest.java |    30 -
 .../cache/GridCacheInterceptorSelfTest.java     |    39 -
 .../GridCacheInterceptorSelfTestSuite.java      |    56 -
 .../GridCacheInterceptorWithStoreSelfTest.java  |    30 -
 .../cache/GridCacheIteratorPerformanceTest.java |   277 -
 .../GridCacheKeyCheckNearEnabledSelfTest.java   |    30 -
 .../cache/GridCacheKeyCheckSelfTest.java        |   205 -
 .../processors/cache/GridCacheLeakTest.java     |   150 -
 .../cache/GridCacheLifecycleAwareSelfTest.java  |   348 -
 .../GridCacheLocalTxStoreExceptionSelfTest.java |    37 -
 .../cache/GridCacheLuceneQueryIndexTest.java    |   465 -
 .../GridCacheMarshallerTxAbstractTest.java      |   132 -
 .../cache/GridCacheMemoryModeSelfTest.java      |   269 -
 .../GridCacheMissingCommitVersionSelfTest.java  |   127 -
 ...GridCacheMixedPartitionExchangeSelfTest.java |   152 -
 .../cache/GridCacheMultiUpdateLockSelfTest.java |   203 -
 ...ridCacheMultinodeUpdateAbstractSelfTest.java |   128 -
 ...ultinodeUpdateAtomicNearEnabledSelfTest.java |    39 -
 .../GridCacheMultinodeUpdateAtomicSelfTest.java |    38 -
 ...inodeUpdateNearEnabledNoBackupsSelfTest.java |    39 -
 ...CacheMultinodeUpdateNearEnabledSelfTest.java |    40 -
 .../cache/GridCacheMultinodeUpdateSelfTest.java |    39 -
 .../cache/GridCacheMvccFlagsTest.java           |   141 -
 .../cache/GridCacheMvccManagerSelfTest.java     |   115 -
 .../cache/GridCacheMvccPartitionedSelfTest.java |   687 -
 .../processors/cache/GridCacheMvccSelfTest.java |  1850 ---
 .../GridCacheNearTxStoreExceptionSelfTest.java  |    32 -
 .../cache/GridCacheNestedTxAbstractTest.java    |   289 -
 .../cache/GridCacheObjectToStringSelfTest.java  |   193 -
 ...ffHeapAtomicMultiThreadedUpdateSelfTest.java |    33 -
 ...HeapMultiThreadedUpdateAbstractSelfTest.java |   389 -
 ...CacheOffHeapMultiThreadedUpdateSelfTest.java |   267 -
 .../cache/GridCacheOffHeapSelfTest.java         |   654 -
 .../processors/cache/GridCacheOffHeapTest.java  |   257 -
 .../GridCacheOffHeapTieredAbstractSelfTest.java |   692 -
 .../GridCacheOffHeapTieredAtomicSelfTest.java   |    32 -
 ...heOffHeapTieredEvictionAbstractSelfTest.java |   414 -
 ...acheOffHeapTieredEvictionAtomicSelfTest.java |    32 -
 .../GridCacheOffHeapTieredEvictionSelfTest.java |    33 -
 .../cache/GridCacheOffHeapTieredSelfTest.java   |    33 -
 .../cache/GridCacheOffheapUpdateSelfTest.java   |   139 -
 .../GridCacheOrderedPreloadingSelfTest.java     |   157 -
 .../cache/GridCacheP2PUndeploySelfTest.java     |   306 -
 .../GridCachePartitionedAffinitySpreadTest.java |   167 -
 .../cache/GridCachePartitionedGetSelfTest.java  |   252 -
 ...hePartitionedProjectionAffinitySelfTest.java |   118 -
 .../cache/GridCachePartitionedWritesTest.java   |   143 -
 .../GridCachePreloadingEvictionsSelfTest.java   |   262 -
 .../cache/GridCachePutAllFailoverSelfTest.java  |   707 -
 .../processors/cache/GridCachePutAllTask.java   |   133 -
 .../cache/GridCacheQueryEmbeddedValue.java      |    49 -
 .../cache/GridCacheQueryIndexSelfTest.java      |   124 -
 .../GridCacheQueryIndexingDisabledSelfTest.java |    97 -
 .../GridCacheQueryInternalKeysSelfTest.java     |   112 -
 .../GridCacheReferenceCleanupSelfTest.java      |   502 -
 .../GridCacheRefreshAheadAbstractSelfTest.java  |   177 -
 .../cache/GridCacheReloadSelfTest.java          |   173 -
 ...ridCacheReplicatedSynchronousCommitTest.java |   202 -
 ...CacheReplicatedTxStoreExceptionSelfTest.java |    38 -
 .../GridCacheReturnValueTransferSelfTest.java   |   193 -
 .../cache/GridCacheSlowTxWarnTest.java          |   147 -
 .../processors/cache/GridCacheStopSelfTest.java |   201 -
 .../cache/GridCacheStorePutxSelfTest.java       |   160 -
 .../cache/GridCacheStoreValueBytesSelfTest.java |   111 -
 .../cache/GridCacheSwapPreloadSelfTest.java     |   223 -
 .../cache/GridCacheSwapReloadSelfTest.java      |   239 -
 .../processors/cache/GridCacheTestEntryEx.java  |   776 -
 .../processors/cache/GridCacheTestKey.java      |    64 -
 .../processors/cache/GridCacheTestStore.java    |   324 -
 .../processors/cache/GridCacheTestValue.java    |    77 -
 .../processors/cache/GridCacheTestValue2.java   |    67 -
 ...cheTransactionalAbstractMetricsSelfTest.java |   280 -
 .../cache/GridCacheTtlManagerLoadTest.java      |    85 -
 .../cache/GridCacheTtlManagerSelfTest.java      |   124 -
 .../cache/GridCacheUtilsSelfTest.java           |   261 -
 .../GridCacheValueBytesPreloadingSelfTest.java  |   151 -
 ...idCacheValueConsistencyAbstractSelfTest.java |   322 -
 ...istencyTransactionalNearEnabledSelfTest.java |    31 -
 ...heValueConsistencyTransactionalSelfTest.java |    37 -
 .../GridCacheVariableTopologySelfTest.java      |   191 -
 .../cache/GridCacheVersionSelfTest.java         |    80 -
 ...idCacheWriteBehindStoreAbstractSelfTest.java |   190 -
 .../GridCacheWriteBehindStoreAbstractTest.java  |   353 -
 .../GridCacheWriteBehindStoreLocalTest.java     |    30 -
 ...heWriteBehindStoreMultithreadedSelfTest.java |   163 -
 ...BehindStorePartitionedMultiNodeSelfTest.java |   207 -
 ...ridCacheWriteBehindStorePartitionedTest.java |    30 -
 ...GridCacheWriteBehindStoreReplicatedTest.java |    30 -
 .../GridCacheWriteBehindStoreSelfTest.java      |   275 -
 .../processors/cache/IgniteTxAbstractTest.java  |   492 -
 .../IgniteTxConcurrentGetAbstractTest.java      |   142 -
 .../IgniteTxExceptionAbstractSelfTest.java      |   639 -
 .../cache/IgniteTxMultiNodeAbstractTest.java    |   926 --
 .../IgniteTxMultiThreadedAbstractTest.java      |   283 -
 .../cache/IgniteTxReentryAbstractSelfTest.java  |   177 -
 .../IgniteTxSingleThreadedAbstractTest.java     |   137 -
 .../IgniteTxStoreExceptionAbstractSelfTest.java |   639 -
 ...eAbstractDataStructuresFailoverSelfTest.java |   994 --
 ...actQueueFailoverDataConsistencySelfTest.java |   373 -
 .../GridCacheAtomicLongApiSelfTest.java         |   484 -
 ...CacheAtomicReferenceApiSelfAbstractTest.java |   187 -
 ...cheAtomicReferenceMultiNodeAbstractTest.java |   202 -
 ...idCacheAtomicStampedApiSelfAbstractTest.java |   153 -
 .../GridCacheCountDownLatchSelfTest.java        |   410 -
 .../GridCacheMultiNodeDataStructureTest.java    |    79 -
 .../GridCacheQueueApiSelfAbstractTest.java      |   712 -
 .../GridCacheQueueCleanupSelfTest.java          |   235 -
 ...ridCacheQueueJoinedNodeSelfAbstractTest.java |   306 -
 ...GridCacheQueueMultiNodeAbstractSelfTest.java |   832 -
 ...dCacheQueueMultiNodeConsistencySelfTest.java |   255 -
 ...CacheQueueRotativeMultiNodeAbstractTest.java |   442 -
 .../GridCacheSequenceApiSelfAbstractTest.java   |   572 -
 ...dCacheSequenceMultiNodeAbstractSelfTest.java |   290 -
 .../GridCacheSetAbstractSelfTest.java           |   897 --
 .../GridCacheSetFailoverAbstractSelfTest.java   |   239 -
 .../GridCacheLocalAtomicQueueApiSelfTest.java   |    39 -
 .../local/GridCacheLocalAtomicSetSelfTest.java  |    44 -
 .../local/GridCacheLocalQueueApiSelfTest.java   |    44 -
 .../GridCacheLocalSequenceApiSelfTest.java      |    46 -
 .../local/GridCacheLocalSetSelfTest.java        |    38 -
 ...dCachePartitionedAtomicQueueApiSelfTest.java |    41 -
 ...ionedAtomicQueueCreateMultiNodeSelfTest.java |    39 -
 ...micQueueFailoverDataConsistencySelfTest.java |    34 -
 ...PartitionedAtomicQueueMultiNodeSelfTest.java |    41 -
 ...itionedAtomicQueueRotativeMultiNodeTest.java |    42 -
 ...hePartitionedAtomicReferenceApiSelfTest.java |    48 -
 ...PartitionedAtomicReferenceMultiNodeTest.java |    47 -
 ...titionedAtomicSequenceMultiThreadedTest.java |   359 -
 ...chePartitionedAtomicSetFailoverSelfTest.java |    39 -
 .../GridCachePartitionedAtomicSetSelfTest.java  |    49 -
 ...achePartitionedAtomicStampedApiSelfTest.java |    52 -
 ...rtitionedDataStructuresFailoverSelfTest.java |    34 -
 ...GridCachePartitionedNodeRestartSelfTest.java |    68 -
 ...idCachePartitionedNodeRestartTxSelfTest.java |   294 -
 .../GridCachePartitionedQueueApiSelfTest.java   |    52 -
 ...PartitionedQueueCreateMultiNodeSelfTest.java |   194 -
 ...dCachePartitionedQueueEntryMoveSelfTest.java |   255 -
 ...nedQueueFailoverDataConsistencySelfTest.java |    27 -
 ...CachePartitionedQueueJoinedNodeSelfTest.java |    52 -
 ...dCachePartitionedQueueMultiNodeSelfTest.java |    50 -
 ...hePartitionedQueueRotativeMultiNodeTest.java |    49 -
 ...GridCachePartitionedSequenceApiSelfTest.java |    51 -
 ...chePartitionedSequenceMultiNodeSelfTest.java |    51 -
 ...GridCachePartitionedSetFailoverSelfTest.java |    33 -
 .../GridCachePartitionedSetSelfTest.java        |    33 -
 ...cheReplicatedAtomicReferenceApiSelfTest.java |    45 -
 ...eReplicatedAtomicReferenceMultiNodeTest.java |    45 -
 ...CacheReplicatedAtomicStampedApiSelfTest.java |    44 -
 ...eplicatedDataStructuresFailoverSelfTest.java |    34 -
 .../GridCacheReplicatedQueueApiSelfTest.java    |    47 -
 ...idCacheReplicatedQueueMultiNodeSelfTest.java |    47 -
 ...cheReplicatedQueueRotativeMultiNodeTest.java |    47 -
 .../GridCacheReplicatedSequenceApiSelfTest.java |    46 -
 ...acheReplicatedSequenceMultiNodeSelfTest.java |    46 -
 .../GridCacheReplicatedSetSelfTest.java         |    33 -
 ...tractDistributedByteArrayValuesSelfTest.java |   389 -
 .../GridCacheAbstractJobExecutionTest.java      |   183 -
 .../GridCacheAbstractNodeRestartSelfTest.java   |   886 --
 ...tractPartitionedByteArrayValuesSelfTest.java |   100 -
 .../GridCacheAbstractPrimarySyncSelfTest.java   |   108 -
 .../GridCacheAtomicTimeoutSelfTest.java         |   297 -
 .../GridCacheBasicOpAbstractTest.java           |   396 -
 .../GridCacheClientModesAbstractSelfTest.java   |   201 -
 .../GridCacheEntrySetAbstractSelfTest.java      |   117 -
 ...acheEntrySetIterationPreloadingSelfTest.java |    90 -
 .../distributed/GridCacheEventAbstractTest.java |   964 --
 ...heExpiredEntriesPreloadAbstractSelfTest.java |   114 -
 .../distributed/GridCacheLockAbstractTest.java  |   463 -
 .../distributed/GridCacheMixedModeSelfTest.java |    81 -
 .../GridCacheModuloAffinityFunction.java        |   200 -
 .../GridCacheMultiNodeAbstractTest.java         |   490 -
 .../GridCacheMultiNodeLockAbstractTest.java     |   695 -
 ...dCacheMultithreadedFailoverAbstractTest.java |   606 -
 .../GridCacheNodeFailureAbstractTest.java       |   296 -
 ...dCachePartitionedAffinityFilterSelfTest.java |   144 -
 ...chePartitionedReloadAllAbstractSelfTest.java |   238 -
 .../GridCachePreloadEventsAbstractSelfTest.java |   131 -
 .../GridCachePreloadLifecycleAbstractTest.java  |   231 -
 ...GridCachePreloadRestartAbstractSelfTest.java |   322 -
 .../GridCacheTransformEventSelfTest.java        |   587 -
 ...iteTxConsistencyRestartAbstractSelfTest.java |   202 -
 ...xOriginatingNodeFailureAbstractSelfTest.java |   303 -
 ...cOriginatingNodeFailureAbstractSelfTest.java |   501 -
 .../IgniteTxPreloadAbstractTest.java            |   200 -
 .../IgniteTxTimeoutAbstractTest.java            |   155 -
 ...tPartitionedOnlyByteArrayValuesSelfTest.java |   168 -
 ...heAbstractTransformWriteThroughSelfTest.java |   320 -
 ...acheAtomicExpiredEntriesPreloadSelfTest.java |    45 -
 .../dht/GridCacheAtomicFullApiSelfTest.java     |   100 -
 .../dht/GridCacheAtomicNearCacheSelfTest.java   |   817 -
 ...idCacheAtomicNearEnabledFullApiSelfTest.java |    32 -
 ...EnabledPrimaryWriteOrderFullApiSelfTest.java |    33 -
 ...eAtomicPrimaryWriteOrderFullApiSelfTest.java |    32 -
 ...tomicPrimaryWriteOrderReloadAllSelfTest.java |    32 -
 .../dht/GridCacheAtomicReloadAllSelfTest.java   |    38 -
 .../dht/GridCacheClientOnlySelfTest.java        |    38 -
 .../dht/GridCacheColocatedDebugTest.java        |   958 --
 .../dht/GridCacheColocatedFailoverSelfTest.java |    39 -
 ...eColocatedOptimisticTransactionSelfTest.java |   156 -
 ...ridCacheColocatedPreloadRestartSelfTest.java |    30 -
 .../GridCacheColocatedPrimarySyncSelfTest.java  |    33 -
 .../GridCacheColocatedRefreshAheadSelfTest.java |    54 -
 .../GridCacheColocatedReloadAllSelfTest.java    |    30 -
 .../GridCacheColocatedTxExceptionSelfTest.java  |    39 -
 ...ssimisticOriginatingNodeFailureSelfTest.java |    49 -
 ...dCacheColocatedTxSingleThreadedSelfTest.java |   107 -
 .../GridCacheDaemonNodePartitionedSelfTest.java |    31 -
 ...cheDhtAtomicEvictionNearReadersSelfTest.java |    32 -
 .../GridCacheDhtAtomicRemoveFailureTest.java    |    51 -
 .../dht/GridCacheDhtEntrySelfTest.java          |   314 -
 .../dht/GridCacheDhtEntrySetSelfTest.java       |    46 -
 ...GridCacheDhtEvictionNearReadersSelfTest.java |   298 -
 .../dht/GridCacheDhtEvictionSelfTest.java       |   364 -
 .../GridCacheDhtEvictionsDisabledSelfTest.java  |   125 -
 ...idCacheDhtExpiredEntriesPreloadSelfTest.java |    39 -
 .../dht/GridCacheDhtInternalEntrySelfTest.java  |   226 -
 .../dht/GridCacheDhtMappingSelfTest.java        |   105 -
 .../dht/GridCacheDhtMultiBackupTest.java        |   136 -
 .../dht/GridCacheDhtPreloadBigDataSelfTest.java |   229 -
 .../dht/GridCacheDhtPreloadDelayedSelfTest.java |   460 -
 .../GridCacheDhtPreloadDisabledSelfTest.java    |   279 -
 .../GridCacheDhtPreloadMessageCountTest.java    |   175 -
 ...ridCacheDhtPreloadMultiThreadedSelfTest.java |   175 -
 .../dht/GridCacheDhtPreloadOffHeapSelfTest.java |    39 -
 .../dht/GridCacheDhtPreloadPutGetSelfTest.java  |   275 -
 .../dht/GridCacheDhtPreloadSelfTest.java        |   675 -
 .../GridCacheDhtPreloadStartStopSelfTest.java   |   270 -
 .../dht/GridCacheDhtPreloadUnloadSelfTest.java  |   322 -
 .../dht/GridCacheDhtRemoveFailureTest.java      |    44 -
 .../distributed/dht/GridCacheDhtTestUtils.java  |   232 -
 .../dht/GridCacheDhtTxPreloadSelfTest.java      |    44 -
 .../GridCacheExColocatedFullApiSelfTest.java    |    33 -
 .../GridCacheGroupLockColocatedSelfTest.java    |    38 -
 ...acheGroupLockMultiNodeColocatedSelfTest.java |    29 -
 ...cheGroupLockPartitionedAbstractSelfTest.java |   136 -
 ...ockPartitionedMultiNodeAbstractSelfTest.java |   173 -
 ...ePartitionedNearDisabledFullApiSelfTest.java |    33 -
 ...ePartitionedNearDisabledMetricsSelfTest.java |   119 -
 ...nedNearDisabledMultiNodeFullApiSelfTest.java |    34 -
 ...bledMultiNodeP2PDisabledFullApiSelfTest.java |    34 -
 ...ionedNearDisabledOffHeapFullApiSelfTest.java |    29 -
 ...DisabledOffHeapMultiNodeFullApiSelfTest.java |    29 -
 ...isabledTxOriginatingNodeFailureSelfTest.java |    32 -
 ...dOnlyP2PDisabledByteArrayValuesSelfTest.java |    29 -
 ...edOnlyP2PEnabledByteArrayValuesSelfTest.java |    29 -
 ...dCachePartitionedOnlyProjectionSelfTest.java |    32 -
 ...idCachePartitionedPreloadEventsSelfTest.java |   124 -
 ...ridCachePartitionedRefreshAheadSelfTest.java |    54 -
 ...dCachePartitionedTopologyChangeSelfTest.java |   600 -
 ...ransformWriteThroughBatchUpdateSelfTest.java |    29 -
 ...itionedTxOriginatingNodeFailureSelfTest.java |   161 -
 ...ridCachePartitionedUnloadEventsSelfTest.java |   151 -
 ...teTxConsistencyColocatedRestartSelfTest.java |    36 -
 .../dht/IgniteTxReentryColocatedSelfTest.java   |    79 -
 ...eAtomicInvalidPartitionHandlingSelfTest.java |   326 -
 .../atomic/GridCacheAtomicPreloadSelfTest.java  |   214 -
 ...lueConsistencyAtomicNearEnabledSelfTest.java |    38 -
 ...micPrimaryWriteOrderNearEnabledSelfTest.java |    39 -
 ...GridCacheValueConsistencyAtomicSelfTest.java |   129 -
 ...tNearPartitionedByteArrayValuesSelfTest.java |    34 -
 ...unctionExcludeNeighborsAbstractSelfTest.java |   184 -
 ...tomicClientOnlyMultiNodeFullApiSelfTest.java |   509 -
 ...OnlyMultiNodeP2PDisabledFullApiSelfTest.java |    35 -
 ...GridCacheAtomicMultiNodeFullApiSelfTest.java |    68 -
 ...omicMultiNodeP2PDisabledFullApiSelfTest.java |    66 -
 ...omicNearEnabledMultiNodeFullApiSelfTest.java |    32 -
 ...imaryWriteOrderMultiNodeFullApiSelfTest.java |    33 -
 ...ridCacheAtomicNearEvictionEventSelfTest.java |    39 -
 .../GridCacheAtomicNearEvictionSelfTest.java    |    32 -
 .../GridCacheAtomicNearMultiNodeSelfTest.java   |    32 -
 ...eAtomicNearOnlyMultiNodeFullApiSelfTest.java |   196 -
 ...OnlyMultiNodeP2PDisabledFullApiSelfTest.java |    35 -
 .../near/GridCacheAtomicNearOnlySelfTest.java   |    32 -
 .../GridCacheAtomicNearReadersSelfTest.java     |    32 -
 .../GridCacheAtomicNearRemoveFailureTest.java   |    51 -
 .../GridCacheAtomicOffHeapFullApiSelfTest.java  |    65 -
 ...heAtomicOffHeapMultiNodeFullApiSelfTest.java |    66 -
 ...idCacheAtomicPartitionedMetricsSelfTest.java |    64 -
 ...imaryWriteOrderMultiNodeFullApiSelfTest.java |    32 -
 ...rderMultiNodeP2PDisabledFullApiSelfTest.java |    33 -
 ...cPrimaryWriteOrderNearRemoveFailureTest.java |    51 -
 ...PrimaryWriteOrderOffHeapFullApiSelfTest.java |    32 -
 ...ityOrderOffHeapMultiNodeFullApiSelfTest.java |    33 -
 ...ffinityFunctionExcludeNeighborsSelfTest.java |    32 -
 .../near/GridCacheExNearFullApiSelfTest.java    |    39 -
 .../near/GridCacheGetStoreErrorSelfTest.java    |   147 -
 ...GridCacheGroupLockMultiNodeNearSelfTest.java |    30 -
 .../near/GridCacheGroupLockNearSelfTest.java    |    38 -
 .../GridCacheNearEvictionEventSelfTest.java     |    48 -
 .../near/GridCacheNearEvictionSelfTest.java     |   186 -
 ...dCacheNearExpiredEntriesPreloadSelfTest.java |    39 -
 .../near/GridCacheNearJobExecutionSelfTest.java |    48 -
 .../near/GridCacheNearMetricsSelfTest.java      |   395 -
 .../near/GridCacheNearMultiGetSelfTest.java     |   308 -
 .../near/GridCacheNearMultiNodeSelfTest.java    |   962 --
 .../near/GridCacheNearOneNodeSelfTest.java      |   382 -
 ...idCacheNearOnlyMultiNodeFullApiSelfTest.java |   465 -
 ...OnlyMultiNodeP2PDisabledFullApiSelfTest.java |    34 -
 .../near/GridCacheNearOnlySelfTest.java         |    68 -
 .../near/GridCacheNearOnlyTopologySelfTest.java |   233 -
 .../GridCacheNearPartitionedClearSelfTest.java  |   150 -
 ...ionedP2PDisabledByteArrayValuesSelfTest.java |    29 -
 ...tionedP2PEnabledByteArrayValuesSelfTest.java |    29 -
 .../GridCacheNearPreloadRestartSelfTest.java    |    30 -
 .../near/GridCacheNearPrimarySyncSelfTest.java  |    33 -
 .../GridCacheNearReaderPreloadSelfTest.java     |   200 -
 .../near/GridCacheNearReadersSelfTest.java      |   584 -
 .../near/GridCacheNearReloadAllSelfTest.java    |    30 -
 .../near/GridCacheNearRemoveFailureTest.java    |    45 -
 .../near/GridCacheNearTxExceptionSelfTest.java  |    33 -
 .../near/GridCacheNearTxMultiNodeSelfTest.java  |   245 -
 ...ssimisticOriginatingNodeFailureSelfTest.java |    49 -
 .../near/GridCacheNearTxPreloadSelfTest.java    |    44 -
 ...AffinityExcludeNeighborsPerformanceTest.java |   254 -
 ...rtitionedAffinityHashIdResolverSelfTest.java |    97 -
 .../GridCachePartitionedAffinitySelfTest.java   |   516 -
 ...ionedAtomicGetAndTransformStoreSelfTest.java |    33 -
 .../near/GridCachePartitionedBasicApiTest.java  |    47 -
 .../GridCachePartitionedBasicOpSelfTest.java    |    67 -
 ...ePartitionedBasicStoreMultiNodeSelfTest.java |   352 -
 .../GridCachePartitionedBasicStoreSelfTest.java |    33 -
 ...ionedClientOnlyNoPrimaryFullApiSelfTest.java |    67 -
 .../GridCachePartitionedEntryLockSelfTest.java  |   111 -
 .../near/GridCachePartitionedEventSelfTest.java |    60 -
 .../GridCachePartitionedEvictionSelfTest.java   |   208 -
 ...titionedExplicitLockNodeFailureSelfTest.java |   164 -
 .../GridCachePartitionedFailoverSelfTest.java   |    33 -
 ...GridCachePartitionedFilteredPutSelfTest.java |   165 -
 .../near/GridCachePartitionedFlagsTest.java     |    41 -
 ...PartitionedFullApiMultithreadedSelfTest.java |    38 -
 .../GridCachePartitionedFullApiSelfTest.java    |   251 -
 ...PartitionedGetAndTransformStoreSelfTest.java |    34 -
 .../GridCachePartitionedIteratorsSelfTest.java  |    43 -
 .../GridCachePartitionedLoadCacheSelfTest.java  |   144 -
 .../near/GridCachePartitionedLockSelfTest.java  |   102 -
 .../GridCachePartitionedMetricsSelfTest.java    |    60 -
 ...achePartitionedMultiNodeCounterSelfTest.java |   779 -
 ...achePartitionedMultiNodeFullApiSelfTest.java |   596 -
 ...idCachePartitionedMultiNodeLockSelfTest.java |    88 -
 ...onedMultiNodeP2PDisabledFullApiSelfTest.java |    35 -
 .../GridCachePartitionedMultiNodeSelfTest.java  |    48 -
 ...ePartitionedMultiThreadedPutGetSelfTest.java |   204 -
 ...NearDisabledBasicStoreMultiNodeSelfTest.java |    33 -
 ...itionedNearOnlyNoPrimaryFullApiSelfTest.java |    31 -
 .../near/GridCachePartitionedNestedTxTest.java  |    50 -
 ...GridCachePartitionedNodeFailureSelfTest.java |    50 -
 .../GridCachePartitionedNodeRestartTest.java    |   131 -
 ...dCachePartitionedOffHeapFullApiSelfTest.java |    28 -
 ...titionedOffHeapMultiNodeFullApiSelfTest.java |    28 -
 ...ePartitionedOptimisticTxNodeRestartTest.java |   127 -
 ...achePartitionedPreloadLifecycleSelfTest.java |   278 -
 .../GridCachePartitionedProjectionSelfTest.java |   155 -
 ...hePartitionedQueryMultiThreadedSelfTest.java |   304 -
 .../GridCachePartitionedStorePutSelfTest.java   |   147 -
 .../near/GridCachePartitionedTtlSelfTest.java   |    33 -
 ...GridCachePartitionedTxConcurrentGetTest.java |    46 -
 ...GridCachePartitionedTxMultiNodeSelfTest.java |    81 -
 ...CachePartitionedTxMultiThreadedSelfTest.java |   105 -
 .../near/GridCachePartitionedTxReadTest.java    |    33 -
 .../GridCachePartitionedTxSalvageSelfTest.java  |   284 -
 ...achePartitionedTxSingleThreadedSelfTest.java |   106 -
 .../GridCachePartitionedTxTimeoutSelfTest.java  |    67 -
 .../near/GridCachePutArrayValueSelfTest.java    |   116 -
 ...idCacheRendezvousAffinityClientSelfTest.java |   105 -
 ...ffinityFunctionExcludeNeighborsSelfTest.java |    32 -
 .../near/GridPartitionedBackupLoadSelfTest.java |   164 -
 .../near/IgniteTxReentryNearSelfTest.java       |    79 -
 ...stractReplicatedByteArrayValuesSelfTest.java |    84 -
 ...ridCacheAtomicReplicatedMetricsSelfTest.java |    59 -
 .../GridCacheDaemonNodeReplicatedSelfTest.java  |    31 -
 .../GridCacheExReplicatedFullApiSelfTest.java   |    33 -
 ...cheGroupLockMultiNodeReplicatedSelfTest.java |    45 -
 .../GridCacheGroupLockReplicatedSelfTest.java   |    39 -
 ...ridCacheReplicatedAtomicFullApiSelfTest.java |    42 -
 ...catedAtomicGetAndTransformStoreSelfTest.java |    33 -
 ...eplicatedAtomicMultiNodeFullApiSelfTest.java |    59 -
 ...imaryWriteOrderMultiNodeFullApiSelfTest.java |    33 -
 .../GridCacheReplicatedBasicApiTest.java        |    42 -
 .../GridCacheReplicatedBasicOpSelfTest.java     |    42 -
 .../GridCacheReplicatedBasicStoreSelfTest.java  |    33 -
 .../GridCacheReplicatedClientOnlySelfTest.java  |    42 -
 .../GridCacheReplicatedEntrySetSelfTest.java    |    33 -
 .../GridCacheReplicatedEventSelfTest.java       |    38 -
 ...ridCacheReplicatedEvictionEventSelfTest.java |    38 -
 .../GridCacheReplicatedEvictionSelfTest.java    |   130 -
 .../GridCacheReplicatedFailoverSelfTest.java    |    33 -
 .../GridCacheReplicatedFlagsTest.java           |    28 -
 ...eReplicatedFullApiMultithreadedSelfTest.java |    38 -
 ...ReplicatedFullApiMultithreadedSelfTest1.java |  1980 ---
 .../GridCacheReplicatedFullApiSelfTest.java     |    57 -
 ...eReplicatedGetAndTransformStoreSelfTest.java |    39 -
 .../GridCacheReplicatedInvalidateSelfTest.java  |   244 -
 .../GridCacheReplicatedIteratorsSelfTest.java   |    43 -
 .../GridCacheReplicatedJobExecutionTest.java    |    45 -
 .../GridCacheReplicatedLockSelfTest.java        |    33 -
 .../GridCacheReplicatedMarshallerTxTest.java    |    47 -
 .../GridCacheReplicatedMetricsSelfTest.java     |    54 -
 ...CacheReplicatedMultiNodeFullApiSelfTest.java |    28 -
 ...ridCacheReplicatedMultiNodeLockSelfTest.java |    42 -
 ...atedMultiNodeP2PDisabledFullApiSelfTest.java |    35 -
 .../GridCacheReplicatedMultiNodeSelfTest.java   |    42 -
 ...licatedNearOnlyMultiNodeFullApiSelfTest.java |    39 -
 .../GridCacheReplicatedNearOnlySelfTest.java    |    42 -
 .../GridCacheReplicatedNodeFailureSelfTest.java |    46 -
 .../GridCacheReplicatedNodeRestartSelfTest.java |    54 -
 ...idCacheReplicatedOffHeapFullApiSelfTest.java |    28 -
 ...plicatedOffHeapMultiNodeFullApiSelfTest.java |    28 -
 ...catedP2PDisabledByteArrayValuesSelfTest.java |    29 -
 ...icatedP2PEnabledByteArrayValuesSelfTest.java |    29 -
 ...ridCacheReplicatedPreloadEventsSelfTest.java |    32 -
 .../GridCacheReplicatedProjectionSelfTest.java  |    66 -
 ...GridCacheReplicatedRefreshAheadSelfTest.java |    51 -
 ...dezvousAffinityMultiNodeFullApiSelfTest.java |    35 -
 .../GridCacheReplicatedTtlSelfTest.java         |    32 -
 .../GridCacheReplicatedTxConcurrentGetTest.java |    45 -
 .../GridCacheReplicatedTxExceptionSelfTest.java |    39 -
 ...GridCacheReplicatedTxMultiNodeBasicTest.java |    81 -
 ...dCacheReplicatedTxMultiThreadedSelfTest.java |   111 -
 ...licatedTxOriginatingNodeFailureSelfTest.java |    37 -
 ...ssimisticOriginatingNodeFailureSelfTest.java |    47 -
 .../GridCacheReplicatedTxReadTest.java          |    33 -
 ...CacheReplicatedTxSingleThreadedSelfTest.java |   102 -
 .../GridCacheReplicatedTxTimeoutSelfTest.java   |    60 -
 ...idCacheReplicatedUnswapAdvancedSelfTest.java |   171 -
 .../GridCacheSyncReplicatedPreloadSelfTest.java |   166 -
 .../replicated/GridReplicatedTxPreloadTest.java |    33 -
 ...CacheReplicatedPreloadLifecycleSelfTest.java |   293 -
 ...idCacheReplicatedPreloadOffHeapSelfTest.java |    38 -
 .../GridCacheReplicatedPreloadSelfTest.java     |   582 -
 ...eplicatedPreloadStartStopEventsSelfTest.java |    95 -
 ...GridCacheReplicatedPreloadUndeploysTest.java |    87 -
 .../GridCacheBatchEvictUnswapSelfTest.java      |   184 -
 ...heConcurrentEvictionConsistencySelfTest.java |   267 -
 .../GridCacheConcurrentEvictionsSelfTest.java   |   183 -
 .../GridCacheDistributedEvictionsSelfTest.java  |   265 -
 .../GridCacheEmptyEntriesAbstractSelfTest.java  |   296 -
 .../GridCacheEmptyEntriesLocalSelfTest.java     |    41 -
 ...ridCacheEmptyEntriesPartitionedSelfTest.java |    41 -
 .../eviction/GridCacheEvictionAbstractTest.java |   462 -
 .../GridCacheEvictionFilterSelfTest.java        |   249 -
 .../GridCacheEvictionLockUnlockSelfTest.java    |   174 -
 .../GridCacheEvictionTouchSelfTest.java         |   337 -
 .../cache/eviction/GridCacheMockEntry.java      |   368 -
 ...cheSynchronousEvictionsFailoverSelfTest.java |   160 -
 .../GridCacheFifoEvictionPolicySelfTest.java    |   380 -
 .../lru/GridCacheLruEvictionPolicySelfTest.java |   426 -
 .../GridCacheLruNearEvictionPolicySelfTest.java |   136 -
 ...heNearOnlyLruNearEvictionPolicySelfTest.java |   167 -
 .../GridCacheRandomEvictionPolicySelfTest.java  |   266 -
 ...dCacheAtomicLocalMetricsNoStoreSelfTest.java |    29 -
 .../GridCacheAtomicLocalMetricsSelfTest.java    |    59 -
 .../local/GridCacheDaemonNodeLocalSelfTest.java |    65 -
 .../local/GridCacheExLocalFullApiSelfTest.java  |    30 -
 .../GridCacheLocalAtomicBasicStoreSelfTest.java |    32 -
 .../GridCacheLocalAtomicFullApiSelfTest.java    |    42 -
 ...LocalAtomicGetAndTransformStoreSelfTest.java |    33 -
 ...dCacheLocalAtomicOffHeapFullApiSelfTest.java |    42 -
 .../GridCacheLocalAtomicProjectionSelfTest.java |    32 -
 .../local/GridCacheLocalBasicApiSelfTest.java   |    42 -
 ...cheLocalBasicStoreMultithreadedSelfTest.java |    30 -
 .../local/GridCacheLocalBasicStoreSelfTest.java |    33 -
 .../GridCacheLocalByteArrayValuesSelfTest.java  |   258 -
 .../local/GridCacheLocalEventSelfTest.java      |    38 -
 .../GridCacheLocalEvictionEventSelfTest.java    |    38 -
 ...dCacheLocalFullApiMultithreadedSelfTest.java |    38 -
 .../local/GridCacheLocalFullApiSelfTest.java    |   141 -
 ...dCacheLocalGetAndTransformStoreSelfTest.java |    33 -
 .../local/GridCacheLocalIteratorsSelfTest.java  |   172 -
 .../local/GridCacheLocalLoadAllSelfTest.java    |   110 -
 .../cache/local/GridCacheLocalLockSelfTest.java |   316 -
 .../local/GridCacheLocalMetricsSelfTest.java    |    55 -
 .../GridCacheLocalMultithreadedSelfTest.java    |   452 -
 .../GridCacheLocalOffHeapFullApiSelfTest.java   |    28 -
 .../local/GridCacheLocalProjectionSelfTest.java |    38 -
 .../GridCacheLocalRefreshAheadSelfTest.java     |    51 -
 .../cache/local/GridCacheLocalTtlSelfTest.java  |    33 -
 .../GridCacheLocalTxExceptionSelfTest.java      |    38 -
 .../GridCacheLocalTxMultiThreadedSelfTest.java  |    91 -
 .../cache/local/GridCacheLocalTxReadTest.java   |    33 -
 .../GridCacheLocalTxSingleThreadedSelfTest.java |    86 -
 .../local/GridCacheLocalTxTimeoutSelfTest.java  |   164 -
 .../GridCacheSwapScanQueryAbstractSelfTest.java |   445 -
 .../query/GridCacheSwapScanQuerySelfTest.java   |    28 -
 .../cache/query/GridCircularQueueTest.java      |   119 -
 ...ridCacheContinuousQueryAbstractSelfTest.java |  1535 --
 ...ontinuousQueryAtomicNearEnabledSelfTest.java |    32 -
 ...ontinuousQueryAtomicP2PDisabledSelfTest.java |    29 -
 .../GridCacheContinuousQueryAtomicSelfTest.java |    43 -
 ...CacheContinuousQueryLocalAtomicSelfTest.java |    32 -
 .../GridCacheContinuousQueryLocalSelfTest.java  |    37 -
 ...eContinuousQueryPartitionedOnlySelfTest.java |    48 -
 ...uousQueryPartitionedP2PDisabledSelfTest.java |    29 -
 ...CacheContinuousQueryPartitionedSelfTest.java |    37 -
 ...ContinuousQueryReplicatedAtomicSelfTest.java |    37 -
 ...nuousQueryReplicatedP2PDisabledSelfTest.java |    28 -
 ...dCacheContinuousQueryReplicatedSelfTest.java |    82 -
 ...dCacheAbstractReduceFieldsQuerySelfTest.java |   426 -
 ...ridCacheReduceFieldsQueryAtomicSelfTest.java |    38 -
 ...GridCacheReduceFieldsQueryLocalSelfTest.java |    37 -
 ...cheReduceFieldsQueryPartitionedSelfTest.java |    58 -
 ...acheReduceFieldsQueryReplicatedSelfTest.java |    37 -
 .../clock/GridTimeSyncProcessorSelfTest.java    |   224 -
 .../closure/GridClosureProcessorRemoteTest.java |   119 -
 .../closure/GridClosureProcessorSelfTest.java   |   542 -
 .../grid/kernal/processors/closure/package.html |    23 -
 .../continuous/GridEventConsumeSelfTest.java    |  1080 --
 .../continuous/GridMessageListenSelfTest.java   |   498 -
 .../dataload/GridDataLoaderImplSelfTest.java    |   215 -
 .../dataload/GridDataLoaderPerformanceTest.java |   215 -
 .../GridDataLoaderProcessorSelfTest.java        |   784 -
 ...heGgfsPerBlockLruEvictionPolicySelfTest.java |   493 -
 .../ggfs/GridGgfsAbstractSelfTest.java          |  2448 ---
 .../ggfs/GridGgfsAttributesSelfTest.java        |    75 -
 .../processors/ggfs/GridGgfsCacheSelfTest.java  |   133 -
 .../ggfs/GridGgfsCommonAbstractTest.java        |    67 -
 .../ggfs/GridGgfsDataManagerSelfTest.java       |   599 -
 .../ggfs/GridGgfsDualAbstractSelfTest.java      |  1601 --
 .../ggfs/GridGgfsDualAsyncSelfTest.java         |    32 -
 .../ggfs/GridGgfsDualSyncSelfTest.java          |    32 -
 .../ggfs/GridGgfsFileInfoSelfTest.java          |    88 -
 .../ggfs/GridGgfsFileMapSelfTest.java           |   337 -
 ...GgfsGroupDataBlockKeyMapperHashSelfTest.java |   136 -
 .../ggfs/GridGgfsMetaManagerSelfTest.java       |   466 -
 .../ggfs/GridGgfsMetricsSelfTest.java           |   534 -
 .../ggfs/GridGgfsModeResolverSelfTest.java      |    77 -
 .../processors/ggfs/GridGgfsModesSelfTest.java  |   602 -
 .../GridGgfsPrimaryOffheapTieredSelfTest.java   |    33 -
 .../GridGgfsPrimaryOffheapValuesSelfTest.java   |    33 -
 .../ggfs/GridGgfsPrimarySelfTest.java           |    32 -
 .../ggfs/GridGgfsProcessorSelfTest.java         |   978 --
 .../GridGgfsProcessorValidationSelfTest.java    |   535 -
 ...IpcEndpointRegistrationAbstractSelfTest.java |   170 -
 ...dpointRegistrationOnLinuxAndMacSelfTest.java |    50 -
 ...pcEndpointRegistrationOnWindowsSelfTest.java |    54 -
 .../processors/ggfs/GridGgfsSizeSelfTest.java   |   875 --
 .../ggfs/GridGgfsStreamsSelfTest.java           |   473 -
 .../processors/ggfs/GridGgfsTaskSelfTest.java   |   317 -
 .../ggfs/GridGgfsTestInputStream.java           |    66 -
 .../grid/kernal/processors/ggfs/package.html    |    23 -
 .../GridGgfsAbstractRecordResolverSelfTest.java |   187 -
 ...GgfsByteDelimiterRecordResolverSelfTest.java |   335 -
 ...idGgfsFixedLengthRecordResolverSelfTest.java |   147 -
 ...sNewLineDelimiterRecordResolverSelfTest.java |   129 -
 ...fsStringDelimiterRecordResolverSelfTest.java |   137 -
 .../GridJobMetricsProcessorLoadTest.java        |    89 -
 .../port/GridPortProcessorSelfTest.java         |   129 -
 .../cache/GridCacheCommandHandlerSelfTest.java  |   263 -
 .../kernal/processors/service/DummyService.java |   148 -
 .../GridServiceProcessorAbstractSelfTest.java   |   677 -
 ...ServiceProcessorMultiNodeConfigSelfTest.java |   200 -
 .../GridServiceProcessorMultiNodeSelfTest.java  |   170 -
 .../GridServiceProcessorProxySelfTest.java      |   376 -
 .../GridServiceProcessorSingleNodeSelfTest.java |    58 -
 .../GridServiceReassignmentSelfTest.java        |   212 -
 .../streamer/GridStreamerEvictionSelfTest.java  |   164 -
 .../streamer/GridStreamerFailoverSelfTest.java  |   267 -
 .../GridStreamerLifecycleAwareSelfTest.java     |   212 -
 .../streamer/GridStreamerSelfTest.java          |   796 -
 .../processors/streamer/GridTestStage.java      |    54 -
 .../streamer/GridTestStreamerEventRouter.java   |    49 -
 .../grid/kernal/processors/streamer/SC.java     |    31 -
 .../timeout/GridTimeoutProcessorSelfTest.java   |   609 -
 .../org/gridgain/grid/kernal/updatestatus.html  |    28 -
 .../grid/lang/GridBasicPerformanceTest.java     |  1077 --
 .../grid/lang/GridByteArrayListSelfTest.java    |   213 -
 .../grid/lang/GridFuncPerformanceTest.java      |   101 -
 .../gridgain/grid/lang/GridFuncSelfTest.java    |  3255 ----
 .../lang/GridFutureListenPerformanceTest.java   |   112 -
 .../GridImmutableCollectionsPerfomanceTest.java |   120 -
 .../lang/GridMetadataAwareAdapterSelfTest.java  |   118 -
 .../grid/lang/GridSetWrapperSelfTest.java       |   224 -
 .../lang/GridSystemCurrentTimeMillisTest.java   |   107 -
 .../grid/lang/GridThreadPriorityTest.java       |    72 -
 .../gridgain/grid/lang/GridTupleSelfTest.java   |   250 -
 .../org/gridgain/grid/lang/GridXSelfTest.java   |   262 -
 .../gridgain/grid/lang/IgniteUuidSelfTest.java  |   326 -
 .../java/org/gridgain/grid/lang/package.html    |    23 -
 ...dBoundedConcurrentLinkedHashMapSelfTest.java |    55 -
 ...GridBoundedConcurrentOrderedMapSelfTest.java |    81 -
 .../GridCircularBufferPerformanceTest.java      |   226 -
 .../lang/utils/GridCircularBufferSelfTest.java  |   176 -
 .../utils/GridConcurrentHashMapSelfTest.java    |   109 -
 .../GridConcurrentLinkedHashMapSelfTest.java    |   246 -
 .../GridConcurrentWeakHashSetSelfTest.java      |   394 -
 .../lang/utils/GridConsistentHashSelfTest.java  |   332 -
 .../lang/utils/GridLeanMapPerformanceTest.java  |    84 -
 .../grid/lang/utils/GridLeanMapSelfTest.java    |   658 -
 .../grid/lang/utils/GridListSetSelfTest.java    |   286 -
 .../grid/lang/utils/GridPCollectionsTest.java   |    54 -
 .../lang/utils/GridStripedLockSelfTest.java     |   200 -
 .../grid/lang/utils/GridTrieMapSelfTest.java    |   242 -
 .../org/gridgain/grid/lang/utils/package.html   |    24 -
 .../grid/loadtest/GridLoadTestStatistics.java   |   210 -
 .../grid/loadtest/GridSingleExecutionTest.java  |   325 -
 .../org/gridgain/grid/loadtest/package.html     |    23 -
 ...idFileSwapSpaceSpiMultithreadedLoadTest.java |   247 -
 .../grid/logger/java/GridJavaLoggerTest.java    |    64 -
 .../org/gridgain/grid/logger/java/package.html  |    23 -
 .../marshaller/GridMarshallerAbstractTest.java  |  1041 --
 .../GridMarshallerExternalizableBean.java       |    63 -
 .../GridMarshallerPerformanceTest.java          |   514 -
 .../marshaller/GridMarshallerResourceBean.java  |   105 -
 .../GridMarshallerTestAbstractBean.java         |    40 -
 .../grid/marshaller/GridMarshallerTestBean.java |   148 -
 .../GridMarshallerTestInheritedBean.java        |    25 -
 .../jdk/GridJdkMarshallerSelfTest.java          |    35 -
 .../gridgain/grid/marshaller/jdk/package.html   |    23 -
 .../org/gridgain/grid/marshaller/package.html   |    23 -
 ...GridMessagingNoPeerClassLoadingSelfTest.java |    90 -
 .../grid/messaging/GridMessagingSelfTest.java   |  1088 --
 .../p2p/GridAbstractMultinodeRedeployTest.java  |   126 -
 ...MultinodeRedeployContinuousModeSelfTest.java |    37 -
 ...idMultinodeRedeployIsolatedModeSelfTest.java |    37 -
 ...ridMultinodeRedeployPrivateModeSelfTest.java |    37 -
 ...GridMultinodeRedeploySharedModeSelfTest.java |    37 -
 .../grid/p2p/GridP2PClassLoadingSelfTest.java   |   157 -
 .../GridP2PContinuousDeploymentSelfTest.java    |   118 -
 .../GridP2PDifferentClassLoaderSelfTest.java    |   221 -
 .../p2p/GridP2PDoubleDeploymentSelfTest.java    |   140 -
 .../p2p/GridP2PHotRedeploymentSelfTest.java     |   233 -
 .../grid/p2p/GridP2PJobClassLoaderSelfTest.java |   157 -
 .../p2p/GridP2PLocalDeploymentSelfTest.java     |   285 -
 .../GridP2PMissedResourceCacheSizeSelfTest.java |   293 -
 .../grid/p2p/GridP2PNodeLeftSelfTest.java       |   134 -
 .../grid/p2p/GridP2PRecursionTaskSelfTest.java  |   194 -
 .../p2p/GridP2PRemoteClassLoadersSelfTest.java  |   283 -
 .../p2p/GridP2PSameClassLoaderSelfTest.java     |   179 -
 .../org/gridgain/grid/p2p/GridP2PTestJob.java   |   129 -
 .../org/gridgain/grid/p2p/GridP2PTestTask.java  |    81 -
 .../grid/p2p/GridP2PTestTaskExecutionTest.java  |    51 -
 .../grid/p2p/GridP2PTimeoutSelfTest.java        |   206 -
 .../grid/p2p/GridP2PUndeploySelfTest.java       |   237 -
 .../grid/p2p/GridSwapSpaceCustomKey.java        |    58 -
 .../grid/p2p/GridSwapSpaceCustomValue.java      |    64 -
 .../java/org/gridgain/grid/p2p/p2p.properties   |     1 -
 .../java/org/gridgain/grid/p2p/package.html     |    23 -
 .../test/java/org/gridgain/grid/package.html    |    23 -
 .../product/GridProductVersionSelfTest.java     |   111 -
 ...SessionCancelSiblingsFromFutureSelfTest.java |   281 -
 ...ridSessionCancelSiblingsFromJobSelfTest.java |   292 -
 ...idSessionCancelSiblingsFromTaskSelfTest.java |   299 -
 .../GridSessionCheckpointAbstractSelfTest.java  |   231 -
 .../session/GridSessionCheckpointSelfTest.java  |    96 -
 .../GridSessionCollisionSpiSelfTest.java        |   144 -
 ...idSessionFutureWaitJobAttributeSelfTest.java |   252 -
 ...dSessionFutureWaitTaskAttributeSelfTest.java |   251 -
 .../session/GridSessionJobFailoverSelfTest.java |   166 -
 ...GridSessionJobWaitTaskAttributeSelfTest.java |   221 -
 .../grid/session/GridSessionLoadSelfTest.java   |   265 -
 .../GridSessionSetFutureAttributeSelfTest.java  |   255 -
 ...nSetFutureAttributeWaitListenerSelfTest.java |   243 -
 .../GridSessionSetJobAttribute2SelfTest.java    |   135 -
 ...GridSessionSetJobAttributeOrderSelfTest.java |   154 -
 .../GridSessionSetJobAttributeSelfTest.java     |   210 -
 ...sionSetJobAttributeWaitListenerSelfTest.java |   245 -
 .../GridSessionSetTaskAttributeSelfTest.java    |   198 -
 ...GridSessionTaskWaitJobAttributeSelfTest.java |   191 -
 .../GridSessionWaitAttributeSelfTest.java       |   481 -
 .../grid/session/GridThreadSerialNumber.java    |    40 -
 .../java/org/gridgain/grid/session/package.html |    24 -
 .../grid/spi/GridSpiLocalHostInjectionTest.java |   156 -
 .../grid/spi/GridSpiStartStopAbstractTest.java  |    80 -
 .../org/gridgain/grid/spi/GridTcpForwarder.java |   169 -
 .../grid/spi/GridTcpSpiForwardingSelfTest.java  |   164 -
 .../java/org/gridgain/grid/spi/package.html     |    24 -
 .../startup/servlet/GridServletLoaderTest.java  |   171 -
 .../gridgain/grid/startup/servlet/package.html  |    23 -
 .../GridThreadPoolExecutorServiceSelfTest.java  |   188 -
 .../gridgain/grid/thread/GridThreadTest.java    |    53 -
 ...dConcurrentLinkedDequeMultiThreadedTest.java |   101 -
 .../util/GridConcurrentLinkedDequeSelfTest.java |   236 -
 ...rrentLinkedHashMapMultiThreadedSelfTest.java |   551 -
 .../gridgain/grid/util/GridIndexFillTest.java   |   255 -
 .../gridgain/grid/util/GridLogThrottleTest.java |   123 -
 .../grid/util/GridLongListSelfTest.java         |   152 -
 .../gridgain/grid/util/GridQueueSelfTest.java   |    70 -
 .../gridgain/grid/util/GridRandomSelfTest.java  |    68 -
 .../grid/util/GridSnapshotLockSelfTest.java     |   112 -
 .../util/GridSpinReadWriteLockSelfTest.java     |   143 -
 ...artupWithSpecifiedWorkDirectorySelfTest.java |   163 -
 ...tartupWithUndefinedGridGainHomeSelfTest.java |   106 -
 .../util/GridStringBuilderFactorySelfTest.java  |    71 -
 .../gridgain/grid/util/GridTestClockTimer.java  |    39 -
 .../grid/util/GridTopologyHeapSizeSelfTest.java |   120 -
 .../gridgain/grid/util/GridTransientTest.java   |    68 -
 .../gridgain/grid/util/GridUtilsSelfTest.java   |   717 -
 .../util/future/GridCompoundFutureSelfTest.java |   204 -
 .../util/future/GridEmbeddedFutureSelfTest.java |   137 -
 .../util/future/GridFinishedFutureSelfTest.java |   104 -
 .../util/future/GridFutureAdapterSelfTest.java  |   441 -
 .../future/GridFutureListenPerformanceTest.java |   107 -
 .../grid/util/future/GridFutureQueueTest.java   |   183 -
 .../nio/GridNioEmbeddedFutureSelfTest.java      |    59 -
 .../util/future/nio/GridNioFutureSelfTest.java  |   210 -
 ...GridUnsafeDataOutputArraySizingSelfTest.java |   161 -
 ...idIpcServerEndpointDeserializerSelfTest.java |   160 -
 .../shmem/GridGgfsSharedMemoryTestClient.java   |    76 -
 .../shmem/GridGgfsSharedMemoryTestServer.java   |    71 -
 ...idIpcSharedMemoryCrashDetectionSelfTest.java |   500 -
 .../shmem/GridIpcSharedMemoryFakeClient.java    |    36 -
 .../shmem/GridIpcSharedMemoryNodeStartup.java   |    87 -
 .../shmem/GridIpcSharedMemorySpaceSelfTest.java |   260 -
 .../shmem/GridIpcSharedMemoryUtilsSelfTest.java |    84 -
 .../GridIpcSharedMemoryBenchmarkParty.java      |    35 -
 .../GridIpcSharedMemoryBenchmarkReader.java     |   133 -
 .../GridIpcSharedMemoryBenchmarkWriter.java     |   125 -
 .../grid/util/mbeans/GridMBeanSelfTest.java     |   344 -
 .../gridgain/grid/util/nio/GridNioSelfTest.java |  1441 --
 .../util/nio/GridNioSessionMetaKeySelfTest.java |    58 -
 .../grid/util/nio/GridNioSslSelfTest.java       |    88 -
 .../grid/util/nio/GridRoundTripTest.java        |   226 -
 .../nio/impl/GridNioFilterChainSelfTest.java    |   390 -
 .../org/gridgain/grid/util/nio/package.html     |    23 -
 .../grid/util/offheap/GridByteArrayWrapper.java |    63 -
 .../offheap/GridOffHeapMapAbstractSelfTest.java |   812 -
 .../GridOffHeapMapPerformanceAbstractTest.java  |   289 -
 ...idOffHeapPartitionedMapAbstractSelfTest.java |  1133 --
 ...apPartitionedMapPerformanceAbstractTest.java |   429 -
 .../unsafe/GridOffheapSnapTreeSelfTest.java     |   321 -
 .../unsafe/GridUnsafeMapPerformanceTest.java    |    30 -
 .../offheap/unsafe/GridUnsafeMapSelfTest.java   |    30 -
 .../unsafe/GridUnsafeMemorySelfTest.java        |   542 -
 ...GridUnsafePartitionedMapPerformanceTest.java |    32 -
 .../GridUnsafePartitionedMapSelfTest.java       |    30 -
 .../unsafe/GridUnsafeStripedLruSefTest.java     |   229 -
 .../java/org/gridgain/grid/util/package.html    |    24 -
 .../tostring/GridToStringBuilderSelfTest.java   |   205 -
 .../gridgain/grid/util/tostring/package.html    |    23 -
 .../org/gridgain/jvmtest/BlockingQueueTest.java |   144 -
 .../org/gridgain/jvmtest/ConcurrentMapTest.java |   193 -
 .../java/org/gridgain/jvmtest/FileIOTest.java   |   138 -
 .../org/gridgain/jvmtest/FileLocksTest.java     |   121 -
 .../org/gridgain/jvmtest/LinkedHashMapTest.java |    87 -
 .../gridgain/jvmtest/MultipleFileIOTest.java    |   134 -
 .../gridgain/jvmtest/NetworkFailureTest.java    |   370 -
 .../QueueSizeCounterMultiThreadedTest.java      |   102 -
 .../jvmtest/ReadWriteLockMultiThreadedTest.java |   207 -
 .../java/org/gridgain/jvmtest/RegExpTest.java   |    56 -
 .../jvmtest/ServerSocketMultiThreadedTest.java  |   102 -
 .../loadtests/GridCacheLoadPopulationTask.java  |   153 -
 .../loadtests/GridCacheMultiNodeLoadTest.java   |   106 -
 .../cache/GridCacheAbstractLoadTest.java        |   376 -
 ...ridCacheAffinityTransactionsOffHeapTest.java |   258 -
 .../loadtests/cache/GridCacheBenchmark.java     |   202 -
 .../cache/GridCacheDataStructuresLoadTest.java  |   365 -
 .../cache/GridCacheGroupLockComparisonTest.java |   203 -
 .../loadtests/cache/GridCacheLoadTest.java      |   162 -
 .../cache/GridCachePutRemoveLoadTest.java       |   373 -
 .../cache/GridCacheSingleNodeLoadTest.java      |   184 -
 .../loadtests/cache/GridCacheSwapLoadTest.java  |   311 -
 .../GridCacheWriteBehindStoreLoadTest.java      |   208 -
 .../capacity/GridCapacityLoadTest.java          |    95 -
 .../capacity/spring-capacity-cache.xml          |   124 -
 .../colocation/GridTestCacheStore.java          |   130 -
 .../loadtests/colocation/GridTestConstants.java |    35 -
 .../loadtests/colocation/GridTestKey.java       |    92 -
 .../colocation/GridTestLifecycleBean.java       |    42 -
 .../loadtests/colocation/GridTestMain.java      |   208 -
 .../loadtests/colocation/spring-colocation.xml  |   182 -
 .../communication/GridIoManagerBenchmark.java   |   338 -
 .../communication/GridIoManagerBenchmark0.java  |   470 -
 .../GridTcpCommunicationBenchmark.java          |   586 -
 .../communication/GridTestMessage.java          |   135 -
 .../GridContinuousOperationsLoadTest.java       |   212 -
 .../GridCachePartitionedAtomicLongLoadTest.java |   129 -
 .../direct/multisplit/GridLoadTestJob.java      |    59 -
 .../multisplit/GridLoadTestJobTarget.java       |    33 -
 .../direct/multisplit/GridLoadTestTask.java     |    84 -
 .../multisplit/GridMultiSplitsLoadTest.java     |   161 -
 .../GridMultiSplitsRedeployLoadTest.java        |   163 -
 .../loadtests/direct/multisplit/package.html    |    24 -
 .../GridSingleSplitNewNodesTestJobTarget.java   |    50 -
 .../GridSingleSplitNewNodesTestTask.java        |    95 -
 ...ridSingleSplitsNewNodesAbstractLoadTest.java |   188 -
 ...idSingleSplitsNewNodesMulticastLoadTest.java |    45 -
 .../loadtests/direct/newnodes/package.html      |    24 -
 .../GridSingleSplitsRedeployLoadTest.java       |   175 -
 .../loadtests/direct/redeploy/package.html      |    24 -
 .../direct/session/GridSessionLoadTest.java     |   112 -
 .../direct/session/GridSessionLoadTestJob.java  |    77 -
 .../direct/session/GridSessionLoadTestTask.java |   137 -
 .../loadtests/direct/session/package.html       |    24 -
 .../direct/stealing/GridStealingLoadTest.java   |   154 -
 .../stealing/GridStealingLoadTestJob.java       |    60 -
 .../stealing/GridStealingLoadTestTask.java      |    96 -
 .../loadtests/direct/stealing/package.html      |    24 -
 .../loadtests/discovery/GridGcTimeoutTest.java  |    64 -
 .../gridgain/loadtests/dsi/GridDsiClient.java   |   420 -
 .../loadtests/dsi/GridDsiLifecycleBean.java     |    59 -
 .../gridgain/loadtests/dsi/GridDsiMessage.java  |    74 -
 .../gridgain/loadtests/dsi/GridDsiPerfJob.java  |   341 -
 .../gridgain/loadtests/dsi/GridDsiRequest.java  |    93 -
 .../loadtests/dsi/GridDsiRequestTask.java       |    41 -
 .../gridgain/loadtests/dsi/GridDsiResponse.java |    87 -
 .../loadtests/dsi/GridDsiResponseTask.java      |    41 -
 .../gridgain/loadtests/dsi/GridDsiSession.java  |    84 -
 .../cacheget/GridBenchmarkCacheGetLoadTest.java |   119 -
 .../org/gridgain/loadtests/dsi/package.html     |    23 -
 ...dBoundedConcurrentLinkedHashSetLoadTest.java |   118 -
 .../loadtests/hashmap/GridCacheTestContext.java |    63 -
 .../loadtests/hashmap/GridHashMapLoadTest.java  |    92 -
 .../job/GridJobExecutionLoadTestClient.java     |   220 -
 ...GridJobExecutionLoadTestClientSemaphore.java |   240 -
 .../job/GridJobExecutionLoadTestJob.java        |    48 -
 .../job/GridJobExecutionLoadTestServer.java     |    40 -
 .../job/GridJobExecutionLoadTestTask.java       |    50 -
 .../job/GridJobExecutionSingleNodeLoadTest.java |   238 -
 ...JobExecutionSingleNodeSemaphoreLoadTest.java |   227 -
 .../gridgain/loadtests/job/GridJobLoadTest.java |   201 -
 .../loadtests/job/GridJobLoadTestJob.java       |   161 -
 .../loadtests/job/GridJobLoadTestParams.java    |    84 -
 .../loadtests/job/GridJobLoadTestSubmitter.java |   143 -
 .../loadtests/job/GridJobLoadTestTask.java      |    73 -
 .../org/gridgain/loadtests/job/package.html     |    23 -
 .../GridConcurrentLinkedHashMapBenchmark.java   |   238 -
 .../mapper/GridContinuousMapperLoadTest1.java   |    51 -
 .../mapper/GridContinuousMapperLoadTest2.java   |    91 -
 .../mapper/GridContinuousMapperTask1.java       |   150 -
 .../mapper/GridContinuousMapperTask2.java       |    88 -
 .../loadtests/mapper/GridNodeStartup.java       |    56 -
 .../gridgain/loadtests/mapper/TestObject.java   |    58 -
 .../mergesort/GridMergeSortLoadTask.java        |   189 -
 .../mergesort/GridMergeSortLoadTest.java        |   144 -
 .../loadtests/nio/GridNioBenchmarkClient.java   |   167 -
 .../loadtests/nio/GridNioBenchmarkTest.java     |   120 -
 .../GridOffHeapMapPerformanceAbstractTest.java  |   290 -
 ...apPartitionedMapPerformanceAbstractTest.java |   430 -
 .../unsafe/GridUnsafeMapPerformanceTest.java    |    30 -
 ...GridUnsafePartitionedMapPerformanceTest.java |    32 -
 .../loadtests/streamer/EventClosure.java        |    61 -
 .../streamer/GridStreamerBenchmark.java         |   140 -
 .../streamer/GridStreamerIndexLoadTest.java     |   180 -
 .../loadtests/streamer/GridStreamerLoad.java    |    62 -
 .../loadtests/streamer/IndexUpdater.java        |    46 -
 .../loadtests/streamer/QueryClosure.java        |   107 -
 .../loadtests/streamer/average/TestAverage.java |    70 -
 .../loadtests/streamer/average/TestStage.java   |    65 -
 .../swap/GridSwapEvictAllBenchmark.java         |   292 -
 .../loadtests/util/GridCumulativeAverage.java   |    63 -
 .../loadtests/util/GridLoadTestArgs.java        |   283 -
 .../startup/GridRandomCommandLineLoader.java    |   401 -
 .../gridgain/startup/GridVmNodesStarter.java    |   271 -
 .../test/java/org/gridgain/startup/package.html |    23 -
 .../gridgain/testframework/GridFileLock.java    |   110 -
 .../testframework/GridGgfsTestUtils.java        |    55 -
 .../testframework/GridJarClassLoader.java       |   178 -
 .../testframework/GridLoadTestUtils.java        |   153 -
 .../testframework/GridSpiTestContext.java       |   563 -
 .../testframework/GridStringLogger.java         |   167 -
 .../testframework/GridTestClassLoader.java      |   110 -
 .../GridTestExternalClassLoader.java            |   194 -
 .../gridgain/testframework/GridTestNode.java    |   254 -
 .../GridTestSafeThreadFactory.java              |   214 -
 .../gridgain/testframework/GridTestThread.java  |   147 -
 .../gridgain/testframework/GridTestUtils.java   |  1400 --
 .../config/GridTestProperties.java              |   304 -
 .../gridgain/testframework/config/package.html  |    23 -
 .../http/GridEmbeddedHttpServer.java            |   189 -
 .../gridgain/testframework/http/package.html    |    23 -
 .../testframework/junits/GridAbstractTest.java  |  1427 --
 .../junits/GridTestKernalContext.java           |    83 -
 .../testframework/junits/GridTestResources.java |   260 -
 .../cache/GridAbstractCacheStoreSelfTest.java   |   513 -
 .../junits/common/GridAbstractExamplesTest.java |    79 -
 .../GridAbstractLifecycleAwareSelfTest.java     |   120 -
 .../junits/common/GridCommonAbstractTest.java   |   564 -
 .../junits/common/GridCommonTest.java           |    36 -
 .../testframework/junits/common/package.html    |    23 -
 .../logger/GridLog4jRollingFileAppender.java    |   114 -
 .../junits/logger/GridTestLog4jLogger.java      |   516 -
 .../gridgain/testframework/junits/package.html  |    24 -
 .../junits/spi/GridSpiAbstractConfigTest.java   |   110 -
 .../junits/spi/GridSpiAbstractTest.java         |   692 -
 .../testframework/junits/spi/GridSpiTest.java   |    62 -
 .../junits/spi/GridSpiTestConfig.java           |    48 -
 .../testframework/junits/spi/package.html       |    23 -
 .../org/gridgain/testframework/package.html     |    23 -
 .../GridCacheDataStructuresSelfTestSuite.java   |    99 -
 .../GridCacheEvictionSelfTestSuite.java         |    62 -
 .../GridCacheFullApiSelfTestSuite.java          |   119 -
 .../GridCacheGroupLockSelfTestSuite.java        |    48 -
 .../GridCacheIteratorsSelfTestSuite.java        |    42 -
 .../GridCacheMetricsSelfTestSuite.java          |    49 -
 .../GridCacheNearOnlySelfTestSuite.java         |    45 -
 .../GridCacheTxRecoverySelfTestSuite.java       |    46 -
 .../GridCacheWriteBehindTestSuite.java          |    45 -
 .../GridContinuousTaskSelfTestSuite.java        |    42 -
 .../GridExternalizableSelfTestSuite.java        |    37 -
 .../GridIpcSharedMemorySelfTestSuite.java       |    40 -
 .../testsuites/GridJobMetricsSelfTestSuite.java |    38 -
 .../testsuites/GridKernalSelfTestSuite.java     |    80 -
 .../testsuites/GridLangSelfTestSuite.java       |    71 -
 .../testsuites/GridLoadersSelfTestSuite.java    |    38 -
 .../testsuites/GridLoggingSelfTestSuite.java    |    38 -
 .../testsuites/GridMarshallerSelfTestSuite.java |    45 -
 .../testsuites/GridP2PSelfTestSuite.java        |    54 -
 .../testsuites/GridRichSelfTestSuite.java       |    42 -
 .../GridSpiCheckpointSelfTestSuite.java         |    56 -
 .../GridSpiCollisionSelfTestSuite.java          |    55 -
 .../GridSpiCommunicationSelfTestSuite.java      |    52 -
 .../GridSpiDeploymentSelfTestSuite.java         |    40 -
 .../GridSpiDiscoverySelfTestSuite.java          |    56 -
 .../GridSpiEventStorageSelfTestSuite.java       |    41 -
 .../GridSpiFailoverSelfTestSuite.java           |    53 -
 .../GridSpiIndexingSelfTestSuite.java           |    38 -
 .../GridSpiLoadBalancingSelfTestSuite.java      |    64 -
 .../GridSpiSwapSpaceSelfTestSuite.java          |    41 -
 .../testsuites/GridStreamerSelfTestSuite.java   |    46 -
 .../GridTaskSessionSelfTestSuite.java           |    56 -
 .../GridTimeoutProcessorSelfTestSuite.java      |    38 -
 .../testsuites/GridUtilSelfTestSuite.java       |    71 -
 .../testsuites/bamboo/GridBasicTestSuite.java   |    77 -
 .../bamboo/GridCacheFailoverTestSuite.java      |    57 -
 .../bamboo/GridComputeGridTestSuite.java        |   100 -
 .../bamboo/GridDataGridRestartTestSuite.java    |    49 -
 .../bamboo/GridDataGridTestSuite.java           |   327 -
 .../testsuites/bamboo/GridGgfsTestSuite.java    |    79 -
 .../bamboo/GridRestHandlerTestSuite.java        |    38 -
 .../testsuites/bamboo/GridSpiTestSuite.java     |    70 -
 .../org/gridgain/testsuites/bamboo/package.html |    23 -
 .../java/org/gridgain/testsuites/package.html   |    24 -
 .../src/test/resources/load/html/index.html     |   957 --
 .../resources/load/js/gg-loadtest-server.js     |    96 -
 .../src/test/resources/log/gridgain.log.tst     | 13706 -----------------
 .../core/src/test/resources/log/ignite.log.tst  | 13706 +++++++++++++++++
 modules/core/src/test/resources/readme.txt      |     2 +-
 .../core/src/test/webapp/META-INF/gg-config.xml |   345 -
 .../webapp/META-INF/ignite-webapp-config.xml    |   349 +
 modules/core/src/test/webapp/WEB-INF/web.xml    |    10 +-
 modules/email/licenses/apache-2.0.txt           |   202 -
 modules/email/pom.xml                           |    51 -
 modules/email/readme.txt                        |    34 -
 .../processors/email/GridEmailProcessor.java    |   297 -
 modules/extdata/p2p/META-INF/gridgain.xml       |    40 -
 modules/extdata/p2p/META-INF/ignite.xml         |    40 +
 modules/extdata/p2p/pom.xml                     |    10 +-
 .../tests/p2p/CacheDeploymentTestKey.java       |    63 +
 .../tests/p2p/CacheDeploymentTestTask1.java     |    64 +
 .../tests/p2p/CacheDeploymentTestTask2.java     |    56 +
 .../tests/p2p/CacheDeploymentTestTask3.java     |    61 +
 .../tests/p2p/CacheDeploymentTestValue.java     |    27 +
 .../tests/p2p/CacheDeploymentTestValue2.java    |    25 +
 .../ignite/tests/p2p/ExcludeNodeFilter.java     |    52 +
 .../p2p/GridCacheDeploymentTestValue3.java      |    42 +
 .../tests/p2p/GridEventConsumeFilter.java       |    31 +
 .../GridEventConsumeProjectionPredicate.java    |    31 +
 .../tests/p2p/GridExternalAffinityFunction.java |   161 +
 .../p2p/GridExternalAffinityKeyMapper.java      |    38 +
 .../tests/p2p/GridP2PAwareTestUserResource.java |    64 +
 .../p2p/GridP2PContinuousDeploymentTask1.java   |    52 +
 .../p2p/GridP2PContinuousDeploymentTask2.java   |    45 +
 .../p2p/GridP2PEventFilterExternalPath1.java    |    49 +
 .../p2p/GridP2PEventFilterExternalPath2.java    |    49 +
 .../tests/p2p/GridSingleSplitTestJobTarget.java |    34 +
 .../tests/p2p/GridTestMessageListener.java      |    56 +
 .../ignite/tests/p2p/GridTestMessageTopic.java  |    35 +
 .../ignite/tests/p2p/JobStealingTask.java       |   119 +
 .../tests/p2p/P2PTestTaskExternalPath1.java     |   144 +
 .../tests/p2p/P2PTestTaskExternalPath2.java     |   137 +
 .../ignite/tests/p2p/SingleSplitTestTask.java   |    75 +
 .../ignite/tests/p2p/TestUserResource.java      |    27 +
 .../org/apache/ignite/tests/p2p/package.html    |    24 +
 .../tests/p2p/GridCacheDeploymentTestKey.java   |    63 -
 .../tests/p2p/GridCacheDeploymentTestTask1.java |    66 -
 .../tests/p2p/GridCacheDeploymentTestTask2.java |    57 -
 .../tests/p2p/GridCacheDeploymentTestTask3.java |    62 -
 .../tests/p2p/GridCacheDeploymentTestValue.java |    26 -
 .../p2p/GridCacheDeploymentTestValue2.java      |    24 -
 .../p2p/GridCacheDeploymentTestValue3.java      |    42 -
 .../grid/tests/p2p/GridEventConsumeFilter.java  |    31 -
 .../GridEventConsumeProjectionPredicate.java    |    31 -
 .../grid/tests/p2p/GridExcludeNodeFilter.java   |    52 -
 .../tests/p2p/GridExternalAffinityFunction.java |   161 -
 .../p2p/GridExternalAffinityKeyMapper.java      |    38 -
 .../GridExternalCacheQueryReducerClosure.java   |    43 -
 .../tests/p2p/GridP2PAwareTestUserResource.java |    84 -
 .../p2p/GridP2PContinuousDeploymentTask1.java   |    53 -
 .../p2p/GridP2PContinuousDeploymentTask2.java   |    47 -
 .../p2p/GridP2PEventFilterExternalPath1.java    |    55 -
 .../p2p/GridP2PEventFilterExternalPath2.java    |    55 -
 .../tests/p2p/GridP2PTestTaskExternalPath1.java |   156 -
 .../tests/p2p/GridP2PTestTaskExternalPath2.java |   145 -
 .../tests/p2p/GridSingleSplitTestJobTarget.java |    34 -
 .../grid/tests/p2p/GridSingleSplitTestTask.java |    77 -
 .../grid/tests/p2p/GridTestMessageListener.java |    56 -
 .../grid/tests/p2p/GridTestMessageTopic.java    |    35 -
 .../grid/tests/p2p/GridTestUserResource.java    |    27 -
 .../grid/tests/p2p/JobStealingTask.java         |   120 -
 .../org/gridgain/grid/tests/p2p/package.html    |    23 -
 modules/extdata/uri/pom.xml                     |     4 +-
 .../GridUriDeploymentAbstractTestTask.java      |     6 +-
 .../uri/tasks/GridUriDeploymentDependency1.java |     5 +-
 .../uri/tasks/GridUriDeploymentDependency2.java |     5 +-
 .../tasks/GridUriDeploymentInnerTestTask.java   |     6 +-
 .../GridUriDeploymentNonePublicTestTask.java    |     6 +-
 .../uri/tasks/GridUriDeploymentTestTask0.java   |     6 +-
 .../uri/tasks/GridUriDeploymentTestTask1.java   |     6 +-
 .../uri/tasks/GridUriDeploymentTestTask2.java   |     9 +-
 .../uri/tasks/GridUriDeploymentTestTask3.java   |     6 +-
 .../uri/tasks/GridUriDeploymentTestTask4.java   |     6 +-
 .../uri/tasks/GridUriDeploymentTestTask5.java   |     6 +-
 .../uri/tasks/GridUriDeploymentTestTask6.java   |     6 +-
 .../GridUriDeploymentTestWithNameTask0.java     |     6 +-
 .../GridUriDeploymentTestWithNameTask3.java     |     6 +-
 .../GridUriDeploymentTestWithNameTask4.java     |     6 +-
 .../GridUriDeploymentTestWithNameTask5.java     |     6 +-
 .../GridUriDeploymentTestWithNameTask6.java     |     6 +-
 .../GridUriDeploymentTestWithNameTask7.java     |     6 +-
 .../spi/deployment/uri/tasks/package.html       |     2 +-
 .../ignite/spi/deployment/uri/tasks/spring1.xml |     4 +-
 .../ignite/spi/deployment/uri/tasks/spring2.xml |     4 +-
 .../java/org/apache/ignite/test/test.properties |    23 +
 .../main/java/org/gridgain/test/test.properties |    23 -
 modules/geospatial/licenses/apache-2.0.txt      |   202 +
 .../geospatial/licenses/jts-lgpl-license.txt    |   165 +
 modules/geospatial/pom.xml                      |    59 +
 modules/geospatial/readme.txt                   |    33 +
 .../query/h2/opt/GridH2SpatialIndex.java        |   326 +
 .../query/h2/GridH2IndexingGeoSelfTest.java     |   249 +
 .../testsuites/GeoSpatialIndexingTestSuite.java |    39 +
 modules/hadoop/pom.xml                          |     8 +-
 modules/hadoop/readme.txt                       |    18 +-
 .../client/hadoop/GridHadoopClientProtocol.java |   333 +
 .../GridHadoopClientProtocolProvider.java       |   137 +
 .../counter/GridHadoopClientCounterGroup.java   |   121 +
 .../counter/GridHadoopClientCounters.java       |   217 +
 .../apache/ignite/client/hadoop/package.html    |    24 +
 .../igfs/hadoop/IgfsHadoopParameters.java       |    94 +
 .../org/apache/ignite/igfs/hadoop/package.html  |    24 +
 .../igfs/hadoop/v1/IgfsHadoopFileSystem.java    |  1253 ++
 .../apache/ignite/igfs/hadoop/v1/package.html   |    24 +
 .../igfs/hadoop/v2/IgfsHadoopFileSystem.java    |  1007 ++
 .../apache/ignite/igfs/hadoop/v2/package.html   |    24 +
 .../java/org/apache/ignite/igfs/package.html    |    24 +
 .../ignite/internal/igfs/hadoop/IgfsHadoop.java |   198 +
 .../IgfsHadoopCommunicationException.java       |    57 +
 .../igfs/hadoop/IgfsHadoopEndpoint.java         |   210 +
 .../internal/igfs/hadoop/IgfsHadoopEx.java      |    88 +
 .../igfs/hadoop/IgfsHadoopFSProperties.java     |    88 +
 .../hadoop/IgfsHadoopFileSystemWrapper.java     |   413 +
 .../internal/igfs/hadoop/IgfsHadoopFuture.java  |    94 +
 .../internal/igfs/hadoop/IgfsHadoopInProc.java  |   409 +
 .../igfs/hadoop/IgfsHadoopInputStream.java      |   626 +
 .../internal/igfs/hadoop/IgfsHadoopIo.java      |    76 +
 .../internal/igfs/hadoop/IgfsHadoopIpcIo.java   |   599 +
 .../igfs/hadoop/IgfsHadoopIpcIoListener.java    |    36 +
 .../igfs/hadoop/IgfsHadoopJclLogger.java        |   112 +
 .../internal/igfs/hadoop/IgfsHadoopOutProc.java |   466 +
 .../igfs/hadoop/IgfsHadoopOutputStream.java     |   201 +
 .../igfs/hadoop/IgfsHadoopProxyInputStream.java |   335 +
 .../hadoop/IgfsHadoopProxyOutputStream.java     |   165 +
 .../internal/igfs/hadoop/IgfsHadoopReader.java  |   104 +
 .../igfs/hadoop/IgfsHadoopStreamDelegate.java   |    96 +
 .../hadoop/IgfsHadoopStreamEventListener.java   |    39 +
 .../internal/igfs/hadoop/IgfsHadoopUtils.java   |   131 +
 .../internal/igfs/hadoop/IgfsHadoopWrapper.java |   511 +
 .../ignite/internal/igfs/hadoop/package.html    |    24 +
 .../apache/ignite/internal/igfs/package.html    |    24 +
 .../hadoop/GridHadoopClassLoader.java           |   552 +
 .../processors/hadoop/GridHadoopComponent.java  |    61 +
 .../processors/hadoop/GridHadoopContext.java    |   196 +
 .../hadoop/GridHadoopDefaultJobInfo.java        |   162 +
 .../processors/hadoop/GridHadoopImpl.java       |   132 +
 .../processors/hadoop/GridHadoopSetup.java      |   506 +
 .../GridHadoopTaskCancelledException.java       |    35 +
 .../processors/hadoop/GridHadoopUtils.java      |   308 +
 .../hadoop/IgniteHadoopProcessor.java           |   225 +
 .../counter/GridHadoopCounterAdapter.java       |   128 +
 .../hadoop/counter/GridHadoopCountersImpl.java  |   198 +
 .../counter/GridHadoopFSCounterWriter.java      |    91 +
 .../hadoop/counter/GridHadoopLongCounter.java   |    92 +
 .../counter/GridHadoopPerformanceCounter.java   |   279 +
 .../fs/GridHadoopDistributedFileSystem.java     |    91 +
 .../hadoop/fs/GridHadoopFileSystemsUtils.java   |    57 +
 .../hadoop/fs/GridHadoopLocalFileSystemV1.java  |    39 +
 .../hadoop/fs/GridHadoopLocalFileSystemV2.java  |    86 +
 .../hadoop/fs/GridHadoopRawLocalFileSystem.java |   304 +
 .../jobtracker/GridHadoopJobMetadata.java       |   305 +
 .../hadoop/jobtracker/GridHadoopJobTracker.java |  1625 ++
 .../hadoop/message/GridHadoopMessage.java       |    27 +
 .../planner/GridHadoopDefaultMapReducePlan.java |   107 +
 .../GridHadoopDefaultMapReducePlanner.java      |   435 +
 .../GridHadoopProtocolJobCountersTask.java      |    45 +
 .../proto/GridHadoopProtocolJobStatusTask.java  |    81 +
 .../proto/GridHadoopProtocolKillJobTask.java    |    46 +
 .../proto/GridHadoopProtocolNextTaskIdTask.java |    35 +
 .../proto/GridHadoopProtocolSubmitJobTask.java  |    57 +
 .../proto/GridHadoopProtocolTaskAdapter.java    |   113 +
 .../proto/GridHadoopProtocolTaskArguments.java  |    81 +
 .../hadoop/shuffle/GridHadoopShuffle.java       |   256 +
 .../hadoop/shuffle/GridHadoopShuffleAck.java    |    91 +
 .../hadoop/shuffle/GridHadoopShuffleJob.java    |   593 +
 .../shuffle/GridHadoopShuffleMessage.java       |   241 +
 .../GridHadoopConcurrentHashMultimap.java       |   611 +
 .../collections/GridHadoopHashMultimap.java     |   174 +
 .../collections/GridHadoopHashMultimapBase.java |   208 +
 .../shuffle/collections/GridHadoopMultimap.java |   112 +
 .../collections/GridHadoopMultimapBase.java     |   368 +
 .../shuffle/collections/GridHadoopSkipList.java |   726 +
 .../shuffle/streams/GridHadoopDataInStream.java |   170 +
 .../streams/GridHadoopDataOutStream.java        |   131 +
 .../streams/GridHadoopOffheapBuffer.java        |   122 +
 .../GridHadoopEmbeddedTaskExecutor.java         |   146 +
 .../taskexecutor/GridHadoopExecutorService.java |   232 +
 .../taskexecutor/GridHadoopRunnableTask.java    |   268 +
 .../GridHadoopTaskExecutorAdapter.java          |    57 +
 .../taskexecutor/GridHadoopTaskState.java       |    38 +
 .../taskexecutor/GridHadoopTaskStatus.java      |   114 +
 .../GridHadoopExternalTaskExecutor.java         |   960 ++
 .../GridHadoopExternalTaskMetadata.java         |    68 +
 .../GridHadoopJobInfoUpdateRequest.java         |   109 +
 .../GridHadoopPrepareForJobRequest.java         |   126 +
 .../external/GridHadoopProcessDescriptor.java   |   150 +
 .../external/GridHadoopProcessStartedAck.java   |    46 +
 .../GridHadoopTaskExecutionRequest.java         |   110 +
 .../external/GridHadoopTaskFinishedMessage.java |    92 +
 .../child/GridHadoopChildProcessRunner.java     |   440 +
 .../child/GridHadoopExternalProcessStarter.java |   296 +
 .../GridHadoopAbstractCommunicationClient.java  |    96 +
 .../GridHadoopCommunicationClient.java          |    72 +
 .../GridHadoopExternalCommunication.java        |  1419 ++
 .../GridHadoopHandshakeTimeoutException.java    |    42 +
 .../GridHadoopIpcToNioAdapter.java              |   239 +
 .../GridHadoopMarshallerFilter.java             |    84 +
 .../GridHadoopMessageListener.java              |    39 +
 .../GridHadoopTcpNioCommunicationClient.java    |    99 +
 .../hadoop/v1/GridHadoopV1CleanupTask.java      |    62 +
 .../hadoop/v1/GridHadoopV1Counter.java          |   105 +
 .../hadoop/v1/GridHadoopV1MapTask.java          |   107 +
 .../hadoop/v1/GridHadoopV1OutputCollector.java  |   130 +
 .../hadoop/v1/GridHadoopV1Partitioner.java      |    44 +
 .../hadoop/v1/GridHadoopV1ReduceTask.java       |    92 +
 .../hadoop/v1/GridHadoopV1Reporter.java         |    79 +
 .../hadoop/v1/GridHadoopV1SetupTask.java        |    56 +
 .../hadoop/v1/GridHadoopV1Splitter.java         |    97 +
 .../processors/hadoop/v1/GridHadoopV1Task.java  |    95 +
 .../hadoop/v2/GridHadoopExternalSplit.java      |    87 +
 .../hadoop/v2/GridHadoopNativeCodeLoader.java   |    74 +
 .../v2/GridHadoopSerializationWrapper.java      |   133 +
 .../v2/GridHadoopShutdownHookManager.java       |    96 +
 .../hadoop/v2/GridHadoopSplitWrapper.java       |   119 +
 .../hadoop/v2/GridHadoopV2CleanupTask.java      |    73 +
 .../hadoop/v2/GridHadoopV2Context.java          |   230 +
 .../hadoop/v2/GridHadoopV2Counter.java          |    87 +
 .../processors/hadoop/v2/GridHadoopV2Job.java   |   280 +
 .../v2/GridHadoopV2JobResourceManager.java      |   305 +
 .../hadoop/v2/GridHadoopV2MapTask.java          |   109 +
 .../hadoop/v2/GridHadoopV2Partitioner.java      |    44 +
 .../hadoop/v2/GridHadoopV2ReduceTask.java       |    88 +
 .../hadoop/v2/GridHadoopV2SetupTask.java        |    66 +
 .../hadoop/v2/GridHadoopV2Splitter.java         |   105 +
 .../processors/hadoop/v2/GridHadoopV2Task.java  |   181 +
 .../hadoop/v2/GridHadoopV2TaskContext.java      |   443 +
 .../v2/GridHadoopWritableSerialization.java     |    74 +
 .../client/hadoop/GridHadoopClientProtocol.java |   334 -
 .../GridHadoopClientProtocolProvider.java       |   138 -
 .../counter/GridHadoopClientCounterGroup.java   |   121 -
 .../counter/GridHadoopClientCounters.java       |   217 -
 .../org/gridgain/client/hadoop/package.html     |    23 -
 .../ggfs/hadoop/GridGgfsHadoopParameters.java   |    94 -
 .../org/gridgain/grid/ggfs/hadoop/package.html  |    23 -
 .../hadoop/v1/GridGgfsHadoopFileSystem.java     |  1254 --
 .../gridgain/grid/ggfs/hadoop/v1/package.html   |    23 -
 .../hadoop/v2/GridGgfsHadoopFileSystem.java     |  1008 --
 .../gridgain/grid/ggfs/hadoop/v2/package.html   |    23 -
 .../java/org/gridgain/grid/ggfs/package.html    |    23 -
 .../grid/hadoop/GridHadoopDefaultJobInfo.java   |   164 -
 .../gridgain/grid/hadoop/GridHadoopSetup.java   |   506 -
 .../grid/kernal/ggfs/hadoop/GridGgfsHadoop.java |   199 -
 .../GridGgfsHadoopCommunicationException.java   |    60 -
 .../ggfs/hadoop/GridGgfsHadoopEndpoint.java     |   211 -
 .../kernal/ggfs/hadoop/GridGgfsHadoopEx.java    |    88 -
 .../ggfs/hadoop/GridGgfsHadoopFSProperties.java |    89 -
 .../hadoop/GridGgfsHadoopFileSystemWrapper.java |   414 -
 .../ggfs/hadoop/GridGgfsHadoopFuture.java       |    94 -
 .../ggfs/hadoop/GridGgfsHadoopInProc.java       |   367 -
 .../ggfs/hadoop/GridGgfsHadoopInputStream.java  |   627 -
 .../kernal/ggfs/hadoop/GridGgfsHadoopIo.java    |    77 -
 .../kernal/ggfs/hadoop/GridGgfsHadoopIpcIo.java |   600 -
 .../hadoop/GridGgfsHadoopIpcIoListener.java     |    36 -
 .../ggfs/hadoop/GridGgfsHadoopJclLogger.java    |   115 -
 .../ggfs/hadoop/GridGgfsHadoopOutProc.java      |   467 -
 .../ggfs/hadoop/GridGgfsHadoopOutputStream.java |   202 -
 .../hadoop/GridGgfsHadoopProxyInputStream.java  |   335 -
 .../hadoop/GridGgfsHadoopProxyOutputStream.java |   165 -
 .../ggfs/hadoop/GridGgfsHadoopReader.java       |   103 -
 .../hadoop/GridGgfsHadoopStreamDelegate.java    |    96 -
 .../GridGgfsHadoopStreamEventListener.java      |    40 -
 .../kernal/ggfs/hadoop/GridGgfsHadoopUtils.java |   132 -
 .../ggfs/hadoop/GridGgfsHadoopWrapper.java      |   512 -
 .../grid/kernal/ggfs/hadoop/package.html        |    23 -
 .../org/gridgain/grid/kernal/ggfs/package.html  |    23 -
 .../hadoop/GridHadoopClassLoader.java           |   553 -
 .../processors/hadoop/GridHadoopComponent.java  |    62 -
 .../processors/hadoop/GridHadoopContext.java    |   197 -
 .../processors/hadoop/GridHadoopImpl.java       |   134 -
 .../processors/hadoop/GridHadoopProcessor.java  |   228 -
 .../GridHadoopTaskCancelledException.java       |    36 -
 .../processors/hadoop/GridHadoopUtils.java      |   307 -
 .../counter/GridHadoopCounterAdapter.java       |   128 -
 .../hadoop/counter/GridHadoopCountersImpl.java  |   199 -
 .../counter/GridHadoopFSCounterWriter.java      |    91 -
 .../hadoop/counter/GridHadoopLongCounter.java   |    91 -
 .../counter/GridHadoopPerformanceCounter.java   |   267 -
 .../fs/GridHadoopDistributedFileSystem.java     |    91 -
 .../hadoop/fs/GridHadoopFileSystemsUtils.java   |    57 -
 .../hadoop/fs/GridHadoopLocalFileSystemV1.java  |    39 -
 .../hadoop/fs/GridHadoopLocalFileSystemV2.java  |    86 -
 .../hadoop/fs/GridHadoopRawLocalFileSystem.java |   304 -
 .../jobtracker/GridHadoopJobMetadata.java       |   305 -
 .../hadoop/jobtracker/GridHadoopJobTracker.java |  1568 --
 .../hadoop/message/GridHadoopMessage.java       |    27 -
 .../planner/GridHadoopDefaultMapReducePlan.java |   107 -
 .../GridHadoopDefaultMapReducePlanner.java      |   430 -
 .../GridHadoopProtocolJobCountersTask.java      |    46 -
 .../proto/GridHadoopProtocolJobStatusTask.java  |    81 -
 .../proto/GridHadoopProtocolKillJobTask.java    |    47 -
 .../proto/GridHadoopProtocolNextTaskIdTask.java |    37 -
 .../proto/GridHadoopProtocolSubmitJobTask.java  |    58 -
 .../proto/GridHadoopProtocolTaskAdapter.java    |   106 -
 .../proto/GridHadoopProtocolTaskArguments.java  |    81 -
 .../hadoop/shuffle/GridHadoopShuffle.java       |   258 -
 .../hadoop/shuffle/GridHadoopShuffleAck.java    |    91 -
 .../hadoop/shuffle/GridHadoopShuffleJob.java    |   593 -
 .../shuffle/GridHadoopShuffleMessage.java       |   242 -
 .../GridHadoopConcurrentHashMultimap.java       |   612 -
 .../collections/GridHadoopHashMultimap.java     |   175 -
 .../collections/GridHadoopHashMultimapBase.java |   209 -
 .../shuffle/collections/GridHadoopMultimap.java |   113 -
 .../collections/GridHadoopMultimapBase.java     |   369 -
 .../shuffle/collections/GridHadoopSkipList.java |   727 -
 .../shuffle/streams/GridHadoopDataInStream.java |   170 -
 .../streams/GridHadoopDataOutStream.java        |   131 -
 .../streams/GridHadoopOffheapBuffer.java        |   122 -
 .../GridHadoopEmbeddedTaskExecutor.java         |   147 -
 .../taskexecutor/GridHadoopExecutorService.java |   232 -
 .../taskexecutor/GridHadoopRunnableTask.java    |   270 -
 .../GridHadoopTaskExecutorAdapter.java          |    59 -
 .../taskexecutor/GridHadoopTaskState.java       |    38 -
 .../taskexecutor/GridHadoopTaskStatus.java      |   114 -
 .../GridHadoopExternalTaskExecutor.java         |   962 --
 .../GridHadoopExternalTaskMetadata.java         |    68 -
 .../GridHadoopJobInfoUpdateRequest.java         |   109 -
 .../GridHadoopPrepareForJobRequest.java         |   126 -
 .../external/GridHadoopProcessDescriptor.java   |   150 -
 .../external/GridHadoopProcessStartedAck.java   |    46 -
 .../GridHadoopTaskExecutionRequest.java         |   110 -
 .../external/GridHadoopTaskFinishedMessage.java |    92 -
 .../child/GridHadoopChildProcessRunner.java     |   441 -
 .../child/GridHadoopExternalProcessStarter.java |   297 -
 .../GridHadoopAbstractCommunicationClient.java  |    96 -
 .../GridHadoopCommunicationClient.java          |    73 -
 .../GridHadoopExternalCommunication.java        |  1421 --
 .../GridHadoopHandshakeTimeoutException.java    |    43 -
 .../GridHadoopIpcToNioAdapter.java              |   240 -
 .../GridHadoopMarshallerFilter.java             |    85 -
 .../GridHadoopMessageListener.java              |    39 -
 .../GridHadoopTcpNioCommunicationClient.java    |   100 -
 .../hadoop/v1/GridHadoopV1CleanupTask.java      |    63 -
 .../hadoop/v1/GridHadoopV1Counter.java          |   105 -
 .../hadoop/v1/GridHadoopV1MapTask.java          |   109 -
 .../hadoop/v1/GridHadoopV1OutputCollector.java  |   134 -
 .../hadoop/v1/GridHadoopV1Partitioner.java      |    44 -
 .../hadoop/v1/GridHadoopV1ReduceTask.java       |    94 -
 .../hadoop/v1/GridHadoopV1Reporter.java         |    79 -
 .../hadoop/v1/GridHadoopV1SetupTask.java        |    57 -
 .../hadoop/v1/GridHadoopV1Splitter.java         |    99 -
 .../processors/hadoop/v1/GridHadoopV1Task.java  |    97 -
 .../hadoop/v2/GridHadoopExternalSplit.java      |    87 -
 .../hadoop/v2/GridHadoopNativeCodeLoader.java   |    74 -
 .../v2/GridHadoopSerializationWrapper.java      |   134 -
 .../v2/GridHadoopShutdownHookManager.java       |    96 -
 .../hadoop/v2/GridHadoopSplitWrapper.java       |   119 -
 .../hadoop/v2/GridHadoopV2CleanupTask.java      |    71 -
 .../hadoop/v2/GridHadoopV2Context.java          |   232 -
 .../hadoop/v2/GridHadoopV2Counter.java          |    87 -
 .../processors/hadoop/v2/GridHadoopV2Job.java   |   282 -
 .../v2/GridHadoopV2JobResourceManager.java      |   305 -
 .../hadoop/v2/GridHadoopV2MapTask.java          |   105 -
 .../hadoop/v2/GridHadoopV2Partitioner.java      |    44 -
 .../hadoop/v2/GridHadoopV2ReduceTask.java       |    87 -
 .../hadoop/v2/GridHadoopV2SetupTask.java        |    65 -
 .../hadoop/v2/GridHadoopV2Splitter.java         |   106 -
 .../processors/hadoop/v2/GridHadoopV2Task.java  |   182 -
 .../hadoop/v2/GridHadoopV2TaskContext.java      |   444 -
 .../v2/GridHadoopWritableSerialization.java     |    75 -
 ...op.mapreduce.protocol.ClientProtocolProvider |     2 +-
 ...ridHadoopClientProtocolEmbeddedSelfTest.java |    34 +
 .../GridHadoopClientProtocolSelfTest.java       |   633 +
 .../apache/ignite/igfs/IgfsEventsTestSuite.java |   267 +
 .../IgfsHadoop20FileSystemAbstractSelfTest.java |  1967 +++
 ...doop20FileSystemLoopbackPrimarySelfTest.java |    74 +
 ...sHadoop20FileSystemShmemPrimarySelfTest.java |    74 +
 .../igfs/IgfsHadoopDualAbstractSelfTest.java    |   304 +
 .../igfs/IgfsHadoopDualAsyncSelfTest.java       |    32 +
 .../ignite/igfs/IgfsHadoopDualSyncSelfTest.java |    32 +
 .../IgfsHadoopFileSystemAbstractSelfTest.java   |  2365 +++
 .../IgfsHadoopFileSystemClientSelfTest.java     |   199 +
 .../IgfsHadoopFileSystemHandshakeSelfTest.java  |   311 +
 .../IgfsHadoopFileSystemIpcCacheSelfTest.java   |   207 +
 .../IgfsHadoopFileSystemLoggerSelfTest.java     |   287 +
 ...IgfsHadoopFileSystemLoggerStateSelfTest.java |   325 +
 ...adoopFileSystemLoopbackAbstractSelfTest.java |    46 +
 ...SystemLoopbackEmbeddedDualAsyncSelfTest.java |    33 +
 ...eSystemLoopbackEmbeddedDualSyncSelfTest.java |    33 +
 ...leSystemLoopbackEmbeddedPrimarySelfTest.java |    33 +
 ...SystemLoopbackEmbeddedSecondarySelfTest.java |    34 +
 ...SystemLoopbackExternalDualAsyncSelfTest.java |    33 +
 ...eSystemLoopbackExternalDualSyncSelfTest.java |    33 +
 ...leSystemLoopbackExternalPrimarySelfTest.java |    33 +
 ...SystemLoopbackExternalSecondarySelfTest.java |    34 +
 ...fsHadoopFileSystemSecondaryModeSelfTest.java |   319 +
 ...fsHadoopFileSystemShmemAbstractSelfTest.java |    88 +
 ...ileSystemShmemEmbeddedDualAsyncSelfTest.java |    33 +
 ...FileSystemShmemEmbeddedDualSyncSelfTest.java |    33 +
 ...pFileSystemShmemEmbeddedPrimarySelfTest.java |    33 +
 ...ileSystemShmemEmbeddedSecondarySelfTest.java |    33 +
 ...ileSystemShmemExternalDualAsyncSelfTest.java |    33 +
 ...FileSystemShmemExternalDualSyncSelfTest.java |    33 +
 ...pFileSystemShmemExternalPrimarySelfTest.java |    33 +
 ...ileSystemShmemExternalSecondarySelfTest.java |    33 +
 .../java/org/apache/ignite/igfs/IgfsLoad.java   |   549 +
 .../igfs/IgfsNearOnlyMultiNodeSelfTest.java     |   212 +
 .../hadoop/GridHadoopAbstractSelfTest.java      |   222 +
 .../hadoop/GridHadoopAbstractWordCountTest.java |   138 +
 .../hadoop/GridHadoopClassLoaderTest.java       |    69 +
 .../hadoop/GridHadoopCommandLineTest.java       |   440 +
 ...idHadoopDefaultMapReducePlannerSelfTest.java |  1220 ++
 .../hadoop/GridHadoopFileSystemsTest.java       |   177 +
 .../hadoop/GridHadoopGroupingTest.java          |   286 +
 .../hadoop/GridHadoopJobTrackerSelfTest.java    |   330 +
 .../GridHadoopMapReduceEmbeddedSelfTest.java    |   245 +
 .../hadoop/GridHadoopMapReduceTest.java         |   195 +
 .../hadoop/GridHadoopPopularWordsTest.java      |   294 +
 .../GridHadoopSerializationWrapperSelfTest.java |    74 +
 .../processors/hadoop/GridHadoopSharedMap.java  |    67 +
 .../hadoop/GridHadoopSortingExternalTest.java   |    32 +
 .../hadoop/GridHadoopSortingTest.java           |   282 +
 .../hadoop/GridHadoopSplitWrapperSelfTest.java  |    68 +
 .../processors/hadoop/GridHadoopStartup.java    |    55 +
 .../hadoop/GridHadoopTaskExecutionSelfTest.java |   551 +
 .../hadoop/GridHadoopTasksAllVersionsTest.java  |   259 +
 .../hadoop/GridHadoopTasksV1Test.java           |    57 +
 .../hadoop/GridHadoopTasksV2Test.java           |    75 +
 .../GridHadoopTestRoundRobinMrPlanner.java      |    66 +
 .../hadoop/GridHadoopTestTaskContext.java       |   219 +
 .../processors/hadoop/GridHadoopTestUtils.java  |   102 +
 .../hadoop/GridHadoopV2JobSelfTest.java         |    88 +
 .../hadoop/GridHadoopValidationSelfTest.java    |    53 +
 .../hadoop/books/alice-in-wonderland.txt        |  3735 +++++
 .../processors/hadoop/books/art-of-war.txt      |  6982 +++++++++
 .../hadoop/books/huckleberry-finn.txt           | 11733 ++++++++++++++
 .../processors/hadoop/books/sherlock-holmes.txt | 13052 ++++++++++++++++
 .../processors/hadoop/books/tom-sawyer.txt      |  8858 +++++++++++
 .../hadoop/examples/GridHadoopWordCount1.java   |    88 +
 .../examples/GridHadoopWordCount1Map.java       |    62 +
 .../examples/GridHadoopWordCount1Reduce.java    |    51 +
 .../hadoop/examples/GridHadoopWordCount2.java   |    95 +
 .../examples/GridHadoopWordCount2Mapper.java    |    72 +
 .../examples/GridHadoopWordCount2Reducer.java   |    70 +
 .../collections/GridHadoopAbstractMapTest.java  |   152 +
 ...ridHadoopConcurrentHashMultimapSelftest.java |   267 +
 .../collections/GridHadoopHashMapSelfTest.java  |   170 +
 .../collections/GridHadoopSkipListSelfTest.java |   303 +
 .../streams/GridHadoopDataStreamSelfTest.java   |   151 +
 .../GridHadoopExecutorServiceTest.java          |   119 +
 ...GridHadoopExternalTaskExecutionSelfTest.java |   210 +
 ...GridHadoopExternalCommunicationSelfTest.java |   209 +
 .../ignite/loadtests/igfs/IgfsNodeStartup.java  |    49 +
 .../igfs/IgfsPerformanceBenchmark.java          |   274 +
 .../testsuites/IgniteHadoopTestSuite.java       |   263 +
 .../IgniteIgfsLinuxAndMacOSTestSuite.java       |    63 +
 ...ridHadoopClientProtocolEmbeddedSelfTest.java |    34 -
 .../GridHadoopClientProtocolSelfTest.java       |   633 -
 .../gridgain/grid/ggfs/GridFileSystemLoad.java  |   548 -
 .../grid/ggfs/GridGgfsEventsTestSuite.java      |   258 -
 ...dGgfsHadoop20FileSystemAbstractSelfTest.java |  1969 ---
 ...doop20FileSystemLoopbackPrimarySelfTest.java |    69 -
 ...sHadoop20FileSystemShmemPrimarySelfTest.java |    69 -
 .../GridGgfsHadoopDualAbstractSelfTest.java     |   297 -
 .../ggfs/GridGgfsHadoopDualAsyncSelfTest.java   |    32 -
 .../ggfs/GridGgfsHadoopDualSyncSelfTest.java    |    32 -
 ...ridGgfsHadoopFileSystemAbstractSelfTest.java |  2368 ---
 .../GridGgfsHadoopFileSystemClientSelfTest.java |   199 -
 ...idGgfsHadoopFileSystemHandshakeSelfTest.java |   307 -
 ...ridGgfsHadoopFileSystemIpcCacheSelfTest.java |   207 -
 .../GridGgfsHadoopFileSystemLoggerSelfTest.java |   288 -
 ...GgfsHadoopFileSystemLoggerStateSelfTest.java |   323 -
 ...adoopFileSystemLoopbackAbstractSelfTest.java |    43 -
 ...SystemLoopbackEmbeddedDualAsyncSelfTest.java |    33 -
 ...eSystemLoopbackEmbeddedDualSyncSelfTest.java |    33 -
 ...leSystemLoopbackEmbeddedPrimarySelfTest.java |    33 -
 ...SystemLoopbackEmbeddedSecondarySelfTest.java |    34 -
 ...SystemLoopbackExternalDualAsyncSelfTest.java |    33 -
 ...eSystemLoopbackExternalDualSyncSelfTest.java |    33 -
 ...leSystemLoopbackExternalPrimarySelfTest.java |    33 -
 ...SystemLoopbackExternalSecondarySelfTest.java |    34 -
 ...fsHadoopFileSystemSecondaryModeSelfTest.java |   314 -
 ...fsHadoopFileSystemShmemAbstractSelfTest.java |    87 -
 ...ileSystemShmemEmbeddedDualAsyncSelfTest.java |    33 -
 ...FileSystemShmemEmbeddedDualSyncSelfTest.java |    33 -
 ...pFileSystemShmemEmbeddedPrimarySelfTest.java |    33 -
 ...ileSystemShmemEmbeddedSecondarySelfTest.java |    33 -
 ...ileSystemShmemExternalDualAsyncSelfTest.java |    33 -
 ...FileSystemShmemExternalDualSyncSelfTest.java |    33 -
 ...pFileSystemShmemExternalPrimarySelfTest.java |    33 -
 ...ileSystemShmemExternalSecondarySelfTest.java |    33 -
 .../ggfs/GridGgfsNearOnlyMultiNodeSelfTest.java |   212 -
 .../grid/hadoop/GridHadoopPopularWordsTest.java |   294 -
 .../grid/hadoop/GridHadoopTestUtils.java        |    86 -
 .../grid/hadoop/books/alice-in-wonderland.txt   |  3735 -----
 .../gridgain/grid/hadoop/books/art-of-war.txt   |  6982 ---------
 .../grid/hadoop/books/huckleberry-finn.txt      | 11733 --------------
 .../grid/hadoop/books/sherlock-holmes.txt       | 13052 ----------------
 .../gridgain/grid/hadoop/books/tom-sawyer.txt   |  8858 -----------
 .../hadoop/GridHadoopAbstractSelfTest.java      |   210 -
 .../hadoop/GridHadoopAbstractWordCountTest.java |   138 -
 .../hadoop/GridHadoopClassLoaderTest.java       |    69 -
 .../hadoop/GridHadoopCommandLineTest.java       |   441 -
 ...idHadoopDefaultMapReducePlannerSelfTest.java |  1223 --
 .../hadoop/GridHadoopFileSystemsTest.java       |   176 -
 .../hadoop/GridHadoopGroupingTest.java          |   287 -
 .../hadoop/GridHadoopJobTrackerSelfTest.java    |   332 -
 .../GridHadoopMapReduceEmbeddedSelfTest.java    |   246 -
 .../hadoop/GridHadoopMapReduceTest.java         |   200 -
 .../GridHadoopSerializationWrapperSelfTest.java |    76 -
 .../processors/hadoop/GridHadoopSharedMap.java  |    67 -
 .../hadoop/GridHadoopSortingExternalTest.java   |    34 -
 .../hadoop/GridHadoopSortingTest.java           |   283 -
 .../hadoop/GridHadoopSplitWrapperSelfTest.java  |    69 -
 .../processors/hadoop/GridHadoopStartup.java    |    55 -
 .../hadoop/GridHadoopTaskExecutionSelfTest.java |   551 -
 .../hadoop/GridHadoopTasksAllVersionsTest.java  |   261 -
 .../hadoop/GridHadoopTasksV1Test.java           |    58 -
 .../hadoop/GridHadoopTasksV2Test.java           |    76 -
 .../GridHadoopTestRoundRobinMrPlanner.java      |    68 -
 .../hadoop/GridHadoopTestTaskContext.java       |   221 -
 .../hadoop/GridHadoopV2JobSelfTest.java         |    90 -
 .../hadoop/GridHadoopValidationSelfTest.java    |    53 -
 .../hadoop/examples/GridHadoopWordCount1.java   |    88 -
 .../examples/GridHadoopWordCount1Map.java       |    62 -
 .../examples/GridHadoopWordCount1Reduce.java    |    51 -
 .../hadoop/examples/GridHadoopWordCount2.java   |    95 -
 .../examples/GridHadoopWordCount2Mapper.java    |    72 -
 .../examples/GridHadoopWordCount2Reducer.java   |    71 -
 .../collections/GridHadoopAbstractMapTest.java  |   153 -
 ...ridHadoopConcurrentHashMultimapSelftest.java |   267 -
 .../collections/GridHadoopHashMapSelfTest.java  |   170 -
 .../collections/GridHadoopSkipListSelfTest.java |   303 -
 .../streams/GridHadoopDataStreamSelfTest.java   |   151 -
 .../GridHadoopExecutorServiceTest.java          |   119 -
 ...GridHadoopExternalTaskExecutionSelfTest.java |   212 -
 ...GridHadoopExternalCommunicationSelfTest.java |   209 -
 .../loadtests/ggfs/GridGgfsNodeStartup.java     |    50 -
 .../ggfs/GridGgfsPerformanceBenchmark.java      |   273 -
 .../bamboo/GridGgfsLinuxAndMacOSTestSuite.java  |    63 -
 .../testsuites/bamboo/GridHadoopTestSuite.java  |   263 -
 modules/hibernate/pom.xml                       |     8 +-
 modules/hibernate/readme.txt                    |    20 +-
 ...idHibernateAbstractRegionAccessStrategy.java |    97 +
 .../GridHibernateAccessStrategyAdapter.java     |   369 +
 .../GridHibernateCollectionRegion.java          |    99 +
 .../hibernate/GridHibernateEntityRegion.java    |   110 +
 .../GridHibernateGeneralDataRegion.java         |    69 +
 .../hibernate/GridHibernateNaturalIdRegion.java |    98 +
 .../GridHibernateNonStrictAccessStrategy.java   |   220 +
 .../GridHibernateQueryResultsRegion.java        |    71 +
 .../GridHibernateReadOnlyAccessStrategy.java    |   106 +
 .../GridHibernateReadWriteAccessStrategy.java   |   282 +
 .../cache/hibernate/GridHibernateRegion.java    |   101 +
 .../hibernate/GridHibernateRegionFactory.java   |   231 +
 .../GridHibernateTimestampsRegion.java          |    40 +
 ...ridHibernateTransactionalAccessStrategy.java |   139 +
 .../GridHibernateTransactionalDataRegion.java   |    96 +
 .../apache/ignite/cache/hibernate/package.html  |    26 +
 .../hibernate/CacheHibernateBlobStore.java      |   605 +
 .../CacheHibernateBlobStoreEntry.hbm.xml        |    31 +
 .../hibernate/CacheHibernateBlobStoreEntry.java |    86 +
 .../ignite/cache/store/hibernate/package.html   |    24 +
 ...idHibernateAbstractRegionAccessStrategy.java |    97 -
 .../GridHibernateAccessStrategyAdapter.java     |   368 -
 .../GridHibernateCollectionRegion.java          |    99 -
 .../hibernate/GridHibernateEntityRegion.java    |   110 -
 .../GridHibernateGeneralDataRegion.java         |    70 -
 .../hibernate/GridHibernateNaturalIdRegion.java |    98 -
 .../GridHibernateNonStrictAccessStrategy.java   |   221 -
 .../GridHibernateQueryResultsRegion.java        |    71 -
 .../GridHibernateReadOnlyAccessStrategy.java    |   107 -
 .../GridHibernateReadWriteAccessStrategy.java   |   282 -
 .../cache/hibernate/GridHibernateRegion.java    |   101 -
 .../hibernate/GridHibernateRegionFactory.java   |   230 -
 .../GridHibernateTimestampsRegion.java          |    40 -
 ...ridHibernateTransactionalAccessStrategy.java |   140 -
 .../GridHibernateTransactionalDataRegion.java   |    96 -
 .../gridgain/grid/cache/hibernate/package.html  |    26 -
 .../hibernate/GridCacheHibernateBlobStore.java  |   563 -
 .../GridCacheHibernateBlobStoreEntry.hbm.xml    |    29 -
 .../GridCacheHibernateBlobStoreEntry.java       |    86 -
 .../grid/cache/store/hibernate/package.html     |    23 -
 ...idHibernateL2CacheConfigurationSelfTest.java |   393 +
 .../hibernate/GridHibernateL2CacheSelfTest.java |  1923 +++
 ...idHibernateL2CacheTransactionalSelfTest.java |   135 +
 .../CacheHibernateBlobStoreSelfTest.java        |   108 +
 .../cache/store/hibernate/hibernate.cfg.xml     |    42 +
 .../ignite/cache/store/hibernate/package.html   |    24 +
 .../testsuites/IgniteHibernateTestSuite.java    |    44 +
 ...idHibernateL2CacheConfigurationSelfTest.java |   379 -
 .../hibernate/GridHibernateL2CacheSelfTest.java |  1922 ---
 ...idHibernateL2CacheTransactionalSelfTest.java |   135 -
 .../GridCacheHibernateBlobStoreSelfTest.java    |   108 -
 .../cache/store/hibernate/hibernate.cfg.xml     |    40 -
 .../grid/cache/store/hibernate/package.html     |    23 -
 .../bamboo/GridHibernateTestSuite.java          |    44 -
 modules/indexing/licenses/jts-lgpl-license.txt  |   165 -
 modules/indexing/pom.xml                        |    14 +-
 modules/indexing/readme.txt                     |    18 +-
 .../query/h2/GridH2ResultSetIterator.java       |   130 +
 .../processors/query/h2/IgniteH2Indexing.java   |  2142 +++
 .../query/h2/opt/GridH2AbstractKeyValueRow.java |   455 +
 .../processors/query/h2/opt/GridH2Cursor.java   |    70 +
 .../query/h2/opt/GridH2IndexBase.java           |   209 +
 .../query/h2/opt/GridH2KeyValueRowOffheap.java  |   356 +
 .../query/h2/opt/GridH2KeyValueRowOnheap.java   |    54 +
 .../processors/query/h2/opt/GridH2Row.java      |    48 +
 .../query/h2/opt/GridH2RowDescriptor.java       |   110 +
 .../processors/query/h2/opt/GridH2Table.java    |   896 ++
 .../query/h2/opt/GridH2TreeIndex.java           |   477 +
 .../processors/query/h2/opt/GridH2Utils.java    |   133 +
 .../query/h2/opt/GridLuceneDirectory.java       |   197 +
 .../processors/query/h2/opt/GridLuceneFile.java |   194 +
 .../query/h2/opt/GridLuceneIndex.java           |   401 +
 .../query/h2/opt/GridLuceneInputStream.java     |   228 +
 .../query/h2/opt/GridLuceneLockFactory.java     |    72 +
 .../query/h2/opt/GridLuceneOutputStream.java    |   239 +
 .../query/h2/opt/GridSearchRowPointer.java      |    28 +
 .../internal/processors/query/h2/package.html   |    24 +
 .../query/h2/sql/GridSqlAggregateFunction.java  |    84 +
 .../processors/query/h2/sql/GridSqlAlias.java   |    63 +
 .../processors/query/h2/sql/GridSqlColumn.java  |    65 +
 .../processors/query/h2/sql/GridSqlConst.java   |    47 +
 .../processors/query/h2/sql/GridSqlElement.java |    81 +
 .../query/h2/sql/GridSqlFunction.java           |   150 +
 .../query/h2/sql/GridSqlFunctionType.java       |    86 +
 .../processors/query/h2/sql/GridSqlJoin.java    |    76 +
 .../query/h2/sql/GridSqlOperation.java          |    81 +
 .../query/h2/sql/GridSqlOperationType.java      |   210 +
 .../query/h2/sql/GridSqlParameter.java          |    52 +
 .../query/h2/sql/GridSqlQueryParser.java        |   503 +
 .../query/h2/sql/GridSqlQuerySplitter.java      |   260 +
 .../processors/query/h2/sql/GridSqlSelect.java  |   295 +
 .../query/h2/sql/GridSqlSubquery.java           |    52 +
 .../processors/query/h2/sql/GridSqlTable.java   |    63 +
 .../processors/query/h2/sql/GridSqlValue.java   |    25 +
 .../query/h2/twostep/GridMapQueryExecutor.java  |   278 +
 .../query/h2/twostep/GridMergeIndex.java        |   298 +
 .../h2/twostep/GridMergeIndexUnsorted.java      |    93 +
 .../query/h2/twostep/GridMergeTable.java        |   186 +
 .../h2/twostep/GridReduceQueryExecutor.java     |   253 +
 .../query/h2/twostep/GridResultPage.java        |    67 +
 .../twostep/messages/GridNextPageRequest.java   |    70 +
 .../twostep/messages/GridNextPageResponse.java  |   191 +
 .../query/h2/twostep/messages/GridQueryAck.java |    45 +
 .../twostep/messages/GridQueryFailResponse.java |    57 +
 .../h2/twostep/messages/GridQueryRequest.java   |    72 +
 .../processors/query/h2/GridH2Indexing.java     |  2006 ---
 .../query/h2/GridH2ResultSetIterator.java       |   130 -
 .../query/h2/opt/GridH2AbstractKeyValueRow.java |   455 -
 .../processors/query/h2/opt/GridH2Cursor.java   |    70 -
 .../query/h2/opt/GridH2IndexBase.java           |   206 -
 .../query/h2/opt/GridH2KeyValueRowOffheap.java  |   356 -
 .../query/h2/opt/GridH2KeyValueRowOnheap.java   |    54 -
 .../processors/query/h2/opt/GridH2Row.java      |    48 -
 .../query/h2/opt/GridH2RowDescriptor.java       |   110 -
 .../query/h2/opt/GridH2SpatialIndex.java        |   326 -
 .../processors/query/h2/opt/GridH2Table.java    |   896 --
 .../query/h2/opt/GridH2TreeIndex.java           |   477 -
 .../processors/query/h2/opt/GridH2Utils.java    |   133 -
 .../query/h2/opt/GridLuceneDirectory.java       |   197 -
 .../processors/query/h2/opt/GridLuceneFile.java |   194 -
 .../query/h2/opt/GridLuceneIndex.java           |   392 -
 .../query/h2/opt/GridLuceneInputStream.java     |   228 -
 .../query/h2/opt/GridLuceneLockFactory.java     |    72 -
 .../query/h2/opt/GridLuceneOutputStream.java    |   238 -
 .../query/h2/opt/GridSearchRowPointer.java      |    28 -
 .../kernal/processors/query/h2/package.html     |    24 -
 .../GridCacheAbstractFieldsQuerySelfTest.java   |  1313 ++
 .../cache/GridCacheAbstractQuerySelfTest.java   |  2094 +++
 .../cache/GridCacheCrossCacheQuerySelfTest.java |   441 +
 .../GridCacheCrossCacheQuerySelfTestNewApi.java |   411 +
 .../cache/GridCacheOffHeapAndSwapSelfTest.java  |   572 +
 ...idCacheQueryEvictsMultiThreadedSelfTest.java |    28 +
 .../cache/GridCacheQueryLoadSelfTest.java       |   379 +
 .../cache/GridCacheQueryMetricsSelfTest.java    |   162 +
 .../GridCacheQueryMultiThreadedSelfTest.java    |   869 ++
 ...QueryOffheapEvictsMultiThreadedSelfTest.java |    28 +
 ...dCacheQueryOffheapMultiThreadedSelfTest.java |    28 +
 .../cache/GridCacheQueryTestValue.java          |   172 +
 ...idCacheReduceQueryMultithreadedSelfTest.java |   158 +
 .../GridCacheSqlQueryMultiThreadedSelfTest.java |   142 +
 .../processors/cache/GridCacheSwapSelfTest.java |   720 +
 .../cache/GridIndexingWithNoopSwapSelfTest.java |   118 +
 .../GridCacheAtomicFieldsQuerySelfTest.java     |    66 +
 ...cheAtomicNearEnabledFieldsQuerySelfTest.java |    32 +
 ...GridCacheAtomicNearEnabledQuerySelfTest.java |    38 +
 .../near/GridCacheAtomicQuerySelfTest.java      |    38 +
 ...artitionedFieldsQueryP2PEnabledSelfTest.java |    34 +
 ...GridCachePartitionedFieldsQuerySelfTest.java |   111 +
 ...CachePartitionedQueryP2PEnabledSelfTest.java |    34 +
 .../near/GridCachePartitionedQuerySelfTest.java |   479 +
 .../near/GridCacheQueryNodeRestartSelfTest.java |   225 +
 ...eReplicatedFieldsQueryP2PEnableSelfTest.java |    34 +
 .../GridCacheReplicatedFieldsQuerySelfTest.java |   157 +
 ...dCacheReplicatedQueryP2PEnabledSelfTest.java |    34 +
 .../GridCacheReplicatedQuerySelfTest.java       |   683 +
 .../GridCacheLocalAtomicQuerySelfTest.java      |    32 +
 .../GridCacheLocalFieldsQuerySelfTest.java      |    38 +
 .../local/GridCacheLocalQuerySelfTest.java      |   107 +
 .../query/h2/GridH2IndexRebuildTest.java        |   249 +
 .../query/h2/GridH2IndexingInMemSelfTest.java   |    25 +
 .../query/h2/GridH2IndexingOffheapSelfTest.java |    44 +
 .../h2/GridIndexingSpiAbstractSelfTest.java     |   559 +
 .../query/h2/opt/GridH2TableSelfTest.java       |   621 +
 .../query/h2/sql/GridQueryParsingTest.java      |   298 +
 .../loadtests/h2indexing/GridTestEntity.java    |    68 +
 .../loadtests/h2indexing/GridTreeBenchmark.java |   276 +
 .../tcp/GridOrderedMessageCancelSelfTest.java   |    66 +-
 .../IgniteCacheQuerySelfTestSuite.java          |   106 +
 .../IgniteH2IndexingSpiTestSuite.java           |    56 +
 .../GridCacheAbstractFieldsQuerySelfTest.java   |  1305 --
 .../cache/GridCacheAbstractQuerySelfTest.java   |  2097 ---
 .../cache/GridCacheCrossCacheQuerySelfTest.java |   352 -
 .../cache/GridCacheOffHeapAndSwapSelfTest.java  |   571 -
 ...idCacheQueryEvictsMultiThreadedSelfTest.java |    28 -
 .../cache/GridCacheQueryLoadSelfTest.java       |   456 -
 .../cache/GridCacheQueryMetricsSelfTest.java    |   161 -
 .../GridCacheQueryMultiThreadedSelfTest.java    |   859 --
 ...QueryOffheapEvictsMultiThreadedSelfTest.java |    28 -
 ...dCacheQueryOffheapMultiThreadedSelfTest.java |    28 -
 .../cache/GridCacheQueryTestValue.java          |   172 -
 .../GridCacheQueryUserResourceSelfTest.java     |   180 -
 ...idCacheReduceQueryMultithreadedSelfTest.java |   158 -
 .../GridCacheSqlQueryMultiThreadedSelfTest.java |   140 -
 .../processors/cache/GridCacheSwapSelfTest.java |   722 -
 .../cache/GridIndexingWithNoopSwapSelfTest.java |   117 -
 .../GridCacheAtomicFieldsQuerySelfTest.java     |    65 -
 ...cheAtomicNearEnabledFieldsQuerySelfTest.java |    32 -
 ...GridCacheAtomicNearEnabledQuerySelfTest.java |    38 -
 .../near/GridCacheAtomicQuerySelfTest.java      |    38 -
 ...rtitionedFieldsQueryP2PDisabledSelfTest.java |    34 -
 ...GridCachePartitionedFieldsQuerySelfTest.java |   109 -
 ...idCachePartitionedHitsAndMissesSelfTest.java |   171 -
 ...achePartitionedQueryP2PDisabledSelfTest.java |    34 -
 .../near/GridCachePartitionedQuerySelfTest.java |   479 -
 .../near/GridCacheQueryNodeRestartSelfTest.java |   224 -
 ...eplicatedFieldsQueryP2PDisabledSelfTest.java |    34 -
 .../GridCacheReplicatedFieldsQuerySelfTest.java |   158 -
 ...CacheReplicatedQueryP2PDisabledSelfTest.java |    34 -
 .../GridCacheReplicatedQuerySelfTest.java       |   683 -
 .../GridCacheLocalAtomicQuerySelfTest.java      |    32 -
 .../GridCacheLocalFieldsQuerySelfTest.java      |    38 -
 .../local/GridCacheLocalQuerySelfTest.java      |   107 -
 .../query/h2/GridH2IndexRebuildTest.java        |   249 -
 .../query/h2/GridH2IndexingGeoSelfTest.java     |   248 -
 .../query/h2/GridH2IndexingInMemSelfTest.java   |    25 -
 .../query/h2/GridH2IndexingOffheapSelfTest.java |    44 -
 .../h2/GridIndexingSpiAbstractSelfTest.java     |   561 -
 .../query/h2/opt/GridH2TableSelfTest.java       |   621 -
 .../loadtests/h2indexing/GridTestEntity.java    |    68 -
 .../loadtests/h2indexing/GridTreeBenchmark.java |   276 -
 .../testsuites/GridCacheQuerySelfTestSuite.java |   102 -
 .../bamboo/GridH2IndexingSpiTestSuite.java      |    61 -
 modules/jcl/pom.xml                             |     2 +-
 modules/jcl/readme.txt                          |    18 +-
 .../ignite/logger/jcl/IgniteJclLogger.java      |   167 +
 .../org/apache/ignite/logger/jcl/package.html   |    24 +
 .../gridgain/grid/logger/jcl/GridJclLogger.java |   171 -
 .../org/gridgain/grid/logger/jcl/package.html   |    23 -
 .../ignite/logger/jcl/IgniteJclLoggerTest.java  |    48 +
 .../org/apache/ignite/logger/jcl/package.html   |    24 +
 .../ignite/testsuites/IgniteJclTestSuite.java   |    38 +
 .../grid/logger/jcl/GridJclLoggerTest.java      |    48 -
 .../org/gridgain/grid/logger/jcl/package.html   |    23 -
 .../testsuites/bamboo/GridJclTestSuite.java     |    38 -
 .../jdk8-backport/licenses/sun-bcl-license.txt  |    50 -
 modules/jdk8-backport/pom.xml                   |    36 -
 .../org/jdk8/backport/ConcurrentHashMap8.java   |  3825 -----
 .../jdk8/backport/ConcurrentLinkedDeque8.java   |  1983 ---
 .../jdk8/backport/ConcurrentLinkedHashMap.java  |  2170 ---
 .../main/java/org/jdk8/backport/LongAdder.java  |   235 -
 .../main/java/org/jdk8/backport/Striped64.java  |   370 -
 .../org/jdk8/backport/ThreadLocalRandom8.java   |   231 -
 .../META-INF/licenses/gnu-gplv2ce-license.txt   |   349 -
 modules/jta/pom.xml                             |     8 +-
 modules/jta/readme.txt                          |    18 +-
 .../apache/ignite/cache/jta/CacheTmLookup.java  |    50 +
 .../cache/jta/jndi/CacheJndiTmLookup.java       |    74 +
 .../apache/ignite/cache/jta/jndi/package.html   |    24 +
 .../org/apache/ignite/cache/jta/package.html    |    24 +
 .../jta/reflect/CacheReflectionTmLookup.java    |   115 +
 .../ignite/cache/jta/reflect/package.html       |    24 +
 .../processors/cache/jta/CacheJtaManager.java   |   117 +
 .../cache/jta/GridCacheXAResource.java          |   248 +
 .../grid/cache/jta/GridCacheTmLookup.java       |    53 -
 .../cache/jta/jndi/GridCacheJndiTmLookup.java   |    74 -
 .../gridgain/grid/cache/jta/jndi/package.html   |    24 -
 .../org/gridgain/grid/cache/jta/package.html    |    24 -
 .../reflect/GridCacheReflectionTmLookup.java    |   115 -
 .../grid/cache/jta/reflect/package.html         |    24 -
 .../cache/jta/GridCacheJtaManager.java          |   113 -
 .../cache/jta/GridCacheXAResource.java          |   248 -
 ...CacheJtaConfigurationValidationSelfTest.java |    74 +
 .../processors/cache/GridCacheJtaSelfTest.java  |   188 +
 .../cache/GridCacheReplicatedJtaSelfTest.java   |    32 +
 .../GridTmLookupLifecycleAwareSelfTest.java     |   102 +
 .../ignite/testsuites/IgniteJtaTestSuite.java   |    41 +
 ...CacheJtaConfigurationValidationSelfTest.java |    74 -
 .../processors/cache/GridCacheJtaSelfTest.java  |   186 -
 .../cache/GridCacheReplicatedJtaSelfTest.java   |    32 -
 .../GridTmLookupLifecycleAwareSelfTest.java     |   103 -
 .../testsuites/bamboo/GridJtaTestSuite.java     |    41 -
 modules/log4j/pom.xml                           |     2 +-
 modules/log4j/readme.txt                        |    18 +-
 .../IgniteLog4jDailyRollingFileAppender.java    |    77 -
 ...IgniteLog4jExternallyRolledFileAppender.java |    63 -
 .../logger/log4j/IgniteLog4jFileAppender.java   |   107 -
 .../logger/log4j/IgniteLog4jFileAware.java      |    32 -
 .../ignite/logger/log4j/IgniteLog4jLogger.java  |   524 -
 .../logger/log4j/IgniteLog4jNodeIdFilePath.java |    64 -
 .../log4j/IgniteLog4jRollingFileAppender.java   |    90 -
 .../log4j/Log4JDailyRollingFileAppender.java    |    77 +
 .../Log4JExternallyRolledFileAppender.java      |    63 +
 .../ignite/logger/log4j/Log4JFileAppender.java  |   107 +
 .../apache/ignite/logger/log4j/Log4JLogger.java |   518 +
 .../ignite/logger/log4j/Log4jFileAware.java     |    32 +
 .../logger/log4j/Log4jNodeIdFilePath.java       |    64 +
 .../logger/log4j/Log4jRollingFileAppender.java  |    90 +
 .../org/apache/ignite/logger/log4j/package.html |     2 +-
 .../log4j/GridLog4jCorrectFileNameTest.java     |   136 +
 .../logger/log4j/GridLog4jInitializedTest.java  |    55 +
 .../logger/log4j/GridLog4jLoggingFileTest.java  |    59 +
 .../logger/log4j/GridLog4jLoggingPathTest.java  |    52 +
 .../logger/log4j/GridLog4jLoggingUrlTest.java   |    59 +
 .../log4j/GridLog4jNotInitializedTest.java      |    46 +
 .../org/apache/ignite/logger/log4j/package.html |    24 +
 .../ignite/testsuites/IgniteLog4jTestSuite.java |    40 +
 .../log4j/GridLog4jCorrectFileNameTest.java     |   137 -
 .../logger/log4j/GridLog4jInitializedTest.java  |    56 -
 .../logger/log4j/GridLog4jLoggingFileTest.java  |    59 -
 .../logger/log4j/GridLog4jLoggingPathTest.java  |    53 -
 .../logger/log4j/GridLog4jLoggingUrlTest.java   |    59 -
 .../log4j/GridLog4jNotInitializedTest.java      |    47 -
 .../org/gridgain/grid/logger/log4j/package.html |    23 -
 .../testsuites/bamboo/GridLog4jTestSuite.java   |    40 -
 modules/rest-http/pom.xml                       |     2 +-
 modules/rest-http/readme.txt                    |    18 +-
 .../http/jetty/GridJettyJsonConfig.java         |    50 +
 .../http/jetty/GridJettyRestHandler.java        |   623 +
 .../http/jetty/GridJettyRestProtocol.java       |   409 +
 .../rest/protocols/http/jetty/favicon.ico       |   Bin 0 -> 1406 bytes
 .../rest/protocols/http/jetty/package.html      |    24 +
 .../rest/protocols/http/jetty/rest.html         |    96 +
 .../http/jetty/GridJettyJsonConfig.java         |    50 -
 .../http/jetty/GridJettyRestHandler.java        |   596 -
 .../http/jetty/GridJettyRestProtocol.java       |   410 -
 .../rest/protocols/http/jetty/favicon.ico       |   Bin 1406 -> 0 bytes
 .../rest/protocols/http/jetty/package.html      |    23 -
 .../rest/protocols/http/jetty/rest.html         |    96 -
 modules/scalar/pom.xml                          |    39 +-
 modules/scalar/readme.txt                       |    18 +-
 .../ignite/scalar/ScalarConversions.scala       |  1225 ++
 .../org/apache/ignite/scalar/lang/Packet.scala  |    23 +
 .../ignite/scalar/lang/ScalarAbsClosure.scala   |    37 +
 .../scalar/lang/ScalarAbsClosureFunction.scala  |    32 +
 .../ignite/scalar/lang/ScalarAbsClosureX.scala  |    36 +
 .../scalar/lang/ScalarAbsClosureXFunction.scala |    34 +
 .../ignite/scalar/lang/ScalarAbsPredicate.scala |    34 +
 .../lang/ScalarAbsPredicateFunction.scala       |    34 +
 .../scalar/lang/ScalarAbsPredicateX.scala       |    36 +
 .../lang/ScalarAbsPredicateXFunction.scala      |    34 +
 .../ignite/scalar/lang/ScalarClosure.scala      |    34 +
 .../ignite/scalar/lang/ScalarClosure2.scala     |    34 +
 .../scalar/lang/ScalarClosure2Function.scala    |    34 +
 .../ignite/scalar/lang/ScalarClosure2X.scala    |    36 +
 .../scalar/lang/ScalarClosure2XFunction.scala   |    34 +
 .../ignite/scalar/lang/ScalarClosure3.scala     |    34 +
 .../scalar/lang/ScalarClosure3Function.scala    |    34 +
 .../ignite/scalar/lang/ScalarClosure3X.scala    |    36 +
 .../scalar/lang/ScalarClosure3XFunction.scala   |    34 +
 .../scalar/lang/ScalarClosureFunction.scala     |    34 +
 .../ignite/scalar/lang/ScalarClosureX.scala     |    36 +
 .../scalar/lang/ScalarClosureXFunction.scala    |    34 +
 .../ignite/scalar/lang/ScalarInClosure.scala    |    34 +
 .../ignite/scalar/lang/ScalarInClosure2.scala   |    34 +
 .../scalar/lang/ScalarInClosure2Function.scala  |    34 +
 .../ignite/scalar/lang/ScalarInClosure2X.scala  |    36 +
 .../scalar/lang/ScalarInClosure2XFunction.scala |    34 +
 .../ignite/scalar/lang/ScalarInClosure3.scala   |    34 +
 .../scalar/lang/ScalarInClosure3Function.scala  |    34 +
 .../ignite/scalar/lang/ScalarInClosure3X.scala  |    36 +
 .../scalar/lang/ScalarInClosure3XFunction.scala |    34 +
 .../scalar/lang/ScalarInClosureFunction.scala   |    34 +
 .../ignite/scalar/lang/ScalarInClosureX.scala   |    36 +
 .../scalar/lang/ScalarInClosureXFunction.scala  |    34 +
 .../apache/ignite/scalar/lang/ScalarJob.scala   |    32 +
 .../ignite/scalar/lang/ScalarOutClosure.scala   |    47 +
 .../scalar/lang/ScalarOutClosureFunction.scala  |    35 +
 .../ignite/scalar/lang/ScalarOutClosureX.scala  |    36 +
 .../scalar/lang/ScalarOutClosureXFunction.scala |    34 +
 .../ignite/scalar/lang/ScalarPredicate.scala    |    32 +
 .../ignite/scalar/lang/ScalarPredicate2.scala   |    32 +
 .../scalar/lang/ScalarPredicate2Function.scala  |    34 +
 .../ignite/scalar/lang/ScalarPredicate2X.scala  |    36 +
 .../scalar/lang/ScalarPredicate2XFunction.scala |    34 +
 .../ignite/scalar/lang/ScalarPredicate3.scala   |    32 +
 .../scalar/lang/ScalarPredicate3Function.scala  |    34 +
 .../ignite/scalar/lang/ScalarPredicate3X.scala  |    36 +
 .../scalar/lang/ScalarPredicate3XFunction.scala |    34 +
 .../scalar/lang/ScalarPredicateFunction.scala   |    34 +
 .../ignite/scalar/lang/ScalarPredicateX.scala   |    36 +
 .../scalar/lang/ScalarPredicateXFunction.scala  |    34 +
 .../ignite/scalar/lang/ScalarReducer.scala      |    47 +
 .../ignite/scalar/lang/ScalarReducer2.scala     |    50 +
 .../scalar/lang/ScalarReducer2Function.scala    |    36 +
 .../ignite/scalar/lang/ScalarReducer3.scala     |    54 +
 .../scalar/lang/ScalarReducer3Function.scala    |    37 +
 .../scalar/lang/ScalarReducerFunction.scala     |    36 +
 .../org/apache/ignite/scalar/pimps/Packet.scala |    23 +
 .../apache/ignite/scalar/pimps/PimpedType.scala |    32 +
 .../ignite/scalar/pimps/ScalarCachePimp.scala   |   693 +
 .../ignite/scalar/pimps/ScalarGridPimp.scala    |    92 +
 .../scalar/pimps/ScalarProjectionPimp.scala     |   657 +
 .../scalar/pimps/ScalarTaskThreadContext.scala  |    45 +
 .../scala/org/apache/ignite/scalar/scalar.scala |   454 +
 .../org/gridgain/scalar/ScalarConversions.scala |  1235 --
 .../scala/org/gridgain/scalar/lang/Packet.scala |    23 -
 .../gridgain/scalar/lang/ScalarAbsClosure.scala |    37 -
 .../scalar/lang/ScalarAbsClosureFunction.scala  |    32 -
 .../scalar/lang/ScalarAbsClosureX.scala         |    37 -
 .../scalar/lang/ScalarAbsClosureXFunction.scala |    34 -
 .../scalar/lang/ScalarAbsPredicate.scala        |    34 -
 .../lang/ScalarAbsPredicateFunction.scala       |    34 -
 .../scalar/lang/ScalarAbsPredicateX.scala       |    37 -
 .../lang/ScalarAbsPredicateXFunction.scala      |    34 -
 .../gridgain/scalar/lang/ScalarClosure.scala    |    34 -
 .../gridgain/scalar/lang/ScalarClosure2.scala   |    34 -
 .../scalar/lang/ScalarClosure2Function.scala    |    34 -
 .../gridgain/scalar/lang/ScalarClosure2X.scala  |    37 -
 .../scalar/lang/ScalarClosure2XFunction.scala   |    34 -
 .../gridgain/scalar/lang/ScalarClosure3.scala   |    34 -
 .../scalar/lang/ScalarClosure3Function.scala    |    34 -
 .../gridgain/scalar/lang/ScalarClosure3X.scala  |    37 -
 .../scalar/lang/ScalarClosure3XFunction.scala   |    34 -
 .../scalar/lang/ScalarClosureFunction.scala     |    34 -
 .../gridgain/scalar/lang/ScalarClosureX.scala   |    37 -
 .../scalar/lang/ScalarClosureXFunction.scala    |    34 -
 .../gridgain/scalar/lang/ScalarInClosure.scala  |    34 -
 .../gridgain/scalar/lang/ScalarInClosure2.scala |    34 -
 .../scalar/lang/ScalarInClosure2Function.scala  |    34 -
 .../scalar/lang/ScalarInClosure2X.scala         |    37 -
 .../scalar/lang/ScalarInClosure2XFunction.scala |    34 -
 .../gridgain/scalar/lang/ScalarInClosure3.scala |    34 -
 .../scalar/lang/ScalarInClosure3Function.scala  |    34 -
 .../scalar/lang/ScalarInClosure3X.scala         |    37 -
 .../scalar/lang/ScalarInClosure3XFunction.scala |    34 -
 .../scalar/lang/ScalarInClosureFunction.scala   |    34 -
 .../gridgain/scalar/lang/ScalarInClosureX.scala |    37 -
 .../scalar/lang/ScalarInClosureXFunction.scala  |    34 -
 .../org/gridgain/scalar/lang/ScalarJob.scala    |    33 -
 .../gridgain/scalar/lang/ScalarOutClosure.scala |    46 -
 .../scalar/lang/ScalarOutClosureFunction.scala  |    33 -
 .../scalar/lang/ScalarOutClosureX.scala         |    37 -
 .../scalar/lang/ScalarOutClosureXFunction.scala |    34 -
 .../gridgain/scalar/lang/ScalarPredicate.scala  |    32 -
 .../gridgain/scalar/lang/ScalarPredicate2.scala |    32 -
 .../scalar/lang/ScalarPredicate2Function.scala  |    34 -
 .../scalar/lang/ScalarPredicate2X.scala         |    37 -
 .../scalar/lang/ScalarPredicate2XFunction.scala |    34 -
 .../gridgain/scalar/lang/ScalarPredicate3.scala |    32 -
 .../scalar/lang/ScalarPredicate3Function.scala  |    34 -
 .../scalar/lang/ScalarPredicate3X.scala         |    37 -
 .../scalar/lang/ScalarPredicate3XFunction.scala |    34 -
 .../scalar/lang/ScalarPredicateFunction.scala   |    34 -
 .../gridgain/scalar/lang/ScalarPredicateX.scala |    37 -
 .../scalar/lang/ScalarPredicateXFunction.scala  |    34 -
 .../gridgain/scalar/lang/ScalarReducer.scala    |    47 -
 .../gridgain/scalar/lang/ScalarReducer2.scala   |    49 -
 .../scalar/lang/ScalarReducer2Function.scala    |    36 -
 .../gridgain/scalar/lang/ScalarReducer3.scala   |    53 -
 .../scalar/lang/ScalarReducer3Function.scala    |    37 -
 .../scalar/lang/ScalarReducerFunction.scala     |    36 -
 .../org/gridgain/scalar/pimps/Packet.scala      |    23 -
 .../org/gridgain/scalar/pimps/PimpedType.scala  |    32 -
 .../gridgain/scalar/pimps/ScalarCachePimp.scala |    69 -
 .../pimps/ScalarCacheProjectionPimp.scala       |  2005 ---
 .../gridgain/scalar/pimps/ScalarGridPimp.scala  |    94 -
 .../scalar/pimps/ScalarProjectionPimp.scala     |   659 -
 .../scalar/pimps/ScalarTaskThreadContext.scala  |    47 -
 .../main/scala/org/gridgain/scalar/scalar.scala |   459 -
 .../scalar/src/test/resources/spring-cache.xml  |     4 +-
 .../test/resources/spring-ping-pong-partner.xml |    48 +-
 .../tests/ScalarAffinityRoutingSpec.scala       |    66 +
 .../scalar/tests/ScalarCacheQueriesSpec.scala   |   224 +
 .../ignite/scalar/tests/ScalarCacheSpec.scala   |    78 +
 .../scalar/tests/ScalarConversionsSpec.scala    |   254 +
 .../scalar/tests/ScalarProjectionSpec.scala     |   149 +
 .../scalar/tests/ScalarReturnableSpec.scala     |    57 +
 .../apache/ignite/scalar/tests/ScalarSpec.scala |    37 +
 .../scalar/testsuites/ScalarSelfTestSuite.scala |    38 +
 .../tests/ScalarAffinityRoutingSpec.scala       |    68 -
 .../tests/ScalarCacheProjectionSpec.scala       |    39 -
 .../scalar/tests/ScalarCacheQueriesSpec.scala   |   600 -
 .../gridgain/scalar/tests/ScalarCacheSpec.scala |    79 -
 .../scalar/tests/ScalarConversionsSpec.scala    |   254 -
 .../scalar/tests/ScalarProjectionSpec.scala     |   150 -
 .../scalar/tests/ScalarReturnableSpec.scala     |    58 -
 .../org/gridgain/scalar/tests/ScalarSpec.scala  |    37 -
 .../scalar/testsuites/ScalarSelfTestSuite.scala |    38 -
 modules/schedule/pom.xml                        |     2 +-
 modules/schedule/readme.txt                     |    18 +-
 .../schedule/IgniteScheduleProcessor.java       |   130 +
 .../processors/schedule/ScheduleFutureImpl.java |  1034 ++
 .../schedule/GridScheduleProcessor.java         |   130 -
 .../processors/schedule/ScheduleFutureImpl.java |  1007 --
 .../schedule/GridScheduleSelfTest.java          |   402 +
 .../testsuites/IgniteSchedulerTestSuite.java    |    38 +
 .../grid/kernal/GridScheduleSelfTest.java       |   402 -
 .../bamboo/GridSchedulerTestSuite.java          |    38 -
 modules/schema-load/pom.xml                     |   107 +
 .../main/java/media/data_connection_48x48.png   |   Bin 0 -> 4443 bytes
 .../src/main/java/media/error_48x48.png         |   Bin 0 -> 4349 bytes
 .../src/main/java/media/ignite_128x128.png      |   Bin 0 -> 4917 bytes
 .../src/main/java/media/ignite_16x16.png        |   Bin 0 -> 608 bytes
 .../src/main/java/media/ignite_24x24.png        |   Bin 0 -> 930 bytes
 .../src/main/java/media/ignite_32x32.png        |   Bin 0 -> 1203 bytes
 .../src/main/java/media/ignite_48x48.png        |   Bin 0 -> 1868 bytes
 .../src/main/java/media/ignite_64x64.png        |   Bin 0 -> 2453 bytes
 .../src/main/java/media/information_48x48.png   |   Bin 0 -> 4102 bytes
 .../src/main/java/media/question_48x48.png      |   Bin 0 -> 3857 bytes
 .../src/main/java/media/sign_warning_48x48.png  |   Bin 0 -> 2988 bytes
 .../schema-load/src/main/java/media/style.css   |   117 +
 .../src/main/java/media/text_tree_48x48.png     |   Bin 0 -> 2567 bytes
 .../ignite/schema/generator/PojoGenerator.java  |   415 +
 .../ignite/schema/generator/XmlGenerator.java   |   343 +
 .../ignite/schema/model/PojoDescriptor.java     |   510 +
 .../apache/ignite/schema/model/PojoField.java   |   425 +
 .../schema/parser/DatabaseMetadataParser.java   |   105 +
 .../apache/ignite/schema/parser/DbColumn.java   |    76 +
 .../apache/ignite/schema/parser/DbTable.java    |   105 +
 .../parser/dialect/DB2MetadataDialect.java      |    30 +
 .../parser/dialect/DatabaseMetadataDialect.java |    78 +
 .../parser/dialect/JdbcMetadataDialect.java     |   144 +
 .../parser/dialect/OracleMetadataDialect.java   |   257 +
 .../ignite/schema/ui/ConfirmCallable.java       |    81 +
 .../org/apache/ignite/schema/ui/Controls.java   |   661 +
 .../org/apache/ignite/schema/ui/GridPaneEx.java |   177 +
 .../org/apache/ignite/schema/ui/MessageBox.java |   239 +
 .../apache/ignite/schema/ui/ModalDialog.java    |    50 +
 .../apache/ignite/schema/ui/SchemaLoadApp.java  |  1613 ++
 .../ignite/schema/ui/TextColumnValidator.java   |    32 +
 .../schema/load/AbstractSchemaLoaderTest.java   |   134 +
 .../load/generator/PojoGeneratorTest.java       |    70 +
 .../schema/load/generator/XmlGeneratorTest.java |    50 +
 .../apache/ignite/schema/load/model/Ignite.xml  |   323 +
 .../apache/ignite/schema/load/model/Objects.txt |   502 +
 .../ignite/schema/load/model/ObjectsKey.txt     |    96 +
 .../ignite/schema/load/model/Primitives.txt     |   506 +
 .../ignite/schema/load/model/PrimitivesKey.txt  |    96 +
 .../load/parser/DbMetadataParserTest.java       |   118 +
 .../testsuites/IgniteSchemaLoadTestSuite.java   |    41 +
 modules/slf4j/pom.xml                           |     2 +-
 modules/slf4j/readme.txt                        |    18 +-
 .../ignite/logger/slf4j/GridSlf4jLogger.java    |   138 +
 .../org/apache/ignite/logger/slf4j/package.html |    24 +
 .../grid/logger/slf4j/GridSlf4jLogger.java      |   142 -
 .../org/gridgain/grid/logger/slf4j/package.html |    23 -
 modules/spring/pom.xml                          |     8 +-
 modules/spring/readme.txt                       |    18 +-
 .../java/org/apache/ignite/IgniteSpring.java    |   117 +
 .../org/apache/ignite/IgniteSpringBean.java     |   375 +
 .../apache/ignite/cache/spring/SpringCache.java |   188 +
 .../ignite/cache/spring/SpringCacheManager.java |   242 +
 .../cache/spring/SpringDynamicCacheManager.java |   319 +
 .../org/apache/ignite/cache/spring/package.html |    24 +
 .../GridResourceSpringBeanInjector.java         |   100 +
 .../resource/GridSpringResourceContextImpl.java |    67 +
 .../spring/IgniteSpringProcessorImpl.java       |   268 +
 .../java/org/gridgain/grid/GridGainSpring.java  |   118 -
 .../java/org/gridgain/grid/GridSpringBean.java  |   344 -
 .../cache/spring/GridSpringCacheManager.java    |   391 -
 .../org/gridgain/grid/cache/spring/package.html |    23 -
 .../GridResourceSpringBeanInjector.java         |   100 -
 .../resource/GridSpringResourceContextImpl.java |    67 -
 .../spring/GridSpringProcessorImpl.java         |   269 -
 .../ignite/internal/GridFactorySelfTest.java    |   790 +
 .../GridSpringBeanSerializationSelfTest.java    |    92 +
 .../resource/GridLoggerInjectionSelfTest.java   |   137 +
 .../resource/GridResourceProcessorSelfTest.java |   465 +
 .../resource/GridResourceTestUtils.java         |    51 +
 .../resource/GridServiceInjectionSelfTest.java  |   309 +
 .../processors/resource/TestClosure.java        |    45 +
 .../internal/processors/resource/package.html   |    24 +
 .../p2p/GridP2PUserVersionChangeSelfTest.java   |   370 +
 .../spring/GridSpringCacheManagerSelfTest.java  |   238 +
 .../ignite/spring/GridSpringCacheTestKey.java   |    59 +
 .../spring/GridSpringCacheTestKeyGenerator.java |    41 +
 .../spring/GridSpringCacheTestService.java      |   124 +
 .../GridSpringDynamicCacheManagerSelfTest.java  |   219 +
 .../GridSpringDynamicCacheTestService.java      |    62 +
 .../org/apache/ignite/spring/spring-caching.xml |    47 +
 .../ignite/spring/spring-dynamic-caching.xml    |    43 +
 .../testsuites/IgniteResourceSelfTestSuite.java |    41 +
 .../testsuites/IgniteSpringTestSuite.java       |    49 +
 .../spring/GridSpringCacheManagerSelfTest.java  |   237 -
 .../cache/spring/GridSpringCacheTestKey.java    |    59 -
 .../spring/GridSpringCacheTestKeyGenerator.java |    41 -
 .../spring/GridSpringCacheTestService.java      |   124 -
 .../grid/cache/spring/spring-caching.xml        |    47 -
 .../GridAbstractUserExternalResource.java       |   155 -
 .../resource/GridUserExternalResource1.java     |    25 -
 .../resource/GridUserExternalResource2.java     |    25 -
 .../resource/GridUserExternalResourceTask1.java |   157 -
 .../resource/GridUserExternalResourceTask2.java |   169 -
 .../grid/external/resource/package.html         |    23 -
 .../grid/kernal/GridFactorySelfTest.java        |   822 -
 .../GridSpringBeanSerializationSelfTest.java    |    92 -
 .../resource/GridAbstractUserResource.java      |   151 -
 .../resource/GridLoggerInjectionSelfTest.java   |   137 -
 .../GridResourceConcurrentUndeploySelfTest.java |   466 -
 .../GridResourceEventFilterSelfTest.java        |   186 -
 .../GridResourceFieldInjectionSelfTest.java     |   638 -
 ...dResourceFieldOverrideInjectionSelfTest.java |   202 -
 .../resource/GridResourceIocSelfTest.java       |   487 -
 ...GridResourceIsolatedClassLoaderSelfTest.java |   762 -
 .../GridResourceIsolatedTaskSelfTest.java       |   742 -
 .../GridResourceMethodInjectionSelfTest.java    |   616 -
 ...ResourceMethodOverrideInjectionSelfTest.java |   489 -
 .../resource/GridResourceProcessorSelfTest.java |   464 -
 .../GridResourceSharedUndeploySelfTest.java     |   673 -
 .../resource/GridResourceTestUtils.java         |    51 -
 .../resource/GridResourceUserExternalTest.java  |    94 -
 .../resource/GridServiceInjectionSelfTest.java  |   309 -
 .../kernal/processors/resource/TestClosure.java |    45 -
 .../kernal/processors/resource/package.html     |    24 -
 .../grid/p2p/GridP2PAbstractUserResource.java   |   184 -
 .../GridP2PContinuousLocalDeploySelfTest.java   |   319 -
 .../p2p/GridP2PUserVersionChangeSelfTest.java   |   361 -
 .../testsuites/GridResourceSelfTestSuite.java   |    52 -
 .../testsuites/bamboo/GridSpringTestSuite.java  |    50 -
 modules/ssh/pom.xml                             |     2 +-
 modules/ssh/readme.txt                          |    18 +-
 .../util/nodestart/IgniteNodeCallableImpl.java  |   344 +
 .../util/nodestart/IgniteSshProcessorImpl.java  |    28 +
 .../util/nodestart/GridNodeCallableImpl.java    |   344 -
 .../util/nodestart/GridSshProcessorImpl.java    |    28 -
 .../internal/IgniteNodeStartUtilsSelfTest.java  |    88 +
 ...gniteProjectionStartStopRestartSelfTest.java |  1032 ++
 .../IgniteStartStopRestartTestSuite.java        |    39 +
 .../grid/kernal/GridNodeStartUtilsSelfTest.java |    89 -
 .../GridProjectionStartStopRestartSelfTest.java |  1033 --
 .../kernal/GridStartStopRestartTestSuite.java   |    39 -
 modules/tools/pom.xml                           |     2 +-
 .../ant/beautifier/GridJavadocAntTask.java      |   465 +
 .../GridJavadocCharArrayLexReader.java          |    93 +
 .../tools/ant/beautifier/GridJavadocToken.java  |    70 +
 .../ant/beautifier/GridJavadocTokenType.java    |    38 +
 .../ignite/tools/ant/beautifier/package.html    |    24 +
 .../ignite/tools/javadoc/IgniteLinkTaglet.java  |   165 +
 .../optimized/OptimizedClassNamesGenerator.java |   325 +
 .../util/antgar/IgniteDeploymentGarAntTask.java |   173 +
 .../org/apache/ignite/util/antgar/package.html  |    24 +
 .../ant/beautifier/GridJavadocAntTask.java      |   465 -
 .../GridJavadocCharArrayLexReader.java          |    93 -
 .../tools/ant/beautifier/GridJavadocToken.java  |    70 -
 .../ant/beautifier/GridJavadocTokenType.java    |    38 -
 .../grid/tools/ant/beautifier/package.html      |    24 -
 .../grid/tools/javadoc/GridLinkTaglet.java      |   165 -
 .../optimized/OptimizedClassNamesGenerator.java |   325 -
 .../util/antgar/GridDeploymentGarAntTask.java   |   172 -
 .../org/gridgain/grid/util/antgar/package.html  |    23 -
 modules/urideploy/pom.xml                       |     2 +-
 modules/urideploy/readme.txt                    |    18 +-
 .../uri/GridUriDeploymentClassLoader.java       |     2 +-
 .../uri/GridUriDeploymentDiscovery.java         |     3 +-
 .../uri/GridUriDeploymentFileProcessor.java     |     7 +-
 .../GridUriDeploymentFileProcessorResult.java   |     3 +-
 .../uri/GridUriDeploymentJarVerifier.java       |     3 +-
 .../deployment/uri/GridUriDeploymentSpi.java    |  1371 --
 .../uri/GridUriDeploymentSpiMBean.java          |    53 -
 .../uri/GridUriDeploymentSpringDocument.java    |     3 +-
 .../uri/GridUriDeploymentSpringParser.java      |     3 +-
 .../uri/GridUriDeploymentUnitDescriptor.java    |     6 +-
 .../uri/GridUriDeploymentUriParser.java         |     4 +-
 .../spi/deployment/uri/UriDeploymentSpi.java    |  1368 ++
 .../deployment/uri/UriDeploymentSpiMBean.java   |    53 +
 .../ignite/spi/deployment/uri/package.html      |     3 +-
 .../uri/scanners/GridUriDeploymentScanner.java  |     4 +-
 .../file/GridUriDeploymentFileScanner.java      |     6 +-
 .../deployment/uri/scanners/file/package.html   |     2 +-
 .../ftp/GridUriDeploymentFtpClient.java         |     3 +-
 .../ftp/GridUriDeploymentFtpConfiguration.java  |     4 +-
 .../scanners/ftp/GridUriDeploymentFtpFile.java  |     3 +-
 .../ftp/GridUriDeploymentFtpScanner.java        |     3 +-
 .../deployment/uri/scanners/ftp/package.html    |     2 +-
 .../http/GridUriDeploymentHttpScanner.java      |     6 +-
 .../deployment/uri/scanners/http/package.html   |     3 +-
 .../spi/deployment/uri/scanners/package.html    |     2 +-
 .../GridTaskUriDeploymentDeadlockSelfTest.java  |   110 +
 .../ignite/p2p/GridP2PDisabledSelfTest.java     |   211 +
 .../uri/GridUriDeploymentAbstractSelfTest.java  |     6 +-
 ...loymentClassLoaderMultiThreadedSelfTest.java |    10 +-
 .../GridUriDeploymentClassLoaderSelfTest.java   |    12 +-
 ...riDeploymentClassloaderRegisterSelfTest.java |    18 +-
 .../uri/GridUriDeploymentConfigSelfTest.java    |    13 +-
 .../GridUriDeploymentFileProcessorSelfTest.java |    27 +-
 .../uri/GridUriDeploymentMd5CheckSelfTest.java  |    11 +-
 ...loymentMultiScannersErrorThrottlingTest.java |     6 +-
 .../GridUriDeploymentMultiScannersSelfTest.java |    11 +-
 .../uri/GridUriDeploymentSimpleSelfTest.java    |    27 +-
 .../META-INF/bad-signed-deployfile-gridgain.xml |    39 -
 .../META-INF/bad-signed-deployfile-ignite.xml   |    39 +
 .../spi/deployment/uri/META-INF/bad_classes.xml |     4 +-
 .../META-INF/deploy-with-resources-gridgain.xml |    37 -
 .../META-INF/deploy-with-resources-ignite.xml   |    37 +
 .../uri/META-INF/deploydepend-gridgain.xml      |    37 -
 .../uri/META-INF/deploydepend-ignite.xml        |    37 +
 .../uri/META-INF/deploydir-gridgain.xml         |    38 -
 .../uri/META-INF/deploydir-ignite.xml           |    38 +
 .../uri/META-INF/deployfile-gridgain.xml        |    38 -
 .../uri/META-INF/deployfile-ignite.xml          |    38 +
 .../deployment/uri/META-INF/gridgain.brokenxml  |    18 -
 .../spi/deployment/uri/META-INF/gridgain.empty  |     0
 .../deployment/uri/META-INF/gridgain.incorrefs  |    18 -
 .../spi/deployment/uri/META-INF/gridgain.xml    |    38 -
 .../deployment/uri/META-INF/ignite.brokenxml    |    18 +
 .../spi/deployment/uri/META-INF/ignite.empty    |     0
 .../deployment/uri/META-INF/ignite.incorrefs    |    18 +
 .../spi/deployment/uri/META-INF/ignite.xml      |    38 +
 .../deployment/uri/META-INF/p2p-gridgain.xml    |    42 -
 .../spi/deployment/uri/META-INF/p2p-ignite.xml  |    42 +
 .../well-signed-deployfile-gridgain.xml         |    38 -
 .../META-INF/well-signed-deployfile-ignite.xml  |    38 +
 .../ignite/spi/deployment/uri/package.html      |     3 +-
 .../file/GridFileDeploymentSelfTest.java        |    11 +-
 .../GridFileDeploymentUndeploySelfTest.java     |    17 +-
 .../deployment/uri/scanners/file/package.html   |     2 +-
 .../uri/scanners/ftp/GridFtpDeploymentTest.java |     7 +-
 .../deployment/uri/scanners/ftp/package.html    |     3 +-
 .../http/GridHttpDeploymentSelfTest.java        |    12 +-
 .../deployment/uri/scanners/http/package.html   |     3 +-
 .../testsuites/IgniteToolsSelfTestSuite.java    |    38 +
 .../IgniteUriDeploymentTestSuite.java           |    58 +
 .../apache/ignite/tools/GridToolsSelfTest.java  |   384 +
 .../ignite/tools/gartask/META-INF/ignite.xml    |    38 +
 .../java/org/apache/ignite/tools/package.html   |    24 +
 .../GridTaskUriDeploymentDeadlockSelfTest.java  |   110 -
 .../grid/p2p/GridP2PDisabledSelfTest.java       |   213 -
 .../gridgain/grid/tools/GridToolsSelfTest.java  |   384 -
 .../grid/tools/gartask/META-INF/gridgain.xml    |    38 -
 .../java/org/gridgain/grid/tools/package.html   |    24 -
 .../testsuites/GridToolsSelfTestSuite.java      |    38 -
 .../bamboo/GridUriDeploymentTestSuite.java      |    59 -
 modules/visor-console/pom.xml                   |    27 +-
 .../scala/org/apache/ignite/visor/Packet.scala  |    38 +
 .../ignite/visor/commands/VisorConsole.scala    |   341 +
 .../visor/commands/VisorConsoleCommand.scala    |    77 +
 .../ignite/visor/commands/VisorTextTable.scala  |   539 +
 .../ignite/visor/commands/ack/Packet.scala      |    55 +
 .../visor/commands/ack/VisorAckCommand.scala    |   161 +
 .../ignite/visor/commands/alert/Packet.scala    |   108 +
 .../commands/alert/VisorAlertCommand.scala      |   769 +
 .../ignite/visor/commands/cache/Packet.scala    |   127 +
 .../commands/cache/VisorCacheClearCommand.scala |   146 +
 .../commands/cache/VisorCacheCommand.scala      |   861 ++
 .../cache/VisorCacheCompactCommand.scala        |   151 +
 .../commands/cache/VisorCacheScanCommand.scala  |   237 +
 .../commands/cache/VisorCacheSwapCommand.scala  |   151 +
 .../ignite/visor/commands/config/Packet.scala   |    55 +
 .../config/VisorConfigurationCommand.scala      |   481 +
 .../ignite/visor/commands/deploy/Packet.scala   |    76 +
 .../commands/deploy/VisorDeployCommand.scala    |   611 +
 .../ignite/visor/commands/disco/Packet.scala    |    72 +
 .../commands/disco/VisorDiscoveryCommand.scala  |   303 +
 .../ignite/visor/commands/events/Packet.scala   |    97 +
 .../commands/events/VisorEventsCommand.scala    |   521 +
 .../ignite/visor/commands/gc/Packet.scala       |    61 +
 .../visor/commands/gc/VisorGcCommand.scala      |   244 +
 .../ignite/visor/commands/ggcube_128x128.png    |   Bin 0 -> 11444 bytes
 .../ignite/visor/commands/ggcube_48x48.png      |   Bin 0 -> 3365 bytes
 .../ignite/visor/commands/kill/Packet.scala     |    78 +
 .../visor/commands/kill/VisorKillCommand.scala  |   356 +
 .../ignite/visor/commands/node/Packet.scala     |    60 +
 .../visor/commands/node/VisorNodeCommand.scala  |   340 +
 .../ignite/visor/commands/ping/Packet.scala     |    50 +
 .../visor/commands/ping/VisorPingCommand.scala  |   228 +
 .../ignite/visor/commands/start/Packet.scala    |    90 +
 .../commands/start/VisorStartCommand.scala      |   428 +
 .../ignite/visor/commands/tasks/Packet.scala    |   116 +
 .../commands/tasks/VisorTasksCommand.scala      |  1484 ++
 .../ignite/visor/commands/top/Packet.scala      |    87 +
 .../commands/top/VisorTopologyCommand.scala     |   428 +
 .../ignite/visor/commands/vvm/Packet.scala      |    61 +
 .../visor/commands/vvm/VisorVvmCommand.scala    |   306 +
 .../scala/org/apache/ignite/visor/visor.scala   |  2667 ++++
 .../main/scala/org/gridgain/visor/Packet.scala  |    38 -
 .../gridgain/visor/commands/VisorConsole.scala  |   343 -
 .../visor/commands/VisorConsoleCommand.scala    |    78 -
 .../visor/commands/VisorTextTable.scala         |   540 -
 .../gridgain/visor/commands/ack/Packet.scala    |    55 -
 .../visor/commands/ack/VisorAckCommand.scala    |   162 -
 .../gridgain/visor/commands/alert/Packet.scala  |   108 -
 .../commands/alert/VisorAlertCommand.scala      |   839 -
 .../gridgain/visor/commands/cache/Packet.scala  |   127 -
 .../commands/cache/VisorCacheClearCommand.scala |   150 -
 .../commands/cache/VisorCacheCommand.scala      |   894 --
 .../cache/VisorCacheCompactCommand.scala        |   150 -
 .../commands/cache/VisorCacheScanCommand.scala  |   236 -
 .../commands/cache/VisorCacheSwapCommand.scala  |   150 -
 .../gridgain/visor/commands/config/Packet.scala |    55 -
 .../config/VisorConfigurationCommand.scala      |   500 -
 .../gridgain/visor/commands/deploy/Packet.scala |    76 -
 .../commands/deploy/VisorDeployCommand.scala    |   611 -
 .../gridgain/visor/commands/disco/Packet.scala  |    72 -
 .../commands/disco/VisorDiscoveryCommand.scala  |   305 -
 .../gridgain/visor/commands/events/Packet.scala |    97 -
 .../commands/events/VisorEventsCommand.scala    |   529 -
 .../org/gridgain/visor/commands/gc/Packet.scala |    61 -
 .../visor/commands/gc/VisorGcCommand.scala      |   244 -
 .../gridgain/visor/commands/ggcube_128x128.png  |   Bin 11444 -> 0 bytes
 .../gridgain/visor/commands/ggcube_48x48.png    |   Bin 3365 -> 0 bytes
 .../gridgain/visor/commands/kill/Packet.scala   |    78 -
 .../visor/commands/kill/VisorKillCommand.scala  |   355 -
 .../gridgain/visor/commands/node/Packet.scala   |    60 -
 .../visor/commands/node/VisorNodeCommand.scala  |   340 -
 .../gridgain/visor/commands/ping/Packet.scala   |    50 -
 .../visor/commands/ping/VisorPingCommand.scala  |   228 -
 .../gridgain/visor/commands/start/Packet.scala  |    90 -
 .../commands/start/VisorStartCommand.scala      |   429 -
 .../gridgain/visor/commands/tasks/Packet.scala  |   116 -
 .../commands/tasks/VisorTasksCommand.scala      |  1487 --
 .../gridgain/visor/commands/top/Packet.scala    |    87 -
 .../commands/top/VisorTopologyCommand.scala     |   430 -
 .../gridgain/visor/commands/vvm/Packet.scala    |    61 -
 .../visor/commands/vvm/VisorVvmCommand.scala    |   306 -
 .../main/scala/org/gridgain/visor/visor.scala   |  2678 ----
 .../ignite/visor/VisorRuntimeBaseSpec.scala     |    75 +
 .../ignite/visor/VisorTextTableSpec.scala       |    44 +
 .../visor/commands/VisorArgListSpec.scala       |    72 +
 .../commands/VisorFileNameCompleterSpec.scala   |    58 +
 .../commands/ack/VisorAckCommandSpec.scala      |    40 +
 .../commands/alert/VisorAlertCommandSpec.scala  |   153 +
 .../cache/VisorCacheClearCommandSpec.scala      |   117 +
 .../commands/cache/VisorCacheCommandSpec.scala  |   139 +
 .../cache/VisorCacheCompactCommandSpec.scala    |   103 +
 .../config/VisorConfigurationCommandSpec.scala  |    50 +
 .../cswap/VisorCacheSwapCommandSpec.scala       |    89 +
 .../deploy/VisorDeployCommandSpec.scala         |    34 +
 .../disco/VisorDiscoveryCommandSpec.scala       |    85 +
 .../events/VisorEventsCommandSpec.scala         |    62 +
 .../visor/commands/gc/VisorGcCommandSpec.scala  |    59 +
 .../commands/help/VisorHelpCommandSpec.scala    |    68 +
 .../commands/kill/VisorKillCommandSpec.scala    |    58 +
 .../commands/log/VisorLogCommandSpec.scala      |    32 +
 .../commands/mem/VisorMemoryCommandSpec.scala   |    75 +
 .../commands/node/VisorNodeCommandSpec.scala    |    42 +
 .../commands/open/VisorOpenCommandSpec.scala    |    38 +
 .../commands/ping/VisorPingCommandSpec.scala    |    38 +
 .../commands/start/VisorStartCommandSpec.scala  |   123 +
 .../commands/tasks/VisorTasksCommandSpec.scala  |   229 +
 .../commands/top/VisorTopologyCommandSpec.scala |    62 +
 .../commands/vvm/VisorVvmCommandSpec.scala      |    46 +
 .../testsuites/VisorConsoleSelfTestSuite.scala  |    95 +
 .../gridgain/visor/VisorRuntimeBaseSpec.scala   |    75 -
 .../org/gridgain/visor/VisorTextTableSpec.scala |    45 -
 .../visor/commands/VisorArgListSpec.scala       |    71 -
 .../commands/VisorFileNameCompleterSpec.scala   |    58 -
 .../commands/ack/VisorAckCommandSpec.scala      |    40 -
 .../commands/alert/VisorAlertCommandSpec.scala  |   154 -
 .../cache/VisorCacheClearCommandSpec.scala      |   113 -
 .../commands/cache/VisorCacheCommandSpec.scala  |   103 -
 .../cache/VisorCacheCompactCommandSpec.scala    |   103 -
 .../config/VisorConfigurationCommandSpec.scala  |    51 -
 .../cswap/VisorCacheSwapCommandSpec.scala       |    90 -
 .../deploy/VisorDeployCommandSpec.scala         |    34 -
 .../disco/VisorDiscoveryCommandSpec.scala       |    86 -
 .../events/VisorEventsCommandSpec.scala         |    63 -
 .../visor/commands/gc/VisorGcCommandSpec.scala  |    57 -
 .../commands/help/VisorHelpCommandSpec.scala    |    69 -
 .../commands/kill/VisorKillCommandSpec.scala    |    58 -
 .../commands/log/VisorLogCommandSpec.scala      |    33 -
 .../commands/mem/VisorMemoryCommandSpec.scala   |    76 -
 .../commands/node/VisorNodeCommandSpec.scala    |    42 -
 .../commands/open/VisorOpenCommandSpec.scala    |    41 -
 .../commands/ping/VisorPingCommandSpec.scala    |    38 -
 .../commands/start/VisorStartCommandSpec.scala  |   123 -
 .../commands/tasks/VisorTasksCommandSpec.scala  |   231 -
 .../commands/top/VisorTopologyCommandSpec.scala |    62 -
 .../commands/vvm/VisorVvmCommandSpec.scala      |    46 -
 .../testsuites/VisorConsoleSelfTestSuite.scala  |    97 -
 modules/visor-plugins/pom.xml                   |     6 +-
 .../visor/plugin/VisorExtensionPoint.java       |    75 +
 .../ignite/visor/plugin/VisorPluggableTab.java  |    63 +
 .../apache/ignite/visor/plugin/VisorPlugin.java |    45 +
 .../visor/plugin/VisorPluginComponent.java      |    30 +
 .../plugin/VisorPluginComponentsFactory.java    |    49 +
 .../visor/plugin/VisorPluginLogPanel.java       |    26 +
 .../ignite/visor/plugin/VisorPluginModel.java   |    97 +
 .../visor/plugin/VisorPluginNodesPanel.java     |    48 +
 .../visor/plugin/VisorSelectionListener.java    |    32 +
 .../visor/plugin/VisorTopologyListener.java     |    53 +
 .../org/apache/ignite/visor/plugin/package.html |    24 +
 .../visor/plugin/VisorExtensionPoint.java       |    75 -
 .../visor/plugin/VisorPluggableTab.java         |    63 -
 .../org/gridgain/visor/plugin/VisorPlugin.java  |    45 -
 .../visor/plugin/VisorPluginComponent.java      |    30 -
 .../plugin/VisorPluginComponentsFactory.java    |    49 -
 .../visor/plugin/VisorPluginLogPanel.java       |    26 -
 .../gridgain/visor/plugin/VisorPluginModel.java |    97 -
 .../visor/plugin/VisorPluginNodesPanel.java     |    48 -
 .../visor/plugin/VisorSelectionListener.java    |    32 -
 .../visor/plugin/VisorTopologyListener.java     |    53 -
 .../java/org/gridgain/visor/plugin/package.html |    23 -
 modules/web/pom.xml                             |     8 +-
 modules/web/readme.txt                          |    22 +-
 .../cache/websession/IgniteWebSession.java      |   286 +
 .../websession/IgniteWebSessionFilter.java      |   466 +
 .../websession/IgniteWebSessionListener.java    |   196 +
 .../apache/ignite/cache/websession/package.html |    24 +
 .../IgniteServletContextListenerStartup.java    |   181 +
 .../startup/servlet/IgniteServletStartup.java   |   187 +
 .../apache/ignite/startup/servlet/package.html  |    24 +
 .../grid/cache/websession/GridWebSession.java   |   286 -
 .../cache/websession/GridWebSessionFilter.java  |   451 -
 .../websession/GridWebSessionListener.java      |   187 -
 .../gridgain/grid/cache/websession/package.html |    24 -
 .../GridServletContextListenerStartup.java      |   182 -
 .../startup/servlet/GridServletStartup.java     |   188 -
 .../gridgain/grid/startup/servlet/package.html  |    23 -
 .../IgniteWebSessionSelfTestSuite.java          |    65 +
 .../internal/websession/WebSessionSelfTest.java |   327 +
 .../websession/WebSessionServerStart.java       |   130 +
 .../internal/websession/WebSessionTest.java     |    62 +
 .../websession/GridWebSessionSelfTest.java      |   327 -
 .../websession/GridWebSessionSelfTestSuite.java |    65 -
 .../websession/GridWebSessionServerStart.java   |   130 -
 .../kernal/websession/GridWebSessionTest.java   |    62 -
 modules/winservice/IgniteService.sln            |    22 +
 .../winservice/IgniteService/IgniteService.cs   |   170 +
 .../IgniteService/IgniteService.csproj          |    90 +
 modules/winservice/README.md                    |     3 +
 modules/yardstick/README.md                     |    67 +
 .../config/benchmark-atomic-win.properties      |    49 +
 .../config/benchmark-atomic.properties          |    55 +
 .../config/benchmark-compute-win.properties     |    45 +
 .../config/benchmark-compute.properties         |    51 +
 .../config/benchmark-multicast.properties       |    74 +
 .../config/benchmark-query-win.properties       |    46 +
 .../yardstick/config/benchmark-query.properties |    52 +
 .../yardstick/config/benchmark-store.properties |    93 +
 .../config/benchmark-tx-win.properties          |    46 +
 .../yardstick/config/benchmark-tx.properties    |    52 +
 .../yardstick/config/benchmark-win.properties   |    50 +
 modules/yardstick/config/benchmark.properties   |    75 +
 modules/yardstick/config/ignite-base-config.xml |   205 +
 .../config/ignite-localhost-config.xml          |    55 +
 .../config/ignite-multicast-config.xml          |    38 +
 .../yardstick/config/ignite-store-config.xml    |   182 +
 modules/yardstick/pom.xml                       |   195 +
 .../yardstick/IgniteAbstractBenchmark.java      |   130 +
 .../yardstick/IgniteBenchmarkArguments.java     |   235 +
 .../org/apache/ignite/yardstick/IgniteNode.java |   196 +
 .../cache/IgniteCacheAbstractBenchmark.java     |    44 +
 .../yardstick/cache/IgniteGetBenchmark.java     |    41 +
 .../cache/IgniteGetOffHeapBenchmark.java        |    32 +
 .../cache/IgniteGetOffHeapValuesBenchmark.java  |    32 +
 .../yardstick/cache/IgnitePutBenchmark.java     |    42 +
 .../yardstick/cache/IgnitePutGetBenchmark.java  |    47 +
 .../cache/IgnitePutGetOffHeapBenchmark.java     |    32 +
 .../IgnitePutGetOffHeapValuesBenchmark.java     |    32 +
 .../cache/IgnitePutGetTxBenchmark.java          |    52 +
 .../cache/IgnitePutGetTxOffHeapBenchmark.java   |    32 +
 .../IgnitePutGetTxOffHeapValuesBenchmark.java   |    32 +
 .../cache/IgnitePutOffHeapBenchmark.java        |    32 +
 .../cache/IgnitePutOffHeapValuesBenchmark.java  |    32 +
 .../yardstick/cache/IgnitePutTxBenchmark.java   |    43 +
 .../cache/IgnitePutTxOffHeapBenchmark.java      |    32 +
 .../IgnitePutTxOffHeapValuesBenchmark.java      |    32 +
 .../cache/IgniteSqlQueryBenchmark.java          |    92 +
 .../cache/IgniteSqlQueryJoinBenchmark.java      |   116 +
 .../IgniteSqlQueryJoinOffHeapBenchmark.java     |    32 +
 .../cache/IgniteSqlQueryOffHeapBenchmark.java   |    32 +
 .../cache/IgniteSqlQueryPutBenchmark.java       |    84 +
 .../IgniteSqlQueryPutOffHeapBenchmark.java      |    32 +
 .../yardstick/cache/model/Organization.java     |   110 +
 .../ignite/yardstick/cache/model/Person.java    |   191 +
 .../ignite/yardstick/cache/model/SampleKey.java |    88 +
 .../yardstick/cache/model/SampleValue.java      |    69 +
 .../jdbc/IgniteJdbcStoreAbstractBenchmark.java  |   129 +
 .../store/jdbc/IgniteJdbcStoreGetBenchmark.java |    47 +
 .../jdbc/IgniteJdbcStoreGetTxBenchmark.java     |    47 +
 .../store/jdbc/IgniteJdbcStorePutBenchmark.java |    47 +
 .../jdbc/IgniteJdbcStorePutGetBenchmark.java    |    52 +
 .../jdbc/IgniteJdbcStorePutGetTxBenchmark.java  |    52 +
 .../jdbc/IgniteJdbcStorePutTxBenchmark.java     |    47 +
 .../compute/IgniteAffinityCallBenchmark.java    |    36 +
 .../yardstick/compute/IgniteApplyBenchmark.java |    72 +
 .../compute/IgniteBroadcastBenchmark.java       |    35 +
 .../compute/IgniteExecuteBenchmark.java         |    35 +
 .../yardstick/compute/IgniteRunBenchmark.java   |    72 +
 .../yardstick/compute/model/NoopCallable.java   |    42 +
 .../yardstick/compute/model/NoopTask.java       |    96 +
 pom.xml                                         |   732 +-
 8129 files changed, 872617 insertions(+), 867430 deletions(-)
----------------------------------------------------------------------



[23/50] [abbrv] incubator-ignite git commit: Merge branches 'ignite-public-api-cleanup' and 'sprint-1' of https://git-wip-us.apache.org/repos/asf/incubator-ignite into ignite-public-api-cleanup

Posted by vk...@apache.org.
Merge branches 'ignite-public-api-cleanup' and 'sprint-1' of https://git-wip-us.apache.org/repos/asf/incubator-ignite into ignite-public-api-cleanup


Project: http://git-wip-us.apache.org/repos/asf/incubator-ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-ignite/commit/b79d3ae9
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/b79d3ae9
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/b79d3ae9

Branch: refs/heads/master
Commit: b79d3ae9cc845e86250a43de32b7027711d3335d
Parents: 4567925 d7f173c
Author: AKuznetsov <ak...@gridgain.com>
Authored: Mon Feb 16 19:58:29 2015 +0700
Committer: AKuznetsov <ak...@gridgain.com>
Committed: Mon Feb 16 19:58:29 2015 +0700

----------------------------------------------------------------------
 .../processors/cache/GridCacheAdapter.java      |  2 +-
 .../cache/GridCacheDeploymentManager.java       | 33 +++++++++-----------
 2 files changed, 16 insertions(+), 19 deletions(-)
----------------------------------------------------------------------



[13/50] [abbrv] incubator-ignite git commit: Merge branch 'sprint-1' into ignite-204

Posted by vk...@apache.org.
Merge branch 'sprint-1' into ignite-204


Project: http://git-wip-us.apache.org/repos/asf/incubator-ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-ignite/commit/9b555ffe
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/9b555ffe
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/9b555ffe

Branch: refs/heads/master
Commit: 9b555ffefd3d3c9e0ce555d8b47ef3c8b09a5746
Parents: 0cf20b3 3ba4f3c
Author: Artem Shutak <as...@gridgain.com>
Authored: Mon Feb 16 15:18:31 2015 +0300
Committer: Artem Shutak <as...@gridgain.com>
Committed: Mon Feb 16 15:18:31 2015 +0300

----------------------------------------------------------------------
 .../near/GridCacheNearMetricsSelfTest.java      |   4 +-
 ...idCachePartitionedHitsAndMissesSelfTest.java | 177 +++++++++++++++++++
 .../IgniteCacheMetricsSelfTestSuite.java        |  21 +--
 ...idCachePartitionedHitsAndMissesSelfTest.java | 176 ------------------
 .../IgniteH2IndexingSpiTestSuite.java           |   2 -
 pom.xml                                         |   7 -
 6 files changed, 190 insertions(+), 197 deletions(-)
----------------------------------------------------------------------



[26/50] [abbrv] incubator-ignite git commit: Merge remote-tracking branch 'origin/sprint-1' into sprint-1

Posted by vk...@apache.org.
Merge remote-tracking branch 'origin/sprint-1' into sprint-1


Project: http://git-wip-us.apache.org/repos/asf/incubator-ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-ignite/commit/761882bb
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/761882bb
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/761882bb

Branch: refs/heads/master
Commit: 761882bb129dcc87bd2c8ba12bbc26c9234d2d5f
Parents: 9138bd6 d7f173c
Author: sboikov <sb...@gridgain.com>
Authored: Mon Feb 16 16:15:32 2015 +0300
Committer: sboikov <sb...@gridgain.com>
Committed: Mon Feb 16 16:15:32 2015 +0300

----------------------------------------------------------------------
 .../processors/cache/GridCacheAdapter.java      |  2 +-
 .../cache/GridCacheDeploymentManager.java       | 33 +++++++++-----------
 2 files changed, 16 insertions(+), 19 deletions(-)
----------------------------------------------------------------------



[44/50] [abbrv] incubator-ignite git commit: # sprint-1 -release notes.

Posted by vk...@apache.org.
# sprint-1 -release notes.


Project: http://git-wip-us.apache.org/repos/asf/incubator-ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-ignite/commit/b5e89710
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/b5e89710
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/b5e89710

Branch: refs/heads/master
Commit: b5e897101cedbfa899dd912fc1d5d57c6dd16b3c
Parents: 66ca116
Author: Dmitiry Setrakyan <ds...@gridgain.com>
Authored: Mon Feb 16 11:08:07 2015 -0800
Committer: Dmitiry Setrakyan <ds...@gridgain.com>
Committed: Mon Feb 16 11:08:43 2015 -0800

----------------------------------------------------------------------
 docs/release_notes.pdf | Bin 59911 -> 19018 bytes
 1 file changed, 0 insertions(+), 0 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b5e89710/docs/release_notes.pdf
----------------------------------------------------------------------
diff --git a/docs/release_notes.pdf b/docs/release_notes.pdf
index 5793b06..fe5e307 100644
Binary files a/docs/release_notes.pdf and b/docs/release_notes.pdf differ


[41/50] [abbrv] incubator-ignite git commit: Merge remote-tracking branch 'remotes/origin/sprint-1' into sprint-1-release

Posted by vk...@apache.org.
Merge remote-tracking branch 'remotes/origin/sprint-1' into sprint-1-release


Project: http://git-wip-us.apache.org/repos/asf/incubator-ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-ignite/commit/bfd14e52
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/bfd14e52
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/bfd14e52

Branch: refs/heads/master
Commit: bfd14e529ca17d4ff09591a5a3aa70ac16afd50a
Parents: bd820ce 82924b6
Author: sboikov <sb...@gridgain.com>
Authored: Mon Feb 16 17:44:53 2015 +0300
Committer: sboikov <sb...@gridgain.com>
Committed: Mon Feb 16 17:44:53 2015 +0300

----------------------------------------------------------------------
 examples/config/example-cache.xml                         | 10 ++++++++++
 .../examples/datastructures/IgniteQueueExample.java       |  2 +-
 2 files changed, 11 insertions(+), 1 deletion(-)
----------------------------------------------------------------------



[17/50] [abbrv] incubator-ignite git commit: IGNITE-261 Scalar: fixed examples and tests.

Posted by vk...@apache.org.
 IGNITE-261 Scalar: fixed examples and tests.


Project: http://git-wip-us.apache.org/repos/asf/incubator-ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-ignite/commit/f0209856
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/f0209856
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/f0209856

Branch: refs/heads/master
Commit: f0209856df3b4898fd54b331e05ba0a7956ab250
Parents: 7007771
Author: AKuznetsov <ak...@gridgain.com>
Authored: Mon Feb 16 19:46:06 2015 +0700
Committer: AKuznetsov <ak...@gridgain.com>
Committed: Mon Feb 16 19:46:06 2015 +0700

----------------------------------------------------------------------
 .../examples/datagrid/CacheQueryExample.java    |   25 +-
 .../scalar/examples/ScalarCacheExample.scala    |    4 -
 .../ScalarCachePopularNumbersExample.scala      |    9 +-
 .../examples/ScalarCacheQueryExample.scala      |   32 +-
 .../examples/ScalarSnowflakeSchemaExample.scala |   26 +-
 .../ignite/scalar/pimps/ScalarCachePimp.scala   | 1340 +-----------------
 .../scalar/tests/ScalarCacheQueriesSpec.scala   |  461 +-----
 .../ignite/scalar/tests/ScalarCacheSpec.scala   |   16 +-
 8 files changed, 118 insertions(+), 1795 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f0209856/examples/src/main/java/org/apache/ignite/examples/datagrid/CacheQueryExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/datagrid/CacheQueryExample.java b/examples/src/main/java/org/apache/ignite/examples/datagrid/CacheQueryExample.java
index e041244..9fe9faf 100644
--- a/examples/src/main/java/org/apache/ignite/examples/datagrid/CacheQueryExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/datagrid/CacheQueryExample.java
@@ -109,10 +109,8 @@ public class CacheQueryExample {
 
     /**
      * Example for SQL queries based on salary ranges.
-     *
-     * @throws IgniteCheckedException In case of error.
      */
-    private static void sqlQuery() throws IgniteCheckedException {
+    private static void sqlQuery() {
         IgniteCache<CacheAffinityKey<UUID>, Person> cache = Ignition.ignite().jcache(CACHE_NAME);
 
         // SQL clause which selects salaries based on range.
@@ -131,10 +129,8 @@ public class CacheQueryExample {
 
     /**
      * Example for SQL queries based on all employees working for a specific organization.
-     *
-     * @throws IgniteCheckedException In case of error.
      */
-    private static void sqlQueryWithJoin() throws IgniteCheckedException {
+    private static void sqlQueryWithJoin() {
         IgniteCache<CacheAffinityKey<UUID>, Person> cache = Ignition.ignite().jcache(CACHE_NAME);
 
         // SQL clause query which joins on 2 types to select people for a specific organization.
@@ -152,10 +148,8 @@ public class CacheQueryExample {
 
     /**
      * Example for TEXT queries using LUCENE-based indexing of people's resumes.
-     *
-     * @throws IgniteCheckedException In case of error.
      */
-    private static void textQuery() throws IgniteCheckedException {
+    private static void textQuery() {
         IgniteCache<CacheAffinityKey<UUID>, Person> cache = Ignition.ignite().jcache(CACHE_NAME);
 
         //  Query for all people with "Master Degree" in their resumes.
@@ -173,10 +167,8 @@ public class CacheQueryExample {
     /**
      * Example for SQL-based fields queries that return only required
      * fields instead of whole key-value pairs.
-     *
-     * @throws IgniteCheckedException In case of error.
      */
-    private static void sqlFieldsQuery() throws IgniteCheckedException {
+    private static void sqlFieldsQuery() {
         IgniteCache<?, ?> cache = Ignition.ignite().jcache(CACHE_NAME);
 
         // Create query to get names of all employees.
@@ -194,10 +186,8 @@ public class CacheQueryExample {
     /**
      * Example for SQL-based fields queries that return only required
      * fields instead of whole key-value pairs.
-     *
-     * @throws IgniteCheckedException In case of error.
      */
-    private static void sqlFieldsQueryWithJoin() throws IgniteCheckedException {
+    private static void sqlFieldsQueryWithJoin() {
         IgniteCache<?, ?> cache = Ignition.ignite().jcache(CACHE_NAME);
 
         // Execute query to get names of all employees.
@@ -214,11 +204,8 @@ public class CacheQueryExample {
 
     /**
      * Populate cache with test data.
-     *
-     * @throws IgniteCheckedException In case of error.
-     * @throws InterruptedException In case of error.
      */
-    private static void initialize() throws IgniteCheckedException, InterruptedException {
+    private static void initialize() {
         IgniteCache cache = Ignition.ignite().jcache(CACHE_NAME);
 
         // Organizations.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f0209856/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCacheExample.scala
----------------------------------------------------------------------
diff --git a/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCacheExample.scala b/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCacheExample.scala
index a263350..e834da3 100644
--- a/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCacheExample.scala
+++ b/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCacheExample.scala
@@ -17,8 +17,6 @@
 
 package org.apache.ignite.scalar.examples
 
-import org.apache.ignite.cache.CachePeekMode
-
 import org.apache.ignite.events.Event
 import org.apache.ignite.events.EventType._
 import org.apache.ignite.lang.IgnitePredicate
@@ -38,8 +36,6 @@ object ScalarCacheExample extends App {
     /** Name of cache specified in spring configuration. */
     private val NAME = "partitioned"
 
-    private val peekModes = Array.empty[CachePeekMode]
-
     scalar("examples/config/example-cache.xml") {
         // Clean up caches on all nodes before run.
         cache$(NAME).get.clear()

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f0209856/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCachePopularNumbersExample.scala
----------------------------------------------------------------------
diff --git a/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCachePopularNumbersExample.scala b/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCachePopularNumbersExample.scala
index 69fe0ed..98d9637 100644
--- a/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCachePopularNumbersExample.scala
+++ b/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCachePopularNumbersExample.scala
@@ -25,6 +25,7 @@ import org.apache.ignite.scalar.scalar
 import org.apache.ignite.scalar.scalar._
 
 import scala.util.Random
+import collection.JavaConversions._
 
 /**
  * Real time popular number counter.
@@ -106,9 +107,11 @@ object ScalarCachePopularNumbersExample extends App {
      * @param cnt Number of most popular numbers to return.
      */
     def query(cnt: Int) {
-        cache$[Int, Long](CACHE_NAME).get.
-            sqlFields(clause = "select _key, _val from Long order by _val desc limit " + cnt).
-            sortBy(_(1).asInstanceOf[Long]).reverse.take(cnt).foreach(println)
+        val results = cache$[Int, Long](CACHE_NAME).get
+            .sqlFields(clause = "select _key, _val from Long order by _val desc limit " + cnt)
+            .getAll
+
+        results.foreach(res => println(res.get(0) + "=" + res.get(1)))
 
         println("------------------")
     }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f0209856/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCacheQueryExample.scala
----------------------------------------------------------------------
diff --git a/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCacheQueryExample.scala b/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCacheQueryExample.scala
index 44b0deb..6d40544 100644
--- a/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCacheQueryExample.scala
+++ b/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCacheQueryExample.scala
@@ -25,6 +25,8 @@ import org.apache.ignite.cache.affinity.CacheAffinityKey
 import org.apache.ignite.scalar.scalar
 import org.apache.ignite.scalar.scalar._
 
+import collection.JavaConversions._
+
 /**
  * Demonstrates cache ad-hoc queries with Scalar.
  * <p>
@@ -62,42 +64,18 @@ object ScalarCacheQueryExample {
         // Using distributed queries for partitioned cache and local queries for replicated cache.
         // Since in replicated caches data is available on all nodes, including local one,
         // it is enough to just query the local node.
-        val prj = if (cache$[Any, Any](CACHE_NAME).get.configuration().getCacheMode == PARTITIONED)
+        val prj = if (cache$(CACHE_NAME).get.configuration().getCacheMode == PARTITIONED)
             ignite.cluster().forRemotes()
         else
             ignite.cluster().forLocal()
 
         // Example for SQL-based querying employees based on salary ranges.
         // Gets all persons with 'salary > 1000'.
-        print("People with salary more than 1000: ", cache.sql(prj, "salary > 1000").map(_._2))
+        print("People with salary more than 1000: ", cache.sql("salary > 1000").getAll.map(e => e.getValue))
 
         // Example for TEXT-based querying for a given string in people resumes.
         // Gets all persons with 'Bachelor' degree.
-        print("People with Bachelor degree: ", cache.text(prj, "Bachelor").map(_._2))
-
-        // Example for SQL-based querying with custom remote transformer to make sure
-        // that only required data without any overhead is returned to caller.
-        // Gets last names of all 'Ignite' employees.
-        print("Last names of all 'Ignite' employees: ",
-            cache.sqlTransform(
-                prj,
-                "from Person, Organization where Person.orgId = Organization.id " +
-                    "and Organization.name = 'Ignite'",
-                (p: Person) => p.lastName
-            ).map(_._2)
-        )
-
-        // Example for SQL-based querying with custom remote and local reducers
-        // to calculate average salary among all employees within a company.
-        // Gets average salary of persons with 'Master' degree.
-        print("Average salary of people with Master degree: ",
-            cache.textReduce(
-                prj,
-                "Master",
-                (e: Iterable[(CacheAffinityKey[UUID], Person)]) => (e.map(_._2.salary).sum, e.size),
-                (e: Iterable[(Double, Int)]) => e.map(_._1).sum / e.map(_._2).sum
-            )
-        )
+        print("People with Bachelor degree: ", cache.text("Bachelor").getAll.map(e => e.getValue))
     }
 
     /**

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f0209856/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarSnowflakeSchemaExample.scala
----------------------------------------------------------------------
diff --git a/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarSnowflakeSchemaExample.scala b/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarSnowflakeSchemaExample.scala
index 723f3be..8e7e434 100644
--- a/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarSnowflakeSchemaExample.scala
+++ b/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarSnowflakeSchemaExample.scala
@@ -17,14 +17,16 @@
 
 package org.apache.ignite.scalar.examples
 
-import org.apache.ignite.Ignition
 import org.apache.ignite.scalar.scalar
 import org.apache.ignite.scalar.scalar._
 
 import org.jdk8.backport.ThreadLocalRandom8
 
+import javax.cache.Cache
 import java.util.ConcurrentModificationException
 
+import collection.JavaConversions._
+
 /**
  * <a href="http://en.wikipedia.org/wiki/Snowflake_schema">Snowflake Schema</a> is a logical
  * arrangement of data in which data is split into `dimensions`  and `facts`
@@ -131,7 +133,7 @@ object ScalarSnowflakeSchemaExample {
             "from \"replicated\".DimStore, \"partitioned\".FactPurchase " +
             "where DimStore.id=FactPurchase.storeId and DimStore.name=?", "Store1")
 
-        printQueryResults("All purchases made at store1:", storePurchases)
+        printQueryResults("All purchases made at store1:", storePurchases.getAll)
     }
 
     /**
@@ -141,7 +143,7 @@ object ScalarSnowflakeSchemaExample {
      * stored in `partitioned` cache.
      */
     private def queryProductPurchases() {
-        val factCache = Ignition.ignite.jcache(PART_CACHE_NAME)
+        val factCache = ignite$.jcache[Int, FactPurchase](PART_CACHE_NAME)
 
         // All purchases for certain product made at store2.
         // =================================================
@@ -151,14 +153,14 @@ object ScalarSnowflakeSchemaExample {
 
         println("IDs of products [p1=" + p1.id + ", p2=" + p2.id + ", p3=" + p3.id + ']')
 
-//        val prodPurchases = factCache.sql(
-//            "from \"replicated\".DimStore, \"replicated\".DimProduct, \"partitioned\".FactPurchase " +
-//            "where DimStore.id=FactPurchase.storeId and " +
-//                "DimProduct.id=FactPurchase.productId and " +
-//                "DimStore.name=? and DimProduct.id in(?, ?, ?)",
-//            "Store2", p1.id, p2.id, p3.id)
-//
-//        printQueryResults("All purchases made at store2 for 3 specific products:", prodPurchases)
+        val prodPurchases = factCache.sql(
+            "from \"replicated\".DimStore, \"replicated\".DimProduct, \"partitioned\".FactPurchase " +
+            "where DimStore.id=FactPurchase.storeId and " +
+                "DimProduct.id=FactPurchase.productId and " +
+                "DimStore.name=? and DimProduct.id in(?, ?, ?)",
+            "Store2", p1.id, p2.id, p3.id)
+
+        printQueryResults("All purchases made at store2 for 3 specific products:", prodPurchases.getAll)
     }
 
     /**
@@ -167,7 +169,7 @@ object ScalarSnowflakeSchemaExample {
      * @param msg Initial message.
      * @param res Results to print.
      */
-    private def printQueryResults[V](msg: String, res: Iterable[(Int, V)]) {
+    private def printQueryResults[V](msg: String, res: Iterable[Cache.Entry[Int, V]]) {
         println(msg)
 
         for (e <- res)

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f0209856/modules/scalar/src/main/scala/org/apache/ignite/scalar/pimps/ScalarCachePimp.scala
----------------------------------------------------------------------
diff --git a/modules/scalar/src/main/scala/org/apache/ignite/scalar/pimps/ScalarCachePimp.scala b/modules/scalar/src/main/scala/org/apache/ignite/scalar/pimps/ScalarCachePimp.scala
index ec2249b..05a5e2b 100644
--- a/modules/scalar/src/main/scala/org/apache/ignite/scalar/pimps/ScalarCachePimp.scala
+++ b/modules/scalar/src/main/scala/org/apache/ignite/scalar/pimps/ScalarCachePimp.scala
@@ -17,20 +17,18 @@
 
 package org.apache.ignite.scalar.pimps
 
-import org.apache.ignite.cache.query.{SqlQuery, QueryCursor}
+import org.apache.ignite.cache.query._
 import org.apache.ignite.configuration.CacheConfiguration
 
 import javax.cache.Cache
 
 import org.apache.ignite._
-import org.apache.ignite.cluster.ClusterGroup
-import org.apache.ignite.internal.util.scala.impl
-import org.apache.ignite.lang.{IgniteBiTuple, IgniteClosure, IgnitePredicate, IgniteReducer}
+import org.apache.ignite.lang.{IgnitePredicate, IgniteReducer}
 import org.apache.ignite.scalar.pimps.ScalarCacheConfigurationHelper._
 import org.apache.ignite.scalar.scalar._
 import org.jetbrains.annotations.Nullable
 
-import java.util.{Set => JavaSet}
+import java.util.{List => JavaList, Set => JavaSet}
 
 import scala.collection._
 import scala.collection.JavaConversions._
@@ -137,15 +135,6 @@ with Iterable[Cache.Entry[K, V]] with Ordered[IgniteCache[K, V]] {
         }
     }
 
-    private def toRemoteTransformer[K, V, T](trans: V => T):
-    IgniteClosure[java.util.Map.Entry[K, V], java.util.Map.Entry[K, T]] = {
-        new IgniteClosure[java.util.Map.Entry[K, V], java.util.Map.Entry[K, T]] {
-            @impl def apply(e: java.util.Map.Entry[K, V]): java.util.Map.Entry[K, T] = {
-                new IgniteBiTuple[K, T](e.getKey, trans(e.getValue))
-            }
-        }
-    }
-
     /**
      * Retrieves value mapped to the specified key from cache. The return value of `null`
      * means entry did not pass the provided filter or cache has no mapping for the key.
@@ -499,60 +488,7 @@ with Iterable[Cache.Entry[K, V]] with Ordered[IgniteCache[K, V]] {
     }
 
     /**
-     * Creates and executes ad-hoc `SCAN` query on given projection returning its result.
-     *
-     * Note that if query is executed more than once (potentially with different
-     * arguments) it is more performant to create query via standard mechanism
-     * and execute it multiple times with different arguments. The analogy is
-     * similar to JDBC `PreparedStatement`. Note also that this function will return
-     * all results at once without pagination and therefore memory limits should be
-     * taken into account.
-     *
-     * @param grid Grid projection on which this query will be executed. If `null` the
-     *     global projection will be used.
-     * @param cls Query values class. Since cache can, in general, contain values of any subtype of `V`
-     *     query needs to know the exact type it should operate on.
-     * @param kvp Filter to be used prior to returning key-value pairs to user. See `CacheQuery` for more details.
-     * @return Collection of cache key-value pairs.
-     */
-    def scan(@Nullable grid: ClusterGroup = null, cls: Class[_ <: V], kvp: KvPred): Iterable[(K, V)] = {
-        assert(cls != null)
-        assert(kvp != null)
-
-        //        val q = value.queries().createScanQuery(kvp)
-        //
-        //        (if (grid != null) q.projection(grid) else q).execute().get.map(e => (e.getKey, e.getValue))
-
-        Iterable.empty
-    }
-
-    /**
-     * Creates and executes ad-hoc `SCAN` query on given projection returning its result.
-     *
-     * Note that if query is executed more than once (potentially with different
-     * arguments) it is more performant to create query via standard mechanism
-     * and execute it multiple times with different arguments. The analogy is
-     * similar to JDBC `PreparedStatement`. Note also that this function will return
-     * all results at once without pagination and therefore memory limits should be
-     * taken into account.
-     *
-     * Note that query value class will be taken implicitly as exact type `V` of this
-     * cache projection.
-     *
-     * @param grid Grid projection on which this query will be executed. If `null` the
-     *     global projection will be used.
-     * @param kvp Filter to be used prior to returning key-value pairs to user. See `CacheQuery` for more details.
-     * @return Collection of cache key-value pairs.
-     */
-    def scan(@Nullable grid: ClusterGroup, kvp: KvPred)
-        (implicit m: Manifest[V]): Iterable[(K, V)] = {
-        assert(kvp != null)
-
-        scan(grid, m.erasure.asInstanceOf[Class[V]], kvp)
-    }
-
-    /**
-     * Creates and executes ad-hoc `SCAN` query on global projection returning its result.
+     * Creates and executes ad-hoc `SCAN` query returning its result.
      *
      * Note that if query is executed more than once (potentially with different
      * arguments) it is more performant to create query via standard mechanism
@@ -566,15 +502,15 @@ with Iterable[Cache.Entry[K, V]] with Ordered[IgniteCache[K, V]] {
      * @param kvp Filter to be used prior to returning key-value pairs to user. See `CacheQuery` for more details.
      * @return Collection of cache key-value pairs.
      */
-    def scan(cls: Class[_ <: V], kvp: KvPred): Iterable[(K, V)] = {
+    def scan(cls: Class[_ <: V], kvp: KvPred): QueryCursor[Cache.Entry[K, V]] = {
         assert(cls != null)
         assert(kvp != null)
 
-        scan(null, cls, kvp)
+        value.query(new ScanQuery(kvp))
     }
 
     /**
-     * Creates and executes ad-hoc `SCAN` query on global projection returning its result.
+     * Creates and executes ad-hoc `SCAN` query returning its result.
      *
      * Note that if query is executed more than once (potentially with different
      * arguments) it is more performant to create query via standard mechanism
@@ -589,14 +525,14 @@ with Iterable[Cache.Entry[K, V]] with Ordered[IgniteCache[K, V]] {
      * @param kvp Filter to be used prior to returning key-value pairs to user. See `CacheQuery` for more details.
      * @return Collection of cache key-value pairs.
      */
-    def scan(kvp: KvPred)(implicit m: Manifest[V]): Iterable[(K, V)] = {
+    def scan(kvp: KvPred)(implicit m: Manifest[V]): QueryCursor[Cache.Entry[K, V]] = {
         assert(kvp != null)
 
         scan(m.erasure.asInstanceOf[Class[V]], kvp)
     }
 
     /**
-     * Creates and executes ad-hoc `SQL` query on given projection returning its result.
+     * Creates and executes ad-hoc `SQL` query returning its result.
      *
      * Note that if query is executed more than once (potentially with different
      * arguments) it is more performant to create query via standard mechanism
@@ -605,77 +541,27 @@ with Iterable[Cache.Entry[K, V]] with Ordered[IgniteCache[K, V]] {
      * all results at once without pagination and therefore memory limits should be
      * taken into account.
      *
-     * @param grid Grid projection on which this query will be executed. If `null` the
-     *     global projection will be used.
      * @param cls Query values class. Since cache can, in general, contain values of any subtype of `V`
      *     query needs to know the exact type it should operate on.
      * @param clause Query SQL clause. See `CacheQuery` for more details.
      * @param args Optional list of query arguments.
      * @return Collection of cache key-value pairs.
      */
-    def sql(@Nullable grid: ClusterGroup, cls: Class[_ <: V], clause: String, args: Any*): Iterable[(K, V)] = {
+    def sql(cls: Class[_ <: V], clause: String, args: Any*): QueryCursor[Cache.Entry[K, V]] = {
         assert(cls != null)
         assert(clause != null)
         assert(args != null)
 
-        value.query(new SqlQuery(cls, clause).setArgs(args))
-
-        return Iterable.empty
-    }
-
-    /**
-     * Creates and executes ad-hoc `SQL` query on given projection returning its result.
-     *
-     * Note that if query is executed more than once (potentially with different
-     * arguments) it is more performant to create query via standard mechanism
-     * and execute it multiple times with different arguments. The analogy is
-     * similar to JDBC `PreparedStatement`. Note also that this function will return
-     * all results at once without pagination and therefore memory limits should be
-     * taken into account.
-     *
-     * @param grid Grid projection on which this query will be executed. If `null` the
-     *     global projection will be used.
-     * @param cls Query values class. Since cache can, in general, contain values of any subtype of `V`
-     *     query needs to know the exact type it should operate on.
-     * @param clause Query SQL clause. See `CacheQuery` for more details.
-     * @return Collection of cache key-value pairs.
-     */
-    def sql(@Nullable grid: ClusterGroup = null, cls: Class[_ <: V], clause: String): Iterable[(K, V)] = {
-        assert(cls != null)
-        assert(clause != null)
-
-        sql(grid, cls, clause, Nil: _*)
-    }
+        val query = new SqlQuery(cls, clause)
 
-    /**
-     * Creates and executes ad-hoc `SQL` query on given projection returning its result.
-     *
-     * Note that if query is executed more than once (potentially with different
-     * arguments) it is more performant to create query via standard mechanism
-     * and execute it multiple times with different arguments. The analogy is
-     * similar to JDBC `PreparedStatement`. Note also that this function will return
-     * all results at once without pagination and therefore memory limits should be
-     * taken into account.
-     *
-     * Note that query value class will be taken implicitly as exact type `V` of this
-     * cache projection.
-     *
-     * @param grid Grid projection on which this query will be executed. If `null` the
-     *     global projection will be used.
-     * @param clause Query SQL clause. See `CacheQuery` for more details.
-     * @param args Optional list of query arguments.
-     * @return Collection of cache key-value pairs.
-     */
-    def sql(@Nullable grid: ClusterGroup, clause: String, args: Any*)
-        (implicit m: Manifest[V]): Iterable[(K, V)] = {
-        assert(clause != null)
-        assert(args != null)
+        if (args != null && args.size > 0)
+            query.setArgs(args.map(_.asInstanceOf[AnyRef]) : _*)
 
-        sql(grid, m.erasure.asInstanceOf[Class[V]], clause, args: _*)
+        value.query(query)
     }
 
     /**
-     * Creates and executes ad-hoc `SQL` query on global projection returning its result.
+     * Creates and executes ad-hoc `SQL` query returning its result.
      *
      * Note that if query is executed more than once (potentially with different
      * arguments) it is more performant to create query via standard mechanism
@@ -687,18 +573,17 @@ with Iterable[Cache.Entry[K, V]] with Ordered[IgniteCache[K, V]] {
      * @param cls Query values class. Since cache can, in general, contain values of any subtype of `V`
      *     query needs to know the exact type it should operate on.
      * @param clause Query SQL clause. See `CacheQuery` for more details.
-     * @param args Optional list of query arguments.
      * @return Collection of cache key-value pairs.
      */
-    def sql(cls: Class[_ <: V], clause: String, args: Any*): Iterable[(K, V)] = {
+    def sql(cls: Class[_ <: V], clause: String): QueryCursor[Cache.Entry[K, V]] = {
         assert(cls != null)
         assert(clause != null)
 
-        sql(null.asInstanceOf[ClusterGroup], cls, clause, args: _*)
+        sql(cls, clause, Nil:_*)
     }
 
     /**
-     * Creates and executes ad-hoc `SQL` query on global projection returning its result.
+     * Creates and executes ad-hoc `SQL` query returning its result.
      *
      * Note that if query is executed more than once (potentially with different
      * arguments) it is more performant to create query via standard mechanism
@@ -714,66 +599,16 @@ with Iterable[Cache.Entry[K, V]] with Ordered[IgniteCache[K, V]] {
      * @param args Optional list of query arguments.
      * @return Collection of cache key-value pairs.
      */
-    def sql(clause: String, args: Any*)(implicit m: Manifest[V]): Iterable[(K, V)] = {
-        assert(clause != null)
-
-        sql(m.erasure.asInstanceOf[Class[V]], clause, args: _*)
-    }
-
-    /**
-     * Creates and executes ad-hoc `TEXT` query on given projection returning its result.
-     *
-     * Note that if query is executed more than once (potentially with different
-     * arguments) it is more performant to create query via standard mechanism
-     * and execute it multiple times with different arguments. The analogy is
-     * similar to JDBC `PreparedStatement`. Note also that this function will return
-     * all results at once without pagination and therefore memory limits should be
-     * taken into account.
-     *
-     * @param grid Grid projection on which this query will be executed. If `null` the
-     *     global projection will be used.
-     * @param cls Query values class. Since cache can, in general, contain values of any subtype of `V`
-     *     query needs to know the exact type it should operate on.
-     * @param clause Query text clause. See `CacheQuery` for more details.
-     * @return Collection of cache key-value pairs.
-     */
-    def text(@Nullable grid: ClusterGroup = null, cls: Class[_ <: V], clause: String): Iterable[(K, V)] = {
-        assert(cls != null)
-        assert(clause != null)
-
-        //        val q = value.cache().queries().createFullTextQuery(cls, clause)
-        //
-        //        (if (grid != null) q.projection(grid) else q).execute().get.map(e => (e.getKey, e.getValue))
-
-        Iterable.empty
-    }
-
-    /**
-     * Creates and executes ad-hoc `TEXT` query on given projection returning its result.
-     *
-     * Note that if query is executed more than once (potentially with different
-     * arguments) it is more performant to create query via standard mechanism
-     * and execute it multiple times with different arguments. The analogy is
-     * similar to JDBC `PreparedStatement`. Note also that this function will return
-     * all results at once without pagination and therefore memory limits should be
-     * taken into account.
-     *
-     * Note that query value class will be taken implicitly as exact type `V` of this
-     * cache projection.
-     *
-     * @param grid Grid projection on which this query will be executed. If `null` the
-     *     global projection will be used.
-     * @param clause Query text clause. See `CacheQuery` for more details.
-     * @return Collection of cache key-value pairs.
-     */
-    def text(@Nullable grid: ClusterGroup, clause: String)(implicit m: Manifest[V]): Iterable[(K, V)] = {
+    def sql(clause: String, args: Any*)
+        (implicit m: Manifest[V]): QueryCursor[Cache.Entry[K, V]] = {
         assert(clause != null)
+        assert(args != null)
 
-        text(grid, m.erasure.asInstanceOf[Class[V]], clause)
+        sql(m.erasure.asInstanceOf[Class[V]], clause, args:_*)
     }
 
     /**
-     * Creates and executes ad-hoc `TEXT` query on global projection returning its result.
+     * Creates and executes ad-hoc `TEXT` query returning its result.
      *
      * Note that if query is executed more than once (potentially with different
      * arguments) it is more performant to create query via standard mechanism
@@ -787,15 +622,15 @@ with Iterable[Cache.Entry[K, V]] with Ordered[IgniteCache[K, V]] {
      * @param clause Query text clause. See `CacheQuery` for more details.
      * @return Collection of cache key-value pairs.
      */
-    def text(cls: Class[_ <: V], clause: String): Iterable[(K, V)] = {
+    def text(cls: Class[_ <: V], clause: String): QueryCursor[Cache.Entry[K, V]] = {
         assert(cls != null)
         assert(clause != null)
 
-        text(null, cls, clause)
+        value.query(new TextQuery(cls, clause))
     }
 
     /**
-     * Creates and executes ad-hoc `TEXT` query on global projection returning its result.
+     * Creates and executes ad-hoc `TEXT` query returning its result.
      *
      * Note that if query is executed more than once (potentially with different
      * arguments) it is more performant to create query via standard mechanism
@@ -810,180 +645,14 @@ with Iterable[Cache.Entry[K, V]] with Ordered[IgniteCache[K, V]] {
      * @param clause Query text clause. See `CacheQuery` for more details.
      * @return Collection of cache key-value pairs.
      */
-    def text(clause: String)(implicit m: Manifest[V]): Iterable[(K, V)] = {
+    def text(clause: String)(implicit m: Manifest[V]): QueryCursor[Cache.Entry[K, V]] = {
         assert(clause != null)
 
         text(m.erasure.asInstanceOf[Class[V]], clause)
     }
 
     /**
-     * Creates and executes ad-hoc `SCAN` transform query on given projection returning its result.
-     *
-     * Note that if query is executed more than once (potentially with different
-     * arguments) it is more performant to create query via standard mechanism
-     * and execute it multiple times with different arguments. The analogy is
-     * similar to JDBC `PreparedStatement`. Note also that this function will return
-     * all results at once without pagination and therefore memory limits should be
-     * taken into account.
-     *
-     * @param grid Grid projection on which this query will be executed. If `null` the
-     *     global projection will be used.
-     * @param cls Query values class. Since cache can, in general, contain values of any subtype of `V`
-     *     query needs to know the exact type it should operate on.
-     * @param kvp Filter to be used prior to returning key-value pairs to user. See `CacheQuery` for more details.
-     * @param trans Transform function that will be applied to each returned value.
-     * @return Collection of cache key-value pairs.
-     */
-    def scanTransform[T](@Nullable grid: ClusterGroup = null, cls: Class[_ <: V], kvp: KvPred, trans: V => T):
-    Iterable[(K, T)] = {
-        assert(cls != null)
-        assert(kvp != null)
-        assert(trans != null)
-
-        //        val q = value.cache[K, V]().queries().createScanQuery(kvp)
-        //
-        //        toScalaItr[K, T]((if (grid != null) q.projection(grid) else q).execute(toRemoteTransformer[K, V, T](trans)).get)
-
-        Iterable.empty
-    }
-
-    /**
-     * Creates and executes ad-hoc `SCAN` transform query on given projection returning its result.
-     *
-     * Note that if query is executed more than once (potentially with different
-     * arguments) it is more performant to create query via standard mechanism
-     * and execute it multiple times with different arguments. The analogy is
-     * similar to JDBC `PreparedStatement`. Note also that this function will return
-     * all results at once without pagination and therefore memory limits should be
-     * taken into account.
-     *
-     * Note that query value class will be taken implicitly as exact type `V` of this
-     * cache projection.
-     *
-     * @param grid Grid projection on which this query will be executed. If `null` the global projection will be used.
-     * @param kvp Filter to be used prior to returning key-value pairs to user. See `CacheQuery` for more details.
-     * @param trans Transform function that will be applied to each returned value.
-     * @return Collection of cache key-value pairs.
-     */
-    def scanTransform[T](@Nullable grid: ClusterGroup, kvp: KvPred, trans: V => T)(implicit m: Manifest[V]):
-    Iterable[(K, T)] = {
-        assert(kvp != null)
-        assert(trans != null)
-
-        scanTransform(grid, m.erasure.asInstanceOf[Class[V]], kvp, trans)
-    }
-
-    /**
-     * Creates and executes ad-hoc `SCAN` transform query on global projection returning its result.
-     *
-     * Note that if query is executed more than once (potentially with different
-     * arguments) it is more performant to create query via standard mechanism
-     * and execute it multiple times with different arguments. The analogy is
-     * similar to JDBC `PreparedStatement`. Note also that this function will return
-     * all results at once without pagination and therefore memory limits should be
-     * taken into account.
-     *
-     * @param cls Query values class. Since cache can, in general, contain values of any subtype of `V`
-     *     query needs to know the exact type it should operate on.
-     * @param kvp Filter to be used prior to returning key-value pairs to user. See `CacheQuery` for more details.
-     * @param trans Transform function that will be applied to each returned value.
-     * @return Collection of cache key-value pairs.
-     */
-    def scanTransform[T](cls: Class[_ <: V], kvp: KvPred, trans: V => T): Iterable[(K, T)] = {
-        assert(cls != null)
-        assert(kvp != null)
-        assert(trans != null)
-
-        scanTransform(null, cls, kvp, trans)
-    }
-
-    /**
-     * Creates and executes ad-hoc `SCAN` transform query on global projection returning its result.
-     *
-     * Note that if query is executed more than once (potentially with different
-     * arguments) it is more performant to create query via standard mechanism
-     * and execute it multiple times with different arguments. The analogy is
-     * similar to JDBC `PreparedStatement`. Note also that this function will return
-     * all results at once without pagination and therefore memory limits should be
-     * taken into account.
-     *
-     * Note that query value class will be taken implicitly as exact type `V` of this
-     * cache projection.
-     *
-     * @param kvp Filter to be used prior to returning key-value pairs to user. See `CacheQuery` for more details.
-     * @param trans Transform function that will be applied to each returned value.
-     * @return Collection of cache key-value pairs.
-     */
-    def scanTransform[T](kvp: KvPred, trans: V => T)
-        (implicit m: Manifest[V]): Iterable[(K, T)] = {
-        assert(kvp != null)
-        assert(trans != null)
-
-        scanTransform(m.erasure.asInstanceOf[Class[V]], kvp, trans)
-    }
-
-    /**
-     * Creates and executes ad-hoc `SQL` transform query on given projection returning its result.
-     *
-     * Note that if query is executed more than once (potentially with different
-     * arguments) it is more performant to create query via standard mechanism
-     * and execute it multiple times with different arguments. The analogy is
-     * similar to JDBC `PreparedStatement`. Note also that this function will return
-     * all results at once without pagination and therefore memory limits should be
-     * taken into account.
-     *
-     * @param grid Grid projection on which this query will be executed. If `null` the
-     *     global projection will be used.
-     * @param cls Query values class. Since cache can, in general, contain values of any subtype of `V`
-     *     query needs to know the exact type it should operate on.
-     * @param clause Query SQL clause. See `CacheQuery` for more details.
-     * @param trans Transform function that will be applied to each returned value.
-     * @param args Optional list of query arguments.
-     * @return Collection of cache key-value pairs.
-     */
-    def sqlTransform[T](@Nullable grid: ClusterGroup, cls: Class[_ <: V], clause: String,
-        trans: V => T, args: Any*): Iterable[(K, T)] = {
-        assert(cls != null)
-        assert(clause != null)
-        assert(trans != null)
-        assert(args != null)
-
-        //        val q = value.cache[K, V]().queries().createSqlQuery(cls, clause)
-        //
-        //        toScalaItr((if (grid != null) q.projection(grid) else q)
-        //            .execute(toRemoteTransformer[K, V, T](trans), args.asInstanceOf[Seq[Object]]: _*).get)
-        Iterable.empty
-    }
-
-    /**
-     * Creates and executes ad-hoc `SQL` transform query on given projection returning its result.
-     *
-     * Note that if query is executed more than once (potentially with different
-     * arguments) it is more performant to create query via standard mechanism
-     * and execute it multiple times with different arguments. The analogy is
-     * similar to JDBC `PreparedStatement`. Note also that this function will return
-     * all results at once without pagination and therefore memory limits should be
-     * taken into account.
-     *
-     * @param grid Grid projection on which this query will be executed. If `null` the
-     *     global projection will be used.
-     * @param cls Query values class. Since cache can, in general, contain values of any subtype of `V`
-     *     query needs to know the exact type it should operate on.
-     * @param clause Query SQL clause. See `CacheQuery` for more details.
-     * @param trans Transform function that will be applied to each returned value.
-     * @return Collection of cache key-value pairs.
-     */
-    def sqlTransform[T](@Nullable grid: ClusterGroup = null, cls: Class[_ <: V], clause: String,
-        trans: V => T): Iterable[(K, T)] = {
-        assert(cls != null)
-        assert(clause != null)
-        assert(trans != null)
-
-        sqlTransform(grid, cls, clause, trans, Nil: _*)
-    }
-
-    /**
-     * Creates and executes ad-hoc `SQL` transform query on given projection returning its result.
+     * Creates and executes ad-hoc `SQL` fields query returning its result.
      *
      * Note that if query is executed more than once (potentially with different
      * arguments) it is more performant to create query via standard mechanism
@@ -992,957 +661,24 @@ with Iterable[Cache.Entry[K, V]] with Ordered[IgniteCache[K, V]] {
      * all results at once without pagination and therefore memory limits should be
      * taken into account.
      *
-     * Note that query value class will be taken implicitly as exact type `V` of this
-     * cache projection.
-     *
-     * @param grid Grid projection on which this query will be executed. If `null` the
-     *     global projection will be used.
      * @param clause Query SQL clause. See `CacheQuery` for more details.
-     * @param trans Transform function that will be applied to each returned value.
      * @param args Optional list of query arguments.
-     * @return Collection of cache key-value pairs.
+     * @return Sequence of sequences of field values.
      */
-    def sqlTransform[T](@Nullable grid: ClusterGroup, clause: String, trans: V => T, args: Any*)
-        (implicit m: Manifest[V]): Iterable[(K, T)] = {
+    def sqlFields(clause: String, args: Any*): QueryCursor[JavaList[_]] = {
         assert(clause != null)
-        assert(trans != null)
         assert(args != null)
 
-        sqlTransform(grid, m.erasure.asInstanceOf[Class[V]], clause, trans, args: _*)
-    }
-
-    /**
-     * Creates and executes ad-hoc `SQL` transform query on global projection returning its result.
-     *
-     * Note that if query is executed more than once (potentially with different
-     * arguments) it is more performant to create query via standard mechanism
-     * and execute it multiple times with different arguments. The analogy is
-     * similar to JDBC `PreparedStatement`. Note also that this function will return
-     * all results at once without pagination and therefore memory limits should be
-     * taken into account.
-     *
-     * @param cls Query values class. Since cache can, in general, contain values of any subtype of `V`
-     *     query needs to know the exact type it should operate on.
-     * @param clause Query SQL clause. See `CacheQuery` for more details.
-     * @param trans Transform function that will be applied to each returned value.
-     * @param args Optional list of query arguments.
-     * @return Collection of cache key-value pairs.
-     */
-    def sqlTransform[T](cls: Class[_ <: V], clause: String, trans: V => T, args: Any*): Iterable[(K, T)] = {
-        assert(cls != null)
-        assert(clause != null)
-        assert(trans != null)
-        assert(args != null)
-
-        sqlTransform(null, cls, clause, trans, args: _*)
-    }
-
-    /**
-     * Creates and executes ad-hoc `SQL` transform query on global projection returning its result.
-     *
-     * Note that if query is executed more than once (potentially with different
-     * arguments) it is more performant to create query via standard mechanism
-     * and execute it multiple times with different arguments. The analogy is
-     * similar to JDBC `PreparedStatement`. Note also that this function will return
-     * all results at once without pagination and therefore memory limits should be
-     * taken into account.
-     *
-     * Note that query value class will be taken implicitly as exact type `V` of this
-     * cache projection.
-     *
-     * @param clause Query SQL clause. See `CacheQuery` for more details.
-     * @param trans Transform function that will be applied to each returned value.
-     * @param args Optional list of query arguments.
-     * @return Collection of cache key-value pairs.
-     */
-    def sqlTransform[T](clause: String, trans: V => T, args: Any*)
-        (implicit m: Manifest[V]): Iterable[(K, T)] = {
-        assert(clause != null)
-        assert(trans != null)
-        assert(args != null)
-
-        sqlTransform(m.erasure.asInstanceOf[Class[V]], clause, trans, args: _*)
-    }
-
-    /**
-     * Creates and executes ad-hoc `TEXT` transform query on given projection returning its result.
-     *
-     * Note that if query is executed more than once (potentially with different
-     * arguments) it is more performant to create query via standard mechanism
-     * and execute it multiple times with different arguments. The analogy is
-     * similar to JDBC `PreparedStatement`. Note also that this function will return
-     * all results at once without pagination and therefore memory limits should be
-     * taken into account.
-     *
-     * @param grid Grid projection on which this query will be executed. If `null` the
-     *     global projection will be used.
-     * @param cls Query values class. Since cache can, in general, contain values of any subtype of `V`
-     *     query needs to know the exact type it should operate on.
-     * @param clause Query text clause. See `CacheQuery` for more details.
-     * @param trans Transform function that will be applied to each returned value.
-     * @return Collection of cache key-value pairs.
-     */
-    def textTransform[T](@Nullable grid: ClusterGroup = null, cls: Class[_ <: V], clause: String,
-        trans: V => T): Iterable[(K, T)] = {
-        assert(cls != null)
-        assert(clause != null)
-        assert(trans != null)
-
-        //        val q = value.cache[K, V]().queries().createFullTextQuery(cls, clause)
-        //
-        //        toScalaItr((if (grid != null) q.projection(grid) else q).execute(toRemoteTransformer[K, V, T](trans)).get)
-
-        Iterable.empty
-    }
-
-    /**
-     * Creates and executes ad-hoc `TEXT` transform query on given projection returning its result.
-     *
-     * Note that if query is executed more than once (potentially with different
-     * arguments) it is more performant to create query via standard mechanism
-     * and execute it multiple times with different arguments. The analogy is
-     * similar to JDBC `PreparedStatement`. Note also that this function will return
-     * all results at once without pagination and therefore memory limits should be
-     * taken into account.
-     *
-     * Note that query value class will be taken implicitly as exact type `V` of this
-     * cache projection.
-     *
-     * @param grid Grid projection on which this query will be executed. If `null` the
-     *     global projection will be used.
-     * @param clause Query text clause. See `CacheQuery` for more details.
-     * @param trans Transform function that will be applied to each returned value.
-     * @return Collection of cache key-value pairs.
-     */
-    def textTransform[T](@Nullable grid: ClusterGroup, clause: String, trans: V => T)
-        (implicit m: Manifest[V]): Iterable[(K, T)] = {
-        assert(clause != null)
-        assert(trans != null)
-
-        textTransform(grid, m.erasure.asInstanceOf[Class[V]], clause, trans)
-    }
-
-    /**
-     * Creates and executes ad-hoc `TEXT` transform query on global projection returning its result.
-     *
-     * Note that if query is executed more than once (potentially with different
-     * arguments) it is more performant to create query via standard mechanism
-     * and execute it multiple times with different arguments. The analogy is
-     * similar to JDBC `PreparedStatement`. Note also that this function will return
-     * all results at once without pagination and therefore memory limits should be
-     * taken into account.
-     *
-     * @param cls Query values class. Since cache can, in general, contain values of any subtype of `V`
-     *     query needs to know the exact type it should operate on.
-     * @param clause Query text clause. See `CacheQuery` for more details.
-     * @param trans Transform function that will be applied to each returned value.
-     * @return Collection of cache key-value pairs.
-     */
-    def textTransform[T](cls: Class[_ <: V], clause: String, trans: V => T): Iterable[(K, T)] = {
-        assert(cls != null)
-        assert(clause != null)
-        assert(trans != null)
-
-        textTransform(null, cls, clause, trans)
-    }
-
-    /**
-     * Creates and executes ad-hoc `TEXT` transform query on global projection returning its result.
-     *
-     * Note that if query is executed more than once (potentially with different
-     * arguments) it is more performant to create query via standard mechanism
-     * and execute it multiple times with different arguments. The analogy is
-     * similar to JDBC `PreparedStatement`. Note also that this function will return
-     * all results at once without pagination and therefore memory limits should be
-     * taken into account.
-     *
-     * Note that query value class will be taken implicitly as exact type `V` of this
-     * cache projection.
-     *
-     * @param clause Query text clause. See `CacheQuery` for more details.
-     * @param trans Transform function that will be applied to each returned value.
-     * @return Collection of cache key-value pairs.
-     */
-    def textTransform[T](clause: String, trans: V => T)
-        (implicit m: Manifest[V]): Iterable[(K, T)] = {
-        assert(clause != null)
-        assert(trans != null)
-
-        textTransform(m.erasure.asInstanceOf[Class[V]], clause, trans)
-    }
-
-    /**
-     * Creates and executes ad-hoc `SCAN` reduce query on given projection returning its result.
-     *
-     * Note that if query is executed more than once (potentially with different
-     * arguments) it is more performant to create query via standard mechanism
-     * and execute it multiple times with different arguments. The analogy is
-     * similar to JDBC `PreparedStatement`. Note also that this function will return
-     * all results at once without pagination and therefore memory limits should be
-     * taken into account.
-     *
-     * @param grid Grid projection on which this query will be executed. If `null` the
-     *     global projection will be used.
-     * @param cls Query values class. Since cache can, in general, contain values of any subtype of `V`
-     *     query needs to know the exact type it should operate on.
-     * @param kvp Filter to be used prior to returning key-value pairs to user. See `CacheQuery` for more details.
-     * @param rmtRdc Reduce function that will be called on each remote node.
-     * @param locRdc Reduce function that will be called on local node.
-     * @return Reduced value.
-     */
-    def scanReduce[R1, R2](@Nullable grid: ClusterGroup = null, cls: Class[_ <: V], kvp: KvPred,
-        rmtRdc: Iterable[(K, V)] => R1, locRdc: Iterable[R1] => R2): R2 = {
-        assert(cls != null)
-        assert(kvp != null)
-        assert(rmtRdc != null)
-        assert(locRdc != null)
-
-        //        val q = value.cache[K, V]().queries().createScanQuery(kvp)
-        //
-        //        locRdc((if (grid != null) q.projection(grid) else q).execute(toEntryReducer(rmtRdc)).get)
-
-        null.asInstanceOf[R2]
-    }
-
-    /**
-     * Creates and executes ad-hoc `SCAN` reduce query on given projection returning its result.
-     *
-     * Note that if query is executed more than once (potentially with different
-     * arguments) it is more performant to create query via standard mechanism
-     * and execute it multiple times with different arguments. The analogy is
-     * similar to JDBC `PreparedStatement`. Note also that this function will return
-     * all results at once without pagination and therefore memory limits should be
-     * taken into account.
-     *
-     * Note that query value class will be taken implicitly as exact type `V` of this
-     * cache projection.
-     *
-     * @param grid Grid projection on which this query will be executed. If `null` the
-     *     global projection will be used.
-     * @param kvp Filter to be used prior to returning key-value pairs to user. See `CacheQuery` for more details.
-     * @param rmtRdc Reduce function that will be called on each remote node.
-     * @param locRdc Reduce function that will be called on local node.
-     * @return Reduced value.
-     */
-    def scanReduce[R1, R2](@Nullable grid: ClusterGroup, kvp: KvPred,
-        rmtRdc: Iterable[(K, V)] => R1, locRdc: Iterable[R1] => R2)(implicit m: Manifest[V]): R2 = {
-        assert(kvp != null)
-        assert(rmtRdc != null)
-        assert(locRdc != null)
-
-        scanReduce(grid, m.erasure.asInstanceOf[Class[V]], kvp, rmtRdc, locRdc)
-    }
-
-    /**
-     * Creates and executes ad-hoc `SCAN` reduce query on global projection returning its result.
-     *
-     * Note that if query is executed more than once (potentially with different
-     * arguments) it is more performant to create query via standard mechanism
-     * and execute it multiple times with different arguments. The analogy is
-     * similar to JDBC `PreparedStatement`. Note also that this function will return
-     * all results at once without pagination and therefore memory limits should be
-     * taken into account.
-     *
-     * @param cls Query values class. Since cache can, in general, contain values of any subtype of `V`
-     *     query needs to know the exact type it should operate on.
-     * @param kvp Filter to be used prior to returning key-value pairs to user. See `CacheQuery` for more details.
-     * @param rmtRdc Reduce function that will be called on each remote node.
-     * @param locRdc Reduce function that will be called on local node.
-     * @return Reduced value.
-     */
-    def scanReduce[R1, R2](cls: Class[_ <: V], kvp: KvPred,
-        rmtRdc: Iterable[(K, V)] => R1, locRdc: Iterable[R1] => R2): R2 = {
-        assert(cls != null)
-        assert(kvp != null)
-        assert(rmtRdc != null)
-        assert(locRdc != null)
-
-        scanReduce(null, cls, kvp, rmtRdc, locRdc)
-    }
-
-    /**
-     * Creates and executes ad-hoc `SCAN` reduce query on global projection returning its result.
-     *
-     * Note that if query is executed more than once (potentially with different
-     * arguments) it is more performant to create query via standard mechanism
-     * and execute it multiple times with different arguments. The analogy is
-     * similar to JDBC `PreparedStatement`. Note also that this function will return
-     * all results at once without pagination and therefore memory limits should be
-     * taken into account.
-     *
-     * Note that query value class will be taken implicitly as exact type `V` of this
-     * cache projection.
-     *
-     * @param kvp Filter to be used prior to returning key-value pairs to user. See `CacheQuery` for more details.
-     * @param rmtRdc Reduce function that will be called on each remote node.
-     * @param locRdc Reduce function that will be called on local node.
-     * @return Reduced value.
-     */
-    def scanReduce[R1, R2](kvp: KvPred, rmtRdc: Iterable[(K, V)] => R1,
-        locRdc: Iterable[R1] => R2)(implicit m: Manifest[V]): R2 = {
-        assert(kvp != null)
-        assert(rmtRdc != null)
-        assert(locRdc != null)
-
-        scanReduce(m.erasure.asInstanceOf[Class[V]], kvp, rmtRdc, locRdc)
-    }
-
-    /**
-     * Creates and executes ad-hoc `SQL` reduce query on given projection returning its result.
-     *
-     * Note that if query is executed more than once (potentially with different
-     * arguments) it is more performant to create query via standard mechanism
-     * and execute it multiple times with different arguments. The analogy is
-     * similar to JDBC `PreparedStatement`. Note also that this function will return
-     * all results at once without pagination and therefore memory limits should be
-     * taken into account.
-     *
-     * @param grid Grid projection on which this query will be executed. If `null` the
-     *     global projection will be used.
-     * @param cls Query values class. Since cache can, in general, contain values of any subtype of `V`
-     *     query needs to know the exact type it should operate on.
-     * @param clause Query SQL clause. See `CacheQuery` for more details.
-     * @param rmtRdc Reduce function that will be called on each remote node.
-     * @param locRdc Reduce function that will be called on local node.
-     * @param args Optional list of query arguments.
-     * @return Reduced value.
-     */
-    def sqlReduce[R1, R2](@Nullable grid: ClusterGroup, cls: Class[_ <: V], clause: String,
-        rmtRdc: Iterable[(K, V)] => R1, locRdc: Iterable[R1] => R2, args: Any*): R2 = {
-        assert(cls != null)
-        assert(clause != null)
-        assert(rmtRdc != null)
-        assert(locRdc != null)
-        assert(args != null)
-
-        //        val q = value.cache[K, V]().queries().createSqlQuery(cls, clause)
-        //
-        //        locRdc((if (grid != null) q.projection(grid) else q)
-        //            .execute(toEntryReducer(rmtRdc), args.asInstanceOf[Seq[Object]]: _*).get)
-
-        null.asInstanceOf[R2]
-    }
-
-    /**
-     * Creates and executes ad-hoc `SQL` reduce query on given projection returning its result.
-     *
-     * Note that if query is executed more than once (potentially with different
-     * arguments) it is more performant to create query via standard mechanism
-     * and execute it multiple times with different arguments. The analogy is
-     * similar to JDBC `PreparedStatement`. Note also that this function will return
-     * all results at once without pagination and therefore memory limits should be
-     * taken into account.
-     *
-     * @param grid Grid projection on which this query will be executed. If `null` the
-     *     global projection will be used.
-     * @param cls Query values class. Since cache can, in general, contain values of any subtype of `V`
-     *     query needs to know the exact type it should operate on.
-     * @param clause Query SQL clause. See `CacheQuery` for more details.
-     * @param rmtRdc Reduce function that will be called on each remote node.
-     * @param locRdc Reduce function that will be called on local node.
-     * @return Reduced value.
-     */
-    def sqlReduce[R1, R2](@Nullable grid: ClusterGroup = null, cls: Class[_ <: V], clause: String,
-        rmtRdc: Iterable[(K, V)] => R1, locRdc: Iterable[R1] => R2): R2 = {
-        assert(cls != null)
-        assert(clause != null)
-        assert(rmtRdc != null)
-        assert(locRdc != null)
-
-        sqlReduce(grid, cls, clause, rmtRdc, locRdc, Nil: _*)
-    }
-
-    /**
-     * Creates and executes ad-hoc `SQL` reduce query on given projection returning its result.
-     *
-     * Note that if query is executed more than once (potentially with different
-     * arguments) it is more performant to create query via standard mechanism
-     * and execute it multiple times with different arguments. The analogy is
-     * similar to JDBC `PreparedStatement`. Note also that this function will return
-     * all results at once without pagination and therefore memory limits should be
-     * taken into account.
-     *
-     * Note that query value class will be taken implicitly as exact type `V` of this
-     * cache projection.
-     *
-     * @param grid Grid projection on which this query will be executed. If `null` the
-     *     global projection will be used.
-     * @param clause Query SQL clause. See `CacheQuery` for more details.
-     * @param rmtRdc Reduce function that will be called on each remote node.
-     * @param locRdc Reduce function that will be called on local node.
-     * @param args Optional list of query arguments.
-     * @return Reduced value.
-     */
-    def sqlReduce[R1, R2](@Nullable grid: ClusterGroup, clause: String, rmtRdc: Iterable[(K, V)] => R1,
-        locRdc: Iterable[R1] => R2, args: Any*)(implicit m: Manifest[V]): R2 = {
-        assert(clause != null)
-        assert(rmtRdc != null)
-        assert(locRdc != null)
-        assert(args != null)
-
-        sqlReduce(grid, m.erasure.asInstanceOf[Class[V]], clause, rmtRdc, locRdc, args: _*)
-    }
-
-    /**
-     * Creates and executes ad-hoc `SQL` reduce query on global projection returning its result.
-     *
-     * Note that if query is executed more than once (potentially with different
-     * arguments) it is more performant to create query via standard mechanism
-     * and execute it multiple times with different arguments. The analogy is
-     * similar to JDBC `PreparedStatement`. Note also that this function will return
-     * all results at once without pagination and therefore memory limits should be
-     * taken into account.
-     *
-     * @param cls Query values class. Since cache can, in general, contain values of any subtype of `V`
-     *     query needs to know the exact type it should operate on.
-     * @param clause Query SQL clause. See `CacheQuery` for more details.
-     * @param rmtRdc Reduce function that will be called on each remote node.
-     * @param locRdc Reduce function that will be called on local node.
-     * @param args Optional list of query arguments.
-     * @return Reduced value.
-     */
-    def sqlReduce[R1, R2](cls: Class[_ <: V], clause: String, rmtRdc: Iterable[(K, V)] => R1,
-        locRdc: Iterable[R1] => R2, args: Any*): R2 = {
-        assert(cls != null)
-        assert(clause != null)
-        assert(rmtRdc != null)
-        assert(locRdc != null)
-        assert(args != null)
-
-        sqlReduce(null, cls, clause, rmtRdc, locRdc, args: _*)
-    }
-
-    /**
-     * Creates and executes ad-hoc `SQL` reduce query on global projection returning its result.
-     *
-     * Note that if query is executed more than once (potentially with different
-     * arguments) it is more performant to create query via standard mechanism
-     * and execute it multiple times with different arguments. The analogy is
-     * similar to JDBC `PreparedStatement`. Note also that this function will return
-     * all results at once without pagination and therefore memory limits should be
-     * taken into account.
-     *
-     * Note that query value class will be taken implicitly as exact type `V` of this
-     * cache projection.
-     *
-     * @param clause Query SQL clause. See `CacheQuery` for more details.
-     * @param rmtRdc Reduce function that will be called on each remote node.
-     * @param locRdc Reduce function that will be called on local node.
-     * @param args Optional list of query arguments.
-     * @return Reduced value.
-     */
-    def sqlReduce[R1, R2](clause: String, rmtRdc: Iterable[(K, V)] => R1,
-        locRdc: Iterable[R1] => R2, args: Any*)(implicit m: Manifest[V]): R2 = {
-        assert(clause != null)
-        assert(rmtRdc != null)
-        assert(locRdc != null)
-        assert(args != null)
-
-        sqlReduce(m.erasure.asInstanceOf[Class[V]], clause, rmtRdc, locRdc, args: _*)
-    }
-
-    /**
-     * Creates and executes ad-hoc `TEXT` reduce query on given projection returning its result.
-     *
-     * Note that if query is executed more than once (potentially with different
-     * arguments) it is more performant to create query via standard mechanism
-     * and execute it multiple times with different arguments. The analogy is
-     * similar to JDBC `PreparedStatement`. Note also that this function will return
-     * all results at once without pagination and therefore memory limits should be
-     * taken into account.
-     *
-     * @param grid Grid projection on which this query will be executed. If `null` the
-     *     global projection will be used.
-     * @param cls Query values class. Since cache can, in general, contain values of any subtype of `V`
-     *     query needs to know the exact type it should operate on.
-     * @param clause Query text clause. See `CacheQuery` for more details.
-     * @param rmtRdc Reduce function that will be called on each remote node.
-     * @param locRdc Reduce function that will be called on local node.
-     * @return Reduced value.
-     */
-    def textReduce[R1, R2](@Nullable grid: ClusterGroup = null, cls: Class[_ <: V], clause: String,
-        rmtRdc: Iterable[(K, V)] => R1, locRdc: Iterable[R1] => R2): R2 = {
-        assert(cls != null)
-        assert(clause != null)
-        assert(rmtRdc != null)
-        assert(locRdc != null)
-
-        //        val q = value.cache[K, V]().queries().createFullTextQuery(cls, clause)
-        //
-        //        locRdc((if (grid != null) q.projection(grid) else q).execute(toEntryReducer(rmtRdc)).get)
-
-        null.asInstanceOf[R2]
-    }
-
-    /**
-     * Creates and executes ad-hoc `TEXT` reduce query on given projection returning its result.
-     *
-     * Note that if query is executed more than once (potentially with different
-     * arguments) it is more performant to create query via standard mechanism
-     * and execute it multiple times with different arguments. The analogy is
-     * similar to JDBC `PreparedStatement`. Note also that this function will return
-     * all results at once without pagination and therefore memory limits should be
-     * taken into account.
-     *
-     * Note that query value class will be taken implicitly as exact type `V` of this
-     * cache projection.
-     *
-     * @param grid Grid projection on which this query will be executed. If `null` the
-     *     global projection will be used.
-     * @param clause Query text clause. See `CacheQuery` for more details.
-     * @param rmtRdc Reduce function that will be called on each remote node.
-     * @param locRdc Reduce function that will be called on local node.
-     * @return Reduced value.
-     */
-    def textReduce[R1, R2](@Nullable grid: ClusterGroup, clause: String, rmtRdc: Iterable[(K, V)] => R1,
-        locRdc: Iterable[R1] => R2)(implicit m: Manifest[V]): R2 = {
-        assert(clause != null)
-        assert(rmtRdc != null)
-        assert(locRdc != null)
-
-        textReduce(grid, m.erasure.asInstanceOf[Class[V]], clause, rmtRdc, locRdc)
-    }
-
-    /**
-     * Creates and executes ad-hoc `TEXT` reduce query on global projection returning its result.
-     *
-     * Note that if query is executed more than once (potentially with different
-     * arguments) it is more performant to create query via standard mechanism
-     * and execute it multiple times with different arguments. The analogy is
-     * similar to JDBC `PreparedStatement`. Note also that this function will return
-     * all results at once without pagination and therefore memory limits should be
-     * taken into account.
-     *
-     * @param cls Query values class. Since cache can, in general, contain values of any subtype of `V`
-     *     query needs to know the exact type it should operate on.
-     * @param clause Query text clause. See `CacheQuery` for more details.
-     * @param rmtRdc Reduce function that will be called on each remote node.
-     * @param locRdc Reduce function that will be called on local node.
-     * @return Reduced value.
-     */
-    def textReduce[R1, R2](cls: Class[_ <: V], clause: String, rmtRdc: Iterable[(K, V)] => R1,
-        locRdc: Iterable[R1] => R2): R2 = {
-        assert(cls != null)
-        assert(clause != null)
-        assert(rmtRdc != null)
-        assert(locRdc != null)
-
-        textReduce(null, cls, clause, rmtRdc, locRdc)
-    }
-
-    /**
-     * Creates and executes ad-hoc `TEXT` reduce query on global projection returning its result.
-     *
-     * Note that if query is executed more than once (potentially with different
-     * arguments) it is more performant to create query via standard mechanism
-     * and execute it multiple times with different arguments. The analogy is
-     * similar to JDBC `PreparedStatement`. Note also that this function will return
-     * all results at once without pagination and therefore memory limits should be
-     * taken into account.
-     *
-     * Note that query value class will be taken implicitly as exact type `V` of this
-     * cache projection.
-     *
-     * @param clause Query text clause. See `CacheQuery` for more details.
-     * @param rmtRdc Reduce function that will be called on each remote node.
-     * @param locRdc Reduce function that will be called on local node.
-     * @return Reduced value.
-     */
-    def textReduce[R1, R2](clause: String, rmtRdc: Iterable[(K, V)] => R1,
-        locRdc: Iterable[R1] => R2)(implicit m: Manifest[V]): R2 = {
-        assert(clause != null)
-        assert(rmtRdc != null)
-        assert(locRdc != null)
-
-        textReduce(m.erasure.asInstanceOf[Class[V]], clause, rmtRdc, locRdc)
-    }
-
-    /**
-     * Creates and executes ad-hoc `SCAN` reduce query on given projection returning its result.
-     *
-     * Note that if query is executed more than once (potentially with different
-     * arguments) it is more performant to create query via standard mechanism
-     * and execute it multiple times with different arguments. The analogy is
-     * similar to JDBC `PreparedStatement`. Note also that this function will return
-     * all results at once without pagination and therefore memory limits should be
-     * taken into account.
-     *
-     * @param grid Grid projection on which this query will be executed. If `null` the
-     *     global projection will be used.
-     * @param cls Query values class. Since cache can, in general, contain values of any subtype of `V`
-     *     query needs to know the exact type it should operate on.
-     * @param kvp Filter to be used prior to returning key-value pairs to user. See `CacheQuery` for more details.
-     * @param rmtRdc Reduce function that will be called on each remote node.
-     * @return Collection of reduced values.
-     */
-    def scanReduceRemote[R](@Nullable grid: ClusterGroup = null, cls: Class[_ <: V], kvp: KvPred,
-        rmtRdc: Iterable[(K, V)] => R): Iterable[R] = {
-        assert(cls != null)
-        assert(kvp != null)
-        assert(rmtRdc != null)
-
-        //        val q = value.cache[K, V]().queries().createScanQuery(kvp)
-        //
-        //        (if (grid != null) q.projection(grid) else q).execute(toEntryReducer(rmtRdc)).get
-
-        Iterable.empty
-    }
-
-    /**
-     * Creates and executes ad-hoc `SCAN` reduce query on given projection returning its result.
-     *
-     * Note that if query is executed more than once (potentially with different
-     * arguments) it is more performant to create query via standard mechanism
-     * and execute it multiple times with different arguments. The analogy is
-     * similar to JDBC `PreparedStatement`. Note also that this function will return
-     * all results at once without pagination and therefore memory limits should be
-     * taken into account.
-     *
-     * Note that query value class will be taken implicitly as exact type `V` of this
-     * cache projection.
-     *
-     * @param grid Grid projection on which this query will be executed. If `null` the global projection will be used.
-     * @param kvp Filter to be used prior to returning key-value pairs to user. See `CacheQuery` for more details.
-     * @param rmtRdc Reduce function that will be called on each remote node.
-     * @return Collection of reduced values.
-     */
-    def scanReduceRemote[R](@Nullable grid: ClusterGroup, kvp: KvPred,
-        rmtRdc: Iterable[(K, V)] => R)(implicit m: Manifest[V]): Iterable[R] = {
-        assert(kvp != null)
-        assert(rmtRdc != null)
-
-        scanReduceRemote(grid, m.erasure.asInstanceOf[Class[V]], kvp, rmtRdc)
-    }
-
-    /**
-     * Creates and executes ad-hoc `SCAN` reduce query on global projection returning its result.
-     *
-     * Note that if query is executed more than once (potentially with different
-     * arguments) it is more performant to create query via standard mechanism
-     * and execute it multiple times with different arguments. The analogy is
-     * similar to JDBC `PreparedStatement`. Note also that this function will return
-     * all results at once without pagination and therefore memory limits should be
-     * taken into account.
-     *
-     * @param cls Query values class. Since cache can, in general, contain values of any subtype of `V`
-     *     query needs to know the exact type it should operate on.
-     * @param kvp Filter to be used prior to returning key-value pairs to user. See `CacheQuery` for more details.
-     * @param rmtRdc Reduce function that will be called on each remote node.
-     * @return Collection of reduced values.
-     */
-    def scanReduceRemote[R](cls: Class[_ <: V], kvp: KvPred, rmtRdc: Iterable[(K, V)] => R): Iterable[R] = {
-        assert(cls != null)
-        assert(kvp != null)
-        assert(rmtRdc != null)
-
-        scanReduceRemote(null, cls, kvp, rmtRdc)
-    }
-
-    /**
-     * Creates and executes ad-hoc `SCAN` reduce query on global projection returning its result.
-     *
-     * Note that if query is executed more than once (potentially with different
-     * arguments) it is more performant to create query via standard mechanism
-     * and execute it multiple times with different arguments. The analogy is
-     * similar to JDBC `PreparedStatement`. Note also that this function will return
-     * all results at once without pagination and therefore memory limits should be
-     * taken into account.
-     *
-     * Note that query value class will be taken implicitly as exact type `V` of this
-     * cache projection.
-     *
-     * @param kvp Filter to be used prior to returning key-value pairs to user. See `CacheQuery` for more details.
-     * @param rmtRdc Reduce function that will be called on each remote node.
-     * @return Collection of reduced values.
-     */
-    def scanReduceRemote[R](kvp: KvPred, rmtRdc: Iterable[(K, V)] => R)(implicit m: Manifest[V]): Iterable[R] = {
-        assert(kvp != null)
-        assert(rmtRdc != null)
-
-        scanReduceRemote(m.erasure.asInstanceOf[Class[V]], kvp, rmtRdc)
-    }
-
-    /**
-     * Creates and executes ad-hoc `SQL` reduce query on given projection returning its result.
-     *
-     * Note that if query is executed more than once (potentially with different
-     * arguments) it is more performant to create query via standard mechanism
-     * and execute it multiple times with different arguments. The analogy is
-     * similar to JDBC `PreparedStatement`. Note also that this function will return
-     * all results at once without pagination and therefore memory limits should be
-     * taken into account.
-     *
-     * @param grid Grid projection on which this query will be executed. If `null` the
-     *     global projection will be used.
-     * @param cls Query values class. Since cache can, in general, contain values of any subtype of `V`
-     *     query needs to know the exact type it should operate on.
-     * @param clause Query SQL clause. See `CacheQuery` for more details.
-     * @param rmtRdc Reduce function that will be called on each remote node.
-     * @param args Optional list of query arguments.
-     * @return Collection of reduced values.
-     */
-    def sqlReduceRemote[R](@Nullable grid: ClusterGroup, cls: Class[_ <: V], clause: String,
-        rmtRdc: Iterable[(K, V)] => R, args: Any*): Iterable[R] = {
-        assert(cls != null)
-        assert(clause != null)
-        assert(rmtRdc != null)
-        assert(args != null)
-
-        //        val q = value.cache[K, V]().queries().createSqlQuery(cls, clause)
-        //
-        //        (if (grid != null) q.projection(grid) else q)
-        //            .execute(toEntryReducer(rmtRdc), args.asInstanceOf[Seq[Object]]: _*).get
-
-        Iterable.empty
-    }
-
-    /**
-     * Creates and executes ad-hoc `SQL` reduce query on given projection returning its result.
-     *
-     * Note that if query is executed more than once (potentially with different
-     * arguments) it is more performant to create query via standard mechanism
-     * and execute it multiple times with different arguments. The analogy is
-     * similar to JDBC `PreparedStatement`. Note also that this function will return
-     * all results at once without pagination and therefore memory limits should be
-     * taken into account.
-     *
-     * @param grid Grid projection on which this query will be executed. If `null` the
-     *     global projection will be used.
-     * @param cls Query values class. Since cache can, in general, contain values of any subtype of `V`
-     *     query needs to know the exact type it should operate on.
-     * @param clause Query SQL clause. See `CacheQuery` for more details.
-     * @param rmtRdc Reduce function that will be called on each remote node.
-     * @return Collection of reduced values.
-     */
-    def sqlReduceRemote[R](@Nullable grid: ClusterGroup = null, cls: Class[_ <: V], clause: String,
-        rmtRdc: Iterable[(K, V)] => R): Iterable[R] = {
-        assert(cls != null)
-        assert(clause != null)
-        assert(rmtRdc != null)
-
-        sqlReduceRemote(grid, cls, clause, rmtRdc, Nil: _*)
-    }
-
-    /**
-     * Creates and executes ad-hoc `SQL` reduce query on given projection returning its result.
-     *
-     * Note that if query is executed more than once (potentially with different
-     * arguments) it is more performant to create query via standard mechanism
-     * and execute it multiple times with different arguments. The analogy is
-     * similar to JDBC `PreparedStatement`. Note also that this function will return
-     * all results at once without pagination and therefore memory limits should be
-     * taken into account.
-     *
-     * Note that query value class will be taken implicitly as exact type `V` of this
-     * cache projection.
-     *
-     * @param grid Grid projection on which this query will be executed. If `null` the
-     *     global projection will be used.
-     * @param clause Query SQL clause. See `CacheQuery` for more details.
-     * @param rmtRdc Reduce function that will be called on each remote node.
-     * @param args Optional list of query arguments.
-     * @return Collection of reduced values.
-     */
-    def sqlReduceRemote[R](@Nullable grid: ClusterGroup, clause: String, rmtRdc: Iterable[(K, V)] => R,
-        args: Any*)(implicit m: Manifest[V]): Iterable[R] = {
-        assert(clause != null)
-        assert(rmtRdc != null)
-        assert(args != null)
-
-        sqlReduceRemote(grid, m.erasure.asInstanceOf[Class[V]], clause, rmtRdc, args: _*)
-    }
-
-    /**
-     * Creates and executes ad-hoc `SQL` reduce query on global projection returning its result.
-     *
-     * Note that if query is executed more than once (potentially with different
-     * arguments) it is more performant to create query via standard mechanism
-     * and execute it multiple times with different arguments. The analogy is
-     * similar to JDBC `PreparedStatement`. Note also that this function will return
-     * all results at once without pagination and therefore memory limits should be
-     * taken into account.
-     *
-     * @param cls Query values class. Since cache can, in general, contain values of any subtype of `V`
-     *     query needs to know the exact type it should operate on.
-     * @param clause Query SQL clause. See `CacheQuery` for more details.
-     * @param rmtRdc Reduce function that will be called on each remote node.
-     * @param args Optional list of query arguments.
-     * @return Collection of reduced values.
-     */
-    def sqlReduceRemote[R](cls: Class[_ <: V], clause: String, rmtRdc: Iterable[(K, V)] => R,
-        args: Any*): Iterable[R] = {
-        assert(cls != null)
-        assert(clause != null)
-        assert(rmtRdc != null)
-        assert(args != null)
-
-        sqlReduceRemote(null, cls, clause, rmtRdc, args: _*)
-    }
-
-    /**
-     * Creates and executes ad-hoc `SQL` reduce query on global projection returning its result.
-     *
-     * Note that if query is executed more than once (potentially with different
-     * arguments) it is more performant to create query via standard mechanism
-     * and execute it multiple times with different arguments. The analogy is
-     * similar to JDBC `PreparedStatement`. Note also that this function will return
-     * all results at once without pagination and therefore memory limits should be
-     * taken into account.
-     *
-     * Note that query value class will be taken implicitly as exact type `V` of this
-     * cache projection.
-     *
-     * @param clause Query SQL clause. See `CacheQuery` for more details.
-     * @param rmtRdc Reduce function that will be called on each remote node.
-     * @param args Optional list of query arguments.
-     * @return Collection of reduced values.
-     */
-    def sqlReduceRemote[R](clause: String, rmtRdc: Iterable[(K, V)] => R, args: Any*)
-        (implicit m: Manifest[V]): Iterable[R] = {
-        assert(clause != null)
-        assert(rmtRdc != null)
-        assert(args != null)
-
-        sqlReduceRemote(m.erasure.asInstanceOf[Class[V]], clause, rmtRdc, args: _*)
-    }
-
-    /**
-     * Creates and executes ad-hoc `TEXT` reduce query on given projection returning its result.
-     *
-     * Note that if query is executed more than once (potentially with different
-     * arguments) it is more performant to create query via standard mechanism
-     * and execute it multiple times with different arguments. The analogy is
-     * similar to JDBC `PreparedStatement`. Note also that this function will return
-     * all results at once without pagination and therefore memory limits should be
-     * taken into account.
-     *
-     * @param grid Grid projection on which this query will be executed. If `null` the
-     *     global projection will be used.
-     * @param cls Query values class. Since cache can, in general, contain values of any subtype of `V`
-     *     query needs to know the exact type it should operate on.
-     * @param clause Query text clause. See `CacheQuery` for more details.
-     * @param rmtRdc Reduce function that will be called on each remote node.
-     * @return Collection of reduced values.
-     */
-    def textReduceRemote[R](@Nullable grid: ClusterGroup = null, cls: Class[_ <: V], clause: String,
-        rmtRdc: Iterable[(K, V)] => R): Iterable[R] = {
-        assert(cls != null)
-        assert(clause != null)
-        assert(rmtRdc != null)
-
-        //        val q = value.cache[K, V]().queries().createFullTextQuery(cls, clause)
-        //
-        //        (if (grid != null) q.projection(grid) else q).execute(toEntryReducer(rmtRdc)).get
-        Iterable.empty
-    }
-
-    /**
-     * Creates and executes ad-hoc `TEXT` reduce query on given projection returning its result.
-     *
-     * Note that if query is executed more than once (potentially with different
-     * arguments) it is more performant to create query via standard mechanism
-     * and execute it multiple times with different arguments. The analogy is
-     * similar to JDBC `PreparedStatement`. Note also that this function will return
-     * all results at once without pagination and therefore memory limits should be
-     * taken into account.
-     *
-     * Note that query value class will be taken implicitly as exact type `V` of this
-     * cache projection.
-     *
-     * @param grid Grid projection on which this query will be executed. If `null` the
-     *     global projection will be used.
-     * @param clause Query text clause. See `CacheQuery` for more details.
-     * @param rmtRdc Reduce function that will be called on each remote node.
-     * @return Collection of reduced values.
-     */
-    def textReduceRemote[R](@Nullable grid: ClusterGroup, clause: String, rmtRdc: Iterable[(K, V)] => R)
-        (implicit m: Manifest[V]): Iterable[R] = {
-        assert(clause != null)
-        assert(rmtRdc != null)
-
-        textReduceRemote(grid, m.erasure.asInstanceOf[Class[V]], clause, rmtRdc)
-    }
-
-    /**
-     * Creates and executes ad-hoc `TEXT` reduce query on global projection returning its result.
-     *
-     * Note that if query is executed more than once (potentially with different
-     * arguments) it is more performant to create query via standard mechanism
-     * and execute it multiple times with different arguments. The analogy is
-     * similar to JDBC `PreparedStatement`. Note also that this function will return
-     * all results at once without pagination and therefore memory limits should be
-     * taken into account.
-     *
-     * @param cls Query values class. Since cache can, in general, contain values of any subtype of `V`
-     *     query needs to know the exact type it should operate on.
-     * @param clause Query text clause. See `CacheQuery` for more details.
-     * @param rmtRdc Reduce function that will be called on each remote node.
-     * @return Collection of reduced values.
-     */
-    def textReduceRemote[R](cls: Class[_ <: V], clause: String,
-        rmtRdc: Iterable[(K, V)] => R): Iterable[R] = {
-        assert(cls != null)
-        assert(clause != null)
-        assert(rmtRdc != null)
-
-        textReduceRemote(null, cls, clause, rmtRdc)
-    }
-
-    /**
-     * Creates and executes ad-hoc `TEXT` reduce query on global projection returning its result.
-     *
-     * Note that if query is executed more than once (potentially with different
-     * arguments) it is more performant to create query via standard mechanism
-     * and execute it multiple times with different arguments. The analogy is
-     * similar to JDBC `PreparedStatement`. Note also that this function will return
-     * all results at once without pagination and therefore memory limits should be
-     * taken into account.
-     *
-     * Note that query value class will be taken implicitly as exact type `V` of this
-     * cache projection.
-     *
-     * @param clause Query text clause. See `CacheQuery` for more details.
-     * @param rmtRdc Reduce function that will be called on each remote node.
-     * @return Collection of reduced values.
-     */
-    def textReduceRemote[R](clause: String, rmtRdc: Iterable[(K, V)] => R)
-        (implicit m: Manifest[V]): Iterable[R] = {
-        assert(clause != null)
-        assert(rmtRdc != null)
-
-        textReduceRemote(m.erasure.asInstanceOf[Class[V]], clause, rmtRdc)
-    }
-
-    /**
-     * Creates and executes ad-hoc `SQL` fields query on given projection returning its result.
-     *
-     * Note that if query is executed more than once (potentially with different
-     * arguments) it is more performant to create query via standard mechanism
-     * and execute it multiple times with different arguments. The analogy is
-     * similar to JDBC `PreparedStatement`. Note also that this function will return
-     * all results at once without pagination and therefore memory limits should be
-     * taken into account.
-     *
-     * @param grid Optional grid projection on which this query will be executed. If `null` the
-     *      global projection will be used.
-     * @param clause Query SQL clause. See `CacheQuery` for more details.
-     * @param args Optional list of query arguments.
-     * @return Sequence of sequences of field values.
-     */
-    def sqlFields(@Nullable grid: ClusterGroup, clause: String, args: Any*): IndexedSeq[IndexedSeq[Any]] = {
-        assert(clause != null)
-        assert(args != null)
+        val query = new SqlFieldsQuery(clause)
 
-        //        val q = value.cache[K, V]().queries().createSqlFieldsQuery(clause)
-        //
-        //        (if (grid != null) q.projection(grid) else q).execute(args.asInstanceOf[Seq[Object]]: _*)
-        //            .get.toIndexedSeq.map((s: java.util.List[_]) => s.toIndexedSeq)
+        if (args != null && args.nonEmpty)
+            query.setArgs(args.map(_.asInstanceOf[AnyRef]) : _*)
 
-        IndexedSeq.empty
+        value.queryFields(query)
     }
 
     /**
-     * Creates and executes ad-hoc `SQL` no-arg fields query on given projection returning its result.
+     * Creates and executes ad-hoc `SQL` no-arg fields query returning its result.
      *
      * Note that if query is executed more than once (potentially with different
      * arguments) it is more performant to create query via standard mechanism
@@ -1951,14 +687,12 @@ with Iterable[Cache.Entry[K, V]] with Ordered[IgniteCache[K, V]] {
      * all results at once without pagination and therefore memory limits should be
      * taken into account.
      *
-     * @param grid Optional grid projection on which this query will be executed. If `null` the
-     *      global projection will be used.
      * @param clause Query SQL clause. See `CacheQuery` for more details.
      * @return Sequence of sequences of field values.
      */
-    def sqlFields(@Nullable grid: ClusterGroup = null, clause: String): IndexedSeq[IndexedSeq[Any]] = {
+    def sqlFields(clause: String): QueryCursor[JavaList[_]] = {
         assert(clause != null)
 
-        sqlFields(grid, clause, Nil: _*)
+        sqlFields(clause, Nil:_*)
     }
 }


[47/50] [abbrv] incubator-ignite git commit: Merge remote-tracking branch 'origin/sprint-1-release' into sprint-1-release

Posted by vk...@apache.org.
Merge remote-tracking branch 'origin/sprint-1-release' into sprint-1-release


Project: http://git-wip-us.apache.org/repos/asf/incubator-ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-ignite/commit/a2453252
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/a2453252
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/a2453252

Branch: refs/heads/master
Commit: a245325256be3bafd7a221a8cb8988b48a6bd9b3
Parents: 4fef190 a8dfdcd
Author: Valentin Kulichenko <vk...@gridgain.com>
Authored: Mon Feb 16 17:03:29 2015 -0800
Committer: Valentin Kulichenko <vk...@gridgain.com>
Committed: Mon Feb 16 17:03:29 2015 -0800

----------------------------------------------------------------------

----------------------------------------------------------------------



[21/50] [abbrv] incubator-ignite git commit: Merge branch 'sprint-1' of https://git-wip-us.apache.org/repos/asf/incubator-ignite into sprint-1

Posted by vk...@apache.org.
Merge branch 'sprint-1' of https://git-wip-us.apache.org/repos/asf/incubator-ignite into sprint-1


Project: http://git-wip-us.apache.org/repos/asf/incubator-ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-ignite/commit/d7f173cc
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/d7f173cc
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/d7f173cc

Branch: refs/heads/master
Commit: d7f173cca161c826a0746cdb940ff491df1dccfe
Parents: 156e0c1 19c1b5c
Author: ivasilinets <iv...@gridgain.com>
Authored: Mon Feb 16 15:56:59 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Mon Feb 16 15:56:59 2015 +0300

----------------------------------------------------------------------
 .../org/apache/ignite/compute/ComputeTask.java  |   3 +-
 .../dht/atomic/GridDhtAtomicCache.java          |   2 +-
 .../transactions/IgniteTxLocalAdapter.java      |   2 +-
 .../GridTransactionalCacheQueueImpl.java        |   4 +-
 .../apache/ignite/resources/package-info.java   |  22 +++
 .../org/apache/ignite/resources/package.html    |  25 ---
 .../near/GridCacheNearMetricsSelfTest.java      |   4 +-
 ...idCachePartitionedHitsAndMissesSelfTest.java | 177 +++++++++++++++++++
 .../IgniteCacheMetricsSelfTestSuite.java        |  21 +--
 ...idCachePartitionedHitsAndMissesSelfTest.java | 176 ------------------
 .../IgniteH2IndexingSpiTestSuite.java           |   2 -
 .../commands/cache/VisorCacheCommand.scala      |   2 +-
 .../commands/top/VisorTopologyCommand.scala     |   3 +-
 .../scala/org/apache/ignite/visor/visor.scala   |   2 +-
 pom.xml                                         |  11 +-
 15 files changed, 222 insertions(+), 234 deletions(-)
----------------------------------------------------------------------



[09/50] [abbrv] incubator-ignite git commit: Fixed cache metrics tests.

Posted by vk...@apache.org.
Fixed cache metrics tests.


Project: http://git-wip-us.apache.org/repos/asf/incubator-ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-ignite/commit/bd28d7db
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/bd28d7db
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/bd28d7db

Branch: refs/heads/master
Commit: bd28d7db79839ff10f6998e8a5eef4e8056c31ef
Parents: f459714
Author: nikolay_tikhonov <nt...@gridgain.com>
Authored: Mon Feb 16 14:47:15 2015 +0300
Committer: nikolay_tikhonov <nt...@gridgain.com>
Committed: Mon Feb 16 14:48:58 2015 +0300

----------------------------------------------------------------------
 .../near/GridCacheNearMetricsSelfTest.java      |   4 +-
 ...idCachePartitionedHitsAndMissesSelfTest.java | 177 +++++++++++++++++++
 .../IgniteCacheMetricsSelfTestSuite.java        |  21 +--
 ...idCachePartitionedHitsAndMissesSelfTest.java | 176 ------------------
 .../IgniteH2IndexingSpiTestSuite.java           |   2 -
 5 files changed, 190 insertions(+), 190 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/bd28d7db/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCacheNearMetricsSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCacheNearMetricsSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCacheNearMetricsSelfTest.java
index 0086311..2c52928 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCacheNearMetricsSelfTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCacheNearMetricsSelfTest.java
@@ -108,7 +108,7 @@ public class GridCacheNearMetricsSelfTest extends GridCacheAbstractSelfTest {
         // Put and get a few keys.
         for (int i = 0; ; i++) {
             if (affinity(cache0).isPrimary(g0.cluster().localNode(), i)) {
-                cache0.put(i, i); // +1 read
+                cache0.getAndPut(i, i); // +1 read
 
                 cache0.get(i); // +1 read.
 
@@ -140,7 +140,7 @@ public class GridCacheNearMetricsSelfTest extends GridCacheAbstractSelfTest {
             if (affinity(jcache).isPrimary(g.cluster().localNode(), key)) {
                 assertEquals(2, jcache.metrics().getCacheGets());
                 assertEquals(1, jcache.metrics().getCacheHits());
-                assertEquals(1, jcache.metrics().getCacheHits());
+                assertEquals(1, jcache.metrics().getCacheMisses());
             }
             else {
                 assertEquals(0, jcache.metrics().getCacheGets());

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/bd28d7db/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCachePartitionedHitsAndMissesSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCachePartitionedHitsAndMissesSelfTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCachePartitionedHitsAndMissesSelfTest.java
new file mode 100644
index 0000000..d3464ea
--- /dev/null
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCachePartitionedHitsAndMissesSelfTest.java
@@ -0,0 +1,177 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+package org.apache.ignite.internal.processors.cache.distributed.near;
+
+import org.apache.ignite.*;
+import org.apache.ignite.cache.*;
+import org.apache.ignite.configuration.*;
+import org.apache.ignite.marshaller.optimized.*;
+import org.apache.ignite.spi.discovery.tcp.*;
+import org.apache.ignite.spi.discovery.tcp.ipfinder.*;
+import org.apache.ignite.spi.discovery.tcp.ipfinder.vm.*;
+import org.apache.ignite.testframework.junits.common.*;
+import org.apache.ignite.transactions.*;
+
+import javax.cache.processor.*;
+import java.util.*;
+
+import static org.apache.ignite.cache.CacheDistributionMode.*;
+import static org.apache.ignite.cache.CacheMode.*;
+import static org.apache.ignite.cache.CacheWriteSynchronizationMode.*;
+
+/**
+ * Test for issue GG-3997 Total Hits and Misses display wrong value for in-memory database.
+ */
+public class GridCachePartitionedHitsAndMissesSelfTest extends GridCommonAbstractTest {
+    /** Amount of grids to start. */
+    private static final int GRID_CNT = 3;
+
+    /** Count of total numbers to generate. */
+    private static final int CNT = 2000;
+
+    /** IP Finder. */
+    private static final TcpDiscoveryIpFinder IP_FINDER = new TcpDiscoveryVmIpFinder(true);
+
+    /** {@inheritDoc} */
+    @Override protected IgniteConfiguration getConfiguration(String gridName) throws Exception {
+        IgniteConfiguration cfg = super.getConfiguration(gridName);
+
+        cfg.setMarshaller(new OptimizedMarshaller(false));
+
+        // DiscoverySpi
+        TcpDiscoverySpi disco = new TcpDiscoverySpi();
+        disco.setIpFinder(IP_FINDER);
+        cfg.setDiscoverySpi(disco);
+
+        // Cache.
+        cfg.setCacheConfiguration(cacheConfiguration(gridName));
+
+        TransactionConfiguration tCfg = new TransactionConfiguration();
+
+        tCfg.setDefaultTxConcurrency(TransactionConcurrency.PESSIMISTIC);
+        tCfg.setDefaultTxIsolation(TransactionIsolation.REPEATABLE_READ);
+
+        cfg.setTransactionConfiguration(tCfg);
+
+        return cfg;
+    }
+
+    /**
+     * Cache configuration.
+     *
+     * @param gridName Grid name.
+     * @return Cache configuration.
+     * @throws Exception In case of error.
+     */
+    protected CacheConfiguration cacheConfiguration(String gridName) throws Exception {
+        CacheConfiguration cfg = defaultCacheConfiguration();
+        cfg.setCacheMode(PARTITIONED);
+        cfg.setStartSize(700000);
+        cfg.setWriteSynchronizationMode(FULL_ASYNC);
+        cfg.setEvictionPolicy(null);
+        cfg.setBackups(1);
+        cfg.setDistributionMode(PARTITIONED_ONLY);
+        cfg.setPreloadPartitionedDelay(-1);
+        cfg.setBackups(1);
+        cfg.setStatisticsEnabled(true);
+
+        CacheQueryConfiguration qcfg = new CacheQueryConfiguration();
+
+        qcfg.setIndexPrimitiveKey(true);
+
+        cfg.setQueryConfiguration(qcfg);
+
+        return cfg;
+    }
+
+    /**
+     * This test is just a wrapper for org.apache.ignite.examples.datagrid.CachePopularNumbersExample
+     *
+     * @throws Exception If failed.
+     */
+    public void testHitsAndMisses() throws Exception {
+        assert(GRID_CNT > 0);
+
+        startGrids(GRID_CNT);
+
+        try {
+            final Ignite g = grid(0);
+
+            realTimePopulate(g);
+
+            // Check metrics for the whole cache.
+            long hits = 0;
+            long misses = 0;
+
+            for (int i = 0; i < GRID_CNT; i++) {
+                CacheMetrics m = grid(i).jcache(null).metrics();
+
+                hits += m.getCacheHits();
+                misses += m.getCacheMisses();
+            }
+
+            // Check that invoke and loader updated metrics
+            assertEquals(CNT, hits);
+            assertEquals(CNT, misses);
+        }
+        finally {
+            stopAllGrids();
+        }
+    }
+
+    /**
+     * Populates cache with data loader.
+     *
+     * @param g Grid.
+     * @throws IgniteCheckedException If failed.
+     */
+    private static void realTimePopulate(final Ignite g) throws IgniteCheckedException {
+        try (IgniteDataLoader<Integer, Long> ldr = g.dataLoader(null)) {
+            // Sets max values to 1 so cache metrics have correct values.
+            ldr.perNodeParallelLoadOperations(1);
+
+            // Count closure which increments a count on remote node.
+            ldr.updater(new IncrementingUpdater());
+
+            for (int i = 0; i < CNT; i++)
+                ldr.addData(i % (CNT / 2), 1L);
+        }
+    }
+
+    /**
+     * Increments value for key.
+     */
+    private static class IncrementingUpdater implements IgniteDataLoader.Updater<Integer, Long> {
+        /** */
+        private static final EntryProcessor<Integer, Long, Void> INC = new EntryProcessor<Integer, Long, Void>() {
+            @Override public Void process(MutableEntry<Integer, Long> e, Object... args) {
+                Long val = e.getValue();
+
+                e.setValue(val == null ? 1 : val + 1);
+
+                return null;
+            }
+        };
+
+        /** {@inheritDoc} */
+        @Override public void update(IgniteCache<Integer, Long> cache, Collection<Map.Entry<Integer, Long>> entries) {
+            for (Map.Entry<Integer, Long> entry : entries)
+                cache.invoke(entry.getKey(), INC);
+        }
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/bd28d7db/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteCacheMetricsSelfTestSuite.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteCacheMetricsSelfTestSuite.java b/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteCacheMetricsSelfTestSuite.java
index ae3fa32..511afec 100644
--- a/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteCacheMetricsSelfTestSuite.java
+++ b/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteCacheMetricsSelfTestSuite.java
@@ -33,18 +33,19 @@ public class IgniteCacheMetricsSelfTestSuite extends TestSuite {
     public static TestSuite suite() throws Exception {
         TestSuite suite = new TestSuite("Cache Metrics Test Suite");
 
-        suite.addTest(new TestSuite(GridCacheLocalMetricsSelfTest.class));
-        suite.addTest(new TestSuite(GridCacheNearMetricsSelfTest.class));
-        suite.addTest(new TestSuite(GridCacheReplicatedMetricsSelfTest.class));
-        suite.addTest(new TestSuite(GridCachePartitionedMetricsSelfTest.class));
+        suite.addTestSuite(GridCacheLocalMetricsSelfTest.class);
+        suite.addTestSuite(GridCacheNearMetricsSelfTest.class);
+        suite.addTestSuite(GridCacheReplicatedMetricsSelfTest.class);
+        suite.addTestSuite(GridCachePartitionedMetricsSelfTest.class);
+        suite.addTestSuite(GridCachePartitionedHitsAndMissesSelfTest.class);
 
         // Atomic cache.
-        suite.addTest(new TestSuite(GridCacheAtomicLocalMetricsSelfTest.class));
-        suite.addTest(new TestSuite(GridCacheAtomicLocalMetricsNoStoreSelfTest.class));
-        suite.addTest(new TestSuite(GridCacheAtomicReplicatedMetricsSelfTest.class));
-        suite.addTest(new TestSuite(GridCacheAtomicPartitionedMetricsSelfTest.class));
-        suite.addTest(new TestSuite(GridCacheAtomicPartitionedTckMetricsSelfTestImpl.class));
-        suite.addTest(new TestSuite(GridCacheAtomicLocalTckMetricsSelfTestImpl.class));
+        suite.addTestSuite(GridCacheAtomicLocalMetricsSelfTest.class);
+        suite.addTestSuite(GridCacheAtomicLocalMetricsNoStoreSelfTest.class);
+        suite.addTestSuite(GridCacheAtomicReplicatedMetricsSelfTest.class);
+        suite.addTestSuite(GridCacheAtomicPartitionedMetricsSelfTest.class);
+        suite.addTestSuite(GridCacheAtomicPartitionedTckMetricsSelfTestImpl.class);
+        suite.addTestSuite(GridCacheAtomicLocalTckMetricsSelfTestImpl.class);
 
         return suite;
     }

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/bd28d7db/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCachePartitionedHitsAndMissesSelfTest.java
----------------------------------------------------------------------
diff --git a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCachePartitionedHitsAndMissesSelfTest.java b/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCachePartitionedHitsAndMissesSelfTest.java
deleted file mode 100644
index 11397f1..0000000
--- a/modules/indexing/src/test/java/org/apache/ignite/internal/processors/cache/distributed/near/GridCachePartitionedHitsAndMissesSelfTest.java
+++ /dev/null
@@ -1,176 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-package org.apache.ignite.internal.processors.cache.distributed.near;
-
-import org.apache.ignite.*;
-import org.apache.ignite.cache.*;
-import org.apache.ignite.configuration.*;
-import org.apache.ignite.marshaller.optimized.*;
-import org.apache.ignite.spi.discovery.tcp.*;
-import org.apache.ignite.spi.discovery.tcp.ipfinder.*;
-import org.apache.ignite.spi.discovery.tcp.ipfinder.vm.*;
-import org.apache.ignite.testframework.junits.common.*;
-import org.apache.ignite.transactions.*;
-
-import javax.cache.processor.*;
-import java.util.*;
-
-import static org.apache.ignite.cache.CacheDistributionMode.*;
-import static org.apache.ignite.cache.CacheMode.*;
-import static org.apache.ignite.cache.CacheWriteSynchronizationMode.*;
-
-/**
- * Test for issue GG-3997 Total Hits and Misses display wrong value for in-memory database.
- */
-public class GridCachePartitionedHitsAndMissesSelfTest extends GridCommonAbstractTest {
-    /** Amount of grids to start. */
-    private static final int GRID_CNT = 3;
-
-    /** Count of total numbers to generate. */
-    private static final int CNT = 2000;
-
-    /** IP Finder. */
-    private static final TcpDiscoveryIpFinder IP_FINDER = new TcpDiscoveryVmIpFinder(true);
-
-    /** {@inheritDoc} */
-    @Override protected IgniteConfiguration getConfiguration(String gridName) throws Exception {
-        IgniteConfiguration cfg = super.getConfiguration(gridName);
-
-        cfg.setMarshaller(new OptimizedMarshaller(false));
-
-        // DiscoverySpi
-        TcpDiscoverySpi disco = new TcpDiscoverySpi();
-        disco.setIpFinder(IP_FINDER);
-        cfg.setDiscoverySpi(disco);
-
-        // Cache.
-        cfg.setCacheConfiguration(cacheConfiguration(gridName));
-
-        TransactionConfiguration tCfg = new TransactionConfiguration();
-
-        tCfg.setDefaultTxConcurrency(TransactionConcurrency.PESSIMISTIC);
-        tCfg.setDefaultTxIsolation(TransactionIsolation.REPEATABLE_READ);
-
-        cfg.setTransactionConfiguration(tCfg);
-
-        return cfg;
-    }
-
-    /**
-     * Cache configuration.
-     *
-     * @param gridName Grid name.
-     * @return Cache configuration.
-     * @throws Exception In case of error.
-     */
-    protected CacheConfiguration cacheConfiguration(String gridName) throws Exception {
-        CacheConfiguration cfg = defaultCacheConfiguration();
-        cfg.setCacheMode(PARTITIONED);
-        cfg.setStartSize(700000);
-        cfg.setWriteSynchronizationMode(FULL_ASYNC);
-        cfg.setEvictionPolicy(null);
-        cfg.setBackups(1);
-        cfg.setDistributionMode(PARTITIONED_ONLY);
-        cfg.setPreloadPartitionedDelay(-1);
-        cfg.setBackups(1);
-        cfg.setStatisticsEnabled(true);
-
-        CacheQueryConfiguration qcfg = new CacheQueryConfiguration();
-
-        qcfg.setIndexPrimitiveKey(true);
-
-        cfg.setQueryConfiguration(qcfg);
-
-        return cfg;
-    }
-
-    /**
-     * This test is just a wrapper for org.apache.ignite.examples.datagrid.CachePopularNumbersExample
-     *
-     * @throws Exception If failed.
-     */
-    public void testHitsAndMisses() throws Exception {
-        assert(GRID_CNT > 0);
-
-        startGrids(GRID_CNT);
-
-        try {
-            final Ignite g = grid(0);
-
-            realTimePopulate(g);
-
-            // Check metrics for the whole cache.
-            long hits = 0;
-            long misses = 0;
-
-            for (int i = 0; i < GRID_CNT; i++) {
-                CacheMetrics m = grid(i).jcache(null).metrics();
-
-                hits += m.getCacheHits();
-                misses += m.getCacheMisses();
-            }
-
-            assertEquals(CNT / 2, hits);
-            assertEquals(CNT / 2, misses);
-        }
-        finally {
-            stopAllGrids();
-        }
-    }
-
-    /**
-     * Populates cache with data loader.
-     *
-     * @param g Grid.
-     * @throws IgniteCheckedException If failed.
-     */
-    private static void realTimePopulate(final Ignite g) throws IgniteCheckedException {
-        try (IgniteDataLoader<Integer, Long> ldr = g.dataLoader(null)) {
-            // Sets max values to 1 so cache metrics have correct values.
-            ldr.perNodeParallelLoadOperations(1);
-
-            // Count closure which increments a count on remote node.
-            ldr.updater(new IncrementingUpdater());
-
-            for (int i = 0; i < CNT; i++)
-                ldr.addData(i % (CNT / 2), 1L);
-        }
-    }
-
-    /**
-     * Increments value for key.
-     */
-    private static class IncrementingUpdater implements IgniteDataLoader.Updater<Integer, Long> {
-        /** */
-        private static final EntryProcessor<Integer, Long, Void> INC = new EntryProcessor<Integer, Long, Void>() {
-            @Override public Void process(MutableEntry<Integer, Long> e, Object... args) {
-                Long val = e.getValue();
-
-                e.setValue(val == null ? 1 : val + 1);
-
-                return null;
-            }
-        };
-
-        /** {@inheritDoc} */
-        @Override public void update(IgniteCache<Integer, Long> cache, Collection<Map.Entry<Integer, Long>> entries) {
-            for (Map.Entry<Integer, Long> entry : entries)
-                cache.invoke(entry.getKey(), INC);
-        }
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/bd28d7db/modules/indexing/src/test/java/org/apache/ignite/testsuites/IgniteH2IndexingSpiTestSuite.java
----------------------------------------------------------------------
diff --git a/modules/indexing/src/test/java/org/apache/ignite/testsuites/IgniteH2IndexingSpiTestSuite.java b/modules/indexing/src/test/java/org/apache/ignite/testsuites/IgniteH2IndexingSpiTestSuite.java
index 58f3a92..bd9cca6 100644
--- a/modules/indexing/src/test/java/org/apache/ignite/testsuites/IgniteH2IndexingSpiTestSuite.java
+++ b/modules/indexing/src/test/java/org/apache/ignite/testsuites/IgniteH2IndexingSpiTestSuite.java
@@ -19,7 +19,6 @@ package org.apache.ignite.testsuites;
 
 import junit.framework.*;
 import org.apache.ignite.internal.processors.cache.*;
-import org.apache.ignite.internal.processors.cache.distributed.near.*;
 import org.apache.ignite.internal.processors.query.h2.*;
 import org.apache.ignite.internal.processors.query.h2.opt.*;
 
@@ -49,7 +48,6 @@ public class IgniteH2IndexingSpiTestSuite extends TestSuite {
         // Tests moved to this suite since they require GridH2IndexingSpi.
         suite.addTestSuite(GridCacheOffHeapAndSwapSelfTest.class);
         suite.addTestSuite(GridIndexingWithNoopSwapSelfTest.class);
-        suite.addTestSuite(GridCachePartitionedHitsAndMissesSelfTest.class);
         suite.addTestSuite(GridCacheSwapSelfTest.class);
         suite.addTestSuite(GridCacheOffHeapSelfTest.class);
 


[48/50] [abbrv] incubator-ignite git commit: # sprint-1 Fixed Visor task.

Posted by vk...@apache.org.
# sprint-1 Fixed Visor task.


Project: http://git-wip-us.apache.org/repos/asf/incubator-ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-ignite/commit/a4101a5f
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/a4101a5f
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/a4101a5f

Branch: refs/heads/master
Commit: a4101a5f52415abe68e4ac471b317657d49099ff
Parents: 659b432
Author: anovikov <an...@gridgain.com>
Authored: Tue Feb 17 10:36:27 2015 +0700
Committer: anovikov <an...@gridgain.com>
Committed: Tue Feb 17 10:36:27 2015 +0700

----------------------------------------------------------------------
 .../internal/visor/node/VisorExecutorServiceConfiguration.java      | 1 +
 1 file changed, 1 insertion(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a4101a5f/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorExecutorServiceConfiguration.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorExecutorServiceConfiguration.java b/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorExecutorServiceConfiguration.java
index 437a3bb..4141999 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorExecutorServiceConfiguration.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/visor/node/VisorExecutorServiceConfiguration.java
@@ -58,6 +58,7 @@ public class VisorExecutorServiceConfiguration implements Serializable {
         cfg.systemThreadPoolSize(c.getSystemThreadPoolSize());
         cfg.managementThreadPoolSize(c.getManagementThreadPoolSize());
         cfg.peerClassLoadingThreadPoolSize(c.getPeerClassLoadingThreadPoolSize());
+        cfg.igfsThreadPoolSize(c.getIgfsThreadPoolSize());
 
         ConnectorConfiguration cc = c.getConnectorConfiguration();
 


[15/50] [abbrv] incubator-ignite git commit: #ignite-268: onUndeploy should be called one time for each cache.

Posted by vk...@apache.org.
#ignite-268: onUndeploy should be called one time for each cache.


Project: http://git-wip-us.apache.org/repos/asf/incubator-ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-ignite/commit/156e0c19
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/156e0c19
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/156e0c19

Branch: refs/heads/master
Commit: 156e0c193517d83b87ad1d38bc703c65b73fae7c
Parents: bbf5163
Author: ivasilinets <iv...@gridgain.com>
Authored: Mon Feb 16 15:33:06 2015 +0300
Committer: ivasilinets <iv...@gridgain.com>
Committed: Mon Feb 16 15:33:06 2015 +0300

----------------------------------------------------------------------
 .../processors/cache/GridCacheAdapter.java      |  2 +-
 .../cache/GridCacheDeploymentManager.java       | 33 +++++++++-----------
 2 files changed, 16 insertions(+), 19 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/156e0c19/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheAdapter.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheAdapter.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheAdapter.java
index c86eed6..0082375 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheAdapter.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheAdapter.java
@@ -1211,7 +1211,7 @@ public abstract class GridCacheAdapter<K, V> implements GridCache<K, V>,
      * @param ldr Class loader to undeploy.
      */
     public void onUndeploy(ClassLoader ldr) {
-        ctx.deploy().onUndeploy(ldr);
+        ctx.deploy().onUndeploy(ldr, context());
     }
 
     /** {@inheritDoc} */

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/156e0c19/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheDeploymentManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheDeploymentManager.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheDeploymentManager.java
index 12cd679..c9467eb 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheDeploymentManager.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheDeploymentManager.java
@@ -205,35 +205,32 @@ public class GridCacheDeploymentManager<K, V> extends GridCacheSharedManagerAdap
      * Undeploys given class loader.
      *
      * @param ldr Class loader to undeploy.
+     * @param ctx Grid cache context.
      */
-    public void onUndeploy(final ClassLoader ldr) {
+    public void onUndeploy(final ClassLoader ldr, final GridCacheContext<K, V> ctx) {
         assert ldr != null;
 
         if (log.isDebugEnabled())
             log.debug("Received onUndeploy() request [ldr=" + ldr + ", cctx=" + cctx + ']');
 
         synchronized (undeploys) {
-            for (final GridCacheContext<K, V> cacheCtx : cctx.cacheContexts()) {
-                List<CA> queue = undeploys.get(cacheCtx.name());
+            List<CA> queue = undeploys.get(ctx.name());
 
-                if (queue == null)
-                    undeploys.put(cacheCtx.name(), queue = new ArrayList<>());
+            if (queue == null)
+                undeploys.put(ctx.name(), queue = new ArrayList<>());
 
-                queue.add(new CA() {
-                    @Override
-                    public void apply() {
-                        onUndeploy0(ldr, cacheCtx);
-                    }
-                });
-            }
+            queue.add(new CA() {
+                @Override
+                public void apply() {
+                    onUndeploy0(ldr, ctx);
+                }
+            });
         }
 
-        for (GridCacheContext<K, V> cacheCtx : cctx.cacheContexts()) {
-            // Unwind immediately for local and replicate caches.
-            // We go through preloader for proper synchronization.
-            if (cacheCtx.isLocal())
-                cacheCtx.preloader().unwindUndeploys();
-        }
+        // Unwind immediately for local and replicate caches.
+        // We go through preloader for proper synchronization.
+        if (ctx.isLocal())
+            ctx.preloader().unwindUndeploys();
     }
 
     /**


[19/50] [abbrv] incubator-ignite git commit: Merge branch 'sprint-1' of https://git-wip-us.apache.org/repos/asf/incubator-ignite into sprint-1-release

Posted by vk...@apache.org.
Merge branch 'sprint-1' of https://git-wip-us.apache.org/repos/asf/incubator-ignite into sprint-1-release


Project: http://git-wip-us.apache.org/repos/asf/incubator-ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-ignite/commit/42fa6d39
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/42fa6d39
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/42fa6d39

Branch: refs/heads/master
Commit: 42fa6d397c591b22d12019c89a7c8524aa4904d7
Parents: 9b3bae7 19c1b5c
Author: Yakov Zhdanov <yz...@gridgain.com>
Authored: Mon Feb 16 15:51:44 2015 +0300
Committer: Yakov Zhdanov <yz...@gridgain.com>
Committed: Mon Feb 16 15:51:44 2015 +0300

----------------------------------------------------------------------
 pom.xml | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/42fa6d39/pom.xml
----------------------------------------------------------------------


[24/50] [abbrv] incubator-ignite git commit: Merge remote-tracking branch 'origin/ignite-public-api-cleanup' into ignite-public-api-cleanup

Posted by vk...@apache.org.
Merge remote-tracking branch 'origin/ignite-public-api-cleanup' into ignite-public-api-cleanup


Project: http://git-wip-us.apache.org/repos/asf/incubator-ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-ignite/commit/887a8073
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/887a8073
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/887a8073

Branch: refs/heads/master
Commit: 887a80738ae3eb6544fd2fa305907c4cb0db1725
Parents: 78b432c b79d3ae
Author: Yakov Zhdanov <yz...@gridgain.com>
Authored: Mon Feb 16 15:59:19 2015 +0300
Committer: Yakov Zhdanov <yz...@gridgain.com>
Committed: Mon Feb 16 15:59:19 2015 +0300

----------------------------------------------------------------------

----------------------------------------------------------------------



[37/50] [abbrv] incubator-ignite git commit: Merge branch 'sprint-1' of https://git-wip-us.apache.org/repos/asf/incubator-ignite into sprint-1-release

Posted by vk...@apache.org.
Merge branch 'sprint-1' of https://git-wip-us.apache.org/repos/asf/incubator-ignite into sprint-1-release


Project: http://git-wip-us.apache.org/repos/asf/incubator-ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-ignite/commit/397b730e
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/397b730e
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/397b730e

Branch: refs/heads/master
Commit: 397b730e0779687b618ab73e49e618f7e0398fae
Parents: 42fa6d3 f27a989
Author: Yakov Zhdanov <yz...@gridgain.com>
Authored: Mon Feb 16 16:48:02 2015 +0300
Committer: Yakov Zhdanov <yz...@gridgain.com>
Committed: Mon Feb 16 16:48:02 2015 +0300

----------------------------------------------------------------------
 assembly/docfiles/tools.js                      |   30 -
 .../examples/datagrid/CacheQueryExample.java    |   31 +-
 .../starschema/CacheStarSchemaExample.java      |   11 +-
 .../datastructures/IgniteQueueExample.java      |    2 +-
 .../examples/ScalarCacheAffinityExample1.scala  |    6 +-
 .../examples/ScalarCacheAffinityExample2.scala  |    4 +-
 .../ScalarCacheAffinitySimpleExample.scala      |   10 +-
 .../scalar/examples/ScalarCacheExample.scala    |   49 +-
 .../ScalarCachePopularNumbersExample.scala      |   13 +-
 .../examples/ScalarCacheQueryExample.scala      |   48 +-
 .../examples/ScalarSnowflakeSchemaExample.scala |   37 +-
 .../clients/src/test/resources/spring-cache.xml |   12 -
 .../src/test/resources/spring-server-node.xml   |   21 -
 .../test/resources/spring-server-ssl-node.xml   |   20 +-
 .../src/main/java/org/apache/ignite/Ignite.java |   27 -
 .../java/org/apache/ignite/IgniteCache.java     |    4 +-
 .../apache/ignite/IgniteSystemProperties.java   |  120 --
 .../apache/ignite/cache/CacheInterceptor.java   |    1 +
 .../apache/ignite/cache/CacheProjection.java    | 1925 -----------------
 .../java/org/apache/ignite/cache/GridCache.java |    1 +
 .../configuration/CacheConfiguration.java       |    1 +
 .../configuration/IgniteConfiguration.java      |  353 ---
 .../ignite/internal/GridKernalContext.java      |    8 -
 .../ignite/internal/GridKernalContextImpl.java  |   12 -
 .../ignite/internal/IgniteComponentType.java    |    7 -
 .../org/apache/ignite/internal/IgniteEx.java    |   12 -
 .../apache/ignite/internal/IgniteKernal.java    |  217 +-
 .../org/apache/ignite/internal/IgnitionEx.java  |   49 -
 .../internal/processors/cache/CacheFlag.java    |    6 +-
 .../processors/cache/CacheProjection.java       | 1925 +++++++++++++++++
 .../processors/cache/GridCacheAdapter.java      |    4 +-
 .../cache/GridCacheDeploymentManager.java       |   33 +-
 .../processors/cache/GridCacheMapAdapter.java   |    1 -
 .../processors/cache/GridCachePeekMode.java     |    2 +-
 .../processors/cache/GridCacheProjectionEx.java |    1 -
 .../cache/query/GridCacheQueriesProxy.java      |    1 -
 .../continuous/CacheContinuousQueryManager.java |   49 +-
 .../datastructures/GridCacheAtomicLongImpl.java |    1 -
 .../GridCacheAtomicReferenceImpl.java           |    1 -
 .../GridCacheAtomicSequenceImpl.java            |    1 -
 .../GridCacheAtomicStampedImpl.java             |    1 -
 .../GridCacheCountDownLatchImpl.java            |    1 -
 .../processors/email/GridEmailHolder.java       |  111 -
 .../email/IgniteEmailProcessorAdapter.java      |   84 -
 .../email/IgniteNoopEmailProcessor.java         |   55 -
 .../internal/processors/email/package.html      |   24 -
 .../visor/node/VisorEmailConfiguration.java     |  177 --
 .../visor/node/VisorGridConfiguration.java      |   18 -
 .../visor/node/VisorLifecycleConfiguration.java |   19 -
 .../internal/visor/query/VisorQueryTask.java    |    1 +
 .../ignite/startup/BasicWarmupClosure.java      |    6 +-
 .../apache/ignite/transactions/Transaction.java |    3 +-
 .../GridCacheFieldsQueryNoDataSelfTest.java     |    4 +-
 .../cache/GridCacheOffHeapSelfTest.java         |    4 +-
 .../cache/GridCacheSwapPreloadSelfTest.java     |    3 +-
 .../IgniteClientAffinityAssignmentSelfTest.java |    5 +-
 .../cache/IgnitePutAllLargeBatchSelfTest.java   |    8 +-
 ...tAllUpdateNonPreloadedPartitionSelfTest.java |    4 +-
 .../cache/IgniteTxMultiNodeAbstractTest.java    |    3 +-
 ...dCacheMultithreadedFailoverAbstractTest.java |    3 +-
 .../GridCacheNodeFailureAbstractTest.java       |    3 +-
 ...chePartitionedReloadAllAbstractSelfTest.java |    8 +-
 ...ridCacheContinuousQueryAbstractSelfTest.java |    4 +-
 ...dCacheAbstractReduceFieldsQuerySelfTest.java |    5 +-
 .../GridDataLoaderProcessorSelfTest.java        |    2 +-
 .../processors/igfs/IgfsCacheSelfTest.java      |    5 +-
 .../ignite/testframework/junits/IgniteMock.java |   10 -
 modules/email/licenses/apache-2.0.txt           |  202 --
 modules/email/pom.xml                           |   51 -
 modules/email/readme.txt                        |   34 -
 .../processors/email/IgniteEmailProcessor.java  |  296 ---
 .../hadoop/jobtracker/GridHadoopJobTracker.java |    1 -
 ...idHadoopDefaultMapReducePlannerSelfTest.java |   10 -
 .../GridHibernateAccessStrategyAdapter.java     |    2 +-
 ...idHibernateL2CacheConfigurationSelfTest.java |    3 +-
 .../hibernate/GridHibernateL2CacheSelfTest.java |    3 +-
 .../GridCacheAbstractFieldsQuerySelfTest.java   |    3 +-
 .../cache/GridCacheAbstractQuerySelfTest.java   |    5 +-
 .../cache/GridCacheCrossCacheQuerySelfTest.java |   12 +-
 .../GridCacheCrossCacheQuerySelfTestNewApi.java |    7 +-
 .../cache/GridCacheOffHeapAndSwapSelfTest.java  |    3 +-
 .../processors/cache/GridCacheSwapSelfTest.java |    4 +-
 .../near/GridCachePartitionedQuerySelfTest.java |    2 +-
 .../GridCacheReplicatedQuerySelfTest.java       |    6 +-
 .../ignite/scalar/ScalarConversions.scala       |   47 +-
 .../ignite/scalar/pimps/ScalarCachePimp.scala   |  662 +++++-
 .../pimps/ScalarCacheProjectionPimp.scala       | 2004 ------------------
 .../scala/org/apache/ignite/scalar/scalar.scala |   25 +-
 .../tests/ScalarAffinityRoutingSpec.scala       |   12 +-
 .../scalar/tests/ScalarCacheQueriesSpec.scala   |  466 +---
 .../ignite/scalar/tests/ScalarCacheSpec.scala   |   10 +-
 .../org/apache/ignite/IgniteSpringBean.java     |   20 +-
 .../apache/ignite/cache/spring/SpringCache.java |    2 +-
 .../ignite/cache/spring/SpringCacheManager.java |    2 +-
 .../commands/alert/VisorAlertCommand.scala      |   83 +-
 .../config/VisorConfigurationCommand.scala      |   15 -
 .../commands/alert/VisorAlertCommandSpec.scala  |    1 -
 .../config/VisorConfigurationCommandSpec.scala  |    1 -
 .../disco/VisorDiscoveryCommandSpec.scala       |    1 -
 .../events/VisorEventsCommandSpec.scala         |    1 -
 .../visor/commands/gc/VisorGcCommandSpec.scala  |    1 -
 .../commands/tasks/VisorTasksCommandSpec.scala  |    2 -
 pom.xml                                         |    1 -
 103 files changed, 2869 insertions(+), 6758 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/397b730e/pom.xml
----------------------------------------------------------------------


[10/50] [abbrv] incubator-ignite git commit: minor - removed organization

Posted by vk...@apache.org.
minor - removed organization


Project: http://git-wip-us.apache.org/repos/asf/incubator-ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-ignite/commit/2c1ba55a
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/2c1ba55a
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/2c1ba55a

Branch: refs/heads/master
Commit: 2c1ba55a81304652acc64908cf681066cc5c853c
Parents: 89b5476
Author: Yakov Zhdanov <yz...@gridgain.com>
Authored: Mon Feb 16 14:51:19 2015 +0300
Committer: Yakov Zhdanov <yz...@gridgain.com>
Committed: Mon Feb 16 14:51:19 2015 +0300

----------------------------------------------------------------------
 pom.xml | 7 -------
 1 file changed, 7 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/2c1ba55a/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
index 9e1d29f..14fd9e3 100644
--- a/pom.xml
+++ b/pom.xml
@@ -84,43 +84,36 @@
             <id>dsetrakyan</id>
             <name>Dmitriy Setrakyan</name>
             <email>dsetrakyan at apache dot org</email>
-            <organization>GridGain</organization>
         </developer>
         <developer>
             <id>agoncharuk</id>
             <name>Alexey Goncharuk</name>
             <email>agoncharuk at apache dot org</email>
-            <organization>GridGain</organization>
         </developer>
         <developer>
             <id>vkulichenko</id>
             <name>Valentin Kulichenko</name>
             <email>vkulichenko at apache dot org</email>
-            <organization>GridGain</organization>
         </developer>
         <developer>
             <id>svladykin</id>
             <name>Sergi Vladykin</name>
             <email>sergi dot vladykin at gmail dot com</email>
-            <organization>GridGain</organization>
         </developer>
         <developer>
             <id>yzhdanov</id>
             <name>Yakov Zhdanov</name>
             <email>yzhdanov at apache dot org</email>
-            <organization>GridGain</organization>
         </developer>
         <developer>
             <id>sboikov</id>
             <name>Semyon Boikov</name>
             <email>sboikov at gridgain dot com</email>
-            <organization>GridGain</organization>
         </developer>
         <developer>
             <id>vozerov</id>
             <name>Vladimir Ozerov</name>
             <email>vozerov at gridgain dot com</email>
-            <organization>GridGain</organization>
         </developer>
     </developers>
 


[04/50] [abbrv] incubator-ignite git commit: # ignite-204 : fix GridGain occurrences

Posted by vk...@apache.org.
# ignite-204 : fix GridGain occurrences


Project: http://git-wip-us.apache.org/repos/asf/incubator-ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-ignite/commit/d220443a
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/d220443a
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/d220443a

Branch: refs/heads/master
Commit: d220443a356676db07e9e05e27f670ca6212f210
Parents: 89b5476
Author: Artem Shutak <as...@gridgain.com>
Authored: Mon Feb 16 13:57:10 2015 +0300
Committer: Artem Shutak <as...@gridgain.com>
Committed: Mon Feb 16 13:57:10 2015 +0300

----------------------------------------------------------------------
 .../org/apache/ignite/examples/datagrid/CacheQueryExample.java | 6 +++---
 pom.xml                                                        | 2 +-
 2 files changed, 4 insertions(+), 4 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/d220443a/examples/src/main/java/org/apache/ignite/examples/datagrid/CacheQueryExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/datagrid/CacheQueryExample.java b/examples/src/main/java/org/apache/ignite/examples/datagrid/CacheQueryExample.java
index e041244..4cfba44 100644
--- a/examples/src/main/java/org/apache/ignite/examples/datagrid/CacheQueryExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/datagrid/CacheQueryExample.java
@@ -144,8 +144,8 @@ public class CacheQueryExample {
             + "and lower(Organization.name) = lower(?)";
 
         // Execute queries for find employees for different organizations.
-        print("Following people are 'GridGain' employees: ",
-            cache.query(sql(Person.class, joinSql).setArgs("GridGain")).getAll());
+        print("Following people are 'Ignite' employees: ",
+            cache.query(sql(Person.class, joinSql).setArgs("Ignite")).getAll());
         print("Following people are 'Other' employees: ",
             cache.query(sql(Person.class, joinSql).setArgs("Other")).getAll());
     }
@@ -222,7 +222,7 @@ public class CacheQueryExample {
         IgniteCache cache = Ignition.ignite().jcache(CACHE_NAME);
 
         // Organizations.
-        Organization org1 = new Organization("GridGain");
+        Organization org1 = new Organization("Ignite");
         Organization org2 = new Organization("Other");
 
         // People.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/d220443a/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
index 9e1d29f..51c3365 100644
--- a/pom.xml
+++ b/pom.xml
@@ -1012,7 +1012,7 @@
                                         </group>
                                         <group>
                                             <title>Visor Plugins</title>
-                                            <packages>org.gridgain.visor.plugin</packages>
+                                            <packages>org.apache.ignite.visor.plugin</packages>
                                         </group>
                                         <group>
                                             <title>Spring Caching</title>


[20/50] [abbrv] incubator-ignite git commit: IGNITE-261 Fixes after merge.

Posted by vk...@apache.org.
 IGNITE-261 Fixes after merge.


Project: http://git-wip-us.apache.org/repos/asf/incubator-ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-ignite/commit/45679252
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/45679252
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/45679252

Branch: refs/heads/master
Commit: 4567925220c448eb101b1c7be97df80988046a33
Parents: d13fcd0
Author: AKuznetsov <ak...@gridgain.com>
Authored: Mon Feb 16 19:56:27 2015 +0700
Committer: AKuznetsov <ak...@gridgain.com>
Committed: Mon Feb 16 19:56:27 2015 +0700

----------------------------------------------------------------------
 .../examples/ScalarCacheQueryExample.scala      |  4 ++-
 .../pimps/ScalarCacheConfigurationHelper.java   | 33 --------------------
 .../ignite/scalar/pimps/ScalarCachePimp.scala   |  5 ---
 3 files changed, 3 insertions(+), 39 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/45679252/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCacheQueryExample.scala
----------------------------------------------------------------------
diff --git a/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCacheQueryExample.scala b/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCacheQueryExample.scala
index 6d40544..9de8954 100644
--- a/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCacheQueryExample.scala
+++ b/examples/src/main/scala/org/apache/ignite/scalar/examples/ScalarCacheQueryExample.scala
@@ -17,6 +17,8 @@
 
 package org.apache.ignite.scalar.examples
 
+import org.apache.ignite.configuration.CacheConfiguration
+
 import java.util._
 
 import org.apache.ignite.{IgniteCache, Ignite}
@@ -64,7 +66,7 @@ object ScalarCacheQueryExample {
         // Using distributed queries for partitioned cache and local queries for replicated cache.
         // Since in replicated caches data is available on all nodes, including local one,
         // it is enough to just query the local node.
-        val prj = if (cache$(CACHE_NAME).get.configuration().getCacheMode == PARTITIONED)
+        val prj = if (cache.getConfiguration(classOf[CacheConfiguration[CacheAffinityKey[UUID], Person]]).getCacheMode == PARTITIONED)
             ignite.cluster().forRemotes()
         else
             ignite.cluster().forLocal()

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/45679252/modules/scalar/src/main/scala/org/apache/ignite/scalar/pimps/ScalarCacheConfigurationHelper.java
----------------------------------------------------------------------
diff --git a/modules/scalar/src/main/scala/org/apache/ignite/scalar/pimps/ScalarCacheConfigurationHelper.java b/modules/scalar/src/main/scala/org/apache/ignite/scalar/pimps/ScalarCacheConfigurationHelper.java
deleted file mode 100644
index 55a4ab6..0000000
--- a/modules/scalar/src/main/scala/org/apache/ignite/scalar/pimps/ScalarCacheConfigurationHelper.java
+++ /dev/null
@@ -1,33 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-package org.apache.ignite.scalar.pimps;
-
-import org.apache.ignite.*;
-import org.apache.ignite.configuration.*;
-
-/**
- * TODO: Add class description.
- */
-public class ScalarCacheConfigurationHelper {
-    /**
-     * @param cache Cache.
-     */
-    public static CacheConfiguration extract(IgniteCache cache) {
-        return (CacheConfiguration)cache.getConfiguration(CacheConfiguration.class);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/45679252/modules/scalar/src/main/scala/org/apache/ignite/scalar/pimps/ScalarCachePimp.scala
----------------------------------------------------------------------
diff --git a/modules/scalar/src/main/scala/org/apache/ignite/scalar/pimps/ScalarCachePimp.scala b/modules/scalar/src/main/scala/org/apache/ignite/scalar/pimps/ScalarCachePimp.scala
index 05a5e2b..42bd716 100644
--- a/modules/scalar/src/main/scala/org/apache/ignite/scalar/pimps/ScalarCachePimp.scala
+++ b/modules/scalar/src/main/scala/org/apache/ignite/scalar/pimps/ScalarCachePimp.scala
@@ -18,13 +18,11 @@
 package org.apache.ignite.scalar.pimps
 
 import org.apache.ignite.cache.query._
-import org.apache.ignite.configuration.CacheConfiguration
 
 import javax.cache.Cache
 
 import org.apache.ignite._
 import org.apache.ignite.lang.{IgnitePredicate, IgniteReducer}
-import org.apache.ignite.scalar.pimps.ScalarCacheConfigurationHelper._
 import org.apache.ignite.scalar.scalar._
 import org.jetbrains.annotations.Nullable
 
@@ -33,7 +31,6 @@ import java.util.{List => JavaList, Set => JavaSet}
 import scala.collection._
 import scala.collection.JavaConversions._
 
-
 /**
  * Companion object.
  */
@@ -97,8 +94,6 @@ with Iterable[Cache.Entry[K, V]] with Ordered[IgniteCache[K, V]] {
      */
     def compare(that: IgniteCache[K, V]): Int = that.getName.compareTo(value.getName)
 
-    def configuration(): CacheConfiguration = extract(value)
-
     /**
      * Gets iterator for cache entries.
      */


[22/50] [abbrv] incubator-ignite git commit: Merge branches 'ignite-public-api-cleanup' and 'sprint-1' of https://git-wip-us.apache.org/repos/asf/incubator-ignite into ignite-public-api-cleanup

Posted by vk...@apache.org.
Merge branches 'ignite-public-api-cleanup' and 'sprint-1' of https://git-wip-us.apache.org/repos/asf/incubator-ignite into ignite-public-api-cleanup


Project: http://git-wip-us.apache.org/repos/asf/incubator-ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-ignite/commit/78b432c8
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/78b432c8
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/78b432c8

Branch: refs/heads/master
Commit: 78b432c8b852cdb425c0c8d97ebb9210884b0df4
Parents: 4567925 d7f173c
Author: Yakov Zhdanov <yz...@gridgain.com>
Authored: Mon Feb 16 15:58:26 2015 +0300
Committer: Yakov Zhdanov <yz...@gridgain.com>
Committed: Mon Feb 16 15:58:26 2015 +0300

----------------------------------------------------------------------
 .../processors/cache/GridCacheAdapter.java      |  2 +-
 .../cache/GridCacheDeploymentManager.java       | 33 +++++++++-----------
 2 files changed, 16 insertions(+), 19 deletions(-)
----------------------------------------------------------------------



[45/50] [abbrv] incubator-ignite git commit: # sprint-1 -release notes and readme.

Posted by vk...@apache.org.
# sprint-1 -release notes and readme.


Project: http://git-wip-us.apache.org/repos/asf/incubator-ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-ignite/commit/659b4329
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/659b4329
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/659b4329

Branch: refs/heads/master
Commit: 659b4329fb8936d2955a441281359274b25ee8fb
Parents: b5e8971
Author: Dmitiry Setrakyan <ds...@gridgain.com>
Authored: Mon Feb 16 11:19:31 2015 -0800
Committer: Dmitiry Setrakyan <ds...@gridgain.com>
Committed: Mon Feb 16 11:19:31 2015 -0800

----------------------------------------------------------------------
 docs/ignite_readme.md  |  12 ++++++------
 docs/ignite_readme.pdf | Bin 76810 -> 77136 bytes
 docs/release_notes.md  |  16 ++++++++++++++++
 docs/release_notes.pdf | Bin 19018 -> 33174 bytes
 4 files changed, 22 insertions(+), 6 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/659b4329/docs/ignite_readme.md
----------------------------------------------------------------------
diff --git a/docs/ignite_readme.md b/docs/ignite_readme.md
index a238109..58de4fc 100644
--- a/docs/ignite_readme.md
+++ b/docs/ignite_readme.md
@@ -10,14 +10,14 @@ Ignite In-Memory Data Fabric is designed to deliver uncompromised performance fo
 
 Following main components are included in the fabric:
 * `Advanced Clustering` - support for auto-discovery of cluster nodes in any environment, including, public clouds (e.g. AWS), private clouds, or hybrid clouds.
+* `Compute Grid` - includes distributed clustering, messaging, events, and computational features.
+* `Data Grid` - partitioned in-memory key-value store with support for ACID transactions, off-heap memory, SQL, and more.
+* `Service Grid` - support for managed user-defined services, like cluster singletons, node-singletons, and services with custom deployment topology.
+* `Distributed Data Structures` - support for common distributed data structures, like maps, sets, queues, atomics, etc.
+* `Streaming & CEP` - supports event workflow, rolling data windows and indexing, continuous querying, and more.
+* `Distributed Filesystem` - distributed Hadoop-compliant in-memory file system.
 * `Distributed Messaging` - support for topic-based and point-to-point message exchange between cluster nodes.
 * `Distributed Events` - support for cluster-wide event notifications.
-* `Managed Services` - support for managed user-defined services, like cluster singletons, node-singletons, and services with custom deployment topology.
-* `Distributed Data Structures` - support for common distributed data structures, like maps, sets, queues, atomics, etc.
-* `In-Memory Compute Grid` - includes distributed clustering, messaging, events, and computational features.
-* `In-Memory Data Grid` - partitioned in-memory key-value store with support for ACID transactions, off-heap memory, SQL, and more.
-* `In-Memory Streaming` - supports event workflow, rolling data windows and indexing, continuous querying, and more.
-* `In-Memory Filesystem` - distributed Hadoop-compliant in-memory file system.
 
 ## 2. Apache Ignite Installation
 Ignite distribution comes in a ZIP file that simply needs to be unzipped, and `IGNITE_HOME` environment variable can optionally be set to point to it.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/659b4329/docs/ignite_readme.pdf
----------------------------------------------------------------------
diff --git a/docs/ignite_readme.pdf b/docs/ignite_readme.pdf
index c270d15..175d59b 100644
Binary files a/docs/ignite_readme.pdf and b/docs/ignite_readme.pdf differ

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/659b4329/docs/release_notes.md
----------------------------------------------------------------------
diff --git a/docs/release_notes.md b/docs/release_notes.md
new file mode 100755
index 0000000..592c7f3
--- /dev/null
+++ b/docs/release_notes.md
@@ -0,0 +1,16 @@
+<center>
+![Ignite Logo](https://ignite.incubator.apache.org/images/logo3.png "Ignite Logo")
+</center>
+##Apache Ignite In-Memory Data Fabric 1.0
+This is the first release of Apache Ignite project. The source code is based on the 7 year old GridGain In-Memory Data Fabric, open source edition, v. 6.6.2, which was donated to Apache Software Foundation in September 2014.
+
+The main feature set of Ignite In-Memory Data Fabric includes:
+* Advanced Clustering
+* Compute Grid
+* Data Grid
+* Service Grid
+* IGFS - Ignite File System
+* Distributed Data Structures
+* Distributed Messaging
+* Distributed Events
+* Streaming & CEP
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/659b4329/docs/release_notes.pdf
----------------------------------------------------------------------
diff --git a/docs/release_notes.pdf b/docs/release_notes.pdf
index fe5e307..f08bba5 100644
Binary files a/docs/release_notes.pdf and b/docs/release_notes.pdf differ


[27/50] [abbrv] incubator-ignite git commit: sprint-1

Posted by vk...@apache.org.
sprint-1


Project: http://git-wip-us.apache.org/repos/asf/incubator-ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-ignite/commit/d7866660
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/d7866660
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/d7866660

Branch: refs/heads/master
Commit: d78666605989c9e23250726e5fed513fa5bbe215
Parents: 3ba4f3c
Author: Yakov Zhdanov <yz...@gridgain.com>
Authored: Mon Feb 16 16:23:28 2015 +0300
Committer: Yakov Zhdanov <yz...@gridgain.com>
Committed: Mon Feb 16 16:23:28 2015 +0300

----------------------------------------------------------------------
 .../apache/ignite/examples/datastructures/IgniteQueueExample.java  | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/d7866660/examples/src/main/java/org/apache/ignite/examples/datastructures/IgniteQueueExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/datastructures/IgniteQueueExample.java b/examples/src/main/java/org/apache/ignite/examples/datastructures/IgniteQueueExample.java
index df043c8..4219dd1 100644
--- a/examples/src/main/java/org/apache/ignite/examples/datastructures/IgniteQueueExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/datastructures/IgniteQueueExample.java
@@ -121,7 +121,7 @@ public class IgniteQueueExample {
         final String queueName = queue.name();
 
         // Write queue items on each node.
-        ignite.compute().run(new QueueClosure(queueName, true));
+        ignite.compute().broadcast(new QueueClosure(queueName, true));
 
         System.out.println("Queue size after writing [expected=" + ignite.cluster().nodes().size() * RETRIES +
             ", actual=" + queue.size() + ']');


[38/50] [abbrv] incubator-ignite git commit: # sprint-1 restored check that queue can not be used with atomic cache in CLOCK mode

Posted by vk...@apache.org.
# sprint-1 restored check that queue can not be used with atomic cache in CLOCK mode


Project: http://git-wip-us.apache.org/repos/asf/incubator-ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-ignite/commit/59264704
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/59264704
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/59264704

Branch: refs/heads/master
Commit: 5926470450dfe799849f722dadf7e0a100fc6be0
Parents: f27a989
Author: sboikov <sb...@gridgain.com>
Authored: Mon Feb 16 17:12:03 2015 +0300
Committer: sboikov <sb...@gridgain.com>
Committed: Mon Feb 16 17:12:03 2015 +0300

----------------------------------------------------------------------
 .../datastructures/IgniteQueueExample.java      |  2 +-
 .../datastructures/DataStructuresProcessor.java | 15 ++++++-
 .../IgniteDataStructureUniqueNameTest.java      | 41 ++++++++++++++++++++
 3 files changed, 56 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/59264704/examples/src/main/java/org/apache/ignite/examples/datastructures/IgniteQueueExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/datastructures/IgniteQueueExample.java b/examples/src/main/java/org/apache/ignite/examples/datastructures/IgniteQueueExample.java
index 4219dd1..519d11a 100644
--- a/examples/src/main/java/org/apache/ignite/examples/datastructures/IgniteQueueExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/datastructures/IgniteQueueExample.java
@@ -36,7 +36,7 @@ import java.util.*;
  */
 public class IgniteQueueExample {
     /** Cache name. */
-    private static final String CACHE_NAME = "partitioned";
+    private static final String CACHE_NAME = "partitioned_tx";
 
     /** Number of retries */
     private static final int RETRIES = 20;

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/59264704/modules/core/src/main/java/org/apache/ignite/internal/processors/datastructures/DataStructuresProcessor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/datastructures/DataStructuresProcessor.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/datastructures/DataStructuresProcessor.java
index 2b55ec5..a2d69fb 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/datastructures/DataStructuresProcessor.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/datastructures/DataStructuresProcessor.java
@@ -38,6 +38,7 @@ import java.io.*;
 import java.util.*;
 import java.util.concurrent.*;
 
+import static org.apache.ignite.cache.CacheAtomicWriteOrderMode.*;
 import static org.apache.ignite.internal.processors.cache.CacheFlag.*;
 import static org.apache.ignite.internal.processors.cache.GridCacheOperation.*;
 import static org.apache.ignite.internal.processors.datastructures.DataStructuresProcessor.DataStructureType.*;
@@ -690,6 +691,8 @@ public final class DataStructuresProcessor extends GridProcessorAdapter {
 
             if (ctx.cache().publicCache(cfg.getCacheName()) == null)
                 throw new IgniteCheckedException("Cache for collection is not configured: " + cfg.getCacheName());
+
+            checkSupportsQueue(ctx.cache().internalCache(cfg.getCacheName()).context());
         }
 
         DataStructureInfo dsInfo = new DataStructureInfo(name,
@@ -1191,6 +1194,16 @@ public final class DataStructuresProcessor extends GridProcessorAdapter {
     }
 
     /**
+     * @param cctx Cache context.
+     * @throws IgniteCheckedException If {@link IgniteQueue} can with given cache.
+     */
+    private void checkSupportsQueue(GridCacheContext cctx) throws IgniteCheckedException {
+        if (cctx.atomic() && !cctx.isLocal() && cctx.config().getAtomicWriteOrderMode() == CLOCK)
+            throw new IgniteCheckedException("IgniteQueue can not be used with ATOMIC cache with CLOCK write order mode" +
+                " (change write order mode to PRIMARY in configuration)");
+    }
+
+    /**
      *
      */
     static enum DataStructureType {
@@ -1261,7 +1274,7 @@ public final class DataStructuresProcessor extends GridProcessorAdapter {
             // No-op.
         }
 
-        /*
+        /**
          * @param cacheName Collection cache name.
          * @param collocated Collocated flag.
          */

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/59264704/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/datastructures/IgniteDataStructureUniqueNameTest.java
----------------------------------------------------------------------
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/datastructures/IgniteDataStructureUniqueNameTest.java b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/datastructures/IgniteDataStructureUniqueNameTest.java
index 92b88ff..7e5d603 100644
--- a/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/datastructures/IgniteDataStructureUniqueNameTest.java
+++ b/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/datastructures/IgniteDataStructureUniqueNameTest.java
@@ -28,13 +28,18 @@ import java.io.*;
 import java.util.*;
 import java.util.concurrent.*;
 
+import static org.apache.ignite.cache.CacheAtomicWriteOrderMode.*;
 import static org.apache.ignite.cache.CacheAtomicityMode.*;
 import static org.apache.ignite.cache.CacheMode.*;
+import static org.apache.ignite.cache.CacheWriteSynchronizationMode.*;
 
 /**
  *
  */
 public class IgniteDataStructureUniqueNameTest extends IgniteCollectionAbstractTest {
+    /** */
+    private static final String ATOMIC_CLOCK_CACHE_NAME = "atomicClockCache";
+
     /** {@inheritDoc} */
     @Override protected int gridCount() {
         return 3;
@@ -61,12 +66,48 @@ public class IgniteDataStructureUniqueNameTest extends IgniteCollectionAbstractT
 
         cfg.setAtomicConfiguration(atomicCfg);
 
+        CacheConfiguration[] ccfgs = cfg.getCacheConfiguration();
+
+        assert ccfgs.length == 1 : ccfgs.length;
+
+        CacheConfiguration ccfg = new CacheConfiguration();
+
+        ccfg.setCacheMode(PARTITIONED);
+        ccfg.setName(ATOMIC_CLOCK_CACHE_NAME);
+        ccfg.setAtomicityMode(ATOMIC);
+        ccfg.setAtomicWriteOrderMode(CLOCK);
+        ccfg.setWriteSynchronizationMode(FULL_SYNC);
+
+        cfg.setCacheConfiguration(ccfgs[0], ccfg);
+
         return cfg;
     }
 
     /**
      * @throws Exception If failed.
      */
+    public void testQueueAtomicClockCache() throws Exception {
+        final String queueName = "testQueueAtomicClockCache";
+
+        GridTestUtils.assertThrows(log, new Callable<Void>() {
+            @Override public Void call() throws Exception {
+                CollectionConfiguration colCfg = new CollectionConfiguration();
+
+                colCfg.setCacheName(ATOMIC_CLOCK_CACHE_NAME);
+
+                ignite(0).queue(queueName, 0, colCfg);
+
+                return null;
+            }
+        }, IgniteException.class, "IgniteQueue can not be used with ATOMIC cache with CLOCK write order mode " +
+            "(change write order mode to PRIMARY in configuration)");
+
+        assertNull(ignite(0).queue(queueName, 0, null));
+    }
+
+    /**
+     * @throws Exception If failed.
+     */
     public void testUniqueNameMultithreaded() throws Exception {
         testUniqueName(true);
     }


[35/50] [abbrv] incubator-ignite git commit: sprint-1: moved cache projection to internal

Posted by vk...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f27a989c/modules/core/src/main/java/org/apache/ignite/cache/CacheProjection.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/cache/CacheProjection.java b/modules/core/src/main/java/org/apache/ignite/cache/CacheProjection.java
deleted file mode 100644
index e26add4..0000000
--- a/modules/core/src/main/java/org/apache/ignite/cache/CacheProjection.java
+++ /dev/null
@@ -1,1925 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-package org.apache.ignite.cache;
-
-import org.apache.ignite.*;
-import org.apache.ignite.cache.store.*;
-import org.apache.ignite.cluster.*;
-import org.apache.ignite.internal.*;
-import org.apache.ignite.internal.processors.cache.*;
-import org.apache.ignite.internal.processors.cache.query.*;
-import org.apache.ignite.internal.processors.cache.transactions.*;
-import org.apache.ignite.lang.*;
-import org.apache.ignite.transactions.*;
-import org.jetbrains.annotations.*;
-
-import javax.cache.*;
-import java.sql.*;
-import java.util.*;
-import java.util.Date;
-import java.util.concurrent.*;
-
-/**
- * This interface provides a rich API for working with distributed caches. It includes the following
- * main functionality:
- * <ul>
- * <li>
- *  Various {@code 'get(..)'} methods to synchronously or asynchronously get values from cache.
- *  All {@code 'get(..)'} methods are transactional and will participate in an ongoing transaction
- *  if there is one.
- * </li>
- * <li>
- *  Various {@code 'put(..)'}, {@code 'putIfAbsent(..)'}, and {@code 'replace(..)'} methods to
- *  synchronously or asynchronously put single or multiple entries into cache.
- *  All these methods are transactional and will participate in an ongoing transaction
- *  if there is one.
- * </li>
- * <li>
- *  Various {@code 'remove(..)'} methods to synchronously or asynchronously remove single or multiple keys
- *  from cache. All {@code 'remove(..)'} methods are transactional and will participate in an ongoing transaction
- *  if there is one.
- * </li>
- * <li>
- *  Various {@code 'contains(..)'} method to check if cache contains certain keys or values locally.
- * </li>
- * <li>
- *  Various {@code 'forEach(..)'}, {@code 'forAny(..)'}, and {@code 'reduce(..)'} methods to visit
- *  every local cache entry within this projection.
- * </li>
- * <li>
- *  Various {@code flagsOn(..)'}, {@code 'flagsOff(..)'}, and {@code 'projection(..)'} methods to
- *  set specific flags and filters on a cache projection.
- * </li>
- * <li>
- *  Methods like {@code 'keySet(..)'}, {@code 'values(..)'}, and {@code 'entrySet(..)'} to provide
- *  views on cache keys, values, and entries.
- * </li>
- * <li>
- *  Various {@code 'peek(..)'} methods to peek at values in global or transactional memory, swap
- *  storage, or persistent storage.
- * </li>
- * <li>
- *  Various {@code 'reload(..)'} methods to reload latest values from persistent storage.
- * </li>
- * <li>
- *  Various {@code 'promote(..)'} methods to load specified keys from swap storage into
- *  global cache memory.
- * </li>
- * <li>
- *  Various {@code 'lock(..)'}, {@code 'unlock(..)'}, and {@code 'isLocked(..)'} methods to acquire, release,
- *  and check on distributed locks on a single or multiple keys in cache. All locking methods
- *  are not transactional and will not enlist keys into ongoing transaction, if any.
- * </li>
- * <li>
- *  Various {@code 'clear(..)'} methods to clear elements from cache, and optionally from
- *  swap storage. All {@code 'clear(..)'} methods are not transactional and will not enlist cleared
- *  keys into ongoing transaction, if any.
- * </li>
- * <li>
- *  Various {@code 'evict(..)'} methods to evict elements from cache, and optionally store
- *  them in underlying swap storage for later access. All {@code 'evict(..)'} methods are not
- *  transactional and will not enlist evicted keys into ongoing transaction, if any.
- * </li>
- * <li>
- *  Various {@code 'txStart(..)'} methods to perform various cache
- *  operations within a transaction (see {@link Transaction} for more information).
- * </li>
- * <li>
- *  {@link #queries()} method to get an instance of {@link CacheQueries} service for working
- *  with distributed cache queries.
- * </li>
- * <li>
- *  Various {@code 'gridProjection(..)'} methods which provide {@link org.apache.ignite.cluster.ClusterGroup} only
- *  for nodes on which given keys reside. All {@code 'gridProjection(..)'} methods are not
- *  transactional and will not enlist keys into ongoing transaction.
- * </li>
- * <li>Method {@link GridCache#toMap()} to convert this interface into standard Java {@link ConcurrentMap} interface.
- * </ul>
- * <h1 class="header">Extended Put And Remove Methods</h1>
- * All methods that end with {@code 'x'} provide the same functionality as their sibling
- * methods that don't end with {@code 'x'}, however instead of returning a previous value they
- * return a {@code boolean} flag indicating whether operation succeeded or not. Returning
- * a previous value may involve a network trip or a persistent store lookup and should be
- * avoided whenever not needed.
- * <h1 class="header">Predicate Filters</h1>
- * All filters passed into methods on this API are checked <b>atomically</b>. In other words the
- * value returned by the methods is guaranteed to be consistent with the filters passed in. Note
- * that filters are optional, and if not passed in, then methods will still work as is without
- * filter validation.
- * <h1 class="header">Transactions</h1>
- * Cache API supports distributed transactions. All {@code 'get(..)'}, {@code 'put(..)'}, {@code 'replace(..)'},
- * and {@code 'remove(..)'} operations are transactional and will participate in an ongoing transaction,
- * if any. Other methods like {@code 'peek(..)'} or various {@code 'contains(..)'} methods may
- * be transaction-aware, i.e. check in-transaction entries first, but will not affect the current
- * state of transaction. See {@link Transaction} documentation for more information
- * about transactions.
- * <h1 class="header">Group Locking</h1>
- * <i>Group Locking</i> is a feature where instead of acquiring individual locks, Ignite will lock
- * multiple keys with one lock to save on locking overhead. There are 2 types of <i>Group Locking</i>:
- * <i>affinity-based</i>, and <i>partitioned-based</i>.
- * <p>
- * With {@code affinity-based-group-locking} the keys are grouped by <i>affinity-key</i>. This means that
- * only keys with identical affinity-key (see {@link org.apache.ignite.cache.affinity.CacheAffinityKeyMapped}) can participate in the
- * transaction, and only one lock on the <i>affinity-key</i> will be acquired for the whole transaction.
- * {@code Affinity-group-locked} transactions are started via
- * {@link #txStartAffinity(Object, TransactionConcurrency, TransactionIsolation, long, int)} method.
- * <p>
- * With {@code partition-based-group-locking} the keys are grouped by partition ID. This means that
- * only keys belonging to identical partition (see {@link org.apache.ignite.cache.affinity.CacheAffinity#partition(Object)}) can participate in the
- * transaction, and only one lock on the whole partition will be acquired for the whole transaction.
- * {@code Partition-group-locked} transactions are started via
- * {@link #txStartPartition(int, TransactionConcurrency, TransactionIsolation, long, int)} method.
- * <p>
- * <i>Group locking</i> should always be used for transactions whenever possible. If your requirements fit either
- * <i>affinity-based</i> or <i>partition-based</i> scenarios outlined above then <i>group-locking</i>
- * can significantly improve performance of your application, often by an order of magnitude.
- * <h1 class="header">Null Keys or Values</h1>
- * Neither {@code null} keys or values are allowed to be stored in cache. If a {@code null} value
- * happens to be in cache (e.g. after invalidation or remove), then cache will treat this case
- * as there is no value at all.
- * <h1 class="header">Peer Class Loading</h1>
- * If peer-class-loading is enabled, all classes passed into cache API will be automatically deployed
- * to any participating grid nodes. However, in case of redeployment, caches will be cleared and
- * all entries will be removed. This behavior is useful during development, but should not be
- * used in production.
- * <h1 class="header">Portable Objects</h1>
- * If an object is defined as portable Ignite cache will automatically store it in portable (i.e. binary)
- * format. User can choose to work either with the portable format or with the deserialized form (assuming
- * that class definitions are present in the classpath). By default, cache works with deserialized form
- * (example shows the case when {@link Integer} is used as a key for a portable object):
- * <pre>
- * CacheProjection<Integer, Value> prj = Ignition.grid().cache(null);
- *
- * // Value will be serialized and stored in cache in portable format.
- * prj.put(1, new Value());
- *
- * // Value will be deserialized since it's stored in portable format.
- * Value val = prj.get(1);
- * </pre>
- * You won't be able to work with deserialized form if class definition for the {@code Value} is not on
- * classpath. Even if you have the class definition, you should always avoid full deserialization if it's not
- * needed for performance reasons. To work with portable format directly you should create special projection
- * using {@link #keepPortable()} method:
- * <pre>
- * CacheProjection<Integer, GridPortableObject> prj = Ignition.grid().cache(null).keepPortable();
- *
- * // Value is not deserialized and returned in portable format.
- * GridPortableObject po = prj.get(1);
- * </pre>
- * See {@link #keepPortable()} method JavaDoc for more details.
- */
-public interface CacheProjection<K, V> extends Iterable<Cache.Entry<K, V>> {
-    /**
-     * Gets name of this cache ({@code null} for default cache).
-     *
-     * @return Cache name.
-     */
-    public String name();
-
-    /**
-     * Gets grid projection for this cache. This projection includes all nodes which have this cache configured.
-     *
-     * @return Projection instance.
-     */
-    public ClusterGroup gridProjection();
-
-    /**
-     * Gets base cache for this projection.
-     *
-     * @param <K1> Cache key type.
-     * @param <V1> Cache value type.
-     * @return Base cache for this projection.
-     */
-    @SuppressWarnings({"ClassReferencesSubclass"})
-    public <K1, V1> GridCache<K1, V1> cache();
-
-    /**
-     * Gets cache flags enabled on this projection.
-     *
-     * @return Flags for this projection (empty set if no flags have been set).
-     */
-    public Set<CacheFlag> flags();
-
-    /**
-     * Returns queries facade responsible for creating various SQL, TEXT, or SCAN queries.
-
-     * @return Queries facade responsible for creating various SQL, TEXT, or SCAN queries.
-     */
-    public CacheQueries<K, V> queries();
-
-    /**
-     * Gets cache projection only for given key and value type. Only {@code non-null} key-value
-     * pairs that have matching key and value pairs will be used in this projection.
-     *
-     * @param keyType Key type.
-     * @param valType Value type.
-     * @param <K1> Key type.
-     * @param <V1> Value type.
-     * @return Cache projection for given key and value types.
-     */
-    public <K1, V1> CacheProjection<K1, V1> projection(Class<? super K1> keyType, Class<? super V1> valType);
-
-    /**
-     * Gets cache projection based on given key-value predicate. Whenever makes sense,
-     * this predicate will be used to pre-filter cache operations. If
-     * operation passed pre-filtering, this filter will be passed through
-     * to cache operations as well.
-     * <p>
-     * For example, for {@link #putAll(Map, org.apache.ignite.lang.IgnitePredicate[])} method only
-     * elements that pass the filter will be given to {@code Cache.putAll(m, filter)}
-     * where it will be checked once again prior to put.
-     *
-     * @param p Key-value predicate for this projection. If {@code null}, then the
-     *      same projection is returned.
-     * @return Projection for given key-value predicate.
-     */
-    public CacheProjection<K, V> projection(@Nullable IgniteBiPredicate<K, V> p);
-
-    /**
-     * Gets cache projection based on given entry filter. This filter will be simply passed through
-     * to all cache operations on this projection. Unlike {@link #projection(org.apache.ignite.lang.IgniteBiPredicate)}
-     * method, this filter will <b>not</b> be used for pre-filtering.
-     *
-     * @param filter Filter to be passed through to all cache operations. If {@code null}, then the
-     *      same projection is returned.  If cache operation receives its own filter, then filters
-     *      will be {@code 'anded'}.
-     * @return Projection based on given filter.
-     */
-    public CacheProjection<K, V> projection(@Nullable IgnitePredicate<Cache.Entry<K, V>> filter);
-
-    /**
-     * Gets cache projection base on this one, but with the specified flags turned on.
-     * <h1 class="header">Cache Flags</h1>
-     * The resulting projection will inherit all the flags from this projection.
-     *
-     * @param flags Flags to turn on (if empty, then no-op).
-     * @return New projection based on this one, but with the specified flags turned on.
-     */
-    public CacheProjection<K, V> flagsOn(@Nullable CacheFlag... flags);
-
-    /**
-     * Gets cache projection base on this but with the specified flags turned off.
-     * <h1 class="header">Cache Flags</h1>
-     * The resulting projection will inherit all the flags from this projection except for
-     * the ones that were turned off.
-     *
-     * @param flags Flags to turn off (if empty, then all flags will be turned off).
-     * @return New projection based on this one, but with the specified flags turned off.
-     */
-    public CacheProjection<K, V> flagsOff(@Nullable CacheFlag... flags);
-
-    /**
-     * Creates projection that will operate with portable objects.
-     * <p>
-     * Projection returned by this method will force cache not to deserialize portable objects,
-     * so keys and values will be returned from cache API methods without changes. Therefore,
-     * signature of the projection can contain only following types:
-     * <ul>
-     *     <li>{@link org.gridgain.grid.portables.PortableObject} for portable classes</li>
-     *     <li>All primitives (byte, int, ...) and there boxed versions (Byte, Integer, ...)</li>
-     *     <li>Arrays of primitives (byte[], int[], ...)</li>
-     *     <li>{@link String} and array of {@link String}s</li>
-     *     <li>{@link UUID} and array of {@link UUID}s</li>
-     *     <li>{@link Date} and array of {@link Date}s</li>
-     *     <li>{@link Timestamp} and array of {@link Timestamp}s</li>
-     *     <li>Enums and array of enums</li>
-     *     <li>
-     *         Maps, collections and array of objects (but objects inside
-     *         them will still be converted if they are portable)
-     *     </li>
-     * </ul>
-     * <p>
-     * For example, if you use {@link Integer} as a key and {@code Value} class as a value
-     * (which will be stored in portable format), you should acquire following projection
-     * to avoid deserialization:
-     * <pre>
-     * CacheProjection<Integer, GridPortableObject> prj = cache.keepPortable();
-     *
-     * // Value is not deserialized and returned in portable format.
-     * GridPortableObject po = prj.get(1);
-     * </pre>
-     * <p>
-     * Note that this method makes sense only if cache is working in portable mode
-     * ({@link org.apache.ignite.configuration.CacheConfiguration#isPortableEnabled()} returns {@code true}. If not,
-     * this method is no-op and will return current projection.
-     *
-     * @return Projection for portable objects.
-     */
-    public <K1, V1> CacheProjection<K1, V1> keepPortable();
-
-    /**
-     * Returns {@code true} if this map contains no key-value mappings.
-     *
-     * @return {@code true} if this map contains no key-value mappings.
-     */
-    public boolean isEmpty();
-
-    /**
-     * Converts this API into standard Java {@link ConcurrentMap} interface.
-     *
-     * @return {@link ConcurrentMap} representation of given cache projection.
-     */
-    public ConcurrentMap<K, V> toMap();
-
-    /**
-     * @param key Key.
-     * @return {@code True} if cache contains mapping for a given key.
-     */
-    public boolean containsKey(K key);
-
-    /**
-     * @param key Key.
-     * @return Future.
-     */
-    public IgniteInternalFuture<Boolean> containsKeyAsync(K key);
-
-    /**
-     * @param keys Keys,
-     * @return {@code True} if cache contains all keys.
-     */
-    public boolean containsKeys(Collection<? extends K> keys);
-
-    /**
-     * @param keys Keys to check.
-     * @return Future.
-     */
-    public IgniteInternalFuture<Boolean> containsKeysAsync(Collection<? extends K> keys);
-
-    /**
-     * Returns {@code true} if this cache contains given value.
-     *
-     * @param val Value to check.
-     * @return {@code True} if given value is present in cache.
-     * @throws NullPointerException if the value is {@code null}.
-     */
-    public boolean containsValue(V val);
-
-    /**
-     * Executes visitor closure on each cache element.
-     * <h2 class="header">Transactions</h2>
-     * This method is not transactional and will not enlist keys into transaction simply
-     * because they were visited. However, if you perform transactional operations on the
-     * visited entries, those operations will enlist the entry into transaction.
-     *
-     * @param vis Closure which will be invoked for each cache entry.
-     */
-    public void forEach(IgniteInClosure<Cache.Entry<K, V>> vis);
-
-    /**
-     * Tests whether the predicate holds for all entries. If cache is empty,
-     * then {@code true} is returned.
-     * <h2 class="header">Transactions</h2>
-     * This method is not transactional and will not enlist keys into transaction simply
-     * because they were visited. However, if you perform transactional operations on the
-     * visited entries, those operations will enlist the entry into transaction.
-     *
-     * @param vis Predicate to test for each cache entry.
-     * @return {@code True} if the given predicate holds for all visited entries, {@code false} otherwise.
-     */
-    public boolean forAll(IgnitePredicate<Cache.Entry<K, V>> vis);
-
-    /**
-     * Reloads a single key from persistent storage. This method
-     * delegates to {@link CacheStore#load(Transaction, Object)}
-     * method.
-     * <h2 class="header">Transactions</h2>
-     * This method does not participate in transactions, however it does not violate
-     * cache integrity and can be used safely with or without transactions.
-     *
-     * @param key Key to reload.
-     * @return Reloaded value or current value if entry was updated while reloading.
-     * @throws IgniteCheckedException If reloading failed.
-     */
-    @Nullable public V reload(K key) throws IgniteCheckedException;
-
-    /**
-     * Asynchronously reloads a single key from persistent storage. This method
-     * delegates to {@link CacheStore#load(Transaction, Object)}
-     * method.
-     * <h2 class="header">Transactions</h2>
-     * This method does not participate in transactions, however it does not violate
-     * cache integrity and can be used safely with or without transactions.
-     *
-     * @param key Key to reload.
-     * @return Future to be completed whenever the entry is reloaded.
-     */
-    public IgniteInternalFuture<V> reloadAsync(K key);
-
-    /**
-     * Reloads all currently cached keys form persistent storage.
-     * <h2 class="header">Transactions</h2>
-     * This method does not participate in transactions, however it does not violate
-     * cache integrity and can be used safely with or without transactions.
-     *
-     * @throws IgniteCheckedException If reloading failed.
-     */
-    public void reloadAll() throws IgniteCheckedException;
-
-    /**
-     * Asynchronously reloads all specified entries from underlying
-     * persistent storage.
-     * <h2 class="header">Transactions</h2>
-     * This method does not participate in transactions, however it does not violate
-     * cache integrity and can be used safely with or without transactions.
-     *
-     * @return Future which will complete whenever {@code reload} completes.
-     */
-    public IgniteInternalFuture<?> reloadAllAsync();
-
-    /**
-     * Reloads specified entries from underlying persistent storage.
-     * <h2 class="header">Transactions</h2>
-     * This method does not participate in transactions, however it does not violate
-     * cache integrity and can be used safely with or without transactions.
-     *
-     * @param keys Keys to reload.
-     * @throws IgniteCheckedException if reloading failed.
-     */
-    public void reloadAll(@Nullable Collection<? extends K> keys) throws IgniteCheckedException;
-
-    /**
-     * Asynchronously reloads all specified entries from underlying
-     * persistent storage.
-     * <h2 class="header">Transactions</h2>
-     * This method does not participate in transactions, however it does not violate
-     * cache integrity and can be used safely with or without transactions.
-     *
-     * @param keys Keys to reload.
-     * @return Future which will complete whenever {@code reload} completes.
-     */
-    public IgniteInternalFuture<?> reloadAllAsync(@Nullable Collection<? extends K> keys);
-
-    /**
-     * Peeks at in-memory cached value using default {@link GridCachePeekMode#SMART}
-     * peek mode.
-     * <p>
-     * This method will not load value from any persistent store or from a remote node.
-     * <h2 class="header">Transactions</h2>
-     * This method does not participate in any transactions, however, it will
-     * peek at transactional value according to the {@link GridCachePeekMode#SMART} mode
-     * semantics. If you need to look at global cached value even from within transaction,
-     * you can use {@link GridCache#peek(Object, Collection)} method.
-     *
-     * @param key Entry key.
-     * @return Peeked value.
-     * @throws NullPointerException If key is {@code null}.
-     */
-    @Nullable public V peek(K key);
-
-    /**
-     * @param key Key.
-     * @param peekModes Peek modes.
-     * @param plc Expiry policy if TTL should be updated.
-     * @return Value.
-     * @throws IgniteCheckedException If failed.
-     */
-    @Nullable public V localPeek(K key, CachePeekMode[] peekModes, @Nullable IgniteCacheExpiryPolicy plc)
-        throws IgniteCheckedException;
-
-    /**
-     * @param peekModes Peek modes.
-     * @return Entries iterable.
-     * @throws IgniteCheckedException If failed.
-     */
-    public Iterable<Cache.Entry<K, V>> localEntries(CachePeekMode[] peekModes) throws IgniteCheckedException;
-
-    /**
-     * Peeks at cached value using optional set of peek modes. This method will sequentially
-     * iterate over given peek modes in the order passed in, and try to peek at value using
-     * each peek mode. Once a {@code non-null} value is found, it will be immediately returned.
-     * <p>
-     * Note that if modes are not provided this method works exactly the same way as
-     * {@link #peek(Object)}, implicitly using {@link GridCachePeekMode#SMART} mode.
-     * <h2 class="header">Transactions</h2>
-     * This method does not participate in any transactions, however, it may
-     * peek at transactional value depending on the peek modes used.
-     *
-     * @param key Entry key.
-     * @param modes Optional set of peek modes.
-     * @return Peeked value.
-     * @throws IgniteCheckedException If peek operation failed.
-     * @throws NullPointerException If key is {@code null}.
-     */
-    @Nullable public V peek(K key, @Nullable Collection<GridCachePeekMode> modes) throws IgniteCheckedException;
-
-    /**
-     * Retrieves value mapped to the specified key from cache. Value will only be returned if
-     * its entry passed the optional filter provided. Filter check is atomic, and therefore the
-     * returned value is guaranteed to be consistent with the filter. The return value of {@code null}
-     * means entry did not pass the provided filter or cache has no mapping for the
-     * key.
-     * <p>
-     * If the value is not present in cache, then it will be looked up from swap storage. If
-     * it's not present in swap, or if swap is disable, and if read-through is allowed, value
-     * will be loaded from {@link CacheStore} persistent storage via
-     * {@link CacheStore#load(Transaction, Object)} method.
-     * <h2 class="header">Transactions</h2>
-     * This method is transactional and will enlist the entry into ongoing transaction
-     * if there is one.
-     * <h2 class="header">Cache Flags</h2>
-     * This method is not available if {@link CacheFlag#LOCAL} flag is set on projection.
-     *
-     * @param key Key to retrieve the value for.
-     * @return Value for the given key.
-     * @throws IgniteCheckedException If get operation failed.
-     * @throws CacheFlagException If failed projection flags validation.
-     * @throws NullPointerException if the key is {@code null}.
-     */
-    @Nullable public V get(K key) throws IgniteCheckedException;
-
-    /**
-     * Asynchronously retrieves value mapped to the specified key from cache. Value will only be returned if
-     * its entry passed the optional filter provided. Filter check is atomic, and therefore the
-     * returned value is guaranteed to be consistent with the filter. The return value of {@code null}
-     * means entry did not pass the provided filter or cache has no mapping for the
-     * key.
-     * <p>
-     * If the value is not present in cache, then it will be looked up from swap storage. If
-     * it's not present in swap, or if swap is disabled, and if read-through is allowed, value
-     * will be loaded from {@link CacheStore} persistent storage via
-     * {@link CacheStore#load(Transaction, Object)} method.
-     * <h2 class="header">Transactions</h2>
-     * This method is transactional and will enlist the entry into ongoing transaction
-     * if there is one.
-     * <h2 class="header">Cache Flags</h2>
-     * This method is not available if {@link CacheFlag#LOCAL} flag is set on projection.
-     *
-     * @param key Key for the value to get.
-     * @return Future for the get operation.
-     * @throws NullPointerException if the key is {@code null}.
-     * @throws CacheFlagException If projection flags validation failed.
-     */
-    public IgniteInternalFuture<V> getAsync(K key);
-
-    /**
-     * Retrieves values mapped to the specified keys from cache. Value will only be returned if
-     * its entry passed the optional filter provided. Filter check is atomic, and therefore the
-     * returned value is guaranteed to be consistent with the filter. If requested key-value pair
-     * is not present in the returned map, then it means that its entry did not pass the provided
-     * filter or cache has no mapping for the key.
-     * <p>
-     * If some value is not present in cache, then it will be looked up from swap storage. If
-     * it's not present in swap, or if swap is disabled, and if read-through is allowed, value
-     * will be loaded from {@link CacheStore} persistent storage via
-     * {@link CacheStore#loadAll(Transaction, Collection, org.apache.ignite.lang.IgniteBiInClosure)} method.
-     * <h2 class="header">Transactions</h2>
-     * This method is transactional and will enlist the entry into ongoing transaction
-     * if there is one.
-     * <h2 class="header">Cache Flags</h2>
-     * This method is not available if {@link CacheFlag#LOCAL} flag is set on projection.
-     *
-     * @param keys Keys to get.
-     * @return Map of key-value pairs.
-     * @throws IgniteCheckedException If get operation failed.
-     * @throws CacheFlagException If failed projection flags validation.
-     */
-    public Map<K, V> getAll(@Nullable Collection<? extends K> keys) throws IgniteCheckedException;
-
-    /**
-     * Asynchronously retrieves values mapped to the specified keys from cache. Value will only be returned if
-     * its entry passed the optional filter provided. Filter check is atomic, and therefore the
-     * returned value is guaranteed to be consistent with the filter. If requested key-value pair
-     * is not present in the returned map, then it means that its entry did not pass the provided
-     * filter or cache has no mapping for the key.
-     * <p>
-     * If some value is not present in cache, then it will be looked up from swap storage. If
-     * it's not present in swap, or if swap is disabled, and if read-through is allowed, value
-     * will be loaded from {@link CacheStore} persistent storage via
-     * {@link CacheStore#loadAll(Transaction, Collection, org.apache.ignite.lang.IgniteBiInClosure)} method.
-     * <h2 class="header">Transactions</h2>
-     * This method is transactional and will enlist the entry into ongoing transaction
-     * if there is one.
-     * <h2 class="header">Cache Flags</h2>
-     * This method is not available if {@link CacheFlag#LOCAL} flag is set on projection.
-     *
-     * @param keys Key for the value to get.
-     * @return Future for the get operation.
-     * @throws CacheFlagException If projection flags validation failed.
-     */
-    public IgniteInternalFuture<Map<K, V>> getAllAsync(@Nullable Collection<? extends K> keys);
-
-    /**
-     * Stores given key-value pair in cache. If filters are provided, then entries will
-     * be stored in cache only if they pass the filter. Note that filter check is atomic,
-     * so value stored in cache is guaranteed to be consistent with the filters. If cache
-     * previously contained value for the given key, then this value is returned.
-     * In case of {@link CacheMode#PARTITIONED} or {@link CacheMode#REPLICATED} caches,
-     * the value will be loaded from the primary node, which in its turn may load the value
-     * from the swap storage, and consecutively, if it's not in swap,
-     * from the underlying persistent storage. If value has to be loaded from persistent
-     * storage,  {@link CacheStore#load(Transaction, Object)} method will be used.
-     * <p>
-     * If the returned value is not needed, method {@link #putx(Object, Object, org.apache.ignite.lang.IgnitePredicate[])} should
-     * always be used instead of this one to avoid the overhead associated with returning of the previous value.
-     * <p>
-     * If write-through is enabled, the stored value will be persisted to {@link CacheStore}
-     * via {@link CacheStore#put(Transaction, Object, Object)} method.
-     * <h2 class="header">Transactions</h2>
-     * This method is transactional and will enlist the entry into ongoing transaction
-     * if there is one.
-     * <h2 class="header">Cache Flags</h2>
-     * This method is not available if any of the following flags are set on projection:
-     * {@link CacheFlag#LOCAL}, {@link CacheFlag#READ}.
-     *
-     * @param key Key to store in cache.
-     * @param val Value to be associated with the given key.
-     * @param filter Optional filter to check prior to putting value in cache. Note
-     *      that filter check is atomic with put operation.
-     * @return Previous value associated with specified key, or {@code null}
-     *  if entry did not pass the filter, or if there was no mapping for the key in swap
-     *  or in persistent storage.
-     * @throws NullPointerException If either key or value are {@code null}.
-     * @throws IgniteCheckedException If put operation failed.
-     * @throws CacheFlagException If projection flags validation failed.
-     */
-    @Nullable public V put(K key, V val, @Nullable IgnitePredicate<Cache.Entry<K, V>>... filter)
-        throws IgniteCheckedException;
-
-    /**
-     * Asynchronously stores given key-value pair in cache. If filters are provided, then entries will
-     * be stored in cache only if they pass the filter. Note that filter check is atomic,
-     * so value stored in cache is guaranteed to be consistent with the filters. If cache
-     * previously contained value for the given key, then this value is returned. Otherwise,
-     * in case of {@link CacheMode#REPLICATED} caches, the value will be loaded from swap
-     * and, if it's not there, and read-through is allowed, from the underlying
-     * {@link CacheStore} storage. In case of {@link CacheMode#PARTITIONED} caches,
-     * the value will be loaded from the primary node, which in its turn may load the value
-     * from the swap storage, and consecutively, if it's not in swap and read-through is allowed,
-     * from the underlying persistent storage. If value has to be loaded from persistent
-     * storage,  {@link CacheStore#load(Transaction, Object)} method will be used.
-     * <p>
-     * If the returned value is not needed, method {@link #putx(Object, Object, org.apache.ignite.lang.IgnitePredicate[])} should
-     * always be used instead of this one to avoid the overhead associated with returning of the previous value.
-     * <p>
-     * If write-through is enabled, the stored value will be persisted to {@link CacheStore}
-     * via {@link CacheStore#put(Transaction, Object, Object)} method.
-     * <h2 class="header">Transactions</h2>
-     * This method is transactional and will enlist the entry into ongoing transaction
-     * if there is one.
-     * <h2 class="header">Cache Flags</h2>
-     * This method is not available if any of the following flags are set on projection:
-     * {@link CacheFlag#LOCAL}, {@link CacheFlag#READ}.
-     *
-     * @param key Key to store in cache.
-     * @param val Value to be associated with the given key.
-     * @param filter Optional filter to check prior to putting value in cache. Note
-     *      that filter check is atomic with put operation.
-     * @return Future for the put operation.
-     * @throws NullPointerException If either key or value are {@code null}.
-     * @throws CacheFlagException If projection flags validation failed.
-     */
-    public IgniteInternalFuture<V> putAsync(K key, V val, @Nullable IgnitePredicate<Cache.Entry<K, V>>... filter);
-
-    /**
-     * Stores given key-value pair in cache. If filters are provided, then entries will
-     * be stored in cache only if they pass the filter. Note that filter check is atomic,
-     * so value stored in cache is guaranteed to be consistent with the filters.
-     * <p>
-     * This method will return {@code true} if value is stored in cache and {@code false} otherwise.
-     * Unlike {@link #put(Object, Object, org.apache.ignite.lang.IgnitePredicate[])} method, it does not return previous
-     * value and, therefore, does not have any overhead associated with returning a value. It
-     * should be used whenever return value is not required.
-     * <p>
-     * If write-through is enabled, the stored value will be persisted to {@link CacheStore}
-     * via {@link CacheStore#put(Transaction, Object, Object)} method.
-     * <h2 class="header">Transactions</h2>
-     * This method is transactional and will enlist the entry into ongoing transaction
-     * if there is one.
-     * <h2 class="header">Cache Flags</h2>
-     * This method is not available if any of the following flags are set on projection:
-     * {@link CacheFlag#LOCAL}, {@link CacheFlag#READ}.
-     *
-     * @param key Key to store in cache.
-     * @param val Value to be associated with the given key.
-     * @param filter Optional filter to check prior to putting value in cache. Note
-     *      that filter check is atomic with put operation.
-     * @return {@code True} if optional filter passed and value was stored in cache,
-     *      {@code false} otherwise. Note that this method will return {@code true} if filter is not
-     *      specified.
-     * @throws NullPointerException If either key or value are {@code null}.
-     * @throws IgniteCheckedException If put operation failed.
-     * @throws CacheFlagException If projection flags validation failed.
-     */
-    public boolean putx(K key, V val, @Nullable IgnitePredicate<Cache.Entry<K, V>>... filter)
-        throws IgniteCheckedException;
-
-    /**
-     * Stores given key-value pair in cache. If filters are provided, then entries will
-     * be stored in cache only if they pass the filter. Note that filter check is atomic,
-     * so value stored in cache is guaranteed to be consistent with the filters.
-     * <p>
-     * This method will return {@code true} if value is stored in cache and {@code false} otherwise.
-     * Unlike {@link #put(Object, Object, org.apache.ignite.lang.IgnitePredicate[])} method, it does not return previous
-     * value and, therefore, does not have any overhead associated with returning of a value. It
-     * should always be used whenever return value is not required.
-     * <p>
-     * If write-through is enabled, the stored value will be persisted to {@link CacheStore}
-     * via {@link CacheStore#put(Transaction, Object, Object)} method.
-     * <h2 class="header">Transactions</h2>
-     * This method is transactional and will enlist the entry into ongoing transaction
-     * if there is one.
-     * <h2 class="header">Cache Flags</h2>
-     * This method is not available if any of the following flags are set on projection:
-     * {@link CacheFlag#LOCAL}, {@link CacheFlag#READ}.
-     *
-     * @param key Key to store in cache.
-     * @param val Value to be associated with the given key.
-     * @param filter Optional filter to check prior to putting value in cache. Note
-     *      that filter check is atomic with put operation.
-     * @return Future for the put operation. Future will return {@code true} if optional filter
-     *      passed and value was stored in cache, {@code false} otherwise. Note that future will
-     *      return {@code true} if filter is not specified.
-     * @throws NullPointerException If either key or value are {@code null}.
-     * @throws CacheFlagException If projection flags validation failed.
-     */
-    public IgniteInternalFuture<Boolean> putxAsync(K key, V val, @Nullable IgnitePredicate<Cache.Entry<K, V>>... filter);
-
-    /**
-     * Stores given key-value pair in cache only if cache had no previous mapping for it. If cache
-     * previously contained value for the given key, then this value is returned.
-     * In case of {@link CacheMode#PARTITIONED} or {@link CacheMode#REPLICATED} caches,
-     * the value will be loaded from the primary node, which in its turn may load the value
-     * from the swap storage, and consecutively, if it's not in swap,
-     * from the underlying persistent storage. If value has to be loaded from persistent
-     * storage, {@link CacheStore#load(Transaction, Object)} method will be used.
-     * <p>
-     * If the returned value is not needed, method {@link #putxIfAbsent(Object, Object)} should
-     * always be used instead of this one to avoid the overhead associated with returning of the
-     * previous value.
-     * <p>
-     * If write-through is enabled, the stored value will be persisted to {@link CacheStore}
-     * via {@link CacheStore#put(Transaction, Object, Object)} method.
-     * <h2 class="header">Transactions</h2>
-     * This method is transactional and will enlist the entry into ongoing transaction
-     * if there is one.
-     * <h2 class="header">Cache Flags</h2>
-     * This method is not available if any of the following flags are set on projection:
-     * {@link CacheFlag#LOCAL}, {@link CacheFlag#READ}.
-     *
-     * @param key Key to store in cache.
-     * @param val Value to be associated with the given key.
-     * @return Previously contained value regardless of whether put happened or not.
-     * @throws NullPointerException If either key or value are {@code null}.
-     * @throws IgniteCheckedException If put operation failed.
-     * @throws CacheFlagException If projection flags validation failed.
-     */
-    @Nullable public V putIfAbsent(K key, V val) throws IgniteCheckedException;
-
-    /**
-     * Asynchronously stores given key-value pair in cache only if cache had no previous mapping for it. If cache
-     * previously contained value for the given key, then this value is returned. In case of
-     * {@link CacheMode#PARTITIONED} or {@link CacheMode#REPLICATED} caches,
-     * the value will be loaded from the primary node, which in its turn may load the value
-     * from the swap storage, and consecutively, if it's not in swap,
-     * from the underlying persistent storage. If value has to be loaded from persistent
-     * storage, {@link CacheStore#load(Transaction, Object)} method will be used.
-     * <p>
-     * If the returned value is not needed, method {@link #putxIfAbsentAsync(Object, Object)} should
-     * always be used instead of this one to avoid the overhead associated with returning of the
-     * previous value.
-     * <p>
-     * If write-through is enabled, the stored value will be persisted to {@link CacheStore}
-     * via {@link CacheStore#put(Transaction, Object, Object)} method.
-     * <h2 class="header">Transactions</h2>
-     * This method is transactional and will enlist the entry into ongoing transaction
-     * if there is one.
-     * <h2 class="header">Cache Flags</h2>
-     * This method is not available if any of the following flags are set on projection:
-     * {@link CacheFlag#LOCAL}, {@link CacheFlag#READ}.
-     *
-     * @param key Key to store in cache.
-     * @param val Value to be associated with the given key.
-     * @return Future of put operation which will provide previously contained value
-     *   regardless of whether put happened or not.
-     * @throws NullPointerException If either key or value are {@code null}.
-     * @throws CacheFlagException If projection flags validation failed.
-     */
-    public IgniteInternalFuture<V> putIfAbsentAsync(K key, V val);
-
-    /**
-     * Stores given key-value pair in cache only if cache had no previous mapping for it.
-     * <p>
-     * This method will return {@code true} if value is stored in cache and {@code false} otherwise.
-     * Unlike {@link #putIfAbsent(Object, Object)} method, it does not return previous
-     * value and, therefore, does not have any overhead associated with returning of a value. It
-     * should always be used whenever return value is not required.
-     * <p>
-     * If write-through is enabled, the stored value will be persisted to {@link CacheStore}
-     * via {@link CacheStore#put(Transaction, Object, Object)} method.
-     * <h2 class="header">Transactions</h2>
-     * This method is transactional and will enlist the entry into ongoing transaction
-     * if there is one.
-     * <h2 class="header">Cache Flags</h2>
-     * This method is not available if any of the following flags are set on projection:
-     * {@link CacheFlag#LOCAL}, {@link CacheFlag#READ}.
-     *
-     * @param key Key to store in cache.
-     * @param val Value to be associated with the given key.
-     * @return {@code true} if value is stored in cache and {@code false} otherwise.
-     * @throws NullPointerException If either key or value are {@code null}.
-     * @throws IgniteCheckedException If put operation failed.
-     * @throws CacheFlagException If projection flags validation failed.
-     */
-    public boolean putxIfAbsent(K key, V val) throws IgniteCheckedException;
-
-    /**
-     * Asynchronously stores given key-value pair in cache only if cache had no previous mapping for it.
-     * <p>
-     * This method will return {@code true} if value is stored in cache and {@code false} otherwise.
-     * Unlike {@link #putIfAbsent(Object, Object)} method, it does not return previous
-     * value and, therefore, does not have any overhead associated with returning of a value. It
-     * should always be used whenever return value is not required.
-     * <p>
-     * If write-through is enabled, the stored value will be persisted to {@link CacheStore}
-     * via {@link CacheStore#put(Transaction, Object, Object)} method.
-     * <h2 class="header">Transactions</h2>
-     * This method is transactional and will enlist the entry into ongoing transaction
-     * if there is one.
-     * <h2 class="header">Cache Flags</h2>
-     * This method is not available if any of the following flags are set on projection:
-     * {@link CacheFlag#LOCAL}, {@link CacheFlag#READ}.
-     *
-     * @param key Key to store in cache.
-     * @param val Value to be associated with the given key.
-     * @return Future for this put operation.
-     * @throws NullPointerException If either key or value are {@code null}.
-     * @throws CacheFlagException If projection flags validation failed.
-     */
-    public IgniteInternalFuture<Boolean> putxIfAbsentAsync(K key, V val);
-
-    /**
-     * Stores given key-value pair in cache only if there is a previous mapping for it.
-     * In case of {@link CacheMode#PARTITIONED} or {@link CacheMode#REPLICATED} caches,
-     * the value will be loaded from the primary node, which in its turn may load the value
-     * from the swap storage, and consecutively, if it's not in swap,
-     * from the underlying persistent storage. If value has to be loaded from persistent
-     * storage, {@link CacheStore#load(Transaction, Object)} method will be used.
-     * <p>
-     * If the returned value is not needed, method {@link #replacex(Object, Object)} should
-     * always be used instead of this one to avoid the overhead associated with returning of the
-     * previous value.
-     * <p>
-     * If write-through is enabled, the stored value will be persisted to {@link CacheStore}
-     * via {@link CacheStore#put(Transaction, Object, Object)} method.
-     * <h2 class="header">Transactions</h2>
-     * This method is transactional and will enlist the entry into ongoing transaction
-     * if there is one.
-     * <h2 class="header">Cache Flags</h2>
-     * This method is not available if any of the following flags are set on projection:
-     * {@link CacheFlag#LOCAL}, {@link CacheFlag#READ}.
-     *
-     * @param key Key to store in cache.
-     * @param val Value to be associated with the given key.
-     * @return Previously contained value regardless of whether replace happened or not.
-     * @throws NullPointerException If either key or value are {@code null}.
-     * @throws IgniteCheckedException If replace operation failed.
-     * @throws CacheFlagException If projection flags validation failed.
-     */
-    @Nullable public V replace(K key, V val) throws IgniteCheckedException;
-
-    /**
-     * Asynchronously stores given key-value pair in cache only if there is a previous mapping for it. If cache
-     * previously contained value for the given key, then this value is returned.In case of
-     * {@link CacheMode#PARTITIONED} caches, the value will be loaded from the primary node,
-     * which in its turn may load the value from the swap storage, and consecutively, if it's not in swap,
-     * from the underlying persistent storage. If value has to be loaded from persistent
-     * storage, {@link CacheStore#load(Transaction, Object)} method will be used.
-     * <p>
-     * If the returned value is not needed, method {@link #replacex(Object, Object)} should
-     * always be used instead of this one to avoid the overhead associated with returning of the
-     * previous value.
-     * <p>
-     * If write-through is enabled, the stored value will be persisted to {@link CacheStore}
-     * via {@link CacheStore#put(Transaction, Object, Object)} method.
-     * <h2 class="header">Transactions</h2>
-     * This method is transactional and will enlist the entry into ongoing transaction
-     * if there is one.
-     * <h2 class="header">Cache Flags</h2>
-     * This method is not available if any of the following flags are set on projection:
-     * {@link CacheFlag#LOCAL}, {@link CacheFlag#READ}.
-     *
-     * @param key Key to store in cache.
-     * @param val Value to be associated with the given key.
-     * @return Future for replace operation.
-     * @throws NullPointerException If either key or value are {@code null}.
-     * @throws CacheFlagException If projection flags validation failed.
-     */
-    public IgniteInternalFuture<V> replaceAsync(K key, V val);
-
-    /**
-     * Stores given key-value pair in cache only if only if there is a previous mapping for it.
-     * <p>
-     * This method will return {@code true} if value is stored in cache and {@code false} otherwise.
-     * Unlike {@link #replace(Object, Object)} method, it does not return previous
-     * value and, therefore, does not have any overhead associated with returning of a value. It
-     * should always be used whenever return value is not required.
-     * <p>
-     * If write-through is enabled, the stored value will be persisted to {@link CacheStore}
-     * via {@link CacheStore#put(Transaction, Object, Object)} method.
-     * <h2 class="header">Transactions</h2>
-     * This method is transactional and will enlist the entry into ongoing transaction
-     * if there is one.
-     * <h2 class="header">Cache Flags</h2>
-     * This method is not available if any of the following flags are set on projection:
-     * {@link CacheFlag#LOCAL}, {@link CacheFlag#READ}.
-     *
-     * @param key Key to store in cache.
-     * @param val Value to be associated with the given key.
-     * @return {@code True} if replace happened, {@code false} otherwise.
-     * @throws NullPointerException If either key or value are {@code null}.
-     * @throws IgniteCheckedException If replace operation failed.
-     * @throws CacheFlagException If projection flags validation failed.
-     */
-    public boolean replacex(K key, V val) throws IgniteCheckedException;
-
-    /**
-     * Asynchronously stores given key-value pair in cache only if only if there is a previous mapping for it.
-     * <p>
-     * This method will return {@code true} if value is stored in cache and {@code false} otherwise.
-     * Unlike {@link #replaceAsync(Object, Object)} method, it does not return previous
-     * value and, therefore, does not have any overhead associated with returning of a value. It
-     * should always be used whenever return value is not required.
-     * <p>
-     * If write-through is enabled, the stored value will be persisted to {@link CacheStore}
-     * via {@link CacheStore#put(Transaction, Object, Object)} method.
-     * <h2 class="header">Transactions</h2>
-     * This method is transactional and will enlist the entry into ongoing transaction
-     * if there is one.
-     * <h2 class="header">Cache Flags</h2>
-     * This method is not available if any of the following flags are set on projection:
-     * {@link CacheFlag#LOCAL}, {@link CacheFlag#READ}.
-     *
-     * @param key Key to store in cache.
-     * @param val Value to be associated with the given key.
-     * @return Future for the replace operation.
-     * @throws NullPointerException If either key or value are {@code null}.
-     * @throws CacheFlagException If projection flags validation failed.
-     */
-    public IgniteInternalFuture<Boolean> replacexAsync(K key, V val);
-
-    /**
-     * Stores given key-value pair in cache only if only if the previous value is equal to the
-     * {@code 'oldVal'} passed in.
-     * <p>
-     * This method will return {@code true} if value is stored in cache and {@code false} otherwise.
-     * <p>
-     * If write-through is enabled, the stored value will be persisted to {@link CacheStore}
-     * via {@link CacheStore#put(Transaction, Object, Object)} method.
-     * <h2 class="header">Transactions</h2>
-     * This method is transactional and will enlist the entry into ongoing transaction
-     * if there is one.
-     * <h2 class="header">Cache Flags</h2>
-     * This method is not available if any of the following flags are set on projection:
-     * {@link CacheFlag#LOCAL}, {@link CacheFlag#READ}.
-     *
-     * @param key Key to store in cache.
-     * @param oldVal Old value to match.
-     * @param newVal Value to be associated with the given key.
-     * @return {@code True} if replace happened, {@code false} otherwise.
-     * @throws NullPointerException If either key or value are {@code null}.
-     * @throws IgniteCheckedException If replace operation failed.
-     * @throws CacheFlagException If projection flags validation failed.
-     */
-    public boolean replace(K key, V oldVal, V newVal) throws IgniteCheckedException;
-
-    /**
-     * Asynchronously stores given key-value pair in cache only if only if the previous value is equal to the
-     * {@code 'oldVal'} passed in.
-     * <p>
-     * This method will return {@code true} if value is stored in cache and {@code false} otherwise.
-     * <p>
-     * If write-through is enabled, the stored value will be persisted to {@link CacheStore}
-     * via {@link CacheStore#put(Transaction, Object, Object)} method.
-     * <h2 class="header">Transactions</h2>
-     * This method is transactional and will enlist the entry into ongoing transaction
-     * if there is one.
-     * <h2 class="header">Cache Flags</h2>
-     * This method is not available if any of the following flags are set on projection:
-     * {@link CacheFlag#LOCAL}, {@link CacheFlag#READ}.
-     *
-     * @param key Key to store in cache.
-     * @param oldVal Old value to match.
-     * @param newVal Value to be associated with the given key.
-     * @return Future for the replace operation.
-     * @throws NullPointerException If either key or value are {@code null}.
-     * @throws CacheFlagException If projection flags validation failed.
-     */
-    public IgniteInternalFuture<Boolean> replaceAsync(K key, V oldVal, V newVal);
-
-    /**
-     * Stores given key-value pairs in cache. If filters are provided, then entries will
-     * be stored in cache only if they pass the filter. Note that filter check is atomic,
-     * so value stored in cache is guaranteed to be consistent with the filters.
-     * <p>
-     * If write-through is enabled, the stored values will be persisted to {@link CacheStore}
-     * via {@link CacheStore#putAll(Transaction, Map)} method.
-     * <h2 class="header">Transactions</h2>
-     * This method is transactional and will enlist the entry into ongoing transaction
-     * if there is one.
-     * <h2 class="header">Cache Flags</h2>
-     * This method is not available if any of the following flags are set on projection:
-     * {@link CacheFlag#LOCAL}, {@link CacheFlag#READ}.
-     *
-     * @param m Key-value pairs to store in cache.
-     * @param filter Optional entry filter. If provided, then entry will
-     *      be stored only if the filter returned {@code true}.
-     * @throws IgniteCheckedException If put operation failed.
-     * @throws CacheFlagException If projection flags validation failed.
-     */
-    public void putAll(@Nullable Map<? extends K, ? extends V> m,
-        @Nullable IgnitePredicate<Cache.Entry<K, V>>... filter) throws IgniteCheckedException;
-
-    /**
-     * Asynchronously stores given key-value pairs in cache. If filters are provided, then entries will
-     * be stored in cache only if they pass the filter. Note that filter check is atomic,
-     * so value stored in cache is guaranteed to be consistent with the filters.
-     * <p>
-     * If write-through is enabled, the stored values will be persisted to {@link CacheStore}
-     * via {@link CacheStore#putAll(Transaction, Map)} method.
-     * <h2 class="header">Transactions</h2>
-     * This method is transactional and will enlist the entry into ongoing transaction
-     * if there is one.
-     * <h2 class="header">Cache Flags</h2>
-     * This method is not available if any of the following flags are set on projection:
-     * {@link CacheFlag#LOCAL}, {@link CacheFlag#READ}.
-     *
-     * @param m Key-value pairs to store in cache.
-     * @param filter Optional entry filter. If provided, then entry will
-     *      be stored only if the filter returned {@code true}.
-     * @return Future for putAll operation.
-     * @throws CacheFlagException If projection flags validation failed.
-     */
-    public IgniteInternalFuture<?> putAllAsync(@Nullable Map<? extends K, ? extends V> m,
-        @Nullable IgnitePredicate<Cache.Entry<K, V>>... filter);
-
-    /**
-     * Set of keys cached on this node. You can remove elements from this set, but you cannot add elements
-     * to this set. All removal operation will be reflected on the cache itself.
-     * <p>
-     * Iterator over this set will not fail if set was concurrently updated
-     * by another thread. This means that iterator may or may not return latest
-     * keys depending on whether they were added before or after current
-     * iterator position.
-     * <p>
-     * NOTE: this operation is not distributed and returns only the keys cached on this node.
-     *
-     * @return Key set for this cache projection.
-     */
-    public Set<K> keySet();
-
-    /**
-     * Set of keys cached on this node. You can remove elements from this set, but you cannot add elements
-     * to this set. All removal operation will be reflected on the cache itself.
-     * <p>
-     * Iterator over this set will not fail if set was concurrently updated
-     * by another thread. This means that iterator may or may not return latest
-     * keys depending on whether they were added before or after current
-     * iterator position.
-     * <p>
-     * NOTE: this operation is not distributed and returns only the keys cached on this node.
-     *
-     * @param filter Optional filter to check prior to getting key form cache. Note
-     * that filter is checked atomically together with get operation.
-     * @return Key set for this cache projection.
-     */
-    public Set<K> keySet(@Nullable IgnitePredicate<Cache.Entry<K, V>>... filter);
-
-    /**
-     * Set of keys for which this node is primary.
-     * This set is dynamic and may change with grid topology changes.
-     * Note that this set will contain mappings for all keys, even if their values are
-     * {@code null} because they were invalidated. You can remove elements from
-     * this set, but you cannot add elements to this set. All removal operation will be
-     * reflected on the cache itself.
-     * <p>
-     * Iterator over this set will not fail if set was concurrently updated
-     * by another thread. This means that iterator may or may not return latest
-     * keys depending on whether they were added before or after current
-     * iterator position.
-     * <p>
-     * NOTE: this operation is not distributed and returns only the keys cached on this node.
-     *
-     * @return Primary key set for the current node.
-     */
-    public Set<K> primaryKeySet();
-
-    /**
-     * Collection of values cached on this node. You can remove
-     * elements from this collection, but you cannot add elements to this collection.
-     * All removal operation will be reflected on the cache itself.
-     * <p>
-     * Iterator over this collection will not fail if collection was
-     * concurrently updated by another thread. This means that iterator may or
-     * may not return latest values depending on whether they were added before
-     * or after current iterator position.
-     * <p>
-     * NOTE: this operation is not distributed and returns only the values cached on this node.
-     *
-     * @return Collection of cached values.
-     */
-    public Collection<V> values();
-
-    /**
-     * Collection of cached values for which this node is primary.
-     * This collection is dynamic and may change with grid topology changes.
-     * Note that this collection will not contain values that are {@code null}
-     * because they were invalided. You can remove elements from this collection,
-     * but you cannot add elements to this collection. All removal operation will be
-     * reflected on the cache itself.
-     * <p>
-     * Iterator over this collection will not fail if collection was
-     * concurrently updated by another thread. This means that iterator may or
-     * may not return latest values depending on whether they were added before
-     * or after current iterator position.
-     * <p>
-     * NOTE: this operation is not distributed and returns only the values cached on this node.
-     *
-     * @return Collection of primary cached values for the current node.
-     */
-    public Collection<V> primaryValues();
-
-    /**
-     * Gets set of all entries cached on this node. You can remove
-     * elements from this set, but you cannot add elements to this set.
-     * All removal operation will be reflected on the cache itself.
-     * <p>
-     * NOTE: this operation is not distributed and returns only the entries cached on this node.
-     *
-     * @return Entries that pass through key filter.
-     */
-    public Set<Cache.Entry<K, V>> entrySet();
-
-    /**
-     * Gets set containing cache entries that belong to provided partition or {@code null}
-     * if partition is not found locally.
-     * <p>
-     * NOTE: this operation is not distributed and returns only the entries cached on this node.
-     *
-     * @param part Partition.
-     * @return Set containing partition's entries or {@code null} if partition is
-     *      not found locally.
-     */
-    @Nullable public Set<Cache.Entry<K, V>> entrySet(int part);
-
-    /**
-     * Gets set of cache entries for which this node is primary.
-     * This set is dynamic and may change with grid topology changes. You can remove
-     * elements from this set, but you cannot add elements to this set.
-     * All removal operation will be reflected on the cache itself.
-     * <p>
-     * NOTE: this operation is not distributed and returns only the entries cached on this node.
-     *
-     * @return Primary cache entries that pass through key filter.
-     */
-    public Set<Cache.Entry<K, V>> primaryEntrySet();
-
-    /**
-     * Starts transaction with default isolation, concurrency, timeout, and invalidation policy.
-     * All defaults are set in {@link org.apache.ignite.configuration.CacheConfiguration} at startup.
-     *
-     * @return New transaction
-     * @throws IllegalStateException If transaction is already started by this thread.
-     * @throws UnsupportedOperationException If cache is {@link CacheAtomicityMode#ATOMIC}.
-     */
-    public Transaction txStart() throws IllegalStateException;
-
-    /**
-     * Starts new transaction with the specified concurrency and isolation.
-     *
-     * @param concurrency Concurrency.
-     * @param isolation Isolation.
-     * @return New transaction.
-     * @throws IllegalStateException If transaction is already started by this thread.
-     * @throws UnsupportedOperationException If cache is {@link CacheAtomicityMode#ATOMIC}.
-     */
-    public Transaction txStart(TransactionConcurrency concurrency, TransactionIsolation isolation);
-
-    /**
-     * @param concurrency Concurrency.
-     * @param isolation Isolation.
-     * @return New transaction.
-     */
-    public IgniteInternalTx txStartEx(TransactionConcurrency concurrency, TransactionIsolation isolation);
-
-    /**
-     * Starts transaction with specified isolation, concurrency, timeout, invalidation flag,
-     * and number of participating entries.
-     *
-     * @param concurrency Concurrency.
-     * @param isolation Isolation.
-     * @param timeout Timeout.
-     * @param txSize Number of entries participating in transaction (may be approximate).
-     * @return New transaction.
-     * @throws IllegalStateException If transaction is already started by this thread.
-     * @throws UnsupportedOperationException If cache is {@link CacheAtomicityMode#ATOMIC}.
-     */
-    public Transaction txStart(TransactionConcurrency concurrency, TransactionIsolation isolation, long timeout,
-        int txSize);
-
-    /**
-     * Gets transaction started by this thread or {@code null} if this thread does
-     * not have a transaction.
-     *
-     * @return Transaction started by this thread or {@code null} if this thread
-     *      does not have a transaction.
-     */
-    @Nullable public Transaction tx();
-
-    /**
-     * Gets entry from cache with the specified key. The returned entry can
-     * be used even after entry key has been removed from cache. In that
-     * case, every operation on returned entry will result in creation of a
-     * new entry.
-     * <p>
-     * Note that this method can return {@code null} if projection is configured as
-     * pre-filtered and entry key and value don't pass key-value filter of the projection.
-     *
-     * @param key Entry key.
-     * @return Cache entry or {@code null} if projection pre-filtering was not passed.
-     */
-    @Nullable public Cache.Entry<K, V> entry(K key);
-
-    /**
-     * Evicts entry associated with given key from cache. Note, that entry will be evicted
-     * only if it's not used (not participating in any locks or transactions).
-     * <p>
-     * If {@link org.apache.ignite.configuration.CacheConfiguration#isSwapEnabled()} is set to {@code true} and
-     * {@link CacheFlag#SKIP_SWAP} is not enabled, the evicted entry will
-     * be swapped to offheap, and then to disk.
-     * <h2 class="header">Cache Flags</h2>
-     * This method is not available if any of the following flags are set on projection:
-     * {@link CacheFlag#READ}.
-     *
-     * @param key Key to evict from cache.
-     * @return {@code True} if entry could be evicted, {@code false} otherwise.
-     */
-    public boolean evict(K key);
-
-    /**
-     * Attempts to evict all cache entries. Note, that entry will be
-     * evicted only if it's not used (not participating in any locks or
-     * transactions).
-     * <p>
-     * If {@link org.apache.ignite.configuration.CacheConfiguration#isSwapEnabled()} is set to {@code true} and
-     * {@link CacheFlag#SKIP_SWAP} is not enabled, the evicted entry will
-     * be swapped to offheap, and then to disk.
-     * <h2 class="header">Cache Flags</h2>
-     * This method is not available if any of the following flags are set on projection:
-     * {@link CacheFlag#READ}.
-     */
-    public void evictAll();
-
-    /**
-     * Attempts to evict all entries associated with keys. Note,
-     * that entry will be evicted only if it's not used (not
-     * participating in any locks or transactions).
-     * <p>
-     * If {@link org.apache.ignite.configuration.CacheConfiguration#isSwapEnabled()} is set to {@code true} and
-     * {@link CacheFlag#SKIP_SWAP} is not enabled, the evicted entry will
-     * be swapped to offheap, and then to disk.
-     * <h2 class="header">Cache Flags</h2>
-     * This method is not available if any of the following flags are set on projection:
-     * {@link CacheFlag#READ}.
-     *
-     * @param keys Keys to evict.
-     */
-    public void evictAll(@Nullable Collection<? extends K> keys);
-
-    /**
-     * Clears all entries from this cache only if the entry is not
-     * currently locked or participating in a transaction.
-     * <p>
-     * If {@link org.apache.ignite.configuration.CacheConfiguration#isSwapEnabled()} is set to {@code true} and
-     * {@link CacheFlag#SKIP_SWAP} is not enabled, the evicted entries will
-     * also be cleared from swap.
-     * <p>
-     * Note that this operation is local as it merely clears
-     * entries from local cache. It does not remove entries from
-     * remote caches or from underlying persistent storage.
-     * <h2 class="header">Cache Flags</h2>
-     * This method is not available if any of the following flags are set on projection:
-     * {@link CacheFlag#READ}.
-     */
-    public void clearLocally();
-
-    /**
-     * Clears an entry from this cache and swap storage only if the entry
-     * is not currently locked, and is not participating in a transaction.
-     * <p>
-     * If {@link org.apache.ignite.configuration.CacheConfiguration#isSwapEnabled()} is set to {@code true} and
-     * {@link CacheFlag#SKIP_SWAP} is not enabled, the evicted entries will
-     * also be cleared from swap.
-     * <p>
-     * Note that this operation is local as it merely clears
-     * an entry from local cache. It does not remove entries from
-     * remote caches or from underlying persistent storage.
-     * <h2 class="header">Cache Flags</h2>
-     * This method is not available if any of the following flags are set on projection:
-     * {@link CacheFlag#READ}.
-     *
-     * @param key Key to clearLocally.
-     * @return {@code True} if entry was successfully cleared from cache, {@code false}
-     *      if entry was in use at the time of this method invocation and could not be
-     *      cleared.
-     */
-    public boolean clearLocally(K key);
-
-    /**
-     * Clears cache on all nodes that store it's data. That is, caches are cleared on remote
-     * nodes and local node, as opposed to {@link CacheProjection#clearLocally()} method which only
-     * clears local node's cache.
-     * <p>
-     * Ignite will make the best attempt to clear caches on all nodes. If some caches
-     * could not be cleared, then exception will be thrown.
-     * <p>
-     * This method is identical to calling {@link #clear(long) clear(0)}.
-     *
-     * @throws IgniteCheckedException In case of cache could not be cleared on any of the nodes.
-     * @deprecated Deprecated in favor of {@link #clear(long)} method.
-     */
-    public void clear() throws IgniteCheckedException;
-
-    /**
-     * @return Clear future.
-     */
-    public IgniteInternalFuture<?> clearAsync();
-
-    /**
-     * Clears cache on all nodes that store it's data. That is, caches are cleared on remote
-     * nodes and local node, as opposed to {@link CacheProjection#clearLocally()} method which only
-     * clears local node's cache.
-     * <p>
-     * Ignite will make the best attempt to clearLocally caches on all nodes. If some caches
-     * could not be cleared, then exception will be thrown.
-     *
-     * @param timeout Timeout for clearLocally all task in milliseconds (0 for never).
-     *      Set it to larger value for large caches.
-     * @throws IgniteCheckedException In case of cache could not be cleared on any of the nodes.
-     */
-    public void clear(long timeout) throws IgniteCheckedException;
-
-    /**
-     * Clears serialized value bytes from entry (if any) leaving only object representation.
-     *
-     * @param key Key to compact.
-     * @throws IgniteCheckedException If failed to compact.
-     * @return {@code true} if entry was deleted from cache (i.e. was expired).
-     */
-    public boolean compact(K key) throws IgniteCheckedException;
-
-    /**
-     * Clears serialized value bytes from cache entries (if any) leaving only object representation.
-     * @throws IgniteCheckedException If failed to compact.
-     */
-    public void compactAll() throws IgniteCheckedException;
-
-    /**
-     * Removes given key mapping from cache. If cache previously contained value for the given key,
-     * then this value is returned. In case of {@link CacheMode#PARTITIONED} or {@link CacheMode#REPLICATED}
-     * caches, the value will be loaded from the primary node, which in its turn may load the value
-     * from the disk-based swap storage, and consecutively, if it's not in swap,
-     * from the underlying persistent storage. If value has to be loaded from persistent
-     * storage, {@link CacheStore#load(Transaction, Object)} method will be used.
-     * <p>
-     * If the returned value is not needed, method {@link #removex(Object, org.apache.ignite.lang.IgnitePredicate[])} should
-     * always be used instead of this one to avoid the overhead associated with returning of the
-     * previous value.
-     * <p>
-     * If write-through is enabled, the value will be removed from {@link CacheStore}
-     * via {@link CacheStore#remove(Transaction, Object)} method.
-     * <h2 class="header">Transactions</h2>
-     * This method is transactional and will enlist the entry into ongoing transaction
-     * if there is one.
-     * <h2 class="header">Cache Flags</h2>
-     * This method is not available if any of the following flags are set on projection:
-     * {@link CacheFlag#LOCAL}, {@link CacheFlag#READ}.
-     *
-     * @param key Key whose mapping is to be removed from cache.
-     * @param filter Optional filter to check prior to removing value form cache. Note
-     *      that filter is checked atomically together with remove operation.
-     * @return Previous value associated with specified key, or {@code null}
-     *      if there was no value for this key.
-     * @throws NullPointerException If key is {@code null}.
-     * @throws IgniteCheckedException If remove operation failed.
-     * @throws CacheFlagException If projection flags validation failed.
-     */
-    @Nullable public V remove(K key, @Nullable IgnitePredicate<Cache.Entry<K, V>>... filter)
-        throws IgniteCheckedException;
-
-    /**
-     * Asynchronously removes given key mapping from cache. If cache previously contained value for the given key,
-     * then this value is returned. In case of {@link CacheMode#PARTITIONED} or {@link CacheMode#REPLICATED}
-     * caches, the value will be loaded from the primary node, which in its turn may load the value
-     * from the swap storage, and consecutively, if it's not in swap,
-     * from the underlying persistent storage. If value has to be loaded from persistent
-     * storage, {@link CacheStore#load(Transaction, Object)} method will be used.
-     * <p>
-     * If the returned value is not needed, method {@link #removex(Object, org.apache.ignite.lang.IgnitePredicate[])} should
-     * always be used instead of this one to avoid the overhead associated with returning of the
-     * previous value.
-     * <p>
-     * If write-through is enabled, the value will be removed from {@link CacheStore}
-     * via {@link CacheStore#remove(Transaction, Object)} method.
-     * <h2 class="header">Transactions</h2>
-     * This method is transactional and will enlist the entry into ongoing transaction
-     * if there is one.
-     * <h2 class="header">Cache Flags</h2>
-     * This method is not available if any of the following flags are set on projection:
-     * {@link CacheFlag#LOCAL}, {@link CacheFlag#READ}.
-     *
-     * @param key Key whose mapping is to be removed from cache.
-     * @param filter Optional filter to check prior to removing value form cache. Note
-     *      that filter is checked atomically together with remove operation.
-     * @return Future for the remove operation.
-     * @throws NullPointerException if the key is {@code null}.
-     * @throws CacheFlagException If projection flags validation failed.
-     */
-    public IgniteInternalFuture<V> removeAsync(K key, IgnitePredicate<Cache.Entry<K, V>>... filter);
-
-    /**
-     * Removes given key mapping from cache.
-     * <p>
-     * This method will return {@code true} if remove did occur, which means that all optionally
-     * provided filters have passed and there was something to remove, {@code false} otherwise.
-     * <p>
-     * If write-through is enabled, the value will be removed from {@link CacheStore}
-     * via {@link CacheStore#remove(Transaction, Object)} method.
-     * <h2 class="header">Transactions</h2>
-     * This method is transactional and will enlist the entry into ongoing transaction
-     * if there is one.
-     * <h2 class="header">Cache Flags</h2>
-     * This method is not available if any of the following flags are set on projection:
-     * {@link CacheFlag#LOCAL}, {@link CacheFlag#READ}.
-     *
-     * @param key Key whose mapping is to be removed from cache.
-     * @param filter Optional filter to check prior to removing value form cache. Note
-     *      that filter is checked atomically together with remove operation.
-     * @return {@code True} if filter passed validation and entry was removed, {@code false} otherwise.
-     *      Note that if filter is not specified, this method will return {@code true}.
-     * @throws NullPointerException if the key is {@code null}.
-     * @throws IgniteCheckedException If remove failed.
-     * @throws CacheFlagException If projection flags validation failed.
-     */
-    public boolean removex(K key, @Nullable IgnitePredicate<Cache.Entry<K, V>>... filter)
-        throws IgniteCheckedException;
-
-    /**
-     * Asynchronously removes given key mapping from cache.
-     * <p>
-     * This method will return {@code true} if remove did occur, which means that all optionally
-     * provided filters have passed and there was something to remove, {@code false} otherwise.
-     * <p>
-     * If write-through is enabled, the value will be removed from {@link CacheStore}
-     * via {@link CacheStore#remove(Transaction, Object)} method.
-     * <h2 class="header">Transactions</h2>
-     * This method is transactional and will enlist the entry into ongoing transaction
-     * if there is one.
-     * <h2 class="header">Cache Flags</h2>
-     * This method is not available if any of the following flags are set on projection:
-     * {@link CacheFlag#LOCAL}, {@link CacheFlag#READ}.
-     *
-     * @param key Key whose mapping is to be removed from cache.
-     * @param filter Optional filter to check prior to removing value form cache. Note
-     *      that filter is checked atomically together with remove operation.
-     * @return Future for the remove operation. The future will return {@code true}
-     *      if optional filters passed validation and remove did occur, {@code false} otherwise.
-     *      Note that if filter is not specified, this method will return {@code true}.
-     * @throws NullPointerException if the key is {@code null}.
-     * @throws CacheFlagException If projection flags validation failed.
-     */
-    public IgniteInternalFuture<Boolean> removexAsync(K key,
-        @Nullable IgnitePredicate<Cache.Entry<K, V>>... filter);
-
-    /**
-     * Removes given key mapping from cache if one exists and value is equal to the passed in value.
-     * <p>
-     * If write-through is enabled, the value will be removed from {@link CacheStore}
-     * via {@link CacheStore#remove(Transaction, Object)} method.
-     * <h2 class="header">Transactions</h2>
-     * This method is transactional and will enlist the entry into ongoing transaction
-     * if there is one.
-     * <h2 class="header">Cache Flags</h2>
-     * This method is not available if any of the following flags are set on projection:
-     * {@link CacheFlag#LOCAL}, {@link CacheFlag#READ}.
-     *
-     * @param key Key whose mapping is to be removed from cache.
-     * @param val Value to match against currently cached value.
-     * @return {@code True} if entry was removed and passed in value matched the cached one,
-     *      {@code false} otherwise.
-     * @throws NullPointerException if the key or value is {@code null}.
-     * @throws IgniteCheckedException If remove failed.
-     * @throws CacheFlagException If projection flags validation failed.
-     */
-    public boolean remove(K key, V val) throws IgniteCheckedException;
-
-    /**
-     * Asynchronously removes given key mapping from cache if one exists and value is equal to the passed in value.
-     * <p>
-     * This method will return {@code true} if remove did occur, which means that all optionally
-     * provided filters have passed and there was something to remove, {@code false} otherwise.
-     * <p>
-     * If write-through is enabled, the value will be removed from {@link CacheStore}
-     * via {@link CacheStore#remove(Transaction, Object)} method.
-     * <h2 class="header">Transactions</h2>
-     * This method is transactional and will enlist the entry into ongoing transaction
-     * if there is one.
-     * <h2 class="header">Cache Flags</h2>
-     * This method is not available if any of the following flags are set on projection:
-     * {@link CacheFlag#LOCAL}, {@link CacheFlag#READ}.
-     *
-     * @param key Key whose mapping is to be removed from cache.
-     * @param val Value to match against currently cached value.
-     * @return Future for the remove operation. The future will return {@code true}
-     *      if currently cached value will match the passed in one.
-     * @throws NullPointerException if the key or value is {@code null}.
-     * @throws CacheFlagException If projection flags validation failed.
-     */
-    public IgniteInternalFuture<Boolean> removeAsync(K key, V val);
-
-    /**
-     * Removes given key mappings from cache for entries for which the optionally passed in filters do
-     * pass.
-     * <p>
-     * If write-through is enabled, the values will be removed from {@link CacheStore}
-     * via {@link CacheStore#removeAll(Transaction, Collection)} method.
-     * <h2 class="header">Transactions</h2>
-     * This method is transactional and will enlist the entry into ongoing transaction
-     * if there is one.
-     * <h2 class="header">Cache Flags</h2>
-     * This method is not available if any of the following flags are set on projection:
-     * {@link CacheFlag#LOCAL}, {@link CacheFlag#READ}.
-     *
-     * @param keys Keys whose mappings are to be removed from cache.
-     * @param filter Optional filter to check prior to removing value form cache. Note
-     *      that filter is checked atomically together with remove operation.
-     * @throws IgniteCheckedException If remove failed.
-     * @throws CacheFlagException If flags validation failed.
-     */
-    public void removeAll(@Nullable Collection<? extends K> keys,
-        @Nullable IgnitePredicate<Cache.Entry<K, V>>... filter) throws IgniteCheckedException;
-
-    /**
-     * Asynchronously removes given key mappings from cache for entries for which the optionally
-     * passed in filters do pass.
-     * <p>
-     * If write-through is enabled, the values will be removed from {@link CacheStore}
-     * via {@link CacheStore#removeAll(Transaction, Collection)} method.
-     * <h2 class="header">Transactions</h2>
-     * This method is transactional and will enlist the entry into ongoing transaction
-     * if there is one.
-     * <h2 class="header">Cache Flags</h2>
-     * This method is not available if any of the following flags are set on projection:
-     * {@link CacheFlag#LOCAL}, {@link CacheFlag#READ}.
-     *
-     * @param keys Keys whose mappings are to be removed from cache.
-     * @param filter Optional filter to check prior to removing value form cache. Note
-     *      that filter is checked atomically together with remove operation.
-     * @return Future for the remove operation. The future will complete whenever
-     *      remove operation completes.
-     * @throws CacheFlagException If flags validation failed.
-     */
-    public IgniteInternalFuture<?> removeAllAsync(@Nullable Collection<? extends K> keys,
-        @Nullable IgnitePredicate<Cache.Entry<K, V>>... filter);
-
-    /**
-     * Removes mappings from cache for entries for which the optionally passed in filters do
-     * pass. If passed in filters are {@code null}, then all entries in cache will be enrolled
-     * into transaction.
-     * <p>
-     * <b>USE WITH CARE</b> - if your cache has many entries that pass through the filter or if filter
-     * is empty, then transaction will quickly become very heavy and slow. Also, locks
-     * are acquired in undefined order, so it may cause a deadlock when used with
-     * other concurrent transactional updates.
-     * <p>
-     * If write-through is enabled, the values will be removed from {@link CacheStore}
-     * via {@link CacheStore#removeAll(Transaction, Collection)} method.
-     * <h2 class="header">Transactions</h2>
-     * This method is transactional and will enlist the entry into ongoing transaction
-     * if there is one.
-     * <h2 class="header">Cache Flags</h2>
-     * This method is not available if any of the following flags are set on projection:
-     * {@link CacheFlag#LOCAL}, {@link CacheFlag#READ}.
-     *
-     * @throws IgniteCheckedException If remove failed.
-     * @throws CacheFlagException If flags validation failed.
-     */
-    public void removeAll() throws IgniteCheckedException;
-
-    /**
-     * @return Remove future.
-     */
-    public IgniteInternalFuture<?> removeAllAsync();
-
-    /**
-     * Asynchronously removes mappings from cache for entries for which the optionally passed in filters do
-     * pass. If passed in filters are {@code null}, then all entries in cache will be enrolled
-     * into transaction.
-     * <p>
-     * <b>USE WITH CARE</b> - if your cache has many entries that pass through the filter or if filter
-     * is empty, then transaction will quickly become very heavy and slow.
-     * <p>
-     * If write-through is enabled, the values will be removed from {@link CacheStore}
-     * via {@link CacheStore#removeAll(Transaction, Collection)} method.
-     * <h2 class="header">Transactions</h2>
-     * This method is transactional and will enlist the entry into ongoing transaction
-     * if there is one.
-     * <h2 class="header">Cache Flags</h2>
-     * This method is not available if any of the following flags are set on projection:
-     * {@link CacheFlag#LOCAL}, {@link CacheFlag#READ}.
-     *
-     * @param filter Filter used to supply keys for remove operation (if {@code null},
-     *      then nothing will be removed).
-     * @return Future for the remove operation. The future will complete whenever
-     *      remove operation completes.
-     * @throws CacheFlagException If flags validation failed.
-     */
-    public IgniteInternalFuture<?> removeAllAsync(@Nullable IgnitePredicate<Cache.Entry<K, V>>... filter);
-
-    /**
-     * Synchronously acquires lock on a cached object with given
-     * key only if the passed in filter (if any) passes. This method
-     * together with filter check will be executed as one atomic operation.
-     * <h2 class="header">Transactions</h2>
-     * Locks are not transactional and should not be used from within transactions. If you do
-     * need explicit locking within transaction, then you should use
-     * {@link TransactionConcurrency#PESSIMISTIC} concurrency control for transaction
-     * which will acquire explicit locks for relevant cache operations.
-     * <h2 class="header">Cache Flags</h2>
-     * This method is not available if any of the following flags are set on projection:
-     * {@link CacheFlag#LOCAL}, {@link CacheFlag#READ}.
-     *
-     * @param key Key to lock.
-     * @param timeout Timeout in milliseconds to wait for lock to be acquired
-     *      ({@code '0'} for no expiration), {@code -1} for immediate failure if
-     *      lock cannot be acquired immediately).
-     * @param filter Optional filter to validate prior to acquiring the lock.
-     * @return {@code True} if all filters passed and lock was acquired,
-     *      {@code false} otherwise.
-     * @throws IgniteCheckedException If lock acquisition resulted in error.
-     * @throws CacheFlagException If flags validation failed.
-     */
-    public boolean lock(K key, long timeout, @Nullable IgnitePredicate<Cache.Entry<K, V>>... filter)
-        throws IgniteCheckedException;
-
-    /**
-     * Asynchronously acquires lock on a cached object with given
-     * key only if the passed in filter (if any) passes. This method
-     * together with filter check will be executed as one atomic operation.
-     * <h2 class="header">Transactions</h2>
-     * Locks are not transactional and should not be used from within transactions. If you do
-     * need explicit locking within transaction, then you should use
-     * {@link TransactionConcurrency#PESSIMISTIC} concurrency control for transaction
-     * which will acquire explicit locks for relevant cache operations.
-     * <h2 class="header">Cache Flags</h2>
-    

<TRUNCATED>

[43/50] [abbrv] incubator-ignite git commit: Merge branches 'sprint-1' and 'sprint-1-release' of https://git-wip-us.apache.org/repos/asf/incubator-ignite into sprint-1-release

Posted by vk...@apache.org.
Merge branches 'sprint-1' and 'sprint-1-release' of https://git-wip-us.apache.org/repos/asf/incubator-ignite into sprint-1-release


Project: http://git-wip-us.apache.org/repos/asf/incubator-ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-ignite/commit/a8dfdcda
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/a8dfdcda
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/a8dfdcda

Branch: refs/heads/master
Commit: a8dfdcda54459de9499135ec05ba94b5e0390fc1
Parents: bfd14e5 66ca116
Author: Yakov Zhdanov <yz...@gridgain.com>
Authored: Mon Feb 16 20:54:37 2015 +0300
Committer: Yakov Zhdanov <yz...@gridgain.com>
Committed: Mon Feb 16 20:54:37 2015 +0300

----------------------------------------------------------------------
 pom.xml | 16 +---------------
 1 file changed, 1 insertion(+), 15 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/a8dfdcda/pom.xml
----------------------------------------------------------------------


[29/50] [abbrv] incubator-ignite git commit: Merge remote-tracking branch 'origin/sprint-1' into sprint-1

Posted by vk...@apache.org.
Merge remote-tracking branch 'origin/sprint-1' into sprint-1


Project: http://git-wip-us.apache.org/repos/asf/incubator-ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-ignite/commit/ff69a8f7
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/ff69a8f7
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/ff69a8f7

Branch: refs/heads/master
Commit: ff69a8f78bb007ce54c4569d1e45f3c8f09ac959
Parents: d786666 761882b
Author: Yakov Zhdanov <yz...@gridgain.com>
Authored: Mon Feb 16 16:23:50 2015 +0300
Committer: Yakov Zhdanov <yz...@gridgain.com>
Committed: Mon Feb 16 16:23:50 2015 +0300

----------------------------------------------------------------------
 .../processors/cache/GridCacheAdapter.java      |  2 +-
 .../cache/GridCacheDeploymentManager.java       | 33 ++++++-------
 .../continuous/CacheContinuousQueryManager.java | 49 ++++++++++++--------
 pom.xml                                         |  2 +-
 4 files changed, 47 insertions(+), 39 deletions(-)
----------------------------------------------------------------------



[03/50] [abbrv] incubator-ignite git commit: # sprint-1 minor

Posted by vk...@apache.org.
# sprint-1 minor


Project: http://git-wip-us.apache.org/repos/asf/incubator-ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-ignite/commit/b1a7ab40
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/b1a7ab40
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/b1a7ab40

Branch: refs/heads/master
Commit: b1a7ab40fbe46709bf1c460e874ad8c1c3620834
Parents: 6e53627
Author: sboikov <sb...@gridgain.com>
Authored: Mon Feb 16 13:48:55 2015 +0300
Committer: sboikov <sb...@gridgain.com>
Committed: Mon Feb 16 13:48:55 2015 +0300

----------------------------------------------------------------------
 .../datastructures/GridTransactionalCacheQueueImpl.java          | 4 ++--
 1 file changed, 2 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/b1a7ab40/modules/core/src/main/java/org/apache/ignite/internal/processors/datastructures/GridTransactionalCacheQueueImpl.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/datastructures/GridTransactionalCacheQueueImpl.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/datastructures/GridTransactionalCacheQueueImpl.java
index 08f15dc..801e27f 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/datastructures/GridTransactionalCacheQueueImpl.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/datastructures/GridTransactionalCacheQueueImpl.java
@@ -110,7 +110,7 @@ public class GridTransactionalCacheQueueImpl<T> extends GridCacheQueueAdapter<T>
 
                         retVal = (T)cache.remove(itemKey(idx), null);
 
-                        assert retVal != null;
+                        assert retVal != null : idx;
                     }
                     else
                         retVal = null;
@@ -212,7 +212,7 @@ public class GridTransactionalCacheQueueImpl<T> extends GridCacheQueueAdapter<T>
 
                         boolean rmv = cache.removex(itemKey(idx));
 
-                        assert rmv;
+                        assert rmv : idx;
                     }
 
                     tx.commit();


[46/50] [abbrv] incubator-ignite git commit: Merge branch 'sprint-1' of https://git-wip-us.apache.org/repos/asf/incubator-ignite into sprint-1-release

Posted by vk...@apache.org.
Merge branch 'sprint-1' of https://git-wip-us.apache.org/repos/asf/incubator-ignite into sprint-1-release


Project: http://git-wip-us.apache.org/repos/asf/incubator-ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-ignite/commit/4fef1900
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/4fef1900
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/4fef1900

Branch: refs/heads/master
Commit: 4fef190064364dfac5d59d89e356de71420fcc4f
Parents: bfd14e5 659b432
Author: Valentin Kulichenko <vk...@gridgain.com>
Authored: Mon Feb 16 17:03:24 2015 -0800
Committer: Valentin Kulichenko <vk...@gridgain.com>
Committed: Mon Feb 16 17:03:24 2015 -0800

----------------------------------------------------------------------
 docs/ignite_readme.md  |  12 ++++++------
 docs/ignite_readme.pdf | Bin 76810 -> 77136 bytes
 docs/release_notes.md  |  16 ++++++++++++++++
 docs/release_notes.pdf | Bin 59911 -> 33174 bytes
 pom.xml                |  16 +---------------
 5 files changed, 23 insertions(+), 21 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/4fef1900/pom.xml
----------------------------------------------------------------------


[12/50] [abbrv] incubator-ignite git commit: Merge branches 'sprint-1' and 'sprint-1-release' of https://git-wip-us.apache.org/repos/asf/incubator-ignite into sprint-1-release

Posted by vk...@apache.org.
Merge branches 'sprint-1' and 'sprint-1-release' of https://git-wip-us.apache.org/repos/asf/incubator-ignite into sprint-1-release


Project: http://git-wip-us.apache.org/repos/asf/incubator-ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-ignite/commit/9b3bae79
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/9b3bae79
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/9b3bae79

Branch: refs/heads/master
Commit: 9b3bae79d5a51406a9b993a5f4ea4480bf795cb7
Parents: 34d0e44 3ba4f3c
Author: Yakov Zhdanov <yz...@gridgain.com>
Authored: Mon Feb 16 15:14:20 2015 +0300
Committer: Yakov Zhdanov <yz...@gridgain.com>
Committed: Mon Feb 16 15:14:20 2015 +0300

----------------------------------------------------------------------
 .../store/dummy/CacheDummyPersonStore.java      |  11 ++
 .../hibernate/CacheHibernatePersonStore.java    |  12 ++
 .../store/jdbc/CacheJdbcPersonStore.java        |  11 +-
 .../cache/store/CacheLoadOnlyStoreAdapter.java  |   2 +-
 .../apache/ignite/cache/store/CacheStore.java   |  31 +---
 .../ignite/cache/store/CacheStoreAdapter.java   |   2 +-
 .../ignite/cache/store/CacheStoreSession.java   |   3 +
 .../store/jdbc/CacheAbstractJdbcStore.java      |  24 ++-
 .../cache/store/jdbc/CacheJdbcBlobStore.java    |  11 ++
 .../apache/ignite/cluster/ClusterMetrics.java   |  41 +++++
 .../org/apache/ignite/compute/ComputeTask.java  |   3 +-
 .../configuration/CacheConfiguration.java       |  26 +--
 .../ClusterLocalNodeMetricsMXBeanImpl.java      |  10 ++
 .../ignite/internal/ClusterMetricsSnapshot.java |  52 ++++++
 .../discovery/GridDiscoveryManager.java         |   2 +
 .../cache/CacheStoreBalancingWrapper.java       |   2 +-
 .../cache/GridCacheLoaderWriterStore.java       |   2 +-
 .../processors/cache/GridCacheMapEntry.java     |   4 +-
 .../processors/cache/GridCacheProcessor.java    |   2 +-
 .../processors/cache/GridCacheStoreManager.java |  84 +++++----
 .../cache/GridCacheWriteBehindStore.java        |   2 +-
 .../dht/atomic/GridDhtAtomicCache.java          |   2 +-
 .../transactions/IgniteTxLocalAdapter.java      |   2 +-
 .../GridTransactionalCacheQueueImpl.java        |   4 +-
 .../processors/query/GridQueryProcessor.java    |   6 +-
 .../processors/resource/GridResourceIoc.java    |  48 +++--
 .../resource/GridResourceProcessor.java         |  21 +++
 .../node/VisorNodeEventsCollectorTask.java      |   9 +-
 .../mxbean/ClusterLocalNodeMetricsMXBean.java   |   9 +
 .../resources/CacheStoreSessionResource.java    |  41 +++++
 .../apache/ignite/resources/package-info.java   |  22 +++
 .../org/apache/ignite/resources/package.html    |  25 ---
 .../store/GridCacheBalancingStoreSelfTest.java  |   2 +-
 .../cache/store/GridGeneratingTestStore.java    |   2 +-
 .../store/jdbc/CacheJdbcPojoStoreTest.java      |   2 +-
 ...idCacheConfigurationConsistencySelfTest.java |   2 +-
 .../cache/GridCacheGenericTestStore.java        |   2 +-
 .../cache/GridCacheLifecycleAwareSelfTest.java  |   2 +-
 .../cache/GridCacheStorePutxSelfTest.java       |   2 +-
 .../processors/cache/GridCacheTestStore.java    |  15 +-
 .../IgniteTxStoreExceptionAbstractSelfTest.java |   2 +-
 .../IgniteCrossCacheTxStoreSelfTest.java        |  14 +-
 .../near/GridCacheNearMetricsSelfTest.java      |   4 +-
 ...idCachePartitionedHitsAndMissesSelfTest.java | 177 +++++++++++++++++++
 .../IgniteCacheStoreSessionAbstractTest.java    |  20 ++-
 ...ClusterMetricsSnapshotSerializeSelfTest.java |   6 +-
 .../cache/GridAbstractCacheStoreSelfTest.java   |   2 +-
 .../IgniteCacheMetricsSelfTestSuite.java        |  21 +--
 .../hibernate/CacheHibernateBlobStore.java      |  11 ++
 ...idCachePartitionedHitsAndMissesSelfTest.java | 176 ------------------
 .../IgniteH2IndexingSpiTestSuite.java           |   2 -
 .../commands/cache/VisorCacheCommand.scala      |   2 +-
 .../commands/top/VisorTopologyCommand.scala     |   3 +-
 .../scala/org/apache/ignite/visor/visor.scala   |   2 +-
 .../cache/VisorCacheClearCommandSpec.scala      |   4 +-
 .../commands/cache/VisorCacheCommandSpec.scala  |   4 +-
 .../cache/VisorCacheCompactCommandSpec.scala    |   4 +-
 .../cswap/VisorCacheSwapCommandSpec.scala       |   4 +-
 pom.xml                                         |  38 +++-
 59 files changed, 696 insertions(+), 355 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/9b3bae79/pom.xml
----------------------------------------------------------------------


[18/50] [abbrv] incubator-ignite git commit: Merge branches 'ignite-public-api-cleanup' and 'sprint-1' of https://git-wip-us.apache.org/repos/asf/incubator-ignite into ignite-public-api-cleanup

Posted by vk...@apache.org.
Merge branches 'ignite-public-api-cleanup' and 'sprint-1' of https://git-wip-us.apache.org/repos/asf/incubator-ignite into ignite-public-api-cleanup


Project: http://git-wip-us.apache.org/repos/asf/incubator-ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-ignite/commit/d13fcd06
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/d13fcd06
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/d13fcd06

Branch: refs/heads/master
Commit: d13fcd06bb520a36a232b77c00263d62e6b5c928
Parents: f020985 19c1b5c
Author: AKuznetsov <ak...@gridgain.com>
Authored: Mon Feb 16 19:46:54 2015 +0700
Committer: AKuznetsov <ak...@gridgain.com>
Committed: Mon Feb 16 19:46:54 2015 +0700

----------------------------------------------------------------------
 .../store/dummy/CacheDummyPersonStore.java      |  11 ++
 .../hibernate/CacheHibernatePersonStore.java    |  12 ++
 .../store/jdbc/CacheJdbcPersonStore.java        |  11 +-
 .../cache/store/CacheLoadOnlyStoreAdapter.java  |   2 +-
 .../apache/ignite/cache/store/CacheStore.java   |  31 +---
 .../ignite/cache/store/CacheStoreAdapter.java   |   2 +-
 .../ignite/cache/store/CacheStoreSession.java   |   3 +
 .../store/jdbc/CacheAbstractJdbcStore.java      |  24 ++-
 .../cache/store/jdbc/CacheJdbcBlobStore.java    |  11 ++
 .../apache/ignite/cluster/ClusterMetrics.java   |  41 +++++
 .../org/apache/ignite/compute/ComputeTask.java  |   3 +-
 .../configuration/CacheConfiguration.java       |  26 +--
 .../ClusterLocalNodeMetricsMXBeanImpl.java      |  10 ++
 .../ignite/internal/ClusterMetricsSnapshot.java |  52 ++++++
 .../discovery/GridDiscoveryManager.java         |   2 +
 .../cache/CacheStoreBalancingWrapper.java       |   2 +-
 .../cache/GridCacheLoaderWriterStore.java       |   2 +-
 .../processors/cache/GridCacheMapEntry.java     |   4 +-
 .../processors/cache/GridCacheProcessor.java    |   2 +-
 .../processors/cache/GridCacheStoreManager.java |  84 +++++----
 .../cache/GridCacheWriteBehindStore.java        |   2 +-
 .../dht/atomic/GridDhtAtomicCache.java          |   2 +-
 .../transactions/IgniteTxLocalAdapter.java      |   2 +-
 .../GridTransactionalCacheQueueImpl.java        |   4 +-
 .../processors/query/GridQueryProcessor.java    |   6 +-
 .../processors/resource/GridResourceIoc.java    |  48 +++--
 .../resource/GridResourceProcessor.java         |  21 +++
 .../node/VisorNodeEventsCollectorTask.java      |   9 +-
 .../mxbean/ClusterLocalNodeMetricsMXBean.java   |   9 +
 .../resources/CacheStoreSessionResource.java    |  41 +++++
 .../apache/ignite/resources/package-info.java   |  22 +++
 .../org/apache/ignite/resources/package.html    |  25 ---
 .../store/GridCacheBalancingStoreSelfTest.java  |   2 +-
 .../cache/store/GridGeneratingTestStore.java    |   2 +-
 .../store/jdbc/CacheJdbcPojoStoreTest.java      |   2 +-
 ...idCacheConfigurationConsistencySelfTest.java |   2 +-
 .../cache/GridCacheGenericTestStore.java        |   2 +-
 .../cache/GridCacheLifecycleAwareSelfTest.java  |   2 +-
 .../cache/GridCacheStorePutxSelfTest.java       |   2 +-
 .../processors/cache/GridCacheTestStore.java    |  15 +-
 .../IgniteTxStoreExceptionAbstractSelfTest.java |   2 +-
 .../IgniteCrossCacheTxStoreSelfTest.java        |  14 +-
 .../near/GridCacheNearMetricsSelfTest.java      |   4 +-
 ...idCachePartitionedHitsAndMissesSelfTest.java | 177 +++++++++++++++++++
 .../IgniteCacheStoreSessionAbstractTest.java    |  20 ++-
 ...ClusterMetricsSnapshotSerializeSelfTest.java |   6 +-
 .../cache/GridAbstractCacheStoreSelfTest.java   |   2 +-
 .../IgniteCacheMetricsSelfTestSuite.java        |  21 +--
 .../hibernate/CacheHibernateBlobStore.java      |  11 ++
 ...idCachePartitionedHitsAndMissesSelfTest.java | 176 ------------------
 .../IgniteH2IndexingSpiTestSuite.java           |   2 -
 .../commands/cache/VisorCacheCommand.scala      |   2 +-
 .../commands/top/VisorTopologyCommand.scala     |   3 +-
 .../scala/org/apache/ignite/visor/visor.scala   |   2 +-
 .../cache/VisorCacheClearCommandSpec.scala      |   4 +-
 .../commands/cache/VisorCacheCommandSpec.scala  |   4 +-
 .../cache/VisorCacheCompactCommandSpec.scala    |   4 +-
 .../cswap/VisorCacheSwapCommandSpec.scala       |   4 +-
 pom.xml                                         |  40 ++++-
 59 files changed, 697 insertions(+), 356 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/d13fcd06/pom.xml
----------------------------------------------------------------------


[25/50] [abbrv] incubator-ignite git commit: # sprint-1 Ignore exception from user cache listener

Posted by vk...@apache.org.
# sprint-1 Ignore exception from user cache listener


Project: http://git-wip-us.apache.org/repos/asf/incubator-ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-ignite/commit/9138bd62
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/9138bd62
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/9138bd62

Branch: refs/heads/master
Commit: 9138bd628a869ff0e9342f738e58880825807f9a
Parents: 19c1b5c
Author: sboikov <sb...@gridgain.com>
Authored: Mon Feb 16 16:15:08 2015 +0300
Committer: sboikov <sb...@gridgain.com>
Committed: Mon Feb 16 16:15:08 2015 +0300

----------------------------------------------------------------------
 .../continuous/CacheContinuousQueryManager.java | 49 ++++++++++++--------
 1 file changed, 30 insertions(+), 19 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/9138bd62/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/query/continuous/CacheContinuousQueryManager.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/query/continuous/CacheContinuousQueryManager.java b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/query/continuous/CacheContinuousQueryManager.java
index b688919..fc9811e 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/query/continuous/CacheContinuousQueryManager.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/query/continuous/CacheContinuousQueryManager.java
@@ -596,8 +596,12 @@ public class CacheContinuousQueryManager<K, V> extends GridCacheManagerAdapter<K
         /** */
         private final Cache<K, V> cache;
 
+        /** */
+        private final IgniteLogger log;
+
         /**
          * @param impl Listener.
+         * @param cache Cache.
          */
         JCacheQueryLocalListener(CacheEntryListener<K, V> impl, Cache<K, V> cache) {
             assert impl != null;
@@ -605,42 +609,49 @@ public class CacheContinuousQueryManager<K, V> extends GridCacheManagerAdapter<K
 
             this.impl = impl;
             this.cache = cache;
+
+            log = cache.unwrap(Ignite.class).log().getLogger(CacheContinuousQueryManager.class);
         }
 
         /** {@inheritDoc} */
         @Override public void onUpdated(Iterable<CacheEntryEvent<? extends K, ? extends V>> evts) {
             for (CacheEntryEvent<? extends K, ? extends V> evt : evts) {
-                switch (evt.getEventType()) {
-                    case CREATED:
-                        assert impl instanceof CacheEntryCreatedListener;
+                try {
+                    switch (evt.getEventType()) {
+                        case CREATED:
+                            assert impl instanceof CacheEntryCreatedListener;
 
-                        ((CacheEntryCreatedListener<K, V>)impl).onCreated(singleton(evt));
+                            ((CacheEntryCreatedListener<K, V>)impl).onCreated(singleton(evt));
 
-                        break;
+                            break;
 
-                    case UPDATED:
-                        assert impl instanceof CacheEntryUpdatedListener;
+                        case UPDATED:
+                            assert impl instanceof CacheEntryUpdatedListener;
 
-                        ((CacheEntryUpdatedListener<K, V>)impl).onUpdated(singleton(evt));
+                            ((CacheEntryUpdatedListener<K, V>)impl).onUpdated(singleton(evt));
 
-                        break;
+                            break;
 
-                    case REMOVED:
-                        assert impl instanceof CacheEntryRemovedListener;
+                        case REMOVED:
+                            assert impl instanceof CacheEntryRemovedListener;
 
-                        ((CacheEntryRemovedListener<K, V>)impl).onRemoved(singleton(evt));
+                            ((CacheEntryRemovedListener<K, V>)impl).onRemoved(singleton(evt));
 
-                        break;
+                            break;
 
-                    case EXPIRED:
-                        assert impl instanceof CacheEntryExpiredListener;
+                        case EXPIRED:
+                            assert impl instanceof CacheEntryExpiredListener;
 
-                        ((CacheEntryExpiredListener<K, V>)impl).onExpired(singleton(evt));
+                            ((CacheEntryExpiredListener<K, V>)impl).onExpired(singleton(evt));
 
-                        break;
+                            break;
 
-                    default:
-                        throw new IllegalStateException("Unknown type: " + evt.getEventType());
+                        default:
+                            throw new IllegalStateException("Unknown type: " + evt.getEventType());
+                    }
+                }
+                catch (Exception e) {
+                    U.error(log, "CacheEntryCreatedListener failed: " + e);
                 }
             }
         }


[30/50] [abbrv] incubator-ignite git commit: Merge branch 'ignite-public-api-cleanup' into sprint-1

Posted by vk...@apache.org.
Merge branch 'ignite-public-api-cleanup' into sprint-1


Project: http://git-wip-us.apache.org/repos/asf/incubator-ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-ignite/commit/a2b5123e
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/a2b5123e
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/a2b5123e

Branch: refs/heads/master
Commit: a2b5123efc21b5bbb80319bc2b9a0e96680f3479
Parents: ff69a8f 1441a7f
Author: AKuznetsov <ak...@gridgain.com>
Authored: Mon Feb 16 20:24:58 2015 +0700
Committer: AKuznetsov <ak...@gridgain.com>
Committed: Mon Feb 16 20:24:58 2015 +0700

----------------------------------------------------------------------
 .../examples/datagrid/CacheQueryExample.java    |   25 +-
 .../starschema/CacheStarSchemaExample.java      |   11 +-
 .../examples/ScalarCacheAffinityExample1.scala  |    6 +-
 .../examples/ScalarCacheAffinityExample2.scala  |    4 +-
 .../ScalarCacheAffinitySimpleExample.scala      |   10 +-
 .../scalar/examples/ScalarCacheExample.scala    |   49 +-
 .../ScalarCachePopularNumbersExample.scala      |   13 +-
 .../examples/ScalarCacheQueryExample.scala      |   48 +-
 .../examples/ScalarSnowflakeSchemaExample.scala |   37 +-
 .../src/main/java/org/apache/ignite/Ignite.java |   27 -
 .../apache/ignite/IgniteSystemProperties.java   |  120 --
 .../configuration/IgniteConfiguration.java      |  353 ---
 .../ignite/internal/GridKernalContext.java      |    8 -
 .../ignite/internal/GridKernalContextImpl.java  |   12 -
 .../ignite/internal/IgniteComponentType.java    |    7 -
 .../org/apache/ignite/internal/IgniteEx.java    |   12 -
 .../apache/ignite/internal/IgniteKernal.java    |  217 +-
 .../org/apache/ignite/internal/IgnitionEx.java  |   49 -
 .../processors/email/GridEmailHolder.java       |  111 -
 .../email/IgniteEmailProcessorAdapter.java      |   84 -
 .../email/IgniteNoopEmailProcessor.java         |   55 -
 .../internal/processors/email/package.html      |   24 -
 .../visor/node/VisorEmailConfiguration.java     |  177 --
 .../visor/node/VisorGridConfiguration.java      |   18 -
 .../visor/node/VisorLifecycleConfiguration.java |   19 -
 .../ignite/startup/BasicWarmupClosure.java      |    6 +-
 .../GridCacheFieldsQueryNoDataSelfTest.java     |    4 +-
 .../cache/GridCacheOffHeapSelfTest.java         |    4 +-
 .../cache/GridCacheSwapPreloadSelfTest.java     |    3 +-
 .../IgniteClientAffinityAssignmentSelfTest.java |    5 +-
 .../cache/IgnitePutAllLargeBatchSelfTest.java   |    8 +-
 ...tAllUpdateNonPreloadedPartitionSelfTest.java |    4 +-
 .../cache/IgniteTxMultiNodeAbstractTest.java    |    3 +-
 ...dCacheMultithreadedFailoverAbstractTest.java |    3 +-
 .../GridCacheNodeFailureAbstractTest.java       |    3 +-
 ...chePartitionedReloadAllAbstractSelfTest.java |    8 +-
 ...ridCacheContinuousQueryAbstractSelfTest.java |    4 +-
 ...dCacheAbstractReduceFieldsQuerySelfTest.java |    4 +-
 .../GridDataLoaderProcessorSelfTest.java        |    2 +-
 .../processors/igfs/IgfsCacheSelfTest.java      |    5 +-
 .../ignite/testframework/junits/IgniteMock.java |   10 -
 modules/email/licenses/apache-2.0.txt           |  202 --
 modules/email/pom.xml                           |   51 -
 modules/email/readme.txt                        |   34 -
 .../processors/email/IgniteEmailProcessor.java  |  296 ---
 ...idHadoopDefaultMapReducePlannerSelfTest.java |   10 -
 ...idHibernateL2CacheConfigurationSelfTest.java |    3 +-
 .../hibernate/GridHibernateL2CacheSelfTest.java |    3 +-
 .../GridCacheAbstractFieldsQuerySelfTest.java   |    3 +-
 .../cache/GridCacheAbstractQuerySelfTest.java   |    5 +-
 .../cache/GridCacheCrossCacheQuerySelfTest.java |   12 +-
 .../GridCacheCrossCacheQuerySelfTestNewApi.java |    7 +-
 .../processors/cache/GridCacheSwapSelfTest.java |    4 +-
 .../near/GridCachePartitionedQuerySelfTest.java |    2 +-
 .../GridCacheReplicatedQuerySelfTest.java       |    6 +-
 .../ignite/scalar/ScalarConversions.scala       |   47 +-
 .../ignite/scalar/pimps/ScalarCachePimp.scala   |  662 +++++-
 .../pimps/ScalarCacheProjectionPimp.scala       | 2004 ------------------
 .../scala/org/apache/ignite/scalar/scalar.scala |   25 +-
 .../tests/ScalarAffinityRoutingSpec.scala       |   12 +-
 .../scalar/tests/ScalarCacheQueriesSpec.scala   |  466 +---
 .../ignite/scalar/tests/ScalarCacheSpec.scala   |   10 +-
 .../org/apache/ignite/IgniteSpringBean.java     |   20 +-
 .../ignite/cache/spring/SpringCacheManager.java |    2 +-
 .../commands/alert/VisorAlertCommand.scala      |   83 +-
 .../config/VisorConfigurationCommand.scala      |   15 -
 .../commands/alert/VisorAlertCommandSpec.scala  |    1 -
 .../config/VisorConfigurationCommandSpec.scala  |    1 -
 .../disco/VisorDiscoveryCommandSpec.scala       |    1 -
 .../events/VisorEventsCommandSpec.scala         |    1 -
 .../visor/commands/gc/VisorGcCommandSpec.scala  |    1 -
 .../commands/tasks/VisorTasksCommandSpec.scala  |    2 -
 pom.xml                                         |    1 -
 73 files changed, 875 insertions(+), 4689 deletions(-)
----------------------------------------------------------------------



[40/50] [abbrv] incubator-ignite git commit: # sprint-1 Use atomic cache in queue example (with tx fails due to IGNITE-264)

Posted by vk...@apache.org.
# sprint-1 Use atomic cache in queue example (with tx fails due to IGNITE-264)


Project: http://git-wip-us.apache.org/repos/asf/incubator-ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-ignite/commit/82924b62
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/82924b62
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/82924b62

Branch: refs/heads/master
Commit: 82924b62eb16567ce7a35f37c4486b931ee3beb8
Parents: 5926470
Author: sboikov <sb...@gridgain.com>
Authored: Mon Feb 16 17:42:54 2015 +0300
Committer: sboikov <sb...@gridgain.com>
Committed: Mon Feb 16 17:42:54 2015 +0300

----------------------------------------------------------------------
 examples/config/example-cache.xml                         | 10 ++++++++++
 .../examples/datastructures/IgniteQueueExample.java       |  2 +-
 2 files changed, 11 insertions(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/82924b62/examples/config/example-cache.xml
----------------------------------------------------------------------
diff --git a/examples/config/example-cache.xml b/examples/config/example-cache.xml
index ad8d5e8..2ccecf9 100644
--- a/examples/config/example-cache.xml
+++ b/examples/config/example-cache.xml
@@ -62,6 +62,16 @@
                     <property name="backups" value="1"/>
                 </bean>
 
+                <!-- Partitioned cache example configuration (Atomic mode, PRIMARY write order mode). -->
+                <bean parent="cache-template">
+                    <property name="name" value="partitioned_primary"/>
+                    <property name="cacheMode" value="PARTITIONED"/>
+                    <property name="atomicityMode" value="ATOMIC"/>
+                    <property name="atomicWriteOrderMode" value="PRIMARY"/>
+                    <property name="distributionMode" value="PARTITIONED_ONLY"/>
+                    <property name="backups" value="1"/>
+                </bean>
+
                 <!-- Partitioned cache example configuration (Transactional mode). -->
                 <bean parent="cache-template">
                     <property name="name" value="partitioned_tx"/>

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/82924b62/examples/src/main/java/org/apache/ignite/examples/datastructures/IgniteQueueExample.java
----------------------------------------------------------------------
diff --git a/examples/src/main/java/org/apache/ignite/examples/datastructures/IgniteQueueExample.java b/examples/src/main/java/org/apache/ignite/examples/datastructures/IgniteQueueExample.java
index 519d11a..8f915f9 100644
--- a/examples/src/main/java/org/apache/ignite/examples/datastructures/IgniteQueueExample.java
+++ b/examples/src/main/java/org/apache/ignite/examples/datastructures/IgniteQueueExample.java
@@ -36,7 +36,7 @@ import java.util.*;
  */
 public class IgniteQueueExample {
     /** Cache name. */
-    private static final String CACHE_NAME = "partitioned_tx";
+    private static final String CACHE_NAME = "partitioned_primary";
 
     /** Number of retries */
     private static final int RETRIES = 20;


[36/50] [abbrv] incubator-ignite git commit: sprint-1: moved cache projection to internal

Posted by vk...@apache.org.
sprint-1: moved cache projection to internal


Project: http://git-wip-us.apache.org/repos/asf/incubator-ignite/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-ignite/commit/f27a989c
Tree: http://git-wip-us.apache.org/repos/asf/incubator-ignite/tree/f27a989c
Diff: http://git-wip-us.apache.org/repos/asf/incubator-ignite/diff/f27a989c

Branch: refs/heads/master
Commit: f27a989cfa963d3e6301118f5337c309839ea72f
Parents: 56da893
Author: Yakov Zhdanov <yz...@gridgain.com>
Authored: Mon Feb 16 16:45:02 2015 +0300
Committer: Yakov Zhdanov <yz...@gridgain.com>
Committed: Mon Feb 16 16:45:02 2015 +0300

----------------------------------------------------------------------
 .../java/org/apache/ignite/IgniteCache.java     |    4 +-
 .../apache/ignite/cache/CacheInterceptor.java   |    1 +
 .../apache/ignite/cache/CacheProjection.java    | 1925 ------------------
 .../java/org/apache/ignite/cache/GridCache.java |    1 +
 .../configuration/CacheConfiguration.java       |    1 +
 .../internal/processors/cache/CacheFlag.java    |    6 +-
 .../processors/cache/CacheProjection.java       | 1925 ++++++++++++++++++
 .../processors/cache/GridCacheAdapter.java      |    2 +-
 .../processors/cache/GridCacheMapAdapter.java   |    1 -
 .../processors/cache/GridCachePeekMode.java     |    2 +-
 .../processors/cache/GridCacheProjectionEx.java |    1 -
 .../cache/query/GridCacheQueriesProxy.java      |    1 -
 .../datastructures/GridCacheAtomicLongImpl.java |    1 -
 .../GridCacheAtomicReferenceImpl.java           |    1 -
 .../GridCacheAtomicSequenceImpl.java            |    1 -
 .../GridCacheAtomicStampedImpl.java             |    1 -
 .../GridCacheCountDownLatchImpl.java            |    1 -
 .../internal/visor/query/VisorQueryTask.java    |    1 +
 .../apache/ignite/transactions/Transaction.java |    3 +-
 ...dCacheAbstractReduceFieldsQuerySelfTest.java |    1 +
 .../hadoop/jobtracker/GridHadoopJobTracker.java |    1 -
 .../GridHibernateAccessStrategyAdapter.java     |    2 +-
 .../cache/GridCacheOffHeapAndSwapSelfTest.java  |    3 +-
 .../apache/ignite/cache/spring/SpringCache.java |    2 +-
 24 files changed, 1942 insertions(+), 1946 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f27a989c/modules/core/src/main/java/org/apache/ignite/IgniteCache.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/IgniteCache.java b/modules/core/src/main/java/org/apache/ignite/IgniteCache.java
index 957b402..05c496e 100644
--- a/modules/core/src/main/java/org/apache/ignite/IgniteCache.java
+++ b/modules/core/src/main/java/org/apache/ignite/IgniteCache.java
@@ -38,8 +38,8 @@ import java.util.concurrent.locks.*;
  * Main entry point for all <b>Data Grid APIs.</b> You can get a named cache by calling {@link Ignite#jcache(String)}
  * method.
  * <h1 class="header">Functionality</h1>
- * This API extends {@link org.apache.ignite.cache.CacheProjection} API which contains vast majority of cache functionality
- * and documentation. In addition to {@link org.apache.ignite.cache.CacheProjection} functionality this API provides:
+ * This API extends {@link CacheProjection} API which contains vast majority of cache functionality
+ * and documentation. In addition to {@link CacheProjection} functionality this API provides:
  * <ul>
  * <li>
  *  Various {@code 'loadCache(..)'} methods to load cache either synchronously or asynchronously.

http://git-wip-us.apache.org/repos/asf/incubator-ignite/blob/f27a989c/modules/core/src/main/java/org/apache/ignite/cache/CacheInterceptor.java
----------------------------------------------------------------------
diff --git a/modules/core/src/main/java/org/apache/ignite/cache/CacheInterceptor.java b/modules/core/src/main/java/org/apache/ignite/cache/CacheInterceptor.java
index 2b03338..a167215 100644
--- a/modules/core/src/main/java/org/apache/ignite/cache/CacheInterceptor.java
+++ b/modules/core/src/main/java/org/apache/ignite/cache/CacheInterceptor.java
@@ -17,6 +17,7 @@
 
 package org.apache.ignite.cache;
 
+import org.apache.ignite.internal.processors.cache.*;
 import org.apache.ignite.lang.*;
 import org.jetbrains.annotations.*;