Pemicu Firestore (generasi ke-2)

Anda dapat mengonfigurasi Cloud Functions agar dipicu oleh peristiwa di database Firestore. Setelah dipicu, fungsi Anda dapat membaca dan mengupdate database Firestore sebagai respons terhadap peristiwa ini melalui API Firestore dan library klien.

Dalam siklus proses umum, fungsi Firestore melakukan hal-hal berikut:

  1. Menunggu perubahan pada dokumen tertentu.

  2. Terpicu ketika suatu peristiwa terjadi dan menjalankan tugasnya.

  3. Menerima objek data dengan snapshot dokumen yang terpengaruh. Untuk peristiwa write atau update, objek data berisi snapshot yang mewakili status dokumen sebelum dan setelah peristiwa pemicuan.

Jenis peristiwa

Firestore mendukung peristiwa create, update, delete, dan write. Peristiwa write mencakup semua perubahan pada dokumen.

Jenis peristiwa Pemicu
google.cloud.firestore.document.v1.created (default) Dipicu saat dokumen ditulisi untuk pertama kalinya.
google.cloud.firestore.document.v1.updated Dipicu saat dokumen sudah ada dan nilainya berubah.
google.cloud.firestore.document.v1.deleted Dipicu saat dokumen yang memuat data dihapus.
google.cloud.firestore.document.v1.written Dipicu saat dokumen dibuat, diperbarui, atau dihapus.

Karakter pengganti ditulis dalam pemicu menggunakan tanda kurung kurawal, seperti berikut: "projects/YOUR_PROJECT_ID/databases/(default)/documents/collection/{document_wildcard}"

Menentukan jalur dokumen

Untuk memicu fungsi Anda, tentukan jalur dokumen yang akan diproses. Jalur dokumen harus berada dalam project Google Cloud yang sama dengan fungsinya.

Berikut adalah beberapa contoh jalur dokumen yang valid:

  • users/marie: pemicu valid. Memantau satu dokumen, /users/marie.

  • users/{username}: pemicu valid. Memantau semua dokumen pengguna. Karakter pengganti digunakan untuk memantau semua dokumen dalam koleksi.

  • users/{username}/addresses: pemicu tidak valid. Mengacu pada subkoleksi addresses, bukan dokumen.

  • users/{username}/addresses/home: pemicu valid. Memantau dokumen alamat rumah untuk semua pengguna.

  • users/{username}/addresses/{addressId}: pemicu valid. Memantau semua dokumen alamat.

  • users/{user=**}: pemicu valid. Memantau semua dokumen pengguna dan setiap dokumen dalam subkoleksi pada setiap dokumen pengguna seperti /users/userID/address/home atau /users/userID/phone/work.

Karakter pengganti dan parameter

Jika tidak mengetahui secara spesifik dokumen yang ingin dipantau, gunakan {wildcard}, bukan ID dokumen:

  • users/{username} akan memproses perubahan pada semua dokumen pengguna.

Dalam contoh ini, saat kolom dalam dokumen pada users diubah, maka akan dicocokkan dengan karakter pengganti yang disebut {username}.

Jika dokumen dalam users memiliki subkoleksi, dan kolom di salah satu dokumen subkoleksi tersebut diubah, karakter pengganti {username} tidak akan terpicu. Jika sasaran Anda adalah juga merespons peristiwa di subkoleksi, gunakan karakter pengganti multi-segmen {username=**}.

Kecocokan karakter pengganti diekstrak dari jalur dokumen. Anda dapat menentukan karakter pengganti sebanyak yang Anda inginkan untuk mengganti koleksi eksplisit atau ID dokumen. Anda dapat menggunakan maksimal satu karakter pengganti multi-segmen seperti {username=**}.

Struktur peristiwa

Pemicu ini memanggil fungsi Anda dengan peristiwa yang mirip dengan ini:

{
    "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
    }
}

Setiap objek Document berisi satu atau beberapa objek Value. Lihat dokumentasi Value untuk referensi jenis. Hal ini sangat berguna jika Anda menggunakan bahasa yang diketik (seperti Go) untuk menulis fungsi.

Menyiapkan database Firestore

Anda memerlukan database Firestore untuk menguji sampel dalam dokumen ini. Atribut ini harus ada sebelum Anda men-deploy fungsi. Jika Anda belum memiliki database Firestore, buat dengan cara berikut:

  1. Buka halaman Data Firestore.

  2. Klik Pilih Mode Native .

  3. Pilih region tempat database Anda berada. Pilihan ini bersifat permanen.

  4. Klik Buat database.

