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/13 08:45:23 UTC

[02/50] [abbrv] ignite git commit: Merge remote-tracking branch 'remotes/origin/ignite-1.9'

Merge remote-tracking branch 'remotes/origin/ignite-1.9'

# Conflicts:
#	modules/core/src/main/java/org/apache/ignite/internal/processors/query/GridQueryIndexing.java
#	modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/IgniteH2Indexing.java
#	modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/sql/GridSqlQuerySplitter.java
#	modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/twostep/GridReduceQueryExecutor.java
#	modules/kubernetes/config/Dockerfile
#	modules/kubernetes/config/ignite-deployment.yaml
#	modules/kubernetes/config/ignite-service.yaml
#	pom.xml


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

Branch: refs/heads/ignite-2.0
Commit: cc6257f8c53da5f6da32b0f184065c1e35a75acf
Parents: 5456caf bea863f
Author: Anton Vinogradov <av...@apache.org>
Authored: Wed Mar 1 17:32:17 2017 +0300
Committer: Anton Vinogradov <av...@apache.org>
Committed: Wed Mar 1 17:32:17 2017 +0300

----------------------------------------------------------------------
 RELEASE_NOTES.txt                               |   20 +
 assembly/dependencies-hadoop.xml                |    3 +
 assembly/release-base.xml                       |    5 -
 assembly/release-fabric-base.xml                |    5 +
 assembly/release-sources.xml                    |    3 +-
 examples/pom-standalone-lgpl.xml                |    6 +
 examples/pom-standalone.xml                     |    6 +
 modules/clients/src/test/config/jdbc-config.xml |    2 +-
 .../jdbc2/JdbcAbstractDmlStatementSelfTest.java |   49 +-
 .../jdbc2/JdbcInsertStatementSelfTest.java      |   51 +
 .../jdbc2/JdbcMergeStatementSelfTest.java       |   51 +
 .../internal/jdbc2/JdbcStreamingSelfTest.java   |  187 ++
 .../jdbc2/JdbcUpdateStatementSelfTest.java      |   50 +
 .../jdbc/suite/IgniteJdbcDriverTestSuite.java   |    1 +
 .../org/apache/ignite/IgniteJdbcDriver.java     |   30 +
 .../apache/ignite/IgniteSystemProperties.java   |   38 +
 .../configuration/CacheConfiguration.java       |   41 +
 .../ignite/internal/binary/BinaryContext.java   |    3 +
 .../ignite/internal/binary/BinaryTreeMap.java   |    6 +-
 .../ignite/internal/jdbc2/JdbcConnection.java   |   72 +-
 .../internal/jdbc2/JdbcPreparedStatement.java   |   34 +-
 .../ignite/internal/jdbc2/JdbcStatement.java    |   20 +-
 .../jdbc2/JdbcStreamedPreparedStatement.java    |   59 +
 .../processors/cache/EntryGetResult.java        |   40 +-
 .../processors/cache/EntryGetWithTtlResult.java |   58 +
 .../processors/cache/GridCacheAdapter.java      |   69 +-
 .../processors/cache/GridCacheContext.java      |  122 +-
 .../processors/cache/GridCacheEntryEx.java      |    2 +-
 .../processors/cache/GridCacheMapEntry.java     |   29 +-
 .../processors/cache/GridCacheProcessor.java    |    3 +
 .../processors/cache/IgniteCacheProxy.java      |    6 +-
 .../distributed/dht/GridDhtCacheAdapter.java    |    4 +-
 .../cache/distributed/dht/GridDhtGetFuture.java |   24 +-
 .../distributed/dht/GridDhtGetSingleFuture.java |   24 +-
 .../dht/GridPartitionedGetFuture.java           |   19 +-
 .../dht/GridPartitionedSingleGetFuture.java     |    7 +-
 .../dht/atomic/GridDhtAtomicCache.java          |   12 +-
 .../dht/colocated/GridDhtColocatedCache.java    |   15 +-
 .../distributed/near/GridNearGetFuture.java     |    9 +-
 .../cache/distributed/near/GridNearTxLocal.java |    8 +-
 .../local/atomic/GridLocalAtomicCache.java      |   13 +-
 .../cache/query/GridCacheSqlQuery.java          |   45 +-
 .../transactions/IgniteTxLocalAdapter.java      |   65 +-
 .../closure/GridClosureProcessor.java           |    2 +-
 .../processors/cluster/GridUpdateNotifier.java  |    2 +-
 .../processors/hadoop/HadoopJobProperty.java    |    2 +-
 .../processors/query/GridQueryIndexing.java     |   58 +-
 .../processors/query/GridQueryProcessor.java    |  194 +-
 .../messages/GridQueryNextPageRequest.java      |   29 +-
 .../messages/GridQueryNextPageResponse.java     |   29 +-
 .../resources/META-INF/classnames.properties    |    6 +-
 .../cache/GridCacheAbstractFullApiSelfTest.java |   20 +-
 .../processors/cache/GridCacheTestEntryEx.java  |    2 +-
 .../CacheLockReleaseNodeLeaveTest.java          |   64 +-
 .../IgniteCacheExpiryPolicyAbstractTest.java    |   42 +
 .../tcp/TcpCommunicationSpiDropNodesTest.java   |    3 +-
 .../TcpCommunicationSpiFaultyClientTest.java    |    3 +-
 .../query/h2/opt/GridH2SpatialIndex.java        |   56 +-
 .../query/h2/GridH2IndexingGeoSelfTest.java     |  409 +++--
 .../h2/GridH2IndexingSegmentedGeoSelfTest.java  |   37 +
 .../testsuites/GeoSpatialIndexingTestSuite.java |    2 +
 .../hadoop/shuffle/HadoopShuffleJob.java        |    3 +-
 .../cache/query/GridCacheTwoStepQuery.java      |   17 +
 .../query/h2/DmlStatementsProcessor.java        |  267 ++-
 .../processors/query/h2/IgniteH2Indexing.java   |  406 ++++-
 .../query/h2/dml/UpdatePlanBuilder.java         |    2 +-
 .../query/h2/opt/DistributedJoinMode.java       |   51 +
 .../query/h2/opt/GridH2CollocationModel.java    |   78 +-
 .../query/h2/opt/GridH2IndexBase.java           |  348 +++-
 .../query/h2/opt/GridH2QueryContext.java        |   84 +-
 .../query/h2/opt/GridH2RowDescriptor.java       |    5 -
 .../query/h2/opt/GridH2TreeIndex.java           |  151 +-
 .../processors/query/h2/sql/DmlAstUtils.java    |   54 +-
 .../processors/query/h2/sql/GridSqlAlias.java   |   13 +-
 .../processors/query/h2/sql/GridSqlArray.java   |    8 +-
 .../processors/query/h2/sql/GridSqlAst.java     |   61 +
 .../processors/query/h2/sql/GridSqlColumn.java  |   85 +-
 .../processors/query/h2/sql/GridSqlConst.java   |    6 +-
 .../processors/query/h2/sql/GridSqlElement.java |   43 +-
 .../query/h2/sql/GridSqlFunction.java           |   18 +-
 .../processors/query/h2/sql/GridSqlJoin.java    |   35 +-
 .../processors/query/h2/sql/GridSqlKeyword.java |    3 +-
 .../query/h2/sql/GridSqlOperation.java          |    6 +-
 .../query/h2/sql/GridSqlOperationType.java      |    4 +-
 .../query/h2/sql/GridSqlParameter.java          |    4 +-
 .../query/h2/sql/GridSqlPlaceholder.java        |    2 +-
 .../processors/query/h2/sql/GridSqlQuery.java   |   80 +-
 .../query/h2/sql/GridSqlQueryParser.java        |  246 ++-
 .../query/h2/sql/GridSqlQuerySplitter.java      | 1656 +++++++++++++++---
 .../processors/query/h2/sql/GridSqlSelect.java  |  121 +-
 .../query/h2/sql/GridSqlStatement.java          |   11 +-
 .../query/h2/sql/GridSqlSubquery.java           |   31 +-
 .../processors/query/h2/sql/GridSqlTable.java   |   19 +-
 .../processors/query/h2/sql/GridSqlType.java    |    6 +-
 .../processors/query/h2/sql/GridSqlUnion.java   |   66 +-
 .../processors/query/h2/sql/GridSqlValue.java   |   25 -
 .../query/h2/twostep/GridMapQueryExecutor.java  |  234 ++-
 .../query/h2/twostep/GridMergeIndex.java        |  457 ++++-
 .../query/h2/twostep/GridMergeIndexSorted.java  |  284 +++
 .../h2/twostep/GridMergeIndexUnsorted.java      |   40 +-
 .../h2/twostep/GridReduceQueryExecutor.java     |  120 +-
 .../h2/twostep/msg/GridH2IndexRangeRequest.java |   60 +-
 .../twostep/msg/GridH2IndexRangeResponse.java   |   62 +-
 .../h2/twostep/msg/GridH2QueryRequest.java      |   12 +
 .../IgniteCacheAbstractFieldsQuerySelfTest.java |    2 +-
 ...niteCacheAbstractInsertSqlQuerySelfTest.java |    6 +-
 .../IgniteCacheInsertSqlQuerySelfTest.java      |   14 +
 .../IgniteCacheUpdateSqlQuerySelfTest.java      |   11 +-
 .../query/IgniteSqlSegmentedIndexSelfTest.java  |  263 +++
 .../query/IgniteSqlSplitterSelfTest.java        |  237 ++-
 .../h2/GridIndexingSpiAbstractSelfTest.java     |   26 +-
 .../h2/sql/AbstractH2CompareQueryTest.java      |   21 +-
 .../query/h2/sql/GridQueryParsingTest.java      |   72 +-
 .../query/h2/sql/H2CompareBigQueryTest.java     |   56 +-
 .../FetchingQueryCursorStressTest.java          |  277 +++
 .../IgniteCacheQuerySelfTestSuite.java          |    2 +
 .../processors/query/h2/sql/bigQuery.sql        |    2 +-
 modules/kubernetes/config/Dockerfile            |   17 +
 .../kubernetes/config/ignite-deployment.yaml    |   15 +
 modules/kubernetes/config/ignite-service.yaml   |   15 +
 .../cpp/common/project/vs/common.vcxproj        |    1 -
 .../common/project/vs/common.vcxproj.filters    |    6 -
 .../platforms/cpp/common/project/vs/targetver.h |   25 -
 modules/platforms/cpp/core-test/Makefile.am     |    1 +
 .../cpp/core-test/config/cache-store.xml        |   71 +
 .../cpp/core-test/project/vs/core-test.vcxproj  |    5 +
 .../project/vs/core-test.vcxproj.filters        |    9 +
 .../src/binary_identity_resolver_test.cpp       |    2 +-
 .../src/binary_reader_writer_raw_test.cpp       |    2 +-
 .../core-test/src/binary_reader_writer_test.cpp |    2 +-
 .../cpp/core-test/src/binary_session_test.cpp   |    2 +-
 .../cpp/core-test/src/cache_query_test.cpp      |    2 +-
 .../cpp/core-test/src/cache_store_test.cpp      |  151 ++
 .../cpp/core-test/src/continuous_query_test.cpp |    2 +-
 .../cpp/core-test/src/handle_registry_test.cpp  |    2 +-
 .../cpp/core-test/src/ignite_error_test.cpp     |    2 +-
 .../cpp/core-test/src/ignition_test.cpp         |    2 +-
 .../cpp/core-test/src/interop_memory_test.cpp   |    2 +-
 .../cpp/core-test/src/reference_test.cpp        |    2 +-
 .../platforms/cpp/core-test/src/test_utils.cpp  |    7 +
 .../cpp/core-test/src/transactions_test.cpp     |    2 +-
 .../cpp/core/include/ignite/cache/cache.h       |   54 +-
 .../cache/query/continuous/continuous_query.h   |    2 +-
 .../core/include/ignite/impl/cache/cache_impl.h |   19 +
 .../ignite/impl/interop/interop_target.h        |   25 +
 .../cpp/core/src/impl/cache/cache_impl.cpp      |   48 +
 .../core/src/impl/interop/interop_target.cpp    |   36 +-
 .../platforms/cpp/jni/project/vs/jni.vcxproj    |    1 -
 .../cpp/jni/project/vs/jni.vcxproj.filters      |    3 -
 .../platforms/cpp/jni/project/vs/targetver.h    |   25 -
 .../Properties/AssemblyInfo.cs                  |    2 +-
 .../Properties/AssemblyInfo.cs                  |    2 +-
 .../Properties/AssemblyInfo.cs                  |    2 +-
 .../Properties/AssemblyInfo.cs                  |    2 +-
 .../Properties/AssemblyInfo.cs                  |    2 +-
 .../Properties/AssemblyInfo.cs                  |    2 +-
 modules/yardstick/config/ignite-base-config.xml |   25 +
 .../yardstick/cache/IgniteGetAllBenchmark.java  |   42 +
 .../cache/IgniteGetAllOffHeapBenchmark.java     |   30 +
 .../yardstick/cache/IgniteGetBenchmark.java     |   35 +
 .../cache/IgnitePutAllOffHeapBenchmark.java     |   30 +
 .../cache/IgnitePutAllTxOffHeapBenchmark.java   |   30 +
 .../IgnitePutOffHeapIndexedValue8Benchmark.java |   30 +
 .../IgnitePutRandomValueSizeBenchmark.java      |   41 +
 parent/pom.xml                                  |    4 +-
 165 files changed, 7532 insertions(+), 1856 deletions(-)
