You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ignite.apache.org by al...@apache.org on 2021/08/12 11:46:34 UTC

[ignite] 01/01: Merge remote-tracking branch 'remotes/upstream/master' into sql-calcite

This is an automated email from the ASF dual-hosted git repository.

alexpl pushed a commit to branch sql-calcite
in repository https://gitbox.apache.org/repos/asf/ignite.git

commit b56eaed89d5e39fb6cc5be55d636e55aba8dc275
Merge: 2a0c9f2 c7a835f
Author: Aleksey Plekhanov <pl...@gmail.com>
AuthorDate: Thu Aug 12 14:27:50 2021 +0300

    Merge remote-tracking branch 'remotes/upstream/master' into sql-calcite
    
    # Conflicts:
    #	modules/core/src/main/java/org/apache/ignite/internal/processors/pool/PoolProcessor.java
    #	parent/pom.xml

 CONTRIBUTING.md                                    |   2 +-
 .../docker}/apache-ignite-net/Dockerfile           |   0
 .../docker}/apache-ignite-net/README.txt           |   0
 .../docker}/apache-ignite/.dockerignore            |   0
 .../docker}/apache-ignite/README.txt               |   0
 {docker => deliveries/docker}/apache-ignite/run.sh |   0
 deliveries/docker/apache-ignite/s390x/Dockerfile   |  70 ++
 .../docker/apache-ignite/x86_64}/Dockerfile        |   0
 docs/_config.yml                                   |   2 +-
 docs/_data/toc.yaml                                |   2 -
 docs/_docs/code-snippets/dotnet/dotnet.csproj      |   2 +-
 docs/_docs/code-snippets/java/pom.xml              |   2 +-
 docs/_docs/data-modeling/data-partitioning.adoc    |   2 +
 docs/_docs/monitoring-metrics/new-metrics.adoc     |   9 +-
 examples/pom.xml                                   |   2 +-
 modules/aop/pom.xml                                |   2 +-
 modules/apache-license-gen/pom.xml                 |   2 +-
 modules/aws/pom.xml                                |   2 +-
 modules/azure/pom.xml                              |   2 +-
 modules/benchmarks/pom.xml                         |   2 +-
 .../stack/LockTrackerNoBarrier.java                |  13 +-
 .../benchmarks/jmh/tree/BPlusTreeBenchmark.java    |  13 +-
 modules/calcite/pom.xml                            |   2 +-
 modules/cassandra/pom.xml                          |   2 +-
 modules/cassandra/serializers/pom.xml              |   4 +-
 modules/cassandra/store/pom.xml                    |   4 +-
 modules/clients/pom.xml                            |   2 +-
 .../ComputeTaskRemoteSecurityContextTest.java      | 527 +++++++++++++
 .../ignite/common/NodeSslConnectionMetricTest.java |   8 +-
 .../internal/TaskEventSubjectIdSelfTest.java       | 422 -----------
 .../client/suite/IgniteClientTestSuite.java        |   6 +-
 modules/cloud/pom.xml                              |   2 +-
 modules/codegen/pom.xml                            |   2 +-
 modules/compatibility/pom.xml                      |   2 +-
 modules/compress/pom.xml                           |   2 +-
 modules/control-utility/pom.xml                    |   2 +-
 .../util/GridCommandHandlerPropertiesTest.java     |  47 ++
 .../apache/ignite/util/GridCommandHandlerTest.java |  25 +-
 .../apache/ignite/util/SystemViewCommandTest.java  |   4 +-
 modules/core/pom.xml                               |   4 +-
 .../main/java/org/apache/ignite/IgniteCache.java   |   6 +-
 .../org/apache/ignite/IgniteSystemProperties.java  |  13 +
 .../events/CacheConsistencyViolationEvent.java     |  52 +-
 .../java/org/apache/ignite/events/EventType.java   |  47 +-
 .../java/org/apache/ignite/events/TaskEvent.java   |  11 +-
 .../ignite/internal/GridEventConsumeHandler.java   |   2 +-
 .../apache/ignite/internal/GridJobContextImpl.java |   2 +-
 .../ignite/internal/GridJobExecuteRequest.java     |  53 +-
 .../apache/ignite/internal/GridJobSessionImpl.java |   5 -
 .../apache/ignite/internal/GridKernalContext.java  | 134 ----
 .../ignite/internal/GridKernalContextImpl.java     | 218 ------
 .../ignite/internal/GridTaskSessionImpl.java       |  11 -
 .../ignite/internal/GridTaskSessionInternal.java   |   6 -
 .../apache/ignite/internal/IgniteComputeImpl.java  |  24 +-
 .../org/apache/ignite/internal/IgniteKernal.java   | 141 ++--
 .../org/apache/ignite/internal/IgnitionEx.java     | 499 -------------
 .../internal/cache/query/index/IndexProcessor.java |  12 +-
 .../DurableBackgroundCleanupIndexTreeTask.java     |  66 +-
 .../DurableBackgroundCleanupIndexTreeTaskV2.java   | 497 +++++++++++++
 .../sorted/defragmentation/DefragIndexFactory.java |   3 +-
 .../index/sorted/inline/InlineIndexFactory.java    |   3 +-
 .../query/index/sorted/inline/InlineIndexImpl.java |  64 +-
 .../query/index/sorted/inline/InlineIndexTree.java |  53 +-
 .../internal/client/thin/TcpIgniteClient.java      |  38 +-
 .../internal/cluster/ClusterGroupAdapter.java      |  54 +-
 .../ignite/internal/cluster/ClusterGroupEx.java    |   9 -
 .../ignite/internal/cluster/IgniteClusterImpl.java |   4 +-
 .../managers/communication/GridIoManager.java      |  10 +-
 .../deployment/GridDeploymentClassLoader.java      | 208 +++---
 .../deployment/GridDeploymentCommunication.java    | 189 +++--
 .../managers/discovery/GridDiscoveryManager.java   |   2 +
 .../managers/encryption/GridEncryptionManager.java |   2 +-
 .../ignite/internal/pagemem/PageIdAllocator.java   |   2 +-
 .../pagemem/wal/IgniteWriteAheadLogManager.java    |   5 +
 .../cache/CacheAffinitySharedManager.java          |   6 +-
 .../processors/cache/CacheDiagnosticManager.java   |   2 +-
 .../processors/cache/GridCacheAdapter.java         |   2 +-
 .../processors/cache/GridCacheIoManager.java       |   2 +-
 .../cache/GridCachePartitionExchangeManager.java   | 209 ++----
 .../processors/cache/GridCachePreloader.java       |  26 +-
 .../cache/GridCachePreloaderAdapter.java           |  24 +-
 .../processors/cache/GridCacheProcessor.java       |   8 +-
 .../cache/IgniteCacheOffheapManager.java           |   6 +-
 .../cache/IgniteCacheOffheapManagerImpl.java       | 110 ++-
 .../distributed/dht/GridPartitionedGetFuture.java  |   5 +
 .../distributed/dht/atomic/GridDhtAtomicCache.java |   2 +-
 .../dht/preloader/GridDhtPartitionDemander.java    |  10 +-
 .../preloader/GridDhtPartitionsExchangeFuture.java |  26 +-
 .../preloader/GridDhtPartitionsFullMessage.java    |   4 +-
 .../dht/preloader/GridDhtPreloader.java            |  29 +-
 .../dht/topology/GridDhtLocalPartition.java        |  59 --
 .../dht/topology/PartitionsEvictManager.java       |   2 +-
 .../GridNearReadRepairAbstractFuture.java          | 137 +++-
 .../GridNearReadRepairCheckOnlyFuture.java         |  52 +-
 .../near/consistency/GridNearReadRepairFuture.java | 116 +--
 .../processors/cache/mvcc/MvccProcessorImpl.java   |   6 +-
 .../processors/cache/mvcc/txlog/TxLog.java         |  31 +-
 .../processors/cache/mvcc/txlog/TxLogTree.java     |  15 +-
 .../cache/persistence/DataStructure.java           |  70 +-
 .../GridCacheDatabaseSharedManager.java            |  70 +-
 .../cache/persistence/GridCacheOffheapManager.java |  86 ++-
 .../IgniteCacheDatabaseSharedManager.java          |  43 +-
 .../processors/cache/persistence/IndexStorage.java |  10 +-
 .../cache/persistence/IndexStorageImpl.java        | 153 ++--
 .../processors/cache/persistence/RootPage.java     |   4 +-
 .../CachePartitionDefragmentationManager.java      |  44 +-
 .../cache/persistence/defragmentation/LinkMap.java |  83 +--
 .../PageLockListenerIndexAdapter.java              |  70 --
 .../pagelocktracker/PageLockTracker.java           |   4 +-
 .../pagelocktracker/PageLockTrackerMXBeanImpl.java |   2 +-
 .../pagelocktracker/PageLockTrackerManager.java    |  78 +-
 .../pagelocktracker/SharedPageLockTracker.java     | 102 ++-
 .../pagelocktracker/SharedPageLockTrackerDump.java |   9 +-
 .../dumpprocessors/ToFileDumpProcessor.java        |  56 +-
 .../dumpprocessors/ToStringDumpHelper.java         |   9 +-
 .../dumpprocessors/ToStringDumpProcessor.java      |  21 +-
 .../persistence/freelist/AbstractFreeList.java     |  20 +-
 .../cache/persistence/freelist/CacheFreeList.java  |  16 +-
 .../cache/persistence/freelist/PagesList.java      |  47 +-
 .../cache/persistence/metastorage/MetaStorage.java |  27 +-
 .../persistence/metastorage/MetastorageTree.java   |   9 +-
 .../pendingtask/DurableBackgroundTask.java         |  14 +-
 .../pendingtask/DurableBackgroundTaskResult.java   |  52 +-
 .../UpgradePendingTreeToPerPartitionTask.java      |   2 +-
 .../partstorage/PartitionMetaStorageImpl.java      |  27 +-
 .../snapshot/IgniteSnapshotManager.java            | 112 ++-
 .../persistence/snapshot/SnapshotFutureTask.java   |   2 +-
 .../snapshot/SnapshotPartitionsVerifyTask.java     |  45 +-
 .../snapshot/SnapshotRestoreProcess.java           |  55 +-
 .../cache/persistence/tree/BPlusTree.java          |  43 +-
 .../persistence/tree/reuse/ReuseListImpl.java      |  14 +-
 .../persistence/tree/util/PageLockListener.java    |   5 +-
 .../persistence/wal/FileWriteAheadLogManager.java  |  16 +-
 .../wal/aware/SegmentArchiveSizeStorage.java       |  90 ++-
 .../cache/persistence/wal/aware/SegmentAware.java  |   7 +
 .../wal/reader/IgniteWalIteratorFactory.java       |  52 +-
 .../wal/reader/StandaloneGridKernalContext.java    | 114 +--
 .../wal/reader/StandaloneWalRecordsIterator.java   |   2 -
 .../continuous/CacheContinuousQueryHandler.java    |   8 +-
 .../query/continuous/SecurityAwareFilter.java      |   5 +
 .../processors/cache/tree/CacheDataTree.java       |   7 +-
 .../processors/cache/tree/PendingEntriesTree.java  |   7 +-
 .../processors/closure/GridClosureProcessor.java   |   8 +-
 .../processors/cluster/ClusterProcessor.java       |   2 +-
 .../cluster/GridClusterStateProcessor.java         |   6 +-
 .../autoadjust/BaselineTopologyUpdater.java        |   2 +-
 .../continuous/GridContinuousProcessor.java        |   2 +-
 .../datastructures/GridCacheSemaphoreImpl.java     |   2 +-
 .../internal/processors/job/GridJobProcessor.java  |  10 +-
 .../internal/processors/job/GridJobWorker.java     |   4 +-
 .../localtask/DurableBackgroundTaskState.java      |  31 +-
 .../localtask/DurableBackgroundTasksProcessor.java | 191 +++--
 .../processors/metric/GridMetricManager.java       |   3 +
 .../odbc/ClientListenerConnectionContext.java      |   5 +
 .../processors/odbc/ClientListenerMetrics.java     | 155 ++++
 .../processors/odbc/ClientListenerNioListener.java |  20 +-
 .../processors/odbc/ClientListenerProcessor.java   |  11 +-
 .../odbc/jdbc/JdbcConnectionContext.java           |  10 +-
 .../odbc/odbc/OdbcConnectionContext.java           |  11 +-
 .../platform/client/ClientConnectionContext.java   |   6 +
 .../platform/client/compute/ClientComputeTask.java |   4 -
 .../client/service/ClientServiceInvokeRequest.java |   3 -
 .../internal/processors/pool/PoolProcessor.java    | 811 ++++++++++++++++++++-
 .../query/schema/SchemaIndexCacheVisitorImpl.java  |   2 +-
 .../processors/rest/GridRestProcessor.java         |  27 +-
 .../redis/GridRedisRestCommandHandler.java         |   2 +-
 .../rest/handlers/task/GridTaskCommandHandler.java |  18 +-
 .../handlers/user/UserActionCommandHandler.java    |   2 -
 .../rest/protocols/tcp/GridTcpRestProtocol.java    |   2 +-
 .../processors/rest/request/GridRestRequest.java   |  19 -
 .../processors/security/IgniteSecurity.java        |   7 +
 .../security/IgniteSecurityProcessor.java          |  89 ++-
 .../security/NoOpIgniteSecurityProcessor.java      |   5 +
 .../processors/security/SecurityUtils.java         |   8 +
 .../security/thread/SecurityAwareCallable.java     |  65 ++
 .../security/thread/SecurityAwareIoPool.java       |  62 ++
 .../security/thread/SecurityAwareRunnable.java     |  54 ++
 .../thread/SecurityAwareStripedExecutor.java       |  77 ++
 .../SecurityAwareStripedThreadPoolExecutor.java    |  49 ++
 .../thread/SecurityAwareThreadPoolExecutor.java    | 103 +++
 .../session/GridTaskSessionProcessor.java          |   4 -
 .../processors/task/GridTaskProcessor.java         |  19 +-
 .../processors/task/GridTaskThreadContextKey.java  |   3 -
 .../internal/processors/task/GridTaskWorker.java   |   3 +-
 .../ignite/internal/util/GridLogThrottle.java      |  13 +
 .../internal/util/collection/IntHashMap.java       |   9 +
 .../ignite/internal/util/collection/IntMap.java    |   5 +
 .../internal/util/collection/IntRWHashMap.java     |  11 +
 .../ignite/internal/util/worker/GridWorker.java    |  18 +-
 .../visor/diagnostic/VisorPageLocksTask.java       |   4 +-
 .../spi/metric/jmx/JmxMetricExporterSpi.java       |   3 +
 modules/core/src/main/resources/ignite.properties  |   2 +-
 .../ignite/cache/AbstractReleaseSegmentTest.java   | 107 +++
 .../ignite/cache/AutoReleaseSegmentSelfTest.java   |  68 ++
 .../ReleaseSegmentOnHistoricalRebalanceTest.java   |  79 +-
 .../org/apache/ignite/client/IgniteBinaryTest.java |  78 ++
 .../test/java/org/apache/ignite/client/Person.java |  14 +-
 .../ignite/failure/SystemWorkersBlockingTest.java  |  52 ++
 .../ignite/internal/GridJobSubjectIdSelfTest.java  | 210 ------
 .../internal/MarshallerContextLockingSelfTest.java |  10 +-
 .../internal/TestRecordingCommunicationSpi.java    |   2 +-
 .../internal/managers/GridManagerStopSelfTest.java |   2 +
 ...loymentRequestOfUnknownClassProcessingTest.java |   4 +-
 .../ignite/internal/metric/JmxExporterSpiTest.java |  27 +-
 .../ignite/internal/metric/SystemViewSelfTest.java |   4 +-
 .../cache/CacheGroupsMetricsRebalanceTest.java     |  36 +-
 .../consistency/AbstractFullSetReadRepairTest.java |  44 +-
 .../cache/consistency/AbstractReadRepairTest.java  |  56 +-
 .../cache/consistency/AtomicReadRepairTest.java    |   4 +
 .../ExplicitTransactionalReadRepairTest.java       |  18 +-
 .../ImplicitTransactionalReadRepairTest.java       |   9 +-
 .../IgniteCacheDatabaseSharedManagerSelfTest.java  |  58 +-
 .../db/wal/WalArchiveSizeConfigurationTest.java    |  21 +
 .../persistence/defragmentation/LinkMapTest.java   |  43 +-
 .../PageLockTrackerManagerTest.java                |   5 +-
 .../PageLockTrackerResourcesTest.java              |  85 +++
 .../pagelocktracker/SharedPageLockTrackerTest.java |  61 +-
 .../dumpprocessors/ToFileDumpProcessorTest.java    |  86 +--
 .../dumpprocessors/ToStringDumpHelperTest.java     |  18 +-
 .../cache/persistence/pagemem/NoOpWALManager.java  |   5 +
 .../snapshot/AbstractSnapshotSelfTest.java         |  12 +-
 .../snapshot/IgniteClusterSnapshotCheckTest.java   |  25 +
 .../IgniteClusterSnapshotRestoreSelfTest.java      |  64 +-
 .../snapshot/IgniteClusterSnapshotSelfTest.java    |  18 +-
 .../snapshot/IgniteSnapshotManagerSelfTest.java    |   9 +-
 .../wal/FileWriteAheadLogManagerSelfTest.java      |  34 +-
 .../persistence/wal/aware/SegmentAwareTest.java    |  48 ++
 .../TxPartitionCounterStateConsistencyTest.java    |   2 -
 .../TxRecoveryWithConcurrentRollbackTest.java      |   8 +-
 .../database/BPlusTreeReuseSelfTest.java           |  42 +-
 .../processors/database/BPlusTreeSelfTest.java     |  17 +-
 .../processors/database/CacheFreeListSelfTest.java |  13 +-
 .../processors/database/IndexStorageSelfTest.java  |  13 +-
 .../processors/localtask/ConvertibleTask.java}     |  36 +-
 .../DurableBackgroundTasksProcessorSelfTest.java   | 127 +++-
 .../internal/processors/localtask/SimpleTask.java  |   6 +-
 .../processors/odbc/ClientListenerMetricsTest.java | 221 ++++++
 .../impl/TestCertificateSecurityProcessor.java     |  14 +-
 .../security/impl/TestSecurityProcessor.java       |  15 +-
 .../internal/util/collection/IntHashMapTest.java   |  23 +
 .../util/future/GridFutureAdapterSelfTest.java     |  19 +-
 .../marshaller/MarshallerContextSelfTest.java      |   8 +-
 .../ClassLoadingProblemExtendedLoggingTest.java    | 178 +++++
 .../IgniteClientReconnectMassiveShutdownTest.java  |   8 +-
 .../spi/discovery/tcp/TestReconnectProcessor.java  |   5 +
 .../junits/GridTestKernalContext.java              |  37 -
 .../junits/multijvm/IgniteClusterProcessProxy.java |   6 -
 .../ignite/testsuites/IgniteBasicTestSuite.java    |   3 +
 .../testsuites/IgniteComputeGridTestSuite.java     |   2 -
 .../ignite/testsuites/IgnitePdsTestSuite4.java     |   4 +
 .../ignite/thread/IgniteThreadPoolSizeTest.java    |  14 +-
 modules/dev-utils/ignite-modules-test/build.gradle |   2 +-
 modules/dev-utils/pom.xml                          |   2 +-
 modules/direct-io/pom.xml                          |   2 +-
 modules/ducktests/pom.xml                          |   2 +-
 modules/ducktests/tests/ignitetest/__init__.py     |   2 +-
 .../ignitetest/tests/rebalance/persistent_test.py  |  16 +-
 modules/extdata/p2p/pom.xml                        |   2 +-
 .../apache/ignite/tests/p2p/P2PTestPredicate.java  |   1 -
 modules/extdata/platform/pom.xml                   |   2 +-
 modules/extdata/uri/modules/uri-dependency/pom.xml |   2 +-
 modules/extdata/uri/pom.xml                        |   2 +-
 modules/gce/pom.xml                                |   2 +-
 modules/geospatial/pom.xml                         |   2 +-
 modules/hibernate-4.2/pom.xml                      |   2 +-
 modules/hibernate-5.1/pom.xml                      |   2 +-
 modules/hibernate-5.3/pom.xml                      |   2 +-
 modules/hibernate-core/pom.xml                     |   2 +-
 modules/ignored-tests/pom.xml                      |   2 +-
 modules/indexing/pom.xml                           |   2 +-
 ...ervationsOnDoneAfterTopologyUnlockFailTest.java |   4 +-
 .../cache/index/AbstractRebuildIndexTest.java      |  28 +
 .../processors/cache/index/DropIndexTest.java      | 547 ++++++++++++++
 .../index/H2TreeCorruptedTreeExceptionTest.java    |   2 +-
 .../cache/index/RenameIndexTreeTest.java           | 131 +++-
 .../index/StopNodeOnRebuildIndexFailureTest.java   |   2 +-
 .../cache/metric/SqlViewExporterSpiTest.java       |   4 +-
 .../db/LongDestroyDurableBackgroundTaskTest.java   | 180 +++--
 .../MultipleParallelCacheDeleteDeadlockTest.java   |  94 +--
 ...niteClusterSnapshotRestoreWithIndexingTest.java |  24 +
 .../query/KillQueryErrorOnCancelTest.java          |   2 +-
 .../internal/processors/query/KillQueryTest.java   |   2 +-
 .../testsuites/IgnitePdsWithIndexingTestSuite.java |   4 +-
 modules/jcl/pom.xml                                |   2 +-
 modules/jta/pom.xml                                |   2 +-
 modules/kubernetes/pom.xml                         |   2 +-
 modules/log4j/pom.xml                              |   2 +-
 modules/log4j2/pom.xml                             |   2 +-
 modules/mesos/pom.xml                              |   2 +-
 modules/ml/catboost-model-parser/pom.xml           |   2 +-
 modules/ml/h2o-model-parser/pom.xml                |   2 +-
 modules/ml/pom.xml                                 |   2 +-
 modules/ml/spark-model-parser/pom.xml              |   2 +-
 modules/ml/xgboost-model-parser/pom.xml            |   2 +-
 modules/opencensus/pom.xml                         |   2 +-
 modules/osgi-karaf/pom.xml                         |   2 +-
 modules/osgi-paxlogging/pom.xml                    |   2 +-
 modules/osgi/pom.xml                               |   2 +-
 modules/platforms/cpp/CMakeLists.txt               |   2 +-
 .../cpp/odbc/install/ignite-odbc-amd64.wxs         |   2 +-
 .../platforms/cpp/odbc/install/ignite-odbc-x86.wxs |   2 +-
 .../cpp/thin-client-test/include/test_utils.h      |  30 +
 .../thin-client-test/src/ignite_client_test.cpp    |  24 +
 .../Properties/AssemblyInfo.cs                     |   6 +-
 .../Properties/AssemblyInfo.cs                     |   6 +-
 .../Properties/AssemblyInfo.cs                     |   6 +-
 .../Properties/AssemblyInfo.cs                     |   6 +-
 .../Properties/AssemblyInfo.cs                     |   6 +-
 .../Properties/AssemblyInfo.cs                     |   6 +-
 .../Cache/Query/Continuous/ContinuousQueryTest.cs  |  63 +-
 .../Properties/AssemblyInfo.cs                     |   6 +-
 .../Apache.Ignite.Core/Properties/AssemblyInfo.cs  |   6 +-
 .../Properties/AssemblyInfo.cs                     |   6 +-
 .../Properties/AssemblyInfo.cs                     |   6 +-
 .../Apache.Ignite.Linq/Properties/AssemblyInfo.cs  |   6 +-
 .../Properties/AssemblyInfo.cs                     |   6 +-
 .../Apache.Ignite.NLog/Properties/AssemblyInfo.cs  |   6 +-
 .../Apache.Ignite/Properties/AssemblyInfo.cs       |   6 +-
 modules/rest-http/pom.xml                          |   2 +-
 modules/scalar-2.10/pom.xml                        |   2 +-
 modules/scalar/pom.xml                             |   2 +-
 modules/schedule/pom.xml                           |   2 +-
 modules/slf4j/pom.xml                              |   2 +-
 modules/spark-2.4/pom.xml                          |   2 +-
 modules/spark/pom.xml                              |   2 +-
 modules/spring/pom.xml                             |   2 +-
 modules/sqlline/pom.xml                            |   2 +-
 modules/ssh/pom.xml                                |   2 +-
 modules/tools/pom.xml                              |   2 +-
 modules/urideploy/pom.xml                          |   2 +-
 .../testsuites/IgniteUriDeploymentTestSuite.java   |   2 +
 modules/visor-console-2.10/pom.xml                 |   2 +-
 modules/visor-console/pom.xml                      |   2 +-
 modules/visor-plugins/pom.xml                      |   2 +-
 modules/web/ignite-appserver-test/pom.xml          |   2 +-
 modules/web/ignite-websphere-test/pom.xml          |   2 +-
 modules/web/pom.xml                                |   2 +-
 modules/yardstick/pom.xml                          |   2 +-
 modules/yarn/pom.xml                               |   2 +-
 modules/yarn/src/main/resources/ignite.properties  |   2 +-
 modules/zookeeper/pom.xml                          |   2 +-
 parent/pom.xml                                     |   5 +-
 pom.xml                                            |   2 +-
 343 files changed, 7597 insertions(+), 4229 deletions(-)

