ClickHouse/dbms/src/Storages/MergeTree
2017-10-12 23:26:54 +03:00
..
AbandonableLockInZooKeeper.h Removed cyclic dependency [#DEVTOOLS-3381]. 2017-06-19 23:06:35 +03:00
ActiveDataPartSet.cpp save MergeTree data format version and parse part names depending on it [#CLICKHOUSE-3000] 2017-09-26 20:40:02 +03:00
ActiveDataPartSet.h save MergeTree data format version and parse part names depending on it [#CLICKHOUSE-3000] 2017-09-26 20:40:02 +03:00
AllMergeSelector.cpp Moved headers and sources to same place [#CLICKHOUSE-3]. 2017-04-01 12:22:42 +03:00
AllMergeSelector.h Moved headers and sources to same place [#CLICKHOUSE-3]. 2017-04-01 12:22:42 +03:00
BackgroundProcessingPool.cpp Replaced Mersenne Twister to PCG-Random [#CLICKHOUSE-2]. 2017-09-10 02:17:38 +03:00
BackgroundProcessingPool.h Fix includes 2017-09-18 21:52:47 +03:00
BoolMask.h translate comments 2017-04-16 23:17:32 +03:00
DataPartsExchange.cpp Disable part sendings and fetches before ALTER. [#CLICKHOUSE-3343] 2017-10-12 23:26:54 +03:00
DataPartsExchange.h Disable part sendings and fetches before ALTER. [#CLICKHOUSE-3343] 2017-10-12 23:26:54 +03:00
DiskSpaceMonitor.cpp Moved headers and sources to same place [#CLICKHOUSE-3]. 2017-04-01 12:22:42 +03:00
DiskSpaceMonitor.h Allow compile on 32bit systems (#1175) 2017-09-01 20:21:03 +03:00
LevelMergeSelector.cpp Moved headers and sources to same place [#CLICKHOUSE-3]. 2017-04-01 12:22:42 +03:00
LevelMergeSelector.h Addition to prev. revision [#CLICKHOUSE-3300]. 2017-09-08 00:26:25 +03:00
MarkRange.h ColumnConst unification (#1011) 2017-07-21 09:35:58 +03:00
MergedBlockOutputStream.cpp Fix array writing (#1314) 2017-10-12 23:13:26 +03:00
MergedBlockOutputStream.h Fix array writing (#1314) 2017-10-12 23:13:26 +03:00
MergeList.cpp Moved headers and sources to same place [#CLICKHOUSE-3]. 2017-04-01 12:22:42 +03:00
MergeList.h Moved headers and sources to same place [#CLICKHOUSE-3]. 2017-04-01 12:22:42 +03:00
MergeSelector.h Moved headers and sources to same place [#CLICKHOUSE-3]. 2017-04-01 12:22:42 +03:00
MergeTreeBaseBlockInputStream.cpp fix reading with preferred_block_size_bytes = 0 2017-09-24 02:16:30 +03:00
MergeTreeBaseBlockInputStream.h Fixed warnings found by cppcheck [#CLICKHOUSE-3300]. 2017-09-08 00:04:48 +03:00
MergeTreeBlockInputStream.cpp Fixed warnings found by cppcheck [#CLICKHOUSE-3300]. 2017-09-08 00:04:48 +03:00
MergeTreeBlockInputStream.h Fixed warnings found by cppcheck [#CLICKHOUSE-3300]. 2017-09-08 00:04:48 +03:00
MergeTreeBlockOutputStream.cpp Preparation: locking block number only after write to filesystem; removed obsolete code [#CLICKHOUSE-3091]. 2017-06-25 03:01:10 +03:00
MergeTreeBlockOutputStream.h Preparation: locking block number only after write to filesystem; removed obsolete code [#CLICKHOUSE-3091]. 2017-06-25 03:01:10 +03:00
MergeTreeBlockReadUtils.cpp Fixed error after merge [#CLICKHOUSE-3150]. 2017-07-21 09:40:05 +03:00
MergeTreeBlockReadUtils.h fixed estimateNumRows in MergeTreeBlockSizePredictor; fixed reading of empty block in prewhere; added test [#CLICKHOUSE-3266] 2017-09-01 15:18:40 +03:00
MergeTreeData.cpp Fix array writing (#1314) 2017-10-12 23:13:26 +03:00
MergeTreeData.h add comments [#CLICKHOUSE-3000] 2017-09-26 20:40:02 +03:00
MergeTreeDataFormatVersion.h add comments [#CLICKHOUSE-3000] 2017-09-26 20:40:02 +03:00
MergeTreeDataMerger.cpp Disable part sendings and fetches before ALTER. [#CLICKHOUSE-3343] 2017-10-12 23:26:54 +03:00
MergeTreeDataMerger.h Disable part sendings and fetches before ALTER. [#CLICKHOUSE-3343] 2017-10-12 23:26:54 +03:00
MergeTreeDataPart.cpp safeguards to protect against distinct partition values with the same partition_id [#CLICKHOUSE-3000] 2017-09-26 20:40:02 +03:00
MergeTreeDataPart.h safeguards to protect against distinct partition values with the same partition_id [#CLICKHOUSE-3000] 2017-09-26 20:40:02 +03:00
MergeTreeDataSelectExecutor.cpp Fix compile with boost 1.65.1+ and clang 3.8 ( https://bugs.freebsd.org/bugzilla/show_bug.cgi?id=222439 ) (#1325) 2017-10-06 19:26:32 +03:00
MergeTreeDataSelectExecutor.h Get rid of ASTSet, because it is not really an AST and it lead to bugs [#CLICKHOUSE-3148]. 2017-07-15 06:48:36 +03:00
MergeTreeDataWriter.cpp safeguards to protect against distinct partition values with the same partition_id [#CLICKHOUSE-3000] 2017-09-26 20:40:02 +03:00
MergeTreeDataWriter.h generic partitioning of inserted blocks [#CLICKHOUSE-3000] 2017-08-31 23:32:03 +03:00
MergeTreePartChecker.cpp Removed obsolete code [#CLICKHOUSE-3270]. 2017-09-01 21:21:01 +03:00
MergeTreePartChecker.h Fixed translation errors [#CLICKHOUSE-3091]. 2017-06-25 03:17:08 +03:00
MergeTreePartInfo.cpp add MergeTreeDataFormatVersion constant [#CLICKHOUSE-3000] 2017-09-26 20:40:02 +03:00
MergeTreePartInfo.h save MergeTree data format version and parse part names depending on it [#CLICKHOUSE-3000] 2017-09-26 20:40:02 +03:00
MergeTreePartition.cpp add comments [#CLICKHOUSE-3000] 2017-09-26 20:40:02 +03:00
MergeTreePartition.h add comments [#CLICKHOUSE-3000] 2017-09-26 20:40:02 +03:00
MergeTreeRangeReader.cpp fixed number of rows to read from first granula in mergetree 2017-08-03 15:58:04 +03:00
MergeTreeRangeReader.h Removed useless variable [#CLICKHOUSE-3161]. 2017-07-19 04:05:39 +03:00
MergeTreeReader.cpp Removed obsolete code [#CLICKHOUSE-3270]. 2017-09-01 21:21:01 +03:00
MergeTreeReader.h refactoring and more comments in MergeTreeBaseBlockInputStream [#CLICKHOUSE-3065] 2017-07-13 21:45:09 +03:00
MergeTreeReadPool.cpp Changed Poco::RWLock to std::shared_lock [#APRILDEV-91]. 2017-07-28 20:34:02 +03:00
MergeTreeReadPool.h Changed Poco::RWLock to std::shared_lock [#APRILDEV-91]. 2017-07-28 20:34:02 +03:00
MergeTreeSettings.h Allow compile on 32bit systems (#1175) 2017-09-01 20:21:03 +03:00
MergeTreeSharder.cpp split partition and minmax index [#CLICKHOUSE-3000] 2017-08-31 23:32:03 +03:00
MergeTreeSharder.h Allow compile on 32bit systems (#1175) 2017-09-01 20:21:03 +03:00
MergeTreeThreadBlockInputStream.cpp Fixed warnings found by cppcheck [#CLICKHOUSE-3300]. 2017-09-08 00:04:48 +03:00
MergeTreeThreadBlockInputStream.h added preferred_max_column_in_block_size_bytes setting, added filtration ratio prediction [#CLICKHOUSE-3065] 2017-07-13 21:45:09 +03:00
MergeTreeWhereOptimizer.cpp ColumnConst unification (#1011) 2017-07-21 09:35:58 +03:00
MergeTreeWhereOptimizer.h ColumnConst unification (#1011) 2017-07-21 09:35:58 +03:00
PKCondition.cpp Implemented some suggestions from clang-tidy (part 3) [#CLICKHOUSE-3301]. 2017-09-08 06:47:27 +03:00
PKCondition.h Implemented some suggestions from clang-tidy (part 3) [#CLICKHOUSE-3301]. 2017-09-08 06:47:27 +03:00
RangesInDataPart.h ColumnConst unification (#1011) 2017-07-21 09:35:58 +03:00
RemoteDiskSpaceMonitor.cpp Disable part sendings and fetches before ALTER. [#CLICKHOUSE-3343] 2017-10-12 23:26:54 +03:00
RemoteDiskSpaceMonitor.h translate comments 2017-04-16 23:17:32 +03:00
RemotePartChecker.cpp fix http methods for ReadWriteBufferFromHTTP (#675) 2017-04-11 17:13:19 +03:00
RemotePartChecker.h ReplicatedMergeTree: Max streams to send data [#CLICKHOUSE-2878] (#656) 2017-04-06 16:03:23 +03:00
RemoteQueryExecutor.cpp Disable part sendings and fetches before ALTER. [#CLICKHOUSE-3343] 2017-10-12 23:26:54 +03:00
RemoteQueryExecutor.h translate comments 2017-04-16 23:17:32 +03:00
ReplicatedMergeTreeAddress.h Fixed error [#CLICKHOUSE-3191]. 2017-08-01 00:39:24 +03:00
ReplicatedMergeTreeAlterThread.cpp Disable part sendings and fetches before ALTER. [#CLICKHOUSE-3343] 2017-10-12 23:26:54 +03:00
ReplicatedMergeTreeAlterThread.h Removed cyclic dependency [#DEVTOOLS-3381]. 2017-06-19 23:06:35 +03:00
ReplicatedMergeTreeBlockOutputStream.cpp add MergeTreeDataFormatVersion constant [#CLICKHOUSE-3000] 2017-09-26 20:40:02 +03:00
ReplicatedMergeTreeBlockOutputStream.h Removed obsolete code that was relevant only in extremely rare case of transforming CollapsingMergeTree to ReplicatedCollapsingMergeTree through ATTACHing data parts and while some considerations about data order in table is important [#CLICKHOUSE-3091]. 2017-06-25 03:51:51 +03:00
ReplicatedMergeTreeCleanupThread.cpp Less noisy logging. [#CLICKHOSUE-2] 2017-10-12 22:28:24 +03:00
ReplicatedMergeTreeCleanupThread.h Add requested changes. [#CLICKHOUSE-3207] 2017-08-10 23:09:05 +03:00
ReplicatedMergeTreeLogEntry.cpp Fixed error [#CLICKHOUSE-3191]. 2017-08-01 00:39:24 +03:00
ReplicatedMergeTreeLogEntry.h reduce number of places where partitioning by month is assumed [#CLICKHOUSE-3000] 2017-08-15 22:30:52 +03:00
ReplicatedMergeTreePartCheckThread.cpp save MergeTree data format version and parse part names depending on it [#CLICKHOUSE-3000] 2017-09-26 20:40:02 +03:00
ReplicatedMergeTreePartCheckThread.h slightly more robust ReplicatedMergeTreePartCheckThread::TemporarilyStop [#CLICKHOUSE-3074] 2017-07-12 20:09:44 +03:00
ReplicatedMergeTreeQueue.cpp Disable part sendings and fetches before ALTER. [#CLICKHOUSE-3343] 2017-10-12 23:26:54 +03:00
ReplicatedMergeTreeQueue.h save MergeTree data format version and parse part names depending on it [#CLICKHOUSE-3000] 2017-09-26 20:40:02 +03:00
ReplicatedMergeTreeQuorumEntry.h Fixed error [#CLICKHOUSE-3191]. 2017-08-01 00:39:24 +03:00
ReplicatedMergeTreeRestartingThread.cpp Disable part sendings and fetches before ALTER. [#CLICKHOUSE-3343] 2017-10-12 23:26:54 +03:00
ReplicatedMergeTreeRestartingThread.h Fixed translation errors, part 1 [#CLICKHOUSE-3]. 2017-05-09 15:07:35 -04:00
ReshardingJob.cpp rename partition -> partition_id for clarity [#CLICKHOUSE-3000] 2017-08-31 23:32:03 +03:00
ReshardingJob.h rename partition -> partition_id for clarity [#CLICKHOUSE-3000] 2017-08-31 23:32:03 +03:00
ReshardingWorker.cpp Replaced Mersenne Twister to PCG-Random [#CLICKHOUSE-2]. 2017-09-10 02:17:38 +03:00
ReshardingWorker.h Remove extra Context reference and add required ones. Part 2. [#CLICKHOUSE-3117] 2017-09-06 04:18:07 +03:00
ShardedPartitionUploader.cpp Disable part sendings and fetches before ALTER. [#CLICKHOUSE-3343] 2017-10-12 23:26:54 +03:00
ShardedPartitionUploader.h translate comments 2017-04-16 23:17:32 +03:00
SimpleMergeSelector.cpp Fixed warnings found by cppcheck [#CLICKHOUSE-3300]. 2017-09-08 00:04:48 +03:00
SimpleMergeSelector.h Addition to prev. revision [#CLICKHOUSE-3300]. 2017-09-08 00:26:25 +03:00