123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476477478479480481482483484485486487488489490491492493494495496497498499500501502503504505506507508509510511512513514515516517518519520521522523524525526527528529530531532533534535536537538539540541542543544545546547548549550551552553554555556557558559560561 |
- /*
- * Copyright 2017 Google
- *
- * Licensed 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.
- */
- #import "FIRFirestore+Internal.h"
- #include <memory>
- #include <string>
- #include <utility>
- #import "FIRFirestoreSettings+Internal.h"
- #import "FIRTransactionOptions+Internal.h"
- #import "FIRTransactionOptions.h"
- #import "FirebaseCore/Extension/FIRAppInternal.h"
- #import "FirebaseCore/Extension/FIRComponentContainer.h"
- #import "FirebaseCore/Extension/FIRComponentType.h"
- #import "Firestore/Source/API/FIRCollectionReference+Internal.h"
- #import "Firestore/Source/API/FIRDocumentReference+Internal.h"
- #import "Firestore/Source/API/FIRListenerRegistration+Internal.h"
- #import "Firestore/Source/API/FIRLoadBundleTask+Internal.h"
- #import "Firestore/Source/API/FIRQuery+Internal.h"
- #import "Firestore/Source/API/FIRTransaction+Internal.h"
- #import "Firestore/Source/API/FIRWriteBatch+Internal.h"
- #import "Firestore/Source/API/FSTFirestoreComponent.h"
- #import "Firestore/Source/API/FSTUserDataReader.h"
- #include "Firestore/core/src/api/collection_reference.h"
- #include "Firestore/core/src/api/document_reference.h"
- #include "Firestore/core/src/api/firestore.h"
- #include "Firestore/core/src/api/write_batch.h"
- #include "Firestore/core/src/core/database_info.h"
- #include "Firestore/core/src/core/event_listener.h"
- #include "Firestore/core/src/core/transaction.h"
- #include "Firestore/core/src/credentials/credentials_provider.h"
- #include "Firestore/core/src/model/database_id.h"
- #include "Firestore/core/src/remote/firebase_metadata_provider.h"
- #include "Firestore/core/src/util/async_queue.h"
- #include "Firestore/core/src/util/byte_stream_apple.h"
- #include "Firestore/core/src/util/config.h"
- #include "Firestore/core/src/util/empty.h"
- #include "Firestore/core/src/util/error_apple.h"
- #include "Firestore/core/src/util/exception.h"
- #include "Firestore/core/src/util/exception_apple.h"
- #include "Firestore/core/src/util/executor_libdispatch.h"
- #include "Firestore/core/src/util/hard_assert.h"
- #include "Firestore/core/src/util/log.h"
- #include "Firestore/core/src/util/status.h"
- #include "Firestore/core/src/util/statusor.h"
- #include "Firestore/core/src/util/string_apple.h"
- #include "absl/memory/memory.h"
- using firebase::firestore::api::DocumentReference;
- using firebase::firestore::api::Firestore;
- using firebase::firestore::api::ListenerRegistration;
- using firebase::firestore::core::EventListener;
- using firebase::firestore::credentials::AuthCredentialsProvider;
- using firebase::firestore::model::DatabaseId;
- using firebase::firestore::remote::FirebaseMetadataProvider;
- using firebase::firestore::util::AsyncQueue;
- using firebase::firestore::util::ByteStreamApple;
- using firebase::firestore::util::Empty;
- using firebase::firestore::util::Executor;
- using firebase::firestore::util::ExecutorLibdispatch;
- using firebase::firestore::util::kLogLevelDebug;
- using firebase::firestore::util::kLogLevelNotice;
- using firebase::firestore::util::LogSetLevel;
- using firebase::firestore::util::MakeCallback;
- using firebase::firestore::util::MakeNSError;
- using firebase::firestore::util::MakeNSString;
- using firebase::firestore::util::MakeString;
- using firebase::firestore::util::ObjcThrowHandler;
- using firebase::firestore::util::SetThrowHandler;
- using firebase::firestore::util::Status;
- using firebase::firestore::util::StatusOr;
- using firebase::firestore::util::StreamReadResult;
- using firebase::firestore::util::ThrowIllegalState;
- using firebase::firestore::util::ThrowInvalidArgument;
- using UserUpdateBlock = id _Nullable (^)(FIRTransaction *, NSError **);
- using UserTransactionCompletion = void (^)(id _Nullable, NSError *_Nullable);
- NS_ASSUME_NONNULL_BEGIN
- #pragma mark - FIRFirestore
- @interface FIRFirestore ()
- @property(nonatomic, strong, readonly) FSTUserDataReader *dataReader;
- @end
- @implementation FIRFirestore {
- std::shared_ptr<Firestore> _firestore;
- FIRFirestoreSettings *_settings;
- __weak id<FSTFirestoreInstanceRegistry> _registry;
- }
- + (void)initialize {
- if (self == [FIRFirestore class]) {
- SetThrowHandler(ObjcThrowHandler);
- Firestore::SetClientLanguage("gl-objc/");
- }
- }
- + (instancetype)firestore {
- FIRApp *app = [FIRApp defaultApp];
- if (!app) {
- ThrowIllegalState("Failed to get FirebaseApp instance. Please call FirebaseApp.configure() "
- "before using Firestore");
- }
- return [self firestoreForApp:app database:MakeNSString(DatabaseId::kDefault)];
- }
- + (instancetype)firestoreForApp:(FIRApp *)app {
- return [self firestoreForApp:app database:MakeNSString(DatabaseId::kDefault)];
- }
- - (instancetype)initWithDatabaseID:(model::DatabaseId)databaseID
- persistenceKey:(std::string)persistenceKey
- authCredentialsProvider:
- (std::shared_ptr<credentials::AuthCredentialsProvider>)authCredentialsProvider
- appCheckCredentialsProvider:
- (std::shared_ptr<credentials::AppCheckCredentialsProvider>)appCheckCredentialsProvider
- workerQueue:(std::shared_ptr<AsyncQueue>)workerQueue
- firebaseMetadataProvider:
- (std::unique_ptr<FirebaseMetadataProvider>)firebaseMetadataProvider
- firebaseApp:(FIRApp *)app
- instanceRegistry:(nullable id<FSTFirestoreInstanceRegistry>)registry {
- if (self = [super init]) {
- _firestore = std::make_shared<Firestore>(
- std::move(databaseID), std::move(persistenceKey), std::move(authCredentialsProvider),
- std::move(appCheckCredentialsProvider), std::move(workerQueue),
- std::move(firebaseMetadataProvider), (__bridge void *)self);
- _app = app;
- _registry = registry;
- FSTPreConverterBlock block = ^id _Nullable(id _Nullable input) {
- if ([input isKindOfClass:[FIRDocumentReference class]]) {
- auto documentReference = (FIRDocumentReference *)input;
- return [[FSTDocumentKeyReference alloc] initWithKey:documentReference.key
- databaseID:documentReference.firestore.databaseID];
- } else {
- return input;
- }
- };
- _dataReader = [[FSTUserDataReader alloc] initWithDatabaseID:_firestore->database_id()
- preConverter:block];
- // Use the property setter so the default settings get plumbed into _firestoreClient.
- self.settings = [[FIRFirestoreSettings alloc] init];
- }
- return self;
- }
- - (FIRFirestoreSettings *)settings {
- // Disallow mutation of our internal settings
- return [_settings copy];
- }
- - (void)setSettings:(FIRFirestoreSettings *)settings {
- if (![settings isEqual:_settings]) {
- _settings = settings;
- _firestore->set_settings([settings internalSettings]);
- #if HAVE_LIBDISPATCH
- std::unique_ptr<Executor> user_executor =
- absl::make_unique<ExecutorLibdispatch>(settings.dispatchQueue);
- #else
- // It's possible to build without libdispatch on macOS for testing purposes.
- // In this case, avoid breaking the build.
- std::unique_ptr<Executor> user_executor =
- Executor::CreateSerial("com.google.firebase.firestore.user");
- #endif // HAVE_LIBDISPATCH
- _firestore->set_user_executor(std::move(user_executor));
- }
- }
- - (void)setIndexConfigurationFromJSON:(NSString *)json
- completion:(nullable void (^)(NSError *_Nullable error))completion {
- _firestore->SetIndexConfiguration(MakeString(json), MakeCallback(completion));
- }
- - (void)setIndexConfigurationFromStream:(NSInputStream *)stream
- completion:(nullable void (^)(NSError *_Nullable error))completion {
- auto input = absl::make_unique<ByteStreamApple>(stream);
- auto callback = MakeCallback(completion);
- std::string json;
- bool eof = false;
- while (!eof) {
- StreamReadResult result = input->Read(1024ul);
- if (!result.ok()) {
- callback(result.status());
- return;
- }
- eof = result.eof();
- json.append(std::move(result).ValueOrDie());
- }
- _firestore->SetIndexConfiguration(json, callback);
- }
- - (FIRCollectionReference *)collectionWithPath:(NSString *)collectionPath {
- if (!collectionPath) {
- ThrowInvalidArgument("Collection path cannot be nil.");
- }
- if (!collectionPath.length) {
- ThrowInvalidArgument("Collection path cannot be empty.");
- }
- if ([collectionPath containsString:@"//"]) {
- ThrowInvalidArgument("Invalid path (%s). Paths must not contain // in them.", collectionPath);
- }
- return [[FIRCollectionReference alloc]
- initWithReference:_firestore->GetCollection(MakeString(collectionPath))];
- }
- - (FIRDocumentReference *)documentWithPath:(NSString *)documentPath {
- if (!documentPath) {
- ThrowInvalidArgument("Document path cannot be nil.");
- }
- if (!documentPath.length) {
- ThrowInvalidArgument("Document path cannot be empty.");
- }
- if ([documentPath containsString:@"//"]) {
- ThrowInvalidArgument("Invalid path (%s). Paths must not contain // in them.", documentPath);
- }
- DocumentReference documentReference = _firestore->GetDocument(MakeString(documentPath));
- return [[FIRDocumentReference alloc] initWithReference:std::move(documentReference)];
- }
- - (FIRQuery *)collectionGroupWithID:(NSString *)collectionID {
- if (!collectionID) {
- ThrowInvalidArgument("Collection ID cannot be nil.");
- }
- if (!collectionID.length) {
- ThrowInvalidArgument("Collection ID cannot be empty.");
- }
- if ([collectionID containsString:@"/"]) {
- ThrowInvalidArgument("Invalid collection ID (%s). Collection IDs must not contain / in them.",
- collectionID);
- }
- auto query = _firestore->GetCollectionGroup(MakeString(collectionID));
- return [[FIRQuery alloc] initWithQuery:std::move(query) firestore:_firestore];
- }
- - (FIRWriteBatch *)batch {
- return [FIRWriteBatch writeBatchWithDataReader:self.dataReader writeBatch:_firestore->GetBatch()];
- }
- - (void)runTransactionWithOptions:(FIRTransactionOptions *_Nullable)options
- block:(UserUpdateBlock)updateBlock
- dispatchQueue:(dispatch_queue_t)queue
- completion:(UserTransactionCompletion)completion {
- if (!updateBlock) {
- ThrowInvalidArgument("Transaction block cannot be nil.");
- }
- if (!completion) {
- ThrowInvalidArgument("Transaction completion block cannot be nil.");
- }
- class TransactionResult {
- public:
- TransactionResult(FIRFirestore *firestore,
- UserUpdateBlock update_block,
- dispatch_queue_t queue,
- UserTransactionCompletion completion)
- : firestore_(firestore),
- user_update_block_(update_block),
- queue_(queue),
- user_completion_(completion) {
- }
- void RunUpdateBlock(std::shared_ptr<core::Transaction> internalTransaction,
- core::TransactionResultCallback internalCallback) {
- dispatch_async(queue_, ^{
- auto transaction = [FIRTransaction transactionWithInternalTransaction:internalTransaction
- firestore:firestore_];
- NSError *_Nullable error = nil;
- user_result_ = user_update_block_(transaction, &error);
- // If the user set an error, disregard the result.
- if (error) {
- // If the error is a user error, set flag to not retry the transaction.
- if (error.domain != FIRFirestoreErrorDomain) {
- internalTransaction->MarkPermanentlyFailed();
- }
- internalCallback(Status::FromNSError(error));
- } else {
- internalCallback(Status::OK());
- }
- });
- }
- void HandleFinalStatus(const Status &status) {
- if (!status.ok()) {
- user_completion_(nil, MakeNSError(status));
- return;
- }
- user_completion_(user_result_, nil);
- }
- private:
- FIRFirestore *firestore_;
- UserUpdateBlock user_update_block_;
- dispatch_queue_t queue_;
- UserTransactionCompletion user_completion_;
- id _Nullable user_result_;
- };
- auto result_capture = std::make_shared<TransactionResult>(self, updateBlock, queue, completion);
- // Wrap the user-supplied updateBlock in a core C++ compatible callback. Wrap the result of the
- // updateBlock invocation up in a TransactionResult for tunneling through the internals of the
- // system.
- auto internalUpdateBlock = [result_capture](
- std::shared_ptr<core::Transaction> internalTransaction,
- core::TransactionResultCallback internalCallback) {
- result_capture->RunUpdateBlock(internalTransaction, internalCallback);
- };
- // Unpacks the TransactionResult value and calls the user completion handler.
- //
- // PORTING NOTE: Other platforms where the user return value is internally representable don't
- // need this wrapper.
- auto objcTranslator = [result_capture](const Status &status) {
- result_capture->HandleFinalStatus(status);
- };
- int max_attempts = [FIRTransactionOptions defaultMaxAttempts];
- if (options) {
- // Note: The cast of `maxAttempts` from `NSInteger` to `int` is safe (i.e. lossless) because
- // `FIRTransactionOptions` does not allow values greater than `INT32_MAX` to be set.
- max_attempts = static_cast<int>(options.maxAttempts);
- }
- _firestore->RunTransaction(std::move(internalUpdateBlock), std::move(objcTranslator),
- max_attempts);
- }
- - (void)runTransactionWithBlock:(id _Nullable (^)(FIRTransaction *, NSError **error))updateBlock
- completion:
- (void (^)(id _Nullable result, NSError *_Nullable error))completion {
- [self runTransactionWithOptions:nil block:updateBlock completion:completion];
- }
- - (void)runTransactionWithOptions:(FIRTransactionOptions *_Nullable)options
- block:(id _Nullable (^)(FIRTransaction *, NSError **))updateBlock
- completion:
- (void (^)(id _Nullable result, NSError *_Nullable error))completion {
- static dispatch_queue_t transactionDispatchQueue;
- static dispatch_once_t onceToken;
- dispatch_once(&onceToken, ^{
- transactionDispatchQueue = dispatch_queue_create("com.google.firebase.firestore.transaction",
- DISPATCH_QUEUE_CONCURRENT);
- });
- [self runTransactionWithOptions:options
- block:updateBlock
- dispatchQueue:transactionDispatchQueue
- completion:completion];
- }
- + (void)enableLogging:(BOOL)logging {
- LogSetLevel(logging ? kLogLevelDebug : kLogLevelNotice);
- }
- - (void)useEmulatorWithHost:(NSString *)host port:(NSInteger)port {
- if (!host.length) {
- ThrowInvalidArgument("Host cannot be nil or empty.");
- }
- if (!_settings.isUsingDefaultHost) {
- LOG_WARN("Overriding previously-set host value: %@", _settings.host);
- }
- // Use a new settings so the new settings are automatically plumbed
- // to the underlying Firestore objects.
- NSString *settingsHost = [NSString stringWithFormat:@"%@:%li", host, (long)port];
- FIRFirestoreSettings *newSettings = [_settings copy];
- newSettings.host = settingsHost;
- self.settings = newSettings;
- }
- - (void)enableNetworkWithCompletion:(nullable void (^)(NSError *_Nullable error))completion {
- _firestore->EnableNetwork(MakeCallback(completion));
- }
- - (void)disableNetworkWithCompletion:(nullable void (^)(NSError *_Nullable))completion {
- _firestore->DisableNetwork(MakeCallback(completion));
- }
- - (void)clearPersistenceWithCompletion:(nullable void (^)(NSError *_Nullable error))completion {
- _firestore->ClearPersistence(MakeCallback(completion));
- }
- - (void)waitForPendingWritesWithCompletion:(void (^)(NSError *_Nullable error))completion {
- _firestore->WaitForPendingWrites(MakeCallback(completion));
- }
- - (void)terminateWithCompletion:(nullable void (^)(NSError *_Nullable error))completion {
- id<FSTFirestoreInstanceRegistry> strongRegistry = _registry;
- if (strongRegistry) {
- [strongRegistry
- removeInstanceWithDatabase:MakeNSString(_firestore->database_id().database_id())];
- }
- [self terminateInternalWithCompletion:completion];
- }
- - (id<FIRListenerRegistration>)addSnapshotsInSyncListener:(void (^)(void))listener {
- std::unique_ptr<core::EventListener<Empty>> eventListener =
- core::EventListener<Empty>::Create([listener](const StatusOr<Empty> &) { listener(); });
- std::unique_ptr<ListenerRegistration> result =
- _firestore->AddSnapshotsInSyncListener(std::move(eventListener));
- return [[FSTListenerRegistration alloc] initWithRegistration:std::move(result)];
- }
- - (FIRLoadBundleTask *)loadBundle:(nonnull NSData *)bundleData {
- auto stream = absl::make_unique<ByteStreamApple>([[NSInputStream alloc] initWithData:bundleData]);
- return [self loadBundleStream:[[NSInputStream alloc] initWithData:bundleData] completion:nil];
- }
- - (FIRLoadBundleTask *)loadBundle:(NSData *)bundleData
- completion:(nullable void (^)(FIRLoadBundleTaskProgress *_Nullable progress,
- NSError *_Nullable error))completion {
- return [self loadBundleStream:[[NSInputStream alloc] initWithData:bundleData]
- completion:completion];
- }
- - (FIRLoadBundleTask *)loadBundleStream:(NSInputStream *)bundleStream {
- return [self loadBundleStream:bundleStream completion:nil];
- }
- - (FIRLoadBundleTask *)loadBundleStream:(NSInputStream *)bundleStream
- completion:
- (nullable void (^)(FIRLoadBundleTaskProgress *_Nullable progress,
- NSError *_Nullable error))completion {
- auto stream = absl::make_unique<ByteStreamApple>(bundleStream);
- std::shared_ptr<api::LoadBundleTask> task = _firestore->LoadBundle(std::move(stream));
- auto callback = [completion](api::LoadBundleTaskProgress progress) {
- if (!completion) {
- return;
- }
- // Ignoring `kInProgress` because we are setting up for completion callback.
- if (progress.state() == api::LoadBundleTaskState::kSuccess) {
- completion([[FIRLoadBundleTaskProgress alloc] initWithInternal:progress], nil);
- } else if (progress.state() == api::LoadBundleTaskState::kError) {
- NSError *error = nil;
- if (!progress.error_status().ok()) {
- LOG_WARN("Progress set to Error, but error_status() is ok()");
- error = MakeNSError(firebase::firestore::Error::kErrorUnknown,
- "Loading bundle failed with unknown error");
- } else {
- error = MakeNSError(progress.error_status());
- }
- completion([[FIRLoadBundleTaskProgress alloc] initWithInternal:progress], error);
- }
- };
- task->SetLastObserver(callback);
- return [[FIRLoadBundleTask alloc] initWithTask:task];
- }
- - (void)getQueryNamed:(NSString *)name completion:(void (^)(FIRQuery *_Nullable query))completion {
- auto firestore = _firestore;
- auto callback = [completion, firestore](core::Query query, bool found) {
- if (!completion) {
- return;
- }
- if (found) {
- FIRQuery *firQuery = [[FIRQuery alloc] initWithQuery:std::move(query) firestore:firestore];
- completion(firQuery);
- } else {
- completion(nil);
- }
- };
- _firestore->GetNamedQuery(MakeString(name), callback);
- }
- @end
- @implementation FIRFirestore (Internal)
- - (std::shared_ptr<Firestore>)wrapped {
- return _firestore;
- }
- - (const std::shared_ptr<AsyncQueue> &)workerQueue {
- return _firestore->worker_queue();
- }
- - (const DatabaseId &)databaseID {
- return _firestore->database_id();
- }
- + (instancetype)firestoreForApp:(FIRApp *)app database:(NSString *)database {
- if (!app) {
- ThrowInvalidArgument("FirebaseApp instance may not be nil. Use FirebaseApp.app() if you'd like "
- "to use the default FirebaseApp instance.");
- }
- if (!database) {
- ThrowInvalidArgument("Database identifier may not be nil. Use '%s' if you want the default "
- "database",
- DatabaseId::kDefault);
- }
- id<FSTFirestoreMultiDBProvider> provider =
- FIR_COMPONENT(FSTFirestoreMultiDBProvider, app.container);
- return [provider firestoreForDatabase:database];
- }
- + (instancetype)firestoreForDatabase:(NSString *)database {
- FIRApp *app = [FIRApp defaultApp];
- if (!app) {
- ThrowIllegalState("Failed to get FirebaseApp instance. Please call FirebaseApp.configure() "
- "before using Firestore");
- }
- return [self firestoreForApp:app database:database];
- }
- + (FIRFirestore *)recoverFromFirestore:(std::shared_ptr<Firestore>)firestore {
- return (__bridge FIRFirestore *)firestore->extension();
- }
- - (void)terminateInternalWithCompletion:(nullable void (^)(NSError *_Nullable error))completion {
- _firestore->Terminate(MakeCallback(completion));
- }
- #pragma mark - Force Link Unreferenced Symbols
- extern void FSTIncludeFSTFirestoreComponent(void);
- /// This method forces the linker to include all the Analytics categories without requiring app
- /// developers to include the '-ObjC' linker flag in their projects. DO NOT CALL THIS METHOD.
- + (void)notCalled {
- NSAssert(NO, @"+notCalled should never be called");
- FSTIncludeFSTFirestoreComponent();
- }
- @end
- NS_ASSUME_NONNULL_END
|