You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ignite.apache.org by ag...@apache.org on 2017/04/13 15:34:37 UTC

[07/39] ignite git commit: Merge branch 'master' into ignite-4587

Merge branch 'master' into ignite-4587

# Conflicts:
#	modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/atomic/GridNearAtomicSingleUpdateFuture.java
#	modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/atomic/GridNearAtomicUpdateFuture.java


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

Branch: refs/heads/ignite-4587
Commit: bc7a9bd88b8d9fc18a291adbb7eb05dd1c2c0862
Parents: 92e11e8 7492843
Author: Max Kozlov <dr...@gmail.com>
Authored: Mon Feb 27 14:33:08 2017 +0300
Committer: Max Kozlov <dr...@gmail.com>
Committed: Mon Feb 27 14:33:08 2017 +0300

----------------------------------------------------------------------
 .gitignore                                      |    1 +
 DEVNOTES.txt                                    |    5 +-
 NOTICE                                          |    2 +-
 assembly/LICENSE_FABRIC                         |   35 +-
 assembly/LICENSE_HADOOP                         |   17 +-
 assembly/NOTICE_FABRIC                          |    2 +-
 assembly/NOTICE_HADOOP                          |    2 +-
 assembly/dependencies-fabric-lgpl.xml           |    1 +
 assembly/dependencies-fabric.xml                |    1 +
 assembly/release-base.xml                       |    5 +
 bin/ignite.sh                                   |    9 +
 config/dotnet/default-dotnet.xml                |   45 +
 examples/config/spark/example-shared-rdd.xml    |   83 +
 examples/pom-standalone-lgpl.xml                |    6 +
 examples/pom-standalone.xml                     |   12 +
 examples/pom.xml                                |   43 +-
 examples/schema-import/bin/h2-server.bat        |    2 +-
 examples/schema-import/bin/h2-server.sh         |    4 +-
 .../schema-import/bin/schema-import.properties  |    2 +-
 examples/schema-import/pom.xml                  |    2 +-
 .../ignite/examples/ExampleNodeStartup.java     |    2 +-
 .../examples/datagrid/CachePutGetExample.java   |    2 +-
 .../scalar/examples/ScalarJvmCloudExample.scala |    2 +-
 .../examples/spark/ScalarSharedRDDExample.scala |   89 +
 .../ignite/examples/spark/SharedRDDExample.java |  127 +
 .../ignite/examples/spark/package-info.java     |   22 +
 .../IgniteExamplesJ8SelfTestSuite.java          |    1 +
 .../tests/examples/ScalarExamplesSelfTest.scala |    6 +
 .../examples/SharedRDDExampleSelfTest.java      |   36 +
 .../IgniteExamplesSparkSelfTestSuite.java       |   46 +
 modules/aop/pom.xml                             |    2 +-
 modules/apache-license-gen/pom.xml              |    2 +-
 .../src/main/resources/META-INF/licenses.txt.vm |    7 +-
 modules/aws/pom.xml                             |    2 +-
 .../tcp/ipfinder/s3/TcpDiscoveryS3IpFinder.java |   37 +-
 .../TcpDiscoveryS3IpFinderAbstractSelfTest.java |   84 +
 ...3IpFinderAwsCredentialsProviderSelfTest.java |   46 +
 ...scoveryS3IpFinderAwsCredentialsSelfTest.java |   45 +
 .../s3/TcpDiscoveryS3IpFinderSelfTest.java      |   79 -
 .../ignite/testsuites/IgniteS3TestSuite.java    |   26 +-
 modules/benchmarks/pom.xml                      |    2 +-
 .../jmh/misc/JmhIncrementBenchmark.java         |   95 +
 modules/camel/pom.xml                           |    2 +-
 .../stream/camel/IgniteCamelStreamerTest.java   |    4 +-
 modules/cassandra/pom.xml                       |   26 +-
 modules/cassandra/serializers/pom.xml           |    4 +-
 modules/cassandra/store/pom.xml                 |    4 +-
 .../store/cassandra/CassandraCacheStore.java    |    6 +
 .../store/cassandra/datasource/DataSource.java  |    9 +
 .../cassandra/persistence/PojoKeyField.java     |    2 +-
 modules/clients/pom.xml                         |   12 +-
 .../ClientAbstractMultiNodeSelfTest.java        |    8 +-
 ...BinaryMarshallerInsertStatementSelfTest.java |    2 -
 ...cBinaryMarshallerMergeStatementSelfTest.java |    2 -
 .../internal/jdbc2/JdbcMetadataSelfTest.java    |    2 +-
 .../rest/ClientMemcachedProtocolSelfTest.java   |    4 +-
 .../rest/protocols/tcp/MockNioSession.java      |   25 +-
 .../tcp/redis/RedisProtocolSelfTest.java        |   13 +-
 .../ignite/jdbc/JdbcMetadataSelfTest.java       |    4 +-
 .../jdbc/suite/IgniteJdbcDriverTestSuite.java   |    3 +-
 modules/cloud/pom.xml                           |    8 +-
 modules/codegen/pom.xml                         |    2 +-
 .../ignite/codegen/MessageCodeGenerator.java    |    2 +-
 modules/core/pom.xml                            |    2 +-
 modules/core/src/main/java/META-INF/NOTICE      |    2 +-
 .../java/org/apache/ignite/IgniteLogger.java    |   10 +-
 .../java/org/apache/ignite/IgniteMessaging.java |   11 +-
 .../java/org/apache/ignite/IgniteServices.java  |   16 +
 .../apache/ignite/IgniteSystemProperties.java   |   30 +
 .../org/apache/ignite/cache/QueryEntity.java    |   22 +-
 .../ignite/cache/affinity/AffinityKey.java      |    4 +-
 .../rendezvous/RendezvousAffinityFunction.java  |   80 +-
 .../ignite/cache/query/SqlFieldsQuery.java      |    6 +
 .../org/apache/ignite/cache/query/SqlQuery.java |   25 +
 .../cache/store/CacheLoadOnlyStoreAdapter.java  |    6 +-
 .../ignite/cache/store/CacheStoreAdapter.java   |    6 +
 .../store/jdbc/CacheAbstractJdbcStore.java      |   11 +-
 .../store/jdbc/CacheJdbcBlobStoreFactory.java   |    2 +-
 .../cache/store/jdbc/CacheJdbcPojoStore.java    |   19 +-
 .../store/jdbc/JdbcTypesDefaultTransformer.java |  119 +-
 .../cache/store/jdbc/JdbcTypesTransformer.java  |   17 +
 .../store/jdbc/dialect/BasicJdbcDialect.java    |   31 +-
 .../configuration/CacheConfiguration.java       |    4 +-
 .../configuration/IgniteConfiguration.java      |   50 +-
 .../org/apache/ignite/events/CacheEvent.java    |    6 +-
 .../ignite/events/CacheQueryReadEvent.java      |    8 +-
 .../internal/GridEventConsumeHandler.java       |    7 +-
 .../ignite/internal/GridJobContextImpl.java     |    4 +-
 .../ignite/internal/GridKernalContext.java      |   10 +
 .../ignite/internal/GridKernalContextImpl.java  |   17 +-
 .../ignite/internal/GridKernalGatewayImpl.java  |   25 +-
 .../internal/GridMessageListenHandler.java      |    5 +
 .../internal/GridPerformanceSuggestions.java    |   92 -
 .../org/apache/ignite/internal/GridTopic.java   |   11 +-
 .../ignite/internal/IgniteInternalFuture.java   |   11 +
 .../apache/ignite/internal/IgniteKernal.java    |  145 +-
 .../ignite/internal/IgniteMessagingImpl.java    |    6 +-
 .../ignite/internal/IgniteServicesImpl.java     |    9 +-
 .../ignite/internal/IgniteVersionUtils.java     |    2 +-
 .../org/apache/ignite/internal/IgnitionEx.java  |   32 +-
 .../ignite/internal/MarshallerContextImpl.java  |    4 +-
 .../internal/StripedExecutorMXBeanAdapter.java  |   90 +
 .../internal/binary/BinaryClassDescriptor.java  |   12 +-
 .../ignite/internal/binary/BinaryContext.java   |    4 +-
 .../internal/binary/BinaryEnumObjectImpl.java   |   14 +-
 .../internal/binary/BinaryMarshaller.java       |    1 -
 .../ignite/internal/binary/BinaryMetadata.java  |    5 +-
 .../internal/binary/BinaryObjectExImpl.java     |    8 +-
 .../ignite/internal/binary/BinaryTypeProxy.java |   15 +-
 .../ignite/internal/binary/BinaryUtils.java     |   14 +-
 .../binary/builder/BinaryObjectBuilderImpl.java |   11 +-
 .../GridClientConnectionManagerAdapter.java     |    8 +-
 .../impl/connection/GridClientTopology.java     |   53 +-
 .../impl/GridRouterCommandLineStartup.java      |    4 +-
 .../client/router/impl/GridTcpRouterImpl.java   |    1 +
 .../client/util/GridClientConsistentHash.java   |   14 +-
 .../cluster/ClusterNodeLocalMapImpl.java        |    1 -
 .../internal/jdbc2/JdbcSqlFieldsQuery.java      |    1 -
 .../ignite/internal/jdbc2/JdbcStatement.java    |    2 -
 .../internal/managers/GridManagerAdapter.java   |    2 +-
 .../managers/communication/GridIoManager.java   |  285 +-
 .../managers/communication/GridIoMessage.java   |   13 +
 .../communication/GridIoMessageFactory.java     |   46 +-
 .../communication/IgniteIoTestMessage.java      |  235 ++
 .../discovery/GridDiscoveryManager.java         |  360 +-
 .../eventstorage/GridEventStorageManager.java   |   34 +-
 .../internal/mxbean/IgniteStandardMXBean.java   |   12 +-
 .../affinity/GridAffinityAssignmentCache.java   |    8 +-
 .../affinity/GridAffinityProcessor.java         |    2 +-
 .../cache/CacheAffinitySharedManager.java       |    2 +-
 .../cache/CacheEvictableEntryImpl.java          |    4 +-
 .../cache/CacheInvokeDirectResult.java          |    2 +-
 .../processors/cache/CacheInvokeResult.java     |    2 +-
 .../processors/cache/CacheLazyEntry.java        |    4 +-
 .../processors/cache/CacheMetricsImpl.java      |   10 +-
 .../processors/cache/CacheObjectAdapter.java    |    7 +-
 .../cache/CacheStoreBalancingWrapper.java       |    6 +
 .../processors/cache/EntryGetResult.java        |   65 +
 .../processors/cache/GridCacheAdapter.java      |  897 ++---
 .../cache/GridCacheAffinityManager.java         |   60 +-
 .../processors/cache/GridCacheAtomicFuture.java |    3 +-
 .../processors/cache/GridCacheContext.java      |   21 +-
 .../cache/GridCacheDeploymentManager.java       |    4 +-
 .../processors/cache/GridCacheEntryEx.java      |   44 +-
 .../cache/GridCacheEvictionManager.java         |   66 +-
 .../processors/cache/GridCacheGateway.java      |   48 +-
 .../processors/cache/GridCacheIoManager.java    |   19 +-
 .../cache/GridCacheLoaderWriterStore.java       |    6 +
 .../processors/cache/GridCacheMapEntry.java     |  155 +-
 .../processors/cache/GridCacheMessage.java      |    7 +
 .../cache/GridCacheMvccCandidate.java           |    9 +-
 .../GridCachePartitionExchangeManager.java      |  205 +-
 .../processors/cache/GridCachePreloader.java    |   17 +-
 .../cache/GridCachePreloaderAdapter.java        |   13 +-
 .../processors/cache/GridCacheProcessor.java    |  107 +-
 .../processors/cache/GridCacheReturn.java       |    2 +-
 .../processors/cache/GridCacheSwapManager.java  |    2 +-
 .../processors/cache/GridCacheTtlManager.java   |    4 +-
 .../processors/cache/GridCacheUtils.java        |   93 +-
 .../processors/cache/IgniteCacheProxy.java      |    9 +-
 .../processors/cache/QueryCursorImpl.java       |    6 +-
 .../processors/cache/ReaderArguments.java       |   74 +
 .../cache/affinity/GridCacheAffinityImpl.java   |   18 +-
 .../binary/CacheObjectBinaryProcessorImpl.java  |    5 +-
 .../CacheDataStructuresManager.java             |    8 +-
 .../distributed/GridCacheTxRecoveryFuture.java  |    4 +-
 .../GridDistributedCacheAdapter.java            |    9 +-
 .../distributed/GridDistributedCacheEntry.java  |    3 -
 .../distributed/GridDistributedLockRequest.java |    5 +
 .../GridDistributedLockResponse.java            |    1 -
 .../GridDistributedTxRemoteAdapter.java         |    2 +-
 .../GridDistributedUnlockRequest.java           |    5 +
 .../dht/GridClientPartitionTopology.java        |  134 +-
 .../dht/GridDhtAssignmentFetchFuture.java       |    8 +-
 .../distributed/dht/GridDhtCacheAdapter.java    |   61 +-
 .../distributed/dht/GridDhtCacheEntry.java      |    2 +-
 .../cache/distributed/dht/GridDhtGetFuture.java |   85 +-
 .../distributed/dht/GridDhtGetSingleFuture.java |   77 +-
 .../distributed/dht/GridDhtLocalPartition.java  |  126 +-
 .../distributed/dht/GridDhtLockFuture.java      |   32 +-
 .../distributed/dht/GridDhtLockResponse.java    |    9 +-
 .../dht/GridDhtPartitionTopology.java           |   29 +-
 .../dht/GridDhtPartitionTopologyImpl.java       |  304 +-
 .../dht/GridDhtTransactionalCacheAdapter.java   |   21 +-
 .../distributed/dht/GridDhtTxFinishFuture.java  |   82 +-
 .../cache/distributed/dht/GridDhtTxLocal.java   |  126 +-
 .../distributed/dht/GridDhtTxLocalAdapter.java  |   18 +-
 .../distributed/dht/GridDhtTxPrepareFuture.java |   52 +-
 .../cache/distributed/dht/GridDhtTxRemote.java  |    2 +-
 .../distributed/dht/GridDhtUnlockRequest.java   |    3 +-
 .../dht/GridPartitionedGetFuture.java           |   13 +-
 .../dht/GridPartitionedSingleGetFuture.java     |   14 +-
 .../GridDhtAtomicAbstractUpdateFuture.java      |    9 +-
 .../GridDhtAtomicAbstractUpdateRequest.java     |    2 +-
 .../dht/atomic/GridDhtAtomicCache.java          |  513 ++-
 .../atomic/GridDhtAtomicSingleUpdateFuture.java |    6 +-
 .../GridDhtAtomicSingleUpdateRequest.java       |   10 +-
 .../dht/atomic/GridDhtAtomicUpdateFuture.java   |    6 +-
 .../dht/atomic/GridDhtAtomicUpdateRequest.java  |   15 +-
 .../dht/atomic/GridDhtAtomicUpdateResponse.java |   31 +-
 .../GridNearAtomicAbstractUpdateFuture.java     |   34 +-
 .../atomic/GridNearAtomicFullUpdateRequest.java |    6 +-
 .../GridNearAtomicSingleUpdateFuture.java       |   43 +-
 .../GridNearAtomicSingleUpdateRequest.java      |    5 +
 .../dht/atomic/GridNearAtomicUpdateFuture.java  |   52 +-
 .../atomic/GridNearAtomicUpdateResponse.java    |   35 +-
 .../dht/colocated/GridDhtColocatedCache.java    |   39 +-
 .../colocated/GridDhtColocatedLockFuture.java   |   18 +-
 .../dht/preloader/GridDhtForceKeysFuture.java   |    8 +-
 .../dht/preloader/GridDhtPartitionDemander.java |  286 +-
 .../dht/preloader/GridDhtPartitionFullMap.java  |   18 +-
 .../dht/preloader/GridDhtPartitionMap2.java     |    3 +-
 .../dht/preloader/GridDhtPartitionSupplier.java |   12 +-
 .../GridDhtPartitionsExchangeFuture.java        |   91 +-
 .../dht/preloader/GridDhtPreloader.java         |   59 +-
 .../distributed/near/GridNearAtomicCache.java   |   68 +-
 .../distributed/near/GridNearCacheEntry.java    |    6 +-
 .../distributed/near/GridNearGetFuture.java     |   31 +-
 .../distributed/near/GridNearGetRequest.java    |   82 +-
 .../distributed/near/GridNearLockFuture.java    |   15 +-
 .../distributed/near/GridNearLockRequest.java   |   81 +-
 ...arOptimisticSerializableTxPrepareFuture.java |    8 +-
 .../near/GridNearOptimisticTxPrepareFuture.java |   28 +-
 .../GridNearPessimisticTxPrepareFuture.java     |    6 +-
 .../near/GridNearSingleGetRequest.java          |   62 +-
 .../near/GridNearTransactionalCache.java        |    8 +-
 .../near/GridNearTxFinishFuture.java            |   61 +-
 .../cache/distributed/near/GridNearTxLocal.java |   67 +-
 .../processors/cache/local/GridLocalCache.java  |    1 +
 .../local/atomic/GridLocalAtomicCache.java      |  186 +-
 .../processors/cache/query/CacheQuery.java      |    1 -
 .../query/GridCacheDistributedQueryManager.java |    2 +-
 .../cache/query/GridCacheQueryAdapter.java      |   12 +-
 .../cache/query/GridCacheQueryManager.java      |  208 +-
 .../cache/query/GridCacheQueryRequest.java      |    8 +-
 .../cache/query/GridCacheSqlQuery.java          |    6 +-
 .../continuous/CacheContinuousQueryEvent.java   |    8 +-
 .../continuous/CacheContinuousQueryHandler.java |  101 +-
 .../continuous/CacheContinuousQueryManager.java |    6 +-
 .../cache/store/CacheStoreManager.java          |    4 +-
 .../store/GridCacheStoreManagerAdapter.java     |   64 +-
 .../cache/store/GridCacheWriteBehindStore.java  |    8 +-
 .../cache/transactions/IgniteTxAdapter.java     |    4 +-
 .../cache/transactions/IgniteTxEntry.java       |    2 +-
 .../cache/transactions/IgniteTxHandler.java     |   27 +-
 .../transactions/IgniteTxLocalAdapter.java      |  156 +-
 .../cache/transactions/IgniteTxLocalEx.java     |    3 +
 .../cache/transactions/IgniteTxManager.java     |   10 +-
 .../cache/transactions/IgniteTxStateImpl.java   |    1 -
 .../cache/transactions/TxDeadlockDetection.java |    2 +-
 .../cache/transactions/TxEntryValueHolder.java  |    6 +-
 .../cache/version/GridCacheVersion.java         |    2 +-
 .../GridCacheVersionConflictContext.java        |    2 +-
 .../cache/version/GridCacheVersionManager.java  |    2 +-
 .../IgniteCacheObjectProcessorImpl.java         |    7 +-
 .../processors/clock/GridClockServer.java       |    4 +-
 .../clock/GridClockSyncProcessor.java           |    2 +-
 .../closure/GridClosureProcessor.java           |   35 +-
 .../continuous/GridContinuousHandler.java       |    5 +
 .../continuous/GridContinuousMessage.java       |    2 +-
 .../continuous/GridContinuousProcessor.java     |    3 +
 .../datastreamer/DataStreamProcessor.java       |   25 +-
 .../datastreamer/DataStreamerImpl.java          |    6 +-
 .../datastructures/CollocatedSetItemKey.java    |    2 +-
 .../GridCacheAtomicLongValue.java               |    2 +
 .../GridCacheAtomicSequenceImpl.java            |   14 +-
 .../GridCacheAtomicSequenceValue.java           |    2 +
 .../GridCacheCountDownLatchValue.java           |    3 +
 .../datastructures/GridCacheSetImpl.java        |    2 +-
 .../datastructures/GridCacheSetItemKey.java     |    2 +-
 .../datastructures/GridSetQueryPredicate.java   |    2 +-
 .../processors/hadoop/HadoopClassLoader.java    |   11 +
 .../processors/hadoop/HadoopClasspathUtils.java |    4 +-
 .../internal/processors/hadoop/HadoopJobId.java |    2 +-
 .../processors/hadoop/HadoopJobProperty.java    |   30 +-
 .../hadoop/HadoopMapperAwareTaskOutput.java     |   32 +
 .../processors/hadoop/HadoopTaskContext.java    |   18 +
 .../processors/hadoop/HadoopTaskInfo.java       |   43 +
 .../io/PartiallyOffheapRawComparatorEx.java     |   33 +
 .../shuffle/HadoopDirectShuffleMessage.java     |  273 ++
 .../hadoop/shuffle/HadoopShuffleAck.java        |    2 +-
 .../shuffle/HadoopShuffleFinishRequest.java     |  172 +
 .../shuffle/HadoopShuffleFinishResponse.java    |  142 +
 .../hadoop/shuffle/HadoopShuffleMessage.java    |    2 +-
 .../internal/processors/igfs/IgfsContext.java   |    4 +-
 .../processors/igfs/IgfsDataManager.java        |    6 +-
 .../internal/processors/igfs/IgfsImpl.java      |    2 +-
 .../internal/processors/igfs/IgfsProcessor.java |    3 +-
 .../igfs/client/IgfsClientSizeCallable.java     |    1 -
 .../processors/job/GridJobProcessor.java        |    2 +-
 .../internal/processors/job/GridJobWorker.java  |   87 +-
 .../internal/processors/odbc/IgniteTypes.java   |   69 +
 .../internal/processors/odbc/OdbcProcessor.java |    1 +
 .../odbc/OdbcQueryExecuteRequest.java           |    6 +-
 .../processors/odbc/OdbcRequestHandler.java     |   16 +-
 .../internal/processors/odbc/OdbcTableMeta.java |   15 +-
 .../internal/processors/odbc/OdbcTypes.java     |  131 +
 .../internal/processors/odbc/OdbcUtils.java     |   85 +
 .../processors/odbc/escape/OdbcEscapeUtils.java |   52 +-
 .../platform/PlatformAbstractBootstrap.java     |    3 +-
 .../platform/PlatformAbstractTarget.java        |  268 +-
 .../platform/PlatformAsyncTarget.java           |   44 +
 .../platform/PlatformConfigurationEx.java       |    3 +-
 .../platform/PlatformContextImpl.java           |    2 +-
 .../platform/PlatformNativeException.java       |    3 +-
 .../platform/PlatformNoopProcessor.java         |   41 +-
 .../processors/platform/PlatformProcessor.java  |   42 +-
 .../platform/PlatformProcessorImpl.java         |   87 +-
 .../processors/platform/PlatformTarget.java     |  103 +-
 .../platform/PlatformTargetProxy.java           |  126 +
 .../platform/PlatformTargetProxyImpl.java       |  222 ++
 .../binary/PlatformBinaryProcessor.java         |    6 +-
 .../platform/cache/PlatformCache.java           |   38 +-
 .../cache/PlatformCacheEntryFilterImpl.java     |    4 +-
 .../cache/PlatformCacheEntryProcessorImpl.java  |   43 +-
 .../platform/cache/PlatformCacheIterator.java   |    2 +-
 .../cache/affinity/PlatformAffinity.java        |    4 +-
 .../affinity/PlatformAffinityFunction.java      |   59 +-
 .../PlatformAffinityFunctionTarget.java         |    4 +-
 .../query/PlatformAbstractQueryCursor.java      |    4 +-
 .../query/PlatformContinuousQueryProxy.java     |    3 +-
 .../callback/PlatformCallbackGateway.java       |  272 +-
 .../platform/callback/PlatformCallbackOp.java   |  206 +
 .../callback/PlatformCallbackUtils.java         |  544 +--
 .../platform/cluster/PlatformClusterGroup.java  |   18 +-
 .../platform/compute/PlatformAbstractJob.java   |    2 +-
 .../platform/compute/PlatformAbstractTask.java  |   15 +-
 .../platform/compute/PlatformClosureJob.java    |   12 +-
 .../platform/compute/PlatformCompute.java       |   21 +-
 .../platform/compute/PlatformFullJob.java       |   15 +-
 .../platform/compute/PlatformFullTask.java      |   18 +-
 .../datastreamer/PlatformDataStreamer.java      |    4 +-
 .../PlatformStreamReceiverImpl.java             |   11 +-
 .../datastructures/PlatformAtomicLong.java      |    4 +-
 .../datastructures/PlatformAtomicReference.java |    8 +-
 .../datastructures/PlatformAtomicSequence.java  |    2 +-
 .../dotnet/PlatformDotNetCacheStore.java        |   17 +-
 .../platform/events/PlatformEvents.java         |   15 +-
 .../platform/messaging/PlatformMessaging.java   |    9 +-
 .../services/PlatformAbstractService.java       |   25 +-
 .../platform/services/PlatformServices.java     |   29 +-
 .../transactions/PlatformTransactions.java      |   17 +-
 .../utils/PlatformConfigurationUtils.java       |  128 +-
 .../platform/utils/PlatformFutureUtils.java     |   18 +-
 .../utils/PlatformListenableTarget.java         |   62 +
 .../platform/utils/PlatformUtils.java           |   38 +-
 .../processors/query/GridQueryIndexing.java     |   21 +-
 .../processors/query/GridQueryProcessor.java    |  105 +-
 .../query/GridQueryTypeDescriptor.java          |    7 +
 .../processors/query/GridRunningQueryInfo.java  |  132 +
 .../resource/GridResourceProcessor.java         |    2 +-
 .../processors/rest/GridRestResponse.java       |    2 +-
 .../handlers/cache/GridCacheCommandHandler.java |   29 +-
 .../redis/GridRedisRestCommandHandler.java      |   36 +
 .../string/GridRedisSetCommandHandler.java      |   45 +-
 .../tcp/GridTcpMemcachedNioListener.java        |   15 +-
 .../protocols/tcp/GridTcpRestNioListener.java   |    2 +-
 .../rest/protocols/tcp/GridTcpRestProtocol.java |    1 +
 .../service/GridServiceProcessor.java           |   21 +-
 .../processors/service/GridServiceProxy.java    |   18 +-
 .../processors/task/GridTaskWorker.java         |    9 +-
 .../suggestions/GridPerformanceSuggestions.java |  105 +
 .../JvmConfigurationSuggestions.java            |  104 +
 .../suggestions/OsConfigurationSuggestions.java |  127 +
 .../internal/suggestions/package-info.java      |   21 +
 .../ignite/internal/util/GridBusyLock.java      |    2 +-
 .../internal/util/GridStripedSpinBusyLock.java  |    2 +-
 .../ignite/internal/util/HostAndPortRange.java  |    2 +-
 .../ignite/internal/util/IgniteUtils.java       |   79 +-
 .../util/StripedCompositeReadWriteLock.java     |   50 +-
 .../ignite/internal/util/StripedExecutor.java   |  718 ++++
 .../util/future/GridCompoundFuture.java         |   56 +-
 .../util/future/GridFinishedFuture.java         |   24 +
 .../internal/util/future/GridFutureAdapter.java |   17 +-
 .../util/future/GridFutureChainListener.java    |   30 +-
 .../internal/util/ipc/IpcToNioAdapter.java      |    2 +-
 .../util/lang/GridMetadataAwareAdapter.java     |    2 +-
 .../nio/GridAbstractCommunicationClient.java    |   49 +-
 .../util/nio/GridCommunicationClient.java       |   14 +-
 .../nio/GridConnectionBytesVerifyFilter.java    |   15 +-
 .../util/nio/GridNioAsyncNotifyFilter.java      |   10 +-
 .../internal/util/nio/GridNioCodecFilter.java   |   17 +-
 .../ignite/internal/util/nio/GridNioFilter.java |   16 +-
 .../internal/util/nio/GridNioFilterAdapter.java |   10 +-
 .../internal/util/nio/GridNioFilterChain.java   |   14 +-
 .../ignite/internal/util/nio/GridNioFuture.java |    4 +-
 .../util/nio/GridNioRecoveryDescriptor.java     |  124 +-
 .../ignite/internal/util/nio/GridNioServer.java | 1511 ++++++--
 .../internal/util/nio/GridNioSession.java       |   25 +-
 .../internal/util/nio/GridNioSessionImpl.java   |   65 +-
 .../ignite/internal/util/nio/GridNioWorker.java |   48 +
 .../util/nio/GridSelectorNioSessionImpl.java    |  221 +-
 .../util/nio/GridShmemCommunicationClient.java  |    7 +-
 .../util/nio/GridTcpNioCommunicationClient.java |   55 +-
 .../internal/util/nio/SessionWriteRequest.java  |   85 +
 .../internal/util/nio/ssl/GridNioSslFilter.java |   10 +-
 .../util/nio/ssl/GridNioSslHandler.java         |    4 +-
 .../util/tostring/GridToStringBuilder.java      |  658 +++-
 .../util/tostring/GridToStringInclude.java      |   12 +-
 .../util/tostring/GridToStringThreadLocal.java  |   12 +-
 .../internal/visor/VisorMultiNodeTask.java      |    2 +-
 .../visor/cache/VisorCacheClearTask.java        |   88 +-
 .../visor/cache/VisorCacheTypeMetadata.java     |    6 +
 .../visor/compute/VisorGatewayTask.java         |   30 +-
 .../visor/node/VisorIgfsConfiguration.java      |    1 -
 .../visor/query/VisorCancelQueriesTask.java     |   72 +
 .../query/VisorCollectRunningQueriesTask.java   |   96 +
 .../internal/visor/query/VisorQueryJob.java     |    2 +-
 .../query/VisorQueryScanSubstringFilter.java    |    5 +-
 .../internal/visor/query/VisorQueryUtils.java   |   60 +
 .../internal/visor/query/VisorRunningQuery.java |  132 +
 .../visor/service/VisorCancelServiceTask.java   |   70 +
 .../visor/service/VisorServiceDescriptor.java   |  132 +
 .../visor/service/VisorServiceTask.java         |   75 +
 .../internal/visor/util/VisorTaskUtils.java     |   15 +-
 .../ignite/lang/IgniteProductVersion.java       |    2 +-
 .../apache/ignite/logger/java/JavaLogger.java   |    4 +-
 .../ignite/marshaller/jdk/JdkMarshaller.java    |    1 -
 .../optimized/OptimizedClassDescriptor.java     |    2 +-
 .../optimized/OptimizedMarshallerUtils.java     |    4 +-
 .../optimized/OptimizedObjectOutputStream.java  |   25 +-
 .../ignite/mxbean/StripedExecutorMXBean.java    |   90 +
 .../communication/tcp/TcpCommunicationSpi.java  | 1369 +++++--
 .../tcp/TcpCommunicationSpiMBean.java           |   38 +
 .../ignite/spi/discovery/tcp/ClientImpl.java    |   94 +-
 .../ignite/spi/discovery/tcp/ServerImpl.java    |  127 +-
 .../spi/discovery/tcp/TcpDiscoverySpi.java      |   14 +-
 .../tcp/internal/TcpDiscoveryStatistics.java    |   12 +-
 .../messages/TcpDiscoveryAbstractMessage.java   |   21 +
 .../apache/ignite/spi/indexing/IndexingSpi.java |    3 +
 .../roundrobin/RoundRobinLoadBalancingSpi.java  |   16 +-
 .../org/apache/ignite/stream/StreamAdapter.java |    4 +-
 .../ignite/stream/socket/SocketStreamer.java    |    1 +
 .../org/apache/ignite/thread/IgniteThread.java  |   26 +-
 .../ignite/thread/IgniteThreadFactory.java      |    8 +-
 .../apache/ignite/util/AttributeNodeFilter.java |  108 +
 .../resources/META-INF/classnames.properties    |   66 +-
 .../core/src/main/resources/ignite.properties   |    2 +-
 modules/core/src/test/config/log4j-test.xml     |    6 +
 .../AbstractAffinityFunctionSelfTest.java       |    2 +-
 .../CacheJdbcPojoStoreAbstractSelfTest.java     |   21 +-
 .../store/jdbc/CacheJdbcPojoStoreTest.java      |   48 +-
 ...eJdbcStoreAbstractMultithreadedSelfTest.java |   17 +-
 .../jdbc/JdbcTypesDefaultTransformerTest.java   |  283 ++
 .../ignite/cache/store/jdbc/model/Gender.java   |   41 +
 .../ignite/cache/store/jdbc/model/Person.java   |   33 +-
 .../internal/ClusterGroupHostsSelfTest.java     |    6 +-
 .../ComputeJobCancelWithServiceSelfTest.java    |    2 +-
 .../internal/GridContinuousTaskSelfTest.java    |   83 +-
 .../GridEventStorageCheckAllEventsSelfTest.java |    2 +-
 .../IgniteClientReconnectApiExceptionTest.java  |    6 +-
 ...niteClientReconnectFailoverAbstractTest.java |    4 +-
 .../IgniteComputeTopologyExceptionTest.java     |    5 +-
 .../IgniteSlowClientDetectionSelfTest.java      |    1 +
 .../internal/binary/BinaryEnumsSelfTest.java    |   18 +
 .../binary/BinaryMarshallerSelfTest.java        |   66 +
 .../communication/GridIoManagerSelfTest.java    |    6 +-
 ...unicationBalanceMultipleConnectionsTest.java |   28 +
 ...mmunicationBalancePairedConnectionsTest.java |   28 +
 .../IgniteCommunicationBalanceTest.java         |  354 ++
 .../communication/IgniteIoTestMessagesTest.java |   95 +
 .../IgniteVariousConnectionNumberTest.java      |  166 +
 .../GridDiscoveryManagerAliveCacheSelfTest.java |   58 +-
 .../GridDiscoveryManagerAttributesSelfTest.java |    4 +-
 .../discovery/GridDiscoveryManagerSelfTest.java |  214 --
 .../BinaryObjectOffHeapUnswapTemporaryTest.java |    1 -
 .../cache/CacheAffinityCallSelfTest.java        |    8 +-
 .../cache/CacheConcurrentReadThroughTest.java   |  184 +
 .../cache/CacheDeferredDeleteQueueTest.java     |  134 +
 .../cache/CacheEntryProcessorCopySelfTest.java  |    6 +-
 .../cache/CacheGetEntryAbstractTest.java        |   16 +-
 .../cache/CacheRebalancingSelfTest.java         |   75 +
 .../CacheSerializableTransactionsTest.java      |  179 +-
 .../CacheStartupInDeploymentModesTest.java      |    7 +-
 .../cache/CacheStopAndDestroySelfTest.java      |    6 +-
 .../processors/cache/CacheTxFastFinishTest.java |    2 +-
 .../cache/CrossCacheTxRandomOperationsTest.java |   30 +-
 ...idAbstractCacheInterceptorRebalanceTest.java |    4 +-
 .../cache/GridCacheAbstractFullApiSelfTest.java |   10 +-
 .../cache/GridCacheBasicStoreAbstractTest.java  |    2 +-
 .../cache/GridCacheLifecycleAwareSelfTest.java  |   33 +
 .../GridCacheMissingCommitVersionSelfTest.java  |    6 +-
 .../cache/GridCacheMvccPartitionedSelfTest.java |   48 +-
 .../processors/cache/GridCacheMvccSelfTest.java |  208 +-
 ...CacheOffHeapMultiThreadedUpdateSelfTest.java |    6 +-
 .../processors/cache/GridCacheOffHeapTest.java  |  274 --
 .../GridCachePartitionedAffinitySpreadTest.java |    7 +-
 .../processors/cache/GridCacheStopSelfTest.java |    4 +-
 .../processors/cache/GridCacheTestEntryEx.java  |   34 +-
 .../cache/GridCacheUtilsSelfTest.java           |    2 +-
 ...ProjectionForCachesOnDaemonNodeSelfTest.java |    8 +-
 .../IgniteCacheConfigVariationsFullApiTest.java |    8 +-
 .../cache/IgniteCachePeekModesAbstractTest.java |    8 +-
 .../cache/IgniteCacheStoreCollectionTest.java   |    1 -
 ...gniteTopologyValidatorAbstractCacheTest.java |    6 +-
 ...niteTopologyValidatorGridSplitCacheTest.java |  334 ++
 .../processors/cache/IgniteTxAbstractTest.java  |    3 +-
 .../cache/IgniteTxConfigCacheSelfTest.java      |    2 +-
 .../IgniteTxExceptionAbstractSelfTest.java      |    3 +-
 .../IgniteTxMultiThreadedAbstractTest.java      |    4 +-
 .../IgniteTxStoreExceptionAbstractSelfTest.java |    1 +
 ...heapCacheMetricsForClusterGroupSelfTest.java |  141 +
 .../CacheKeepBinaryWithInterceptorTest.java     |    1 -
 ...yAtomicEntryProcessorDeploymentSelfTest.java |    4 +-
 .../GridCacheBinaryObjectsAbstractSelfTest.java |    7 +-
 ...IgniteCacheAbstractExecutionContextTest.java |    2 -
 ...eAbstractDataStructuresFailoverSelfTest.java |   16 +-
 ...actQueueFailoverDataConsistencySelfTest.java |    2 +-
 ...CacheAtomicReferenceApiSelfAbstractTest.java |   60 +-
 ...idCacheAtomicStampedApiSelfAbstractTest.java |   59 +
 .../GridCacheQueueApiSelfAbstractTest.java      |   58 +
 .../GridCacheSetAbstractSelfTest.java           |   53 +
 .../IgniteAtomicLongApiAbstractSelfTest.java    |   27 +
 .../IgniteCountDownLatchAbstractSelfTest.java   |   43 +
 .../IgniteLockAbstractSelfTest.java             |   78 +-
 .../IgniteSemaphoreAbstractSelfTest.java        |   52 +-
 ...achePartitionedAtomicSequenceTxSelfTest.java |  169 +
 .../CacheGetFutureHangsSelfTest.java            |    6 +-
 .../CacheLateAffinityAssignmentTest.java        |    2 +-
 .../CacheLockReleaseNodeLeaveTest.java          |  135 +
 ...ridCachePartitionNotLoadedEventSelfTest.java |    4 +-
 ...eAtomicMessageRecovery10ConnectionsTest.java |   28 +
 ...micMessageRecoveryPairedConnectionsTest.java |   47 +
 ...niteCacheClientNodeChangingTopologyTest.java |   20 +-
 ...acheConnectionRecovery10ConnectionsTest.java |   35 +
 .../distributed/IgniteCacheCreatePutTest.java   |    2 +-
 .../IgniteCacheMessageRecoveryAbstractTest.java |   24 +-
 .../IgniteCacheMessageWriteTimeoutTest.java     |   17 +-
 ...teSynchronizationModesMultithreadedTest.java |    8 +-
 .../GridCacheDhtEvictionsDisabledSelfTest.java  |    5 +-
 .../distributed/dht/GridCacheDhtTestUtils.java  |  232 --
 .../IgniteCacheCrossCacheTxFailoverTest.java    |    6 +-
 .../dht/IgniteCacheMultiTxLockSelfTest.java     |    6 +-
 ...ePrimaryNodeFailureRecoveryAbstractTest.java |    4 +-
 ...gniteCachePutRetryTransactionalSelfTest.java |    4 +-
 .../AtomicPutAllChangingTopologyTest.java       |  212 +
 ...eAtomicInvalidPartitionHandlingSelfTest.java |    4 +-
 ...nabledMultiNodeLongTxTimeoutFullApiTest.java |    2 +-
 ...erNoStripedPoolMultiNodeFullApiSelfTest.java |   35 +
 ...idCacheNearOnlyMultiNodeFullApiSelfTest.java |    4 +-
 ...achePartitionedMultiNodeFullApiSelfTest.java |   37 +-
 ...edNoStripedPoolMultiNodeFullApiSelfTest.java |   35 +
 .../near/GridNearCacheStoreUpdateTest.java      |  466 +++
 .../GridNearOffheapCacheStoreUpdateTest.java    |   35 +
 .../GridCacheRebalancingSyncSelfTest.java       |    2 +
 .../GridCacheReplicatedNodeRestartSelfTest.java |    3 +-
 .../GridCacheReplicatedPreloadSelfTest.java     |    1 -
 .../IgniteCacheExpiryPolicyAbstractTest.java    |    4 +-
 ...eCacheExpiryPolicyWithStoreAbstractTest.java |  102 +
 .../IgniteCacheTxExpiryPolicyWithStoreTest.java |   21 +
 .../CacheOffHeapAndSwapMetricsSelfTest.java     |  621 ---
 ...LocalCacheOffHeapAndSwapMetricsSelfTest.java |  621 +++
 .../IgniteCacheQueryCacheDestroySelfTest.java   |  142 +
 .../cache/query/IndexingSpiQuerySelfTest.java   |  244 +-
 .../IndexingSpiQueryWithH2IndexingSelfTest.java |   36 +
 ...ContinuousQueryFailoverAbstractSelfTest.java |    6 +-
 .../ClientReconnectContinuousQueryTest.java     |  201 +
 ...dCacheContinuousQueryNodesFilteringTest.java |    2 +-
 ...IgniteCacheContinuousQueryReconnectTest.java |   12 +-
 .../TxDeadlockDetectionNoHangsTest.java         |    4 +-
 .../transactions/TxDeadlockDetectionTest.java   |    2 +-
 .../TxOptimisticDeadlockDetectionTest.java      |   31 +-
 .../TxPessimisticDeadlockDetectionTest.java     |    2 +-
 .../closure/GridClosureSerializationTest.java   |  177 +
 ...ComputeJobExecutionErrorToLogManualTest.java |    4 +-
 .../datastreamer/DataStreamerImplSelfTest.java  |    8 +-
 .../datastreamer/DataStreamerTimeoutTest.java   |    6 +-
 .../processors/igfs/IgfsAbstractSelfTest.java   |   32 +-
 ...lockMessageSystemPoolStarvationSelfTest.java |   14 +-
 .../processors/igfs/IgfsFileInfoSelfTest.java   |    4 +-
 .../igfs/IgfsMetaManagerSelfTest.java           |    3 +-
 .../igfs/IgfsModeResolverSelfTest.java          |   10 +-
 .../processors/igfs/IgfsTaskSelfTest.java       |   87 +-
 .../igfs/benchmark/IgfsBenchmark.java           |    4 +-
 ...niteMessagingConfigVariationFullApiTest.java |  195 +-
 .../odbc/OdbcEscapeSequenceSelfTest.java        |  131 +
 .../cache/GridCacheCommandHandlerSelfTest.java  |    1 -
 ...rviceDeploymentExceptionPropagationTest.java |    2 +-
 .../GridServiceProcessorProxySelfTest.java      |    2 +-
 .../GridServiceProcessorStopSelfTest.java       |    2 +-
 ...gniteServiceProxyTimeoutInitializedTest.java |  284 ++
 .../service/IgniteServiceReassignmentTest.java  |    2 +-
 .../internal/util/IgniteUtilsSelfTest.java      |    5 +-
 .../internal/util/StripedExecutorTest.java      |  168 +
 .../util/future/GridFutureAdapterSelfTest.java  |  122 +-
 .../nio/impl/GridNioFilterChainSelfTest.java    |   32 +-
 .../unsafe/GridOffheapSnapTreeSelfTest.java     |    7 +-
 .../tostring/GridToStringBuilderSelfTest.java   |   33 +-
 .../lang/GridMetadataAwareAdapterSelfTest.java  |    4 +-
 .../loadtests/nio/GridNioBenchmarkClient.java   |    4 +-
 .../GridMarshallerPerformanceTest.java          |    4 +
 .../ignite/messaging/GridMessagingSelfTest.java |  114 +-
 .../messaging/IgniteMessagingSendAsyncTest.java |  544 +++
 .../p2p/GridP2PRecursionTaskSelfTest.java       |    2 +-
 .../p2p/GridP2PSameClassLoaderSelfTest.java     |   14 +-
 .../platform/PlatformEventsWriteEventTask.java  |    9 -
 .../ignite/platform/PlatformExceptionTask.java  |   78 +
 .../spi/GridTcpSpiForwardingSelfTest.java       |   18 +-
 .../GridTcpCommunicationSpiAbstractTest.java    |   28 +-
 ...mmunicationSpiConcurrentConnectSelfTest.java |   82 +-
 .../GridTcpCommunicationSpiConfigSelfTest.java  |    5 +-
 ...cpCommunicationSpiMultithreadedSelfTest.java |   23 +-
 ...dTcpCommunicationSpiRecoveryAckSelfTest.java |    9 +-
 ...tionSpiRecoveryFailureDetectionSelfTest.java |    1 +
 ...ationSpiRecoveryNoPairedConnectionsTest.java |   28 +
 ...GridTcpCommunicationSpiRecoverySelfTest.java |   67 +-
 ...CommunicationRecoveryAckClosureSelfTest.java |    9 +-
 .../tcp/TcpCommunicationSpiDropNodesTest.java   |  322 ++
 .../TcpCommunicationSpiFaultyClientTest.java    |  265 ++
 .../local/GridLocalDeploymentSpiSelfTest.java   |    6 +-
 ...lientDiscoverySpiFailureTimeoutSelfTest.java |    4 +-
 .../spi/discovery/tcp/TcpDiscoverySelfTest.java |    8 +-
 .../TcpDiscoverySpiFailureTimeoutSelfTest.java  |   14 +-
 .../GridSwapSpaceSpiAbstractSelfTest.java       |    3 +-
 .../startup/GridRandomCommandLineLoader.java    |    2 +-
 .../testframework/GridSpiTestContext.java       |    5 +-
 .../ignite/testframework/GridTestNode.java      |    1 +
 .../ignite/testframework/IgniteTestSuite.java   |    2 +-
 .../testframework/junits/GridAbstractTest.java  |    2 +
 .../junits/GridTestKernalContext.java           |    4 +-
 .../junits/logger/GridTestLog4jLogger.java      |    4 +-
 .../junits/multijvm/IgniteProcessProxy.java     |    5 +-
 .../ignite/testsuites/IgniteBasicTestSuite.java |    7 +
 .../IgniteCacheDataStructuresSelfTestSuite.java |    7 +-
 .../IgniteCacheFailoverTestSuite.java           |    3 +
 .../IgniteCacheFullApiSelfTestSuite.java        |    6 +
 .../IgniteCacheMetricsSelfTestSuite.java        |    6 +-
 .../ignite/testsuites/IgniteCacheTestSuite.java |   23 +-
 .../testsuites/IgniteCacheTestSuite2.java       |    7 +
 .../testsuites/IgniteCacheTestSuite4.java       |    3 +
 .../testsuites/IgniteCacheTestSuite5.java       |    9 +-
 .../testsuites/IgniteComputeGridTestSuite.java  |    2 +
 .../testsuites/IgniteKernalSelfTestSuite.java   |    7 +-
 ...essagingConfigVariationFullApiTestSuite.java |    4 +-
 .../IgniteSpiCommunicationSelfTestSuite.java    |    7 +
 .../IgniteSpiDiscoverySelfTestSuite.java        |    2 +-
 .../IgniteTopologyValidatorTestSuit.java        |    1 +
 .../util/AttributeNodeFilterSelfTest.java       |  184 +
 .../ignite/util/mbeans/GridMBeanSelfTest.java   |   10 +-
 modules/docker/1.8.0/Dockerfile                 |   46 +
 modules/docker/1.8.0/run.sh                     |   51 +
 modules/docker/Dockerfile                       |    6 +-
 modules/extdata/p2p/pom.xml                     |    2 +-
 .../CacheNoValueClassOnServerTestClient.java    |    3 +-
 .../CacheConfigurationP2PTestClient.java        |    3 +-
 .../extdata/uri/modules/uri-dependency/pom.xml  |    2 +-
 modules/extdata/uri/pom.xml                     |    2 +-
 modules/flink/pom.xml                           |    4 +-
 modules/flume/pom.xml                           |    2 +-
 .../apache/ignite/stream/flume/IgniteSink.java  |    7 +-
 modules/gce/pom.xml                             |    6 +-
 .../gce/TcpDiscoveryGoogleStorageIpFinder.java  |    4 +-
 modules/geospatial/pom.xml                      |    2 +-
 modules/hadoop/pom.xml                          |    9 +-
 .../io/BytesWritablePartiallyRawComparator.java |   51 +
 .../hadoop/io/PartiallyRawComparator.java       |   33 +
 .../org/apache/ignite/hadoop/io/RawMemory.java  |   86 +
 .../hadoop/io/TextPartiallyRawComparator.java   |   51 +
 .../apache/ignite/hadoop/io/package-info.java   |   22 +
 .../IgniteHadoopClientProtocolProvider.java     |   70 +-
 .../processors/hadoop/HadoopMapperUtils.java    |   56 +
 .../hadoop/igfs/HadoopIgfsEndpoint.java         |    4 +-
 .../processors/hadoop/impl/HadoopUtils.java     |   66 +
 .../HadoopBasicFileSystemFactoryDelegate.java   |    2 +-
 .../hadoop/impl/fs/HadoopFileSystemsUtils.java  |   11 +
 .../hadoop/impl/igfs/HadoopIgfsInProc.java      |   40 +-
 .../hadoop/impl/igfs/HadoopIgfsJclLogger.java   |    9 +-
 .../hadoop/impl/proto/HadoopClientProtocol.java |   55 +-
 .../hadoop/impl/v1/HadoopV1MapTask.java         |   89 +-
 .../hadoop/impl/v1/HadoopV1ReduceTask.java      |   69 +-
 .../hadoop/impl/v2/HadoopV2Context.java         |    2 +-
 ...DelegatingPartiallyOffheapRawComparator.java |   54 +
 .../processors/hadoop/impl/v2/HadoopV2Job.java  |   22 +-
 .../impl/v2/HadoopV2JobResourceManager.java     |   25 +-
 .../hadoop/impl/v2/HadoopV2MapTask.java         |   26 +-
 .../hadoop/impl/v2/HadoopV2ReduceTask.java      |   14 +
 .../hadoop/impl/v2/HadoopV2TaskContext.java     |  100 +-
 .../processors/hadoop/io/OffheapRawMemory.java  |  131 +
 .../hadoop/jobtracker/HadoopJobTracker.java     |    8 +-
 .../hadoop/mapreduce/MapReduceClient.java       |  147 +
 .../hadoop/shuffle/HadoopShuffle.java           |   66 +-
 .../hadoop/shuffle/HadoopShuffleJob.java        |  646 +++-
 .../hadoop/shuffle/HadoopShuffleLocalState.java |   67 +
 .../shuffle/HadoopShuffleRemoteState.java       |   61 +
 .../shuffle/collections/HadoopMultimapBase.java |    5 +-
 .../shuffle/collections/HadoopSkipList.java     |   14 +-
 .../shuffle/direct/HadoopDirectDataInput.java   |  166 +
 .../shuffle/direct/HadoopDirectDataOutput.java  |  235 ++
 .../direct/HadoopDirectDataOutputContext.java   |  140 +
 .../direct/HadoopDirectDataOutputState.java     |   66 +
 .../taskexecutor/HadoopExecutorService.java     |    6 +-
 .../hadoop/taskexecutor/HadoopRunnableTask.java |   12 +-
 .../child/HadoopChildProcessRunner.java         |   16 +-
 .../HadoopExternalCommunication.java            |    5 +-
 .../communication/HadoopIpcToNioAdapter.java    |    2 +-
 .../communication/HadoopMarshallerFilter.java   |    6 +-
 .../impl/HadoopAbstractMapReduceTest.java       |    2 +
 .../hadoop/impl/HadoopAbstractSelfTest.java     |   13 +-
 .../impl/HadoopAbstractWordCountTest.java       |    6 +-
 .../hadoop/impl/HadoopErrorSimulator.java       |   12 +-
 .../hadoop/impl/HadoopFileSystemsTest.java      |    9 +
 .../hadoop/impl/HadoopJobTrackerSelfTest.java   |    4 +-
 .../impl/HadoopMapReduceEmbeddedSelfTest.java   |   24 +-
 .../impl/HadoopTaskExecutionSelfTest.java       |    4 +-
 .../hadoop/impl/HadoopTeraSortTest.java         |  409 ++
 ...opClientProtocolMultipleServersSelfTest.java |   93 +-
 .../client/HadoopClientProtocolSelfTest.java    |  232 +-
 .../HadoopIgfs20FileSystemAbstractSelfTest.java |    3 +-
 .../IgniteHadoopFileSystemClientSelfTest.java   |    6 +-
 .../collections/HadoopAbstractMapTest.java      |    6 +
 .../collections/HadoopSkipListSelfTest.java     |   14 +-
 .../HadoopExternalTaskExecutionSelfTest.java    |    2 +
 .../testsuites/IgniteHadoopTestSuite.java       |    3 +
 modules/hibernate/pom.xml                       |    2 +-
 modules/indexing/pom.xml                        |    2 +-
 .../cache/query/GridCacheTwoStepQuery.java      |   18 +-
 .../query/h2/GridH2ResultSetIterator.java       |    3 +-
 .../processors/query/h2/IgniteH2Indexing.java   |  200 +-
 .../query/h2/opt/GridH2IndexBase.java           |    6 +-
 .../processors/query/h2/sql/DmlAstUtils.java    |    2 +-
 .../query/h2/sql/GridSqlQuerySplitter.java      |    4 +-
 .../h2/twostep/GridReduceQueryExecutor.java     |   74 +-
 .../query/h2/twostep/msg/GridH2Geometry.java    |    2 +-
 .../cache/BinarySerializationQuerySelfTest.java |    2 -
 .../CacheRandomOperationsMultithreadedTest.java |    4 +-
 ...CacheScanPartitionQueryFallbackSelfTest.java |    2 +-
 .../cache/CacheSqlQueryValueCopySelfTest.java   |  208 +-
 .../ClientReconnectAfterClusterRestartTest.java |    4 +-
 .../cache/GridCacheCrossCacheQuerySelfTest.java |    2 +-
 .../GridCacheQueryIndexDisabledSelfTest.java    |   20 +-
 ...niteCacheAbstractInsertSqlQuerySelfTest.java |   14 +-
 .../cache/IgniteCacheAbstractQuerySelfTest.java |  297 +-
 .../IgniteCacheAbstractSqlDmlQuerySelfTest.java |    6 +-
 .../IgniteCacheInsertSqlQuerySelfTest.java      |   18 +-
 .../cache/IgniteCacheLargeResultSelfTest.java   |   15 +-
 ...eLockPartitionOnAffinityRunAbstractTest.java |    1 -
 ...PartitionOnAffinityRunAtomicCacheOpTest.java |   11 +-
 ...niteCacheLockPartitionOnAffinityRunTest.java |   51 +-
 ...titionOnAffinityRunWithCollisionSpiTest.java |   10 +-
 .../cache/IgniteCacheMergeSqlQuerySelfTest.java |   15 +-
 .../cache/IgniteCacheOffheapEvictQueryTest.java |    4 +-
 ...niteCacheP2pUnmarshallingQueryErrorTest.java |    4 +-
 .../IgniteCacheUpdateSqlQuerySelfTest.java      |    6 +-
 .../cache/QueryEntityCaseMismatchTest.java      |  107 +
 ...niteCacheDistributedQueryCancelSelfTest.java |    4 +-
 ...niteCachePartitionedFieldsQuerySelfTest.java |   25 +
 .../IgniteCachePartitionedQuerySelfTest.java    |   85 +
 .../IgniteCacheQueryNodeRestartSelfTest2.java   |    4 +-
 .../IgniteSqlEntryCacheModeAgnosticTest.java    |  140 +
 .../query/IgniteSqlSchemaIndexingTest.java      |   15 +-
 .../query/IgniteSqlSplitterSelfTest.java        |    4 +-
 .../h2/GridIndexingSpiAbstractSelfTest.java     |   40 +-
 .../query/h2/sql/GridQueryParsingTest.java      |    4 -
 .../IgniteCacheQuerySelfTestSuite.java          |  136 +-
 .../IgniteCacheQuerySelfTestSuite2.java         |  111 +-
 .../IgniteCacheQuerySelfTestSuite3.java         |    2 +
 .../IgniteH2IndexingSpiTestSuite.java           |   16 +-
 modules/jcl/pom.xml                             |    2 +-
 .../org/apache/ignite/logger/jcl/JclLogger.java |    9 +-
 modules/jms11/pom.xml                           |    2 +-
 .../apache/ignite/stream/jms11/JmsStreamer.java |    4 +-
 modules/jta/pom.xml                             |    2 +-
 modules/kafka/pom.xml                           |    2 +-
 .../ignite/stream/kafka/KafkaStreamer.java      |   52 +-
 .../kafka/KafkaIgniteStreamerSelfTest.java      |   36 +-
 .../ignite/stream/kafka/TestKafkaBroker.java    |    2 +-
 .../connect/IgniteSourceConnectorTest.java      |    2 +-
 modules/kubernetes/DEVNOTES.txt                 |   63 +
 modules/kubernetes/README.txt                   |   33 +
 modules/kubernetes/config/Dockerfile            |   45 +
 modules/kubernetes/config/example-kube.xml      |   44 +
 .../kubernetes/config/ignite-deployment.yaml    |   26 +
 modules/kubernetes/config/ignite-service.yaml   |   14 +
 modules/kubernetes/config/run.sh                |   50 +
 modules/kubernetes/licenses/apache-2.0.txt      |  202 +
 modules/kubernetes/pom.xml                      |   93 +
 .../TcpDiscoveryKubernetesIpFinder.java         |  317 ++
 .../tcp/ipfinder/kubernetes/package-info.java   |   22 +
 .../TcpDiscoveryKubernetesIpFinderSelfTest.java |   93 +
 .../tcp/ipfinder/kubernetes/package-info.java   |   22 +
 .../testsuites/IgniteKubernetesTestSuite.java   |   41 +
 modules/log4j/pom.xml                           |    2 +-
 .../apache/ignite/logger/log4j/Log4JLogger.java |    4 +-
 modules/log4j2/pom.xml                          |    2 +-
 modules/mesos/pom.xml                           |    2 +-
 modules/mqtt/pom.xml                            |    2 +-
 .../stream/mqtt/IgniteMqttStreamerTest.java     |    4 +-
 modules/osgi-karaf/pom.xml                      |    2 +-
 modules/osgi-paxlogging/pom.xml                 |    2 +-
 modules/osgi/pom.xml                            |    2 +-
 .../BundleDelegatingClassLoader.java            |    4 +-
 .../classloaders/ContainerSweepClassLoader.java |    4 +-
 modules/platforms/cpp/binary/Makefile.am        |    5 +-
 .../platforms/cpp/binary/include/Makefile.am    |    6 +
 .../cpp/binary/include/ignite/binary/binary.h   |   15 +-
 .../binary/binary_array_identity_resolver.h     |   64 +
 .../ignite/binary/binary_identity_resolver.h    |   61 +
 .../include/ignite/binary/binary_object.h       |   78 +
 .../include/ignite/binary/binary_raw_reader.h   |   21 +
 .../binary/include/ignite/binary/binary_type.h  |   16 -
 .../ignite/impl/binary/binary_object_header.h   |  250 ++
 .../ignite/impl/binary/binary_object_impl.h     |  109 +
 .../ignite/impl/binary/binary_reader_impl.h     |    9 +-
 .../include/ignite/impl/binary/binary_schema.h  |    2 +-
 .../ignite/impl/binary/binary_type_impl.h       |  149 +
 .../ignite/impl/binary/binary_type_manager.h    |    2 +-
 .../ignite/impl/binary/binary_type_snapshot.h   |   18 +-
 .../include/ignite/impl/binary/binary_utils.h   |  236 +-
 .../ignite/impl/binary/binary_writer_impl.h     |   11 +-
 .../ignite/impl/interop/interop_output_stream.h |   10 +-
 .../cpp/binary/project/vs/binary.vcxproj        |    9 +
 .../binary/project/vs/binary.vcxproj.filters    |   27 +
 .../binary/binary_array_identity_resolver.cpp   |   42 +
 .../cpp/binary/src/binary/binary_type.cpp       |    4 +-
 .../src/impl/binary/binary_object_header.cpp    |   51 +
 .../src/impl/binary/binary_object_impl.cpp      |   56 +
 .../src/impl/binary/binary_reader_impl.cpp      |   17 +
 .../src/impl/binary/binary_type_manager.cpp     |   16 +-
 .../cpp/binary/src/impl/binary/binary_utils.cpp |  169 +-
 .../src/impl/binary/binary_writer_impl.cpp      |    4 +-
 .../binary/src/impl/interop/interop_memory.cpp  |    2 +-
 .../src/impl/interop/interop_output_stream.cpp  |    5 +
 modules/platforms/cpp/common/Makefile.am        |    7 +-
 .../platforms/cpp/common/include/Makefile.am    |    6 +-
 .../common/include/ignite/common/concurrent.h   |   90 +-
 .../include/ignite/common/dynamic_size_array.h  |    2 +-
 .../include/ignite/common/platform_utils.h      |   79 +
 .../include/ignite/common/reference_impl.h      |  286 ++
 .../cpp/common/include/ignite/common/utils.h    |  249 +-
 .../cpp/common/include/ignite/reference.h       |  564 +++
 .../os/linux/src/common/platform_utils.cpp      |   81 +
 .../cpp/common/os/linux/src/common/utils.cpp    |  136 -
 .../common/os/win/src/common/platform_utils.cpp |   88 +
 .../cpp/common/os/win/src/common/utils.cpp      |  142 -
 .../cpp/common/project/vs/common.vcxproj        |    7 +-
 .../common/project/vs/common.vcxproj.filters    |   18 +-
 .../platforms/cpp/common/src/common/utils.cpp   |  153 +
 modules/platforms/cpp/configure.ac              |    2 +-
 modules/platforms/cpp/configure.acrel           |    2 +-
 modules/platforms/cpp/core-test/Makefile.am     |   14 +-
 .../cpp/core-test/config/cache-identity.xml     |  121 +
 .../core-test/config/cache-query-continuous.xml |   87 +
 .../cpp/core-test/config/cache-query.xml        |   10 -
 .../cpp/core-test/config/cache-test.xml         |    1 +
 .../platforms/cpp/core-test/config/invalid.xml  |   39 +
 .../core-test/include/ignite/binary_test_defs.h |   25 +
 .../cpp/core-test/include/ignite/complex_type.h |  135 +
 .../cpp/core-test/include/ignite/test_type.h    |  186 +
 .../cpp/core-test/include/ignite/test_utils.h   |   63 +
 .../cpp/core-test/project/vs/core-test.vcxproj  |   20 +-
 .../project/vs/core-test.vcxproj.filters        |   40 +-
 .../src/binary_identity_resolver_test.cpp       |  522 +++
 .../cpp/core-test/src/binary_object_test.cpp    |  282 ++
 .../cpp/core-test/src/binary_session_test.cpp   |    4 +-
 .../cpp/core-test/src/cache_query_test.cpp      |  223 +-
 .../platforms/cpp/core-test/src/cache_test.cpp  |   43 +-
 .../cpp/core-test/src/continuous_query_test.cpp |  584 +++
 .../cpp/core-test/src/handle_registry_test.cpp  |   18 +-
 .../cpp/core-test/src/ignition_test.cpp         |   19 +-
 .../cpp/core-test/src/interop_test.cpp          |   51 +-
 .../cpp/core-test/src/reference_test.cpp        |  422 ++
 .../platforms/cpp/core-test/src/test_utils.cpp  |   79 +
 .../cpp/core-test/src/transactions_test.cpp     |   23 +-
 modules/platforms/cpp/core/Makefile.am          |    3 +-
 .../cpp/core/include/ignite/cache/cache.h       |  104 +-
 .../cpp/core/include/ignite/cache/cache_entry.h |   40 +-
 .../ignite/cache/event/cache_entry_event.h      |  139 +
 .../cache/event/cache_entry_event_listener.h    |   71 +
 .../cache/query/continuous/continuous_query.h   |  239 ++
 .../query/continuous/continuous_query_handle.h  |  133 +
 .../include/ignite/cache/query/query_cursor.h   |    4 +-
 .../core/include/ignite/impl/cache/cache_impl.h |  116 +-
 .../continuous/continuous_query_handle_impl.h   |  101 +
 .../query/continuous/continuous_query_impl.h    |  351 ++
 .../core/include/ignite/impl/handle_registry.h  |   62 +-
 .../include/ignite/impl/ignite_environment.h    |   34 +-
 .../cpp/core/include/ignite/impl/operations.h   |    4 +-
 modules/platforms/cpp/core/namespaces.dox       |   74 +-
 .../platforms/cpp/core/project/vs/core.vcxproj  |    7 +
 .../cpp/core/project/vs/core.vcxproj.filters    |   30 +
 modules/platforms/cpp/core/src/ignition.cpp     |   15 +-
 .../cpp/core/src/impl/cache/cache_impl.cpp      |   32 +
 .../continuous/continuous_query_handle_impl.cpp |   96 +
 .../cpp/core/src/impl/handle_registry.cpp       |  102 +-
 .../cpp/core/src/impl/ignite_environment.cpp    |  146 +-
 .../platforms/cpp/core/src/impl/ignite_impl.cpp |    4 +-
 modules/platforms/cpp/examples/Makefile.am      |    1 +
 modules/platforms/cpp/examples/configure.ac     |    3 +-
 .../continuous-query-example/Makefile.am        |   58 +
 .../config/continuous-query-example.xml         |   52 +
 .../project/vs/continuous-query-example.vcxproj |  110 +
 .../vs/continuous-query-example.vcxproj.filters |   35 +
 .../src/continuous_query_example.cpp            |  142 +
 .../examples/include/ignite/examples/person.h   |    2 +-
 .../cpp/examples/odbc-example/Makefile.am       |    2 +-
 .../cpp/examples/project/vs/ignite-examples.sln |    6 +
 .../cpp/examples/putget-example/Makefile.am     |    2 +-
 .../cpp/examples/query-example/Makefile.am      |    2 +-
 modules/platforms/cpp/ignite/Makefile.am        |    2 +-
 modules/platforms/cpp/jni/Makefile.am           |    2 +-
 .../cpp/jni/include/ignite/jni/exports.h        |    3 -
 .../platforms/cpp/jni/include/ignite/jni/java.h |   94 +-
 .../platforms/cpp/jni/project/vs/jni.vcxproj    |    1 +
 modules/platforms/cpp/jni/project/vs/module.def |    6 +-
 modules/platforms/cpp/jni/src/exports.cpp       |    8 -
 modules/platforms/cpp/jni/src/java.cpp          |  421 +-
 modules/platforms/cpp/odbc-test/Makefile.am     |    3 +-
 .../cpp/odbc-test/config/queries-default.xml    |  146 +
 .../odbc-test/config/queries-test-noodbc.xml    |   84 +-
 .../cpp/odbc-test/config/queries-test.xml       |   85 +-
 .../platforms/cpp/odbc-test/include/Makefile.am |    1 +
 .../cpp/odbc-test/include/complex_type.h        |  122 +
 .../odbc-test/include/sql_test_suite_fixture.h  |   16 +
 .../platforms/cpp/odbc-test/include/test_type.h |   20 +-
 .../cpp/odbc-test/include/test_utils.h          |   51 +-
 .../cpp/odbc-test/project/vs/odbc-test.vcxproj  |    6 +-
 .../project/vs/odbc-test.vcxproj.filters        |    6 +
 .../cpp/odbc-test/src/api_robustness_test.cpp   |  150 +-
 .../src/application_data_buffer_test.cpp        |   24 +-
 .../platforms/cpp/odbc-test/src/column_test.cpp |  189 +
 .../cpp/odbc-test/src/queries_test.cpp          |  248 +-
 .../src/sql_aggregate_functions_test.cpp        |    5 +-
 .../src/sql_date_time_functions_test.cpp        |   26 +-
 .../src/sql_esc_convert_function_test.cpp       |  160 +
 .../src/sql_numeric_functions_test.cpp          |    1 +
 .../cpp/odbc-test/src/sql_outer_join_test.cpp   |    1 +
 .../odbc-test/src/sql_string_functions_test.cpp |    1 +
 .../odbc-test/src/sql_test_suite_fixture.cpp    |  105 +-
 .../cpp/odbc-test/src/sql_types_test.cpp        |  256 ++
 .../platforms/cpp/odbc-test/src/test_utils.cpp  |   60 +-
 .../cpp/odbc-test/src/utility_test.cpp          |   27 +-
 modules/platforms/cpp/odbc/Makefile.am          |    5 +-
 modules/platforms/cpp/odbc/include/Makefile.am  |    3 +-
 .../cpp/odbc/include/ignite/odbc/common_types.h |   29 +-
 .../ignite/odbc/config/connection_info.h        |    2 -
 .../cpp/odbc/include/ignite/odbc/log.h          |  123 +
 .../odbc/include/ignite/odbc/meta/column_meta.h |    2 -
 .../cpp/odbc/include/ignite/odbc/statement.h    |  143 +-
 .../cpp/odbc/include/ignite/odbc/utility.h      |   26 +-
 .../cpp/odbc/install/ignite-odbc-amd64.wxs      |    2 +-
 .../cpp/odbc/install/ignite-odbc-x86.wxs        |    2 +-
 .../odbc/os/linux/src/system/socket_client.cpp  |    9 +-
 .../odbc/os/win/src/system/socket_client.cpp    |    9 +-
 .../src/system/ui/dsn_configuration_window.cpp  |   18 +-
 .../cpp/odbc/os/win/src/system_dsn.cpp          |   17 +-
 .../platforms/cpp/odbc/project/vs/odbc.vcxproj  |    2 +
 .../cpp/odbc/project/vs/odbc.vcxproj.filters    |    6 +
 .../odbc/src/app/application_data_buffer.cpp    |   66 +-
 .../platforms/cpp/odbc/src/app/parameter.cpp    |    4 +-
 modules/platforms/cpp/odbc/src/column.cpp       |   65 +-
 .../cpp/odbc/src/config/connection_info.cpp     |  267 +-
 modules/platforms/cpp/odbc/src/connection.cpp   |   21 +-
 .../odbc/src/diagnostic/diagnosable_adapter.cpp |    3 +-
 .../odbc/src/diagnostic/diagnostic_record.cpp   |   38 +
 modules/platforms/cpp/odbc/src/entry_points.cpp |   52 +-
 modules/platforms/cpp/odbc/src/log.cpp          |   83 +
 .../platforms/cpp/odbc/src/meta/column_meta.cpp |    4 -
 modules/platforms/cpp/odbc/src/odbc.cpp         |  286 +-
 .../odbc/src/query/column_metadata_query.cpp    |   13 +-
 .../platforms/cpp/odbc/src/query/data_query.cpp |   23 +-
 .../cpp/odbc/src/query/table_metadata_query.cpp |   12 +-
 modules/platforms/cpp/odbc/src/statement.cpp    |  187 +-
 modules/platforms/cpp/odbc/src/type_traits.cpp  |    3 +
 modules/platforms/cpp/odbc/src/utility.cpp      |   39 +-
 modules/platforms/cpp/project/vs/ignite.slnrel  |    3 +
 .../platforms/cpp/project/vs/ignite_x86.slnrel  |    3 +
 .../Apache.Ignite.AspNet.Tests.csproj           |    7 +-
 .../Properties/AssemblyInfo.cs                  |    8 +-
 .../Apache.Ignite.AspNet.csproj                 |    5 +
 .../Apache.Ignite.AspNet.nuspec                 |    2 +-
 .../Properties/AssemblyInfo.cs                  |    8 +-
 .../Apache.Ignite.Benchmarks.csproj             |    5 +
 .../Properties/AssemblyInfo.cs                  |    8 +-
 .../Properties/AssemblyInfo.cs                  |    8 +-
 .../Apache.Ignite.Core.Tests.TestDll.csproj     |    5 +
 .../Properties/AssemblyInfo.cs                  |    8 +-
 .../Apache.Ignite.Core.Tests.csproj             |   12 +
 .../Binary/BinaryBuilderSelfTest.cs             |  159 +-
 .../BinaryBuilderSelfTestArrayIdentity.cs       |   34 +
 .../Binary/BinaryCompactFooterInteropTest.cs    |   31 +-
 .../Binary/BinaryEqualityComparerTest.cs        |  279 ++
 .../Binary/BinaryStructureTest.cs               |  122 +
 .../Binary/IO/BinaryStreamsTest.cs              |   19 +
 .../Cache/CacheAbstractTest.cs                  |  648 +---
 .../Cache/CacheAbstractTransactionalTest.cs     |  904 +++++
 .../Cache/CacheConfigurationTest.cs             |    5 +-
 .../Cache/CacheLocalAtomicTest.cs               |    5 -
 .../Cache/CacheLocalTest.cs                     |    6 +-
 .../CachePartitionedAtomicNearEnabledTest.cs    |    5 -
 .../Cache/CachePartitionedAtomicTest.cs         |    5 -
 .../Cache/CachePartitionedNearEnabledTest.cs    |    7 +-
 .../Cache/CachePartitionedTest.cs               |    7 +-
 .../Cache/CacheReplicatedAtomicTest.cs          |    5 -
 .../Cache/CacheReplicatedTest.cs                |    7 +-
 .../Cache/Query/CacheDmlQueriesTest.cs          |  296 ++
 .../Cache/Query/CacheLinqTest.cs                |  168 +-
 .../Query/CacheQueriesCodeConfigurationTest.cs  |   17 +-
 .../Cache/Query/CacheQueriesTest.cs             |    8 +
 .../Cache/Store/CacheParallelLoadStoreTest.cs   |    9 +-
 .../Cache/Store/CacheStoreSessionTest.cs        |   22 +-
 .../Cache/Store/CacheStoreTest.cs               |  363 +-
 .../Cache/Store/CacheTestStore.cs               |   14 +
 .../Cache/Store/NamedNodeCacheStoreTest.cs      |   34 +
 .../Examples/Example.cs                         |    5 +-
 .../Examples/ExamplesTest.cs                    |  107 +-
 .../Apache.Ignite.Core.Tests/ExceptionsTest.cs  |   38 +
 .../Apache.Ignite.Core.Tests/ExecutableTest.cs  |    2 +-
 .../IgniteConfigurationSerializerTest.cs        |   46 +-
 .../IgniteConfigurationTest.cs                  |   28 +
 .../Log/ConcurrentMemoryTarget.cs               |   73 +
 .../Log/NLogLoggerTest.cs                       |    5 +-
 .../Apache.Ignite.Core.Tests/MessagingTest.cs   |    6 +-
 .../Properties/AssemblyInfo.cs                  |    8 +-
 .../Apache.Ignite.Core.Tests/ReconnectTest.cs   |   28 +-
 .../Services/ServicesTest.cs                    |   46 +-
 .../Apache.Ignite.Core.Tests/TestUtils.cs       |    4 +-
 .../Apache.Ignite.Core.Schema.nuspec            |    2 +-
 .../Apache.Ignite.Core.csproj                   |   25 +-
 .../Apache.Ignite.Core.nuspec                   |    2 +-
 .../Binary/BinaryArrayEqualityComparer.cs       |  149 +
 .../Binary/BinaryConfiguration.cs               |   24 +
 .../Binary/BinaryTypeConfiguration.cs           |   14 +
 .../dotnet/Apache.Ignite.Core/Binary/IBinary.cs |    3 +-
 .../Cache/Configuration/QueryEntity.cs          |   33 +-
 .../Cache/Configuration/QueryField.cs           |    6 +
 .../dotnet/Apache.Ignite.Core/Cache/ICache.cs   |    4 +-
 .../Apache.Ignite.Core/Cache/Query/QueryBase.cs |   15 +-
 .../Apache.Ignite.Core/IgniteConfiguration.cs   |   85 +-
 .../IgniteConfigurationSection.xsd              |   19 +
 .../Apache.Ignite.Core/Impl/Binary/Binary.cs    |   28 +-
 .../Binary/BinaryEqualityComparerSerializer.cs  |   99 +
 .../Impl/Binary/BinaryFieldEqualityComparer.cs  |  138 +
 .../Impl/Binary/BinaryFullTypeDescriptor.cs     |   21 +-
 .../Impl/Binary/BinaryObject.cs                 |   31 +-
 .../Impl/Binary/BinaryObjectBuilder.cs          |   62 +-
 .../Impl/Binary/BinaryObjectHeader.cs           |   21 +-
 .../Impl/Binary/BinaryObjectSchemaHolder.cs     |   22 +
 .../Impl/Binary/BinaryReader.cs                 |  153 +-
 .../Binary/BinarySurrogateTypeDescriptor.cs     |    6 +
 .../Impl/Binary/BinarySystemHandlers.cs         |    6 +-
 .../Impl/Binary/BinaryUtils.cs                  |   16 +
 .../Impl/Binary/BinaryWriter.cs                 |   11 +-
 .../Impl/Binary/DateTimeHolder.cs               |   35 +-
 .../Impl/Binary/IBinaryEqualityComparer.cs      |   53 +
 .../Impl/Binary/IBinaryTypeDescriptor.cs        |    5 +
 .../Impl/Binary/Io/BinaryHeapStream.cs          |    9 +
 .../Impl/Binary/Io/BinaryStreamBase.cs          |   17 +-
 .../Impl/Binary/Io/IBinaryStream.cs             |   11 +-
 .../Impl/Binary/Io/IBinaryStreamProcessor.cs    |   36 +
 .../Impl/Binary/Marshaller.cs                   |   22 +-
 .../Impl/Binary/SerializableObjectHolder.cs     |   16 +
 .../Apache.Ignite.Core/Impl/Cache/CacheImpl.cs  |  133 +-
 .../Apache.Ignite.Core/Impl/Common/Future.cs    |   13 +-
 .../Common/IgniteConfigurationXmlSerializer.cs  |    5 +-
 .../Impl/Common/Listenable.cs                   |   49 +
 .../Impl/Compute/ComputeImpl.cs                 |    4 +-
 .../Impl/Compute/ComputeTaskHolder.cs           |   14 +-
 .../Apache.Ignite.Core/Impl/ExceptionUtils.cs   |    6 +-
 .../Impl/Memory/PlatformMemoryStream.cs         |   16 +
 .../Apache.Ignite.Core/Impl/PlatformTarget.cs   |    2 +-
 .../Transactions/CacheTransactionManager.cs     |  161 +
 .../Impl/Transactions/Transaction.cs            |    8 +
 .../Impl/Transactions/TransactionImpl.cs        |   13 +
 .../Impl/Transactions/TransactionsImpl.cs       |   28 +
 .../Impl/Unmanaged/IgniteJniNativeMethods.cs    |    8 -
 .../Impl/Unmanaged/UnmanagedCallbackHandlers.cs |   79 +-
 .../Impl/Unmanaged/UnmanagedCallbackOp.cs       |   86 +
 .../Impl/Unmanaged/UnmanagedCallbacks.cs        | 1229 +++---
 .../Impl/Unmanaged/UnmanagedUtils.cs            |    9 +-
 .../Properties/AssemblyInfo.cs                  |    8 +-
 .../Transactions/ITransactions.cs               |   19 +-
 .../Apache.Ignite.EntityFramework.Tests.csproj  |    5 +
 .../EntityFrameworkCacheTest.cs                 |   58 +-
 .../Properties/AssemblyInfo.cs                  |    6 +-
 .../Apache.Ignite.EntityFramework.csproj        |    9 +-
 .../Apache.Ignite.EntityFramework.nuspec        |    2 +-
 .../Impl/ArrayDbDataReader.cs                   |    5 +
 .../Impl/DataReaderResult.cs                    |    2 +
 .../Impl/DbCommandInfo.cs                       |   32 +-
 .../Impl/DbCommandProxy.cs                      |    1 +
 .../Properties/AssemblyInfo.cs                  |    6 +-
 .../Apache.Ignite.Linq.csproj                   |    5 +
 .../Apache.Ignite.Linq.nuspec                   |    2 +-
 .../Impl/CacheQueryExpressionVisitor.cs         |  139 +-
 .../Impl/CacheQueryModelVisitor.cs              |    3 +
 .../Apache.Ignite.Linq/Impl/ExpressionWalker.cs |    8 +
 .../Apache.Ignite.Linq/Impl/MethodVisitor.cs    |   34 +-
 .../Properties/AssemblyInfo.cs                  |    8 +-
 .../Apache.Ignite.Log4Net.csproj                |    5 +
 .../Apache.Ignite.Log4Net.nuspec                |    2 +-
 .../IgniteLog4NetLogger.cs                      |   16 +-
 .../Properties/AssemblyInfo.cs                  |    8 +-
 .../Apache.Ignite.NLog.csproj                   |    5 +
 .../Apache.Ignite.NLog.nuspec                   |    2 +-
 .../Properties/AssemblyInfo.cs                  |    8 +-
 modules/platforms/dotnet/Apache.Ignite.sln      |    5 +
 .../dotnet/Apache.Ignite/Apache.Ignite.csproj   |    5 +
 .../Apache.Ignite/Properties/AssemblyInfo.cs    |    8 +-
 modules/platforms/dotnet/DEVNOTES.txt           |   12 +-
 modules/platforms/dotnet/README.md              |    6 +-
 modules/platforms/dotnet/build.bat              |   19 +
 modules/platforms/dotnet/build.ps1              |  211 +
 .../Apache.Ignite.Examples.csproj               |    5 +
 .../examples/Apache.Ignite.Examples/App.config  |    2 +
 .../DataStructures/AtomicSequenceExample.cs     |   26 +-
 .../Datagrid/QueryDmlExample.cs                 |  162 +
 .../Datagrid/TransactionExample.cs              |   75 +-
 .../Properties/AssemblyInfo.cs                  |    8 +-
 .../Apache.Ignite.ExamplesDll.csproj            |    4 +
 .../Properties/AssemblyInfo.cs                  |    6 +-
 .../Services/MapService.cs                      |    2 -
 modules/rest-http/pom.xml                       |    2 +-
 modules/scalar-2.10/pom.xml                     |    4 +-
 modules/scalar/pom.xml                          |    4 +-
 modules/schedule/pom.xml                        |    2 +-
 modules/schema-import-db/pom.xml                |    2 +-
 modules/schema-import/pom.xml                   |    2 +-
 modules/slf4j/pom.xml                           |    2 +-
 .../apache/ignite/logger/slf4j/Slf4jLogger.java |   11 +-
 modules/spark-2.10/pom.xml                      |   56 +-
 modules/spark/pom.xml                           |  185 +-
 .../org/apache/ignite/spark/IgniteContext.scala |   22 +-
 .../apache/ignite/spark/JavaIgniteContext.scala |    6 +
 .../spark/JavaEmbeddedIgniteRDDSelfTest.java    |   10 +-
 .../spark/JavaStandaloneIgniteRDDSelfTest.java  |   25 +-
 modules/spring/pom.xml                          |    2 +-
 .../util/spring/IgniteSpringHelperImpl.java     |    8 +-
 .../src/test/config/jdbc-pojo-store-builtin.xml |    8 +
 .../src/test/config/jdbc-pojo-store-obj.xml     |    8 +
 .../ignite/internal/GridFactorySelfTest.java    |    2 +-
 .../internal/IgniteDynamicCacheConfigTest.java  |    4 +-
 .../GridSpringTransactionManagerSelfTest.java   |    2 +-
 modules/ssh/pom.xml                             |    2 +-
 modules/storm/pom.xml                           |    2 +-
 modules/tools/pom.xml                           |    2 +-
 .../ignite/tools/classgen/ClassesGenerator.java |   14 +-
 modules/twitter/pom.xml                         |    2 +-
 .../twitter/IgniteTwitterStreamerTest.java      |    4 +-
 modules/urideploy/pom.xml                       |    2 +-
 .../spi/deployment/uri/UriDeploymentSpi.java    |    2 +-
 .../GridUriDeploymentFileProcessorSelfTest.java |    3 +-
 modules/visor-console-2.10/pom.xml              |    2 +-
 modules/visor-console/pom.xml                   |    2 +-
 .../scala/org/apache/ignite/visor/visor.scala   |  115 +-
 .../commands/mem/VisorMemoryCommandSpec.scala   |   33 +
 modules/visor-plugins/pom.xml                   |    2 +-
 modules/web-console/backend/app/agent.js        |   71 +-
 modules/web-console/backend/app/browser.js      |   39 +
 modules/web-console/backend/app/mongo.js        |   92 +-
 modules/web-console/backend/app/routes.js       |    5 +-
 .../web-console/backend/routes/activities.js    |   45 +
 modules/web-console/backend/routes/admin.js     |    2 +-
 modules/web-console/backend/routes/agent.js     |   10 +-
 modules/web-console/backend/routes/demo.js      |   17 +-
 modules/web-console/backend/routes/profile.js   |    5 +-
 modules/web-console/backend/routes/public.js    |    1 -
 .../web-console/backend/services/activities.js  |  116 +
 .../web-console/backend/services/notebooks.js   |   14 +-
 .../web-console/backend/services/sessions.js    |   12 +-
 modules/web-console/backend/services/spaces.js  |   15 +
 modules/web-console/backend/services/users.js   |   20 +-
 .../backend/test/unit/ActivitiesService.test.js |  131 +
 modules/web-console/frontend/app/app.config.js  |   13 +
 modules/web-console/frontend/app/app.js         |   34 +-
 .../activities-user-dialog.controller.js        |   27 +
 .../activities-user-dialog.jade                 |   36 +
 .../components/activities-user-dialog/index.js  |   35 +
 .../form-field-datepicker.jade                  |   55 +
 .../form-field-datepicker.scss                  |   20 +
 .../list-of-registered-users/index.js           |   28 +
 .../list-of-registered-users.categories.js      |   30 +
 .../list-of-registered-users.column-defs.js     |   80 +
 .../list-of-registered-users.controller.js      |  235 ++
 .../list-of-registered-users.jade               |   58 +
 .../ui-grid-header/ui-grid-header.jade          |   27 +
 .../ui-grid-header/ui-grid-header.scss          |   84 +
 .../ui-grid-settings/ui-grid-settings.jade      |   33 +
 .../ui-grid-settings/ui-grid-settings.scss      |   99 +
 .../controllers/reset-password.controller.js    |   14 +-
 .../app/core/activities/Activities.data.js      |   34 +
 .../frontend/app/core/admin/Admin.data.js       |   77 +
 modules/web-console/frontend/app/core/index.js  |   25 +
 .../frontend/app/data/event-groups.json         |  169 +
 .../frontend/app/data/event-types.json          |  169 -
 modules/web-console/frontend/app/data/i18n.js   |   39 +
 .../frontend/app/data/pom-dependencies.json     |   12 +-
 .../ui-ace-docker/ui-ace-docker.controller.js   |    2 +-
 .../directives/ui-ace-docker/ui-ace-docker.jade |    2 +-
 .../ui-ace-pojos/ui-ace-pojos.controller.js     |   12 +-
 .../ui-ace-pom/ui-ace-pom.controller.js         |    4 +-
 .../ui-grid-settings/ui-grid-settings.jade      |   33 -
 .../ui-grid-settings/ui-grid-settings.scss      |   38 -
 .../app/filters/uiGridSubcategories.filter.js   |   24 +
 .../helpers/jade/form/form-field-dropdown.jade  |    5 +-
 .../helpers/jade/form/form-field-number.jade    |    3 +-
 .../app/helpers/jade/form/form-field-text.jade  |   19 +-
 .../frontend/app/helpers/jade/mixins.jade       |   52 +-
 .../frontend/app/modules/Demo/Demo.module.js    |  166 -
 .../frontend/app/modules/agent/agent.module.js  |   15 -
 .../app/modules/branding/branding.provider.js   |    2 +-
 .../configuration/EventGroups.provider.js       |   30 -
 .../modules/configuration/Version.service.js    |   39 +-
 .../configuration/configuration.module.js       |   63 +-
 .../generator/AbstractTransformer.js            |   22 +
 .../modules/configuration/generator/Beans.js    |    9 +
 .../generator/ConfigurationGenerator.js         | 2816 +++++++-------
 .../configuration/generator/Custom.service.js   |   23 +
 .../configuration/generator/Docker.service.js   |    4 +-
 .../generator/JavaTransformer.service.js        | 2318 +++++------
 .../configuration/generator/Maven.service.js    |  236 ++
 .../configuration/generator/Pom.service.js      |  233 --
 .../generator/Properties.service.js             |    2 +-
 .../configuration/generator/Readme.service.js   |    2 +-
 .../generator/SharpTransformer.service.js       |  437 ++-
 .../generator/SpringTransformer.service.js      |  497 ++-
 .../defaults/Cache.platform.service.js          |   56 +
 .../generator/defaults/Cache.service.js         |  131 +
 .../defaults/Cluster.platform.service.js        |   43 +
 .../generator/defaults/Cluster.service.js       |  289 ++
 .../generator/defaults/Event-groups.service.js  |   27 +
 .../generator/defaults/IGFS.service.js          |   64 +
 .../defaults/cache.platform.provider.js         |   60 -
 .../generator/defaults/cache.provider.js        |  137 -
 .../defaults/cluster.platform.provider.js       |   49 -
 .../generator/defaults/cluster.provider.js      |  293 --
 .../generator/defaults/igfs.provider.js         |   68 -
 .../configuration/generator/generator-common.js |  625 ---
 .../configuration/generator/generator-java.js   | 3617 ------------------
 .../generator/generator-optional.js             |   25 -
 .../configuration/generator/generator-spring.js | 2111 ----------
 .../frontend/app/modules/demo/Demo.module.js    |  172 +
 .../frontend/app/modules/sql/Notebook.data.js   |   11 +-
 .../app/modules/sql/Notebook.service.js         |    2 +-
 .../app/modules/sql/scan-filter-input.jade      |   39 -
 .../modules/sql/scan-filter-input.service.js    |   51 -
 .../frontend/app/modules/sql/sql.controller.js  |  221 +-
 .../frontend/app/modules/sql/sql.module.js      |    4 +-
 .../frontend/app/modules/states/admin.state.js  |    2 +-
 .../app/modules/states/configuration.state.js   |    2 +
 .../states/configuration/caches/affinity.jade   |   82 +
 .../states/configuration/caches/memory.jade     |    4 +-
 .../configuration/caches/node-filter.jade       |    2 +-
 .../states/configuration/caches/query.jade      |    3 +
 .../states/configuration/caches/store.jade      |    4 +-
 .../configuration/clusters/checkpoint.jade      |   11 +-
 .../configuration/clusters/checkpoint/fs.jade   |    8 +-
 .../configuration/clusters/checkpoint/jdbc.jade |    8 +-
 .../configuration/clusters/checkpoint/s3.jade   |   25 +-
 .../clusters/collision/custom.jade              |    2 +-
 .../clusters/collision/job-stealing.jade        |    2 +-
 .../configuration/clusters/deployment.jade      |  129 +-
 .../states/configuration/clusters/events.jade   |    4 +-
 .../states/configuration/clusters/failover.jade |    4 +-
 .../clusters/general/discovery/zookeeper.jade   |    2 +-
 .../discovery/zookeeper/retrypolicy/custom.jade |    2 +-
 .../configuration/clusters/load-balancing.jade  |   23 +-
 .../configuration/clusters/logger/custom.jade   |    2 +-
 .../states/configuration/clusters/ssl.jade      |    2 +-
 .../summary/summary-zipper.service.js           |   37 +
 .../configuration/summary/summary.controller.js |  103 +-
 .../configuration/summary/summary.worker.js     |  119 +
 .../app/modules/user/AclRoute.provider.js       |   31 +-
 .../frontend/app/modules/user/Auth.service.js   |   11 +-
 .../frontend/app/modules/user/permissions.js    |    2 +-
 .../frontend/app/modules/user/user.module.js    |    6 +-
 .../frontend/app/services/JavaTypes.service.js  |   13 +-
 .../frontend/app/services/Messages.service.js   |   17 +-
 modules/web-console/frontend/app/vendor.js      |    1 +
 .../frontend/controllers/admin-controller.js    |   93 -
 .../frontend/controllers/caches-controller.js   |   22 +-
 .../frontend/controllers/clusters-controller.js |   42 +-
 .../frontend/controllers/domains-controller.js  |   44 +-
 .../frontend/controllers/igfs-controller.js     |   20 +-
 .../frontend/controllers/profile-controller.js  |    3 +-
 .../gulpfile.babel.js/webpack/common.js         |   17 +-
 .../webpack/environments/development.js         |   14 +-
 .../webpack/environments/production.js          |    3 +-
 .../webpack/plugins/progress.js                 |   82 -
 modules/web-console/frontend/package.json       |  181 +-
 .../frontend/public/images/cache.png            |  Bin 23700 -> 24791 bytes
 .../frontend/public/images/domains.png          |  Bin 23828 -> 22131 bytes
 .../web-console/frontend/public/images/igfs.png |  Bin 14307 -> 14139 bytes
 .../frontend/public/images/query-chart.png      |  Bin 16637 -> 17142 bytes
 .../frontend/public/images/query-metadata.png   |  Bin 32298 -> 39361 bytes
 .../frontend/public/images/query-table.png      |  Bin 29189 -> 28065 bytes
 .../frontend/public/images/summary.png          |  Bin 31997 -> 33650 bytes
 .../stylesheets/_font-awesome-custom.scss       |   51 +-
 .../frontend/public/stylesheets/form-field.scss |   37 +
 .../frontend/public/stylesheets/style.scss      |  140 +-
 .../frontend/test/unit/JavaTypes.test.js        |   17 +-
 .../frontend/test/unit/Version.test.js          |   34 +-
 .../frontend/views/configuration/caches.jade    |    1 +
 .../views/configuration/domains-import.jade     |    5 +-
 .../frontend/views/configuration/summary.jade   |   25 +-
 .../frontend/views/settings/admin.jade          |   61 +-
 .../frontend/views/sql/notebook-new.jade        |    2 +-
 modules/web-console/frontend/views/sql/sql.jade |  237 +-
 .../views/templates/agent-download.jade         |   12 +-
 .../frontend/views/templates/alert.jade         |    2 +-
 .../frontend/views/templates/select.jade        |    2 +-
 modules/web-console/pom.xml                     |    2 +-
 modules/web-console/web-agent/README.txt        |    2 +-
 .../web-agent/bin/ignite-web-agent.bat          |    4 +-
 .../web-agent/bin/ignite-web-agent.sh           |    2 +
 modules/web-console/web-agent/pom.xml           |    2 +-
 .../ignite/console/agent/AgentLauncher.java     |  259 +-
 .../apache/ignite/console/agent/AgentUtils.java |   80 +
 .../console/agent/handlers/AbstractHandler.java |  110 -
 .../agent/handlers/AbstractListener.java        |  104 +
 .../console/agent/handlers/DatabaseHandler.java |  298 --
 .../agent/handlers/DatabaseListener.java        |  316 ++
 .../console/agent/handlers/RestHandler.java     |  276 --
 .../console/agent/handlers/RestListener.java    |  287 ++
 .../ignite/console/demo/AgentClusterDemo.java   |  475 +--
 .../ignite/console/demo/AgentDemoUtils.java     |   79 +
 .../demo/service/DemoCachesLoadService.java     |  456 +++
 .../service/DemoRandomCacheLoadService.java     |  120 +
 .../service/DemoServiceClusterSingleton.java    |   41 +
 .../demo/service/DemoServiceKeyAffinity.java    |   41 +
 .../service/DemoServiceMultipleInstances.java   |   41 +
 .../demo/service/DemoServiceNodeSingleton.java  |   41 +
 modules/web/ignite-appserver-test/pom.xml       |    2 +-
 modules/web/ignite-websphere-test/pom.xml       |    2 +-
 modules/web/pom.xml                             |    2 +-
 .../ignite/cache/websession/WebSessionV2.java   |    2 +-
 .../internal/websession/WebSessionSelfTest.java |    6 +-
 modules/yardstick/DEVNOTES-standalone.txt       |   16 +
 modules/yardstick/DEVNOTES.txt                  |   20 +
 modules/yardstick/README.txt                    |  140 +-
 .../config/benchmark-atomic-win.properties      |    2 +-
 .../config/benchmark-atomic.properties          |   35 +-
 .../config/benchmark-bin-identity.properties    |   16 +-
 .../config/benchmark-cache-load-win.properties  |    2 +-
 .../config/benchmark-cache-load.properties      |    4 +-
 .../config/benchmark-client-mode.properties     |   68 +-
 .../config/benchmark-compute-win.properties     |    2 +-
 .../config/benchmark-compute.properties         |   30 +-
 .../config/benchmark-failover.properties        |    2 +-
 .../yardstick/config/benchmark-full.properties  |   62 +-
 .../config/benchmark-multicast.properties       |  107 +-
 .../config/benchmark-put-indexed-val.properties |   23 +-
 .../benchmark-query-put-separated.properties    |    3 +-
 .../config/benchmark-query-win.properties       |    2 +-
 .../yardstick/config/benchmark-query.properties |   33 +-
 .../config/benchmark-remote-sample.properties   |   80 +
 .../config/benchmark-remote.properties          |  119 +
 .../config/benchmark-sample.properties          |   80 +
 .../config/benchmark-sql-dml.properties         |   36 +-
 .../yardstick/config/benchmark-store.properties |    3 +-
 .../config/benchmark-tx-win.properties          |    2 +-
 .../yardstick/config/benchmark-tx.properties    |   33 +-
 .../yardstick/config/benchmark-win.properties   |    2 +-
 modules/yardstick/config/benchmark.properties   |   76 +-
 .../yardstick/config/ignite-remote-config.xml   |   47 +
 .../test-max-int-values-offheap.properties      |    3 +-
 .../test-max-int-values-onheap.properties       |    3 +-
 .../config/test-max-int-values-swap.properties  |    3 +-
 modules/yardstick/pom-standalone.xml            |  209 +
 modules/yardstick/pom.xml                       |   16 +-
 .../yardstick/IgniteAbstractBenchmark.java      |   30 +
 .../yardstick/IgniteBenchmarkArguments.java     |   33 +
 .../ignite/yardstick/IgniteBenchmarkUtils.java  |   48 +-
 .../org/apache/ignite/yardstick/IgniteNode.java |    2 +-
 .../apache/ignite/yardstick/PreloadLogger.java  |  155 +
 .../yardstick/cache/CacheEntryEventProbe.java   |    2 +-
 .../cache/IgnitePutRemoveBenchmark.java         |   42 +
 .../cache/IgnitePutRemoveTxBenchmark.java       |   30 +
 .../cache/IgnitePutValue8Benchmark.java         |   42 +
 .../IgniteCacheRandomOperationBenchmark.java    |   74 +-
 .../io/IgniteIoTestAbstractBenchmark.java       |   61 +
 .../io/IgniteIoTestSendAllBenchmark.java        |   32 +
 .../io/IgniteIoTestSendRandomBenchmark.java     |   35 +
 modules/yarn/pom.xml                            |    2 +-
 .../apache/ignite/yarn/ApplicationMaster.java   |    4 +-
 .../org/apache/ignite/yarn/IgniteProvider.java  |    4 +-
 modules/zeromq/README.txt                       |   37 +
 modules/zeromq/licenses/apache-2.0.txt          |  202 +
 modules/zeromq/pom.xml                          |   75 +
 .../stream/zeromq/IgniteZeroMqStreamer.java     |  146 +
 .../ignite/stream/zeromq/ZeroMqTypeSocket.java  |   56 +
 .../ignite/stream/zeromq/package-info.java      |   21 +
 .../stream/zeromq/IgniteZeroMqStreamerTest.java |  235 ++
 .../zeromq/IgniteZeroMqStreamerTestSuite.java   |   37 +
 .../ZeroMqStringSingleTupleExtractor.java       |   46 +
 .../ignite/stream/zeromq/package-info.java      |   21 +
 modules/zookeeper/pom.xml                       |    2 +-
 .../tcp/ipfinder/zk/ZookeeperIpFinderTest.java  |    2 +-
 parent/pom.xml                                  |    7 +-
 pom.xml                                         |  103 +-
 1389 files changed, 57337 insertions(+), 26692 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/bc7a9bd8/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/GridCacheProcessor.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/bc7a9bd8/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/atomic/GridDhtAtomicCache.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/bc7a9bd8/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/atomic/GridNearAtomicAbstractUpdateFuture.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/bc7a9bd8/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/atomic/GridNearAtomicSingleUpdateFuture.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/bc7a9bd8/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/dht/atomic/GridNearAtomicUpdateFuture.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/bc7a9bd8/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/GridCacheAbstractFullApiSelfTest.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/bc7a9bd8/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/IgniteCacheClientNodeChangingTopologyTest.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/bc7a9bd8/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/distributed/dht/atomic/GridCacheAtomicInvalidPartitionHandlingSelfTest.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/bc7a9bd8/modules/core/src/test/java/org/apache/ignite/internal/processors/cache/expiry/IgniteCacheExpiryPolicyAbstractTest.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/bc7a9bd8/modules/platforms/dotnet/Apache.Ignite.Core.Tests/Cache/CacheConfigurationTest.cs
----------------------------------------------------------------------