blob: 8e45cf2e24a32d9ca3f3e38c2e2634b3a063f0ee [file] [log] [blame]
// Copyright 2013 The Chromium Authors. All rights reserved.
// Use of this source code is governed by a BSD-style license that can be
// found in the LICENSE file.
#include "chrome/browser/sync_file_system/local/local_file_sync_context.h"
#include "base/bind.h"
#include "base/file_util.h"
#include "base/location.h"
#include "base/platform_file.h"
#include "base/single_thread_task_runner.h"
#include "base/stl_util.h"
#include "base/task_runner_util.h"
#include "chrome/browser/sync_file_system/file_change.h"
#include "chrome/browser/sync_file_system/local/local_file_change_tracker.h"
#include "chrome/browser/sync_file_system/local/local_origin_change_observer.h"
#include "chrome/browser/sync_file_system/local/sync_file_system_backend.h"
#include "chrome/browser/sync_file_system/local/syncable_file_operation_runner.h"
#include "chrome/browser/sync_file_system/sync_file_metadata.h"
#include "chrome/browser/sync_file_system/syncable_file_system_util.h"
#include "webkit/browser/fileapi/file_system_context.h"
#include "webkit/browser/fileapi/file_system_file_util.h"
#include "webkit/browser/fileapi/file_system_operation_context.h"
#include "webkit/browser/fileapi/file_system_operation_runner.h"
#include "webkit/common/blob/scoped_file.h"
#include "webkit/common/fileapi/file_system_util.h"
using fileapi::FileSystemContext;
using fileapi::FileSystemFileUtil;
using fileapi::FileSystemOperation;
using fileapi::FileSystemOperationContext;
using fileapi::FileSystemURL;
namespace sync_file_system {
namespace {
const int kMaxConcurrentSyncableOperation = 3;
const int kNotifyChangesDurationInSec = 1;
const int kMaxURLsToFetchForLocalSync = 5;
const base::FilePath::CharType kSnapshotDir[] = FILE_PATH_LITERAL("snapshots");
} // namespace
LocalFileSyncContext::LocalFileSyncContext(
const base::FilePath& base_path,
base::SingleThreadTaskRunner* ui_task_runner,
base::SingleThreadTaskRunner* io_task_runner)
: local_base_path_(base_path.Append(FILE_PATH_LITERAL("local"))),
ui_task_runner_(ui_task_runner),
io_task_runner_(io_task_runner),
shutdown_on_ui_(false),
mock_notify_changes_duration_in_sec_(-1) {
DCHECK(ui_task_runner_->RunsTasksOnCurrentThread());
}
void LocalFileSyncContext::MaybeInitializeFileSystemContext(
const GURL& source_url,
FileSystemContext* file_system_context,
const SyncStatusCallback& callback) {
DCHECK(ui_task_runner_->RunsTasksOnCurrentThread());
if (ContainsKey(file_system_contexts_, file_system_context)) {
// The context has been already initialized. Just dispatch the callback
// with SYNC_STATUS_OK.
ui_task_runner_->PostTask(FROM_HERE,
base::Bind(callback,
SYNC_STATUS_OK));
return;
}
StatusCallbackQueue& callback_queue =
pending_initialize_callbacks_[file_system_context];
callback_queue.push_back(callback);
if (callback_queue.size() > 1)
return;
io_task_runner_->PostTask(
FROM_HERE,
base::Bind(&LocalFileSyncContext::InitializeFileSystemContextOnIOThread,
this, source_url,
make_scoped_refptr(file_system_context)));
}
void LocalFileSyncContext::ShutdownOnUIThread() {
DCHECK(ui_task_runner_->RunsTasksOnCurrentThread());
shutdown_on_ui_ = true;
io_task_runner_->PostTask(
FROM_HERE,
base::Bind(&LocalFileSyncContext::ShutdownOnIOThread,
this));
}
void LocalFileSyncContext::GetFileForLocalSync(
FileSystemContext* file_system_context,
const LocalFileSyncInfoCallback& callback) {
DCHECK(file_system_context);
DCHECK(ui_task_runner_->RunsTasksOnCurrentThread());
std::deque<FileSystemURL>* urls = new std::deque<FileSystemURL>;
file_system_context->default_file_task_runner()->PostTaskAndReply(
FROM_HERE,
base::Bind(&LocalFileSyncContext::GetNextURLsForSyncOnFileThread,
this, make_scoped_refptr(file_system_context),
base::Unretained(urls)),
base::Bind(&LocalFileSyncContext::TryPrepareForLocalSync,
this, make_scoped_refptr(file_system_context),
base::Owned(urls), callback));
}
void LocalFileSyncContext::ClearChangesForURL(
FileSystemContext* file_system_context,
const FileSystemURL& url,
const base::Closure& done_callback) {
// This is initially called on UI thread and to be relayed to FILE thread.
DCHECK(file_system_context);
if (!file_system_context->default_file_task_runner()->
RunsTasksOnCurrentThread()) {
DCHECK(ui_task_runner_->RunsTasksOnCurrentThread());
file_system_context->default_file_task_runner()->PostTask(
FROM_HERE,
base::Bind(&LocalFileSyncContext::ClearChangesForURL,
this, make_scoped_refptr(file_system_context),
url, done_callback));
return;
}
SyncFileSystemBackend* backend =
SyncFileSystemBackend::GetBackend(file_system_context);
DCHECK(backend);
DCHECK(backend->change_tracker());
backend->change_tracker()->ClearChangesForURL(url);
// Call the completion callback on UI thread.
ui_task_runner_->PostTask(FROM_HERE, done_callback);
}
void LocalFileSyncContext::CommitChangeStatusForURL(
fileapi::FileSystemContext* file_system_context,
const fileapi::FileSystemURL& url,
SyncStatusCode sync_finish_status,
const base::Closure& done_callback) {
DCHECK(file_system_context);
if (!file_system_context->default_file_task_runner()->
RunsTasksOnCurrentThread()) {
file_system_context->default_file_task_runner()->PostTask(
FROM_HERE,
base::Bind(&LocalFileSyncContext::CommitChangeStatusForURL,
this, make_scoped_refptr(file_system_context),
url, sync_finish_status, done_callback));
return;
}
SyncFileSystemBackend* backend =
SyncFileSystemBackend::GetBackend(file_system_context);
DCHECK(backend);
DCHECK(backend->change_tracker());
if (sync_finish_status == SYNC_STATUS_OK ||
sync_finish_status == SYNC_STATUS_HAS_CONFLICT) {
// Commit the in-memory mirror change.
backend->change_tracker()->ResetToMirrorAndCommitChangesForURL(url);
} else {
// Abort in-memory mirror change.
backend->change_tracker()->RemoveMirrorAndCommitChangesForURL(url);
}
// We've been keeping it in writing mode, so clear the writing counter
// to unblock sync activities.
io_task_runner_->PostTask(
FROM_HERE, base::Bind(&LocalFileSyncContext::EndWritingOnIOThread,
this, url));
// Call the completion callback on UI thread.
ui_task_runner_->PostTask(FROM_HERE, done_callback);
}
void LocalFileSyncContext::ClearSyncFlagForURL(const FileSystemURL& url) {
// This is initially called on UI thread and to be relayed to IO thread.
io_task_runner_->PostTask(
FROM_HERE,
base::Bind(&LocalFileSyncContext::ClearSyncFlagOnIOThread,
this, url, false /* keep_url_in_writing */));
}
void LocalFileSyncContext::PrepareForSync(
FileSystemContext* file_system_context,
const FileSystemURL& url,
SyncMode sync_mode,
const LocalFileSyncInfoCallback& callback) {
// This is initially called on UI thread and to be relayed to IO thread.
if (!io_task_runner_->RunsTasksOnCurrentThread()) {
DCHECK(ui_task_runner_->RunsTasksOnCurrentThread());
io_task_runner_->PostTask(
FROM_HERE,
base::Bind(&LocalFileSyncContext::PrepareForSync, this,
make_scoped_refptr(file_system_context), url,
sync_mode, callback));
return;
}
DCHECK(io_task_runner_->RunsTasksOnCurrentThread());
const bool syncable = sync_status()->IsSyncable(url);
// Disable writing if it's ready to be synced.
if (syncable)
sync_status()->StartSyncing(url);
ui_task_runner_->PostTask(
FROM_HERE,
base::Bind(&LocalFileSyncContext::DidGetWritingStatusForSync,
this, make_scoped_refptr(file_system_context),
syncable ? SYNC_STATUS_OK :
SYNC_STATUS_FILE_BUSY,
url, sync_mode, callback));
}
void LocalFileSyncContext::RegisterURLForWaitingSync(
const FileSystemURL& url,
const base::Closure& on_syncable_callback) {
// This is initially called on UI thread and to be relayed to IO thread.
if (!io_task_runner_->RunsTasksOnCurrentThread()) {
DCHECK(ui_task_runner_->RunsTasksOnCurrentThread());
io_task_runner_->PostTask(
FROM_HERE,
base::Bind(&LocalFileSyncContext::RegisterURLForWaitingSync,
this, url, on_syncable_callback));
return;
}
DCHECK(io_task_runner_->RunsTasksOnCurrentThread());
if (sync_status()->IsSyncable(url)) {
// No need to register; fire the callback now.
ui_task_runner_->PostTask(FROM_HERE, on_syncable_callback);
return;
}
url_waiting_sync_on_io_ = url;
url_syncable_callback_ = on_syncable_callback;
}
void LocalFileSyncContext::ApplyRemoteChange(
FileSystemContext* file_system_context,
const FileChange& change,
const base::FilePath& local_path,
const FileSystemURL& url,
const SyncStatusCallback& callback) {
if (!io_task_runner_->RunsTasksOnCurrentThread()) {
DCHECK(ui_task_runner_->RunsTasksOnCurrentThread());
io_task_runner_->PostTask(
FROM_HERE,
base::Bind(&LocalFileSyncContext::ApplyRemoteChange, this,
make_scoped_refptr(file_system_context),
change, local_path, url, callback));
return;
}
DCHECK(io_task_runner_->RunsTasksOnCurrentThread());
DCHECK(!sync_status()->IsWritable(url));
DCHECK(!sync_status()->IsWriting(url));
FileSystemOperation::StatusCallback operation_callback;
if (change.change() == FileChange::FILE_CHANGE_ADD_OR_UPDATE) {
operation_callback = base::Bind(
&LocalFileSyncContext::DidRemoveExistingEntryForApplyRemoteChange,
this,
make_scoped_refptr(file_system_context),
change,
local_path,
url,
callback);
} else {
DCHECK_EQ(FileChange::FILE_CHANGE_DELETE, change.change());
operation_callback = base::Bind(
&LocalFileSyncContext::DidApplyRemoteChange, this, url, callback);
}
FileSystemURL url_for_sync = CreateSyncableFileSystemURLForSync(
file_system_context, url);
file_system_context->operation_runner()->Remove(
url_for_sync, true /* recursive */, operation_callback);
}
void LocalFileSyncContext::DidRemoveExistingEntryForApplyRemoteChange(
FileSystemContext* file_system_context,
const FileChange& change,
const base::FilePath& local_path,
const FileSystemURL& url,
const SyncStatusCallback& callback,
base::PlatformFileError error) {
// Remove() may fail if the target entry does not exist (which is ok),
// so we ignore |error| here.
if (!sync_status()) {
callback.Run(SYNC_FILE_ERROR_ABORT);
return;
}
DCHECK(io_task_runner_->RunsTasksOnCurrentThread());
DCHECK(!sync_status()->IsWritable(url));
DCHECK(!sync_status()->IsWriting(url));
FileSystemURL url_for_sync = CreateSyncableFileSystemURLForSync(
file_system_context, url);
FileSystemOperation::StatusCallback operation_callback = base::Bind(
&LocalFileSyncContext::DidApplyRemoteChange, this, url, callback);
DCHECK_EQ(FileChange::FILE_CHANGE_ADD_OR_UPDATE, change.change());
switch (change.file_type()) {
case SYNC_FILE_TYPE_FILE: {
DCHECK(!local_path.empty());
base::FilePath dir_path = fileapi::VirtualPath::DirName(url.path());
if (dir_path.empty() ||
fileapi::VirtualPath::DirName(dir_path) == dir_path) {
// Copying into the root directory.
file_system_context->operation_runner()->CopyInForeignFile(
local_path, url_for_sync, operation_callback);
} else {
FileSystemURL dir_url = file_system_context->CreateCrackedFileSystemURL(
url_for_sync.origin(),
url_for_sync.mount_type(),
fileapi::VirtualPath::DirName(url_for_sync.virtual_path()));
file_system_context->operation_runner()->CreateDirectory(
dir_url,
false /* exclusive */,
true /* recursive */,
base::Bind(&LocalFileSyncContext::DidCreateDirectoryForCopyIn,
this,
make_scoped_refptr(file_system_context),
local_path,
url,
operation_callback));
}
break;
}
case SYNC_FILE_TYPE_DIRECTORY:
file_system_context->operation_runner()->CreateDirectory(
url_for_sync, false /* exclusive */, true /* recursive */,
operation_callback);
break;
case SYNC_FILE_TYPE_UNKNOWN:
NOTREACHED() << "File type unknown for ADD_OR_UPDATE change";
}
}
void LocalFileSyncContext::RecordFakeLocalChange(
FileSystemContext* file_system_context,
const FileSystemURL& url,
const FileChange& change,
const SyncStatusCallback& callback) {
// This is called on UI thread and to be relayed to FILE thread.
DCHECK(file_system_context);
if (!file_system_context->default_file_task_runner()->
RunsTasksOnCurrentThread()) {
DCHECK(ui_task_runner_->RunsTasksOnCurrentThread());
file_system_context->default_file_task_runner()->PostTask(
FROM_HERE,
base::Bind(&LocalFileSyncContext::RecordFakeLocalChange,
this, make_scoped_refptr(file_system_context),
url, change, callback));
return;
}
SyncFileSystemBackend* backend =
SyncFileSystemBackend::GetBackend(file_system_context);
DCHECK(backend);
DCHECK(backend->change_tracker());
backend->change_tracker()->MarkDirtyOnDatabase(url);
backend->change_tracker()->RecordChange(url, change);
// Fire the callback on UI thread.
ui_task_runner_->PostTask(FROM_HERE,
base::Bind(callback,
SYNC_STATUS_OK));
}
void LocalFileSyncContext::GetFileMetadata(
FileSystemContext* file_system_context,
const FileSystemURL& url,
const SyncFileMetadataCallback& callback) {
// This is initially called on UI thread and to be relayed to IO thread.
if (!io_task_runner_->RunsTasksOnCurrentThread()) {
DCHECK(ui_task_runner_->RunsTasksOnCurrentThread());
io_task_runner_->PostTask(
FROM_HERE,
base::Bind(&LocalFileSyncContext::GetFileMetadata, this,
make_scoped_refptr(file_system_context), url, callback));
return;
}
DCHECK(io_task_runner_->RunsTasksOnCurrentThread());
FileSystemURL url_for_sync = CreateSyncableFileSystemURLForSync(
file_system_context, url);
file_system_context->operation_runner()->GetMetadata(
url_for_sync, base::Bind(&LocalFileSyncContext::DidGetFileMetadata,
this, callback));
}
void LocalFileSyncContext::HasPendingLocalChanges(
FileSystemContext* file_system_context,
const FileSystemURL& url,
const HasPendingLocalChangeCallback& callback) {
// This gets called on UI thread and relays the task on FILE thread.
DCHECK(file_system_context);
if (!file_system_context->default_file_task_runner()->
RunsTasksOnCurrentThread()) {
DCHECK(ui_task_runner_->RunsTasksOnCurrentThread());
file_system_context->default_file_task_runner()->PostTask(
FROM_HERE,
base::Bind(&LocalFileSyncContext::HasPendingLocalChanges,
this, make_scoped_refptr(file_system_context),
url, callback));
return;
}
SyncFileSystemBackend* backend =
SyncFileSystemBackend::GetBackend(file_system_context);
DCHECK(backend);
DCHECK(backend->change_tracker());
FileChangeList changes;
backend->change_tracker()->GetChangesForURL(url, &changes);
// Fire the callback on UI thread.
ui_task_runner_->PostTask(FROM_HERE,
base::Bind(callback,
SYNC_STATUS_OK,
!changes.empty()));
}
void LocalFileSyncContext::AddOriginChangeObserver(
LocalOriginChangeObserver* observer) {
origin_change_observers_.AddObserver(observer);
}
void LocalFileSyncContext::RemoveOriginChangeObserver(
LocalOriginChangeObserver* observer) {
origin_change_observers_.RemoveObserver(observer);
}
base::WeakPtr<SyncableFileOperationRunner>
LocalFileSyncContext::operation_runner() const {
DCHECK(io_task_runner_->RunsTasksOnCurrentThread());
if (operation_runner_)
return operation_runner_->AsWeakPtr();
return base::WeakPtr<SyncableFileOperationRunner>();
}
LocalFileSyncStatus* LocalFileSyncContext::sync_status() const {
DCHECK(io_task_runner_->RunsTasksOnCurrentThread());
return sync_status_.get();
}
void LocalFileSyncContext::OnSyncEnabled(const FileSystemURL& url) {
DCHECK(io_task_runner_->RunsTasksOnCurrentThread());
origins_with_pending_changes_.insert(url.origin());
ScheduleNotifyChangesUpdatedOnIOThread();
if (url_syncable_callback_.is_null() ||
sync_status()->IsWriting(url_waiting_sync_on_io_)) {
return;
}
// TODO(kinuko): may want to check how many pending tasks we have.
ui_task_runner_->PostTask(FROM_HERE, url_syncable_callback_);
url_syncable_callback_.Reset();
}
void LocalFileSyncContext::OnWriteEnabled(const FileSystemURL& url) {
DCHECK(io_task_runner_->RunsTasksOnCurrentThread());
// Nothing to do for now.
}
LocalFileSyncContext::~LocalFileSyncContext() {
}
void LocalFileSyncContext::ScheduleNotifyChangesUpdatedOnIOThread() {
DCHECK(io_task_runner_->RunsTasksOnCurrentThread());
if (base::Time::Now() > last_notified_changes_ + NotifyChangesDuration()) {
NotifyAvailableChangesOnIOThread();
} else if (!timer_on_io_->IsRunning()) {
timer_on_io_->Start(
FROM_HERE, NotifyChangesDuration(), this,
&LocalFileSyncContext::NotifyAvailableChangesOnIOThread);
}
}
void LocalFileSyncContext::NotifyAvailableChangesOnIOThread() {
DCHECK(io_task_runner_->RunsTasksOnCurrentThread());
ui_task_runner_->PostTask(
FROM_HERE,
base::Bind(&LocalFileSyncContext::NotifyAvailableChanges,
this, origins_with_pending_changes_));
last_notified_changes_ = base::Time::Now();
origins_with_pending_changes_.clear();
}
void LocalFileSyncContext::NotifyAvailableChanges(
const std::set<GURL>& origins) {
FOR_EACH_OBSERVER(LocalOriginChangeObserver, origin_change_observers_,
OnChangesAvailableInOrigins(origins));
}
void LocalFileSyncContext::ShutdownOnIOThread() {
DCHECK(io_task_runner_->RunsTasksOnCurrentThread());
operation_runner_.reset();
sync_status_.reset();
timer_on_io_.reset();
}
void LocalFileSyncContext::InitializeFileSystemContextOnIOThread(
const GURL& source_url,
FileSystemContext* file_system_context) {
DCHECK(io_task_runner_->RunsTasksOnCurrentThread());
DCHECK(file_system_context);
SyncFileSystemBackend* backend =
SyncFileSystemBackend::GetBackend(file_system_context);
DCHECK(backend);
if (!backend->change_tracker()) {
// First registers the service name.
RegisterSyncableFileSystem();
// Create and initialize LocalFileChangeTracker and call back this method
// later again.
std::set<GURL>* origins_with_changes = new std::set<GURL>;
scoped_ptr<LocalFileChangeTracker>* tracker_ptr(
new scoped_ptr<LocalFileChangeTracker>);
base::PostTaskAndReplyWithResult(
file_system_context->default_file_task_runner(),
FROM_HERE,
base::Bind(&LocalFileSyncContext::InitializeChangeTrackerOnFileThread,
this, tracker_ptr,
make_scoped_refptr(file_system_context),
origins_with_changes),
base::Bind(&LocalFileSyncContext::DidInitializeChangeTrackerOnIOThread,
this, base::Owned(tracker_ptr),
source_url,
make_scoped_refptr(file_system_context),
base::Owned(origins_with_changes)));
return;
}
if (!operation_runner_) {
DCHECK(!sync_status_);
DCHECK(!timer_on_io_);
sync_status_.reset(new LocalFileSyncStatus);
timer_on_io_.reset(new base::OneShotTimer<LocalFileSyncContext>);
operation_runner_.reset(new SyncableFileOperationRunner(
kMaxConcurrentSyncableOperation,
sync_status_.get()));
sync_status_->AddObserver(this);
}
backend->set_sync_context(this);
DidInitialize(source_url, file_system_context,
SYNC_STATUS_OK);
}
SyncStatusCode LocalFileSyncContext::InitializeChangeTrackerOnFileThread(
scoped_ptr<LocalFileChangeTracker>* tracker_ptr,
FileSystemContext* file_system_context,
std::set<GURL>* origins_with_changes) {
DCHECK(file_system_context);
DCHECK(tracker_ptr);
DCHECK(origins_with_changes);
tracker_ptr->reset(new LocalFileChangeTracker(
file_system_context->partition_path(),
file_system_context->default_file_task_runner()));
const SyncStatusCode status = (*tracker_ptr)->Initialize(file_system_context);
if (status != SYNC_STATUS_OK)
return status;
// Get all origins that have pending changes.
std::deque<FileSystemURL> urls;
(*tracker_ptr)->GetNextChangedURLs(&urls, 0);
for (std::deque<FileSystemURL>::iterator iter = urls.begin();
iter != urls.end(); ++iter) {
origins_with_changes->insert(iter->origin());
}
// Creates snapshot directory.
file_util::CreateDirectory(local_base_path_.Append(kSnapshotDir));
return status;
}
void LocalFileSyncContext::DidInitializeChangeTrackerOnIOThread(
scoped_ptr<LocalFileChangeTracker>* tracker_ptr,
const GURL& source_url,
FileSystemContext* file_system_context,
std::set<GURL>* origins_with_changes,
SyncStatusCode status) {
DCHECK(io_task_runner_->RunsTasksOnCurrentThread());
DCHECK(file_system_context);
DCHECK(origins_with_changes);
if (status != SYNC_STATUS_OK) {
DidInitialize(source_url, file_system_context, status);
return;
}
SyncFileSystemBackend* backend =
SyncFileSystemBackend::GetBackend(file_system_context);
DCHECK(backend);
backend->SetLocalFileChangeTracker(tracker_ptr->Pass());
origins_with_pending_changes_.insert(origins_with_changes->begin(),
origins_with_changes->end());
ScheduleNotifyChangesUpdatedOnIOThread();
InitializeFileSystemContextOnIOThread(source_url, file_system_context);
}
void LocalFileSyncContext::DidInitialize(
const GURL& source_url,
FileSystemContext* file_system_context,
SyncStatusCode status) {
if (!ui_task_runner_->RunsTasksOnCurrentThread()) {
ui_task_runner_->PostTask(
FROM_HERE,
base::Bind(&LocalFileSyncContext::DidInitialize,
this, source_url,
make_scoped_refptr(file_system_context), status));
return;
}
DCHECK(ui_task_runner_->RunsTasksOnCurrentThread());
DCHECK(!ContainsKey(file_system_contexts_, file_system_context));
DCHECK(ContainsKey(pending_initialize_callbacks_, file_system_context));
SyncFileSystemBackend* backend =
SyncFileSystemBackend::GetBackend(file_system_context);
DCHECK(backend);
DCHECK(backend->change_tracker());
file_system_contexts_.insert(file_system_context);
StatusCallbackQueue& callback_queue =
pending_initialize_callbacks_[file_system_context];
for (StatusCallbackQueue::iterator iter = callback_queue.begin();
iter != callback_queue.end(); ++iter) {
ui_task_runner_->PostTask(FROM_HERE, base::Bind(*iter, status));
}
pending_initialize_callbacks_.erase(file_system_context);
}
void LocalFileSyncContext::GetNextURLsForSyncOnFileThread(
FileSystemContext* file_system_context,
std::deque<FileSystemURL>* urls) {
DCHECK(file_system_context);
DCHECK(file_system_context->default_file_task_runner()->
RunsTasksOnCurrentThread());
SyncFileSystemBackend* backend =
SyncFileSystemBackend::GetBackend(file_system_context);
DCHECK(backend);
DCHECK(backend->change_tracker());
backend->change_tracker()->GetNextChangedURLs(
urls, kMaxURLsToFetchForLocalSync);
}
void LocalFileSyncContext::TryPrepareForLocalSync(
FileSystemContext* file_system_context,
std::deque<FileSystemURL>* urls,
const LocalFileSyncInfoCallback& callback) {
DCHECK(ui_task_runner_->RunsTasksOnCurrentThread());
DCHECK(urls);
if (shutdown_on_ui_) {
callback.Run(SYNC_STATUS_ABORT, LocalFileSyncInfo(),
scoped_ptr<webkit_blob::ScopedFile>());
return;
}
if (urls->empty()) {
callback.Run(SYNC_STATUS_NO_CHANGE_TO_SYNC, LocalFileSyncInfo(),
scoped_ptr<webkit_blob::ScopedFile>());
return;
}
const FileSystemURL url = urls->front();
urls->pop_front();
std::deque<FileSystemURL>* remaining = new std::deque<FileSystemURL>;
remaining->swap(*urls);
PrepareForSync(
file_system_context, url, SYNC_SNAPSHOT,
base::Bind(&LocalFileSyncContext::DidTryPrepareForLocalSync,
this, make_scoped_refptr(file_system_context),
base::Owned(remaining), callback));
}
void LocalFileSyncContext::DidTryPrepareForLocalSync(
FileSystemContext* file_system_context,
std::deque<FileSystemURL>* remaining_urls,
const LocalFileSyncInfoCallback& callback,
SyncStatusCode status,
const LocalFileSyncInfo& sync_file_info,
scoped_ptr<webkit_blob::ScopedFile> snapshot) {
DCHECK(ui_task_runner_->RunsTasksOnCurrentThread());
if (status != SYNC_STATUS_FILE_BUSY) {
callback.Run(status, sync_file_info, snapshot.Pass());
return;
}
// Recursively call TryPrepareForLocalSync with remaining_urls.
TryPrepareForLocalSync(file_system_context, remaining_urls, callback);
}
void LocalFileSyncContext::DidGetWritingStatusForSync(
FileSystemContext* file_system_context,
SyncStatusCode status,
const FileSystemURL& url,
SyncMode sync_mode,
const LocalFileSyncInfoCallback& callback) {
// This gets called on UI thread and relays the task on FILE thread.
DCHECK(file_system_context);
if (!file_system_context->default_file_task_runner()->
RunsTasksOnCurrentThread()) {
DCHECK(ui_task_runner_->RunsTasksOnCurrentThread());
if (shutdown_on_ui_) {
callback.Run(SYNC_STATUS_ABORT, LocalFileSyncInfo(),
scoped_ptr<webkit_blob::ScopedFile>());
return;
}
file_system_context->default_file_task_runner()->PostTask(
FROM_HERE,
base::Bind(&LocalFileSyncContext::DidGetWritingStatusForSync,
this, make_scoped_refptr(file_system_context),
status, url, sync_mode, callback));
return;
}
SyncFileSystemBackend* backend =
SyncFileSystemBackend::GetBackend(file_system_context);
DCHECK(backend);
DCHECK(backend->change_tracker());
FileChangeList changes;
backend->change_tracker()->GetChangesForURL(url, &changes);
base::FilePath platform_path;
base::PlatformFileInfo file_info;
FileSystemFileUtil* file_util =
file_system_context->sandbox_delegate()->sync_file_util();
DCHECK(file_util);
base::PlatformFileError file_error = file_util->GetFileInfo(
make_scoped_ptr(
new FileSystemOperationContext(file_system_context)).get(),
url,
&file_info,
&platform_path);
scoped_ptr<webkit_blob::ScopedFile> snapshot;
if (file_error == base::PLATFORM_FILE_OK && sync_mode == SYNC_SNAPSHOT) {
base::FilePath snapshot_path;
file_util::CreateTemporaryFileInDir(local_base_path_.Append(kSnapshotDir),
&snapshot_path);
if (base::CopyFile(platform_path, snapshot_path)) {
platform_path = snapshot_path;
snapshot.reset(new webkit_blob::ScopedFile(
snapshot_path,
webkit_blob::ScopedFile::DELETE_ON_SCOPE_OUT,
file_system_context->default_file_task_runner()));
}
}
if (status == SYNC_STATUS_OK &&
file_error != base::PLATFORM_FILE_OK &&
file_error != base::PLATFORM_FILE_ERROR_NOT_FOUND)
status = PlatformFileErrorToSyncStatusCode(file_error);
DCHECK(!file_info.is_symbolic_link);
SyncFileType file_type = SYNC_FILE_TYPE_FILE;
if (file_error == base::PLATFORM_FILE_ERROR_NOT_FOUND)
file_type = SYNC_FILE_TYPE_UNKNOWN;
else if (file_info.is_directory)
file_type = SYNC_FILE_TYPE_DIRECTORY;
LocalFileSyncInfo sync_file_info;
sync_file_info.url = url;
sync_file_info.local_file_path = platform_path;
sync_file_info.metadata.file_type = file_type;
sync_file_info.metadata.size = file_info.size;
sync_file_info.metadata.last_modified = file_info.last_modified;
sync_file_info.changes = changes;
if (status == SYNC_STATUS_OK) {
if (!changes.empty()) {
// Now we create an empty mirror change record for URL (and we record
// changes to both mirror and original records during sync), so that
// we can reset to the mirror when the sync succeeds.
backend->change_tracker()->CreateFreshMirrorForURL(url);
}
// 'Unlock' the file if sync_mode is not SYNC_EXCLUSIVE.
// (But keep it in writing status so that no other sync starts on
// the same URL)
if (sync_mode != SYNC_EXCLUSIVE) {
io_task_runner_->PostTask(
FROM_HERE,
base::Bind(&LocalFileSyncContext::ClearSyncFlagOnIOThread,
this, url, true /* keep_url_in_writing */));
}
}
ui_task_runner_->PostTask(FROM_HERE,
base::Bind(callback, status, sync_file_info,
base::Passed(&snapshot)));
}
void LocalFileSyncContext::ClearSyncFlagOnIOThread(
const FileSystemURL& url,
bool keep_url_in_writing) {
DCHECK(io_task_runner_->RunsTasksOnCurrentThread());
if (!sync_status()) {
// The service might have been shut down.
return;
}
sync_status()->EndSyncing(url);
if (keep_url_in_writing) {
// The caller will hold shared lock on this one.
sync_status()->StartWriting(url);
return;
}
// Since a sync has finished the number of changes must have been updated.
origins_with_pending_changes_.insert(url.origin());
ScheduleNotifyChangesUpdatedOnIOThread();
}
void LocalFileSyncContext::EndWritingOnIOThread(
const FileSystemURL& url) {
DCHECK(io_task_runner_->RunsTasksOnCurrentThread());
if (!sync_status()) {
// The service might have been shut down.
return;
}
sync_status()->EndWriting(url);
}
void LocalFileSyncContext::DidApplyRemoteChange(
const FileSystemURL& url,
const SyncStatusCallback& callback_on_ui,
base::PlatformFileError file_error) {
DCHECK(io_task_runner_->RunsTasksOnCurrentThread());
ui_task_runner_->PostTask(
FROM_HERE,
base::Bind(callback_on_ui,
PlatformFileErrorToSyncStatusCode(file_error)));
ClearSyncFlagOnIOThread(url, false /* keep_url_in_writing */);
}
void LocalFileSyncContext::DidGetFileMetadata(
const SyncFileMetadataCallback& callback,
base::PlatformFileError file_error,
const base::PlatformFileInfo& file_info) {
DCHECK(io_task_runner_->RunsTasksOnCurrentThread());
SyncFileMetadata metadata;
if (file_error == base::PLATFORM_FILE_OK) {
metadata.file_type = file_info.is_directory ?
SYNC_FILE_TYPE_DIRECTORY : SYNC_FILE_TYPE_FILE;
metadata.size = file_info.size;
metadata.last_modified = file_info.last_modified;
}
ui_task_runner_->PostTask(
FROM_HERE,
base::Bind(callback,
PlatformFileErrorToSyncStatusCode(file_error),
metadata));
}
base::TimeDelta LocalFileSyncContext::NotifyChangesDuration() {
if (mock_notify_changes_duration_in_sec_ >= 0)
return base::TimeDelta::FromSeconds(mock_notify_changes_duration_in_sec_);
return base::TimeDelta::FromSeconds(kNotifyChangesDurationInSec);
}
void LocalFileSyncContext::DidCreateDirectoryForCopyIn(
FileSystemContext* file_system_context,
const base::FilePath& local_path,
const FileSystemURL& dest_url,
const StatusCallback& callback,
base::PlatformFileError error) {
if (error != base::PLATFORM_FILE_OK) {
callback.Run(error);
return;
}
FileSystemURL url_for_sync = CreateSyncableFileSystemURLForSync(
file_system_context, dest_url);
file_system_context->operation_runner()->CopyInForeignFile(
local_path, url_for_sync, callback);
}
} // namespace sync_file_system