blob: 324d9a968839f389092cd7282dcf20b8ef8b51c6 [file] [log] [blame]
// Licensed to the Apache Software Foundation (ASF) under one
// or more contributor license agreements. See the NOTICE file
// distributed with this work for additional information
// regarding copyright ownership. The ASF licenses this file
// to you under the Apache License, Version 2.0 (the
// "License"); you may not use this file except in compliance
// with the License. You may obtain a copy of the License at
//
// http://www.apache.org/licenses/LICENSE-2.0
//
// Unless required by applicable law or agreed to in writing,
// software distributed under the License is distributed on an
// "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
// KIND, either express or implied. See the License for the
// specific language governing permissions and limitations
// under the License.
#include "http/action/compaction_action.h"
// IWYU pragma: no_include <bits/chrono.h>
#include <chrono> // IWYU pragma: keep
#include <exception>
#include <future>
#include <memory>
#include <mutex>
#include <sstream>
#include <string>
#include <thread>
#include <utility>
#include "absl/strings/substitute.h"
#include "common/logging.h"
#include "common/status.h"
#include "http/http_channel.h"
#include "http/http_headers.h"
#include "http/http_request.h"
#include "http/http_status.h"
#include "olap/base_compaction.h"
#include "olap/cumulative_compaction.h"
#include "olap/cumulative_compaction_policy.h"
#include "olap/cumulative_compaction_time_series_policy.h"
#include "olap/full_compaction.h"
#include "olap/olap_define.h"
#include "olap/single_replica_compaction.h"
#include "olap/storage_engine.h"
#include "olap/tablet_manager.h"
#include "util/doris_metrics.h"
#include "util/stopwatch.hpp"
namespace doris {
using namespace ErrorCode;
namespace {
constexpr std::string_view HEADER_JSON = "application/json";
} // namespace
CompactionAction::CompactionAction(CompactionActionType ctype, ExecEnv* exec_env,
StorageEngine& engine, TPrivilegeHier::type hier,
TPrivilegeType::type ptype)
: HttpHandlerWithAuth(exec_env, hier, ptype), _engine(engine), _compaction_type(ctype) {}
/// check param and fetch tablet_id & table_id from req
static Status _check_param(HttpRequest* req, uint64_t* tablet_id, uint64_t* table_id) {
// req tablet id and table id, we have to set only one of them.
const auto& req_tablet_id = req->param(TABLET_ID_KEY);
const auto& req_table_id = req->param(TABLE_ID_KEY);
if (req_tablet_id.empty()) {
if (req_table_id.empty()) {
// both tablet id and table id are empty, return error.
return Status::InternalError(
"tablet id and table id can not be empty at the same time!");
} else {
try {
*table_id = std::stoull(req_table_id);
} catch (const std::exception& e) {
return Status::InternalError("convert table_id failed, {}", e.what());
}
return Status::OK();
}
} else if (req_table_id.empty()) {
try {
*tablet_id = std::stoull(req_tablet_id);
} catch (const std::exception& e) {
return Status::InternalError("convert tablet_id failed, {}", e.what());
}
return Status::OK();
} else {
// both tablet id and table id are not empty, return err.
return Status::InternalError("tablet id and table id can not be set at the same time!");
}
}
/// retrieve specific id from req
static Status _check_param(HttpRequest* req, uint64_t* id_param, const std::string param_name) {
const auto& req_id_param = req->param(param_name);
if (!req_id_param.empty()) {
try {
*id_param = std::stoull(req_id_param);
} catch (const std::exception& e) {
return Status::InternalError("convert {} failed, {}", param_name, e.what());
}
}
return Status::OK();
}
// for viewing the compaction status
Status CompactionAction::_handle_show_compaction(HttpRequest* req, std::string* json_result) {
uint64_t tablet_id = 0;
// check & retrieve tablet_id from req if it contains
RETURN_NOT_OK_STATUS_WITH_WARN(_check_param(req, &tablet_id, TABLET_ID_KEY),
"check param failed");
if (tablet_id == 0) {
return Status::InternalError("check param failed: missing tablet_id");
}
TabletSharedPtr tablet = _engine.tablet_manager()->get_tablet(tablet_id);
if (tablet == nullptr) {
return Status::NotFound("Tablet not found. tablet_id={}", tablet_id);
}
tablet->get_compaction_status(json_result);
return Status::OK();
}
Status CompactionAction::_handle_run_compaction(HttpRequest* req, std::string* json_result) {
// 1. param check
// check req_tablet_id or req_table_id is not empty and can not be set together.
uint64_t tablet_id = 0;
uint64_t table_id = 0;
RETURN_NOT_OK_STATUS_WITH_WARN(_check_param(req, &tablet_id, &table_id), "check param failed");
// check compaction_type equals 'base' or 'cumulative'
std::string compaction_type = req->param(PARAM_COMPACTION_TYPE);
if (compaction_type != PARAM_COMPACTION_BASE &&
compaction_type != PARAM_COMPACTION_CUMULATIVE &&
compaction_type != PARAM_COMPACTION_FULL) {
return Status::NotSupported("The compaction type '{}' is not supported", compaction_type);
}
// "remote" = "true" means tablet should do single replica compaction to fetch rowset from peer
bool fetch_from_remote = false;
std::string param_remote = req->param(PARAM_COMPACTION_REMOTE);
if (param_remote == "true") {
fetch_from_remote = true;
} else if (!param_remote.empty() && param_remote != "false") {
return Status::NotSupported("The remote = '{}' is not supported", param_remote);
}
if (tablet_id == 0 && table_id != 0) {
std::vector<TabletSharedPtr> tablet_vec = _engine.tablet_manager()->get_all_tablet(
[table_id](Tablet* tablet) -> bool { return tablet->get_table_id() == table_id; });
for (const auto& tablet : tablet_vec) {
tablet->set_last_full_compaction_schedule_time(UnixMillis());
RETURN_IF_ERROR(
_engine.submit_compaction_task(tablet, CompactionType::FULL_COMPACTION, false));
}
} else {
// 2. fetch the tablet by tablet_id
TabletSharedPtr tablet = _engine.tablet_manager()->get_tablet(tablet_id);
if (tablet == nullptr) {
return Status::NotFound("Tablet not found. tablet_id={}", tablet_id);
}
if (fetch_from_remote && !tablet->should_fetch_from_peer()) {
return Status::NotSupported("tablet should do compaction locally");
}
DBUG_EXECUTE_IF("CompactionAction._handle_run_compaction.submit_cumu_task", {
RETURN_IF_ERROR(_engine.submit_compaction_task(
tablet, CompactionType::CUMULATIVE_COMPACTION, false));
LOG(INFO) << "Manual debug compaction task is successfully triggered";
*json_result =
R"({"status": "Success", "msg": "debug compaction task is successfully triggered. Table id: )" +
std::to_string(table_id) + ". Tablet id: " + std::to_string(tablet_id) + "\"}";
return Status::OK();
})
// 3. execute compaction task
std::packaged_task<Status()> task([this, tablet, compaction_type, fetch_from_remote]() {
return _execute_compaction_callback(tablet, compaction_type, fetch_from_remote);
});
std::future<Status> future_obj = task.get_future();
std::thread(std::move(task)).detach();
// æ›´æ–°schedule_time
if (compaction_type == PARAM_COMPACTION_BASE) {
tablet->set_last_base_compaction_schedule_time(UnixMillis());
} else if (compaction_type == PARAM_COMPACTION_CUMULATIVE) {
tablet->set_last_cumu_compaction_schedule_time(UnixMillis());
} else if (compaction_type == PARAM_COMPACTION_FULL) {
tablet->set_last_full_compaction_schedule_time(UnixMillis());
}
// 4. wait for result for 2 seconds by async
std::future_status status = future_obj.wait_for(std::chrono::seconds(2));
if (status == std::future_status::ready) {
// fetch execute result
Status olap_status = future_obj.get();
if (!olap_status.ok()) {
return olap_status;
}
} else {
LOG(INFO) << "Manual compaction task is timeout for waiting "
<< (status == std::future_status::timeout);
}
}
LOG(INFO) << "Manual compaction task is successfully triggered";
*json_result =
R"({"status": "Success", "msg": "compaction task is successfully triggered. Table id: )" +
std::to_string(table_id) + ". Tablet id: " + std::to_string(tablet_id) + "\"}";
return Status::OK();
}
Status CompactionAction::_handle_run_status_compaction(HttpRequest* req, std::string* json_result) {
uint64_t tablet_id = 0;
// check & retrieve tablet_id from req if it contains
RETURN_NOT_OK_STATUS_WITH_WARN(_check_param(req, &tablet_id, TABLET_ID_KEY),
"check param failed");
if (tablet_id == 0) {
// overall compaction status
_engine.get_compaction_status_json(json_result);
return Status::OK();
} else {
// fetch the tablet by tablet_id
TabletSharedPtr tablet = _engine.tablet_manager()->get_tablet(tablet_id);
if (tablet == nullptr) {
LOG(WARNING) << "invalid argument.tablet_id:" << tablet_id;
return Status::InternalError("fail to get {}", tablet_id);
}
std::string json_template = R"({
"status" : "Success",
"run_status" : $0,
"msg" : "$1",
"tablet_id" : $2,
"compact_type" : "$3"
})";
std::string msg = "compaction task for this tablet is not running";
std::string compaction_type;
bool run_status = false;
{
// Full compaction holds both base compaction lock and cumu compaction lock.
// So we can not judge if full compaction is running by check these two locks holding.
// Here, we use a variable 'is_full_compaction_running' to check if full compaction is running.
if (tablet->is_full_compaction_running()) {
msg = "compaction task for this tablet is running";
compaction_type = "full";
run_status = true;
*json_result = absl::Substitute(json_template, run_status, msg, tablet_id,
compaction_type);
return Status::OK();
}
}
{
// use try lock to check this tablet is running cumulative compaction
std::unique_lock<std::mutex> lock_cumulative(tablet->get_cumulative_compaction_lock(),
std::try_to_lock);
if (!lock_cumulative.owns_lock()) {
msg = "compaction task for this tablet is running";
compaction_type = "cumulative";
run_status = true;
*json_result = absl::Substitute(json_template, run_status, msg, tablet_id,
compaction_type);
return Status::OK();
}
}
{
// use try lock to check this tablet is running base compaction
std::unique_lock<std::mutex> lock_base(tablet->get_base_compaction_lock(),
std::try_to_lock);
if (!lock_base.owns_lock()) {
msg = "compaction task for this tablet is running";
compaction_type = "base";
run_status = true;
*json_result = absl::Substitute(json_template, run_status, msg, tablet_id,
compaction_type);
return Status::OK();
}
}
// not running any compaction
*json_result = absl::Substitute(json_template, run_status, msg, tablet_id, compaction_type);
return Status::OK();
}
}
Status CompactionAction::_execute_compaction_callback(TabletSharedPtr tablet,
const std::string& compaction_type,
bool fetch_from_remote) {
MonotonicStopWatch timer;
timer.start();
std::shared_ptr<CumulativeCompactionPolicy> cumulative_compaction_policy =
CumulativeCompactionPolicyFactory::create_cumulative_compaction_policy(
tablet->tablet_meta()->compaction_policy());
if (tablet->get_cumulative_compaction_policy() == nullptr) {
tablet->set_cumulative_compaction_policy(cumulative_compaction_policy);
}
Status res = Status::OK();
auto do_compact = [](Compaction& compaction) {
RETURN_IF_ERROR(compaction.prepare_compact());
return compaction.execute_compact();
};
if (compaction_type == PARAM_COMPACTION_BASE) {
BaseCompaction base_compaction(_engine, tablet);
res = do_compact(base_compaction);
if (!res) {
if (!res.is<BE_NO_SUITABLE_VERSION>()) {
DorisMetrics::instance()->base_compaction_request_failed->increment(1);
}
}
} else if (compaction_type == PARAM_COMPACTION_CUMULATIVE) {
if (fetch_from_remote) {
SingleReplicaCompaction single_compaction(_engine, tablet,
CompactionType::CUMULATIVE_COMPACTION);
res = do_compact(single_compaction);
if (!res) {
LOG(WARNING) << "failed to do single compaction. res=" << res
<< ", table=" << tablet->tablet_id();
}
} else {
CumulativeCompaction cumulative_compaction(_engine, tablet);
res = do_compact(cumulative_compaction);
if (!res) {
if (res.is<CUMULATIVE_NO_SUITABLE_VERSION>()) {
// Ignore this error code.
VLOG_NOTICE
<< "failed to init cumulative compaction due to no suitable version,"
<< "tablet=" << tablet->tablet_id();
} else {
DorisMetrics::instance()->cumulative_compaction_request_failed->increment(1);
LOG(WARNING) << "failed to do cumulative compaction. res=" << res
<< ", table=" << tablet->tablet_id();
}
}
}
} else if (compaction_type == PARAM_COMPACTION_FULL) {
FullCompaction full_compaction(_engine, tablet);
res = do_compact(full_compaction);
if (!res) {
if (res.is<FULL_NO_SUITABLE_VERSION>()) {
// Ignore this error code.
VLOG_NOTICE << "failed to init full compaction due to no suitable version,"
<< "tablet=" << tablet->tablet_id();
} else {
LOG(WARNING) << "failed to do full compaction. res=" << res
<< ", table=" << tablet->tablet_id();
}
}
}
timer.stop();
LOG(INFO) << "Manual compaction task finish, status=" << res
<< ", compaction_use_time=" << timer.elapsed_time() / 1000000 << "ms";
return res;
}
void CompactionAction::handle(HttpRequest* req) {
req->add_output_header(HttpHeaders::CONTENT_TYPE, HEADER_JSON.data());
if (_compaction_type == CompactionActionType::SHOW_INFO) {
std::string json_result;
Status st = _handle_show_compaction(req, &json_result);
if (!st.ok()) {
HttpChannel::send_reply(req, HttpStatus::OK, st.to_json());
} else {
HttpChannel::send_reply(req, HttpStatus::OK, json_result);
}
} else if (_compaction_type == CompactionActionType::RUN_COMPACTION) {
std::string json_result;
Status st = _handle_run_compaction(req, &json_result);
if (!st.ok()) {
HttpChannel::send_reply(req, HttpStatus::OK, st.to_json());
} else {
HttpChannel::send_reply(req, HttpStatus::OK, json_result);
}
} else {
std::string json_result;
Status st = _handle_run_status_compaction(req, &json_result);
if (!st.ok()) {
HttpChannel::send_reply(req, HttpStatus::OK, st.to_json());
} else {
HttpChannel::send_reply(req, HttpStatus::OK, json_result);
}
}
}
} // end namespace doris