حذف البيانات من Cloud Firestore

توضّح الأمثلة التالية كيفية حذف المستندات والحقول والمجموعات.

حذف المستندات

لحذف مستند، استخدِم delete() الطرق التالية الخاصة بكل لغة:

استخدِم طريقة deleteDoc():

import { doc, deleteDoc } from "firebase/firestore";

await deleteDoc(doc(db, "cities", "DC"));

استخدِم طريقة delete():

db.collection("cities").doc("DC").delete().then(() => {
    console.log("Document successfully deleted!");
}).catch((error) => {
    console.error("Error removing document: ", error);
});

استخدِم طريقة delete():

ملاحظة: لا يتوفّر هذا المنتج على watchOS واستهدافات "مقاطع التطبيقات".
do {
  try await db.collection("cities").document("DC").delete()
  print("Document successfully removed!")
} catch {
  print("Error removing document: \(error)")
}

استخدِم طريقة deleteDocumentWithCompletion::

ملاحظة: لا يتوفّر هذا المنتج على watchOS واستهدافات "مقاطع التطبيقات".
[[[self.db collectionWithPath:@"cities"] documentWithPath:@"DC"]
    deleteDocumentWithCompletion:^(NSError * _Nullable error) {
      if (error != nil) {
        NSLog(@"Error removing document: %@", error);
      } else {
        NSLog(@"Document successfully removed!");
      }
}];

استخدِم طريقة delete():

db.collection("cities").document("DC")
    .delete()
    .addOnSuccessListener { Log.d(TAG, "DocumentSnapshot successfully deleted!") }
    .addOnFailureListener { e -> Log.w(TAG, "Error deleting document", e) }

استخدِم طريقة delete():

db.collection("cities").document("DC")
        .delete()
        .addOnSuccessListener(new OnSuccessListener<Void>() {
            @Override
            public void onSuccess(Void aVoid) {
                Log.d(TAG, "DocumentSnapshot successfully deleted!");
            }
        })
        .addOnFailureListener(new OnFailureListener() {
            @Override
            public void onFailure(@NonNull Exception e) {
                Log.w(TAG, "Error deleting document", e);
            }
        });

استخدِم طريقة delete():

db.collection("cities").doc("DC").delete().then(
      (doc) => print("Document deleted"),
      onError: (e) => print("Error updating document $e"),
    );

استخدِم طريقة delete():

// asynchronously delete a document
ApiFuture<WriteResult> writeResult = db.collection("cities").document("DC").delete();
// ...
System.out.println("Update time : " + writeResult.get().getUpdateTime());

استخدِم طريقة delete():

db.collection("cities").document("DC").delete()

استخدِم طريقة delete():

await db.collection("cities").document("DC").delete()

استخدِم طريقة Delete():

db->Collection("cities").Document("DC").Delete().OnCompletion(
    [](const Future<void>& future) {
      if (future.error() == Error::kErrorOk) {
        std::cout << "DocumentSnapshot successfully deleted!" << std::endl;
      } else {
        std::cout << "Error deleting document: " << future.error_message()
                  << std::endl;
      }
    });

استخدِم طريقة delete():

const res = await db.collection('cities').doc('DC').delete();

استخدِم طريقة Delete():


import (
	"context"
	"log"

	"cloud.google.com/go/firestore"
)

func deleteDoc(ctx context.Context, client *firestore.Client) error {
	_, err := client.Collection("cities").Doc("DC").Delete(ctx)
	if err != nil {
		// Handle any errors in an appropriate way, such as returning them.
		log.Printf("An error has occurred: %s", err)
	}

	return err
}

استخدِم طريقة delete():

$db->collection('samples/php/cities')->document('DC')->delete();

استخدِم طريقة DeleteAsync():

DocumentReference cityRef = db.Collection("cities").Document("DC");
cityRef.DeleteAsync();

استخدِم طريقة DeleteAsync():

DocumentReference cityRef = db.Collection("cities").Document("DC");
await cityRef.DeleteAsync();

استخدِم طريقة delete():

city_ref = firestore.doc "#{collection_path}/DC"
city_ref.delete

عند حذف مستند، لا تحذف Cloud Firestore تلقائيًا المستندات داخل مجموعاتها الفرعية. سيظل بإمكانك الوصول إلى مستندات المجموعة الفرعية بالرجوع إليها. على سبيل المثال، يمكنك الوصول إلى المستند في المسار /mycoll/mydoc/mysubcoll/mysubdoc حتى إذا حذفت المستند الأصلي في /mycoll/mydoc.

تظهر مستندات الأصل غير المتوفّرة في وحدة التحكّم، ولكنّها لا تظهر في نتائج البحث واللقطات.

