You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ignite.apache.org by sb...@apache.org on 2016/06/28 13:07:36 UTC

[49/50] [abbrv] ignite git commit: Merge remote-tracking branch 'remotes/origin/master' into ignite-1232

Merge remote-tracking branch 'remotes/origin/master' into ignite-1232

# Conflicts:
#	modules/core/src/main/java/org/apache/ignite/internal/managers/communication/GridIoManager.java
#	modules/core/src/main/java/org/apache/ignite/internal/managers/communication/GridIoPolicy.java
#	modules/core/src/main/java/org/apache/ignite/internal/processors/closure/GridClosureProcessor.java
#	modules/core/src/main/java/org/apache/ignite/internal/processors/igfs/IgfsIpcHandler.java
#	modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/IgniteH2Indexing.java
#	modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/opt/GridH2AbstractKeyValueRow.java
#	modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/opt/GridH2IndexBase.java
#	modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/opt/GridH2Table.java
#	modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/sql/GridSqlQuerySplitter.java
#	modules/indexing/src/test/java/org/apache/ignite/testsuites/IgniteCacheQuerySelfTestSuite.java


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

Branch: refs/heads/ignite-1232
Commit: bc1902b8098ce783894f3051c374b0152f2260c3
Parents: 1c19f72 cbb77c9
Author: sboikov <sb...@gridgain.com>
Authored: Tue Jun 28 16:04:28 2016 +0300
Committer: sboikov <sb...@gridgain.com>
Committed: Tue Jun 28 16:04:28 2016 +0300

