Xóa dữ liệu khỏi Cloud Firestore

Các ví dụ sau đây minh họa cách xóa tài liệu, trường và bộ sưu tập.

Xóa tài liệu

Để xóa tài liệu, hãy sử dụng các phương thức delete() dành riêng cho ngôn ngữ sau:

Web modular API

Sử dụng phương thức deleteDoc() :

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

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

Web namespaced API

Sử dụng phương thức delete() :

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

Sử dụng phương thức delete() :

Lưu ý: Sản phẩm này không khả dụng trên các mục tiêu watchOS và App Clip.
do {
  try await db.collection("cities").document("DC").delete()
  print("Document successfully removed!")
} catch {
  print("Error removing document: \(error)")
}
Mục tiêu-C

Sử dụng phương thức deleteDocumentWithCompletion: ::

Lưu ý: Sản phẩm này không khả dụng trên các mục tiêu watchOS và App Clip.
[[[self.db collectionWithPath:@"cities"] documentWithPath:@"DC"]
    deleteDocumentWithCompletion:^(NSError * _Nullable error) {
      if (error != nil) {
        NSLog(@"Error removing document: %@", error);
      } else {
        NSLog(@"Document successfully removed!");
      }
}];

Kotlin+KTX

Sử dụng phương thức delete() :

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

Java

Sử dụng phương thức 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);
            }
        });

Dart

Sử dụng phương thức delete() :

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

Sử dụng phương thức delete() :

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

Sử dụng phương thức delete() :

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

Python

Sử dụng phương thức delete() :

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

Sử dụng phương thức 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;
      }
    });
Node.js

Sử dụng phương thức delete() :

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

Sử dụng phương thức 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
}
PHP

Sử dụng phương thức delete() :

$db->collection('samples/php/cities')->document('DC')->delete();
Đoàn kết

Sử dụng phương thức DeleteAsync() :

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

Sử dụng phương thức DeleteAsync() :

DocumentReference cityRef = db.Collection("cities").Document("DC");
await cityRef.DeleteAsync();
hồng ngọc

Sử dụng phương thức delete() :

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

Khi bạn xóa tài liệu, Cloud Firestore không tự động xóa tài liệu trong các bộ sưu tập con của nó. Bạn vẫn có thể truy cập các tài liệu bộ sưu tập con bằng cách tham khảo. Ví dụ: bạn có thể truy cập tài liệu tại đường dẫn /mycoll/mydoc/mysubcoll/mysubdoc ngay cả khi bạn xóa tài liệu tổ tiên tại /mycoll/mydoc .

Các tài liệu gốc không tồn tại xuất hiện trong bảng điều khiển nhưng chúng không xuất hiện trong kết quả truy vấn và ảnh chụp nhanh.

Nếu bạn muốn xóa một tài liệu và tất cả các tài liệu trong các bộ sưu tập con của nó, bạn phải thực hiện việc đó một cách thủ công. Để biết thêm thông tin, hãy xem Xóa bộ sưu tập .

Xóa các trường

Để xóa các trường cụ thể khỏi tài liệu, hãy sử dụng các phương thức FieldValue.delete() dành riêng cho ngôn ngữ sau đây khi bạn cập nhật tài liệu:

Web modular API

Sử dụng phương thức 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()
});

Web namespaced API

Sử dụng phương thức 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()
});
Nhanh

Sử dụng phương thức FieldValue.delete() :

Lưu ý: Sản phẩm này không khả dụng trên các mục tiêu watchOS và App Clip.
do {

  try await db.collection("cities").document("BJ").updateData([
    "capital": FieldValue.delete(),
  ])
  print("Document successfully updated")
} catch {
  print("Error updating document: \(error)")
}
Mục tiêu-C

Sử dụng phương thức fieldValueForDelete: : :

Lưu ý: Sản phẩm này không khả dụng trên các mục tiêu watchOS và App Clip.
[[[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");
  }
}];

Kotlin+KTX

Sử dụng phương thức 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 { }

Java

Sử dụng phương thức 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>() {
    // ...
    // ...

Dart

Sử dụng phương thức 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);
Java

Sử dụng phương thức 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());
Python

Sử dụng phương thức firestore.DELETE_FIELD :

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

Python

Sử dụng phương thức firestore.DELETE_FIELD :

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

Sử dụng phương thức FieldValue::Delete() :

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

Sử dụng phương thức 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()
});
Đi

Sử dụng phương thức 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
}
PHP

