Commit Graph

2888 Commits

Author SHA1 Message Date
tavplubix
b8685322b7
Merge pull request #11767 from amosbird/fs1
add scalars in time
2020-06-20 01:01:20 +03:00
Anton Popov
7a76abeb2a distinct combinator for function of multiuple arguments 2020-06-19 23:13:23 +03:00
Alexander Kuzmenkov
288f217df3 Merge remote-tracking branch 'origin/master' into HEAD 2020-06-19 23:07:53 +03:00
Azat Khuzhin
5f14622bfd Preserve column alias with optimize_aggregators_of_group_by_keys
optimize_aggregators_of_group_by_keys has been introduced in #11667
2020-06-19 23:04:19 +03:00
alexey-milovidov
8a33cd7483
Merge pull request #11785 from abyss7/h3-arcadia
Support H3 in Arcadia
2020-06-19 22:52:07 +03:00
alesapin
85070ea2fd Remove unused variable 2020-06-19 22:41:24 +03:00
alexey-milovidov
08b53c1ab5
Update gtest_pod_array.cpp 2020-06-19 22:10:04 +03:00
Nikolai Kochetov
8a048340b0 Fix tests. 2020-06-19 21:23:44 +03:00
alesapin
4c0879ae30 Better logging in storages 2020-06-19 20:17:13 +03:00
Nikolai Kochetov
9ca456f255 Try fix totals. 2020-06-19 19:58:27 +03:00
Nikolai Kochetov
4cafa3d703 Try fix totals. 2020-06-19 19:51:44 +03:00
alesapin
a462462610 Merge branch 'master' into atomic_metadata5 2020-06-19 18:58:42 +03:00
alesapin
c9fa5d2ec3 Better naming 2020-06-19 18:39:41 +03:00
alesapin
a2e7e9f232 Remove unused constructor and rename method 2020-06-19 18:21:48 +03:00
alesapin
3c47faa9da Move partition key initialization into registerMergeTree 2020-06-19 18:14:08 +03:00
Nikolai Kochetov
f6cd3f43bb Fix Context leak in InterpreterSelectQuery 2020-06-19 17:42:01 +03:00
Alexey Milovidov
468eaa8d93 Remove unused method 2020-06-19 17:21:26 +03:00
Alexey Milovidov
5211a42c04 Remove leader election, step 3 2020-06-19 17:18:58 +03:00
Nikolai Kochetov
6c9c33f870 Fix Context leak in InterpreterSelectQuery 2020-06-19 17:00:11 +03:00
Nikolai Kochetov
ec892775a5 Fix Context leak in InterpreterSelectQuery 2020-06-19 16:34:40 +03:00
Maxim Babenko
5895f25166 Styling 2020-06-19 16:30:00 +03:00
Maxim Babenko
8436688437 Add unittests for push_back_raw_many 2020-06-19 16:21:54 +03:00
alesapin
016ee6316f Add missed check 2020-06-19 15:05:29 +03:00
alexey-milovidov
3e06182079
Update InterpreterSelectQuery.cpp 2020-06-19 14:28:48 +03:00
Nikolai Kochetov
b85b6a6cc2 Fix MergingAggregatedStep 2020-06-19 14:27:07 +03:00
alexey-milovidov
397f0aa721
Merge pull request #11746 from azat/build-fix
Fix usage/linking of static dbms library (add clickhouse_aggregate_functions)
2020-06-19 14:26:52 +03:00
alesapin
ce0c5faf9e Merge branch 'fix_alter_with_materialized' into atomic_metadata5 2020-06-19 14:00:32 +03:00
Nikolai Kochetov
0335c698e0 Limit the number of threads. 2020-06-19 13:57:44 +03:00
alesapin
4b6db63fff Fix alter key when materialized column passed 2020-06-19 13:53:20 +03:00
Nikolai Kochetov
cac365689f Fix mx_threads in query_plan. 2020-06-19 13:45:48 +03:00
Ivan Lezhankin
747a3bb0e8 Support H3 in Arcadia 2020-06-19 13:06:42 +03:00
Nikolai Kochetov
690b88d331
Merge pull request #11291 from Provet/master
Partial sorting optimization fix
2020-06-19 12:58:44 +03:00
Nikolai Kochetov
9ddd7b98cc Fix tests. 2020-06-19 12:47:15 +03:00
Mikhail Filimonov
9609bd9dee Kafka better states, formats based on PeekableReadBuffer, and other minor fixes.
Add formats tests, fixes for JSONCompactEachRowWithNamesAndTypes, TSVWithNamesAndTypes. Some CR fixes
Add sanitizing for kafka_max_block_size and kafka_poll_max_batch_size
2020-06-19 10:49:05 +02:00
Nikolai Kochetov
6708ae75f3 Fix build. 2020-06-19 11:30:21 +03:00
Nikolai Kochetov
cda4de40d7 Merge branch 'master' into query-plan 2020-06-19 11:29:15 +03:00
alesapin
67062f45be Merge branch 'master' into atomic_metadata5 2020-06-19 11:09:03 +03:00
Anton Popov
36b9847d9a
Merge pull request #11768 from CurtizJ/any-input-optimize
Sligtly better code after #11529.
2020-06-19 03:36:49 +03:00
tavplubix
bed1f37790
Merge pull request #11214 from Potya/multiword_data_type
Add some multiword data types
2020-06-18 23:47:37 +03:00
Nikolai Kochetov
1f013208db Fix style. 2020-06-18 23:11:42 +03:00
alesapin
009977c20c Fix locks 2020-06-18 22:45:37 +03:00
Nikolai Kochetov
de6ef17d27 Fix QueryPipeline::unitePipelines 2020-06-18 22:42:28 +03:00
Ruslan
f44dbcd2ab
Fix crash in min(multiply(1)) with optimize_arithmetic_operations_in_aggregate_functions (#11756) 2020-06-18 22:25:28 +03:00
Nikolai Kochetov
26161aac8a Fix ReadFromStorageStep 2020-06-18 22:17:21 +03:00
Nikolai Kochetov
6cbdb6da00 Fix build. 2020-06-18 22:03:21 +03:00
Azat Khuzhin
d34e6217bc Add logging of adjusting conditional settings for distributed queries 2020-06-18 21:49:29 +03:00
Azat Khuzhin
6507247328 optimize_skip_unused_shards=2 will disable it for nested distributed queries
P.S. Looks like settings can be converted between SettingUInt64 and
SettingBool without breaking binary protocol.

FWIW maybe it is a good idea to change the semantics of the settings as
follow (but I guess that changing semantic is not a good idea, better to
add new settings and deprecate old ones):
- optimize_skip_unused_shards -- accept nesting level on which the
  optimization will work
- force_skip_optimize_shards_nesting -- accept nesting level on which
  the optimization will work
2020-06-18 21:49:29 +03:00
Azat Khuzhin
041533eae2 Disable optimize_skip_unused_shards if sharding_key has non-deterministic func
Example of such functions is rand()

And this patch disables only optimize_skip_unused_shards, i.e. INSERT
code path does not changed, so it will work as before.
2020-06-18 21:49:29 +03:00
Nikolai Kochetov
0ba7ff85e1 Fix build. 2020-06-18 21:45:27 +03:00
Nikolai Kochetov
7bfb5c9a47 Fix build. 2020-06-18 21:40:02 +03:00
Nikolai Kochetov
a99d9f7712 Fix build. 2020-06-18 21:36:37 +03:00
Nikolai Kochetov
b7bed87a7f Use QueryPlan in InterpreterSelectQuery [part 3]. 2020-06-18 21:29:33 +03:00
Nikolai Kochetov
45adacf0bc Use QueryPlan in InterpreterSelectQuery [part 2]. 2020-06-18 20:45:00 +03:00
alesapin
2ca9cfa753 Merge branch 'master' into atomic_metadata5 2020-06-18 20:28:01 +03:00
alesapin
8b131e2079 Remove int contention 2020-06-18 20:19:11 +03:00
alesapin
c666763cc0 Remove unused method better 2020-06-18 20:09:06 +03:00
Anton Popov
bd28b7e1c2 better code 2020-06-18 20:05:26 +03:00
alesapin
e888dafdc2 Remove unused method 2020-06-18 20:03:42 +03:00
Ruslan
23cd919681
Any input optimize (#11529)
* workig commit №1

* working commit №2

* first version of ArithmeticOperationsInAgrFuncOptimize (min, max, sum)

* fix conflicts

* fix №2

* attempt №3

* Description + little mistake

* fix style + expanded optimization + add performance test

* style + merge with new version

* one more branch

* bug fix + merge

* just merge

* some code style and logic fixes

* little changes

* tests

* test(2)

* style

* seems to have fixed everything that was required

* bug fix

* style

* build fix

* fix typo

* fix clang-10 warning

* fix clang-10 warning

* nolint

* add new files to ya.make

* extract all functions from Any

* add last new lines.

* extract all functions from Any

* add last new lines.

* build + requested changes

* code style

* build + little perf test + anyLast

* minor changes

* bug fix

* minor changes

* another minor changes

* fix + experement

* experement 2.0

* experement 3.0

* experement 3.1

* experement 4.0

* last experement(think so)

* just another attempt to fix UB

* minor changes

* I think I won

* ya.make

* fix requested changes

Co-authored-by: Artem Zuikov <chertus@gmail.com>
2020-06-18 19:34:29 +03:00
alesapin
b3ee8967dc Fix style 2020-06-18 19:28:20 +03:00
alesapin
54e5fe7dbc Less locks 2020-06-18 19:19:40 +03:00
Amos Bird
d524301038
add scalars in time 2020-06-19 00:14:19 +08:00
alesapin
d79982f497 Better locks in Storages 2020-06-18 19:10:47 +03:00
Alexander Tokmakov
e42c07954d fix 2020-06-18 19:01:49 +03:00
Alexander Tokmakov
5a6b70f5c1 Merge branch 'master' into multiword_data_type 2020-06-18 17:10:19 +03:00
Alexander Tokmakov
acd0d3c528 separate parser for data type 2020-06-18 17:09:24 +03:00
Nikolai Kochetov
4ec8012e27 Fix msan test. 2020-06-18 16:43:29 +03:00
Nikolai Kochetov
e0841360db Use QueryPlan in InterpreterSelectQuery [part 1]. 2020-06-18 16:38:45 +03:00
Nikolai Kochetov
35ab9ad051 Merge branch 'master' into fix-parallel-final-stuck 2020-06-18 16:04:14 +03:00
Nikolai Kochetov
5bb2ddc6f9 Add DISTINCT trait for QueryPlanStep. 2020-06-18 16:00:16 +03:00
Alexander Kuzmenkov
730c22f767
Merge pull request #11748 from ClickHouse/aku/unbreak-jemalloc-metrics
Unbreak jemalloc stats + add more of them
2020-06-18 15:24:30 +03:00
alesapin
c8a58299ac Fix storage buffer metadata 2020-06-18 14:42:48 +03:00
alesapin
1a69c3234a Fix style 2020-06-18 14:09:55 +03:00
alesapin
d4c49816ab Really atomic metadata 2020-06-18 14:02:31 +03:00
alesapin
4de5331b0d Fix SystemTables 2020-06-18 13:39:33 +03:00
alesapin
aab4ce6394 Truncate with metadata 2020-06-18 13:29:13 +03:00
Artem Zuikov
6af36cb703
CAST keep nullable (#11733) 2020-06-18 13:18:28 +03:00
alesapin
35ce47951d Fix storage merge 2020-06-18 12:22:54 +03:00
Nikolai Kochetov
21d9c7fcc8 Fix build. 2020-06-18 12:22:29 +03:00
Nikolai Kochetov
c111836ada Update PartialSortingTransform. 2020-06-18 12:08:25 +03:00
alesapin
760e9a8488 Fix crash 2020-06-18 12:08:24 +03:00
alesapin
f4037b8f54 Fix build 2020-06-18 12:00:43 +03:00
alesapin
ebb36bec8a Merge branch 'master' into atomic_metadata5 2020-06-18 11:57:16 +03:00
alesapin
d0beeaf7c4
Merge pull request #11744 from ClickHouse/stop_fetches_before_metadata_alter
Cancel fetches before metadata alter
2020-06-18 11:32:16 +03:00
Azat Khuzhin
2bd05baa7a Move AggregateFunctionCount out from clickhouse_aggregate_functions to dbms
As suggested by @alexey-milovidov
2020-06-18 11:22:40 +03:00
alexey-milovidov
c9924b8aa1
Merge pull request #11697 from CurtizJ/fix-with-fill
Fix 'ORDER BY ... WITH FILL' over const columns.
2020-06-18 06:38:24 +03:00
Alexander Kuzmenkov
07ead3c815 Use hours instead of days.
std::chrono::days is C++20 which the barbarian Arcadia build is unable
to appreciate.
2020-06-18 05:03:59 +03:00
Alexander Kuzmenkov
4e42903eac Unbreak jemalloc stats + add more of them
We didn't call the `epoch` mallctl, so all the statistics were stale.
Fix that, and also add some more statistics for arenas.
2020-06-18 04:54:10 +03:00
alexey-milovidov
b42f622a77
Merge pull request #11739 from azat/replicated-parse-zk-metadata
[RFC] Parse metadata stored in zookeeper before checking for equality
2020-06-18 03:26:48 +03:00
Anton Popov
fb7f4c6369 fix build 2020-06-18 02:42:40 +03:00
Azat Khuzhin
65c17f0c2c Fix usage of static dbms library (add clickhouse_aggregate_functions)
The following error reported:

    FAILED: src/Interpreters/tests/hash_map
    ...
    ld.lld: error: undefined symbol: typeinfo for DB::AggregateFunctionCount
    >>> referenced by typeinfo:308 (../contrib/libcxx/include/typeinfo:308)
    >>>               InterpreterSelectQuery.cpp.o:(std::__1::enable_if<is_pointer_v<DB::AggregateFunctionCount*>, DB::AggregateFunctionCount*>::type typeid_cast<DB::AggregateFunctionCount*, DB::IAggregateFunction>(DB::IAggregateFunction*)) in archive src/libdbms.a
    collect2: error: ld returned 1 exit status

And also this one with gold linker:

  FAILED: programs/clickhouse-odbc-bridge
  ...  src/AggregateFunctions/libclickhouse_aggregate_functions.a ... src/libdbms.a ...
  ../contrib/libcxx/include/typeinfo:308: error: undefined reference to 'typeinfo for DB::AggregateFunctionCount'

Due to order?

Introduced by 394fb64a9cda376ca8dfa8bac08a4fbcfa9bf3bf/#11661 I guess.
2020-06-18 01:53:14 +03:00
Anton Popov
8ba5bd8530 Merge remote-tracking branch 'upstream/master' into distinct-combinator 2020-06-18 01:44:36 +03:00
tavplubix
bb16544bee
Merge pull request #11732 from ClickHouse/fix_type_duduction_in_values_format
Fix type duduction in Values format
2020-06-18 00:21:03 +03:00
alesapin
870d891257 Cancel fetches before metadata alter 2020-06-17 23:25:43 +03:00
Nikolai Kochetov
9ad00187e3 Update InterpreterSelectQuery.. 2020-06-17 23:19:55 +03:00
Nikolai Kochetov
169ad5e805 Add FinishSortingStep. 2020-06-17 22:57:13 +03:00
Nikolai Kochetov
e8049d34c5 Add OffsetsStep. 2020-06-17 22:38:45 +03:00
Anton Popov
88b325dcdc rework distinct combinator 2020-06-17 22:36:27 +03:00
Nikolai Kochetov
69ff3a8f7d Add ExtremesStep. 2020-06-17 22:30:36 +03:00
Nikolai Kochetov
d795b2b037 Add FillingStep 2020-06-17 22:20:30 +03:00
Nikolai Kochetov
7fcea660de Fix ya.make/ 2020-06-17 22:08:30 +03:00
Nikolai Kochetov
38bebfb20d Merge remote-tracking branch 'origin' into provert-master 2020-06-17 22:05:45 +03:00
Nikolai Kochetov
84fd7fe51c Update having. 2020-06-17 22:02:46 +03:00
Azat Khuzhin
caa88777be Parse metadata stored in zookeeper before checking for equality
After #11325 trailing whitespaces has been removed for data skipping
indicies, and it may be different, if you have multiple skip indices,
and in this case new server will not load such tables, because metadata
will be different.

Fix this by re-parse metadata in zookeeper.
2020-06-17 21:03:22 +03:00
Nikolai Kochetov
2cffa56914 Add RollupStep and CubeStep. 2020-06-17 20:20:09 +03:00
Nikolai Kochetov
d41db3622f Add RollupStep and CubeStep. 2020-06-17 20:15:24 +03:00
alesapin
51a47560e0 Fix segmentation fault 2020-06-17 19:59:26 +03:00
Nikolai Kochetov
c5d9379df0 Add TotalsHavingStep. 2020-06-17 19:54:51 +03:00
alesapin
dffdece350 getColumns in StorageInMemoryMetadta (only compilable) 2020-06-17 19:39:58 +03:00
maxim-babenko
c3dbf7d6bf
Fix PODArrayBase::push_back_raw_many
1) capacity check must be ready for overflow during memcpy
2) reserve must be called with the new size, not just delta
2020-06-17 19:38:23 +03:00
Nikolai Kochetov
ce7c8782e2
Update PartialSortingTransform.cpp 2020-06-17 19:13:44 +03:00
Nikolai Kochetov
1ad4f2c0fd Add CreatingSets step. 2020-06-17 18:50:21 +03:00
alesapin
ef8781cce7 Better getVirtuals method 2020-06-17 17:37:21 +03:00
alesapin
33c27de54d Check methods in metadata 2020-06-17 17:32:25 +03:00
Nikolai Kochetov
f279df6015 Added AggregatingStep. 2020-06-17 17:21:48 +03:00
alesapin
31abbe5dbd Select query in metadata 2020-06-17 17:06:22 +03:00
alesapin
eaaef83742 Settings changes in StorageInMemoryMetadata 2020-06-17 16:46:01 +03:00
alesapin
ed8f3b2fc4 TTL in storage in memory metadata 2020-06-17 16:39:26 +03:00
Nikolai Kochetov
582ea24469 Added AddingDelayedStreamStep 2020-06-17 16:38:17 +03:00
Vitaly Baranov
7011401cd4
Merge pull request #11670 from vitlibar/rbac-improve-parser-multiple-entities
RBAC: improve syntax
2020-06-17 16:26:02 +03:00
Alexander Tokmakov
3938b051c2 fix type duduction in values format 2020-06-17 16:21:06 +03:00
Alexander Tokmakov
eebfc9d2da fix build with clang-9 2020-06-17 16:19:15 +03:00
alesapin
7064a366e2 Missed change for primary key 2020-06-17 15:40:27 +03:00
alesapin
1afdebeebd Primary key in storage metadata 2020-06-17 15:39:20 +03:00
alesapin
1da393b218 Sampling key in StorageInMemoryMetadata 2020-06-17 15:07:09 +03:00
Nikolai Kochetov
8c78ae0cd9 Fix style. 2020-06-17 15:03:33 +03:00
Anton Popov
5abbaeecf5 distinct combinator for single numeric arguments 2020-06-17 15:01:47 +03:00
alesapin
eca6e9087e Fix race condition 2020-06-17 14:52:19 +03:00
Nikolai Kochetov
6c477d06ad Review fixes. 2020-06-17 14:43:55 +03:00
alexey-milovidov
f55fb33731
Merge pull request #11726 from ClickHouse/remove-old-tests
Remove old non-automated tests (examples)
2020-06-17 14:25:20 +03:00
alesapin
ba04d02f1e Compilable sorting key in metadata 2020-06-17 14:05:11 +03:00
Nikita Mikhaylov
d2be6c036b
Merge pull request #11602 from ClickHouse/fix-buffer-sample
Fix buffer sample
2020-06-17 14:44:48 +04:00
Nikita Mikhaylov
ff0262626a
Merge pull request #11645 from azat/load-balancing-round-robin
Add round_robin load_balancing
2020-06-17 14:34:59 +04:00
alesapin
ab61abccc1 Partition key in StorageInMemoryMetadata 2020-06-17 13:34:23 +03:00
Nikita Mikhaylov
9b88065e77
add small comment 2020-06-17 13:33:35 +03:00
alesapin
62f2c17a66 Secondary indices in StorageInMemoryMetadata 2020-06-17 12:38:47 +03:00
xPoSx
2d8110ce45
Eliminate min/max/any aggregators of GROUP BY keys in SELECT section (#11667) 2020-06-17 12:32:43 +03:00
Nikolai Kochetov
0829d1d16d Fix ya.make 2020-06-17 12:16:01 +03:00
Nikita Mikhaylov
edec79cf69
Merge pull request #11703 from nikitamikhaylov/merging-alter-query
Merging #11508
2020-06-17 12:47:34 +04:00
Nikita Mikhaylov
edff6eac6e comment 2020-06-17 11:44:52 +03:00
alesapin
2fac3290f0 Merge branch 'master' into atomic_metadata5 2020-06-17 11:14:03 +03:00
Alexey Milovidov
3c023fe8b8 Remove old non-automated tests 2020-06-17 10:45:51 +03:00
Nikita Mikhaylov
ab04a6bb62
Merge pull request #11615 from azat/SYSTEM-FLUSH-LOGS-force-table-creation-v2
Force table creation on SYSTEM FLUSH LOGS (v2)
2020-06-17 11:09:19 +04:00
alexey-milovidov
e07d02015c
Merge pull request #11661 from ClickHouse/return-not-nullable-from-count-distinct-2
Return non-Nullable results from COUNT(DISTINCT), more complete.
2020-06-17 09:25:45 +03:00
alexey-milovidov
598fd75caf
Merge pull request #11639 from ClickHouse/remove-leader-election-2
Remove leader election, step 2: allow multiple leaders
2020-06-17 09:25:23 +03:00
alexey-milovidov
6e61f708d7
Merge pull request #11690 from ClickHouse/odbc-bridge-timeouts
Pass proper timeouts when communicating with XDBC bridge.
2020-06-17 03:18:29 +03:00
Alexey Milovidov
e720d78f23 Fix tests 2020-06-17 03:08:01 +03:00
Alexey Milovidov
a655765040 Merge branch 'master' into return-not-nullable-from-count-distinct-2 2020-06-17 01:15:57 +03:00
Alexander Kuzmenkov
9cab822718
Merge pull request #11683 from ClickHouse/aku/merge-minmap-11603
Merge minMap, maxMap (#11603)
2020-06-17 00:02:33 +03:00
Artem Zuikov
857d84bf7c
Buffer left blocks optimisation for MergeJoin (#10601) 2020-06-16 23:13:18 +03:00
alexey-milovidov
f387752cf1
Merge pull request #11702 from ClickHouse/fix-mv-header
Fix mv header
2020-06-16 22:43:38 +03:00
Alexey Milovidov
0a6054eece Merge branch 'master' into return-not-nullable-from-count-distinct-2 2020-06-16 22:31:33 +03:00
alexey-milovidov
ad53ef2c14
Merge pull request #11686 from ClickHouse/proper-query-formatting-in-log
Don't break multiline queries when they are printed in server log
2020-06-16 22:17:30 +03:00
Alexey Milovidov
6c93016c91 Add suggestion from @alesap 2020-06-16 22:16:01 +03:00
Alexey Milovidov
b7ec5f94f2 Merge branch 'master' into odbc-bridge-timeouts 2020-06-16 22:14:43 +03:00
alexey-milovidov
47bd8df9de
Merge pull request #11692 from ClickHouse/fix-flaky-test-incremental-streaming
Fix flaky test 01064_incremental_streaming_from_2_src_with_feedback
2020-06-16 22:12:46 +03:00
alexey-milovidov
6f2d9999be
Merge pull request #11693 from ClickHouse/fix-flaky-unit-tests
More robust unit tests if ZooKeeper is unavailable for some time.
2020-06-16 22:12:30 +03:00
Nikolai Kochetov
fdacc9f90e Add MergingAggregatedStep. 2020-06-16 21:57:21 +03:00
alesapin
fa60903620 Fix race condition 2020-06-16 21:41:11 +03:00
alesapin
d214a504d7
Merge pull request #11681 from ClickHouse/fix_mutations_premature_finish
Fix mutations premature "finish"
2020-06-16 21:26:14 +03:00
Nikolai Kochetov
148257abb5 Add LimitStep. 2020-06-16 21:23:01 +03:00
Anton Popov
d92ba0b216 Merge remote-tracking branch 'upstream/master' into distinct-combinator 2020-06-16 21:13:20 +03:00
Azat Khuzhin
8fbf93012d Fix data race between reading/writing is_force_prepare_tables 2020-06-16 21:08:44 +03:00
Nikita Mikhaylov
fc06f99476 build and test fixes 2020-06-16 21:07:41 +03:00
alesapin
ccc2bda666 getConstraints() in StorageInMemoryMetadata (suspicious commit, but pretend to work) 2020-06-16 19:55:04 +03:00
Nikolai Kochetov
5bb1d5cc43 Add LimitByStep. 2020-06-16 19:49:49 +03:00
Artem Zuikov
a3d6e047fe
Fix lambdas with multiple_joins_rewriter v2 (#11587) 2020-06-16 19:32:32 +03:00
Nikolai Kochetov
603bcdde2d Add DistinctStep. 2020-06-16 19:13:07 +03:00
alesapin
1ddeb3d149 Buildable getSampleBlock in StorageInMemoryMetadata 2020-06-16 18:51:29 +03:00
Nikolai Kochetov
cfe87a77ea Add MergingSortedStep. 2020-06-16 18:49:09 +03:00
Nikolai Kochetov
08e9ce8661 Add MergingSortedStep. 2020-06-16 18:47:40 +03:00
Nikolai Kochetov
a0a1445da9 Fix build. 2020-06-16 18:10:40 +03:00
Nikolai Kochetov
f563193967 Add MergeSortingStep. 2020-06-16 18:08:01 +03:00
Nikolai Kochetov
815ac03892 Add PartialSortingStep. 2020-06-16 17:45:52 +03:00
alesapin
71f99a274d Compileable getSampleBlockWithColumns in StorageInMemoryMetadata 2020-06-16 17:25:08 +03:00
Nikolai Kochetov
ab452e9391 Added source steps. 2020-06-16 17:14:14 +03:00
Nikolai Kochetov
4407bd7daa Added source steps. 2020-06-16 17:11:19 +03:00
Ivan Blinkov
7e2bb1fd83 Merge branch 'master' of github.com:ClickHouse/ClickHouse into sentry 2020-06-16 16:02:55 +03:00
alesapin
08b9aa6b2e getSampleBlockWithVirtuals in StorageInMemoryMetadata 2020-06-16 15:58:05 +03:00
alesapin
53cb5210de Move getSampleBlockNonMaterialized to StorageInMemoryMetadata 2020-06-16 15:48:10 +03:00
alesapin
0bcd22008a Get column dependencies in StorageInMemoryMetadata 2020-06-16 15:19:21 +03:00
alesapin
0f286ac133 Copy some methods to metdata 2020-06-16 15:03:27 +03:00
Nikolai Kochetov
be8029e54f Expression and Filter steps. 2020-06-16 15:02:10 +03:00
alesapin
eae901f58d Merge branch 'master' into atomic_metadata5 2020-06-16 14:44:45 +03:00
alesapin
0a33ccb77b Fix remove method 2020-06-16 14:12:52 +03:00
alesapin
d1052f2dfe Better logic 2020-06-16 13:50:47 +03:00
Alexander Kuzmenkov
be008cd186 remove some code 2020-06-16 13:44:23 +03:00
alesapin
d5b76b2fe1 Fix parts count in mutations 2020-06-16 13:34:59 +03:00
alesapin
0cb14c836c
Merge pull request #11691 from ClickHouse/fix-race-condition-system-sync-replicas
Fix race condition in SYSTEM SYNC REPLICA
2020-06-16 13:29:18 +03:00
alesapin
362aaf1385
Merge pull request #11516 from ClickHouse/consistent_metadata4
Storage metadata as a single struct.
2020-06-16 13:28:22 +03:00
Nikolai Kochetov
e28552ec71 Fix build. 2020-06-16 12:53:59 +03:00
Nikolai Kochetov
1bb72205bd Expression and Filter steps. 2020-06-16 12:42:25 +03:00
alesapin
f6f3605258
Merge pull request #11695 from ClickHouse/avoid-attempt-to-fetch-when-fetches-are-cancelled
Avoid connection to replica when fetches are cancelled
2020-06-16 12:30:58 +03:00
xPoSx
9fc37e1f75
Remove functions of other keys in GROUP BY section (#10051) 2020-06-16 12:14:25 +03:00
Vitaly Baranov
c5229301fc
Merge pull request #11671 from vitlibar/fix-minor-bugs-in-rbac
Fix minor bugs in RBAC
2020-06-16 12:09:54 +03:00
frank
e26e873b0d fix for style check.
(cherry picked from commit 0be7b09490)
2020-06-16 11:54:01 +03:00
franklee
afa666792b typo
(cherry picked from commit 76c75c947e)
2020-06-16 11:53:52 +03:00
franklee
264e44ecef support distributed DDLs on cross replication clusters.
(cherry picked from commit fd09994d91)
2020-06-16 11:53:27 +03:00
alesapin
605c904fc6 Add method for compatibility 2020-06-16 11:39:12 +03:00
Nikolai Kochetov
66c0ef2610 Do not materialize header for merge tables. 2020-06-16 11:08:32 +03:00
Nikolai Kochetov
61070a03cd Fix build. 2020-06-16 10:56:22 +03:00
Bharat Nallan
334c5abe9b remove extra vertical space 2020-06-15 22:04:30 -07:00
Bharat Nallan
c43bd228ab make max global thread pool setting configurable
This PR adds a server level config for overriding the default max number
of threads in global thread pool that is currently allowed (10,000).

This might be useful in scenarios where there are a large number of
distributed queries that are executing concurrently and where the
default number of max threads might not be necessarily be sufficient.
2020-06-15 22:04:30 -07:00
alexey-milovidov
82b27ab618
Merge pull request #11689 from CurtizJ/fix-with-ties
Fix 'LIMIT WITH TIES' with aliases
2020-06-16 06:04:27 +03:00
Alexey Milovidov
125b007360 Merge branch 'master' into remove-leader-election-2 2020-06-16 05:56:29 +03:00
Anton Popov
03058c3c25 fix 'ORDER BY WITH FILL' over const columns 2020-06-16 05:56:16 +03:00
Alexey Milovidov
22a92faab6 Avoid connection to replica when fetches are cancelled 2020-06-16 05:14:53 +03:00
alexey-milovidov
ceb8775bc1
Merge pull request #11685 from ClickHouse/remove-duplicate-line
Remove excessive statement
2020-06-16 03:28:40 +03:00
Alexey Milovidov
85a7676bf4 Fix flaky unit tests with ZooKeeper. 2020-06-16 02:32:30 +03:00
Alexey Milovidov
d08736f708 Added a comment 2020-06-16 02:27:22 +03:00
Alexey Milovidov
53d985909e Fix race condition in SYSTEM SYNC REPLICA 2020-06-16 01:54:19 +03:00
Alexey Milovidov
cf0bd501e5 Remove harmful default values from code 2020-06-16 01:36:12 +03:00
Alexey Milovidov
186d336e31 Use proper timeouts when communicating with xdbc-bridge 2020-06-16 01:35:15 +03:00
Anton Popov
eabbabed04 fix 'LIMIT WITH TIES' with aliases 2020-06-16 01:24:00 +03:00
Alexey Milovidov
1e73a56a77 Whitespace 2020-06-16 01:23:56 +03:00
Alexey Milovidov
bc58e22c5b Whitespace 2020-06-16 01:23:13 +03:00
Nikolai Kochetov
03e0a5ddbc Merge branch 'master' into query-plan 2020-06-15 23:38:35 +03:00
Nikolai Kochetov
da11190677 Fix tests. 2020-06-15 23:20:45 +03:00
Alexey Milovidov
511fa106af Better comment 2020-06-15 23:05:21 +03:00
Alexey Milovidov
1976b10ee0 Proper query formatting in logs #3853 2020-06-15 23:01:58 +03:00
Nikolai Kochetov
dbef88e073 Fix tests. 2020-06-15 22:33:24 +03:00
Alexey Milovidov
d10109dc38 Remove excessive statement #11131 2020-06-15 22:18:33 +03:00
alesapin
36ba0192df Metadata in read and write methods of IStorage 2020-06-15 22:08:58 +03:00
Vitaly Baranov
a40885fa84 Add new command SHOW ACCESS. 2020-06-15 22:07:47 +03:00
Vitaly Baranov
9fe47df2e8 Support multiple users/roles in SHOW CREATE USER(ROLE, etc.) and SHOW GRANTS FOR commands.
Support syntax "SHOW CREATE USER ALL" and "SHOW GRANTS FOR ALL".
2020-06-15 22:07:47 +03:00
Vitaly Baranov
6146766465 Use function ParserList::parseUtil() to parse lists more accurately. 2020-06-15 22:07:47 +03:00
Vitaly Baranov
15132d47c9 Slightly improve syntax of CREATE POLICY.
Also rename column source=>storage in table system.row_policies.
2020-06-15 22:07:42 +03:00
Alexander Kuzmenkov
7cc54fd4f1 renames + perf test 2020-06-15 21:53:54 +03:00
Nikolai Kochetov
012fb819db Fix build. 2020-06-15 21:49:41 +03:00
Nikolai Kochetov
68f8372c12 Fix build. 2020-06-15 21:41:47 +03:00
Alexander Kuzmenkov
82b5ada130
Merge pull request #11650 from ksvladimir/master
Allow using groupArrayArray and groupUniqArrayArray as SimpleAggregateFunction
2020-06-15 21:29:57 +03:00
alesapin
b47a7327fd All set methods in metadata 2020-06-15 21:08:05 +03:00
alesapin
33a74a3ea0 TTL methods in StorageInMemoryMetadata 2020-06-15 20:50:53 +03:00
Nikolai Kochetov
b456a3cc77 Fix tests. 2020-06-15 20:48:04 +03:00
tavplubix
86e2cfe999
Merge pull request #11628 from zhang2014/feature/ISSUES-7572
ISSUES-7572 support config default http handler
2020-06-15 20:37:04 +03:00
alesapin
e667eb57b2 Working set*Keys methods 2020-06-15 20:24:49 +03:00
alesapin
5fc41c7ecc Move set*Key methods to StorageInMemoryMetadata 2020-06-15 20:17:06 +03:00
Vitaly Baranov
4bd00b02e2 Improve syntax of CREATE QUOTA. Now resource types and key types could be written with underscores.
Also rename columns key_type=>keys and source=>storage in table system.quotas.
2020-06-15 20:10:34 +03:00
Vitaly Baranov
7d1951a79b Improve messages for errors in access storages. 2020-06-15 20:10:34 +03:00
Vitaly Baranov
92b9f4a88d Rename ExtendedRoleSet => RolesOrUsersSet. 2020-06-15 20:10:34 +03:00
Vitaly Baranov
9f31184d76 Support for multiple names in one CREATE/ALTER command. 2020-06-15 20:10:28 +03:00
alesapin
aa30649ce5 Working setColumns, setConstraints, setIndices 2020-06-15 20:10:14 +03:00
alesapin
af2fe2ba55 Compilable setColumns, setConstraints, setIndices 2020-06-15 19:55:33 +03:00
Alexey Milovidov
a5e9d793b0 Merge branch 'master' into avoid-trailing-whitespaces-in-some-cases 2020-06-15 19:48:07 +03:00
Alexander Kuzmenkov
0743e8c15d Merge remote-tracking branch 'origin/master' into minmap 2020-06-15 19:39:57 +03:00
Alexander Kuzmenkov
e460d7c2bd
Merge pull request #11638 from azat/skip-idx-bloom-filter-fix
Fix bloom filters for String (data skipping indices)
2020-06-15 18:41:04 +03:00
Nikolai Kochetov
5436ef38bf Fix MergingSortedAlgorithm. 2020-06-15 18:21:10 +03:00
Nikolai Kochetov
b725df6366 Added ReadFromStorageStep. 2020-06-15 18:17:44 +03:00
alesapin
8f66c1b22c Merge with master 2020-06-15 17:31:37 +03:00
Nikolai Kochetov
b5ecef6adf Fix tests. 2020-06-15 16:56:38 +03:00
alesapin
8945d0073a Fix misunderstanding bug in mutations finalization 2020-06-15 16:37:40 +03:00
Vitaly Baranov
c7140724a8 Fix that ALTER USER RENAME could change allowed hosts. 2020-06-15 16:34:16 +03:00
Artem Zuikov
24059efad5
Change push down logic in VIEW (#11513) 2020-06-15 15:36:10 +03:00
Mikhail Malafeev
10566e2b43
Remove duplicate ORDER BY and DISTINCT from subqueries (#10067) 2020-06-15 15:03:01 +03:00
Alexander Tokmakov
def0158638 configure query handler as default 2020-06-15 14:33:44 +03:00
Nikolai Kochetov
ccf2ceb876 Fix pipeline stuck for parallel final. 2020-06-15 14:02:47 +03:00
alesapin
2c9ce0f3fa
Bump CI 2020-06-15 13:14:36 +03:00
tavplubix
20b8e1e9ec
Merge pull request #11057 from Potya/null_data_mods
Null data mods
2020-06-15 13:04:51 +03:00
alesapin
bc9a3c0458 Merge branch 'master' into consistent_metadata4 2020-06-15 11:20:30 +03:00
alesapin
c20ce687cf
bump ci 2020-06-15 11:12:01 +03:00
Alexey Milovidov
94d55abfd1 Update tests 2020-06-15 07:40:03 +03:00
Alexey Milovidov
e2607f005c Fix error with ALTER CONSTRAINT formatting; added a test 2020-06-15 07:36:20 +03:00
Alexey Milovidov
e9eb722d4a Better formatting of CREATE queries 2020-06-15 07:27:33 +03:00
Alexey Milovidov
1c5c2f8c69 Fix formatting of CREATE DICTIONARY 2020-06-15 07:08:20 +03:00
Alexey Milovidov
fdc8f7ad14 Merge branch 'master' into avoid-trailing-whitespaces-in-some-cases 2020-06-15 06:52:14 +03:00
alexey-milovidov
fd6115cccf
Merge pull request #11648 from ClickHouse/simplify-code-functions-comparison-3
Allow comparison with String in index analysis; simplify code.
2020-06-15 05:47:03 +03:00
Alexey Milovidov
1ab599b0a0 Remove "current_password" but keep it for Arcadians 2020-06-15 05:17:08 +03:00
Alexey Milovidov
d2c66f9688 Added comments 2020-06-15 05:14:59 +03:00
Alexey Milovidov
bbe5f4c909 Revert "Remove "current_password" because it is harmful"
This reverts commit 66ccb2f6b1.
2020-06-15 05:13:41 +03:00
Alexey Milovidov
5866401f60 Less noise in cleanup thread 2020-06-15 05:12:06 +03:00
Alexey Milovidov
66ccb2f6b1 Remove "current_password" because it is harmful 2020-06-15 04:12:01 +03:00
Alexey Milovidov
689b6901f8 Fix typo 2020-06-15 04:04:42 +03:00
Alexey Milovidov
1c438a133e Leader election both backward and forward compatible 2020-06-15 03:59:12 +03:00
alexey-milovidov
550838adbb
Merge pull request #11647 from ClickHouse/simplify-code-functions-comparison-2
Allow comparison of numbers with constant string in IN and VALUES
2020-06-15 03:33:45 +03:00
Alexey Milovidov
b596831342 Merge branch 'master' into remove-leader-election-2 2020-06-15 03:16:41 +03:00
alexey-milovidov
814265b66e
Merge pull request #11665 from ClickHouse/clear-password-from-command-line
Clear password from command line
2020-06-15 02:17:21 +03:00
Vitaly Baranov
3ffcb8e790 Fix casting values of settings while reading profiles from users.xml. 2020-06-15 01:44:25 +03:00
Vitaly Baranov
ca2fb59321 Fix calculating full names of row policies. 2020-06-15 01:44:25 +03:00
Vitaly Baranov
ceaaf67d3f Fix parsing CREATE SETTINGS PROFILE with WRITABLE keyword. 2020-06-15 01:44:25 +03:00
Alexey Milovidov
6467302ad3 Fix gcc build 2020-06-15 01:29:22 +03:00
Alexey Milovidov
303d1ebdaf Fix error; more tests 2020-06-15 01:17:06 +03:00
Alexey Milovidov
c4f18d2896 Fix tests 2020-06-15 00:39:22 +03:00
Alexander Tokmakov
045f804879 Merge branch 'master' into multiword_data_type 2020-06-15 00:35:17 +03:00
Alexey Milovidov
07ba7ffea5 Clear password from command line #11624 2020-06-14 22:23:05 +03:00
Alexey Milovidov
3663e2a47e Fix syntax hilite in CREATE USER query 2020-06-14 22:11:32 +03:00
Alexey Milovidov
8dac30ae95 Split file for better build times 2020-06-14 21:42:10 +03:00
Alexey Milovidov
067cf4cc40 Fix gcc build 2020-06-14 21:31:42 +03:00
Alexey Milovidov
f6c52fe1c2 Allow comparison with String in index analysis; simplify code #11630 2020-06-14 21:31:42 +03:00
Alexey Milovidov
db0fc6c9a6 Fix tests 2020-06-14 21:24:25 +03:00
alexey-milovidov
561d4b5b01
Merge pull request #11655 from ClickHouse/position-in-system-columns
Added column "position" to system.columns and "column_position" to system.parts_columns
2020-06-14 21:01:41 +03:00
Alexey Milovidov
217d05443a Remove old non-automated test 2020-06-14 20:42:11 +03:00
Alexey Milovidov
394fb64a9c Better way of implementation 2020-06-14 20:42:11 +03:00
alexey-milovidov
d990b98b90
Merge pull request #11593 from ClickHouse/return-not-nullable-from-count-distinct
Return non-Nullable results from COUNT(DISTINCT)
2020-06-14 20:39:19 +03:00
Alexander Tokmakov
6a439a5eb5 fixes 2020-06-14 19:39:06 +03:00
Alexander Tokmakov
5f9739fbf9 Merge branch 'master' into fork-potya/null_data_mods 2020-06-14 18:11:55 +03:00
Winter Zhang
dc6f904f0a
Merge branch 'master' into feature/ISSUES-7572 2020-06-14 18:28:06 +08:00
alexey-milovidov
88cf3f7083
Merge pull request #11653 from ClickHouse/parse-date-time-best-effort-incompletely-parsed-value
Return NULL or zero when value is not parsed completely in parseDateTimeBestEffortOr* functions
2020-06-14 10:59:10 +03:00
alexey-milovidov
361cb880a3
Merge pull request #11657 from ClickHouse/dont-use-elf-if-foreign
Don't use debug info from ELF file if it doesn't correspond to the running binary.
2020-06-14 10:58:21 +03:00
alexey-milovidov
da3a075821
Merge pull request #11660 from bharatnc/bnc/fix-remove-unused-imports
remove unused imports from HTTPHandlerFactory
2020-06-14 09:43:52 +03:00
alexey-milovidov
56b8d81ef6
Merge pull request #11651 from ClickHouse/empty-parameters-url
Skip empty URL parameters
2020-06-14 09:00:52 +03:00