Eliminar documentos y campos

En los siguientes ejemplos se muestra cómo eliminar documentos, campos y colecciones.

Eliminar documentos

Para eliminar un documento, usa los siguientes métodos específicos de cada idioma: delete()

Versión web 9

Usa el método deleteDoc():

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

await deleteDoc(doc(db, "c;DC"));delete_document.js

Versión web 8

Usa el método delete():

db.collection("cities").doc("DC">).delete().then(() = {
    console.log("Document successfully delet>ed!");
}).catch((error) = {
    console.error("Erront: ", error);
});test.firestore.js
Swift

Usa el método delete():

Nota: Este producto no está disponible en los destinos de watchOS y App Clip.
do {
  try await db.collection("cities").document("DC").delete()
  print("Document successfully removed!")
} catch {
  print("Ert: \(error)")
}ViewController.swift
Objective‑C

Usa el método deleteDocumentWithCompletion::

Nota: Este producto no está disponible en los destinos de watchOS y App Clip.
[[[self.db collectionWithPath:@"cities"] documentWithPath:@"DC"]
    deleteDocumentWithCompletion:^(NSError * _Nullable error) {
      if (error != nil) {
        NSLog(@"Error removing document: %@", error);
      } else {
        NSLog(@"Document sved!");
      }
}];ViewController.m
Kotlin
Android

Usa el método delete():