diff --cc modules/calcite/pom.xml
index 5fdeffc,0000000..1f15b34
mode 100644,000000..100644
--- a/modules/calcite/pom.xml
+++ b/modules/calcite/pom.xml
@@@ -1,295 -1,0 +1,295 @@@
 +<?xml version="1.0" encoding="UTF-8"?>
 +
 +<!--
 +  Licensed to the Apache Software Foundation (ASF) under one or more
 +  contributor license agreements.  See the NOTICE file distributed with
 +  this work for additional information regarding copyright ownership.
 +  The ASF licenses this file to You under the Apache License, Version 2.0
 +  (the "License"); you may not use this file except in compliance with
 +  the License.  You may obtain a copy of the License at
 +
 +       http://www.apache.org/licenses/LICENSE-2.0
 +
 +  Unless required by applicable law or agreed to in writing, software
 +  distributed under the License is distributed on an "AS IS" BASIS,
 +  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
 +  See the License for the specific language governing permissions and
 +  limitations under the License.
 +-->
 +
 +<!--
 +    POM file.
 +-->
 +<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
 +         xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
 +    <modelVersion>4.0.0</modelVersion>
 +
 +    <!-- Module specific package versions -->
 +    <properties>
 +        <calcite.version>1.27.0</calcite.version>
 +        <janino.version>3.1.4</janino.version>
 +        <avatica.version>1.18.0</avatica.version>
 +        <jsonpath.version>2.4.0</jsonpath.version>
 +        <reflections.version>0.9.10</reflections.version>
 +        <javassist.version>3.28.0-GA</javassist.version>
 +        <esri.geometry.version>2.2.0</esri.geometry.version>
 +        <checker.version>3.10.0</checker.version>
 +    </properties>
 +
 +    <parent>
 +        <groupId>org.apache.ignite</groupId>
 +        <artifactId>ignite-parent</artifactId>
 +        <version>1</version>
 +        <relativePath>../../parent</relativePath>
 +    </parent>
 +
 +    <artifactId>ignite-calcite</artifactId>
