Trigger di Firestore

Puoi configurare le funzioni Cloud Run in modo che vengano attivate da eventi in un database Firestore. Una volta attivata, la funzione può leggere e aggiornare un database Firestore in risposta a questi eventi tramite le API e le librerie client di Firestore.

In un ciclo di vita tipico, una funzione Firestore esegue le seguenti operazioni:

  1. Attende le modifiche a un determinato documento.

  2. Si attiva quando si verifica un evento ed esegue le relative attività.

  3. Riceve un oggetto dati con uno snapshot del documento interessato. Per write o update eventi, l'oggetto dati contiene snapshot che rappresentano prima e dopo l'evento di attivazione.

Tipi di evento

Firestore supporta gli eventi create, update, delete e write. L'evento write include tutte le modifiche a un documento.

Tipo di evento Trigger
google.cloud.firestore.document.v1.created (valore predefinito) Si attiva quando un documento viene scritto per la prima volta.
google.cloud.firestore.document.v1.updated Viene attivato quando esiste già un documento e un valore è stato modificato.
google.cloud.firestore.document.v1.deleted Viene attivato quando viene eliminato un documento con dati.
google.cloud.firestore.document.v1.written Si attiva quando un documento viene creato, aggiornato o eliminato.

I caratteri jolly sono scritti nei trigger utilizzando parentesi graffe, come segue: "projects/YOUR_PROJECT_ID/databases/(default)/documents/collection/{document_wildcard}"

Specifica il percorso del documento

Per attivare la funzione, specifica un percorso del documento da monitorare. Il documento il percorso deve trovarsi nello stesso progetto Google Cloud della funzione.

Ecco alcuni esempi di percorsi dei documenti validi:

  • users/marie: trigger valido. Monitora un singolo documento, /users/marie.

  • users/{username}: trigger valido. Monitora tutti i documenti dell'utente. I caratteri jolly vengono utilizzati per monitorare tutti i documenti della raccolta.

  • users/{username}/addresses: attivatore non valido. Si riferisce alla sottoraccoltaaddresses, non a un documento.

  • users/{username}/addresses/home: attivatore valido. Monitora il documento dell'indirizzo di casa per tutti gli utenti.

  • users/{username}/addresses/{addressId}: trigger valido. Monitora tutti gli indirizzi documenti.

  • users/{user=**}: trigger valido. Monitora tutti i documenti utente e eventuali documenti nelle raccolte secondarie di ciascun documento utente, ad esempio /users/userID/address/home o /users/userID/phone/work.

Caratteri jolly e parametri

Se non conosci il documento specifico che vuoi monitorare, utilizza un {wildcard} instead of the document ID:

  • users/{username} rimane in ascolto delle modifiche a tutti i documenti dell'utente.

In questo esempio, quando viene modificato un campo in qualsiasi documento in users, corrisponde a un carattere jolly denominato {username}.

Se un documento in users ha sottoraccolte e una in una delle sottoraccolte documenti vengono modificati, {username} il carattere jolly non viene attivato. Se il tuo obiettivo è rispondere agli eventi in Inoltre, utilizza il carattere jolly multisegmento {username=**}.

Le corrispondenze con caratteri jolly vengono estratte dai percorsi dei documenti. Puoi definire quanti simboli jolly vuoi per sostituire ID raccolta o documento espliciti. Puoi utilizza fino a un carattere jolly multisegmento come {username=**}.

Strutture per eventi

Questo trigger richiama la tua funzione con un evento simile al seguente:

{
    "oldValue": { // Update and Delete operations only
        A Document object containing a pre-operation document snapshot
    },
    "updateMask": { // Update operations only
        A DocumentMask object that lists changed fields.
    },
    "value": {
        // A Document object containing a post-operation document snapshot
    }
}

Ogni oggetto Document contiene uno o più oggetti Value. Per i riferimenti ai tipi, consulta la documentazione di Value. Ciò è particolarmente utile se utilizzi una lingua digitata (come Go) per scrivere le tue funzioni.

Esempi

I seguenti esempi mostrano come scrivere funzioni che rispondono a una Trigger di Firestore.