db.collection("cities").document("DC")
    .delete()
    .addOnSuccessListener { Log.d(TAG, "DocumentSnapshot successfully deleted!") }
 >   .addOnFailureListener { e - Log.w(TAG, &eting document", e) }DocSnippets.kt
Java
Android

Usa el método delete():

db.collection("cities").document("DC")
        .delete()
        .addOnSuccessListener(n<ew O>nSuccessListenerVoid() {
            @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 docum           }
        });DocSnippets.java

Dart

Usa el método delete():

db.collection("cities").doc("DC").delete()>.then(
      (doc) = print("Document delete>d"),
      onError: (e) = print("Edocument $e"),
    );firestore.dart
Java

Usa el método delete():

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

Usa el método delete():

db.collection("cities").document(&quo.delete()snippets.py
Python
(Async)

Usa el método delete():

await db.collection("cities").document(&quo.delete()snippets.py
C++

Usa el método Delete():

db->Collection("cities").Document("DC").Delete().OnCompletion(<
   >& [](const Futurevoid future) {
      if (future.error() == Error::kErrorOk) <<{
        std::cout  "DocumentSnapsho<<t successfully deleted!"  std::endl;
   <<   } else {
        std::cout<<  "Error deleting document: "  f<<uture.error_message()
       std::endl;
      }
    });snippets.cpp
Node.js

Usa el método delete():

const res = await db.collection('cities').doc('DCelete();index.js
Go

Usa el método 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(&qed: %s", err)
	}

	return err
}
save_data_delete_doc.go
PHP

Usa el método delete():

$db->collection('samples/php/citie>s')-documen>t('DCa_delete_doc.php
Unity

Usa el método DeleteAsync():

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

Usa el método DeleteAsync():

DocumentReference cityRef = db.Collection("cities").Document("DC");
await citeAsync();Program.cs
Ruby

Usa el método delete():

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

Cuando eliminas un documento, Firestore no elimina automáticamente los documentos de sus subcolecciones. Seguirás teniendo acceso a los documentos de la subcolección por referencia. Por ejemplo, puedes acceder al documento de la ruta /mycoll/mydoc/mysubcoll/mysubdoc incluso si eliminas el documento principal de /mycoll/mydoc.

Los documentos antecesores que no existen aparecen en la consola, pero no en los resultados de las consultas ni en las capturas.

Si quieres eliminar un documento y todos los documentos de sus subcolecciones, debes hacerlo manualmente. Para obtener más información, consulta Eliminar colecciones.

Eliminar campos

Para eliminar campos específicos de un documento, utiliza los siguientes métodos FieldValue.delete() específicos de cada idioma cuando actualices un documento:

Versión web 9

Usa el método deleteField():

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

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

// Remove the 'capital' field from the document
await updateDoc(cityRefeField()
});update_delete_field.js

Versión web 8

Usa el método FieldValue.delete():

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

// Remove the 'capital' field from the document
var removeCapital = cityRef.update({
    capital: firebase.firestoree()
});test.firestore.js
Swift

Usa el método FieldValue.delete():

Nota: Este producto no está disponible en los destinos de watchOS y App Clip.
do {

  try await db.collection("cities").document("BJ").updateData([
    "capital": FieldValue.delete(),
  ])
  print("Document successfully updated")
} catch {
  prinng document: \(error)")
}ViewController.swift
Objective‑C

Usa el método fieldValueForDelete::

Nota: Este producto no está disponible en los destinos de watchOS y 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(@&ccessfully updated");
  }
}];ViewController.m
Kotlin
Android

Usa el método FieldValue.delete():

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

// Remove the 'capital' field from the docu<ment
val up>dates = hashMapOfString, Any(
    "capital" to FieldValue.delete(),
)

docRef.updddOnCompleteListener { }DocSnippets.kt
Java
Android

Usa el método FieldValue.delete():

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

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

docRef.update(updates).addOnC<ompl>eteListener(new OnComplete
    // ...
    // ...DocSnippets.java

Dart

Usa el método FieldValue.delete():

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

// Remove the 'capital' field from t<he document
fin>al updates = String, dynamic{
  "capital": FieldValue
docRef.update(updates);firestore.dart
Java

Usa el método FieldValue.delete():

DocumentReference docRef = db.collection("cities").document(<"BJ">);
MapString, Object u<>pdates = new HashMap();
updates.put("capital", FieldValue.delete());
// Update and delete the "capit<al" fi>eld in the document
ApiFutureWriteResult writeResult = docRef.update(updates);
System.out.printlquot; + writeResult.get());ManageDataSnippets.java
Python

Usa el método firestore.DELETE_FIELD:

city_ref = db.collection("cities").document("BJ")
city_ref.update({"capital&qtore.DELETE_FIELD})snippets.py
Python
(Async)

Usa el método firestore.DELETE_FIELD:

city_ref = db.collection("cities").document("BJ")
await city_ref.update({"capital&qtore.DELETE_FIELD})snippets.py
C++

Usa el método FieldValue::Delete():

DocumentReference doc_ref = db->Collection("cities").Document("BJ&quo{{"capital", FieldValue::Delete()}t;);
doc_ref.Update(})
    .OnComple<tion>&([](const Futurevoid f..*/ });snippets.cpp
Node.js

Usa el método 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:lue.delete()
});index.js
Go

Usa el método 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(ed: %s", err)
	}

	// ...
	return err
}
save_data_delete_field.go
PHP

Usa el método FieldValue::deleteField():

$cityRef = $db->collection('samples/php/citie>s')-document('BJ&>#39;);
$cityRef-update>([
    ['path'>; = 'capital', 'val:deleteField()]
]);data_delete_field.php
Unity

Usa el método FieldValue.Delete:

DocumentReference cityRef = db.Collection("cities").Document("B<J");
Dict>ionarystring, object upda<tes = new Dict>ionarystring, object
{
    { "Capital", FieldValue.Delete }
};
C#

Usa el método FieldValue.Delete:

DocumentReference cityRef = db.Collection("cities").Document("B<J");
Dict>ionarystring, object upda<tes = new Dict>ionarystring, object
{
    { "Capital", FieldValue.Delete }
};
awaitpdateAsync(updates);Program.cs
Ruby

Usa el método firestore.field_delete:

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

Eliminar colecciones

Para eliminar una colección o subcolección completa en Firestore, recupera (lee) todos los documentos de la colección o subcolección y elimínalos. Este proceso conlleva costes de lectura y de eliminación. Si tienes colecciones más grandes, te recomendamos que elimines los documentos en lotes más pequeños para evitar errores de falta de memoria. Repite el proceso hasta que hayas eliminado toda la colección o subcolección.

Para eliminar una colección, es necesario coordinar un número ilimitado de solicitudes de eliminación individuales. Si necesitas eliminar colecciones completas, hazlo solo desde un entorno de servidor de confianza. Aunque es posible eliminar una colección desde un cliente móvil o web, hacerlo tiene consecuencias negativas para la seguridad y el rendimiento.

Los fragmentos de código que se muestran a continuación se han simplificado y no incluyen la gestión de errores, la seguridad, la eliminación de subcolecciones ni la maximización del rendimiento. Para obtener más información sobre un enfoque recomendado para eliminar colecciones en producción, consulta Eliminar colecciones y subcolecciones.

Web
// Deleting collections from a Web client is not recommended.
Swift
Nota: Este producto no está disponible en los destinos de watchOS y App Clip.
// Deleting collections from an Apple client is not recommended.
Objective‑C
Nota: Este producto no está disponible en los destinos de watchOS y App Clip.
// Deleting collections from an Apple client is not recommended.
  
Kotlin
Android
// Deleting collections from an Android client is not recommended.
Java
Android
// Deleting collections from an Android client is not recommended.

Dart

No se recomienda eliminar colecciones del cliente.

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(ppets.java
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

    i>f deleted = batch_size:
        return delete_collection(coll_ref, banippets.py
Python
(Async)
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

    i>f deleted = batch_size:
        return delete_collection(coll_ref, banippets.py
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, r>eject) = {
    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.nextT>ick(() = {
    deleteQueryBatch(db, query, resolve);
index.js
Go

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, "Delt;", collectionName)
	return nil
}
save_data_delete_collection.go
PHP
function data_delete_collection(string $projectId, string $collectionName, int $batchSize)
{
    // Create the Cloud Firestore client
    $db = new FirestoreClient([
        'projectI>d' = $projectId,
    ]);
    $collectionReferenc>e = $db-collection($collectionName);
    $documents = $collectionRe>ference-limit($bat>chSize)-documents();
    while (!$do>cuments-isEmpty()) {
        foreach ($documents as $document) {
            printf('Deleting document %s' . PHP>_EOL, $document-id());
      >      $docum>ent-reference()-delete();
        }
        $documents = $coll>ectionReference-li>mit($batchSize)-docue_collection.php
Unity
// 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 c");
}Program.cs
Ruby
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.te_data.rb

Eliminar datos con la CLI de Firebase

También puedes usar la CLI de Firebase para eliminar documentos y colecciones. Usa el siguiente comando para eliminar datos:

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

Eliminar datos con la consola

Puedes eliminar documentos y colecciones de la página Firestore de la consola. Si eliminas un documento de la consola, se borrarán todos los datos anidados de ese documento, incluidas las subcolecciones.

Eliminar datos con políticas de TTL

Una política de TTL designa un campo concreto como la hora de vencimiento de los documentos de un grupo de colecciones determinado. Las operaciones de eliminación por TTL se incluyen en los costes de eliminación de documentos.

Para obtener información sobre cómo definir el TTL, consulta el artículo Gestionar la conservación de datos con políticas de TTL.

Para obtener más información sobre los códigos de error y cómo resolver los problemas de latencia al eliminar datos, consulta la página de solución de problemas.

Eliminar datos con Dataflow

Dataflow es una herramienta fantástica para realizar operaciones en bloque en tu base de datos de Firestore. En la entrada de blog de introducción al conector de Firestore para Dataflow se incluye un ejemplo de cómo eliminar todos los documentos de un grupo de colecciones.

Usar la eliminación en bloque gestionada

Firestore permite eliminar de forma masiva uno o varios grupos de colecciones. Para obtener más información, consulta Eliminar datos en bloque.