Google Cloud v8.21.0 published on Wednesday, Mar 5, 2025 by Pulumi
gcp.pubsub.getTopic
Explore with Pulumi AI
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 dictionaryThe following arguments are supported:
getTopic Result
The following output properties are available:
- EffectiveLabels Dictionary<string, string>
- Id string
- The provider-assigned unique ID for this managed resource.
- IngestionData List<GetSource Settings Topic Ingestion Data Source Setting> 
- KmsKey stringName 
- Labels Dictionary<string, string>
- MessageRetention stringDuration 
- MessageStorage List<GetPolicies Topic Message Storage Policy> 
- Name string
- PulumiLabels Dictionary<string, string>
- SchemaSettings List<GetTopic Schema Setting> 
- Project string
- EffectiveLabels map[string]string
- Id string
- The provider-assigned unique ID for this managed resource.
- IngestionData []GetSource Settings Topic Ingestion Data Source Setting 
- KmsKey stringName 
- Labels map[string]string
- MessageRetention stringDuration 
- MessageStorage []GetPolicies Topic Message Storage Policy 
- Name string
- PulumiLabels map[string]string
- SchemaSettings []GetTopic Schema Setting 
- Project string
- effectiveLabels Map<String,String>
- id String
- The provider-assigned unique ID for this managed resource.
- ingestionData List<GetSource Settings Topic Ingestion Data Source Setting> 
- kmsKey StringName 
- labels Map<String,String>
- messageRetention StringDuration 
- messageStorage List<GetPolicies Topic Message Storage Policy> 
- name String
- pulumiLabels Map<String,String>
- schemaSettings List<GetTopic Schema Setting> 
- project String
- effectiveLabels {[key: string]: string}
- id string
- The provider-assigned unique ID for this managed resource.
- ingestionData GetSource Settings Topic Ingestion Data Source Setting[] 
- kmsKey stringName 
- labels {[key: string]: string}
- messageRetention stringDuration 
- messageStorage GetPolicies Topic Message Storage Policy[] 
- name string
- pulumiLabels {[key: string]: string}
- schemaSettings GetTopic Schema Setting[] 
- project string
- effective_labels Mapping[str, str]
- id str
- The provider-assigned unique ID for this managed resource.
- ingestion_data_ Sequence[Getsource_ settings Topic Ingestion Data Source Setting] 
- kms_key_ strname 
- labels Mapping[str, str]
- message_retention_ strduration 
- message_storage_ Sequence[Getpolicies Topic Message Storage Policy] 
- name str
- pulumi_labels Mapping[str, str]
- schema_settings Sequence[GetTopic Schema Setting] 
- project str
- effectiveLabels Map<String>
- id String
- The provider-assigned unique ID for this managed resource.
- ingestionData List<Property Map>Source Settings 
- kmsKey StringName 
- labels Map<String>
- messageRetention StringDuration 
- messageStorage List<Property Map>Policies 
- name String
- pulumiLabels Map<String>
- schemaSettings List<Property Map>
- project String
Supporting Types
GetTopicIngestionDataSourceSetting     
- AwsKineses List<GetTopic Ingestion Data Source Setting Aws Kinese> 
- Settings for ingestion from Amazon Kinesis Data Streams.
- AwsMsks List<GetTopic Ingestion Data Source Setting Aws Msk> 
- Settings for ingestion from Amazon Managed Streaming for Apache Kafka.
- AzureEvent List<GetHubs Topic Ingestion Data Source Setting Azure Event Hub> 
- Settings for ingestion from Azure Event Hubs.
- CloudStorages List<GetTopic Ingestion Data Source Setting Cloud Storage> 
- Settings for ingestion from Cloud Storage.
- ConfluentClouds List<GetTopic Ingestion Data Source Setting Confluent Cloud> 
- Settings for ingestion from Confluent Cloud.
- PlatformLogs List<GetSettings Topic Ingestion Data Source Setting Platform Logs Setting> 
- Settings for Platform Logs regarding ingestion to Pub/Sub. If unset, no Platform Logs will be generated.'
- AwsKineses []GetTopic Ingestion Data Source Setting Aws Kinese 
- Settings for ingestion from Amazon Kinesis Data Streams.
- AwsMsks []GetTopic Ingestion Data Source Setting Aws Msk 
- Settings for ingestion from Amazon Managed Streaming for Apache Kafka.
- AzureEvent []GetHubs Topic Ingestion Data Source Setting Azure Event Hub 
- Settings for ingestion from Azure Event Hubs.
- CloudStorages []GetTopic Ingestion Data Source Setting Cloud Storage 
- Settings for ingestion from Cloud Storage.
- ConfluentClouds []GetTopic Ingestion Data Source Setting Confluent Cloud 
- Settings for ingestion from Confluent Cloud.
- PlatformLogs []GetSettings Topic Ingestion Data Source Setting Platform Logs Setting 
- Settings for Platform Logs regarding ingestion to Pub/Sub. If unset, no Platform Logs will be generated.'
- awsKineses List<GetTopic Ingestion Data Source Setting Aws Kinese> 
- Settings for ingestion from Amazon Kinesis Data Streams.
- awsMsks List<GetTopic Ingestion Data Source Setting Aws Msk> 
- Settings for ingestion from Amazon Managed Streaming for Apache Kafka.
- azureEvent List<GetHubs Topic Ingestion Data Source Setting Azure Event Hub> 
- Settings for ingestion from Azure Event Hubs.
- cloudStorages List<GetTopic Ingestion Data Source Setting Cloud Storage> 
- Settings for ingestion from Cloud Storage.
- confluentClouds List<GetTopic Ingestion Data Source Setting Confluent Cloud> 
- Settings for ingestion from Confluent Cloud.
- platformLogs List<GetSettings Topic Ingestion Data Source Setting Platform Logs Setting> 
- Settings for Platform Logs regarding ingestion to Pub/Sub. If unset, no Platform Logs will be generated.'
- awsKineses GetTopic Ingestion Data Source Setting Aws Kinese[] 
- Settings for ingestion from Amazon Kinesis Data Streams.
- awsMsks GetTopic Ingestion Data Source Setting Aws Msk[] 
- Settings for ingestion from Amazon Managed Streaming for Apache Kafka.
- azureEvent GetHubs Topic Ingestion Data Source Setting Azure Event Hub[] 
- Settings for ingestion from Azure Event Hubs.
- cloudStorages GetTopic Ingestion Data Source Setting Cloud Storage[] 
- Settings for ingestion from Cloud Storage.
- confluentClouds GetTopic Ingestion Data Source Setting Confluent Cloud[] 
- Settings for ingestion from Confluent Cloud.
- platformLogs GetSettings Topic Ingestion Data Source Setting Platform Logs Setting[] 
- Settings for Platform Logs regarding ingestion to Pub/Sub. If unset, no Platform Logs will be generated.'
- aws_kineses Sequence[GetTopic Ingestion Data Source Setting Aws Kinese] 
- Settings for ingestion from Amazon Kinesis Data Streams.
- aws_msks Sequence[GetTopic Ingestion Data Source Setting Aws Msk] 
- Settings for ingestion from Amazon Managed Streaming for Apache Kafka.
- azure_event_ Sequence[Gethubs Topic Ingestion Data Source Setting Azure Event Hub] 
- Settings for ingestion from Azure Event Hubs.
- cloud_storages Sequence[GetTopic Ingestion Data Source Setting Cloud Storage] 
- Settings for ingestion from Cloud Storage.
- confluent_clouds Sequence[GetTopic Ingestion Data Source Setting Confluent Cloud] 
- Settings for ingestion from Confluent Cloud.
- platform_logs_ Sequence[Getsettings Topic Ingestion Data Source Setting Platform Logs Setting] 
- 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.
- azureEvent List<Property Map>Hubs 
- 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.
- platformLogs List<Property Map>Settings 
- Settings for Platform Logs regarding ingestion to Pub/Sub. If unset, no Platform Logs will be generated.'
GetTopicIngestionDataSourceSettingAwsKinese       
- AwsRole stringArn 
- 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.
- GcpService stringAccount 
- 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.
- AwsRole stringArn 
- 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.
- GcpService stringAccount 
- 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.
- awsRole StringArn 
- 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.
- gcpService StringAccount 
- 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.
- awsRole stringArn 
- 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.
- gcpService stringAccount 
- 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_ strarn 
- 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_ straccount 
- 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.
- awsRole StringArn 
- 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.
- gcpService StringAccount 
- 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       
- AwsRole stringArn 
- 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.
- GcpService stringAccount 
- 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.
- AwsRole stringArn 
- 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.
- GcpService stringAccount 
- 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.
- awsRole StringArn 
- 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.
- gcpService StringAccount 
- 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.
- awsRole stringArn 
- 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.
- gcpService stringAccount 
- 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_ strarn 
- 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_ straccount 
- 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.
- awsRole StringArn 
- 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.
- gcpService StringAccount 
- 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.
- GcpService stringAccount 
- 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.
- GcpService stringAccount 
- 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.
- gcpService StringAccount 
- 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.
- gcpService stringAccount 
- 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_ straccount 
- 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.
- gcpService StringAccount 
- 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<GetTopic Ingestion Data Source Setting Cloud Storage Avro Format> 
- 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
- MinimumObject stringCreate Time 
- 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.
- PubsubAvro List<GetFormats Topic Ingestion Data Source Setting Cloud Storage Pubsub Avro Format> 
- 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<GetTopic Ingestion Data Source Setting Cloud Storage Text Format> 
- 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 []GetTopic Ingestion Data Source Setting Cloud Storage Avro Format 
- 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
- MinimumObject stringCreate Time 
- 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.
- PubsubAvro []GetFormats Topic Ingestion Data Source Setting Cloud Storage Pubsub Avro Format 
- 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 []GetTopic Ingestion Data Source Setting Cloud Storage Text Format 
- 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<GetTopic Ingestion Data Source Setting Cloud Storage Avro Format> 
- 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
- minimumObject StringCreate Time 
- 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.
- pubsubAvro List<GetFormats Topic Ingestion Data Source Setting Cloud Storage Pubsub Avro Format> 
- 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<GetTopic Ingestion Data Source Setting Cloud Storage Text Format> 
- 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 GetTopic Ingestion Data Source Setting Cloud Storage Avro Format[] 
- 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
- minimumObject stringCreate Time 
- 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.
- pubsubAvro GetFormats Topic Ingestion Data Source Setting Cloud Storage Pubsub Avro Format[] 
- 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 GetTopic Ingestion Data Source Setting Cloud Storage Text Format[] 
- 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[GetTopic Ingestion Data Source Setting Cloud Storage Avro Format] 
- 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_ strcreate_ time 
- 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_ Sequence[Getformats Topic Ingestion Data Source Setting Cloud Storage Pubsub Avro Format] 
- 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[GetTopic Ingestion Data Source Setting Cloud Storage Text Format] 
- 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
- minimumObject StringCreate Time 
- 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.
- pubsubAvro List<Property Map>Formats 
- 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.
- GcpService stringAccount 
- The GCP service account to be used for Federated Identity authentication with Confluent Cloud.
- IdentityPool stringId 
- 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.
- GcpService stringAccount 
- The GCP service account to be used for Federated Identity authentication with Confluent Cloud.
- IdentityPool stringId 
- 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.
- gcpService StringAccount 
- The GCP service account to be used for Federated Identity authentication with Confluent Cloud.
- identityPool StringId 
- 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.
- gcpService stringAccount 
- The GCP service account to be used for Federated Identity authentication with Confluent Cloud.
- identityPool stringId 
- 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_ straccount 
- The GCP service account to be used for Federated Identity authentication with Confluent Cloud.
- identity_pool_ strid 
- 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.
- gcpService StringAccount 
- The GCP service account to be used for Federated Identity authentication with Confluent Cloud.
- identityPool StringId 
- 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    
- AllowedPersistence List<string>Regions 
- 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.
- EnforceIn boolTransit 
- 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'.
- AllowedPersistence []stringRegions 
- 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.
- EnforceIn boolTransit 
- 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'.
- allowedPersistence List<String>Regions 
- 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.
- enforceIn BooleanTransit 
- 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'.
- allowedPersistence string[]Regions 
- 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.
- enforceIn booleanTransit 
- 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_ Sequence[str]regions 
- 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_ booltransit 
- 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'.
- allowedPersistence List<String>Regions 
- 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.
- enforceIn BooleanTransit 
- 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-betaTerraform Provider.