-     <version>2.11.0-SNAPSHOT</version>
++    <version>2.12.0-SNAPSHOT</version>
 +    <url>http://ignite.apache.org</url>
 +
 +    <dependencies>
 +        <dependency>
 +            <groupId>org.apache.ignite</groupId>
 +            <artifactId>ignite-core</artifactId>
 +            <version>${project.version}</version>
 +        </dependency>
 +
 +        <!--
 +            At now the new calcite engine reuses some logic
 +            and doesn't work without "old" indexing module.
 +        -->
 +        <dependency>
 +            <groupId>org.apache.ignite</groupId>
 +            <artifactId>ignite-indexing</artifactId>
 +            <version>${project.version}</version>
 +        </dependency>
 +
 +        <dependency>
 +            <groupId>org.apache.calcite</groupId>
 +            <artifactId>calcite-core</artifactId>
 +            <version>${calcite.version}</version>
 +        </dependency>
 +
 +        <dependency>
 +            <groupId>org.apache.calcite</groupId>
 +            <artifactId>calcite-linq4j</artifactId>
 +            <version>${calcite.version}</version>
 +        </dependency>
 +
 +        <dependency>
 +            <groupId>com.google.guava</groupId>
 +            <artifactId>guava</artifactId>
 +            <version>${guava.version}</version>
 +        </dependency>
 +
 +        <dependency>
 +            <groupId>org.checkerframework</groupId>
 +            <artifactId>checker-qual</artifactId>
 +            <version>${checker.version}</version>
 +        </dependency>
 +
 +        <dependency>
 +            <groupId>org.codehaus.janino</groupId>
 +            <artifactId>commons-compiler</artifactId>
 +            <version>${janino.version}</version>
 +        </dependency>
 +
 +        <dependency>
 +            <groupId>org.codehaus.janino</groupId>
 +            <artifactId>janino</artifactId>
 +            <version>${janino.version}</version>
 +        </dependency>
 +
 +        <dependency>
 +            <groupId>org.apache.calcite.avatica</groupId>
 +            <artifactId>avatica-core</artifactId>
 +            <version>${avatica.version}</version>
 +        </dependency>
 +
 +        <dependency>
 +            <groupId>com.fasterxml.jackson.core</groupId>
 +            <artifactId>jackson-core</artifactId>
 +            <version>${jackson.version}</version>
 +        </dependency>
 +
 +        <dependency>
 +            <groupId>com.fasterxml.jackson.core</groupId>
 +            <artifactId>jackson-databind</artifactId>
 +            <version>${jackson.version}</version>
 +        </dependency>
 +
 +        <dependency>
 +            <groupId>com.fasterxml.jackson.core</groupId>
 +            <artifactId>jackson-annotations</artifactId>
 +            <version>${jackson.version}</version>
 +        </dependency>
 +
 +        <dependency>
 +            <groupId>com.jayway.jsonpath</groupId>
 +            <artifactId>json-path</artifactId>
 +            <version>${jsonpath.version}</version>
 +        </dependency>
 +
 +        <dependency>
 +            <groupId>org.reflections</groupId>
 +            <artifactId>reflections</artifactId>
 +            <version>${reflections.version}</version>
 +        </dependency>
 +
 +        <dependency>
 +            <groupId>org.javassist</groupId>
 +            <artifactId>javassist</artifactId>
 +            <version>${javassist.version}</version>
 +        </dependency>
 +
 +        <dependency>
 +            <groupId>com.esri.geometry</groupId>
 +            <artifactId>esri-geometry-api</artifactId>
 +            <version>${esri.geometry.version}</version>
 +        </dependency>
 +
 +        <dependency>
 +            <groupId>org.apache.ignite</groupId>
 +            <artifactId>ignite-core</artifactId>
 +            <version>${project.version}</version>
 +            <type>test-jar</type>
 +            <scope>test</scope>
 +        </dependency>
 +
 +        <dependency>
 +            <groupId>org.springframework</groupId>
 +            <artifactId>spring-core</artifactId>
 +            <version>${spring.version}</version>
 +            <scope>test</scope>
 +        </dependency>
 +
 +        <dependency>
 +            <groupId>log4j</groupId>
 +            <artifactId>log4j</artifactId>
 +            <scope>test</scope>
 +        </dependency>
 +
 +        <dependency>
 +            <groupId>org.slf4j</groupId>
 +            <artifactId>slf4j-log4j12</artifactId>
 +            <version>${slf4j.version}</version>
 +            <scope>test</scope>
 +        </dependency>
 +
 +        <dependency>
 +            <groupId>org.springframework</groupId>
 +            <artifactId>spring-beans</artifactId>
 +            <version>${spring.version}</version>
 +            <scope>test</scope>
 +        </dependency>
 +
 +        <dependency>
 +            <groupId>org.springframework</groupId>
 +            <artifactId>spring-context</artifactId>
 +            <version>${spring.version}</version>
 +            <scope>test</scope>
 +        </dependency>
 +
 +        <dependency>
 +            <groupId>org.apache.ignite</groupId>
 +            <artifactId>ignite-clients</artifactId>
 +            <version>${project.version}</version>
 +            <scope>test</scope>
 +        </dependency>
 +    </dependencies>
 +
 +    <build>
 +        <plugins>
 +            <!-- Generate the OSGi MANIFEST.MF for this bundle. -->
 +            <plugin>
 +                <groupId>org.apache.felix</groupId>
 +                <artifactId>maven-bundle-plugin</artifactId>
 +            </plugin>
 +            <plugin>
 +                <artifactId>maven-resources-plugin</artifactId>
 +                <executions>
 +                    <execution>
 +                        <id>copy-fmpp-resources</id>
 +                        <phase>validate</phase>
 +                        <goals>
 +                            <goal>copy-resources</goal>
 +                        </goals>
 +                        <configuration>
 +                            <outputDirectory>${project.build.directory}/codegen</outputDirectory>
 +                            <resources>
 +                                <resource>
 +                                    <directory>src/main/codegen</directory>
 +                                    <filtering>false</filtering>
 +                                </resource>
 +                            </resources>
 +                        </configuration>
 +                    </execution>
 +                </executions>
 +            </plugin>
 +            <plugin>
 +                <groupId>org.apache.maven.plugins</groupId>
 +                <artifactId>maven-dependency-plugin</artifactId>
 +                <executions>
 +                    <execution>
 +                        <id>unpack-parser-template</id>
 +                        <phase>validate</phase>
 +                        <goals>
 +                            <goal>unpack</goal>
 +                        </goals>
 +                        <configuration>
 +                            <artifactItems>
 +                                <artifactItem>
 +                                    <groupId>org.apache.calcite</groupId>
 +                                    <artifactId>calcite-core</artifactId>
 +                                    <type>jar</type>
 +                                    <overWrite>true</overWrite>
 +                                    <outputDirectory>${project.build.directory}/</outputDirectory>
 +                                    <includes>codegen/templates/Parser.jj</includes>
 +                                </artifactItem>
 +                            </artifactItems>
 +                        </configuration>
 +                    </execution>
 +                </executions>
 +            </plugin>
 +            <plugin>
 +                <groupId>com.googlecode.fmpp-maven-plugin</groupId>
 +                <artifactId>fmpp-maven-plugin</artifactId>
 +                <version>1.0</version>
 +                <configuration>
 +                    <cfgFile>${project.build.directory}/codegen/config.fmpp</cfgFile>
 +                    <templateDirectory>${project.build.directory}/codegen/templates</templateDirectory>
 +                </configuration>
 +                <executions>
 +                    <execution>
 +                        <id>generate-fmpp-sources</id>
 +                        <phase>validate</phase>
 +                        <goals>
 +                            <goal>generate</goal>
 +                        </goals>
 +                    </execution>
 +                </executions>
 +            </plugin>
 +            <plugin>
 +                <groupId>org.codehaus.mojo</groupId>
 +                <artifactId>javacc-maven-plugin</artifactId>
 +                <executions>
 +                    <execution>
 +                        <id>javacc</id>
 +                        <goals>
 +                            <goal>javacc</goal>
 +                        </goals>
 +                        <configuration>
 +                            <sourceDirectory>${project.build.directory}/generated-sources/fmpp</sourceDirectory>
 +                            <outputDirectory>${project.build.directory}/generated-sources/javacc</outputDirectory>
 +                            <includes>
 +                                <include>**/Parser.jj</include>
 +                            </includes>
 +                            <lookAhead>2</lookAhead>
 +                            <isStatic>false</isStatic>
 +                        </configuration>
 +                    </execution>
 +                </executions>
 +            </plugin>
 +        </plugins>
 +    </build>
 +</project>
