ClickHouse/dbms/src/Databases/DatabaseAtomic.cpp

302 lines
11 KiB
C++
Raw Normal View History

2019-10-23 13:46:38 +00:00
#include <Databases/DatabaseAtomic.h>
2019-10-30 12:17:52 +00:00
#include <Databases/DatabaseOnDisk.h>
2019-11-11 11:34:03 +00:00
#include <Poco/File.h>
#include <IO/ReadHelpers.h>
#include <IO/WriteHelpers.h>
2020-01-23 19:10:09 +00:00
#include <Common/Stopwatch.h>
2020-01-27 20:31:39 +00:00
#include <Parsers/formatAST.h>
2019-10-23 13:46:38 +00:00
namespace DB
{
2019-11-11 11:34:03 +00:00
namespace ErrorCodes
{
extern const int UNKNOWN_TABLE;
extern const int TABLE_ALREADY_EXISTS;
2019-11-11 14:28:28 +00:00
extern const int FILE_DOESNT_EXIST;
2020-01-27 20:31:39 +00:00
extern const int DATABASE_NOT_EMPTY;
2019-11-11 11:34:03 +00:00
}
2019-10-23 13:46:38 +00:00
2020-01-22 11:30:11 +00:00
DatabaseAtomic::DatabaseAtomic(String name_, String metadata_path_, Context & context_)
2019-10-23 13:46:38 +00:00
: DatabaseOrdinary(name_, metadata_path_, context_)
{
2019-11-11 11:34:03 +00:00
data_path = "store/";
2020-01-22 11:30:11 +00:00
auto log_name = "DatabaseAtomic (" + name_ + ")";
log = &Logger::get(log_name);
drop_task = context_.getSchedulePool().createTask(log_name, [this](){ this->dropTableDataTask(); });
2019-11-11 11:34:03 +00:00
}
String DatabaseAtomic::getTableDataPath(const String & table_name) const
2019-11-11 11:34:03 +00:00
{
2019-12-02 19:11:18 +00:00
std::lock_guard lock(mutex);
2019-11-11 11:34:03 +00:00
auto it = table_name_to_path.find(table_name);
if (it == table_name_to_path.end())
throw Exception("Table " + table_name + " not found in database " + getDatabaseName(), ErrorCodes::UNKNOWN_TABLE);
2020-01-16 18:13:18 +00:00
assert(it->second != data_path && !it->second.empty());
return it->second;
2019-11-11 11:34:03 +00:00
}
String DatabaseAtomic::getTableDataPath(const ASTCreateQuery & query) const
2019-11-11 11:34:03 +00:00
{
//stringToUUID(query.uuid); /// Check UUID is valid
2019-11-11 11:34:03 +00:00
const size_t uuid_prefix_len = 3;
2020-01-16 18:13:18 +00:00
auto tmp = data_path + toString(query.uuid).substr(0, uuid_prefix_len) + '/' + toString(query.uuid) + '/';
assert(tmp != data_path && !tmp.empty());
return tmp;
2019-11-11 11:34:03 +00:00
}
void DatabaseAtomic::drop(const Context &)
{
2020-01-27 20:31:39 +00:00
//constexpr size_t max_attempts = 5;
//for (size_t i = 0; i < max_attempts; ++i)
//{
// auto it = tables_to_drop.begin();
// while (it != tables_to_drop.end())
// {
// if (it->table.unique())
// {
// /// No queries use table, it can be safely dropped
// dropTableFinally(*it);
// it = tables_to_drop.erase(it);
// }
// ++it;
// }
//
// if (tables_to_drop.empty())
// {
// Poco::File(getMetadataPath()).remove(false);
// return;
// }
//}
//throw Exception("Cannot drop database", ErrorCodes::TABLE_WAS_NOT_DROPPED);
/// IDatabase::drop() is called under global context lock (TODO can it be fixed?)
auto it = std::find_if(tables_to_drop.begin(), tables_to_drop.end(), [](const TableToDrop & elem)
{
return !elem.table.unique();
});
if (it != tables_to_drop.end())
throw Exception("Cannot drop database " + getDatabaseName() +
". It contains table " + it->table->getStorageID().getNameForLogs() +
", which is used by " + std::to_string(it->table.use_count() - 1) + " queries. "
"Client should retry later.", ErrorCodes::DATABASE_NOT_EMPTY);
2020-03-17 23:51:35 +00:00
//FIXME maybe make `tables_to_drop` global for all Atomic databases?
//for (auto & table : tables_to_drop)
//{
// try
// {
// /// IStorage::drop() may use DatabaseCatalog, so databases mutex will be acquired (possible deadlock here)
// dropTableFinally(table);
// }
// catch (...)
// {
// tryLogCurrentException(log, "Cannot drop table. Metadata " + table.data_path + " will be removed forcefully. "
// "Garbage may be left in /store directory and ZooKeeper.");
// }
//}
2020-01-27 20:31:39 +00:00
Poco::File(getMetadataPath()).remove(true);
2019-11-11 11:34:03 +00:00
}
void DatabaseAtomic::attachTable(const String & name, const StoragePtr & table, const String & relative_table_path)
{
2020-01-16 18:13:18 +00:00
assert(relative_table_path != data_path && !relative_table_path.empty());
2019-11-11 11:34:03 +00:00
DatabaseWithDictionaries::attachTable(name, table, relative_table_path);
std::lock_guard lock(mutex);
2019-12-02 19:11:18 +00:00
table_name_to_path.emplace(std::make_pair(name, relative_table_path));
2019-10-23 13:46:38 +00:00
}
2019-11-11 11:34:03 +00:00
StoragePtr DatabaseAtomic::detachTable(const String & name)
{
{
std::lock_guard lock(mutex);
table_name_to_path.erase(name);
}
return DatabaseWithDictionaries::detachTable(name);
}
2019-10-23 13:46:38 +00:00
2020-01-22 11:30:11 +00:00
void DatabaseAtomic::dropTable(const Context & context, const String & table_name)
{
String table_metadata_path = getObjectMetadataPath(table_name);
String table_metadata_path_drop = table_metadata_path + drop_suffix;
String table_data_path_relative = getTableDataPath(table_name);
assert(!table_data_path_relative.empty());
StoragePtr table = detachTable(table_name);
try
{
// FIXME
// 1. CREATE table_name: + table_name.sql
// 2. DROP table_name: table_name.sql -> table_name.sql.tmp_drop
// 3. CREATE table_name: + table_name.sql
2020-01-23 19:10:09 +00:00
// 4. DROP table_name: table_name.sql -> table_name.sql.tmp_drop overwrites table_name.sql.tmp_drop
2020-01-22 11:30:11 +00:00
Poco::File(table_metadata_path).renameTo(table_metadata_path_drop);
{
LOG_INFO(log, "Mark table " + table->getStorageID().getNameForLogs() + " to drop.");
2020-01-28 19:39:52 +00:00
/// Context:getPath acquires lock
2020-03-18 17:38:52 +00:00
auto table_data_path = context.getPath() + table_data_path_relative;
2020-01-22 11:30:11 +00:00
std::lock_guard lock(tables_to_drop_mutex);
time_t current_time = std::chrono::system_clock::to_time_t(std::chrono::system_clock::now());
2020-03-18 17:38:52 +00:00
tables_to_drop.push_back({table, table_data_path, current_time});
2020-01-22 11:30:11 +00:00
}
}
catch (...)
{
LOG_WARNING(log, getCurrentExceptionMessage(__PRETTY_FUNCTION__));
attachTable(table_name, table, table_data_path_relative);
Poco::File(table_metadata_path_drop).renameTo(table_metadata_path);
throw;
}
}
2019-11-11 14:28:28 +00:00
void DatabaseAtomic::renameTable(const Context & context, const String & table_name, IDatabase & to_database,
2019-12-02 19:11:18 +00:00
const String & to_table_name)
2019-11-11 14:28:28 +00:00
{
if (typeid(*this) != typeid(to_database))
2019-12-02 19:11:18 +00:00
{
if (!typeid_cast<DatabaseOrdinary *>(&to_database))
throw Exception("Moving tables between databases of different engines is not supported", ErrorCodes::NOT_IMPLEMENTED);
/// Allow moving tables from Atomic to Ordinary (with table lock)
DatabaseOnDisk::renameTable(context, table_name, to_database, to_table_name);
return;
}
2019-11-11 14:28:28 +00:00
StoragePtr table = tryGetTable(context, table_name);
if (!table)
throw Exception("Table " + backQuote(getDatabaseName()) + "." + backQuote(table_name) + " doesn't exist.", ErrorCodes::UNKNOWN_TABLE);
2019-12-02 19:11:18 +00:00
/// Update database and table name in memory without moving any data on disk
2019-11-11 14:28:28 +00:00
table->renameInMemory(to_database.getDatabaseName(), to_table_name);
/// NOTE Non-atomic.
2020-03-17 23:51:35 +00:00
auto path = getTableDataPath(table_name);
2019-12-02 19:11:18 +00:00
detachTable(table_name);
Poco::File(getObjectMetadataPath(table_name)).renameTo(to_database.getObjectMetadataPath(to_table_name));
2020-03-17 23:51:35 +00:00
to_database.attachTable(to_table_name, table, path);
2019-11-11 14:28:28 +00:00
}
2020-01-22 11:30:11 +00:00
void DatabaseAtomic::loadStoredObjects(Context & context, bool has_force_restore_data_flag)
{
2020-01-23 19:10:09 +00:00
iterateMetadataFiles(context, [](const String &) {}, [&](const String & file_name)
{
2020-01-27 20:31:39 +00:00
/// Process .sql.tmp_drop files with metadata of partially dropped tables
2020-01-23 19:10:09 +00:00
String full_path = getMetadataPath() + file_name;
LOG_INFO(log, "Trying load partially dropped table from " << full_path);
2020-01-27 20:31:39 +00:00
ASTPtr ast;
const ASTCreateQuery * create = nullptr;
2020-01-23 19:10:09 +00:00
try
{
2020-01-27 20:31:39 +00:00
ast = parseQueryFromMetadata(context, full_path, /*throw_on_error*/ false, /*remove_empty*/false);
create = typeid_cast<ASTCreateQuery *>(ast.get());
if (!create || create->uuid == UUIDHelpers::Nil)
{
LOG_WARNING(log, "Cannot parse metadata of partially dropped table from " << full_path
<< ". Removing metadata. Garbage may be left in /store directory and ZooKeeper.");
if (Poco::File(full_path).exists())
Poco::File(full_path).remove();
2020-01-23 19:10:09 +00:00
return;
2020-01-27 20:31:39 +00:00
}
auto [_, table] = createTableFromAST(*create, database_name, getTableDataPath(*create), context, has_force_restore_data_flag);
2020-01-23 19:10:09 +00:00
time_t drop_time = Poco::File(full_path).getLastModified().epochTime();
2020-01-27 20:31:39 +00:00
tables_to_drop.push_back({table, context.getPath() + getTableDataPath(*create), drop_time});
2020-01-23 19:10:09 +00:00
}
2020-01-27 20:31:39 +00:00
catch (...)
2020-01-23 19:10:09 +00:00
{
2020-01-27 20:31:39 +00:00
if (!create)
throw;
auto table_data_relative_path = getTableDataPath(*create);
if (table_data_relative_path.empty())
throw;
Poco::File table_data{context.getPath() + table_data_relative_path};
tryLogCurrentException(log, "Cannot load partially dropped table from: " + full_path +
". Parsed query: " + serializeAST(*create) +
". Removing metadata and " + table_data.path() +
". Garbage may be left in ZooKeeper.");
if (table_data.exists())
table_data.remove(true);
Poco::File{full_path}.remove();
2020-01-23 19:10:09 +00:00
}
});
2020-01-22 11:30:11 +00:00
DatabaseOrdinary::loadStoredObjects(context, has_force_restore_data_flag);
drop_task->activateAndSchedule();
}
void DatabaseAtomic::shutdown()
{
drop_task->deactivate();
DatabaseWithDictionaries::shutdown();
}
void DatabaseAtomic::dropTableDataTask()
{
LOG_INFO(log, String("Wake up ") + __PRETTY_FUNCTION__);
TableToDrop table;
try
{
std::lock_guard lock(tables_to_drop_mutex);
LOG_INFO(log, "There are " + std::to_string(tables_to_drop.size()) + " tables to drop");
time_t current_time = std::chrono::system_clock::to_time_t(std::chrono::system_clock::now());
auto it = std::find_if(tables_to_drop.begin(), tables_to_drop.end(), [current_time, this](const TableToDrop & elem)
{
LOG_INFO(log, "Check table " + elem.table->getStorageID().getNameForLogs() + ": " +
"refcount = " + std::to_string(elem.table.unique()) + ", " +
"time elapsed = " + std::to_string(current_time - elem.drop_time));
return elem.table.unique() && elem.drop_time + drop_delay_s < current_time;
});
if (it != tables_to_drop.end())
{
table = std::move(*it);
LOG_INFO(log, "Will try drop " + table.table->getStorageID().getNameForLogs());
tables_to_drop.erase(it);
}
}
catch (...)
{
tryLogCurrentException(log, __PRETTY_FUNCTION__);
}
if (table.table)
{
try
{
2020-01-27 20:31:39 +00:00
dropTableFinally(table);
2020-01-22 11:30:11 +00:00
}
catch (...)
{
tryLogCurrentException(log, "Cannot drop table " + table.table->getStorageID().getNameForLogs() +
". Will retry later.");
{
std::lock_guard lock(tables_to_drop_mutex);
tables_to_drop.emplace_back(std::move(table));
}
}
}
drop_task->scheduleAfter(reschedule_time_ms);
}
2020-01-27 20:31:39 +00:00
void DatabaseAtomic::dropTableFinally(const DatabaseAtomic::TableToDrop & table) const
{
LOG_INFO(log, "Trying to drop table " + table.table->getStorageID().getNameForLogs());
table.table->drop();
table.table->is_dropped = true;
Poco::File table_data_dir{table.data_path};
if (table_data_dir.exists())
table_data_dir.remove(true);
String metadata_tmp_drop = getObjectMetadataPath(table.table->getStorageID().getTableName()) + drop_suffix;
Poco::File(metadata_tmp_drop).remove();
}
2019-10-23 13:46:38 +00:00
}