----------------------------------------------------------------------


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

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

http://git-wip-us.apache.org/repos/asf/ignite/blob/cc6257f8/modules/core/src/main/java/org/apache/ignite/internal/processors/cache/distributed/near/GridNearTxLocal.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/ignite/blob/cc6257f8/modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/IgniteH2Indexing.java
----------------------------------------------------------------------
diff --cc modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/IgniteH2Indexing.java
index e4b0c1f,b4bf608..247b5a6
--- a/modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/IgniteH2Indexing.java
+++ b/modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/IgniteH2Indexing.java
@@@ -91,7 -94,9 +94,8 @@@ import org.apache.ignite.internal.proce
  import org.apache.ignite.internal.processors.query.GridQueryIndexing;
  import org.apache.ignite.internal.processors.query.GridQueryProperty;
  import org.apache.ignite.internal.processors.query.GridQueryTypeDescriptor;
 -import org.apache.ignite.internal.processors.query.GridRunningQueryInfo;
  import org.apache.ignite.internal.processors.query.IgniteSQLException;
+ import org.apache.ignite.internal.processors.query.h2.opt.DistributedJoinMode;
  import org.apache.ignite.internal.processors.query.h2.opt.GridH2DefaultTableEngine;
  import org.apache.ignite.internal.processors.query.h2.opt.GridH2KeyValueRowOffheap;
  import org.apache.ignite.internal.processors.query.h2.opt.GridH2KeyValueRowOnheap;
