You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ignite.apache.org by an...@apache.org on 2016/09/08 04:46:32 UTC

[15/50] [abbrv] ignite git commit: Merge branches 'ignite-1.7.2' and 'web-console-staging'.

Merge branches 'ignite-1.7.2' and 'web-console-staging'.


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

Branch: refs/heads/ignite-3629
Commit: 1640e66bd56bfdefe112243bb4153324c37c91ef
Parents: 63cfc55 4343c73
Author: Alexey Kuznetsov <ak...@apache.org>
Authored: Thu Aug 25 14:49:33 2016 +0700
Committer: Alexey Kuznetsov <ak...@apache.org>
Committed: Thu Aug 25 14:49:33 2016 +0700

----------------------------------------------------------------------
 .gitignore                                      |    1 +
 RELEASE_NOTES.txt                               |   19 +
 assembly/libs/README.txt                        |   39 +-
 .../hibernate/HibernateL2CacheExample.java      |    2 +-
 .../examples/datagrid/CacheQueryExample.java    |   78 +-
 .../jdbc2/JdbcDistributedJoinsQueryTest.java    |  319 ++++
 .../JettyRestProcessorAbstractSelfTest.java     |  178 +-
 .../jdbc/suite/IgniteJdbcDriverTestSuite.java   |    2 +
 .../ignite/codegen/MessageCodeGenerator.java    |    6 +
 modules/core/pom.xml                            |    6 +
 .../src/main/java/org/apache/ignite/Ignite.java |    4 +-
 .../org/apache/ignite/IgniteJdbcDriver.java     |   14 +-
 .../org/apache/ignite/cache/QueryEntity.java    |   18 +
 .../ignite/cache/query/SqlFieldsQuery.java      |   53 +
 .../org/apache/ignite/cache/query/SqlQuery.java |   28 +
 .../store/jdbc/CacheAbstractJdbcStore.java      |  144 +-
 .../cache/store/jdbc/CacheJdbcPojoStore.java    |    7 +-
 .../store/jdbc/CacheJdbcPojoStoreFactory.java   |   26 +
 .../store/jdbc/JdbcTypesDefaultTransformer.java |  117 ++
 .../cache/store/jdbc/JdbcTypesTransformer.java  |   39 +
 .../store/jdbc/dialect/BasicJdbcDialect.java    |    7 +-
 .../cache/store/jdbc/dialect/JdbcDialect.java   |   11 +-
 .../cache/store/jdbc/dialect/MySQLDialect.java  |   18 +-
 .../configuration/IgniteConfiguration.java      |   42 +-
 .../ignite/internal/MarshallerContextImpl.java  |    9 +-
 .../internal/cluster/ClusterGroupAdapter.java   |   18 +-
 .../ignite/internal/jdbc2/JdbcConnection.java   |   12 +
 .../ignite/internal/jdbc2/JdbcQueryTask.java    |    9 +-
 .../ignite/internal/jdbc2/JdbcResultSet.java    |    4 +-
 .../ignite/internal/jdbc2/JdbcStatement.java    |    2 +-
 .../managers/communication/GridIoManager.java   |   34 +-
 .../communication/GridIoMessageFactory.java     |    2 +-
 .../managers/communication/GridIoPolicy.java    |    5 +-
 .../discovery/GridDiscoveryManager.java         |    3 +-
 .../GridAffinityFunctionContextImpl.java        |    2 +-
 .../cache/GridCacheAffinityManager.java         |    2 +-
 .../processors/cache/GridCacheContext.java      |   19 +
 .../GridCacheDefaultAffinityKeyMapper.java      |   19 +
 .../processors/cache/GridCacheIoManager.java    |   21 +-
 .../processors/cache/IgniteCacheProxy.java      |    8 +
 .../binary/CacheObjectBinaryProcessorImpl.java  |    8 +
 .../distributed/GridCacheTxRecoveryFuture.java  |    7 +
 .../distributed/GridCacheTxRecoveryRequest.java |    1 -
 .../GridCacheTxRecoveryResponse.java            |   23 +-
 .../GridDistributedTxFinishRequest.java         |   19 +-
 .../GridDistributedTxFinishResponse.java        |    1 -
 .../GridDistributedTxPrepareRequest.java        |   26 +-
 .../GridDistributedTxPrepareResponse.java       |   20 +-
 .../dht/GridCachePartitionedConcurrentMap.java  |  142 +-
 .../dht/GridDhtPartitionTopology.java           |    2 +-
 .../dht/GridDhtPartitionTopologyImpl.java       |  176 +-
 .../dht/GridDhtPartitionsReservation.java       |    3 +-
 .../cache/distributed/dht/GridReservable.java   |    5 +-
 .../near/GridNearTxPrepareFutureAdapter.java    |    7 +
 .../cache/query/GridCacheQueryManager.java      |  110 +-
 .../cache/query/GridCacheQueryMarshallable.java |   37 +
 .../cache/query/GridCacheSqlQuery.java          |   33 +-
 .../cache/query/GridCacheTwoStepQuery.java      |  123 +-
 .../continuous/CacheContinuousQueryManager.java |    2 +-
 .../cache/transactions/IgniteTxHandler.java     |   55 +-
 .../IgniteTxImplicitSingleStateImpl.java        |   13 +
 .../IgniteTxRemoteSingleStateImpl.java          |   13 +
 .../transactions/IgniteTxRemoteStateImpl.java   |   38 +-
 .../cache/transactions/IgniteTxState.java       |    6 +
 .../cache/transactions/IgniteTxStateAware.java  |   34 +
 .../cache/transactions/IgniteTxStateImpl.java   |   12 +
 .../cacheobject/IgniteCacheObjectProcessor.java |    6 +
 .../IgniteCacheObjectProcessorImpl.java         |    5 +
 .../processors/closure/GridClosurePolicy.java   |   51 -
 .../closure/GridClosureProcessor.java           |   52 +-
 .../datastructures/GridCacheSemaphoreImpl.java  |  108 +-
 .../internal/processors/igfs/IgfsImpl.java      |    6 +-
 .../processors/job/GridJobProcessor.java        |    4 +-
 .../processors/odbc/OdbcHandshakeRequest.java   |   42 +-
 .../processors/odbc/OdbcHandshakeResult.java    |   17 +-
 .../processors/odbc/OdbcMessageParser.java      |   34 +-
 .../processors/odbc/OdbcProtocolVersion.java    |  125 ++
 .../processors/odbc/OdbcRequestHandler.java     |   26 +-
 .../platform/PlatformAbstractBootstrap.java     |    5 +
 .../processors/platform/PlatformBootstrap.java  |    6 +
 .../processors/platform/PlatformIgnition.java   |    7 +-
 .../platform/PlatformProcessorImpl.java         |   35 +-
 .../platform/cache/PlatformCache.java           |   12 +-
 .../affinity/PlatformAffinityFunction.java      |   27 +
 .../cache/affinity/PlatformAffinityUtils.java   |    2 +
 .../callback/PlatformCallbackGateway.java       |   13 +-
 .../callback/PlatformCallbackUtils.java         |    8 +
 .../platform/cluster/PlatformClusterGroup.java  |    7 +
 .../platform/compute/PlatformAbstractTask.java  |    1 +
 .../dotnet/PlatformDotNetBootstrap.java         |   12 +
 .../dotnet/PlatformDotNetCacheStore.java        |   27 +-
 .../PlatformDotNetConfigurationClosure.java     |   58 +-
 .../dotnet/PlatformDotNetConsoleStream.java     |   54 +
 .../services/PlatformAbstractService.java       |    3 +-
 .../utils/PlatformConfigurationUtils.java       |  106 +-
 .../platform/utils/PlatformFutureUtils.java     |    2 +
 .../platform/utils/PlatformUtils.java           |   12 +
 .../processors/query/GridQueryIndexing.java     |   51 +-
 .../processors/query/GridQueryProcessor.java    |  194 +--
 .../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 +-
 .../handlers/cache/GridCacheCommandHandler.java |  100 +-
 .../handlers/query/QueryCommandHandler.java     |    4 +
 .../rest/request/RestQueryRequest.java          |   17 +
 .../ignite/internal/util/IgniteUtils.java       |   47 +-
 .../internal/util/PartitionedReadOnlySet.java   |   71 -
 .../ignite/internal/util/lang/GridFunc.java     |   20 +
 .../offheap/unsafe/GridOffHeapSnapTreeMap.java  |   91 +-
 .../internal/visor/query/VisorQueryArgV2.java   |   49 +
 .../internal/visor/query/VisorQueryJob.java     |    1 +
 .../internal/visor/util/VisorTaskUtils.java     |    8 +
 .../dotnet/PlatformDotNetAffinityFunction.java  |   15 +
 .../SpringApplicationContextResource.java       |    4 +-
 .../apache/ignite/resources/SpringResource.java |   15 +-
 .../ignite/scheduler/SchedulerFuture.java       |    5 +-
 .../communication/tcp/TcpCommunicationSpi.java  |    6 +-
 .../ignite/spi/discovery/tcp/ClientImpl.java    |    8 +-
 .../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    |   20 +-
 .../ignite/internal/ClusterGroupSelfTest.java   |   30 +-
 .../MarshallerContextLockingSelfTest.java       |  139 ++
 .../cache/GridCacheAbstractFullApiSelfTest.java |  127 +-
 ...eDynamicCacheStartNoExchangeTimeoutTest.java |    2 +
 .../IgniteTxExceptionAbstractSelfTest.java      |   45 +-
 .../IgniteSemaphoreAbstractSelfTest.java        |   25 +-
 .../CacheLateAffinityAssignmentTest.java        |    4 -
 .../dht/IgniteCacheConcurrentPutGetRemove.java  |  201 +++
 .../IgniteCacheSyncRebalanceModeSelfTest.java   |    2 +
 .../processors/igfs/IgfsAbstractSelfTest.java   |    4 +-
 ...niteMessagingConfigVariationFullApiTest.java |  484 ++++++
 .../GridCacheAtomicCommandHandlerSelfTest.java  |   39 +
 .../cache/GridCacheCommandHandlerSelfTest.java  |   20 +-
 .../ignite/platform/PlatformStringTestTask.java |   67 +
 .../jdbc/TcpDiscoveryJdbcIpFinderSelfTest.java  |    2 +-
 .../junits/common/GridCommonAbstractTest.java   |   39 +-
 .../ignite/testsuites/IgniteBasicTestSuite.java |    3 +
 ...essagingConfigVariationFullApiTestSuite.java |   72 +
 .../testsuites/IgniteRestHandlerTestSuite.java  |    2 +
 modules/docker/1.6.0/Dockerfile                 |   44 +
 modules/docker/1.6.0/run.sh                     |   51 +
 modules/docker/Dockerfile                       |   24 +-
 .../query/h2/opt/GridH2SpatialIndex.java        |   74 +-
 .../processors/query/h2/IgniteH2Indexing.java   |  726 ++++++--
 .../query/h2/opt/GridH2AbstractKeyValueRow.java |   72 +-
 .../query/h2/opt/GridH2CollocationModel.java    |  783 +++++++++
 .../processors/query/h2/opt/GridH2Cursor.java   |   36 +-
 .../query/h2/opt/GridH2DefaultTableEngine.java  |   38 +
 .../query/h2/opt/GridH2IndexBase.java           | 1392 ++++++++++++++-
 .../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    |  372 ++--
 .../query/h2/opt/GridH2TreeIndex.java           |  142 +-
 .../processors/query/h2/opt/GridH2Utils.java    |  133 --
 .../query/h2/opt/GridH2ValueCacheObject.java    |    3 +-
 .../query/h2/opt/GridLuceneIndex.java           |    7 +-
 .../processors/query/h2/sql/GridSqlAlias.java   |   12 +
 .../processors/query/h2/sql/GridSqlColumn.java  |   22 +-
 .../processors/query/h2/sql/GridSqlElement.java |   11 +
 .../query/h2/sql/GridSqlOperation.java          |    2 +-
 .../query/h2/sql/GridSqlOperationType.java      |    8 +-
 .../query/h2/sql/GridSqlQueryParser.java        |   97 +-
 .../query/h2/sql/GridSqlQuerySplitter.java      |  293 +++-
 .../processors/query/h2/sql/GridSqlSelect.java  |    9 +-
 .../processors/query/h2/sql/GridSqlTable.java   |   70 +
 .../query/h2/twostep/GridMapQueryExecutor.java  |  415 +++--
 .../query/h2/twostep/GridMergeIndex.java        |   75 +-
 .../h2/twostep/GridMergeIndexUnsorted.java      |    6 +-
 .../query/h2/twostep/GridMergeTable.java        |    4 +-
 .../h2/twostep/GridReduceQueryExecutor.java     |  338 ++--
 .../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 +-
 .../cache/CacheIndexingOffheapCleanupTest.java  |  178 ++
 ...idCacheReduceQueryMultithreadedSelfTest.java |  168 --
 .../cache/IgniteCacheAbstractQuerySelfTest.java |   30 +-
 .../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 |    2 +-
 ...IgniteCachePrimitiveFieldsQuerySelfTest.java |  134 ++
 .../cache/IgniteCacheQueryLoadSelfTest.java     |   12 +-
 .../cache/IgniteCacheUnionDuplicatesTest.java   |  151 ++
 .../cache/IgniteCrossCachesJoinsQueryTest.java  | 1641 ++++++++++++++++++
 ...QueryNodeRestartDistributedJoinSelfTest.java |  476 +++++
 ...dCacheAbstractReduceFieldsQuerySelfTest.java |  420 -----
 ...ridCacheReduceFieldsQueryAtomicSelfTest.java |   38 -
 ...GridCacheReduceFieldsQueryLocalSelfTest.java |   37 -
 ...cheReduceFieldsQueryPartitionedSelfTest.java |   59 -
 ...acheReduceFieldsQueryReplicatedSelfTest.java |   37 -
 .../query/IgniteSqlSchemaIndexingTest.java      |    5 +-
 .../query/IgniteSqlSplitterSelfTest.java        |  833 ++++++++-
 .../h2/GridIndexingSpiAbstractSelfTest.java     |  145 +-
 .../query/h2/opt/GridH2TableSelfTest.java       |   10 +-
 .../h2/sql/AbstractH2CompareQueryTest.java      |  165 +-
 .../query/h2/sql/GridQueryParsingTest.java      |   28 +-
 .../H2CompareBigQueryDistributedJoinsTest.java  |   28 +
 .../query/h2/sql/H2CompareBigQueryTest.java     |  119 +-
 .../IgniteCacheQuerySelfTestSuite.java          |   27 +-
 .../IgniteCacheQuerySelfTestSuite2.java         |   10 -
 .../IgniteCacheWithIndexingTestSuite.java       |    2 +
 .../ignite/stream/kafka/KafkaStreamer.java      |    4 +-
 .../connect/IgniteSourceConnectorTest.java      |   58 +-
 .../cpp/common/include/ignite/common/utils.h    |   18 +
 modules/platforms/cpp/core-test/Makefile.am     |    1 +
 .../cpp/core-test/config/cache-query.xml        |   42 +-
 .../cpp/core-test/project/vs/core-test.vcxproj  |    3 +-
 .../project/vs/core-test.vcxproj.filters        |    5 +-
 .../cpp/core-test/src/cache_query_test.cpp      |  443 ++++-
 .../cpp/core-test/src/interop_test.cpp          |  148 ++
 .../core/include/ignite/cache/query/query_sql.h |   61 +-
 .../ignite/cache/query/query_sql_fields.h       |  111 +-
 modules/platforms/cpp/examples/README.txt       |    1 +
 .../cpp/jni/include/ignite/jni/exports.h        |    4 +
 .../platforms/cpp/jni/include/ignite/jni/java.h |   17 +-
 modules/platforms/cpp/jni/project/vs/module.def |    4 +
 modules/platforms/cpp/jni/src/exports.cpp       |   12 +
 modules/platforms/cpp/jni/src/java.cpp          |  120 +-
 modules/platforms/cpp/odbc-test/Makefile.am     |    1 +
 .../odbc-test/config/queries-test-noodbc.xml    |  103 ++
 .../cpp/odbc-test/config/queries-test.xml       |   54 +-
 .../cpp/odbc-test/project/vs/odbc-test.vcxproj  |    1 +
 .../project/vs/odbc-test.vcxproj.filters        |    3 +
 .../cpp/odbc-test/src/configuration_test.cpp    |  244 ++-
 .../cpp/odbc-test/src/queries_test.cpp          |  285 ++-
 modules/platforms/cpp/odbc/Makefile.am          |    1 +
 modules/platforms/cpp/odbc/include/Makefile.am  |    1 +
 .../cpp/odbc/include/ignite/odbc/common_types.h |    3 +
 .../include/ignite/odbc/config/configuration.h  |  182 +-
 .../cpp/odbc/include/ignite/odbc/connection.h   |   54 +-
 .../cpp/odbc/include/ignite/odbc/message.h      |   35 +-
 .../cpp/odbc/include/ignite/odbc/parser.h       |    3 -
 .../odbc/include/ignite/odbc/protocol_version.h |  172 ++
 .../platforms/cpp/odbc/project/vs/odbc.vcxproj  |    2 +
 .../cpp/odbc/project/vs/odbc.vcxproj.filters    |    6 +
 .../cpp/odbc/src/config/configuration.cpp       |  273 +--
 modules/platforms/cpp/odbc/src/connection.cpp   |   70 +-
 .../odbc/src/diagnostic/diagnostic_record.cpp   |    6 +
 modules/platforms/cpp/odbc/src/odbc.cpp         |   27 +-
 .../platforms/cpp/odbc/src/protocol_version.cpp |  134 ++
 .../Apache.Ignite.AspNet.csproj                 |   73 +
 .../Apache.Ignite.AspNet.nuspec                 |   57 +
 .../Apache.Ignite.AspNet.ruleset                |    9 +
 .../Apache.Ignite.AspNet.snk                    |  Bin 0 -> 596 bytes
 .../IgniteOutputCacheProvider.cs                |  220 +++
 .../Apache.Ignite.AspNet/IgniteWebUtils.cs      |   44 +
 .../dotnet/Apache.Ignite.AspNet/Package-Info.cs |   26 +
 .../Properties/AssemblyInfo.cs                  |   39 +
 .../Properties/AssemblyInfo.cs                  |    2 +-
 .../Apache.Ignite.Core.Tests.NuGet.csproj       |   14 +
 .../AspNetTest.cs                               |   73 +
 .../Properties/AssemblyInfo.cs                  |    2 +-
 .../SchemaTest.cs                               |   62 +
 .../install-package.ps1                         |   21 +-
 .../packages.config                             |    2 +
 .../Properties/AssemblyInfo.cs                  |    2 +-
 .../Apache.Ignite.Core.Tests.csproj             |   19 +-
 .../AspNet/IgniteOutputCacheProviderTest.cs     |  172 ++
 .../Binary/BinarySelfTest.cs                    |  164 +-
 .../Binary/BinaryStringTest.cs                  |  120 ++
 .../Cache/Affinity/AffinityFieldTest.cs         |  199 +++
 .../Affinity/AffinityFunctionSpringTest.cs      |    2 +-
 .../Cache/Affinity/AffinityFunctionTest.cs      |  485 ++++++
 .../Cache/Affinity/AffinityTest.cs              |  138 ++
 .../Cache/CacheAffinityFieldTest.cs             |  199 ---
 .../Cache/CacheAffinityTest.cs                  |  139 --
 .../Cache/CacheConfigurationTest.cs             |  134 +-
 .../Cache/Query/CacheLinqTest.cs                |  280 ++-
 .../Cache/Query/CacheQueriesTest.cs             |  257 +--
 .../Continuous/ContinuousQueryAbstractTest.cs   |   18 +-
 .../Cache/Store/CacheStoreTest.cs               |   11 +-
 .../Compute/AbstractTaskTest.cs                 |    9 +
 .../Compute/BinarizableTaskTest.cs              |   13 +-
 .../Compute/ComputeApiTest.cs                   |  110 +-
 .../Compute/FailoverTaskSelfTest.cs             |    2 +-
 .../Compute/IgniteExceptionTaskSelfTest.cs      |   18 +-
 .../Compute/ResourceTaskTest.cs                 |    8 +-
 .../Compute/TaskAdapterTest.cs                  |   16 +-
 .../Compute/TaskResultTest.cs                   |   10 +-
 .../Config/Cache/Affinity/affinity-function.xml |    4 +-
 .../Config/cache-query-continuous.xml           |    1 +
 .../native-client-test-cache-affinity.xml       |    2 +-
 .../ConsoleRedirectTest.cs                      |  177 ++
 .../Apache.Ignite.Core.Tests/EventsTest.cs      |    4 +-
 .../Examples/Example.cs                         |    8 +-
 .../Examples/ExamplesTest.cs                    |   46 +-
 .../Examples/PathUtil.cs                        |   10 +-
 .../Examples/ProjectFilesTest.cs                |    2 +-
 .../Apache.Ignite.Core.Tests/ExceptionsTest.cs  |   81 +-
 .../IgniteConfigurationSectionTest.cs           |   32 +
 .../IgniteConfigurationSerializerTest.cs        |   21 +
 .../IgniteConfigurationTest.cs                  |   12 +-
 .../IgniteStartStopTest.cs                      |    3 +-
 .../Apache.Ignite.Core.Tests/LifecycleTest.cs   |    9 +
 .../Apache.Ignite.Core.Tests/MessagingTest.cs   |   16 +-
 .../Properties/AssemblyInfo.cs                  |    2 +-
 .../Apache.Ignite.Core.Tests/ReconnectTest.cs   |   13 +
 .../Services/ServiceProxyTest.cs                |    6 +-
 .../Services/ServicesTest.cs                    |   26 +-
 .../Apache.Ignite.Core.Tests/TestAppConfig.cs   |  100 ++
 .../Apache.Ignite.Core.Tests/TestRunner.cs      |   46 +-
 .../Apache.Ignite.Core.Tests/TestUtils.cs       |   15 +-
 .../dotnet/Apache.Ignite.Core.Tests/app.config  |    2 +-
 .../Apache.Ignite.Core.Tests/custom_app.config  |   34 +
 .../Apache.Ignite.Core.Schema.nuspec            |   53 +
 .../Apache.Ignite.Core.csproj                   |   19 +-
 .../Apache.Ignite.Core.nuspec                   |    2 +-
 .../Binary/BinaryReflectiveSerializer.cs        |  193 +-
 .../Cache/Configuration/CacheConfiguration.cs   |   18 +-
 .../Cache/Query/SqlFieldsQuery.cs               |   27 +-
 .../Apache.Ignite.Core/Cache/Query/SqlQuery.cs  |   13 +
 .../Apache.Ignite.Core/Cluster/IClusterGroup.cs |    6 +
 .../Apache.Ignite.Core/Common/JavaException.cs  |   65 +
 .../Configuration/AtomicConfiguration.cs        |    9 +
 .../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 +
 .../Apache.Ignite.Core/Events/EventBase.cs      |    2 +-
 .../dotnet/Apache.Ignite.Core/IIgnite.cs        |   25 +
 .../Apache.Ignite.Core/IgniteConfiguration.cs   |    2 +
 .../IgniteConfigurationSection.xsd              |    9 +-
 .../dotnet/Apache.Ignite.Core/Ignition.cs       |   91 +-
 .../Impl/Binary/BinarizableSerializer.cs        |   22 +-
 .../Impl/Binary/BinaryFullTypeDescriptor.cs     |    8 +-
 .../Impl/Binary/BinaryReader.cs                 |   38 +-
 .../Impl/Binary/BinaryReaderExtensions.cs       |    2 +-
 .../Impl/Binary/BinaryReflectiveActions.cs      |   10 +-
 .../BinaryReflectiveSerializerInternal.cs       |  169 ++
 .../Binary/BinarySurrogateTypeDescriptor.cs     |    4 +-
 .../Impl/Binary/BinarySystemTypeSerializer.cs   |   20 +-
 .../Impl/Binary/BinaryUtils.cs                  |  180 +-
 .../Impl/Binary/BinaryWriter.cs                 |    2 +-
 .../Impl/Binary/DateTimeSerializer.cs           |   48 +
 .../Impl/Binary/IBinarySerializerInternal.cs    |   42 +
 .../Impl/Binary/IBinarySystemTypeSerializer.cs  |   34 -
 .../Impl/Binary/IBinaryTypeDescriptor.cs        |    2 +-
 .../Impl/Binary/Io/BinaryHeapStream.cs          |    2 +-
 .../Impl/Binary/Io/BinaryStreamBase.cs          |   14 -
 .../Impl/Binary/Marshaller.cs                   |   77 +-
 .../Impl/Binary/SerializableSerializer.cs       |   48 +
 .../Impl/Binary/UserSerializerProxy.cs          |   68 +
 .../Apache.Ignite.Core/Impl/Cache/CacheImpl.cs  |    6 +-
 .../Impl/Cache/Store/CacheStore.cs              |    4 +-
 .../Impl/Cluster/ClusterGroupImpl.cs            |    6 +
 .../Impl/Common/DelegateConverter.cs            |   44 +
 .../Impl/Compute/ComputeTaskHolder.cs           |    3 +-
 .../Apache.Ignite.Core/Impl/ExceptionUtils.cs   |   31 +-
 .../dotnet/Apache.Ignite.Core/Impl/Ignite.cs    |   48 +-
 .../Apache.Ignite.Core/Impl/IgniteProxy.cs      |   43 +-
 .../Apache.Ignite.Core/Impl/IgniteUtils.cs      |   47 +-
 .../Impl/LifecycleBeanHolder.cs                 |    2 +-
 .../Impl/Memory/PlatformMemoryStream.cs         |    3 +-
 .../Apache.Ignite.Core/Impl/NativeMethods.cs    |    6 +
 .../Impl/Services/ServiceProxyInvoker.cs        |   14 +-
 .../Impl/Services/Services.cs                   |   17 +-
 .../Impl/Unmanaged/IgniteJniNativeMethods.cs    |    9 +
 .../Impl/Unmanaged/UnmanagedCallbacks.cs        |   94 +-
 .../Impl/Unmanaged/UnmanagedUtils.cs            |   23 +
 .../Apache.Ignite.Core/Interop/Package-Info.cs  |   26 +
 .../Lifecycle/ClientReconnectEventArgs.cs       |   47 +
 .../Properties/AssemblyInfo.cs                  |    4 +-
 .../Transactions/TransactionConfiguration.cs    |   12 +
 .../Apache.Ignite.Linq.csproj                   |    4 +-
 .../Apache.Ignite.Linq.nuspec                   |    6 +-
 .../Apache.Ignite.Linq/CacheExtensions.cs       |   24 +-
 .../dotnet/Apache.Ignite.Linq/CompiledQuery.cs  |    1 +
 .../dotnet/Apache.Ignite.Linq/CompiledQuery2.cs |  257 +++
 .../Apache.Ignite.Linq/Impl/AliasDictionary.cs  |   74 +-
 .../Impl/CacheFieldsQueryExecutor.cs            |  163 +-
 .../Impl/CacheQueryExpressionVisitor.cs         |   19 +-
 .../Impl/CacheQueryModelVisitor.cs              |   21 +-
 .../Apache.Ignite.Linq/Impl/CacheQueryable.cs   |   10 +-
 .../Impl/CacheQueryableBase.cs                  |   29 +-
 .../Apache.Ignite.Linq/Impl/ExpressionWalker.cs |   44 +-
 .../Apache.Ignite.Linq/Impl/ICacheQueryProxy.cs |   40 -
 .../Impl/ICacheQueryableInternal.cs             |   14 +-
 .../dotnet/Apache.Ignite.Linq/Package-Info.cs   |   26 +
 .../Properties/AssemblyInfo.cs                  |    2 +-
 .../dotnet/Apache.Ignite.Linq/QueryOptions.cs   |   91 +
 modules/platforms/dotnet/Apache.Ignite.dxg      |    4 +-
 modules/platforms/dotnet/Apache.Ignite.sln      |   15 +-
 .../dotnet/Apache.Ignite.sln.DotSettings        |    7 +-
 .../dotnet/Apache.Ignite/Config/Configurator.cs |   11 +-
 .../Apache.Ignite/Properties/AssemblyInfo.cs    |    2 +-
 .../dotnet/examples/Apache.Ignite.Examples.sln  |    8 -
 .../examples/Apache.Ignite.Examples/App.config  |   33 +-
 .../Compute/ClosureExample.cs                   |    4 +-
 .../Compute/TaskExample.cs                      |    4 +-
 .../Datagrid/ContinuousQueryExample.cs          |    4 +-
 .../Datagrid/DataStreamerExample.cs             |    4 +-
 .../Datagrid/LinqExample.cs                     |    4 +-
 .../Datagrid/PutGetExample.cs                   |    4 +-
 .../Datagrid/QueryExample.cs                    |    4 +-
 .../Datagrid/StoreExample.cs                    |    4 +-
 .../Datagrid/TransactionExample.cs              |    4 +-
 .../Events/EventsExample.cs                     |    6 +-
 .../Messaging/MessagingExample.cs               |    4 +-
 .../Misc/LifecycleExample.cs                    |   13 +-
 .../Properties/AssemblyInfo.cs                  |    2 +-
 .../Services/ServicesExample.cs                 |    4 +-
 .../Properties/AssemblyInfo.cs                  |    2 +-
 .../dotnet/examples/Config/examples-config.xml  |   98 --
 .../http/jetty/GridJettyRestHandler.java        |    5 +
 .../processors/schedule/ScheduleFutureImpl.java |    7 +-
 .../schedule/GridScheduleSelfTest.java          |   33 +-
 .../parser/dialect/DatabaseMetadataDialect.java |   18 +
 .../parser/dialect/JdbcMetadataDialect.java     |    5 +-
 .../parser/dialect/OracleMetadataDialect.java   |    5 +-
 .../ignite/schema/generator/CodeGenerator.java  |   23 +-
 .../schema/parser/DatabaseMetadataParser.java   |    4 +-
 .../ignite/schema/ui/SchemaImportApp.java       |    3 +-
 .../schema/test/AbstractSchemaImportTest.java   |   27 +-
 .../test/generator/CodeGeneratorTest.java       |   28 +-
 .../schema/test/generator/XmlGeneratorTest.java |   22 +-
 .../ignite/schema/test/model/CacheConfig.txt    |  409 +++++
 .../schema/test/model/ignite-type-metadata.xml  |   50 +-
 .../test/parser/DbMetadataParserTest.java       |    6 +-
 .../apache/ignite/logger/slf4j/Slf4jLogger.java |    2 +-
 .../org/apache/ignite/spark/IgniteContext.scala |    8 +-
 .../org/apache/ignite/spark/IgniteRDD.scala     |   10 +-
 .../apache/ignite/spark/JavaIgniteContext.scala |    2 +-
 .../org/apache/ignite/spark/JavaIgniteRDD.scala |   12 +-
 .../ignite/spark/impl/IgniteAbstractRDD.scala   |    2 +-
 .../apache/ignite/spark/impl/IgniteSqlRDD.scala |    2 +-
 .../spark/JavaEmbeddedIgniteRDDSelfTest.java    |   19 +-
 .../org/apache/ignite/spark/IgniteRDDSpec.scala |   38 +-
 modules/spring/pom.xml                          |    7 -
 .../org/apache/ignite/IgniteSpringBean.java     |  143 +-
 .../GridResourceSpringBeanInjector.java         |   39 +-
 .../jdbc/CacheJdbcPojoStoreFactorySelfTest.java |   11 +-
 .../ignite/internal/IgniteSpringBeanTest.java   |   55 +
 .../GridSpringResourceInjectionSelfTest.java    |  311 +++-
 .../spring-resource-with-duplicate-beans.xml    |   30 +
 .../processors/resource/spring-resource.xml     |    2 +-
 .../org/apache/ignite/spring-injection-test.xml |    2 +-
 .../testsuites/IgniteSpringTestSuite.java       |    2 +
 .../commands/alert/VisorAlertCommand.scala      |   43 +-
 .../commands/cache/VisorCacheCommand.scala      |   16 +-
 .../cache/websession/WebSessionFilter.java      |   11 +-
 .../ignite/cache/websession/WebSessionV2.java   |   10 +-
 .../internal/websession/WebSessionSelfTest.java |    8 +-
 modules/yardstick/config/queries.sql            |    1 +
 .../ignite/yardstick/IgniteBenchmarkUtils.java  |   71 +-
 .../IgniteSqlQueryDistributedJoinBenchmark.java |  166 ++
 ...lQueryDistributedJoinBroadcastBenchmark.java |   28 +
 .../IgniteCacheRandomOperationBenchmark.java    |   71 +-
 parent/pom.xml                                  |   25 +-
 492 files changed, 28413 insertions(+), 5475 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/1640e66b/modules/core/src/main/java/org/apache/ignite/internal/visor/util/VisorTaskUtils.java
----------------------------------------------------------------------