Prima di iniziare

  1. Sign in to your Google Cloud account. If you're new to Google Cloud, create an account to evaluate how our products perform in real-world scenarios. New customers also get $300 in free credits to run, test, and deploy workloads.
  2. In the Google Cloud console, on the project selector page, select or create a Google Cloud project.

    Go to project selector

  3. Make sure that billing is enabled for your Google Cloud project.

  4. Enable the Cloud Functions, Cloud Build, Artifact Registry, Eventarc, Logging, Pub/Sub, and Cloud Run APIs.

    Enable the APIs

  5. Install the Google Cloud CLI.
  6. To initialize the gcloud CLI, run the following command:

    gcloud init
  7. In the Google Cloud console, on the project selector page, select or create a Google Cloud project.

    Go to project selector

  8. Make sure that billing is enabled for your Google Cloud project.

  9. Enable the Cloud Functions, Cloud Build, Artifact Registry, Eventarc, Logging, Pub/Sub, and Cloud Run APIs.

    Enable the APIs

  10. Install the Google Cloud CLI.
  11. To initialize the gcloud CLI, run the following command:

    gcloud init
  12. Se hai già installato gcloud CLI, aggiornalo eseguendo il seguente comando:

    gcloud components update
  13. Prepara l'ambiente di sviluppo.

Configura il tuo database Firestore

Per testare gli esempi in questo documento, devi avere un database Firestore. Deve essere implementato prima di eseguire il deployment delle funzioni. Se non disponi già di un Database Firestore, creane uno come segue:

  1. Vai alla pagina Dati di Firestore.

  2. Fai clic su Seleziona modalità nativa.

  3. Scegli la regione (località) in cui si trova il database. Questa scelta è definitiva.

  4. Fai clic su Crea database.

Il modello dati di Firestore è costituito da raccolte che contengono documenti. Un documento contiene una serie di coppie chiave/valore.

Le funzioni create in questo tutorial vengono attivate quando apporti modifiche un documento all'interno di una raccolta specificata.

Esempio 1: funzione Hello Firestore

La seguente funzione Cloud Run di esempio stampa i campi di un evento Firestore che attiva:

Node.js

Utilizzare protobufjs per decodificare l'evento e i dati di Google Cloud. Includi google.events.cloud.firestore.v1 data.proto nella sorgente.

/**
 * Cloud Event Function triggered by a change to a Firestore document.
 */
const functions = require('@google-cloud/functions-framework');
const protobuf = require('protobufjs');

functions.cloudEvent('helloFirestore', async cloudEvent => {
  console.log(`Function triggered by event on: ${cloudEvent.source}`);
  console.log(`Event type: ${cloudEvent.type}`);

  console.log('Loading protos...');
  const root = await protobuf.load('data.proto');
  const DocumentEventData = root.lookupType(
    'google.events.cloud.firestore.v1.DocumentEventData'
  );

  console.log('Decoding data...');
  const firestoreReceived = DocumentEventData.decode(cloudEvent.data);

  console.log('\nOld value:');
  console.log(JSON.stringify(firestoreReceived.oldValue, null, 2));

  console.log('\nNew value:');
  console.log(JSON.stringify(firestoreReceived.value, null, 2));
});

Python

from cloudevents.http import CloudEvent
import functions_framework
from google.events.cloud import firestore


@functions_framework.cloud_event
def hello_firestore(cloud_event: CloudEvent) -> None:
    """Triggers by a change to a Firestore document.

    Args:
        cloud_event: cloud event with information on the firestore event trigger
    """
    firestore_payload = firestore.DocumentEventData()
    firestore_payload._pb.ParseFromString(cloud_event.data)

    print(f"Function triggered by change to: {cloud_event['source']}")

    print("\nOld value:")
    print(firestore_payload.old_value)

    print("\nNew value:")
    print(firestore_payload.value)

Vai


// Package hellofirestore contains a Cloud Event Function triggered by a Cloud Firestore event.
package hellofirestore

import (
	"context"
	"fmt"

	"github.com/GoogleCloudPlatform/functions-framework-go/functions"
	"github.com/cloudevents/sdk-go/v2/event"
	"github.com/googleapis/google-cloudevents-go/cloud/firestoredata"
	"google.golang.org/protobuf/proto"
)