diff --cc modules/core/src/main/java/org/apache/ignite/internal/processors/pool/PoolProcessor.java
index 9ec75e1,3a6e8b0..534a50d
--- a/modules/core/src/main/java/org/apache/ignite/internal/processors/pool/PoolProcessor.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/processors/pool/PoolProcessor.java
@@@ -27,10 -41,26 +41,27 @@@ import org.apache.ignite.internal.Ignit
  import org.apache.ignite.internal.managers.communication.GridIoPolicy;
  import org.apache.ignite.internal.processors.GridProcessorAdapter;
  import org.apache.ignite.internal.processors.plugin.IgnitePluginProcessor;
+ import org.apache.ignite.internal.processors.security.IgniteSecurity;
+ import org.apache.ignite.internal.processors.security.thread.SecurityAwareIoPool;
+ import org.apache.ignite.internal.processors.security.thread.SecurityAwareStripedExecutor;
+ import org.apache.ignite.internal.processors.security.thread.SecurityAwareStripedThreadPoolExecutor;
+ import org.apache.ignite.internal.processors.security.thread.SecurityAwareThreadPoolExecutor;
+ import org.apache.ignite.internal.util.StripedExecutor;
+ import org.apache.ignite.internal.util.tostring.GridToStringExclude;
+ import org.apache.ignite.internal.util.typedef.F;
+ import org.apache.ignite.internal.util.typedef.internal.U;
+ import org.apache.ignite.internal.util.worker.GridWorkerListener;
+ import org.apache.ignite.internal.worker.WorkersRegistry;
+ import org.apache.ignite.lang.IgniteInClosure;
  import org.apache.ignite.plugin.extensions.communication.IoPool;