Model data Firestore terdiri dari koleksi yang berisi dokumen. Setiap dokumen berisi kumpulan key-value pair.

Fungsi yang Anda buat dalam tutorial ini dipicu saat Anda membuat perubahan pada dokumen di dalam koleksi tertentu.

Contoh 1: Fungsi Hello Firestore

Contoh Cloud Function berikut mencetak kolom peristiwa Firestore yang memicu:

Node.js

Gunakan protobufjs untuk mendekode data peristiwa. Sertakan google.events.cloud.firestore.v1 data.proto dalam sumber Anda.

/**
 * 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)

Go


// 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));
    }
}

Men-deploy fungsi Hello Firestore

  1. Jika Anda belum melakukannya, siapkan database Firestore.

  2. Untuk men-deploy fungsi Hello Firestore dengan pemicu Firestore, jalankan perintah berikut di direktori yang berisi kode contoh (atau untuk Java, 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}'
    

    Ganti kode berikut:

    • FUNCTION_NAME: Nama untuk fungsi yang di-deploy.
    • RUNTIME: Runtime bahasa yang digunakan fungsi Anda.
    • REGION: Region tempat men-deploy fungsi Anda.
    • TRIGGER_REGION: Lokasi pemicu, yang harus sama dengan region database Firestore.
    • ENTRY_POINT: Titik entri ke fungsi Anda dalam kode sumber. Ini adalah kode yang dijalankan saat fungsi Anda berjalan.

    Gunakan kolom lainnya sebagaimana adanya:

    • --trigger-event-filters=type=google.cloud.firestore.document.v1.written menentukan bahwa fungsi dipicu saat dokumen dibuat, diupdate, atau dihapus, sesuai dengan jenis peristiwa google.cloud.firestore.document.v1.written.
    • --trigger-event-filters=database='(default)' menentukan database Firebase. Untuk nama database default, gunakan (default).
    • --trigger-event-filters-path-pattern=document='users/{username}' memberikan pola jalur dokumen yang harus dipantau untuk melihat perubahan yang relevan. Pola jalur ini menyatakan bahwa semua dokumen dalam koleksi users harus dipantau. Untuk mengetahui informasi selengkapnya, lihat Memahami pola jalur.

Menguji fungsi Hello Firestore

Untuk menguji fungsi Hello Firestore, siapkan koleksi bernama users di database Firestore Anda:

  1. Di halaman data Firestore, klik Mulai koleksi baru.

  2. Tentukan users sebagai ID koleksi.

  3. Untuk mulai menambahkan dokumen pertama koleksi, di bagian Tambahkan dokumen pertamanya, terima ID Dokumen yang dihasilkan secara otomatis.

  4. Tambahkan setidaknya satu kolom untuk dokumen, dengan menentukan nama dan nilai. Dalam contoh ini, namanya adalah "username" dan nilainya adalah "rowan:"

    Screenshot yang menunjukkan pembuatan koleksi Firestore

  5. Bila telah selesai, klik Simpan.

    Tindakan ini akan membuat dokumen baru, sehingga memicu fungsi Anda.

  6. Untuk mengonfirmasi bahwa fungsi Anda dipicu, klik nama fungsi tertaut di halaman Ringkasan Cloud Functions di Google Cloud Console untuk membuka Detail Functions.

  7. Buka tab Log, lalu cari string ini:

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

Contoh 2: Fungsi Mengonversi ke Huruf Besar

Contoh ini mengambil nilai yang ditambahkan oleh pengguna, mengubah string di lokasi tersebut menjadi huruf besar, dan mengganti nilai dengan string huruf besar:

Node.js

Gunakan protobufjs untuk mendekode data peristiwa. Sertakan google.events.cloud.firestore.v1 data.proto dalam sumber Anda.

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.")

Go


// 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);
    }
}

Men-deploy fungsi Mengonversi ke Huruf Besar

  1. Jika Anda belum melakukannya, siapkan database Firestore.

  2. Gunakan perintah berikut untuk men-deploy fungsi yang dipicu oleh peristiwa tulis pada companies/{CompanyId} dokumen:

    gcloud functions deploy FUNCTION_NAME \
    --gen2 \
    --runtime=RUNTIME \
    --trigger-location=TRIGGER REGION \
    --region=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='messages/{pushId}'
    

    Ganti kode berikut:

    • FUNCTION_NAME: Nama untuk fungsi yang di-deploy.
    • RUNTIME: Runtime bahasa yang digunakan fungsi Anda.
    • REGION: Region tempat men-deploy fungsi Anda.
    • TRIGGER_REGION: Lokasi pemicu, yang harus sama dengan region database Firestore.
    • ENTRY_POINT: Titik entri ke fungsi Anda dalam kode sumber. Ini adalah kode yang dijalankan saat fungsi Anda berjalan.

    Gunakan kolom lainnya sebagaimana adanya:

    • --trigger-event-filters=type=google.cloud.firestore.document.v1.written menentukan bahwa fungsi dipicu saat dokumen dibuat, diupdate, atau dihapus, sesuai dengan jenis peristiwa google.cloud.firestore.document.v1.written.
    • --trigger-event-filters=database='(default)' menentukan database Firestore. Untuk nama database default, gunakan (default).
    • --trigger-event-filters-path-pattern=document='messages/{pushId}' memberikan pola jalur dokumen yang harus dipantau untuk melihat perubahan yang relevan. Pola jalur ini menyatakan bahwa semua dokumen dalam koleksi messages harus dipantau. Untuk mengetahui informasi selengkapnya, lihat Memahami pola jalur.

Menguji fungsi Mengonversi ke Huruf Besar

Untuk menguji fungsi Mengonversi ke Huruf Besar yang baru saja Anda deploy, siapkan koleksi bernama messages di database Firestore Anda:

  1. Buka halaman data Firestore.

  2. Klik Mulai koleksi.

  3. Tentukan messages sebagai ID koleksi.

  4. Untuk mulai menambahkan dokumen pertama koleksi, di bagian Tambahkan dokumen pertamanya, terima ID Dokumen yang dihasilkan secara otomatis.

  5. Untuk memicu fungsi yang di-deploy, tambahkan dokumen dengan nama kolom yang "asli" dan nilai kolomnya adalah kata huruf kecil, misalnya:

    Screenshot yang menunjukkan pembuatan koleksi Firestore

  6. Saat menyimpan dokumen, Anda dapat melihat kata dalam huruf kecil di kolom nilai yang dikonversi menjadi huruf besar.

    Jika kemudian Anda mengedit nilai kolom agar berisi huruf kecil, hal tersebut akan memicu fungsi lagi, dan mengonversi semua huruf kecil menjadi huruf besar.

Batasan

Perhatikan batasan berikut untuk pemicu Firestore untuk Cloud Functions:

  • Pengurutan tidak dijamin. Perubahan cepat dapat memicu pemanggilan fungsi dalam urutan yang tidak terduga.
  • Peristiwa dikirim setidaknya satu kali, tetapi satu peristiwa dapat menghasilkan beberapa pemanggilan fungsi. Hindari mengandalkan mekanisme tepat satu kali, dan tulis fungsi idempoten.
  • Firestore dalam mode Datastore memerlukan Cloud Functions (generasi ke-2). Cloud Functions (generasi ke-1) tidak mendukung mode Datastore.
  • Cloud Functions (generasi ke-1) hanya berfungsi dengan database "(default)" dan tidak mendukung database bernama Firestore. Gunakan Cloud Functions (generasi ke-2) untuk mengonfigurasi peristiwa untuk database bernama.
  • Pemicu dikaitkan dengan satu database. Anda tidak dapat membuat pemicu yang cocok dengan beberapa database.
  • Menghapus database tidak secara otomatis menghapus pemicu untuk database tersebut. Pemicu berhenti mengirim peristiwa, tetapi akan tetap ada sampai Anda menghapus pemicu.
  • Jika peristiwa yang cocok melebihi ukuran permintaan maksimum, peristiwa tersebut mungkin tidak akan dikirim ke Cloud Functions (generasi ke-1).
    • Peristiwa yang tidak terkirim karena ukuran permintaan akan dicatat ke dalam log dalam log platform dan akan diperhitungkan dalam penggunaan log untuk project.
    • Anda dapat menemukan log ini di Logs Explorer dengan pesan "Event dapat mengirim ke Cloud function karena ukuran melebihi batas untuk generasi ke-1..." dengan tingkat keparahan error. Anda dapat menemukan nama fungsi di bawah kolom functionName. Jika kolom receiveTimestamp masih berada dalam waktu satu jam dari sekarang, Anda dapat menyimpulkan konten peristiwa yang sebenarnya dengan membaca dokumen yang dimaksud menggunakan snapshot sebelum dan setelah stempel waktu.
    • Untuk menghindari peristiwa seperti ini, Anda dapat:
      • Melakukan migrasi dan upgrade ke Cloud Functions (generasi ke-2)
      • Memperkecil dokumen
      • Menghapus Cloud Functions yang dimaksud
    • Anda dapat menonaktifkan logging itu sendiri menggunakan pengecualian, tetapi perhatikan bahwa peristiwa yang melanggar tetap tidak akan dikirim.