func init() {
	functions.CloudEvent("helloFirestore", HelloFirestore)
}

// HelloFirestore is triggered by a change to a Firestore document.
func HelloFirestore(ctx context.Context, event event.Event) error {
	var data firestoredata.DocumentEventData
	if err := proto.Unmarshal(event.Data(), &data); err != nil {
		return fmt.Errorf("proto.Unmarshal: %w", err)
	}

	fmt.Printf("Function triggered by change to: %v\n", event.Source())
	fmt.Printf("Old value: %+v\n", data.GetOldValue())
	fmt.Printf("New value: %+v\n", data.GetValue())
	return nil
}

Java

import com.google.cloud.functions.CloudEventsFunction;
import com.google.events.cloud.firestore.v1.DocumentEventData;
import com.google.protobuf.InvalidProtocolBufferException;
import io.cloudevents.CloudEvent;
import java.util.logging.Logger;

public class FirebaseFirestore implements CloudEventsFunction {
  private static final Logger logger = Logger.getLogger(FirebaseFirestore.class.getName());

  @Override
  public void accept(CloudEvent event) throws InvalidProtocolBufferException {
    DocumentEventData firestorEventData = DocumentEventData.parseFrom(event.getData().toBytes());

    logger.info("Function triggered by event on: " + event.getSource());
    logger.info("Event type: " + event.getType());

    logger.info("Old value:");
    logger.info(firestorEventData.getOldValue().toString());

    logger.info("New value:");
    logger.info(firestorEventData.getValue().toString());
  }
}

C#

using CloudNative.CloudEvents;
using Google.Cloud.Functions.Framework;
using Google.Events.Protobuf.Cloud.Firestore.V1;
using Microsoft.Extensions.Logging;
using System.Collections.Generic;
using System.Linq;
using System.Threading;
using System.Threading.Tasks;

namespace FirebaseFirestore;

public class Function : ICloudEventFunction<DocumentEventData>
{
    private readonly ILogger _logger;

    public Function(ILogger<Function> logger) =>
        _logger = logger;

    public Task HandleAsync(CloudEvent cloudEvent, DocumentEventData data, CancellationToken cancellationToken)
    {
        _logger.LogInformation("Function triggered by event on {subject}", cloudEvent.Subject);
        _logger.LogInformation("Event type: {type}", cloudEvent.Type);
        MaybeLogDocument("Old value", data.OldValue);
        MaybeLogDocument("New value", data.Value);

        // In this example, we don't need to perform any asynchronous operations, so the
        // method doesn't need to be declared async.
        return Task.CompletedTask;
    }

    /// <summary>
    /// Logs the names and values of the fields in a document in a very simplistic way.
    /// </summary>
    private void MaybeLogDocument(string message, Document document)
    {
        if (document is null)
        {
            return;
        }

        // ConvertFields converts the Firestore representation into a .NET-friendly
        // representation.
        IReadOnlyDictionary<string, object> fields = document.ConvertFields();
        var fieldNamesAndTypes = fields
            .OrderBy(pair => pair.Key)
            .Select(pair => $"{pair.Key}: {pair.Value}");
        _logger.LogInformation(message + ": {fields}", string.Join(", ", fieldNamesAndTypes));
    }
}