----------------------------------------------------------------------
 .gitignore                                      |   42 +-
 RELEASE_NOTES.txt                               |   89 +
 assembly/dependencies-fabric-lgpl.xml           |    3 +
 assembly/dependencies-fabric.xml                |    3 +
 assembly/dependencies-schema-import.xml         |    1 +
 assembly/release-fabric-base.xml                |   30 +
 assembly/release-schema-import.xml              |    2 +-
 config/hadoop/default-config.xml                |  111 +-
 examples/config/filesystem/example-igfs.xml     |    3 -
 examples/pom.xml                                |    2 +-
 examples/schema-import/pom.xml                  |    2 +-
 .../java/org/apache/ignite/schema/Demo.java     |   23 +-
 .../ignite/schema/H2DataSourceFactory.java      |   35 +
 .../CacheContinuousAsyncQueryExample.java       |  138 +
 .../datagrid/CacheContinuousQueryExample.java   |   13 +-
 .../store/CacheLoadOnlyStoreExample.java        |  171 +
 .../datastructures/IgniteLockExample.java       |  293 ++
 .../streaming/StreamVisitorExample.java         |   31 +-
 examples/src/main/resources/person.csv          |   20 +
 .../ignite/examples/CacheExamplesSelfTest.java  |   16 +
 modules/aop/pom.xml                             |    2 +-
 modules/apache-license-gen/pom.xml              |    2 +-
 modules/aws/pom.xml                             |   40 +-
 modules/benchmarks/pom.xml                      |    2 +-
 .../internal/benchmarks/model/IntValue.java     |   19 +-
 modules/camel/pom.xml                           |    2 +-
 modules/cassandra/README.txt                    |   32 +
 modules/cassandra/licenses/apache-2.0.txt       |  202 ++
 modules/cassandra/pom.xml                       |  337 ++
 .../store/cassandra/CassandraCacheStore.java    |  409 +++
 .../cassandra/CassandraCacheStoreFactory.java   |  200 +
 .../store/cassandra/common/CassandraHelper.java |  133 +
 .../cassandra/common/PropertyMappingHelper.java |  220 ++
 .../store/cassandra/common/RandomSleeper.java   |  104 +
 .../store/cassandra/common/SystemHelper.java    |   46 +
 .../store/cassandra/datasource/Credentials.java |   37 +
 .../store/cassandra/datasource/DataSource.java  |  550 +++
 .../cassandra/datasource/PlainCredentials.java  |   50 +
 .../persistence/KeyPersistenceSettings.java     |  274 ++
 .../KeyValuePersistenceSettings.java            |  478 +++
 .../persistence/PersistenceController.java      |  421 +++
 .../persistence/PersistenceSettings.java        |  335 ++
 .../persistence/PersistenceStrategy.java        |   62 +
 .../store/cassandra/persistence/PojoField.java  |  219 ++
 .../cassandra/persistence/PojoKeyField.java     |   91 +
 .../cassandra/persistence/PojoValueField.java   |  152 +
 .../persistence/ValuePersistenceSettings.java   |  107 +
 .../cassandra/serializer/JavaSerializer.java    |   81 +
 .../cassandra/serializer/KryoSerializer.java    |   93 +
 .../store/cassandra/serializer/Serializer.java  |   43 +
 .../session/BatchExecutionAssistant.java        |   95 +
 .../cassandra/session/BatchLoaderAssistant.java |   47 +
 .../cassandra/session/CassandraSession.java     |   60 +
 .../cassandra/session/CassandraSessionImpl.java |  832 +++++
 .../cassandra/session/ExecutionAssistant.java   |   77 +
 .../session/GenericBatchExecutionAssistant.java |   71 +
 .../session/LoadCacheCustomQueryWorker.java     |  105 +
 .../cassandra/session/pool/SessionPool.java     |  173 +
 .../cassandra/session/pool/SessionWrapper.java  |   71 +
 .../store/cassandra/utils/DDLGenerator.java     |   64 +
 .../aws/cassandra/cassandra-bootstrap.sh        |  373 ++
 .../bootstrap/aws/cassandra/cassandra-env.sh    |  283 ++
 .../bootstrap/aws/cassandra/cassandra-start.sh  |  550 +++
 .../aws/cassandra/cassandra-template.yaml       |  889 +++++
 .../bootstrap/aws/ignite/ignite-bootstrap.sh    |  384 ++
 .../ignite/ignite-cassandra-server-template.xml |  177 +
 .../src/test/bootstrap/aws/ignite/ignite-env.sh |   25 +
 .../test/bootstrap/aws/ignite/ignite-start.sh   |  637 ++++
 .../src/test/bootstrap/aws/logs-collector.sh    |  102 +
 .../tests/ignite-cassandra-client-template.xml  |  173 +
 .../test/bootstrap/aws/tests/tests-bootstrap.sh |  379 ++
 .../test/bootstrap/aws/tests/tests-report.sh    |  590 +++
 .../src/test/bootstrap/aws/tests/tests-run.sh   |  715 ++++
 .../CassandraDirectPersistenceLoadTest.java     |  107 +
 .../tests/CassandraDirectPersistenceTest.java   |  371 ++
 .../apache/ignite/tests/DDLGeneratorTest.java   |   43 +
 .../tests/IgnitePersistentStoreLoadTest.java    |  111 +
 .../ignite/tests/IgnitePersistentStoreTest.java |  369 ++
 .../org/apache/ignite/tests/load/Generator.java |   27 +
 .../apache/ignite/tests/load/IntGenerator.java  |   33 +
 .../ignite/tests/load/LoadTestDriver.java       |  238 ++
 .../apache/ignite/tests/load/LongGenerator.java |   28 +
 .../ignite/tests/load/PersonGenerator.java      |   43 +
 .../ignite/tests/load/PersonIdGenerator.java    |   31 +
 .../ignite/tests/load/StringGenerator.java      |   28 +
 .../org/apache/ignite/tests/load/Worker.java    |  429 +++
 .../tests/load/cassandra/BulkReadWorker.java    |   63 +
 .../tests/load/cassandra/BulkWriteWorker.java   |   52 +
 .../ignite/tests/load/cassandra/ReadWorker.java |   51 +
 .../tests/load/cassandra/WriteWorker.java       |   51 +
 .../tests/load/ignite/BulkReadWorker.java       |   52 +
 .../tests/load/ignite/BulkWriteWorker.java      |   52 +
 .../ignite/tests/load/ignite/ReadWorker.java    |   51 +
 .../ignite/tests/load/ignite/WriteWorker.java   |   51 +
 .../org/apache/ignite/tests/pojos/Person.java   |  246 ++
 .../org/apache/ignite/tests/pojos/PersonId.java |  110 +
 .../ignite/tests/utils/CacheStoreHelper.java    |   64 +
 .../tests/utils/CassandraAdminCredentials.java  |   36 +
 .../ignite/tests/utils/CassandraHelper.java     |  358 ++
 .../tests/utils/CassandraLifeCycleBean.java     |  149 +
 .../utils/CassandraRegularCredentials.java      |   36 +
 .../ignite/tests/utils/TestCacheSession.java    |   91 +
 .../apache/ignite/tests/utils/TestsHelper.java  |  375 ++
 .../src/test/resources/log4j.properties         |  119 +
 .../tests/cassandra/connection-settings.xml     |   48 +
 .../tests/cassandra/connection.properties       |   17 +
 .../tests/cassandra/credentials.properties      |   22 +
 .../tests/cassandra/embedded-cassandra.yaml     |  119 +
 .../ignite/tests/cassandra/keyspaces.properties |   17 +
 .../tests/persistence/blob/ignite-config.xml    |  100 +
 .../persistence/blob/persistence-settings-1.xml |   21 +
 .../persistence/blob/persistence-settings-2.xml |   21 +
 .../persistence/blob/persistence-settings-3.xml |   29 +
 .../tests/persistence/pojo/ignite-config.xml    |  119 +
 .../persistence/pojo/persistence-settings-1.xml |   21 +
 .../persistence/pojo/persistence-settings-2.xml |   21 +
 .../persistence/pojo/persistence-settings-3.xml |  173 +
 .../persistence/primitive/ignite-config.xml     |  100 +
 .../primitive/ignite-remote-client-config.xml   |   95 +
 .../primitive/ignite-remote-server-config.xml   |  106 +
 .../primitive/persistence-settings-1.xml        |   21 +
 .../primitive/persistence-settings-2.xml        |   21 +
 .../src/test/resources/tests.properties         |   50 +
 .../src/test/scripts/cassandra-load-tests.bat   |   41 +
 .../src/test/scripts/cassandra-load-tests.sh    |   39 +
 .../src/test/scripts/ignite-load-tests.bat      |   41 +
 .../src/test/scripts/ignite-load-tests.sh       |   39 +
 modules/cassandra/src/test/scripts/jvm-opt.sh   |   21 +
 modules/cassandra/src/test/scripts/jvm-opts.bat |   24 +
 modules/clients/pom.xml                         |   10 +-
 modules/clients/src/test/config/jdbc-config.xml |    3 +-
 .../client/ClientDefaultCacheSelfTest.java      |  119 +-
 .../ignite/internal/client/ClientHttpTask.java  |   33 +-
 .../ignite/internal/client/ClientTcpTask.java   |   10 +-
 .../ClientAbstractMultiNodeSelfTest.java        |    8 +-
 .../integration/ClientAbstractSelfTest.java     |   92 +-
 .../internal/jdbc2/JdbcConnectionSelfTest.java  |    2 +
 .../internal/jdbc2/JdbcNoDefaultCacheTest.java  |  161 +
 .../JettyRestProcessorAbstractSelfTest.java     | 1428 +++++---
 .../rest/JettyRestProcessorSignedSelfTest.java  |    5 +-
 .../JettyRestProcessorUnsignedSelfTest.java     |    5 +-
 .../rest/RestBinaryProtocolSelfTest.java        |    4 +-
 .../rest/RestMemcacheProtocolSelfTest.java      |    4 +-
 .../internal/processors/rest/SimplePerson.java  |   74 +
 .../ignite/jdbc/JdbcNoDefaultCacheTest.java     |  161 +
 .../jdbc/suite/IgniteJdbcDriverTestSuite.java   |    3 +
 modules/cloud/pom.xml                           |    2 +-
 modules/codegen/pom.xml                         |    2 +-
 .../ignite/codegen/MessageCodeGenerator.java    |  133 +-
 modules/core/pom.xml                            |   17 +-
 .../src/main/java/org/apache/ignite/Ignite.java |   21 +-
 .../java/org/apache/ignite/IgniteCache.java     |  217 +-
 .../java/org/apache/ignite/IgniteCondition.java |  338 ++
 .../org/apache/ignite/IgniteJdbcDriver.java     |    2 +-
 .../main/java/org/apache/ignite/IgniteLock.java |  489 +++
 .../apache/ignite/IgniteSystemProperties.java   |   75 +-
 .../main/java/org/apache/ignite/Ignition.java   |   19 +-
 .../ignite/cache/CacheInterceptorEntry.java     |   39 +
 .../cache/CacheWriteSynchronizationMode.java    |    5 +-
 .../ignite/cache/affinity/AffinityFunction.java |    2 +
 .../affinity/fair/FairAffinityFunction.java     |   83 +-
 .../rendezvous/RendezvousAffinityFunction.java  |   41 +-
 .../cache/query/CacheQueryEntryEvent.java       |   12 +-
 .../ignite/cache/query/ContinuousQuery.java     |   27 +
 .../store/jdbc/CacheAbstractJdbcStore.java      |    4 +
 .../cache/store/jdbc/CacheJdbcBlobStore.java    |   20 +-
 .../cache/store/jdbc/CacheJdbcPojoStore.java    |    2 +-
 .../store/jdbc/CacheJdbcPojoStoreFactory.java   |   59 +-
 .../org/apache/ignite/compute/ComputeJob.java   |    2 +-
 .../ignite/compute/ComputeJobAfterSend.java     |    2 +-
 .../compute/ComputeJobBeforeFailover.java       |    2 +-
 .../ignite/compute/ComputeJobContext.java       |    2 +-
 .../compute/ComputeJobContinuationAdapter.java  |   12 +-
 .../ignite/compute/ComputeLoadBalancer.java     |   12 +-
 .../org/apache/ignite/compute/ComputeTask.java  |   26 +-
 .../ignite/compute/ComputeTaskAdapter.java      |    8 +-
 .../compute/ComputeTaskNoResultCache.java       |    6 +-
 .../ignite/compute/ComputeTaskSession.java      |    4 +-
 .../ignite/compute/ComputeTaskSplitAdapter.java |    8 +-
 .../apache/ignite/compute/gridify/Gridify.java  |    2 +-
 .../configuration/CacheConfiguration.java       |    7 +
 .../configuration/ConnectorConfiguration.java   |    3 +
 .../configuration/FileSystemConfiguration.java  |  154 +-
 .../configuration/HadoopConfiguration.java      |   37 +-
 .../configuration/IgniteConfiguration.java      |  152 +-
 .../ignite/configuration/OdbcConfiguration.java |  118 +
 .../configuration/TransactionConfiguration.java |   40 +
 .../igfs/IgfsGroupDataBlocksKeyMapper.java      |   43 +-
 .../igfs/IgfsIpcEndpointConfiguration.java      |   28 +
 .../java/org/apache/ignite/igfs/IgfsPath.java   |   48 +-
 .../org/apache/ignite/igfs/IgfsPathSummary.java |   32 +-
 .../apache/ignite/igfs/mapreduce/IgfsTask.java  |    6 +-
 .../ignite/internal/GridCodegenConverter.java   |   56 +
 .../internal/GridEventConsumeHandler.java       |    3 +-
 .../ignite/internal/GridKernalContext.java      |   16 +
 .../ignite/internal/GridKernalContextImpl.java  |   28 +-
 .../apache/ignite/internal/GridLoggerProxy.java |    3 +-
 .../internal/GridMessageListenHandler.java      |    3 +-
 .../ignite/internal/GridTaskSessionImpl.java    |    2 +-
 .../org/apache/ignite/internal/GridTopic.java   |    5 +-
 .../ignite/internal/IgniteComponentType.java    |    4 +-
 .../ignite/internal/IgniteEventsImpl.java       |   11 +-
 .../apache/ignite/internal/IgniteKernal.java    |  110 +-
 .../ignite/internal/IgniteMessagingImpl.java    |    7 +-
 .../ignite/internal/IgniteNodeAttributes.java   |   10 +
 .../ignite/internal/IgniteServicesImpl.java     |    2 +-
 .../org/apache/ignite/internal/IgnitionEx.java  |   88 +-
 .../apache/ignite/internal/LessNamingBean.java  |   28 +
 .../ignite/internal/MarshallerContextImpl.java  |   91 +-
 .../internal/binary/BinaryClassDescriptor.java  |   43 +-
 .../ignite/internal/binary/BinaryContext.java   |  203 +-
 .../internal/binary/BinaryFieldAccessor.java    |    1 +
 .../internal/binary/BinaryObjectImpl.java       |   66 +-
 .../binary/BinaryObjectOffheapImpl.java         |   40 +-
 .../internal/binary/BinaryReaderExImpl.java     |   75 +-
 .../ignite/internal/binary/BinarySchema.java    |   11 +-
 .../ignite/internal/binary/BinaryTypeImpl.java  |    8 +
 .../ignite/internal/binary/BinaryUtils.java     |  249 +-
 .../internal/binary/BinaryWriterExImpl.java     |    7 +-
 .../internal/binary/GridBinaryMarshaller.java   |    7 +-
 .../binary/builder/BinaryBuilderReader.java     |   11 +-
 .../binary/builder/BinaryObjectBuilderImpl.java |  107 +-
 .../GridClientConnectionManagerAdapter.java     |   25 +-
 .../connection/GridClientNioTcpConnection.java  |    3 +
 .../GridClientOptimizedMarshaller.java          |    4 +-
 .../GridClientZipOptimizedMarshaller.java       |  167 +
 .../impl/GridTcpRouterNioListenerAdapter.java   |   11 +-
 .../internal/cluster/ClusterGroupAdapter.java   |   24 +-
 .../ignite/internal/cluster/ClusterGroupEx.java |   14 +-
 .../internal/direct/DirectMessageReader.java    |    7 +-
 .../internal/direct/DirectMessageWriter.java    |    4 +-
 .../direct/state/DirectMessageState.java        |    7 +-
 .../stream/v2/DirectByteBufferStreamImplV2.java |    2 +-
 .../ignite/internal/jdbc/JdbcStatement.java     |    9 +-
 .../ignite/internal/jdbc2/JdbcConnection.java   |   21 +-
 .../ignite/internal/jdbc2/JdbcQueryTask.java    |   15 +
 .../ignite/internal/jdbc2/JdbcStatement.java    |    7 +-
 .../internal/managers/GridManagerAdapter.java   |   21 +-
 .../managers/communication/GridIoManager.java   |  238 +-
 .../communication/GridIoMessageFactory.java     |   28 +-
 .../deployment/GridDeploymentCommunication.java |    3 +-
 .../discovery/GridDiscoveryManager.java         |  149 +-
 .../affinity/GridAffinityAssignment.java        |   64 +-
 .../affinity/GridAffinityAssignmentCache.java   |  312 +-
 .../GridAffinityFunctionContextImpl.java        |    9 +
 .../affinity/GridAffinityProcessor.java         |    8 +-
 .../processors/affinity/GridAffinityUtils.java  |    3 +-
 .../cache/CacheAffinityChangeMessage.java       |  160 +
 .../cache/CacheAffinitySharedManager.java       | 1795 +++++++++
 .../cache/CacheClusterMetricsMXBeanImpl.java    |  410 +++
 .../cache/CacheEvictableEntryImpl.java          |    2 +-
 .../processors/cache/CacheInvokeEntry.java      |   41 +-
 .../processors/cache/CacheLazyEntry.java        |   56 +-
 .../cache/CacheLocalMetricsMXBeanImpl.java      |  410 +++
 .../cache/CacheMetricsMXBeanImpl.java           |  410 ---
 .../processors/cache/CacheObjectContext.java    |    3 +
 .../processors/cache/CacheOperationFilter.java  |   61 +
 .../cache/CacheWeakQueryIteratorsHolder.java    |  169 +-
 .../cache/DynamicCacheChangeRequest.java        |   17 +
 .../cache/DynamicCacheDescriptor.java           |   49 +
 .../processors/cache/GridCacheAdapter.java      | 1335 ++++---
 .../cache/GridCacheAffinityManager.java         |  144 +-
 .../processors/cache/GridCacheAtomicFuture.java |    5 -
 .../cache/GridCacheClearAllRunnable.java        |    3 +-
 .../cache/GridCacheConcurrentMap.java           | 1996 +---------
 .../cache/GridCacheConcurrentMapImpl.java       |  344 ++
 .../processors/cache/GridCacheContext.java      |   85 +-
 .../cache/GridCacheDeploymentManager.java       |    2 +-
 .../processors/cache/GridCacheEntryEx.java      |   35 +-
 .../processors/cache/GridCacheEntrySet.java     |  113 -
 .../cache/GridCacheEvictionManager.java         |   34 +-
 .../processors/cache/GridCacheIoManager.java    |   48 +-
 .../processors/cache/GridCacheKeySet.java       |  104 -
 .../processors/cache/GridCacheLogger.java       |    3 +-
 .../processors/cache/GridCacheMapEntry.java     | 1014 ++++--
 .../processors/cache/GridCacheMvcc.java         |    7 +
 .../cache/GridCacheMvccCandidate.java           |   16 +-
 .../processors/cache/GridCacheMvccManager.java  |   20 +-
 .../GridCachePartitionExchangeManager.java      |  233 +-
 .../processors/cache/GridCachePreloader.java    |   23 +-
 .../cache/GridCachePreloaderAdapter.java        |   17 +-
 .../processors/cache/GridCacheProcessor.java    |  360 +-
 .../processors/cache/GridCacheProxyImpl.java    |  112 +-
 .../processors/cache/GridCacheReturn.java       |   10 +-
 .../cache/GridCacheSharedContext.java           |   54 +-
 .../processors/cache/GridCacheSwapManager.java  |  139 +-
 .../processors/cache/GridCacheTtlManager.java   |   26 +-
 .../processors/cache/GridCacheUtils.java        |  164 +-
 .../processors/cache/GridNoStorageCacheMap.java |  107 +
 .../processors/cache/IgniteCacheProxy.java      |  113 +-
 .../processors/cache/IgniteInternalCache.java   |  121 +-
 .../processors/cache/KeyCacheObject.java        |   11 +
 .../processors/cache/KeyCacheObjectImpl.java    |   32 +-
 .../cache/affinity/GridCacheAffinityImpl.java   |    2 +-
 .../binary/CacheObjectBinaryProcessorImpl.java  |   69 +-
 .../CacheDataStructuresManager.java             |    4 +-
 .../distributed/GridCacheCommittedTxInfo.java   |    1 +
 .../distributed/GridCacheTxRecoveryFuture.java  |   65 +-
 .../GridCacheTxRecoveryResponse.java            |   22 +-
 .../GridDistributedCacheAdapter.java            |    6 +-
 .../distributed/GridDistributedLockRequest.java |   19 +-
 .../GridDistributedLockResponse.java            |    8 -
 .../GridDistributedTxFinishRequest.java         |   21 +-
 .../GridDistributedTxPrepareRequest.java        |   26 +-
 .../GridDistributedTxPrepareResponse.java       |   18 +-
 .../GridDistributedTxRemoteAdapter.java         |   20 +-
 .../GridDistributedUnlockRequest.java           |   16 +-
 .../dht/CacheDistributedGetFutureAdapter.java   |    3 -
 .../dht/GridCachePartitionedConcurrentMap.java  |  271 ++
 .../dht/GridClientPartitionTopology.java        |   23 +-
 .../dht/GridDhtAffinityAssignmentResponse.java  |  198 +-
 .../dht/GridDhtAssignmentFetchFuture.java       |   80 +-
 .../distributed/dht/GridDhtCacheAdapter.java    |  163 +-
 .../distributed/dht/GridDhtCacheEntry.java      |   35 +-
 .../cache/distributed/dht/GridDhtGetFuture.java |   76 +-
 .../distributed/dht/GridDhtGetSingleFuture.java |    6 +
 .../distributed/dht/GridDhtLocalPartition.java  |  154 +-
 .../distributed/dht/GridDhtLockFuture.java      |   47 +-
 .../distributed/dht/GridDhtLockRequest.java     |   16 +-
 .../dht/GridDhtOffHeapCacheEntry.java           |    8 +
 .../dht/GridDhtPartitionTopology.java           |   21 +-
 .../dht/GridDhtPartitionTopologyImpl.java       |  615 ++--
 .../dht/GridDhtTransactionalCacheAdapter.java   |   72 +-
 .../distributed/dht/GridDhtTxFinishFuture.java  |   29 +-
 .../cache/distributed/dht/GridDhtTxLocal.java   |  210 +-
 .../distributed/dht/GridDhtTxLocalAdapter.java  |   15 +-
 .../distributed/dht/GridDhtTxPrepareFuture.java |   52 +-
 .../cache/distributed/dht/GridDhtTxRemote.java  |    9 +-
 .../distributed/dht/GridDhtUnlockRequest.java   |   15 +-
 .../distributed/dht/GridNoStorageCacheMap.java  |  122 -
 .../dht/GridPartitionedGetFuture.java           |   17 +-
 .../dht/GridPartitionedSingleGetFuture.java     |   17 +-
 .../dht/atomic/GridDhtAtomicCache.java          |  656 ++--
 .../atomic/GridDhtAtomicOffHeapCacheEntry.java  |    8 +
 .../dht/atomic/GridDhtAtomicUpdateFuture.java   |  144 +-
 .../dht/atomic/GridDhtAtomicUpdateRequest.java  |  149 +-
 .../GridNearAtomicAbstractUpdateFuture.java     |  244 ++
 .../GridNearAtomicSingleUpdateFuture.java       |  645 ++++
 .../dht/atomic/GridNearAtomicUpdateFuture.java  | 1398 +++----
 .../dht/atomic/GridNearAtomicUpdateRequest.java |   31 +-
 .../dht/colocated/GridDhtColocatedCache.java    |   30 +-
 .../colocated/GridDhtColocatedLockFuture.java   |   88 +-
 .../GridDhtColocatedOffHeapCacheEntry.java      |    8 +
 .../colocated/GridDhtDetachedCacheEntry.java    |    2 +-
 .../dht/preloader/GridDhtForceKeysFuture.java   |    9 +-
 .../dht/preloader/GridDhtPartitionDemander.java |   57 +-
 .../dht/preloader/GridDhtPartitionMap2.java     |    9 +-
 .../dht/preloader/GridDhtPartitionSupplier.java |   37 +-
 .../GridDhtPartitionsExchangeFuture.java        | 1575 ++++----
 .../dht/preloader/GridDhtPreloader.java         |  158 +-
 .../distributed/near/GridNearAtomicCache.java   |   44 +-
 .../distributed/near/GridNearCacheAdapter.java  |  114 +-
 .../distributed/near/GridNearCacheEntry.java    |  118 +-
 .../distributed/near/GridNearGetFuture.java     |   50 +-
 .../distributed/near/GridNearGetRequest.java    |   45 +-
 .../distributed/near/GridNearLockFuture.java    |   13 +-
 .../distributed/near/GridNearLockRequest.java   |   16 +-
 ...arOptimisticSerializableTxPrepareFuture.java |    5 +-
 .../near/GridNearOptimisticTxPrepareFuture.java |   34 +-
 ...ridNearOptimisticTxPrepareFutureAdapter.java |   16 +-
 .../near/GridNearSingleGetRequest.java          |   24 +-
 .../near/GridNearTransactionalCache.java        |    7 +-
 .../near/GridNearTxFinishFuture.java            |  123 +-
 .../near/GridNearTxFinishRequest.java           |   46 +-
 .../cache/distributed/near/GridNearTxLocal.java |   96 +-
 .../near/GridNearTxPrepareFutureAdapter.java    |   12 +-
 .../distributed/near/GridNearTxRemote.java      |   24 +-
 .../distributed/near/GridNearUnlockRequest.java |   21 +-
 .../processors/cache/dr/GridCacheDrManager.java |    4 +-
 .../cache/dr/GridOsCacheDrManager.java          |    2 +-
 .../processors/cache/local/GridLocalCache.java  |    7 +-
 .../cache/local/GridLocalCacheEntry.java        |   27 -
 .../cache/local/GridLocalLockFuture.java        |   77 +-
 .../local/atomic/GridLocalAtomicCache.java      |  172 +-
 .../processors/cache/query/CacheQuery.java      |   10 +-
 .../cache/query/CacheQueryFuture.java           |   13 +-
 .../query/GridCacheDistributedQueryManager.java |  100 +-
 .../cache/query/GridCacheLocalQueryManager.java |   34 +-
 .../cache/query/GridCacheQueryAdapter.java      |  175 +-
 .../cache/query/GridCacheQueryErrorFuture.java  |   12 +-
 .../query/GridCacheQueryFutureAdapter.java      |   10 +-
 .../cache/query/GridCacheQueryManager.java      |  574 ++-
 .../cache/query/GridCacheSqlIndexMetadata.java  |    3 +-
 .../cache/query/GridCacheSqlMetadata.java       |    3 +-
 .../continuous/CacheContinuousQueryEntry.java   |   40 +-
 .../continuous/CacheContinuousQueryEvent.java   |    7 +
 .../continuous/CacheContinuousQueryHandler.java |  605 +++-
 .../CacheContinuousQueryListener.java           |    6 +-
 .../continuous/CacheContinuousQueryManager.java |  226 +-
 .../query/jdbc/GridCacheQueryJdbcTask.java      |   59 +-
 .../jdbc/GridCacheQueryJdbcValidationTask.java  |   10 +-
 .../store/GridCacheStoreManagerAdapter.java     |   32 +-
 .../cache/transactions/IgniteInternalTx.java    |   40 +-
 .../transactions/IgniteTransactionsImpl.java    |    9 +-
 .../cache/transactions/IgniteTxAdapter.java     |  386 +-
 .../cache/transactions/IgniteTxEntry.java       |   72 +-
 .../cache/transactions/IgniteTxHandler.java     |  139 +-
 .../IgniteTxImplicitSingleStateImpl.java        |   53 +-
 .../transactions/IgniteTxLocalAdapter.java      |  531 +--
 .../cache/transactions/IgniteTxLocalEx.java     |   26 +-
 .../cache/transactions/IgniteTxManager.java     |  570 ++-
 .../IgniteTxRemoteSingleStateImpl.java          |   30 +
 .../IgniteTxRemoteStateAdapter.java             |   16 +-
 .../transactions/IgniteTxRemoteStateImpl.java   |   72 +-
 .../cache/transactions/IgniteTxState.java       |   11 +-
 .../cache/transactions/IgniteTxStateAware.java  |   34 +
 .../cache/transactions/IgniteTxStateImpl.java   |   42 +-
 .../cache/transactions/TxDeadlock.java          |  159 +
 .../cache/transactions/TxDeadlockDetection.java |  599 +++
 .../processors/cache/transactions/TxLock.java   |  225 ++
 .../cache/transactions/TxLockList.java          |  134 +
 .../cache/transactions/TxLocksRequest.java      |  205 ++
 .../cache/transactions/TxLocksResponse.java     |  318 ++
 .../GridCacheLazyPlainVersionedEntry.java       |  107 +
 .../version/GridCachePlainVersionedEntry.java   |    7 +-
 .../cache/version/GridCacheVersion.java         |   14 +-
 .../cache/version/GridCacheVersionEx.java       |    9 +
 .../cache/version/GridCacheVersionManager.java  |   21 +-
 .../cacheobject/IgniteCacheObjectProcessor.java |   17 +
 .../IgniteCacheObjectProcessorImpl.java         |   41 +-
 .../processors/clock/GridClockServer.java       |    3 +-
 .../closure/GridClosureProcessor.java           |  416 ++-
 .../processors/cluster/GridUpdateNotifier.java  |    3 +-
 .../continuous/GridContinuousHandler.java       |    4 +-
 .../continuous/GridContinuousProcessor.java     |  286 +-
 .../StartRoutineAckDiscoveryMessage.java        |   22 +-
 .../StartRoutineDiscoveryMessage.java           |   22 +-
 .../datastreamer/DataStreamProcessor.java       |    8 +-
 .../datastreamer/DataStreamerImpl.java          |   40 +-
 .../datastructures/DataStructuresProcessor.java |  167 +-
 .../datastructures/GridCacheAtomicLongImpl.java |    3 +-
 .../GridCacheAtomicReferenceImpl.java           |    4 +-
 .../GridCacheAtomicSequenceImpl.java            |    3 +-
 .../GridCacheAtomicStampedImpl.java             |    3 +-
 .../GridCacheCountDownLatchImpl.java            |   57 +-
 .../datastructures/GridCacheLockEx.java         |   52 +
 .../datastructures/GridCacheLockImpl.java       | 1538 ++++++++
 .../datastructures/GridCacheLockState.java      |  353 ++
 .../datastructures/GridCacheQueueProxy.java     |    3 +-
 .../datastructures/GridCacheSemaphoreEx.java    |    5 +
 .../datastructures/GridCacheSemaphoreImpl.java  |  197 +-
 .../datastructures/GridCacheSetImpl.java        |    9 +-
 .../datastructures/GridCacheSetProxy.java       |    3 +-
 .../processors/hadoop/HadoopJobInfo.java        |    3 +-
 .../processors/hadoop/HadoopNoopProcessor.java  |   24 +-
 .../internal/processors/igfs/IgfsAsyncImpl.java |    6 -
 .../internal/processors/igfs/IgfsBlockKey.java  |   30 +-
 .../processors/igfs/IgfsBlockLocationImpl.java  |   87 +-
 .../IgfsColocatedMetadataAffinityKeyMapper.java |   47 +
 .../internal/processors/igfs/IgfsContext.java   |   14 +-
 .../processors/igfs/IgfsCreateResult.java       |   66 +
 .../processors/igfs/IgfsDataManager.java        |  373 +-
 .../processors/igfs/IgfsDeleteResult.java       |   62 +
 .../processors/igfs/IgfsDeleteWorker.java       |  111 +-
 .../processors/igfs/IgfsDirectoryInfo.java      |  284 ++
 .../internal/processors/igfs/IgfsEntryInfo.java |  319 ++
 .../ignite/internal/processors/igfs/IgfsEx.java |   21 -
 .../processors/igfs/IgfsFileAffinityRange.java  |   32 +-
 .../internal/processors/igfs/IgfsFileImpl.java  |   78 +-
 .../internal/processors/igfs/IgfsFileInfo.java  |  519 +--
 .../internal/processors/igfs/IgfsFileMap.java   |   50 +-
 .../processors/igfs/IgfsFileWorkerBatch.java    |   75 +-
 .../IgfsFileWorkerBatchCancelledException.java  |   51 +
 .../igfs/IgfsFragmentizerManager.java           |  107 +-
 .../internal/processors/igfs/IgfsImpl.java      |  623 ++--
 .../processors/igfs/IgfsInputStreamAdapter.java |    5 +-
 .../processors/igfs/IgfsInputStreamImpl.java    |   40 +-
 .../igfs/IgfsInvalidRangeException.java         |    4 +-
 .../processors/igfs/IgfsIpcHandler.java         |  108 +-
 ...zySecondaryFileSystemPositionedReadable.java |   77 +
 .../processors/igfs/IgfsListingEntry.java       |  161 +-
 .../processors/igfs/IgfsMetaManager.java        | 3157 +++++++---------
 .../processors/igfs/IgfsNodePredicate.java      |   80 +
 .../igfs/IgfsOutputStreamAdapter.java           |  265 --
 .../processors/igfs/IgfsOutputStreamImpl.java   |  642 ++--
 .../internal/processors/igfs/IgfsPathIds.java   |  325 ++
 .../processors/igfs/IgfsPathsCreateResult.java  |   64 +
 .../internal/processors/igfs/IgfsProcessor.java |  107 +-
 .../IgfsSecondaryFileSystemCreateContext.java   |  111 +
 .../IgfsSecondaryInputStreamDescriptor.java     |    6 +-
 .../IgfsSecondaryOutputStreamDescriptor.java    |   73 -
 .../internal/processors/igfs/IgfsServer.java    |    2 +-
 .../internal/processors/igfs/IgfsUtils.java     |  613 +++-
 .../igfs/client/IgfsClientAbstractCallable.java |  125 +
 .../igfs/client/IgfsClientAffinityCallable.java |   95 +
 .../igfs/client/IgfsClientDeleteCallable.java   |   77 +
 .../igfs/client/IgfsClientExistsCallable.java   |   58 +
 .../igfs/client/IgfsClientInfoCallable.java     |   59 +
 .../client/IgfsClientListFilesCallable.java     |   61 +
 .../client/IgfsClientListPathsCallable.java     |   60 +
 .../igfs/client/IgfsClientMkdirsCallable.java   |   82 +
 .../igfs/client/IgfsClientRenameCallable.java   |   80 +
 .../igfs/client/IgfsClientSetTimesCallable.java |   87 +
 .../igfs/client/IgfsClientSizeCallable.java     |   59 +
 .../igfs/client/IgfsClientSummaryCallable.java  |   59 +
 .../igfs/client/IgfsClientUpdateCallable.java   |   81 +
 .../meta/IgfsClientMetaIdsForPathCallable.java  |   65 +
 .../meta/IgfsClientMetaInfoForPathCallable.java |   63 +
 .../igfs/data/IgfsDataPutProcessor.java         |   99 +
 .../meta/IgfsMetaDirectoryCreateProcessor.java  |  182 +
 .../IgfsMetaDirectoryListingAddProcessor.java   |  136 +
 ...IgfsMetaDirectoryListingRemoveProcessor.java |  132 +
 ...IgfsMetaDirectoryListingRenameProcessor.java |  133 +
 ...gfsMetaDirectoryListingReplaceProcessor.java |  130 +
 .../igfs/meta/IgfsMetaFileCreateProcessor.java  |  194 +
 .../igfs/meta/IgfsMetaFileLockProcessor.java    |  107 +
 .../meta/IgfsMetaFileRangeDeleteProcessor.java  |  111 +
 .../meta/IgfsMetaFileRangeUpdateProcessor.java  |  120 +
 .../meta/IgfsMetaFileReserveSpaceProcessor.java |  120 +
 .../igfs/meta/IgfsMetaFileUnlockProcessor.java  |  166 +
 .../meta/IgfsMetaUpdatePropertiesProcessor.java |  121 +
 .../igfs/meta/IgfsMetaUpdateTimesProcessor.java |  113 +
 .../internal/processors/igfs/package-info.java  |    2 +-
 .../processors/job/GridJobProcessor.java        |   20 +-
 .../internal/processors/job/GridJobWorker.java  |    4 +-
 .../processors/odbc/OdbcBufferedParser.java     |   81 +
 .../processors/odbc/OdbcColumnMeta.java         |  110 +
 .../processors/odbc/OdbcHandshakeRequest.java   |   49 +
 .../processors/odbc/OdbcHandshakeResult.java    |   66 +
 .../processors/odbc/OdbcMessageParser.java      |  277 ++
 .../processors/odbc/OdbcNioListener.java        |  179 +
 .../processors/odbc/OdbcNioServerBuffer.java    |  114 +
 .../internal/processors/odbc/OdbcProcessor.java |  165 +
 .../processors/odbc/OdbcQueryCloseRequest.java  |   49 +
 .../processors/odbc/OdbcQueryCloseResult.java   |   40 +
 .../odbc/OdbcQueryExecuteRequest.java           |   78 +
 .../processors/odbc/OdbcQueryExecuteResult.java |   54 +
 .../processors/odbc/OdbcQueryFetchRequest.java  |   61 +
 .../processors/odbc/OdbcQueryFetchResult.java   |   66 +
 .../odbc/OdbcQueryGetColumnsMetaRequest.java    |   74 +
 .../odbc/OdbcQueryGetColumnsMetaResult.java     |   42 +
 .../odbc/OdbcQueryGetTablesMetaRequest.java     |   85 +
 .../odbc/OdbcQueryGetTablesMetaResult.java      |   42 +
 .../internal/processors/odbc/OdbcRequest.java   |   58 +
 .../processors/odbc/OdbcRequestHandler.java     |  362 ++
 .../internal/processors/odbc/OdbcResponse.java  |   96 +
 .../internal/processors/odbc/OdbcTableMeta.java |   85 +
 .../internal/processors/odbc/OdbcUtils.java     |   56 +
 .../offheap/GridOffHeapProcessor.java           |   12 +
 .../platform/PlatformAbstractBootstrap.java     |   17 +-
 .../processors/platform/PlatformBootstrap.java  |    6 +-
 .../processors/platform/PlatformContext.java    |   11 +-
 .../platform/PlatformContextImpl.java           |   74 +-
 .../PlatformDefaultJavaObjectFactory.java       |   62 +
 .../processors/platform/PlatformIgnition.java   |   18 +-
 .../platform/PlatformJavaObjectFactoryEx.java   |   36 +
 .../PlatformJavaObjectFactoryProxy.java         |  192 +
 .../PlatformJavaObjectSingletonFactory.java     |   48 +
 .../platform/PlatformNoopProcessor.java         |   19 +-
 .../processors/platform/PlatformProcessor.java  |   26 +
 .../platform/PlatformProcessorImpl.java         |  102 +-
 .../platform/cache/PlatformCache.java           |   56 +-
 .../affinity/PlatformAffinityFunction.java      |  242 ++
 .../query/PlatformContinuousQueryImpl.java      |   50 +-
 .../callback/PlatformCallbackGateway.java       |   90 +-
 .../callback/PlatformCallbackUtils.java         |   46 +
 .../platform/cluster/PlatformClusterGroup.java  |   19 +
 .../platform/compute/PlatformCompute.java       |    7 +-
 .../datastreamer/PlatformDataStreamer.java      |    7 +-
 .../dotnet/PlatformDotNetCacheStore.java        |   27 +-
 .../PlatformDotNetConfigurationClosure.java     |    5 -
 .../platform/services/PlatformServices.java     |  249 +-
 .../utils/PlatformConfigurationUtils.java       |  409 ++-
 .../platform/utils/PlatformFutureUtils.java     |    2 +-
 .../platform/utils/PlatformUtils.java           |  197 +
 .../processors/plugin/CachePluginManager.java   |   25 +
 .../GridResourceJobContextInjector.java         |    4 +-
 .../message/GridClientHandshakeRequest.java     |    4 +-
 .../handlers/cache/GridCacheCommandHandler.java |    2 +-
 .../handlers/query/QueryCommandHandler.java     |    8 +-
 .../handlers/task/GridTaskCommandHandler.java   |    2 +-
 .../protocols/tcp/GridTcpRestNioListener.java   |   19 +-
 .../rest/protocols/tcp/GridTcpRestProtocol.java |   19 +-
 .../service/GridServiceAssignments.java         |   10 +-
 .../service/GridServiceNotFoundException.java   |    4 +-
 .../service/GridServiceProcessor.java           |  801 +++--
 .../processors/service/GridServiceProxy.java    |  332 +-
 .../service/LazyServiceConfiguration.java       |  129 +
 .../processors/service/ServiceContextImpl.java  |   29 +-
 .../service/ServiceDescriptorImpl.java          |   17 +-
 .../processors/task/GridTaskProcessor.java      |    6 +-
 .../processors/task/GridTaskWorker.java         |   56 +-
 .../apache/ignite/internal/util/ClassCache.java |   32 +
 .../org/apache/ignite/internal/util/F0.java     |    4 +-
 .../internal/util/GridExecutionStatistics.java  |  106 -
 .../ignite/internal/util/GridLeanSet.java       |    1 +
 .../ignite/internal/util/HostAndPortRange.java  |  205 ++
 .../internal/util/IgniteExceptionRegistry.java  |    5 +-
 .../ignite/internal/util/IgniteUtils.java       |  138 +-
 .../util/StripedCompositeReadWriteLock.java     |   24 +-
 .../internal/util/future/GridFutureAdapter.java |    3 +-
 .../shmem/IpcSharedMemoryServerEndpoint.java    |    6 +-
 .../ignite/internal/util/lang/GridFunc.java     |   99 +-
 .../ignite/internal/util/lang/GridTuple.java    |    2 -
 .../ignite/internal/util/lang/GridTuple3.java   |    2 -
 .../ignite/internal/util/lang/GridTuple4.java   |    2 -
 .../ignite/internal/util/lang/GridTuple5.java   |    2 -
 .../ignite/internal/util/lang/GridTuple6.java   |    2 -
 .../ignite/internal/util/lang/GridTupleV.java   |    1 +
 .../internal/util/nio/GridDirectParser.java     |    4 +-
 .../util/nio/GridNioRecoveryDescriptor.java     |   21 +-
 .../ignite/internal/util/nio/GridNioServer.java |   70 +-
 .../util/offheap/unsafe/GridUnsafeMap.java      |    4 +-
 .../apache/ignite/internal/util/typedef/PN.java |    2 +-
 .../apache/ignite/internal/util/typedef/X.java  |    2 +-
 .../ignite/internal/visor/cache/VisorCache.java |   75 +-
 .../cache/VisorCacheAffinityConfiguration.java  |    5 +-
 .../visor/cache/VisorCacheAffinityNodeTask.java |   70 +
 .../cache/VisorCacheAggregatedMetrics.java      |    3 +-
 .../visor/cache/VisorCacheConfiguration.java    |    8 +-
 .../cache/VisorCacheDefaultConfiguration.java   |    5 +-
 .../cache/VisorCacheEvictionConfiguration.java  |    5 +-
 .../internal/visor/cache/VisorCacheMetrics.java |   14 +-
 .../cache/VisorCacheNearConfiguration.java      |    5 +-
 .../visor/cache/VisorCachePartition.java        |   90 +
 .../visor/cache/VisorCachePartitions.java       |   89 +
 .../visor/cache/VisorCachePartitionsTask.java   |  152 +
 .../cache/VisorCacheQueryConfiguration.java     |    3 +-
 .../visor/cache/VisorCacheQueryMetrics.java     |    5 +-
 .../cache/VisorCacheRebalanceConfiguration.java |    5 +-
 .../visor/cache/VisorCacheResetMetricsTask.java |    2 +-
 .../cache/VisorCacheStoreConfiguration.java     |    3 +-
 .../cache/VisorCacheTypeFieldMetadata.java      |    3 +-
 .../visor/cache/VisorCacheTypeMetadata.java     |    3 +-
 .../internal/visor/cache/VisorCacheV3.java      |   52 +
 .../internal/visor/cache/VisorCacheV4.java      |  124 +
 .../visor/compute/VisorGatewayTask.java         |  362 ++
 .../internal/visor/debug/VisorThreadInfo.java   |    5 +-
 .../visor/debug/VisorThreadLockInfo.java        |    5 +-
 .../internal/visor/event/VisorGridEvent.java    |    5 +-
 .../internal/visor/file/VisorFileBlock.java     |    5 +-
 .../ignite/internal/visor/igfs/VisorIgfs.java   |    5 +-
 .../internal/visor/igfs/VisorIgfsEndpoint.java  |    5 +-
 .../internal/visor/igfs/VisorIgfsMetrics.java   |    5 +-
 .../visor/igfs/VisorIgfsProfilerEntry.java      |    5 +-
 .../visor/igfs/VisorIgfsProfilerTask.java       |   20 +-
 .../VisorIgfsProfilerUniformityCounters.java    |    5 +-
 .../visor/log/VisorLogSearchResult.java         |    5 +-
 .../visor/node/VisorAtomicConfiguration.java    |    5 +-
 .../visor/node/VisorBasicConfiguration.java     |    5 +-
 .../node/VisorExecutorServiceConfiguration.java |    5 +-
 .../visor/node/VisorGridConfiguration.java      |    5 +-
 .../visor/node/VisorIgfsConfiguration.java      |    3 +-
 .../visor/node/VisorLifecycleConfiguration.java |    5 +-
 .../visor/node/VisorMetricsConfiguration.java   |    5 +-
 .../visor/node/VisorNodeDataCollectorJob.java   |   49 +-
 .../node/VisorNodeDataCollectorTaskResult.java  |    5 +-
 .../node/VisorPeerToPeerConfiguration.java      |    5 +-
 .../visor/node/VisorRestConfiguration.java      |    5 +-
 .../node/VisorSegmentationConfiguration.java    |    5 +-
 .../visor/node/VisorSpisConfiguration.java      |    5 +-
 .../node/VisorTransactionConfiguration.java     |    5 +-
 .../internal/visor/query/VisorQueryField.java   |    5 +-
 .../internal/visor/query/VisorQueryResult.java  |    5 +-
 .../internal/visor/util/VisorTaskUtils.java     |   14 +-
 .../WebSessionAttributeProcessor.java           |  134 +
 .../internal/websession/WebSessionEntity.java   |  193 +
 .../apache/ignite/lang/IgniteAsyncCallback.java |  111 +
 .../java/org/apache/ignite/lang/IgniteUuid.java |    2 +-
 .../ignite/logger/java/JavaLoggerFormatter.java |    4 +-
 .../apache/ignite/marshaller/Marshaller.java    |    6 +-
 .../platform/PlatformJavaObjectFactory.java     |   36 +
 .../ignite/plugin/CachePluginProvider.java      |   11 +
 .../extensions/communication/MessageReader.java |    9 +
 .../plugin/security/SecurityPermissionSet.java  |    5 +-
 .../ignite/plugin/security/SecuritySubject.java |    5 +-
 .../SpringApplicationContextResource.java       |    4 +-
 .../apache/ignite/resources/SpringResource.java |   15 +-
 .../ignite/services/ServiceConfiguration.java   |   14 +-
 .../ignite/spi/IgniteNodeValidationResult.java  |    8 +-
 .../org/apache/ignite/spi/IgniteSpiAdapter.java |   29 +-
 .../jobstealing/JobStealingCollisionSpi.java    |   14 +-
 .../jobstealing/JobStealingDisabled.java        |    2 +-
 .../communication/tcp/TcpCommunicationSpi.java  |   52 +-
 .../tcp/TcpCommunicationSpiMBean.java           |    8 +-
 .../ignite/spi/discovery/tcp/ClientImpl.java    |   15 +-
 .../ignite/spi/discovery/tcp/ServerImpl.java    |  740 ++--
 .../spi/discovery/tcp/TcpDiscoveryImpl.java     |   13 +-
 .../spi/discovery/tcp/TcpDiscoverySpi.java      |   38 +-
 .../tcp/internal/TcpDiscoveryNode.java          |   18 +-
 .../ipfinder/jdbc/BasicJdbcIpFinderDialect.java |   28 +
 .../tcp/ipfinder/jdbc/JdbcIpFinderDialect.java  |   28 +
 .../jdbc/OracleJdbcIpFinderDialect.java         |   28 +
 .../ipfinder/jdbc/TcpDiscoveryJdbcIpFinder.java |   69 +-
 .../sharedfs/TcpDiscoverySharedFsIpFinder.java  |   60 +-
 .../messages/TcpDiscoveryAbstractMessage.java   |    4 +-
 .../TcpDiscoveryClientHeartbeatMessage.java     |    1 +
 .../TcpDiscoveryClientReconnectMessage.java     |   16 +
 .../TcpDiscoveryCustomEventMessage.java         |   13 +-
 .../TcpDiscoveryJoinRequestMessage.java         |   16 +-
 .../TcpDiscoveryStatusCheckMessage.java         |   18 +-
 .../spi/indexing/IndexingQueryFilter.java       |    9 +
 .../spi/loadbalancing/LoadBalancingSpi.java     |    8 +-
 .../adaptive/AdaptiveLoadBalancingSpi.java      |   20 +-
 .../adaptive/AdaptiveLoadProbe.java             |    2 +-
 .../roundrobin/RoundRobinLoadBalancingSpi.java  |    6 +-
 .../WeightedRandomLoadBalancingSpi.java         |   14 +-
 .../thread/IgniteStripedThreadPoolExecutor.java |  164 +-
 .../org/apache/ignite/thread/IgniteThread.java  |   34 +-
 .../ignite/thread/IgniteThreadFactory.java      |    7 +-
 .../apache/ignite/transactions/Transaction.java |   19 +-
 .../TransactionDeadlockException.java           |   42 +
 .../TransactionTimeoutException.java            |    5 +-
 .../resources/META-INF/classnames.properties    |  104 +-
 .../core/src/main/resources/ignite.properties   |    2 +-
 modules/core/src/test/config/igfs-loopback.xml  |    7 -
 modules/core/src/test/config/igfs-shmem.xml     |    7 -
 .../config/websession/example-cache-base.xml    |  148 +
 .../config/websession/example-cache-client.xml  |   33 +
 .../test/config/websession/example-cache.xml    |  128 +-
 .../test/config/websession/example-cache2.xml   |   31 +
 .../GridCacheAffinityBackupsSelfTest.java       |    2 +-
 .../affinity/AffinityClientNodeSelfTest.java    |    4 +-
 ...ityFunctionBackupFilterAbstractSelfTest.java |  131 +-
 .../affinity/AffinityHistoryCleanupTest.java    |  414 +++
 ...airAffinityFunctionBackupFilterSelfTest.java |    9 +
 .../fair/FairAffinityFunctionNodesSelfTest.java |    2 +
 .../local/LocalAffinityFunctionTest.java        |   80 +
 ...ousAffinityFunctionBackupFilterSelfTest.java |    9 +
 .../CacheJdbcPojoStoreAbstractSelfTest.java     |   69 +-
 ...eJdbcStoreAbstractMultithreadedSelfTest.java |   25 +-
 .../cache/store/jdbc/H2DataSourceFactory.java   |   35 +
 .../ignite/cache/store/jdbc/model/Person.java   |   25 +
 .../ignite/igfs/IgfsEventsAbstractSelfTest.java |   24 +-
 .../igfs/IgfsFragmentizerAbstractSelfTest.java  |    4 +-
 .../ignite/igfs/IgfsFragmentizerSelfTest.java   |    2 -
 .../ignite/internal/ClusterGroupSelfTest.java   |   30 +-
 .../internal/ClusterNodeMetricsSelfTest.java    |  101 +-
 .../ComputeJobCancelWithServiceSelfTest.java    |  154 +
 .../ignite/internal/GridAffinitySelfTest.java   |    9 +-
 ...omputationBinarylizableClosuresSelfTest.java |  413 +++
 .../GridEventStorageCheckAllEventsSelfTest.java |   30 +-
 .../ignite/internal/GridGetOrStartSelfTest.java |   70 +
 .../GridTaskCancelSingleNodeSelfTest.java       |   37 +-
 .../internal/GridTaskExecutionSelfTest.java     |   90 +-
 .../GridTaskFailoverAffinityRunTest.java        |    6 +-
 .../IgniteClientReconnectAbstractTest.java      |   15 +-
 .../IgniteClientReconnectAtomicsTest.java       |   66 +-
 .../IgniteClientReconnectCollectionsTest.java   |    4 +-
 .../IgniteClientReconnectComputeTest.java       |    6 +-
 ...eClientReconnectContinuousProcessorTest.java |   60 +-
 .../IgniteClientReconnectFailoverTest.java      |    2 +
 .../IgniteClientReconnectServicesTest.java      |    4 +-
 .../IgniteClientReconnectStreamerTest.java      |    2 +-
 ...eConcurrentEntryProcessorAccessStopTest.java |   82 +
 .../internal/TestRecordingCommunicationSpi.java |   65 +-
 .../ignite/internal/binary/AffinityKey.java     |   69 +
 .../binary/BinaryMarshallerSelfTest.java        |  223 +-
 .../BinaryObjectBuilderAdditionalSelfTest.java  |  144 +-
 ...naryObjectBuilderDefaultMappersSelfTest.java |    2 +-
 .../binary/GridBinaryAffinityKeySelfTest.java   |   15 +
 .../binary/GridBinaryWildcardsSelfTest.java     |   53 +-
 ...aultBinaryMappersBinaryMetaDataSelfTest.java |   17 +
 .../GridDiscoveryManagerAttributesSelfTest.java |  126 +
 .../BinaryObjectOffHeapUnswapTemporaryTest.java |  368 ++
 .../cache/CacheAffinityCallSelfTest.java        |   85 +-
 .../cache/CacheClientStoreSelfTest.java         |  209 +-
 ...GetEntryOptimisticReadCommittedSeltTest.java |    2 +-
 ...erceptorPartitionCounterLocalSanityTest.java |  687 ++++
 ...torPartitionCounterRandomOperationsTest.java | 1054 ++++++
 .../CacheMetricsForClusterGroupSelfTest.java    |    2 +-
 .../processors/cache/CacheNamesSelfTest.java    |   16 +-
 .../CacheNamesWithSpecialCharactersTest.java    |   71 +
 ...cheNearUpdateTopologyChangeAbstractTest.java |    2 +
 .../cache/CacheReadThroughRestartSelfTest.java  |    2 +
 .../CacheStartupInDeploymentModesTest.java      |  230 ++
 .../CacheStoreUsageMultinodeAbstractTest.java   |    5 +-
 .../cache/CacheSwapUnswapGetTest.java           |    4 +-
 .../processors/cache/CacheTxFastFinishTest.java |  253 ++
 .../cache/CrossCacheTxRandomOperationsTest.java |   13 +-
 .../EntryVersionConsistencyReadThroughTest.java |  265 ++
 .../cache/GridCacheAbstractFullApiSelfTest.java |  127 +-
 .../GridCacheAbstractLocalStoreSelfTest.java    |  480 ++-
 .../cache/GridCacheAbstractMetricsSelfTest.java |  124 +-
 .../GridCacheAbstractRemoveFailureTest.java     |   10 +-
 .../cache/GridCacheDeploymentSelfTest.java      |    2 +
 .../cache/GridCacheEntryVersionSelfTest.java    |    2 +-
 .../GridCacheOffHeapValuesEvictionSelfTest.java |   18 +-
 .../GridCachePartitionedLocalStoreSelfTest.java |    6 -
 ...chePartitionedOffHeapLocalStoreSelfTest.java |    6 -
 .../GridCachePreloadingEvictionsSelfTest.java   |    4 +-
 .../GridCacheReplicatedLocalStoreSelfTest.java  |    6 -
 ...ridCacheStoreManagerDeserializationTest.java |  354 ++
 .../cache/GridCacheStoreValueBytesSelfTest.java |    2 +-
 ...acheTcpClientDiscoveryMultiThreadedTest.java |    2 +-
 .../processors/cache/GridCacheTestEntryEx.java  |   18 +-
 ...cheTransactionalAbstractMetricsSelfTest.java |    4 +-
 .../cache/GridCacheTtlManagerSelfTest.java      |    2 +-
 ...ridCacheTxPartitionedLocalStoreSelfTest.java |    6 -
 ...idCacheValueConsistencyAbstractSelfTest.java |    9 +-
 .../GridCacheVersionTopologyChangeTest.java     |  246 ++
 ...calCacheStoreManagerDeserializationTest.java |  101 +
 .../cache/IgniteCacheAbstractTest.java          |    8 +-
 .../IgniteCacheBinaryObjectsScanSelfTest.java   |    2 +
 .../IgniteCacheConfigVariationsFullApiTest.java |   50 +-
 .../IgniteCacheEntryListenerAbstractTest.java   |   16 +-
 .../IgniteCacheEntryProcessorNodeJoinTest.java  |  147 +-
 ...niteCacheExpireAndUpdateConsistencyTest.java |  437 +++
 .../cache/IgniteCacheIncrementTxTest.java       |  299 ++
 .../IgniteCacheInterceptorSelfTestSuite.java    |    2 +
 ...gniteCacheInvokeReadThroughAbstractTest.java |  382 ++
 ...iteCacheInvokeReadThroughSingleNodeTest.java |  106 +
 .../cache/IgniteCacheInvokeReadThroughTest.java |  182 +-
 .../cache/IgniteCacheNearLockValueSelfTest.java |    2 +-
 .../IgniteCacheP2pUnmarshallingErrorTest.java   |    1 -
 ...CacheP2pUnmarshallingRebalanceErrorTest.java |   36 +-
 .../IgniteCacheP2pUnmarshallingTxErrorTest.java |    2 +
 .../cache/IgniteCachePeekModesAbstractTest.java |    8 +-
 .../IgniteCacheReadThroughEvictionSelfTest.java |  297 ++
 ...acheReadThroughEvictionsVariationsSuite.java |   58 +
 .../IgniteCacheReadThroughStoreCallTest.java    |  288 ++
 .../IgniteClientAffinityAssignmentSelfTest.java |    2 +-
 ...niteDynamicCacheStartStopConcurrentTest.java |    6 +-
 .../IgniteDynamicClientCacheStartSelfTest.java  |  107 +-
 .../cache/IgniteTxConfigCacheSelfTest.java      |  249 ++
 .../IgniteTxExceptionAbstractSelfTest.java      |   38 +-
 .../cache/IgniteTxReentryAbstractSelfTest.java  |    2 +-
 .../IgniteTxStoreExceptionAbstractSelfTest.java |    8 +-
 ...rceptorCacheConfigVariationsFullApiTest.java |  118 +
 ...terceptorWithKeepBinaryCacheFullApiTest.java |  124 +
 .../MarshallerCacheJobRunNodeRestartTest.java   |  307 ++
 .../cache/WithKeepBinaryCacheFullApiTest.java   | 1234 +++++++
 .../CacheKeepBinaryWithInterceptorTest.java     |  419 +++
 ...acheBinaryObjectUserClassloaderSelfTest.java |  274 ++
 .../GridCacheBinaryObjectsAbstractSelfTest.java |  261 +-
 ...eAbstractDataStructuresFailoverSelfTest.java |  264 +-
 ...actQueueFailoverDataConsistencySelfTest.java |    2 +-
 .../GridCacheQueueCleanupSelfTest.java          |    4 +-
 .../GridCacheSequenceApiSelfAbstractTest.java   |   37 -
 .../GridCacheSetAbstractSelfTest.java           |    5 +-
 .../GridCacheSetFailoverAbstractSelfTest.java   |    8 +-
 .../IgniteClientDataStructuresAbstractTest.java |   70 +
 .../IgniteCountDownLatchAbstractSelfTest.java   |  156 +-
 .../IgniteDataStructureUniqueNameTest.java      |   16 +-
 .../IgniteLockAbstractSelfTest.java             | 1629 +++++++++
 .../IgniteSemaphoreAbstractSelfTest.java        |   31 +
 .../local/IgniteLocalLockSelfTest.java          |  110 +
 .../IgnitePartitionedLockSelfTest.java          |   33 +
 .../IgnitePartitionedQueueNoBackupsTest.java    |    6 +-
 .../IgnitePartitionedSetNoBackupsSelfTest.java  |    6 +-
 .../IgniteReplicatedLockSelfTest.java           |   33 +
 .../CacheGetInsideLockChangingTopologyTest.java |    6 +
 ...eLateAffinityAssignmentFairAffinityTest.java |   32 +
 ...ffinityAssignmentNodeJoinValidationTest.java |  134 +
 .../CacheLateAffinityAssignmentTest.java        | 2688 ++++++++++++++
 .../GridCacheAbstractJobExecutionTest.java      |    6 +-
 .../distributed/GridCacheLockAbstractTest.java  |    2 +-
 .../GridCacheTransformEventSelfTest.java        |    2 +-
 ...niteCacheClientNodeChangingTopologyTest.java |   37 +-
 ...teCacheClientNodePartitionsExchangeTest.java |   85 +-
 .../IgniteCacheClientReconnectTest.java         |    2 +
 .../distributed/IgniteCacheCreatePutTest.java   |  143 +-
 .../distributed/IgniteCacheGetRestartTest.java  |    4 +
 .../distributed/IgniteCacheManyClientsTest.java |    6 +
 .../IgniteCacheMessageWriteTimeoutTest.java     |  129 +
 .../IgniteCacheNearRestartRollbackSelfTest.java |   28 +-
 .../distributed/IgniteCachePrimarySyncTest.java |   45 +-
 .../IgniteCacheReadFromBackupTest.java          |   12 +-
 .../IgniteCacheServerNodeConcurrentStart.java   |    3 +
 .../IgniteCacheSingleGetMessageTest.java        |    8 +-
 .../IgniteCacheTxIteratorSelfTest.java          |  241 ++
 .../IgniteTxCachePrimarySyncTest.java           | 1114 ++++++
 ...teSynchronizationModesMultithreadedTest.java |  422 +++
 .../dht/GridCacheColocatedDebugTest.java        |    2 +-
 .../dht/GridCacheDhtEvictionSelfTest.java       |   15 +-
 .../GridCacheDhtPreloadMessageCountTest.java    |    6 +-
 .../distributed/dht/GridCacheDhtTestUtils.java  |    9 +-
 ...ePartitionedNearDisabledMetricsSelfTest.java |    2 +-
 ...idCachePartitionedPreloadEventsSelfTest.java |   11 +
 ...ridCachePartitionedUnloadEventsSelfTest.java |    2 +
 .../dht/GridCacheTxNodeFailureSelfTest.java     |   12 +-
 .../dht/IgniteCacheConcurrentPutGetRemove.java  |  201 ++
 .../IgniteCachePutRetryAbstractSelfTest.java    |    4 +-
 ...imaryWriteOrderMultiNodeFullApiSelfTest.java |   35 +
 ...AtomicPartitionedTckMetricsSelfTestImpl.java |   92 +-
 .../near/GridCacheNearJobExecutionSelfTest.java |    2 -
 .../near/GridCacheNearMetricsSelfTest.java      |  152 +-
 .../near/GridCacheNearMultiNodeSelfTest.java    |    4 +-
 .../near/GridCacheNearOneNodeSelfTest.java      |    4 +-
 .../near/GridCacheNearReadersSelfTest.java      |    2 +
 .../near/GridCacheNearTxForceKeyTest.java       |    6 +-
 ...idCachePartitionedHitsAndMissesSelfTest.java |    2 +-
 ...LateAffDisabledMultiNodeFullApiSelfTest.java |   34 +
 ...achePartitionedMultiNodeCounterSelfTest.java |   43 +-
 ...achePartitionedMultiNodeFullApiSelfTest.java |    2 +
 ...achePartitionedPreloadLifecycleSelfTest.java |  102 +-
 ...idCacheRendezvousAffinityClientSelfTest.java |    2 +
 ...cingDelayedPartitionMapExchangeSelfTest.java |   14 +-
 .../GridCacheRebalancingSyncSelfTest.java       |  245 +-
 .../GridCacheReplicatedJobExecutionTest.java    |    2 -
 .../IgniteCacheSyncRebalanceModeSelfTest.java   |  116 +
 ...CacheReplicatedPreloadLifecycleSelfTest.java |  132 +-
 .../IgniteCacheExpiryPolicyAbstractTest.java    |    3 +-
 .../IgniteCacheExpiryPolicyTestSuite.java       |    6 +
 .../IgniteCacheLoaderWriterAbstractTest.java    |   10 +
 ...CacheLocalOffHeapAndSwapMetricsSelfTest.java |  415 ---
 .../CacheOffHeapAndSwapMetricsSelfTest.java     |  621 ++++
 ...dCacheAtomicLocalTckMetricsSelfTestImpl.java |   92 +-
 ...FailoverAtomicPrimaryWriteOrderSelfTest.java |   50 +
 ...sQueryAsyncFailoverTxReplicatedSelfTest.java |   37 +
 ...eContinuousQueryAsyncFailoverTxSelfTest.java |   44 +
 ...eContinuousQueryAsyncFilterListenerTest.java |  986 +++++
 ...acheContinuousQueryExecuteInPrimaryTest.java |  306 ++
 ...ryFactoryAsyncFilterRandomOperationTest.java |  131 +
 ...usQueryFactoryFilterRandomOperationTest.java |  725 ++++
 .../CacheContinuousQueryFactoryFilterTest.java  |  714 ----
 ...ContinuousQueryFailoverAbstractSelfTest.java |  112 +-
 .../CacheContinuousQueryLostPartitionTest.java  |   14 +-
 ...ontinuousQueryOperationFromCallbackTest.java |  627 ++++
 .../CacheContinuousQueryOrderingEventTest.java  |  722 ++++
 ...acheContinuousQueryRandomOperationsTest.java |  553 ++-
 ...inuousQueryRandomOperationsTwoNodesTest.java |   28 +
 .../CacheContinuousQueryVariationsTest.java     |  949 +++++
 ...CacheKeepBinaryIterationNearEnabledTest.java |   44 +
 ...acheKeepBinaryIterationStoreEnabledTest.java |   90 +
 ...CacheKeepBinaryIterationSwapEnabledTest.java |   56 +
 .../CacheKeepBinaryIterationTest.java           |  471 +++
 ...yRemoteFilterMissingInClassPathSelfTest.java |  237 ++
 ...ridCacheContinuousQueryAbstractSelfTest.java |    2 +-
 .../GridCacheContinuousQueryConcurrentTest.java |  466 +++
 ...niteCacheContinuousQueryBackupQueueTest.java |  135 +
 ...eCacheContinuousQueryImmutableEntryTest.java |  205 ++
 ...BehindStorePartitionedMultiNodeSelfTest.java |   11 +-
 .../transactions/DepthFirstSearchTest.java      |  252 ++
 .../transactions/TxDeadlockDetectionTest.java   |  495 +++
 ...simisticDeadlockDetectionCrossCacheTest.java |  165 +
 .../TxPessimisticDeadlockDetectionTest.java     |  487 +++
 .../cluster/GridAddressResolverSelfTest.java    |   97 +
 ...gniteComputeConfigVariationsFullApiTest.java | 2011 +++++++++++
 .../continuous/GridMessageListenSelfTest.java   |   30 +-
 .../IgniteNoCustomEventsOnNodeStart.java        |   85 +
 .../processors/igfs/IgfsAbstractSelfTest.java   |  247 +-
 ...lockMessageSystemPoolStarvationSelfTest.java |  299 ++
 .../igfs/IgfsClientCacheSelfTest.java           |  139 -
 .../igfs/IgfsDataManagerSelfTest.java           |   67 +-
 .../igfs/IgfsDualAbstractSelfTest.java          |   30 +-
 .../igfs/IgfsDualAsyncClientSelfTest.java       |   28 +
 .../igfs/IgfsDualSyncClientSelfTest.java        |   28 +
 .../processors/igfs/IgfsFileInfoSelfTest.java   |   31 +-
 .../igfs/IgfsMetaManagerSelfTest.java           |  125 +-
 .../processors/igfs/IgfsModesSelfTest.java      |    1 +
 .../processors/igfs/IgfsOneClientNodeTest.java  |    7 +-
 .../igfs/IgfsPrimaryClientSelfTest.java         |   30 +
 .../igfs/IgfsPrimaryMultiNodeSelfTest.java      |   28 +
 .../IgfsPrimaryOptimziedMarshallerSelfTest.java |   28 +
 ...PrimaryRelaxedConsistencyClientSelfTest.java |   28 +
 ...maryRelaxedConsistencyMultiNodeSelfTest.java |   28 +
 .../IgfsPrimaryRelaxedConsistencySelfTest.java  |   28 +
 .../processors/igfs/IgfsProcessorSelfTest.java  |   71 +-
 .../igfs/IgfsProcessorValidationSelfTest.java   |   70 +-
 .../processors/igfs/IgfsSizeSelfTest.java       |  151 +-
 .../processors/igfs/IgfsStartCacheTest.java     |    9 +-
 .../processors/igfs/IgfsStreamsSelfTest.java    |   27 +-
 .../processors/igfs/IgfsTaskSelfTest.java       |    2 +-
 ...niteMessagingConfigVariationFullApiTest.java |  484 +++
 .../odbc/OdbcProcessorValidationSelfTest.java   |  144 +
 .../service/GridServiceClientNodeTest.java      |  102 +-
 ...GridServiceProxyClientReconnectSelfTest.java |  124 +
 .../GridServiceProxyNodeStopSelfTest.java       |    2 +-
 ...gniteServiceConfigVariationsFullApiTest.java |  350 ++
 ...yment2ClassLoadersDefaultMarshallerTest.java |  259 ++
 ...eployment2ClassLoadersJdkMarshallerTest.java |   31 +
 ...ent2ClassLoadersOptimizedMarshallerTest.java |   31 +
 ...oymentClassLoadingDefaultMarshallerTest.java |  212 ++
 ...DeploymentClassLoadingJdkMarshallerTest.java |   31 +
 ...mentClassLoadingOptimizedMarshallerTest.java |   31 +
 .../internal/util/IgniteUtilsSelfTest.java      |   15 +
 ...GridUnsafeDataOutputArraySizingSelfTest.java |  144 +-
 .../unsafe/GridOffheapSnapTreeSelfTest.java     |    2 +-
 .../ignite/jvmtest/ConcurrentMapTest.java       |    3 +-
 .../cache/GridCacheDataStructuresLoadTest.java  |   53 +
 .../GridTcpCommunicationBenchmark.java          |   26 +-
 .../loadtests/hashmap/GridCacheTestContext.java |    2 +
 .../marshaller/MarshallerContextTestImpl.java   |    7 +
 .../GridP2PMissedResourceCacheSizeSelfTest.java |    6 +-
 .../platform/PlatformAttributeNodeFilter.java   |   31 +
 .../platform/PlatformCacheEntryEventFilter.java |  193 +
 .../PlatformCacheEntryEventFilterFactory.java   |   59 +
 .../platform/PlatformComputeEchoTask.java       |   11 +-
 ...latformDefaultJavaObjectFactorySelfTest.java |  185 +
 .../platform/PlatformDeployServiceTask.java     |  360 ++
 .../PlatformJavaObjectFactoryProxySelfTest.java |  220 ++
 .../ignite/platform/PlatformSqlQueryTask.java   |  117 +
 .../platform/PlatformStartIgniteTask.java       |    1 +
 .../ignite/platform/PlatformStopIgniteTask.java |    1 +
 .../ignite/platform/PlatformStringTestTask.java |   67 +
 .../platform/javaobject/TestJavaObject.java     |  271 ++
 .../javaobject/TestJavaObjectNoDefaultCtor.java |   49 +
 .../TestJavaObjectNoDefaultCtorFactory.java     |   68 +
 .../GridTcpCommunicationSpiConfigSelfTest.java  |   22 +
 .../tcp/TcpClientDiscoverySpiSelfTest.java      |   48 +-
 .../spi/discovery/tcp/TcpDiscoverySelfTest.java |  221 +-
 .../tcp/TcpDiscoverySpiConfigSelfTest.java      |   22 +
 .../TcpDiscoverySpiFailureTimeoutSelfTest.java  |   23 +-
 .../spi/discovery/tcp/TestTcpDiscoverySpi.java  |    5 +-
 .../TcpDiscoverySharedFsIpFinderSelfTest.java   |   25 +
 .../vm/TcpDiscoveryVmIpFinderSelfTest.java      |   75 +
 .../properties/NotStringSystemPropertyTest.java |  124 +
 .../ignite/testframework/GridTestUtils.java     |    5 +-
 .../configvariations/ConfigVariations.java      |    2 +-
 .../ConfigVariationsTestSuiteBuilder.java       |   31 +-
 .../configvariations/VariationsTestsConfig.java |   21 +-
 .../testframework/junits/GridAbstractTest.java  |    6 +-
 .../junits/GridTestKernalContext.java           |    1 +
 ...IgniteCacheConfigVariationsAbstractTest.java |   21 +-
 .../IgniteConfigVariationsAbstractTest.java     |  282 +-
 .../ignite/testframework/junits/IgniteMock.java |   10 +
 .../junits/common/GridCommonAbstractTest.java   |  169 +-
 .../multijvm/IgniteCacheProcessProxy.java       |    8 +
 .../multijvm/IgniteClusterProcessProxy.java     |    5 +
 .../junits/multijvm/IgniteProcessProxy.java     |    7 +
 ...naryObjectsTxDeadlockDetectionTestSuite.java |   37 +
 .../ignite/testsuites/IgniteBasicTestSuite.java |    9 +-
 .../testsuites/IgniteBinaryCacheTestSuite.java  |    2 +
 ...IgniteBinaryObjectsComputeGridTestSuite.java |    7 +-
 .../IgniteBinaryObjectsTestSuite.java           |   11 +-
 .../IgniteCacheDataStructuresSelfTestSuite.java |   17 +-
 .../IgniteCacheFullApiSelfTestSuite.java        |    6 +
 .../IgniteCacheMetricsSelfTestSuite.java        |    4 +-
 .../ignite/testsuites/IgniteCacheTestSuite.java |   16 +-
 .../testsuites/IgniteCacheTestSuite2.java       |    7 +
 .../testsuites/IgniteCacheTestSuite3.java       |    4 +
 .../testsuites/IgniteCacheTestSuite4.java       |   24 +-
 .../testsuites/IgniteCacheTestSuite5.java       |   18 +-
 ...teBasicConfigVariationsFullApiTestSuite.java |   72 +
 ...iteContinuousQueryConfigVariationsSuite.java |   60 +
 .../ignite/testsuites/IgniteIgfsTestSuite.java  |   30 +-
 .../testsuites/IgniteKernalSelfTestSuite.java   |   21 +
 .../IgniteMarshallerSelfTestSuite.java          |    2 +-
 ...essagingConfigVariationFullApiTestSuite.java |   72 +
 .../testsuites/IgnitePlatformsTestSuite.java    |   41 +
 ...ServiceConfigVariationsFullApiTestSuite.java |   92 +
 ...orCacheConfigVariationsFullApiTestSuite.java |   41 +
 .../TxDeadlockDetectionTestSuite.java           |   44 +
 ...ryCacheConfigVariationsFullApiTestSuite.java |   71 +
 modules/docker/1.6.0/Dockerfile                 |   44 +
 modules/docker/1.6.0/run.sh                     |   51 +
 modules/docker/Dockerfile                       |   24 +-
 modules/extdata/p2p/pom.xml                     |    2 +-
 ...CacheDeploymentCachePluginConfiguration.java |    7 +
 .../apache/ignite/tests/p2p/NoopService.java    |   41 +
 .../apache/ignite/tests/p2p/NoopService2.java   |   41 +
 .../extdata/uri/modules/uri-dependency/pom.xml  |    2 +-
 modules/extdata/uri/pom.xml                     |    2 +-
 modules/flink/README.txt                        |   33 +
 modules/flink/licenses/apache-2.0.txt           |  202 ++
 modules/flink/pom.xml                           |  167 +
 .../apache/ignite/sink/flink/IgniteSink.java    |  204 ++
 .../apache/ignite/sink/flink/package-info.java  |   22 +
 .../sink/flink/FlinkIgniteSinkSelfTest.java     |  188 +
 .../flink/FlinkIgniteSinkSelfTestSuite.java     |   38 +
 .../flink/src/test/resources/example-ignite.xml |   70 +
 modules/flume/pom.xml                           |    2 +-
 modules/gce/pom.xml                             |    2 +-
 modules/geospatial/pom.xml                      |    2 +-
 modules/hadoop/pom.xml                          |    2 +-
 .../hadoop/fs/BasicHadoopFileSystemFactory.java |   56 +-
 .../fs/CachingHadoopFileSystemFactory.java      |    7 +-
 .../fs/IgniteHadoopIgfsSecondaryFileSystem.java |   46 +-
 .../fs/KerberosHadoopFileSystemFactory.java     |    4 +-
 .../hadoop/fs/v1/IgniteHadoopFileSystem.java    |   19 +-
 .../hadoop/fs/v2/IgniteHadoopFileSystem.java    |   21 +-
 .../mapreduce/IgniteHadoopMapReducePlanner.java |   72 +-
 .../ignite/hadoop/util/BasicUserNameMapper.java |  112 +
 .../hadoop/util/ChainedUserNameMapper.java      |   94 +
 .../hadoop/util/KerberosUserNameMapper.java     |  137 +
 .../ignite/hadoop/util/UserNameMapper.java      |   37 +
 .../apache/ignite/hadoop/util/package-info.java |   22 +
 .../processors/hadoop/HadoopClassLoader.java    |   49 +-
 .../processors/hadoop/HadoopContext.java        |    3 +-
 .../processors/hadoop/HadoopDefaultJobInfo.java |    8 +-
 .../hadoop/igfs/HadoopIgfsProperties.java       |   11 +-
 .../hadoop/igfs/HadoopIgfsWrapper.java          |   11 +-
 .../hadoop/jobtracker/HadoopJobTracker.java     |   22 +-
 .../shuffle/collections/HadoopMultimapBase.java |   90 +-
 .../child/HadoopChildProcessRunner.java         |    4 +-
 .../processors/hadoop/v2/HadoopV2Job.java       |   14 +-
 .../hadoop/v2/HadoopV2JobResourceManager.java   |    6 +-
 .../hadoop/cache/HadoopTxConfigCacheTest.java   |   42 +
 .../util/BasicUserNameMapperSelfTest.java       |  133 +
 .../util/ChainedUserNameMapperSelfTest.java     |  107 +
 .../util/KerberosUserNameMapperSelfTest.java    |   99 +
 .../ignite/igfs/Hadoop1DualAbstractTest.java    |   51 +-
 .../igfs/HadoopFIleSystemFactorySelfTest.java   |    1 +
 ...oopFileSystemUniversalFileSystemAdapter.java |    8 +-
 .../HadoopIgfs20FileSystemAbstractSelfTest.java |    2 +
 .../igfs/HadoopIgfsDualAbstractSelfTest.java    |   11 +-
 .../apache/ignite/igfs/IgfsEventsTestSuite.java |   16 +-
 .../IgniteHadoopFileSystemAbstractSelfTest.java |    2 +
 ...IgniteHadoopFileSystemHandshakeSelfTest.java |  121 +-
 .../IgniteHadoopFileSystemLoggerSelfTest.java   |   21 +-
 .../hadoop/HadoopAbstractMapReduceTest.java     |  405 +++
 .../hadoop/HadoopClassLoaderTest.java           |    2 +-
 .../HadoopDefaultMapReducePlannerSelfTest.java  |    8 +-
 .../processors/hadoop/HadoopErrorSimulator.java |  326 ++
 .../HadoopMapReduceErrorResilienceTest.java     |  154 +
 .../processors/hadoop/HadoopMapReduceTest.java  |  379 +-
 .../hadoop/HadoopNoHadoopMapReduceTest.java     |   47 +
 .../hadoop/HadoopSnappyFullMapReduceTest.java   |    8 +
 .../processors/hadoop/HadoopSnappyTest.java     |    2 +-
 .../processors/hadoop/HadoopTasksV1Test.java    |    2 +-
 .../processors/hadoop/HadoopTasksV2Test.java    |    2 +-
 .../processors/hadoop/HadoopV2JobSelfTest.java  |    2 +-
 .../hadoop/examples/HadoopWordCount1Map.java    |   12 +
 .../hadoop/examples/HadoopWordCount1Reduce.java |    5 +
 .../hadoop/examples/HadoopWordCount2.java       |    2 +-
 .../examples/HadoopWordCount2Combiner.java      |   45 +
 .../hadoop/examples/HadoopWordCount2Mapper.java |   19 +-
 .../examples/HadoopWordCount2Reducer.java       |   43 +-
 .../collections/HadoopAbstractMapTest.java      |    6 +-
 .../testsuites/IgniteHadoopTestSuite.java       |   51 +-
 modules/hibernate/pom.xml                       |    2 +-
 .../HibernateL2CacheTransactionalSelfTest.java  |    9 +
 ...nateL2CacheTransactionalUseSyncSelfTest.java |   31 +
 .../testsuites/IgniteHibernateTestSuite.java    |    4 +-
 modules/indexing/pom.xml                        |    9 +-
 .../processors/query/h2/IgniteH2Indexing.java   |   63 +
 .../query/h2/opt/GridH2AbstractKeyValueRow.java |   23 +-
 .../query/h2/opt/GridH2IndexBase.java           |   28 +-
 .../query/h2/opt/GridH2KeyValueRowOffheap.java  |   17 +-
 .../processors/query/h2/sql/GridSqlConst.java   |    5 +
 .../processors/query/h2/sql/GridSqlJoin.java    |   17 +-
 .../query/h2/sql/GridSqlQuerySplitter.java      |    6 +-
 .../processors/query/h2/sql/GridSqlSelect.java  |    2 +-
 .../processors/query/h2/sql/GridSqlType.java    |    5 +
 .../query/h2/twostep/GridMapQueryExecutor.java  |    2 +-
 .../h2/twostep/GridReduceQueryExecutor.java     |    4 +-
 .../CacheAbstractQueryMetricsSelfTest.java      |    4 +-
 .../CacheOffheapBatchIndexingBaseTest.java      |  313 ++
 .../CacheOffheapBatchIndexingMultiTypeTest.java |  108 +
 ...CacheOffheapBatchIndexingSingleTypeTest.java |  161 +
 .../CacheOperationsWithExpirationTest.java      |  355 ++
 .../cache/GridCacheOffheapIndexGetSelfTest.java |   48 +
 .../cache/IgniteCacheAbstractQuerySelfTest.java |   34 +-
 .../IgniteCacheConfigVariationsQueryTest.java   |  505 +++
 .../cache/IgniteCacheOffheapIndexScanTest.java  |  195 +
 .../IgniteCacheQueryH2IndexingLeakTest.java     |  214 ++
 .../IgniteCacheStarvationOnRebalanceTest.java   |  166 +
 .../cache/IgniteClientReconnectQueriesTest.java |    4 +-
 .../IgniteCacheQueryNoRebalanceSelfTest.java    |   82 +
 .../IgniteCacheQueryNodeRestartSelfTest2.java   |    3 +
 .../query/IgniteSqlSplitterSelfTest.java        |   75 +
 .../query/h2/sql/GridQueryParsingTest.java      |   11 +-
 .../IgniteBinaryCacheQueryTestSuite.java        |    2 -
 .../IgniteBinaryCacheQueryTestSuite2.java       |   39 +
 .../IgniteBinaryCacheQueryTestSuite3.java       |   39 +
 .../IgniteBinaryCacheQueryTestSuite4.java       |   39 +
 ...gniteCacheConfigVariationQueryTestSuite.java |   41 +
 .../IgniteCacheQuerySelfTestSuite.java          |  109 +-
 .../IgniteCacheQuerySelfTestSuite2.java         |  111 +
 .../IgniteCacheQuerySelfTestSuite3.java         |  123 +
 .../IgniteCacheQuerySelfTestSuite4.java         |   56 +
 .../IgniteCacheWithIndexingTestSuite.java       |    4 +
 modules/jcl/pom.xml                             |    2 +-
 modules/jms11/pom.xml                           |    2 +-
 modules/jta/pom.xml                             |    2 +-
 .../websphere/WebSphereLibertyTmFactory.java    |   77 +
 .../cache/jta/websphere/WebSphereTmFactory.java |  244 ++
 .../cache/jta/websphere/package-info.java       |   22 +
 .../processors/cache/jta/CacheJtaManager.java   |   26 +-
 .../processors/cache/jta/CacheJtaResource.java  |  304 ++
 .../cache/jta/GridCacheXAResource.java          |  251 --
 .../cache/AbstarctCacheJtaSelfTest.java         |  183 -
 .../cache/AbstractCacheJtaSelfTest.java         |  183 +
 .../GridPartitionedCacheJtaFactorySelfTest.java |    2 +-
 ...rtitionedCacheJtaFactoryUseSyncSelfTest.java |   32 +
 ...titionedCacheJtaLookupClassNameSelfTest.java |    2 +-
 ...eplicatedCacheJtaFactoryUseSyncSelfTest.java |   32 +
 .../ignite/testsuites/IgniteJtaTestSuite.java   |    5 +
 modules/kafka/README.txt                        |   85 +-
 modules/kafka/pom.xml                           |    5 +-
 .../ignite/stream/kafka/KafkaStreamer.java      |    4 +-
 .../kafka/connect/IgniteSourceConnector.java    |   81 +
 .../kafka/connect/IgniteSourceConstants.java    |   44 +
 .../stream/kafka/connect/IgniteSourceTask.java  |  363 ++
 .../serialization/CacheEventConverter.java      |   66 +
 .../serialization/CacheEventDeserializer.java   |   54 +
 .../serialization/CacheEventSerializer.java     |   54 +
 .../kafka/IgniteKafkaStreamerSelfTestSuite.java |    4 +-
 .../kafka/KafkaIgniteStreamerSelfTest.java      |   11 +-
 .../ignite/stream/kafka/TestKafkaBroker.java    |   27 +-
 .../kafka/connect/IgniteSinkConnectorTest.java  |   21 +-
 .../connect/IgniteSourceConnectorMock.java      |   30 +
 .../connect/IgniteSourceConnectorTest.java      |  353 ++
 .../kafka/connect/IgniteSourceTaskMock.java     |   31 +
 .../kafka/connect/TestCacheEventFilter.java     |   31 +
 .../kafka/src/test/resources/example-ignite.xml |    4 +-
 modules/log4j/pom.xml                           |    2 +-
 modules/log4j2/pom.xml                          |    2 +-
 modules/mesos/pom.xml                           |   42 +-
 .../apache/ignite/mesos/ClusterProperties.java  |  133 +-
 .../apache/ignite/mesos/IgniteFramework.java    |   23 +-
 .../ignite/mesos/resource/IgniteProvider.java   |  198 +-
 .../ignite/mesos/resource/JettyServer.java      |   16 +-
 .../ignite/mesos/resource/ResourceProvider.java |   78 +-
 modules/mqtt/pom.xml                            |    2 +-
 modules/osgi-karaf/pom.xml                      |    2 +-
 modules/osgi-paxlogging/pom.xml                 |    2 +-
 modules/osgi/pom.xml                            |    2 +-
 modules/platforms/cpp/DEVNOTES.txt              |   66 +-
 modules/platforms/cpp/Makefile.am               |   61 +
 modules/platforms/cpp/Makefile.amrel            |   49 +
 modules/platforms/cpp/README.txt                |   29 +-
 modules/platforms/cpp/binary/Makefile.am        |   69 +
 .../platforms/cpp/binary/include/Makefile.am    |   46 +
 .../cpp/binary/include/ignite/binary/binary.h   |   34 +
 .../include/ignite/binary/binary_consts.h       |   86 +
 .../include/ignite/binary/binary_containers.h   |  650 ++++
 .../include/ignite/binary/binary_raw_reader.h   |  408 +++
 .../include/ignite/binary/binary_raw_writer.h   |  376 ++
 .../include/ignite/binary/binary_reader.h       |  446 +++
 .../binary/include/ignite/binary/binary_type.h  |  310 ++
 .../include/ignite/binary/binary_writer.h       |  414 +++
 .../include/ignite/impl/binary/binary_common.h  |  194 +
 .../ignite/impl/binary/binary_id_resolver.h     |  106 +
 .../ignite/impl/binary/binary_reader_impl.h     | 1422 ++++++++
 .../include/ignite/impl/binary/binary_schema.h  |  136 +
 .../ignite/impl/binary/binary_type_handler.h    |  102 +
 .../ignite/impl/binary/binary_type_manager.h    |  120 +
 .../ignite/impl/binary/binary_type_snapshot.h   |  122 +
 .../ignite/impl/binary/binary_type_updater.h    |   53 +
 .../include/ignite/impl/binary/binary_utils.h   |  546 +++
 .../ignite/impl/binary/binary_writer_impl.h     |  985 +++++
 .../include/ignite/impl/interop/interop.h       |   25 +
 .../ignite/impl/interop/interop_input_stream.h  |  250 ++
 .../ignite/impl/interop/interop_memory.h        |  269 ++
 .../ignite/impl/interop/interop_output_stream.h |  250 ++
 .../interop/interop_stream_position_guard.h     |   79 +
 .../cpp/binary/project/vs/binary.vcxproj        |  233 ++
 .../binary/project/vs/binary.vcxproj.filters    |  145 +
 .../cpp/binary/src/binary/binary_containers.cpp |   76 +
 .../cpp/binary/src/binary/binary_raw_reader.cpp |  166 +
 .../cpp/binary/src/binary/binary_raw_writer.cpp |  167 +
 .../cpp/binary/src/binary/binary_reader.cpp     |  173 +
 .../cpp/binary/src/binary/binary_type.cpp       |   51 +
 .../cpp/binary/src/binary/binary_writer.cpp     |  174 +
 .../src/impl/binary/binary_reader_impl.cpp      |  907 +++++
 .../binary/src/impl/binary/binary_schema.cpp    |  135 +
 .../src/impl/binary/binary_type_handler.cpp     |   78 +
 .../src/impl/binary/binary_type_manager.cpp     |  201 ++
 .../src/impl/binary/binary_type_snapshot.cpp    |   70 +
 .../src/impl/binary/binary_type_updater.cpp     |   32 +
 .../cpp/binary/src/impl/binary/binary_utils.cpp |  303 ++
 .../src/impl/binary/binary_writer_impl.cpp      |  770 ++++
 .../src/impl/interop/interop_input_stream.cpp   |  236 ++
 .../binary/src/impl/interop/interop_memory.cpp  |  171 +
 .../src/impl/interop/interop_output_stream.cpp  |  234 ++
 modules/platforms/cpp/common/Makefile.am        |   50 +-
 modules/platforms/cpp/common/configure.ac       |   62 -
 .../platforms/cpp/common/ignite-common.pc.in    |    9 -
 .../platforms/cpp/common/include/Makefile.am    |   15 +-
 .../common/include/ignite/common/concurrent.h   |  191 +-
 .../cpp/common/include/ignite/common/exports.h  |  182 -
 .../cpp/common/include/ignite/common/java.h     |  743 ----
 .../cpp/common/include/ignite/common/utils.h    |  208 +-
 .../platforms/cpp/common/include/ignite/date.h  |  138 +
 .../platforms/cpp/common/include/ignite/guid.h  |  172 +
 .../cpp/common/include/ignite/ignite_error.h    |  285 ++
 .../cpp/common/include/ignite/timestamp.h       |  166 +
 .../cpp/common/os/linux/include/Makefile.am     |    9 +-
 .../os/linux/include/ignite/common/common.h     |   57 +-
 .../linux/include/ignite/common/concurrent_os.h |    2 +-
 .../cpp/common/os/linux/src/common.cpp          |   59 -
 .../os/linux/src/common/concurrent_os.cpp       |  175 +
 .../cpp/common/os/linux/src/common/utils.cpp    |  136 +
 .../cpp/common/os/linux/src/concurrent_os.cpp   |  175 -
 .../os/win/include/ignite/common/common.h       |   26 +-
 .../win/include/ignite/common/concurrent_os.h   |    4 +-
 .../platforms/cpp/common/os/win/src/common.cpp  |   65 -
 .../common/os/win/src/common/concurrent_os.cpp  |  175 +
 .../cpp/common/os/win/src/common/utils.cpp      |  143 +
 .../cpp/common/os/win/src/concurrent_os.cpp     |  175 -
 .../cpp/common/project/vs/common.vcxproj        |   61 +-
 .../common/project/vs/common.vcxproj.filters    |   50 +-
 .../platforms/cpp/common/project/vs/module.def  |  132 -
 .../cpp/common/src/common/concurrent.cpp        |  105 +
 modules/platforms/cpp/common/src/concurrent.cpp |   94 -
 modules/platforms/cpp/common/src/date.cpp       |   83 +
 modules/platforms/cpp/common/src/exports.cpp    |  545 ---
 modules/platforms/cpp/common/src/guid.cpp       |   65 +
 .../platforms/cpp/common/src/ignite_error.cpp   |  226 ++
 modules/platforms/cpp/common/src/java.cpp       | 2735 --------------
 modules/platforms/cpp/common/src/timestamp.cpp  |  117 +
 modules/platforms/cpp/configure.ac              |  108 +
 modules/platforms/cpp/configure.acrel           |   93 +
 modules/platforms/cpp/core-test/Makefile.am     |   63 +-
 .../cpp/core-test/config/cache-query.xml        |    2 +
 .../cpp/core-test/config/cache-test.xml         |    6 +
 modules/platforms/cpp/core-test/configure.ac    |   62 -
 .../platforms/cpp/core-test/include/Makefile.am |   10 +-
 .../include/ignite/binary_test_utils.h          |   96 +
 .../cpp/core-test/project/vs/core-test.vcxproj  |   18 +-
 .../project/vs/core-test.vcxproj.filters        |    9 +
 .../src/binary_reader_writer_raw_test.cpp       |  124 +
 .../core-test/src/binary_reader_writer_test.cpp |  192 +
 .../cpp/core-test/src/binary_session_test.cpp   |   36 +
 .../cpp/core-test/src/cache_query_test.cpp      |  462 ++-
 .../platforms/cpp/core-test/src/cache_test.cpp  |   24 +
 .../cpp/core-test/src/concurrent_test.cpp       |   93 +
 .../cpp/core-test/src/ignite_error_test.cpp     |   45 +
 .../cpp/core-test/src/interop_test.cpp          |  148 +
 .../cpp/core-test/src/transactions_test.cpp     |  639 ++++
 modules/platforms/cpp/core/Makefile.am          |   86 +-
 modules/platforms/cpp/core/configure.ac         |   62 -
 modules/platforms/cpp/core/include/Makefile.am  |   83 +-
 .../cpp/core/include/ignite/binary/binary.h     |   34 -
 .../core/include/ignite/binary/binary_consts.h  |   86 -
 .../include/ignite/binary/binary_containers.h   |  530 ---
 .../include/ignite/binary/binary_raw_reader.h   |  355 --
 .../include/ignite/binary/binary_raw_writer.h   |  331 --
 .../core/include/ignite/binary/binary_reader.h  |  389 --
 .../core/include/ignite/binary/binary_type.h    |  310 --
 .../core/include/ignite/binary/binary_writer.h  |  367 --
 .../cpp/core/include/ignite/cache/cache.h       |  202 +-
 .../cpp/core/include/ignite/cache/cache_entry.h |   45 +-
 .../core/include/ignite/cache/cache_peek_mode.h |    6 +-
 .../cpp/core/include/ignite/cache/query/query.h |    6 +-
 .../include/ignite/cache/query/query_argument.h |   39 +-
 .../include/ignite/cache/query/query_cursor.h   |   70 +-
 .../ignite/cache/query/query_fields_cursor.h    |   52 +-
 .../ignite/cache/query/query_fields_row.h       |   59 +-
 .../include/ignite/cache/query/query_scan.h     |   18 +-
 .../core/include/ignite/cache/query/query_sql.h |   21 +-
 .../ignite/cache/query/query_sql_fields.h       |   21 +-
 .../include/ignite/cache/query/query_text.h     |    6 +-
 .../platforms/cpp/core/include/ignite/guid.h    |  117 -
 .../platforms/cpp/core/include/ignite/ignite.h  |   49 +-
 .../core/include/ignite/ignite_configuration.h  |   12 +-
 .../cpp/core/include/ignite/ignite_error.h      |  265 --
 .../cpp/core/include/ignite/ignition.h          |    7 +-
 .../include/ignite/impl/binary/binary_common.h  |  188 -
 .../ignite/impl/binary/binary_id_resolver.h     |  106 -
 .../ignite/impl/binary/binary_reader_impl.h     | 1309 -------
 .../include/ignite/impl/binary/binary_schema.h  |  136 -
 .../ignite/impl/binary/binary_type_handler.h    |  102 -
 .../ignite/impl/binary/binary_type_manager.h    |  120 -
 .../ignite/impl/binary/binary_type_snapshot.h   |  122 -
 .../ignite/impl/binary/binary_type_updater.h    |   53 -
 .../impl/binary/binary_type_updater_impl.h      |    8 +-
 .../include/ignite/impl/binary/binary_utils.h   |  344 --
 .../ignite/impl/binary/binary_writer_impl.h     |  913 -----
 .../core/include/ignite/impl/cache/cache_impl.h |   75 +-
 .../impl/cache/query/query_fields_row_impl.h    |   24 +-
 .../ignite/impl/cache/query/query_impl.h        |    9 +-
 .../core/include/ignite/impl/handle_registry.h  |    6 +-
 .../include/ignite/impl/ignite_environment.h    |   18 +-
 .../cpp/core/include/ignite/impl/ignite_impl.h  |   71 +-
 .../core/include/ignite/impl/interop/interop.h  |   25 -
 .../impl/interop/interop_external_memory.h      |   54 +
 .../ignite/impl/interop/interop_input_stream.h  |  250 --
 .../ignite/impl/interop/interop_memory.h        |  280 --
 .../ignite/impl/interop/interop_output_stream.h |  250 --
 .../interop/interop_stream_position_guard.h     |   79 -
 .../ignite/impl/interop/interop_target.h        |  142 +
 .../cpp/core/include/ignite/impl/operations.h   |   89 +-
 .../ignite/impl/transactions/transaction_impl.h |  220 ++
 .../impl/transactions/transactions_impl.h       |  138 +
 .../include/ignite/transactions/transaction.h   |  278 ++
 .../ignite/transactions/transaction_consts.h    |  144 +
 .../ignite/transactions/transaction_metrics.h   |  181 +
 .../include/ignite/transactions/transactions.h  |  180 +
 modules/platforms/cpp/core/namespaces.dox       |   10 +-
 .../cpp/core/os/linux/include/Makefile.am       |   23 -
 .../core/os/linux/include/ignite/impl/utils.h   |  155 -
 .../cpp/core/os/linux/src/impl/utils.cpp        |  439 ---
 .../cpp/core/os/win/include/ignite/impl/utils.h |  155 -
 .../cpp/core/os/win/src/impl/utils.cpp          |  453 ---
 .../platforms/cpp/core/project/vs/core.vcxproj  |   90 +-
 .../cpp/core/project/vs/core.vcxproj.filters    |  179 +-
 .../cpp/core/src/binary/binary_containers.cpp   |   76 -
 .../cpp/core/src/binary/binary_raw_reader.cpp   |  145 -
 .../cpp/core/src/binary/binary_raw_writer.cpp   |  147 -
 .../cpp/core/src/binary/binary_reader.cpp       |  152 -
 .../cpp/core/src/binary/binary_type.cpp         |   51 -
 .../cpp/core/src/binary/binary_writer.cpp       |  154 -
 modules/platforms/cpp/core/src/guid.cpp         |   65 -
 modules/platforms/cpp/core/src/ignite.cpp       |   12 +-
 modules/platforms/cpp/core/src/ignite_error.cpp |  222 --
 modules/platforms/cpp/core/src/ignition.cpp     |   16 +-
 .../core/src/impl/binary/binary_reader_impl.cpp |  760 ----
 .../cpp/core/src/impl/binary/binary_schema.cpp  |  135 -
 .../src/impl/binary/binary_type_handler.cpp     |   78 -
 .../src/impl/binary/binary_type_manager.cpp     |  201 --
 .../src/impl/binary/binary_type_snapshot.cpp    |   70 -
 .../src/impl/binary/binary_type_updater.cpp     |   32 -
 .../impl/binary/binary_type_updater_impl.cpp    |    5 +-
 .../cpp/core/src/impl/binary/binary_utils.cpp   |  211 --
 .../core/src/impl/binary/binary_writer_impl.cpp |  623 ----
 .../cpp/core/src/impl/cache/cache_impl.cpp      |  141 +-
 .../core/src/impl/cache/query/query_impl.cpp    |    3 +-
 .../cpp/core/src/impl/ignite_environment.cpp    |    3 +-
 .../platforms/cpp/core/src/impl/ignite_impl.cpp |   30 +-
 .../impl/interop/interop_external_memory.cpp    |   45 +
 .../src/impl/interop/interop_input_stream.cpp   |  235 --
 .../core/src/impl/interop/interop_memory.cpp    |  182 -
 .../src/impl/interop/interop_output_stream.cpp  |  233 --
 .../core/src/impl/interop/interop_target.cpp    |  142 +
 .../src/impl/transactions/transaction_impl.cpp  |  196 +
 .../src/impl/transactions/transactions_impl.cpp |  200 +
 .../cpp/core/src/transactions/transaction.cpp   |  204 ++
 .../cpp/core/src/transactions/transactions.cpp  |  142 +
 modules/platforms/cpp/cpp.dxg                   |    6 +-
 modules/platforms/cpp/examples/Makefile.am      |   26 +-
 modules/platforms/cpp/examples/README.txt       |   15 +-
 .../cpp/examples/config/example-cache.xml       |   77 -
 modules/platforms/cpp/examples/configure.ac     |   45 +-
 .../platforms/cpp/examples/include/Makefile.am  |    9 +-
 .../examples/include/ignite/examples/address.h  |   26 +-
 .../include/ignite/examples/organization.h      |   33 +-
 .../examples/include/ignite/examples/person.h   |  110 +
 .../cpp/examples/odbc-example/Makefile.am       |   57 +
 .../odbc-example/config/example-odbc.xml        |  113 +
 .../project/vs/odbc-example.vcxproj             |  108 +
 .../project/vs/odbc-example.vcxproj.filters     |   28 +
 .../examples/odbc-example/src/odbc_example.cpp  |  286 ++
 .../cpp/examples/project/vs/ignite-examples.sln |   17 +-
 .../examples/project/vs/ignite-examples.vcxproj |  107 -
 .../project/vs/ignite-examples.vcxproj.filters  |   30 -
 .../cpp/examples/putget-example/Makefile.am     |   56 +
 .../putget-example/config/example-cache.xml     |   75 +
 .../project/vs/putget-example.vcxproj           |  107 +
 .../project/vs/putget-example.vcxproj.filters   |   30 +
 .../putget-example/src/putget_example.cpp       |  126 +
 .../cpp/examples/query-example/Makefile.am      |   56 +
 .../query-example/config/query-example.xml      |  121 +
 .../project/vs/query-example.vcxproj            |  108 +
 .../project/vs/query-example.vcxproj.filters    |   27 +
 .../query-example/src/query_example.cpp         |  405 +++
 .../cpp/examples/src/putgetexample.cpp          |  126 -
 modules/platforms/cpp/ignite/Makefile.am        |   40 +-
 modules/platforms/cpp/ignite/configure.ac       |   62 -
 .../cpp/ignite/project/vs/ignite.vcxproj        |   47 +-
 .../ignite/project/vs/ignite.vcxproj.filters    |    8 -
 modules/platforms/cpp/ignite/src/ignite.cpp     |   10 +-
 modules/platforms/cpp/jni/Makefile.am           |   62 +
 modules/platforms/cpp/jni/include/Makefile.am   |   25 +
 .../cpp/jni/include/ignite/jni/exports.h        |  186 +
 .../platforms/cpp/jni/include/ignite/jni/java.h |  764 ++++
 .../cpp/jni/include/ignite/jni/utils.h          |  101 +
 .../platforms/cpp/jni/os/linux/src/utils.cpp    |  417 +++
 modules/platforms/cpp/jni/os/win/src/utils.cpp  |  428 +++
 modules/platforms/cpp/jni/project/README.TXT    |    1 +
 modules/platforms/cpp/jni/project/vs/README.TXT |    1 +
 .../platforms/cpp/jni/project/vs/jni.vcxproj    |  205 ++
 .../cpp/jni/project/vs/jni.vcxproj.filters      |   42 +
 modules/platforms/cpp/jni/project/vs/module.def |  137 +
 .../platforms/cpp/jni/project/vs/targetver.h    |   25 +
 modules/platforms/cpp/jni/src/exports.cpp       |  561 +++
 modules/platforms/cpp/jni/src/java.cpp          | 2871 +++++++++++++++
 modules/platforms/cpp/odbc-test/Makefile.am     |   81 +
 modules/platforms/cpp/odbc-test/README.TXT      |    1 +
 .../cpp/odbc-test/config/queries-test.xml       |   95 +
 .../platforms/cpp/odbc-test/include/Makefile.am |   23 +
 .../include/teamcity/teamcity_messages.h        |   55 +
 .../platforms/cpp/odbc-test/include/test_type.h |  130 +
 .../cpp/odbc-test/project/vs/odbc-test.vcxproj  |  200 +
 .../project/vs/odbc-test.vcxproj.filters        |   96 +
 .../src/application_data_buffer_test.cpp        | 1001 ++++++
 .../platforms/cpp/odbc-test/src/column_test.cpp |  290 ++
 .../cpp/odbc-test/src/configuration_test.cpp    |  224 ++
 .../cpp/odbc-test/src/connection_info_test.cpp  |  219 ++
 .../platforms/cpp/odbc-test/src/cursor_test.cpp |  205 ++
 .../platforms/cpp/odbc-test/src/parser_test.cpp |   87 +
 .../cpp/odbc-test/src/queries_test.cpp          |  516 +++
 .../platforms/cpp/odbc-test/src/row_test.cpp    |  208 ++
 .../odbc-test/src/teamcity/teamcity_boost.cpp   |  159 +
 .../src/teamcity/teamcity_messages.cpp          |  150 +
 .../cpp/odbc-test/src/utility_test.cpp          |   81 +
 modules/platforms/cpp/odbc/Makefile.am          |   84 +
 modules/platforms/cpp/odbc/README.txt           |   89 +
 modules/platforms/cpp/odbc/include/Makefile.am  |   58 +
 .../platforms/cpp/odbc/include/ignite/odbc.h    |  257 ++
 .../ignite/odbc/app/application_data_buffer.h   |  379 ++
 .../odbc/include/ignite/odbc/app/parameter.h    |  113 +
 .../cpp/odbc/include/ignite/odbc/column.h       |  155 +
 .../cpp/odbc/include/ignite/odbc/common_types.h |  225 ++
 .../include/ignite/odbc/config/configuration.h  |  164 +
 .../ignite/odbc/config/connection_info.h        |   98 +
 .../cpp/odbc/include/ignite/odbc/connection.h   |  281 ++
 .../cpp/odbc/include/ignite/odbc/cursor.h       |  114 +
 .../cpp/odbc/include/ignite/odbc/decimal.h      |  137 +
 .../ignite/odbc/diagnostic/diagnosable.h        |   82 +
 .../odbc/diagnostic/diagnosable_adapter.h       |  107 +
 .../ignite/odbc/diagnostic/diagnostic_record.h  |  165 +
 .../odbc/diagnostic/diagnostic_record_storage.h |  198 +
 .../cpp/odbc/include/ignite/odbc/environment.h  |  137 +
 .../cpp/odbc/include/ignite/odbc/message.h      |  751 ++++
 .../odbc/include/ignite/odbc/meta/column_meta.h |  195 +
 .../include/ignite/odbc/meta/primary_key_meta.h |  188 +
 .../odbc/include/ignite/odbc/meta/table_meta.h  |  166 +
 .../cpp/odbc/include/ignite/odbc/parser.h       |  137 +
 .../ignite/odbc/query/column_metadata_query.h   |  146 +
 .../odbc/include/ignite/odbc/query/data_query.h |  152 +
 .../ignite/odbc/query/foreign_keys_query.h      |  143 +
 .../ignite/odbc/query/primary_keys_query.h      |  137 +
 .../cpp/odbc/include/ignite/odbc/query/query.h  |  119 +
 .../ignite/odbc/query/special_columns_query.h   |  142 +
 .../ignite/odbc/query/table_metadata_query.h    |  150 +
 .../include/ignite/odbc/query/type_info_query.h |  118 +
 .../cpp/odbc/include/ignite/odbc/result_page.h  |  101 +
 .../cpp/odbc/include/ignite/odbc/row.h          |  132 +
 .../cpp/odbc/include/ignite/odbc/statement.h    |  525 +++
 .../include/ignite/odbc/system/odbc_constants.h |   45 +
 .../include/ignite/odbc/system/socket_client.h  |   92 +
 .../cpp/odbc/include/ignite/odbc/type_traits.h  |  316 ++
 .../cpp/odbc/include/ignite/odbc/utility.h      |  180 +
 .../cpp/odbc/install/ignite-odbc-install.ini    |    5 +
 .../cpp/odbc/install/install_amd64.cmd          |   40 +
 .../platforms/cpp/odbc/install/install_x86.cmd  |   21 +
 .../odbc/os/linux/src/system/socket_client.cpp  |  120 +
 .../odbc/os/win/src/system/socket_client.cpp    |  133 +
 modules/platforms/cpp/odbc/project/README.TXT   |    1 +
 .../platforms/cpp/odbc/project/vs/README.TXT    |    1 +
 .../platforms/cpp/odbc/project/vs/module.def    |   69 +
 .../platforms/cpp/odbc/project/vs/odbc.vcxproj  |  238 ++
 .../cpp/odbc/project/vs/odbc.vcxproj.filters    |  234 ++
 .../odbc/src/app/application_data_buffer.cpp    | 1216 +++++++
 .../platforms/cpp/odbc/src/app/parameter.cpp    |  175 +
 modules/platforms/cpp/odbc/src/column.cpp       |  488 +++
 modules/platforms/cpp/odbc/src/common_types.cpp |  120 +
 .../cpp/odbc/src/config/configuration.cpp       |  251 ++
 .../cpp/odbc/src/config/connection_info.cpp     |  428 +++
 modules/platforms/cpp/odbc/src/connection.cpp   |  347 ++
 modules/platforms/cpp/odbc/src/cursor.cpp       |   82 +
 modules/platforms/cpp/odbc/src/decimal.cpp      |  135 +
 .../odbc/src/diagnostic/diagnosable_adapter.cpp |   51 +
 .../odbc/src/diagnostic/diagnostic_record.cpp   |  241 ++
 .../diagnostic/diagnostic_record_storage.cpp    |  242 ++
 modules/platforms/cpp/odbc/src/entry_points.cpp |  694 ++++
 modules/platforms/cpp/odbc/src/environment.cpp  |  172 +
 .../platforms/cpp/odbc/src/meta/column_meta.cpp |  274 ++
 .../platforms/cpp/odbc/src/meta/table_meta.cpp  |   50 +
 modules/platforms/cpp/odbc/src/odbc.cpp         | 1364 +++++++
 .../odbc/src/query/column_metadata_query.cpp    |  318 ++
 .../platforms/cpp/odbc/src/query/data_query.cpp |  278 ++
 .../cpp/odbc/src/query/foreign_keys_query.cpp   |  131 +
 .../cpp/odbc/src/query/primary_keys_query.cpp   |  210 ++
 .../odbc/src/query/special_columns_query.cpp    |  121 +
 .../cpp/odbc/src/query/table_metadata_query.cpp |  244 ++
 .../cpp/odbc/src/query/type_info_query.cpp      |  394 ++
 modules/platforms/cpp/odbc/src/result_page.cpp  |   58 +
 modules/platforms/cpp/odbc/src/row.cpp          |  120 +
 modules/platforms/cpp/odbc/src/statement.cpp    |  524 +++
 modules/platforms/cpp/odbc/src/type_traits.cpp  |  669 ++++
 modules/platforms/cpp/odbc/src/utility.cpp      |  130 +
 modules/platforms/cpp/project/vs/ignite.sln     |   69 +-
 modules/platforms/cpp/project/vs/ignite.slnrel  |   49 +-
 .../platforms/cpp/project/vs/ignite_x86.slnrel  |   49 +-
 .../Apache.Ignite.AspNet.csproj                 |   72 +
 .../Apache.Ignite.AspNet.nuspec                 |   57 +
 .../Apache.Ignite.AspNet.ruleset                |    9 +
 .../Apache.Ignite.AspNet.snk                    |  Bin 0 -> 596 bytes
 .../IgniteOutputCacheProvider.cs                |  220 ++
 .../Apache.Ignite.AspNet/IgniteWebUtils.cs      |   44 +
 .../Properties/AssemblyInfo.cs                  |   39 +
 .../Apache.Ignite.Benchmarks.csproj             |   36 +-
 .../Properties/AssemblyInfo.cs                  |    8 +-
 .../Apache.Ignite.Core.Tests.NuGet.csproj       |   57 +-
 .../Apache.Ignite.Core.Tests.NuGet.sln          |    6 +
 .../AspNetTest.cs                               |   73 +
 .../Apache.Ignite.Core.Tests.NuGet/CacheTest.cs |   37 +-
 .../Apache.Ignite.Core.Tests.NuGet/NuGet.config |    5 +-
 .../Properties/AssemblyInfo.cs                  |    8 +-
 .../SchemaTest.cs                               |   62 +
 .../install-package.cmd                         |    3 -
 .../install-package.ps1                         |   34 +
 .../packages.config                             |   26 +
 .../Apache.Ignite.Core.Tests.TestDll.csproj     |   32 +-
 .../Properties/AssemblyInfo.cs                  |    8 +-
 .../Apache.Ignite.Core.Tests.csproj             |  142 +-
 .../AspNet/IgniteOutputCacheProviderTest.cs     |  172 +
 .../Binary/BinaryBuilderSelfTest.cs             |   87 +-
 .../Binary/BinaryBuilderSelfTestFullFooter.cs   |   31 +
 .../Binary/BinaryCompactFooterInteropTest.cs    |  128 +
 .../Binary/BinarySelfTest.cs                    |  300 +-
 .../Binary/BinarySelfTestFullFooter.cs          |   35 +
 .../Binary/BinaryStringTest.cs                  |  120 +
 .../Cache/Affinity/AffinityFieldTest.cs         |  199 +
 .../Cache/Affinity/AffinityFunctionTest.cs      |  282 ++
 .../Cache/Affinity/AffinityTest.cs              |  138 +
 .../Cache/CacheAbstractTest.cs                  |   18 +
 .../Cache/CacheAffinityTest.cs                  |  139 -
 .../Cache/CacheConfigurationTest.cs             |  207 +-
 .../Cache/CacheNearTest.cs                      |  188 +
 .../Cache/CacheTestAsyncWrapper.cs              |   12 +
 .../Cache/Query/CacheLinqTest.cs                | 1270 +++++++
 .../Query/CacheQueriesCodeConfigurationTest.cs  |   16 +-
 .../Cache/Query/CacheQueriesTest.cs             |   13 +-
 .../Continuous/ContinuousQueryAbstractTest.cs   |   43 +-
 .../Continuous/ContinuousQueryJavaFilterTest.cs |  322 ++
 .../Cache/Store/CacheStoreTest.cs               |   46 +-
 .../Cache/Store/CacheStoreTestCodeConfig.cs     |  106 +
 .../Cache/Store/CacheTestStore.cs               |    2 +-
 .../Compute/AbstractTaskTest.cs                 |    9 +
 .../Compute/BinarizableTaskTest.cs              |   13 +-
 .../Compute/ComputeApiTest.cs                   |  131 +-
 .../Compute/ComputeApiTestFullFooter.cs         |   65 +
 .../Compute/FailoverTaskSelfTest.cs             |    2 +-
 .../Compute/IgniteExceptionTaskSelfTest.cs      |   18 +-
 .../Compute/MixedClusterTest.cs                 |  123 +-
 .../Compute/ResourceTaskTest.cs                 |    8 +-
 .../Compute/TaskAdapterTest.cs                  |   16 +-
 .../Compute/TaskResultTest.cs                   |   10 +-
 .../Config/Apache.Ignite.exe.config.test2       |   58 +
 .../Config/Apache.Ignite.exe.config.test3       |   34 +
 .../Config/Cache/Store/cache-store-session.xml  |    3 +-
 .../Config/Compute/compute-grid1.xml            |   23 +-
 .../Config/Compute/compute-grid2.xml            |    5 +-
 .../Config/Compute/compute-grid3.xml            |    7 +-
 .../Config/Compute/compute-standalone.xml       |    4 +-
 .../Config/Dynamic/dynamic-client.xml           |    3 +-
 .../Config/Dynamic/dynamic-data-no-cfg.xml      |    3 +-
 .../Config/Dynamic/dynamic-data.xml             |    3 +-
 .../Config/Lifecycle/lifecycle-beans.xml        |    3 +-
 .../Config/Lifecycle/lifecycle-no-beans.xml     |    3 +-
 .../Apache.Ignite.Core.Tests/Config/binary.xml  |   56 -
 .../Config/cache-binarizables.xml               |    3 +-
 .../Config/cache-local-node.xml                 |   66 +
 .../Config/cache-query-continuous.xml           |    4 +-
 .../Config/cache-query.xml                      |    5 +-
 .../Config/ignite-dotnet-cfg.xml                |   52 +
 .../Config/marshaller-default.xml               |    3 +-
 .../Config/marshaller-explicit.xml              |    3 +-
 .../Config/marshaller-invalid.xml               |    3 +-
 .../native-client-test-cache-affinity.xml       |    5 +-
 .../native-client-test-cache-parallel-store.xml |    3 +-
 .../Config/native-client-test-cache-store.xml   |    3 +-
 .../Config/native-client-test-cache.xml         |    3 +-
 .../Config/reconnect-test.xml                   |   43 +
 .../Config/spring-test.xml                      |   46 +
 .../Config/start-test-grid1.xml                 |    3 +-
 .../Config/start-test-grid2.xml                 |    3 +-
 .../Config/start-test-grid3.xml                 |    3 +-
 .../Dataload/DataStreamerTestTopologyChange.cs  |  104 +
 .../Apache.Ignite.Core.Tests/DeploymentTest.cs  |  179 +
 .../Apache.Ignite.Core.Tests/EventsTest.cs      |    8 +-
 .../Examples/ExamplesTest.cs                    |    3 +-
 .../Examples/ProjectFilesTest.cs                |    2 +-
 .../Apache.Ignite.Core.Tests/ExceptionsTest.cs  |    5 +
 .../Apache.Ignite.Core.Tests/ExecutableTest.cs  |   88 +-
 .../IgniteConfigurationSerializerTest.cs        |  160 +-
 .../IgniteConfigurationTest.cs                  |  144 +-
 .../IgniteStartStopTest.cs                      |    1 -
 .../Apache.Ignite.Core.Tests/JavaHomeTest.cs    |   69 +
 .../Apache.Ignite.Core.Tests/LifecycleTest.cs   |    9 +
 .../Process/IgniteProcess.cs                    |   15 +-
 .../ProjectFilesTest.cs                         |    8 +-
 .../Properties/AssemblyInfo.cs                  |    8 +-
 .../Apache.Ignite.Core.Tests/ReconnectTest.cs   |   15 +-
 .../Services/ServiceProxyTest.cs                |    6 +-
 .../Services/ServicesTest.cs                    |  292 +-
 .../Services/ServicesTestFullFooter.cs          |   33 +
 .../Apache.Ignite.Core.Tests/TestRunner.cs      |   26 +-
 .../Apache.Ignite.Core.Tests/TestUtils.cs       |   18 +-
 .../WindowsServiceTest.cs                       |  124 +
 .../dotnet/Apache.Ignite.Core.Tests/app.config  |   10 +-
 .../Apache.Ignite.Core.Schema.nuspec            |   53 +
 .../Apache.Ignite.Core.csproj                   |  108 +-
 .../Apache.Ignite.Core.nuspec                   |   17 +-
 .../Binary/BinaryConfiguration.cs               |   44 +-
 .../Binary/BinaryReflectiveSerializer.cs        |  193 +-
 .../Binary/UserSerializerProxy.cs               |   68 +
 .../Cache/Affinity/AffinityFunctionBase.cs      |  190 +
 .../Cache/Affinity/AffinityFunctionContext.cs   |  116 +
 .../Cache/Affinity/AffinityKey.cs               |  162 +
 .../Affinity/AffinityKeyMappedAttribute.cs      |   46 +
 .../Cache/Affinity/AffinityTopologyVersion.cs   |  138 +
 .../Cache/Affinity/Fair/FairAffinityFunction.cs |   28 +
 .../Cache/Affinity/IAffinityFunction.cs         |   82 +
 .../Rendezvous/RendezvousAffinityFunction.cs    |   27 +
 .../Cache/Configuration/CacheConfiguration.cs   |   79 +-
 .../Configuration/NearCacheConfiguration.cs     |   75 +
 .../Cache/Configuration/QueryEntity.cs          |   13 +-
 .../Cache/Configuration/QueryField.cs           |    2 +-
 .../Cache/Eviction/EvictionPolicyBase.cs        |  126 +
 .../Cache/Eviction/FifoEvictionPolicy.cs        |   39 +
 .../Cache/Eviction/IEvictionPolicy.cs           |   32 +
 .../Cache/Eviction/LruEvictionPolicy.cs         |   39 +
 .../dotnet/Apache.Ignite.Core/Cache/ICache.cs   |   26 +
 .../Continuous/ContinuousQueryExtensions.cs     |   42 +
 .../Apache.Ignite.Core/Cluster/IClusterGroup.cs |    6 +
 .../Communication/ICommunicationSpi.cs          |   37 +
 .../Communication/Tcp/TcpCommunicationSpi.cs    |  283 ++
 .../Configuration/AtomicConfiguration.cs        |   67 +
 .../Discovery/Tcp/TcpDiscoverySpi.cs            |  161 +
 .../Apache.Ignite.Core/Events/CacheEvent.cs     |    9 +-
 .../Apache.Ignite.Core/Events/EventBase.cs      |    2 +-
 .../Apache.Ignite.Core/Events/EventReader.cs    |    8 +-
 .../dotnet/Apache.Ignite.Core/IIgnite.cs        |   75 +
 .../Apache.Ignite.Core/IgniteConfiguration.cs   |  352 +-
 .../IgniteConfigurationSection.xsd              |  102 +-
 .../dotnet/Apache.Ignite.Core/Ignition.cs       |   28 +-
 .../Impl/Binary/BinarizableSerializer.cs        |   22 +-
 .../Apache.Ignite.Core/Impl/Binary/Binary.cs    |    8 +-
 .../Impl/Binary/BinaryFullTypeDescriptor.cs     |    8 +-
 .../Impl/Binary/BinaryHandleDictionary.cs       |   32 +-
 .../Impl/Binary/BinaryObject.cs                 |    9 +-
 .../Impl/Binary/BinaryObjectBuilder.cs          |    9 +-
 .../Impl/Binary/BinaryObjectHeader.cs           |  176 +-
 .../Impl/Binary/BinaryObjectSchema.cs           |   20 +
 .../Impl/Binary/BinaryObjectSchemaHolder.cs     |   18 +-
 .../Impl/Binary/BinaryObjectSchemaSerializer.cs |  262 ++
 .../Impl/Binary/BinaryReader.cs                 |  145 +-
 .../Impl/Binary/BinaryReaderExtensions.cs       |   24 +
 .../Impl/Binary/BinaryReaderHandleDictionary.cs |    2 +-
 .../Impl/Binary/BinaryReflectiveActions.cs      |   43 +
 .../BinaryReflectiveSerializerInternal.cs       |  169 +
 .../Binary/BinarySurrogateTypeDescriptor.cs     |    4 +-
 .../Impl/Binary/BinarySystemHandlers.cs         |  147 +-
 .../Impl/Binary/BinarySystemTypeSerializer.cs   |   20 +-
 .../Impl/Binary/BinaryUtils.cs                  |  192 +-
 .../Impl/Binary/BinaryWriter.cs                 |   46 +-
 .../Impl/Binary/BinaryWriterExtensions.cs       |   78 +
 .../Impl/Binary/DateTimeSerializer.cs           |   48 +
 .../Impl/Binary/IBinarySerializerInternal.cs    |   42 +
 .../Impl/Binary/IBinarySystemTypeSerializer.cs  |   34 -
 .../Impl/Binary/IBinaryTypeDescriptor.cs        |    2 +-
 .../Impl/Binary/Io/BinaryHeapStream.cs          |    2 +-
 .../Impl/Binary/Io/BinaryStreamBase.cs          |   14 -
 .../Apache.Ignite.Core/Impl/Binary/JavaTypes.cs |   29 +-
 .../Impl/Binary/Marshaller.cs                   |  112 +-
 .../Impl/Binary/Metadata/BinaryType.cs          |   28 +-
 .../Impl/Binary/ReferenceEqualityComparer.cs    |   45 +
 .../Impl/Binary/SerializableSerializer.cs       |   48 +
 .../Apache.Ignite.Core/Impl/Cache/CacheEntry.cs |    2 +-
 .../Apache.Ignite.Core/Impl/Cache/CacheImpl.cs  |   54 +-
 .../Apache.Ignite.Core/Impl/Cache/CacheOp.cs    |    3 +-
 .../Cache/Event/JavaCacheEntryEventFilter.cs    |   49 +
 .../Impl/Cache/ICacheInternal.cs                |   40 +
 .../Continuous/ContinuousQueryHandleImpl.cs     |   17 +-
 .../Impl/Cache/Query/FieldsQueryCursor.cs       |   26 +-
 .../Impl/Cluster/ClusterGroupImpl.cs            |   21 +
 .../Impl/Cluster/ClusterNodeImpl.cs             |    2 +-
 .../Apache.Ignite.Core/Impl/Common/Classpath.cs |   18 +-
 .../Impl/Common/DelegateConverter.cs            |  175 +-
 .../Common/IgniteConfigurationXmlSerializer.cs  |   67 +-
 .../Impl/Common/IgniteHome.cs                   |    2 +-
 .../Apache.Ignite.Core/Impl/Common/Logger.cs    |   37 +
 .../Impl/Common/ObjectStringConverter.cs        |  104 +
 .../Apache.Ignite.Core/Impl/Common/Platform.cs  |   35 +
 .../Common/PlatformJavaObjectFactoryProxy.cs    |  106 +
 .../Impl/Common/TypeCaster.cs                   |   12 +
 .../Impl/Datastream/DataStreamerImpl.cs         |    9 +-
 .../Apache.Ignite.Core/Impl/ExceptionUtils.cs   |    2 +-
 .../dotnet/Apache.Ignite.Core/Impl/Ignite.cs    |  152 +-
 .../Apache.Ignite.Core/Impl/IgniteManager.cs    |   19 +-
 .../Apache.Ignite.Core/Impl/IgniteProxy.cs      |   75 +-
 .../Apache.Ignite.Core/Impl/IgniteUtils.cs      |   69 +-
 .../Impl/LifecycleBeanHolder.cs                 |    2 +-
 .../Impl/Memory/PlatformMemoryStream.cs         |    3 +-
 .../Apache.Ignite.Core/Impl/NativeMethods.cs    |    6 +
 .../Apache.Ignite.Core/Impl/PlatformTarget.cs   |   47 +-
 .../Impl/Services/ServiceDescriptor.cs          |    7 +-
 .../Impl/Services/ServiceProxyInvoker.cs        |   33 +-
 .../Impl/Services/ServiceProxySerializer.cs     |   63 +-
 .../Impl/Services/Services.cs                   |   13 +-
 .../Impl/Unmanaged/IgniteJniNativeMethods.cs    |   12 +
 .../Impl/Unmanaged/UnmanagedCallbackHandlers.cs |    6 +
 .../Impl/Unmanaged/UnmanagedCallbacks.cs        |  126 +-
 .../Impl/Unmanaged/UnmanagedUtils.cs            |   50 +-
 .../Apache.Ignite.Core/Interop/JavaObject.cs    |   80 +
 .../Lifecycle/ClientReconnectEventArgs.cs       |   47 +
 .../NuGet/LINQPad/ComputeExample.linq           |    8 +-
 .../NuGet/LINQPad/PutGetExample.linq            |    8 +-
 .../NuGet/LINQPad/QueryExample.linq             |    8 +-
 .../Properties/AssemblyInfo.cs                  |   10 +-
 .../Transactions/ITransaction.cs                |    3 +-
 .../Transactions/TransactionConfiguration.cs    |   88 +
 .../dotnet/Apache.Ignite.Core/build-common.ps1  |   77 +
 .../powershell.exe.activation_config            |   29 +
 modules/platforms/dotnet/Apache.Ignite.FxCop    |    4 +-
 .../Apache.Ignite.Linq.csproj                   |   93 +
 .../Apache.Ignite.Linq.nuspec                   |   64 +
 .../Apache.Ignite.Linq/Apache.Ignite.Linq.snk   |  Bin 0 -> 596 bytes
 .../Apache.Ignite.Linq/CacheExtensions.cs       |   98 +
 .../dotnet/Apache.Ignite.Linq/CompiledQuery.cs  |  208 ++
 .../Apache.Ignite.Linq/ICacheQueryable.cs       |   53 +
 .../Apache.Ignite.Linq/Impl/AliasDictionary.cs  |  102 +
 .../Impl/CacheFieldsQueryExecutor.cs            |  223 ++
 .../Impl/CacheFieldsQueryProvider.cs            |  239 ++
 .../Impl/CacheFieldsQueryable.cs                |   40 +
 .../Impl/CacheQueryExpressionVisitor.cs         |  506 +++
 .../Impl/CacheQueryModelVisitor.cs              |  509 +++
 .../Apache.Ignite.Linq/Impl/CacheQueryParser.cs |   56 +
 .../Apache.Ignite.Linq/Impl/CacheQueryable.cs   |   43 +
 .../Impl/CacheQueryableBase.cs                  |  122 +
 .../Apache.Ignite.Linq/Impl/ExpressionWalker.cs |  172 +
 .../Apache.Ignite.Linq/Impl/ICacheQueryProxy.cs |   40 +
 .../Impl/ICacheQueryableInternal.cs             |   54 +
 .../Apache.Ignite.Linq/Impl/MethodVisitor.cs    |  250 ++
 .../dotnet/Apache.Ignite.Linq/Impl/QueryData.cs |   92 +
 .../dotnet/Apache.Ignite.Linq/Impl/SqlTypes.cs  |   63 +
 .../NuGet/LINQPad/QueryExample.linq             |  111 +
 .../Properties/AssemblyInfo.cs                  |   40 +
 .../dotnet/Apache.Ignite.Linq/packages.config   |   22 +
 modules/platforms/dotnet/Apache.Ignite.sln      |  176 +-
 .../dotnet/Apache.Ignite.sln.DotSettings        |    7 +-
 .../dotnet/Apache.Ignite/Apache.Ignite.csproj   |   40 +-
 .../Config/AppSettingsConfigurator.cs           |   97 +-
 .../Apache.Ignite/Config/ArgsConfigurator.cs    |  145 +-
 .../dotnet/Apache.Ignite/Config/Configurator.cs |  173 +
 .../Apache.Ignite/Config/IConfigurator.cs       |   34 -
 .../dotnet/Apache.Ignite/IgniteRunner.cs        |   24 +-
 .../Apache.Ignite/Properties/AssemblyInfo.cs    |    8 +-
 .../Apache.Ignite/Service/IgniteService.cs      |  113 +-
 .../Service/IgniteServiceInstaller.cs           |   64 +
 .../Apache.Ignite/Service/NativeMethods.cs      |   57 -
 modules/platforms/dotnet/DEVNOTES.txt           |    7 +-
 modules/platforms/dotnet/build.bat              |   94 -
 .../dotnet/examples/Apache.Ignite.Examples.sln  |   24 +-
 .../Apache.Ignite.Examples.csproj               |   49 +-
 .../Compute/ClosureExample.cs                   |   10 +-
 .../Compute/TaskExample.cs                      |   13 +-
 .../Datagrid/ContinuousQueryExample.cs          |   15 +-
 .../Datagrid/DataStreamerExample.cs             |   16 +-
 .../Datagrid/LinqExample.cs                     |  247 ++
 .../Datagrid/PutGetExample.cs                   |   15 +-
 .../Datagrid/QueryExample.cs                    |   29 +-
 .../Datagrid/StoreExample.cs                    |   25 +-
 .../Datagrid/TransactionExample.cs              |   24 +-
 .../Events/EventsExample.cs                     |   14 +-
 .../Messaging/MessagingExample.cs               |   11 +-
 .../Misc/LifecycleExample.cs                    |    3 +-
 .../Properties/AssemblyInfo.cs                  |    8 +-
 .../Services/ServicesExample.cs                 |   11 +-
 .../Apache.Ignite.ExamplesDll.csproj            |   43 +-
 .../Apache.Ignite.ExamplesDll/Binary/Account.cs |    1 -
 .../Apache.Ignite.ExamplesDll/Binary/Address.cs |    5 +-
 .../Binary/Employee.cs                          |    4 +
 .../Binary/EmployeeKey.cs                       |    6 +-
 .../Binary/Organization.cs                      |   11 +-
 .../Binary/OrganizationType.cs                  |    3 -
 .../Datagrid/EmployeeStoreFactory.cs            |   38 +
 .../Properties/AssemblyInfo.cs                  |    8 +-
 .../examples/Config/example-cache-query.xml     |  118 -
 .../examples/Config/example-cache-store.xml     |   59 -
 .../dotnet/examples/Config/example-cache.xml    |   87 -
 .../dotnet/examples/Config/example-compute.xml  |   70 -
 .../dotnet/examples/Config/examples-config.xml  |   98 +
 modules/rest-http/pom.xml                       |   27 +-
 .../http/jetty/GridJettyJsonConfig.java         |  195 -
 .../http/jetty/GridJettyObjectMapper.java       |  274 ++
 .../http/jetty/GridJettyRestHandler.java        |  127 +-
 .../http/jetty/GridJettyRestProtocol.java       |    6 +-
 modules/scalar-2.10/pom.xml                     |    2 +-
 modules/scalar/pom.xml                          |    2 +-
 .../scalar/pimps/ScalarProjectionPimp.scala     |    4 +-
 .../scalar/pimps/ScalarTaskThreadContext.scala  |    4 +-
 modules/schedule/pom.xml                        |    2 +-
 modules/schema-import-db/README.txt             |    4 +
 modules/schema-import-db/pom.xml                |   43 +
 .../apache/ignite/schema/parser/DbColumn.java   |   76 +
 .../ignite/schema/parser/DbMetadataReader.java  |  147 +
 .../apache/ignite/schema/parser/DbTable.java    |   82 +
 .../parser/dialect/DB2MetadataDialect.java      |   33 +
 .../parser/dialect/DatabaseMetadataDialect.java |   75 +
 .../parser/dialect/JdbcMetadataDialect.java     |  197 +
 .../parser/dialect/MySQLMetadataDialect.java    |   62 +
 .../parser/dialect/OracleMetadataDialect.java   |  364 ++
 modules/schema-import/README.txt                |   12 +-
 modules/schema-import/pom.xml                   |    8 +-
 .../ignite/schema/generator/CodeGenerator.java  |  134 +-
 .../ignite/schema/generator/GeneratorUtils.java |   70 +
 .../ignite/schema/generator/XmlGenerator.java   |  107 +-
 .../schema/parser/DatabaseMetadataParser.java   |   50 +-
 .../apache/ignite/schema/parser/DbColumn.java   |   76 -
 .../apache/ignite/schema/parser/DbTable.java    |   82 -
 .../parser/dialect/DB2MetadataDialect.java      |   33 -
 .../parser/dialect/DatabaseMetadataDialect.java |   75 -
 .../parser/dialect/JdbcMetadataDialect.java     |  197 -
 .../parser/dialect/MySQLMetadataDialect.java    |   61 -
 .../parser/dialect/OracleMetadataDialect.java   |  364 --
 .../ignite/schema/ui/SchemaImportApp.java       |  548 ++-
 .../schema/test/AbstractSchemaImportTest.java   |   10 +-
 .../schema/test/generator/XmlGeneratorTest.java |    4 +-
 .../apache/ignite/schema/test/model/Objects.txt |   31 +-
 .../ignite/schema/test/model/Primitives.txt     |   31 +-
 .../org/apache/ignite/schema/test/model/Tst.txt |   31 +-
 .../schema/test/model/ignite-type-metadata.xml  |   86 +-
 .../test/parser/DbMetadataParserTest.java       |    2 +-
 modules/slf4j/pom.xml                           |    2 +-
 modules/spark-2.10/pom.xml                      |    2 +-
 modules/spark/pom.xml                           |    2 +-
 .../org/apache/ignite/spark/IgniteContext.scala |   77 +-
 .../org/apache/ignite/spark/IgniteRDD.scala     |  125 +-
 .../apache/ignite/spark/JavaIgniteContext.scala |   18 +-
 .../org/apache/ignite/spark/JavaIgniteRDD.scala |   17 +-
 .../ignite/spark/impl/IgniteAbstractRDD.scala   |   15 +-
 .../apache/ignite/spark/impl/IgniteSqlRDD.scala |    5 +-
 .../spark/impl/JavaIgniteAbstractRDD.scala      |   34 -
 .../spark/JavaEmbeddedIgniteRDDSelfTest.java    |  344 ++
 .../ignite/spark/JavaIgniteRDDSelfTest.java     |  302 --
 .../spark/JavaStandaloneIgniteRDDSelfTest.java  |  365 ++
 .../ignite/testsuites/IgniteRDDTestSuite.java   |   40 +
 .../ignite/spark/EntityTestAllTypeFields.scala  |   60 +
 .../org/apache/ignite/spark/IgniteRDDSpec.scala |  165 +-
 modules/spring/pom.xml                          |    2 +-
 .../org/apache/ignite/IgniteSpringBean.java     |  152 +-
 .../GridResourceSpringBeanInjector.java         |   39 +-
 .../src/test/config/jdbc-pojo-store-builtin.xml |  194 +
 .../src/test/config/jdbc-pojo-store-obj.xml     |  194 +
 .../store/jdbc/CachePojoStoreXmlSelfTest.java   |   51 +
 .../ignite/internal/GridFactorySelfTest.java    |  112 +-
 .../ignite/internal/IgniteSpringBeanTest.java   |   55 +
 .../GridSpringResourceInjectionSelfTest.java    |  311 +-
 .../spring-resource-with-duplicate-beans.xml    |   30 +
 .../processors/resource/spring-resource.xml     |    2 +-
 .../GridServiceInjectionSpringResourceTest.java |  245 ++
 .../spring/injection/spring-resource.tmpl.xml   |   66 +
 .../testsuites/IgniteSpringTestSuite.java       |    5 +
 modules/ssh/pom.xml                             |    2 +-
 modules/storm/pom.xml                           |    2 +-
 modules/tools/pom.xml                           |    2 +-
 modules/twitter/pom.xml                         |    2 +-
 modules/urideploy/pom.xml                       |    2 +-
 .../uri/GridUriDeploymentFileProcessor.java     |    2 +-
 modules/visor-console-2.10/pom.xml              |    2 +-
 modules/visor-console/pom.xml                   |    2 +-
 .../commands/alert/VisorAlertCommand.scala      |  359 +-
 .../commands/cache/VisorCacheCommand.scala      |   12 +-
 .../commands/disco/VisorDiscoveryCommand.scala  |    7 +-
 .../commands/events/VisorEventsCommand.scala    |    7 +-
 .../commands/tasks/VisorTasksCommand.scala      |    7 +-
 .../commands/top/VisorTopologyCommand.scala     |    2 +-
 .../scala/org/apache/ignite/visor/visor.scala   |   34 +-
 .../commands/alert/VisorAlertCommandSpec.scala  |    2 +-
 modules/visor-plugins/pom.xml                   |    2 +-
 modules/web-agent/.gitignore                    |    2 +
 modules/web-agent/README.txt                    |   88 +
 .../web-agent/assembly/release-web-agent.xml    |   72 +
 modules/web-agent/bin/ignite-web-agent.bat      |   70 +
 modules/web-agent/bin/ignite-web-agent.sh       |   87 +
 modules/web-agent/demo/README.txt               |    4 +
 modules/web-agent/demo/db-init.sql              |  102 +
 modules/web-agent/jdbc-drivers/README.txt       |   10 +
 modules/web-agent/logs/README.txt               |    5 +
 modules/web-agent/pom.xml                       |  189 +
 .../console/agent/AgentConfiguration.java       |  268 ++
 .../ignite/console/agent/AgentLauncher.java     |  344 ++
 .../apache/ignite/console/agent/AgentUtils.java |  111 +
 .../console/agent/handlers/AbstractHandler.java |  110 +
 .../console/agent/handlers/DatabaseHandler.java |  298 ++
 .../console/agent/handlers/RestHandler.java     |  276 ++
 .../ignite/console/demo/AgentClusterDemo.java   |  638 ++++
 .../ignite/console/demo/AgentMetadataDemo.java  |   92 +
 .../apache/ignite/console/demo/model/Car.java   |  152 +
 .../ignite/console/demo/model/Country.java      |  152 +
 .../ignite/console/demo/model/Department.java   |  152 +
 .../ignite/console/demo/model/Employee.java     |  356 ++
 .../ignite/console/demo/model/Parking.java      |  152 +
 .../src/main/resources/log4j.properties         |   53 +
 modules/web-console/DEVNOTES.txt                |   27 +
 modules/web-console/README.txt                  |   36 +
 modules/web-console/licenses/apache-2.0.txt     |  202 ++
 modules/web-console/pom.xml                     |   69 +
 modules/web-console/src/main/js/.babelrc        |    3 +
 modules/web-console/src/main/js/.eslintrc       |  202 ++
 modules/web-console/src/main/js/.gitignore      |   11 +
 .../src/main/js/app/data/colors.json            |   22 +
 .../src/main/js/app/data/countries.json         |   94 +
 .../src/main/js/app/data/demo-info.json         |   14 +
 .../src/main/js/app/data/event-types.json       |  169 +
 .../src/main/js/app/data/getting-started.json   |  109 +
 .../src/main/js/app/data/java-classes.json      |   18 +
 .../src/main/js/app/data/java-keywords.json     |   55 +
 .../src/main/js/app/data/java-primitives.json   |    9 +
 .../src/main/js/app/data/pom-dependencies.json  |   20 +
 .../src/main/js/app/decorator/select.js         |   77 +
 .../src/main/js/app/decorator/tooltip.js        |   56 +
 .../app/directives/bs-affix-update.directive.js |   34 +
 .../js/app/directives/centered/centered.css     |   37 +
 .../directives/centered/centered.directive.js   |   26 +
 .../hide-on-state-change.directive.js           |   31 +
 .../information/information.directive.js        |   30 +
 .../app/directives/information/information.jade |   20 +
 .../app/directives/information/information.scss |   56 +
 .../ui-ace-docker/ui-ace-docker.controller.js   |   33 +
 .../ui-ace-docker/ui-ace-docker.directive.js    |   46 +
 .../directives/ui-ace-docker/ui-ace-docker.jade |   31 +
 .../ui-ace-java/ui-ace-java.controller.js       |   32 +
 .../ui-ace-java/ui-ace-java.directive.js        |  133 +
 .../app/directives/ui-ace-java/ui-ace-java.jade |   22 +
 .../ui-ace-pojos/ui-ace-pojos.controller.js     |   95 +
 .../ui-ace-pojos/ui-ace-pojos.directive.js      |   46 +
 .../directives/ui-ace-pojos/ui-ace-pojos.jade   |   40 +
 .../ui-ace-pom/ui-ace-pom.controller.js         |   33 +
 .../ui-ace-pom/ui-ace-pom.directive.js          |   41 +
 .../app/directives/ui-ace-pom/ui-ace-pom.jade   |   17 +
 .../js/app/directives/ui-ace-tabs.directive.js  |   23 +
 .../ui-ace-xml/ui-ace-xml.controller.js         |   27 +
 .../ui-ace-xml/ui-ace-xml.directive.js          |  133 +
 .../app/directives/ui-ace-xml/ui-ace-xml.jade   |   17 +
 .../src/main/js/app/filters/byName.filter.js    |   23 +
 .../src/main/js/app/filters/hasPojo.filter.js   |   18 +
 .../src/main/js/app/helpers/jade/mixins.jade    |  588 +++
 modules/web-console/src/main/js/app/index.js    |  241 ++
 .../src/main/js/app/modules/Demo/Demo.module.js |  167 +
 .../js/app/modules/Version/Version.provider.js  |   32 +
 .../src/main/js/app/modules/ace.module.js       |  269 ++
 .../main/js/app/modules/agent/agent.module.js   |  323 ++
 .../js/app/modules/branding/branding.module.js  |   46 +
 .../app/modules/branding/branding.provider.js   |  111 +
 .../app/modules/branding/features.directive.js  |   35 +
 .../js/app/modules/branding/footer.directive.js |   34 +
 .../modules/branding/header-logo.directive.js   |   34 +
 .../js/app/modules/branding/header-logo.jade    |   18 +
 .../modules/branding/header-title.directive.js  |   35 +
 .../branding/powered-by-apache.directive.js     |   35 +
 .../app/modules/branding/powered-by-apache.jade |   18 +
 .../js/app/modules/branding/terms.directive.js  |   30 +
 .../configuration/EventGroups.provider.js       |   30 +
 .../modules/configuration/Sidebar.provider.js   |   39 +
 .../configuration/configuration.module.js       |   41 +
 .../configuration/generator/Docker.service.js   |   78 +
 .../configuration/generator/Java.service.js     |   21 +
 .../configuration/generator/Pom.service.js      |  210 ++
 .../configuration/generator/Xml.service.js      |   21 +
 .../modules/configuration/sidebar.directive.js  |   30 +
 .../modules/dialog/dialog-content.directive.js  |   31 +
 .../modules/dialog/dialog-title.directive.js    |   31 +
 .../js/app/modules/dialog/dialog.controller.js  |   40 +
 .../js/app/modules/dialog/dialog.directive.js   |   32 +
 .../js/app/modules/dialog/dialog.factory.js     |   32 +
 .../src/main/js/app/modules/dialog/dialog.jade  |   26 +
 .../main/js/app/modules/dialog/dialog.module.js |   32 +
 .../field/bs-select-placeholder.directive.js    |   46 +
 .../js/app/modules/form/field/down.directive.js |   43 +
 .../modules/form/field/dropdown.directive.js    |   84 +
 .../js/app/modules/form/field/dropdown.jade     |   61 +
 .../main/js/app/modules/form/field/field.css    |   23 +
 .../app/modules/form/field/field.directive.js   |   44 +
 .../main/js/app/modules/form/field/field.jade   |   27 +
 .../field/form-control-feedback.directive.js    |   40 +
 .../form/field/input/autofocus.directive.js     |   30 +
 .../form/field/input/checkbox.directive.js      |   67 +
 .../app/modules/form/field/input/checkbox.jade  |   30 +
 .../form/field/input/datalist.directive.js      |  123 +
 .../app/modules/form/field/input/datalist.jade  |   51 +
 .../form/field/input/number.directive.js        |   77 +
 .../js/app/modules/form/field/input/number.jade |   50 +
 .../js/app/modules/form/field/input/text.css    |   41 +
 .../modules/form/field/input/text.directive.js  |  127 +
 .../js/app/modules/form/field/input/text.jade   |   48 +
 .../app/modules/form/field/label.directive.js   |   47 +
 .../app/modules/form/field/tooltip.directive.js |   49 +
 .../js/app/modules/form/field/up.directive.js   |   44 +
 .../src/main/js/app/modules/form/form.module.js |  101 +
 .../js/app/modules/form/group/add.directive.js  |   40 +
 .../app/modules/form/group/group.directive.js   |   81 +
 .../main/js/app/modules/form/group/group.jade   |   21 +
 .../app/modules/form/group/table.directive.js   |   29 +
 .../main/js/app/modules/form/group/table.jade   |   17 +
 .../app/modules/form/group/tooltip.directive.js |   40 +
 .../app/modules/form/panel/chevron.directive.js |   53 +
 .../app/modules/form/panel/panel.directive.js   |   37 +
 .../app/modules/form/panel/revert.directive.js  |   53 +
 .../form/validator/ipaddress.directive.js       |   86 +
 .../validator/java-built-in-class.directive.js  |   31 +
 .../form/validator/java-identifier.directive.js |   31 +
 .../form/validator/java-keywords.directive.js   |   42 +
 .../validator/java-package-name.directive.js    |   31 +
 .../java-package-specified.directive.js         |   34 +
 .../form/validator/property-unique.directive.js |   47 +
 .../property-value-specified.directive.js       |   31 +
 .../modules/form/validator/unique.directive.js  |   49 +
 .../getting-started/GettingStarted.provider.js  |  112 +
 .../src/main/js/app/modules/loading/loading.css |   73 +
 .../js/app/modules/loading/loading.directive.js |   51 +
 .../main/js/app/modules/loading/loading.jade    |   23 +
 .../js/app/modules/loading/loading.module.js    |   26 +
 .../js/app/modules/loading/loading.service.js   |   48 +
 .../js/app/modules/navbar/Navbar.provider.js    |   28 +
 .../js/app/modules/navbar/Userbar.provider.js   |   28 +
 .../js/app/modules/navbar/navbar.directive.js   |   30 +
 .../main/js/app/modules/navbar/navbar.module.js |   33 +
 .../js/app/modules/navbar/userbar.directive.js  |   48 +
 .../query-notebooks/query-notebooks.module.js   |  115 +
 .../src/main/js/app/modules/socket.module.js    |   41 +
 .../main/js/app/modules/states/admin.state.js   |   34 +
 .../app/modules/states/configuration.state.js   |  226 ++
 .../caches/concurrency.directive.js             |   27 +
 .../configuration/caches/concurrency.jade       |   65 +
 .../configuration/caches/general.directive.js   |   27 +
 .../states/configuration/caches/general.jade    |   65 +
 .../configuration/caches/memory.directive.js    |   27 +
 .../states/configuration/caches/memory.jade     |   88 +
 .../configuration/caches/query.directive.js     |   27 +
 .../states/configuration/caches/query.jade      |   93 +
 .../configuration/caches/rebalance.directive.js |   27 +
 .../states/configuration/caches/rebalance.jade  |   65 +
 .../caches/server-near-cache.directive.js       |   27 +
 .../configuration/caches/server-near-cache.jade |   45 +
 .../caches/statistics.directive.js              |   27 +
 .../states/configuration/caches/statistics.jade |   37 +
 .../configuration/caches/store.directive.js     |   27 +
 .../states/configuration/caches/store.jade      |  271 ++
 .../configuration/clusters/atomic.directive.js  |   27 +
 .../states/configuration/clusters/atomic.jade   |   53 +
 .../clusters/attributes.directive.js            |   27 +
 .../configuration/clusters/attributes.jade      |   58 +
 .../configuration/clusters/binary.directive.js  |   27 +
 .../states/configuration/clusters/binary.jade   |  100 +
 .../clusters/collision.directive.js             |   27 +
 .../configuration/clusters/collision.jade       |   60 +
 .../clusters/collision/custom.directive.js      |   27 +
 .../clusters/collision/custom.jade              |   24 +
 .../clusters/collision/fifo-queue.directive.js  |   27 +
 .../clusters/collision/fifo-queue.jade          |   28 +
 .../collision/job-stealing.directive.js         |   27 +
 .../clusters/collision/job-stealing.jade        |   64 +
 .../collision/priority-queue.directive.js       |   27 +
 .../clusters/collision/priority-queue.jade      |   43 +
 .../clusters/communication.directive.js         |   27 +
 .../configuration/clusters/communication.jade   |   96 +
 .../clusters/connector.directive.js             |   27 +
 .../configuration/clusters/connector.jade       |  103 +
 .../clusters/deployment.directive.js            |   27 +
 .../configuration/clusters/deployment.jade      |  119 +
 .../clusters/discovery.directive.js             |   27 +
 .../configuration/clusters/discovery.jade       |   83 +
 .../configuration/clusters/events.directive.js  |   27 +
 .../states/configuration/clusters/events.jade   |   37 +
 .../clusters/failover.directive.js              |   27 +
 .../states/configuration/clusters/failover.jade |   82 +
 .../configuration/clusters/general.directive.js |   27 +
 .../states/configuration/clusters/general.jade  |   68 +
 .../general/discovery/cloud.directive.js        |   27 +
 .../clusters/general/discovery/cloud.jade       |  127 +
 .../general/discovery/google.directive.js       |   27 +
 .../clusters/general/discovery/google.jade      |   38 +
 .../general/discovery/jdbc.directive.js         |   27 +
 .../clusters/general/discovery/jdbc.jade        |   24 +
 .../general/discovery/multicast.directive.js    |   27 +
 .../clusters/general/discovery/multicast.jade   |  109 +
 .../clusters/general/discovery/s3.directive.js  |   27 +
 .../clusters/general/discovery/s3.jade          |   27 +
 .../general/discovery/shared.directive.js       |   27 +
 .../clusters/general/discovery/shared.jade      |   23 +
 .../clusters/general/discovery/vm.directive.js  |   27 +
 .../clusters/general/discovery/vm.jade          |   90 +
 .../general/discovery/zookeeper.directive.js    |   27 +
 .../clusters/general/discovery/zookeeper.jade   |   74 +
 .../bounded-exponential-backoff.directive.js    |   27 +
 .../bounded-exponential-backoff.jade            |   27 +
 .../zookeeper/retrypolicy/custom.directive.js   |   27 +
 .../discovery/zookeeper/retrypolicy/custom.jade |   24 +
 .../exponential-backoff.directive.js            |   27 +
 .../retrypolicy/exponential-backoff.jade        |   27 +
 .../zookeeper/retrypolicy/forever.directive.js  |   27 +
 .../zookeeper/retrypolicy/forever.jade          |   22 +
 .../zookeeper/retrypolicy/n-times.directive.js  |   27 +
 .../zookeeper/retrypolicy/n-times.jade          |   25 +
 .../zookeeper/retrypolicy/one-time.directive.js |   27 +
 .../zookeeper/retrypolicy/one-time.jade         |   23 +
 .../retrypolicy/until-elapsed.directive.js      |   27 +
 .../zookeeper/retrypolicy/until-elapsed.jade    |   25 +
 .../configuration/clusters/igfs.directive.js    |   27 +
 .../states/configuration/clusters/igfs.jade     |   37 +
 .../configuration/clusters/logger.directive.js  |   27 +
 .../states/configuration/clusters/logger.jade   |   65 +
 .../clusters/logger/custom.directive.js         |   27 +
 .../configuration/clusters/logger/custom.jade   |   24 +
 .../clusters/logger/log4j.directive.js          |   27 +
 .../configuration/clusters/logger/log4j.jade    |   49 +
 .../clusters/logger/log4j2.directive.js         |   27 +
 .../configuration/clusters/logger/log4j2.jade   |   38 +
 .../clusters/marshaller.directive.js            |   27 +
 .../configuration/clusters/marshaller.jade      |   69 +
 .../configuration/clusters/metrics.directive.js |   27 +
 .../states/configuration/clusters/metrics.jade  |   50 +
 .../configuration/clusters/ssl.directive.js     |   27 +
 .../states/configuration/clusters/ssl.jade      |  108 +
 .../configuration/clusters/swap.directive.js    |   27 +
 .../states/configuration/clusters/swap.jade     |   67 +
 .../configuration/clusters/thread.directive.js  |   27 +
 .../states/configuration/clusters/thread.jade   |   48 +
 .../configuration/clusters/time.directive.js    |   27 +
 .../states/configuration/clusters/time.jade     |   47 +
 .../clusters/transactions.directive.js          |   27 +
 .../configuration/clusters/transactions.jade    |   59 +
 .../configuration/domains/general.directive.js  |   27 +
 .../states/configuration/domains/general.jade   |   46 +
 .../configuration/domains/query.directive.js    |   27 +
 .../states/configuration/domains/query.jade     |  169 +
 .../configuration/domains/store.directive.js    |   27 +
 .../states/configuration/domains/store.jade     |  126 +
 .../states/configuration/igfs/dual.directive.js |   27 +
 .../modules/states/configuration/igfs/dual.jade |   42 +
 .../igfs/fragmentizer.directive.js              |   27 +
 .../states/configuration/igfs/fragmentizer.jade |   43 +
 .../configuration/igfs/general.directive.js     |   27 +
 .../states/configuration/igfs/general.jade      |   53 +
 .../states/configuration/igfs/ipc.directive.js  |   27 +
 .../modules/states/configuration/igfs/ipc.jade  |   57 +
 .../states/configuration/igfs/misc.directive.js |   27 +
 .../modules/states/configuration/igfs/misc.jade |  108 +
 .../configuration/igfs/secondary.directive.js   |   27 +
 .../states/configuration/igfs/secondary.jade    |   44 +
 .../configuration/preview-panel.directive.js    |  239 ++
 .../summary/summary-tabs.directive.js           |   50 +
 .../configuration/summary/summary.controller.js |  360 ++
 .../configuration/summary/summary.resource.js   |   40 +
 .../main/js/app/modules/states/logout.state.js  |   36 +
 .../js/app/modules/states/password.state.js     |   46 +
 .../main/js/app/modules/states/profile.state.js |   34 +
 .../main/js/app/modules/states/signin.state.js  |   52 +
 .../src/main/js/app/modules/states/sql.state.js |   46 +
 .../main/js/app/modules/user/Auth.service.js    |   76 +
 .../main/js/app/modules/user/User.service.js    |   65 +
 .../src/main/js/app/modules/user/user.module.js |   28 +
 .../main/js/app/services/ChartColors.service.js |   22 +
 .../main/js/app/services/Countries.service.js   |   31 +
 .../main/js/app/services/InetAddress.service.js |   53 +
 .../main/js/app/services/JavaTypes.service.js   |   84 +
 .../src/main/js/app/services/cleanup.service.js |   46 +
 .../src/main/js/app/services/confirm.service.js |   70 +
 .../src/main/js/build/system.config.js          |  424 +++
 .../src/main/js/controllers/admin-controller.js |   92 +
 .../main/js/controllers/caches-controller.js    |  477 +++
 .../main/js/controllers/clusters-controller.js  |  634 ++++
 .../src/main/js/controllers/common-module.js    | 1741 +++++++++
 .../main/js/controllers/domains-controller.js   | 1761 +++++++++
 .../src/main/js/controllers/igfs-controller.js  |  413 +++
 .../main/js/controllers/profile-controller.js   |   92 +
 .../src/main/js/controllers/sql-controller.js   | 1595 ++++++++
 .../src/main/js/generator/generator-common.js   |  611 ++++
 .../src/main/js/generator/generator-java.js     | 3403 ++++++++++++++++++
 .../src/main/js/generator/generator-optional.js |   25 +
 .../main/js/generator/generator-properties.js   |  150 +
 .../src/main/js/generator/generator-readme.js   |   85 +
 .../src/main/js/generator/generator-xml.js      | 1979 ++++++++++
 .../src/main/js/gulpfile.babel.js/index.js      |   26 +
 .../src/main/js/gulpfile.babel.js/paths.js      |  101 +
 .../main/js/gulpfile.babel.js/tasks/build.js    |   21 +
 .../main/js/gulpfile.babel.js/tasks/bundle.js   |   76 +
 .../main/js/gulpfile.babel.js/tasks/clean.js    |   35 +
 .../main/js/gulpfile.babel.js/tasks/connect.js  |   47 +
 .../src/main/js/gulpfile.babel.js/tasks/copy.js |   57 +
 .../main/js/gulpfile.babel.js/tasks/eslint.js   |   46 +
 .../gulpfile.babel.js/tasks/ignite-modules.js   |   56 +
 .../src/main/js/gulpfile.babel.js/tasks/jade.js |   40 +
 .../src/main/js/gulpfile.babel.js/tasks/sass.js |   25 +
 .../main/js/gulpfile.babel.js/tasks/watch.js    |   39 +
 .../src/main/js/ignite_modules/README.txt       |    6 +
 .../src/main/js/ignite_modules/index.js         |   27 +
 modules/web-console/src/main/js/package.json    |  271 ++
 .../web-console/src/main/js/public/favicon.ico  |  Bin 0 -> 1150 bytes
 .../src/main/js/public/images/cache.png         |  Bin 0 -> 23700 bytes
 .../src/main/js/public/images/cluster.png       |  Bin 0 -> 29376 bytes
 .../src/main/js/public/images/docker.png        |  Bin 0 -> 521 bytes
 .../src/main/js/public/images/domains.png       |  Bin 0 -> 23828 bytes
 .../src/main/js/public/images/igfs.png          |  Bin 0 -> 14307 bytes
 .../src/main/js/public/images/ignite-logo.png   |  Bin 0 -> 1982 bytes
 .../main/js/public/images/ignite-logo@2x.png    |  Bin 0 -> 3325 bytes
 .../src/main/js/public/images/ignite-puzzle.png |  Bin 0 -> 71974 bytes
 .../src/main/js/public/images/java.png          |  Bin 0 -> 170 bytes
 .../src/main/js/public/images/pb-ignite.png     |  Bin 0 -> 3493 bytes
 .../src/main/js/public/images/pb-ignite@2x.png  |  Bin 0 -> 8558 bytes
 .../src/main/js/public/images/query-chart.png   |  Bin 0 -> 16637 bytes
 .../main/js/public/images/query-metadata.png    |  Bin 0 -> 32298 bytes
 .../src/main/js/public/images/query-table.png   |  Bin 0 -> 29189 bytes
 .../src/main/js/public/images/summary.png       |  Bin 0 -> 31997 bytes
 .../src/main/js/public/images/xml.png           |  Bin 0 -> 232 bytes
 .../public/stylesheets/_bootstrap-custom.scss   |   65 +
 .../stylesheets/_bootstrap-variables.scss       |  891 +++++
 .../stylesheets/_font-awesome-custom.scss       |   31 +
 .../src/main/js/public/stylesheets/style.scss   | 2156 +++++++++++
 .../main/js/public/stylesheets/variables.scss   |   28 +
 modules/web-console/src/main/js/serve.js        |  116 +
 modules/web-console/src/main/js/serve/agent.js  |  713 ++++
 .../src/main/js/serve/agent_dists/README.txt    |    7 +
 modules/web-console/src/main/js/serve/app.js    |   42 +
 .../web-console/src/main/js/serve/browser.js    |  378 ++
 .../main/js/serve/config/settings.json.sample   |   26 +
 .../web-console/src/main/js/serve/configure.js  |   84 +
 .../web-console/src/main/js/serve/keys/test.crt |   13 +
 .../web-console/src/main/js/serve/keys/test.key |   18 +
 modules/web-console/src/main/js/serve/mail.js   |   75 +
 modules/web-console/src/main/js/serve/mongo.js  |  676 ++++
 .../src/main/js/serve/routes/admin.js           |  126 +
 .../src/main/js/serve/routes/agent.js           |   81 +
 .../src/main/js/serve/routes/caches.js          |  132 +
 .../src/main/js/serve/routes/clusters.js        |  146 +
 .../src/main/js/serve/routes/demo.js            |  135 +
 .../src/main/js/serve/routes/demo/caches.json   |   87 +
 .../src/main/js/serve/routes/demo/clusters.json |   50 +
 .../src/main/js/serve/routes/demo/domains.json  |  307 ++
 .../src/main/js/serve/routes/demo/igfss.json    |   10 +
 .../src/main/js/serve/routes/domains.js         |  195 +
 .../src/main/js/serve/routes/igfs.js            |  122 +
 .../src/main/js/serve/routes/notebooks.js       |  121 +
 .../src/main/js/serve/routes/profile.js         |  102 +
 .../src/main/js/serve/routes/public.js          |  235 ++
 .../src/main/js/serve/routes/routes.js          |  103 +
 .../web-console/src/main/js/serve/settings.js   |   84 +
 modules/web-console/src/main/js/views/base.jade |   22 +
 .../src/main/js/views/configuration/caches.jade |   52 +
 .../main/js/views/configuration/clusters.jade   |   64 +
 .../js/views/configuration/domains-import.jade  |  211 ++
 .../main/js/views/configuration/domains.jade    |   66 +
 .../src/main/js/views/configuration/igfs.jade   |   51 +
 .../main/js/views/configuration/sidebar.jade    |   29 +
 .../summary-project-structure.jade              |   27 +
 .../js/views/configuration/summary-tabs.jade    |   25 +
 .../main/js/views/configuration/summary.jade    |  152 +
 .../src/main/js/views/includes/footer.jade      |   23 +
 .../src/main/js/views/includes/header.jade      |   48 +
 .../web-console/src/main/js/views/index.jade    |   66 +
 .../web-console/src/main/js/views/reset.jade    |   48 +
 .../src/main/js/views/settings/admin.jade       |   76 +
 .../src/main/js/views/settings/profile.jade     |   76 +
 .../web-console/src/main/js/views/signin.jade   |  163 +
 .../src/main/js/views/sql/cache-metadata.jade   |   40 +
 .../src/main/js/views/sql/chart-settings.jade   |   40 +
 .../src/main/js/views/sql/notebook-new.jade     |   31 +
 .../src/main/js/views/sql/paragraph-rate.jade   |   31 +
 .../web-console/src/main/js/views/sql/sql.jade  |  201 ++
 .../main/js/views/templates/agent-download.jade |   48 +
 .../src/main/js/views/templates/alert.jade      |   21 +
 .../main/js/views/templates/batch-confirm.jade  |   32 +
 .../src/main/js/views/templates/clone.jade      |   31 +
 .../src/main/js/views/templates/confirm.jade    |   31 +
 .../src/main/js/views/templates/demo-info.jade  |   45 +
 .../src/main/js/views/templates/dropdown.jade   |   21 +
 .../js/views/templates/getting-started.jade     |   32 +
 .../src/main/js/views/templates/message.jade    |   26 +
 .../src/main/js/views/templates/pagination.jade |   32 +
 .../src/main/js/views/templates/select.jade     |   26 +
 .../js/views/templates/validation-error.jade    |   25 +
 modules/web-console/src/test/js/routes/agent.js |   94 +
 modules/web/ignite-appserver-test/pom.xml       |   75 +
 .../webapp/META-INF/config/default-config.xml   |   37 +
 .../src/main/webapp/WEB-INF/web.xml             |   52 +
 .../src/main/webapp/index.jsp                   |   36 +
 modules/web/ignite-websphere-test/pom.xml       |   69 +
 .../apache/ignite/webtest/TestJtaTxServlet.java |  106 +
 .../webapp/META-INF/config/default-config.xml   |   70 +
 .../src/main/webapp/WEB-INF/web.xml             |   62 +
 .../src/main/webapp/index.jsp                   |   36 +
 modules/web/pom.xml                             |    2 +-
 .../ignite/cache/websession/WebSession.java     |  105 +-
 .../cache/websession/WebSessionFilter.java      |  746 +++-
 .../cache/websession/WebSessionListener.java    |  133 +-
 .../ignite/cache/websession/WebSessionV2.java   |  403 +++
 .../IgniteWebSessionSelfTestSuite.java          |   45 +
 .../internal/websession/WebSessionSelfTest.java |  940 ++++-
 .../webapp2/META-INF/ignite-webapp-config.xml   |  279 ++
 modules/web/src/test/webapp2/WEB-INF/web.xml    |   45 +
 .../config/benchmark-cache-load-win.properties  |   60 +
 .../config/benchmark-cache-load.properties      |   92 +
 .../yardstick/config/benchmark-full.properties  |  116 +
 .../config/ignite-base-load-config.xml          |  255 ++
 .../config/ignite-cache-load-config.xml         |   71 +
 modules/yardstick/config/queries.sql            |    2 +
 modules/yardstick/pom.xml                       |    2 +-
 .../yardstick/IgniteBenchmarkArguments.java     |   39 +-
 .../cache/CacheEntryEventAsyncProbe.java        |   61 +
 .../yardstick/cache/CacheEntryEventProbe.java   |   33 +-
 .../cache/IgniteCacheAbstractBenchmark.java     |    5 +
 .../IgniteCacheRandomOperationBenchmark.java    | 1160 ++++++
 .../yardstick/cache/load/model/ModelUtil.java   |  181 +
 .../cache/load/model/key/Identifier.java        |  113 +
 .../yardstick/cache/load/model/key/Mark.java    |  115 +
 .../yardstick/cache/load/model/value/Car.java   |  126 +
 .../yardstick/cache/load/model/value/Color.java |   50 +
 .../yardstick/cache/load/model/value/Truck.java |   69 +
 .../ignite/yardstick/cache/model/Account.java   |    6 +
 .../ignite/yardstick/cache/model/Person1.java   |    2 +-
 .../ignite/yardstick/cache/model/Person2.java   |    2 +-
 .../ignite/yardstick/cache/model/SampleKey.java |    2 +-
 .../yardstick/cache/model/SampleValue.java      |    2 +-
 modules/yarn/pom.xml                            |    2 +-
 modules/zookeeper/pom.xml                       |    5 +-
 .../zk/TcpDiscoveryZookeeperIpFinder.java       |   84 +-
 .../tcp/ipfinder/zk/ZookeeperIpFinderTest.java  |   16 +-
 parent/pom.xml                                  |   27 +-
 pom.xml                                         |   50 +-
 2377 files changed, 223596 insertions(+), 44888 deletions(-)
----------------------------------------------------------------------