ccls/src/pipeline.cc

650 lines
18 KiB
C++
Raw Normal View History

2018-08-21 05:27:52 +00:00
// Copyright 2017-2018 ccls Authors
// SPDX-License-Identifier: Apache-2.0
2018-05-27 19:24:56 +00:00
#include "pipeline.hh"
#include "clang_complete.hh"
2018-10-29 04:21:21 +00:00
#include "config.hh"
#include "include_complete.hh"
2018-05-27 19:24:56 +00:00
#include "log.hh"
#include "lsp.hh"
2018-10-29 04:21:21 +00:00
#include "match.hh"
#include "message_handler.hh"
2018-08-09 17:08:14 +00:00
#include "pipeline.hh"
2018-10-29 04:21:21 +00:00
#include "platform.hh"
#include "project.hh"
2018-10-29 04:21:21 +00:00
#include "query_utils.hh"
#include "serializers/json.hh"
#include <rapidjson/document.h>
#include <rapidjson/writer.h>
#include <llvm/Support/Process.h>
2018-05-27 19:24:56 +00:00
#include <llvm/Support/Threading.h>
#include <llvm/Support/Timer.h>
2018-05-27 19:24:56 +00:00
using namespace llvm;
#include <chrono>
2018-09-10 06:46:13 +00:00
#include <mutex>
#include <shared_mutex>
#include <thread>
2018-07-03 22:47:43 +00:00
#ifndef _WIN32
#include <unistd.h>
#endif
namespace ccls {
namespace {
struct PublishDiagnosticParam {
DocumentUri uri;
std::vector<Diagnostic> diagnostics;
};
MAKE_REFLECT_STRUCT(PublishDiagnosticParam, uri, diagnostics);
} // namespace
2018-09-21 01:04:55 +00:00
void VFS::Clear() {
std::lock_guard lock(mutex);
state.clear();
}
bool VFS::Loaded(const std::string &path) {
std::lock_guard lock(mutex);
return state[path].loaded;
}
bool VFS::Stamp(const std::string &path, int64_t ts, int step) {
std::lock_guard<std::mutex> lock(mutex);
State &st = state[path];
if (st.timestamp < ts || (st.timestamp == ts && st.step < step)) {
st.timestamp = ts;
st.step = step;
return true;
} else
return false;
}
struct MessageHandler;
void StandaloneInitialize(MessageHandler &, const std::string &root);
namespace pipeline {
2018-09-18 01:03:59 +00:00
std::atomic<int64_t> loaded_ts = ATOMIC_VAR_INIT(0),
pending_index_requests = ATOMIC_VAR_INIT(0);
int64_t tick = 0;
2018-09-18 01:03:59 +00:00
namespace {
2018-05-28 00:50:02 +00:00
struct Index_Request {
std::string path;
2018-09-19 16:31:45 +00:00
std::vector<const char *> args;
IndexMode mode;
RequestId id;
2018-09-18 01:03:59 +00:00
int64_t ts = tick++;
2018-05-28 00:50:02 +00:00
};
2018-08-09 17:08:14 +00:00
MultiQueueWaiter *main_waiter;
MultiQueueWaiter *indexer_waiter;
MultiQueueWaiter *stdout_waiter;
ThreadedQueue<InMessage> *on_request;
2018-08-09 17:08:14 +00:00
ThreadedQueue<Index_Request> *index_request;
ThreadedQueue<IndexUpdate> *on_indexed;
ThreadedQueue<std::string> *for_stdout;
2018-05-28 00:50:02 +00:00
struct InMemoryIndexFile {
std::string content;
IndexFile index;
};
2018-09-10 06:46:13 +00:00
std::shared_mutex g_index_mutex;
std::unordered_map<std::string, InMemoryIndexFile> g_index;
2018-07-08 18:51:07 +00:00
bool CacheInvalid(VFS *vfs, IndexFile *prev, const std::string &path,
2018-09-19 16:31:45 +00:00
const std::vector<const char *> &args,
2018-07-08 18:51:07 +00:00
const std::optional<std::string> &from) {
{
std::lock_guard<std::mutex> lock(vfs->mutex);
if (prev->mtime < vfs->state[path].timestamp) {
LOG_S(INFO) << "timestamp changed for " << path
<< (from ? " (via " + *from + ")" : std::string());
return true;
}
2018-01-18 05:53:03 +00:00
}
2018-09-19 16:31:45 +00:00
bool changed = prev->args.size() != args.size();
for (size_t i = 0; !changed && i < args.size(); i++)
if (strcmp(prev->args[i], args[i]))
changed = true;
if (changed)
2018-08-09 17:08:14 +00:00
LOG_S(INFO) << "args changed for " << path
<< (from ? " (via " + *from + ")" : std::string());
2018-09-19 16:31:45 +00:00
return changed;
2018-01-18 05:53:03 +00:00
};
2018-01-18 05:48:09 +00:00
2018-08-09 17:08:14 +00:00
std::string AppendSerializationFormat(const std::string &base) {
2018-05-28 00:50:02 +00:00
switch (g_config->cacheFormat) {
2018-08-09 17:08:14 +00:00
case SerializeFormat::Binary:
return base + ".blob";
case SerializeFormat::Json:
return base + ".json";
2018-05-28 00:50:02 +00:00
}
}
2018-08-09 17:08:14 +00:00
std::string GetCachePath(const std::string &source_file) {
2018-10-08 05:02:28 +00:00
for (auto &root : g_config->workspaceFolders)
if (StringRef(source_file).startswith(root)) {
2018-10-08 05:02:28 +00:00
auto len = root.size();
return g_config->cacheDirectory +
EscapeFileName(root.substr(0, len - 1)) + '/' +
EscapeFileName(source_file.substr(len));
}
return g_config->cacheDirectory + '@' +
EscapeFileName(g_config->fallbackFolder.substr(
0, g_config->fallbackFolder.size() - 1)) +
'/' + EscapeFileName(source_file);
2018-05-28 00:50:02 +00:00
}
2018-08-09 17:08:14 +00:00
std::unique_ptr<IndexFile> RawCacheLoad(const std::string &path) {
if (g_config->cacheDirectory.empty()) {
2018-09-10 06:46:13 +00:00
std::shared_lock lock(g_index_mutex);
auto it = g_index.find(path);
if (it == g_index.end())
return nullptr;
return std::make_unique<IndexFile>(it->second.index);
}
2018-05-28 00:50:02 +00:00
std::string cache_path = GetCachePath(path);
std::optional<std::string> file_content = ReadContent(cache_path);
std::optional<std::string> serialized_indexed_content =
ReadContent(AppendSerializationFormat(cache_path));
if (!file_content || !serialized_indexed_content)
return nullptr;
return ccls::Deserialize(g_config->cacheFormat, path,
*serialized_indexed_content, *file_content,
IndexFile::kMajorVersion);
2018-05-28 00:50:02 +00:00
}
std::mutex &GetFileMutex(const std::string &path) {
2018-09-18 01:03:59 +00:00
const int N_MUTEXES = 256;
static std::mutex mutexes[N_MUTEXES];
return mutexes[std::hash<std::string>()(path) % N_MUTEXES];
}
bool Indexer_Parse(CompletionManager *completion, WorkingFiles *wfiles,
Project *project, VFS *vfs, const GroupMatch &matcher) {
2018-05-28 00:50:02 +00:00
std::optional<Index_Request> opt_request = index_request->TryPopFront();
if (!opt_request)
return false;
2018-08-09 17:08:14 +00:00
auto &request = *opt_request;
bool loud = request.mode != IndexMode::OnChange;
struct RAII {
~RAII() { pending_index_requests--; }
} raii;
2018-01-18 07:59:48 +00:00
2018-05-08 15:56:20 +00:00
// Dummy one to trigger refresh semantic highlight.
2018-05-08 07:35:32 +00:00
if (request.path.empty()) {
2018-05-08 15:56:20 +00:00
IndexUpdate dummy;
dummy.refresh = true;
2018-06-01 04:21:34 +00:00
on_indexed->PushBack(std::move(dummy), false);
2018-05-08 07:35:32 +00:00
return false;
}
2018-09-18 01:03:59 +00:00
if (!matcher.IsMatch(request.path)) {
LOG_IF_S(INFO, loud) << "skip " << request.path;
return false;
}
Project::Entry entry = project->FindEntry(request.path, true);
if (request.args.size())
entry.args = request.args;
std::string path_to_index = entry.filename;
std::unique_ptr<IndexFile> prev;
2018-01-18 07:59:48 +00:00
std::optional<int64_t> write_time = LastWriteTime(path_to_index);
if (!write_time)
return true;
int reparse = vfs->Stamp(path_to_index, *write_time, 0);
if (request.path != path_to_index) {
std::optional<int64_t> mtime1 = LastWriteTime(request.path);
if (!mtime1)
return true;
if (vfs->Stamp(request.path, *mtime1, 0))
reparse = 2;
}
if (g_config->index.onChange) {
reparse = 2;
std::lock_guard lock(vfs->mutex);
vfs->state[path_to_index].step = 0;
if (request.path != path_to_index)
vfs->state[request.path].step = 0;
}
bool track = g_config->index.trackDependency > 1 ||
(g_config->index.trackDependency == 1 && request.ts < loaded_ts);
if (!reparse && !track)
return true;
if (reparse < 2)
do {
std::unique_lock lock(GetFileMutex(path_to_index));
prev = RawCacheLoad(path_to_index);
if (!prev || CacheInvalid(vfs, prev.get(), path_to_index, entry.args,
std::nullopt))
break;
if (track)
for (const auto &dep : prev->dependencies) {
if (auto mtime1 = LastWriteTime(dep.first.val().str())) {
if (dep.second < *mtime1) {
reparse = 2;
break;
}
} else {
reparse = 2;
break;
}
}
if (reparse == 0)
return true;
if (reparse == 2)
break;
2018-09-18 01:03:59 +00:00
if (vfs->Loaded(path_to_index))
return true;
2018-09-18 01:03:59 +00:00
LOG_S(INFO) << "load cache for " << path_to_index;
auto dependencies = prev->dependencies;
IndexUpdate update = IndexUpdate::CreateDelta(nullptr, prev.get());
on_indexed->PushBack(std::move(update),
request.mode != IndexMode::NonInteractive);
{
2018-09-18 01:03:59 +00:00
std::lock_guard lock1(vfs->mutex);
vfs->state[path_to_index].loaded = true;
}
lock.unlock();
2018-09-18 01:03:59 +00:00
for (const auto &dep : dependencies) {
std::string path = dep.first.val().str();
if (!vfs->Stamp(path, dep.second, 1))
continue;
std::lock_guard lock1(GetFileMutex(path));
2018-09-18 01:03:59 +00:00
prev = RawCacheLoad(path);
if (!prev)
continue;
{
2018-09-18 01:03:59 +00:00
std::lock_guard lock2(vfs->mutex);
VFS::State &st = vfs->state[path];
if (st.loaded)
continue;
st.loaded = true;
st.timestamp = prev->mtime;
}
2018-09-18 01:03:59 +00:00
IndexUpdate update = IndexUpdate::CreateDelta(nullptr, prev.get());
on_indexed->PushBack(std::move(update),
request.mode != IndexMode::NonInteractive);
if (entry.id >= 0) {
2018-09-18 01:03:59 +00:00
std::lock_guard lock2(project->mutex_);
2018-10-08 05:02:28 +00:00
project->root2folder[entry.root].path2entry_index[path] = entry.id;
}
}
2018-09-18 01:03:59 +00:00
return true;
} while (0);
LOG_IF_S(INFO, loud) << "parse " << path_to_index;
std::vector<std::pair<std::string, std::string>> remapped;
if (g_config->index.onChange) {
std::string content = wfiles->GetContent(path_to_index);
if (content.size())
remapped.emplace_back(path_to_index, content);
}
2018-09-23 01:00:50 +00:00
bool ok;
auto indexes = idx::Index(completion, wfiles, vfs, entry.directory,
2018-09-23 01:00:50 +00:00
path_to_index, entry.args, remapped, ok);
2018-01-20 07:56:49 +00:00
2018-09-23 01:00:50 +00:00
if (!ok) {
if (request.id.Valid()) {
ResponseError err;
err.code = ErrorCode::InternalError;
err.message = "failed to index " + path_to_index;
pipeline::ReplyError(request.id, err);
2018-01-20 07:56:49 +00:00
}
return true;
2018-01-20 07:56:49 +00:00
}
2018-08-09 17:08:14 +00:00
for (std::unique_ptr<IndexFile> &curr : indexes) {
std::string path = curr->path;
2018-09-18 01:03:59 +00:00
if (!matcher.IsMatch(path)) {
LOG_IF_S(INFO, loud) << "skip index for " << path;
continue;
}
LOG_IF_S(INFO, loud) << "store index for " << path << " (delta: " << !!prev
<< ")";
2018-09-18 01:03:59 +00:00
{
std::lock_guard lock(GetFileMutex(path));
if (vfs->Loaded(path))
2018-09-18 01:03:59 +00:00
prev = RawCacheLoad(path);
else
prev.reset();
if (g_config->cacheDirectory.empty()) {
std::lock_guard lock(g_index_mutex);
auto it = g_index.insert_or_assign(
path, InMemoryIndexFile{curr->file_contents, *curr});
std::string().swap(it.first->second.index.file_contents);
} else {
std::string cache_path = GetCachePath(path);
WriteToFile(cache_path, curr->file_contents);
WriteToFile(AppendSerializationFormat(cache_path),
Serialize(g_config->cacheFormat, *curr));
}
on_indexed->PushBack(IndexUpdate::CreateDelta(prev.get(), curr.get()),
request.mode != IndexMode::NonInteractive);
{
std::lock_guard lock1(vfs->mutex);
vfs->state[path].loaded = true;
}
if (entry.id >= 0) {
std::lock_guard<std::mutex> lock(project->mutex_);
2018-10-08 05:02:28 +00:00
auto &folder = project->root2folder[entry.root];
2018-09-18 01:03:59 +00:00
for (auto &dep : curr->dependencies)
2018-10-08 05:02:28 +00:00
folder.path2entry_index[dep.first.val().str()] = entry.id;
2018-09-18 01:03:59 +00:00
}
}
}
return true;
}
2018-08-09 17:08:14 +00:00
} // namespace
2018-05-28 00:50:02 +00:00
void Init() {
main_waiter = new MultiQueueWaiter;
on_request = new ThreadedQueue<InMessage>(main_waiter);
2018-06-01 04:21:34 +00:00
on_indexed = new ThreadedQueue<IndexUpdate>(main_waiter);
2018-05-28 00:50:02 +00:00
indexer_waiter = new MultiQueueWaiter;
index_request = new ThreadedQueue<Index_Request>(indexer_waiter);
stdout_waiter = new MultiQueueWaiter;
for_stdout = new ThreadedQueue<std::string>(stdout_waiter);
2018-05-28 00:50:02 +00:00
}
2018-09-08 23:00:14 +00:00
void Indexer_Main(CompletionManager *completion, VFS *vfs, Project *project,
WorkingFiles *wfiles) {
GroupMatch matcher(g_config->index.whitelist, g_config->index.blacklist);
while (true)
2018-09-08 23:00:14 +00:00
if (!Indexer_Parse(completion, wfiles, project, vfs, matcher))
2018-05-28 00:50:02 +00:00
indexer_waiter->Wait(index_request);
2018-02-05 03:38:57 +00:00
}
2018-10-29 04:21:21 +00:00
void Main_OnIndexed(DB *db, WorkingFiles *wfiles, IndexUpdate *update) {
2018-06-01 04:21:34 +00:00
if (update->refresh) {
2018-08-09 17:08:14 +00:00
LOG_S(INFO)
<< "loaded project. Refresh semantic highlight for all working file.";
2018-10-29 04:21:21 +00:00
std::lock_guard<std::mutex> lock(wfiles->files_mutex);
for (auto &f : wfiles->files) {
2018-05-08 15:56:20 +00:00
std::string filename = LowerPathIfInsensitive(f->filename);
if (db->name2file_id.find(filename) == db->name2file_id.end())
continue;
QueryFile &file = db->files[db->name2file_id[filename]];
EmitSemanticHighlight(db, f.get(), file);
2018-05-08 07:35:32 +00:00
}
return;
}
2018-07-03 22:47:43 +00:00
static Timer timer("apply", "apply index");
timer.startTimer();
2018-06-01 04:21:34 +00:00
db->ApplyIndexUpdate(update);
timer.stopTimer();
2018-02-05 03:38:57 +00:00
2018-07-08 19:49:27 +00:00
// Update indexed content, skipped ranges, and semantic highlighting.
2018-06-01 04:21:34 +00:00
if (update->files_def_update) {
2018-08-09 17:08:14 +00:00
auto &def_u = *update->files_def_update;
if (WorkingFile *wfile = wfiles->GetFileByFilename(def_u.first.path)) {
// FIXME With index.onChange: true, use buffer_content only for
// request.path
wfile->SetIndexContent(g_config->index.onChange ? wfile->buffer_content
: def_u.second);
QueryFile &file = db->files[update->file_id];
EmitSkippedRanges(wfile, file);
EmitSemanticHighlight(db, wfile, file);
2018-02-05 03:38:57 +00:00
}
}
}
2018-03-20 03:01:23 +00:00
void LaunchStdin() {
std::thread([]() {
2018-05-27 19:24:56 +00:00
set_thread_name("stdin");
std::string str;
while (true) {
constexpr std::string_view kContentLength("Content-Length: ");
int len = 0;
str.clear();
while (true) {
int c = getchar();
if (c == EOF)
return;
if (c == '\n') {
if (str.empty())
break;
if (!str.compare(0, kContentLength.size(), kContentLength))
len = atoi(str.c_str() + kContentLength.size());
str.clear();
} else if (c != '\r') {
str += c;
}
}
2018-02-05 03:38:57 +00:00
str.resize(len);
for (int i = 0; i < len; ++i) {
int c = getchar();
if (c == EOF)
return;
str[i] = c;
}
auto message = std::make_unique<char[]>(len);
std::copy(str.begin(), str.end(), message.get());
auto document = std::make_unique<rapidjson::Document>();
document->Parse(message.get(), len);
assert(!document->HasParseError());
JsonReader reader{document.get()};
if (!reader.HasMember("jsonrpc") ||
std::string(reader["jsonrpc"]->GetString()) != "2.0")
return;
RequestId id;
std::string method;
ReflectMember(reader, "id", id);
ReflectMember(reader, "method", method);
auto param = std::make_unique<rapidjson::Value>();
on_request->PushBack(
{id, std::move(method), std::move(message), std::move(document)});
if (method == "exit")
break;
}
2018-08-09 17:08:14 +00:00
})
.detach();
}
void LaunchStdout() {
std::thread([=]() {
2018-05-27 19:24:56 +00:00
set_thread_name("stdout");
while (true) {
std::vector<std::string> messages = for_stdout->DequeueAll();
for (auto &s : messages) {
llvm::outs() << "Content-Length: " << s.size() << "\r\n\r\n" << s;
llvm::outs().flush();
}
stdout_waiter->Wait(for_stdout);
}
2018-08-09 17:08:14 +00:00
})
.detach();
}
2018-05-28 00:50:02 +00:00
void MainLoop() {
Project project;
2018-10-29 04:21:21 +00:00
WorkingFiles wfiles;
VFS vfs;
CompletionManager clang_complete(
2018-10-29 04:21:21 +00:00
&project, &wfiles,
[&](std::string path, std::vector<Diagnostic> diagnostics) {
PublishDiagnosticParam params;
params.uri = DocumentUri::FromPath(path);
params.diagnostics = diagnostics;
Notify("textDocument/publishDiagnostics", params);
},
[](RequestId id) {
if (id.Valid()) {
ResponseError err;
err.code = ErrorCode::InternalError;
err.message = "drop older completion request";
ReplyError(id, err);
}
});
IncludeComplete include_complete(&project);
DB db;
// Setup shared references.
MessageHandler handler;
handler.db = &db;
handler.project = &project;
handler.vfs = &vfs;
2018-10-29 04:21:21 +00:00
handler.wfiles = &wfiles;
handler.clang_complete = &clang_complete;
handler.include_complete = &include_complete;
bool has_indexed = false;
while (true) {
std::vector<InMessage> messages = on_request->DequeueAll();
bool did_work = messages.size();
for (InMessage &message : messages)
handler.Run(message);
bool indexed = false;
for (int i = 20; i--;) {
2018-06-01 04:21:34 +00:00
std::optional<IndexUpdate> update = on_indexed->TryPopFront();
if (!update)
break;
did_work = true;
indexed = true;
2018-10-29 04:21:21 +00:00
Main_OnIndexed(&db, &wfiles, &*update);
}
if (did_work)
has_indexed |= indexed;
else {
if (has_indexed) {
FreeUnusedMemory();
has_indexed = false;
}
2018-05-28 00:50:02 +00:00
main_waiter->Wait(on_indexed, on_request);
}
}
}
2018-05-28 00:50:02 +00:00
void Standalone(const std::string &root) {
Project project;
WorkingFiles wfiles;
VFS vfs;
IncludeComplete complete(&project);
MessageHandler handler;
handler.project = &project;
2018-10-29 04:21:21 +00:00
handler.wfiles = &wfiles;
handler.vfs = &vfs;
handler.include_complete = &complete;
StandaloneInitialize(handler, root);
bool tty = sys::Process::StandardOutIsDisplayed();
if (tty) {
int entries = 0;
for (auto &[_, folder] : project.root2folder)
entries += folder.entries.size();
printf("entries: %5d\n", entries);
}
while (1) {
(void)on_indexed->DequeueAll();
int pending = pending_index_requests;
if (tty) {
printf("\rpending: %5d", pending);
fflush(stdout);
}
if (!pending)
break;
std::this_thread::sleep_for(std::chrono::milliseconds(100));
}
if (tty)
puts("");
}
2018-09-19 16:31:45 +00:00
void Index(const std::string &path, const std::vector<const char *> &args,
IndexMode mode, RequestId id) {
pending_index_requests++;
index_request->PushBack({path, args, mode, id}, mode != IndexMode::NonInteractive);
2018-05-28 00:50:02 +00:00
}
std::optional<std::string> LoadIndexedContent(const std::string &path) {
if (g_config->cacheDirectory.empty()) {
2018-09-10 06:46:13 +00:00
std::shared_lock lock(g_index_mutex);
auto it = g_index.find(path);
if (it == g_index.end())
return {};
return it->second.content;
}
2018-05-28 00:50:02 +00:00
return ReadContent(GetCachePath(path));
}
void Notify(const char *method, const std::function<void(Writer &)> &fn) {
rapidjson::StringBuffer output;
rapidjson::Writer<rapidjson::StringBuffer> w(output);
w.StartObject();
w.Key("jsonrpc");
w.String("2.0");
w.Key("method");
w.String(method);
w.Key("params");
JsonWriter writer(&w);
fn(writer);
w.EndObject();
for_stdout->PushBack(output.GetString());
}
static void Reply(RequestId id, const char *key,
const std::function<void(Writer &)> &fn) {
rapidjson::StringBuffer output;
rapidjson::Writer<rapidjson::StringBuffer> w(output);
w.StartObject();
w.Key("jsonrpc");
w.String("2.0");
w.Key("id");
switch (id.type) {
case RequestId::kNone:
w.Null();
break;
case RequestId::kInt:
w.Int(id.value);
break;
case RequestId::kString:
auto s = std::to_string(id.value);
w.String(s.c_str(), s.length());
break;
}
w.Key(key);
JsonWriter writer(&w);
fn(writer);
w.EndObject();
for_stdout->PushBack(output.GetString());
}
void Reply(RequestId id, const std::function<void(Writer &)> &fn) {
Reply(id, "result", fn);
}
2018-05-28 00:50:02 +00:00
void ReplyError(RequestId id, const std::function<void(Writer &)> &fn) {
Reply(id, "error", fn);
2018-05-28 00:50:02 +00:00
}
} // namespace pipeline
} // namespace ccls