Esegui il deployment della funzione Hello Firestore

  1. Se non l'hai ancora fatto, configura Database Firestore.

  2. Per eseguire il deployment della funzione Hello Firestore con un file Firestore esegui questo comando nella directory che contiene l'esempio (o, nel caso di Java, il file pom.xml):

    gcloud functions deploy FUNCTION_NAME \
    --gen2 \
    --runtime=RUNTIME \
    --region=REGION \
    --trigger-location=TRIGGER REGION \
    --source=. \
    --entry-point=ENTRY_POINT \
    --trigger-event-filters=type=google.cloud.firestore.document.v1.written \
    --trigger-event-filters=database='(default)' \
    --trigger-event-filters-path-pattern=document='users/{username}'

    Sostituisci quanto segue:

    • FUNCTION_NAME: un nome per la funzione di cui hai eseguito il deployment.
    • RUNTIME: il runtime del linguaggio utilizzato dalla tua funzione.
    • REGION: la regione in cui eseguire il deployment della funzione.
    • TRIGGER_REGION: la posizione dell'attivatore, che deve essere uguale alla regione del database Firestore.
    • ENTRY_POINT: il punto di contatto della funzione nel codice sorgente. Questo è il codice che viene eseguito quando la funzione viene eseguita.

    Utilizza gli altri campi così come sono:

    • --trigger-event-filters=type=google.cloud.firestore.document.v1.written specifica che la funzione viene attivata quando un documento viene creato, aggiornato o eliminato, in base al google.cloud.firestore.document.v1.written tipo di evento.
    • --trigger-event-filters=database='(default)' specifica per configurare un database. Per il nome predefinito del database, utilizza (default).
    • --trigger-event-filters-path-pattern=document='users/{username}' fornisce il parametro del percorso dei documenti che devono essere monitorati per verificare le modifiche pertinenti. Questo pattern di percorso indica che tutti i documenti della raccolta users devono essere monitorati. Per ulteriori informazioni, vedi Comprendi i pattern dei percorsi.

Testa la funzione Hello Firestore

Per testare la funzione Hello Firestore, configura una raccolta denominata users nel tuo database Firestore:

  1. Nella pagina Dati di Firestore, fai clic su Avvia una raccolta.

  2. Specifica users come ID raccolta.

  3. Per iniziare ad aggiungere il primo documento della raccolta, in Aggiungi il primo documento accetta l'ID documento generato automaticamente.

  4. Aggiungi almeno un campo per il documento, specificando un nome e un valore. In questo esempio, il nome è "username" e il valore è "rowan:"

    Screenshot che mostra la creazione di una raccolta Firestore

  5. Quando hai terminato, fai clic su Salva.

    Questa azione crea un nuovo documento, attivando così la funzione.

  6. Per confermare che la funzione è stata attivata, fai clic sul nome collegato del nella console Google Cloud Pagina Panoramica delle funzioni di Cloud Run per aprire la pagina Dettagli funzione.

  7. Apri la scheda Log e cerca questa stringa:

Function triggered by change to: //firestore.googleapis.com/projects/your-project-id/databases/(default)'

Esempio 2: funzione Converti in lettere maiuscole

Questo esempio recupera il valore aggiunto dall'utente, converte la stringa in quella posizione in maiuscolo e sostituisce il valore con la stringa in maiuscolo:

Node.js

Utilizzare protobufjs per decodificare l'evento e i dati di Google Cloud. Includi google.events.cloud.firestore.v1 data.proto nel codice sorgente.

const functions = require('@google-cloud/functions-framework');
const Firestore = require('@google-cloud/firestore');
const protobuf = require('protobufjs');

const firestore = new Firestore({
  projectId: process.env.GOOGLE_CLOUD_PROJECT,
});

// Converts strings added to /messages/{pushId}/original to uppercase
functions.cloudEvent('makeUpperCase', async cloudEvent => {
  console.log('Loading protos...');
  const root = await protobuf.load('data.proto');
  const DocumentEventData = root.lookupType(
    'google.events.cloud.firestore.v1.DocumentEventData'
  );

  console.log('Decoding data...');
  const firestoreReceived = DocumentEventData.decode(cloudEvent.data);

  const resource = firestoreReceived.value.name;
  const affectedDoc = firestore.doc(resource.split('/documents/')[1]);

  const curValue = firestoreReceived.value.fields.original.stringValue;
  const newValue = curValue.toUpperCase();

  if (curValue === newValue) {
    // Value is already upper-case
    // Don't perform a(nother) write to avoid infinite loops
    console.log('Value is already upper-case.');
    return;
  }

  console.log(`Replacing value: ${curValue} --> ${newValue}`);
  affectedDoc.set({
    original: newValue,
  });
});

Python

from cloudevents.http import CloudEvent
import functions_framework
from google.cloud import firestore
from google.events.cloud import firestore as firestoredata

client = firestore.Client()