Sử dụng phương thức FieldValue::deleteField() :

$cityRef = $db->collection('samples/php/cities')->document('BJ');
$cityRef->update([
    ['path' => 'capital', 'value' => FieldValue::deleteField()]
]);
Đoàn kết

Sử dụng phương thức FieldValue.Delete :

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

Sử dụng phương thức FieldValue.Delete :

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

Sử dụng phương thức firestore.field_delete :

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

Xóa bộ sưu tập

Để xóa toàn bộ bộ sưu tập hoặc bộ sưu tập con trong Cloud Firestore, hãy truy xuất (đọc) tất cả tài liệu trong bộ sưu tập hoặc bộ sưu tập con và xóa chúng. Quá trình này phát sinh cả chi phí đọc và xóa. Nếu bạn có bộ sưu tập lớn hơn, bạn có thể muốn xóa tài liệu theo lô nhỏ hơn để tránh lỗi hết bộ nhớ. Lặp lại quy trình cho đến khi bạn xóa toàn bộ bộ sưu tập hoặc bộ sưu tập con.

Việc xóa một bộ sưu tập yêu cầu phải điều phối số lượng yêu cầu xóa riêng lẻ không giới hạn. Nếu bạn cần xóa toàn bộ bộ sưu tập, chỉ thực hiện việc đó từ môi trường máy chủ đáng tin cậy. Mặc dù có thể xóa bộ sưu tập khỏi ứng dụng khách trên thiết bị di động/web, nhưng làm như vậy sẽ có tác động tiêu cực đến hiệu suất và bảo mật.

Các đoạn mã bên dưới được đơn giản hóa phần nào và không đề cập đến việc xử lý lỗi, bảo mật, xóa các bộ sưu tập con hoặc tối đa hóa hiệu suất. Để tìm hiểu thêm về một phương pháp được đề xuất để xóa các bộ sưu tập trong quá trình sản xuất, hãy xem Xóa Bộ sưu tập và Bộ sưu tập con .

Web
// Deleting collections from a Web client is not recommended.
Nhanh
Lưu ý: Sản phẩm này không khả dụng trên các mục tiêu watchOS và App Clip.
// Deleting collections from an Apple client is not recommended.
Mục tiêu-C
Lưu ý: Sản phẩm này không khả dụng trên các mục tiêu watchOS và App Clip.
// Deleting collections from an Apple client is not recommended.
  

Kotlin+KTX

// Deleting collections from an Android client is not recommended.

Java

// Deleting collections from an Android client is not recommended.

Dart

Không nên xóa bộ sưu tập khỏi máy khách.

Java
/**
 * 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());
  }
}
Python
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)

Python

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)
C++
// This is not supported. Delete data using CLI as discussed below.
  
Node.js
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);
  });
}
Đi

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
}
PHP
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();
    }
}
Đoàn kết
// This is not supported. Delete data using CLI as discussed below.
C#
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.");
}
hồng ngọc
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

Xóa dữ liệu bằng Firebase CLI

Bạn cũng có thể sử dụng Firebase CLI để xóa tài liệu và bộ sưu tập. Sử dụng lệnh sau để xóa dữ liệu:

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

Xóa dữ liệu bằng bảng điều khiển

Bạn có thể xóa tài liệu và bộ sưu tập khỏi trang Cloud Firestore trong bảng điều khiển . Xóa tài liệu khỏi bảng điều khiển sẽ xóa tất cả dữ liệu lồng nhau trong tài liệu đó, bao gồm mọi bộ sưu tập con.

Xóa dữ liệu bằng chính sách TTL

Chính sách TTL chỉ định một trường nhất định làm thời gian hết hạn cho các tài liệu trong một nhóm bộ sưu tập nhất định. Hoạt động xóa TTL được tính vào chi phí xóa tài liệu của bạn.

Để biết thông tin về cách cài đặt TTL, hãy xem Quản lý lưu giữ dữ liệu bằng chính sách TTL .

Để biết thêm thông tin về mã lỗi và cách giải quyết vấn đề về độ trễ khi xóa dữ liệu, hãy xem trang xử lý sự cố .

Xóa dữ liệu bằng Dataflow

Dataflow là một công cụ tuyệt vời để thực hiện các thao tác hàng loạt trên cơ sở dữ liệu Firestore của bạn. Bài đăng trên blog giới thiệu Trình kết nối Firestore cho Dataflow có ví dụ về xóa tất cả tài liệu trong một nhóm bộ sưu tập.