1. Packages
  2. Google Cloud (GCP) Classic
  3. API Docs
  4. pubsub
  5. getTopic
Google Cloud v8.23.0 published on Monday, Mar 24, 2025 by Pulumi

gcp.pubsub.getTopic

Explore with Pulumi AI

gcp logo
Google Cloud v8.23.0 published on Monday, Mar 24, 2025 by Pulumi

    Get information about a Google Cloud Pub/Sub Topic. For more information see the official documentation and API.

    Example Usage

    import * as pulumi from "@pulumi/pulumi";
    import * as gcp from "@pulumi/gcp";
    
    const my_pubsub_topic = gcp.pubsub.getTopic({
        name: "my-pubsub-topic",
    });
    
    import pulumi
    import pulumi_gcp as gcp
    
    my_pubsub_topic = gcp.pubsub.get_topic(name="my-pubsub-topic")
    
    package main
    
    import (
    	"github.com/pulumi/pulumi-gcp/sdk/v8/go/gcp/pubsub"
    	"github.com/pulumi/pulumi/sdk/v3/go/pulumi"
    )
    
    func main() {
    	pulumi.Run(func(ctx *pulumi.Context) error {
    		_, err := pubsub.LookupTopic(ctx, &pubsub.LookupTopicArgs{
    			Name: "my-pubsub-topic",
    		}, nil)
    		if err != nil {
    			return err
    		}
    		return nil
    	})
    }
    
    using System.Collections.Generic;
    using System.Linq;
    using Pulumi;
    using Gcp = Pulumi.Gcp;
    
    return await Deployment.RunAsync(() => 
    {
        var my_pubsub_topic = Gcp.PubSub.GetTopic.Invoke(new()
        {
            Name = "my-pubsub-topic",
        });
    
    });
    
    package generated_program;
    
    import com.pulumi.Context;
    import com.pulumi.Pulumi;
    import com.pulumi.core.Output;
    import com.pulumi.gcp.pubsub.PubsubFunctions;
    import com.pulumi.gcp.pubsub.inputs.GetTopicArgs;
    import java.util.List;
    import java.util.ArrayList;
    import java.util.Map;
    import java.io.File;
    import java.nio.file.Files;
    import java.nio.file.Paths;
    
    public class App {
        public static void main(String[] args) {
            Pulumi.run(App::stack);
        }
    
        public static void stack(Context ctx) {
            final var my-pubsub-topic = PubsubFunctions.getTopic(GetTopicArgs.builder()
                .name("my-pubsub-topic")
                .build());
    
        }
    }
    
    variables:
      my-pubsub-topic:
        fn::invoke:
          function: gcp:pubsub:getTopic
          arguments:
            name: my-pubsub-topic
    

    Using getTopic

    Two invocation forms are available. The direct form accepts plain arguments and either blocks until the result value is available, or returns a Promise-wrapped result. The output form accepts Input-wrapped arguments and returns an Output-wrapped result.

    function getTopic(args: GetTopicArgs, opts?: InvokeOptions): Promise<GetTopicResult>
    function getTopicOutput(args: GetTopicOutputArgs, opts?: InvokeOptions): Output<GetTopicResult>
    def get_topic(name: Optional[str] = None,
                  project: Optional[str] = None,
                  opts: Optional[InvokeOptions] = None) -> GetTopicResult
    def get_topic_output(name: Optional[pulumi.Input[str]] = None,
                  project: Optional[pulumi.Input[str]] = None,
                  opts: Optional[InvokeOptions] = None) -> Output[GetTopicResult]
    func LookupTopic(ctx *Context, args *LookupTopicArgs, opts ...InvokeOption) (*LookupTopicResult, error)
    func LookupTopicOutput(ctx *Context, args *LookupTopicOutputArgs, opts ...InvokeOption) LookupTopicResultOutput

    > Note: This function is named LookupTopic in the Go SDK.

    public static class GetTopic 
    {
        public static Task<GetTopicResult> InvokeAsync(GetTopicArgs args, InvokeOptions? opts = null)
        public static Output<GetTopicResult> Invoke(GetTopicInvokeArgs args, InvokeOptions? opts = null)
    }
    public static CompletableFuture<GetTopicResult> getTopic(GetTopicArgs args, InvokeOptions options)
    public static Output<GetTopicResult> getTopic(GetTopicArgs args, InvokeOptions options)
    
    fn::invoke:
      function: gcp:pubsub/getTopic:getTopic
      arguments:
        # arguments dictionary

    The following arguments are supported:

    Name string
    The name of the Cloud Pub/Sub Topic.


    Project string
    The project in which the resource belongs. If it is not provided, the provider project is used.
    Name string
    The name of the Cloud Pub/Sub Topic.


    Project string
    The project in which the resource belongs. If it is not provided, the provider project is used.
    name String
    The name of the Cloud Pub/Sub Topic.


    project String
    The project in which the resource belongs. If it is not provided, the provider project is used.
    name string
    The name of the Cloud Pub/Sub Topic.


    project string
    The project in which the resource belongs. If it is not provided, the provider project is used.
    name str
    The name of the Cloud Pub/Sub Topic.


    project str
    The project in which the resource belongs. If it is not provided, the provider project is used.
    name String
    The name of the Cloud Pub/Sub Topic.


    project String
    The project in which the resource belongs. If it is not provided, the provider project is used.

    getTopic Result

    The following output properties are available:

    EffectiveLabels Dictionary<string, string>
    Id string
    The provider-assigned unique ID for this managed resource.
    IngestionDataSourceSettings List<GetTopicIngestionDataSourceSetting>
    KmsKeyName string
    Labels Dictionary<string, string>
    MessageRetentionDuration string
    MessageStoragePolicies List<GetTopicMessageStoragePolicy>
    Name string
    PulumiLabels Dictionary<string, string>
    SchemaSettings List<GetTopicSchemaSetting>
    Project string
    effectiveLabels {[key: string]: string}
    id string
    The provider-assigned unique ID for this managed resource.
    ingestionDataSourceSettings GetTopicIngestionDataSourceSetting[]
    kmsKeyName string
    labels {[key: string]: string}
    messageRetentionDuration string
    messageStoragePolicies GetTopicMessageStoragePolicy[]
    name string
    pulumiLabels {[key: string]: string}
    schemaSettings GetTopicSchemaSetting[]
    project string
    effectiveLabels Map<String>
    id String
    The provider-assigned unique ID for this managed resource.
    ingestionDataSourceSettings List<Property Map>
    kmsKeyName String
    labels Map<String>
    messageRetentionDuration String
    messageStoragePolicies List<Property Map>
    name String
    pulumiLabels Map<String>
    schemaSettings List<Property Map>
    project String

    Supporting Types

    GetTopicIngestionDataSourceSetting

    AwsKineses List<GetTopicIngestionDataSourceSettingAwsKinese>
    Settings for ingestion from Amazon Kinesis Data Streams.
    AwsMsks List<GetTopicIngestionDataSourceSettingAwsMsk>
    Settings for ingestion from Amazon Managed Streaming for Apache Kafka.
    AzureEventHubs List<GetTopicIngestionDataSourceSettingAzureEventHub>
    Settings for ingestion from Azure Event Hubs.
    CloudStorages List<GetTopicIngestionDataSourceSettingCloudStorage>
    Settings for ingestion from Cloud Storage.
    ConfluentClouds List<GetTopicIngestionDataSourceSettingConfluentCloud>
    Settings for ingestion from Confluent Cloud.
    PlatformLogsSettings List<GetTopicIngestionDataSourceSettingPlatformLogsSetting>
    Settings for Platform Logs regarding ingestion to Pub/Sub. If unset, no Platform Logs will be generated.'
    AwsKineses []GetTopicIngestionDataSourceSettingAwsKinese
    Settings for ingestion from Amazon Kinesis Data Streams.
    AwsMsks []GetTopicIngestionDataSourceSettingAwsMsk
    Settings for ingestion from Amazon Managed Streaming for Apache Kafka.
    AzureEventHubs []GetTopicIngestionDataSourceSettingAzureEventHub
    Settings for ingestion from Azure Event Hubs.
    CloudStorages []GetTopicIngestionDataSourceSettingCloudStorage
    Settings for ingestion from Cloud Storage.
    ConfluentClouds []GetTopicIngestionDataSourceSettingConfluentCloud
    Settings for ingestion from Confluent Cloud.
    PlatformLogsSettings []GetTopicIngestionDataSourceSettingPlatformLogsSetting
    Settings for Platform Logs regarding ingestion to Pub/Sub. If unset, no Platform Logs will be generated.'
    awsKineses List<GetTopicIngestionDataSourceSettingAwsKinese>
    Settings for ingestion from Amazon Kinesis Data Streams.
    awsMsks List<GetTopicIngestionDataSourceSettingAwsMsk>
    Settings for ingestion from Amazon Managed Streaming for Apache Kafka.
    azureEventHubs List<GetTopicIngestionDataSourceSettingAzureEventHub>
    Settings for ingestion from Azure Event Hubs.
    cloudStorages List<GetTopicIngestionDataSourceSettingCloudStorage>
    Settings for ingestion from Cloud Storage.
    confluentClouds List<GetTopicIngestionDataSourceSettingConfluentCloud>
    Settings for ingestion from Confluent Cloud.
    platformLogsSettings List<GetTopicIngestionDataSourceSettingPlatformLogsSetting>
    Settings for Platform Logs regarding ingestion to Pub/Sub. If unset, no Platform Logs will be generated.'
    awsKineses GetTopicIngestionDataSourceSettingAwsKinese[]
    Settings for ingestion from Amazon Kinesis Data Streams.
    awsMsks GetTopicIngestionDataSourceSettingAwsMsk[]
    Settings for ingestion from Amazon Managed Streaming for Apache Kafka.
    azureEventHubs GetTopicIngestionDataSourceSettingAzureEventHub[]
    Settings for ingestion from Azure Event Hubs.
    cloudStorages GetTopicIngestionDataSourceSettingCloudStorage[]
    Settings for ingestion from Cloud Storage.
    confluentClouds GetTopicIngestionDataSourceSettingConfluentCloud[]
    Settings for ingestion from Confluent Cloud.
    platformLogsSettings GetTopicIngestionDataSourceSettingPlatformLogsSetting[]
    Settings for Platform Logs regarding ingestion to Pub/Sub. If unset, no Platform Logs will be generated.'
    aws_kineses Sequence[GetTopicIngestionDataSourceSettingAwsKinese]
    Settings for ingestion from Amazon Kinesis Data Streams.
    aws_msks Sequence[GetTopicIngestionDataSourceSettingAwsMsk]
    Settings for ingestion from Amazon Managed Streaming for Apache Kafka.
    azure_event_hubs Sequence[GetTopicIngestionDataSourceSettingAzureEventHub]
    Settings for ingestion from Azure Event Hubs.
    cloud_storages Sequence[GetTopicIngestionDataSourceSettingCloudStorage]
    Settings for ingestion from Cloud Storage.
    confluent_clouds Sequence[GetTopicIngestionDataSourceSettingConfluentCloud]
    Settings for ingestion from Confluent Cloud.
    platform_logs_settings Sequence[GetTopicIngestionDataSourceSettingPlatformLogsSetting]
    Settings for Platform Logs regarding ingestion to Pub/Sub. If unset, no Platform Logs will be generated.'
    awsKineses List<Property Map>
    Settings for ingestion from Amazon Kinesis Data Streams.
    awsMsks List<Property Map>
    Settings for ingestion from Amazon Managed Streaming for Apache Kafka.
    azureEventHubs List<Property Map>
    Settings for ingestion from Azure Event Hubs.
    cloudStorages List<Property Map>
    Settings for ingestion from Cloud Storage.
    confluentClouds List<Property Map>
    Settings for ingestion from Confluent Cloud.
    platformLogsSettings List<Property Map>
    Settings for Platform Logs regarding ingestion to Pub/Sub. If unset, no Platform Logs will be generated.'

    GetTopicIngestionDataSourceSettingAwsKinese

    AwsRoleArn string
    AWS role ARN to be used for Federated Identity authentication with Kinesis. Check the Pub/Sub docs for how to set up this role and the required permissions that need to be attached to it.
    ConsumerArn string
    The Kinesis consumer ARN to used for ingestion in Enhanced Fan-Out mode. The consumer must be already created and ready to be used.
    GcpServiceAccount string
    The GCP service account to be used for Federated Identity authentication with Kinesis (via a 'AssumeRoleWithWebIdentity' call for the provided role). The 'awsRoleArn' must be set up with 'accounts.google.com:sub' equals to this service account number.
    StreamArn string
    The Kinesis stream ARN to ingest data from.
    AwsRoleArn string
    AWS role ARN to be used for Federated Identity authentication with Kinesis. Check the Pub/Sub docs for how to set up this role and the required permissions that need to be attached to it.
    ConsumerArn string
    The Kinesis consumer ARN to used for ingestion in Enhanced Fan-Out mode. The consumer must be already created and ready to be used.
    GcpServiceAccount string
    The GCP service account to be used for Federated Identity authentication with Kinesis (via a 'AssumeRoleWithWebIdentity' call for the provided role). The 'awsRoleArn' must be set up with 'accounts.google.com:sub' equals to this service account number.
    StreamArn string
    The Kinesis stream ARN to ingest data from.
    awsRoleArn String
    AWS role ARN to be used for Federated Identity authentication with Kinesis. Check the Pub/Sub docs for how to set up this role and the required permissions that need to be attached to it.
    consumerArn String
    The Kinesis consumer ARN to used for ingestion in Enhanced Fan-Out mode. The consumer must be already created and ready to be used.
    gcpServiceAccount String
    The GCP service account to be used for Federated Identity authentication with Kinesis (via a 'AssumeRoleWithWebIdentity' call for the provided role). The 'awsRoleArn' must be set up with 'accounts.google.com:sub' equals to this service account number.
    streamArn String
    The Kinesis stream ARN to ingest data from.
    awsRoleArn string
    AWS role ARN to be used for Federated Identity authentication with Kinesis. Check the Pub/Sub docs for how to set up this role and the required permissions that need to be attached to it.
    consumerArn string
    The Kinesis consumer ARN to used for ingestion in Enhanced Fan-Out mode. The consumer must be already created and ready to be used.
    gcpServiceAccount string
    The GCP service account to be used for Federated Identity authentication with Kinesis (via a 'AssumeRoleWithWebIdentity' call for the provided role). The 'awsRoleArn' must be set up with 'accounts.google.com:sub' equals to this service account number.
    streamArn string
    The Kinesis stream ARN to ingest data from.
    aws_role_arn str
    AWS role ARN to be used for Federated Identity authentication with Kinesis. Check the Pub/Sub docs for how to set up this role and the required permissions that need to be attached to it.
    consumer_arn str
    The Kinesis consumer ARN to used for ingestion in Enhanced Fan-Out mode. The consumer must be already created and ready to be used.
    gcp_service_account str
    The GCP service account to be used for Federated Identity authentication with Kinesis (via a 'AssumeRoleWithWebIdentity' call for the provided role). The 'awsRoleArn' must be set up with 'accounts.google.com:sub' equals to this service account number.
    stream_arn str
    The Kinesis stream ARN to ingest data from.
    awsRoleArn String
    AWS role ARN to be used for Federated Identity authentication with Kinesis. Check the Pub/Sub docs for how to set up this role and the required permissions that need to be attached to it.
    consumerArn String
    The Kinesis consumer ARN to used for ingestion in Enhanced Fan-Out mode. The consumer must be already created and ready to be used.
    gcpServiceAccount String
    The GCP service account to be used for Federated Identity authentication with Kinesis (via a 'AssumeRoleWithWebIdentity' call for the provided role). The 'awsRoleArn' must be set up with 'accounts.google.com:sub' equals to this service account number.
    streamArn String
    The Kinesis stream ARN to ingest data from.

    GetTopicIngestionDataSourceSettingAwsMsk

    AwsRoleArn string
    AWS role ARN to be used for Federated Identity authentication with MSK. Check the Pub/Sub docs for how to set up this role and the required permissions that need to be attached to it.
    ClusterArn string
    ARN that uniquely identifies the MSK cluster.
    GcpServiceAccount string
    The GCP service account to be used for Federated Identity authentication with MSK (via a 'AssumeRoleWithWebIdentity' call for the provided role). The 'awsRoleArn' must be set up with 'accounts.google.com:sub' equals to this service account number.
    Topic string
    The name of the MSK topic that Pub/Sub will import from.
    AwsRoleArn string
    AWS role ARN to be used for Federated Identity authentication with MSK. Check the Pub/Sub docs for how to set up this role and the required permissions that need to be attached to it.
    ClusterArn string
    ARN that uniquely identifies the MSK cluster.
    GcpServiceAccount string
    The GCP service account to be used for Federated Identity authentication with MSK (via a 'AssumeRoleWithWebIdentity' call for the provided role). The 'awsRoleArn' must be set up with 'accounts.google.com:sub' equals to this service account number.
    Topic string
    The name of the MSK topic that Pub/Sub will import from.
    awsRoleArn String
    AWS role ARN to be used for Federated Identity authentication with MSK. Check the Pub/Sub docs for how to set up this role and the required permissions that need to be attached to it.
    clusterArn String
    ARN that uniquely identifies the MSK cluster.
    gcpServiceAccount String
    The GCP service account to be used for Federated Identity authentication with MSK (via a 'AssumeRoleWithWebIdentity' call for the provided role). The 'awsRoleArn' must be set up with 'accounts.google.com:sub' equals to this service account number.
    topic String
    The name of the MSK topic that Pub/Sub will import from.
    awsRoleArn string
    AWS role ARN to be used for Federated Identity authentication with MSK. Check the Pub/Sub docs for how to set up this role and the required permissions that need to be attached to it.
    clusterArn string
    ARN that uniquely identifies the MSK cluster.
    gcpServiceAccount string
    The GCP service account to be used for Federated Identity authentication with MSK (via a 'AssumeRoleWithWebIdentity' call for the provided role). The 'awsRoleArn' must be set up with 'accounts.google.com:sub' equals to this service account number.
    topic string
    The name of the MSK topic that Pub/Sub will import from.
    aws_role_arn str
    AWS role ARN to be used for Federated Identity authentication with MSK. Check the Pub/Sub docs for how to set up this role and the required permissions that need to be attached to it.
    cluster_arn str
    ARN that uniquely identifies the MSK cluster.
    gcp_service_account str
    The GCP service account to be used for Federated Identity authentication with MSK (via a 'AssumeRoleWithWebIdentity' call for the provided role). The 'awsRoleArn' must be set up with 'accounts.google.com:sub' equals to this service account number.
    topic str
    The name of the MSK topic that Pub/Sub will import from.
    awsRoleArn String
    AWS role ARN to be used for Federated Identity authentication with MSK. Check the Pub/Sub docs for how to set up this role and the required permissions that need to be attached to it.
    clusterArn String
    ARN that uniquely identifies the MSK cluster.
    gcpServiceAccount String
    The GCP service account to be used for Federated Identity authentication with MSK (via a 'AssumeRoleWithWebIdentity' call for the provided role). The 'awsRoleArn' must be set up with 'accounts.google.com:sub' equals to this service account number.
    topic String
    The name of the MSK topic that Pub/Sub will import from.

    GetTopicIngestionDataSourceSettingAzureEventHub

    ClientId string
    The Azure event hub client ID to use for ingestion.
    EventHub string
    The Azure event hub to ingest data from.
    GcpServiceAccount string
    The GCP service account to be used for Federated Identity authentication with Azure (via a 'AssumeRoleWithWebIdentity' call for the provided role).
    Namespace string
    The Azure event hub namespace to ingest data from.
    ResourceGroup string
    The name of the resource group within an Azure subscription.
    SubscriptionId string
    The Azure event hub subscription ID to use for ingestion.
    TenantId string
    The Azure event hub tenant ID to use for ingestion.
    ClientId string
    The Azure event hub client ID to use for ingestion.
    EventHub string
    The Azure event hub to ingest data from.
    GcpServiceAccount string
    The GCP service account to be used for Federated Identity authentication with Azure (via a 'AssumeRoleWithWebIdentity' call for the provided role).
    Namespace string
    The Azure event hub namespace to ingest data from.
    ResourceGroup string
    The name of the resource group within an Azure subscription.
    SubscriptionId string
    The Azure event hub subscription ID to use for ingestion.
    TenantId string
    The Azure event hub tenant ID to use for ingestion.
    clientId String
    The Azure event hub client ID to use for ingestion.
    eventHub String
    The Azure event hub to ingest data from.
    gcpServiceAccount String
    The GCP service account to be used for Federated Identity authentication with Azure (via a 'AssumeRoleWithWebIdentity' call for the provided role).
    namespace String
    The Azure event hub namespace to ingest data from.
    resourceGroup String
    The name of the resource group within an Azure subscription.
    subscriptionId String
    The Azure event hub subscription ID to use for ingestion.
    tenantId String
    The Azure event hub tenant ID to use for ingestion.
    clientId string
    The Azure event hub client ID to use for ingestion.
    eventHub string
    The Azure event hub to ingest data from.
    gcpServiceAccount string
    The GCP service account to be used for Federated Identity authentication with Azure (via a 'AssumeRoleWithWebIdentity' call for the provided role).
    namespace string
    The Azure event hub namespace to ingest data from.
    resourceGroup string
    The name of the resource group within an Azure subscription.
    subscriptionId string
    The Azure event hub subscription ID to use for ingestion.
    tenantId string
    The Azure event hub tenant ID to use for ingestion.
    client_id str
    The Azure event hub client ID to use for ingestion.
    event_hub str
    The Azure event hub to ingest data from.
    gcp_service_account str
    The GCP service account to be used for Federated Identity authentication with Azure (via a 'AssumeRoleWithWebIdentity' call for the provided role).
    namespace str
    The Azure event hub namespace to ingest data from.
    resource_group str
    The name of the resource group within an Azure subscription.
    subscription_id str
    The Azure event hub subscription ID to use for ingestion.
    tenant_id str
    The Azure event hub tenant ID to use for ingestion.
    clientId String
    The Azure event hub client ID to use for ingestion.
    eventHub String
    The Azure event hub to ingest data from.
    gcpServiceAccount String
    The GCP service account to be used for Federated Identity authentication with Azure (via a 'AssumeRoleWithWebIdentity' call for the provided role).
    namespace String
    The Azure event hub namespace to ingest data from.
    resourceGroup String
    The name of the resource group within an Azure subscription.
    subscriptionId String
    The Azure event hub subscription ID to use for ingestion.
    tenantId String
    The Azure event hub tenant ID to use for ingestion.

    GetTopicIngestionDataSourceSettingCloudStorage

    AvroFormats List<GetTopicIngestionDataSourceSettingCloudStorageAvroFormat>
    Configuration for reading Cloud Storage data in Avro binary format. The bytes of each object will be set to the 'data' field of a Pub/Sub message.
    Bucket string
    Cloud Storage bucket. The bucket name must be without any prefix like "gs://". See the bucket naming requirements: https://cloud.google.com/storage/docs/buckets#naming.
    MatchGlob string
    Glob pattern used to match objects that will be ingested. If unset, all objects will be ingested. See the supported patterns: https://cloud.google.com/storage/docs/json_api/v1/objects/list#list-objects-and-prefixes-using-glob
    MinimumObjectCreateTime string
    The timestamp set in RFC3339 text format. If set, only objects with a larger or equal timestamp will be ingested. Unset by default, meaning all objects will be ingested.
    PubsubAvroFormats List<GetTopicIngestionDataSourceSettingCloudStoragePubsubAvroFormat>
    Configuration for reading Cloud Storage data written via Cloud Storage subscriptions(See https://cloud.google.com/pubsub/docs/cloudstorage). The data and attributes fields of the originally exported Pub/Sub message will be restored when publishing.
    TextFormats List<GetTopicIngestionDataSourceSettingCloudStorageTextFormat>
    Configuration for reading Cloud Storage data in text format. Each line of text as specified by the delimiter will be set to the 'data' field of a Pub/Sub message.
    AvroFormats []GetTopicIngestionDataSourceSettingCloudStorageAvroFormat
    Configuration for reading Cloud Storage data in Avro binary format. The bytes of each object will be set to the 'data' field of a Pub/Sub message.
    Bucket string
    Cloud Storage bucket. The bucket name must be without any prefix like "gs://". See the bucket naming requirements: https://cloud.google.com/storage/docs/buckets#naming.
    MatchGlob string
    Glob pattern used to match objects that will be ingested. If unset, all objects will be ingested. See the supported patterns: https://cloud.google.com/storage/docs/json_api/v1/objects/list#list-objects-and-prefixes-using-glob
    MinimumObjectCreateTime string
    The timestamp set in RFC3339 text format. If set, only objects with a larger or equal timestamp will be ingested. Unset by default, meaning all objects will be ingested.
    PubsubAvroFormats []GetTopicIngestionDataSourceSettingCloudStoragePubsubAvroFormat
    Configuration for reading Cloud Storage data written via Cloud Storage subscriptions(See https://cloud.google.com/pubsub/docs/cloudstorage). The data and attributes fields of the originally exported Pub/Sub message will be restored when publishing.
    TextFormats []GetTopicIngestionDataSourceSettingCloudStorageTextFormat
    Configuration for reading Cloud Storage data in text format. Each line of text as specified by the delimiter will be set to the 'data' field of a Pub/Sub message.
    avroFormats List<GetTopicIngestionDataSourceSettingCloudStorageAvroFormat>
    Configuration for reading Cloud Storage data in Avro binary format. The bytes of each object will be set to the 'data' field of a Pub/Sub message.
    bucket String
    Cloud Storage bucket. The bucket name must be without any prefix like "gs://". See the bucket naming requirements: https://cloud.google.com/storage/docs/buckets#naming.
    matchGlob String
    Glob pattern used to match objects that will be ingested. If unset, all objects will be ingested. See the supported patterns: https://cloud.google.com/storage/docs/json_api/v1/objects/list#list-objects-and-prefixes-using-glob
    minimumObjectCreateTime String
    The timestamp set in RFC3339 text format. If set, only objects with a larger or equal timestamp will be ingested. Unset by default, meaning all objects will be ingested.
    pubsubAvroFormats List<GetTopicIngestionDataSourceSettingCloudStoragePubsubAvroFormat>
    Configuration for reading Cloud Storage data written via Cloud Storage subscriptions(See https://cloud.google.com/pubsub/docs/cloudstorage). The data and attributes fields of the originally exported Pub/Sub message will be restored when publishing.
    textFormats List<GetTopicIngestionDataSourceSettingCloudStorageTextFormat>
    Configuration for reading Cloud Storage data in text format. Each line of text as specified by the delimiter will be set to the 'data' field of a Pub/Sub message.
    avroFormats GetTopicIngestionDataSourceSettingCloudStorageAvroFormat[]
    Configuration for reading Cloud Storage data in Avro binary format. The bytes of each object will be set to the 'data' field of a Pub/Sub message.
    bucket string
    Cloud Storage bucket. The bucket name must be without any prefix like "gs://". See the bucket naming requirements: https://cloud.google.com/storage/docs/buckets#naming.
    matchGlob string
    Glob pattern used to match objects that will be ingested. If unset, all objects will be ingested. See the supported patterns: https://cloud.google.com/storage/docs/json_api/v1/objects/list#list-objects-and-prefixes-using-glob
    minimumObjectCreateTime string
    The timestamp set in RFC3339 text format. If set, only objects with a larger or equal timestamp will be ingested. Unset by default, meaning all objects will be ingested.
    pubsubAvroFormats GetTopicIngestionDataSourceSettingCloudStoragePubsubAvroFormat[]
    Configuration for reading Cloud Storage data written via Cloud Storage subscriptions(See https://cloud.google.com/pubsub/docs/cloudstorage). The data and attributes fields of the originally exported Pub/Sub message will be restored when publishing.
    textFormats GetTopicIngestionDataSourceSettingCloudStorageTextFormat[]
    Configuration for reading Cloud Storage data in text format. Each line of text as specified by the delimiter will be set to the 'data' field of a Pub/Sub message.
    avro_formats Sequence[GetTopicIngestionDataSourceSettingCloudStorageAvroFormat]
    Configuration for reading Cloud Storage data in Avro binary format. The bytes of each object will be set to the 'data' field of a Pub/Sub message.
    bucket str
    Cloud Storage bucket. The bucket name must be without any prefix like "gs://". See the bucket naming requirements: https://cloud.google.com/storage/docs/buckets#naming.
    match_glob str
    Glob pattern used to match objects that will be ingested. If unset, all objects will be ingested. See the supported patterns: https://cloud.google.com/storage/docs/json_api/v1/objects/list#list-objects-and-prefixes-using-glob
    minimum_object_create_time str
    The timestamp set in RFC3339 text format. If set, only objects with a larger or equal timestamp will be ingested. Unset by default, meaning all objects will be ingested.
    pubsub_avro_formats Sequence[GetTopicIngestionDataSourceSettingCloudStoragePubsubAvroFormat]
    Configuration for reading Cloud Storage data written via Cloud Storage subscriptions(See https://cloud.google.com/pubsub/docs/cloudstorage). The data and attributes fields of the originally exported Pub/Sub message will be restored when publishing.
    text_formats Sequence[GetTopicIngestionDataSourceSettingCloudStorageTextFormat]
    Configuration for reading Cloud Storage data in text format. Each line of text as specified by the delimiter will be set to the 'data' field of a Pub/Sub message.
    avroFormats List<Property Map>
    Configuration for reading Cloud Storage data in Avro binary format. The bytes of each object will be set to the 'data' field of a Pub/Sub message.
    bucket String
    Cloud Storage bucket. The bucket name must be without any prefix like "gs://". See the bucket naming requirements: https://cloud.google.com/storage/docs/buckets#naming.
    matchGlob String
    Glob pattern used to match objects that will be ingested. If unset, all objects will be ingested. See the supported patterns: https://cloud.google.com/storage/docs/json_api/v1/objects/list#list-objects-and-prefixes-using-glob
    minimumObjectCreateTime String
    The timestamp set in RFC3339 text format. If set, only objects with a larger or equal timestamp will be ingested. Unset by default, meaning all objects will be ingested.
    pubsubAvroFormats List<Property Map>
    Configuration for reading Cloud Storage data written via Cloud Storage subscriptions(See https://cloud.google.com/pubsub/docs/cloudstorage). The data and attributes fields of the originally exported Pub/Sub message will be restored when publishing.
    textFormats List<Property Map>
    Configuration for reading Cloud Storage data in text format. Each line of text as specified by the delimiter will be set to the 'data' field of a Pub/Sub message.

    GetTopicIngestionDataSourceSettingCloudStorageTextFormat

    Delimiter string
    The delimiter to use when using the 'text' format. Each line of text as specified by the delimiter will be set to the 'data' field of a Pub/Sub message. When unset, '\n' is used.
    Delimiter string
    The delimiter to use when using the 'text' format. Each line of text as specified by the delimiter will be set to the 'data' field of a Pub/Sub message. When unset, '\n' is used.
    delimiter String
    The delimiter to use when using the 'text' format. Each line of text as specified by the delimiter will be set to the 'data' field of a Pub/Sub message. When unset, '\n' is used.
    delimiter string
    The delimiter to use when using the 'text' format. Each line of text as specified by the delimiter will be set to the 'data' field of a Pub/Sub message. When unset, '\n' is used.
    delimiter str
    The delimiter to use when using the 'text' format. Each line of text as specified by the delimiter will be set to the 'data' field of a Pub/Sub message. When unset, '\n' is used.
    delimiter String
    The delimiter to use when using the 'text' format. Each line of text as specified by the delimiter will be set to the 'data' field of a Pub/Sub message. When unset, '\n' is used.

    GetTopicIngestionDataSourceSettingConfluentCloud

    BootstrapServer string
    The Confluent Cloud bootstrap server. The format is url:port.
    ClusterId string
    The Confluent Cloud cluster ID.
    GcpServiceAccount string
    The GCP service account to be used for Federated Identity authentication with Confluent Cloud.
    IdentityPoolId string
    Identity pool ID to be used for Federated Identity authentication with Confluent Cloud.
    Topic string
    Name of the Confluent Cloud topic that Pub/Sub will import from.
    BootstrapServer string
    The Confluent Cloud bootstrap server. The format is url:port.
    ClusterId string
    The Confluent Cloud cluster ID.
    GcpServiceAccount string
    The GCP service account to be used for Federated Identity authentication with Confluent Cloud.
    IdentityPoolId string
    Identity pool ID to be used for Federated Identity authentication with Confluent Cloud.
    Topic string
    Name of the Confluent Cloud topic that Pub/Sub will import from.
    bootstrapServer String
    The Confluent Cloud bootstrap server. The format is url:port.
    clusterId String
    The Confluent Cloud cluster ID.
    gcpServiceAccount String
    The GCP service account to be used for Federated Identity authentication with Confluent Cloud.
    identityPoolId String
    Identity pool ID to be used for Federated Identity authentication with Confluent Cloud.
    topic String
    Name of the Confluent Cloud topic that Pub/Sub will import from.
    bootstrapServer string
    The Confluent Cloud bootstrap server. The format is url:port.
    clusterId string
    The Confluent Cloud cluster ID.
    gcpServiceAccount string
    The GCP service account to be used for Federated Identity authentication with Confluent Cloud.
    identityPoolId string
    Identity pool ID to be used for Federated Identity authentication with Confluent Cloud.
    topic string
    Name of the Confluent Cloud topic that Pub/Sub will import from.
    bootstrap_server str
    The Confluent Cloud bootstrap server. The format is url:port.
    cluster_id str
    The Confluent Cloud cluster ID.
    gcp_service_account str
    The GCP service account to be used for Federated Identity authentication with Confluent Cloud.
    identity_pool_id str
    Identity pool ID to be used for Federated Identity authentication with Confluent Cloud.
    topic str
    Name of the Confluent Cloud topic that Pub/Sub will import from.
    bootstrapServer String
    The Confluent Cloud bootstrap server. The format is url:port.
    clusterId String
    The Confluent Cloud cluster ID.
    gcpServiceAccount String
    The GCP service account to be used for Federated Identity authentication with Confluent Cloud.
    identityPoolId String
    Identity pool ID to be used for Federated Identity authentication with Confluent Cloud.
    topic String
    Name of the Confluent Cloud topic that Pub/Sub will import from.

    GetTopicIngestionDataSourceSettingPlatformLogsSetting

    Severity string
    The minimum severity level of Platform Logs that will be written. If unspecified, no Platform Logs will be written. Default value: "SEVERITY_UNSPECIFIED" Possible values: ["SEVERITY_UNSPECIFIED", "DISABLED", "DEBUG", "INFO", "WARNING", "ERROR"]
    Severity string
    The minimum severity level of Platform Logs that will be written. If unspecified, no Platform Logs will be written. Default value: "SEVERITY_UNSPECIFIED" Possible values: ["SEVERITY_UNSPECIFIED", "DISABLED", "DEBUG", "INFO", "WARNING", "ERROR"]
    severity String
    The minimum severity level of Platform Logs that will be written. If unspecified, no Platform Logs will be written. Default value: "SEVERITY_UNSPECIFIED" Possible values: ["SEVERITY_UNSPECIFIED", "DISABLED", "DEBUG", "INFO", "WARNING", "ERROR"]
    severity string
    The minimum severity level of Platform Logs that will be written. If unspecified, no Platform Logs will be written. Default value: "SEVERITY_UNSPECIFIED" Possible values: ["SEVERITY_UNSPECIFIED", "DISABLED", "DEBUG", "INFO", "WARNING", "ERROR"]
    severity str
    The minimum severity level of Platform Logs that will be written. If unspecified, no Platform Logs will be written. Default value: "SEVERITY_UNSPECIFIED" Possible values: ["SEVERITY_UNSPECIFIED", "DISABLED", "DEBUG", "INFO", "WARNING", "ERROR"]
    severity String
    The minimum severity level of Platform Logs that will be written. If unspecified, no Platform Logs will be written. Default value: "SEVERITY_UNSPECIFIED" Possible values: ["SEVERITY_UNSPECIFIED", "DISABLED", "DEBUG", "INFO", "WARNING", "ERROR"]

    GetTopicMessageStoragePolicy

    AllowedPersistenceRegions List<string>
    A list of IDs of GCP regions where messages that are published to the topic may be persisted in storage. Messages published by publishers running in non-allowed GCP regions (or running outside of GCP altogether) will be routed for storage in one of the allowed regions. An empty list means that no regions are allowed, and is not a valid configuration.
    EnforceInTransit bool
    If true, 'allowedPersistenceRegions' is also used to enforce in-transit guarantees for messages. That is, Pub/Sub will fail topics.publish operations on this topic and subscribe operations on any subscription attached to this topic in any region that is not in 'allowedPersistenceRegions'.
    AllowedPersistenceRegions []string
    A list of IDs of GCP regions where messages that are published to the topic may be persisted in storage. Messages published by publishers running in non-allowed GCP regions (or running outside of GCP altogether) will be routed for storage in one of the allowed regions. An empty list means that no regions are allowed, and is not a valid configuration.
    EnforceInTransit bool
    If true, 'allowedPersistenceRegions' is also used to enforce in-transit guarantees for messages. That is, Pub/Sub will fail topics.publish operations on this topic and subscribe operations on any subscription attached to this topic in any region that is not in 'allowedPersistenceRegions'.
    allowedPersistenceRegions List<String>
    A list of IDs of GCP regions where messages that are published to the topic may be persisted in storage. Messages published by publishers running in non-allowed GCP regions (or running outside of GCP altogether) will be routed for storage in one of the allowed regions. An empty list means that no regions are allowed, and is not a valid configuration.
    enforceInTransit Boolean
    If true, 'allowedPersistenceRegions' is also used to enforce in-transit guarantees for messages. That is, Pub/Sub will fail topics.publish operations on this topic and subscribe operations on any subscription attached to this topic in any region that is not in 'allowedPersistenceRegions'.
    allowedPersistenceRegions string[]
    A list of IDs of GCP regions where messages that are published to the topic may be persisted in storage. Messages published by publishers running in non-allowed GCP regions (or running outside of GCP altogether) will be routed for storage in one of the allowed regions. An empty list means that no regions are allowed, and is not a valid configuration.
    enforceInTransit boolean
    If true, 'allowedPersistenceRegions' is also used to enforce in-transit guarantees for messages. That is, Pub/Sub will fail topics.publish operations on this topic and subscribe operations on any subscription attached to this topic in any region that is not in 'allowedPersistenceRegions'.
    allowed_persistence_regions Sequence[str]
    A list of IDs of GCP regions where messages that are published to the topic may be persisted in storage. Messages published by publishers running in non-allowed GCP regions (or running outside of GCP altogether) will be routed for storage in one of the allowed regions. An empty list means that no regions are allowed, and is not a valid configuration.
    enforce_in_transit bool
    If true, 'allowedPersistenceRegions' is also used to enforce in-transit guarantees for messages. That is, Pub/Sub will fail topics.publish operations on this topic and subscribe operations on any subscription attached to this topic in any region that is not in 'allowedPersistenceRegions'.
    allowedPersistenceRegions List<String>
    A list of IDs of GCP regions where messages that are published to the topic may be persisted in storage. Messages published by publishers running in non-allowed GCP regions (or running outside of GCP altogether) will be routed for storage in one of the allowed regions. An empty list means that no regions are allowed, and is not a valid configuration.
    enforceInTransit Boolean
    If true, 'allowedPersistenceRegions' is also used to enforce in-transit guarantees for messages. That is, Pub/Sub will fail topics.publish operations on this topic and subscribe operations on any subscription attached to this topic in any region that is not in 'allowedPersistenceRegions'.

    GetTopicSchemaSetting

    Encoding string
    The encoding of messages validated against schema. Default value: "ENCODING_UNSPECIFIED" Possible values: ["ENCODING_UNSPECIFIED", "JSON", "BINARY"]
    Schema string
    The name of the schema that messages published should be validated against. Format is projects/{project}/schemas/{schema}. The value of this field will be deleted-schema if the schema has been deleted.
    Encoding string
    The encoding of messages validated against schema. Default value: "ENCODING_UNSPECIFIED" Possible values: ["ENCODING_UNSPECIFIED", "JSON", "BINARY"]
    Schema string
    The name of the schema that messages published should be validated against. Format is projects/{project}/schemas/{schema}. The value of this field will be deleted-schema if the schema has been deleted.
    encoding String
    The encoding of messages validated against schema. Default value: "ENCODING_UNSPECIFIED" Possible values: ["ENCODING_UNSPECIFIED", "JSON", "BINARY"]
    schema String
    The name of the schema that messages published should be validated against. Format is projects/{project}/schemas/{schema}. The value of this field will be deleted-schema if the schema has been deleted.
    encoding string
    The encoding of messages validated against schema. Default value: "ENCODING_UNSPECIFIED" Possible values: ["ENCODING_UNSPECIFIED", "JSON", "BINARY"]
    schema string
    The name of the schema that messages published should be validated against. Format is projects/{project}/schemas/{schema}. The value of this field will be deleted-schema if the schema has been deleted.
    encoding str
    The encoding of messages validated against schema. Default value: "ENCODING_UNSPECIFIED" Possible values: ["ENCODING_UNSPECIFIED", "JSON", "BINARY"]
    schema str
    The name of the schema that messages published should be validated against. Format is projects/{project}/schemas/{schema}. The value of this field will be deleted-schema if the schema has been deleted.
    encoding String
    The encoding of messages validated against schema. Default value: "ENCODING_UNSPECIFIED" Possible values: ["ENCODING_UNSPECIFIED", "JSON", "BINARY"]
    schema String
    The name of the schema that messages published should be validated against. Format is projects/{project}/schemas/{schema}. The value of this field will be deleted-schema if the schema has been deleted.

    Package Details

    Repository
    Google Cloud (GCP) Classic pulumi/pulumi-gcp
    License
    Apache-2.0
    Notes
    This Pulumi package is based on the google-beta Terraform Provider.
    gcp logo
    Google Cloud v8.23.0 published on Monday, Mar 24, 2025 by Pulumi