# Converts strings added to /messages/{pushId}/original to uppercase
@functions_framework.cloud_event
def make_upper_case(cloud_event: CloudEvent) -> None:
    firestore_payload = firestoredata.DocumentEventData()
    firestore_payload._pb.ParseFromString(cloud_event.data)

    path_parts = firestore_payload.value.name.split("/")
    separator_idx = path_parts.index("documents")
    collection_path = path_parts[separator_idx + 1]
    document_path = "/".join(path_parts[(separator_idx + 2) :])

    print(f"Collection path: {collection_path}")
    print(f"Document path: {document_path}")

    affected_doc = client.collection(collection_path).document(document_path)

    cur_value = firestore_payload.value.fields["original"].string_value
    new_value = cur_value.upper()

    if cur_value != new_value:
        print(f"Replacing value: {cur_value} --> {new_value}")
        affected_doc.set({"original": new_value})
    else:
        # Value is already upper-case
        # Don't perform a second write (which can trigger an infinite loop)
        print("Value is already upper-case.")

Vai


// Package upper contains a Firestore Cloud Function.
package upper

import (
	"context"
	"errors"
	"fmt"
	"log"
	"os"
	"strings"

	"cloud.google.com/go/firestore"
	firebase "firebase.google.com/go/v4"
	"github.com/GoogleCloudPlatform/functions-framework-go/functions"
	"github.com/cloudevents/sdk-go/v2/event"
	"github.com/googleapis/google-cloudevents-go/cloud/firestoredata"
	"google.golang.org/protobuf/proto"
)

// set the GOOGLE_CLOUD_PROJECT environment variable when deploying.
var projectID = os.Getenv("GOOGLE_CLOUD_PROJECT")

// client is a Firestore client, reused between function invocations.
var client *firestore.Client

func init() {
	// Use the application default credentials.
	conf := &firebase.Config{ProjectID: projectID}

	// Use context.Background() because the app/client should persist across
	// invocations.
	ctx := context.Background()

	app, err := firebase.NewApp(ctx, conf)
	if err != nil {
		log.Fatalf("firebase.NewApp: %v", err)
	}

	client, err = app.Firestore(ctx)
	if err != nil {
		log.Fatalf("app.Firestore: %v", err)
	}

	// Register cloud event function
	functions.CloudEvent("MakeUpperCase", MakeUpperCase)
}

// MakeUpperCase is triggered by a change to a Firestore document. It updates
// the `original` value of the document to upper case.
func MakeUpperCase(ctx context.Context, e event.Event) error {
	var data firestoredata.DocumentEventData
	if err := proto.Unmarshal(e.Data(), &data); err != nil {
		return fmt.Errorf("proto.Unmarshal: %w", err)
	}

	if data.GetValue() == nil {
		return errors.New("Invalid message: 'Value' not present")
	}

	fullPath := strings.Split(data.GetValue().GetName(), "/documents/")[1]
	pathParts := strings.Split(fullPath, "/")
	collection := pathParts[0]
	doc := strings.Join(pathParts[1:], "/")

	var originalStringValue string
	if v, ok := data.GetValue().GetFields()["original"]; ok {
		originalStringValue = v.GetStringValue()
	} else {
		return errors.New("Document did not contain field \"original\"")
	}

	newValue := strings.ToUpper(originalStringValue)
	if originalStringValue == newValue {
		log.Printf("%q is already upper case: skipping", originalStringValue)
		return nil
	}
	log.Printf("Replacing value: %q -> %q", originalStringValue, newValue)

	newDocumentEntry := map[string]string{"original": newValue}
	_, err := client.Collection(collection).Doc(doc).Set(ctx, newDocumentEntry)
	if err != nil {
		return fmt.Errorf("Set: %w", err)
	}
	return nil
}

Java

import com.google.cloud.firestore.Firestore;
import com.google.cloud.firestore.FirestoreOptions;
import com.google.cloud.firestore.SetOptions;
import com.google.cloud.functions.CloudEventsFunction;
import com.google.events.cloud.firestore.v1.DocumentEventData;
import com.google.events.cloud.firestore.v1.Value;
import com.google.protobuf.InvalidProtocolBufferException;
import io.cloudevents.CloudEvent;
import java.util.Map;
import java.util.concurrent.ExecutionException;
import java.util.logging.Logger;

public class FirebaseFirestoreReactive implements CloudEventsFunction {
  private static final Logger logger = Logger.getLogger(FirebaseFirestoreReactive.class.getName());
  private final Firestore firestore;

