2013-02-26 11:48:09 +00:00
|
|
|
|
#include <Poco/Path.h>
|
2010-03-18 19:32:14 +00:00
|
|
|
|
|
2011-11-05 23:31:19 +00:00
|
|
|
|
#include <DB/Common/escapeForFileName.h>
|
|
|
|
|
|
2010-03-18 19:32:14 +00:00
|
|
|
|
#include <DB/Core/Exception.h>
|
|
|
|
|
#include <DB/Core/ErrorCodes.h>
|
|
|
|
|
|
2015-01-25 05:07:51 +00:00
|
|
|
|
#include <DB/IO/ReadBufferFromFile.h>
|
|
|
|
|
#include <DB/IO/WriteBufferFromFile.h>
|
|
|
|
|
#include <DB/IO/CompressedReadBuffer.h>
|
|
|
|
|
#include <DB/IO/CompressedWriteBuffer.h>
|
2012-01-10 22:11:51 +00:00
|
|
|
|
#include <DB/IO/ReadHelpers.h>
|
2012-01-09 19:20:48 +00:00
|
|
|
|
#include <DB/IO/WriteHelpers.h>
|
|
|
|
|
|
2012-08-29 20:07:24 +00:00
|
|
|
|
#include <DB/DataTypes/DataTypeArray.h>
|
2013-07-12 13:35:05 +00:00
|
|
|
|
#include <DB/DataTypes/DataTypeNested.h>
|
2012-08-29 20:07:24 +00:00
|
|
|
|
|
2015-01-18 08:25:56 +00:00
|
|
|
|
#include <DB/DataStreams/IProfilingBlockInputStream.h>
|
2015-01-25 05:07:51 +00:00
|
|
|
|
#include <DB/DataStreams/IBlockOutputStream.h>
|
2015-01-18 08:25:56 +00:00
|
|
|
|
|
2012-08-29 20:07:24 +00:00
|
|
|
|
#include <DB/Columns/ColumnArray.h>
|
2013-07-12 13:35:05 +00:00
|
|
|
|
#include <DB/Columns/ColumnNested.h>
|
2012-08-29 20:07:24 +00:00
|
|
|
|
|
2010-03-18 19:32:14 +00:00
|
|
|
|
#include <DB/Storages/StorageLog.h>
|
|
|
|
|
|
2014-01-17 15:19:20 +00:00
|
|
|
|
#include <DB/DataTypes/DataTypeString.h>
|
|
|
|
|
|
2010-03-18 19:32:14 +00:00
|
|
|
|
|
2012-01-09 19:20:48 +00:00
|
|
|
|
#define DBMS_STORAGE_LOG_DATA_FILE_EXTENSION ".bin"
|
2013-02-26 13:06:01 +00:00
|
|
|
|
#define DBMS_STORAGE_LOG_MARKS_FILE_EXTENSION ".mrk"
|
|
|
|
|
#define DBMS_STORAGE_LOG_MARKS_FILE_NAME "__marks.mrk"
|
2012-01-09 19:20:48 +00:00
|
|
|
|
|
|
|
|
|
|
2010-03-18 19:32:14 +00:00
|
|
|
|
namespace DB
|
|
|
|
|
{
|
|
|
|
|
|
|
|
|
|
using Poco::SharedPtr;
|
|
|
|
|
|
|
|
|
|
|
2015-01-18 08:25:56 +00:00
|
|
|
|
class LogBlockInputStream : public IProfilingBlockInputStream
|
2010-03-18 19:32:14 +00:00
|
|
|
|
{
|
2015-01-18 08:25:56 +00:00
|
|
|
|
public:
|
2015-04-12 04:47:03 +00:00
|
|
|
|
LogBlockInputStream(
|
|
|
|
|
size_t block_size_, const Names & column_names_, StorageLog & storage_,
|
|
|
|
|
size_t mark_number_, size_t rows_limit_, size_t max_read_buffer_size_)
|
2015-01-18 08:25:56 +00:00
|
|
|
|
: block_size(block_size_), column_names(column_names_), storage(storage_),
|
2015-04-12 04:47:03 +00:00
|
|
|
|
mark_number(mark_number_), rows_limit(rows_limit_), current_mark(mark_number_), max_read_buffer_size(max_read_buffer_size_) {}
|
2015-01-18 08:25:56 +00:00
|
|
|
|
|
2015-06-08 20:22:02 +00:00
|
|
|
|
String getName() const { return "Log"; }
|
2015-01-18 08:25:56 +00:00
|
|
|
|
|
|
|
|
|
String getID() const
|
|
|
|
|
{
|
|
|
|
|
std::stringstream res;
|
|
|
|
|
res << "Log(" << storage.getTableName() << ", " << &storage << ", " << mark_number << ", " << rows_limit;
|
2010-03-18 19:32:14 +00:00
|
|
|
|
|
2015-01-18 08:25:56 +00:00
|
|
|
|
for (const auto & name : column_names)
|
|
|
|
|
res << ", " << name;
|
2010-03-18 19:32:14 +00:00
|
|
|
|
|
2015-01-18 08:25:56 +00:00
|
|
|
|
res << ")";
|
|
|
|
|
return res.str();
|
|
|
|
|
}
|
|
|
|
|
|
|
|
|
|
protected:
|
|
|
|
|
Block readImpl();
|
|
|
|
|
private:
|
|
|
|
|
size_t block_size;
|
|
|
|
|
Names column_names;
|
|
|
|
|
StorageLog & storage;
|
|
|
|
|
size_t mark_number; /// С какой засечки читать данные
|
|
|
|
|
size_t rows_limit; /// Максимальное количество строк, которых можно прочитать
|
|
|
|
|
size_t rows_read = 0;
|
|
|
|
|
size_t current_mark;
|
2015-04-12 04:47:03 +00:00
|
|
|
|
size_t max_read_buffer_size;
|
2015-01-18 08:25:56 +00:00
|
|
|
|
|
|
|
|
|
struct Stream
|
|
|
|
|
{
|
2015-04-12 04:47:03 +00:00
|
|
|
|
Stream(const std::string & data_path, size_t offset, size_t max_read_buffer_size)
|
|
|
|
|
: plain(data_path, std::min(max_read_buffer_size, Poco::File(data_path).getSize())),
|
2015-01-18 08:25:56 +00:00
|
|
|
|
compressed(plain)
|
|
|
|
|
{
|
|
|
|
|
if (offset)
|
|
|
|
|
plain.seek(offset);
|
|
|
|
|
}
|
|
|
|
|
|
|
|
|
|
ReadBufferFromFile plain;
|
|
|
|
|
CompressedReadBuffer compressed;
|
|
|
|
|
};
|
|
|
|
|
|
|
|
|
|
typedef std::map<std::string, std::unique_ptr<Stream> > FileStreams;
|
|
|
|
|
FileStreams streams;
|
|
|
|
|
|
|
|
|
|
void addStream(const String & name, const IDataType & type, size_t level = 0);
|
|
|
|
|
void readData(const String & name, const IDataType & type, IColumn & column, size_t max_rows_to_read, size_t level = 0, bool read_offsets = true);
|
|
|
|
|
};
|
|
|
|
|
|
|
|
|
|
|
|
|
|
|
class LogBlockOutputStream : public IBlockOutputStream
|
2014-03-19 10:45:13 +00:00
|
|
|
|
{
|
2015-01-18 08:25:56 +00:00
|
|
|
|
public:
|
|
|
|
|
LogBlockOutputStream(StorageLog & storage_)
|
|
|
|
|
: storage(storage_),
|
|
|
|
|
lock(storage.rwlock), marks_stream(storage.marks_file.path(), 4096, O_APPEND | O_CREAT | O_WRONLY)
|
|
|
|
|
{
|
|
|
|
|
for (const auto & column : storage.getColumnsList())
|
|
|
|
|
addStream(column.name, *column.type);
|
|
|
|
|
}
|
2014-03-19 10:45:13 +00:00
|
|
|
|
|
2015-04-02 23:58:26 +00:00
|
|
|
|
~LogBlockOutputStream()
|
|
|
|
|
{
|
|
|
|
|
try
|
|
|
|
|
{
|
|
|
|
|
writeSuffix();
|
|
|
|
|
}
|
|
|
|
|
catch (...)
|
|
|
|
|
{
|
|
|
|
|
tryLogCurrentException(__PRETTY_FUNCTION__);
|
|
|
|
|
}
|
|
|
|
|
}
|
2014-03-19 10:45:13 +00:00
|
|
|
|
|
2015-01-18 08:25:56 +00:00
|
|
|
|
void write(const Block & block);
|
|
|
|
|
void writeSuffix();
|
2015-04-02 23:58:26 +00:00
|
|
|
|
|
2015-01-18 08:25:56 +00:00
|
|
|
|
private:
|
|
|
|
|
StorageLog & storage;
|
|
|
|
|
Poco::ScopedWriteRWLock lock;
|
2015-04-02 23:58:26 +00:00
|
|
|
|
bool done = false;
|
2015-01-18 08:25:56 +00:00
|
|
|
|
|
|
|
|
|
struct Stream
|
|
|
|
|
{
|
|
|
|
|
Stream(const std::string & data_path, size_t max_compress_block_size) :
|
|
|
|
|
plain(data_path, max_compress_block_size, O_APPEND | O_CREAT | O_WRONLY),
|
2015-08-16 07:01:41 +00:00
|
|
|
|
compressed(plain, CompressionMethod::LZ4, max_compress_block_size)
|
2015-01-18 08:25:56 +00:00
|
|
|
|
{
|
|
|
|
|
plain_offset = Poco::File(data_path).getSize();
|
|
|
|
|
}
|
|
|
|
|
|
|
|
|
|
WriteBufferFromFile plain;
|
|
|
|
|
CompressedWriteBuffer compressed;
|
|
|
|
|
|
|
|
|
|
size_t plain_offset; /// Сколько байт было в файле на момент создания LogBlockOutputStream.
|
|
|
|
|
|
|
|
|
|
void finalize()
|
|
|
|
|
{
|
|
|
|
|
compressed.next();
|
|
|
|
|
plain.next();
|
|
|
|
|
}
|
|
|
|
|
};
|
|
|
|
|
|
|
|
|
|
typedef std::vector<std::pair<size_t, Mark> > MarksForColumns;
|
|
|
|
|
|
|
|
|
|
typedef std::map<std::string, std::unique_ptr<Stream> > FileStreams;
|
|
|
|
|
FileStreams streams;
|
|
|
|
|
|
|
|
|
|
typedef std::set<std::string> OffsetColumns;
|
|
|
|
|
|
|
|
|
|
WriteBufferFromFile marks_stream; /// Объявлен ниже lock, чтобы файл открывался при захваченном rwlock.
|
|
|
|
|
|
|
|
|
|
void addStream(const String & name, const IDataType & type, size_t level = 0);
|
|
|
|
|
void writeData(const String & name, const IDataType & type, const IColumn & column, MarksForColumns & out_marks, OffsetColumns & offset_columns, size_t level = 0);
|
|
|
|
|
void writeMarks(MarksForColumns marks);
|
|
|
|
|
};
|
2014-03-19 10:45:13 +00:00
|
|
|
|
|
|
|
|
|
|
2011-09-04 21:23:19 +00:00
|
|
|
|
Block LogBlockInputStream::readImpl()
|
2010-03-18 19:32:14 +00:00
|
|
|
|
{
|
|
|
|
|
Block res;
|
|
|
|
|
|
2012-06-22 17:13:03 +00:00
|
|
|
|
if (rows_read == rows_limit)
|
|
|
|
|
return res;
|
|
|
|
|
|
2012-06-21 16:16:58 +00:00
|
|
|
|
/// Если файлы не открыты, то открываем их.
|
|
|
|
|
if (streams.empty())
|
2012-11-30 04:28:13 +00:00
|
|
|
|
{
|
|
|
|
|
Poco::ScopedReadRWLock lock(storage.rwlock);
|
2014-06-26 00:58:14 +00:00
|
|
|
|
|
2012-06-21 16:16:58 +00:00
|
|
|
|
for (Names::const_iterator it = column_names.begin(); it != column_names.end(); ++it)
|
2014-01-17 15:19:20 +00:00
|
|
|
|
if (*it != storage._table_column_name) /// Для виртуального столбца не надо ничего открывать
|
|
|
|
|
addStream(*it, *storage.getDataTypeByName(*it));
|
2012-11-30 04:28:13 +00:00
|
|
|
|
}
|
2012-06-21 16:16:58 +00:00
|
|
|
|
|
2014-01-17 15:19:20 +00:00
|
|
|
|
bool has_virtual_column_table = false;
|
|
|
|
|
for (Names::const_iterator it = column_names.begin(); it != column_names.end(); ++it)
|
|
|
|
|
if (*it == storage._table_column_name)
|
|
|
|
|
has_virtual_column_table = true;
|
|
|
|
|
|
2012-06-22 16:54:51 +00:00
|
|
|
|
/// Сколько строк читать для следующего блока.
|
|
|
|
|
size_t max_rows_to_read = std::min(block_size, rows_limit - rows_read);
|
2014-01-17 15:19:20 +00:00
|
|
|
|
const Marks & marks = storage.getMarksWithRealRowCount();
|
|
|
|
|
std::pair<String, size_t> current_table;
|
|
|
|
|
|
|
|
|
|
/// Отдельно обрабатываем виртуальный столбец
|
|
|
|
|
if (has_virtual_column_table)
|
|
|
|
|
{
|
|
|
|
|
size_t current_row = rows_read;
|
|
|
|
|
if (mark_number > 0)
|
|
|
|
|
current_row += marks[mark_number-1].rows;
|
|
|
|
|
while (current_mark < marks.size() && marks[current_mark].rows <= current_row)
|
2014-03-27 19:09:23 +00:00
|
|
|
|
++current_mark;
|
2014-01-17 15:19:20 +00:00
|
|
|
|
|
|
|
|
|
current_table = storage.getTableFromMark(current_mark);
|
|
|
|
|
current_table.second = std::min(current_table.second, marks.size() - 1);
|
|
|
|
|
max_rows_to_read = std::min(max_rows_to_read, marks[current_table.second].rows - current_row);
|
|
|
|
|
}
|
2012-06-22 16:54:51 +00:00
|
|
|
|
|
2013-07-16 14:55:01 +00:00
|
|
|
|
/// Указатели на столбцы смещений, общие для столбцов из вложенных структур данных
|
|
|
|
|
typedef std::map<std::string, ColumnPtr> OffsetColumns;
|
|
|
|
|
OffsetColumns offset_columns;
|
|
|
|
|
|
2011-08-09 15:57:33 +00:00
|
|
|
|
for (Names::const_iterator it = column_names.begin(); it != column_names.end(); ++it)
|
2010-03-18 19:32:14 +00:00
|
|
|
|
{
|
2014-01-17 15:19:20 +00:00
|
|
|
|
/// Виртуальный столбец не надо считывать с жесткого диска
|
|
|
|
|
if (*it == storage._table_column_name)
|
|
|
|
|
continue;
|
|
|
|
|
|
2015-07-17 01:27:35 +00:00
|
|
|
|
ColumnWithTypeAndName column;
|
2010-03-18 19:32:14 +00:00
|
|
|
|
column.name = *it;
|
2011-11-01 17:12:11 +00:00
|
|
|
|
column.type = storage.getDataTypeByName(*it);
|
2014-06-26 00:58:14 +00:00
|
|
|
|
|
2013-07-16 14:55:01 +00:00
|
|
|
|
bool read_offsets = true;
|
2014-06-26 00:58:14 +00:00
|
|
|
|
|
2013-07-16 14:55:01 +00:00
|
|
|
|
/// Для вложенных структур запоминаем указатели на столбцы со смещениями
|
2014-06-26 00:58:14 +00:00
|
|
|
|
if (const DataTypeArray * type_arr = typeid_cast<const DataTypeArray *>(&*column.type))
|
2013-07-16 14:55:01 +00:00
|
|
|
|
{
|
|
|
|
|
String name = DataTypeNested::extractNestedTableName(column.name);
|
2014-06-26 00:58:14 +00:00
|
|
|
|
|
2013-07-16 14:55:01 +00:00
|
|
|
|
if (offset_columns.count(name) == 0)
|
|
|
|
|
offset_columns[name] = new ColumnArray::ColumnOffsets_t;
|
|
|
|
|
else
|
|
|
|
|
read_offsets = false; /// на предыдущих итерациях смещения уже считали вызовом readData
|
2014-06-26 00:58:14 +00:00
|
|
|
|
|
2013-07-16 14:55:01 +00:00
|
|
|
|
column.column = new ColumnArray(type_arr->getNestedType()->createColumn(), offset_columns[name]);
|
|
|
|
|
}
|
|
|
|
|
else
|
|
|
|
|
column.column = column.type->createColumn();
|
2014-06-26 00:58:14 +00:00
|
|
|
|
|
2015-07-01 20:14:23 +00:00
|
|
|
|
try
|
|
|
|
|
{
|
|
|
|
|
readData(*it, *column.type, *column.column, max_rows_to_read, 0, read_offsets);
|
|
|
|
|
}
|
|
|
|
|
catch (Exception & e)
|
|
|
|
|
{
|
|
|
|
|
e.addMessage("while reading column " + *it + " at " + storage.path + escapeForFileName(storage.name));
|
|
|
|
|
throw;
|
|
|
|
|
}
|
2010-03-18 19:32:14 +00:00
|
|
|
|
|
2010-05-24 18:58:14 +00:00
|
|
|
|
if (column.column->size())
|
|
|
|
|
res.insert(column);
|
2010-03-18 19:32:14 +00:00
|
|
|
|
}
|
|
|
|
|
|
2014-01-17 15:19:20 +00:00
|
|
|
|
/// Отдельно обрабатываем виртуальный столбец
|
|
|
|
|
if (has_virtual_column_table)
|
|
|
|
|
{
|
|
|
|
|
size_t rows = max_rows_to_read;
|
|
|
|
|
if (res.columns() > 0)
|
|
|
|
|
rows = res.rows();
|
|
|
|
|
if (rows > 0)
|
|
|
|
|
{
|
2014-01-22 12:50:19 +00:00
|
|
|
|
ColumnPtr column_ptr = ColumnConst<String> (rows, current_table.first, new DataTypeString).convertToFullColumn();
|
2015-07-17 01:27:35 +00:00
|
|
|
|
ColumnWithTypeAndName column(column_ptr, new DataTypeString, storage._table_column_name);
|
2014-01-17 15:19:20 +00:00
|
|
|
|
res.insert(column);
|
|
|
|
|
}
|
|
|
|
|
}
|
|
|
|
|
|
2012-03-05 02:34:20 +00:00
|
|
|
|
if (res)
|
2012-06-22 17:00:59 +00:00
|
|
|
|
rows_read += res.rows();
|
2012-06-22 16:54:51 +00:00
|
|
|
|
|
2012-06-22 17:00:59 +00:00
|
|
|
|
if (!res || rows_read == rows_limit)
|
2012-06-21 16:16:58 +00:00
|
|
|
|
{
|
|
|
|
|
/** Закрываем файлы (ещё до уничтожения объекта).
|
|
|
|
|
* Чтобы при создании многих источников, но одновременном чтении только из нескольких,
|
|
|
|
|
* буферы не висели в памяти.
|
|
|
|
|
*/
|
|
|
|
|
streams.clear();
|
|
|
|
|
}
|
2014-06-26 00:58:14 +00:00
|
|
|
|
|
2010-03-18 19:32:14 +00:00
|
|
|
|
return res;
|
|
|
|
|
}
|
|
|
|
|
|
|
|
|
|
|
2012-08-29 20:07:24 +00:00
|
|
|
|
void LogBlockInputStream::addStream(const String & name, const IDataType & type, size_t level)
|
|
|
|
|
{
|
|
|
|
|
/// Для массивов используются отдельные потоки для размеров.
|
2014-06-26 00:58:14 +00:00
|
|
|
|
if (const DataTypeArray * type_arr = typeid_cast<const DataTypeArray *>(&type))
|
2012-08-29 20:07:24 +00:00
|
|
|
|
{
|
2013-07-16 14:55:01 +00:00
|
|
|
|
String size_name = DataTypeNested::extractNestedTableName(name) + ARRAY_SIZES_COLUMN_NAME_SUFFIX + toString(level);
|
2014-01-15 16:12:48 +00:00
|
|
|
|
if (!streams.count(size_name))
|
2014-04-22 22:43:55 +00:00
|
|
|
|
streams.emplace(size_name, std::unique_ptr<Stream>(new Stream(
|
2014-01-15 16:12:48 +00:00
|
|
|
|
storage.files[size_name].data_file.path(),
|
|
|
|
|
mark_number
|
|
|
|
|
? storage.files[size_name].marks[mark_number].offset
|
2015-04-12 04:47:03 +00:00
|
|
|
|
: 0,
|
|
|
|
|
max_read_buffer_size)));
|
2012-08-29 20:07:24 +00:00
|
|
|
|
|
|
|
|
|
addStream(name, *type_arr->getNestedType(), level + 1);
|
|
|
|
|
}
|
|
|
|
|
else
|
2014-04-22 22:43:55 +00:00
|
|
|
|
streams[name].reset(new Stream(
|
2012-08-29 20:07:24 +00:00
|
|
|
|
storage.files[name].data_file.path(),
|
2013-06-15 08:38:30 +00:00
|
|
|
|
mark_number
|
|
|
|
|
? storage.files[name].marks[mark_number].offset
|
2015-04-12 04:47:03 +00:00
|
|
|
|
: 0,
|
|
|
|
|
max_read_buffer_size));
|
2012-08-29 20:07:24 +00:00
|
|
|
|
}
|
|
|
|
|
|
|
|
|
|
|
2013-07-16 14:55:01 +00:00
|
|
|
|
void LogBlockInputStream::readData(const String & name, const IDataType & type, IColumn & column, size_t max_rows_to_read,
|
|
|
|
|
size_t level, bool read_offsets)
|
2012-08-29 20:07:24 +00:00
|
|
|
|
{
|
|
|
|
|
/// Для массивов требуется сначала десериализовать размеры, а потом значения.
|
2014-06-26 00:58:14 +00:00
|
|
|
|
if (const DataTypeArray * type_arr = typeid_cast<const DataTypeArray *>(&type))
|
2012-08-29 20:07:24 +00:00
|
|
|
|
{
|
2013-07-16 14:55:01 +00:00
|
|
|
|
if (read_offsets)
|
|
|
|
|
{
|
|
|
|
|
type_arr->deserializeOffsets(
|
|
|
|
|
column,
|
|
|
|
|
streams[DataTypeNested::extractNestedTableName(name) + ARRAY_SIZES_COLUMN_NAME_SUFFIX + toString(level)]->compressed,
|
|
|
|
|
max_rows_to_read);
|
|
|
|
|
}
|
2012-08-29 20:07:24 +00:00
|
|
|
|
|
2012-08-30 20:35:02 +00:00
|
|
|
|
if (column.size())
|
|
|
|
|
readData(
|
|
|
|
|
name,
|
|
|
|
|
*type_arr->getNestedType(),
|
2014-06-26 00:58:14 +00:00
|
|
|
|
typeid_cast<ColumnArray &>(column).getData(),
|
|
|
|
|
typeid_cast<const ColumnArray &>(column).getOffsets()[column.size() - 1],
|
2012-08-30 20:35:02 +00:00
|
|
|
|
level + 1);
|
2012-08-29 20:07:24 +00:00
|
|
|
|
}
|
|
|
|
|
else
|
2015-02-15 12:38:21 +00:00
|
|
|
|
type.deserializeBinary(column, streams[name]->compressed, max_rows_to_read, 0); /// TODO Использовать avg_value_size_hint.
|
2012-08-29 20:07:24 +00:00
|
|
|
|
}
|
|
|
|
|
|
|
|
|
|
|
2010-03-18 19:32:14 +00:00
|
|
|
|
void LogBlockOutputStream::write(const Block & block)
|
|
|
|
|
{
|
2013-02-26 11:47:15 +00:00
|
|
|
|
storage.check(block, true);
|
2014-06-26 00:58:14 +00:00
|
|
|
|
|
2013-07-16 14:55:01 +00:00
|
|
|
|
/// Множество записанных столбцов со смещениями, чтобы не писать общие для вложенных структур столбцы несколько раз
|
|
|
|
|
OffsetColumns offset_columns;
|
2010-03-18 19:32:14 +00:00
|
|
|
|
|
2013-02-26 13:06:01 +00:00
|
|
|
|
MarksForColumns marks;
|
|
|
|
|
marks.reserve(storage.files.size());
|
2010-03-18 19:32:14 +00:00
|
|
|
|
for (size_t i = 0; i < block.columns(); ++i)
|
|
|
|
|
{
|
2015-07-17 01:27:35 +00:00
|
|
|
|
const ColumnWithTypeAndName & column = block.getByPosition(i);
|
2013-07-16 14:55:01 +00:00
|
|
|
|
writeData(column.name, *column.type, *column.column, marks, offset_columns);
|
2012-08-29 20:07:24 +00:00
|
|
|
|
}
|
2013-02-26 13:06:01 +00:00
|
|
|
|
writeMarks(marks);
|
2012-08-29 20:07:24 +00:00
|
|
|
|
}
|
|
|
|
|
|
|
|
|
|
|
2013-09-15 01:40:29 +00:00
|
|
|
|
void LogBlockOutputStream::writeSuffix()
|
|
|
|
|
{
|
2015-04-02 23:58:26 +00:00
|
|
|
|
if (done)
|
|
|
|
|
return;
|
|
|
|
|
done = true;
|
|
|
|
|
|
2013-09-15 01:40:29 +00:00
|
|
|
|
/// Заканчиваем запись.
|
2013-09-26 19:16:43 +00:00
|
|
|
|
marks_stream.next();
|
2013-09-15 01:40:29 +00:00
|
|
|
|
|
|
|
|
|
for (FileStreams::iterator it = streams.begin(); it != streams.end(); ++it)
|
2013-09-26 19:16:43 +00:00
|
|
|
|
it->second->finalize();
|
2013-09-15 01:40:29 +00:00
|
|
|
|
|
2014-08-04 06:36:24 +00:00
|
|
|
|
std::vector<Poco::File> column_files;
|
|
|
|
|
for (auto & pair : streams)
|
|
|
|
|
column_files.push_back(storage.files[pair.first].data_file);
|
|
|
|
|
column_files.push_back(storage.marks_file);
|
|
|
|
|
|
|
|
|
|
storage.file_checker.update(column_files.begin(), column_files.end());
|
|
|
|
|
|
2013-09-15 01:40:29 +00:00
|
|
|
|
streams.clear();
|
|
|
|
|
}
|
|
|
|
|
|
|
|
|
|
|
2012-08-29 20:07:24 +00:00
|
|
|
|
void LogBlockOutputStream::addStream(const String & name, const IDataType & type, size_t level)
|
|
|
|
|
{
|
|
|
|
|
/// Для массивов используются отдельные потоки для размеров.
|
2014-06-26 00:58:14 +00:00
|
|
|
|
if (const DataTypeArray * type_arr = typeid_cast<const DataTypeArray *>(&type))
|
2012-08-29 20:07:24 +00:00
|
|
|
|
{
|
2013-07-16 14:55:01 +00:00
|
|
|
|
String size_name = DataTypeNested::extractNestedTableName(name) + ARRAY_SIZES_COLUMN_NAME_SUFFIX + toString(level);
|
2014-01-15 16:12:48 +00:00
|
|
|
|
if (!streams.count(size_name))
|
2014-04-22 22:43:55 +00:00
|
|
|
|
streams.emplace(size_name, std::unique_ptr<Stream>(new Stream(
|
2014-03-28 14:36:24 +00:00
|
|
|
|
storage.files[size_name].data_file.path(), storage.max_compress_block_size)));
|
2012-08-29 20:07:24 +00:00
|
|
|
|
|
|
|
|
|
addStream(name, *type_arr->getNestedType(), level + 1);
|
|
|
|
|
}
|
|
|
|
|
else
|
2014-04-22 22:43:55 +00:00
|
|
|
|
streams[name].reset(new Stream(storage.files[name].data_file.path(), storage.max_compress_block_size));
|
2012-08-29 20:07:24 +00:00
|
|
|
|
}
|
|
|
|
|
|
|
|
|
|
|
2013-07-16 14:55:01 +00:00
|
|
|
|
void LogBlockOutputStream::writeData(const String & name, const IDataType & type, const IColumn & column, MarksForColumns & out_marks,
|
|
|
|
|
OffsetColumns & offset_columns, size_t level)
|
2012-08-29 20:07:24 +00:00
|
|
|
|
{
|
|
|
|
|
/// Для массивов требуется сначала сериализовать размеры, а потом значения.
|
2014-06-26 00:58:14 +00:00
|
|
|
|
if (const DataTypeArray * type_arr = typeid_cast<const DataTypeArray *>(&type))
|
2012-08-29 20:07:24 +00:00
|
|
|
|
{
|
2013-07-16 14:55:01 +00:00
|
|
|
|
String size_name = DataTypeNested::extractNestedTableName(name) + ARRAY_SIZES_COLUMN_NAME_SUFFIX + toString(level);
|
2014-06-26 00:58:14 +00:00
|
|
|
|
|
2013-07-16 14:55:01 +00:00
|
|
|
|
if (offset_columns.count(size_name) == 0)
|
|
|
|
|
{
|
|
|
|
|
offset_columns.insert(size_name);
|
2014-06-26 00:58:14 +00:00
|
|
|
|
|
2013-07-16 14:55:01 +00:00
|
|
|
|
Mark mark;
|
|
|
|
|
mark.rows = (storage.files[size_name].marks.empty() ? 0 : storage.files[size_name].marks.back().rows) + column.size();
|
|
|
|
|
mark.offset = streams[size_name]->plain_offset + streams[size_name]->plain.count();
|
|
|
|
|
|
|
|
|
|
out_marks.push_back(std::make_pair(storage.files[size_name].column_index, mark));
|
2014-06-26 00:58:14 +00:00
|
|
|
|
|
2013-07-16 14:55:01 +00:00
|
|
|
|
type_arr->serializeOffsets(column, streams[size_name]->compressed);
|
|
|
|
|
streams[size_name]->compressed.next();
|
|
|
|
|
}
|
2012-08-29 20:07:24 +00:00
|
|
|
|
|
2014-06-26 00:58:14 +00:00
|
|
|
|
writeData(name, *type_arr->getNestedType(), typeid_cast<const ColumnArray &>(column).getData(), out_marks, offset_columns, level + 1);
|
2012-08-29 20:07:24 +00:00
|
|
|
|
}
|
|
|
|
|
else
|
|
|
|
|
{
|
|
|
|
|
Mark mark;
|
|
|
|
|
mark.rows = (storage.files[name].marks.empty() ? 0 : storage.files[name].marks.back().rows) + column.size();
|
2012-09-19 18:45:01 +00:00
|
|
|
|
mark.offset = streams[name]->plain_offset + streams[name]->plain.count();
|
2012-08-29 20:07:24 +00:00
|
|
|
|
|
2013-02-26 13:06:01 +00:00
|
|
|
|
out_marks.push_back(std::make_pair(storage.files[name].column_index, mark));
|
2012-08-29 20:07:24 +00:00
|
|
|
|
|
|
|
|
|
type.serializeBinary(column, streams[name]->compressed);
|
|
|
|
|
streams[name]->compressed.next();
|
2010-03-18 19:32:14 +00:00
|
|
|
|
}
|
|
|
|
|
}
|
|
|
|
|
|
2013-02-26 13:06:01 +00:00
|
|
|
|
static bool ColumnIndexLess(const std::pair<size_t, Mark> & a, const std::pair<size_t, Mark> & b)
|
|
|
|
|
{
|
|
|
|
|
return a.first < b.first;
|
|
|
|
|
}
|
|
|
|
|
|
|
|
|
|
void LogBlockOutputStream::writeMarks(MarksForColumns marks)
|
|
|
|
|
{
|
|
|
|
|
if (marks.size() != storage.files.size())
|
|
|
|
|
throw Exception("Wrong number of marks generated from block. Makes no sense.", ErrorCodes::LOGICAL_ERROR);
|
2014-06-26 00:58:14 +00:00
|
|
|
|
|
2013-02-26 13:06:01 +00:00
|
|
|
|
sort(marks.begin(), marks.end(), ColumnIndexLess);
|
2014-06-26 00:58:14 +00:00
|
|
|
|
|
2013-02-26 13:06:01 +00:00
|
|
|
|
for (size_t i = 0; i < marks.size(); ++i)
|
|
|
|
|
{
|
|
|
|
|
if (marks[i].first != i)
|
|
|
|
|
throw Exception("Invalid marks generated from block. Makes no sense.", ErrorCodes::LOGICAL_ERROR);
|
2014-06-26 00:58:14 +00:00
|
|
|
|
|
2013-02-26 13:06:01 +00:00
|
|
|
|
Mark mark = marks[i].second;
|
2014-06-26 00:58:14 +00:00
|
|
|
|
|
2013-02-26 13:06:01 +00:00
|
|
|
|
writeIntBinary(mark.rows, marks_stream);
|
|
|
|
|
writeIntBinary(mark.offset, marks_stream);
|
2014-06-26 00:58:14 +00:00
|
|
|
|
|
2013-02-26 13:06:01 +00:00
|
|
|
|
storage.files[storage.column_names[i]].marks.push_back(mark);
|
|
|
|
|
}
|
|
|
|
|
}
|
|
|
|
|
|
2010-03-18 19:32:14 +00:00
|
|
|
|
|
2014-09-30 03:08:47 +00:00
|
|
|
|
StorageLog::StorageLog(
|
|
|
|
|
const std::string & path_,
|
|
|
|
|
const std::string & name_,
|
|
|
|
|
NamesAndTypesListPtr columns_,
|
2014-10-03 15:30:10 +00:00
|
|
|
|
const NamesAndTypesList & materialized_columns_,
|
2014-09-30 03:08:47 +00:00
|
|
|
|
const NamesAndTypesList & alias_columns_,
|
|
|
|
|
const ColumnDefaults & column_defaults_,
|
|
|
|
|
size_t max_compress_block_size_)
|
2014-10-03 15:30:10 +00:00
|
|
|
|
: IStorage{materialized_columns_, alias_columns_, column_defaults_},
|
2014-09-30 03:08:47 +00:00
|
|
|
|
path(path_), name(name_), columns(columns_),
|
|
|
|
|
loaded_marks(false), max_compress_block_size(max_compress_block_size_),
|
2015-08-16 07:01:41 +00:00
|
|
|
|
file_checker(path + escapeForFileName(name) + '/' + "sizes.json")
|
2010-03-18 19:32:14 +00:00
|
|
|
|
{
|
2012-01-10 22:11:51 +00:00
|
|
|
|
if (columns->empty())
|
|
|
|
|
throw Exception("Empty list of columns passed to StorageLog constructor", ErrorCodes::EMPTY_LIST_OF_COLUMNS_PASSED);
|
2014-06-26 00:58:14 +00:00
|
|
|
|
|
2010-03-18 19:32:14 +00:00
|
|
|
|
/// создаём файлы, если их нет
|
2011-11-05 23:31:19 +00:00
|
|
|
|
Poco::File(path + escapeForFileName(name) + '/').createDirectories();
|
2012-01-10 22:11:51 +00:00
|
|
|
|
|
2014-10-10 15:45:43 +00:00
|
|
|
|
for (const auto & column : getColumnsList())
|
|
|
|
|
addFile(column.name, *column.type);
|
2014-06-26 00:58:14 +00:00
|
|
|
|
|
2013-02-26 13:06:01 +00:00
|
|
|
|
marks_file = Poco::File(path + escapeForFileName(name) + '/' + DBMS_STORAGE_LOG_MARKS_FILE_NAME);
|
2012-08-29 20:07:24 +00:00
|
|
|
|
}
|
|
|
|
|
|
2014-09-30 03:08:47 +00:00
|
|
|
|
StoragePtr StorageLog::create(
|
|
|
|
|
const std::string & path_,
|
|
|
|
|
const std::string & name_,
|
|
|
|
|
NamesAndTypesListPtr columns_,
|
2014-10-03 15:30:10 +00:00
|
|
|
|
const NamesAndTypesList & materialized_columns_,
|
2014-09-30 03:08:47 +00:00
|
|
|
|
const NamesAndTypesList & alias_columns_,
|
|
|
|
|
const ColumnDefaults & column_defaults_,
|
|
|
|
|
size_t max_compress_block_size_)
|
2013-02-06 11:26:35 +00:00
|
|
|
|
{
|
2014-09-30 03:08:47 +00:00
|
|
|
|
return (new StorageLog{
|
2014-10-03 15:30:10 +00:00
|
|
|
|
path_, name_, columns_,
|
|
|
|
|
materialized_columns_, alias_columns_, column_defaults_,
|
2014-09-30 03:08:47 +00:00
|
|
|
|
max_compress_block_size_
|
|
|
|
|
})->thisPtr();
|
2013-02-06 11:26:35 +00:00
|
|
|
|
}
|
|
|
|
|
|
2014-10-23 13:53:16 +00:00
|
|
|
|
StoragePtr StorageLog::create(
|
|
|
|
|
const std::string & path_,
|
|
|
|
|
const std::string & name_,
|
|
|
|
|
NamesAndTypesListPtr columns_,
|
|
|
|
|
size_t max_compress_block_size_)
|
|
|
|
|
{
|
|
|
|
|
return (new StorageLog{
|
|
|
|
|
path_, name_, columns_,
|
2015-01-21 03:56:28 +00:00
|
|
|
|
{}, {}, ColumnDefaults{},
|
2014-10-23 13:53:16 +00:00
|
|
|
|
max_compress_block_size_
|
|
|
|
|
})->thisPtr();
|
2013-02-06 11:26:35 +00:00
|
|
|
|
}
|
|
|
|
|
|
2012-08-29 20:07:24 +00:00
|
|
|
|
|
|
|
|
|
void StorageLog::addFile(const String & column_name, const IDataType & type, size_t level)
|
|
|
|
|
{
|
|
|
|
|
if (files.end() != files.find(column_name))
|
2013-07-12 13:35:05 +00:00
|
|
|
|
throw Exception("Duplicate column with name " + column_name + " in constructor of StorageLog.",
|
2012-08-29 20:07:24 +00:00
|
|
|
|
ErrorCodes::DUPLICATE_COLUMN);
|
|
|
|
|
|
2014-06-26 00:58:14 +00:00
|
|
|
|
if (const DataTypeArray * type_arr = typeid_cast<const DataTypeArray *>(&type))
|
2010-03-18 19:32:14 +00:00
|
|
|
|
{
|
2013-06-21 20:34:19 +00:00
|
|
|
|
String size_column_suffix = ARRAY_SIZES_COLUMN_NAME_SUFFIX + toString(level);
|
2013-07-16 14:55:01 +00:00
|
|
|
|
String size_name = DataTypeNested::extractNestedTableName(column_name) + size_column_suffix;
|
2010-03-18 19:32:14 +00:00
|
|
|
|
|
2013-07-16 14:55:01 +00:00
|
|
|
|
if (files.end() == files.find(size_name))
|
|
|
|
|
{
|
|
|
|
|
ColumnData & column_data = files.insert(std::make_pair(size_name, ColumnData())).first->second;
|
|
|
|
|
column_data.column_index = column_names.size();
|
|
|
|
|
column_data.data_file = Poco::File(
|
|
|
|
|
path + escapeForFileName(name) + '/' + escapeForFileName(DataTypeNested::extractNestedTableName(column_name)) + size_column_suffix + DBMS_STORAGE_LOG_DATA_FILE_EXTENSION);
|
2014-06-26 00:58:14 +00:00
|
|
|
|
|
2013-07-16 14:55:01 +00:00
|
|
|
|
column_names.push_back(size_name);
|
|
|
|
|
}
|
2012-08-29 20:07:24 +00:00
|
|
|
|
|
|
|
|
|
addFile(column_name, *type_arr->getNestedType(), level + 1);
|
|
|
|
|
}
|
|
|
|
|
else
|
|
|
|
|
{
|
2013-02-26 13:06:01 +00:00
|
|
|
|
ColumnData & column_data = files.insert(std::make_pair(column_name, ColumnData())).first->second;
|
|
|
|
|
column_data.column_index = column_names.size();
|
|
|
|
|
column_data.data_file = Poco::File(
|
2012-08-29 20:07:24 +00:00
|
|
|
|
path + escapeForFileName(name) + '/' + escapeForFileName(column_name) + DBMS_STORAGE_LOG_DATA_FILE_EXTENSION);
|
2014-06-26 00:58:14 +00:00
|
|
|
|
|
2013-02-26 13:06:01 +00:00
|
|
|
|
column_names.push_back(column_name);
|
2012-06-21 16:33:00 +00:00
|
|
|
|
}
|
|
|
|
|
}
|
2012-01-10 22:11:51 +00:00
|
|
|
|
|
2012-06-21 16:33:00 +00:00
|
|
|
|
|
|
|
|
|
void StorageLog::loadMarks()
|
|
|
|
|
{
|
2012-11-30 04:28:13 +00:00
|
|
|
|
Poco::ScopedWriteRWLock lock(rwlock);
|
2014-06-26 00:58:14 +00:00
|
|
|
|
|
2012-06-21 16:33:00 +00:00
|
|
|
|
if (loaded_marks)
|
|
|
|
|
return;
|
2014-06-26 00:58:14 +00:00
|
|
|
|
|
2013-02-26 13:06:01 +00:00
|
|
|
|
typedef std::vector<Files_t::iterator> FilesByIndex;
|
|
|
|
|
FilesByIndex files_by_index(files.size());
|
2012-08-29 20:07:24 +00:00
|
|
|
|
for (Files_t::iterator it = files.begin(); it != files.end(); ++it)
|
2012-06-21 16:33:00 +00:00
|
|
|
|
{
|
2013-02-26 13:06:01 +00:00
|
|
|
|
files_by_index[it->second.column_index] = it;
|
|
|
|
|
}
|
2014-06-26 00:58:14 +00:00
|
|
|
|
|
2013-02-26 13:06:01 +00:00
|
|
|
|
if (marks_file.exists())
|
|
|
|
|
{
|
|
|
|
|
size_t file_size = marks_file.getSize();
|
|
|
|
|
if (file_size % (files.size() * sizeof(Mark)) != 0)
|
|
|
|
|
throw Exception("Size of marks file is inconsistent", ErrorCodes::SIZES_OF_MARKS_FILES_ARE_INCONSISTENT);
|
2014-06-26 00:58:14 +00:00
|
|
|
|
|
2013-02-26 13:06:01 +00:00
|
|
|
|
int marks_count = file_size / (files.size() * sizeof(Mark));
|
2012-06-21 16:33:00 +00:00
|
|
|
|
|
2013-02-26 13:06:01 +00:00
|
|
|
|
for (size_t i = 0; i < files_by_index.size(); ++i)
|
|
|
|
|
{
|
|
|
|
|
files_by_index[i]->second.marks.reserve(marks_count);
|
|
|
|
|
}
|
2014-06-26 00:58:14 +00:00
|
|
|
|
|
2013-02-26 13:06:01 +00:00
|
|
|
|
ReadBufferFromFile marks_rb(marks_file.path(), 32768);
|
|
|
|
|
while (!marks_rb.eof())
|
|
|
|
|
{
|
|
|
|
|
for (size_t i = 0; i < files_by_index.size(); ++i)
|
2012-01-10 22:11:51 +00:00
|
|
|
|
{
|
|
|
|
|
Mark mark;
|
|
|
|
|
readIntBinary(mark.rows, marks_rb);
|
|
|
|
|
readIntBinary(mark.offset, marks_rb);
|
2013-02-26 13:06:01 +00:00
|
|
|
|
files_by_index[i]->second.marks.push_back(mark);
|
|
|
|
|
}
|
|
|
|
|
}
|
|
|
|
|
}
|
2012-06-21 16:33:00 +00:00
|
|
|
|
|
|
|
|
|
loaded_marks = true;
|
2010-03-18 19:32:14 +00:00
|
|
|
|
}
|
|
|
|
|
|
|
|
|
|
|
2013-02-07 13:03:19 +00:00
|
|
|
|
size_t StorageLog::marksCount()
|
|
|
|
|
{
|
|
|
|
|
return files.begin()->second.marks.size();
|
|
|
|
|
}
|
|
|
|
|
|
|
|
|
|
|
2014-07-28 14:33:05 +00:00
|
|
|
|
void StorageLog::rename(const String & new_path_to_db, const String & new_database_name, const String & new_table_name)
|
2012-06-18 06:19:13 +00:00
|
|
|
|
{
|
2012-11-30 04:28:13 +00:00
|
|
|
|
Poco::ScopedWriteRWLock lock(rwlock);
|
2014-06-26 00:58:14 +00:00
|
|
|
|
|
2012-06-18 06:19:13 +00:00
|
|
|
|
/// Переименовываем директорию с данными.
|
2014-07-28 14:33:05 +00:00
|
|
|
|
Poco::File(path + escapeForFileName(name)).renameTo(new_path_to_db + escapeForFileName(new_table_name));
|
2014-06-26 00:58:14 +00:00
|
|
|
|
|
2012-06-18 06:19:13 +00:00
|
|
|
|
path = new_path_to_db;
|
2014-07-28 14:33:05 +00:00
|
|
|
|
name = new_table_name;
|
2014-08-06 13:22:52 +00:00
|
|
|
|
file_checker.setPath(path + escapeForFileName(name) + '/' + "sizes.json");
|
2012-06-18 06:19:13 +00:00
|
|
|
|
|
2012-08-29 20:07:24 +00:00
|
|
|
|
for (Files_t::iterator it = files.begin(); it != files.end(); ++it)
|
2012-06-18 06:19:13 +00:00
|
|
|
|
{
|
2013-02-26 11:47:15 +00:00
|
|
|
|
it->second.data_file = Poco::File(path + escapeForFileName(name) + '/' + Poco::Path(it->second.data_file.path()).getFileName());
|
2012-06-18 06:19:13 +00:00
|
|
|
|
}
|
2014-06-26 00:58:14 +00:00
|
|
|
|
|
2013-02-26 13:06:01 +00:00
|
|
|
|
marks_file = Poco::File(path + escapeForFileName(name) + '/' + DBMS_STORAGE_LOG_MARKS_FILE_NAME);
|
2012-06-18 06:19:13 +00:00
|
|
|
|
}
|
|
|
|
|
|
|
|
|
|
|
2013-12-12 22:55:47 +00:00
|
|
|
|
const Marks & StorageLog::getMarksWithRealRowCount() const
|
|
|
|
|
{
|
2014-07-09 11:45:51 +00:00
|
|
|
|
const String & column_name = columns->front().name;
|
|
|
|
|
const IDataType & column_type = *columns->front().type;
|
2013-12-12 22:55:47 +00:00
|
|
|
|
String file_name;
|
|
|
|
|
|
|
|
|
|
/** Засечки достаём из первого столбца.
|
|
|
|
|
* Если это - массив, то берём засечки, соответствующие размерам, а не внутренностям массивов.
|
|
|
|
|
*/
|
|
|
|
|
|
2014-06-26 00:58:14 +00:00
|
|
|
|
if (typeid_cast<const DataTypeArray *>(&column_type))
|
2013-12-12 22:55:47 +00:00
|
|
|
|
{
|
|
|
|
|
file_name = DataTypeNested::extractNestedTableName(column_name) + ARRAY_SIZES_COLUMN_NAME_SUFFIX "0";
|
|
|
|
|
}
|
|
|
|
|
else
|
|
|
|
|
{
|
|
|
|
|
file_name = column_name;
|
|
|
|
|
}
|
|
|
|
|
|
|
|
|
|
Files_t::const_iterator it = files.find(file_name);
|
|
|
|
|
if (files.end() == it)
|
|
|
|
|
throw Exception("Cannot find file " + file_name, ErrorCodes::LOGICAL_ERROR);
|
|
|
|
|
|
|
|
|
|
return it->second.marks;
|
|
|
|
|
}
|
|
|
|
|
|
|
|
|
|
|
2012-01-09 19:20:48 +00:00
|
|
|
|
BlockInputStreams StorageLog::read(
|
2013-02-07 13:03:19 +00:00
|
|
|
|
size_t from_mark,
|
|
|
|
|
size_t to_mark,
|
2011-08-09 15:57:33 +00:00
|
|
|
|
const Names & column_names,
|
2011-08-15 01:12:57 +00:00
|
|
|
|
ASTPtr query,
|
2014-12-17 11:53:17 +00:00
|
|
|
|
const Context & context,
|
2013-02-01 19:02:04 +00:00
|
|
|
|
const Settings & settings,
|
2012-05-22 18:32:45 +00:00
|
|
|
|
QueryProcessingStage::Enum & processed_stage,
|
2012-01-09 19:20:48 +00:00
|
|
|
|
size_t max_block_size,
|
2012-05-30 04:45:49 +00:00
|
|
|
|
unsigned threads)
|
2010-03-18 19:32:14 +00:00
|
|
|
|
{
|
2013-06-15 08:38:30 +00:00
|
|
|
|
/** Если читаем все данные в один поток, то засечки не требуются.
|
|
|
|
|
* Отсутствие необходимости загружать засечки позволяет уменьшить потребление памяти при использовании таблицы типа ChunkMerger.
|
|
|
|
|
*/
|
|
|
|
|
bool read_all_data_in_one_thread = (threads == 1 && from_mark == 0 && to_mark == std::numeric_limits<size_t>::max());
|
|
|
|
|
if (!read_all_data_in_one_thread)
|
|
|
|
|
loadMarks();
|
2014-06-26 00:58:14 +00:00
|
|
|
|
|
2014-01-17 15:19:20 +00:00
|
|
|
|
bool has_virtual_column = false;
|
|
|
|
|
Names real_column_names;
|
|
|
|
|
for (const auto & column : column_names)
|
|
|
|
|
if (column != _table_column_name)
|
|
|
|
|
real_column_names.push_back(column);
|
|
|
|
|
else
|
|
|
|
|
has_virtual_column = true;
|
|
|
|
|
|
|
|
|
|
/// Если есть виртуальный столбец и нет остальных, то ничего проверять не надо
|
|
|
|
|
if (!(has_virtual_column && real_column_names.size() == 0))
|
|
|
|
|
check(real_column_names);
|
|
|
|
|
|
2012-05-22 18:32:45 +00:00
|
|
|
|
processed_stage = QueryProcessingStage::FetchColumns;
|
2012-01-10 22:11:51 +00:00
|
|
|
|
|
2012-11-30 04:28:13 +00:00
|
|
|
|
Poco::ScopedReadRWLock lock(rwlock);
|
|
|
|
|
|
2012-01-10 22:11:51 +00:00
|
|
|
|
BlockInputStreams res;
|
2014-06-26 00:58:14 +00:00
|
|
|
|
|
2013-06-15 08:38:30 +00:00
|
|
|
|
if (read_all_data_in_one_thread)
|
2012-01-10 22:11:51 +00:00
|
|
|
|
{
|
|
|
|
|
res.push_back(new LogBlockInputStream(
|
|
|
|
|
max_block_size,
|
|
|
|
|
column_names,
|
2014-03-19 10:45:13 +00:00
|
|
|
|
*this,
|
2015-04-12 04:47:03 +00:00
|
|
|
|
0, std::numeric_limits<size_t>::max(),
|
|
|
|
|
settings.max_read_buffer_size));
|
2012-01-10 22:11:51 +00:00
|
|
|
|
}
|
2013-06-15 08:38:30 +00:00
|
|
|
|
else
|
|
|
|
|
{
|
2013-12-12 22:55:47 +00:00
|
|
|
|
const Marks & marks = getMarksWithRealRowCount();
|
2013-06-15 08:38:30 +00:00
|
|
|
|
size_t marks_size = marks.size();
|
|
|
|
|
|
|
|
|
|
if (to_mark == std::numeric_limits<size_t>::max())
|
|
|
|
|
to_mark = marks_size;
|
|
|
|
|
|
|
|
|
|
if (to_mark > marks_size || to_mark < from_mark)
|
|
|
|
|
throw Exception("Marks out of range in StorageLog::read", ErrorCodes::LOGICAL_ERROR);
|
|
|
|
|
|
|
|
|
|
if (threads > to_mark - from_mark)
|
|
|
|
|
threads = to_mark - from_mark;
|
|
|
|
|
|
|
|
|
|
for (size_t thread = 0; thread < threads; ++thread)
|
|
|
|
|
{
|
|
|
|
|
res.push_back(new LogBlockInputStream(
|
|
|
|
|
max_block_size,
|
|
|
|
|
column_names,
|
2014-03-19 10:45:13 +00:00
|
|
|
|
*this,
|
2013-06-15 08:38:30 +00:00
|
|
|
|
from_mark + thread * (to_mark - from_mark) / threads,
|
|
|
|
|
marks[from_mark + (thread + 1) * (to_mark - from_mark) / threads - 1].rows -
|
|
|
|
|
((thread == 0 && from_mark == 0)
|
|
|
|
|
? 0
|
2015-04-12 04:47:03 +00:00
|
|
|
|
: marks[from_mark + thread * (to_mark - from_mark) / threads - 1].rows),
|
|
|
|
|
settings.max_read_buffer_size));
|
2013-06-15 08:38:30 +00:00
|
|
|
|
}
|
|
|
|
|
}
|
|
|
|
|
|
2012-01-10 22:11:51 +00:00
|
|
|
|
return res;
|
2010-03-18 19:32:14 +00:00
|
|
|
|
}
|
|
|
|
|
|
2013-02-07 13:03:19 +00:00
|
|
|
|
|
|
|
|
|
BlockInputStreams StorageLog::read(
|
|
|
|
|
const Names & column_names,
|
|
|
|
|
ASTPtr query,
|
2014-12-17 11:53:17 +00:00
|
|
|
|
const Context & context,
|
2013-02-07 13:03:19 +00:00
|
|
|
|
const Settings & settings,
|
|
|
|
|
QueryProcessingStage::Enum & processed_stage,
|
2014-12-17 11:53:17 +00:00
|
|
|
|
const size_t max_block_size,
|
|
|
|
|
const unsigned threads)
|
2013-02-07 13:03:19 +00:00
|
|
|
|
{
|
2014-12-17 11:53:17 +00:00
|
|
|
|
return read(0, std::numeric_limits<size_t>::max(), column_names,
|
|
|
|
|
query, context, settings, processed_stage,
|
|
|
|
|
max_block_size, threads);
|
2013-02-07 13:03:19 +00:00
|
|
|
|
}
|
|
|
|
|
|
2013-02-11 08:53:34 +00:00
|
|
|
|
|
2011-08-28 02:22:23 +00:00
|
|
|
|
BlockOutputStreamPtr StorageLog::write(
|
2011-08-15 01:12:57 +00:00
|
|
|
|
ASTPtr query)
|
2010-03-18 19:32:14 +00:00
|
|
|
|
{
|
2012-06-21 16:33:00 +00:00
|
|
|
|
loadMarks();
|
2014-03-19 10:45:13 +00:00
|
|
|
|
return new LogBlockOutputStream(*this);
|
2010-03-18 19:32:14 +00:00
|
|
|
|
}
|
|
|
|
|
|
2014-08-04 06:36:24 +00:00
|
|
|
|
bool StorageLog::checkData() const
|
|
|
|
|
{
|
2014-08-04 11:17:05 +00:00
|
|
|
|
Poco::ScopedReadRWLock lock(const_cast<Poco::RWLock &>(rwlock));
|
|
|
|
|
|
2014-08-05 12:50:20 +00:00
|
|
|
|
return file_checker.check();
|
2014-08-04 06:36:24 +00:00
|
|
|
|
}
|
2011-11-05 23:31:19 +00:00
|
|
|
|
|
2010-03-18 19:32:14 +00:00
|
|
|
|
}
|