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

[50/50] [abbrv] ignite git commit: Merge branch 'ignite-2.0' into ignite-4565-ddl

Merge branch 'ignite-2.0' into ignite-4565-ddl


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

Branch: refs/heads/ignite-4565-ddl
Commit: 796c933ac70d751111f4f642f5b351abc762effd
Parents: fcadf67 50f8741
Author: devozerov <vo...@gridgain.com>
Authored: Thu Mar 2 14:29:53 2017 +0300
Committer: devozerov <vo...@gridgain.com>
Committed: Thu Mar 2 14:29:53 2017 +0300

----------------------------------------------------------------------
 NOTICE                                          |   2 +-
 assembly/LICENSE_FABRIC                         |  35 +-
 assembly/LICENSE_HADOOP                         |  17 +-
 assembly/NOTICE_FABRIC                          |   2 +-
 assembly/NOTICE_HADOOP                          |   2 +-
 config/hadoop/default-config.xml                |  29 -
 examples/config/filesystem/example-igfs.xml     |  27 -
 examples/config/spark/example-shared-rdd.xml    |  83 +++
 examples/pom.xml                                |  27 +-
 examples/schema-import/bin/h2-server.bat        |   2 +-
 examples/schema-import/bin/h2-server.sh         |   4 +-
 .../schema-import/bin/schema-import.properties  |   2 +-
 .../examples/java8/spark/SharedRDDExample.java  | 110 ++++
 .../examples/spark/ScalarSharedRDDExample.scala |  89 +++
 .../examples/SharedRDDExampleSelfTest.java      |  36 ++
 .../IgniteExamplesJ8SelfTestSuite.java          |   3 +
 .../tests/examples/ScalarExamplesSelfTest.scala |   6 +
 .../src/main/resources/META-INF/licenses.txt.vm |   7 +-
 .../JettyRestProcessorAbstractSelfTest.java     |  23 -
 modules/core/src/main/java/META-INF/NOTICE      |   2 +-
 .../java/org/apache/ignite/IgniteMessaging.java |  11 +-
 .../apache/ignite/IgniteSystemProperties.java   |  14 +
 .../apache/ignite/binary/BinaryRawReader.java   |  13 +
 .../apache/ignite/binary/BinaryRawWriter.java   |  13 +
 .../org/apache/ignite/binary/BinaryReader.java  |  15 +
 .../org/apache/ignite/binary/BinaryWriter.java  |  15 +
 .../org/apache/ignite/cache/QueryEntity.java    |  23 +
 .../org/apache/ignite/cache/QueryIndex.java     |  25 +-
 .../org/apache/ignite/cache/query/SqlQuery.java |  25 +
 .../configuration/CacheConfiguration.java       |  16 +-
 .../configuration/FileSystemConfiguration.java  |  75 ++-
 .../configuration/IgniteConfiguration.java      |  31 ++
 .../local/LocalIgfsSecondaryFileSystem.java     |   6 +-
 .../internal/GridEventConsumeHandler.java       |   5 +
 .../ignite/internal/GridKernalContext.java      |   8 +
 .../ignite/internal/GridKernalContextImpl.java  |  14 +
 .../ignite/internal/GridKernalGatewayImpl.java  |  25 +-
 .../internal/GridMessageListenHandler.java      |   5 +
 .../internal/GridPerformanceSuggestions.java    |  92 ---
 .../org/apache/ignite/internal/GridTopic.java   |   2 +-
 .../apache/ignite/internal/IgniteKernal.java    |  72 ++-
 .../ignite/internal/IgniteMessagingImpl.java    |   6 +-
 .../ignite/internal/IgniteVersionUtils.java     |   2 +-
 .../org/apache/ignite/internal/IgnitionEx.java  |  88 ++-
 .../ignite/internal/MappingStoreTask.java       |   3 +-
 .../ignite/internal/MarshallerContextImpl.java  |  50 +-
 .../internal/StripedExecutorMXBeanAdapter.java  |  90 +++
 .../internal/binary/BinaryClassDescriptor.java  |  94 ++--
 .../ignite/internal/binary/BinaryContext.java   |   7 +
 .../internal/binary/BinaryFieldAccessor.java    |  79 ++-
 .../binary/BinaryMetadataCollector.java         |  11 +
 .../internal/binary/BinaryObjectImpl.java       |   9 +
 .../binary/BinaryObjectOffheapImpl.java         |   9 +
 .../internal/binary/BinaryReaderExImpl.java     | 342 ++++++++++--
 .../binary/BinarySerializedFieldComparator.java |   3 +
 .../ignite/internal/binary/BinaryUtils.java     | 147 ++++-
 .../ignite/internal/binary/BinaryWriteMode.java |   6 +
 .../internal/binary/BinaryWriterExImpl.java     |  80 ++-
 .../internal/binary/GridBinaryMarshaller.java   |   8 +-
 .../binary/builder/BinaryBuilderReader.java     |  37 ++
 .../client/util/GridClientConsistentHash.java   |  14 +-
 .../internal/managers/GridManagerAdapter.java   |   2 +-
 .../managers/communication/GridIoManager.java   |  88 +--
 .../communication/GridIoMessageFactory.java     |  20 +-
 .../managers/communication/GridIoPolicy.java    |   3 +
 .../discovery/GridDiscoveryManager.java         | 268 +++------
 .../eventstorage/GridEventStorageManager.java   |  34 +-
 .../affinity/GridAffinityAssignmentCache.java   |   8 +-
 .../cache/CacheAffinitySharedManager.java       |   2 +-
 .../processors/cache/EntryGetResult.java        |  65 +++
 .../processors/cache/GridCacheAdapter.java      | 128 +++--
 .../processors/cache/GridCacheContext.java      |   4 +-
 .../processors/cache/GridCacheEntryEx.java      |  42 +-
 .../cache/GridCacheEvictionManager.java         |  60 +-
 .../processors/cache/GridCacheGateway.java      |  48 +-
 .../processors/cache/GridCacheIoManager.java    |  19 +-
 .../processors/cache/GridCacheMapEntry.java     | 140 ++++-
 .../processors/cache/GridCacheProcessor.java    |  97 +++-
 .../processors/cache/GridCacheUtils.java        |   9 +-
 .../processors/cache/IgniteCacheProxy.java      |   3 +
 .../processors/cache/ReaderArguments.java       |  74 +++
 .../cache/affinity/GridCacheAffinityImpl.java   |   2 +-
 .../dht/GridClientPartitionTopology.java        |  13 +-
 .../dht/GridDhtAssignmentFetchFuture.java       |   5 +-
 .../distributed/dht/GridDhtCacheAdapter.java    |  42 +-
 .../cache/distributed/dht/GridDhtGetFuture.java |  83 ++-
 .../distributed/dht/GridDhtGetSingleFuture.java |  75 +--
 .../distributed/dht/GridDhtLocalPartition.java  | 120 +++-
 .../dht/GridDhtPartitionTopologyImpl.java       |  14 +-
 .../distributed/dht/GridDhtTxPrepareFuture.java |  35 +-
 .../dht/GridPartitionedGetFuture.java           |  10 +-
 .../dht/GridPartitionedSingleGetFuture.java     |  10 +-
 .../GridDhtAtomicAbstractUpdateFuture.java      |   7 +-
 .../GridDhtAtomicAbstractUpdateRequest.java     |   2 +-
 .../dht/atomic/GridDhtAtomicCache.java          |  28 +-
 .../atomic/GridDhtAtomicSingleUpdateFuture.java |   6 +-
 .../GridDhtAtomicSingleUpdateRequest.java       |   5 +-
 .../dht/atomic/GridDhtAtomicUpdateFuture.java   |   6 +-
 .../dht/atomic/GridDhtAtomicUpdateRequest.java  |  10 +-
 .../dht/atomic/GridDhtAtomicUpdateResponse.java |  31 +-
 .../GridNearAtomicSingleUpdateFuture.java       |   7 +-
 .../dht/atomic/GridNearAtomicUpdateFuture.java  |   7 +-
 .../atomic/GridNearAtomicUpdateResponse.java    |  35 +-
 .../dht/colocated/GridDhtColocatedCache.java    |  10 +-
 .../dht/preloader/GridDhtPreloader.java         |  39 +-
 .../distributed/near/GridNearGetFuture.java     |  19 +-
 .../near/GridNearSingleGetRequest.java          |   5 +
 .../local/atomic/GridLocalAtomicCache.java      |  11 +-
 .../cache/query/GridCacheQueryManager.java      | 191 +++++--
 .../continuous/CacheContinuousQueryHandler.java |  97 +++-
 .../cache/transactions/IgniteTxHandler.java     |   6 +-
 .../transactions/IgniteTxLocalAdapter.java      |  65 ++-
 .../cache/version/GridCacheVersion.java         |   2 +-
 .../cache/version/GridCacheVersionManager.java  |   2 +-
 .../clock/GridClockSyncProcessor.java           |   2 +-
 .../continuous/GridContinuousHandler.java       |   5 +
 .../continuous/GridContinuousProcessor.java     |   3 +
 .../processors/igfs/IgfsDataManager.java        |  11 +-
 .../internal/processors/igfs/IgfsImpl.java      |  32 +-
 .../processors/igfs/IgfsMetaManager.java        |  27 +-
 .../internal/processors/igfs/IgfsProcessor.java | 130 +----
 .../internal/processors/igfs/IgfsUtils.java     | 215 +++++--
 .../igfs/client/IgfsClientAbstractCallable.java |  23 +-
 .../igfs/client/IgfsClientAffinityCallable.java |   6 +-
 .../igfs/client/IgfsClientDeleteCallable.java   |   6 +-
 .../igfs/client/IgfsClientExistsCallable.java   |   5 +-
 .../igfs/client/IgfsClientInfoCallable.java     |   5 +-
 .../client/IgfsClientListFilesCallable.java     |   5 +-
 .../client/IgfsClientListPathsCallable.java     |   5 +-
 .../igfs/client/IgfsClientMkdirsCallable.java   |   6 +-
 .../igfs/client/IgfsClientRenameCallable.java   |   6 +-
 .../igfs/client/IgfsClientSetTimesCallable.java |   6 +-
 .../igfs/client/IgfsClientSizeCallable.java     |   5 +-
 .../igfs/client/IgfsClientSummaryCallable.java  |   5 +-
 .../igfs/client/IgfsClientUpdateCallable.java   |   6 +-
 .../meta/IgfsClientMetaIdsForPathCallable.java  |   5 +-
 .../meta/IgfsClientMetaInfoForPathCallable.java |   5 +-
 .../meta/IgfsClientMetaUnlockCallable.java      |   8 +-
 .../secondary/local/LocalFileSystemUtils.java   |  25 +
 .../internal/processors/job/GridJobWorker.java  |   4 +
 .../marshaller/ClientRequestFuture.java         |   2 +-
 .../GridMarshallerMappingProcessor.java         |  39 +-
 .../marshaller/MappingUpdatedListener.java      |  29 +
 .../MissingMappingRequestMessage.java           |   2 +-
 .../MissingMappingResponseMessage.java          |   2 +-
 .../processors/odbc/OdbcRequestHandler.java     |   2 +
 .../platform/PlatformProcessorImpl.java         |   9 -
 .../cache/PlatformCacheEntryProcessorImpl.java  |   6 +-
 .../callback/PlatformCallbackGateway.java       |  23 +
 .../platform/callback/PlatformCallbackOp.java   |   3 +
 .../utils/PlatformConfigurationUtils.java       | 132 ++++-
 .../internal/processors/pool/PoolProcessor.java |   5 +
 .../processors/query/GridQueryIndexing.java     |  21 +-
 .../processors/query/GridQueryProcessor.java    | 216 +++++---
 .../processors/query/GridQueryProperty.java     |  21 +-
 .../query/GridQueryTypeDescriptor.java          |   7 +
 .../processors/query/GridRunningQueryInfo.java  | 132 +++++
 .../suggestions/GridPerformanceSuggestions.java | 105 ++++
 .../JvmConfigurationSuggestions.java            | 104 ++++
 .../suggestions/OsConfigurationSuggestions.java | 127 +++++
 .../internal/suggestions/package-info.java      |  21 +
 .../ignite/internal/util/GridBusyLock.java      |   2 +-
 .../ignite/internal/util/IgniteUtils.java       |  14 +
 .../util/StripedCompositeReadWriteLock.java     |  50 +-
 .../ignite/internal/util/StripedExecutor.java   |  65 ++-
 .../nio/GridAbstractCommunicationClient.java    |  37 +-
 .../util/nio/GridCommunicationClient.java       |   5 -
 .../util/tostring/GridToStringBuilder.java      |   2 +-
 .../internal/visor/VisorMultiNodeTask.java      |   2 +-
 .../visor/cache/VisorCacheClearTask.java        |  88 +--
 .../visor/cache/VisorCacheTypeMetadata.java     |   6 +
 .../visor/compute/VisorGatewayTask.java         |  30 +-
 .../visor/node/VisorIgfsConfiguration.java      |   4 +-
 .../visor/node/VisorNodeDataCollectorJob.java   |   6 +-
 .../visor/query/VisorCancelQueriesTask.java     |  72 +++
 .../query/VisorCollectRunningQueriesTask.java   |  96 ++++
 .../internal/visor/query/VisorRunningQuery.java | 132 +++++
 .../ignite/lang/IgniteProductVersion.java       |   2 +-
 .../java/org/apache/ignite/lang/IgniteUuid.java |  25 +-
 .../ignite/mxbean/StripedExecutorMXBean.java    |  90 +++
 ...PlatformCachePluginConfigurationClosure.java |  31 ++
 ...mCachePluginConfigurationClosureFactory.java |  37 ++
 .../PlatformPluginConfigurationClosure.java     |  30 +
 ...atformPluginConfigurationClosureFactory.java |  37 ++
 .../communication/tcp/TcpCommunicationSpi.java  |  25 +
 .../ignite/spi/discovery/tcp/ClientImpl.java    |  90 ++-
 .../ignite/spi/discovery/tcp/ServerImpl.java    |  63 ++-
 .../messages/TcpDiscoveryAbstractMessage.java   |  21 +
 .../org/apache/ignite/thread/IgniteThread.java  |  26 +-
 modules/core/src/test/config/igfs-loopback.xml  |  27 -
 modules/core/src/test/config/igfs-shmem.xml     |  27 -
 modules/core/src/test/config/log4j-test.xml     |   6 +
 ...atformCachePluginConfigurationClosureFactory |   1 +
 ...rm.PlatformPluginConfigurationClosureFactory |   1 +
 .../ignite/igfs/IgfsEventsAbstractSelfTest.java |  51 +-
 .../igfs/IgfsFragmentizerAbstractSelfTest.java  |  17 +-
 .../ignite/igfs/IgfsFragmentizerSelfTest.java   |   3 +-
 .../internal/GridContinuousTaskSelfTest.java    |  79 +++
 .../MarshallerContextLockingSelfTest.java       |   6 +
 .../binary/BinaryMarshallerSelfTest.java        |  99 ++++
 .../binary/BinaryObjectExceptionSelfTest.java   | 209 +++++++
 .../communication/GridIoManagerSelfTest.java    |   6 +-
 .../GridDiscoveryManagerAliveCacheSelfTest.java |  55 --
 .../discovery/GridDiscoveryManagerSelfTest.java | 214 -------
 .../cache/CacheConcurrentReadThroughTest.java   | 184 ++++++
 .../cache/CacheDeferredDeleteQueueTest.java     | 134 +++++
 .../cache/GridCacheLifecycleAwareSelfTest.java  |  33 ++
 .../processors/cache/GridCacheOffHeapTest.java  | 274 ---------
 .../processors/cache/GridCacheTestEntryEx.java  |  30 +-
 ...lerCacheClientRequestsMappingOnMissTest.java |  24 +-
 ...niteTopologyValidatorGridSplitCacheTest.java | 334 +++++++++++
 ...CacheAtomicReferenceApiSelfAbstractTest.java |  60 +-
 ...idCacheAtomicStampedApiSelfAbstractTest.java |  59 ++
 .../GridCacheQueueApiSelfAbstractTest.java      |  58 ++
 .../GridCacheSetAbstractSelfTest.java           |  53 ++
 .../IgniteAtomicLongApiAbstractSelfTest.java    |  27 +
 .../IgniteCountDownLatchAbstractSelfTest.java   |  43 ++
 .../IgniteLockAbstractSelfTest.java             |  54 +-
 .../IgniteSemaphoreAbstractSelfTest.java        |  52 +-
 .../near/GridNearCacheStoreUpdateTest.java      | 466 ++++++++++++++++
 .../GridNearOffheapCacheStoreUpdateTest.java    |  35 ++
 .../cache/query/IndexingSpiQuerySelfTest.java   |  69 ++-
 .../IndexingSpiQueryWithH2IndexingSelfTest.java |  36 ++
 .../ClientReconnectContinuousQueryTest.java     | 201 +++++++
 .../igfs/IgfsAbstractBaseSelfTest.java          |  17 +-
 .../igfs/IgfsBackupFailoverSelfTest.java        |   7 +-
 ...lockMessageSystemPoolStarvationSelfTest.java |  17 +-
 ...sCachePerBlockLruEvictionPolicySelfTest.java |  18 +-
 .../processors/igfs/IgfsCacheSelfTest.java      |  19 +-
 .../igfs/IgfsDataManagerSelfTest.java           |  33 +-
 .../processors/igfs/IgfsMaxSizeSelfTest.java    |   6 +-
 .../igfs/IgfsMetaManagerSelfTest.java           |   6 +-
 .../processors/igfs/IgfsMetricsSelfTest.java    |  16 +-
 .../processors/igfs/IgfsModesSelfTest.java      |  51 +-
 .../processors/igfs/IgfsOneClientNodeTest.java  |  13 +-
 .../processors/igfs/IgfsProcessorSelfTest.java  |  25 +-
 .../igfs/IgfsProcessorValidationSelfTest.java   | 320 +++--------
 ...gfsSecondaryFileSystemInjectionSelfTest.java |   8 +-
 ...IpcEndpointRegistrationAbstractSelfTest.java |  17 +-
 .../processors/igfs/IgfsSizeSelfTest.java       |  27 +-
 .../processors/igfs/IgfsStartCacheTest.java     |  28 +-
 .../processors/igfs/IgfsStreamsSelfTest.java    |  46 +-
 .../processors/igfs/IgfsTaskSelfTest.java       |   8 +-
 .../IgfsAbstractRecordResolverSelfTest.java     |   8 +-
 ...niteMessagingConfigVariationFullApiTest.java | 195 +++++--
 .../internal/util/StripedExecutorTest.java      | 168 ++++++
 .../ipc/shmem/IpcSharedMemoryNodeStartup.java   |  30 +-
 .../marshaller/MarshallerContextSelfTest.java   |   8 +
 .../marshaller/MarshallerContextTestImpl.java   |   1 +
 .../ignite/messaging/GridMessagingSelfTest.java | 114 +++-
 .../messaging/IgniteMessagingSendAsyncTest.java | 544 ++++++++++++++++++
 .../plugin/PlatformTestPluginConfiguration.java |  63 +++
 ...rmTestPluginConfigurationClosureFactory.java |  61 ++
 .../plugin/PlatformTestPluginException.java     |  34 ++
 .../plugin/PlatformTestPluginExtension.java     |   2 +-
 .../plugin/PlatformTestPluginProvider.java      |   8 +-
 .../plugin/PlatformTestPluginTarget.java        |  62 ++-
 .../cache/PlatformGetCachePluginsTask.java      |  85 +++
 .../PlatformTestCachePluginConfiguration.java   |  60 ++
 ...formTestCachePluginConfigurationClosure.java |  48 ++
 ...tCachePluginConfigurationClosureFactory.java |  37 ++
 .../cache/PlatformTestCachePluginProvider.java  |  73 +++
 .../tcp/TcpCommunicationSpiDropNodesTest.java   | 322 +++++++++++
 .../TcpCommunicationSpiFaultyClientTest.java    | 265 +++++++++
 .../startup/GridRandomCommandLineLoader.java    |   2 +-
 .../ignite/testframework/GridTestNode.java      |   1 +
 .../testframework/junits/GridAbstractTest.java  |  23 +-
 .../junits/GridTestKernalContext.java           |   1 +
 .../junits/multijvm/IgniteNodeRunner.java       |  55 +-
 .../junits/multijvm/IgniteProcessProxy.java     |  63 ++-
 .../ignite/testsuites/IgniteBasicTestSuite.java |   2 +
 .../IgniteBinaryObjectsTestSuite.java           |   2 +
 .../ignite/testsuites/IgniteCacheTestSuite.java |   2 +
 .../testsuites/IgniteCacheTestSuite2.java       |   7 +
 .../testsuites/IgniteComputeGridTestSuite.java  |   2 +
 .../testsuites/IgniteKernalSelfTestSuite.java   |   5 +-
 .../IgniteSpiCommunicationSelfTestSuite.java    |   5 +
 .../IgniteSpiDiscoverySelfTestSuite.java        |   2 +-
 .../IgniteTopologyValidatorTestSuit.java        |   1 +
 modules/hadoop/pom.xml                          |   7 +
 .../hadoop/impl/igfs/HadoopIgfsInProc.java      | 190 ++++++-
 .../hadoop/impl/igfs/HadoopIgfsUtils.java       |   6 +
 .../hadoop/impl/igfs/HadoopIgfsWrapper.java     |  99 ++--
 .../processors/hadoop/impl/v2/HadoopV2Job.java  |  10 +-
 .../hadoop/shuffle/HadoopShuffle.java           |   2 +-
 .../test/config/hadoop-fs-open-test/grid-0.xml  | 126 +++++
 .../test/config/hadoop-fs-open-test/grid-1.xml  | 126 +++++
 .../test/config/hadoop-fs-open-test/grid-2.xml  | 126 +++++
 .../test/config/igfs-cli-config-dual-async.xml  | 135 +++++
 .../test/config/igfs-cli-config-dual-sync.xml   | 133 +++++
 .../src/test/config/igfs-cli-config-primary.xml | 124 +++++
 .../src/test/config/igfs-cli-config-proxy.xml   | 133 +++++
 .../impl/HadoopAbstractMapReduceTest.java       |   6 +-
 .../hadoop/impl/HadoopAbstractSelfTest.java     |  18 +-
 .../igfs/HadoopFIleSystemFactorySelfTest.java   |   8 +-
 .../HadoopIgfs20FileSystemAbstractSelfTest.java |  52 +-
 .../igfs/HadoopIgfsDualAbstractSelfTest.java    |   8 +-
 ...oopSecondaryFileSystemConfigurationTest.java |  69 +--
 .../igfs/IgfsNearOnlyMultiNodeSelfTest.java     |   6 +-
 .../IgniteHadoopFileSystemAbstractSelfTest.java | 184 +++---
 ...opFileSystemClientBasedAbstractSelfTest.java | 193 +++++++
 ...pFileSystemClientBasedDualAsyncSelfTest.java |  38 ++
 ...opFileSystemClientBasedDualSyncSelfTest.java |  38 ++
 ...niteHadoopFileSystemClientBasedOpenTest.java | 305 ++++++++++
 ...oopFileSystemClientBasedPrimarySelfTest.java |  38 ++
 ...adoopFileSystemClientBasedProxySelfTest.java |  37 ++
 .../IgniteHadoopFileSystemClientSelfTest.java   |  56 +-
 ...IgniteHadoopFileSystemHandshakeSelfTest.java |   8 +-
 .../IgniteHadoopFileSystemIpcCacheSelfTest.java |  47 +-
 ...niteHadoopFileSystemLoggerStateSelfTest.java |  22 +-
 ...oopbackExternalToClientAbstractSelfTest.java |  61 ++
 ...opbackExternalToClientDualAsyncSelfTest.java |  33 ++
 ...oopbackExternalToClientDualSyncSelfTest.java |  33 ++
 ...LoopbackExternalToClientPrimarySelfTest.java |  33 ++
 ...emLoopbackExternalToClientProxySelfTest.java |  33 ++
 ...condaryFileSystemInitializationSelfTest.java |  30 +-
 ...ileSystemShmemEmbeddedDualAsyncSelfTest.java |  33 --
 ...FileSystemShmemEmbeddedDualSyncSelfTest.java |  33 --
 ...pFileSystemShmemEmbeddedPrimarySelfTest.java |  33 --
 ...ileSystemShmemEmbeddedSecondarySelfTest.java |  33 --
 ...emShmemExternalToClientAbstractSelfTest.java | 106 ++++
 ...mShmemExternalToClientDualAsyncSelfTest.java |  33 ++
 ...emShmemExternalToClientDualSyncSelfTest.java |  33 ++
 ...temShmemExternalToClientPrimarySelfTest.java |  33 ++
 ...ystemShmemExternalToClientProxySelfTest.java |  33 ++
 .../testsuites/IgniteHadoopTestSuite.java       |  21 +-
 .../IgniteIgfsLinuxAndMacOSTestSuite.java       |  17 +-
 .../cache/query/GridCacheTwoStepQuery.java      |  18 +-
 .../query/h2/DmlStatementsProcessor.java        |  69 +--
 .../processors/query/h2/IgniteH2Indexing.java   | 119 +++-
 .../query/h2/dml/UpdatePlanBuilder.java         | 105 ++--
 .../query/h2/sql/GridSqlQuerySplitter.java      |   4 +-
 .../query/h2/twostep/GridMapQueryExecutor.java  |   8 +-
 .../h2/twostep/GridReduceQueryExecutor.java     |  69 ++-
 ...CacheScanPartitionQueryFallbackSelfTest.java |   2 +-
 .../cache/CacheSqlQueryValueCopySelfTest.java   | 208 ++++++-
 .../cache/GridCacheCrossCacheQuerySelfTest.java |   2 +-
 .../IgniteCacheAbstractFieldsQuerySelfTest.java |  21 +
 ...niteCacheAbstractInsertSqlQuerySelfTest.java |   4 +
 .../cache/IgniteCacheAbstractQuerySelfTest.java | 391 +++++++++++++
 .../IgniteCacheAbstractSqlDmlQuerySelfTest.java |   2 +-
 .../IgniteCacheInsertSqlQuerySelfTest.java      |  22 +
 .../cache/IgniteCacheMergeSqlQuerySelfTest.java |  24 +
 .../IgniteCacheUpdateSqlQuerySelfTest.java      |  63 ++-
 .../cache/QueryEntityCaseMismatchTest.java      | 107 ++++
 .../IgniteCachePartitionedQuerySelfTest.java    |  85 +++
 .../IgniteSqlEntryCacheModeAgnosticTest.java    | 140 +++++
 .../query/IgniteSqlQueryDedicatedPoolTest.java  | 110 ++++
 .../h2/GridIndexingSpiAbstractSelfTest.java     |  41 +-
 .../IgniteCacheQuerySelfTestSuite.java          |   6 +
 .../IgniteCacheQuerySelfTestSuite3.java         |   2 +
 modules/kubernetes/DEVNOTES.txt                 |  63 +++
 modules/kubernetes/README.txt                   |  33 ++
 modules/kubernetes/config/Dockerfile            |  45 ++
 modules/kubernetes/config/example-kube.xml      |  44 ++
 .../kubernetes/config/ignite-deployment.yaml    |  26 +
 modules/kubernetes/config/ignite-service.yaml   |  14 +
 modules/kubernetes/config/run.sh                |  50 ++
 modules/kubernetes/licenses/apache-2.0.txt      | 202 +++++++
 modules/kubernetes/pom.xml                      |  93 ++++
 .../TcpDiscoveryKubernetesIpFinder.java         | 317 +++++++++++
 .../tcp/ipfinder/kubernetes/package-info.java   |  22 +
 .../TcpDiscoveryKubernetesIpFinderSelfTest.java |  93 ++++
 .../tcp/ipfinder/kubernetes/package-info.java   |  22 +
 .../testsuites/IgniteKubernetesTestSuite.java   |  41 ++
 .../include/ignite/binary/binary_object.h       |  22 +-
 .../binary/include/ignite/binary/binary_type.h  |   8 +-
 .../include/ignite/impl/binary/binary_common.h  |   6 +
 .../ignite/impl/binary/binary_object_header.h   |   9 +-
 .../ignite/impl/binary/binary_object_impl.h     |  61 +-
 .../ignite/impl/binary/binary_reader_impl.h     |  29 +-
 .../ignite/impl/binary/binary_type_updater.h    |   2 +-
 .../binary/binary_array_identity_resolver.cpp   |   2 +-
 .../src/impl/binary/binary_object_header.cpp    |  26 +-
 .../src/impl/binary/binary_object_impl.cpp      |  61 +-
 .../src/impl/binary/binary_type_manager.cpp     |   2 +-
 modules/platforms/cpp/common/Makefile.am        |   1 +
 .../common/include/ignite/common/concurrent.h   |  29 +-
 .../include/ignite/common/platform_utils.h      |   6 +-
 .../cpp/common/include/ignite/ignite_error.h    |   2 +-
 .../include/ignite/common/dynamic_load_os.h     | 131 +++++
 .../os/linux/src/common/dynamic_load_os.cpp     |  90 +++
 .../os/linux/src/common/platform_utils.cpp      |  18 +-
 .../win/include/ignite/common/dynamic_load_os.h | 133 +++++
 .../os/win/src/common/dynamic_load_os.cpp       | 115 ++++
 .../common/os/win/src/common/platform_utils.cpp |  26 +-
 .../cpp/common/project/vs/common.vcxproj        |   2 +
 .../common/project/vs/common.vcxproj.filters    |   6 +
 .../platforms/cpp/common/src/common/utils.cpp   |   3 +-
 .../platforms/cpp/common/src/ignite_error.cpp   |  68 +--
 modules/platforms/cpp/core-test/Makefile.am     |   5 +-
 .../core-test/include/ignite/binary_test_defs.h | 106 ++--
 .../cpp/core-test/project/vs/core-test.vcxproj  |   2 +
 .../project/vs/core-test.vcxproj.filters        |   6 +
 .../cpp/core-test/src/binary_object_test.cpp    |   6 +-
 .../src/binary_reader_writer_raw_test.cpp       |  23 +-
 .../cpp/core-test/src/cache_invoke_test.cpp     | 553 +++++++++++++++++++
 .../platforms/cpp/core-test/src/cache_test.cpp  |   5 +-
 .../cpp/core-test/src/cluster_test.cpp          |  98 ++++
 .../cpp/core-test/src/interop_memory_test.cpp   |   3 +-
 modules/platforms/cpp/core/Makefile.am          |   1 +
 modules/platforms/cpp/core/include/Makefile.am  |   8 +
 .../cpp/core/include/ignite/cache/cache.h       | 217 ++++++--
 .../ignite/cache/cache_entry_processor.h        | 111 ++++
 .../include/ignite/cache/mutable_cache_entry.h  | 176 ++++++
 .../include/ignite/cache/query/query_cursor.h   |   2 +-
 .../platforms/cpp/core/include/ignite/ignite.h  |  18 +
 .../cpp/core/include/ignite/ignite_binding.h    | 119 ++++
 .../include/ignite/ignite_binding_context.h     |  88 +++
 .../core/include/ignite/ignite_configuration.h  |   2 -
 .../impl/binary/binary_type_updater_impl.h      |   2 +-
 .../impl/cache/cache_entry_processor_holder.h   | 282 ++++++++++
 .../core/include/ignite/impl/cache/cache_impl.h |  71 +--
 .../ignite/impl/cluster/cluster_group_impl.h    |  77 +++
 .../include/ignite/impl/ignite_binding_impl.h   | 121 ++++
 .../include/ignite/impl/ignite_environment.h    |  61 +-
 .../cpp/core/include/ignite/impl/ignite_impl.h  |  50 +-
 .../ignite/impl/interop/interop_target.h        |  37 +-
 .../core/include/ignite/impl/module_manager.h   | 131 +++++
 .../cpp/core/include/ignite/impl/operations.h   |  62 +--
 .../platforms/cpp/core/project/vs/core.vcxproj  |   9 +
 .../cpp/core/project/vs/core.vcxproj.filters    |  30 +
 modules/platforms/cpp/core/src/ignite.cpp       |  12 +-
 modules/platforms/cpp/core/src/ignition.cpp     | 343 +++++++-----
 .../impl/binary/binary_type_updater_impl.cpp    |   2 +-
 .../cpp/core/src/impl/cache/cache_impl.cpp      |  66 ++-
 .../continuous/continuous_query_handle_impl.cpp |   2 +-
 .../core/src/impl/cache/query/query_impl.cpp    |   8 +-
 .../src/impl/cluster/cluster_group_impl.cpp     |  64 +++
 .../cpp/core/src/impl/ignite_environment.cpp    |  92 ++-
 .../platforms/cpp/core/src/impl/ignite_impl.cpp |  32 +-
 .../core/src/impl/interop/interop_target.cpp    |  49 +-
 .../src/impl/transactions/transactions_impl.cpp |  14 +-
 .../platforms/cpp/jni/include/ignite/jni/java.h |   2 +-
 .../cpp/jni/include/ignite/jni/utils.h          |  69 ++-
 .../platforms/cpp/jni/os/linux/src/utils.cpp    | 221 ++++----
 modules/platforms/cpp/jni/os/win/src/utils.cpp  | 227 ++++----
 modules/platforms/cpp/jni/src/java.cpp          |  53 +-
 modules/platforms/cpp/odbc/src/utility.cpp      |  17 +-
 .../Properties/AssemblyInfo.cs                  |   2 +-
 .../Apache.Ignite.AspNet.nuspec                 |   2 +-
 .../Properties/AssemblyInfo.cs                  |   2 +-
 .../Properties/AssemblyInfo.cs                  |   2 +-
 .../Properties/AssemblyInfo.cs                  |   2 +-
 .../Properties/AssemblyInfo.cs                  |   2 +-
 .../Apache.Ignite.Core.Tests.csproj             |   3 +
 .../Cache/CacheAbstractTransactionalTest.cs     | 105 ++--
 .../Cache/Query/CacheLinqTest.cs                |  96 ++++
 .../Cache/Store/CacheStoreTest.cs               |  30 +-
 .../Compute/ComputeApiTest.cs                   |  18 +-
 .../Apache.Ignite.Core.Tests/ExceptionsTest.cs  |  28 +
 .../Cache/CacheJavaPluginConfiguration.cs       |  45 ++
 .../Plugin/Cache/CacheJavaPluginTest.cs         | 113 ++++
 .../Plugin/Cache/CachePluginConfiguration.cs    |  24 +
 .../Plugin/Cache/CachePluginTest.cs             |   7 +-
 .../Plugin/PluginTest.cs                        |  66 ++-
 .../Plugin/TestIgnitePluginConfiguration.cs     |  20 +
 .../Plugin/TestIgnitePluginException.cs         |  64 +++
 .../Plugin/TestIgnitePluginProvider.cs          |  18 +
 .../Properties/AssemblyInfo.cs                  |   2 +-
 .../Apache.Ignite.Core.Schema.nuspec            |   2 +-
 .../Apache.Ignite.Core.csproj                   |   2 +
 .../Apache.Ignite.Core.nuspec                   |   2 +-
 .../Cache/Configuration/CacheConfiguration.cs   |  22 +-
 .../Cache/Configuration/QueryEntity.cs          |   2 +-
 .../Common/ExceptionFactory.cs                  |  31 ++
 .../Apache.Ignite.Core/Common/JavaException.cs  |  62 ++-
 .../Apache.Ignite.Core/IgniteConfiguration.cs   |  28 +
 .../IgniteConfigurationSection.xsd              |   5 +
 .../Impl/Binary/BinaryUtils.cs                  |  44 +-
 .../Apache.Ignite.Core/Impl/Cache/CacheImpl.cs  |   9 +-
 .../Common/IgniteConfigurationXmlSerializer.cs  |   7 +
 .../Apache.Ignite.Core/Impl/ExceptionUtils.cs   |  96 ++--
 .../Impl/Plugin/PluginContext.cs                |  19 +
 .../Impl/Plugin/PluginProcessor.cs              | 116 ++++
 .../Impl/Unmanaged/UnmanagedCallbackOp.cs       |   3 +-
 .../Impl/Unmanaged/UnmanagedCallbacks.cs        |  11 +-
 .../Plugin/Cache/ICachePluginConfiguration.cs   |  18 +-
 .../Plugin/IPluginConfiguration.cs              |  15 +-
 .../Apache.Ignite.Core/Plugin/IPluginContext.cs |  16 +
 .../Apache.Ignite.Core/Plugin/PluginCallback.cs |  29 +
 .../Properties/AssemblyInfo.cs                  |   2 +-
 .../Apache.Ignite.EntityFramework.nuspec        |   2 +-
 .../Apache.Ignite.Linq.nuspec                   |   2 +-
 .../Impl/CacheQueryExpressionVisitor.cs         | 127 ++++-
 .../Impl/CacheQueryModelVisitor.cs              |   3 +
 .../Properties/AssemblyInfo.cs                  |   2 +-
 .../Apache.Ignite.Log4Net.nuspec                |   2 +-
 .../Properties/AssemblyInfo.cs                  |   2 +-
 .../Apache.Ignite.NLog.nuspec                   |   2 +-
 .../Properties/AssemblyInfo.cs                  |   2 +-
 .../Apache.Ignite/Properties/AssemblyInfo.cs    |   2 +-
 .../Apache.Ignite.Examples.csproj               |   1 +
 .../Datagrid/TransactionExample.cs              |  75 ++-
 .../Properties/AssemblyInfo.cs                  |   2 +-
 modules/scalar-2.10/pom.xml                     |   2 +-
 modules/scalar/pom.xml                          |   2 +-
 .../apache/ignite/spark/JavaIgniteContext.scala |   6 +
 .../org/apache/ignite/spring/sprint-exclude.xml |   2 -
 .../ignite/tools/classgen/ClassesGenerator.java |   4 +-
 modules/web-console/backend/app/agent.js        |  44 +-
 modules/web-console/backend/app/browser.js      |  26 +
 modules/web-console/backend/app/mongo.js        |  49 +-
 modules/web-console/backend/app/routes.js       |   5 +-
 .../web-console/backend/routes/activities.js    |  45 ++
 modules/web-console/backend/routes/admin.js     |   2 +-
 modules/web-console/backend/routes/agent.js     |  10 +-
 modules/web-console/backend/routes/profile.js   |   4 +-
 modules/web-console/backend/routes/public.js    |   1 -
 .../web-console/backend/services/activities.js  | 116 ++++
 .../web-console/backend/services/sessions.js    |   6 +-
 modules/web-console/backend/services/users.js   |  20 +-
 .../backend/test/unit/ActivitiesService.test.js | 131 +++++
 modules/web-console/frontend/app/app.config.js  |  13 +
 modules/web-console/frontend/app/app.js         |  29 +-
 .../activities-user-dialog.controller.js        |  27 +
 .../activities-user-dialog.jade                 |  36 ++
 .../components/activities-user-dialog/index.js  |  35 ++
 .../form-field-datepicker.jade                  |  55 ++
 .../form-field-datepicker.scss                  |  20 +
 .../list-of-registered-users/index.js           |  28 +
 .../list-of-registered-users.categories.js      |  30 +
 .../list-of-registered-users.column-defs.js     |  80 +++
 .../list-of-registered-users.controller.js      | 235 ++++++++
 .../list-of-registered-users.jade               |  58 ++
 .../ui-grid-header/ui-grid-header.jade          |  27 +
 .../ui-grid-header/ui-grid-header.scss          |  84 +++
 .../ui-grid-settings/ui-grid-settings.jade      |  33 ++
 .../ui-grid-settings/ui-grid-settings.scss      |  99 ++++
 .../app/core/activities/Activities.data.js      |  34 ++
 .../frontend/app/core/admin/Admin.data.js       |  77 +++
 modules/web-console/frontend/app/core/index.js  |  25 +
 modules/web-console/frontend/app/data/i18n.js   |  39 ++
 .../ui-ace-pom/ui-ace-pom.controller.js         |   4 +-
 .../ui-grid-settings/ui-grid-settings.jade      |  33 --
 .../ui-grid-settings/ui-grid-settings.scss      |  38 --
 .../app/filters/uiGridSubcategories.filter.js   |  24 +
 .../frontend/app/modules/Demo/Demo.module.js    | 166 ------
 .../frontend/app/modules/agent/agent.module.js  |  15 -
 .../app/modules/branding/branding.provider.js   |   2 +-
 .../modules/configuration/Version.service.js    |  35 +-
 .../configuration/configuration.module.js       |   6 +-
 .../configuration/generator/Maven.service.js    |  10 +-
 .../frontend/app/modules/demo/Demo.module.js    | 172 ++++++
 .../frontend/app/modules/sql/sql.controller.js  |  14 +-
 .../frontend/app/modules/sql/sql.module.js      |   2 +-
 .../frontend/app/modules/states/admin.state.js  |   2 +-
 .../configuration/summary/summary.controller.js |   6 +-
 .../configuration/summary/summary.worker.js     |  34 +-
 .../app/modules/user/AclRoute.provider.js       |  31 +-
 .../frontend/app/modules/user/Auth.service.js   |   2 +-
 .../frontend/app/modules/user/permissions.js    |   2 +-
 .../frontend/app/modules/user/user.module.js    |   6 +-
 modules/web-console/frontend/app/vendor.js      |   1 +
 .../frontend/controllers/admin-controller.js    | 234 --------
 .../frontend/controllers/domains-controller.js  |  12 +-
 modules/web-console/frontend/package.json       | 181 +++---
 .../stylesheets/_font-awesome-custom.scss       |  28 +
 .../frontend/public/stylesheets/style.scss      |  31 +-
 .../frontend/test/unit/Version.test.js          |  26 +-
 .../frontend/views/settings/admin.jade          |  32 +-
 modules/web-console/frontend/views/sql/sql.jade |   4 +-
 .../views/templates/agent-download.jade         |  12 +-
 modules/web-console/web-agent/README.txt        |   2 +-
 .../ignite/console/agent/AgentLauncher.java     | 203 ++++---
 .../apache/ignite/console/agent/AgentUtils.java |  80 +++
 .../console/agent/handlers/AbstractHandler.java | 110 ----
 .../agent/handlers/AbstractListener.java        | 104 ++++
 .../console/agent/handlers/DatabaseHandler.java | 298 ----------
 .../agent/handlers/DatabaseListener.java        | 316 +++++++++++
 .../console/agent/handlers/RestHandler.java     | 276 ---------
 .../console/agent/handlers/RestListener.java    | 287 ++++++++++
 .../ignite/console/demo/AgentClusterDemo.java   | 475 +---------------
 .../ignite/console/demo/AgentDemoUtils.java     |  79 +++
 .../demo/service/DemoCachesLoadService.java     | 456 +++++++++++++++
 .../service/DemoRandomCacheLoadService.java     | 120 ++++
 .../service/DemoServiceClusterSingleton.java    |  41 ++
 .../demo/service/DemoServiceKeyAffinity.java    |  41 ++
 .../service/DemoServiceMultipleInstances.java   |  41 ++
 .../demo/service/DemoServiceNodeSingleton.java  |  41 ++
 modules/yardstick/DEVNOTES-standalone.txt       |  16 +
 modules/yardstick/DEVNOTES.txt                  |  20 +-
 modules/yardstick/README.txt                    | 142 +++--
 .../config/benchmark-atomic-win.properties      |   2 +-
 .../config/benchmark-atomic.properties          |  35 +-
 .../config/benchmark-bin-identity.properties    |  16 +-
 .../config/benchmark-cache-load-win.properties  |   2 +-
 .../config/benchmark-cache-load.properties      |   4 +-
 .../config/benchmark-client-mode.properties     |  68 ++-
 .../config/benchmark-compute-win.properties     |   2 +-
 .../config/benchmark-compute.properties         |  30 +-
 .../config/benchmark-failover.properties        |   2 +-
 .../yardstick/config/benchmark-full.properties  |  62 +--
 .../config/benchmark-multicast.properties       | 107 ++--
 .../config/benchmark-put-indexed-val.properties |  23 +-
 .../benchmark-query-put-separated.properties    |   3 +-
 .../config/benchmark-query-win.properties       |   2 +-
 .../yardstick/config/benchmark-query.properties |  33 +-
 .../config/benchmark-remote-sample.properties   |  80 +++
 .../config/benchmark-remote.properties          | 119 ++++
 .../config/benchmark-sample.properties          |  80 +++
 .../config/benchmark-sql-dml.properties         |  36 +-
 .../yardstick/config/benchmark-store.properties |   3 +-
 .../config/benchmark-tx-win.properties          |   2 +-
 .../yardstick/config/benchmark-tx.properties    |  33 +-
 .../yardstick/config/benchmark-win.properties   |   2 +-
 modules/yardstick/config/benchmark.properties   |  76 ++-
 .../yardstick/config/ignite-remote-config.xml   |  47 ++
 .../test-max-int-values-offheap.properties      |   3 +-
 .../test-max-int-values-onheap.properties       |   3 +-
 .../config/test-max-int-values-swap.properties  |   3 +-
 modules/yardstick/pom-standalone.xml            |   2 +-
 modules/yardstick/pom.xml                       |   4 +-
 .../yardstick/IgniteBenchmarkArguments.java     |  28 +-
 .../org/apache/ignite/yardstick/IgniteNode.java |   2 +-
 .../cache/IgnitePutRemoveBenchmark.java         |  42 ++
 .../cache/IgnitePutRemoveTxBenchmark.java       |  30 +
 .../cache/IgnitePutValue8Benchmark.java         |  42 ++
 .../IgniteCacheRandomOperationBenchmark.java    |  49 ++
 parent/pom.xml                                  |   2 +-
 pom.xml                                         |   7 +-
 621 files changed, 24816 insertions(+), 6758 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ignite/blob/796c933a/modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/DmlStatementsProcessor.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/796c933a/modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/IgniteH2Indexing.java
----------------------------------------------------------------------