  private static final String FIELD_KEY = "original";
  private static final String APPLICATION_PROTOBUF = "application/protobuf";

  public FirebaseFirestoreReactive() {
    this(FirestoreOptions.getDefaultInstance().getService());
  }

  public FirebaseFirestoreReactive(Firestore firestore) {
    this.firestore = firestore;
  }

  @Override
  public void accept(CloudEvent event)
      throws InvalidProtocolBufferException, InterruptedException, ExecutionException {
    if (event.getData() == null) {
      logger.warning("No data found in event!");
      return;
    }

    if (!event.getDataContentType().equals(APPLICATION_PROTOBUF)) {
      logger.warning(String.format("Found unexpected content type %s, expected %s",
          event.getDataContentType(),
          APPLICATION_PROTOBUF));
      return;
    }

    DocumentEventData firestoreEventData = DocumentEventData
        .parseFrom(event.getData().toBytes());

    // Get the fields from the post-operation document snapshot
    // https://firebase.google.com/docs/firestore/reference/rest/v1/projects.databases.documents#Document
    Map<String, Value> fields = firestoreEventData.getValue().getFieldsMap();
    if (!fields.containsKey(FIELD_KEY)) {
      logger.warning("Document does not contain original field");
      return;
    }
    String currValue = fields.get(FIELD_KEY).getStringValue();
    String newValue = currValue.toUpperCase();

    if (currValue.equals(newValue)) {
      logger.info("Value is already upper-case");
      return;
    }

    // Retrieve the document name from the resource path:
    // projects/{project_id}/databases/{database_id}/documents/{document_path}
    String affectedDoc = firestoreEventData.getValue()
        .getName()
        .split("/documents/")[1]
        .replace("\"", "");

    logger.info(String.format("Replacing values: %s --> %s", currValue, newValue));

    // Wait for the async call to complete
    this.firestore
        .document(affectedDoc)
        .set(Map.of(FIELD_KEY, newValue), SetOptions.merge())
        .get();
  }
}

C#

using CloudNative.CloudEvents;
using Google.Cloud.Firestore;
using Google.Cloud.Functions.Framework;
using Google.Cloud.Functions.Hosting;
using Google.Events.Protobuf.Cloud.Firestore.V1;
using Microsoft.AspNetCore.Hosting;
using Microsoft.Extensions.DependencyInjection;
using Microsoft.Extensions.Logging;
using System.Collections.Generic;
using System.Threading;
using System.Threading.Tasks;

namespace FirestoreReactive;

public class Startup : FunctionsStartup
{
    public override void ConfigureServices(WebHostBuilderContext context, IServiceCollection services) =>
        services.AddSingleton(FirestoreDb.Create());
}

// Register the startup class to provide the Firestore dependency.
[FunctionsStartup(typeof(Startup))]
public class Function : ICloudEventFunction<DocumentEventData>
{
    private readonly ILogger _logger;
    private readonly FirestoreDb _firestoreDb;

    public Function(ILogger<Function> logger, FirestoreDb firestoreDb) =>
        (_logger, _firestoreDb) = (logger, firestoreDb);

    public async Task HandleAsync(CloudEvent cloudEvent, DocumentEventData data, CancellationToken cancellationToken)
    {
        // Get the recently-written value. This expression will result in a null value
        // if any of the following is true:
        // - The event doesn't contain a "new" document
        // - The value doesn't contain a field called "original"
        // - The "original" field isn't a string
        string currentValue = data.Value?.ConvertFields().GetValueOrDefault("original") as string;
        if (currentValue is null)
        {
            _logger.LogWarning($"Event did not contain a suitable document");
            return;
        }

        string newValue = currentValue.ToUpperInvariant();
        if (newValue == currentValue)
        {
            _logger.LogInformation("Value is already upper-cased; no replacement necessary");
            return;
        }

        // The CloudEvent subject is "documents/x/y/...".
        // The Firestore SDK FirestoreDb.Document method expects a reference relative to
        // "documents" (so just the "x/y/..." part). This may be simplified over time.
        if (cloudEvent.Subject is null || !cloudEvent.Subject.StartsWith("documents/"))
        {
            _logger.LogWarning("CloudEvent subject is not a document reference.");
            return;
        }
        string documentPath = cloudEvent.Subject.Substring("documents/".Length);

        _logger.LogInformation("Replacing '{current}' with '{new}' in '{path}'", currentValue, newValue, documentPath);
        await _firestoreDb.Document(documentPath).UpdateAsync("original", newValue, cancellationToken: cancellationToken);
    }
}