+ import org.apache.ignite.thread.IgniteStripedThreadPoolExecutor;
+ import org.apache.ignite.thread.IgniteThreadPoolExecutor;
 +import org.apache.ignite.thread.SameThreadExecutor;
  import org.jetbrains.annotations.Nullable;
  
+ import static org.apache.ignite.configuration.IgniteConfiguration.DFLT_THREAD_KEEP_ALIVE_TIME;
+ import static org.apache.ignite.failure.FailureType.SYSTEM_WORKER_TERMINATION;
+ 
  /**
   * Processor which abstracts out thread pool management.
   */
@@@ -106,49 -475,46 +476,49 @@@ public class PoolProcessor extends Grid
      public Executor poolForPolicy(byte plc) throws IgniteCheckedException {
          switch (plc) {
              case GridIoPolicy.P2P_POOL:
-                 return ctx.getPeerClassLoadingExecutorService();
+                 return getPeerClassLoadingExecutorService();
              case GridIoPolicy.SYSTEM_POOL:
-                 return ctx.getSystemExecutorService();
+                 return getSystemExecutorService();
              case GridIoPolicy.PUBLIC_POOL:
-                 return ctx.getExecutorService();
+                 return getExecutorService();
              case GridIoPolicy.MANAGEMENT_POOL:
-                 return ctx.getManagementExecutorService();
+                 return getManagementExecutorService();
              case GridIoPolicy.AFFINITY_POOL:
-                 return ctx.getAffinityExecutorService();
+                 return getAffinityExecutorService();
  
              case GridIoPolicy.IDX_POOL:
-                 assert ctx.getIndexingExecutorService() != null : "Indexing pool is not configured.";
+                 assert getIndexingExecutorService() != null : "Indexing pool is not configured.";
  
-                 return ctx.getIndexingExecutorService();
+                 return getIndexingExecutorService();
  
              case GridIoPolicy.UTILITY_CACHE_POOL:
-                 assert ctx.utilityCachePool() != null : "Utility cache pool is not configured.";
+                 assert utilityCachePool() != null : "Utility cache pool is not configured.";
  
-                 return ctx.utilityCachePool();
+                 return utilityCachePool();
  
              case GridIoPolicy.SERVICE_POOL:
-                 assert ctx.getServiceExecutorService() != null : "Service pool is not configured.";
+                 assert getServiceExecutorService() != null : "Service pool is not configured.";
  
-                 return ctx.getServiceExecutorService();
+                 return getServiceExecutorService();
  
              case GridIoPolicy.DATA_STREAMER_POOL:
-                 assert ctx.getDataStreamerExecutorService() != null : "Data streamer pool is not configured.";
+                 assert getDataStreamerExecutorService() != null : "Data streamer pool is not configured.";
  
-                 return ctx.getDataStreamerExecutorService();
+                 return getDataStreamerExecutorService();
  
              case GridIoPolicy.QUERY_POOL:
-                 assert ctx.getQueryExecutorService() != null : "Query pool is not configured.";
+                 assert getQueryExecutorService() != null : "Query pool is not configured.";
  
-                 return ctx.getQueryExecutorService();
+                 return getQueryExecutorService();
  
              case GridIoPolicy.SCHEMA_POOL:
-                 assert ctx.getSchemaExecutorService() != null : "Query pool is not configured.";
+                 assert getSchemaExecutorService() != null : "Query pool is not configured.";
  
-                 return ctx.getSchemaExecutorService();
+                 return getSchemaExecutorService();
  
 +            case GridIoPolicy.CALLER_THREAD:
 +                return SameThreadExecutor.INSTANCE;
 +
              default: {
                  if (plc < 0)
                      throw new IgniteCheckedException("Policy cannot be negative: " + plc);