You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ignite.apache.org by sh...@apache.org on 2016/11/07 04:30:37 UTC

[50/50] [abbrv] ignite git commit: Merge branch 'master' into ignite-2788

Merge branch 'master' into ignite-2788


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

Branch: refs/heads/ignite-2788
Commit: 0cd6723d2e413be61d31827a9f0444d4253a30ed
Parents: a8dae9d 45bb1ac
Author: shtykh_roman <rs...@yahoo.com>
Authored: Mon Nov 7 13:28:04 2016 +0900
Committer: shtykh_roman <rs...@yahoo.com>
Committed: Mon Nov 7 13:28:04 2016 +0900

----------------------------------------------------------------------
 .gitignore                                      |    42 +-
 RELEASE_NOTES.txt                               |   108 +
 assembly/LICENSE_FABRIC                         |     3 +-
 assembly/LICENSE_HADOOP                         |     1 -
 assembly/dependencies-fabric-lgpl.xml           |     4 +-
 assembly/dependencies-fabric.xml                |     4 +-
 assembly/dependencies-schema-import.xml         |     1 +
 assembly/libs/README.txt                        |    39 +-
 assembly/release-fabric-base.xml                |    30 +
 assembly/release-schema-import.xml              |     2 +-
 bin/include/hadoop-classpath.bat                |    73 -
 bin/include/hadoop-classpath.sh                 |    65 -
 bin/include/setenv.bat                          |    10 -
 bin/include/setenv.sh                           |    12 -
 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 +
 .../hibernate/HibernateL2CacheExample.java      |     2 +-
 .../CacheContinuousAsyncQueryExample.java       |   138 +
 .../datagrid/CacheContinuousQueryExample.java   |    13 +-
 .../examples/datagrid/CacheQueryExample.java    |    78 +-
 .../datastructures/IgniteLockExample.java       |   293 +
 .../ignite/examples/CacheExamplesSelfTest.java  |     8 +
 .../examples/IndexingBridgeMethodTest.java      |    93 +
 .../IgniteExamplesJ8SelfTestSuite.java          |     2 +
 modules/aop/pom.xml                             |     2 +-
 modules/apache-license-gen/pom.xml              |     2 +-
 modules/aws/pom.xml                             |     2 +-
 .../s3/S3CheckpointManagerSelfTest.java         |     3 +
 .../checkpoint/s3/S3CheckpointSpiSelfTest.java  |     4 +
 .../s3/S3CheckpointSpiStartStopSelfTest.java    |     7 +
 .../s3/S3SessionCheckpointSelfTest.java         |     2 +
 .../s3/TcpDiscoveryS3IpFinderSelfTest.java      |     7 +
 .../ignite/testsuites/IgniteS3TestSuite.java    |    15 +-
 modules/benchmarks/pom.xml                      |     6 +-
 .../jmh/notify/JmhParkVsNotifyBenchmark.java    |   105 +
 .../jmh/notify/JmhWaitStategyBenchmark.java     |   259 +
 .../internal/benchmarks/model/IntValue.java     |    19 +-
 modules/camel/pom.xml                           |     2 +-
 modules/cassandra/README.txt                    |    28 +
 modules/cassandra/pom.xml                       |    52 +
 modules/cassandra/serializers/README.txt        |    33 +
 .../serializers/licenses/apache-2.0.txt         |   202 +
 modules/cassandra/serializers/pom.xml           |   129 +
 .../cassandra/serializer/KryoSerializer.java    |    95 +
 .../apache/ignite/tests/KryoSerializerTest.java |    70 +
 .../java/org/apache/ignite/tests/MyPojo.java    |   102 +
 modules/cassandra/store/README.txt              |    32 +
 modules/cassandra/store/licenses/apache-2.0.txt |   202 +
 modules/cassandra/store/pom.xml                 |   305 +
 .../store/cassandra/CassandraCacheStore.java    |   519 +
 .../cassandra/CassandraCacheStoreFactory.java   |   200 +
 .../store/cassandra/common/CassandraHelper.java |   176 +
 .../cassandra/common/PropertyMappingHelper.java |   219 +
 .../store/cassandra/common/RandomSleeper.java   |   104 +
 .../store/cassandra/common/SystemHelper.java    |    46 +
 .../store/cassandra/common/package-info.java    |    21 +
 .../store/cassandra/datasource/Credentials.java |    39 +
 .../store/cassandra/datasource/DataSource.java  |   647 +
 .../cassandra/datasource/PlainCredentials.java  |    53 +
 .../cassandra/datasource/package-info.java      |    21 +
 .../cache/store/cassandra/package-info.java     |    21 +
 .../persistence/KeyPersistenceSettings.java     |   305 +
 .../KeyValuePersistenceSettings.java            |   526 +
 .../persistence/PersistenceController.java      |   462 +
 .../persistence/PersistenceSettings.java        |   446 +
 .../persistence/PersistenceStrategy.java        |    62 +
 .../store/cassandra/persistence/PojoField.java  |   245 +
 .../cassandra/persistence/PojoKeyField.java     |    87 +
 .../cassandra/persistence/PojoValueField.java   |   143 +
 .../persistence/ValuePersistenceSettings.java   |   120 +
 .../cassandra/persistence/package-info.java     |    21 +
 .../cassandra/serializer/JavaSerializer.java    |    80 +
 .../store/cassandra/serializer/Serializer.java  |    43 +
 .../cassandra/serializer/package-info.java      |    21 +
 .../session/BatchExecutionAssistant.java        |   102 +
 .../cassandra/session/BatchLoaderAssistant.java |    47 +
 .../cassandra/session/CassandraSession.java     |    70 +
 .../cassandra/session/CassandraSessionImpl.java |   943 ++
 .../cassandra/session/ExecutionAssistant.java   |    84 +
 .../session/GenericBatchExecutionAssistant.java |    71 +
 .../session/LoadCacheCustomQueryWorker.java     |   105 +
 .../store/cassandra/session/package-info.java   |    21 +
 .../cassandra/session/pool/SessionPool.java     |   173 +
 .../cassandra/session/pool/SessionWrapper.java  |    71 +
 .../cassandra/session/pool/package-info.java    |    21 +
 .../session/transaction/BaseMutation.java       |    68 +
 .../session/transaction/DeleteMutation.java     |    57 +
 .../cassandra/session/transaction/Mutation.java |    63 +
 .../session/transaction/WriteMutation.java      |    60 +
 .../session/transaction/package-info.java       |    21 +
 .../store/cassandra/utils/DDLGenerator.java     |    76 +
 .../store/cassandra/utils/package-info.java     |    21 +
 .../store/src/test/bootstrap/aws/README.txt     |    13 +
 .../aws/cassandra/cassandra-bootstrap.sh        |   336 +
 .../bootstrap/aws/cassandra/cassandra-env.sh    |   287 +
 .../bootstrap/aws/cassandra/cassandra-start.sh  |   217 +
 .../aws/cassandra/cassandra-template.yaml       |   888 ++
 .../store/src/test/bootstrap/aws/common.sh      |  1481 ++
 .../store/src/test/bootstrap/aws/env.sh         |   113 +
 .../test/bootstrap/aws/ganglia/agent-start.sh   |    75 +
 .../bootstrap/aws/ganglia/ganglia-bootstrap.sh  |   417 +
 .../bootstrap/aws/ignite/ignite-bootstrap.sh    |   336 +
 .../ignite/ignite-cassandra-server-template.xml |   190 +
 .../src/test/bootstrap/aws/ignite/ignite-env.sh |    29 +
 .../test/bootstrap/aws/ignite/ignite-start.sh   |   266 +
 .../src/test/bootstrap/aws/logs-collector.sh    |   173 +
 .../tests/ignite-cassandra-client-template.xml  |   192 +
 .../test/bootstrap/aws/tests/tests-bootstrap.sh |   317 +
 .../test/bootstrap/aws/tests/tests-manager.sh   |   458 +
 .../test/bootstrap/aws/tests/tests-report.sh    |   499 +
 .../CassandraDirectPersistenceLoadTest.java     |   107 +
 .../tests/CassandraDirectPersistenceTest.java   |   696 +
 .../ignite/tests/CassandraLocalServer.java      |    59 +
 .../apache/ignite/tests/DDLGeneratorTest.java   |    57 +
 .../tests/DatasourceSerializationTest.java      |   158 +
 .../tests/IgnitePersistentStoreLoadTest.java    |   111 +
 .../ignite/tests/IgnitePersistentStoreTest.java |   666 +
 .../LoadTestsCassandraArtifactsCreator.java     |   104 +
 .../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/cassandra/package-info.java      |    21 +
 .../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 +
 .../ignite/tests/load/ignite/package-info.java  |    21 +
 .../apache/ignite/tests/load/package-info.java  |    21 +
 .../org/apache/ignite/tests/package-info.java   |    21 +
 .../org/apache/ignite/tests/pojos/Person.java   |   279 +
 .../org/apache/ignite/tests/pojos/PersonId.java |   110 +
 .../org/apache/ignite/tests/pojos/Product.java  |   123 +
 .../apache/ignite/tests/pojos/ProductOrder.java |   148 +
 .../apache/ignite/tests/pojos/package-info.java |    21 +
 .../ignite/tests/utils/CacheStoreHelper.java    |    77 +
 .../tests/utils/CassandraAdminCredentials.java  |    38 +
 .../ignite/tests/utils/CassandraHelper.java     |   358 +
 .../tests/utils/CassandraLifeCycleBean.java     |   149 +
 .../utils/CassandraRegularCredentials.java      |    38 +
 .../ignite/tests/utils/TestCacheSession.java    |    95 +
 .../ignite/tests/utils/TestTransaction.java     |   132 +
 .../apache/ignite/tests/utils/TestsHelper.java  |   660 +
 .../apache/ignite/tests/utils/package-info.java |    21 +
 .../store/src/test/resources/log4j.properties   |   119 +
 .../tests/cassandra/connection-settings.xml     |    52 +
 .../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    |    94 +
 .../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    |   169 +
 .../ignite/tests/persistence/pojo/order.xml     |    21 +
 .../persistence/pojo/persistence-settings-1.xml |    21 +
 .../persistence/pojo/persistence-settings-2.xml |    21 +
 .../persistence/pojo/persistence-settings-3.xml |   175 +
 .../persistence/pojo/persistence-settings-4.xml |   175 +
 .../ignite/tests/persistence/pojo/product.xml   |    21 +
 .../persistence/primitive/ignite-config.xml     |    94 +
 .../primitive/ignite-remote-client-config.xml   |    99 +
 .../primitive/ignite-remote-server-config.xml   |   110 +
 .../primitive/persistence-settings-1.xml        |    21 +
 .../primitive/persistence-settings-2.xml        |    21 +
 .../store/src/test/resources/tests.properties   |    65 +
 .../src/test/scripts/cassandra-load-tests.bat   |    41 +
 .../src/test/scripts/cassandra-load-tests.sh    |    39 +
 .../src/test/scripts/ignite-load-tests.bat      |    41 +
 .../store/src/test/scripts/ignite-load-tests.sh |    39 +
 .../cassandra/store/src/test/scripts/jvm-opt.sh |    21 +
 .../store/src/test/scripts/jvm-opts.bat         |    24 +
 .../scripts/recreate-cassandra-artifacts.bat    |    41 +
 .../scripts/recreate-cassandra-artifacts.sh     |    39 +
 modules/clients/pom.xml                         |    10 +-
 modules/clients/src/test/config/jdbc-config.xml |     3 +-
 .../client/ClientDefaultCacheSelfTest.java      |   119 +-
 .../ignite/internal/client/ClientHttpTask.java  |    33 +-
 .../client/ClientReconnectionSelfTest.java      |     4 +-
 .../ignite/internal/client/ClientTcpTask.java   |    10 +-
 .../ClientAbstractMultiNodeSelfTest.java        |     8 +-
 .../integration/ClientAbstractSelfTest.java     |    92 +-
 .../client/router/TcpSslRouterSelfTest.java     |     7 +-
 .../client/suite/IgniteClientTestSuite.java     |    71 +-
 .../internal/jdbc2/JdbcConnectionSelfTest.java  |     2 +
 .../jdbc2/JdbcDistributedJoinsQueryTest.java    |   319 +
 .../internal/jdbc2/JdbcMetadataSelfTest.java    |    63 +-
 .../internal/jdbc2/JdbcNoDefaultCacheTest.java  |   161 +
 .../internal/jdbc2/JdbcResultSetSelfTest.java   |     4 +-
 .../JettyRestProcessorAbstractSelfTest.java     |  1586 +-
 .../rest/JettyRestProcessorSignedSelfTest.java  |     5 +-
 .../JettyRestProcessorUnsignedSelfTest.java     |     5 +-
 .../internal/processors/rest/SimplePerson.java  |    74 +
 .../ignite/jdbc/JdbcMetadataSelfTest.java       |    18 +
 .../ignite/jdbc/JdbcNoDefaultCacheTest.java     |   161 +
 .../ignite/jdbc/JdbcResultSetSelfTest.java      |     4 +-
 .../jdbc/suite/IgniteJdbcDriverTestSuite.java   |     5 +
 modules/cloud/pom.xml                           |     2 +-
 .../TcpDiscoveryCloudIpFinderSelfTest.java      |     6 +-
 .../ignite/testsuites/IgniteCloudTestSuite.java |     5 +-
 modules/codegen/pom.xml                         |     2 +-
 .../ignite/codegen/MessageCodeGenerator.java    |   139 +-
 modules/core/pom.xml                            |    23 +-
 .../src/main/java/org/apache/ignite/Ignite.java |    98 +-
 .../java/org/apache/ignite/IgniteCache.java     |   237 +-
 .../java/org/apache/ignite/IgniteCompute.java   |    69 +-
 .../java/org/apache/ignite/IgniteCondition.java |   338 +
 .../org/apache/ignite/IgniteDataStreamer.java   |    57 +-
 .../IgniteDataStreamerTimeoutException.java     |    45 +
 .../org/apache/ignite/IgniteFileSystem.java     |    39 +-
 .../org/apache/ignite/IgniteJdbcDriver.java     |    16 +-
 .../main/java/org/apache/ignite/IgniteLock.java |   489 +
 .../java/org/apache/ignite/IgniteServices.java  |    48 +-
 .../apache/ignite/IgniteSystemProperties.java   |   100 +-
 .../main/java/org/apache/ignite/Ignition.java   |    19 +-
 .../ignite/binary/BinaryObjectBuilder.java      |    11 +
 .../ignite/cache/CacheInterceptorEntry.java     |    39 +
 .../cache/CacheWriteSynchronizationMode.java    |     5 +-
 .../org/apache/ignite/cache/QueryEntity.java    |    18 +
 .../ignite/cache/affinity/AffinityFunction.java |     2 +
 .../affinity/fair/FairAffinityFunction.java     |    91 +-
 .../rendezvous/RendezvousAffinityFunction.java  |    47 +-
 .../cache/query/CacheQueryEntryEvent.java       |    12 +-
 .../ignite/cache/query/ContinuousQuery.java     |    74 +-
 .../ignite/cache/query/SqlFieldsQuery.java      |    53 +
 .../org/apache/ignite/cache/query/SqlQuery.java |    28 +
 .../store/jdbc/CacheAbstractJdbcStore.java      |   335 +-
 .../cache/store/jdbc/CacheJdbcBlobStore.java    |    20 +-
 .../cache/store/jdbc/CacheJdbcPojoStore.java    |    31 +-
 .../store/jdbc/CacheJdbcPojoStoreFactory.java   |   130 +-
 .../ignite/cache/store/jdbc/JdbcType.java       |     2 +-
 .../store/jdbc/JdbcTypesDefaultTransformer.java |   117 +
 .../cache/store/jdbc/JdbcTypesTransformer.java  |    39 +
 .../store/jdbc/dialect/BasicJdbcDialect.java    |    15 +-
 .../cache/store/jdbc/dialect/DB2Dialect.java    |     6 +-
 .../cache/store/jdbc/dialect/H2Dialect.java     |     5 +-
 .../cache/store/jdbc/dialect/JdbcDialect.java   |    29 +-
 .../cache/store/jdbc/dialect/MySQLDialect.java  |    27 +-
 .../cache/store/jdbc/dialect/OracleDialect.java |     5 +-
 .../store/jdbc/dialect/SQLServerDialect.java    |    16 +-
 .../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 +-
 .../apache/ignite/compute/ComputeTaskSpis.java  |     8 +-
 .../ignite/compute/ComputeTaskSplitAdapter.java |     8 +-
 .../apache/ignite/compute/gridify/Gridify.java  |     2 +-
 .../configuration/BasicAddressResolver.java     |   146 +
 .../configuration/CacheConfiguration.java       |    45 +-
 .../configuration/ConnectorConfiguration.java   |     4 +
 .../configuration/FileSystemConfiguration.java  |    60 +-
 .../configuration/HadoopConfiguration.java      |    41 +-
 .../configuration/IgniteConfiguration.java      |   154 +-
 .../ignite/configuration/OdbcConfiguration.java |   212 +
 .../configuration/TransactionConfiguration.java |     8 +
 .../igfs/IgfsGroupDataBlocksKeyMapper.java      |    43 +-
 .../java/org/apache/ignite/igfs/IgfsPath.java   |    40 +-
 .../org/apache/ignite/igfs/IgfsPathSummary.java |    35 +-
 .../apache/ignite/igfs/mapreduce/IgfsTask.java  |     6 +-
 .../igfs/secondary/IgfsSecondaryFileSystem.java |     6 +-
 .../local/LocalIgfsSecondaryFileSystem.java     |   415 +
 .../igfs/secondary/local/package-info.java      |    22 +
 .../ignite/igfs/secondary/package-info.java     |     2 +-
 .../ignite/internal/GridCodegenConverter.java   |    56 +
 .../internal/GridEventConsumeHandler.java       |    10 +-
 .../ignite/internal/GridJobExecuteRequest.java  |   148 +-
 .../ignite/internal/GridJobExecuteResponse.java |    42 +-
 .../ignite/internal/GridKernalContext.java      |    24 +
 .../ignite/internal/GridKernalContextImpl.java  |    40 +-
 .../apache/ignite/internal/GridLoggerProxy.java |     6 +-
 .../internal/GridMessageListenHandler.java      |    10 +-
 .../ignite/internal/GridTaskSessionImpl.java    |    17 +-
 .../org/apache/ignite/internal/GridTopic.java   |     5 +-
 .../ignite/internal/IgniteComponentType.java    |    15 +-
 .../ignite/internal/IgniteComputeImpl.java      |   120 +-
 .../ignite/internal/IgniteEventsImpl.java       |    11 +-
 .../apache/ignite/internal/IgniteKernal.java    |   244 +-
 .../ignite/internal/IgniteMessagingImpl.java    |     7 +-
 .../ignite/internal/IgniteNodeAttributes.java   |    10 +
 .../ignite/internal/IgniteServicesImpl.java     |     6 +-
 .../org/apache/ignite/internal/IgnitionEx.java  |   117 +-
 .../apache/ignite/internal/LessNamingBean.java  |    28 +
 .../ignite/internal/MarshallerContextImpl.java  |   107 +-
 .../internal/binary/BinaryClassDescriptor.java  |   102 +-
 .../ignite/internal/binary/BinaryContext.java   |   251 +-
 .../internal/binary/BinaryEnumObjectImpl.java   |    14 +-
 .../internal/binary/BinaryMarshaller.java       |    28 +-
 .../binary/BinaryMethodWriteReplacer.java       |    59 +
 .../ignite/internal/binary/BinaryObjectEx.java  |    19 +
 .../internal/binary/BinaryObjectExImpl.java     |   166 +-
 .../internal/binary/BinaryObjectImpl.java       |   100 +-
 .../binary/BinaryObjectOffheapImpl.java         |    55 +-
 .../internal/binary/BinaryReaderExImpl.java     |    99 +-
 .../internal/binary/BinaryReaderHandles.java    |     2 +-
 .../ignite/internal/binary/BinaryTreeMap.java   |    96 +
 .../binary/BinaryTreeMapWriteReplacer.java      |    34 +
 .../ignite/internal/binary/BinaryTreeSet.java   |    93 +
 .../binary/BinaryTreeSetWriteReplacer.java      |    34 +
 .../ignite/internal/binary/BinaryTypeImpl.java  |     8 +
 .../ignite/internal/binary/BinaryTypeProxy.java |   111 +
 .../ignite/internal/binary/BinaryUtils.java     |   269 +-
 .../internal/binary/BinaryWriteReplacer.java    |    33 +
 .../internal/binary/BinaryWriterExImpl.java     |    51 +-
 .../internal/binary/GridBinaryMarshaller.java   |     7 +-
 .../binary/builder/BinaryBuilderReader.java     |    11 +-
 .../binary/builder/BinaryObjectBuilderImpl.java |    13 +-
 .../client/GridClientConfiguration.java         |     1 -
 .../GridClientConnectionManagerAdapter.java     |    25 +-
 .../connection/GridClientNioTcpConnection.java  |     3 +
 .../GridClientOptimizedMarshaller.java          |     4 +-
 .../GridClientZipOptimizedMarshaller.java       |   167 +
 .../impl/GridTcpRouterNioListenerAdapter.java   |    11 +-
 .../internal/cluster/ClusterGroupAdapter.java   |    26 +-
 .../ignite/internal/cluster/ClusterGroupEx.java |    14 +-
 .../cluster/ClusterNodeLocalMapImpl.java        |     3 +-
 .../internal/cluster/IgniteClusterImpl.java     |     9 +-
 .../internal/direct/DirectMessageReader.java    |     5 +
 .../igfs/common/IgfsControlResponse.java        |    19 +-
 .../internal/igfs/common/IgfsMarshaller.java    |    14 +-
 .../ignite/internal/jdbc2/JdbcConnection.java   |    33 +-
 .../ignite/internal/jdbc2/JdbcQueryTask.java    |    24 +-
 .../ignite/internal/jdbc2/JdbcResultSet.java    |     6 +-
 .../ignite/internal/jdbc2/JdbcStatement.java    |     2 +-
 .../logger/platform/PlatformLogger.java         |   223 +
 .../internal/managers/GridManagerAdapter.java   |    36 +-
 .../managers/communication/GridIoManager.java   |    34 +-
 .../communication/GridIoMessageFactory.java     |    36 +-
 .../managers/communication/GridIoPolicy.java    |     5 +-
 .../deployment/GridDeploymentCommunication.java |     3 +-
 .../GridDeploymentPerVersionStore.java          |     2 +-
 .../discovery/GridDiscoveryManager.java         |   221 +-
 .../eventstorage/GridEventStorageManager.java   |     2 +-
 .../failover/GridFailoverContextImpl.java       |    27 +-
 .../managers/failover/GridFailoverManager.java  |    17 +-
 .../loadbalancer/GridLoadBalancerManager.java   |    10 +-
 .../affinity/GridAffinityAssignment.java        |    64 +-
 .../affinity/GridAffinityAssignmentCache.java   |   312 +-
 .../GridAffinityFunctionContextImpl.java        |     9 +
 .../affinity/GridAffinityProcessor.java         |   143 +-
 .../processors/affinity/GridAffinityUtils.java  |     3 +-
 .../cache/CacheAffinityChangeMessage.java       |   160 +
 .../cache/CacheAffinitySharedManager.java       |  1795 +++
 .../cache/CacheEvictableEntryImpl.java          |    13 +-
 .../processors/cache/CacheInvokeEntry.java      |    41 +-
 .../processors/cache/CacheLazyEntry.java        |    58 +-
 .../processors/cache/CacheObjectContext.java    |    15 +
 .../processors/cache/CacheOperationFilter.java  |    61 +
 .../cache/CacheWeakQueryIteratorsHolder.java    |   169 +-
 .../cache/DynamicCacheChangeRequest.java        |    17 +
 .../cache/DynamicCacheDescriptor.java           |    49 +
 .../EntryProcessorResourceInjectorProxy.java    |   105 +
 .../processors/cache/GridCacheAdapter.java      |  1518 +-
 .../cache/GridCacheAffinityManager.java         |   154 +-
 .../processors/cache/GridCacheAtomicFuture.java |     5 -
 .../cache/GridCacheClearAllRunnable.java        |     3 +-
 .../cache/GridCacheConcurrentMap.java           |  1996 +--
 .../cache/GridCacheConcurrentMapImpl.java       |   344 +
 .../processors/cache/GridCacheContext.java      |    94 +-
 .../GridCacheDefaultAffinityKeyMapper.java      |    19 +
 .../cache/GridCacheDeploymentManager.java       |     6 +-
 .../processors/cache/GridCacheEntryEx.java      |    40 +-
 .../processors/cache/GridCacheEntryInfo.java    |     2 +-
 .../processors/cache/GridCacheEntrySet.java     |   113 -
 .../processors/cache/GridCacheEventManager.java |    10 +-
 .../cache/GridCacheEvictionManager.java         |    34 +-
 .../processors/cache/GridCacheIoManager.java    |   220 +-
 .../processors/cache/GridCacheKeySet.java       |   104 -
 .../processors/cache/GridCacheLogger.java       |     3 +-
 .../processors/cache/GridCacheMapEntry.java     |  1022 +-
 .../processors/cache/GridCacheMessage.java      |    11 +-
 .../processors/cache/GridCacheMvcc.java         |     7 +
 .../cache/GridCacheMvccCandidate.java           |    16 +-
 .../processors/cache/GridCacheMvccManager.java  |    20 +-
 .../GridCachePartitionExchangeManager.java      |   338 +-
 .../processors/cache/GridCachePreloader.java    |    23 +-
 .../cache/GridCachePreloaderAdapter.java        |    17 +-
 .../processors/cache/GridCacheProcessor.java    |   635 +-
 .../processors/cache/GridCacheProxyImpl.java    |   103 +-
 .../processors/cache/GridCacheReturn.java       |    10 +-
 .../GridCacheReturnCompletableWrapper.java      |   101 +
 .../cache/GridCacheSharedContext.java           |   144 +-
 .../cache/GridCacheSharedTtlCleanupManager.java |   132 +
 .../processors/cache/GridCacheSwapManager.java  |   175 +-
 .../processors/cache/GridCacheTtlManager.java   |   112 +-
 .../processors/cache/GridCacheUtils.java        |   162 +-
 .../cache/GridDeferredAckMessageSender.java     |   219 +
 .../processors/cache/GridNoStorageCacheMap.java |   107 +
 .../processors/cache/IgniteCacheProxy.java      |   240 +-
 .../processors/cache/IgniteInternalCache.java   |   113 +-
 .../processors/cache/KeyCacheObject.java        |    18 +
 .../processors/cache/KeyCacheObjectImpl.java    |    40 +-
 .../cache/affinity/GridCacheAffinityImpl.java   |     2 +-
 .../cache/binary/CacheObjectBinaryContext.java  |    10 +-
 .../binary/CacheObjectBinaryProcessorImpl.java  |   149 +-
 .../CacheDataStructuresManager.java             |     4 +-
 .../distributed/GridCacheCommittedTxInfo.java   |     1 +
 .../distributed/GridCacheTxRecoveryFuture.java  |   141 +-
 .../distributed/GridCacheTxRecoveryRequest.java |     7 +
 .../GridCacheTxRecoveryResponse.java            |    29 +-
 .../GridDistributedCacheAdapter.java            |     6 +-
 .../distributed/GridDistributedLockRequest.java |    25 +-
 .../GridDistributedLockResponse.java            |    14 +-
 .../GridDistributedTxFinishRequest.java         |    28 +-
 .../GridDistributedTxFinishResponse.java        |     7 +
 .../GridDistributedTxPrepareRequest.java        |    36 +-
 .../GridDistributedTxPrepareResponse.java       |    25 +-
 .../GridDistributedTxRemoteAdapter.java         |    85 +-
 .../GridDistributedUnlockRequest.java           |    22 +-
 .../dht/CacheDistributedGetFutureAdapter.java   |     3 -
 .../dht/GridCachePartitionedConcurrentMap.java  |   271 +
 .../dht/GridClientPartitionTopology.java        |    23 +-
 .../dht/GridDhtAffinityAssignmentResponse.java  |   198 +-
 .../dht/GridDhtAssignmentFetchFuture.java       |    80 +-
 .../distributed/dht/GridDhtCacheAdapter.java    |   182 +-
 .../distributed/dht/GridDhtCacheEntry.java      |    33 +-
 .../cache/distributed/dht/GridDhtGetFuture.java |    78 +-
 .../distributed/dht/GridDhtGetSingleFuture.java |     6 +
 .../distributed/dht/GridDhtLocalPartition.java  |   188 +-
 .../distributed/dht/GridDhtLockFuture.java      |   149 +-
 .../distributed/dht/GridDhtLockRequest.java     |    16 +-
 .../dht/GridDhtOffHeapCacheEntry.java           |     8 +
 .../dht/GridDhtPartitionTopology.java           |    21 +-
 .../dht/GridDhtPartitionTopologyImpl.java       |   656 +-
 .../dht/GridDhtPartitionsReservation.java       |     3 +-
 .../dht/GridDhtTransactionalCacheAdapter.java   |   149 +-
 .../distributed/dht/GridDhtTxFinishFuture.java  |   137 +-
 .../distributed/dht/GridDhtTxFinishRequest.java |    33 +-
 .../dht/GridDhtTxFinishResponse.java            |    52 +-
 .../cache/distributed/dht/GridDhtTxLocal.java   |   263 +-
 .../distributed/dht/GridDhtTxLocalAdapter.java  |    15 +-
 .../dht/GridDhtTxOnePhaseCommitAckRequest.java  |   134 +
 .../distributed/dht/GridDhtTxPrepareFuture.java |   295 +-
 .../dht/GridDhtTxPrepareRequest.java            |    97 +-
 .../cache/distributed/dht/GridDhtTxRemote.java  |    15 +-
 .../distributed/dht/GridDhtUnlockRequest.java   |    15 +-
 .../distributed/dht/GridNoStorageCacheMap.java  |   122 -
 .../dht/GridPartitionedGetFuture.java           |    17 +-
 .../dht/GridPartitionedSingleGetFuture.java     |    17 +-
 .../dht/atomic/GridDhtAtomicCache.java          |  1170 +-
 .../GridDhtAtomicDeferredUpdateResponse.java    |     7 +
 .../atomic/GridDhtAtomicOffHeapCacheEntry.java  |     8 +
 .../dht/atomic/GridDhtAtomicUpdateFuture.java   |   179 +-
 .../dht/atomic/GridDhtAtomicUpdateRequest.java  |   155 +-
 .../dht/atomic/GridDhtAtomicUpdateResponse.java |     6 +
 .../GridNearAtomicAbstractUpdateFuture.java     |   318 +
 .../GridNearAtomicSingleUpdateFuture.java       |   600 +
 .../dht/atomic/GridNearAtomicUpdateFuture.java  |  1445 +-
 .../dht/atomic/GridNearAtomicUpdateRequest.java |    37 +-
 .../atomic/GridNearAtomicUpdateResponse.java    |     6 +
 .../dht/colocated/GridDhtColocatedCache.java    |    40 +-
 .../colocated/GridDhtColocatedLockFuture.java   |   188 +-
 .../GridDhtColocatedOffHeapCacheEntry.java      |     8 +
 .../colocated/GridDhtDetachedCacheEntry.java    |     2 +-
 .../dht/preloader/GridDhtForceKeysFuture.java   |     9 +-
 .../dht/preloader/GridDhtPartitionDemander.java |    24 +-
 .../dht/preloader/GridDhtPartitionMap2.java     |     9 +-
 .../dht/preloader/GridDhtPartitionSupplier.java |    37 +-
 .../GridDhtPartitionsExchangeFuture.java        |  1586 +-
 .../dht/preloader/GridDhtPreloader.java         |   158 +-
 .../distributed/near/GridNearAtomicCache.java   |    44 +-
 .../distributed/near/GridNearCacheAdapter.java  |   121 +-
 .../distributed/near/GridNearCacheEntry.java    |   118 +-
 .../distributed/near/GridNearGetFuture.java     |    50 +-
 .../distributed/near/GridNearGetRequest.java    |    45 +-
 .../distributed/near/GridNearLockFuture.java    |   109 +-
 .../distributed/near/GridNearLockRequest.java   |    16 +-
 ...arOptimisticSerializableTxPrepareFuture.java |    28 +-
 .../near/GridNearOptimisticTxPrepareFuture.java |   323 +-
 ...ridNearOptimisticTxPrepareFutureAdapter.java |    21 +-
 .../GridNearPessimisticTxPrepareFuture.java     |    54 +-
 .../near/GridNearSingleGetRequest.java          |    24 +-
 .../near/GridNearTransactionalCache.java        |     9 +-
 .../near/GridNearTxFinishFuture.java            |   359 +-
 .../near/GridNearTxFinishRequest.java           |    46 +-
 .../cache/distributed/near/GridNearTxLocal.java |   126 +-
 .../near/GridNearTxPrepareFutureAdapter.java    |    19 +-
 .../near/GridNearTxPrepareRequest.java          |     4 +-
 .../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      |   190 +-
 .../processors/cache/query/CacheQuery.java      |    19 +-
 .../cache/query/CacheQueryFuture.java           |    13 +-
 .../query/GridCacheDistributedQueryManager.java |   102 +-
 .../cache/query/GridCacheLocalQueryManager.java |    33 +-
 .../cache/query/GridCacheQueryAdapter.java      |   236 +-
 .../cache/query/GridCacheQueryBean.java         |     8 +-
 .../cache/query/GridCacheQueryErrorFuture.java  |    12 +-
 .../query/GridCacheQueryFutureAdapter.java      |    10 +-
 .../cache/query/GridCacheQueryInfo.java         |     8 +-
 .../cache/query/GridCacheQueryManager.java      |   729 +-
 .../cache/query/GridCacheQueryMarshallable.java |    37 +
 .../query/GridCacheQueryMetricsAdapter.java     |    12 +-
 .../cache/query/GridCacheQueryRequest.java      |     6 +-
 .../cache/query/GridCacheSqlIndexMetadata.java  |     3 +-
 .../cache/query/GridCacheSqlMetadata.java       |     3 +-
 .../cache/query/GridCacheSqlQuery.java          |    42 +-
 .../cache/query/GridCacheTwoStepQuery.java      |   123 +-
 .../continuous/CacheContinuousQueryEntry.java   |    54 +-
 .../continuous/CacheContinuousQueryEvent.java   |     7 +
 .../continuous/CacheContinuousQueryHandler.java |   607 +-
 .../CacheContinuousQueryListener.java           |     6 +-
 .../continuous/CacheContinuousQueryManager.java |   216 +-
 .../query/jdbc/GridCacheQueryJdbcTask.java      |    59 +-
 .../jdbc/GridCacheQueryJdbcValidationTask.java  |    10 +-
 .../store/GridCacheStoreManagerAdapter.java     |    34 +-
 .../cache/store/GridCacheWriteBehindStore.java  |     2 +-
 .../cache/transactions/IgniteInternalTx.java    |    43 +-
 .../cache/transactions/IgniteTxAdapter.java     |   463 +-
 .../cache/transactions/IgniteTxEntry.java       |   112 +-
 .../cache/transactions/IgniteTxHandler.java     |   552 +-
 .../IgniteTxImplicitSingleStateImpl.java        |    29 +-
 .../transactions/IgniteTxLocalAdapter.java      |   578 +-
 .../cache/transactions/IgniteTxLocalEx.java     |    26 +-
 .../cache/transactions/IgniteTxManager.java     |   791 +-
 .../IgniteTxRemoteSingleStateImpl.java          |    30 +
 .../IgniteTxRemoteStateAdapter.java             |    16 +-
 .../transactions/IgniteTxRemoteStateImpl.java   |    72 +-
 .../cache/transactions/IgniteTxState.java       |    11 +-
 .../cache/transactions/IgniteTxStateAware.java  |    34 +
 .../cache/transactions/IgniteTxStateImpl.java   |    53 +-
 .../cache/transactions/TxDeadlock.java          |   159 +
 .../cache/transactions/TxDeadlockDetection.java |   626 +
 .../processors/cache/transactions/TxLock.java   |   225 +
 .../cache/transactions/TxLockList.java          |   134 +
 .../cache/transactions/TxLocksRequest.java      |   205 +
 .../cache/transactions/TxLocksResponse.java     |   318 +
 .../GridCacheLazyPlainVersionedEntry.java       |   113 +
 .../version/GridCachePlainVersionedEntry.java   |    12 +-
 .../cache/version/GridCacheVersion.java         |    14 +-
 .../cache/version/GridCacheVersionEx.java       |     9 +
 .../cache/version/GridCacheVersionManager.java  |    21 +-
 .../cacheobject/IgniteCacheObjectProcessor.java |    18 +-
 .../IgniteCacheObjectProcessorImpl.java         |    91 +-
 .../processors/clock/GridClockServer.java       |     3 +-
 .../clock/GridClockSyncProcessor.java           |     2 +-
 .../processors/closure/AffinityTask.java        |    17 +-
 .../processors/closure/GridClosurePolicy.java   |    51 -
 .../closure/GridClosureProcessor.java           |   226 +-
 .../processors/cluster/GridUpdateNotifier.java  |     3 +-
 .../continuous/GridContinuousHandler.java       |    13 +-
 .../continuous/GridContinuousProcessor.java     |   293 +-
 .../continuous/GridContinuousQueryBatch.java    |    47 +
 .../datastreamer/DataStreamerImpl.java          |   150 +-
 .../datastructures/DataStructuresProcessor.java |   162 +-
 .../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/GridCacheSemaphoreImpl.java  |   144 +-
 .../datastructures/GridCacheSetImpl.java        |     9 +-
 .../datastructures/GridCacheSetProxy.java       |     3 +-
 .../processors/hadoop/HadoopClassLoader.java    |   487 +
 .../processors/hadoop/HadoopClasspathUtils.java |   424 +
 .../processors/hadoop/HadoopDefaultJobInfo.java |   156 +
 .../processors/hadoop/HadoopHelper.java         |    55 +
 .../processors/hadoop/HadoopJobInfo.java        |     5 +-
 .../processors/hadoop/HadoopLocations.java      |   123 +
 .../processors/hadoop/HadoopNoopHelper.java     |    66 +
 .../processors/hadoop/HadoopNoopProcessor.java  |    29 +-
 .../hadoop/HadoopProcessorAdapter.java          |     7 +
 .../igfs/IgfsAbstractOutputStream.java          |   266 +
 .../internal/processors/igfs/IgfsAsyncImpl.java |    29 +-
 .../processors/igfs/IgfsBlockLocationImpl.java  |    87 +-
 .../internal/processors/igfs/IgfsContext.java   |    70 +-
 .../processors/igfs/IgfsCreateResult.java       |    66 +
 .../processors/igfs/IgfsDataManager.java        |   395 +-
 .../processors/igfs/IgfsDeleteResult.java       |    62 +
 .../processors/igfs/IgfsDeleteWorker.java       |    60 +-
 .../ignite/internal/processors/igfs/IgfsEx.java |    34 +-
 .../processors/igfs/IgfsFileAffinityRange.java  |    40 +-
 .../internal/processors/igfs/IgfsFileImpl.java  |    59 +-
 .../igfs/IgfsFragmentizerManager.java           |    29 +-
 .../internal/processors/igfs/IgfsImpl.java      |  1171 +-
 .../processors/igfs/IgfsInputStreamAdapter.java |    51 -
 .../processors/igfs/IgfsInputStreamImpl.java    |   219 +-
 .../processors/igfs/IgfsIpcHandler.java         |    19 +-
 .../processors/igfs/IgfsKernalContextAware.java |    32 +
 ...zySecondaryFileSystemPositionedReadable.java |    77 +
 .../processors/igfs/IgfsMetaManager.java        |  1266 +-
 .../processors/igfs/IgfsModeResolver.java       |   104 +-
 .../processors/igfs/IgfsNodePredicate.java      |    80 +
 .../igfs/IgfsOutputStreamAdapter.java           |   265 -
 .../processors/igfs/IgfsOutputStreamImpl.java   |   406 +-
 .../igfs/IgfsOutputStreamProxyImpl.java         |   163 +
 .../internal/processors/igfs/IgfsPathIds.java   |    12 +-
 .../internal/processors/igfs/IgfsPaths.java     |    11 +-
 .../internal/processors/igfs/IgfsProcessor.java |    88 +-
 .../IgfsSecondaryFileSystemCreateContext.java   |   114 +
 .../igfs/IgfsSecondaryFileSystemImpl.java       |    17 +-
 .../igfs/IgfsSecondaryFileSystemV2.java         |    40 +
 .../IgfsSecondaryOutputStreamDescriptor.java    |    59 -
 .../internal/processors/igfs/IgfsUtils.java     |   306 +-
 .../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 +
 .../meta/IgfsClientMetaUnlockCallable.java      |   123 +
 .../igfs/data/IgfsDataPutProcessor.java         |    99 +
 .../meta/IgfsMetaDirectoryCreateProcessor.java  |    40 +-
 ...IgfsMetaDirectoryListingRemoveProcessor.java |     2 -
 ...IgfsMetaDirectoryListingRenameProcessor.java |   133 +
 .../igfs/meta/IgfsMetaFileCreateProcessor.java  |    46 +-
 .../igfs/meta/IgfsMetaFileUnlockProcessor.java  |    69 +-
 .../local/LocalFileSystemIgfsFile.java          |   134 +
 .../local/LocalFileSystemSizeVisitor.java       |    60 +
 ...fsSecondaryFileSystemPositionedReadable.java |    65 +
 .../processors/job/GridJobProcessor.java        |   160 +-
 .../internal/processors/job/GridJobWorker.java  |   207 +-
 .../OsDiscoveryNodeValidationProcessor.java     |     2 +-
 .../processors/odbc/OdbcBufferedParser.java     |    81 +
 .../processors/odbc/OdbcColumnMeta.java         |   110 +
 .../processors/odbc/OdbcHandshakeRequest.java   |    83 +
 .../processors/odbc/OdbcHandshakeResult.java    |    73 +
 .../processors/odbc/OdbcMessageParser.java      |   295 +
 .../processors/odbc/OdbcNioListener.java        |   179 +
 .../processors/odbc/OdbcNioServerBuffer.java    |   114 +
 .../internal/processors/odbc/OdbcProcessor.java |   199 +
 .../processors/odbc/OdbcProtocolVersion.java    |   125 +
 .../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     |   409 +
 .../internal/processors/odbc/OdbcResponse.java  |    96 +
 .../internal/processors/odbc/OdbcTableMeta.java |    85 +
 .../internal/processors/odbc/OdbcUtils.java     |    56 +
 .../odbc/escape/OdbcEscapeParseResult.java      |    73 +
 .../processors/odbc/escape/OdbcEscapeToken.java |    61 +
 .../processors/odbc/escape/OdbcEscapeType.java  |   112 +
 .../processors/odbc/escape/OdbcEscapeUtils.java |   392 +
 .../offheap/GridOffHeapProcessor.java           |    26 +
 .../platform/PlatformAbstractBootstrap.java     |    40 +-
 .../platform/PlatformAbstractTarget.java        |    17 +-
 .../processors/platform/PlatformBootstrap.java  |    12 +-
 .../platform/PlatformConfigurationEx.java       |    14 +
 .../platform/PlatformContextImpl.java           |     5 +-
 .../PlatformDefaultJavaObjectFactory.java       |    62 +
 .../processors/platform/PlatformIgnition.java   |    25 +-
 .../platform/PlatformJavaObjectFactoryEx.java   |    36 +
 .../PlatformJavaObjectFactoryProxy.java         |   192 +
 .../PlatformJavaObjectSingletonFactory.java     |    48 +
 .../platform/PlatformNoopProcessor.java         |    29 +-
 .../processors/platform/PlatformProcessor.java  |    52 +-
 .../platform/PlatformProcessorImpl.java         |   224 +-
 .../platform/cache/PlatformCache.java           |   453 +-
 .../platform/cache/PlatformCacheExtension.java  |    47 +
 .../affinity/PlatformAffinityFunction.java      |   304 +
 .../PlatformAffinityFunctionTarget.java         |   113 +
 .../cache/affinity/PlatformAffinityUtils.java   |   118 +
 .../query/PlatformAbstractQueryCursor.java      |    11 +-
 .../query/PlatformContinuousQueryImpl.java      |    50 +-
 .../cache/query/PlatformFieldsQueryCursor.java  |     6 +
 .../callback/PlatformCallbackGateway.java       |   147 +-
 .../callback/PlatformCallbackUtils.java         |    77 +
 .../platform/cluster/PlatformClusterGroup.java  |     7 +
 .../platform/compute/PlatformAbstractTask.java  |     1 +
 .../cpp/PlatformCppConfigurationEx.java         |    13 +
 .../dotnet/PlatformDotNetBootstrap.java         |    21 +
 .../dotnet/PlatformDotNetCacheStore.java        |    37 +-
 .../PlatformDotNetConfigurationClosure.java     |    54 +-
 .../dotnet/PlatformDotNetConfigurationEx.java   |    21 +-
 .../dotnet/PlatformDotNetConsoleStream.java     |    54 +
 .../services/PlatformAbstractService.java       |     3 +-
 .../platform/services/PlatformServices.java     |   249 +-
 .../utils/PlatformConfigurationUtils.java       |   476 +-
 .../platform/utils/PlatformFutureUtils.java     |     4 +-
 .../platform/utils/PlatformUtils.java           |   234 +
 .../PlatformDotNetSessionCacheExtension.java    |   144 +
 .../websession/PlatformDotNetSessionData.java   |   260 +
 .../PlatformDotNetSessionLockProcessor.java     |    84 +
 .../PlatformDotNetSessionLockResult.java        |   106 +
 ...tformDotNetSessionSetAndUnlockProcessor.java |   179 +
 .../processors/plugin/CachePluginManager.java   |    25 +
 .../processors/query/GridQueryIndexing.java     |    51 +-
 .../processors/query/GridQueryProcessor.java    |   215 +-
 .../query/GridQueryTypeDescriptor.java          |     7 +
 .../messages/GridQueryCancelRequest.java        |     2 +-
 .../twostep/messages/GridQueryFailResponse.java |     2 +-
 .../messages/GridQueryNextPageRequest.java      |     2 +-
 .../messages/GridQueryNextPageResponse.java     |    12 +-
 .../h2/twostep/messages/GridQueryRequest.java   |    28 +-
 .../processors/resource/GridResourceIoc.java    |   438 +-
 .../GridResourceJobContextInjector.java         |     4 +-
 .../resource/GridResourceProcessor.java         |   396 +-
 .../message/GridClientHandshakeRequest.java     |     4 +-
 .../handlers/cache/GridCacheCommandHandler.java |   100 +-
 .../handlers/query/QueryCommandHandler.java     |    28 +-
 .../handlers/task/GridTaskCommandHandler.java   |     2 +-
 .../protocols/tcp/GridTcpRestNioListener.java   |    19 +-
 .../rest/protocols/tcp/GridTcpRestProtocol.java |    19 +-
 .../rest/request/RestQueryRequest.java          |    19 +-
 .../service/GridServiceAssignments.java         |    10 +-
 .../service/GridServiceNotFoundException.java   |     4 +-
 .../service/GridServiceProcessor.java           |   885 +-
 .../processors/service/GridServiceProxy.java    |   332 +-
 .../service/LazyServiceConfiguration.java       |   129 +
 .../processors/service/ServiceContextImpl.java  |    29 +-
 .../service/ServiceDescriptorImpl.java          |    17 +-
 .../session/GridTaskSessionProcessor.java       |     9 +-
 .../processors/task/GridTaskProcessor.java      |     9 +-
 .../processors/task/GridTaskWorker.java         |   277 +-
 .../apache/ignite/internal/util/ClassCache.java |    32 +
 .../org/apache/ignite/internal/util/F0.java     |     4 +-
 .../util/GridBoundedConcurrentOrderedMap.java   |     5 +
 .../internal/util/GridExecutionStatistics.java  |   106 -
 .../ignite/internal/util/GridJavaProcess.java   |     5 +-
 .../ignite/internal/util/GridLeanSet.java       |     1 +
 .../ignite/internal/util/GridLogThrottle.java   |    35 +-
 .../ignite/internal/util/HostAndPortRange.java  |   205 +
 .../internal/util/IgniteExceptionRegistry.java  |     5 +-
 .../ignite/internal/util/IgniteUtils.java       |   303 +-
 .../util/StripedCompositeReadWriteLock.java     |    10 +
 .../util/future/GridCompoundFuture.java         |   100 +-
 .../internal/util/future/GridFutureAdapter.java |     3 +-
 .../ipc/shmem/IpcSharedMemoryNativeLoader.java  |     2 +-
 .../shmem/IpcSharedMemoryServerEndpoint.java    |    10 +-
 .../ignite/internal/util/lang/GridFunc.java     |   119 +-
 .../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 +
 .../nio/GridConnectionBytesVerifyFilter.java    |     2 +-
 .../internal/util/nio/GridNioCodecFilter.java   |     2 +-
 .../internal/util/nio/GridNioFilterChain.java   |     2 +-
 .../util/nio/GridNioRecoveryDescriptor.java     |    19 +-
 .../ignite/internal/util/nio/GridNioServer.java |    62 +-
 .../util/nio/GridSelectorNioSessionImpl.java    |     9 +-
 .../util/nio/GridTcpNioCommunicationClient.java |     5 +-
 .../offheap/unsafe/GridOffHeapSnapTreeMap.java  |    91 +-
 .../util/offheap/unsafe/GridUnsafeLru.java      |    30 +-
 .../apache/ignite/internal/util/typedef/PN.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 |    12 +-
 .../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 +-
 .../cache/VisorCacheResetQueryMetricsTask.java  |    69 +
 .../cache/VisorCacheStoreConfiguration.java     |     3 +-
 .../cache/VisorCacheTypeFieldMetadata.java      |     3 +-
 .../visor/cache/VisorCacheTypeMetadata.java     |    23 +-
 .../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 +-
 .../visor/event/VisorGridDiscoveryEventV2.java  |    80 +
 .../internal/visor/event/VisorGridEvent.java    |     5 +-
 .../internal/visor/file/VisorFileBlock.java     |     5 +-
 .../ignite/internal/visor/igfs/VisorIgfs.java   |     7 +-
 .../internal/visor/igfs/VisorIgfsEndpoint.java  |     5 +-
 .../internal/visor/igfs/VisorIgfsMetrics.java   |    16 +-
 .../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   |    82 +-
 .../visor/node/VisorNodeDataCollectorTask.java  |    26 -
 .../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/VisorQueryArgV2.java   |    49 +
 .../internal/visor/query/VisorQueryField.java   |     5 +-
 .../internal/visor/query/VisorQueryJob.java     |    39 +-
 .../internal/visor/query/VisorQueryResult.java  |     5 +-
 .../query/VisorQueryScanSubstringFilter.java    |    63 +
 .../internal/visor/query/VisorQueryUtils.java   |     6 +
 .../internal/visor/util/VisorEventMapper.java   |    96 +-
 .../internal/visor/util/VisorTaskUtils.java     |    38 +-
 .../WebSessionAttributeProcessor.java           |   134 +
 .../internal/websession/WebSessionEntity.java   |   193 +
 .../apache/ignite/lang/IgniteAsyncCallback.java |   111 +
 .../java/org/apache/ignite/lang/IgniteUuid.java |     2 +-
 .../ignite/marshaller/AbstractMarshaller.java   |    41 +-
 .../AbstractNodeNameAwareMarshaller.java        |   142 +
 .../apache/ignite/marshaller/Marshaller.java    |     6 +-
 .../ignite/marshaller/MarshallerUtils.java      |    58 +
 .../ignite/marshaller/jdk/JdkMarshaller.java    |    40 +-
 .../optimized/OptimizedMarshaller.java          |    12 +-
 .../platform/PlatformJavaObjectFactory.java     |    36 +
 .../dotnet/PlatformDotNetAffinityFunction.java  |   186 +
 .../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/scheduler/SchedulerFuture.java       |     5 +-
 .../org/apache/ignite/services/Service.java     |    12 +-
 .../ignite/services/ServiceConfiguration.java   |    14 +-
 .../ignite/spi/IgniteNodeValidationResult.java  |     8 +-
 .../org/apache/ignite/spi/IgniteSpiAdapter.java |    40 +-
 .../org/apache/ignite/spi/IgniteSpiContext.java |    26 +-
 .../sharedfs/SharedFsCheckpointSpi.java         |     7 +-
 .../jobstealing/JobStealingCollisionSpi.java    |    14 +-
 .../jobstealing/JobStealingDisabled.java        |     2 +-
 .../communication/tcp/TcpCommunicationSpi.java  |   238 +-
 .../ignite/spi/discovery/tcp/ClientImpl.java    |    53 +-
 .../ignite/spi/discovery/tcp/ServerImpl.java    |   905 +-
 .../spi/discovery/tcp/TcpDiscoveryImpl.java     |    15 +-
 .../spi/discovery/tcp/TcpDiscoverySpi.java      |    64 +-
 .../tcp/internal/TcpDiscoveryNode.java          |     2 +-
 .../tcp/internal/TcpDiscoveryStatistics.java    |    45 +-
 .../ipfinder/jdbc/BasicJdbcIpFinderDialect.java |    28 +
 .../tcp/ipfinder/jdbc/JdbcIpFinderDialect.java  |    28 +
 .../jdbc/OracleJdbcIpFinderDialect.java         |    28 +
 .../ipfinder/jdbc/TcpDiscoveryJdbcIpFinder.java |    69 +-
 .../TcpDiscoveryMulticastIpFinder.java          |     7 +-
 .../sharedfs/TcpDiscoverySharedFsIpFinder.java  |    60 +-
 .../messages/TcpDiscoveryAbstractMessage.java   |     4 +-
 .../TcpDiscoveryClientHeartbeatMessage.java     |     1 +
 .../TcpDiscoveryClientReconnectMessage.java     |    16 +
 .../TcpDiscoveryCustomEventMessage.java         |    13 +-
 .../TcpDiscoveryJoinRequestMessage.java         |    16 +-
 .../TcpDiscoveryStatusCheckMessage.java         |    18 +-
 .../ignite/spi/failover/FailoverContext.java    |    15 +-
 .../spi/failover/always/AlwaysFailoverSpi.java  |    15 +-
 .../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 +-
 .../spi/swapspace/file/FileSwapSpaceSpi.java    |    91 +-
 .../ignite/stream/socket/SocketStreamer.java    |    18 +-
 .../thread/IgniteStripedThreadPoolExecutor.java |   164 +-
 .../apache/ignite/transactions/Transaction.java |    19 +-
 .../TransactionDeadlockException.java           |    42 +
 .../TransactionTimeoutException.java            |     5 +-
 .../java/org/jetbrains/annotations/NotNull.java |    38 -
 .../org/jetbrains/annotations/Nullable.java     |    33 -
 .../org/jetbrains/annotations/package-info.java |    27 -
 .../resources/META-INF/classnames.properties    |   249 +-
 .../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 -
 modules/core/src/test/config/log4j-test.xml     |     6 +
 .../GridCacheAffinityBackupsSelfTest.java       |     2 +-
 .../AbstractAffinityFunctionSelfTest.java       |    18 +-
 .../affinity/AffinityClientNodeSelfTest.java    |    77 +-
 ...ityFunctionBackupFilterAbstractSelfTest.java |   131 +-
 .../affinity/AffinityHistoryCleanupTest.java    |   414 +
 ...airAffinityFunctionBackupFilterSelfTest.java |     9 +
 .../fair/FairAffinityFunctionNodesSelfTest.java |     2 +
 .../local/LocalAffinityFunctionTest.java        |    80 +
 ...ousAffinityFunctionBackupFilterSelfTest.java |     9 +
 .../CacheJdbcPojoStoreAbstractSelfTest.java     |   212 +-
 ...heJdbcPojoStoreBinaryMarshallerSelfTest.java |    26 +-
 ...reBinaryMarshallerWithSqlEscapeSelfTest.java |    28 +
 ...dbcPojoStoreOptimizedMarshallerSelfTest.java |     2 +-
 ...ptimizedMarshallerWithSqlEscapeSelfTest.java |    28 +
 ...eJdbcStoreAbstractMultithreadedSelfTest.java |    25 +-
 .../cache/store/jdbc/H2DataSourceFactory.java   |    35 +
 .../ignite/cache/store/jdbc/model/Person.java   |    25 +
 .../ignite/igfs/IgfsEventsAbstractSelfTest.java |    26 +-
 .../ignite/igfs/IgfsFragmentizerSelfTest.java   |     2 -
 .../apache/ignite/igfs/IgfsPathSelfTest.java    |     6 -
 .../ignite/internal/ClusterGroupSelfTest.java   |    32 +-
 .../internal/ClusterNodeMetricsSelfTest.java    |   101 +-
 .../ignite/internal/GridAffinitySelfTest.java   |     5 +-
 .../GridEventStorageCheckAllEventsSelfTest.java |    30 +-
 .../internal/GridEventStorageSelfTest.java      |    97 +-
 .../ignite/internal/GridGetOrStartSelfTest.java |    70 +
 .../GridJobMasterLeaveAwareSelfTest.java        |     4 +-
 ...ectionLocalJobMultipleArgumentsSelfTest.java |     4 +-
 .../internal/GridTaskExecutionSelfTest.java     |    90 +-
 .../GridTaskFailoverAffinityRunTest.java        |     8 +-
 .../IgniteClientReconnectAbstractTest.java      |    15 +-
 .../IgniteClientReconnectAtomicsTest.java       |    66 +-
 .../IgniteClientReconnectCacheTest.java         |    35 +
 .../IgniteClientReconnectCollectionsTest.java   |     4 +-
 .../IgniteClientReconnectComputeTest.java       |     6 +-
 ...eClientReconnectContinuousProcessorTest.java |    60 +-
 .../IgniteClientReconnectFailoverTest.java      |     2 +
 .../IgniteClientReconnectServicesTest.java      |     4 +-
 .../IgniteClientReconnectStreamerTest.java      |     2 +-
 .../IgniteComputeEmptyClusterGroupTest.java     |     8 +-
 ...eConcurrentEntryProcessorAccessStopTest.java |    82 +
 .../IgniteLocalNodeMapBeforeStartTest.java      |    82 +
 .../MarshallerContextLockingSelfTest.java       |   139 +
 .../internal/TestRecordingCommunicationSpi.java |    65 +-
 .../ignite/internal/binary/AffinityKey.java     |    69 +
 .../binary/BinaryMarshallerSelfTest.java        |   304 +-
 .../BinaryObjectBuilderAdditionalSelfTest.java  |    92 +-
 .../binary/BinaryObjectToStringSelfTest.java    |    92 +
 .../internal/binary/BinaryTreeSelfTest.java     |   341 +
 .../binary/GridBinaryAffinityKeySelfTest.java   |    19 +-
 .../binary/GridBinaryWildcardsSelfTest.java     |    53 +-
 ...aultBinaryMappersBinaryMetaDataSelfTest.java |    17 +
 ...GridManagerLocalMessageListenerSelfTest.java |   222 +
 .../GridDiscoveryManagerAliveCacheSelfTest.java |     4 +-
 .../GridDiscoveryManagerAttributesSelfTest.java |   126 +
 .../discovery/GridDiscoveryManagerSelfTest.java |     6 +-
 .../BinaryObjectOffHeapUnswapTemporaryTest.java |   368 +
 .../cache/CacheAffinityCallSelfTest.java        |    85 +-
 .../cache/CacheClientStoreSelfTest.java         |   209 +-
 .../cache/CacheGetEntryAbstractTest.java        |    39 +-
 ...GetEntryOptimisticReadCommittedSeltTest.java |     2 +-
 ...erceptorPartitionCounterLocalSanityTest.java |   687 +
 ...torPartitionCounterRandomOperationsTest.java |  1054 ++
 .../processors/cache/CacheNamesSelfTest.java    |    16 +-
 .../CacheNamesWithSpecialCharactersTest.java    |    71 +
 ...cheNearUpdateTopologyChangeAbstractTest.java |     2 +
 .../cache/CacheReadThroughRestartSelfTest.java  |     2 +
 .../CacheSerializableTransactionsTest.java      |     5 +
 .../CacheStartupInDeploymentModesTest.java      |   230 +
 .../CacheStoreUsageMultinodeAbstractTest.java   |     5 +-
 .../CacheSwapUnswapGetTestSmallQueueSize.java   |    35 +
 .../processors/cache/CacheTxFastFinishTest.java |   253 +
 .../CacheTxNotAllowReadFromBackupTest.java      |   297 +
 .../cache/CrossCacheTxRandomOperationsTest.java |    13 +-
 .../EntryVersionConsistencyReadThroughTest.java |   265 +
 ...idAbstractCacheInterceptorRebalanceTest.java |   356 +
 .../cache/GridCacheAbstractFullApiSelfTest.java |   849 +-
 .../GridCacheAbstractLocalStoreSelfTest.java    |   480 +-
 .../cache/GridCacheAbstractMetricsSelfTest.java |     2 +-
 .../GridCacheAbstractRemoveFailureTest.java     |    10 +-
 .../cache/GridCacheAbstractSelfTest.java        |   243 +-
 ...acheAbstractUsersAffinityMapperSelfTest.java |     2 +-
 .../cache/GridCacheDeploymentSelfTest.java      |     2 +
 .../cache/GridCacheEntryVersionSelfTest.java    |     2 +-
 .../GridCacheInterceptorAbstractSelfTest.java   |     2 +-
 ...heInterceptorAtomicOffheapRebalanceTest.java |    30 +
 ...GridCacheInterceptorAtomicRebalanceTest.java |    36 +
 ...ceptorTransactionalOffheapRebalanceTest.java |    35 +
 ...heInterceptorTransactionalRebalanceTest.java |    36 +
 .../cache/GridCacheOffHeapCleanupTest.java      |   169 +
 .../GridCachePartitionedLocalStoreSelfTest.java |     6 -
 ...chePartitionedOffHeapLocalStoreSelfTest.java |     6 -
 .../GridCachePreloadingEvictionsSelfTest.java   |     4 +-
 .../GridCacheReplicatedLocalStoreSelfTest.java  |     6 -
 ...ridCacheStoreManagerDeserializationTest.java |    41 +-
 .../cache/GridCacheStoreValueBytesSelfTest.java |     2 +-
 .../cache/GridCacheSwapCleanupTest.java         |    99 +
 ...acheTcpClientDiscoveryMultiThreadedTest.java |     2 +-
 .../processors/cache/GridCacheTestEntryEx.java  |    20 +-
 .../GridCacheTtlManagerNotificationTest.java    |   297 +
 .../cache/GridCacheTtlManagerSelfTest.java      |     2 +-
 ...ridCacheTxPartitionedLocalStoreSelfTest.java |     6 -
 .../cache/GridCacheUtilsSelfTest.java           |    64 +-
 ...idCacheValueConsistencyAbstractSelfTest.java |     9 +-
 .../GridCacheVersionTopologyChangeTest.java     |   246 +
 ...calCacheStoreManagerDeserializationTest.java |     2 +-
 .../cache/GridLocalIgniteSerializationTest.java |   378 +
 .../processors/cache/H2CacheStoreStrategy.java  |   468 +
 .../cache/IgniteCacheAbstractTest.java          |     2 +-
 .../cache/IgniteCacheAtomicPeekModesTest.java   |     2 +-
 .../IgniteCacheBinaryObjectsScanSelfTest.java   |     2 +
 .../IgniteCacheConfigVariationsFullApiTest.java |   336 +-
 .../cache/IgniteCacheCreateRestartSelfTest.java |     2 -
 .../IgniteCacheEntryProcessorNodeJoinTest.java  |   147 +-
 ...niteCacheExpireAndUpdateConsistencyTest.java |   444 +
 .../cache/IgniteCacheIncrementTxTest.java       |   299 +
 .../IgniteCacheInterceptorSelfTestSuite.java    |     7 +
 ...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 |   471 +-
 .../IgniteCacheReadThroughEvictionSelfTest.java |   297 +
 ...acheReadThroughEvictionsVariationsSuite.java |    58 +
 .../IgniteCacheReadThroughStoreCallTest.java    |   288 +
 .../IgniteClientAffinityAssignmentSelfTest.java |     2 +-
 ...eDynamicCacheStartNoExchangeTimeoutTest.java |     2 +
 .../cache/IgniteDynamicCacheStartSelfTest.java  |   217 +-
 ...niteDynamicCacheStartStopConcurrentTest.java |     8 +-
 .../IgniteDynamicClientCacheStartSelfTest.java  |    10 -
 .../cache/IgniteTxConfigCacheSelfTest.java      |    91 +-
 .../IgniteTxExceptionAbstractSelfTest.java      |    38 +-
 .../cache/IgniteTxReentryAbstractSelfTest.java  |     2 +-
 .../IgniteTxStoreExceptionAbstractSelfTest.java |     8 +-
 ...rceptorCacheConfigVariationsFullApiTest.java |   118 +
 ...terceptorWithKeepBinaryCacheFullApiTest.java |   124 +
 .../processors/cache/MapCacheStoreStrategy.java |   145 +
 .../MarshallerCacheJobRunNodeRestartTest.java   |   307 +
 .../cache/TestCacheStoreStrategy.java           |    96 +
 .../cache/WithKeepBinaryCacheFullApiTest.java   |  1226 ++
 .../CacheKeepBinaryWithInterceptorTest.java     |   419 +
 ...acheBinaryObjectUserClassloaderSelfTest.java |   274 +
 .../GridCacheBinaryObjectsAbstractSelfTest.java |   298 +-
 ...eAbstractDataStructuresFailoverSelfTest.java |   220 +-
 ...actQueueFailoverDataConsistencySelfTest.java |     2 +-
 .../GridCacheQueueCleanupSelfTest.java          |     4 +-
 .../GridCacheSequenceApiSelfAbstractTest.java   |    37 -
 .../GridCacheSetAbstractSelfTest.java           |     5 +-
 .../GridCacheSetFailoverAbstractSelfTest.java   |     8 +-
 .../IgniteClientDataStructuresAbstractTest.java |    70 +
 .../IgniteCountDownLatchAbstractSelfTest.java   |   158 +-
 .../IgniteDataStructureUniqueNameTest.java      |    16 +-
 .../IgniteLockAbstractSelfTest.java             |  1629 ++
 .../IgniteSemaphoreAbstractSelfTest.java        |    56 +-
 ...SemaphoreFailoverSafeReleasePermitsTest.java |   129 +
 .../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        |  2684 ++++
 .../GridCacheAbstractJobExecutionTest.java      |     6 +-
 .../distributed/GridCacheLockAbstractTest.java  |     2 +-
 .../GridCacheTransformEventSelfTest.java        |    68 +-
 ...niteCacheClientNodeChangingTopologyTest.java |    37 +-
 ...teCacheClientNodePartitionsExchangeTest.java |    85 +-
 .../IgniteCacheClientReconnectTest.java         |     2 +
 .../IgniteCacheConnectionRecoveryTest.java      |   205 +
 .../distributed/IgniteCacheCreatePutTest.java   |     6 +-
 .../distributed/IgniteCacheGetRestartTest.java  |     4 +
 .../IgniteCacheMessageRecoveryAbstractTest.java |    14 +-
 ...eCacheMessageRecoveryIdleConnectionTest.java |   157 +
 .../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 +
 .../IgniteTxTimeoutAbstractTest.java            |     8 +-
 .../dht/GridCacheDhtEvictionSelfTest.java       |    15 +-
 .../GridCacheDhtPreloadMessageCountTest.java    |     6 +-
 .../distributed/dht/GridCacheDhtTestUtils.java  |     9 +-
 ...idCachePartitionedPreloadEventsSelfTest.java |    11 +
 ...ridCachePartitionedUnloadEventsSelfTest.java |     2 +
 .../dht/GridCacheTxNodeFailureSelfTest.java     |    12 +-
 .../dht/IgniteCacheConcurrentPutGetRemove.java  |   201 +
 .../IgniteCachePutRetryAbstractSelfTest.java    |    43 +-
 ...gniteCachePutRetryTransactionalSelfTest.java |    75 +-
 ...tionedMultiNodeLongTxTimeoutFullApiTest.java |    34 +
 ...nabledMultiNodeLongTxTimeoutFullApiTest.java |    41 +
 ...tomicClientOnlyMultiNodeFullApiSelfTest.java |    17 +-
 ...imaryWriteOrderMultiNodeFullApiSelfTest.java |    35 +
 ...eAtomicNearOnlyMultiNodeFullApiSelfTest.java |    17 +-
 .../near/GridCacheNearJobExecutionSelfTest.java |     2 -
 .../near/GridCacheNearMultiNodeSelfTest.java    |     4 +-
 .../near/GridCacheNearOneNodeSelfTest.java      |     4 +-
 ...idCacheNearOnlyMultiNodeFullApiSelfTest.java |   170 +-
 .../near/GridCacheNearReadersSelfTest.java      |     2 +
 .../near/GridCacheNearTxForceKeyTest.java       |     6 +-
 ...ePartitionedBasicStoreMultiNodeSelfTest.java |     2 +
 ...LateAffDisabledMultiNodeFullApiSelfTest.java |    34 +
 ...achePartitionedMultiNodeCounterSelfTest.java |    43 +-
 ...achePartitionedMultiNodeFullApiSelfTest.java |     2 +
 ...edOffHeapTieredMultiNodeFullApiSelfTest.java |     2 +-
 ...achePartitionedPreloadLifecycleSelfTest.java |   102 +-
 ...idCacheRendezvousAffinityClientSelfTest.java |     2 +
 .../rebalancing/CacheNodeSafeAssertion.java     |   118 +
 ...cingDelayedPartitionMapExchangeSelfTest.java |    14 +-
 .../GridCacheRebalancingOrderingTest.java       |   916 ++
 ...cheRebalancingPartitionDistributionTest.java |   149 +
 .../GridCacheRebalancingSyncSelfTest.java       |   245 +-
 .../GridCacheReplicatedJobExecutionTest.java    |     2 -
 .../IgniteCacheSyncRebalanceModeSelfTest.java   |   116 +
 ...CacheReplicatedPreloadLifecycleSelfTest.java |   132 +-
 .../IgniteCacheExpiryPolicyAbstractTest.java    |    17 +-
 .../IgniteCacheExpiryPolicyTestSuite.java       |    11 +
 ...eCacheOnlyOneTtlCleanupThreadExistsTest.java |   102 +
 .../expiry/IgniteCacheTtlCleanupSelfTest.java   |     2 +-
 .../IgniteCacheLoaderWriterAbstractTest.java    |    10 +
 ...CacheLocalOffHeapAndSwapMetricsSelfTest.java |   415 -
 .../CacheOffHeapAndSwapMetricsSelfTest.java     |   621 +
 .../local/GridCacheLocalTxTimeoutSelfTest.java  |     5 +-
 .../GridCacheQueryTransformerSelfTest.java      |   575 +
 ...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 |   198 +-
 .../CacheContinuousQueryLostPartitionTest.java  |    14 +
 ...ontinuousQueryOperationFromCallbackTest.java |   627 +
 .../CacheContinuousQueryOrderingEventTest.java  |   722 +
 ...acheContinuousQueryRandomOperationsTest.java |    23 +
 .../CacheContinuousQueryVariationsTest.java     |   949 ++
 .../CacheEntryProcessorNonSerializableTest.java |   410 +
 ...CacheKeepBinaryIterationNearEnabledTest.java |    44 +
 ...acheKeepBinaryIterationStoreEnabledTest.java |    90 +
 ...CacheKeepBinaryIterationSwapEnabledTest.java |    56 +
 .../CacheKeepBinaryIterationTest.java           |   471 +
 ...yRemoteFilterMissingInClassPathSelfTest.java |   237 +
 ...ridCacheContinuousQueryAbstractSelfTest.java |    49 +-
 ...eContinuousQueryMultiNodesFilteringTest.java |   439 +
 ...dCacheContinuousQueryNodesFilteringTest.java |   168 +
 ...niteCacheContinuousQueryBackupQueueTest.java |   299 +
 ...eCacheContinuousQueryImmutableEntryTest.java |   205 +
 ...teCacheContinuousQueryNoUnsubscribeTest.java |   153 +
 ...BehindStorePartitionedMultiNodeSelfTest.java |    11 +-
 .../transactions/DepthFirstSearchTest.java      |   350 +
 .../TxDeadlockDetectionNoHangsTest.java         |   246 +
 .../transactions/TxDeadlockDetectionTest.java   |   494 +
 ...timisticDeadlockDetectionCrossCacheTest.java |   257 +
 .../TxOptimisticDeadlockDetectionTest.java      |   574 +
 ...simisticDeadlockDetectionCrossCacheTest.java |   212 +
 .../TxPessimisticDeadlockDetectionTest.java     |   517 +
 .../cluster/GridAddressResolverSelfTest.java    |    97 +
 ...gniteComputeConfigVariationsFullApiTest.java |  2011 +++
 .../continuous/GridMessageListenSelfTest.java   |    30 +-
 .../IgniteNoCustomEventsOnNodeStart.java        |    85 +
 .../datastreamer/DataStreamerTimeoutTest.java   |   163 +
 ...faultIgfsSecondaryFileSystemTestAdapter.java |   117 +
 .../igfs/IgfsAbstractBaseSelfTest.java          |  1074 ++
 .../processors/igfs/IgfsAbstractSelfTest.java   |  1924 +--
 .../IgfsAtomicPrimaryMultiNodeSelfTest.java     |    39 +
 .../IgfsAtomicPrimaryOffheapTieredSelfTest.java |    39 +
 .../IgfsAtomicPrimaryOffheapValuesSelfTest.java |    39 +
 .../igfs/IgfsAtomicPrimarySelfTest.java         |    39 +
 .../igfs/IgfsBackupFailoverSelfTest.java        |     2 +-
 ...sCachePerBlockLruEvictionPolicySelfTest.java |     7 +-
 .../igfs/IgfsClientCacheSelfTest.java           |   139 -
 .../igfs/IgfsDataManagerSelfTest.java           |    18 +-
 .../igfs/IgfsDualAbstractSelfTest.java          |   319 +-
 .../igfs/IgfsDualAsyncClientSelfTest.java       |    28 +
 .../igfs/IgfsDualSyncClientSelfTest.java        |    28 +
 .../igfs/IgfsExUniversalFileSystemAdapter.java  |   101 -
 .../processors/igfs/IgfsIgniteMock.java         |   520 +
 ...SecondaryFileSystemDualAbstractSelfTest.java |   279 +
 ...ondaryFileSystemDualAsyncClientSelfTest.java |    28 +
 ...calSecondaryFileSystemDualAsyncSelfTest.java |    32 +
 ...condaryFileSystemDualSyncClientSelfTest.java |    28 +
 ...ocalSecondaryFileSystemDualSyncSelfTest.java |    32 +
 ...lSecondaryFileSystemProxyClientSelfTest.java |    28 +
 ...fsLocalSecondaryFileSystemProxySelfTest.java |   272 +
 ...IgfsLocalSecondaryFileSystemTestAdapter.java |   141 +
 .../processors/igfs/IgfsMaxSizeSelfTest.java    |   122 +
 .../igfs/IgfsMetaManagerSelfTest.java           |    28 +-
 .../processors/igfs/IgfsMetricsSelfTest.java    |    75 +-
 .../internal/processors/igfs/IgfsMock.java      |   405 +
 .../igfs/IgfsModeResolverSelfTest.java          |   161 +-
 .../processors/igfs/IgfsModesSelfTest.java      |    64 +-
 .../processors/igfs/IgfsOneClientNodeTest.java  |     7 +-
 .../igfs/IgfsPrimaryClientSelfTest.java         |    30 +
 ...PrimaryRelaxedConsistencyClientSelfTest.java |    28 +
 .../processors/igfs/IgfsProcessorSelfTest.java  |    11 +-
 .../igfs/IgfsProcessorValidationSelfTest.java   |    64 +-
 .../processors/igfs/IgfsProxySelfTest.java      |    32 +
 .../IgfsSecondaryFileSystemTestAdapter.java     |   118 +
 .../processors/igfs/IgfsSizeSelfTest.java       |   133 -
 .../processors/igfs/IgfsStreamsSelfTest.java    |     9 +-
 .../processors/igfs/IgfsTaskSelfTest.java       |     2 +-
 .../igfs/UniversalFileSystemAdapter.java        |    98 -
 ...niteMessagingConfigVariationFullApiTest.java |   484 +
 .../odbc/OdbcEscapeSequenceSelfTest.java        |   778 +
 .../odbc/OdbcProcessorValidationSelfTest.java   |   175 +
 .../GridCacheAtomicCommandHandlerSelfTest.java  |    39 +
 .../cache/GridCacheCommandHandlerSelfTest.java  |    20 +-
 .../query/GridQueryCommandHandlerTest.java      |   191 +
 .../service/GridServiceClientNodeTest.java      |   102 +-
 ...rviceDeploymentExceptionPropagationTest.java |    80 +
 ...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 +
 .../service/IgniteServiceReassignmentTest.java  |   250 +
 .../ServicePredicateAccessCacheTest.java        |     4 +-
 .../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 |     4 +
 .../marshaller/MarshallerContextSelfTest.java   |    90 +
 .../marshaller/MarshallerContextTestImpl.java   |    35 +-
 .../GridP2PMissedResourceCacheSizeSelfTest.java |     6 +-
 .../platform/PlatformCacheEntryEventFilter.java |   193 +
 .../PlatformCacheEntryEventFilterFactory.java   |    59 +
 ...latformDefaultJavaObjectFactorySelfTest.java |   185 +
 .../platform/PlatformDeployServiceTask.java     |   360 +
 .../PlatformJavaObjectFactoryProxySelfTest.java |   220 +
 .../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 +
 .../spi/GridTcpSpiForwardingSelfTest.java       |   237 +-
 .../GridTcpCommunicationSpiConfigSelfTest.java  |    22 +
 .../tcp/TcpClientDiscoverySpiMulticastTest.java |     2 +-
 .../tcp/TcpClientDiscoverySpiSelfTest.java      |    48 +-
 .../tcp/TcpDiscoveryMultiThreadedTest.java      |   222 +
 .../spi/discovery/tcp/TcpDiscoverySelfTest.java |   278 +-
 .../tcp/TcpDiscoverySpiConfigSelfTest.java      |    22 +
 .../TcpDiscoverySpiFailureTimeoutSelfTest.java  |    23 +-
 .../spi/discovery/tcp/TestTcpDiscoverySpi.java  |     5 +-
 .../jdbc/TcpDiscoveryJdbcIpFinderSelfTest.java  |     2 +-
 .../TcpDiscoveryMulticastIpFinderSelfTest.java  |     6 +-
 .../TcpDiscoverySharedFsIpFinderSelfTest.java   |    25 +
 .../vm/TcpDiscoveryVmIpFinderSelfTest.java      |    75 +
 .../spi/failover/GridFailoverTestContext.java   |     6 +
 .../GridInternalTasksLoadBalancingSelfTest.java |   201 +
 .../file/GridFileSwapSpaceSpiSelfTest.java      |    89 +
 .../properties/NotStringSystemPropertyTest.java |   124 +
 .../testframework/GridSpiTestContext.java       |   115 +-
 .../ignite/testframework/GridTestUtils.java     |     7 +-
 .../ignite/testframework/IgniteTestSuite.java   |   419 +
 .../assertions/AlwaysAssertion.java             |    29 +
 .../testframework/assertions/Assertion.java     |    31 +
 .../testframework/assertions/package-info.java  |    22 +
 .../configvariations/ConfigVariations.java      |     8 +-
 .../ConfigVariationsTestSuiteBuilder.java       |    31 +-
 .../configvariations/VariationsTestsConfig.java |    21 +-
 .../testframework/junits/GridAbstractTest.java  |    69 +-
 .../junits/GridTestKernalContext.java           |     1 +
 ...IgniteCacheConfigVariationsAbstractTest.java |    88 +-
 .../IgniteConfigVariationsAbstractTest.java     |   282 +-
 .../ignite/testframework/junits/IgniteMock.java |    25 +
 .../junits/common/GridCommonAbstractTest.java   |   226 +-
 .../common/GridRollingRestartAbstractTest.java  |   324 +
 .../multijvm/IgniteCacheProcessProxy.java       |   160 +-
 .../multijvm/IgniteClusterProcessProxy.java     |     5 +
 .../junits/multijvm/IgniteProcessProxy.java     |    46 +-
 ...naryObjectsTxDeadlockDetectionTestSuite.java |    37 +
 .../ignite/testsuites/IgniteBasicTestSuite.java |    19 +-
 .../testsuites/IgniteBinaryCacheTestSuite.java  |     2 +
 .../IgniteBinaryObjectsTestSuite.java           |    15 +-
 .../IgniteCacheDataStructuresSelfTestSuite.java |    11 +
 .../IgniteCacheFailoverTestSuite.java           |     2 +
 .../IgniteCacheFullApiSelfTestSuite.java        |    10 +
 .../IgniteCacheMetricsSelfTestSuite.java        |     4 +-
 .../ignite/testsuites/IgniteCacheTestSuite.java |    25 +
 .../testsuites/IgniteCacheTestSuite2.java       |     7 +
 .../testsuites/IgniteCacheTestSuite3.java       |     4 +
 .../testsuites/IgniteCacheTestSuite4.java       |    17 +
 .../testsuites/IgniteCacheTestSuite5.java       |    21 +-
 ...teBasicConfigVariationsFullApiTestSuite.java |    72 +
 ...iteContinuousQueryConfigVariationsSuite.java |    60 +
 .../ignite/testsuites/IgniteIgfsTestSuite.java  |    39 +-
 .../apache/ignite/testsuites/IgniteIgnore.java  |    40 +
 .../testsuites/IgniteKernalSelfTestSuite.java   |    23 +
 .../IgniteMarshallerSelfTestSuite.java          |     2 +-
 ...essagingConfigVariationFullApiTestSuite.java |    72 +
 .../testsuites/IgnitePlatformsTestSuite.java    |    41 +
 .../testsuites/IgniteRestHandlerTestSuite.java  |     4 +
 ...ServiceConfigVariationsFullApiTestSuite.java |    92 +
 .../IgniteSpiLoadBalancingSelfTestSuite.java    |    34 +-
 .../ignite/testsuites/IgniteSpiTestSuite.java   |     6 +-
 ...orCacheConfigVariationsFullApiTestSuite.java |    41 +
 .../TxDeadlockDetectionTestSuite.java           |    50 +
 ...ryCacheConfigVariationsFullApiTestSuite.java |    71 +
 .../apache/ignite/util/GridLogThrottleTest.java |    27 +-
 modules/docker/1.6.0/Dockerfile                 |    44 +
 modules/docker/1.6.0/run.sh                     |    51 +
 modules/docker/1.7.0/Dockerfile                 |    44 +
 modules/docker/1.7.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 +-
 .../query/h2/opt/GridH2SpatialIndex.java        |    74 +-
 modules/hadoop/pom.xml                          |     2 +-
 .../hadoop/fs/BasicHadoopFileSystemFactory.java |   152 +-
 .../fs/CachingHadoopFileSystemFactory.java      |    55 +-
 .../hadoop/fs/HadoopFileSystemFactory.java      |    11 +-
 .../fs/IgniteHadoopFileSystemCounterWriter.java |    79 +-
 .../fs/IgniteHadoopIgfsSecondaryFileSystem.java |   392 +-
 .../fs/KerberosHadoopFileSystemFactory.java     |    77 +-
 .../hadoop/fs/v1/IgniteHadoopFileSystem.java    |    54 +-
 .../hadoop/fs/v2/IgniteHadoopFileSystem.java    |    76 +-
 .../IgniteHadoopClientProtocolProvider.java     |    12 +-
 .../mapreduce/IgniteHadoopMapReducePlanner.java |   138 +-
 .../IgniteHadoopWeightedMapReducePlanner.java   |   846 ++
 .../ignite/hadoop/util/BasicUserNameMapper.java |   112 +
 .../hadoop/util/ChainedUserNameMapper.java      |    94 +
 .../hadoop/util/KerberosUserNameMapper.java     |   137 +
 .../ignite/hadoop/util/UserNameMapper.java      |    35 +
 .../apache/ignite/hadoop/util/package-info.java |    22 +
 .../processors/hadoop/HadoopAttributes.java     |   168 +
 .../processors/hadoop/HadoopClassLoader.java    |   992 --
 .../processors/hadoop/HadoopCommonUtils.java    |   154 +
 .../processors/hadoop/HadoopContext.java        |     4 +-
 .../processors/hadoop/HadoopDefaultJobInfo.java |   157 -
 .../processors/hadoop/HadoopExternalSplit.java  |    88 +
 .../processors/hadoop/HadoopHelperImpl.java     |   120 +
 .../hadoop/HadoopMapReduceCounterGroup.java     |   123 -
 .../hadoop/HadoopMapReduceCounters.java         |   228 -
 .../processors/hadoop/HadoopProcessor.java      |   150 +-
 .../processors/hadoop/HadoopSplitWrapper.java   |   119 +
 .../internal/processors/hadoop/HadoopUtils.java |   355 -
 .../hadoop/counter/HadoopCounterAdapter.java    |     1 +
 .../counter/HadoopPerformanceCounter.java       |    12 +-
 .../hadoop/delegate/HadoopDelegateUtils.java    |   138 +
 .../HadoopFileSystemCounterWriterDelegate.java  |    36 +
 .../HadoopFileSystemFactoryDelegate.java        |    36 +
 .../HadoopIgfsSecondaryFileSystemDelegate.java  |    28 +
 .../hadoop/fs/HadoopFileSystemCacheUtils.java   |   242 -
 .../hadoop/fs/HadoopFileSystemsUtils.java       |    51 -
 .../hadoop/fs/HadoopLazyConcurrentMap.java      |   212 -
 .../hadoop/fs/HadoopLocalFileSystemV1.java      |    39 -
 .../hadoop/fs/HadoopLocalFileSystemV2.java      |    88 -
 .../processors/hadoop/fs/HadoopParameters.java  |    94 -
 .../hadoop/fs/HadoopRawLocalFileSystem.java     |   314 -
 .../processors/hadoop/igfs/HadoopIgfs.java      |   202 -
 .../igfs/HadoopIgfsCommunicationException.java  |    57 -
 .../processors/hadoop/igfs/HadoopIgfsEx.java    |    93 -
 .../hadoop/igfs/HadoopIgfsFuture.java           |    97 -
 .../hadoop/igfs/HadoopIgfsInProc.java           |   510 -
 .../hadoop/igfs/HadoopIgfsInputStream.java      |   629 -
 .../processors/hadoop/igfs/HadoopIgfsIo.java    |    76 -
 .../processors/hadoop/igfs/HadoopIgfsIpcIo.java |   624 -
 .../hadoop/igfs/HadoopIgfsIpcIoListener.java    |    36 -
 .../hadoop/igfs/HadoopIgfsJclLogger.java        |   116 -
 .../hadoop/igfs/HadoopIgfsOutProc.java          |   524 -
 .../hadoop/igfs/HadoopIgfsOutputStream.java     |   201 -
 .../hadoop/igfs/HadoopIgfsProperties.java       |    86 -
 .../hadoop/igfs/HadoopIgfsProxyInputStream.java |   337 -
 .../igfs/HadoopIgfsProxyOutputStream.java       |   165 -
 ...fsSecondaryFileSystemPositionedReadable.java |   105 -
 .../hadoop/igfs/HadoopIgfsStreamDelegate.java   |    96 -
 .../igfs/HadoopIgfsStreamEventListener.java     |    39 -
 .../processors/hadoop/igfs/HadoopIgfsUtils.java |   174 -
 .../hadoop/igfs/HadoopIgfsWrapper.java          |   547 -
 .../impl/HadoopMapReduceCounterGroup.java       |   124 +
 .../hadoop/impl/HadoopMapReduceCounters.java    |   229 +
 .../processors/hadoop/impl/HadoopUtils.java     |   328 +
 .../HadoopBasicFileSystemFactoryDelegate.java   |   164 +
 .../HadoopCachingFileSystemFactoryDelegate.java |    75 +
 .../HadoopDefaultFileSystemFactoryDelegate.java |    62 +
 ...doopFileSystemCounterWriterDelegateImpl.java |   108 +
 ...doopIgfsSecondaryFileSystemDelegateImpl.java |   472 +
 ...HadoopKerberosFileSystemFactoryDelegate.java |   112 +
 .../impl/fs/HadoopFileSystemCacheUtils.java     |   243 +
 .../hadoop/impl/fs/HadoopFileSystemsUtils.java  |    51 +
 .../hadoop/impl/fs/HadoopLazyConcurrentMap.java |   210 +
 .../hadoop/impl/fs/HadoopLocalFileSystemV1.java |    40 +
 .../hadoop/impl/fs/HadoopLocalFileSystemV2.java |    89 +
 .../hadoop/impl/fs/HadoopParameters.java        |    94 +
 .../impl/fs/HadoopRawLocalFileSystem.java       |   315 +
 .../processors/hadoop/impl/igfs/HadoopIgfs.java |   203 +
 .../igfs/HadoopIgfsCommunicationException.java  |    57 +
 .../hadoop/impl/igfs/HadoopIgfsEx.java          |    94 +
 .../hadoop/impl/igfs/HadoopIgfsFuture.java      |    97 +
 .../hadoop/impl/igfs/HadoopIgfsInProc.java      |   511 +
 .../hadoop/impl/igfs/HadoopIgfsInputStream.java |   630 +
 .../hadoop/impl/igfs/HadoopIgfsIo.java          |    76 +
 .../hadoop/impl/igfs/HadoopIgfsIpcIo.java       |   625 +
 .../impl/igfs/HadoopIgfsIpcIoListener.java      |    36 +
 .../hadoop/impl/igfs/HadoopIgfsJclLogger.java   |   116 +
 .../hadoop/impl/igfs/HadoopIgfsOutProc.java     |   525 +
 .../impl/igfs/HadoopIgfsOutputStream.java       |   202 +
 .../hadoop/impl/igfs/HadoopIgfsProperties.java  |    87 +
 .../impl/igfs/HadoopIgfsProxyInputStream.java   |   338 +
 .../impl/igfs/HadoopIgfsProxyOutputStream.java  |   166 +
 ...fsSecondaryFileSystemPositionedReadable.java |   106 +
 .../impl/igfs/HadoopIgfsStreamDelegate.java     |    96 +
 .../igfs/HadoopIgfsStreamEventListener.java     |    39 +
 .../hadoop/impl/igfs/HadoopIgfsUtils.java       |   175 +
 .../hadoop/impl/igfs/HadoopIgfsWrapper.java     |   554 +
 .../hadoop/impl/proto/HadoopClientProtocol.java |   354 +
 .../hadoop/impl/v1/HadoopV1CleanupTask.java     |    65 +
 .../hadoop/impl/v1/HadoopV1Counter.java         |   107 +
 .../hadoop/impl/v1/HadoopV1MapTask.java         |   122 +
 .../hadoop/impl/v1/HadoopV1OutputCollector.java |   138 +
 .../hadoop/impl/v1/HadoopV1Partitioner.java     |    44 +
 .../hadoop/impl/v1/HadoopV1ReduceTask.java      |   101 +
 .../hadoop/impl/v1/HadoopV1Reporter.java        |    81 +
 .../hadoop/impl/v1/HadoopV1SetupTask.java       |    57 +
 .../hadoop/impl/v1/HadoopV1Splitter.java        |   103 +
 .../processors/hadoop/impl/v1/HadoopV1Task.java |    98 +
 .../processors/hadoop/impl/v2/HadoopDaemon.java |   126 +
 .../impl/v2/HadoopSerializationWrapper.java     |   139 +
 .../impl/v2/HadoopShutdownHookManager.java      |    98 +
 .../hadoop/impl/v2/HadoopV2CleanupTask.java     |    73 +
 .../hadoop/impl/v2/HadoopV2Context.java         |   244 +
 .../hadoop/impl/v2/HadoopV2Counter.java         |    89 +
 .../processors/hadoop/impl/v2/HadoopV2Job.java  |   452 +
 .../impl/v2/HadoopV2JobResourceManager.java     |   324 +
 .../hadoop/impl/v2/HadoopV2MapTask.java         |    99 +
 .../hadoop/impl/v2/HadoopV2Partitioner.java     |    44 +
 .../hadoop/impl/v2/HadoopV2ReduceTask.java      |    91 +
 .../hadoop/impl/v2/HadoopV2SetupTask.java       |    66 +
 .../hadoop/impl/v2/HadoopV2Splitter.java        |   112 +
 .../processors/hadoop/impl/v2/HadoopV2Task.java |   186 +
 .../hadoop/impl/v2/HadoopV2TaskContext.java     |   563 +
 .../impl/v2/HadoopWritableSerialization.java    |    76 +
 .../hadoop/jobtracker/HadoopJobTracker.java     |    31 +-
 .../planner/HadoopAbstractMapReducePlanner.java |   116 +
 .../planner/HadoopDefaultMapReducePlan.java     |     7 +-
 .../planner/HadoopMapReducePlanGroup.java       |   150 +
 .../planner/HadoopMapReducePlanTopology.java    |    89 +
 .../hadoop/proto/HadoopClientProtocol.java      |   349 -
 .../shuffle/collections/HadoopMultimapBase.java |    90 +-
 .../child/HadoopChildProcessRunner.java         |    18 +-
 .../HadoopExternalCommunication.java            |     6 +-
 .../hadoop/v1/HadoopV1CleanupTask.java          |    64 -
 .../processors/hadoop/v1/HadoopV1Counter.java   |   106 -
 .../processors/hadoop/v1/HadoopV1MapTask.java   |   122 -
 .../hadoop/v1/HadoopV1OutputCollector.java      |   137 -
 .../hadoop/v1/HadoopV1Partitioner.java          |    44 -
 .../hadoop/v1/HadoopV1ReduceTask.java           |   101 -
 .../processors/hadoop/v1/HadoopV1Reporter.java  |    81 -
 .../processors/hadoop/v1/HadoopV1SetupTask.java |    56 -
 .../processors/hadoop/v1/HadoopV1Splitter.java  |   102 -
 .../processors/hadoop/v1/HadoopV1Task.java      |    97 -
 .../processors/hadoop/v2/HadoopDaemon.java      |   126 -
 .../hadoop/v2/HadoopExternalSplit.java          |    89 -
 .../hadoop/v2/HadoopSerializationWrapper.java   |   138 -
 .../hadoop/v2/HadoopShutdownHookManager.java    |    98 -
 .../hadoop/v2/HadoopSplitWrapper.java           |   119 -
 .../hadoop/v2/HadoopV2CleanupTask.java          |    72 -
 .../processors/hadoop/v2/HadoopV2Context.java   |   243 -
 .../processors/hadoop/v2/HadoopV2Counter.java   |    88 -
 .../processors/hadoop/v2/HadoopV2Job.java       |   435 -
 .../hadoop/v2/HadoopV2JobResourceManager.java   |   326 -
 .../processors/hadoop/v2/HadoopV2MapTask.java   |    99 -
 .../hadoop/v2/HadoopV2Partitioner.java          |    44 -
 .../hadoop/v2/HadoopV2ReduceTask.java           |    91 -
 .../processors/hadoop/v2/HadoopV2SetupTask.java |    65 -
 .../processors/hadoop/v2/HadoopV2Splitter.java  |   111 -
 .../processors/hadoop/v2/HadoopV2Task.java      |   185 -
 .../hadoop/v2/HadoopV2TaskContext.java          |   559 -
 .../hadoop/v2/HadoopWritableSerialization.java  |    75 -
 .../HadoopClientProtocolEmbeddedSelfTest.java   |    35 -
 .../hadoop/HadoopClientProtocolSelfTest.java    |   654 -
 .../hadoop/cache/HadoopTxConfigCacheTest.java   |    42 -
 ...KerberosHadoopFileSystemFactorySelfTest.java |   121 -
 .../ignite/igfs/Hadoop1DualAbstractTest.java    |   113 -
 .../igfs/Hadoop1OverIgfsDualAsyncTest.java      |    30 -
 .../igfs/Hadoop1OverIgfsDualSyncTest.java       |    30 -
 .../igfs/HadoopFIleSystemFactorySelfTest.java   |   326 -
 ...oopFileSystemUniversalFileSystemAdapter.java |   131 -
 .../HadoopIgfs20FileSystemAbstractSelfTest.java |  2038 ---
 ...Igfs20FileSystemLoopbackPrimarySelfTest.java |    74 -
 ...oopIgfs20FileSystemShmemPrimarySelfTest.java |    74 -
 .../igfs/HadoopIgfsDualAbstractSelfTest.java    |   321 -
 .../igfs/HadoopIgfsDualAsyncSelfTest.java       |    32 -
 .../ignite/igfs/HadoopIgfsDualSyncSelfTest.java |    32 -
 ...oopSecondaryFileSystemConfigurationTest.java |   575 -
 .../apache/ignite/igfs/IgfsEventsTestSuite.java |   279 -
 .../igfs/IgfsNearOnlyMultiNodeSelfTest.java     |   223 -
 .../IgniteHadoopFileSystemAbstractSelfTest.java |  2431 ---
 .../IgniteHadoopFileSystemClientSelfTest.java   |   212 -
 ...IgniteHadoopFileSystemHandshakeSelfTest.java |   314 -
 .../IgniteHadoopFileSystemIpcCacheSelfTest.java |   214 -
 .../IgniteHadoopFileSystemLoggerSelfTest.java   |   298 -
 ...niteHadoopFileSystemLoggerStateSelfTest.java |   329 -
 ...adoopFileSystemLoopbackAbstractSelfTest.java |    46 -
 ...SystemLoopbackEmbeddedDualAsyncSelfTest.java |    33 -
 ...eSystemLoopbackEmbeddedDualSyncSelfTest.java |    33 -
 ...leSystemLoopbackEmbeddedPrimarySelfTest.java |    33 -
 ...SystemLoopbackEmbeddedSecondarySelfTest.java |    34 -
 ...SystemLoopbackExternalDualAsyncSelfTest.java |    33 -
 ...eSystemLoopbackExternalDualSyncSelfTest.java |    33 -
 ...leSystemLoopbackExternalPrimarySelfTest.java |    33 -
 ...SystemLoopbackExternalSecondarySelfTest.java |    34 -
 ...condaryFileSystemInitializationSelfTest.java |   214 -
 ...teHadoopFileSystemSecondaryModeSelfTest.java |   327 -
 ...teHadoopFileSystemShmemAbstractSelfTest.java |    91 -
 ...ileSystemShmemEmbeddedDualAsyncSelfTest.java |    33 -
 ...FileSystemShmemEmbeddedDualSyncSelfTest.java |    33 -
 ...pFileSystemShmemEmbeddedPrimarySelfTest.java |    33 -
 ...ileSystemShmemEmbeddedSecondarySelfTest.java |    33 -
 ...ileSystemShmemExternalDualAsyncSelfTest.java |    33 -
 ...FileSystemShmemExternalDualSyncSelfTest.java |    33 -
 ...pFileSystemShmemExternalPrimarySelfTest.java |    33 -
 ...ileSystemShmemExternalSecondarySelfTest.java |    33 -
 .../hadoop/HadoopAbstractSelfTest.java          |   239 -
 .../hadoop/HadoopAbstractWordCountTest.java     |   175 -
 .../hadoop/HadoopClassLoaderTest.java           |   110 -
 .../hadoop/HadoopCommandLineTest.java           |   474 -
 .../HadoopDefaultMapReducePlannerSelfTest.java  |  1028 --
 .../hadoop/HadoopFileSystemsTest.java           |   155 -
 .../processors/hadoop/HadoopGroupingTest.java   |   307 -
 .../hadoop/HadoopJobTrackerSelfTest.java        |   345 -
 .../hadoop/HadoopMapReduceEmbeddedSelfTest.java |   253 -
 .../processors/hadoop/HadoopMapReduceTest.java  |   410 -
 .../hadoop/HadoopPopularWordsTest.java          |   298 -
 .../HadoopSerializationWrapperSelfTest.java     |    79 -
 .../processors/hadoop/HadoopSharedMap.java      |     1 +
 .../hadoop/HadoopSnappyFullMapReduceTest.java   |    28 -
 .../processors/hadoop/HadoopSnappyTest.java     |   102 -
 .../hadoop/HadoopSortingExternalTest.java       |    46 -
 .../processors/hadoop/HadoopSortingTest.java    |   303 -
 .../hadoop/HadoopSplitWrapperSelfTest.java      |    72 -
 .../processors/hadoop/HadoopStartup.java        |    54 -
 .../hadoop/HadoopTaskExecutionSelfTest.java     |   567 -
 .../hadoop/HadoopTasksAllVersionsTest.java      |   260 -
 .../processors/hadoop/HadoopTasksV1Test.java    |    58 -
 .../processors/hadoop/HadoopTasksV2Test.java    |    77 -
 .../hadoop/HadoopTestClassLoader.java           |   106 +
 .../hadoop/HadoopTestRoundRobinMrPlanner.java   |    71 -
 .../hadoop/HadoopTestTaskContext.java           |   228 -
 .../processors/hadoop/HadoopTestUtils.java      |   107 -
 .../processors/hadoop/HadoopV2JobSelfTest.java  |   100 -
 .../hadoop/HadoopValidationSelfTest.java        |    53 -
 .../hadoop/books/alice-in-wonderland.txt        |  3735 -----
 .../processors/hadoop/books/art-of-war.txt      |  6982 ---------
 .../hadoop/books/huckleberry-finn.txt           | 11733 ---------------
 .../processors/hadoop/books/sherlock-holmes.txt | 13052 -----------------
 .../processors/hadoop/books/tom-sawyer.txt      |  8858 -----------
 .../hadoop/deps/CircularWIthHadoop.java         |    32 -
 .../hadoop/deps/CircularWithoutHadoop.java      |    27 -
 .../processors/hadoop/deps/WithCast.java        |    41 -
 .../hadoop/deps/WithClassAnnotation.java        |    28 -
 .../hadoop/deps/WithConstructorInvocation.java  |    31 -
 .../processors/hadoop/deps/WithExtends.java     |    27 -
 .../processors/hadoop/deps/WithField.java       |    29 -
 .../processors/hadoop/deps/WithImplements.java  |    36 -
 .../hadoop/deps/WithIndirectField.java          |    27 -
 .../processors/hadoop/deps/WithInitializer.java |    33 -
 .../processors/hadoop/deps/WithInnerClass.java  |    31 -
 .../hadoop/deps/WithLocalVariable.java          |    38 -
 .../hadoop/deps/WithMethodAnnotation.java       |    32 -
 .../hadoop/deps/WithMethodArgument.java         |    31 -
 .../hadoop/deps/WithMethodCheckedException.java |    31 -
 .../hadoop/deps/WithMethodInvocation.java       |    31 -
 .../hadoop/deps/WithMethodReturnType.java       |    31 -
 .../hadoop/deps/WithMethodRuntimeException.java |    31 -
 .../processors/hadoop/deps/WithOuterClass.java  |    38 -
 .../hadoop/deps/WithParameterAnnotation.java    |    31 -
 .../processors/hadoop/deps/WithStaticField.java |    29 -
 .../hadoop/deps/WithStaticInitializer.java      |    34 -
 .../processors/hadoop/deps/Without.java         |    25 -
 .../hadoop/examples/HadoopWordCount1.java       |    94 -
 .../hadoop/examples/HadoopWordCount1Map.java    |    67 -
 .../hadoop/examples/HadoopWordCount1Reduce.java |    56 -
 .../hadoop/examples/HadoopWordCount2.java       |   111 -
 .../hadoop/examples/HadoopWordCount2Mapper.java |    73 -
 .../examples/HadoopWordCount2Reducer.java       |    72 -
 .../impl/HadoopAbstractMapReduceTest.java       |   430 +
 .../hadoop/impl/HadoopAbstractSelfTest.java     |   239 +
 .../impl/HadoopAbstractWordCountTest.java       |   175 +
 .../hadoop/impl/HadoopCommandLineTest.java      |   476 +
 .../HadoopDefaultMapReducePlannerSelfTest.java  |   619 +
 .../hadoop/impl/HadoopErrorSimulator.java       |   326 +
 .../hadoop/impl/HadoopFileSystemsTest.java      |   155 +
 .../hadoop/impl/HadoopGroupingTest.java         |   302 +
 .../hadoop/impl/HadoopJobTrackerSelfTest.java   |   334 +
 .../impl/HadoopMapReduceEmbeddedSelfTest.java   |   249 +
 .../HadoopMapReduceErrorResilienceTest.java     |   154 +
 .../hadoop/impl/HadoopMapReduceTest.java        |    66 +
 .../impl/HadoopNoHadoopMapReduceTest.java       |    47 +
 .../hadoop/impl/HadoopPlannerMockJob.java       |   175 +
 .../hadoop/impl/HadoopPopularWordsTest.java     |   298 +
 .../HadoopSerializationWrapperSelfTest.java     |    80 +
 .../impl/HadoopSnappyFullMapReduceTest.java     |    36 +
 .../hadoop/impl/HadoopSnappyTest.java           |   104 +
 .../hadoop/impl/HadoopSortingExternalTest.java  |    46 +
 .../hadoop/impl/HadoopSortingTest.java          |   304 +
 .../hadoop/impl/HadoopSplitWrapperSelfTest.java |    72 +
 .../processors/hadoop/impl/HadoopStartup.java   |    54 +
 .../impl/HadoopTaskExecutionSelfTest.java       |   550 +
 .../hadoop/impl/HadoopTasksAllVersionsTest.java |   264 +
 .../hadoop/impl/HadoopTasksV1Test.java          |    62 +
 .../hadoop/impl/HadoopTasksV2Test.java          |    81 +
 .../impl/HadoopTestRoundRobinMrPlanner.java     |    75 +
 .../hadoop/impl/HadoopTestTaskContext.java      |   233 +
 .../processors/hadoop/impl/HadoopTestUtils.java |   178 +
 .../hadoop/impl/HadoopTxConfigCacheTest.java    |    42 +
 .../hadoop/impl/HadoopUserLibsSelfTest.java     |   261 +
 .../hadoop/impl/HadoopV2JobSelfTest.java        |   108 +
 .../hadoop/impl/HadoopValidationSelfTest.java   |    53 +
 .../HadoopWeightedMapReducePlannerTest.java     |   602 +
 .../HadoopWeightedPlannerMapReduceTest.java     |    38 +
 .../hadoop/impl/books/alice-in-wonderland.txt   |  3735 +++++
 .../processors/hadoop/impl/books/art-of-war.txt |  6982 +++++++++
 .../hadoop/impl/books/huckleberry-finn.txt      | 11733 +++++++++++++++
 .../hadoop/impl/books/sherlock-holmes.txt       | 13052 +++++++++++++++++
 .../processors/hadoop/impl/books/tom-sawyer.txt |  8858 +++++++++++
 .../HadoopClientProtocolEmbeddedSelfTest.java   |    35 +
 .../client/HadoopClientProtocolSelfTest.java    |   654 +
 .../hadoop/impl/examples/HadoopWordCount1.java  |    94 +
 .../impl/examples/HadoopWordCount1Map.java      |    79 +
 .../impl/examples/HadoopWordCount1Reduce.java   |    61 +
 .../hadoop/impl/examples/HadoopWordCount2.java  |   111 +
 .../impl/examples/HadoopWordCount2Combiner.java |    45 +
 .../impl/examples/HadoopWordCount2Mapper.java   |    88 +
 .../impl/examples/HadoopWordCount2Reducer.java  |   113 +
 ...KerberosHadoopFileSystemFactorySelfTest.java |   126 +
 .../impl/igfs/Hadoop1DualAbstractTest.java      |   157 +
 .../impl/igfs/Hadoop1OverIgfsDualAsyncTest.java |    32 +
 .../impl/igfs/Hadoop1OverIgfsDualSyncTest.java  |    32 +
 .../igfs/HadoopFIleSystemFactorySelfTest.java   |   345 +
 .../HadoopIgfs20FileSystemAbstractSelfTest.java |  2047 +++
 ...Igfs20FileSystemLoopbackPrimarySelfTest.java |    77 +
 ...oopIgfs20FileSystemShmemPrimarySelfTest.java |    77 +
 .../igfs/HadoopIgfsDualAbstractSelfTest.java    |   328 +
 .../impl/igfs/HadoopIgfsDualAsyncSelfTest.java  |    32 +
 .../impl/igfs/HadoopIgfsDualSyncSelfTest.java   |    32 +
 ...adoopIgfsSecondaryFileSystemTestAdapter.java |   153 +
 ...oopSecondaryFileSystemConfigurationTest.java |   583 +
 .../hadoop/impl/igfs/IgfsEventsTestSuite.java   |   289 +
 .../igfs/IgfsNearOnlyMultiNodeSelfTest.java     |   226 +
 .../IgniteHadoopFileSystemAbstractSelfTest.java |  2435 +++
 .../IgniteHadoopFileSystemClientSelfTest.java   |   216 +
 ...IgniteHadoopFileSystemHandshakeSelfTest.java |   393 +
 .../IgniteHadoopFileSystemIpcCacheSelfTest.java |   215 +
 .../IgniteHadoopFileSystemLoggerSelfTest.java   |   299 +
 ...niteHadoopFileSystemLoggerStateSelfTest.java |   332 +
 ...adoopFileSystemLoopbackAbstractSelfTest.java |    50 +
 ...SystemLoopbackEmbeddedDualAsyncSelfTest.java |    33 +
 ...eSystemLoopbackEmbeddedDualSyncSelfTest.java |    33 +
 ...leSystemLoopbackEmbeddedPrimarySelfTest.java |    33 +
 ...SystemLoopbackEmbeddedSecondarySelfTest.java |    34 +
 ...SystemLoopbackExternalDualAsyncSelfTest.java |    33 +
 ...eSystemLoopbackExternalDualSyncSelfTest.java |    33 +
 ...leSystemLoopbackExternalPrimarySelfTest.java |    33 +
 ...SystemLoopbackExternalSecondarySelfTest.java |    34 +
 ...condaryFileSystemInitializationSelfTest.java |   217 +
 ...teHadoopFileSystemShmemAbstractSelfTest.java |    94 +
 ...ileSystemShmemEmbeddedDualAsyncSelfTest.java |    33 +
 ...FileSystemShmemEmbeddedDualSyncSelfTest.java |    33 +
 ...pFileSystemShmemEmbeddedPrimarySelfTest.java |    33 +
 ...ileSystemShmemEmbeddedSecondarySelfTest.java |    33 +
 ...ileSystemShmemExternalDualAsyncSelfTest.java |    33 +
 ...FileSystemShmemExternalDualSyncSelfTest.java |    33 +
 ...pFileSystemShmemExternalPrimarySelfTest.java |    33 +
 ...ileSystemShmemExternalSecondarySelfTest.java |    33 +
 .../collections/HadoopAbstractMapTest.java      |   175 +
 .../HadoopConcurrentHashMultimapSelftest.java   |   280 +
 .../collections/HadoopHashMapSelfTest.java      |   133 +
 .../collections/HadoopSkipListSelfTest.java     |   320 +
 .../streams/HadoopDataStreamSelfTest.java       |   153 +
 .../taskexecutor/HadoopExecutorServiceTest.java |   119 +
 .../HadoopExternalTaskExecutionSelfTest.java    |   232 +
 .../HadoopExternalCommunicationSelfTest.java    |   222 +
 .../impl/util/BasicUserNameMapperSelfTest.java  |   134 +
 .../util/ChainedUserNameMapperSelfTest.java     |   111 +
 .../util/KerberosUserNameMapperSelfTest.java    |   100 +
 .../collections/HadoopAbstractMapTest.java      |   172 -
 .../HadoopConcurrentHashMultimapSelftest.java   |   278 -
 .../collections/HadoopHashMapSelfTest.java      |   177 -
 .../collections/HadoopSkipListSelfTest.java     |   318 -
 .../streams/HadoopDataStreamSelfTest.java       |   150 -
 .../hadoop/state/HadoopGroupingTestState.java   |    40 +
 .../state/HadoopJobTrackerSelfTestState.java    |    45 +
 .../HadoopMapReduceEmbeddedSelfTestState.java   |    32 +
 .../HadoopTaskExecutionSelfTestValues.java      |    51 +
 .../taskexecutor/HadoopExecutorServiceTest.java |   118 -
 .../HadoopExternalTaskExecutionSelfTest.java    |   232 -
 .../HadoopExternalCommunicationSelfTest.java    |   220 -
 .../testsuites/IgniteHadoopTestSuite.java       |   131 +-
 .../IgniteIgfsLinuxAndMacOSTestSuite.java       |    25 +-
 modules/hibernate/pom.xml                       |     2 +-
 modules/ignored-tests/README.txt                |     4 +
 modules/ignored-tests/pom.xml                   |   233 +
 .../testsuites/IgniteIgnoredTestSuite.java      |    57 +
 .../apache/ignite/testsuites/package-info.java  |    22 +
 modules/indexing/pom.xml                        |     9 +-
 .../query/h2/GridH2ResultSetIterator.java       |    62 +-
 .../processors/query/h2/IgniteH2Indexing.java   |   795 +-
 .../query/h2/opt/GridH2AbstractKeyValueRow.java |    95 +-
 .../query/h2/opt/GridH2CollocationModel.java    |   783 +
 .../processors/query/h2/opt/GridH2Cursor.java   |    36 +-
 .../query/h2/opt/GridH2DefaultTableEngine.java  |    38 +
 .../query/h2/opt/GridH2IndexBase.java           |  1426 +-
 .../query/h2/opt/GridH2KeyValueRowOffheap.java  |    17 +-
 .../query/h2/opt/GridH2MetaTable.java           |   383 +
 .../query/h2/opt/GridH2QueryContext.java        |   612 +
 .../query/h2/opt/GridH2QueryType.java           |    49 +
 .../query/h2/opt/GridH2RetryException.java      |    32 +
 .../processors/query/h2/opt/GridH2Row.java      |    86 +-
 .../query/h2/opt/GridH2RowDescriptor.java       |    28 +-
 .../query/h2/opt/GridH2RowFactory.java          |   179 +
 .../processors/query/h2/opt/GridH2Table.java    |   371 +-
 .../query/h2/opt/GridH2TreeIndex.java           |   142 +-
 .../processors/query/h2/opt/GridH2Utils.java    |   133 -
 .../query/h2/opt/GridH2ValueCacheObject.java    |    22 +-
 .../query/h2/opt/GridLuceneIndex.java           |     7 +-
 .../processors/query/h2/sql/GridSqlAlias.java   |    12 +
 .../processors/query/h2/sql/GridSqlColumn.java  |    22 +-
 .../processors/query/h2/sql/GridSqlConst.java   |     5 +
 .../processors/query/h2/sql/GridSqlElement.java |    11 +
 .../processors/query/h2/sql/GridSqlJoin.java    |    17 +-
 .../query/h2/sql/GridSqlOperation.java          |     2 +-
 .../query/h2/sql/GridSqlOperationType.java      |     8 +-
 .../query/h2/sql/GridSqlQueryParser.java        |    97 +-
 .../query/h2/sql/GridSqlQuerySplitter.java      |   299 +-
 .../processors/query/h2/sql/GridSqlSelect.java  |    11 +-
 .../processors/query/h2/sql/GridSqlTable.java   |    70 +
 .../processors/query/h2/sql/GridSqlType.java    |     5 +
 .../query/h2/twostep/GridMapQueryExecutor.java  |   451 +-
 .../query/h2/twostep/GridMergeIndex.java        |    75 +-
 .../h2/twostep/GridMergeIndexUnsorted.java      |     6 +-
 .../query/h2/twostep/GridMergeTable.java        |     4 +-
 .../h2/twostep/GridReduceQueryExecutor.java     |   343 +-
 .../query/h2/twostep/GridThreadLocalTable.java  |    68 +-
 .../query/h2/twostep/msg/GridH2Array.java       |     9 +-
 .../query/h2/twostep/msg/GridH2Boolean.java     |    10 +-
 .../query/h2/twostep/msg/GridH2Byte.java        |     9 +-
 .../query/h2/twostep/msg/GridH2Bytes.java       |    11 +-
 .../query/h2/twostep/msg/GridH2CacheObject.java |     9 +-
 .../query/h2/twostep/msg/GridH2Date.java        |     9 +-
 .../query/h2/twostep/msg/GridH2Decimal.java     |    11 +-
 .../query/h2/twostep/msg/GridH2Double.java      |     9 +-
 .../query/h2/twostep/msg/GridH2Float.java       |     9 +-
 .../query/h2/twostep/msg/GridH2Geometry.java    |    11 +-
 .../h2/twostep/msg/GridH2IndexRangeRequest.java |   208 +
 .../twostep/msg/GridH2IndexRangeResponse.java   |   279 +
 .../query/h2/twostep/msg/GridH2Integer.java     |    20 +-
 .../query/h2/twostep/msg/GridH2JavaObject.java  |    11 +-
 .../query/h2/twostep/msg/GridH2Long.java        |     9 +-
 .../query/h2/twostep/msg/GridH2Null.java        |    15 +-
 .../h2/twostep/msg/GridH2QueryRequest.java      |   401 +
 .../query/h2/twostep/msg/GridH2RowMessage.java  |   116 +
 .../query/h2/twostep/msg/GridH2RowRange.java    |   181 +
 .../h2/twostep/msg/GridH2RowRangeBounds.java    |   188 +
 .../query/h2/twostep/msg/GridH2Short.java       |     9 +-
 .../query/h2/twostep/msg/GridH2String.java      |     9 +-
 .../query/h2/twostep/msg/GridH2Time.java        |     9 +-
 .../query/h2/twostep/msg/GridH2Timestamp.java   |    11 +-
 .../query/h2/twostep/msg/GridH2Uuid.java        |     9 +-
 .../h2/twostep/msg/GridH2ValueMessage.java      |     2 +-
 .../twostep/msg/GridH2ValueMessageFactory.java  |    22 +-
 .../CacheAbstractQueryMetricsSelfTest.java      |    10 +-
 .../CacheBinaryKeyConcurrentQueryTest.java      |   298 +
 .../cache/CacheIndexingOffheapCleanupTest.java  |   178 +
 .../CacheOffheapBatchIndexingBaseTest.java      |   313 +
 .../CacheOffheapBatchIndexingMultiTypeTest.java |   108 +
 ...CacheOffheapBatchIndexingSingleTypeTest.java |   161 +
 .../CacheOperationsWithExpirationTest.java      |   355 +
 .../cache/CacheSqlQueryValueCopySelfTest.java   |   226 +
 .../ClientReconnectAfterClusterRestartTest.java |   225 +
 .../cache/GridCacheOffheapIndexGetSelfTest.java |    48 +
 ...idCacheReduceQueryMultithreadedSelfTest.java |   168 -
 ...niteBinaryObjectLocalQueryArgumentsTest.java |    28 +
 ...aryObjectQueryArgumentsOffheapLocalTest.java |    28 +
 ...teBinaryObjectQueryArgumentsOffheapTest.java |    30 +
 .../IgniteBinaryObjectQueryArgumentsTest.java   |   472 +-
 .../IgniteCacheAbstractFieldsQuerySelfTest.java |     2 +-
 .../cache/IgniteCacheAbstractQuerySelfTest.java |    64 +-
 .../IgniteCacheConfigVariationsQueryTest.java   |   505 +
 .../IgniteCacheCrossCacheJoinRandomTest.java    |   442 +
 ...acheDistributedJoinCollocatedAndNotTest.java |   365 +
 ...acheDistributedJoinCustomAffinityMapper.java |   262 +
 .../IgniteCacheDistributedJoinNoIndexTest.java  |   299 +
 ...ributedJoinPartitionedAndReplicatedTest.java |   487 +
 ...CacheDistributedJoinQueryConditionsTest.java |   624 +
 .../cache/IgniteCacheDistributedJoinTest.java   |   316 +
 ...PartitionedAndReplicatedCollocationTest.java |   399 +
 ...teCacheJoinPartitionedAndReplicatedTest.java |   316 +
 ...IgniteCacheJoinQueryWithAffinityKeyTest.java |   646 +
 ...eLockPartitionOnAffinityRunAbstractTest.java |   430 +
 ...PartitionOnAffinityRunAtomicCacheOpTest.java |   329 +
 ...niteCacheLockPartitionOnAffinityRunTest.java |   852 ++
 ...LockPartitionOnAffinityRunTxCacheOpTest.java |    33 +
 ...titionOnAffinityRunWithCollisionSpiTest.java |   204 +
 .../cache/IgniteCacheOffheapEvictQueryTest.java |     2 +-
 .../cache/IgniteCacheOffheapIndexScanTest.java  |   195 +
 ...IgniteCachePrimitiveFieldsQuerySelfTest.java |   134 +
 .../cache/IgniteCacheQueriesLoadTest1.java      |   604 +
 .../IgniteCacheQueryH2IndexingLeakTest.java     |   214 +
 .../cache/IgniteCacheQueryIndexSelfTest.java    |     2 +-
 .../cache/IgniteCacheQueryLoadSelfTest.java     |    12 +-
 .../IgniteCacheStarvationOnRebalanceTest.java   |   166 +
 .../cache/IgniteCacheUnionDuplicatesTest.java   |   151 +
 .../cache/IgniteClientReconnectQueriesTest.java |     4 +-
 .../cache/IgniteCrossCachesJoinsQueryTest.java  |  1641 +++
 .../IgniteCacheQueryNoRebalanceSelfTest.java    |    82 +
 ...QueryNodeRestartDistributedJoinSelfTest.java |   476 +
 .../IgniteCacheQueryNodeRestartSelfTest2.java   |     3 +
 ...gniteCacheReplicatedFieldsQuerySelfTest.java |     6 +-
 .../IgniteCacheReplicatedQuerySelfTest.java     |    54 +-
 .../IgniteCacheLocalFieldsQuerySelfTest.java    |    16 +
 ...dCacheAbstractReduceFieldsQuerySelfTest.java |   420 -
 ...ridCacheReduceFieldsQueryAtomicSelfTest.java |    38 -
 ...GridCacheReduceFieldsQueryLocalSelfTest.java |    37 -
 ...cheReduceFieldsQueryPartitionedSelfTest.java |    59 -
 ...acheReduceFieldsQueryReplicatedSelfTest.java |    37 -
 .../query/IgniteSqlSchemaIndexingTest.java      |     5 +-
 .../query/IgniteSqlSplitterSelfTest.java        |   908 +-
 .../h2/GridIndexingSpiAbstractSelfTest.java     |   147 +-
 .../query/h2/opt/GridH2TableSelfTest.java       |    10 +-
 .../h2/sql/AbstractH2CompareQueryTest.java      |   165 +-
 .../query/h2/sql/GridQueryParsingTest.java      |    30 +-
 .../H2CompareBigQueryDistributedJoinsTest.java  |    28 +
 .../query/h2/sql/H2CompareBigQueryTest.java     |   119 +-
 .../IgniteBinaryCacheQueryTestSuite.java        |     3 -
 .../IgniteBinaryCacheQueryTestSuite2.java       |     3 +
 .../IgniteCacheAffinityRunTestSuite.java        |    45 +
 ...gniteCacheConfigVariationQueryTestSuite.java |    41 +
 .../IgniteCacheQuerySelfTestSuite.java          |    44 +-
 .../IgniteCacheQuerySelfTestSuite2.java         |    14 +-
 .../IgniteCacheQuerySelfTestSuite3.java         |    36 +-
 .../IgniteCacheQuerySelfTestSuite4.java         |     7 +
 .../IgniteCacheWithIndexingTestSuite.java       |    13 +-
 modules/jcl/pom.xml                             |     2 +-
 modules/jms11/pom.xml                           |     2 +-
 .../stream/jms11/IgniteJmsStreamerTest.java     |   206 +-
 .../jms11/IgniteJmsStreamerTestSuite.java       |     2 +-
 modules/jta/pom.xml                             |     2 +-
 .../websphere/WebSphereLibertyTmFactory.java    |    77 +
 .../cache/jta/websphere/WebSphereTmFactory.java |   244 +
 .../cache/jta/websphere/package-info.java       |    22 +
 ...titionedCacheJtaLookupClassNameSelfTest.java |     4 +-
 .../ignite/testsuites/IgniteJtaTestSuite.java   |     3 +-
 modules/kafka/README.txt                        |    85 +-
 modules/kafka/pom.xml                           |     5 +-
 .../ignite/stream/kafka/KafkaStreamer.java      |     4 +-
 .../kafka/connect/IgniteSinkConnector.java      |     9 +
 .../kafka/connect/IgniteSourceConnector.java    |    90 +
 .../kafka/connect/IgniteSourceConstants.java    |    44 +
 .../stream/kafka/connect/IgniteSourceTask.java  |   363 +
 .../stream/kafka/connect/package-info.java      |    21 +
 .../serialization/CacheEventConverter.java      |    66 +
 .../serialization/CacheEventDeserializer.java   |    54 +
 .../serialization/CacheEventSerializer.java     |    54 +
 .../connect/serialization/package-info.java     |    21 +
 .../kafka/IgniteKafkaStreamerSelfTestSuite.java |     4 +-
 .../kafka/KafkaIgniteStreamerSelfTest.java      |    11 +-
 .../ignite/stream/kafka/TestKafkaBroker.java    |    27 +-
 .../kafka/connect/IgniteSinkConnectorTest.java  |    32 +-
 .../connect/IgniteSourceConnectorMock.java      |    30 +
 .../connect/IgniteSourceConnectorTest.java      |   355 +
 .../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 +-
 .../osgi-karaf/src/main/resources/features.xml  |    12 +-
 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     |   104 +
 .../ignite/impl/binary/binary_reader_impl.h     |  1426 ++
 .../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   |   633 +
 .../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      |   921 ++
 .../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   |   238 +
 .../binary/src/impl/interop/interop_memory.cpp  |   171 +
 .../src/impl/interop/interop_output_stream.cpp  |   234 +
 modules/platforms/cpp/common/Makefile.am        |    53 +-
 modules/platforms/cpp/common/configure.ac       |    62 -
 .../platforms/cpp/common/ignite-common.pc.in    |     9 -
 .../platforms/cpp/common/include/Makefile.am    |    22 +-
 .../common/include/ignite/common/big_integer.h  |   523 +
 .../cpp/common/include/ignite/common/bits.h     |   218 +
 .../common/include/ignite/common/concurrent.h   |   196 +-
 .../cpp/common/include/ignite/common/decimal.h  |   527 +
 .../include/ignite/common/default_allocator.h   |    95 +
 .../include/ignite/common/dynamic_size_array.h  |   415 +
 .../cpp/common/include/ignite/common/exports.h  |   182 -
 .../include/ignite/common/fixed_size_array.h    |   288 +
 .../cpp/common/include/ignite/common/java.h     |   743 -
 .../cpp/common/include/ignite/common/utils.h    |   226 +-
 .../platforms/cpp/common/include/ignite/date.h  |   138 +
 .../platforms/cpp/common/include/ignite/guid.h  |   172 +
 .../cpp/common/include/ignite/ignite_error.h    |   294 +
 .../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      |   142 +
 .../cpp/common/os/win/src/concurrent_os.cpp     |   175 -
 .../cpp/common/project/vs/common.vcxproj        |    78 +-
 .../common/project/vs/common.vcxproj.filters    |    75 +-
 .../platforms/cpp/common/project/vs/module.def  |   132 -
 .../cpp/common/src/common/big_integer.cpp       |   829 ++
 .../platforms/cpp/common/src/common/bits.cpp    |   233 +
 .../cpp/common/src/common/concurrent.cpp        |   105 +
 .../platforms/cpp/common/src/common/decimal.cpp |   275 +
 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       |  2779 ----
 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     |    67 +-
 .../cpp/core-test/config/cache-query.xml        |    44 +-
 .../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  |    25 +-
 .../project/vs/core-test.vcxproj.filters        |    23 +-
 .../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 +
 .../platforms/cpp/core-test/src/bits_test.cpp   |   124 +
 .../cpp/core-test/src/cache_query_test.cpp      |  1093 +-
 .../platforms/cpp/core-test/src/cache_test.cpp  |    24 +
 .../cpp/core-test/src/concurrent_test.cpp       |    93 +
 .../cpp/core-test/src/decimal_test.cpp          |  1101 ++
 .../core-test/src/dynamic_size_array_test.cpp   |   360 +
 .../cpp/core-test/src/fixed_size_array_test.cpp |   208 +
 .../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          |    87 +-
 modules/platforms/cpp/core/configure.ac         |    62 -
 modules/platforms/cpp/core/include/Makefile.am  |    84 +-
 .../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   |    76 +-
 .../ignite/cache/query/query_fields_cursor.h    |    56 +-
 .../ignite/cache/query/query_fields_row.h       |    59 +-
 .../include/ignite/cache/query/query_scan.h     |    18 +-
 .../core/include/ignite/cache/query/query_sql.h |    76 +-
 .../ignite/cache/query/query_sql_fields.h       |   126 +-
 .../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          |     9 +-
 .../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 +-
 .../ignite/impl/cache/query/query_batch.h       |   148 +
 .../impl/cache/query/query_fields_row_impl.h    |    50 +-
 .../ignite/impl/cache/query/query_impl.h        |    39 +-
 .../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        |   153 +
 .../cpp/core/include/ignite/impl/operations.h   |   134 +-
 .../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  |    92 +-
 .../cpp/core/project/vs/core.vcxproj.filters    |   181 +-
 .../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     |    24 +-
 .../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    |     3 +-
 .../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_batch.cpp   |    52 +
 .../core/src/impl/cache/query/query_impl.cpp    |   183 +-
 .../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    |   179 +
 .../src/impl/transactions/transaction_impl.cpp  |   196 +
 .../src/impl/transactions/transactions_impl.cpp |   205 +
 .../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       |    16 +-
 .../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         |   459 +
 .../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        |   191 +
 .../platforms/cpp/jni/include/ignite/jni/java.h |   787 +
 .../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 |   140 +
 .../platforms/cpp/jni/project/vs/targetver.h    |    25 +
 modules/platforms/cpp/jni/src/exports.cpp       |   577 +
 modules/platforms/cpp/jni/src/java.cpp          |  3027 ++++
 modules/platforms/cpp/odbc-test/Makefile.am     |    93 +
 modules/platforms/cpp/odbc-test/README.TXT      |     1 +
 .../odbc-test/config/queries-test-noodbc.xml    |   103 +
 .../cpp/odbc-test/config/queries-test.xml       |   109 +
 .../platforms/cpp/odbc-test/include/Makefile.am |    25 +
 .../odbc-test/include/sql_test_suite_fixture.h  |   197 +
 .../include/teamcity/teamcity_messages.h        |    55 +
 .../platforms/cpp/odbc-test/include/test_type.h |   130 +
 .../cpp/odbc-test/include/test_utils.h          |    53 +
 .../cpp/odbc-test/project/vs/odbc-test.vcxproj  |   215 +
 .../project/vs/odbc-test.vcxproj.filters        |   141 +
 .../cpp/odbc-test/src/api_robustness_test.cpp   |  1006 ++
 .../src/application_data_buffer_test.cpp        |   997 ++
 .../platforms/cpp/odbc-test/src/column_test.cpp |   290 +
 .../cpp/odbc-test/src/configuration_test.cpp    |   394 +
 .../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          |   823 ++
 .../platforms/cpp/odbc-test/src/row_test.cpp    |   209 +
 .../src/sql_aggregate_functions_test.cpp        |   249 +
 .../src/sql_date_time_functions_test.cpp        |   213 +
 .../src/sql_numeric_functions_test.cpp          |   309 +
 .../cpp/odbc-test/src/sql_operators_test.cpp    |   214 +
 .../cpp/odbc-test/src/sql_outer_join_test.cpp   |   498 +
 .../odbc-test/src/sql_string_functions_test.cpp |   354 +
 .../odbc-test/src/sql_system_functions_test.cpp |    47 +
 .../odbc-test/src/sql_test_suite_fixture.cpp    |   288 +
 .../cpp/odbc-test/src/sql_types_test.cpp        |    60 +
 .../src/sql_value_expressions_test.cpp          |    94 +
 .../odbc-test/src/teamcity/teamcity_boost.cpp   |   159 +
 .../src/teamcity/teamcity_messages.cpp          |   150 +
 .../platforms/cpp/odbc-test/src/test_utils.cpp  |    36 +
 .../cpp/odbc-test/src/utility_test.cpp          |    81 +
 modules/platforms/cpp/odbc/Makefile.am          |    86 +
 modules/platforms/cpp/odbc/README.txt           |    89 +
 modules/platforms/cpp/odbc/include/Makefile.am  |    59 +
 .../platforms/cpp/odbc/include/ignite/odbc.h    |   260 +
 .../ignite/odbc/app/application_data_buffer.h   |   422 +
 .../odbc/include/ignite/odbc/app/parameter.h    |   138 +
 .../cpp/odbc/include/ignite/odbc/column.h       |   155 +
 .../cpp/odbc/include/ignite/odbc/common_types.h |   238 +
 .../include/ignite/odbc/config/configuration.h  |   418 +
 .../ignite/odbc/config/connection_info.h        |    98 +
 .../cpp/odbc/include/ignite/odbc/connection.h   |   276 +
 .../cpp/odbc/include/ignite/odbc/cursor.h       |   114 +
 .../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/dsn_config.h   |    61 +
 .../cpp/odbc/include/ignite/odbc/environment.h  |   137 +
 .../cpp/odbc/include/ignite/odbc/message.h      |   766 +
 .../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       |   134 +
 .../odbc/include/ignite/odbc/protocol_version.h |   188 +
 .../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  |    98 +
 .../cpp/odbc/include/ignite/odbc/row.h          |   132 +
 .../cpp/odbc/include/ignite/odbc/statement.h    |   567 +
 .../include/ignite/odbc/system/odbc_constants.h |    41 +
 .../include/ignite/odbc/system/socket_client.h  |    92 +
 .../odbc/system/ui/dsn_configuration_window.h   |   160 +
 .../cpp/odbc/include/ignite/odbc/type_traits.h  |   316 +
 .../cpp/odbc/include/ignite/odbc/utility.h      |   180 +
 .../cpp/odbc/install/ignite-odbc-install.ini    |     6 +
 .../cpp/odbc/install/install_amd64.cmd          |    42 +
 .../platforms/cpp/odbc/install/install_x86.cmd  |    22 +
 .../odbc/os/linux/src/system/socket_client.cpp  |   120 +
 .../ignite/odbc/system/ui/custom_window.h       |   189 +
 .../win/include/ignite/odbc/system/ui/window.h  |   201 +
 .../odbc/os/win/src/system/socket_client.cpp    |   133 +
 .../odbc/os/win/src/system/ui/custom_window.cpp |   184 +
 .../src/system/ui/dsn_configuration_window.cpp  |   326 +
 .../cpp/odbc/os/win/src/system/ui/window.cpp    |   192 +
 .../cpp/odbc/os/win/src/system_dsn.cpp          |   218 +
 modules/platforms/cpp/odbc/project/README.TXT   |     1 +
 .../platforms/cpp/odbc/project/vs/README.TXT    |     1 +
 .../platforms/cpp/odbc/project/vs/module.def    |    68 +
 .../platforms/cpp/odbc/project/vs/odbc.vcxproj  |   247 +
 .../cpp/odbc/project/vs/odbc.vcxproj.filters    |   264 +
 .../odbc/src/app/application_data_buffer.cpp    |  1484 ++
 .../platforms/cpp/odbc/src/app/parameter.cpp    |   269 +
 modules/platforms/cpp/odbc/src/column.cpp       |   484 +
 modules/platforms/cpp/odbc/src/common_types.cpp |   123 +
 .../cpp/odbc/src/config/configuration.cpp       |   328 +
 .../cpp/odbc/src/config/connection_info.cpp     |   454 +
 modules/platforms/cpp/odbc/src/connection.cpp   |   374 +
 modules/platforms/cpp/odbc/src/cursor.cpp       |    82 +
 .../odbc/src/diagnostic/diagnosable_adapter.cpp |    51 +
 .../odbc/src/diagnostic/diagnostic_record.cpp   |   265 +
 .../diagnostic/diagnostic_record_storage.cpp    |   242 +
 modules/platforms/cpp/odbc/src/dsn_config.cpp   |   123 +
 modules/platforms/cpp/odbc/src/entry_points.cpp |   697 +
 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         |  1368 ++
 .../platforms/cpp/odbc/src/protocol_version.cpp |   145 +
 .../odbc/src/query/column_metadata_query.cpp    |   318 +
 .../platforms/cpp/odbc/src/query/data_query.cpp |   274 +
 .../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    |   660 +
 modules/platforms/cpp/odbc/src/type_traits.cpp  |   669 +
 modules/platforms/cpp/odbc/src/utility.cpp      |   141 +
 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.Tests.csproj           |    77 +
 .../Apache.Ignite.AspNet.Tests.snk              |   Bin 0 -> 596 bytes
 .../Apache.Ignite.AspNet.Tests/App.config       |    72 +
 .../ExpiryCacheHolderTest.cs                    |   492 +
 .../IgniteOutputCacheProviderTest.cs            |   172 +
 .../IgniteSessionStateItemCollectionTest.cs     |   267 +
 .../IgniteSessionStateStoreDataTest.cs          |   117 +
 .../IgniteSessionStateStoreProviderTest.cs      |   438 +
 .../Properties/AssemblyInfo.cs                  |    42 +
 .../Apache.Ignite.AspNet.Tests/packages.config  |    22 +
 .../Apache.Ignite.AspNet.csproj                 |    79 +
 .../Apache.Ignite.AspNet.nuspec                 |    54 +
 .../Apache.Ignite.AspNet.ruleset                |    12 +
 .../Apache.Ignite.AspNet.snk                    |   Bin 0 -> 596 bytes
 .../IgniteOutputCacheProvider.cs                |   124 +
 .../IgniteSessionStateStoreProvider.cs          |   500 +
 .../Apache.Ignite.AspNet/IgniteWebUtils.cs      |    44 +
 .../Apache.Ignite.AspNet/Impl/ConfigUtil.cs     |   110 +
 .../Impl/ExpiryCacheHolder.cs                   |   113 +
 .../Impl/IgniteSessionStateItemCollection.cs    |   534 +
 .../Impl/IgniteSessionStateStoreData.cs         |   116 +
 .../Impl/SessionStateLockResult.cs              |    91 +
 .../dotnet/Apache.Ignite.AspNet/Package-Info.cs |    26 +
 .../Properties/AssemblyInfo.cs                  |    42 +
 .../Apache.Ignite.Benchmarks.csproj             |    36 +-
 .../Apache.Ignite.Benchmarks/BenchmarkRunner.cs |     5 +-
 .../Interop/PlatformBenchmarkBase.cs            |     2 +-
 .../Properties/AssemblyInfo.cs                  |    40 +-
 .../Apache.Ignite.Core.Tests.NuGet.csproj       |    86 +-
 .../Apache.Ignite.Core.Tests.NuGet.sln          |     6 +
 .../AspNetTest.cs                               |    73 +
 .../Apache.Ignite.Core.Tests.NuGet/CacheTest.cs |    37 +-
 .../Log4NetTest.cs                              |    87 +
 .../Apache.Ignite.Core.Tests.NuGet/NLogTest.cs  |    82 +
 .../Apache.Ignite.Core.Tests.NuGet/NuGet.config |     5 +-
 .../Properties/AssemblyInfo.cs                  |    36 +-
 .../SchemaTest.cs                               |    62 +
 .../install-package.cmd                         |    10 -
 .../install-package.ps1                         |    34 +
 .../packages.config                             |    29 +
 .../Apache.Ignite.Core.Tests.TestDll.csproj     |    37 +-
 .../Properties/AssemblyInfo.cs                  |    40 +-
 .../Apache.Ignite.Core.Tests.csproj             |   189 +-
 .../Binary/BinaryBuilderSelfTest.cs             |   410 +-
 .../Binary/BinaryCompactFooterInteropTest.cs    |     1 -
 .../Binary/BinaryReaderWriterTest.cs            |   171 +
 .../Binary/BinarySelfTest.cs                    |   167 +-
 .../Binary/BinaryStringTest.cs                  |   100 +
 .../Binary/IO/BinaryStreamsTest.cs              |   151 +
 .../Binary/JavaTypeMappingTest.cs               |   158 +
 .../Binary/TypeResolverTest.cs                  |   107 +
 .../Cache/Affinity/AffinityFieldTest.cs         |   199 +
 .../Affinity/AffinityFunctionSpringTest.cs      |   184 +
 .../Cache/Affinity/AffinityFunctionTest.cs      |   485 +
 .../Cache/Affinity/AffinityKeyTest.cs           |    66 +
 .../Cache/Affinity/AffinityTest.cs              |   138 +
 .../Affinity/AffinityTopologyVersionTest.cs     |    59 +
 .../Cache/CacheAbstractTest.cs                  |    82 +-
 .../Cache/CacheAffinityFieldTest.cs             |   199 -
 .../Cache/CacheAffinityTest.cs                  |   139 -
 .../Cache/CacheConfigurationTest.cs             |   190 +-
 .../Cache/CacheNearTest.cs                      |   188 +
 .../Cache/CacheResultTest.cs                    |    75 +
 .../Cache/Query/CacheLinqTest.cs                |  1543 ++
 .../Query/CacheQueriesCodeConfigurationTest.cs  |    12 +
 .../Cache/Query/CacheQueriesTest.cs             |   303 +-
 .../Continuous/ContinuousQueryAbstractTest.cs   |    85 +-
 .../Continuous/ContinuousQueryJavaFilterTest.cs |   322 +
 .../Cache/Store/CacheParallelLoadStoreTest.cs   |     2 +-
 .../Cache/Store/CacheStoreAdapterTest.cs        |    90 +
 .../Cache/Store/CacheStoreTest.cs               |    51 +-
 .../Cache/Store/CacheTestParallelLoadStore.cs   |     9 +
 .../Cache/Store/CacheTestStore.cs               |    50 +-
 .../Collections/MultiValueDictionaryTest.cs     |    58 +
 .../Collections/ReadOnlyCollectionTest.cs       |    59 +
 .../Collections/ReadOnlyDictionaryTest.cs       |    70 +
 .../Common/IgniteGuidTest.cs                    |    62 +
 .../Compute/AbstractTaskTest.cs                 |    49 +-
 .../Compute/BinarizableClosureTaskTest.cs       |    18 +-
 .../Compute/BinarizableTaskTest.cs              |    31 +-
 .../Compute/CancellationTest.cs                 |    10 +
 .../Compute/ClosureTaskTest.cs                  |   192 +-
 .../Compute/ComputeApiTest.cs                   |   221 +-
 .../Compute/FailoverTaskSelfTest.cs             |     7 +-
 .../Compute/IgniteExceptionTaskSelfTest.cs      |    55 +-
 .../Compute/MixedClusterTest.cs                 |   123 +-
 .../Compute/ResourceTaskTest.cs                 |    59 +-
 .../Compute/SerializableClosureTaskTest.cs      |     5 +
 .../Compute/TaskAdapterTest.cs                  |    21 +-
 .../Compute/TaskResultTest.cs                   |    24 +-
 .../Config/Apache.Ignite.exe.config.test2       |     2 +-
 .../Config/Cache/Affinity/affinity-function.xml |   127 +
 .../Cache/Affinity/affinity-function2.xml       |    49 +
 .../Config/Cache/Store/cache-store-session.xml  |     3 +-
 .../Config/Compute/compute-grid1.xml            |     3 +-
 .../Config/Compute/compute-grid2.xml            |     3 +-
 .../Config/Compute/compute-grid3.xml            |     5 +-
 .../Config/Compute/compute-standalone.xml       |     5 +-
 .../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 +-
 .../Config/Log/custom-log.xml                   |    50 +
 .../Config/Log/dotnet-log4j.xml                 |   143 +
 .../Config/cache-binarizables.xml               |     3 +-
 .../Config/cache-local-node.xml                 |     3 +-
 .../Config/cache-query-continuous.xml           |     4 +-
 .../Config/cache-query.xml                      |    43 +-
 .../Config/ignite-dotnet-cfg.xml                |     2 +-
 .../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 +-
 .../ConsoleRedirectTest.cs                      |   177 +
 .../Apache.Ignite.Core.Tests/DeploymentTest.cs  |     3 +-
 .../Apache.Ignite.Core.Tests/EventsTest.cs      |   200 +-
 .../Examples/Example.cs                         |     8 +-
 .../Examples/ExamplesTest.cs                    |    48 +-
 .../Examples/PathUtil.cs                        |    10 +-
 .../Examples/ProjectFilesTest.cs                |     4 +-
 .../Apache.Ignite.Core.Tests/ExceptionsTest.cs  |   132 +-
 .../Apache.Ignite.Core.Tests/ExecutableTest.cs  |     1 -
 .../IgniteConfigurationSectionTest.cs           |    32 +
 .../IgniteConfigurationSerializerTest.cs        |   398 +-
 .../IgniteConfigurationTest.cs                  |   142 +-
 .../IgniteStartStopTest.cs                      |     4 +-
 .../Apache.Ignite.Core.Tests/LifecycleTest.cs   |     9 +
 .../Log/CustomLoggerTest.cs                     |   449 +
 .../Log/DefaultLoggerTest.cs                    |   114 +
 .../Log/Log4NetLoggerTest.cs                    |   188 +
 .../Log/NLogLoggerTest.cs                       |   166 +
 .../Apache.Ignite.Core.Tests/MessagingTest.cs   |    16 +-
 .../ProjectFilesTest.cs                         |    44 +-
 .../Properties/AssemblyInfo.cs                  |    40 +-
 .../Apache.Ignite.Core.Tests/ReconnectTest.cs   |    19 +-
 .../Services/ServiceProxyTest.cs                |    12 +-
 .../Services/ServicesTest.cs                    |   272 +-
 .../Apache.Ignite.Core.Tests/TestAppConfig.cs   |   100 +
 .../Apache.Ignite.Core.Tests/TestRunner.cs      |    76 +-
 .../Apache.Ignite.Core.Tests/TestUtils.cs       |    56 +-
 .../TypeResolverTest.cs                         |   107 -
 .../WindowsServiceTest.cs                       |   124 +
 .../dotnet/Apache.Ignite.Core.Tests/app.config  |    10 +-
 .../Apache.Ignite.Core.Tests/custom_app.config  |    34 +
 .../Apache.Ignite.Core.Tests/packages.config    |    24 +
 .../Apache.Ignite.Core.Schema.nuspec            |    52 +
 .../Apache.Ignite.Core.csproj                   |   128 +-
 .../Apache.Ignite.Core.nuspec                   |    16 +-
 .../Binary/BinaryReflectiveSerializer.cs        |   193 +-
 .../Binary/IBinaryObjectBuilder.cs              |     2 +-
 .../Cache/Affinity/AffinityFunctionContext.cs   |   120 +
 .../Cache/Affinity/AffinityKey.cs               |    11 +
 .../Cache/Affinity/AffinityTopologyVersion.cs   |   138 +
 .../Cache/Affinity/Fair/FairAffinityFunction.cs |    33 +
 .../Cache/Affinity/Fair/Package-Info.cs         |    26 +
 .../Cache/Affinity/IAffinityFunction.cs         |    82 +
 .../Cache/Affinity/Package-Info.cs              |    26 +
 .../Cache/Affinity/Rendezvous/Package-Info.cs   |    26 +
 .../Rendezvous/RendezvousAffinityFunction.cs    |    32 +
 .../Cache/CachePartialUpdateException.cs        |     6 +-
 .../Cache/Configuration/CacheConfiguration.cs   |    61 +-
 .../Configuration/NearCacheConfiguration.cs     |    75 +
 .../Cache/Configuration/Package-Info.cs         |    26 +
 .../Cache/Configuration/QueryEntity.cs          |    21 +
 .../Cache/Configuration/QueryField.cs           |    17 +-
 .../Cache/Eviction/EvictionPolicyBase.cs        |   126 +
 .../Cache/Eviction/FifoEvictionPolicy.cs        |    39 +
 .../Cache/Eviction/IEvictionPolicy.cs           |    32 +
 .../Cache/Eviction/LruEvictionPolicy.cs         |    39 +
 .../Cache/Eviction/Package-Info.cs              |    26 +
 .../Apache.Ignite.Core/Cache/ICacheLock.cs      |     2 +-
 .../Apache.Ignite.Core/Cache/ICacheMetrics.cs   |     8 +-
 .../Continuous/ContinuousQueryExtensions.cs     |    42 +
 .../Cache/Query/SqlFieldsQuery.cs               |    43 +-
 .../Apache.Ignite.Core/Cache/Query/SqlQuery.cs  |    13 +
 .../Store/CacheParallelLoadStoreAdapter.cs      |     7 +
 .../Apache.Ignite.Core/Cluster/IClusterGroup.cs |    20 +
 .../Apache.Ignite.Core/Common/JavaException.cs  |    66 +
 .../Communication/ICommunicationSpi.cs          |    37 +
 .../Communication/Package-Info.cs               |    26 +
 .../Communication/Tcp/Package-Info.cs           |    26 +
 .../Communication/Tcp/TcpCommunicationSpi.cs    |   283 +
 .../Apache.Ignite.Core/Compute/ICompute.cs      |     6 +-
 .../Configuration/AtomicConfiguration.cs        |    67 +
 .../Configuration/Package-Info.cs               |    26 +
 .../Discovery/Package-Info.cs                   |    26 +
 .../Discovery/Tcp/Multicast/Package-Info.cs     |    26 +
 .../Multicast/TcpDiscoveryMulticastIpFinder.cs  |     7 +
 .../Discovery/Tcp/Package-Info.cs               |    26 +
 .../Discovery/Tcp/Static/Package-Info.cs        |    26 +
 .../Discovery/Tcp/TcpDiscoverySpi.cs            |   161 +
 .../Apache.Ignite.Core/Events/CacheEvent.cs     |     9 +-
 .../Apache.Ignite.Core/Events/DiscoveryEvent.cs |     4 +-
 .../Apache.Ignite.Core/Events/EventBase.cs      |     2 +-
 .../Apache.Ignite.Core/Events/EventReader.cs    |    12 +-
 .../dotnet/Apache.Ignite.Core/IIgnite.cs        |    83 +
 .../Apache.Ignite.Core/IgniteConfiguration.cs   |   429 +-
 .../IgniteConfigurationSection.xsd              |  1140 +-
 .../dotnet/Apache.Ignite.Core/Ignition.cs       |   157 +-
 .../Impl/Binary/BinarizableSerializer.cs        |    22 +-
 .../Impl/Binary/BinaryFullTypeDescriptor.cs     |     8 +-
 .../Impl/Binary/BinaryObject.cs                 |     2 +
 .../Impl/Binary/BinaryObjectBuilder.cs          |    18 +-
 .../Impl/Binary/BinaryObjectHandle.cs           |    59 -
 .../Impl/Binary/BinaryObjectHeader.cs           |     5 +-
 .../Impl/Binary/BinaryReader.cs                 |    56 +-
 .../Impl/Binary/BinaryReaderExtensions.cs       |    38 +
 .../Impl/Binary/BinaryReflectiveActions.cs      |    43 +
 .../BinaryReflectiveSerializerInternal.cs       |   169 +
 .../Binary/BinarySurrogateTypeDescriptor.cs     |     6 +-
 .../Impl/Binary/BinarySystemHandlers.cs         |    21 +-
 .../Impl/Binary/BinarySystemTypeSerializer.cs   |    20 +-
 .../Impl/Binary/BinaryUtils.cs                  |   183 +-
 .../Impl/Binary/BinaryWriter.cs                 |   155 +-
 .../Impl/Binary/BinaryWriterExtensions.cs       |    78 +
 .../Impl/Binary/DateTimeHolder.cs               |     4 +-
 .../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/BinaryStreamAdapter.cs       |     5 +
 .../Impl/Binary/Io/BinaryStreamBase.cs          |    25 +-
 .../Impl/Binary/Io/IBinaryStream.cs             |     2 +-
 .../Apache.Ignite.Core/Impl/Binary/JavaTypes.cs |    74 +-
 .../Impl/Binary/Marshaller.cs                   |   152 +-
 .../Impl/Binary/SerializableObjectHolder.cs     |     6 +-
 .../Impl/Binary/SerializableSerializer.cs       |    48 +
 .../Binary/Structure/BinaryStructureTracker.cs  |     7 +-
 .../Impl/Binary/UserSerializerProxy.cs          |    68 +
 .../Impl/Cache/Affinity/AffinityFunctionBase.cs |   140 +
 .../Affinity/AffinityFunctionSerializer.cs      |   277 +
 .../Cache/Affinity/PlatformAffinityFunction.cs  |    74 +
 .../Apache.Ignite.Core/Impl/Cache/CacheEntry.cs |     2 +-
 .../Impl/Cache/CacheEntryFilterHolder.cs        |    10 +-
 .../Impl/Cache/CacheEntryProcessorHolder.cs     |     8 +-
 .../Apache.Ignite.Core/Impl/Cache/CacheImpl.cs  |   295 +-
 .../Apache.Ignite.Core/Impl/Cache/CacheOp.cs    |     3 +-
 .../Cache/Event/JavaCacheEntryEventFilter.cs    |    51 +
 .../Impl/Cache/ICacheInternal.cs                |    54 +
 .../Continuous/ContinuousQueryFilterHolder.cs   |     8 +-
 .../Continuous/ContinuousQueryHandleImpl.cs     |    17 +-
 .../Impl/Cache/Query/FieldsQueryCursor.cs       |    29 +-
 .../Impl/Cache/Store/CacheStore.cs              |     4 +-
 .../Impl/Cluster/ClusterGroupImpl.cs            |    12 +
 .../Impl/Cluster/ClusterNodeImpl.cs             |     2 +-
 .../Impl/Collections/MultiValueDictionary.cs    |    26 -
 .../Impl/Collections/ReadOnlyDictionary.cs      |     2 +-
 .../Apache.Ignite.Core/Impl/Common/Classpath.cs |    12 +-
 .../Impl/Common/DelegateConverter.cs            |   171 +-
 .../Apache.Ignite.Core/Impl/Common/Fnv1Hash.cs  |     2 +-
 .../Common/IgniteConfigurationXmlSerializer.cs  |    88 +-
 .../Impl/Common/IgniteHome.cs                   |    30 +-
 .../Impl/Common/ObjectInfoHolder.cs             |    86 +
 .../Impl/Common/ObjectStringConverter.cs        |   104 +
 .../Apache.Ignite.Core/Impl/Common/Platform.cs  |    35 +
 .../Common/PlatformJavaObjectFactoryProxy.cs    |   106 +
 .../Impl/Common/ResizeableArray.cs              |    64 -
 .../Impl/Common/TypeCaster.cs                   |    12 +
 .../Impl/Compute/Closure/ComputeActionJob.cs    |     6 +-
 .../Impl/Compute/Closure/ComputeFuncJob.cs      |     8 +-
 .../Impl/Compute/Closure/ComputeOutFuncJob.cs   |     9 +-
 .../Impl/Compute/ComputeFunc.cs                 |    12 +-
 .../Impl/Compute/ComputeJob.cs                  |    16 +-
 .../Impl/Compute/ComputeJobHolder.cs            |     8 +-
 .../Impl/Compute/ComputeOutFunc.cs              |    11 +-
 .../Impl/Compute/ComputeTaskHolder.cs           |     3 +-
 .../Impl/Datastream/StreamReceiverHolder.cs     |     2 +-
 .../Impl/Events/EventTypeConverter.cs           |     3 +
 .../Apache.Ignite.Core/Impl/Events/Events.cs    |     3 +
 .../Apache.Ignite.Core/Impl/ExceptionUtils.cs   |    38 +-
 .../Apache.Ignite.Core/Impl/Handle/Handle.cs    |    12 +-
 .../Impl/Handle/HandleRegistry.cs               |    19 +-
 .../Apache.Ignite.Core/Impl/Handle/IHandle.cs   |     5 -
 .../dotnet/Apache.Ignite.Core/Impl/Ignite.cs    |   154 +-
 .../Apache.Ignite.Core/Impl/IgniteManager.cs    |    12 +-
 .../Apache.Ignite.Core/Impl/IgniteProxy.cs      |    89 +-
 .../Apache.Ignite.Core/Impl/IgniteUtils.cs      |    77 +-
 .../Impl/InteropExceptionHolder.cs              |    88 -
 .../Impl/LifecycleBeanHolder.cs                 |     2 +-
 .../Apache.Ignite.Core/Impl/Log/JavaLogger.cs   |   110 +
 .../Memory/PlatformBigEndianMemoryStream.cs     |    34 +-
 .../Impl/Memory/PlatformMemoryStream.cs         |     3 +-
 .../Impl/Memory/PlatformMemoryUtils.cs          |    30 -
 .../Impl/Memory/PlatformRawMemory.cs            |     5 +
 .../Impl/Messaging/MessageListenerHolder.cs     |    14 +-
 .../Apache.Ignite.Core/Impl/NativeMethods.cs    |     6 +
 .../Apache.Ignite.Core/Impl/PlatformTarget.cs   |    88 +-
 .../Impl/Services/ServiceDescriptor.cs          |     7 +-
 .../Impl/Services/ServiceProxyInvoker.cs        |    33 +-
 .../Impl/Services/ServiceProxySerializer.cs     |    63 +-
 .../Impl/Services/Services.cs                   |    28 +-
 .../Impl/Unmanaged/IgniteJniNativeMethods.cs    |    25 +
 .../Impl/Unmanaged/UnmanagedCallbackHandlers.cs |     9 +
 .../Impl/Unmanaged/UnmanagedCallbacks.cs        |   338 +-
 .../Impl/Unmanaged/UnmanagedUtils.cs            |    93 +-
 .../Apache.Ignite.Core/Interop/JavaObject.cs    |    80 +
 .../Apache.Ignite.Core/Interop/Package-Info.cs  |    26 +
 .../Lifecycle/ClientReconnectEventArgs.cs       |    47 +
 .../Apache.Ignite.Core/Log/CategoryLogger.cs    |    82 +
 .../dotnet/Apache.Ignite.Core/Log/ILogger.cs    |    51 +
 .../dotnet/Apache.Ignite.Core/Log/LogLevel.cs   |    53 +
 .../Apache.Ignite.Core/Log/LoggerExtensions.cs  |   320 +
 .../NuGet/LINQPad/BinaryModeExample.linq        |    94 +
 .../NuGet/LINQPad/ComputeExample.linq           |     6 +-
 .../NuGet/LINQPad/PutGetExample.linq            |     8 +-
 .../NuGet/LINQPad/QueryExample.linq             |    12 +-
 .../Properties/AssemblyInfo.cs                  |    43 +-
 .../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    |     6 +-
 .../Apache.Ignite.Linq.csproj                   |    90 +
 .../Apache.Ignite.Linq.nuspec                   |    61 +
 .../Apache.Ignite.Linq/Apache.Ignite.Linq.snk   |   Bin 0 -> 596 bytes
 .../Apache.Ignite.Linq/CacheExtensions.cs       |   120 +
 .../dotnet/Apache.Ignite.Linq/CompiledQuery.cs  |   209 +
 .../dotnet/Apache.Ignite.Linq/CompiledQuery2.cs |   257 +
 .../Apache.Ignite.Linq/ICacheQueryable.cs       |    53 +
 .../Apache.Ignite.Linq/Impl/AliasDictionary.cs  |   148 +
 .../Impl/CacheFieldsQueryExecutor.cs            |   344 +
 .../Impl/CacheFieldsQueryProvider.cs            |   239 +
 .../Impl/CacheFieldsQueryable.cs                |    40 +
 .../Impl/CacheQueryExpressionVisitor.cs         |   521 +
 .../Impl/CacheQueryModelVisitor.cs              |   502 +
 .../Apache.Ignite.Linq/Impl/CacheQueryParser.cs |    56 +
 .../Apache.Ignite.Linq/Impl/CacheQueryable.cs   |    43 +
 .../Impl/CacheQueryableBase.cs                  |   145 +
 .../Apache.Ignite.Linq/Impl/ExpressionWalker.cs |   174 +
 .../Impl/ICacheQueryableInternal.cs             |    66 +
 .../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 +
 .../dotnet/Apache.Ignite.Linq/Package-Info.cs   |    26 +
 .../Properties/AssemblyInfo.cs                  |    40 +
 .../dotnet/Apache.Ignite.Linq/QueryOptions.cs   |    91 +
 .../dotnet/Apache.Ignite.Linq/packages.config   |    22 +
 .../Apache.Ignite.Log4Net.csproj                |    76 +
 .../Apache.Ignite.Log4Net.nuspec                |    50 +
 .../Apache.Ignite.Log4Net.snk                   |   Bin 0 -> 596 bytes
 .../IgniteLog4NetLogger.cs                      |   123 +
 .../Properties/AssemblyInfo.cs                  |    40 +
 .../Apache.Ignite.Log4Net/packages.config       |    20 +
 .../Apache.Ignite.NLog.csproj                   |    69 +
 .../Apache.Ignite.NLog.nuspec                   |    50 +
 .../Apache.Ignite.NLog/Apache.Ignite.NLog.snk   |   Bin 0 -> 596 bytes
 .../Apache.Ignite.NLog/IgniteNLogLogger.cs      |   125 +
 .../Properties/AssemblyInfo.cs                  |    40 +
 .../dotnet/Apache.Ignite.NLog/packages.config   |    22 +
 modules/platforms/dotnet/Apache.Ignite.dxg      |     4 +-
 modules/platforms/dotnet/Apache.Ignite.sln      |   214 +-
 .../dotnet/Apache.Ignite.sln.DotSettings        |    11 +-
 .../dotnet/Apache.Ignite/Apache.Ignite.csproj   |    43 +-
 .../dotnet/Apache.Ignite/Config/Configurator.cs |    16 +-
 .../dotnet/Apache.Ignite/IgniteRunner.cs        |    20 +-
 .../Apache.Ignite/Properties/AssemblyInfo.cs    |    40 +-
 .../Apache.Ignite/Service/IgniteService.cs      |   102 +-
 .../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  |    32 +-
 .../Apache.Ignite.Examples.csproj               |    50 +-
 .../examples/Apache.Ignite.Examples/App.config  |    33 +-
 .../Compute/ClosureExample.cs                   |    22 +-
 .../Compute/TaskExample.cs                      |    21 +-
 .../Datagrid/BinaryModeExample.cs               |   272 +
 .../Datagrid/ContinuousQueryExample.cs          |    26 +-
 .../Datagrid/DataStreamerExample.cs             |    20 +-
 .../Datagrid/LinqExample.cs                     |   339 +
 .../Datagrid/PutGetExample.cs                   |    19 +-
 .../Datagrid/QueryExample.cs                    |   212 +-
 .../Datagrid/StoreExample.cs                    |    25 +-
 .../Datagrid/TransactionExample.cs              |    20 +-
 .../Events/EventsExample.cs                     |    26 +-
 .../Messaging/MessagingExample.cs               |    21 +-
 .../Misc/LifecycleExample.cs                    |    27 +-
 .../Properties/AssemblyInfo.cs                  |    44 +-
 .../Services/IMapService.cs                     |     4 +-
 .../Services/ServicesExample.cs                 |    21 +-
 .../Apache.Ignite.ExamplesDll.csproj            |    43 +-
 .../Apache.Ignite.ExamplesDll/Binary/Account.cs |     6 +-
 .../Apache.Ignite.ExamplesDll/Binary/Address.cs |     2 +-
 .../Binary/Employee.cs                          |    18 +-
 .../Binary/EmployeeKey.cs                       |    88 -
 .../Binary/Organization.cs                      |     2 +-
 .../Compute/AverageSalaryJob.cs                 |    11 +-
 .../Compute/AverageSalaryTask.cs                |     9 +-
 .../Compute/CharacterCountClosure.cs            |     6 +-
 .../Compute/CharacterCountReducer.cs            |     4 +-
 .../Datagrid/ContinuousQueryFilter.cs           |     6 +-
 .../Datagrid/EmployeeStore.cs                   |    13 +-
 .../Datagrid/EmployeeStorePredicate.cs          |     5 +-
 .../Events/LocalListener.cs                     |    10 +-
 .../Messaging/LocalListener.cs                  |     8 +-
 .../Messaging/RemoteOrderedListener.cs          |    10 +-
 .../Messaging/RemoteUnorderedListener.cs        |    10 +-
 .../Properties/AssemblyInfo.cs                  |    42 +-
 .../Services/MapService.cs                      |    12 +-
 .../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        |   132 +-
 .../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 +-
 .../processors/schedule/ScheduleFutureImpl.java |     7 +-
 .../schedule/GridScheduleSelfTest.java          |    33 +-
 modules/schema-import-db/README.txt             |     4 +
 modules/schema-import-db/pom.xml                |    55 +
 .../apache/ignite/schema/parser/DbColumn.java   |    88 +
 .../ignite/schema/parser/DbMetadataReader.java  |   147 +
 .../apache/ignite/schema/parser/DbTable.java    |    82 +
 .../parser/dialect/DB2MetadataDialect.java      |    33 +
 .../parser/dialect/DatabaseMetadataDialect.java |   102 +
 .../parser/dialect/JdbcMetadataDialect.java     |   199 +
 .../parser/dialect/MySQLMetadataDialect.java    |    82 +
 .../parser/dialect/OracleMetadataDialect.java   |   360 +
 modules/schema-import/README.txt                |    12 +-
 modules/schema-import/pom.xml                   |    16 +-
 .../ignite/schema/generator/CodeGenerator.java  |   157 +-
 .../ignite/schema/generator/GeneratorUtils.java |    70 +
 .../ignite/schema/generator/XmlGenerator.java   |   107 +-
 .../ignite/schema/model/PojoDescriptor.java     |    24 +-
 .../schema/parser/DatabaseMetadataParser.java   |    54 +-
 .../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       |   551 +-
 .../schema/test/AbstractSchemaImportTest.java   |    37 +-
 .../test/generator/CodeGeneratorTest.java       |    28 +-
 .../schema/test/generator/XmlGeneratorTest.java |    24 +-
 .../ignite/schema/test/model/CacheConfig.txt    |   409 +
 .../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  |   136 +-
 .../test/parser/DbMetadataParserTest.java       |     8 +-
 modules/slf4j/pom.xml                           |     2 +-
 .../apache/ignite/logger/slf4j/Slf4jLogger.java |     2 +-
 modules/spark-2.10/pom.xml                      |     2 +-
 modules/spark/pom.xml                           |     2 +-
 .../org/apache/ignite/spark/IgniteContext.scala |    85 +-
 .../org/apache/ignite/spark/IgniteRDD.scala     |   127 +-
 .../apache/ignite/spark/JavaIgniteContext.scala |    18 +-
 .../org/apache/ignite/spark/JavaIgniteRDD.scala |    17 +-
 .../ignite/spark/impl/IgniteAbstractRDD.scala   |    17 +-
 .../apache/ignite/spark/impl/IgniteSqlRDD.scala |     7 +-
 .../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 |   179 +-
 modules/spring/pom.xml                          |     9 +-
 .../org/apache/ignite/IgniteSpringBean.java     |   173 +-
 .../apache/ignite/cache/spring/SpringCache.java |    44 +-
 .../ignite/cache/spring/SpringCacheManager.java |    22 +-
 .../GridResourceSpringBeanInjector.java         |    39 +-
 .../spring/SpringTransactionManager.java        |    59 +-
 .../src/test/config/jdbc-pojo-store-builtin.xml |   194 +
 .../src/test/config/jdbc-pojo-store-obj.xml     |   194 +
 .../test/java/config/spring-transactions.xml    |     4 +-
 .../ignite/TestInjectionLifecycleBean.java      |    42 +
 .../spring/GridSpringCacheManagerSelfTest.java  |   438 +
 .../cache/spring/GridSpringCacheTestKey.java    |    61 +
 .../spring/GridSpringCacheTestKeyGenerator.java |    40 +
 .../spring/GridSpringCacheTestService.java      |   181 +
 .../GridSpringDynamicCacheTestService.java      |    85 +
 .../SpringCacheManagerContextInjectionTest.java |   125 +
 .../ignite/cache/spring/spring-caching.xml      |    57 +
 .../jdbc/CacheJdbcBlobStoreFactorySelfTest.java |    12 +-
 .../jdbc/CacheJdbcPojoStoreFactorySelfTest.java |    25 +-
 .../store/jdbc/CachePojoStoreXmlSelfTest.java   |    58 +
 .../CachePojoStoreXmlWithSqlEscapeSelfTest.java |    28 +
 .../ignite/internal/GridFactorySelfTest.java    |   112 +-
 .../ignite/internal/IgniteSpringBeanTest.java   |    55 +
 .../GridSpringResourceInjectionSelfTest.java    |   311 +-
 .../GridTransformSpringInjectionSelfTest.java   |   186 +
 .../spring-resource-with-duplicate-beans.xml    |    30 +
 .../processors/resource/spring-resource.xml     |     2 +-
 .../p2p/GridP2PUserVersionChangeSelfTest.java   |     7 +-
 .../org/apache/ignite/spring-injection-test.xml |    43 +
 .../spring/GridSpringCacheManagerSelfTest.java  |   342 -
 .../ignite/spring/GridSpringCacheTestKey.java   |    61 -
 .../spring/GridSpringCacheTestKeyGenerator.java |    40 -
 .../spring/GridSpringCacheTestService.java      |   125 -
 .../GridSpringDynamicCacheTestService.java      |    85 -
 .../GridServiceInjectionSpringResourceTest.java |   245 +
 .../spring/injection/spring-resource.tmpl.xml   |    66 +
 .../org/apache/ignite/spring/spring-caching.xml |    57 -
 .../testsuites/IgniteResourceSelfTestSuite.java |    11 +-
 .../testsuites/IgniteSpringTestSuite.java       |    35 +-
 ...gTransactionManagerContextInjectionTest.java |   125 +
 modules/ssh/pom.xml                             |     2 +-
 modules/storm/README.txt                        |     2 +-
 modules/storm/pom.xml                           |     4 +-
 .../ignite/stream/storm/StormStreamer.java      |    10 +-
 .../storm/StormIgniteStreamerSelfTest.java      |    20 +-
 .../ignite/stream/storm/TestStormSpout.java     |    10 +-
 modules/tools/pom.xml                           |     2 +-
 modules/twitter/pom.xml                         |     2 +-
 modules/urideploy/pom.xml                       |     2 +-
 .../uri/GridUriDeploymentFileProcessor.java     |     2 +-
 .../scanners/http/UriDeploymentHttpScanner.java |     8 +-
 modules/visor-console-2.10/pom.xml              |     2 +-
 modules/visor-console/pom.xml                   |     2 +-
 .../ignite/visor/commands/VisorConsole.scala    |     6 +-
 .../commands/alert/VisorAlertCommand.scala      |   378 +-
 .../commands/cache/VisorCacheCommand.scala      |    99 +-
 .../commands/cache/VisorCacheResetCommand.scala |   129 +
 .../commands/cache/VisorCacheStopCommand.scala  |     7 +-
 .../config/VisorConfigurationCommand.scala      |    23 +-
 .../commands/disco/VisorDiscoveryCommand.scala  |     7 +-
 .../commands/events/VisorEventsCommand.scala    |    36 +-
 .../visor/commands/gc/VisorGcCommand.scala      |    11 +-
 .../visor/commands/kill/VisorKillCommand.scala  |   184 +-
 .../visor/commands/node/VisorNodeCommand.scala  |    13 +-
 .../commands/tasks/VisorTasksCommand.scala      |     7 +-
 .../commands/top/VisorTopologyCommand.scala     |     2 +-
 .../visor/commands/vvm/VisorVvmCommand.scala    |    11 +-
 .../scala/org/apache/ignite/visor/visor.scala   |   110 +-
 .../commands/alert/VisorAlertCommandSpec.scala  |     2 +-
 .../cache/VisorCacheResetCommandSpec.scala      |   114 +
 modules/visor-plugins/pom.xml                   |     2 +-
 modules/web-console/.gitignore                  |     6 +
 modules/web-console/DEVNOTES.txt                |    29 +
 modules/web-console/README.txt                  |    36 +
 modules/web-console/backend/.eslintrc           |   186 +
 modules/web-console/backend/.gitignore          |     6 +
 .../web-console/backend/agent_dists/README.txt  |     7 +
 modules/web-console/backend/app/agent.js        |   791 +
 modules/web-console/backend/app/app.js          |    63 +
 modules/web-console/backend/app/browser.js      |   443 +
 modules/web-console/backend/app/configure.js    |    86 +
 modules/web-console/backend/app/mongo.js        |   678 +
 modules/web-console/backend/app/mongoose.js     |    29 +
 modules/web-console/backend/app/nconf.js        |    48 +
 modules/web-console/backend/app/routes.js       |    64 +
 modules/web-console/backend/app/settings.js     |    78 +
 .../backend/config/settings.json.sample         |    30 +
 .../backend/errors/AppErrorException.js         |    36 +
 .../backend/errors/AuthFailedException.js       |    30 +
 .../backend/errors/DuplicateKeyException.js     |    28 +
 .../backend/errors/IllegalAccessError.js        |    29 +
 .../backend/errors/IllegalArgumentException.js  |    29 +
 .../backend/errors/MissingResourceException.js  |    30 +
 .../backend/errors/ServerErrorException.js      |    36 +
 modules/web-console/backend/errors/index.js     |    41 +
 modules/web-console/backend/index.js            |   104 +
 modules/web-console/backend/injector.js         |    30 +
 modules/web-console/backend/middlewares/api.js  |    44 +
 modules/web-console/backend/middlewares/host.js |    39 +
 modules/web-console/backend/middlewares/user.js |    36 +
 modules/web-console/backend/package.json        |    62 +
 modules/web-console/backend/routes/admin.js     |    84 +
 modules/web-console/backend/routes/agent.js     |    53 +
 modules/web-console/backend/routes/caches.js    |    65 +
 modules/web-console/backend/routes/clusters.js  |    64 +
 .../web-console/backend/routes/configuration.js |    41 +
 modules/web-console/backend/routes/demo.js      |   133 +
 .../web-console/backend/routes/demo/caches.json |    87 +
 .../backend/routes/demo/clusters.json           |    50 +
 .../backend/routes/demo/domains.json            |   307 +
 .../web-console/backend/routes/demo/igfss.json  |    10 +
 modules/web-console/backend/routes/domains.js   |    76 +
 modules/web-console/backend/routes/igfss.js     |    65 +
 modules/web-console/backend/routes/notebooks.js |    80 +
 modules/web-console/backend/routes/profile.js   |    73 +
 modules/web-console/backend/routes/public.js    |   129 +
 modules/web-console/backend/services/agents.js  |    82 +
 modules/web-console/backend/services/auth.js    |   114 +
 modules/web-console/backend/services/caches.js  |   144 +
 .../web-console/backend/services/clusters.js    |   141 +
 .../backend/services/configurations.js          |    59 +
 modules/web-console/backend/services/domains.js |   189 +
 modules/web-console/backend/services/igfss.js   |   136 +
 modules/web-console/backend/services/mails.js   |   131 +
 .../web-console/backend/services/notebooks.js   |   104 +
 .../web-console/backend/services/sessions.js    |    65 +
 modules/web-console/backend/services/spaces.js  |    75 +
 modules/web-console/backend/services/users.js   |   229 +
 modules/web-console/backend/test/app/db.js      |    66 +
 .../web-console/backend/test/app/httpAgent.js   |    50 +
 .../web-console/backend/test/app/mockgoose.js   |    30 +
 .../backend/test/config/settings.json           |    20 +
 .../web-console/backend/test/data/accounts.json |    19 +
 .../web-console/backend/test/data/caches.json   |    97 +
 .../web-console/backend/test/data/clusters.json |    54 +
 .../web-console/backend/test/data/domains.json  |   317 +
 .../web-console/backend/test/data/igfss.json    |    12 +
 .../web-console/backend/test/data/spaces.json   |    14 +
 modules/web-console/backend/test/index.js       |    35 +
 modules/web-console/backend/test/injector.js    |    48 +
 .../web-console/backend/test/routes/clusters.js |    83 +
 .../web-console/backend/test/routes/public.js   |    68 +
 .../backend/test/unit/AuthService.test.js       |   107 +
 .../backend/test/unit/CacheService.test.js      |   192 +
 .../backend/test/unit/ClusterService.test.js    |   191 +
 .../backend/test/unit/DomainService.test.js     |   199 +
 .../backend/test/unit/IgfsService.test.js       |   191 +
 .../docker/compose/backend/.dockerignore        |     1 +
 .../docker/compose/backend/Dockerfile           |    30 +
 .../web-console/docker/compose/backend/build.sh |    57 +
 .../docker/compose/docker-compose.yml           |    59 +
 .../docker/compose/frontend/.dockerignore       |     3 +
 .../docker/compose/frontend/Dockerfile          |    32 +
 .../docker/compose/frontend/DockerfileBuild     |    30 +
 .../docker/compose/frontend/build.sh            |    59 +
 .../docker/compose/frontend/nginx/nginx.conf    |    57 +
 .../compose/frontend/nginx/web-console.conf     |    59 +
 .../web-console/docker/standalone/.dockerignore |     2 +
 .../web-console/docker/standalone/Dockerfile    |    87 +
 modules/web-console/docker/standalone/build.sh  |    59 +
 .../docker/standalone/docker-compose.yml        |    41 +
 .../web-console/docker/standalone/entrypoint.sh |    23 +
 .../docker/standalone/nginx/nginx.conf          |    55 +
 .../docker/standalone/nginx/web-console.conf    |    54 +
 modules/web-console/frontend/.babelrc           |     9 +
 modules/web-console/frontend/.eslintrc          |   202 +
 modules/web-console/frontend/.gitignore         |     7 +
 modules/web-console/frontend/app/app.config.js  |    86 +
 modules/web-console/frontend/app/app.js         |   271 +
 .../frontend/app/controllers/auth.controller.js |    30 +
 .../controllers/reset-password.controller.js    |    50 +
 .../web-console/frontend/app/data/colors.json   |    22 +
 .../frontend/app/data/countries.json            |    94 +
 .../frontend/app/data/demo-info.json            |    14 +
 .../frontend/app/data/event-types.json          |   169 +
 .../frontend/app/data/getting-started.json      |   109 +
 .../frontend/app/data/java-classes.json         |    19 +
 .../frontend/app/data/java-keywords.json        |    55 +
 .../frontend/app/data/java-primitives.json      |     9 +
 .../frontend/app/data/jdbc-types.json           |    44 +
 .../frontend/app/data/pom-dependencies.json     |    20 +
 .../frontend/app/data/sql-keywords.json         |    41 +
 .../frontend/app/decorator/select.js            |    77 +
 .../frontend/app/decorator/tooltip.js           |    70 +
 .../app/directives/auto-focus.directive.js      |    26 +
 .../app/directives/bs-affix-update.directive.js |    34 +
 .../app/directives/centered/centered.css        |    37 +
 .../directives/centered/centered.directive.js   |    26 +
 .../directives/copy-to-clipboard.directive.js   |    29 +
 .../hide-on-state-change.directive.js           |    31 +
 .../information/information.directive.js        |    30 +
 .../app/directives/information/information.jade |    20 +
 .../app/directives/information/information.scss |    56 +
 .../frontend/app/directives/match.directive.js  |    27 +
 .../app/directives/on-click-focus.directive.js  |    26 +
 .../directives/on-enter-focus-move.directive.js |    29 +
 .../app/directives/on-enter.directive.js        |    32 +
 .../app/directives/on-escape.directive.js       |    32 +
 .../directives/retain-selection.directive.js    |    67 +
 .../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        |   147 +
 .../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 +
 .../app/directives/ui-ace-tabs.directive.js     |    24 +
 .../ui-ace-xml/ui-ace-xml.controller.js         |    27 +
 .../ui-ace-xml/ui-ace-xml.directive.js          |   147 +
 .../app/directives/ui-ace-xml/ui-ace-xml.jade   |    17 +
 .../frontend/app/filters/byName.filter.js       |    23 +
 .../app/filters/domainsValidation.filter.js     |    33 +
 .../frontend/app/filters/duration.filter.js     |    38 +
 .../frontend/app/filters/hasPojo.filter.js      |    18 +
 .../frontend/app/helpers/jade/form.jade         |    28 +
 .../helpers/jade/form/form-field-checkbox.jade  |    38 +
 .../helpers/jade/form/form-field-datalist.jade  |    51 +
 .../app/helpers/jade/form/form-field-down.jade  |    18 +
 .../helpers/jade/form/form-field-dropdown.jade  |    50 +
 .../helpers/jade/form/form-field-feedback.jade  |    29 +
 .../app/helpers/jade/form/form-field-label.jade |    23 +
 .../helpers/jade/form/form-field-number.jade    |    52 +
 .../helpers/jade/form/form-field-password.jade  |    47 +
 .../app/helpers/jade/form/form-field-text.jade  |    47 +
 .../app/helpers/jade/form/form-field-up.jade    |    18 +
 .../app/helpers/jade/form/form-group.jade       |    23 +
 .../frontend/app/helpers/jade/mixins.jade       |   524 +
 .../frontend/app/modules/Demo/Demo.module.js    |   166 +
 .../frontend/app/modules/ace.module.js          |   269 +
 .../frontend/app/modules/agent/agent.module.js  |   341 +
 .../app/modules/branding/branding.module.js     |    45 +
 .../app/modules/branding/branding.provider.js   |   111 +
 .../app/modules/branding/features.directive.js  |    35 +
 .../app/modules/branding/footer.directive.js    |    34 +
 .../modules/branding/header-logo.directive.js   |    34 +
 .../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 +
 .../app/modules/branding/terms.directive.js     |    30 +
 .../configuration/EventGroups.provider.js       |    30 +
 .../modules/configuration/Sidebar.provider.js   |    39 +
 .../modules/configuration/Version.service.js    |    25 +
 .../configuration/configuration.module.js       |    43 +
 .../configuration/generator/Docker.service.js   |    78 +
 .../configuration/generator/Java.service.js     |    21 +
 .../configuration/generator/Pom.service.js      |   226 +
 .../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 +
 .../app/modules/dialog/dialog.controller.js     |    40 +
 .../app/modules/dialog/dialog.directive.js      |    32 +
 .../app/modules/dialog/dialog.factory.js        |    32 +
 .../frontend/app/modules/dialog/dialog.jade     |    26 +
 .../app/modules/dialog/dialog.module.js         |    32 +
 .../field/bs-select-placeholder.directive.js    |    47 +
 .../app/modules/form/field/down.directive.js    |    39 +
 .../app/modules/form/field/feedback.scss        |    37 +
 .../frontend/app/modules/form/field/field.scss  |    43 +
 .../field/form-control-feedback.directive.js    |    40 +
 .../form/field/input/autofocus.directive.js     |    30 +
 .../app/modules/form/field/input/select.scss    |    21 +
 .../app/modules/form/field/input/text.scss      |    41 +
 .../app/modules/form/field/label.directive.js   |    47 +
 .../app/modules/form/field/tooltip.directive.js |    49 +
 .../app/modules/form/field/up.directive.js      |    39 +
 .../frontend/app/modules/form/form.module.js    |    96 +
 .../app/modules/form/group/add.directive.js     |    40 +
 .../app/modules/form/group/tooltip.directive.js |    40 +
 .../app/modules/form/panel/chevron.directive.js |    53 +
 .../app/modules/form/panel/field.directive.js   |    69 +
 .../app/modules/form/panel/panel.directive.js   |    37 +
 .../app/modules/form/panel/revert.directive.js  |    54 +
 .../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         |    35 +
 .../form/validator/property-unique.directive.js |    47 +
 .../property-value-specified.directive.js       |    31 +
 .../modules/form/validator/unique.directive.js  |    49 +
 .../modules/form/validator/uuid.directive.js    |    31 +
 .../getting-started/GettingStarted.provider.js  |   112 +
 .../frontend/app/modules/loading/loading.css    |    73 +
 .../app/modules/loading/loading.directive.js    |    51 +
 .../frontend/app/modules/loading/loading.jade   |    23 +
 .../app/modules/loading/loading.module.js       |    26 +
 .../app/modules/loading/loading.service.js      |    48 +
 .../app/modules/navbar/Navbar.provider.js       |    28 +
 .../app/modules/navbar/Userbar.provider.js      |    28 +
 .../app/modules/navbar/navbar.directive.js      |    30 +
 .../app/modules/navbar/navbar.module.js         |    33 +
 .../app/modules/navbar/userbar.directive.js     |    48 +
 .../frontend/app/modules/socket.module.js       |    41 +
 .../frontend/app/modules/sql/Notebook.data.js   |   165 +
 .../app/modules/sql/Notebook.service.js         |    74 +
 .../app/modules/sql/notebook.controller.js      |    60 +
 .../app/modules/sql/scan-filter-input.jade      |    39 +
 .../modules/sql/scan-filter-input.service.js    |    51 +
 .../frontend/app/modules/sql/sql.controller.js  |  1632 +++
 .../frontend/app/modules/sql/sql.module.js      |    60 +
 .../frontend/app/modules/states/admin.state.js  |    35 +
 .../app/modules/states/configuration.state.js   |    97 +
 .../configuration/Configuration.resource.js     |    42 +
 .../configuration/caches/concurrency.jade       |    65 +
 .../states/configuration/caches/general.jade    |    66 +
 .../states/configuration/caches/memory.jade     |   101 +
 .../configuration/caches/node-filter.jade       |   108 +
 .../states/configuration/caches/query.jade      |   103 +
 .../states/configuration/caches/rebalance.jade  |    65 +
 .../configuration/caches/server-near-cache.jade |    51 +
 .../states/configuration/caches/statistics.jade |    39 +
 .../states/configuration/caches/store.jade      |   244 +
 .../states/configuration/clusters/atomic.jade   |    53 +
 .../configuration/clusters/attributes.jade      |    57 +
 .../states/configuration/clusters/binary.jade   |    77 +
 .../configuration/clusters/cache-key-cfg.jade   |    53 +
 .../configuration/clusters/collision.jade       |    62 +
 .../clusters/collision/custom.jade              |    24 +
 .../clusters/collision/fifo-queue.jade          |    27 +
 .../clusters/collision/job-stealing.jade        |    63 +
 .../clusters/collision/priority-queue.jade      |    42 +
 .../configuration/clusters/communication.jade   |    99 +
 .../configuration/clusters/connector.jade       |   103 +
 .../configuration/clusters/deployment.jade      |   113 +
 .../configuration/clusters/discovery.jade       |    87 +
 .../states/configuration/clusters/events.jade   |    37 +
 .../states/configuration/clusters/failover.jade |    72 +
 .../states/configuration/clusters/general.jade  |    73 +
 .../clusters/general/discovery/cloud.jade       |   134 +
 .../clusters/general/discovery/google.jade      |    38 +
 .../clusters/general/discovery/jdbc.jade        |    32 +
 .../clusters/general/discovery/multicast.jade   |    99 +
 .../clusters/general/discovery/s3.jade          |    27 +
 .../clusters/general/discovery/shared.jade      |    23 +
 .../clusters/general/discovery/vm.jade          |    79 +
 .../clusters/general/discovery/zookeeper.jade   |    83 +
 .../bounded-exponential-backoff.jade            |    27 +
 .../discovery/zookeeper/retrypolicy/custom.jade |    24 +
 .../retrypolicy/exponential-backoff.jade        |    27 +
 .../zookeeper/retrypolicy/forever.jade          |    22 +
 .../zookeeper/retrypolicy/n-times.jade          |    25 +
 .../zookeeper/retrypolicy/one-time.jade         |    23 +
 .../zookeeper/retrypolicy/until-elapsed.jade    |    25 +
 .../states/configuration/clusters/igfs.jade     |    37 +
 .../states/configuration/clusters/logger.jade   |    66 +
 .../configuration/clusters/logger/custom.jade   |    25 +
 .../configuration/clusters/logger/log4j.jade    |    50 +
 .../configuration/clusters/logger/log4j2.jade   |    39 +
 .../configuration/clusters/marshaller.jade      |    75 +
 .../states/configuration/clusters/metrics.jade  |    51 +
 .../states/configuration/clusters/odbc.jade     |    47 +
 .../states/configuration/clusters/ssl.jade      |   109 +
 .../states/configuration/clusters/swap.jade     |    71 +
 .../states/configuration/clusters/thread.jade   |    48 +
 .../states/configuration/clusters/time.jade     |    47 +
 .../configuration/clusters/transactions.jade    |    69 +
 .../states/configuration/domains/general.jade   |    46 +
 .../states/configuration/domains/query.jade     |   170 +
 .../states/configuration/domains/store.jade     |   126 +
 .../modules/states/configuration/igfs/dual.jade |    42 +
 .../states/configuration/igfs/fragmentizer.jade |    43 +
 .../states/configuration/igfs/general.jade      |    54 +
 .../modules/states/configuration/igfs/ipc.jade  |    60 +
 .../modules/states/configuration/igfs/misc.jade |   108 +
 .../states/configuration/igfs/secondary.jade    |    44 +
 .../configuration/preview-panel.directive.js    |   239 +
 .../summary/summary-tabs.directive.js           |    50 +
 .../configuration/summary/summary.controller.js |   383 +
 .../frontend/app/modules/states/errors.state.js |    43 +
 .../frontend/app/modules/states/logout.state.js |    35 +
 .../app/modules/states/password.state.js        |    46 +
 .../app/modules/states/profile.state.js         |    35 +
 .../frontend/app/modules/states/signin.state.js |    43 +
 .../app/modules/user/AclRoute.provider.js       |    47 +
 .../frontend/app/modules/user/Auth.service.js   |    56 +
 .../frontend/app/modules/user/User.service.js   |    51 +
 .../frontend/app/modules/user/permissions.js    |    28 +
 .../frontend/app/modules/user/user.module.js    |    73 +
 .../app/services/ChartColors.service.js         |    22 +
 .../frontend/app/services/Clone.service.js      |    64 +
 .../frontend/app/services/Confirm.service.js    |    68 +
 .../app/services/ConfirmBatch.service.js        |    92 +
 .../app/services/CopyToClipboard.service.js     |    50 +
 .../frontend/app/services/Countries.service.js  |    31 +
 .../app/services/ErrorPopover.service.js        |   129 +
 .../frontend/app/services/Focus.service.js      |    33 +
 .../frontend/app/services/FormUtils.service.js  |   435 +
 .../app/services/InetAddress.service.js         |    53 +
 .../frontend/app/services/JavaTypes.service.js  |   118 +
 .../app/services/LegacyTable.service.js         |   209 +
 .../app/services/LegacyUtils.service.js         |   528 +
 .../frontend/app/services/Messages.service.js   |    63 +
 .../app/services/ModelNormalizer.service.js     |    59 +
 .../frontend/app/services/SqlTypes.service.js   |    67 +
 .../app/services/UnsavedChangesGuard.service.js |    38 +
 modules/web-console/frontend/app/vendor.js      |    55 +
 .../frontend/controllers/admin-controller.js    |    93 +
 .../frontend/controllers/caches-controller.js   |   538 +
 .../frontend/controllers/clusters-controller.js |   689 +
 .../frontend/controllers/domains-controller.js  |  1804 +++
 .../frontend/controllers/igfs-controller.js     |   416 +
 .../frontend/controllers/profile-controller.js  |    95 +
 .../frontend/generator/generator-common.js      |   625 +
 .../frontend/generator/generator-java.js        |  3611 +++++
 .../frontend/generator/generator-optional.js    |    25 +
 .../frontend/generator/generator-properties.js  |   175 +
 .../frontend/generator/generator-readme.js      |    85 +
 .../frontend/generator/generator-xml.js         |  2108 +++
 .../frontend/gulpfile.babel.js/index.js         |    26 +
 .../frontend/gulpfile.babel.js/paths.js         |    74 +
 .../frontend/gulpfile.babel.js/tasks/build.js   |    21 +
 .../frontend/gulpfile.babel.js/tasks/bundle.js  |    32 +
 .../frontend/gulpfile.babel.js/tasks/clean.js   |    32 +
 .../frontend/gulpfile.babel.js/tasks/copy.js    |    33 +
 .../gulpfile.babel.js/tasks/ignite-modules.js   |    55 +
 .../frontend/gulpfile.babel.js/tasks/jade.js    |    40 +
 .../frontend/gulpfile.babel.js/tasks/test.js    |    92 +
 .../frontend/gulpfile.babel.js/tasks/watch.js   |    31 +
 .../gulpfile.babel.js/webpack/common.js         |   189 +
 .../webpack/environments/development.js         |    69 +
 .../webpack/environments/production.js          |    45 +
 .../frontend/gulpfile.babel.js/webpack/index.js |    32 +
 .../webpack/plugins/progress.js                 |    82 +
 .../frontend/ignite_modules/README.txt          |     6 +
 .../frontend/ignite_modules/index.js            |    27 +
 modules/web-console/frontend/package.json       |   125 +
 modules/web-console/frontend/public/favicon.ico |   Bin 0 -> 1150 bytes
 .../frontend/public/images/cache.png            |   Bin 0 -> 23700 bytes
 .../frontend/public/images/cluster.png          |   Bin 0 -> 29376 bytes
 .../frontend/public/images/docker.png           |   Bin 0 -> 521 bytes
 .../frontend/public/images/domains.png          |   Bin 0 -> 23828 bytes
 .../web-console/frontend/public/images/igfs.png |   Bin 0 -> 14307 bytes
 .../frontend/public/images/ignite-logo.png      |   Bin 0 -> 1982 bytes
 .../frontend/public/images/ignite-logo@2x.png   |   Bin 0 -> 3325 bytes
 .../frontend/public/images/ignite-puzzle.png    |   Bin 0 -> 71974 bytes
 .../web-console/frontend/public/images/java.png |   Bin 0 -> 170 bytes
 .../frontend/public/images/pb-ignite.png        |   Bin 0 -> 3493 bytes
 .../frontend/public/images/pb-ignite@2x.png     |   Bin 0 -> 8558 bytes
 .../frontend/public/images/query-chart.png      |   Bin 0 -> 16637 bytes
 .../frontend/public/images/query-metadata.png   |   Bin 0 -> 32298 bytes
 .../frontend/public/images/query-table.png      |   Bin 0 -> 29189 bytes
 .../frontend/public/images/summary.png          |   Bin 0 -> 31997 bytes
 .../web-console/frontend/public/images/xml.png  |   Bin 0 -> 232 bytes
 .../public/stylesheets/_bootstrap-custom.scss   |    65 +
 .../stylesheets/_bootstrap-variables.scss       |   891 ++
 .../stylesheets/_font-awesome-custom.scss       |    32 +
 .../public/stylesheets/blocks/error.scss        |    31 +
 .../frontend/public/stylesheets/form-field.scss |   108 +
 .../frontend/public/stylesheets/style.scss      |  2172 +++
 .../frontend/public/stylesheets/variables.scss  |    28 +
 .../frontend/test/e2e/exampe.test.js            |    40 +
 modules/web-console/frontend/test/karma.conf.js |   113 +
 .../frontend/test/protractor.conf.js            |    50 +
 .../frontend/test/unit/JavaTypes.test.js        |   107 +
 .../frontend/test/unit/SqlTypes.test.js         |    68 +
 .../frontend/test/unit/UserAuth.test.js         |    35 +
 modules/web-console/frontend/views/403.jade     |    22 +
 modules/web-console/frontend/views/404.jade     |    22 +
 modules/web-console/frontend/views/base.jade    |    22 +
 .../frontend/views/configuration/caches.jade    |    53 +
 .../frontend/views/configuration/clusters.jade  |    67 +
 .../views/configuration/domains-import.jade     |   163 +
 .../frontend/views/configuration/domains.jade   |    66 +
 .../frontend/views/configuration/igfs.jade      |    51 +
 .../frontend/views/configuration/sidebar.jade   |    29 +
 .../summary-project-structure.jade              |    27 +
 .../views/configuration/summary-tabs.jade       |    25 +
 .../frontend/views/configuration/summary.jade   |   122 +
 .../frontend/views/includes/footer.jade         |    23 +
 .../frontend/views/includes/header.jade         |    51 +
 modules/web-console/frontend/views/index.jade   |    47 +
 modules/web-console/frontend/views/reset.jade   |    48 +
 .../frontend/views/settings/admin.jade          |    76 +
 .../frontend/views/settings/profile.jade        |    76 +
 modules/web-console/frontend/views/signin.jade  |   163 +
 .../frontend/views/sql/cache-metadata.jade      |    40 +
 .../frontend/views/sql/chart-settings.jade      |    40 +
 .../frontend/views/sql/notebook-new.jade        |    31 +
 .../frontend/views/sql/paragraph-rate.jade      |    31 +
 modules/web-console/frontend/views/sql/sql.jade |   193 +
 .../views/templates/agent-download.jade         |    48 +
 .../frontend/views/templates/alert.jade         |    21 +
 .../frontend/views/templates/batch-confirm.jade |    32 +
 .../frontend/views/templates/clone.jade         |    37 +
 .../frontend/views/templates/confirm.jade       |    31 +
 .../frontend/views/templates/demo-info.jade     |    45 +
 .../frontend/views/templates/dropdown.jade      |    24 +
 .../views/templates/getting-started.jade        |    32 +
 .../frontend/views/templates/message.jade       |    26 +
 .../frontend/views/templates/pagination.jade    |    32 +
 .../frontend/views/templates/select.jade        |    26 +
 .../views/templates/validation-error.jade       |    25 +
 modules/web-console/licenses/apache-2.0.txt     |   202 +
 modules/web-console/pom.xml                     |    94 +
 modules/web-console/web-agent/.gitignore        |     2 +
 modules/web-console/web-agent/README.txt        |    88 +
 .../web-agent/assembly/release-web-agent.xml    |    66 +
 .../web-agent/bin/ignite-web-agent.bat          |    70 +
 .../web-agent/bin/ignite-web-agent.sh           |    87 +
 modules/web-console/web-agent/demo/README.txt   |     4 +
 modules/web-console/web-agent/demo/db-init.sql  |   102 +
 .../web-agent/jdbc-drivers/README.txt           |    10 +
 modules/web-console/web-agent/logs/README.txt   |     5 +
 modules/web-console/web-agent/pom.xml           |   199 +
 .../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   |   641 +
 .../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/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-weblogic-test/pom.xml        |    76 -
 .../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     |    21 +-
 .../cache/websession/WebSessionFilter.java      |   548 +-
 .../cache/websession/WebSessionListener.java    |   117 +-
 .../ignite/cache/websession/WebSessionV2.java   |   409 +
 .../IgniteWebSessionSelfTestSuite.java          |    43 +-
 .../WebSessionReplicatedSelfTest.java           |    28 +
 .../WebSessionReplicatedV1SelfTest.java         |    28 +
 .../internal/websession/WebSessionSelfTest.java |   660 +-
 .../WebSessionTransactionalSelfTest.java        |    48 +
 .../WebSessionTransactionalV1SelfTest.java      |    28 +
 .../websession/WebSessionV1SelfTest.java        |    28 +
 .../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 +
 .../config/benchmark-client-mode.properties     |     2 +
 .../yardstick/config/benchmark-full.properties  |   116 +
 .../config/benchmark-tx-win.properties          |     2 +
 .../yardstick/config/benchmark-tx.properties    |     2 +
 .../yardstick/config/benchmark-win.properties   |     2 +
 modules/yardstick/config/benchmark.properties   |     2 +
 .../config/ignite-base-load-config.xml          |   255 +
 .../config/ignite-cache-load-config.xml         |    71 +
 modules/yardstick/config/queries.sql            |     3 +
 modules/yardstick/pom.xml                       |    48 +-
 .../yardstick/IgniteBenchmarkArguments.java     |    39 +-
 .../ignite/yardstick/IgniteBenchmarkUtils.java  |    71 +-
 .../org/apache/ignite/yardstick/IgniteNode.java |    74 +-
 .../cache/CacheEntryEventAsyncProbe.java        |    61 +
 .../yardstick/cache/CacheEntryEventProbe.java   |    33 +-
 .../cache/IgniteAtomicSequenceBenchmark.java    |    47 +
 .../cache/IgniteCacheAbstractBenchmark.java     |     5 +
 .../cache/IgniteGetAndPutBenchmark.java         |    41 +
 .../cache/IgniteGetAndPutTxBenchmark.java       |    70 +
 .../cache/IgniteInvokeTxBenchmark.java          |    40 +
 .../IgniteInvokeWithInjectionBenchmark.java     |    74 +
 .../IgniteInvokeWithInjectionTxBenchmark.java   |    30 +
 .../IgniteSqlQueryDistributedJoinBenchmark.java |   166 +
 ...lQueryDistributedJoinBroadcastBenchmark.java |    28 +
 .../IgniteCacheRandomOperationBenchmark.java    |  1246 ++
 .../yardstick/cache/load/model/ModelUtil.java   |   185 +
 .../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                                  |    56 +-
 pom.xml                                         |    58 +-
 3374 files changed, 383167 insertions(+), 128892 deletions(-)
----------------------------------------------------------------------