Esegui il deployment della funzione Converti in maiuscolo

  1. Se non l'hai ancora fatto, configura Database Firestore.

  2. Utilizza questo comando per eseguire il deployment di una funzione che viene attivata scrivi eventi sul documento companies/{CompanyId}:

    gcloud functions deploy FUNCTION_NAME \
    --gen2 \
    --runtime=RUNTIME \
    --trigger-location=TRIGGER REGION \
    --region=REGION \
    --source=. \
    --entry-point=ENTRY_POINT \
    --set-env-vars GOOGLE_CLOUD_PROJECT=PROJECT_ID \
    --trigger-event-filters=type=google.cloud.firestore.document.v1.written \
    --trigger-event-filters=database='(default)' \
    --trigger-event-filters-path-pattern=document='messages/{pushId}'

    Sostituisci quanto segue:

    • FUNCTION_NAME: un nome per la funzione di cui hai eseguito il deployment.
    • RUNTIME: il runtime del linguaggio utilizzato dalla tua funzione.
    • REGION: la regione in cui eseguire il deployment della funzione.
    • TRIGGER_REGION: la posizione dell'attivatore, che deve essere uguale alla regione del database Firestore.
    • ENTRY_POINT: il punto di accesso alla funzione in codice sorgente. Questo è il codice che viene eseguito quando viene eseguita la funzione.
    • PROJECT_ID: l'identificatore univoco del progetto.

    Utilizza gli altri campi così come sono:

    • --trigger-event-filters=type=google.cloud.firestore.document.v1.written specifica che la funzione viene attivata quando viene creato, aggiornato o eliminato un documento, in base al google.cloud.firestore.document.v1.written tipo di evento.
    • --trigger-event-filters=database='(default)' specifica il database Firestore. Per il nome predefinito del database, utilizza (default).
    • --trigger-event-filters-path-pattern=document='messages/{pushId}' fornisce il pattern del percorso dei documenti che devono essere monitorati per verificare modifiche. Questo pattern di percorso indica che tutti i documenti della raccolta messages devono essere monitorati. Per ulteriori informazioni, consulta Informazioni sui pattern di percorso.

Testa la funzione Converti in lettere maiuscole

Per testare la funzione Converti in maiuscole di cui hai appena eseguito il deployment, configura una raccolta chiamata messages nel tuo Database Firestore:

  1. Vai alla pagina Dati di Firestore.

  2. Fai clic su Crea una raccolta.

  3. Specifica messages come ID raccolta.

  4. Per iniziare ad aggiungere il primo documento della raccolta, in Aggiungi il primo documento accetta l'ID documento generato automaticamente.

  5. Per attivare la funzione di cui hai eseguito il deployment, aggiungi un documento in cui il nome del campo è "originale" e il valore del campo è una parola minuscola, ad esempio:

    Screenshot che mostra la creazione di una raccolta Firestore

  6. Quando salvi il documento, puoi vedere la parola minuscola nel valore viene convertito in lettere maiuscole.

    Se successivamente modifichi il valore del campo in modo che contenga lettere minuscole, la funzione viene attivata di nuovo e tutte le lettere minuscole vengono convertite in maiuscole.

Limitazioni

  • L'ordine non è garantito. Le variazioni rapide possono attivare le chiamate di funzione in un ordine imprevisto.
  • Gli eventi vengono pubblicati almeno una volta, ma un singolo evento può generare più chiamate di funzione. Da evitare in base a la meccanica "exactly-once" e scrivere funzioni idempotenti:
  • Un trigger è associato a un singolo database. Non puoi creare un trigger che corrisponde a più database.
  • L'eliminazione di un database non comporta l'eliminazione automatica degli attivatori per quel database. La interrompe la pubblicazione degli eventi, ma continua a esistere finché non elimini l'attivatore.