Los SDKs cliente de Cloud Functions for Firebase te permiten llamar a funciones directamente desde una app de Firebase. Para hacerlo, escribe e implementa una función de HTTP que admita llamadas en Cloud Functions y, luego, agrega lógica de cliente para llamar a la función desde tu app.
Es importante tener en cuenta que las funciones de HTTP que admiten llamadas son similares, pero no idénticas a las funciones de HTTP. Para usar funciones de HTTP que admiten llamadas, debes utilizar el SDK cliente de tu plataforma junto con la API de backend (o implementar el protocolo). Las funciones que admiten llamadas tienen esta diferencia clave respecto de las funciones de HTTP:
- Con las funciones que admiten llamadas, los tokens de Firebase Authentication, los tokens de FCM y los tokens de App Check se incluyen en las solicitudes automáticamente cuando están disponibles.
- El activador deserializa automáticamente el cuerpo de la solicitud y valida los tokens de autenticación.
El SDK de Firebase para Cloud Functions de 2ª gen. y versiones posteriores funciona en conjunto con estas versiones mínimas del SDK cliente de Firebase para ofrecer compatibilidad con las funciones HTTPS que admiten llamadas:
- SDK de Firebase para plataformas de Apple 12.4.0
- SDK de Firebase para Android 22.0.1
- SDK de Firebase web modular 9.7.0
Si quieres agregar una funcionalidad similar a una app creada en una plataforma
no compatible, consulta la especificación del protocolo de https.onCall. En el resto de esta guía, se proporcionan
instrucciones para escribir, implementar y llamar
a una función de HTTP que admite llamadas en las plataformas de Apple, Android, la Web, C++ y Unity.
Escribe e implementa la función que admite llamadas
Los ejemplos de código de esta sección se basan en una muestra de inicio rápido completa que demuestra cómo enviar solicitudes a una función del servidor y obtener una respuesta con uno de los SDKs cliente. Para comenzar, importa los módulos obligatorios:
Node.js
// Dependencies for callable functions.
const {onCall, HttpsError} = require("firebase-functions/https");
const {logger} = require("firebase-functions");
// Dependencies for the addMessage function.
const {getDatabase} = require("firebase-admin/database");
const sanitizer = require("./sanitizer");
Python
# Dependencies for callable functions.
from firebase_functions import https_fn, options
# Dependencies for writing to Realtime Database.
from firebase_admin import db, initialize_app
Usa el controlador de solicitudes de tu plataforma (functions.https.onCall)
o (on_call)
para crear una función HTTPS que admite llamadas. Este método
toma un parámetro de solicitud:
Node.js
// Saves a message to the Firebase Realtime Database but sanitizes the
// text by removing swearwords.
exports.addmessage = onCall((request) => {
  // ...
});
Python
@https_fn.on_call()
def addmessage(req: https_fn.CallableRequest) -> Any:
    """Saves a message to the Firebase Realtime Database but sanitizes the text
    by removing swear words."""