@@@ -1115,15 -1279,16 +1278,21 @@@ public class IgniteH2Indexing implement
  
          setupConnection(conn, false, false);
  
-         GridH2QueryContext.set(new GridH2QueryContext(nodeId, nodeId, 0, LOCAL).filter(filter).distributedJoins(false));
+         GridH2QueryContext.set(new GridH2QueryContext(nodeId, nodeId, 0, LOCAL).filter(filter)
+             .distributedJoinMode(OFF));
+ 
+         GridRunningQueryInfo run = new GridRunningQueryInfo(qryIdGen.incrementAndGet(), qry, SQL, spaceName,
+             U.currentTimeMillis(), null, true);
+ 
+         runs.put(run.id(), run);
  
 +        GridRunningQueryInfo run = new GridRunningQueryInfo(qryIdGen.incrementAndGet(), qry, SQL, spaceName,
 +            U.currentTimeMillis(), null, true);
 +
 +        runs.put(run.id(), run);
 +
          try {
-             ResultSet rs = executeSqlQueryWithTimer(spaceName, conn, sql, params, true, 0, null);
+             ResultSet rs = executeSqlQueryWithTimer(spaceName, conn, sql, params, true, 0, cancel);
  
              return new KeyValIterator(rs);
          }

http://git-wip-us.apache.org/repos/asf/ignite/blob/cc6257f8/modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/twostep/GridReduceQueryExecutor.java
----------------------------------------------------------------------
diff --cc modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/twostep/GridReduceQueryExecutor.java
index f54fab6,4cae6ac..a419c24
--- a/modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/twostep/GridReduceQueryExecutor.java
+++ b/modules/indexing/src/main/java/org/apache/ignite/internal/processors/query/h2/twostep/GridReduceQueryExecutor.java
@@@ -62,12 -62,11 +62,12 @@@ import org.apache.ignite.internal.proce
  import org.apache.ignite.internal.processors.cache.query.GridCacheQueryMarshallable;
  import org.apache.ignite.internal.processors.cache.query.GridCacheSqlQuery;
  import org.apache.ignite.internal.processors.cache.query.GridCacheTwoStepQuery;
 +import org.apache.ignite.internal.processors.query.GridRunningQueryInfo;
  import org.apache.ignite.internal.processors.query.GridQueryCacheObjectsIterator;
  import org.apache.ignite.internal.processors.query.GridQueryCancel;
+ import org.apache.ignite.internal.processors.query.GridRunningQueryInfo;
  import org.apache.ignite.internal.processors.query.h2.IgniteH2Indexing;
  import org.apache.ignite.internal.processors.query.h2.opt.GridH2QueryContext;
- import org.apache.ignite.internal.processors.query.h2.sql.GridSqlQuerySplitter;
  import org.apache.ignite.internal.processors.query.h2.sql.GridSqlType;
  import org.apache.ignite.internal.processors.query.h2.twostep.messages.GridQueryCancelRequest;
  import org.apache.ignite.internal.processors.query.h2.twostep.messages.GridQueryFailResponse;