إذا أردت حذف مستند وجميع المستندات ضِمن مجموعاته الفرعية، عليك إجراء ذلك يدويًا. لمزيد من المعلومات، يُرجى الاطّلاع على حذف المجموعات.

حذف الحقول

لحذف حقول معيّنة من مستند، استخدِم FieldValue.delete() الطرق الخاصة باللغة التالية عند تعديل مستند:

استخدِم طريقة deleteField():

import { doc, updateDoc, deleteField } from "firebase/firestore";

const cityRef = doc(db, 'cities', 'BJ');

// Remove the 'capital' field from the document
await updateDoc(cityRef, {
    capital: deleteField()
});

استخدِم طريقة FieldValue.delete():

var cityRef = db.collection('cities').doc('BJ');

// Remove the 'capital' field from the document
var removeCapital = cityRef.update({
    capital: firebase.firestore.FieldValue.delete()
});

استخدِم طريقة FieldValue.delete():

ملاحظة: لا يتوفّر هذا المنتج على watchOS واستهدافات "مقاطع التطبيقات".
do {

  try await db.collection("cities").document("BJ").updateData([
    "capital": FieldValue.delete(),
  ])
  print("Document successfully updated")
} catch {
  print("Error updating document: \(error)")
}

استخدِم طريقة fieldValueForDelete::

ملاحظة: لا يتوفّر هذا المنتج على watchOS واستهدافات "مقاطع التطبيقات".
[[[self.db collectionWithPath:@"cities"] documentWithPath:@"BJ"] updateData:@{
  @"capital": [FIRFieldValue fieldValueForDelete]
} completion:^(NSError * _Nullable error) {
  if (error != nil) {
    NSLog(@"Error updating document: %@", error);
  } else {
    NSLog(@"Document successfully updated");
  }
}];

استخدِم طريقة FieldValue.delete():

val docRef = db.collection("cities").document("BJ")

// Remove the 'capital' field from the document
val updates = hashMapOf<String, Any>(
    "capital" to FieldValue.delete(),
)

docRef.update(updates).addOnCompleteListener { }

استخدِم طريقة FieldValue.delete():

DocumentReference docRef = db.collection("cities").document("BJ");

// Remove the 'capital' field from the document
Map<String,Object> updates = new HashMap<>();
updates.put("capital", FieldValue.delete());

