blob: 00813ad499bbe30dcf0fda8805fa77dbaeb2d6fb [file] [log] [blame]
// Copyright 2025 The Chromium Authors
// Use of this source code is governed by a BSD-style license that can be
// found in the LICENSE file.
#include "net/disk_cache/sql/sql_backend_impl.h"
#include <algorithm>
#include <utility>
#include <vector>
#include "base/barrier_callback.h"
#include "base/containers/flat_set.h"
#include "base/containers/span.h"
#include "base/files/file.h"
#include "base/files/file_path.h"
#include "base/files/file_util.h"
#include "base/functional/callback_helpers.h"
#include "base/memory/scoped_refptr.h"
#include "base/memory/weak_ptr.h"
#include "base/metrics/histogram_functions.h"
#include "base/notimplemented.h"
#include "base/strings/string_number_conversions.h"
#include "base/task/task_runner.h"
#include "base/task/thread_pool.h"
#include "base/types/expected.h"
#include "net/base/io_buffer.h"
#include "net/base/net_errors.h"
#include "net/disk_cache/sql/sql_entry_impl.h"
#include "net/disk_cache/sql/sql_persistent_store.h"
#include "sql_backend_constants.h"
namespace disk_cache {
namespace {
using FakeIndexFileError = SqlBackendImpl::FakeIndexFileError;
// Checks the fake index file, creating it if it doesn't exist. Returns an
// error code if the file is corrupted or cannot be created.
FakeIndexFileError CheckFakeIndexFileInternal(const base::FilePath& path) {
const base::FilePath file_path = path.Append(kSqlBackendFakeIndexFileName);
const std::optional<int64_t> file_size = base::GetFileSize(file_path);
if (file_size.has_value()) {
if (file_size != sizeof(kSqlBackendFakeIndexMagicNumber)) {
return FakeIndexFileError::kWrongFileSize;
}
base::File file(file_path, base::File::FLAG_OPEN | base::File::FLAG_READ);
if (!file.IsValid()) {
return FakeIndexFileError::kOpenFileFailed;
}
uint64_t magic_number = 0;
if (!file.ReadAndCheck(0, base::byte_span_from_ref(magic_number))) {
return FakeIndexFileError::kReadFileFailed;
}
if (magic_number != kSqlBackendFakeIndexMagicNumber) {
return FakeIndexFileError::kWrongMagicNumber;
}
return FakeIndexFileError::kOkExisting;
}
if (!base::DirectoryExists(path) && !base::CreateDirectory(path)) {
return FakeIndexFileError::kFailedToCreateDirectory;
}
base::File file(file_path, base::File::FLAG_CREATE | base::File::FLAG_WRITE);
if (!file.IsValid()) {
return FakeIndexFileError::kCreateFileFailed;
}
if (!file.WriteAndCheck(
0, base::byte_span_from_ref(kSqlBackendFakeIndexMagicNumber))) {
return FakeIndexFileError::kWriteFileFailed;
}
return FakeIndexFileError::kOkNew;
}
// Checks the fake index file and records a histogram of the result.
bool CheckFakeIndexFile(const base::FilePath& path) {
FakeIndexFileError error = CheckFakeIndexFileInternal(path);
base::UmaHistogramEnumeration("Net.SqlDiskCache.FakeIndexFileError", error);
return error == FakeIndexFileError::kOkNew ||
error == FakeIndexFileError::kOkExisting;
}
// A helper to handle methods that may complete synchronously.
//
// This allows a caller to dispatch an async operation and immediately check if
// it completed synchronously. If so, the result is returned directly. If not,
// a provided callback is invoked later.
template <typename T>
class SyncResultReceiver : public base::RefCounted<SyncResultReceiver<T>> {
public:
using ResultCallback = base::OnceCallback<void(T)>;
explicit SyncResultReceiver(ResultCallback callback)
: callback_(std::move(callback)) {}
~SyncResultReceiver() {
// As a contract, FinishSyncCall() must be called. If it's not, it's a
// bug in the calling code.
CHECK(sync_call_finished_);
}
SyncResultReceiver(const SyncResultReceiver&) = delete;
SyncResultReceiver& operator=(const SyncResultReceiver&) = delete;
// Returns a callback to pass to the async operation.
ResultCallback GetCallback() {
return base::BindOnce(&SyncResultReceiver::OnResult, this);
}
// Checks for a synchronous result. If the operation already completed,
// returns the result. Otherwise, returns nullopt and the original callback
// will be run asynchronously.
std::optional<T> FinishSyncCall() {
sync_call_finished_ = true;
if (result_) {
callback_.Reset();
return std::move(result_);
}
return std::nullopt;
}
private:
// Receives the result from the async operation.
void OnResult(T result) {
if (sync_call_finished_) {
// The caller is already waiting for the async result.
if (callback_) {
std::move(callback_).Run(std::move(result));
}
} else {
// The result arrived synchronously. Store it for FinishSyncCall.
result_ = std::move(result);
}
}
// The original callback, to be run on async completion.
ResultCallback callback_;
// Holds the result if it arrives synchronously.
std::optional<T> result_;
// Set to true when FinishSyncCall is called.
bool sync_call_finished_ = false;
};
// Creates a `base::OnceClosure` that takes ownership of an `OperationHandle`.
// When the closure is run, the handle is destroyed, signaling the completion
// of the operation to the `ExclusiveOperationCoordinator`. This is typically
// used with `base::OnceCallback::Then()` to ensure the handle is released only
// after the primary callback has finished.
base::OnceClosure DoNothingWithBoundHandle(
std::unique_ptr<ExclusiveOperationCoordinator::OperationHandle> handle) {
return base::OnceClosure(base::DoNothingWithBoundArgs(std::move(handle)));
}
// Retrieves the `ResId` from `res_id_or_error` if it holds a `ResId` value.
// This function should only be called after the speculative entry creation has
// completed and `res_id_or_error->data` is populated. The call is sequenced
// by the ExclusiveOperationCoordinator, which ensures that this function runs
// only after the handle for the creation operation is released.
std::optional<SqlPersistentStore::ResId> GetResId(
const scoped_refptr<SqlBackendImpl::ResIdOrErrorHolder>& res_id_or_error) {
CHECK(res_id_or_error);
CHECK(res_id_or_error->data.has_value());
if (std::holds_alternative<SqlPersistentStore::ResId>(
res_id_or_error->data.value())) {
return std::get<SqlPersistentStore::ResId>(res_id_or_error->data.value());
}
return std::nullopt;
}
// Retrieves the `Error` from `res_id_or_error` if it holds an `Error` value.
// This function should only be called after the speculative entry creation has
// completed and `res_id_or_error->data` is populated. The call is sequenced
// by the ExclusiveOperationCoordinator, which ensures that this function runs
// only after the handle for the creation operation is released.
std::optional<SqlPersistentStore::Error> GetError(
const scoped_refptr<SqlBackendImpl::ResIdOrErrorHolder>& res_id_or_error) {
CHECK(res_id_or_error);
CHECK(res_id_or_error->data.has_value());
if (std::holds_alternative<SqlPersistentStore::Error>(
res_id_or_error->data.value())) {
return std::get<SqlPersistentStore::Error>(res_id_or_error->data.value());
}
return std::nullopt;
}
} // namespace
// IteratorImpl provides an implementation of Backend::Iterator for the
// SqlBackendImpl. It allows iterating through cache entries stored in the
// SQLite database. Iteration is performed in reverse `res_id` order (from
// newest to oldest entry in the database).
class SqlBackendImpl::IteratorImpl : public Backend::Iterator {
public:
explicit IteratorImpl(base::WeakPtr<SqlBackendImpl> backend)
: backend_(backend) {}
~IteratorImpl() override = default;
EntryResult OpenNextEntry(EntryResultCallback callback) override {
CHECK(!callback_);
if (!backend_) {
return EntryResult::MakeError(net::ERR_FAILED);
}
callback_ = std::move(callback);
// Schedule `DoOpenNextEntry` as an exclusive operation to ensure that
// iteration does not conflict with other backend-wide operations (e.g.,
// mass deletion).
backend_->exclusive_operation_coordinator_.PostOrRunExclusiveOperation(
base::BindOnce(&IteratorImpl::DoOpenNextEntry,
weak_factory_.GetWeakPtr()));
return EntryResult::MakeError(net::ERR_IO_PENDING);
}
private:
// Performs the actual logic for opening the next entry. This method is
// executed when it's its turn in the exclusive operation queue.
void DoOpenNextEntry(
std::unique_ptr<ExclusiveOperationCoordinator::OperationHandle> handle) {
if (!backend_) {
std::move(callback_).Run(EntryResult::MakeError(net::ERR_FAILED));
// `handle` is destroyed here, but `backend_` is null, so it's a no-op.
return;
}
// Request the next entry from the persistent store. `res_id_iterator_`
// keeps track of the last `res_id` returned, allowing the store to fetch
// entries older than that.
// `handle` will be destroyed after executing
// `OnOpenLatestEntryBeforeResIdFinished()`, may be triggering queued
// operations.
backend_->store_->OpenLatestEntryBeforeResId(
res_id_iterator_,
base::BindOnce(&IteratorImpl::OnOpenLatestEntryBeforeResIdFinished,
weak_factory_.GetWeakPtr())
.Then(DoNothingWithBoundHandle(std::move(handle))));
}
// Callback for `SqlPersistentStore::OpenLatestEntryBeforeResId`.
void OnOpenLatestEntryBeforeResIdFinished(
SqlPersistentStore::OptionalEntryInfoWithIdAndKey result) {
CHECK(callback_);
if (!backend_) {
std::move(callback_).Run(EntryResult::MakeError(net::ERR_FAILED));
return;
}
// If no more entries are found or an error occurred in the store.
if (!result.has_value()) {
std::move(callback_).Run(EntryResult::MakeError(net::ERR_FAILED));
return;
}
SqlPersistentStore::EntryInfoWithIdAndKey& entry_info = *result;
// Update the iterator's cursor to the `res_id` of the current entry,
// so the next call to `OpenLatestEntryBeforeResId` starts from here.
res_id_iterator_ = entry_info.res_id;
// Check if the entry is already active in `active_entries_`. If so,
// reuse the existing `SqlEntryImpl` instance.
if (SqlEntryImpl* entry = backend_->GetActiveEntry(entry_info.key)) {
entry->AddRef();
std::move(callback_).Run(EntryResult::MakeOpened(entry));
return;
}
// This DCHECK ensures that an entry returned by the store for iteration
// is not already in the `doomed_entries_` set. This invariant is
// maintained because iterator operations are "exclusive" and dooming
// operations are "normal", and the `ExclusiveOperationCoordinator`
// ensures they do not run concurrently. If a doom operation runs first,
// the entry is marked as doomed in the database and
// `OpenLatestEntryBeforeResId` will not return it. If the iterator
// operation runs first, any subsequent doom operation will be queued until
// the iteration step is complete.
DCHECK(std::none_of(backend_->doomed_entries_.begin(),
backend_->doomed_entries_.end(),
[&](const raw_ref<const SqlEntryImpl>& doomed_entry) {
const auto optional_res_id =
GetResId(doomed_entry.get().res_id_or_error());
return optional_res_id.has_value() &&
*optional_res_id == entry_info.info.res_id;
}));
// Apply any in-flight modifications (e.g., last_used time updates, header
// changes) that were queued for this entry while it was not active.
backend_->ApplyInFlightEntryModifications(entry_info.key, entry_info.info);
// If the entry is not active, create a new `SqlEntryImpl`.
scoped_refptr<SqlEntryImpl> new_entry = base::MakeRefCounted<SqlEntryImpl>(
backend_, entry_info.key,
base::MakeRefCounted<ResIdOrErrorHolder>(entry_info.info.res_id),
entry_info.info.last_used, entry_info.info.body_end,
entry_info.info.head);
new_entry->AddRef();
CHECK(backend_->active_entries_
.insert(std::make_pair(entry_info.key,
raw_ref<SqlEntryImpl>(*new_entry.get())))
.second);
// Return the newly opened entry.
std::move(callback_).Run(EntryResult::MakeOpened(new_entry.get()));
}
base::WeakPtr<SqlBackendImpl> backend_;
// The `res_id` of the last entry returned by the iterator. Used to fetch
// entries with smaller `res_id`s in subsequent calls.
SqlPersistentStore::ResId res_id_iterator_ =
SqlPersistentStore::ResId(std::numeric_limits<int64_t>::max());
EntryResultCallback callback_;
base::WeakPtrFactory<IteratorImpl> weak_factory_{this};
};
SqlBackendImpl::SqlBackendImpl(const base::FilePath& path,
int64_t max_bytes,
net::CacheType cache_type)
: Backend(cache_type),
path_(path),
background_task_runner_(base::ThreadPool::CreateSequencedTaskRunner(
{base::MayBlock(), base::TaskPriority::USER_BLOCKING,
base::TaskShutdownBehavior::BLOCK_SHUTDOWN})),
store_(SqlPersistentStore::Create(path,
max_bytes > 0 ? max_bytes : 0,
GetCacheType(),
background_task_runner_)) {
DVLOG(1) << "SqlBackendImpl::SqlBackendImpl " << path;
}
SqlBackendImpl::~SqlBackendImpl() = default;
void SqlBackendImpl::Init(CompletionOnceCallback callback) {
auto barrier_callback = base::BarrierCallback<bool>(
2, base::BindOnce(&SqlBackendImpl::OnInitialized,
weak_factory_.GetWeakPtr(), std::move(callback)));
store_->Initialize(base::BindOnce([](SqlPersistentStore::Error result) {
return result == SqlPersistentStore::Error::kOk;
}).Then(barrier_callback));
base::ThreadPool::PostTaskAndReplyWithResult(
FROM_HERE,
{base::MayBlock(), base::TaskPriority::USER_BLOCKING,
base::TaskShutdownBehavior::BLOCK_SHUTDOWN},
base::BindOnce(&CheckFakeIndexFile, path_),
base::OnceCallback<void(bool)>(barrier_callback));
}
void SqlBackendImpl::OnInitialized(CompletionOnceCallback callback,
const std::vector<bool>& results) {
const bool success = std::all_of(results.begin(), results.end(),
[](bool result) { return result; });
if (success) {
// Schedule a one-time task to clean up doomed entries from previous
// sessions. This runs after a delay to avoid impacting startup performance.
base::SequencedTaskRunner::GetCurrentDefault()->PostDelayedTask(
FROM_HERE,
base::BindOnce(&SqlBackendImpl::TriggerDeleteDoomedEntries,
weak_factory_.GetWeakPtr()),
kSqlBackendDeleteDoomedEntriesDelay);
}
std::move(callback).Run(success ? net::OK : net::ERR_FAILED);
}
int64_t SqlBackendImpl::MaxFileSize() const {
// Delegates to the persistent store to get the max file size.
return store_->MaxFileSize();
}
int32_t SqlBackendImpl::GetEntryCount(
net::Int32CompletionOnceCallback callback) const {
// Asynchronously retrieves the entry count from the persistent store.
store_->GetEntryCount(std::move(callback));
return net::ERR_IO_PENDING;
}
EntryResult SqlBackendImpl::OpenOrCreateEntry(const std::string& key,
net::RequestPriority priority,
EntryResultCallback callback) {
return OpenOrCreateEntryInternal(
OpenOrCreateEntryOperationType::kOpenOrCreateEntry, key,
std::move(callback));
}
EntryResult SqlBackendImpl::OpenEntry(const std::string& key,
net::RequestPriority priority,
EntryResultCallback callback) {
return OpenOrCreateEntryInternal(OpenOrCreateEntryOperationType::kOpenEntry,
key, std::move(callback));
}
EntryResult SqlBackendImpl::CreateEntry(const std::string& key,
net::RequestPriority priority,
EntryResultCallback callback) {
return OpenOrCreateEntryInternal(OpenOrCreateEntryOperationType::kCreateEntry,
key, std::move(callback));
}
EntryResult SqlBackendImpl::OpenOrCreateEntryInternal(
OpenOrCreateEntryOperationType type,
const std::string& key,
EntryResultCallback callback) {
const CacheEntryKey entry_key(key);
auto sync_result_receiver =
base::MakeRefCounted<SyncResultReceiver<EntryResult>>(
std::move(callback));
exclusive_operation_coordinator_.PostOrRunNormalOperation(
entry_key,
base::BindOnce(&SqlBackendImpl::HandleOpenOrCreateEntryOperation,
weak_factory_.GetWeakPtr(), type, entry_key,
sync_result_receiver->GetCallback()));
auto sync_result = sync_result_receiver->FinishSyncCall();
return sync_result ? std::move(*sync_result)
: EntryResult::MakeError(net::ERR_IO_PENDING);
}
void SqlBackendImpl::HandleOpenOrCreateEntryOperation(
OpenOrCreateEntryOperationType type,
const CacheEntryKey& entry_key,
EntryResultCallback callback,
std::unique_ptr<ExclusiveOperationCoordinator::OperationHandle> handle) {
if (SqlEntryImpl* entry = GetActiveEntry(entry_key)) {
if (type == OpenOrCreateEntryOperationType::kCreateEntry) {
std::move(callback).Run(EntryResult::MakeError(net::ERR_FAILED));
} else {
entry->AddRef();
std::move(callback).Run(EntryResult::MakeOpened(entry));
}
return;
}
if (store_->GetIndexStateForHash(entry_key.hash()) ==
SqlPersistentStore::IndexState::kHashNotFound) {
if (type == OpenOrCreateEntryOperationType::kOpenEntry) {
std::move(callback).Run(EntryResult::MakeError(net::ERR_FAILED));
return;
}
std::move(callback).Run(
SpeculativeCreateEntry(entry_key, std::move(handle)));
return;
}
switch (type) {
case OpenOrCreateEntryOperationType::kOpenOrCreateEntry:
store_->OpenOrCreateEntry(
entry_key, base::BindOnce(&SqlBackendImpl::OnEntryOperationFinished,
base::Unretained(this), entry_key,
std::move(callback), std::move(handle)));
break;
case OpenOrCreateEntryOperationType::kOpenEntry:
store_->OpenEntry(
entry_key,
base::BindOnce(&SqlBackendImpl::OnOptionalEntryOperationFinished,
base::Unretained(this), entry_key, std::move(callback),
std::move(handle)));
break;
case OpenOrCreateEntryOperationType::kCreateEntry:
store_->CreateEntry(
entry_key, base::Time::Now(),
base::BindOnce(&SqlBackendImpl::OnEntryOperationFinished,
base::Unretained(this), entry_key, std::move(callback),
std::move(handle)));
break;
}
}
SqlEntryImpl* SqlBackendImpl::GetActiveEntry(const CacheEntryKey& key) {
if (auto it = active_entries_.find(key); it != active_entries_.end()) {
// Return a pointer to the SqlEntryImpl if found.
return &it->second.get();
}
return nullptr;
}
void SqlBackendImpl::DoomActiveEntry(SqlEntryImpl& entry) {
exclusive_operation_coordinator_.PostOrRunNormalOperation(
entry.cache_key(),
base::BindOnce(&SqlBackendImpl::HandleDoomActiveEntryOperation,
weak_factory_.GetWeakPtr(),
scoped_refptr<SqlEntryImpl>(&entry)));
}
void SqlBackendImpl::HandleDoomActiveEntryOperation(
scoped_refptr<SqlEntryImpl> entry,
std::unique_ptr<ExclusiveOperationCoordinator::OperationHandle> handle) {
if (entry->doomed()) {
return;
}
DoomActiveEntryInternal(*entry,
base::DoNothingWithBoundArgs(std::move(handle)));
}
void SqlBackendImpl::DoomActiveEntryInternal(SqlEntryImpl& entry,
CompletionOnceCallback callback) {
// Mark the entry as doomed internally.
entry.MarkAsDoomed();
// Move it from the active_entries_ map to the doomed_entries_ set.
ReleaseActiveEntry(entry);
doomed_entries_.emplace(entry);
const auto optional_res_id = GetResId(entry.res_id_or_error());
if (!optional_res_id) {
// Speculative entry creation was failed.
CHECK(GetError(entry.res_id_or_error()).has_value());
std::move(callback).Run(net::ERR_FAILED);
return;
}
// Ask the store to mark the entry as doomed in the database.
store_->DoomEntry(
entry.cache_key(), *optional_res_id,
base::BindOnce(
[](base::WeakPtr<SqlBackendImpl> weak_ptr,
CompletionOnceCallback callback, SqlPersistentStore::Error error) {
// Do not call the `callback` if the backend has been destroyed.
// This is safe for both backend-initiated and entry-initiated
// dooms:
// - For backend operations (e.g., `DoomEntry`), the provided
// callback should be cancelled if the backend is gone.
// - For entry operations (`SqlEntryImpl::Doom`), the callback is a
// `base::DoNothing()`, so cancelling it has no effect.
if (weak_ptr) {
// Return net::OK even if the entry is not found. This matches
// the behavior of SimpleCache. This is tested by
// BackendFailedOpenThenMultipleDoomsNonExistentEntry in
// DiskCacheGenericBackendTest.
std::move(callback).Run(net::OK);
}
},
weak_factory_.GetWeakPtr(), std::move(callback)));
}
net::Error SqlBackendImpl::DoomEntry(const std::string& key,
net::RequestPriority priority,
CompletionOnceCallback callback) {
const CacheEntryKey entry_key(key);
exclusive_operation_coordinator_.PostOrRunNormalOperation(
entry_key, base::BindOnce(&SqlBackendImpl::HandleDoomEntryOperation,
weak_factory_.GetWeakPtr(), entry_key, priority,
std::move(callback)));
return net::ERR_IO_PENDING;
}
void SqlBackendImpl::HandleDoomEntryOperation(
const CacheEntryKey& key,
net::RequestPriority priority,
CompletionOnceCallback callback,
std::unique_ptr<ExclusiveOperationCoordinator::OperationHandle> handle) {
// If the entry is currently active, doom it directly.
if (auto* active_entry = GetActiveEntry(key)) {
DoomActiveEntryInternal(*active_entry, std::move(callback));
// The handle for this operation is released upon returning, allowing the
// next queued operation to run.
return;
}
// If the entry is not active and no operation is pending, it means the entry
// is not currently open. In this case, we can directly ask the store to
// delete the "live" (not yet doomed) entry from the database.
store_->DeleteLiveEntry(
key, base::BindOnce(
[](base::WeakPtr<SqlBackendImpl> weak_ptr,
CompletionOnceCallback callback,
SqlPersistentStore::Error result) {
// Convert store error to net error. kNotFound is
// considered a success for dooming (idempotency).
std::move(callback).Run(
(result == SqlPersistentStore::Error::kOk ||
result == SqlPersistentStore::Error::kNotFound)
? net::OK
: net::ERR_FAILED);
},
weak_factory_.GetWeakPtr(), std::move(callback))
.Then(DoNothingWithBoundHandle(std::move(handle))));
}
net::Error SqlBackendImpl::DoomAllEntries(CompletionOnceCallback callback) {
// DoomAllEntries is a special case of DoomEntriesBetween with an unbounded
// time range.
return DoomEntriesBetween(base::Time::Min(), base::Time::Max(),
std::move(callback));
}
net::Error SqlBackendImpl::DoomEntriesBetween(base::Time initial_time,
base::Time end_time,
CompletionOnceCallback callback) {
exclusive_operation_coordinator_.PostOrRunExclusiveOperation(base::BindOnce(
&SqlBackendImpl::HandleDoomEntriesBetweenOperation,
weak_factory_.GetWeakPtr(), initial_time, end_time, std::move(callback)));
return net::ERR_IO_PENDING;
}
void SqlBackendImpl::HandleDoomEntriesBetweenOperation(
base::Time initial_time,
base::Time end_time,
CompletionOnceCallback callback,
std::unique_ptr<ExclusiveOperationCoordinator::OperationHandle> handle) {
if (initial_time.is_null()) {
// If initial_time is null, use the minimum possible time.
initial_time = base::Time::Min();
}
if (end_time.is_null()) {
// If end_time is null, use the maximum possible time.
end_time = base::Time::Max();
}
// Optimization: If dooming all entries (min to max time) and there are no
// active, doomed, or pending entries, we can directly ask the store to
// delete all entries, which is more efficient.
if (initial_time.is_min() && end_time.is_max() && active_entries_.empty() &&
doomed_entries_.empty()) {
// Ask the store to delete all entries from the database.
store_->DeleteAllEntries(
base::BindOnce(
[](CompletionOnceCallback callback,
SqlPersistentStore::Error result) {
std::move(callback).Run(result == SqlPersistentStore::Error::kOk
? net::OK
: net::ERR_FAILED);
},
std::move(callback))
.Then(DoNothingWithBoundHandle(std::move(handle))));
return;
}
// Collect keys of active entries to exclude them from the store's
// DeleteLiveEntriesBetween operation, as they will be handled by dooming them
// directly within this method.
std::vector<CacheEntryKey> excluded_keys_vec;
excluded_keys_vec.reserve(active_entries_.size());
std::vector<SqlEntryImpl*> active_entries_to_be_doomed;
for (auto& it : active_entries_) {
excluded_keys_vec.push_back(it.first);
// Check if the active entry falls within the specified time range.
const base::Time last_used_time = it.second->GetLastUsed();
if (last_used_time >= initial_time && last_used_time < end_time) {
active_entries_to_be_doomed.push_back(&it.second.get());
}
}
base::flat_set<CacheEntryKey> excluded_keys(base::sorted_unique,
std::move(excluded_keys_vec));
auto barrier_callback = base::BarrierCallback<int>(
active_entries_to_be_doomed.size() + // For active entries being doomed
1, // For store's DeleteLiveEntriesBetween
base::BindOnce(
// This final callback is run after all individual doom operations
// complete.
[](base::WeakPtr<SqlBackendImpl> weak_ptr,
CompletionOnceCallback callback, const std::vector<int>& result) {
if (weak_ptr) {
std::move(callback).Run(net::OK);
}
},
weak_factory_.GetWeakPtr(), std::move(callback))
.Then(DoNothingWithBoundHandle(std::move(handle))));
// Doom active entries that fall within the time range.
for (auto* entry : active_entries_to_be_doomed) {
DoomActiveEntryInternal(*entry, barrier_callback);
}
// Ask the store to delete all other "live" (not doomed, not active, not
// pending) entries within the specified time range, excluding those already
// handled.
store_->DeleteLiveEntriesBetween(
initial_time, end_time, std::move(excluded_keys),
base::BindOnce(
[](CompletionOnceCallback callback,
SqlPersistentStore::Error result) {
std::move(callback).Run(result == SqlPersistentStore::Error::kOk
? net::OK
: net::ERR_FAILED);
},
std::move(barrier_callback)));
}
net::Error SqlBackendImpl::DoomEntriesSince(base::Time initial_time,
CompletionOnceCallback callback) {
// DoomEntriesSince is a special case of DoomEntriesBetween with end_time set
// to the maximum possible time.
return DoomEntriesBetween(initial_time, base::Time::Max(),
std::move(callback));
}
int64_t SqlBackendImpl::CalculateSizeOfAllEntries(
Int64CompletionOnceCallback callback) {
return CalculateSizeOfEntriesBetween(base::Time::Min(), base::Time::Max(),
std::move(callback));
}
int64_t SqlBackendImpl::CalculateSizeOfEntriesBetween(
base::Time initial_time,
base::Time end_time,
Int64CompletionOnceCallback callback) {
exclusive_operation_coordinator_.PostOrRunExclusiveOperation(base::BindOnce(
&SqlBackendImpl::HandleCalculateSizeOfEntriesBetweenOperation,
weak_factory_.GetWeakPtr(), initial_time, end_time, std::move(callback)));
return net::ERR_IO_PENDING;
}
void SqlBackendImpl::HandleCalculateSizeOfEntriesBetweenOperation(
base::Time initial_time,
base::Time end_time,
Int64CompletionOnceCallback callback,
std::unique_ptr<ExclusiveOperationCoordinator::OperationHandle> handle) {
store_->CalculateSizeOfEntriesBetween(
initial_time, end_time,
base::BindOnce(
[](base::WeakPtr<SqlBackendImpl> weak_ptr,
Int64CompletionOnceCallback callback,
std::unique_ptr<ExclusiveOperationCoordinator::OperationHandle>
handle,
SqlPersistentStore::Int64OrError result) {
if (weak_ptr) {
std::move(callback).Run(result.has_value() ? result.value()
: net::ERR_FAILED);
}
},
weak_factory_.GetWeakPtr(), std::move(callback), std::move(handle)));
}
std::unique_ptr<Backend::Iterator> SqlBackendImpl::CreateIterator() {
return std::make_unique<IteratorImpl>(weak_factory_.GetWeakPtr());
}
void SqlBackendImpl::GetStats(base::StringPairs* stats) {
stats->emplace_back(std::make_pair("Cache type", "SQL Cache"));
// TODO(crbug.com/422065015): Write more stats.
}
void SqlBackendImpl::OnExternalCacheHit(const std::string& key) {
const CacheEntryKey entry_key(key);
if (auto it = active_entries_.find(entry_key); it != active_entries_.end()) {
it->second->UpdateLastUsed();
return;
}
const base::Time now = base::Time::Now();
in_flight_entry_modifications_[entry_key].emplace_back(nullptr, now);
exclusive_operation_coordinator_.PostOrRunNormalOperation(
entry_key,
base::BindOnce(&SqlBackendImpl::HandleOnExternalCacheHitOperation,
weak_factory_.GetWeakPtr(), entry_key, now));
}
void SqlBackendImpl::HandleOnExternalCacheHitOperation(
const CacheEntryKey& key,
base::Time now,
std::unique_ptr<ExclusiveOperationCoordinator::OperationHandle> handle) {
store_->UpdateEntryLastUsed(
key, now,
WrapErrorCallbackToPopInFlightEntryModification(key, base::DoNothing())
.Then(DoNothingWithBoundHandle(std::move(handle))));
}
void SqlBackendImpl::OnBrowserIdle() {
store_->MaybeRunCheckpoint(base::DoNothing());
}
void SqlBackendImpl::OnOptionalEntryOperationFinished(
const CacheEntryKey& key,
EntryResultCallback callback,
std::unique_ptr<ExclusiveOperationCoordinator::OperationHandle> handle,
SqlPersistentStore::OptionalEntryInfoOrError result) {
// If the store operation failed or the entry was not found (for OpenEntry).
if (!result.has_value() || !result->has_value()) {
std::move(callback).Run(EntryResult::MakeError(net::ERR_FAILED));
return;
}
SqlPersistentStore::EntryInfo& entry_info = *(*result);
ApplyInFlightEntryModifications(key, entry_info);
// Create a new SqlEntryImpl instance.
scoped_refptr<SqlEntryImpl> new_entry = base::MakeRefCounted<SqlEntryImpl>(
weak_factory_.GetWeakPtr(), key,
base::MakeRefCounted<ResIdOrErrorHolder>(entry_info.res_id),
entry_info.last_used, entry_info.body_end, entry_info.head);
// Add a reference for passing to the `callback`.
new_entry->AddRef();
// Add the new entry to the active_entries_ map.
auto insert_result = active_entries_.insert(
std::make_pair(key, raw_ref<SqlEntryImpl>(*new_entry.get())));
CHECK(insert_result.second);
// Run the original callback with the newly created/opened entry.
std::move(callback).Run((*result)->opened
? EntryResult::MakeOpened(new_entry.get())
: EntryResult::MakeCreated(new_entry.get()));
MaybeTriggerEviction();
}
void SqlBackendImpl::OnEntryOperationFinished(
const CacheEntryKey& key,
EntryResultCallback callback,
std::unique_ptr<ExclusiveOperationCoordinator::OperationHandle> handle,
SqlPersistentStore::EntryInfoOrError result) {
// This is a helper to adapt EntryInfoOrError to
// OnOptionalEntryOperationFinished which expects OptionalEntryInfoOrError.
if (result.has_value()) {
OnOptionalEntryOperationFinished(key, std::move(callback),
std::move(handle), std::move(*result));
} else {
OnOptionalEntryOperationFinished(key, std::move(callback),
std::move(handle),
base::unexpected(result.error()));
}
}
EntryResult SqlBackendImpl::SpeculativeCreateEntry(
const CacheEntryKey& entry_key,
std::unique_ptr<ExclusiveOperationCoordinator::OperationHandle> handle) {
auto optional_res_id_or_error =
base::MakeRefCounted<ResIdOrErrorHolder>(std::nullopt);
const auto creation_time = base::Time::Now();
store_->CreateEntry(
entry_key, creation_time,
base::BindOnce(&SqlBackendImpl::OnSpeculativeCreateEntryFinished,
base::Unretained(this), optional_res_id_or_error,
std::move(handle)));
// Create a new SqlEntryImpl instance.
scoped_refptr<SqlEntryImpl> new_entry = base::MakeRefCounted<SqlEntryImpl>(
weak_factory_.GetWeakPtr(), entry_key,
std::move(optional_res_id_or_error), creation_time, /*body_end=*/0,
/*head=*/nullptr);
// Add a reference for passing to the `callback`.
new_entry->AddRef();
// Add the new entry to the active_entries_ map.
auto insert_result = active_entries_.insert(
std::make_pair(entry_key, raw_ref<SqlEntryImpl>(*new_entry.get())));
CHECK(insert_result.second);
return EntryResult::MakeCreated(new_entry.get());
}
void SqlBackendImpl::OnSpeculativeCreateEntryFinished(
const scoped_refptr<ResIdOrErrorHolder>& res_id_or_error,
std::unique_ptr<ExclusiveOperationCoordinator::OperationHandle> handle,
SqlPersistentStore::EntryInfoOrError result) {
if (result.has_value()) {
res_id_or_error->data = result->res_id;
} else {
res_id_or_error->data = result.error();
}
MaybeTriggerEviction();
}
void SqlBackendImpl::ReleaseActiveEntry(SqlEntryImpl& entry) {
auto it = active_entries_.find(entry.cache_key());
// The entry must exist in the active_entries_ map.
CHECK(it != active_entries_.end());
CHECK_EQ(&it->second.get(), &entry);
active_entries_.erase(it);
}
void SqlBackendImpl::ReleaseDoomedEntry(SqlEntryImpl& entry) {
auto it = doomed_entries_.find(entry);
// The entry must exist in the doomed_entries_ set.
CHECK(it != doomed_entries_.end());
doomed_entries_.erase(it);
exclusive_operation_coordinator_.PostOrRunNormalOperation(
entry.cache_key(),
base::BindOnce(&SqlBackendImpl::HandleDeleteDoomedEntry,
weak_factory_.GetWeakPtr(), entry.cache_key(),
entry.res_id_or_error()));
}
void SqlBackendImpl::HandleDeleteDoomedEntry(
const CacheEntryKey& key,
const scoped_refptr<ResIdOrErrorHolder>& res_id_or_error,
std::unique_ptr<ExclusiveOperationCoordinator::OperationHandle> handle) {
const auto optional_res_id = GetResId(res_id_or_error);
if (!optional_res_id) {
// Speculative entry creation was failed.
return;
}
store_->DeleteDoomedEntry(
key, *optional_res_id,
base::BindOnce(
[](std::unique_ptr<ExclusiveOperationCoordinator::OperationHandle>
handle,
SqlPersistentStore::Error error) {},
std::move(handle)));
}
void SqlBackendImpl::UpdateEntryLastUsed(
const CacheEntryKey& key,
const scoped_refptr<ResIdOrErrorHolder>& res_id_or_error,
base::Time last_used) {
in_flight_entry_modifications_[key].emplace_back(res_id_or_error, last_used);
exclusive_operation_coordinator_.PostOrRunNormalOperation(
key, base::BindOnce(&SqlBackendImpl::HandleUpdateEntryLastUsedOperation,
weak_factory_.GetWeakPtr(), key, res_id_or_error,
last_used));
}
void SqlBackendImpl::HandleUpdateEntryLastUsedOperation(
const CacheEntryKey& key,
const scoped_refptr<ResIdOrErrorHolder>& res_id_or_error,
base::Time last_used,
std::unique_ptr<ExclusiveOperationCoordinator::OperationHandle> handle) {
store_->UpdateEntryLastUsed(
key, last_used,
WrapErrorCallbackToPopInFlightEntryModification(
key, base::DoNothingWithBoundArgs(std::move(handle))));
}
void SqlBackendImpl::UpdateEntryHeaderAndLastUsed(
const CacheEntryKey& key,
const scoped_refptr<ResIdOrErrorHolder>& res_id_or_error,
base::Time last_used,
scoped_refptr<net::GrowableIOBuffer> buffer,
int64_t header_size_delta) {
in_flight_entry_modifications_[key].emplace_back(res_id_or_error, last_used,
buffer);
exclusive_operation_coordinator_.PostOrRunNormalOperation(
key, base::BindOnce(
&SqlBackendImpl::HandleUpdateEntryHeaderAndLastUsedOperation,
weak_factory_.GetWeakPtr(), key, res_id_or_error, last_used,
std::move(buffer), header_size_delta));
}
void SqlBackendImpl::HandleUpdateEntryHeaderAndLastUsedOperation(
const CacheEntryKey& key,
const scoped_refptr<ResIdOrErrorHolder>& res_id_or_error,
base::Time last_used,
scoped_refptr<net::GrowableIOBuffer> buffer,
int64_t header_size_delta,
std::unique_ptr<ExclusiveOperationCoordinator::OperationHandle> handle) {
const auto optional_res_id = GetResId(res_id_or_error);
if (!optional_res_id) {
// Speculative entry creation was failed.
const auto optional_error = GetError(res_id_or_error);
CHECK(optional_error.has_value());
return;
}
store_->UpdateEntryHeaderAndLastUsed(
key, *optional_res_id, last_used, std::move(buffer), header_size_delta,
WrapErrorCallbackToPopInFlightEntryModification(
key, base::DoNothingWithBoundArgs(std::move(handle))));
}
void SqlBackendImpl::WriteEntryData(
const CacheEntryKey& key,
const scoped_refptr<ResIdOrErrorHolder>& res_id_or_error,
int64_t old_body_end,
int64_t body_end,
int64_t offset,
scoped_refptr<net::IOBuffer> buffer,
int buf_len,
bool truncate,
SqlPersistentStore::ErrorCallback callback) {
in_flight_entry_modifications_[key].emplace_back(res_id_or_error, body_end);
exclusive_operation_coordinator_.PostOrRunNormalOperation(
key, base::BindOnce(&SqlBackendImpl::HandleWriteEntryDataOperation,
weak_factory_.GetWeakPtr(), key, res_id_or_error,
old_body_end, offset, std::move(buffer), buf_len,
truncate, std::move(callback)));
}
void SqlBackendImpl::HandleWriteEntryDataOperation(
const CacheEntryKey& key,
const scoped_refptr<ResIdOrErrorHolder>& res_id_or_error,
int64_t old_body_end,
int64_t offset,
scoped_refptr<net::IOBuffer> buffer,
int buf_len,
bool truncate,
SqlPersistentStore::ErrorCallback callback,
std::unique_ptr<ExclusiveOperationCoordinator::OperationHandle> handle) {
const auto optional_res_id = GetResId(res_id_or_error);
if (!optional_res_id) {
// Speculative entry creation was failed.
const auto optional_error = GetError(res_id_or_error);
CHECK(optional_error.has_value());
std::move(callback).Run(*optional_error);
return;
}
store_->WriteEntryData(
key, *optional_res_id, old_body_end, offset, std::move(buffer), buf_len,
truncate,
WrapErrorCallbackToPopInFlightEntryModification(key, std::move(callback))
.Then(DoNothingWithBoundHandle(std::move(handle))));
}
void SqlBackendImpl::ReadEntryData(
const CacheEntryKey& key,
const scoped_refptr<ResIdOrErrorHolder>& res_id_or_error,
int64_t offset,
scoped_refptr<net::IOBuffer> buffer,
int buf_len,
int64_t body_end,
bool sparse_reading,
SqlPersistentStore::IntOrErrorCallback callback) {
exclusive_operation_coordinator_.PostOrRunNormalOperation(
key, base::BindOnce(&SqlBackendImpl::HandleReadEntryDataOperation,
weak_factory_.GetWeakPtr(), res_id_or_error, offset,
std::move(buffer), buf_len, body_end, sparse_reading,
std::move(callback)));
}
void SqlBackendImpl::HandleReadEntryDataOperation(
const scoped_refptr<ResIdOrErrorHolder>& res_id_or_error,
int64_t offset,
scoped_refptr<net::IOBuffer> buffer,
int buf_len,
int64_t body_end,
bool sparse_reading,
SqlPersistentStore::IntOrErrorCallback callback,
std::unique_ptr<ExclusiveOperationCoordinator::OperationHandle> handle) {
const auto optional_res_id = GetResId(res_id_or_error);
if (!optional_res_id) {
// Speculative entry creation was failed.
const auto optional_error = GetError(res_id_or_error);
CHECK(optional_error.has_value());
std::move(callback).Run(net::ERR_FAILED);
return;
}
store_->ReadEntryData(
*optional_res_id, offset, buffer, buf_len, body_end, sparse_reading,
std::move(callback).Then(DoNothingWithBoundHandle(std::move(handle))));
}
void SqlBackendImpl::GetEntryAvailableRange(
const CacheEntryKey& key,
const scoped_refptr<ResIdOrErrorHolder>& res_id_or_error,
int64_t offset,
int len,
RangeResultCallback callback) {
exclusive_operation_coordinator_.PostOrRunNormalOperation(
key,
base::BindOnce(&SqlBackendImpl::HandleGetEntryAvailableRangeOperation,
weak_factory_.GetWeakPtr(), res_id_or_error, offset, len,
std::move(callback)));
}
void SqlBackendImpl::HandleGetEntryAvailableRangeOperation(
const scoped_refptr<ResIdOrErrorHolder>& res_id_or_error,
int64_t offset,
int len,
RangeResultCallback callback,
std::unique_ptr<ExclusiveOperationCoordinator::OperationHandle> handle) {
const auto optional_res_id = GetResId(res_id_or_error);
if (!optional_res_id) {
// Speculative entry creation was failed.
const auto optional_error = GetError(res_id_or_error);
CHECK(optional_error.has_value());
std::move(callback).Run(RangeResult(net::ERR_FAILED));
return;
}
store_->GetEntryAvailableRange(*optional_res_id, offset, len,
std::move(callback));
}
void SqlBackendImpl::ApplyInFlightEntryModifications(
const CacheEntryKey& key,
SqlPersistentStore::EntryInfo& entry_info) {
auto it = in_flight_entry_modifications_.find(key);
if (it == in_flight_entry_modifications_.end()) {
return;
}
for (const auto& modification : it->second) {
std::optional<SqlPersistentStore::ResId> optional_res_id =
modification.res_id_or_error ? GetResId(modification.res_id_or_error)
: std::nullopt;
if (!modification.res_id_or_error ||
(optional_res_id.has_value() &&
*optional_res_id == entry_info.res_id)) {
if (modification.last_used.has_value()) {
entry_info.last_used = *modification.last_used;
}
if (modification.head.has_value()) {
entry_info.head = *modification.head;
}
if (modification.body_end.has_value()) {
entry_info.body_end = *modification.body_end;
}
}
}
}
SqlPersistentStore::ErrorCallback
SqlBackendImpl::WrapErrorCallbackToPopInFlightEntryModification(
const CacheEntryKey& key,
SqlPersistentStore::ErrorCallback callback) {
return base::BindOnce(
[](base::WeakPtr<SqlBackendImpl> weak_ptr, const CacheEntryKey& key,
SqlPersistentStore::ErrorCallback callback,
SqlPersistentStore::Error result) {
if (weak_ptr) {
// The in-flight modifications for a given key are queued and removed
// in FIFO order. This is safe because
// `exclusive_operation_coordinator_` serializes all normal operations
// for the same key. This guarantees that modifications are enqueued
// and the corresponding store operations are executed in the same
// order.
auto it = weak_ptr->in_flight_entry_modifications_.find(key);
CHECK(it != weak_ptr->in_flight_entry_modifications_.end());
CHECK(!it->second.empty());
it->second.pop_front();
if (it->second.empty()) {
weak_ptr->in_flight_entry_modifications_.erase(it);
}
}
std::move(callback).Run(result);
},
weak_factory_.GetWeakPtr(), key, std::move(callback));
}
int SqlBackendImpl::FlushQueueForTest(CompletionOnceCallback callback) {
exclusive_operation_coordinator_.PostOrRunExclusiveOperation(base::BindOnce(
[](scoped_refptr<base::SequencedTaskRunner> background_task_runner,
CompletionOnceCallback callback,
std::unique_ptr<ExclusiveOperationCoordinator::OperationHandle>
handle) {
background_task_runner->PostTaskAndReply(
// Post a no-op task to the background runner.
FROM_HERE, base::BindOnce([]() {}),
base::BindOnce(std::move(callback), net::OK)
.Then(DoNothingWithBoundHandle(std::move(handle))));
},
background_task_runner_, std::move(callback)));
return net::ERR_IO_PENDING;
}
void SqlBackendImpl::MaybeTriggerEviction() {
if (!store_->ShouldStartEviction() || eviction_operation_queued_) {
return;
}
eviction_operation_queued_ = true;
exclusive_operation_coordinator_.PostOrRunExclusiveOperation(base::BindOnce(
base::BindOnce(&SqlBackendImpl::HandleTriggerEvictionOperation,
weak_factory_.GetWeakPtr())));
}
void SqlBackendImpl::HandleTriggerEvictionOperation(
std::unique_ptr<ExclusiveOperationCoordinator::OperationHandle> handle) {
eviction_operation_queued_ = false;
if (!store_->ShouldStartEviction()) {
return;
}
std::vector<CacheEntryKey> excluded_keys_vec;
excluded_keys_vec.reserve(active_entries_.size());
for (const auto& pair : active_entries_) {
excluded_keys_vec.push_back(pair.first);
}
base::flat_set<CacheEntryKey> excluded_keys(base::sorted_unique,
std::move(excluded_keys_vec));
store_->StartEviction(
std::move(excluded_keys),
base::BindOnce([](SqlPersistentStore::Error result) {}));
}
void SqlBackendImpl::TriggerDeleteDoomedEntries() {
// TODO(crbug.com/443171275): Get information on whether a doomed entry
// exists when initializing SqlPersistentStore, and if it does not exist, do
// not execute TriggerDeleteDoomedEntries.
// TODO(crbug.com/443171275): Execute only when the browser is idle.
exclusive_operation_coordinator_.PostOrRunExclusiveOperation(base::BindOnce(
base::BindOnce(&SqlBackendImpl::HandleDeleteDoomedEntriesOperation,
weak_factory_.GetWeakPtr())));
}
void SqlBackendImpl::HandleDeleteDoomedEntriesOperation(
std::unique_ptr<ExclusiveOperationCoordinator::OperationHandle> handle) {
std::vector<SqlPersistentStore::ResId> excluded_ids_vec;
excluded_ids_vec.reserve(doomed_entries_.size());
for (const auto& entry : doomed_entries_) {
const auto optional_res_id = GetResId(entry->res_id_or_error());
if (optional_res_id.has_value()) {
excluded_ids_vec.push_back(*optional_res_id);
}
}
std::sort(excluded_ids_vec.begin(), excluded_ids_vec.end());
base::flat_set<SqlPersistentStore::ResId> excluded_ids(
base::sorted_unique, std::move(excluded_ids_vec));
store_->DeleteDoomedEntries(
std::move(excluded_ids),
base::BindOnce([](SqlPersistentStore::Error result) {
}).Then(DoNothingWithBoundHandle(std::move(handle))));
}
void SqlBackendImpl::EnableStrictCorruptionCheckForTesting() {
store_->EnableStrictCorruptionCheckForTesting(); // IN-TEST
}
SqlBackendImpl::InFlightEntryModification::InFlightEntryModification(
const scoped_refptr<ResIdOrErrorHolder>& res_id_or_error,
base::Time last_used)
: res_id_or_error(res_id_or_error), last_used(last_used) {}
SqlBackendImpl::InFlightEntryModification::InFlightEntryModification(
const scoped_refptr<ResIdOrErrorHolder>& res_id_or_error,
base::Time last_used,
scoped_refptr<net::GrowableIOBuffer> head)
: res_id_or_error(res_id_or_error),
last_used(last_used),
head(std::move(head)) {}
SqlBackendImpl::InFlightEntryModification::InFlightEntryModification(
const scoped_refptr<ResIdOrErrorHolder>& res_id_or_error,
int64_t body_end)
: res_id_or_error(res_id_or_error), body_end(body_end) {}
SqlBackendImpl::InFlightEntryModification::~InFlightEntryModification() =
default;
SqlBackendImpl::InFlightEntryModification::InFlightEntryModification(
InFlightEntryModification&&) = default;
} // namespace disk_cache