2022-08-31 12:53:26 +00:00
|
|
|
#include <Interpreters/TemporaryDataOnDisk.h>
|
|
|
|
|
2022-08-31 17:17:31 +00:00
|
|
|
#include <IO/WriteBufferFromFile.h>
|
|
|
|
#include <IO/ReadBufferFromFile.h>
|
|
|
|
#include <Compression/CompressedWriteBuffer.h>
|
|
|
|
#include <Compression/CompressedReadBuffer.h>
|
|
|
|
#include <Formats/NativeWriter.h>
|
|
|
|
#include <Formats/NativeReader.h>
|
2022-09-01 12:22:49 +00:00
|
|
|
#include <Core/ProtocolDefines.h>
|
|
|
|
|
|
|
|
#include <Common/logger_useful.h>
|
2022-08-31 12:53:26 +00:00
|
|
|
|
|
|
|
namespace DB
|
|
|
|
{
|
2022-09-01 12:22:49 +00:00
|
|
|
|
2022-08-31 12:53:26 +00:00
|
|
|
namespace ErrorCodes
|
|
|
|
{
|
2022-09-21 12:51:46 +00:00
|
|
|
extern const int TOO_MANY_ROWS_OR_BYTES;
|
2022-08-31 17:17:31 +00:00
|
|
|
extern const int LOGICAL_ERROR;
|
2022-09-01 12:22:49 +00:00
|
|
|
extern const int NOT_ENOUGH_SPACE;
|
2022-08-31 12:53:26 +00:00
|
|
|
}
|
|
|
|
|
2022-09-21 12:51:46 +00:00
|
|
|
void TemporaryDataOnDiskScope::deltaAllocAndCheck(int compressed_delta, int uncompressed_delta)
|
2022-08-31 12:53:26 +00:00
|
|
|
{
|
|
|
|
if (parent)
|
2022-09-21 12:51:46 +00:00
|
|
|
parent->deltaAllocAndCheck(compressed_delta, uncompressed_delta);
|
|
|
|
|
2022-08-31 12:53:26 +00:00
|
|
|
|
2022-09-21 12:51:46 +00:00
|
|
|
/// check that we don't go negative
|
|
|
|
if ((compressed_delta < 0 && stat.compressed_size < static_cast<size_t>(-compressed_delta)) ||
|
|
|
|
(uncompressed_delta < 0 && stat.uncompressed_size < static_cast<size_t>(-uncompressed_delta)))
|
|
|
|
{
|
|
|
|
throw Exception(ErrorCodes::LOGICAL_ERROR, "Negative temporary data size");
|
|
|
|
}
|
|
|
|
|
|
|
|
size_t new_consumprion = stat.compressed_size + compressed_delta;
|
|
|
|
if (compressed_delta > 0 && limit && new_consumprion > limit)
|
|
|
|
throw Exception(ErrorCodes::TOO_MANY_ROWS_OR_BYTES, "Limit for temporary files size exceeded");
|
|
|
|
|
|
|
|
stat.compressed_size += compressed_delta;
|
|
|
|
stat.uncompressed_size += uncompressed_delta;
|
2022-08-31 12:53:26 +00:00
|
|
|
}
|
|
|
|
|
2022-09-01 12:22:49 +00:00
|
|
|
TemporaryFileStream & TemporaryDataOnDisk::createStream(const Block & header, CurrentMetrics::Value metric_scope, size_t reserve_size)
|
2022-08-31 12:53:26 +00:00
|
|
|
{
|
|
|
|
DiskPtr disk = nullptr;
|
|
|
|
ReservationPtr reservation = nullptr;
|
2022-08-31 17:17:31 +00:00
|
|
|
if (reserve_size > 0)
|
2022-08-31 12:53:26 +00:00
|
|
|
{
|
2022-09-01 12:22:49 +00:00
|
|
|
reservation = volume->reserve(reserve_size);
|
2022-08-31 12:53:26 +00:00
|
|
|
if (!reservation)
|
|
|
|
throw Exception("Not enough space on temporary disk", ErrorCodes::NOT_ENOUGH_SPACE);
|
|
|
|
disk = reservation->getDisk();
|
|
|
|
}
|
|
|
|
else
|
|
|
|
{
|
|
|
|
disk = volume->getDisk();
|
|
|
|
}
|
|
|
|
|
2022-09-01 12:22:49 +00:00
|
|
|
auto tmp_file = std::make_unique<TemporaryFileOnDisk>(disk, metric_scope);
|
2022-09-15 10:19:39 +00:00
|
|
|
|
|
|
|
std::lock_guard lock(mutex);
|
2022-09-21 12:51:46 +00:00
|
|
|
TemporaryFileStreamPtr & tmp_stream = streams.emplace_back(std::make_unique<TemporaryFileStream>(std::move(tmp_file), header, this));
|
2022-08-31 17:17:31 +00:00
|
|
|
return *tmp_stream;
|
2022-08-31 12:53:26 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
|
2022-09-15 10:19:39 +00:00
|
|
|
std::vector<TemporaryFileStream *> TemporaryDataOnDisk::getStreams()
|
|
|
|
{
|
|
|
|
std::vector<TemporaryFileStream *> res;
|
|
|
|
std::lock_guard lock(mutex);
|
|
|
|
for (auto & stream : streams)
|
|
|
|
res.push_back(stream.get());
|
|
|
|
return res;
|
|
|
|
}
|
|
|
|
|
2022-09-21 12:51:46 +00:00
|
|
|
bool TemporaryDataOnDisk::empty() const
|
|
|
|
{
|
|
|
|
std::lock_guard lock(mutex);
|
|
|
|
return streams.empty();
|
|
|
|
}
|
|
|
|
|
2022-08-31 12:53:26 +00:00
|
|
|
struct TemporaryFileStream::OutputWriter
|
|
|
|
{
|
2022-09-15 10:19:39 +00:00
|
|
|
OutputWriter(const String & path, const Block & header_)
|
2022-08-31 12:53:26 +00:00
|
|
|
: out_file_buf(path)
|
|
|
|
, out_compressed_buf(out_file_buf)
|
2022-09-15 10:19:39 +00:00
|
|
|
, out_writer(out_compressed_buf, DBMS_TCP_PROTOCOL_VERSION, header_)
|
2022-08-31 12:53:26 +00:00
|
|
|
{
|
|
|
|
}
|
|
|
|
|
|
|
|
void write(const Block & block)
|
|
|
|
{
|
|
|
|
if (finalized)
|
|
|
|
throw Exception("Cannot write to finalized stream", ErrorCodes::LOGICAL_ERROR);
|
|
|
|
out_writer.write(block);
|
|
|
|
}
|
|
|
|
|
|
|
|
|
|
|
|
void finalize()
|
|
|
|
{
|
|
|
|
if (finalized)
|
|
|
|
return;
|
2022-09-21 12:51:46 +00:00
|
|
|
|
|
|
|
/// if we called finalize() explicitly, and got an exception,
|
|
|
|
/// we don't want to get it again in the destructor, so set finalized flag first
|
2022-09-14 11:21:25 +00:00
|
|
|
finalized = true;
|
2022-09-21 12:51:46 +00:00
|
|
|
|
|
|
|
out_writer.flush();
|
|
|
|
out_compressed_buf.finalize();
|
|
|
|
out_file_buf.finalize();
|
2022-08-31 12:53:26 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
~OutputWriter()
|
|
|
|
{
|
|
|
|
try
|
|
|
|
{
|
|
|
|
finalize();
|
|
|
|
}
|
|
|
|
catch (...)
|
|
|
|
{
|
|
|
|
tryLogCurrentException(__PRETTY_FUNCTION__);
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
WriteBufferFromFile out_file_buf;
|
|
|
|
CompressedWriteBuffer out_compressed_buf;
|
|
|
|
NativeWriter out_writer;
|
|
|
|
|
|
|
|
bool finalized = false;
|
|
|
|
};
|
|
|
|
|
|
|
|
struct TemporaryFileStream::InputReader
|
|
|
|
{
|
2022-09-15 10:19:39 +00:00
|
|
|
InputReader(const String & path, const Block & header_)
|
|
|
|
: in_file_buf(path)
|
|
|
|
, in_compressed_buf(in_file_buf)
|
|
|
|
, in_reader(in_compressed_buf, header_, DBMS_TCP_PROTOCOL_VERSION)
|
|
|
|
{
|
|
|
|
}
|
|
|
|
|
|
|
|
explicit InputReader(const String & path)
|
2022-08-31 12:53:26 +00:00
|
|
|
: in_file_buf(path)
|
|
|
|
, in_compressed_buf(in_file_buf)
|
2022-09-15 10:19:39 +00:00
|
|
|
, in_reader(in_compressed_buf, DBMS_TCP_PROTOCOL_VERSION)
|
|
|
|
{
|
|
|
|
}
|
2022-08-31 17:17:31 +00:00
|
|
|
|
|
|
|
Block read() { return in_reader.read(); }
|
2022-08-31 12:53:26 +00:00
|
|
|
|
|
|
|
ReadBufferFromFile in_file_buf;
|
|
|
|
CompressedReadBuffer in_compressed_buf;
|
|
|
|
NativeReader in_reader;
|
|
|
|
};
|
|
|
|
|
2022-09-15 10:19:39 +00:00
|
|
|
TemporaryFileStream::TemporaryFileStream(TemporaryFileOnDiskHolder file_, const Block & header_, TemporaryDataOnDisk * parent_)
|
2022-08-31 17:17:31 +00:00
|
|
|
: parent(parent_)
|
2022-09-15 10:19:39 +00:00
|
|
|
, header(header_)
|
2022-09-01 12:22:49 +00:00
|
|
|
, file(std::move(file_))
|
2022-08-31 17:17:31 +00:00
|
|
|
, out_writer(std::make_unique<OutputWriter>(file->path(), header))
|
|
|
|
{
|
|
|
|
}
|
|
|
|
|
|
|
|
void TemporaryFileStream::write(const Block & block)
|
|
|
|
{
|
|
|
|
if (!out_writer)
|
2022-09-02 14:33:54 +00:00
|
|
|
throw Exception("Writing has been finished", ErrorCodes::LOGICAL_ERROR);
|
2022-08-31 17:17:31 +00:00
|
|
|
|
2022-09-21 12:51:46 +00:00
|
|
|
updateAllocAndCheck();
|
2022-08-31 17:17:31 +00:00
|
|
|
out_writer->write(block);
|
|
|
|
}
|
|
|
|
|
2022-09-21 13:04:43 +00:00
|
|
|
TemporaryFileStream::Stat TemporaryFileStream::finishWriting(bool use_header)
|
2022-08-31 17:17:31 +00:00
|
|
|
{
|
|
|
|
if (out_writer)
|
|
|
|
{
|
|
|
|
out_writer->finalize();
|
2022-09-21 12:51:46 +00:00
|
|
|
/// The amount of written data can be changed after finalization, some buffers can be flushed
|
|
|
|
/// Need to update the stat
|
|
|
|
updateAllocAndCheck();
|
2022-09-01 12:22:49 +00:00
|
|
|
out_writer.reset();
|
2022-08-31 17:17:31 +00:00
|
|
|
|
2022-09-21 13:04:43 +00:00
|
|
|
/// TODO: workaround to make aggregation work
|
|
|
|
/// For some reason NativeReader constuctors behave differently ?
|
|
|
|
if (use_header)
|
|
|
|
in_reader = std::make_unique<InputReader>(file->path(), header);
|
|
|
|
else
|
|
|
|
in_reader = std::make_unique<InputReader>(file->path());
|
2022-08-31 17:17:31 +00:00
|
|
|
}
|
2022-09-15 10:19:39 +00:00
|
|
|
return stat;
|
2022-08-31 17:17:31 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
bool TemporaryFileStream::isWriteFinished() const
|
|
|
|
{
|
2022-09-21 12:51:46 +00:00
|
|
|
assert((out_writer == nullptr) ^ (in_reader == nullptr));
|
2022-08-31 17:17:31 +00:00
|
|
|
return out_writer == nullptr;
|
|
|
|
}
|
|
|
|
|
|
|
|
Block TemporaryFileStream::read()
|
|
|
|
{
|
2022-09-21 12:51:46 +00:00
|
|
|
if (!isWriteFinished())
|
|
|
|
throw Exception(ErrorCodes::LOGICAL_ERROR, "Writing has been not finished");
|
2022-08-31 17:17:31 +00:00
|
|
|
|
|
|
|
return in_reader->read();
|
|
|
|
}
|
|
|
|
|
2022-09-21 12:51:46 +00:00
|
|
|
void TemporaryFileStream::updateAllocAndCheck()
|
2022-09-01 12:22:49 +00:00
|
|
|
{
|
2022-09-14 11:21:25 +00:00
|
|
|
assert(out_writer);
|
2022-09-01 12:22:49 +00:00
|
|
|
size_t new_compressed_size = out_writer->out_compressed_buf.getCompressedBytes();
|
|
|
|
size_t new_uncompressed_size = out_writer->out_compressed_buf.getUncompressedBytes();
|
|
|
|
|
2022-09-15 10:19:39 +00:00
|
|
|
if (unlikely(new_compressed_size < stat.compressed_size || new_uncompressed_size < stat.uncompressed_size))
|
2022-09-01 12:22:49 +00:00
|
|
|
{
|
2022-09-21 12:51:46 +00:00
|
|
|
throw Exception(ErrorCodes::LOGICAL_ERROR,
|
2022-09-01 12:22:49 +00:00
|
|
|
"Temporary file {} size decreased after write: compressed: {} -> {}, uncompressed: {} -> {}",
|
2022-09-15 10:19:39 +00:00
|
|
|
file->path(), new_compressed_size, stat.compressed_size, new_uncompressed_size, stat.uncompressed_size);
|
2022-09-01 12:22:49 +00:00
|
|
|
}
|
|
|
|
|
2022-09-21 12:51:46 +00:00
|
|
|
parent->deltaAllocAndCheck(new_compressed_size - stat.compressed_size, new_uncompressed_size - stat.uncompressed_size);
|
2022-09-15 10:19:39 +00:00
|
|
|
stat.compressed_size = new_compressed_size;
|
|
|
|
stat.uncompressed_size = new_uncompressed_size;
|
2022-09-01 12:22:49 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
TemporaryFileStream::~TemporaryFileStream()
|
2022-08-31 17:17:31 +00:00
|
|
|
{
|
|
|
|
try
|
|
|
|
{
|
2022-09-21 12:51:46 +00:00
|
|
|
parent->deltaAllocAndCheck(-stat.compressed_size, -stat.uncompressed_size);
|
2022-08-31 17:17:31 +00:00
|
|
|
}
|
|
|
|
catch (...)
|
|
|
|
{
|
|
|
|
tryLogCurrentException(__PRETTY_FUNCTION__);
|
2022-09-21 12:51:46 +00:00
|
|
|
assert(false); /// deltaAllocAndCheck with negative can't throw exception
|
2022-08-31 17:17:31 +00:00
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2022-08-31 12:53:26 +00:00
|
|
|
}
|