docRef.update(updates).addOnCompleteListener(new OnCompleteListener<Void>() {
    // ...
    // ...

استخدِم طريقة FieldValue.delete():

final docRef = db.collection("cities").doc("BJ");

// Remove the 'capital' field from the document
final updates = <String, dynamic>{
  "capital": FieldValue.delete(),
};

docRef.update(updates);

استخدِم طريقة FieldValue.delete():

DocumentReference docRef = db.collection("cities").document("BJ");
Map<String, Object> updates = new HashMap<>();
updates.put("capital", FieldValue.delete());
// Update and delete the "capital" field in the document
ApiFuture<WriteResult> writeResult = docRef.update(updates);
System.out.println("Update time : " + writeResult.get());

استخدِم طريقة firestore.DELETE_FIELD:

city_ref = db.collection("cities").document("BJ")
city_ref.update({"capital": firestore.DELETE_FIELD})

استخدِم طريقة firestore.DELETE_FIELD:

city_ref = db.collection("cities").document("BJ")
await city_ref.update({"capital": firestore.DELETE_FIELD})

استخدِم طريقة FieldValue::Delete():

DocumentReference doc_ref = db->Collection("cities").Document("BJ");
doc_ref.Update({{"capital", FieldValue::Delete()}})
    .OnCompletion([](const Future<void>& future) { /*...*/ });

استخدِم طريقة FieldValue.delete():

// Create a document reference
const cityRef = db.collection('cities').doc('BJ');

// Remove the 'capital' field from the document
const res = await cityRef.update({
  capital: FieldValue.delete()
});

استخدِم طريقة firestore.Delete:


import (
	"context"
	"log"

	"cloud.google.com/go/firestore"
)

func deleteField(ctx context.Context, client *firestore.Client) error {
	_, err := client.Collection("cities").Doc("BJ").Update(ctx, []firestore.Update{
		{
			Path:  "capital",
			Value: firestore.Delete,
		},
	})
	if err != nil {
		// Handle any errors in an appropriate way, such as returning them.
		log.Printf("An error has occurred: %s", err)
	}

	// ...
	return err
}

استخدِم طريقة FieldValue::deleteField():

$cityRef = $db->collection('samples/php/cities')->document('BJ');
$cityRef->update([
    ['path' => 'capital', 'value' => FieldValue::deleteField()]
]);

استخدِم طريقة FieldValue.Delete:

DocumentReference cityRef = db.Collection("cities").Document("BJ");
Dictionary<string, object> updates = new Dictionary<string, object>
{
    { "Capital", FieldValue.Delete }
};

استخدِم طريقة FieldValue.Delete:

DocumentReference cityRef = db.Collection("cities").Document("BJ");
Dictionary<string, object> updates = new Dictionary<string, object>
{
    { "Capital", FieldValue.Delete }
};
await cityRef.UpdateAsync(updates);

استخدِم طريقة firestore.field_delete:

city_ref = firestore.doc "#{collection_path}/BJ"
city_ref.update({ capital: firestore.field_delete })

حذف المجموعات

لحذف مجموعة أو مجموعة فرعية بأكملها في Cloud Firestore، عليك استرداد (قراءة) جميع المستندات داخل المجموعة أو المجموعة الفرعية وحذفها. تتضمّن هذه العملية تكاليف القراءة والحذف. إذا كانت لديك مجموعات أكبر، ننصحك بحذف المستندات على دفعات أصغر لتجنُّب أخطاء نفاد الذاكرة. كرِّر العملية إلى أن تحذف المجموعة أو المجموعة الفرعية بأكملها.

يتطلّب حذف مجموعة تنسيق عدد غير محدود من طلبات الحذف الفردية. إذا كنت بحاجة إلى حذف مجموعات كاملة، احرص على إجراء ذلك فقط من بيئة خادم موثوقة. على الرغم من أنّه يمكن حذف مجموعة من تطبيق جوّال أو تطبيق ويب، إلا أنّ ذلك يؤدي إلى آثار سلبية على الأمان والأداء.

إنّ المقتطفات أدناه مبسطة إلى حد ما ولا تتناول معالجة الأخطاء أو الأمان أو حذف المجموعات الفرعية أو تحسين الأداء إلى أقصى حد. لمزيد من المعلومات حول إحدى الطرق المقترَحة لحذف المجموعات في مرحلة الإنتاج، يمكنك الاطّلاع على حذف المجموعات والمجموعات الفرعية.

// Deleting collections from a Web client is not recommended.
ملاحظة: لا يتوفّر هذا المنتج على watchOS واستهدافات "مقاطع التطبيقات".
// Deleting collections from an Apple client is not recommended.
ملاحظة: لا يتوفّر هذا المنتج على watchOS واستهدافات "مقاطع التطبيقات".
// Deleting collections from an Apple client is not recommended.
  
// Deleting collections from an Android client is not recommended.
// Deleting collections from an Android client is not recommended.

لا يُنصح بحذف المجموعات من العميل.

/**
 * Delete a collection in batches to avoid out-of-memory errors. Batch size may be tuned based on
 * document size (atmost 1MB) and application requirements.
 */
void deleteCollection(CollectionReference collection, int batchSize) {
  try {
    // retrieve a small batch of documents to avoid out-of-memory errors
    ApiFuture<QuerySnapshot> future = collection.limit(batchSize).get();
    int deleted = 0;
    // future.get() blocks on document retrieval
    List<QueryDocumentSnapshot> documents = future.get().getDocuments();
    for (QueryDocumentSnapshot document : documents) {
      document.getReference().delete();
      ++deleted;
    }
    if (deleted >= batchSize) {
      // retrieve and delete another batch
      deleteCollection(collection, batchSize);
    }
  } catch (Exception e) {
    System.err.println("Error deleting collection : " + e.getMessage());
  }
}
def delete_collection(coll_ref, batch_size):
    if batch_size == 0:
        return

    docs = coll_ref.list_documents(page_size=batch_size)
    deleted = 0

    for doc in docs:
        print(f"Deleting doc {doc.id} => {doc.get().to_dict()}")
        doc.delete()
        deleted = deleted + 1

    if deleted >= batch_size:
        return delete_collection(coll_ref, batch_size)
async def delete_collection(coll_ref, batch_size):
    docs = coll_ref.limit(batch_size).stream()
    deleted = 0

    async for doc in docs:
        print(f"Deleting doc {doc.id} => {doc.to_dict()}")
        await doc.reference.delete()
        deleted = deleted + 1

    if deleted >= batch_size:
        return delete_collection(coll_ref, batch_size)
// This is not supported. Delete data using CLI as discussed below.
  
async function deleteCollection(db, collectionPath, batchSize) {
  const collectionRef = db.collection(collectionPath);
  const query = collectionRef.orderBy('__name__').limit(batchSize);

  return new Promise((resolve, reject) => {
    deleteQueryBatch(db, query, resolve).catch(reject);
  });
}

async function deleteQueryBatch(db, query, resolve) {
  const snapshot = await query.get();

  const batchSize = snapshot.size;
  if (batchSize === 0) {
    // When there are no documents left, we are done
    resolve();
    return;
  }

  // Delete documents in a batch
  const batch = db.batch();
  snapshot.docs.forEach((doc) => {
    batch.delete(doc.ref);
  });
  await batch.commit();

  // Recurse on the next process tick, to avoid
  // exploding the stack.
  process.nextTick(() => {
    deleteQueryBatch(db, query, resolve);
  });
}

import (
	"context"
	"fmt"
	"io"

	"cloud.google.com/go/firestore"
	"google.golang.org/api/iterator"
)

func deleteCollection(w io.Writer, projectID, collectionName string,
	batchSize int) error {

	// Instantiate a client
	ctx := context.Background()
	client, err := firestore.NewClient(ctx, projectID)
	if err != nil {
		return err
	}

	col := client.Collection(collectionName)
	bulkwriter := client.BulkWriter(ctx)

	for {
		// Get a batch of documents
		iter := col.Limit(batchSize).Documents(ctx)
		numDeleted := 0

		// Iterate through the documents, adding
		// a delete operation for each one to the BulkWriter.
		for {
			doc, err := iter.Next()
			if err == iterator.Done {
				break
			}
			if err != nil {
				return err
			}

			bulkwriter.Delete(doc.Ref)
			numDeleted++
		}

		// If there are no documents to delete,
		// the process is over.
		if numDeleted == 0 {
			bulkwriter.End()
			break
		}

		bulkwriter.Flush()
	}
	fmt.Fprintf(w, "Deleted collection \"%s\"", collectionName)
	return nil
}
function data_delete_collection(string $projectId, string $collectionName, int $batchSize)
{
    // Create the Cloud Firestore client
    $db = new FirestoreClient([
        'projectId' => $projectId,
    ]);
    $collectionReference = $db->collection($collectionName);
    $documents = $collectionReference->limit($batchSize)->documents();
    while (!$documents->isEmpty()) {
        foreach ($documents as $document) {
            printf('Deleting document %s' . PHP_EOL, $document->id());
            $document->reference()->delete();
        }
        $documents = $collectionReference->limit($batchSize)->documents();
    }
}
// This is not supported. Delete data using CLI as discussed below.
private static async Task DeleteCollection(CollectionReference collectionReference, int batchSize)
{
    QuerySnapshot snapshot = await collectionReference.Limit(batchSize).GetSnapshotAsync();
    IReadOnlyList<DocumentSnapshot> documents = snapshot.Documents;
    while (documents.Count > 0)
    {
        foreach (DocumentSnapshot document in documents)
        {
            Console.WriteLine("Deleting document {0}", document.Id);
            await document.Reference.DeleteAsync();
        }
        snapshot = await collectionReference.Limit(batchSize).GetSnapshotAsync();
        documents = snapshot.Documents;
    }
    Console.WriteLine("Finished deleting all documents from the collection.");
}
cities_ref = firestore.col collection_path
query      = cities_ref

query.get do |document_snapshot|
  puts "Deleting document #{document_snapshot.document_id}."
  document_ref = document_snapshot.ref
  document_ref.delete
end

حذف البيانات باستخدام واجهة سطر الأوامر في Firebase

يمكنك أيضًا استخدام Firebase CLI لحذف المستندات والمجموعات. استخدِم الأمر التالي لحذف البيانات:

firebase firestore:delete [options] <<path>>

حذف البيانات باستخدام وحدة التحكّم

يمكنك حذف المستندات والمجموعات من صفحة Cloud Firestore في وحدة التحكّم. يؤدي حذف مستند من وحدة التحكّم إلى حذف جميع البيانات المتداخلة في هذا المستند، بما في ذلك أي مجموعات فرعية.

حذف البيانات باستخدام سياسات TTL

تحدّد سياسة TTL حقلًا معيّنًا ليكون وقت انتهاء صلاحية المستندات في مجموعة محدّدة. يتم احتساب عمليات الحذف التي تستخدم ميزة &quot;مدة البقاء&quot; ضمن تكاليف حذف المستندات.

للحصول على معلومات حول ضبط TTL، يُرجى الاطّلاع على إدارة الاحتفاظ بالبيانات باستخدام سياسات TTL.

لمزيد من المعلومات حول رموز الأخطاء وكيفية حلّ مشاكل التأخير عند حذف البيانات، يمكنك الاطّلاع على صفحة تحديد المشاكل وحلّها.

حذف البيانات باستخدام Dataflow

‫Dataflow هي أداة رائعة لإجراء عمليات مجمّعة على قاعدة بيانات Firestore. تتضمّن مشاركة المدونة حول موصّل Firestore لخدمة Dataflow مثالاً على حذف جميع المستندات في مجموعة مجموعات.

استخدام الحذف المجمّع المُدار

تتيح Cloud Firestore حذف مجموعة واحدة أو أكثر من مجموعات المحتوى بشكل مجمّع. لمزيد من المعلومات، يُرجى الاطّلاع على الحذف المجمّع للبيانات.