El parámetro request contiene datos que se pasaron desde la app cliente y un contexto adicional, como el estado de autenticación. En el caso de una función que admite llamadas y guarda un mensaje de texto en Realtime Database,
por ejemplo, data podría contener el texto del mensaje y la información de autenticación
en auth:
Node.js
// Message text passed from the client.
const text = request.data.text;
// Authentication / user information is automatically added to the request.
const uid = request.auth.uid;
const name = request.auth.token.name || null;
const picture = request.auth.token.picture || null;
const email = request.auth.token.email || null;
Python
# Message text passed from the client.
text = req.data["text"]
# Authentication / user information is automatically added to the request.
uid = req.auth.uid
name = req.auth.token.get("name", "")
picture = req.auth.token.get("picture", "")
email = req.auth.token.get("email", "")
La distancia entre la ubicación de la función que admite llamadas y la ubicación del cliente que emite la llamada puede generar latencia de red. Para optimizar el rendimiento, especifica la ubicación de la función cuando corresponda. Además, asegúrate de alinear la ubicación de la función que admite llamadas con la ubicación establecida cuando inicialices el SDK en el cliente.
De manera opcional, puedes adjuntar una certificación de App Check para proteger tus recursos de backend contra los abusos, como el fraude de facturación o la suplantación de identidad (phishing). Consulta Habilita la aplicación forzosa de App Check para Cloud Functions.
Devuelve el resultado
Para devolver los datos al cliente, muestra los datos que pueden tener codificación JSON. Por ejemplo, para mostrar el resultado de una operación de suma:
Node.js
// returning result.
return {
  firstNumber: firstNumber,
  secondNumber: secondNumber,
  operator: "+",
  operationResult: firstNumber + secondNumber,
};
Python
return {
    "firstNumber": first_number,
    "secondNumber": second_number,
    "operator": "+",
    "operationResult": first_number + second_number
}
El texto depurado del ejemplo de texto del mensaje se muestra al cliente y a Realtime Database. En Node.js, esto se puede hacer de forma asíncrona mediante una promesa de JavaScript:
Node.js
// Saving the new message to the Realtime Database.
const sanitizedMessage = sanitizer.sanitizeText(text); // Sanitize message.
return getDatabase().ref("/messages").push({
  text: sanitizedMessage,
  author: {uid, name, picture, email},
}).then(() => {
  logger.info("New Message written");
  // Returning the sanitized message to the client.
  return {text: sanitizedMessage};
})
Python
# Saving the new message to the Realtime Database.
sanitized_message = sanitize_text(text)  # Sanitize message.
db.reference("/messages").push({  # type: ignore
    "text": sanitized_message,
    "author": {
        "uid": uid,
        "name": name,
        "picture": picture,
        "email": email
    }
})
print("New message written")
# Returning the sanitized message to the client.
return {"text": sanitized_message}
Tu función debe devolver un valor o, en el caso de Node.js, una promesa que se resuelva con un valor. De lo contrario, es posible que la función finalice antes de que se envíen los datos al cliente. Consulta Cómo finalizar funciones para obtener más información.
Envía y recibe resultados de transmisión
Las funciones que admiten llamadas tienen mecanismos para controlar los resultados de una transmisión. Si tienes un caso de uso que requiere transmisión, puedes configurar la transmisión en la solicitud que admite llamadas y, luego, usar el método adecuado del SDK cliente para llamar a la función.
Cómo enviar resultados de transmisión
Para transmitir de manera eficiente los resultados que se generan con el tiempo, como desde una serie de solicitudes independientes a la API o una API de IA generativa, verifica la propiedad acceptsStreaming en tu solicitud que se puede llamar. Cuando esta propiedad se establece en true, puedes transmitir los resultados al cliente con response.sendChunk().
Por ejemplo, si una app necesita recuperar datos del pronóstico del clima para varias ubicaciones, la función que se puede llamar podría enviar el pronóstico de cada ubicación por separado a los clientes que solicitaron una respuesta de transmisión, en lugar de hacerlos esperar hasta que se resuelvan todas las solicitudes de pronóstico:
exports.getForecast = onCall(async (request, response) => { if (request.data?.locations?.length < 1) { throw new HttpsError("invalid-argument", "Missing locations to forecast"); } // fetch forecast data for all requested locations const allRequests = request.data.locations.map( async ({latitude, longitude}) => { const forecast = await weatherForecastApi(latitude, longitude); const result = {latitude, longitude, forecast}; // clients that support streaming will have each // forecast streamed to them as they complete if (request.acceptsStreaming) { response.sendChunk(result); } return result; }, ); // Return the full set of data to all clients return Promise.all(allRequests); });
Ten en cuenta que la forma en que opera response.sendChunk() depende de ciertos detalles de la solicitud del cliente:
- Si el cliente solicita una respuesta de transmisión, - response.sendChunk(data)envía el fragmento de datos de inmediato.
- Si el cliente no solicita una respuesta de transmisión, - response.sendChunk()no realiza ninguna acción para esa llamada. La respuesta completa se envía una vez que todos los datos están listos.
Para determinar si el cliente solicita una respuesta de transmisión, verifica la propiedad request.acceptsStreaming. Por ejemplo, si request.acceptsStreaming es falso, puedes decidir omitir cualquier trabajo intensivo en recursos relacionado específicamente con la preparación o el envío de fragmentos individuales, ya que el cliente no espera una entrega incremental.
Recibe resultados de transmisión
En una situación típica, el cliente solicita la transmisión con el método .stream y, luego, itera a través de los resultados:
Swift
func listenToWeatherForecast() async throws {
    isLoading = true
    defer { isLoading = false }
    Functions
      .functions(region: "us-central1")
    let getForecast: Callable<WeatherRequest, StreamResponse<WeatherResponse, [WeatherResponse]>> = Functions.functions().httpsCallable("getForecast")
    let request = WeatherRequest(locations: locations)
    let stream = try getForecast.stream(request)
    for try await response in stream {
      switch response {
      case .message(let singleResponse):
        weatherData["\(singleResponse.latitude),\(singleResponse.longitude)"] = singleResponse
      case .result(let arrayOfResponses):
        for response in arrayOfResponses {
          weatherData["\(response.latitude),\(response.longitude)"] = response
        }
        print("Stream ended.")
        return
      }
    }
  }
Web
// Get the callable by passing an initialized functions SDK.
const getForecast = httpsCallable(functions, "getForecast");
// Call the function with the `.stream()` method to start streaming.
const { stream, data } = await getForecast.stream({
  locations: favoriteLocations,
});
// The `stream` async iterable returned by `.stream()`
// will yield a new value every time the callable
// function calls `sendChunk()`.
for await (const forecastDataChunk of stream) {
  // update the UI every time a new chunk is received
  // from the callable function
  updateUi(forecastDataChunk);
}
// The `data` promise resolves when the callable
// function completes.
const allWeatherForecasts = await data;
finalizeUi(allWeatherForecasts);
Realiza un bucle a través del iterable asíncrono stream como se muestra. La espera de la promesa de data le indica al cliente que la solicitud está completa.
Kotlin
// Get the callable by passing an initialized functions SDK.
val getForecast = functions.getHttpsCallable("getForecast");
// Call the function with the `.stream()` method and convert it to a flow
getForecast.stream(
  mapOf("locations" to favoriteLocations)
).asFlow().collect { response ->
  when (response) {
    is StreamResponse.Message -> {
      // The flow will emit a [StreamResponse.Message] value every time the
      // callable function calls `sendChunk()`.
      val forecastDataChunk = response.message.data as Map<String, Any>
      // Update the UI every time a new chunk is received
      // from the callable function
      updateUI(
        forecastDataChunk["latitude"] as Double,
        forecastDataChunk["longitude"] as Double,
        forecastDataChunk["forecast"] as Double,
      )
    }
    is StreamResponse.Result -> {
      // The flow will emit a [StreamResponse.Result] value when the
      // callable function completes.
      val allWeatherForecasts = response.result.data as List<Map<String, Any>>
      finalizeUI(allWeatherForecasts)
    }
  }
}
Para usar la función de extensión asFlow(), agrega la biblioteca org.jetbrains.kotlinx:kotlinx-coroutines-reactive como una dependencia al archivo build.gradle(.kts) de la app.
Java
// Get the callable by passing an initialized functions SDK.
HttpsCallableReference getForecast = mFunctions.getHttpsCallable("getForecast");
getForecast.stream(
  new HashMap<String, Object>() {{
    put("locations", favoriteLocations);
  }}
).subscribe(new Subscriber<StreamResponse>() {
  @Override
  public void onSubscribe(Subscription subscription) {
    subscription.request(Long.MAX_VALUE);
  }
  @Override
  public void onNext(StreamResponse streamResponse) {
    if (streamResponse instanceof StreamResponse.Message) {
      // The flow will emit a [StreamResponse.Message] value every time the
      // callable function calls `sendChunk()`.
      StreamResponse.Message response = (StreamResponse.Message) streamResponse;
      Map<String, Object> forecastDataChunk =
        (Map<String, Object>) response.getMessage().getData();
      // Update the UI every time a new chunk is received
      // from the callable function
      updateUI(
        (double) forecastDataChunk.get("latitude"),
        (double) forecastDataChunk.get("longitude"),
        (double) forecastDataChunk.get("forecast")
      );
    } else if(streamResponse instanceof StreamResponse.Result) {
      // The flow will emit a [StreamResponse.Result] value when the
      // callable function completes.
      StreamResponse.Result response = (StreamResponse.Result) streamResponse;
      List<Map<String, Object>> allWeatherForecasts =
        (List<Map<String, Object>>) response.getResult().getData();
      finalizeUI();
    }
  }
  @Override
  public void onError(Throwable throwable) {
    // an error occurred in the function
  }
  @Override
  public void onComplete() {
  }
});
Configura el CORS (uso compartido de recursos entre dominios)
Usa la opción cors para controlar qué orígenes pueden acceder a tu función.
De forma predeterminada, las funciones que admiten llamadas tienen el CORS configurado para permitir solicitudes de todos los orígenes. Para permitir algunas solicitudes de origen cruzado, pero no todas, debes pasar una lista de dominios específicos o expresiones regulares que deberían permitirse. Por ejemplo:
Node.js
const { onCall } = require("firebase-functions/v2/https");
exports.getGreeting = onCall(
  { cors: [/firebase\.com$/, "https://flutter.com"] },
  (request) => {
    return "Hello, world!";
  }
);
Para prohibir las solicitudes de origen cruzado, establece la política cors como false.
Soluciona errores
Para garantizar que el cliente obtenga información útil sobre los errores, muéstralos desde una función que admita llamadas
arrojando una instancia de functions.https.HttpsError o https_fn.HttpsError, o mostrando una promesa rechazada
con ese error para Node.js.
El error tiene un atributo code que puede ser uno de los valores que se muestran en los
códigos de estado de gRPC.
Los errores también tienen una cadena message, que está vacía en su
configuración predeterminada. También pueden tener un campo details opcional con un
valor arbitrario. Si se arroja un error de HTTPS distinto desde tus funciones,
el cliente recibirá en su lugar un error con el mensaje INTERNAL y el código
internal.
Por ejemplo, una función podría arrojar errores de autenticación y validación de datos con mensajes de error que se muestran al cliente que emite la llamada:
Node.js
// Checking attribute.
if (!(typeof text === "string") || text.length === 0) {
  // Throwing an HttpsError so that the client gets the error details.
  throw new HttpsError("invalid-argument", "The function must be called " +
          "with one arguments \"text\" containing the message text to add.");
}
// Checking that the user is authenticated.
if (!request.auth) {
  // Throwing an HttpsError so that the client gets the error details.
  throw new HttpsError("failed-precondition", "The function must be " +
          "called while authenticated.");
}
Python
# Checking attribute.
if not isinstance(text, str) or len(text) < 1:
    # Throwing an HttpsError so that the client gets the error details.
    raise https_fn.HttpsError(code=https_fn.FunctionsErrorCode.INVALID_ARGUMENT,
                              message=('The function must be called with one argument, "text",'
                                       " containing the message text to add."))
# Checking that the user is authenticated.
if req.auth is None:
    # Throwing an HttpsError so that the client gets the error details.
    raise https_fn.HttpsError(code=https_fn.FunctionsErrorCode.FAILED_PRECONDITION,
                              message="The function must be called while authenticated.")
Implementa la función que admite llamadas
Cuando guardas en index.js una función que admite llamadas que se completó, esta se implementa con todas las otras funciones al ejecutar firebase deploy.
Para implementar solo la función que admite llamadas, usa el argumento --only para ejecutar implementaciones parciales, como se muestra a continuación:
firebase deploy --only functions:addMessage
Si ves errores de permisos cuando implementas funciones, asegúrate de que se asignen los roles de IAM adecuados al usuario que ejecuta los comandos de implementación.
Configura el entorno de desarrollo de tu cliente
Asegúrate de cumplir todos los requisitos; luego agrega las dependencias y las bibliotecas cliente necesarias a tu app.
iOS+
Sigue las instrucciones para agregar Firebase a tu app para Apple.
Usa Swift Package Manager para instalar y administrar las dependencias de Firebase.
- En Xcode, con tu proyecto de app abierto, navega a File > Add Packages.
- Cuando se te solicite, agrega el repositorio del SDK de Firebase para plataformas de Apple:
- Elige la biblioteca de Cloud Functions.
- Agrega la marca -ObjCa la sección Other Linker Flags de la configuración de compilación de tu destino.
- Cuando termines, Xcode comenzará a resolver y descargar automáticamente tus dependencias en segundo plano.
https://github.com/firebase/firebase-ios-sdk.git
Web
- Sigue las instrucciones para
agregar Firebase a tu app web. Asegúrate de ejecutar
el siguiente comando desde la terminal:
npm install firebase@12.4.0 --save 
- Solicita manualmente Firebase Core y Cloud Functions de la siguiente manera: - import { initializeApp } from 'firebase/app'; import { getFunctions } from 'firebase/functions'; const app = initializeApp({ projectId: '### CLOUD FUNCTIONS PROJECT ID ###', apiKey: '### FIREBASE API KEY ###', authDomain: '### FIREBASE AUTH DOMAIN ###', }); const functions = getFunctions(app); 
Android
- Sigue las instrucciones para agregar Firebase a tu app para Android. 
- En el archivo Gradle del módulo (nivel de la app) (generalmente - <project>/<app-module>/build.gradle.ktso- <project>/<app-module>/build.gradle), agrega la dependencia de la biblioteca de Cloud Functions para Android. Te recomendamos usar Firebase Android BoM para controlar las versiones de las bibliotecas.- dependencies { // Import the BoM for the Firebase platform implementation(platform("com.google.firebase:firebase-bom:34.4.0")) // Add the dependency for the Cloud Functions library // When using the BoM, you don't specify versions in Firebase library dependencies implementation("com.google.firebase:firebase-functions") } - Cuando usas Firebase Android BoM, tu app siempre usará versiones compatibles de las bibliotecas de Firebase para Android. - (Alternativa) Agrega dependencias de la biblioteca de Firebase sin usar la BoM - Si eliges no usar la Firebase BoM, debes especificar cada versión de la biblioteca de Firebase en su línea de dependencia. - Ten en cuenta que, si usas múltiples bibliotecas de Firebase en tu app, es muy recomendable que uses la BoM para administrar las versiones de las bibliotecas para garantizar que todas las versiones sean compatibles. - dependencies { // Add the dependency for the Cloud Functions library // When NOT using the BoM, you must specify versions in Firebase library dependencies implementation("com.google.firebase:firebase-functions:22.0.1") } 
Inicializa el SDK cliente
Inicializa una instancia de Cloud Functions:
Swift
lazy var functions = Functions.functions()
Objective-C
@property(strong, nonatomic) FIRFunctions *functions;
// ...
self.functions = [FIRFunctions functions];
Web
const app = initializeApp({
  projectId: '### CLOUD FUNCTIONS PROJECT ID ###',
  apiKey: '### FIREBASE API KEY ###',
  authDomain: '### FIREBASE AUTH DOMAIN ###',
});
const functions = getFunctions(app);
Kotlin
private lateinit var functions: FirebaseFunctions // ... functions = Firebase.functions
Java
private FirebaseFunctions mFunctions; // ... mFunctions = FirebaseFunctions.getInstance();
Llama a la función
Swift
functions.httpsCallable("addMessage").call(["text": inputField.text]) { result, error in
  if let error = error as NSError? {
    if error.domain == FunctionsErrorDomain {
      let code = FunctionsErrorCode(rawValue: error.code)
      let message = error.localizedDescription
      let details = error.userInfo[FunctionsErrorDetailsKey]
    }
    // ...
  }
  if let data = result?.data as? [String: Any], let text = data["text"] as? String {
    self.resultField.text = text
  }
}
Objective-C
[[_functions HTTPSCallableWithName:@"addMessage"] callWithObject:@{@"text": _inputField.text}
                                                      completion:^(FIRHTTPSCallableResult * _Nullable result, NSError * _Nullable error) {
  if (error) {
    if ([error.domain isEqual:@"com.firebase.functions"]) {
      FIRFunctionsErrorCode code = error.code;
      NSString *message = error.localizedDescription;
      NSObject *details = error.userInfo[@"details"];
    }
    // ...
  }
  self->_resultField.text = result.data[@"text"];
}];
Web
var addMessage = firebase.functions().httpsCallable('addMessage');
addMessage({ text: messageText })
  .then((result) => {
    // Read result of the Cloud Function.
    var sanitizedMessage = result.data.text;
  });
Web
import { getFunctions, httpsCallable } from "firebase/functions";
const functions = getFunctions();
const addMessage = httpsCallable(functions, 'addMessage');
addMessage({ text: messageText })
  .then((result) => {
    // Read result of the Cloud Function.
    /** @type {any} */
    const data = result.data;
    const sanitizedMessage = data.text;
  });
Kotlin
private fun addMessage(text: String): Task<String> { // Create the arguments to the callable function. val data = hashMapOf( "text" to text, "push" to true, ) return functions .getHttpsCallable("addMessage") .call(data) .continueWith { task -> // This continuation runs on either success or failure, but if the task // has failed then result will throw an Exception which will be // propagated down. val result = task.result?.data as String result } }
Java
private Task<String> addMessage(String text) { // Create the arguments to the callable function. Map<String, Object> data = new HashMap<>(); data.put("text", text); data.put("push", true); return mFunctions .getHttpsCallable("addMessage") .call(data) .continueWith(new Continuation<HttpsCallableResult, String>() { @Override public String then(@NonNull Task<HttpsCallableResult> task) throws Exception { // This continuation runs on either success or failure, but if the task // has failed then getResult() will throw an Exception which will be // propagated down. String result = (String) task.getResult().getData(); return result; } }); }
Dart
    final result = await FirebaseFunctions.instance.httpsCallable('addMessage').call(
      {
        "text": text,
        "push": true,
      },
    );
    _response = result.data as String;
C++
firebase::Future<firebase::functions::HttpsCallableResult> AddMessage(
    const std::string& text) {
  // Create the arguments to the callable function.
  firebase::Variant data = firebase::Variant::EmptyMap();
  data.map()["text"] = firebase::Variant(text);
  data.map()["push"] = true;
  // Call the function and add a callback for the result.
  firebase::functions::HttpsCallableReference doSomething =
      functions->GetHttpsCallable("addMessage");
  return doSomething.Call(data);
}
Unity
private Task<string> addMessage(string text) {
  // Create the arguments to the callable function.
  var data = new Dictionary<string, object>();
  data["text"] = text;
  data["push"] = true;
  // Call the function and extract the operation from the result.
  var function = functions.GetHttpsCallable("addMessage");
  return function.CallAsync(data).ContinueWith((task) => {
    return (string) task.Result.Data;
  });
}
Maneja errores en el cliente
El cliente recibe un error si el servidor arrojó un error o si se rechazó la promesa que se genera como resultado.
Si el error que muestra la función es del tipo function.https.HttpsError, el cliente recibe el code, el message y los details del error del servidor. En caso contrario, el error contiene el mensaje INTERNAL y el código INTERNAL. Obtén información para
manejar errores en tu función que admite llamadas.
Swift
if let error = error as NSError? {
  if error.domain == FunctionsErrorDomain {
    let code = FunctionsErrorCode(rawValue: error.code)
    let message = error.localizedDescription
    let details = error.userInfo[FunctionsErrorDetailsKey]
  }
  // ...
}
Objective-C
if (error) {
  if ([error.domain isEqual:@"com.firebase.functions"]) {
    FIRFunctionsErrorCode code = error.code;
    NSString *message = error.localizedDescription;
    NSObject *details = error.userInfo[@"details"];
  }
  // ...
}
Web
var addMessage = firebase.functions().httpsCallable('addMessage');
addMessage({ text: messageText })
  .then((result) => {
    // Read result of the Cloud Function.
    var sanitizedMessage = result.data.text;
  })
  .catch((error) => {
    // Getting the Error details.
    var code = error.code;
    var message = error.message;
    var details = error.details;
    // ...
  });
Web
import { getFunctions, httpsCallable } from "firebase/functions";
const functions = getFunctions();
const addMessage = httpsCallable(functions, 'addMessage');
addMessage({ text: messageText })
  .then((result) => {
    // Read result of the Cloud Function.
    /** @type {any} */
    const data = result.data;
    const sanitizedMessage = data.text;
  })
  .catch((error) => {
    // Getting the Error details.
    const code = error.code;
    const message = error.message;
    const details = error.details;
    // ...
  });
Kotlin
addMessage(inputMessage) .addOnCompleteListener { task -> if (!task.isSuccessful) { val e = task.exception if (e is FirebaseFunctionsException) { val code = e.code val details = e.details } } }
Java
addMessage(inputMessage) .addOnCompleteListener(new OnCompleteListener<String>() { @Override public void onComplete(@NonNull Task<String> task) { if (!task.isSuccessful()) { Exception e = task.getException(); if (e instanceof FirebaseFunctionsException) { FirebaseFunctionsException ffe = (FirebaseFunctionsException) e; FirebaseFunctionsException.Code code = ffe.getCode(); Object details = ffe.getDetails(); } } } });
Dart
try {
  final result =
      await FirebaseFunctions.instance.httpsCallable('addMessage').call();
} on FirebaseFunctionsException catch (error) {
  print(error.code);
  print(error.details);
  print(error.message);
}
C++
void OnAddMessageCallback(
    const firebase::Future<firebase::functions::HttpsCallableResult>& future) {
  if (future.error() != firebase::functions::kErrorNone) {
    // Function error code, will be kErrorInternal if the failure was not
    // handled properly in the function call.
    auto code = static_cast<firebase::functions::Error>(future.error());
    // Display the error in the UI.
    DisplayError(code, future.error_message());
    return;
  }
  const firebase::functions::HttpsCallableResult* result = future.result();
  firebase::Variant data = result->data();
  // This will assert if the result returned from the function wasn't a string.
  std::string message = data.string_value();
  // Display the result in the UI.
  DisplayResult(message);
}
// ...
// ...
  auto future = AddMessage(message);
  future.OnCompletion(OnAddMessageCallback);
  // ...
Unity
 addMessage(text).ContinueWith((task) => {
  if (task.IsFaulted) {
    foreach (var inner in task.Exception.InnerExceptions) {
      if (inner is FunctionsException) {
        var e = (FunctionsException) inner;
        // Function error code, will be INTERNAL if the failure
        // was not handled properly in the function call.
        var code = e.ErrorCode;
        var message = e.ErrorMessage;
      }
    }
  } else {
    string result = task.Result;
  }
});
Recomendado: Evita los abusos con App Check
Antes de lanzar tu app, debes habilitar la App Check para asegurarte de que solo tus apps puedan acceder a los extremos de las funciones que admiten llamadas.