1. Packages
  2. Google Cloud (GCP) Classic
  3. API Docs
  4. pubsub
  5. Subscription
Google Cloud Classic v7.20.0 published on Wednesday, Apr 24, 2024 by Pulumi

gcp.pubsub.Subscription

Explore with Pulumi AI

gcp logo
Google Cloud Classic v7.20.0 published on Wednesday, Apr 24, 2024 by Pulumi

    A named resource representing the stream of messages from a single, specific topic, to be delivered to the subscribing application.

    To get more information about Subscription, see:

    Note: You can retrieve the email of the Google Managed Pub/Sub Service Account used for forwarding by using the gcp.projects.ServiceIdentity resource.

    Example Usage

    Pubsub Subscription Push

    import * as pulumi from "@pulumi/pulumi";
    import * as gcp from "@pulumi/gcp";
    
    const example = new gcp.pubsub.Topic("example", {name: "example-topic"});
    const exampleSubscription = new gcp.pubsub.Subscription("example", {
        name: "example-subscription",
        topic: example.id,
        ackDeadlineSeconds: 20,
        labels: {
            foo: "bar",
        },
        pushConfig: {
            pushEndpoint: "https://example.com/push",
            attributes: {
                "x-goog-version": "v1",
            },
        },
    });
    
    import pulumi
    import pulumi_gcp as gcp
    
    example = gcp.pubsub.Topic("example", name="example-topic")
    example_subscription = gcp.pubsub.Subscription("example",
        name="example-subscription",
        topic=example.id,
        ack_deadline_seconds=20,
        labels={
            "foo": "bar",
        },
        push_config=gcp.pubsub.SubscriptionPushConfigArgs(
            push_endpoint="https://example.com/push",
            attributes={
                "x-goog-version": "v1",
            },
        ))
    
    package main
    
    import (
    	"github.com/pulumi/pulumi-gcp/sdk/v7/go/gcp/pubsub"
    	"github.com/pulumi/pulumi/sdk/v3/go/pulumi"
    )
    
    func main() {
    	pulumi.Run(func(ctx *pulumi.Context) error {
    		example, err := pubsub.NewTopic(ctx, "example", &pubsub.TopicArgs{
    			Name: pulumi.String("example-topic"),
    		})
    		if err != nil {
    			return err
    		}
    		_, err = pubsub.NewSubscription(ctx, "example", &pubsub.SubscriptionArgs{
    			Name:               pulumi.String("example-subscription"),
    			Topic:              example.ID(),
    			AckDeadlineSeconds: pulumi.Int(20),
    			Labels: pulumi.StringMap{
    				"foo": pulumi.String("bar"),
    			},
    			PushConfig: &pubsub.SubscriptionPushConfigArgs{
    				PushEndpoint: pulumi.String("https://example.com/push"),
    				Attributes: pulumi.StringMap{
    					"x-goog-version": pulumi.String("v1"),
    				},
    			},
    		})
    		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 example = new Gcp.PubSub.Topic("example", new()
        {
            Name = "example-topic",
        });
    
        var exampleSubscription = new Gcp.PubSub.Subscription("example", new()
        {
            Name = "example-subscription",
            Topic = example.Id,
            AckDeadlineSeconds = 20,
            Labels = 
            {
                { "foo", "bar" },
            },
            PushConfig = new Gcp.PubSub.Inputs.SubscriptionPushConfigArgs
            {
                PushEndpoint = "https://example.com/push",
                Attributes = 
                {
                    { "x-goog-version", "v1" },
                },
            },
        });
    
    });
    
    package generated_program;
    
    import com.pulumi.Context;
    import com.pulumi.Pulumi;
    import com.pulumi.core.Output;
    import com.pulumi.gcp.pubsub.Topic;
    import com.pulumi.gcp.pubsub.TopicArgs;
    import com.pulumi.gcp.pubsub.Subscription;
    import com.pulumi.gcp.pubsub.SubscriptionArgs;
    import com.pulumi.gcp.pubsub.inputs.SubscriptionPushConfigArgs;
    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) {
            var example = new Topic("example", TopicArgs.builder()        
                .name("example-topic")
                .build());
    
            var exampleSubscription = new Subscription("exampleSubscription", SubscriptionArgs.builder()        
                .name("example-subscription")
                .topic(example.id())
                .ackDeadlineSeconds(20)
                .labels(Map.of("foo", "bar"))
                .pushConfig(SubscriptionPushConfigArgs.builder()
                    .pushEndpoint("https://example.com/push")
                    .attributes(Map.of("x-goog-version", "v1"))
                    .build())
                .build());
    
        }
    }
    
    resources:
      example:
        type: gcp:pubsub:Topic
        properties:
          name: example-topic
      exampleSubscription:
        type: gcp:pubsub:Subscription
        name: example
        properties:
          name: example-subscription
          topic: ${example.id}
          ackDeadlineSeconds: 20
          labels:
            foo: bar
          pushConfig:
            pushEndpoint: https://example.com/push
            attributes:
              x-goog-version: v1
    

    Pubsub Subscription Pull

    import * as pulumi from "@pulumi/pulumi";
    import * as gcp from "@pulumi/gcp";
    
    const example = new gcp.pubsub.Topic("example", {name: "example-topic"});
    const exampleSubscription = new gcp.pubsub.Subscription("example", {
        name: "example-subscription",
        topic: example.id,
        labels: {
            foo: "bar",
        },
        messageRetentionDuration: "1200s",
        retainAckedMessages: true,
        ackDeadlineSeconds: 20,
        expirationPolicy: {
            ttl: "300000.5s",
        },
        retryPolicy: {
            minimumBackoff: "10s",
        },
        enableMessageOrdering: false,
    });
    
    import pulumi
    import pulumi_gcp as gcp
    
    example = gcp.pubsub.Topic("example", name="example-topic")
    example_subscription = gcp.pubsub.Subscription("example",
        name="example-subscription",
        topic=example.id,
        labels={
            "foo": "bar",
        },
        message_retention_duration="1200s",
        retain_acked_messages=True,
        ack_deadline_seconds=20,
        expiration_policy=gcp.pubsub.SubscriptionExpirationPolicyArgs(
            ttl="300000.5s",
        ),
        retry_policy=gcp.pubsub.SubscriptionRetryPolicyArgs(
            minimum_backoff="10s",
        ),
        enable_message_ordering=False)
    
    package main
    
    import (
    	"github.com/pulumi/pulumi-gcp/sdk/v7/go/gcp/pubsub"
    	"github.com/pulumi/pulumi/sdk/v3/go/pulumi"
    )
    
    func main() {
    	pulumi.Run(func(ctx *pulumi.Context) error {
    		example, err := pubsub.NewTopic(ctx, "example", &pubsub.TopicArgs{
    			Name: pulumi.String("example-topic"),
    		})
    		if err != nil {
    			return err
    		}
    		_, err = pubsub.NewSubscription(ctx, "example", &pubsub.SubscriptionArgs{
    			Name:  pulumi.String("example-subscription"),
    			Topic: example.ID(),
    			Labels: pulumi.StringMap{
    				"foo": pulumi.String("bar"),
    			},
    			MessageRetentionDuration: pulumi.String("1200s"),
    			RetainAckedMessages:      pulumi.Bool(true),
    			AckDeadlineSeconds:       pulumi.Int(20),
    			ExpirationPolicy: &pubsub.SubscriptionExpirationPolicyArgs{
    				Ttl: pulumi.String("300000.5s"),
    			},
    			RetryPolicy: &pubsub.SubscriptionRetryPolicyArgs{
    				MinimumBackoff: pulumi.String("10s"),
    			},
    			EnableMessageOrdering: pulumi.Bool(false),
    		})
    		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 example = new Gcp.PubSub.Topic("example", new()
        {
            Name = "example-topic",
        });
    
        var exampleSubscription = new Gcp.PubSub.Subscription("example", new()
        {
            Name = "example-subscription",
            Topic = example.Id,
            Labels = 
            {
                { "foo", "bar" },
            },
            MessageRetentionDuration = "1200s",
            RetainAckedMessages = true,
            AckDeadlineSeconds = 20,
            ExpirationPolicy = new Gcp.PubSub.Inputs.SubscriptionExpirationPolicyArgs
            {
                Ttl = "300000.5s",
            },
            RetryPolicy = new Gcp.PubSub.Inputs.SubscriptionRetryPolicyArgs
            {
                MinimumBackoff = "10s",
            },
            EnableMessageOrdering = false,
        });
    
    });
    
    package generated_program;
    
    import com.pulumi.Context;
    import com.pulumi.Pulumi;
    import com.pulumi.core.Output;
    import com.pulumi.gcp.pubsub.Topic;
    import com.pulumi.gcp.pubsub.TopicArgs;
    import com.pulumi.gcp.pubsub.Subscription;
    import com.pulumi.gcp.pubsub.SubscriptionArgs;
    import com.pulumi.gcp.pubsub.inputs.SubscriptionExpirationPolicyArgs;
    import com.pulumi.gcp.pubsub.inputs.SubscriptionRetryPolicyArgs;
    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) {
            var example = new Topic("example", TopicArgs.builder()        
                .name("example-topic")
                .build());
    
            var exampleSubscription = new Subscription("exampleSubscription", SubscriptionArgs.builder()        
                .name("example-subscription")
                .topic(example.id())
                .labels(Map.of("foo", "bar"))
                .messageRetentionDuration("1200s")
                .retainAckedMessages(true)
                .ackDeadlineSeconds(20)
                .expirationPolicy(SubscriptionExpirationPolicyArgs.builder()
                    .ttl("300000.5s")
                    .build())
                .retryPolicy(SubscriptionRetryPolicyArgs.builder()
                    .minimumBackoff("10s")
                    .build())
                .enableMessageOrdering(false)
                .build());
    
        }
    }
    
    resources:
      example:
        type: gcp:pubsub:Topic
        properties:
          name: example-topic
      exampleSubscription:
        type: gcp:pubsub:Subscription
        name: example
        properties:
          name: example-subscription
          topic: ${example.id}
          labels:
            foo: bar
          messageRetentionDuration: 1200s
          retainAckedMessages: true
          ackDeadlineSeconds: 20
          expirationPolicy:
            ttl: 300000.5s
          retryPolicy:
            minimumBackoff: 10s
          enableMessageOrdering: false
    

    Pubsub Subscription Dead Letter

    import * as pulumi from "@pulumi/pulumi";
    import * as gcp from "@pulumi/gcp";
    
    const example = new gcp.pubsub.Topic("example", {name: "example-topic"});
    const exampleDeadLetter = new gcp.pubsub.Topic("example_dead_letter", {name: "example-topic-dead-letter"});
    const exampleSubscription = new gcp.pubsub.Subscription("example", {
        name: "example-subscription",
        topic: example.id,
        deadLetterPolicy: {
            deadLetterTopic: exampleDeadLetter.id,
            maxDeliveryAttempts: 10,
        },
    });
    
    import pulumi
    import pulumi_gcp as gcp
    
    example = gcp.pubsub.Topic("example", name="example-topic")
    example_dead_letter = gcp.pubsub.Topic("example_dead_letter", name="example-topic-dead-letter")
    example_subscription = gcp.pubsub.Subscription("example",
        name="example-subscription",
        topic=example.id,
        dead_letter_policy=gcp.pubsub.SubscriptionDeadLetterPolicyArgs(
            dead_letter_topic=example_dead_letter.id,
            max_delivery_attempts=10,
        ))
    
    package main
    
    import (
    	"github.com/pulumi/pulumi-gcp/sdk/v7/go/gcp/pubsub"
    	"github.com/pulumi/pulumi/sdk/v3/go/pulumi"
    )
    
    func main() {
    	pulumi.Run(func(ctx *pulumi.Context) error {
    		example, err := pubsub.NewTopic(ctx, "example", &pubsub.TopicArgs{
    			Name: pulumi.String("example-topic"),
    		})
    		if err != nil {
    			return err
    		}
    		exampleDeadLetter, err := pubsub.NewTopic(ctx, "example_dead_letter", &pubsub.TopicArgs{
    			Name: pulumi.String("example-topic-dead-letter"),
    		})
    		if err != nil {
    			return err
    		}
    		_, err = pubsub.NewSubscription(ctx, "example", &pubsub.SubscriptionArgs{
    			Name:  pulumi.String("example-subscription"),
    			Topic: example.ID(),
    			DeadLetterPolicy: &pubsub.SubscriptionDeadLetterPolicyArgs{
    				DeadLetterTopic:     exampleDeadLetter.ID(),
    				MaxDeliveryAttempts: pulumi.Int(10),
    			},
    		})
    		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 example = new Gcp.PubSub.Topic("example", new()
        {
            Name = "example-topic",
        });
    
        var exampleDeadLetter = new Gcp.PubSub.Topic("example_dead_letter", new()
        {
            Name = "example-topic-dead-letter",
        });
    
        var exampleSubscription = new Gcp.PubSub.Subscription("example", new()
        {
            Name = "example-subscription",
            Topic = example.Id,
            DeadLetterPolicy = new Gcp.PubSub.Inputs.SubscriptionDeadLetterPolicyArgs
            {
                DeadLetterTopic = exampleDeadLetter.Id,
                MaxDeliveryAttempts = 10,
            },
        });
    
    });
    
    package generated_program;
    
    import com.pulumi.Context;
    import com.pulumi.Pulumi;
    import com.pulumi.core.Output;
    import com.pulumi.gcp.pubsub.Topic;
    import com.pulumi.gcp.pubsub.TopicArgs;
    import com.pulumi.gcp.pubsub.Subscription;
    import com.pulumi.gcp.pubsub.SubscriptionArgs;
    import com.pulumi.gcp.pubsub.inputs.SubscriptionDeadLetterPolicyArgs;
    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) {
            var example = new Topic("example", TopicArgs.builder()        
                .name("example-topic")
                .build());
    
            var exampleDeadLetter = new Topic("exampleDeadLetter", TopicArgs.builder()        
                .name("example-topic-dead-letter")
                .build());
    
            var exampleSubscription = new Subscription("exampleSubscription", SubscriptionArgs.builder()        
                .name("example-subscription")
                .topic(example.id())
                .deadLetterPolicy(SubscriptionDeadLetterPolicyArgs.builder()
                    .deadLetterTopic(exampleDeadLetter.id())
                    .maxDeliveryAttempts(10)
                    .build())
                .build());
    
        }
    }
    
    resources:
      example:
        type: gcp:pubsub:Topic
        properties:
          name: example-topic
      exampleDeadLetter:
        type: gcp:pubsub:Topic
        name: example_dead_letter
        properties:
          name: example-topic-dead-letter
      exampleSubscription:
        type: gcp:pubsub:Subscription
        name: example
        properties:
          name: example-subscription
          topic: ${example.id}
          deadLetterPolicy:
            deadLetterTopic: ${exampleDeadLetter.id}
            maxDeliveryAttempts: 10
    

    Pubsub Subscription Push Bq

    import * as pulumi from "@pulumi/pulumi";
    import * as gcp from "@pulumi/gcp";
    
    const example = new gcp.pubsub.Topic("example", {name: "example-topic"});
    const test = new gcp.bigquery.Dataset("test", {datasetId: "example_dataset"});
    const testTable = new gcp.bigquery.Table("test", {
        deletionProtection: false,
        tableId: "example_table",
        datasetId: test.datasetId,
        schema: `[
      {
        "name": "data",
        "type": "STRING",
        "mode": "NULLABLE",
        "description": "The data"
      }
    ]
    `,
    });
    const exampleSubscription = new gcp.pubsub.Subscription("example", {
        name: "example-subscription",
        topic: example.id,
        bigqueryConfig: {
            table: pulumi.interpolate`${testTable.project}.${testTable.datasetId}.${testTable.tableId}`,
        },
    });
    const project = gcp.organizations.getProject({});
    const viewer = new gcp.projects.IAMMember("viewer", {
        project: project.then(project => project.projectId),
        role: "roles/bigquery.metadataViewer",
        member: project.then(project => `serviceAccount:service-${project.number}@gcp-sa-pubsub.iam.gserviceaccount.com`),
    });
    const editor = new gcp.projects.IAMMember("editor", {
        project: project.then(project => project.projectId),
        role: "roles/bigquery.dataEditor",
        member: project.then(project => `serviceAccount:service-${project.number}@gcp-sa-pubsub.iam.gserviceaccount.com`),
    });
    
    import pulumi
    import pulumi_gcp as gcp
    
    example = gcp.pubsub.Topic("example", name="example-topic")
    test = gcp.bigquery.Dataset("test", dataset_id="example_dataset")
    test_table = gcp.bigquery.Table("test",
        deletion_protection=False,
        table_id="example_table",
        dataset_id=test.dataset_id,
        schema="""[
      {
        "name": "data",
        "type": "STRING",
        "mode": "NULLABLE",
        "description": "The data"
      }
    ]
    """)
    example_subscription = gcp.pubsub.Subscription("example",
        name="example-subscription",
        topic=example.id,
        bigquery_config=gcp.pubsub.SubscriptionBigqueryConfigArgs(
            table=pulumi.Output.all(test_table.project, test_table.dataset_id, test_table.table_id).apply(lambda project, dataset_id, table_id: f"{project}.{dataset_id}.{table_id}"),
        ))
    project = gcp.organizations.get_project()
    viewer = gcp.projects.IAMMember("viewer",
        project=project.project_id,
        role="roles/bigquery.metadataViewer",
        member=f"serviceAccount:service-{project.number}@gcp-sa-pubsub.iam.gserviceaccount.com")
    editor = gcp.projects.IAMMember("editor",
        project=project.project_id,
        role="roles/bigquery.dataEditor",
        member=f"serviceAccount:service-{project.number}@gcp-sa-pubsub.iam.gserviceaccount.com")
    
    package main
    
    import (
    	"fmt"
    
    	"github.com/pulumi/pulumi-gcp/sdk/v7/go/gcp/bigquery"
    	"github.com/pulumi/pulumi-gcp/sdk/v7/go/gcp/organizations"
    	"github.com/pulumi/pulumi-gcp/sdk/v7/go/gcp/projects"
    	"github.com/pulumi/pulumi-gcp/sdk/v7/go/gcp/pubsub"
    	"github.com/pulumi/pulumi/sdk/v3/go/pulumi"
    )
    
    func main() {
    	pulumi.Run(func(ctx *pulumi.Context) error {
    		example, err := pubsub.NewTopic(ctx, "example", &pubsub.TopicArgs{
    			Name: pulumi.String("example-topic"),
    		})
    		if err != nil {
    			return err
    		}
    		test, err := bigquery.NewDataset(ctx, "test", &bigquery.DatasetArgs{
    			DatasetId: pulumi.String("example_dataset"),
    		})
    		if err != nil {
    			return err
    		}
    		testTable, err := bigquery.NewTable(ctx, "test", &bigquery.TableArgs{
    			DeletionProtection: pulumi.Bool(false),
    			TableId:            pulumi.String("example_table"),
    			DatasetId:          test.DatasetId,
    			Schema: pulumi.String(`[
      {
        "name": "data",
        "type": "STRING",
        "mode": "NULLABLE",
        "description": "The data"
      }
    ]
    `),
    		})
    		if err != nil {
    			return err
    		}
    		_, err = pubsub.NewSubscription(ctx, "example", &pubsub.SubscriptionArgs{
    			Name:  pulumi.String("example-subscription"),
    			Topic: example.ID(),
    			BigqueryConfig: &pubsub.SubscriptionBigqueryConfigArgs{
    				Table: pulumi.All(testTable.Project, testTable.DatasetId, testTable.TableId).ApplyT(func(_args []interface{}) (string, error) {
    					project := _args[0].(string)
    					datasetId := _args[1].(string)
    					tableId := _args[2].(string)
    					return fmt.Sprintf("%v.%v.%v", project, datasetId, tableId), nil
    				}).(pulumi.StringOutput),
    			},
    		})
    		if err != nil {
    			return err
    		}
    		project, err := organizations.LookupProject(ctx, nil, nil)
    		if err != nil {
    			return err
    		}
    		_, err = projects.NewIAMMember(ctx, "viewer", &projects.IAMMemberArgs{
    			Project: pulumi.String(project.ProjectId),
    			Role:    pulumi.String("roles/bigquery.metadataViewer"),
    			Member:  pulumi.String(fmt.Sprintf("serviceAccount:service-%v@gcp-sa-pubsub.iam.gserviceaccount.com", project.Number)),
    		})
    		if err != nil {
    			return err
    		}
    		_, err = projects.NewIAMMember(ctx, "editor", &projects.IAMMemberArgs{
    			Project: pulumi.String(project.ProjectId),
    			Role:    pulumi.String("roles/bigquery.dataEditor"),
    			Member:  pulumi.String(fmt.Sprintf("serviceAccount:service-%v@gcp-sa-pubsub.iam.gserviceaccount.com", project.Number)),
    		})
    		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 example = new Gcp.PubSub.Topic("example", new()
        {
            Name = "example-topic",
        });
    
        var test = new Gcp.BigQuery.Dataset("test", new()
        {
            DatasetId = "example_dataset",
        });
    
        var testTable = new Gcp.BigQuery.Table("test", new()
        {
            DeletionProtection = false,
            TableId = "example_table",
            DatasetId = test.DatasetId,
            Schema = @"[
      {
        ""name"": ""data"",
        ""type"": ""STRING"",
        ""mode"": ""NULLABLE"",
        ""description"": ""The data""
      }
    ]
    ",
        });
    
        var exampleSubscription = new Gcp.PubSub.Subscription("example", new()
        {
            Name = "example-subscription",
            Topic = example.Id,
            BigqueryConfig = new Gcp.PubSub.Inputs.SubscriptionBigqueryConfigArgs
            {
                Table = Output.Tuple(testTable.Project, testTable.DatasetId, testTable.TableId).Apply(values =>
                {
                    var project = values.Item1;
                    var datasetId = values.Item2;
                    var tableId = values.Item3;
                    return $"{project}.{datasetId}.{tableId}";
                }),
            },
        });
    
        var project = Gcp.Organizations.GetProject.Invoke();
    
        var viewer = new Gcp.Projects.IAMMember("viewer", new()
        {
            Project = project.Apply(getProjectResult => getProjectResult.ProjectId),
            Role = "roles/bigquery.metadataViewer",
            Member = $"serviceAccount:service-{project.Apply(getProjectResult => getProjectResult.Number)}@gcp-sa-pubsub.iam.gserviceaccount.com",
        });
    
        var editor = new Gcp.Projects.IAMMember("editor", new()
        {
            Project = project.Apply(getProjectResult => getProjectResult.ProjectId),
            Role = "roles/bigquery.dataEditor",
            Member = $"serviceAccount:service-{project.Apply(getProjectResult => getProjectResult.Number)}@gcp-sa-pubsub.iam.gserviceaccount.com",
        });
    
    });
    
    package generated_program;
    
    import com.pulumi.Context;
    import com.pulumi.Pulumi;
    import com.pulumi.core.Output;
    import com.pulumi.gcp.pubsub.Topic;
    import com.pulumi.gcp.pubsub.TopicArgs;
    import com.pulumi.gcp.bigquery.Dataset;
    import com.pulumi.gcp.bigquery.DatasetArgs;
    import com.pulumi.gcp.bigquery.Table;
    import com.pulumi.gcp.bigquery.TableArgs;
    import com.pulumi.gcp.pubsub.Subscription;
    import com.pulumi.gcp.pubsub.SubscriptionArgs;
    import com.pulumi.gcp.pubsub.inputs.SubscriptionBigqueryConfigArgs;
    import com.pulumi.gcp.organizations.OrganizationsFunctions;
    import com.pulumi.gcp.organizations.inputs.GetProjectArgs;
    import com.pulumi.gcp.projects.IAMMember;
    import com.pulumi.gcp.projects.IAMMemberArgs;
    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) {
            var example = new Topic("example", TopicArgs.builder()        
                .name("example-topic")
                .build());
    
            var test = new Dataset("test", DatasetArgs.builder()        
                .datasetId("example_dataset")
                .build());
    
            var testTable = new Table("testTable", TableArgs.builder()        
                .deletionProtection(false)
                .tableId("example_table")
                .datasetId(test.datasetId())
                .schema("""
    [
      {
        "name": "data",
        "type": "STRING",
        "mode": "NULLABLE",
        "description": "The data"
      }
    ]
                """)
                .build());
    
            var exampleSubscription = new Subscription("exampleSubscription", SubscriptionArgs.builder()        
                .name("example-subscription")
                .topic(example.id())
                .bigqueryConfig(SubscriptionBigqueryConfigArgs.builder()
                    .table(Output.tuple(testTable.project(), testTable.datasetId(), testTable.tableId()).applyValue(values -> {
                        var project = values.t1;
                        var datasetId = values.t2;
                        var tableId = values.t3;
                        return String.format("%s.%s.%s", project,datasetId,tableId);
                    }))
                    .build())
                .build());
    
            final var project = OrganizationsFunctions.getProject();
    
            var viewer = new IAMMember("viewer", IAMMemberArgs.builder()        
                .project(project.applyValue(getProjectResult -> getProjectResult.projectId()))
                .role("roles/bigquery.metadataViewer")
                .member(String.format("serviceAccount:service-%s@gcp-sa-pubsub.iam.gserviceaccount.com", project.applyValue(getProjectResult -> getProjectResult.number())))
                .build());
    
            var editor = new IAMMember("editor", IAMMemberArgs.builder()        
                .project(project.applyValue(getProjectResult -> getProjectResult.projectId()))
                .role("roles/bigquery.dataEditor")
                .member(String.format("serviceAccount:service-%s@gcp-sa-pubsub.iam.gserviceaccount.com", project.applyValue(getProjectResult -> getProjectResult.number())))
                .build());
    
        }
    }
    
    resources:
      example:
        type: gcp:pubsub:Topic
        properties:
          name: example-topic
      exampleSubscription:
        type: gcp:pubsub:Subscription
        name: example
        properties:
          name: example-subscription
          topic: ${example.id}
          bigqueryConfig:
            table: ${testTable.project}.${testTable.datasetId}.${testTable.tableId}
      viewer:
        type: gcp:projects:IAMMember
        properties:
          project: ${project.projectId}
          role: roles/bigquery.metadataViewer
          member: serviceAccount:service-${project.number}@gcp-sa-pubsub.iam.gserviceaccount.com
      editor:
        type: gcp:projects:IAMMember
        properties:
          project: ${project.projectId}
          role: roles/bigquery.dataEditor
          member: serviceAccount:service-${project.number}@gcp-sa-pubsub.iam.gserviceaccount.com
      test:
        type: gcp:bigquery:Dataset
        properties:
          datasetId: example_dataset
      testTable:
        type: gcp:bigquery:Table
        name: test
        properties:
          deletionProtection: false
          tableId: example_table
          datasetId: ${test.datasetId}
          schema: |
            [
              {
                "name": "data",
                "type": "STRING",
                "mode": "NULLABLE",
                "description": "The data"
              }
            ]        
    variables:
      project:
        fn::invoke:
          Function: gcp:organizations:getProject
          Arguments: {}
    

    Pubsub Subscription Push Bq Table Schema

    import * as pulumi from "@pulumi/pulumi";
    import * as gcp from "@pulumi/gcp";
    
    const example = new gcp.pubsub.Topic("example", {name: "example-topic"});
    const test = new gcp.bigquery.Dataset("test", {datasetId: "example_dataset"});
    const testTable = new gcp.bigquery.Table("test", {
        deletionProtection: false,
        tableId: "example_table",
        datasetId: test.datasetId,
        schema: `[
      {
        "name": "data",
        "type": "STRING",
        "mode": "NULLABLE",
        "description": "The data"
      }
    ]
    `,
    });
    const exampleSubscription = new gcp.pubsub.Subscription("example", {
        name: "example-subscription",
        topic: example.id,
        bigqueryConfig: {
            table: pulumi.interpolate`${testTable.project}.${testTable.datasetId}.${testTable.tableId}`,
            useTableSchema: true,
        },
    });
    const project = gcp.organizations.getProject({});
    const viewer = new gcp.projects.IAMMember("viewer", {
        project: project.then(project => project.projectId),
        role: "roles/bigquery.metadataViewer",
        member: project.then(project => `serviceAccount:service-${project.number}@gcp-sa-pubsub.iam.gserviceaccount.com`),
    });
    const editor = new gcp.projects.IAMMember("editor", {
        project: project.then(project => project.projectId),
        role: "roles/bigquery.dataEditor",
        member: project.then(project => `serviceAccount:service-${project.number}@gcp-sa-pubsub.iam.gserviceaccount.com`),
    });
    
    import pulumi
    import pulumi_gcp as gcp
    
    example = gcp.pubsub.Topic("example", name="example-topic")
    test = gcp.bigquery.Dataset("test", dataset_id="example_dataset")
    test_table = gcp.bigquery.Table("test",
        deletion_protection=False,
        table_id="example_table",
        dataset_id=test.dataset_id,
        schema="""[
      {
        "name": "data",
        "type": "STRING",
        "mode": "NULLABLE",
        "description": "The data"
      }
    ]
    """)
    example_subscription = gcp.pubsub.Subscription("example",
        name="example-subscription",
        topic=example.id,
        bigquery_config=gcp.pubsub.SubscriptionBigqueryConfigArgs(
            table=pulumi.Output.all(test_table.project, test_table.dataset_id, test_table.table_id).apply(lambda project, dataset_id, table_id: f"{project}.{dataset_id}.{table_id}"),
            use_table_schema=True,
        ))
    project = gcp.organizations.get_project()
    viewer = gcp.projects.IAMMember("viewer",
        project=project.project_id,
        role="roles/bigquery.metadataViewer",
        member=f"serviceAccount:service-{project.number}@gcp-sa-pubsub.iam.gserviceaccount.com")
    editor = gcp.projects.IAMMember("editor",
        project=project.project_id,
        role="roles/bigquery.dataEditor",
        member=f"serviceAccount:service-{project.number}@gcp-sa-pubsub.iam.gserviceaccount.com")
    
    package main
    
    import (
    	"fmt"
    
    	"github.com/pulumi/pulumi-gcp/sdk/v7/go/gcp/bigquery"
    	"github.com/pulumi/pulumi-gcp/sdk/v7/go/gcp/organizations"
    	"github.com/pulumi/pulumi-gcp/sdk/v7/go/gcp/projects"
    	"github.com/pulumi/pulumi-gcp/sdk/v7/go/gcp/pubsub"
    	"github.com/pulumi/pulumi/sdk/v3/go/pulumi"
    )
    
    func main() {
    	pulumi.Run(func(ctx *pulumi.Context) error {
    		example, err := pubsub.NewTopic(ctx, "example", &pubsub.TopicArgs{
    			Name: pulumi.String("example-topic"),
    		})
    		if err != nil {
    			return err
    		}
    		test, err := bigquery.NewDataset(ctx, "test", &bigquery.DatasetArgs{
    			DatasetId: pulumi.String("example_dataset"),
    		})
    		if err != nil {
    			return err
    		}
    		testTable, err := bigquery.NewTable(ctx, "test", &bigquery.TableArgs{
    			DeletionProtection: pulumi.Bool(false),
    			TableId:            pulumi.String("example_table"),
    			DatasetId:          test.DatasetId,
    			Schema: pulumi.String(`[
      {
        "name": "data",
        "type": "STRING",
        "mode": "NULLABLE",
        "description": "The data"
      }
    ]
    `),
    		})
    		if err != nil {
    			return err
    		}
    		_, err = pubsub.NewSubscription(ctx, "example", &pubsub.SubscriptionArgs{
    			Name:  pulumi.String("example-subscription"),
    			Topic: example.ID(),
    			BigqueryConfig: &pubsub.SubscriptionBigqueryConfigArgs{
    				Table: pulumi.All(testTable.Project, testTable.DatasetId, testTable.TableId).ApplyT(func(_args []interface{}) (string, error) {
    					project := _args[0].(string)
    					datasetId := _args[1].(string)
    					tableId := _args[2].(string)
    					return fmt.Sprintf("%v.%v.%v", project, datasetId, tableId), nil
    				}).(pulumi.StringOutput),
    				UseTableSchema: pulumi.Bool(true),
    			},
    		})
    		if err != nil {
    			return err
    		}
    		project, err := organizations.LookupProject(ctx, nil, nil)
    		if err != nil {
    			return err
    		}
    		_, err = projects.NewIAMMember(ctx, "viewer", &projects.IAMMemberArgs{
    			Project: pulumi.String(project.ProjectId),
    			Role:    pulumi.String("roles/bigquery.metadataViewer"),
    			Member:  pulumi.String(fmt.Sprintf("serviceAccount:service-%v@gcp-sa-pubsub.iam.gserviceaccount.com", project.Number)),
    		})
    		if err != nil {
    			return err
    		}
    		_, err = projects.NewIAMMember(ctx, "editor", &projects.IAMMemberArgs{
    			Project: pulumi.String(project.ProjectId),
    			Role:    pulumi.String("roles/bigquery.dataEditor"),
    			Member:  pulumi.String(fmt.Sprintf("serviceAccount:service-%v@gcp-sa-pubsub.iam.gserviceaccount.com", project.Number)),
    		})
    		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 example = new Gcp.PubSub.Topic("example", new()
        {
            Name = "example-topic",
        });
    
        var test = new Gcp.BigQuery.Dataset("test", new()
        {
            DatasetId = "example_dataset",
        });
    
        var testTable = new Gcp.BigQuery.Table("test", new()
        {
            DeletionProtection = false,
            TableId = "example_table",
            DatasetId = test.DatasetId,
            Schema = @"[
      {
        ""name"": ""data"",
        ""type"": ""STRING"",
        ""mode"": ""NULLABLE"",
        ""description"": ""The data""
      }
    ]
    ",
        });
    
        var exampleSubscription = new Gcp.PubSub.Subscription("example", new()
        {
            Name = "example-subscription",
            Topic = example.Id,
            BigqueryConfig = new Gcp.PubSub.Inputs.SubscriptionBigqueryConfigArgs
            {
                Table = Output.Tuple(testTable.Project, testTable.DatasetId, testTable.TableId).Apply(values =>
                {
                    var project = values.Item1;
                    var datasetId = values.Item2;
                    var tableId = values.Item3;
                    return $"{project}.{datasetId}.{tableId}";
                }),
                UseTableSchema = true,
            },
        });
    
        var project = Gcp.Organizations.GetProject.Invoke();
    
        var viewer = new Gcp.Projects.IAMMember("viewer", new()
        {
            Project = project.Apply(getProjectResult => getProjectResult.ProjectId),
            Role = "roles/bigquery.metadataViewer",
            Member = $"serviceAccount:service-{project.Apply(getProjectResult => getProjectResult.Number)}@gcp-sa-pubsub.iam.gserviceaccount.com",
        });
    
        var editor = new Gcp.Projects.IAMMember("editor", new()
        {
            Project = project.Apply(getProjectResult => getProjectResult.ProjectId),
            Role = "roles/bigquery.dataEditor",
            Member = $"serviceAccount:service-{project.Apply(getProjectResult => getProjectResult.Number)}@gcp-sa-pubsub.iam.gserviceaccount.com",
        });
    
    });
    
    package generated_program;
    
    import com.pulumi.Context;
    import com.pulumi.Pulumi;
    import com.pulumi.core.Output;
    import com.pulumi.gcp.pubsub.Topic;
    import com.pulumi.gcp.pubsub.TopicArgs;
    import com.pulumi.gcp.bigquery.Dataset;
    import com.pulumi.gcp.bigquery.DatasetArgs;
    import com.pulumi.gcp.bigquery.Table;
    import com.pulumi.gcp.bigquery.TableArgs;
    import com.pulumi.gcp.pubsub.Subscription;
    import com.pulumi.gcp.pubsub.SubscriptionArgs;
    import com.pulumi.gcp.pubsub.inputs.SubscriptionBigqueryConfigArgs;
    import com.pulumi.gcp.organizations.OrganizationsFunctions;
    import com.pulumi.gcp.organizations.inputs.GetProjectArgs;
    import com.pulumi.gcp.projects.IAMMember;
    import com.pulumi.gcp.projects.IAMMemberArgs;
    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) {
            var example = new Topic("example", TopicArgs.builder()        
                .name("example-topic")
                .build());
    
            var test = new Dataset("test", DatasetArgs.builder()        
                .datasetId("example_dataset")
                .build());
    
            var testTable = new Table("testTable", TableArgs.builder()        
                .deletionProtection(false)
                .tableId("example_table")
                .datasetId(test.datasetId())
                .schema("""
    [
      {
        "name": "data",
        "type": "STRING",
        "mode": "NULLABLE",
        "description": "The data"
      }
    ]
                """)
                .build());
    
            var exampleSubscription = new Subscription("exampleSubscription", SubscriptionArgs.builder()        
                .name("example-subscription")
                .topic(example.id())
                .bigqueryConfig(SubscriptionBigqueryConfigArgs.builder()
                    .table(Output.tuple(testTable.project(), testTable.datasetId(), testTable.tableId()).applyValue(values -> {
                        var project = values.t1;
                        var datasetId = values.t2;
                        var tableId = values.t3;
                        return String.format("%s.%s.%s", project,datasetId,tableId);
                    }))
                    .useTableSchema(true)
                    .build())
                .build());
    
            final var project = OrganizationsFunctions.getProject();
    
            var viewer = new IAMMember("viewer", IAMMemberArgs.builder()        
                .project(project.applyValue(getProjectResult -> getProjectResult.projectId()))
                .role("roles/bigquery.metadataViewer")
                .member(String.format("serviceAccount:service-%s@gcp-sa-pubsub.iam.gserviceaccount.com", project.applyValue(getProjectResult -> getProjectResult.number())))
                .build());
    
            var editor = new IAMMember("editor", IAMMemberArgs.builder()        
                .project(project.applyValue(getProjectResult -> getProjectResult.projectId()))
                .role("roles/bigquery.dataEditor")
                .member(String.format("serviceAccount:service-%s@gcp-sa-pubsub.iam.gserviceaccount.com", project.applyValue(getProjectResult -> getProjectResult.number())))
                .build());
    
        }
    }
    
    resources:
      example:
        type: gcp:pubsub:Topic
        properties:
          name: example-topic
      exampleSubscription:
        type: gcp:pubsub:Subscription
        name: example
        properties:
          name: example-subscription
          topic: ${example.id}
          bigqueryConfig:
            table: ${testTable.project}.${testTable.datasetId}.${testTable.tableId}
            useTableSchema: true
      viewer:
        type: gcp:projects:IAMMember
        properties:
          project: ${project.projectId}
          role: roles/bigquery.metadataViewer
          member: serviceAccount:service-${project.number}@gcp-sa-pubsub.iam.gserviceaccount.com
      editor:
        type: gcp:projects:IAMMember
        properties:
          project: ${project.projectId}
          role: roles/bigquery.dataEditor
          member: serviceAccount:service-${project.number}@gcp-sa-pubsub.iam.gserviceaccount.com
      test:
        type: gcp:bigquery:Dataset
        properties:
          datasetId: example_dataset
      testTable:
        type: gcp:bigquery:Table
        name: test
        properties:
          deletionProtection: false
          tableId: example_table
          datasetId: ${test.datasetId}
          schema: |
            [
              {
                "name": "data",
                "type": "STRING",
                "mode": "NULLABLE",
                "description": "The data"
              }
            ]        
    variables:
      project:
        fn::invoke:
          Function: gcp:organizations:getProject
          Arguments: {}
    

    Pubsub Subscription Push Cloudstorage

    import * as pulumi from "@pulumi/pulumi";
    import * as gcp from "@pulumi/gcp";
    
    const example = new gcp.storage.Bucket("example", {
        name: "example-bucket",
        location: "US",
        uniformBucketLevelAccess: true,
    });
    const exampleTopic = new gcp.pubsub.Topic("example", {name: "example-topic"});
    const exampleSubscription = new gcp.pubsub.Subscription("example", {
        name: "example-subscription",
        topic: exampleTopic.id,
        cloudStorageConfig: {
            bucket: example.name,
            filenamePrefix: "pre-",
            filenameSuffix: "-_2605",
            maxBytes: 1000,
            maxDuration: "300s",
        },
    });
    const project = gcp.organizations.getProject({});
    const admin = new gcp.storage.BucketIAMMember("admin", {
        bucket: example.name,
        role: "roles/storage.admin",
        member: project.then(project => `serviceAccount:service-${project.number}@gcp-sa-pubsub.iam.gserviceaccount.com`),
    });
    
    import pulumi
    import pulumi_gcp as gcp
    
    example = gcp.storage.Bucket("example",
        name="example-bucket",
        location="US",
        uniform_bucket_level_access=True)
    example_topic = gcp.pubsub.Topic("example", name="example-topic")
    example_subscription = gcp.pubsub.Subscription("example",
        name="example-subscription",
        topic=example_topic.id,
        cloud_storage_config=gcp.pubsub.SubscriptionCloudStorageConfigArgs(
            bucket=example.name,
            filename_prefix="pre-",
            filename_suffix="-_2605",
            max_bytes=1000,
            max_duration="300s",
        ))
    project = gcp.organizations.get_project()
    admin = gcp.storage.BucketIAMMember("admin",
        bucket=example.name,
        role="roles/storage.admin",
        member=f"serviceAccount:service-{project.number}@gcp-sa-pubsub.iam.gserviceaccount.com")
    
    package main
    
    import (
    	"fmt"
    
    	"github.com/pulumi/pulumi-gcp/sdk/v7/go/gcp/organizations"
    	"github.com/pulumi/pulumi-gcp/sdk/v7/go/gcp/pubsub"
    	"github.com/pulumi/pulumi-gcp/sdk/v7/go/gcp/storage"
    	"github.com/pulumi/pulumi/sdk/v3/go/pulumi"
    )
    
    func main() {
    	pulumi.Run(func(ctx *pulumi.Context) error {
    		example, err := storage.NewBucket(ctx, "example", &storage.BucketArgs{
    			Name:                     pulumi.String("example-bucket"),
    			Location:                 pulumi.String("US"),
    			UniformBucketLevelAccess: pulumi.Bool(true),
    		})
    		if err != nil {
    			return err
    		}
    		exampleTopic, err := pubsub.NewTopic(ctx, "example", &pubsub.TopicArgs{
    			Name: pulumi.String("example-topic"),
    		})
    		if err != nil {
    			return err
    		}
    		_, err = pubsub.NewSubscription(ctx, "example", &pubsub.SubscriptionArgs{
    			Name:  pulumi.String("example-subscription"),
    			Topic: exampleTopic.ID(),
    			CloudStorageConfig: &pubsub.SubscriptionCloudStorageConfigArgs{
    				Bucket:         example.Name,
    				FilenamePrefix: pulumi.String("pre-"),
    				FilenameSuffix: pulumi.String("-_2605"),
    				MaxBytes:       pulumi.Int(1000),
    				MaxDuration:    pulumi.String("300s"),
    			},
    		})
    		if err != nil {
    			return err
    		}
    		project, err := organizations.LookupProject(ctx, nil, nil)
    		if err != nil {
    			return err
    		}
    		_, err = storage.NewBucketIAMMember(ctx, "admin", &storage.BucketIAMMemberArgs{
    			Bucket: example.Name,
    			Role:   pulumi.String("roles/storage.admin"),
    			Member: pulumi.String(fmt.Sprintf("serviceAccount:service-%v@gcp-sa-pubsub.iam.gserviceaccount.com", project.Number)),
    		})
    		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 example = new Gcp.Storage.Bucket("example", new()
        {
            Name = "example-bucket",
            Location = "US",
            UniformBucketLevelAccess = true,
        });
    
        var exampleTopic = new Gcp.PubSub.Topic("example", new()
        {
            Name = "example-topic",
        });
    
        var exampleSubscription = new Gcp.PubSub.Subscription("example", new()
        {
            Name = "example-subscription",
            Topic = exampleTopic.Id,
            CloudStorageConfig = new Gcp.PubSub.Inputs.SubscriptionCloudStorageConfigArgs
            {
                Bucket = example.Name,
                FilenamePrefix = "pre-",
                FilenameSuffix = "-_2605",
                MaxBytes = 1000,
                MaxDuration = "300s",
            },
        });
    
        var project = Gcp.Organizations.GetProject.Invoke();
    
        var admin = new Gcp.Storage.BucketIAMMember("admin", new()
        {
            Bucket = example.Name,
            Role = "roles/storage.admin",
            Member = $"serviceAccount:service-{project.Apply(getProjectResult => getProjectResult.Number)}@gcp-sa-pubsub.iam.gserviceaccount.com",
        });
    
    });
    
    package generated_program;
    
    import com.pulumi.Context;
    import com.pulumi.Pulumi;
    import com.pulumi.core.Output;
    import com.pulumi.gcp.storage.Bucket;
    import com.pulumi.gcp.storage.BucketArgs;
    import com.pulumi.gcp.pubsub.Topic;
    import com.pulumi.gcp.pubsub.TopicArgs;
    import com.pulumi.gcp.pubsub.Subscription;
    import com.pulumi.gcp.pubsub.SubscriptionArgs;
    import com.pulumi.gcp.pubsub.inputs.SubscriptionCloudStorageConfigArgs;
    import com.pulumi.gcp.organizations.OrganizationsFunctions;
    import com.pulumi.gcp.organizations.inputs.GetProjectArgs;
    import com.pulumi.gcp.storage.BucketIAMMember;
    import com.pulumi.gcp.storage.BucketIAMMemberArgs;
    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) {
            var example = new Bucket("example", BucketArgs.builder()        
                .name("example-bucket")
                .location("US")
                .uniformBucketLevelAccess(true)
                .build());
    
            var exampleTopic = new Topic("exampleTopic", TopicArgs.builder()        
                .name("example-topic")
                .build());
    
            var exampleSubscription = new Subscription("exampleSubscription", SubscriptionArgs.builder()        
                .name("example-subscription")
                .topic(exampleTopic.id())
                .cloudStorageConfig(SubscriptionCloudStorageConfigArgs.builder()
                    .bucket(example.name())
                    .filenamePrefix("pre-")
                    .filenameSuffix("-_2605")
                    .maxBytes(1000)
                    .maxDuration("300s")
                    .build())
                .build());
    
            final var project = OrganizationsFunctions.getProject();
    
            var admin = new BucketIAMMember("admin", BucketIAMMemberArgs.builder()        
                .bucket(example.name())
                .role("roles/storage.admin")
                .member(String.format("serviceAccount:service-%s@gcp-sa-pubsub.iam.gserviceaccount.com", project.applyValue(getProjectResult -> getProjectResult.number())))
                .build());
    
        }
    }
    
    resources:
      example:
        type: gcp:storage:Bucket
        properties:
          name: example-bucket
          location: US
          uniformBucketLevelAccess: true
      exampleTopic:
        type: gcp:pubsub:Topic
        name: example
        properties:
          name: example-topic
      exampleSubscription:
        type: gcp:pubsub:Subscription
        name: example
        properties:
          name: example-subscription
          topic: ${exampleTopic.id}
          cloudStorageConfig:
            bucket: ${example.name}
            filenamePrefix: pre-
            filenameSuffix: -_2605
            maxBytes: 1000
            maxDuration: 300s
      admin:
        type: gcp:storage:BucketIAMMember
        properties:
          bucket: ${example.name}
          role: roles/storage.admin
          member: serviceAccount:service-${project.number}@gcp-sa-pubsub.iam.gserviceaccount.com
    variables:
      project:
        fn::invoke:
          Function: gcp:organizations:getProject
          Arguments: {}
    

    Pubsub Subscription Push Cloudstorage Avro

    import * as pulumi from "@pulumi/pulumi";
    import * as gcp from "@pulumi/gcp";
    
    const example = new gcp.storage.Bucket("example", {
        name: "example-bucket",
        location: "US",
        uniformBucketLevelAccess: true,
    });
    const exampleTopic = new gcp.pubsub.Topic("example", {name: "example-topic"});
    const exampleSubscription = new gcp.pubsub.Subscription("example", {
        name: "example-subscription",
        topic: exampleTopic.id,
        cloudStorageConfig: {
            bucket: example.name,
            filenamePrefix: "pre-",
            filenameSuffix: "-_34535",
            maxBytes: 1000,
            maxDuration: "300s",
            avroConfig: {
                writeMetadata: true,
            },
        },
    });
    const project = gcp.organizations.getProject({});
    const admin = new gcp.storage.BucketIAMMember("admin", {
        bucket: example.name,
        role: "roles/storage.admin",
        member: project.then(project => `serviceAccount:service-${project.number}@gcp-sa-pubsub.iam.gserviceaccount.com`),
    });
    
    import pulumi
    import pulumi_gcp as gcp
    
    example = gcp.storage.Bucket("example",
        name="example-bucket",
        location="US",
        uniform_bucket_level_access=True)
    example_topic = gcp.pubsub.Topic("example", name="example-topic")
    example_subscription = gcp.pubsub.Subscription("example",
        name="example-subscription",
        topic=example_topic.id,
        cloud_storage_config=gcp.pubsub.SubscriptionCloudStorageConfigArgs(
            bucket=example.name,
            filename_prefix="pre-",
            filename_suffix="-_34535",
            max_bytes=1000,
            max_duration="300s",
            avro_config=gcp.pubsub.SubscriptionCloudStorageConfigAvroConfigArgs(
                write_metadata=True,
            ),
        ))
    project = gcp.organizations.get_project()
    admin = gcp.storage.BucketIAMMember("admin",
        bucket=example.name,
        role="roles/storage.admin",
        member=f"serviceAccount:service-{project.number}@gcp-sa-pubsub.iam.gserviceaccount.com")
    
    package main
    
    import (
    	"fmt"
    
    	"github.com/pulumi/pulumi-gcp/sdk/v7/go/gcp/organizations"
    	"github.com/pulumi/pulumi-gcp/sdk/v7/go/gcp/pubsub"
    	"github.com/pulumi/pulumi-gcp/sdk/v7/go/gcp/storage"
    	"github.com/pulumi/pulumi/sdk/v3/go/pulumi"
    )
    
    func main() {
    	pulumi.Run(func(ctx *pulumi.Context) error {
    		example, err := storage.NewBucket(ctx, "example", &storage.BucketArgs{
    			Name:                     pulumi.String("example-bucket"),
    			Location:                 pulumi.String("US"),
    			UniformBucketLevelAccess: pulumi.Bool(true),
    		})
    		if err != nil {
    			return err
    		}
    		exampleTopic, err := pubsub.NewTopic(ctx, "example", &pubsub.TopicArgs{
    			Name: pulumi.String("example-topic"),
    		})
    		if err != nil {
    			return err
    		}
    		_, err = pubsub.NewSubscription(ctx, "example", &pubsub.SubscriptionArgs{
    			Name:  pulumi.String("example-subscription"),
    			Topic: exampleTopic.ID(),
    			CloudStorageConfig: &pubsub.SubscriptionCloudStorageConfigArgs{
    				Bucket:         example.Name,
    				FilenamePrefix: pulumi.String("pre-"),
    				FilenameSuffix: pulumi.String("-_34535"),
    				MaxBytes:       pulumi.Int(1000),
    				MaxDuration:    pulumi.String("300s"),
    				AvroConfig: &pubsub.SubscriptionCloudStorageConfigAvroConfigArgs{
    					WriteMetadata: pulumi.Bool(true),
    				},
    			},
    		})
    		if err != nil {
    			return err
    		}
    		project, err := organizations.LookupProject(ctx, nil, nil)
    		if err != nil {
    			return err
    		}
    		_, err = storage.NewBucketIAMMember(ctx, "admin", &storage.BucketIAMMemberArgs{
    			Bucket: example.Name,
    			Role:   pulumi.String("roles/storage.admin"),
    			Member: pulumi.String(fmt.Sprintf("serviceAccount:service-%v@gcp-sa-pubsub.iam.gserviceaccount.com", project.Number)),
    		})
    		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 example = new Gcp.Storage.Bucket("example", new()
        {
            Name = "example-bucket",
            Location = "US",
            UniformBucketLevelAccess = true,
        });
    
        var exampleTopic = new Gcp.PubSub.Topic("example", new()
        {
            Name = "example-topic",
        });
    
        var exampleSubscription = new Gcp.PubSub.Subscription("example", new()
        {
            Name = "example-subscription",
            Topic = exampleTopic.Id,
            CloudStorageConfig = new Gcp.PubSub.Inputs.SubscriptionCloudStorageConfigArgs
            {
                Bucket = example.Name,
                FilenamePrefix = "pre-",
                FilenameSuffix = "-_34535",
                MaxBytes = 1000,
                MaxDuration = "300s",
                AvroConfig = new Gcp.PubSub.Inputs.SubscriptionCloudStorageConfigAvroConfigArgs
                {
                    WriteMetadata = true,
                },
            },
        });
    
        var project = Gcp.Organizations.GetProject.Invoke();
    
        var admin = new Gcp.Storage.BucketIAMMember("admin", new()
        {
            Bucket = example.Name,
            Role = "roles/storage.admin",
            Member = $"serviceAccount:service-{project.Apply(getProjectResult => getProjectResult.Number)}@gcp-sa-pubsub.iam.gserviceaccount.com",
        });
    
    });
    
    package generated_program;
    
    import com.pulumi.Context;
    import com.pulumi.Pulumi;
    import com.pulumi.core.Output;
    import com.pulumi.gcp.storage.Bucket;
    import com.pulumi.gcp.storage.BucketArgs;
    import com.pulumi.gcp.pubsub.Topic;
    import com.pulumi.gcp.pubsub.TopicArgs;
    import com.pulumi.gcp.pubsub.Subscription;
    import com.pulumi.gcp.pubsub.SubscriptionArgs;
    import com.pulumi.gcp.pubsub.inputs.SubscriptionCloudStorageConfigArgs;
    import com.pulumi.gcp.pubsub.inputs.SubscriptionCloudStorageConfigAvroConfigArgs;
    import com.pulumi.gcp.organizations.OrganizationsFunctions;
    import com.pulumi.gcp.organizations.inputs.GetProjectArgs;
    import com.pulumi.gcp.storage.BucketIAMMember;
    import com.pulumi.gcp.storage.BucketIAMMemberArgs;
    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) {
            var example = new Bucket("example", BucketArgs.builder()        
                .name("example-bucket")
                .location("US")
                .uniformBucketLevelAccess(true)
                .build());
    
            var exampleTopic = new Topic("exampleTopic", TopicArgs.builder()        
                .name("example-topic")
                .build());
    
            var exampleSubscription = new Subscription("exampleSubscription", SubscriptionArgs.builder()        
                .name("example-subscription")
                .topic(exampleTopic.id())
                .cloudStorageConfig(SubscriptionCloudStorageConfigArgs.builder()
                    .bucket(example.name())
                    .filenamePrefix("pre-")
                    .filenameSuffix("-_34535")
                    .maxBytes(1000)
                    .maxDuration("300s")
                    .avroConfig(SubscriptionCloudStorageConfigAvroConfigArgs.builder()
                        .writeMetadata(true)
                        .build())
                    .build())
                .build());
    
            final var project = OrganizationsFunctions.getProject();
    
            var admin = new BucketIAMMember("admin", BucketIAMMemberArgs.builder()        
                .bucket(example.name())
                .role("roles/storage.admin")
                .member(String.format("serviceAccount:service-%s@gcp-sa-pubsub.iam.gserviceaccount.com", project.applyValue(getProjectResult -> getProjectResult.number())))
                .build());
    
        }
    }
    
    resources:
      example:
        type: gcp:storage:Bucket
        properties:
          name: example-bucket
          location: US
          uniformBucketLevelAccess: true
      exampleTopic:
        type: gcp:pubsub:Topic
        name: example
        properties:
          name: example-topic
      exampleSubscription:
        type: gcp:pubsub:Subscription
        name: example
        properties:
          name: example-subscription
          topic: ${exampleTopic.id}
          cloudStorageConfig:
            bucket: ${example.name}
            filenamePrefix: pre-
            filenameSuffix: -_34535
            maxBytes: 1000
            maxDuration: 300s
            avroConfig:
              writeMetadata: true
      admin:
        type: gcp:storage:BucketIAMMember
        properties:
          bucket: ${example.name}
          role: roles/storage.admin
          member: serviceAccount:service-${project.number}@gcp-sa-pubsub.iam.gserviceaccount.com
    variables:
      project:
        fn::invoke:
          Function: gcp:organizations:getProject
          Arguments: {}
    

    Create Subscription Resource

    Resources are created with functions called constructors. To learn more about declaring and configuring resources, see Resources.

    Constructor syntax

    new Subscription(name: string, args: SubscriptionArgs, opts?: CustomResourceOptions);
    @overload
    def Subscription(resource_name: str,
                     args: SubscriptionArgs,
                     opts: Optional[ResourceOptions] = None)
    
    @overload
    def Subscription(resource_name: str,
                     opts: Optional[ResourceOptions] = None,
                     topic: Optional[str] = None,
                     labels: Optional[Mapping[str, str]] = None,
                     message_retention_duration: Optional[str] = None,
                     dead_letter_policy: Optional[SubscriptionDeadLetterPolicyArgs] = None,
                     enable_exactly_once_delivery: Optional[bool] = None,
                     enable_message_ordering: Optional[bool] = None,
                     expiration_policy: Optional[SubscriptionExpirationPolicyArgs] = None,
                     cloud_storage_config: Optional[SubscriptionCloudStorageConfigArgs] = None,
                     ack_deadline_seconds: Optional[int] = None,
                     filter: Optional[str] = None,
                     name: Optional[str] = None,
                     project: Optional[str] = None,
                     push_config: Optional[SubscriptionPushConfigArgs] = None,
                     retain_acked_messages: Optional[bool] = None,
                     retry_policy: Optional[SubscriptionRetryPolicyArgs] = None,
                     bigquery_config: Optional[SubscriptionBigqueryConfigArgs] = None)
    func NewSubscription(ctx *Context, name string, args SubscriptionArgs, opts ...ResourceOption) (*Subscription, error)
    public Subscription(string name, SubscriptionArgs args, CustomResourceOptions? opts = null)
    public Subscription(String name, SubscriptionArgs args)
    public Subscription(String name, SubscriptionArgs args, CustomResourceOptions options)
    
    type: gcp:pubsub:Subscription
    properties: # The arguments to resource properties.
    options: # Bag of options to control resource's behavior.
    
    

    Parameters

    name string
    The unique name of the resource.
    args SubscriptionArgs
    The arguments to resource properties.
    opts CustomResourceOptions
    Bag of options to control resource's behavior.
    resource_name str
    The unique name of the resource.
    args SubscriptionArgs
    The arguments to resource properties.
    opts ResourceOptions
    Bag of options to control resource's behavior.
    ctx Context
    Context object for the current deployment.
    name string
    The unique name of the resource.
    args SubscriptionArgs
    The arguments to resource properties.
    opts ResourceOption
    Bag of options to control resource's behavior.
    name string
    The unique name of the resource.
    args SubscriptionArgs
    The arguments to resource properties.
    opts CustomResourceOptions
    Bag of options to control resource's behavior.
    name String
    The unique name of the resource.
    args SubscriptionArgs
    The arguments to resource properties.
    options CustomResourceOptions
    Bag of options to control resource's behavior.

    Example

    The following reference example uses placeholder values for all input properties.

    var subscriptionResource = new Gcp.PubSub.Subscription("subscriptionResource", new()
    {
        Topic = "string",
        Labels = 
        {
            { "string", "string" },
        },
        MessageRetentionDuration = "string",
        DeadLetterPolicy = new Gcp.PubSub.Inputs.SubscriptionDeadLetterPolicyArgs
        {
            DeadLetterTopic = "string",
            MaxDeliveryAttempts = 0,
        },
        EnableExactlyOnceDelivery = false,
        EnableMessageOrdering = false,
        ExpirationPolicy = new Gcp.PubSub.Inputs.SubscriptionExpirationPolicyArgs
        {
            Ttl = "string",
        },
        CloudStorageConfig = new Gcp.PubSub.Inputs.SubscriptionCloudStorageConfigArgs
        {
            Bucket = "string",
            AvroConfig = new Gcp.PubSub.Inputs.SubscriptionCloudStorageConfigAvroConfigArgs
            {
                WriteMetadata = false,
            },
            FilenamePrefix = "string",
            FilenameSuffix = "string",
            MaxBytes = 0,
            MaxDuration = "string",
            State = "string",
        },
        AckDeadlineSeconds = 0,
        Filter = "string",
        Name = "string",
        Project = "string",
        PushConfig = new Gcp.PubSub.Inputs.SubscriptionPushConfigArgs
        {
            PushEndpoint = "string",
            Attributes = 
            {
                { "string", "string" },
            },
            NoWrapper = new Gcp.PubSub.Inputs.SubscriptionPushConfigNoWrapperArgs
            {
                WriteMetadata = false,
            },
            OidcToken = new Gcp.PubSub.Inputs.SubscriptionPushConfigOidcTokenArgs
            {
                ServiceAccountEmail = "string",
                Audience = "string",
            },
        },
        RetainAckedMessages = false,
        RetryPolicy = new Gcp.PubSub.Inputs.SubscriptionRetryPolicyArgs
        {
            MaximumBackoff = "string",
            MinimumBackoff = "string",
        },
        BigqueryConfig = new Gcp.PubSub.Inputs.SubscriptionBigqueryConfigArgs
        {
            Table = "string",
            DropUnknownFields = false,
            UseTableSchema = false,
            UseTopicSchema = false,
            WriteMetadata = false,
        },
    });
    
    example, err := pubsub.NewSubscription(ctx, "subscriptionResource", &pubsub.SubscriptionArgs{
    	Topic: pulumi.String("string"),
    	Labels: pulumi.StringMap{
    		"string": pulumi.String("string"),
    	},
    	MessageRetentionDuration: pulumi.String("string"),
    	DeadLetterPolicy: &pubsub.SubscriptionDeadLetterPolicyArgs{
    		DeadLetterTopic:     pulumi.String("string"),
    		MaxDeliveryAttempts: pulumi.Int(0),
    	},
    	EnableExactlyOnceDelivery: pulumi.Bool(false),
    	EnableMessageOrdering:     pulumi.Bool(false),
    	ExpirationPolicy: &pubsub.SubscriptionExpirationPolicyArgs{
    		Ttl: pulumi.String("string"),
    	},
    	CloudStorageConfig: &pubsub.SubscriptionCloudStorageConfigArgs{
    		Bucket: pulumi.String("string"),
    		AvroConfig: &pubsub.SubscriptionCloudStorageConfigAvroConfigArgs{
    			WriteMetadata: pulumi.Bool(false),
    		},
    		FilenamePrefix: pulumi.String("string"),
    		FilenameSuffix: pulumi.String("string"),
    		MaxBytes:       pulumi.Int(0),
    		MaxDuration:    pulumi.String("string"),
    		State:          pulumi.String("string"),
    	},
    	AckDeadlineSeconds: pulumi.Int(0),
    	Filter:             pulumi.String("string"),
    	Name:               pulumi.String("string"),
    	Project:            pulumi.String("string"),
    	PushConfig: &pubsub.SubscriptionPushConfigArgs{
    		PushEndpoint: pulumi.String("string"),
    		Attributes: pulumi.StringMap{
    			"string": pulumi.String("string"),
    		},
    		NoWrapper: &pubsub.SubscriptionPushConfigNoWrapperArgs{
    			WriteMetadata: pulumi.Bool(false),
    		},
    		OidcToken: &pubsub.SubscriptionPushConfigOidcTokenArgs{
    			ServiceAccountEmail: pulumi.String("string"),
    			Audience:            pulumi.String("string"),
    		},
    	},
    	RetainAckedMessages: pulumi.Bool(false),
    	RetryPolicy: &pubsub.SubscriptionRetryPolicyArgs{
    		MaximumBackoff: pulumi.String("string"),
    		MinimumBackoff: pulumi.String("string"),
    	},
    	BigqueryConfig: &pubsub.SubscriptionBigqueryConfigArgs{
    		Table:             pulumi.String("string"),
    		DropUnknownFields: pulumi.Bool(false),
    		UseTableSchema:    pulumi.Bool(false),
    		UseTopicSchema:    pulumi.Bool(false),
    		WriteMetadata:     pulumi.Bool(false),
    	},
    })
    
    var subscriptionResource = new Subscription("subscriptionResource", SubscriptionArgs.builder()        
        .topic("string")
        .labels(Map.of("string", "string"))
        .messageRetentionDuration("string")
        .deadLetterPolicy(SubscriptionDeadLetterPolicyArgs.builder()
            .deadLetterTopic("string")
            .maxDeliveryAttempts(0)
            .build())
        .enableExactlyOnceDelivery(false)
        .enableMessageOrdering(false)
        .expirationPolicy(SubscriptionExpirationPolicyArgs.builder()
            .ttl("string")
            .build())
        .cloudStorageConfig(SubscriptionCloudStorageConfigArgs.builder()
            .bucket("string")
            .avroConfig(SubscriptionCloudStorageConfigAvroConfigArgs.builder()
                .writeMetadata(false)
                .build())
            .filenamePrefix("string")
            .filenameSuffix("string")
            .maxBytes(0)
            .maxDuration("string")
            .state("string")
            .build())
        .ackDeadlineSeconds(0)
        .filter("string")
        .name("string")
        .project("string")
        .pushConfig(SubscriptionPushConfigArgs.builder()
            .pushEndpoint("string")
            .attributes(Map.of("string", "string"))
            .noWrapper(SubscriptionPushConfigNoWrapperArgs.builder()
                .writeMetadata(false)
                .build())
            .oidcToken(SubscriptionPushConfigOidcTokenArgs.builder()
                .serviceAccountEmail("string")
                .audience("string")
                .build())
            .build())
        .retainAckedMessages(false)
        .retryPolicy(SubscriptionRetryPolicyArgs.builder()
            .maximumBackoff("string")
            .minimumBackoff("string")
            .build())
        .bigqueryConfig(SubscriptionBigqueryConfigArgs.builder()
            .table("string")
            .dropUnknownFields(false)
            .useTableSchema(false)
            .useTopicSchema(false)
            .writeMetadata(false)
            .build())
        .build());
    
    subscription_resource = gcp.pubsub.Subscription("subscriptionResource",
        topic="string",
        labels={
            "string": "string",
        },
        message_retention_duration="string",
        dead_letter_policy=gcp.pubsub.SubscriptionDeadLetterPolicyArgs(
            dead_letter_topic="string",
            max_delivery_attempts=0,
        ),
        enable_exactly_once_delivery=False,
        enable_message_ordering=False,
        expiration_policy=gcp.pubsub.SubscriptionExpirationPolicyArgs(
            ttl="string",
        ),
        cloud_storage_config=gcp.pubsub.SubscriptionCloudStorageConfigArgs(
            bucket="string",
            avro_config=gcp.pubsub.SubscriptionCloudStorageConfigAvroConfigArgs(
                write_metadata=False,
            ),
            filename_prefix="string",
            filename_suffix="string",
            max_bytes=0,
            max_duration="string",
            state="string",
        ),
        ack_deadline_seconds=0,
        filter="string",
        name="string",
        project="string",
        push_config=gcp.pubsub.SubscriptionPushConfigArgs(
            push_endpoint="string",
            attributes={
                "string": "string",
            },
            no_wrapper=gcp.pubsub.SubscriptionPushConfigNoWrapperArgs(
                write_metadata=False,
            ),
            oidc_token=gcp.pubsub.SubscriptionPushConfigOidcTokenArgs(
                service_account_email="string",
                audience="string",
            ),
        ),
        retain_acked_messages=False,
        retry_policy=gcp.pubsub.SubscriptionRetryPolicyArgs(
            maximum_backoff="string",
            minimum_backoff="string",
        ),
        bigquery_config=gcp.pubsub.SubscriptionBigqueryConfigArgs(
            table="string",
            drop_unknown_fields=False,
            use_table_schema=False,
            use_topic_schema=False,
            write_metadata=False,
        ))
    
    const subscriptionResource = new gcp.pubsub.Subscription("subscriptionResource", {
        topic: "string",
        labels: {
            string: "string",
        },
        messageRetentionDuration: "string",
        deadLetterPolicy: {
            deadLetterTopic: "string",
            maxDeliveryAttempts: 0,
        },
        enableExactlyOnceDelivery: false,
        enableMessageOrdering: false,
        expirationPolicy: {
            ttl: "string",
        },
        cloudStorageConfig: {
            bucket: "string",
            avroConfig: {
                writeMetadata: false,
            },
            filenamePrefix: "string",
            filenameSuffix: "string",
            maxBytes: 0,
            maxDuration: "string",
            state: "string",
        },
        ackDeadlineSeconds: 0,
        filter: "string",
        name: "string",
        project: "string",
        pushConfig: {
            pushEndpoint: "string",
            attributes: {
                string: "string",
            },
            noWrapper: {
                writeMetadata: false,
            },
            oidcToken: {
                serviceAccountEmail: "string",
                audience: "string",
            },
        },
        retainAckedMessages: false,
        retryPolicy: {
            maximumBackoff: "string",
            minimumBackoff: "string",
        },
        bigqueryConfig: {
            table: "string",
            dropUnknownFields: false,
            useTableSchema: false,
            useTopicSchema: false,
            writeMetadata: false,
        },
    });
    
    type: gcp:pubsub:Subscription
    properties:
        ackDeadlineSeconds: 0
        bigqueryConfig:
            dropUnknownFields: false
            table: string
            useTableSchema: false
            useTopicSchema: false
            writeMetadata: false
        cloudStorageConfig:
            avroConfig:
                writeMetadata: false
            bucket: string
            filenamePrefix: string
            filenameSuffix: string
            maxBytes: 0
            maxDuration: string
            state: string
        deadLetterPolicy:
            deadLetterTopic: string
            maxDeliveryAttempts: 0
        enableExactlyOnceDelivery: false
        enableMessageOrdering: false
        expirationPolicy:
            ttl: string
        filter: string
        labels:
            string: string
        messageRetentionDuration: string
        name: string
        project: string
        pushConfig:
            attributes:
                string: string
            noWrapper:
                writeMetadata: false
            oidcToken:
                audience: string
                serviceAccountEmail: string
            pushEndpoint: string
        retainAckedMessages: false
        retryPolicy:
            maximumBackoff: string
            minimumBackoff: string
        topic: string
    

    Subscription Resource Properties

    To learn more about resource properties and how to use them, see Inputs and Outputs in the Architecture and Concepts docs.

    Inputs

    The Subscription resource accepts the following input properties:

    Topic string
    A reference to a Topic resource, of the form projects/{project}/topics/{{name}} (as in the id property of a google_pubsub_topic), or just a topic name if the topic is in the same project as the subscription.


    AckDeadlineSeconds int
    This value is the maximum time after a subscriber receives a message before the subscriber should acknowledge the message. After message delivery but before the ack deadline expires and before the message is acknowledged, it is an outstanding message and will not be delivered again during that time (on a best-effort basis). For pull subscriptions, this value is used as the initial value for the ack deadline. To override this value for a given message, call subscriptions.modifyAckDeadline with the corresponding ackId if using pull. The minimum custom deadline you can specify is 10 seconds. The maximum custom deadline you can specify is 600 seconds (10 minutes). If this parameter is 0, a default value of 10 seconds is used. For push delivery, this value is also used to set the request timeout for the call to the push endpoint. If the subscriber never acknowledges the message, the Pub/Sub system will eventually redeliver the message.
    BigqueryConfig SubscriptionBigqueryConfig
    If delivery to BigQuery is used with this subscription, this field is used to configure it. Either pushConfig, bigQueryConfig or cloudStorageConfig can be set, but not combined. If all three are empty, then the subscriber will pull and ack messages using API methods. Structure is documented below.
    CloudStorageConfig SubscriptionCloudStorageConfig
    If delivery to Cloud Storage is used with this subscription, this field is used to configure it. Either pushConfig, bigQueryConfig or cloudStorageConfig can be set, but not combined. If all three are empty, then the subscriber will pull and ack messages using API methods. Structure is documented below.
    DeadLetterPolicy SubscriptionDeadLetterPolicy
    A policy that specifies the conditions for dead lettering messages in this subscription. If dead_letter_policy is not set, dead lettering is disabled. The Cloud Pub/Sub service account associated with this subscription's parent project (i.e., service-{project_number}@gcp-sa-pubsub.iam.gserviceaccount.com) must have permission to Acknowledge() messages on this subscription. Structure is documented below.
    EnableExactlyOnceDelivery bool
    If true, Pub/Sub provides the following guarantees for the delivery of a message with a given value of messageId on this Subscriptions':

    • The message sent to a subscriber is guaranteed not to be resent before the message's acknowledgement deadline expires.
    • An acknowledged message will not be resent to a subscriber. Note that subscribers may still receive multiple copies of a message when enable_exactly_once_delivery is true if the message was published multiple times by a publisher client. These copies are considered distinct by Pub/Sub and have distinct messageId values
    EnableMessageOrdering bool
    If true, messages published with the same orderingKey in PubsubMessage will be delivered to the subscribers in the order in which they are received by the Pub/Sub system. Otherwise, they may be delivered in any order.
    ExpirationPolicy SubscriptionExpirationPolicy
    A policy that specifies the conditions for this subscription's expiration. A subscription is considered active as long as any connected subscriber is successfully consuming messages from the subscription or is issuing operations on the subscription. If expirationPolicy is not set, a default policy with ttl of 31 days will be used. If it is set but ttl is "", the resource never expires. The minimum allowed value for expirationPolicy.ttl is 1 day. Structure is documented below.
    Filter string
    The subscription only delivers the messages that match the filter. Pub/Sub automatically acknowledges the messages that don't match the filter. You can filter messages by their attributes. The maximum length of a filter is 256 bytes. After creating the subscription, you can't modify the filter.
    Labels Dictionary<string, string>

    A set of key/value label pairs to assign to this Subscription.

    Note: This field is non-authoritative, and will only manage the labels present in your configuration. Please refer to the field effective_labels for all of the labels present on the resource.

    MessageRetentionDuration string
    How long to retain unacknowledged messages in the subscription's backlog, from the moment a message is published. If retain_acked_messages is true, then this also configures the retention of acknowledged messages, and thus configures how far back in time a subscriptions.seek can be done. Defaults to 7 days. Cannot be more than 7 days ("604800s") or less than 10 minutes ("600s"). A duration in seconds with up to nine fractional digits, terminated by 's'. Example: "600.5s".
    Name string
    Name of the subscription.
    Project string
    The ID of the project in which the resource belongs. If it is not provided, the provider project is used.
    PushConfig SubscriptionPushConfig
    If push delivery is used with this subscription, this field is used to configure it. An empty pushConfig signifies that the subscriber will pull and ack messages using API methods. Structure is documented below.
    RetainAckedMessages bool
    Indicates whether to retain acknowledged messages. If true, then messages are not expunged from the subscription's backlog, even if they are acknowledged, until they fall out of the messageRetentionDuration window.
    RetryPolicy SubscriptionRetryPolicy
    A policy that specifies how Pub/Sub retries message delivery for this subscription. If not set, the default retry policy is applied. This generally implies that messages will be retried as soon as possible for healthy subscribers. RetryPolicy will be triggered on NACKs or acknowledgement deadline exceeded events for a given message Structure is documented below.
    Topic string
    A reference to a Topic resource, of the form projects/{project}/topics/{{name}} (as in the id property of a google_pubsub_topic), or just a topic name if the topic is in the same project as the subscription.


    AckDeadlineSeconds int
    This value is the maximum time after a subscriber receives a message before the subscriber should acknowledge the message. After message delivery but before the ack deadline expires and before the message is acknowledged, it is an outstanding message and will not be delivered again during that time (on a best-effort basis). For pull subscriptions, this value is used as the initial value for the ack deadline. To override this value for a given message, call subscriptions.modifyAckDeadline with the corresponding ackId if using pull. The minimum custom deadline you can specify is 10 seconds. The maximum custom deadline you can specify is 600 seconds (10 minutes). If this parameter is 0, a default value of 10 seconds is used. For push delivery, this value is also used to set the request timeout for the call to the push endpoint. If the subscriber never acknowledges the message, the Pub/Sub system will eventually redeliver the message.
    BigqueryConfig SubscriptionBigqueryConfigArgs
    If delivery to BigQuery is used with this subscription, this field is used to configure it. Either pushConfig, bigQueryConfig or cloudStorageConfig can be set, but not combined. If all three are empty, then the subscriber will pull and ack messages using API methods. Structure is documented below.
    CloudStorageConfig SubscriptionCloudStorageConfigArgs
    If delivery to Cloud Storage is used with this subscription, this field is used to configure it. Either pushConfig, bigQueryConfig or cloudStorageConfig can be set, but not combined. If all three are empty, then the subscriber will pull and ack messages using API methods. Structure is documented below.
    DeadLetterPolicy SubscriptionDeadLetterPolicyArgs
    A policy that specifies the conditions for dead lettering messages in this subscription. If dead_letter_policy is not set, dead lettering is disabled. The Cloud Pub/Sub service account associated with this subscription's parent project (i.e., service-{project_number}@gcp-sa-pubsub.iam.gserviceaccount.com) must have permission to Acknowledge() messages on this subscription. Structure is documented below.
    EnableExactlyOnceDelivery bool
    If true, Pub/Sub provides the following guarantees for the delivery of a message with a given value of messageId on this Subscriptions':

    • The message sent to a subscriber is guaranteed not to be resent before the message's acknowledgement deadline expires.
    • An acknowledged message will not be resent to a subscriber. Note that subscribers may still receive multiple copies of a message when enable_exactly_once_delivery is true if the message was published multiple times by a publisher client. These copies are considered distinct by Pub/Sub and have distinct messageId values
    EnableMessageOrdering bool
    If true, messages published with the same orderingKey in PubsubMessage will be delivered to the subscribers in the order in which they are received by the Pub/Sub system. Otherwise, they may be delivered in any order.
    ExpirationPolicy SubscriptionExpirationPolicyArgs
    A policy that specifies the conditions for this subscription's expiration. A subscription is considered active as long as any connected subscriber is successfully consuming messages from the subscription or is issuing operations on the subscription. If expirationPolicy is not set, a default policy with ttl of 31 days will be used. If it is set but ttl is "", the resource never expires. The minimum allowed value for expirationPolicy.ttl is 1 day. Structure is documented below.
    Filter string
    The subscription only delivers the messages that match the filter. Pub/Sub automatically acknowledges the messages that don't match the filter. You can filter messages by their attributes. The maximum length of a filter is 256 bytes. After creating the subscription, you can't modify the filter.
    Labels map[string]string

    A set of key/value label pairs to assign to this Subscription.

    Note: This field is non-authoritative, and will only manage the labels present in your configuration. Please refer to the field effective_labels for all of the labels present on the resource.

    MessageRetentionDuration string
    How long to retain unacknowledged messages in the subscription's backlog, from the moment a message is published. If retain_acked_messages is true, then this also configures the retention of acknowledged messages, and thus configures how far back in time a subscriptions.seek can be done. Defaults to 7 days. Cannot be more than 7 days ("604800s") or less than 10 minutes ("600s"). A duration in seconds with up to nine fractional digits, terminated by 's'. Example: "600.5s".
    Name string
    Name of the subscription.
    Project string
    The ID of the project in which the resource belongs. If it is not provided, the provider project is used.
    PushConfig SubscriptionPushConfigArgs
    If push delivery is used with this subscription, this field is used to configure it. An empty pushConfig signifies that the subscriber will pull and ack messages using API methods. Structure is documented below.
    RetainAckedMessages bool
    Indicates whether to retain acknowledged messages. If true, then messages are not expunged from the subscription's backlog, even if they are acknowledged, until they fall out of the messageRetentionDuration window.
    RetryPolicy SubscriptionRetryPolicyArgs
    A policy that specifies how Pub/Sub retries message delivery for this subscription. If not set, the default retry policy is applied. This generally implies that messages will be retried as soon as possible for healthy subscribers. RetryPolicy will be triggered on NACKs or acknowledgement deadline exceeded events for a given message Structure is documented below.
    topic String
    A reference to a Topic resource, of the form projects/{project}/topics/{{name}} (as in the id property of a google_pubsub_topic), or just a topic name if the topic is in the same project as the subscription.


    ackDeadlineSeconds Integer
    This value is the maximum time after a subscriber receives a message before the subscriber should acknowledge the message. After message delivery but before the ack deadline expires and before the message is acknowledged, it is an outstanding message and will not be delivered again during that time (on a best-effort basis). For pull subscriptions, this value is used as the initial value for the ack deadline. To override this value for a given message, call subscriptions.modifyAckDeadline with the corresponding ackId if using pull. The minimum custom deadline you can specify is 10 seconds. The maximum custom deadline you can specify is 600 seconds (10 minutes). If this parameter is 0, a default value of 10 seconds is used. For push delivery, this value is also used to set the request timeout for the call to the push endpoint. If the subscriber never acknowledges the message, the Pub/Sub system will eventually redeliver the message.
    bigqueryConfig SubscriptionBigqueryConfig
    If delivery to BigQuery is used with this subscription, this field is used to configure it. Either pushConfig, bigQueryConfig or cloudStorageConfig can be set, but not combined. If all three are empty, then the subscriber will pull and ack messages using API methods. Structure is documented below.
    cloudStorageConfig SubscriptionCloudStorageConfig
    If delivery to Cloud Storage is used with this subscription, this field is used to configure it. Either pushConfig, bigQueryConfig or cloudStorageConfig can be set, but not combined. If all three are empty, then the subscriber will pull and ack messages using API methods. Structure is documented below.
    deadLetterPolicy SubscriptionDeadLetterPolicy
    A policy that specifies the conditions for dead lettering messages in this subscription. If dead_letter_policy is not set, dead lettering is disabled. The Cloud Pub/Sub service account associated with this subscription's parent project (i.e., service-{project_number}@gcp-sa-pubsub.iam.gserviceaccount.com) must have permission to Acknowledge() messages on this subscription. Structure is documented below.
    enableExactlyOnceDelivery Boolean
    If true, Pub/Sub provides the following guarantees for the delivery of a message with a given value of messageId on this Subscriptions':

    • The message sent to a subscriber is guaranteed not to be resent before the message's acknowledgement deadline expires.
    • An acknowledged message will not be resent to a subscriber. Note that subscribers may still receive multiple copies of a message when enable_exactly_once_delivery is true if the message was published multiple times by a publisher client. These copies are considered distinct by Pub/Sub and have distinct messageId values
    enableMessageOrdering Boolean
    If true, messages published with the same orderingKey in PubsubMessage will be delivered to the subscribers in the order in which they are received by the Pub/Sub system. Otherwise, they may be delivered in any order.
    expirationPolicy SubscriptionExpirationPolicy
    A policy that specifies the conditions for this subscription's expiration. A subscription is considered active as long as any connected subscriber is successfully consuming messages from the subscription or is issuing operations on the subscription. If expirationPolicy is not set, a default policy with ttl of 31 days will be used. If it is set but ttl is "", the resource never expires. The minimum allowed value for expirationPolicy.ttl is 1 day. Structure is documented below.
    filter String
    The subscription only delivers the messages that match the filter. Pub/Sub automatically acknowledges the messages that don't match the filter. You can filter messages by their attributes. The maximum length of a filter is 256 bytes. After creating the subscription, you can't modify the filter.
    labels Map<String,String>

    A set of key/value label pairs to assign to this Subscription.

    Note: This field is non-authoritative, and will only manage the labels present in your configuration. Please refer to the field effective_labels for all of the labels present on the resource.

    messageRetentionDuration String
    How long to retain unacknowledged messages in the subscription's backlog, from the moment a message is published. If retain_acked_messages is true, then this also configures the retention of acknowledged messages, and thus configures how far back in time a subscriptions.seek can be done. Defaults to 7 days. Cannot be more than 7 days ("604800s") or less than 10 minutes ("600s"). A duration in seconds with up to nine fractional digits, terminated by 's'. Example: "600.5s".
    name String
    Name of the subscription.
    project String
    The ID of the project in which the resource belongs. If it is not provided, the provider project is used.
    pushConfig SubscriptionPushConfig
    If push delivery is used with this subscription, this field is used to configure it. An empty pushConfig signifies that the subscriber will pull and ack messages using API methods. Structure is documented below.
    retainAckedMessages Boolean
    Indicates whether to retain acknowledged messages. If true, then messages are not expunged from the subscription's backlog, even if they are acknowledged, until they fall out of the messageRetentionDuration window.
    retryPolicy SubscriptionRetryPolicy
    A policy that specifies how Pub/Sub retries message delivery for this subscription. If not set, the default retry policy is applied. This generally implies that messages will be retried as soon as possible for healthy subscribers. RetryPolicy will be triggered on NACKs or acknowledgement deadline exceeded events for a given message Structure is documented below.
    topic string
    A reference to a Topic resource, of the form projects/{project}/topics/{{name}} (as in the id property of a google_pubsub_topic), or just a topic name if the topic is in the same project as the subscription.


    ackDeadlineSeconds number
    This value is the maximum time after a subscriber receives a message before the subscriber should acknowledge the message. After message delivery but before the ack deadline expires and before the message is acknowledged, it is an outstanding message and will not be delivered again during that time (on a best-effort basis). For pull subscriptions, this value is used as the initial value for the ack deadline. To override this value for a given message, call subscriptions.modifyAckDeadline with the corresponding ackId if using pull. The minimum custom deadline you can specify is 10 seconds. The maximum custom deadline you can specify is 600 seconds (10 minutes). If this parameter is 0, a default value of 10 seconds is used. For push delivery, this value is also used to set the request timeout for the call to the push endpoint. If the subscriber never acknowledges the message, the Pub/Sub system will eventually redeliver the message.
    bigqueryConfig SubscriptionBigqueryConfig
    If delivery to BigQuery is used with this subscription, this field is used to configure it. Either pushConfig, bigQueryConfig or cloudStorageConfig can be set, but not combined. If all three are empty, then the subscriber will pull and ack messages using API methods. Structure is documented below.
    cloudStorageConfig SubscriptionCloudStorageConfig
    If delivery to Cloud Storage is used with this subscription, this field is used to configure it. Either pushConfig, bigQueryConfig or cloudStorageConfig can be set, but not combined. If all three are empty, then the subscriber will pull and ack messages using API methods. Structure is documented below.
    deadLetterPolicy SubscriptionDeadLetterPolicy
    A policy that specifies the conditions for dead lettering messages in this subscription. If dead_letter_policy is not set, dead lettering is disabled. The Cloud Pub/Sub service account associated with this subscription's parent project (i.e., service-{project_number}@gcp-sa-pubsub.iam.gserviceaccount.com) must have permission to Acknowledge() messages on this subscription. Structure is documented below.
    enableExactlyOnceDelivery boolean
    If true, Pub/Sub provides the following guarantees for the delivery of a message with a given value of messageId on this Subscriptions':

    • The message sent to a subscriber is guaranteed not to be resent before the message's acknowledgement deadline expires.
    • An acknowledged message will not be resent to a subscriber. Note that subscribers may still receive multiple copies of a message when enable_exactly_once_delivery is true if the message was published multiple times by a publisher client. These copies are considered distinct by Pub/Sub and have distinct messageId values
    enableMessageOrdering boolean
    If true, messages published with the same orderingKey in PubsubMessage will be delivered to the subscribers in the order in which they are received by the Pub/Sub system. Otherwise, they may be delivered in any order.
    expirationPolicy SubscriptionExpirationPolicy
    A policy that specifies the conditions for this subscription's expiration. A subscription is considered active as long as any connected subscriber is successfully consuming messages from the subscription or is issuing operations on the subscription. If expirationPolicy is not set, a default policy with ttl of 31 days will be used. If it is set but ttl is "", the resource never expires. The minimum allowed value for expirationPolicy.ttl is 1 day. Structure is documented below.
    filter string
    The subscription only delivers the messages that match the filter. Pub/Sub automatically acknowledges the messages that don't match the filter. You can filter messages by their attributes. The maximum length of a filter is 256 bytes. After creating the subscription, you can't modify the filter.
    labels {[key: string]: string}

    A set of key/value label pairs to assign to this Subscription.

    Note: This field is non-authoritative, and will only manage the labels present in your configuration. Please refer to the field effective_labels for all of the labels present on the resource.

    messageRetentionDuration string
    How long to retain unacknowledged messages in the subscription's backlog, from the moment a message is published. If retain_acked_messages is true, then this also configures the retention of acknowledged messages, and thus configures how far back in time a subscriptions.seek can be done. Defaults to 7 days. Cannot be more than 7 days ("604800s") or less than 10 minutes ("600s"). A duration in seconds with up to nine fractional digits, terminated by 's'. Example: "600.5s".
    name string
    Name of the subscription.
    project string
    The ID of the project in which the resource belongs. If it is not provided, the provider project is used.
    pushConfig SubscriptionPushConfig
    If push delivery is used with this subscription, this field is used to configure it. An empty pushConfig signifies that the subscriber will pull and ack messages using API methods. Structure is documented below.
    retainAckedMessages boolean
    Indicates whether to retain acknowledged messages. If true, then messages are not expunged from the subscription's backlog, even if they are acknowledged, until they fall out of the messageRetentionDuration window.
    retryPolicy SubscriptionRetryPolicy
    A policy that specifies how Pub/Sub retries message delivery for this subscription. If not set, the default retry policy is applied. This generally implies that messages will be retried as soon as possible for healthy subscribers. RetryPolicy will be triggered on NACKs or acknowledgement deadline exceeded events for a given message Structure is documented below.
    topic str
    A reference to a Topic resource, of the form projects/{project}/topics/{{name}} (as in the id property of a google_pubsub_topic), or just a topic name if the topic is in the same project as the subscription.


    ack_deadline_seconds int
    This value is the maximum time after a subscriber receives a message before the subscriber should acknowledge the message. After message delivery but before the ack deadline expires and before the message is acknowledged, it is an outstanding message and will not be delivered again during that time (on a best-effort basis). For pull subscriptions, this value is used as the initial value for the ack deadline. To override this value for a given message, call subscriptions.modifyAckDeadline with the corresponding ackId if using pull. The minimum custom deadline you can specify is 10 seconds. The maximum custom deadline you can specify is 600 seconds (10 minutes). If this parameter is 0, a default value of 10 seconds is used. For push delivery, this value is also used to set the request timeout for the call to the push endpoint. If the subscriber never acknowledges the message, the Pub/Sub system will eventually redeliver the message.
    bigquery_config SubscriptionBigqueryConfigArgs
    If delivery to BigQuery is used with this subscription, this field is used to configure it. Either pushConfig, bigQueryConfig or cloudStorageConfig can be set, but not combined. If all three are empty, then the subscriber will pull and ack messages using API methods. Structure is documented below.
    cloud_storage_config SubscriptionCloudStorageConfigArgs
    If delivery to Cloud Storage is used with this subscription, this field is used to configure it. Either pushConfig, bigQueryConfig or cloudStorageConfig can be set, but not combined. If all three are empty, then the subscriber will pull and ack messages using API methods. Structure is documented below.
    dead_letter_policy SubscriptionDeadLetterPolicyArgs
    A policy that specifies the conditions for dead lettering messages in this subscription. If dead_letter_policy is not set, dead lettering is disabled. The Cloud Pub/Sub service account associated with this subscription's parent project (i.e., service-{project_number}@gcp-sa-pubsub.iam.gserviceaccount.com) must have permission to Acknowledge() messages on this subscription. Structure is documented below.
    enable_exactly_once_delivery bool
    If true, Pub/Sub provides the following guarantees for the delivery of a message with a given value of messageId on this Subscriptions':

    • The message sent to a subscriber is guaranteed not to be resent before the message's acknowledgement deadline expires.
    • An acknowledged message will not be resent to a subscriber. Note that subscribers may still receive multiple copies of a message when enable_exactly_once_delivery is true if the message was published multiple times by a publisher client. These copies are considered distinct by Pub/Sub and have distinct messageId values
    enable_message_ordering bool
    If true, messages published with the same orderingKey in PubsubMessage will be delivered to the subscribers in the order in which they are received by the Pub/Sub system. Otherwise, they may be delivered in any order.
    expiration_policy SubscriptionExpirationPolicyArgs
    A policy that specifies the conditions for this subscription's expiration. A subscription is considered active as long as any connected subscriber is successfully consuming messages from the subscription or is issuing operations on the subscription. If expirationPolicy is not set, a default policy with ttl of 31 days will be used. If it is set but ttl is "", the resource never expires. The minimum allowed value for expirationPolicy.ttl is 1 day. Structure is documented below.
    filter str
    The subscription only delivers the messages that match the filter. Pub/Sub automatically acknowledges the messages that don't match the filter. You can filter messages by their attributes. The maximum length of a filter is 256 bytes. After creating the subscription, you can't modify the filter.
    labels Mapping[str, str]

    A set of key/value label pairs to assign to this Subscription.

    Note: This field is non-authoritative, and will only manage the labels present in your configuration. Please refer to the field effective_labels for all of the labels present on the resource.

    message_retention_duration str
    How long to retain unacknowledged messages in the subscription's backlog, from the moment a message is published. If retain_acked_messages is true, then this also configures the retention of acknowledged messages, and thus configures how far back in time a subscriptions.seek can be done. Defaults to 7 days. Cannot be more than 7 days ("604800s") or less than 10 minutes ("600s"). A duration in seconds with up to nine fractional digits, terminated by 's'. Example: "600.5s".
    name str
    Name of the subscription.
    project str
    The ID of the project in which the resource belongs. If it is not provided, the provider project is used.
    push_config SubscriptionPushConfigArgs
    If push delivery is used with this subscription, this field is used to configure it. An empty pushConfig signifies that the subscriber will pull and ack messages using API methods. Structure is documented below.
    retain_acked_messages bool
    Indicates whether to retain acknowledged messages. If true, then messages are not expunged from the subscription's backlog, even if they are acknowledged, until they fall out of the messageRetentionDuration window.
    retry_policy SubscriptionRetryPolicyArgs
    A policy that specifies how Pub/Sub retries message delivery for this subscription. If not set, the default retry policy is applied. This generally implies that messages will be retried as soon as possible for healthy subscribers. RetryPolicy will be triggered on NACKs or acknowledgement deadline exceeded events for a given message Structure is documented below.
    topic String
    A reference to a Topic resource, of the form projects/{project}/topics/{{name}} (as in the id property of a google_pubsub_topic), or just a topic name if the topic is in the same project as the subscription.


    ackDeadlineSeconds Number
    This value is the maximum time after a subscriber receives a message before the subscriber should acknowledge the message. After message delivery but before the ack deadline expires and before the message is acknowledged, it is an outstanding message and will not be delivered again during that time (on a best-effort basis). For pull subscriptions, this value is used as the initial value for the ack deadline. To override this value for a given message, call subscriptions.modifyAckDeadline with the corresponding ackId if using pull. The minimum custom deadline you can specify is 10 seconds. The maximum custom deadline you can specify is 600 seconds (10 minutes). If this parameter is 0, a default value of 10 seconds is used. For push delivery, this value is also used to set the request timeout for the call to the push endpoint. If the subscriber never acknowledges the message, the Pub/Sub system will eventually redeliver the message.
    bigqueryConfig Property Map
    If delivery to BigQuery is used with this subscription, this field is used to configure it. Either pushConfig, bigQueryConfig or cloudStorageConfig can be set, but not combined. If all three are empty, then the subscriber will pull and ack messages using API methods. Structure is documented below.
    cloudStorageConfig Property Map
    If delivery to Cloud Storage is used with this subscription, this field is used to configure it. Either pushConfig, bigQueryConfig or cloudStorageConfig can be set, but not combined. If all three are empty, then the subscriber will pull and ack messages using API methods. Structure is documented below.
    deadLetterPolicy Property Map
    A policy that specifies the conditions for dead lettering messages in this subscription. If dead_letter_policy is not set, dead lettering is disabled. The Cloud Pub/Sub service account associated with this subscription's parent project (i.e., service-{project_number}@gcp-sa-pubsub.iam.gserviceaccount.com) must have permission to Acknowledge() messages on this subscription. Structure is documented below.
    enableExactlyOnceDelivery Boolean
    If true, Pub/Sub provides the following guarantees for the delivery of a message with a given value of messageId on this Subscriptions':

    • The message sent to a subscriber is guaranteed not to be resent before the message's acknowledgement deadline expires.
    • An acknowledged message will not be resent to a subscriber. Note that subscribers may still receive multiple copies of a message when enable_exactly_once_delivery is true if the message was published multiple times by a publisher client. These copies are considered distinct by Pub/Sub and have distinct messageId values
    enableMessageOrdering Boolean
    If true, messages published with the same orderingKey in PubsubMessage will be delivered to the subscribers in the order in which they are received by the Pub/Sub system. Otherwise, they may be delivered in any order.
    expirationPolicy Property Map
    A policy that specifies the conditions for this subscription's expiration. A subscription is considered active as long as any connected subscriber is successfully consuming messages from the subscription or is issuing operations on the subscription. If expirationPolicy is not set, a default policy with ttl of 31 days will be used. If it is set but ttl is "", the resource never expires. The minimum allowed value for expirationPolicy.ttl is 1 day. Structure is documented below.
    filter String
    The subscription only delivers the messages that match the filter. Pub/Sub automatically acknowledges the messages that don't match the filter. You can filter messages by their attributes. The maximum length of a filter is 256 bytes. After creating the subscription, you can't modify the filter.
    labels Map<String>

    A set of key/value label pairs to assign to this Subscription.

    Note: This field is non-authoritative, and will only manage the labels present in your configuration. Please refer to the field effective_labels for all of the labels present on the resource.

    messageRetentionDuration String
    How long to retain unacknowledged messages in the subscription's backlog, from the moment a message is published. If retain_acked_messages is true, then this also configures the retention of acknowledged messages, and thus configures how far back in time a subscriptions.seek can be done. Defaults to 7 days. Cannot be more than 7 days ("604800s") or less than 10 minutes ("600s"). A duration in seconds with up to nine fractional digits, terminated by 's'. Example: "600.5s".
    name String
    Name of the subscription.
    project String
    The ID of the project in which the resource belongs. If it is not provided, the provider project is used.
    pushConfig Property Map
    If push delivery is used with this subscription, this field is used to configure it. An empty pushConfig signifies that the subscriber will pull and ack messages using API methods. Structure is documented below.
    retainAckedMessages Boolean
    Indicates whether to retain acknowledged messages. If true, then messages are not expunged from the subscription's backlog, even if they are acknowledged, until they fall out of the messageRetentionDuration window.
    retryPolicy Property Map
    A policy that specifies how Pub/Sub retries message delivery for this subscription. If not set, the default retry policy is applied. This generally implies that messages will be retried as soon as possible for healthy subscribers. RetryPolicy will be triggered on NACKs or acknowledgement deadline exceeded events for a given message Structure is documented below.

    Outputs

    All input properties are implicitly available as output properties. Additionally, the Subscription resource produces the following output properties:

    EffectiveLabels Dictionary<string, string>
    All of labels (key/value pairs) present on the resource in GCP, including the labels configured through Pulumi, other clients and services.
    Id string
    The provider-assigned unique ID for this managed resource.
    PulumiLabels Dictionary<string, string>
    The combination of labels configured directly on the resource and default labels configured on the provider.
    EffectiveLabels map[string]string
    All of labels (key/value pairs) present on the resource in GCP, including the labels configured through Pulumi, other clients and services.
    Id string
    The provider-assigned unique ID for this managed resource.
    PulumiLabels map[string]string
    The combination of labels configured directly on the resource and default labels configured on the provider.
    effectiveLabels Map<String,String>
    All of labels (key/value pairs) present on the resource in GCP, including the labels configured through Pulumi, other clients and services.
    id String
    The provider-assigned unique ID for this managed resource.
    pulumiLabels Map<String,String>
    The combination of labels configured directly on the resource and default labels configured on the provider.
    effectiveLabels {[key: string]: string}
    All of labels (key/value pairs) present on the resource in GCP, including the labels configured through Pulumi, other clients and services.
    id string
    The provider-assigned unique ID for this managed resource.
    pulumiLabels {[key: string]: string}
    The combination of labels configured directly on the resource and default labels configured on the provider.
    effective_labels Mapping[str, str]
    All of labels (key/value pairs) present on the resource in GCP, including the labels configured through Pulumi, other clients and services.
    id str
    The provider-assigned unique ID for this managed resource.
    pulumi_labels Mapping[str, str]
    The combination of labels configured directly on the resource and default labels configured on the provider.
    effectiveLabels Map<String>
    All of labels (key/value pairs) present on the resource in GCP, including the labels configured through Pulumi, other clients and services.
    id String
    The provider-assigned unique ID for this managed resource.
    pulumiLabels Map<String>
    The combination of labels configured directly on the resource and default labels configured on the provider.

    Look up Existing Subscription Resource

    Get an existing Subscription resource’s state with the given name, ID, and optional extra properties used to qualify the lookup.

    public static get(name: string, id: Input<ID>, state?: SubscriptionState, opts?: CustomResourceOptions): Subscription
    @staticmethod
    def get(resource_name: str,
            id: str,
            opts: Optional[ResourceOptions] = None,
            ack_deadline_seconds: Optional[int] = None,
            bigquery_config: Optional[SubscriptionBigqueryConfigArgs] = None,
            cloud_storage_config: Optional[SubscriptionCloudStorageConfigArgs] = None,
            dead_letter_policy: Optional[SubscriptionDeadLetterPolicyArgs] = None,
            effective_labels: Optional[Mapping[str, str]] = None,
            enable_exactly_once_delivery: Optional[bool] = None,
            enable_message_ordering: Optional[bool] = None,
            expiration_policy: Optional[SubscriptionExpirationPolicyArgs] = None,
            filter: Optional[str] = None,
            labels: Optional[Mapping[str, str]] = None,
            message_retention_duration: Optional[str] = None,
            name: Optional[str] = None,
            project: Optional[str] = None,
            pulumi_labels: Optional[Mapping[str, str]] = None,
            push_config: Optional[SubscriptionPushConfigArgs] = None,
            retain_acked_messages: Optional[bool] = None,
            retry_policy: Optional[SubscriptionRetryPolicyArgs] = None,
            topic: Optional[str] = None) -> Subscription
    func GetSubscription(ctx *Context, name string, id IDInput, state *SubscriptionState, opts ...ResourceOption) (*Subscription, error)
    public static Subscription Get(string name, Input<string> id, SubscriptionState? state, CustomResourceOptions? opts = null)
    public static Subscription get(String name, Output<String> id, SubscriptionState state, CustomResourceOptions options)
    Resource lookup is not supported in YAML
    name
    The unique name of the resulting resource.
    id
    The unique provider ID of the resource to lookup.
    state
    Any extra arguments used during the lookup.
    opts
    A bag of options that control this resource's behavior.
    resource_name
    The unique name of the resulting resource.
    id
    The unique provider ID of the resource to lookup.
    name
    The unique name of the resulting resource.
    id
    The unique provider ID of the resource to lookup.
    state
    Any extra arguments used during the lookup.
    opts
    A bag of options that control this resource's behavior.
    name
    The unique name of the resulting resource.
    id
    The unique provider ID of the resource to lookup.
    state
    Any extra arguments used during the lookup.
    opts
    A bag of options that control this resource's behavior.
    name
    The unique name of the resulting resource.
    id
    The unique provider ID of the resource to lookup.
    state
    Any extra arguments used during the lookup.
    opts
    A bag of options that control this resource's behavior.
    The following state arguments are supported:
    AckDeadlineSeconds int
    This value is the maximum time after a subscriber receives a message before the subscriber should acknowledge the message. After message delivery but before the ack deadline expires and before the message is acknowledged, it is an outstanding message and will not be delivered again during that time (on a best-effort basis). For pull subscriptions, this value is used as the initial value for the ack deadline. To override this value for a given message, call subscriptions.modifyAckDeadline with the corresponding ackId if using pull. The minimum custom deadline you can specify is 10 seconds. The maximum custom deadline you can specify is 600 seconds (10 minutes). If this parameter is 0, a default value of 10 seconds is used. For push delivery, this value is also used to set the request timeout for the call to the push endpoint. If the subscriber never acknowledges the message, the Pub/Sub system will eventually redeliver the message.
    BigqueryConfig SubscriptionBigqueryConfig
    If delivery to BigQuery is used with this subscription, this field is used to configure it. Either pushConfig, bigQueryConfig or cloudStorageConfig can be set, but not combined. If all three are empty, then the subscriber will pull and ack messages using API methods. Structure is documented below.
    CloudStorageConfig SubscriptionCloudStorageConfig
    If delivery to Cloud Storage is used with this subscription, this field is used to configure it. Either pushConfig, bigQueryConfig or cloudStorageConfig can be set, but not combined. If all three are empty, then the subscriber will pull and ack messages using API methods. Structure is documented below.
    DeadLetterPolicy SubscriptionDeadLetterPolicy
    A policy that specifies the conditions for dead lettering messages in this subscription. If dead_letter_policy is not set, dead lettering is disabled. The Cloud Pub/Sub service account associated with this subscription's parent project (i.e., service-{project_number}@gcp-sa-pubsub.iam.gserviceaccount.com) must have permission to Acknowledge() messages on this subscription. Structure is documented below.
    EffectiveLabels Dictionary<string, string>
    All of labels (key/value pairs) present on the resource in GCP, including the labels configured through Pulumi, other clients and services.
    EnableExactlyOnceDelivery bool
    If true, Pub/Sub provides the following guarantees for the delivery of a message with a given value of messageId on this Subscriptions':

    • The message sent to a subscriber is guaranteed not to be resent before the message's acknowledgement deadline expires.
    • An acknowledged message will not be resent to a subscriber. Note that subscribers may still receive multiple copies of a message when enable_exactly_once_delivery is true if the message was published multiple times by a publisher client. These copies are considered distinct by Pub/Sub and have distinct messageId values
    EnableMessageOrdering bool
    If true, messages published with the same orderingKey in PubsubMessage will be delivered to the subscribers in the order in which they are received by the Pub/Sub system. Otherwise, they may be delivered in any order.
    ExpirationPolicy SubscriptionExpirationPolicy
    A policy that specifies the conditions for this subscription's expiration. A subscription is considered active as long as any connected subscriber is successfully consuming messages from the subscription or is issuing operations on the subscription. If expirationPolicy is not set, a default policy with ttl of 31 days will be used. If it is set but ttl is "", the resource never expires. The minimum allowed value for expirationPolicy.ttl is 1 day. Structure is documented below.
    Filter string
    The subscription only delivers the messages that match the filter. Pub/Sub automatically acknowledges the messages that don't match the filter. You can filter messages by their attributes. The maximum length of a filter is 256 bytes. After creating the subscription, you can't modify the filter.
    Labels Dictionary<string, string>

    A set of key/value label pairs to assign to this Subscription.

    Note: This field is non-authoritative, and will only manage the labels present in your configuration. Please refer to the field effective_labels for all of the labels present on the resource.

    MessageRetentionDuration string
    How long to retain unacknowledged messages in the subscription's backlog, from the moment a message is published. If retain_acked_messages is true, then this also configures the retention of acknowledged messages, and thus configures how far back in time a subscriptions.seek can be done. Defaults to 7 days. Cannot be more than 7 days ("604800s") or less than 10 minutes ("600s"). A duration in seconds with up to nine fractional digits, terminated by 's'. Example: "600.5s".
    Name string
    Name of the subscription.
    Project string
    The ID of the project in which the resource belongs. If it is not provided, the provider project is used.
    PulumiLabels Dictionary<string, string>
    The combination of labels configured directly on the resource and default labels configured on the provider.
    PushConfig SubscriptionPushConfig
    If push delivery is used with this subscription, this field is used to configure it. An empty pushConfig signifies that the subscriber will pull and ack messages using API methods. Structure is documented below.
    RetainAckedMessages bool
    Indicates whether to retain acknowledged messages. If true, then messages are not expunged from the subscription's backlog, even if they are acknowledged, until they fall out of the messageRetentionDuration window.
    RetryPolicy SubscriptionRetryPolicy
    A policy that specifies how Pub/Sub retries message delivery for this subscription. If not set, the default retry policy is applied. This generally implies that messages will be retried as soon as possible for healthy subscribers. RetryPolicy will be triggered on NACKs or acknowledgement deadline exceeded events for a given message Structure is documented below.
    Topic string
    A reference to a Topic resource, of the form projects/{project}/topics/{{name}} (as in the id property of a google_pubsub_topic), or just a topic name if the topic is in the same project as the subscription.


    AckDeadlineSeconds int
    This value is the maximum time after a subscriber receives a message before the subscriber should acknowledge the message. After message delivery but before the ack deadline expires and before the message is acknowledged, it is an outstanding message and will not be delivered again during that time (on a best-effort basis). For pull subscriptions, this value is used as the initial value for the ack deadline. To override this value for a given message, call subscriptions.modifyAckDeadline with the corresponding ackId if using pull. The minimum custom deadline you can specify is 10 seconds. The maximum custom deadline you can specify is 600 seconds (10 minutes). If this parameter is 0, a default value of 10 seconds is used. For push delivery, this value is also used to set the request timeout for the call to the push endpoint. If the subscriber never acknowledges the message, the Pub/Sub system will eventually redeliver the message.
    BigqueryConfig SubscriptionBigqueryConfigArgs
    If delivery to BigQuery is used with this subscription, this field is used to configure it. Either pushConfig, bigQueryConfig or cloudStorageConfig can be set, but not combined. If all three are empty, then the subscriber will pull and ack messages using API methods. Structure is documented below.
    CloudStorageConfig SubscriptionCloudStorageConfigArgs
    If delivery to Cloud Storage is used with this subscription, this field is used to configure it. Either pushConfig, bigQueryConfig or cloudStorageConfig can be set, but not combined. If all three are empty, then the subscriber will pull and ack messages using API methods. Structure is documented below.
    DeadLetterPolicy SubscriptionDeadLetterPolicyArgs
    A policy that specifies the conditions for dead lettering messages in this subscription. If dead_letter_policy is not set, dead lettering is disabled. The Cloud Pub/Sub service account associated with this subscription's parent project (i.e., service-{project_number}@gcp-sa-pubsub.iam.gserviceaccount.com) must have permission to Acknowledge() messages on this subscription. Structure is documented below.
    EffectiveLabels map[string]string
    All of labels (key/value pairs) present on the resource in GCP, including the labels configured through Pulumi, other clients and services.
    EnableExactlyOnceDelivery bool
    If true, Pub/Sub provides the following guarantees for the delivery of a message with a given value of messageId on this Subscriptions':

    • The message sent to a subscriber is guaranteed not to be resent before the message's acknowledgement deadline expires.
    • An acknowledged message will not be resent to a subscriber. Note that subscribers may still receive multiple copies of a message when enable_exactly_once_delivery is true if the message was published multiple times by a publisher client. These copies are considered distinct by Pub/Sub and have distinct messageId values
    EnableMessageOrdering bool
    If true, messages published with the same orderingKey in PubsubMessage will be delivered to the subscribers in the order in which they are received by the Pub/Sub system. Otherwise, they may be delivered in any order.
    ExpirationPolicy SubscriptionExpirationPolicyArgs
    A policy that specifies the conditions for this subscription's expiration. A subscription is considered active as long as any connected subscriber is successfully consuming messages from the subscription or is issuing operations on the subscription. If expirationPolicy is not set, a default policy with ttl of 31 days will be used. If it is set but ttl is "", the resource never expires. The minimum allowed value for expirationPolicy.ttl is 1 day. Structure is documented below.
    Filter string
    The subscription only delivers the messages that match the filter. Pub/Sub automatically acknowledges the messages that don't match the filter. You can filter messages by their attributes. The maximum length of a filter is 256 bytes. After creating the subscription, you can't modify the filter.
    Labels map[string]string

    A set of key/value label pairs to assign to this Subscription.

    Note: This field is non-authoritative, and will only manage the labels present in your configuration. Please refer to the field effective_labels for all of the labels present on the resource.

    MessageRetentionDuration string
    How long to retain unacknowledged messages in the subscription's backlog, from the moment a message is published. If retain_acked_messages is true, then this also configures the retention of acknowledged messages, and thus configures how far back in time a subscriptions.seek can be done. Defaults to 7 days. Cannot be more than 7 days ("604800s") or less than 10 minutes ("600s"). A duration in seconds with up to nine fractional digits, terminated by 's'. Example: "600.5s".
    Name string
    Name of the subscription.
    Project string
    The ID of the project in which the resource belongs. If it is not provided, the provider project is used.
    PulumiLabels map[string]string
    The combination of labels configured directly on the resource and default labels configured on the provider.
    PushConfig SubscriptionPushConfigArgs
    If push delivery is used with this subscription, this field is used to configure it. An empty pushConfig signifies that the subscriber will pull and ack messages using API methods. Structure is documented below.
    RetainAckedMessages bool
    Indicates whether to retain acknowledged messages. If true, then messages are not expunged from the subscription's backlog, even if they are acknowledged, until they fall out of the messageRetentionDuration window.
    RetryPolicy SubscriptionRetryPolicyArgs
    A policy that specifies how Pub/Sub retries message delivery for this subscription. If not set, the default retry policy is applied. This generally implies that messages will be retried as soon as possible for healthy subscribers. RetryPolicy will be triggered on NACKs or acknowledgement deadline exceeded events for a given message Structure is documented below.
    Topic string
    A reference to a Topic resource, of the form projects/{project}/topics/{{name}} (as in the id property of a google_pubsub_topic), or just a topic name if the topic is in the same project as the subscription.


    ackDeadlineSeconds Integer
    This value is the maximum time after a subscriber receives a message before the subscriber should acknowledge the message. After message delivery but before the ack deadline expires and before the message is acknowledged, it is an outstanding message and will not be delivered again during that time (on a best-effort basis). For pull subscriptions, this value is used as the initial value for the ack deadline. To override this value for a given message, call subscriptions.modifyAckDeadline with the corresponding ackId if using pull. The minimum custom deadline you can specify is 10 seconds. The maximum custom deadline you can specify is 600 seconds (10 minutes). If this parameter is 0, a default value of 10 seconds is used. For push delivery, this value is also used to set the request timeout for the call to the push endpoint. If the subscriber never acknowledges the message, the Pub/Sub system will eventually redeliver the message.
    bigqueryConfig SubscriptionBigqueryConfig
    If delivery to BigQuery is used with this subscription, this field is used to configure it. Either pushConfig, bigQueryConfig or cloudStorageConfig can be set, but not combined. If all three are empty, then the subscriber will pull and ack messages using API methods. Structure is documented below.
    cloudStorageConfig SubscriptionCloudStorageConfig
    If delivery to Cloud Storage is used with this subscription, this field is used to configure it. Either pushConfig, bigQueryConfig or cloudStorageConfig can be set, but not combined. If all three are empty, then the subscriber will pull and ack messages using API methods. Structure is documented below.
    deadLetterPolicy SubscriptionDeadLetterPolicy
    A policy that specifies the conditions for dead lettering messages in this subscription. If dead_letter_policy is not set, dead lettering is disabled. The Cloud Pub/Sub service account associated with this subscription's parent project (i.e., service-{project_number}@gcp-sa-pubsub.iam.gserviceaccount.com) must have permission to Acknowledge() messages on this subscription. Structure is documented below.
    effectiveLabels Map<String,String>
    All of labels (key/value pairs) present on the resource in GCP, including the labels configured through Pulumi, other clients and services.
    enableExactlyOnceDelivery Boolean
    If true, Pub/Sub provides the following guarantees for the delivery of a message with a given value of messageId on this Subscriptions':

    • The message sent to a subscriber is guaranteed not to be resent before the message's acknowledgement deadline expires.
    • An acknowledged message will not be resent to a subscriber. Note that subscribers may still receive multiple copies of a message when enable_exactly_once_delivery is true if the message was published multiple times by a publisher client. These copies are considered distinct by Pub/Sub and have distinct messageId values
    enableMessageOrdering Boolean
    If true, messages published with the same orderingKey in PubsubMessage will be delivered to the subscribers in the order in which they are received by the Pub/Sub system. Otherwise, they may be delivered in any order.
    expirationPolicy SubscriptionExpirationPolicy
    A policy that specifies the conditions for this subscription's expiration. A subscription is considered active as long as any connected subscriber is successfully consuming messages from the subscription or is issuing operations on the subscription. If expirationPolicy is not set, a default policy with ttl of 31 days will be used. If it is set but ttl is "", the resource never expires. The minimum allowed value for expirationPolicy.ttl is 1 day. Structure is documented below.
    filter String
    The subscription only delivers the messages that match the filter. Pub/Sub automatically acknowledges the messages that don't match the filter. You can filter messages by their attributes. The maximum length of a filter is 256 bytes. After creating the subscription, you can't modify the filter.
    labels Map<String,String>

    A set of key/value label pairs to assign to this Subscription.

    Note: This field is non-authoritative, and will only manage the labels present in your configuration. Please refer to the field effective_labels for all of the labels present on the resource.

    messageRetentionDuration String
    How long to retain unacknowledged messages in the subscription's backlog, from the moment a message is published. If retain_acked_messages is true, then this also configures the retention of acknowledged messages, and thus configures how far back in time a subscriptions.seek can be done. Defaults to 7 days. Cannot be more than 7 days ("604800s") or less than 10 minutes ("600s"). A duration in seconds with up to nine fractional digits, terminated by 's'. Example: "600.5s".
    name String
    Name of the subscription.
    project String
    The ID of the project in which the resource belongs. If it is not provided, the provider project is used.
    pulumiLabels Map<String,String>
    The combination of labels configured directly on the resource and default labels configured on the provider.
    pushConfig SubscriptionPushConfig
    If push delivery is used with this subscription, this field is used to configure it. An empty pushConfig signifies that the subscriber will pull and ack messages using API methods. Structure is documented below.
    retainAckedMessages Boolean
    Indicates whether to retain acknowledged messages. If true, then messages are not expunged from the subscription's backlog, even if they are acknowledged, until they fall out of the messageRetentionDuration window.
    retryPolicy SubscriptionRetryPolicy
    A policy that specifies how Pub/Sub retries message delivery for this subscription. If not set, the default retry policy is applied. This generally implies that messages will be retried as soon as possible for healthy subscribers. RetryPolicy will be triggered on NACKs or acknowledgement deadline exceeded events for a given message Structure is documented below.
    topic String
    A reference to a Topic resource, of the form projects/{project}/topics/{{name}} (as in the id property of a google_pubsub_topic), or just a topic name if the topic is in the same project as the subscription.


    ackDeadlineSeconds number
    This value is the maximum time after a subscriber receives a message before the subscriber should acknowledge the message. After message delivery but before the ack deadline expires and before the message is acknowledged, it is an outstanding message and will not be delivered again during that time (on a best-effort basis). For pull subscriptions, this value is used as the initial value for the ack deadline. To override this value for a given message, call subscriptions.modifyAckDeadline with the corresponding ackId if using pull. The minimum custom deadline you can specify is 10 seconds. The maximum custom deadline you can specify is 600 seconds (10 minutes). If this parameter is 0, a default value of 10 seconds is used. For push delivery, this value is also used to set the request timeout for the call to the push endpoint. If the subscriber never acknowledges the message, the Pub/Sub system will eventually redeliver the message.
    bigqueryConfig SubscriptionBigqueryConfig
    If delivery to BigQuery is used with this subscription, this field is used to configure it. Either pushConfig, bigQueryConfig or cloudStorageConfig can be set, but not combined. If all three are empty, then the subscriber will pull and ack messages using API methods. Structure is documented below.
    cloudStorageConfig SubscriptionCloudStorageConfig
    If delivery to Cloud Storage is used with this subscription, this field is used to configure it. Either pushConfig, bigQueryConfig or cloudStorageConfig can be set, but not combined. If all three are empty, then the subscriber will pull and ack messages using API methods. Structure is documented below.
    deadLetterPolicy SubscriptionDeadLetterPolicy
    A policy that specifies the conditions for dead lettering messages in this subscription. If dead_letter_policy is not set, dead lettering is disabled. The Cloud Pub/Sub service account associated with this subscription's parent project (i.e., service-{project_number}@gcp-sa-pubsub.iam.gserviceaccount.com) must have permission to Acknowledge() messages on this subscription. Structure is documented below.
    effectiveLabels {[key: string]: string}
    All of labels (key/value pairs) present on the resource in GCP, including the labels configured through Pulumi, other clients and services.
    enableExactlyOnceDelivery boolean
    If true, Pub/Sub provides the following guarantees for the delivery of a message with a given value of messageId on this Subscriptions':

    • The message sent to a subscriber is guaranteed not to be resent before the message's acknowledgement deadline expires.
    • An acknowledged message will not be resent to a subscriber. Note that subscribers may still receive multiple copies of a message when enable_exactly_once_delivery is true if the message was published multiple times by a publisher client. These copies are considered distinct by Pub/Sub and have distinct messageId values
    enableMessageOrdering boolean
    If true, messages published with the same orderingKey in PubsubMessage will be delivered to the subscribers in the order in which they are received by the Pub/Sub system. Otherwise, they may be delivered in any order.
    expirationPolicy SubscriptionExpirationPolicy
    A policy that specifies the conditions for this subscription's expiration. A subscription is considered active as long as any connected subscriber is successfully consuming messages from the subscription or is issuing operations on the subscription. If expirationPolicy is not set, a default policy with ttl of 31 days will be used. If it is set but ttl is "", the resource never expires. The minimum allowed value for expirationPolicy.ttl is 1 day. Structure is documented below.
    filter string
    The subscription only delivers the messages that match the filter. Pub/Sub automatically acknowledges the messages that don't match the filter. You can filter messages by their attributes. The maximum length of a filter is 256 bytes. After creating the subscription, you can't modify the filter.
    labels {[key: string]: string}

    A set of key/value label pairs to assign to this Subscription.

    Note: This field is non-authoritative, and will only manage the labels present in your configuration. Please refer to the field effective_labels for all of the labels present on the resource.

    messageRetentionDuration string
    How long to retain unacknowledged messages in the subscription's backlog, from the moment a message is published. If retain_acked_messages is true, then this also configures the retention of acknowledged messages, and thus configures how far back in time a subscriptions.seek can be done. Defaults to 7 days. Cannot be more than 7 days ("604800s") or less than 10 minutes ("600s"). A duration in seconds with up to nine fractional digits, terminated by 's'. Example: "600.5s".
    name string
    Name of the subscription.
    project string
    The ID of the project in which the resource belongs. If it is not provided, the provider project is used.
    pulumiLabels {[key: string]: string}
    The combination of labels configured directly on the resource and default labels configured on the provider.
    pushConfig SubscriptionPushConfig
    If push delivery is used with this subscription, this field is used to configure it. An empty pushConfig signifies that the subscriber will pull and ack messages using API methods. Structure is documented below.
    retainAckedMessages boolean
    Indicates whether to retain acknowledged messages. If true, then messages are not expunged from the subscription's backlog, even if they are acknowledged, until they fall out of the messageRetentionDuration window.
    retryPolicy SubscriptionRetryPolicy
    A policy that specifies how Pub/Sub retries message delivery for this subscription. If not set, the default retry policy is applied. This generally implies that messages will be retried as soon as possible for healthy subscribers. RetryPolicy will be triggered on NACKs or acknowledgement deadline exceeded events for a given message Structure is documented below.
    topic string
    A reference to a Topic resource, of the form projects/{project}/topics/{{name}} (as in the id property of a google_pubsub_topic), or just a topic name if the topic is in the same project as the subscription.


    ack_deadline_seconds int
    This value is the maximum time after a subscriber receives a message before the subscriber should acknowledge the message. After message delivery but before the ack deadline expires and before the message is acknowledged, it is an outstanding message and will not be delivered again during that time (on a best-effort basis). For pull subscriptions, this value is used as the initial value for the ack deadline. To override this value for a given message, call subscriptions.modifyAckDeadline with the corresponding ackId if using pull. The minimum custom deadline you can specify is 10 seconds. The maximum custom deadline you can specify is 600 seconds (10 minutes). If this parameter is 0, a default value of 10 seconds is used. For push delivery, this value is also used to set the request timeout for the call to the push endpoint. If the subscriber never acknowledges the message, the Pub/Sub system will eventually redeliver the message.
    bigquery_config SubscriptionBigqueryConfigArgs
    If delivery to BigQuery is used with this subscription, this field is used to configure it. Either pushConfig, bigQueryConfig or cloudStorageConfig can be set, but not combined. If all three are empty, then the subscriber will pull and ack messages using API methods. Structure is documented below.
    cloud_storage_config SubscriptionCloudStorageConfigArgs
    If delivery to Cloud Storage is used with this subscription, this field is used to configure it. Either pushConfig, bigQueryConfig or cloudStorageConfig can be set, but not combined. If all three are empty, then the subscriber will pull and ack messages using API methods. Structure is documented below.
    dead_letter_policy SubscriptionDeadLetterPolicyArgs
    A policy that specifies the conditions for dead lettering messages in this subscription. If dead_letter_policy is not set, dead lettering is disabled. The Cloud Pub/Sub service account associated with this subscription's parent project (i.e., service-{project_number}@gcp-sa-pubsub.iam.gserviceaccount.com) must have permission to Acknowledge() messages on this subscription. Structure is documented below.
    effective_labels Mapping[str, str]
    All of labels (key/value pairs) present on the resource in GCP, including the labels configured through Pulumi, other clients and services.
    enable_exactly_once_delivery bool
    If true, Pub/Sub provides the following guarantees for the delivery of a message with a given value of messageId on this Subscriptions':

    • The message sent to a subscriber is guaranteed not to be resent before the message's acknowledgement deadline expires.
    • An acknowledged message will not be resent to a subscriber. Note that subscribers may still receive multiple copies of a message when enable_exactly_once_delivery is true if the message was published multiple times by a publisher client. These copies are considered distinct by Pub/Sub and have distinct messageId values
    enable_message_ordering bool
    If true, messages published with the same orderingKey in PubsubMessage will be delivered to the subscribers in the order in which they are received by the Pub/Sub system. Otherwise, they may be delivered in any order.
    expiration_policy SubscriptionExpirationPolicyArgs
    A policy that specifies the conditions for this subscription's expiration. A subscription is considered active as long as any connected subscriber is successfully consuming messages from the subscription or is issuing operations on the subscription. If expirationPolicy is not set, a default policy with ttl of 31 days will be used. If it is set but ttl is "", the resource never expires. The minimum allowed value for expirationPolicy.ttl is 1 day. Structure is documented below.
    filter str
    The subscription only delivers the messages that match the filter. Pub/Sub automatically acknowledges the messages that don't match the filter. You can filter messages by their attributes. The maximum length of a filter is 256 bytes. After creating the subscription, you can't modify the filter.
    labels Mapping[str, str]

    A set of key/value label pairs to assign to this Subscription.

    Note: This field is non-authoritative, and will only manage the labels present in your configuration. Please refer to the field effective_labels for all of the labels present on the resource.

    message_retention_duration str
    How long to retain unacknowledged messages in the subscription's backlog, from the moment a message is published. If retain_acked_messages is true, then this also configures the retention of acknowledged messages, and thus configures how far back in time a subscriptions.seek can be done. Defaults to 7 days. Cannot be more than 7 days ("604800s") or less than 10 minutes ("600s"). A duration in seconds with up to nine fractional digits, terminated by 's'. Example: "600.5s".
    name str
    Name of the subscription.
    project str
    The ID of the project in which the resource belongs. If it is not provided, the provider project is used.
    pulumi_labels Mapping[str, str]
    The combination of labels configured directly on the resource and default labels configured on the provider.
    push_config SubscriptionPushConfigArgs
    If push delivery is used with this subscription, this field is used to configure it. An empty pushConfig signifies that the subscriber will pull and ack messages using API methods. Structure is documented below.
    retain_acked_messages bool
    Indicates whether to retain acknowledged messages. If true, then messages are not expunged from the subscription's backlog, even if they are acknowledged, until they fall out of the messageRetentionDuration window.
    retry_policy SubscriptionRetryPolicyArgs
    A policy that specifies how Pub/Sub retries message delivery for this subscription. If not set, the default retry policy is applied. This generally implies that messages will be retried as soon as possible for healthy subscribers. RetryPolicy will be triggered on NACKs or acknowledgement deadline exceeded events for a given message Structure is documented below.
    topic str
    A reference to a Topic resource, of the form projects/{project}/topics/{{name}} (as in the id property of a google_pubsub_topic), or just a topic name if the topic is in the same project as the subscription.


    ackDeadlineSeconds Number
    This value is the maximum time after a subscriber receives a message before the subscriber should acknowledge the message. After message delivery but before the ack deadline expires and before the message is acknowledged, it is an outstanding message and will not be delivered again during that time (on a best-effort basis). For pull subscriptions, this value is used as the initial value for the ack deadline. To override this value for a given message, call subscriptions.modifyAckDeadline with the corresponding ackId if using pull. The minimum custom deadline you can specify is 10 seconds. The maximum custom deadline you can specify is 600 seconds (10 minutes). If this parameter is 0, a default value of 10 seconds is used. For push delivery, this value is also used to set the request timeout for the call to the push endpoint. If the subscriber never acknowledges the message, the Pub/Sub system will eventually redeliver the message.
    bigqueryConfig Property Map
    If delivery to BigQuery is used with this subscription, this field is used to configure it. Either pushConfig, bigQueryConfig or cloudStorageConfig can be set, but not combined. If all three are empty, then the subscriber will pull and ack messages using API methods. Structure is documented below.
    cloudStorageConfig Property Map
    If delivery to Cloud Storage is used with this subscription, this field is used to configure it. Either pushConfig, bigQueryConfig or cloudStorageConfig can be set, but not combined. If all three are empty, then the subscriber will pull and ack messages using API methods. Structure is documented below.
    deadLetterPolicy Property Map
    A policy that specifies the conditions for dead lettering messages in this subscription. If dead_letter_policy is not set, dead lettering is disabled. The Cloud Pub/Sub service account associated with this subscription's parent project (i.e., service-{project_number}@gcp-sa-pubsub.iam.gserviceaccount.com) must have permission to Acknowledge() messages on this subscription. Structure is documented below.
    effectiveLabels Map<String>
    All of labels (key/value pairs) present on the resource in GCP, including the labels configured through Pulumi, other clients and services.
    enableExactlyOnceDelivery Boolean
    If true, Pub/Sub provides the following guarantees for the delivery of a message with a given value of messageId on this Subscriptions':

    • The message sent to a subscriber is guaranteed not to be resent before the message's acknowledgement deadline expires.
    • An acknowledged message will not be resent to a subscriber. Note that subscribers may still receive multiple copies of a message when enable_exactly_once_delivery is true if the message was published multiple times by a publisher client. These copies are considered distinct by Pub/Sub and have distinct messageId values
    enableMessageOrdering Boolean
    If true, messages published with the same orderingKey in PubsubMessage will be delivered to the subscribers in the order in which they are received by the Pub/Sub system. Otherwise, they may be delivered in any order.
    expirationPolicy Property Map
    A policy that specifies the conditions for this subscription's expiration. A subscription is considered active as long as any connected subscriber is successfully consuming messages from the subscription or is issuing operations on the subscription. If expirationPolicy is not set, a default policy with ttl of 31 days will be used. If it is set but ttl is "", the resource never expires. The minimum allowed value for expirationPolicy.ttl is 1 day. Structure is documented below.
    filter String
    The subscription only delivers the messages that match the filter. Pub/Sub automatically acknowledges the messages that don't match the filter. You can filter messages by their attributes. The maximum length of a filter is 256 bytes. After creating the subscription, you can't modify the filter.
    labels Map<String>

    A set of key/value label pairs to assign to this Subscription.

    Note: This field is non-authoritative, and will only manage the labels present in your configuration. Please refer to the field effective_labels for all of the labels present on the resource.

    messageRetentionDuration String
    How long to retain unacknowledged messages in the subscription's backlog, from the moment a message is published. If retain_acked_messages is true, then this also configures the retention of acknowledged messages, and thus configures how far back in time a subscriptions.seek can be done. Defaults to 7 days. Cannot be more than 7 days ("604800s") or less than 10 minutes ("600s"). A duration in seconds with up to nine fractional digits, terminated by 's'. Example: "600.5s".
    name String
    Name of the subscription.
    project String
    The ID of the project in which the resource belongs. If it is not provided, the provider project is used.
    pulumiLabels Map<String>
    The combination of labels configured directly on the resource and default labels configured on the provider.
    pushConfig Property Map
    If push delivery is used with this subscription, this field is used to configure it. An empty pushConfig signifies that the subscriber will pull and ack messages using API methods. Structure is documented below.
    retainAckedMessages Boolean
    Indicates whether to retain acknowledged messages. If true, then messages are not expunged from the subscription's backlog, even if they are acknowledged, until they fall out of the messageRetentionDuration window.
    retryPolicy Property Map
    A policy that specifies how Pub/Sub retries message delivery for this subscription. If not set, the default retry policy is applied. This generally implies that messages will be retried as soon as possible for healthy subscribers. RetryPolicy will be triggered on NACKs or acknowledgement deadline exceeded events for a given message Structure is documented below.
    topic String
    A reference to a Topic resource, of the form projects/{project}/topics/{{name}} (as in the id property of a google_pubsub_topic), or just a topic name if the topic is in the same project as the subscription.


    Supporting Types

    SubscriptionBigqueryConfig, SubscriptionBigqueryConfigArgs

    Table string
    The name of the table to which to write data, of the form {projectId}:{datasetId}.{tableId}
    DropUnknownFields bool
    When true and use_topic_schema or use_table_schema is true, any fields that are a part of the topic schema or message schema that are not part of the BigQuery table schema are dropped when writing to BigQuery. Otherwise, the schemas must be kept in sync and any messages with extra fields are not written and remain in the subscription's backlog.
    UseTableSchema bool
    When true, use the BigQuery table's schema as the columns to write to in BigQuery. Messages must be published in JSON format. Only one of use_topic_schema and use_table_schema can be set.
    UseTopicSchema bool
    When true, use the topic's schema as the columns to write to in BigQuery, if it exists. Only one of use_topic_schema and use_table_schema can be set.
    WriteMetadata bool
    When true, write the subscription name, messageId, publishTime, attributes, and orderingKey to additional columns in the table. The subscription name, messageId, and publishTime fields are put in their own columns while all other message properties (other than data) are written to a JSON object in the attributes column.
    Table string
    The name of the table to which to write data, of the form {projectId}:{datasetId}.{tableId}
    DropUnknownFields bool
    When true and use_topic_schema or use_table_schema is true, any fields that are a part of the topic schema or message schema that are not part of the BigQuery table schema are dropped when writing to BigQuery. Otherwise, the schemas must be kept in sync and any messages with extra fields are not written and remain in the subscription's backlog.
    UseTableSchema bool
    When true, use the BigQuery table's schema as the columns to write to in BigQuery. Messages must be published in JSON format. Only one of use_topic_schema and use_table_schema can be set.
    UseTopicSchema bool
    When true, use the topic's schema as the columns to write to in BigQuery, if it exists. Only one of use_topic_schema and use_table_schema can be set.
    WriteMetadata bool
    When true, write the subscription name, messageId, publishTime, attributes, and orderingKey to additional columns in the table. The subscription name, messageId, and publishTime fields are put in their own columns while all other message properties (other than data) are written to a JSON object in the attributes column.
    table String
    The name of the table to which to write data, of the form {projectId}:{datasetId}.{tableId}
    dropUnknownFields Boolean
    When true and use_topic_schema or use_table_schema is true, any fields that are a part of the topic schema or message schema that are not part of the BigQuery table schema are dropped when writing to BigQuery. Otherwise, the schemas must be kept in sync and any messages with extra fields are not written and remain in the subscription's backlog.
    useTableSchema Boolean
    When true, use the BigQuery table's schema as the columns to write to in BigQuery. Messages must be published in JSON format. Only one of use_topic_schema and use_table_schema can be set.
    useTopicSchema Boolean
    When true, use the topic's schema as the columns to write to in BigQuery, if it exists. Only one of use_topic_schema and use_table_schema can be set.
    writeMetadata Boolean
    When true, write the subscription name, messageId, publishTime, attributes, and orderingKey to additional columns in the table. The subscription name, messageId, and publishTime fields are put in their own columns while all other message properties (other than data) are written to a JSON object in the attributes column.
    table string
    The name of the table to which to write data, of the form {projectId}:{datasetId}.{tableId}
    dropUnknownFields boolean
    When true and use_topic_schema or use_table_schema is true, any fields that are a part of the topic schema or message schema that are not part of the BigQuery table schema are dropped when writing to BigQuery. Otherwise, the schemas must be kept in sync and any messages with extra fields are not written and remain in the subscription's backlog.
    useTableSchema boolean
    When true, use the BigQuery table's schema as the columns to write to in BigQuery. Messages must be published in JSON format. Only one of use_topic_schema and use_table_schema can be set.
    useTopicSchema boolean
    When true, use the topic's schema as the columns to write to in BigQuery, if it exists. Only one of use_topic_schema and use_table_schema can be set.
    writeMetadata boolean
    When true, write the subscription name, messageId, publishTime, attributes, and orderingKey to additional columns in the table. The subscription name, messageId, and publishTime fields are put in their own columns while all other message properties (other than data) are written to a JSON object in the attributes column.
    table str
    The name of the table to which to write data, of the form {projectId}:{datasetId}.{tableId}
    drop_unknown_fields bool
    When true and use_topic_schema or use_table_schema is true, any fields that are a part of the topic schema or message schema that are not part of the BigQuery table schema are dropped when writing to BigQuery. Otherwise, the schemas must be kept in sync and any messages with extra fields are not written and remain in the subscription's backlog.
    use_table_schema bool
    When true, use the BigQuery table's schema as the columns to write to in BigQuery. Messages must be published in JSON format. Only one of use_topic_schema and use_table_schema can be set.
    use_topic_schema bool
    When true, use the topic's schema as the columns to write to in BigQuery, if it exists. Only one of use_topic_schema and use_table_schema can be set.
    write_metadata bool
    When true, write the subscription name, messageId, publishTime, attributes, and orderingKey to additional columns in the table. The subscription name, messageId, and publishTime fields are put in their own columns while all other message properties (other than data) are written to a JSON object in the attributes column.
    table String
    The name of the table to which to write data, of the form {projectId}:{datasetId}.{tableId}
    dropUnknownFields Boolean
    When true and use_topic_schema or use_table_schema is true, any fields that are a part of the topic schema or message schema that are not part of the BigQuery table schema are dropped when writing to BigQuery. Otherwise, the schemas must be kept in sync and any messages with extra fields are not written and remain in the subscription's backlog.
    useTableSchema Boolean
    When true, use the BigQuery table's schema as the columns to write to in BigQuery. Messages must be published in JSON format. Only one of use_topic_schema and use_table_schema can be set.
    useTopicSchema Boolean
    When true, use the topic's schema as the columns to write to in BigQuery, if it exists. Only one of use_topic_schema and use_table_schema can be set.
    writeMetadata Boolean
    When true, write the subscription name, messageId, publishTime, attributes, and orderingKey to additional columns in the table. The subscription name, messageId, and publishTime fields are put in their own columns while all other message properties (other than data) are written to a JSON object in the attributes column.

    SubscriptionCloudStorageConfig, SubscriptionCloudStorageConfigArgs

    Bucket string
    User-provided name for the Cloud Storage bucket. The bucket must be created by the user. The bucket name must be without any prefix like "gs://".
    AvroConfig SubscriptionCloudStorageConfigAvroConfig
    If set, message data will be written to Cloud Storage in Avro format. Structure is documented below.
    FilenamePrefix string
    User-provided prefix for Cloud Storage filename.
    FilenameSuffix string
    User-provided suffix for Cloud Storage filename. Must not end in "/".
    MaxBytes int
    The maximum bytes that can be written to a Cloud Storage file before a new file is created. Min 1 KB, max 10 GiB. The maxBytes limit may be exceeded in cases where messages are larger than the limit.
    MaxDuration string
    The maximum duration that can elapse before a new Cloud Storage file is created. Min 1 minute, max 10 minutes, default 5 minutes. May not exceed the subscription's acknowledgement deadline. A duration in seconds with up to nine fractional digits, ending with 's'. Example: "3.5s".
    State string
    (Output) An output-only field that indicates whether or not the subscription can receive messages.
    Bucket string
    User-provided name for the Cloud Storage bucket. The bucket must be created by the user. The bucket name must be without any prefix like "gs://".
    AvroConfig SubscriptionCloudStorageConfigAvroConfig
    If set, message data will be written to Cloud Storage in Avro format. Structure is documented below.
    FilenamePrefix string
    User-provided prefix for Cloud Storage filename.
    FilenameSuffix string
    User-provided suffix for Cloud Storage filename. Must not end in "/".
    MaxBytes int
    The maximum bytes that can be written to a Cloud Storage file before a new file is created. Min 1 KB, max 10 GiB. The maxBytes limit may be exceeded in cases where messages are larger than the limit.
    MaxDuration string
    The maximum duration that can elapse before a new Cloud Storage file is created. Min 1 minute, max 10 minutes, default 5 minutes. May not exceed the subscription's acknowledgement deadline. A duration in seconds with up to nine fractional digits, ending with 's'. Example: "3.5s".
    State string
    (Output) An output-only field that indicates whether or not the subscription can receive messages.
    bucket String
    User-provided name for the Cloud Storage bucket. The bucket must be created by the user. The bucket name must be without any prefix like "gs://".
    avroConfig SubscriptionCloudStorageConfigAvroConfig
    If set, message data will be written to Cloud Storage in Avro format. Structure is documented below.
    filenamePrefix String
    User-provided prefix for Cloud Storage filename.
    filenameSuffix String
    User-provided suffix for Cloud Storage filename. Must not end in "/".
    maxBytes Integer
    The maximum bytes that can be written to a Cloud Storage file before a new file is created. Min 1 KB, max 10 GiB. The maxBytes limit may be exceeded in cases where messages are larger than the limit.
    maxDuration String
    The maximum duration that can elapse before a new Cloud Storage file is created. Min 1 minute, max 10 minutes, default 5 minutes. May not exceed the subscription's acknowledgement deadline. A duration in seconds with up to nine fractional digits, ending with 's'. Example: "3.5s".
    state String
    (Output) An output-only field that indicates whether or not the subscription can receive messages.
    bucket string
    User-provided name for the Cloud Storage bucket. The bucket must be created by the user. The bucket name must be without any prefix like "gs://".
    avroConfig SubscriptionCloudStorageConfigAvroConfig
    If set, message data will be written to Cloud Storage in Avro format. Structure is documented below.
    filenamePrefix string
    User-provided prefix for Cloud Storage filename.
    filenameSuffix string
    User-provided suffix for Cloud Storage filename. Must not end in "/".
    maxBytes number
    The maximum bytes that can be written to a Cloud Storage file before a new file is created. Min 1 KB, max 10 GiB. The maxBytes limit may be exceeded in cases where messages are larger than the limit.
    maxDuration string
    The maximum duration that can elapse before a new Cloud Storage file is created. Min 1 minute, max 10 minutes, default 5 minutes. May not exceed the subscription's acknowledgement deadline. A duration in seconds with up to nine fractional digits, ending with 's'. Example: "3.5s".
    state string
    (Output) An output-only field that indicates whether or not the subscription can receive messages.
    bucket str
    User-provided name for the Cloud Storage bucket. The bucket must be created by the user. The bucket name must be without any prefix like "gs://".
    avro_config SubscriptionCloudStorageConfigAvroConfig
    If set, message data will be written to Cloud Storage in Avro format. Structure is documented below.
    filename_prefix str
    User-provided prefix for Cloud Storage filename.
    filename_suffix str
    User-provided suffix for Cloud Storage filename. Must not end in "/".
    max_bytes int
    The maximum bytes that can be written to a Cloud Storage file before a new file is created. Min 1 KB, max 10 GiB. The maxBytes limit may be exceeded in cases where messages are larger than the limit.
    max_duration str
    The maximum duration that can elapse before a new Cloud Storage file is created. Min 1 minute, max 10 minutes, default 5 minutes. May not exceed the subscription's acknowledgement deadline. A duration in seconds with up to nine fractional digits, ending with 's'. Example: "3.5s".
    state str
    (Output) An output-only field that indicates whether or not the subscription can receive messages.
    bucket String
    User-provided name for the Cloud Storage bucket. The bucket must be created by the user. The bucket name must be without any prefix like "gs://".
    avroConfig Property Map
    If set, message data will be written to Cloud Storage in Avro format. Structure is documented below.
    filenamePrefix String
    User-provided prefix for Cloud Storage filename.
    filenameSuffix String
    User-provided suffix for Cloud Storage filename. Must not end in "/".
    maxBytes Number
    The maximum bytes that can be written to a Cloud Storage file before a new file is created. Min 1 KB, max 10 GiB. The maxBytes limit may be exceeded in cases where messages are larger than the limit.
    maxDuration String
    The maximum duration that can elapse before a new Cloud Storage file is created. Min 1 minute, max 10 minutes, default 5 minutes. May not exceed the subscription's acknowledgement deadline. A duration in seconds with up to nine fractional digits, ending with 's'. Example: "3.5s".
    state String
    (Output) An output-only field that indicates whether or not the subscription can receive messages.

    SubscriptionCloudStorageConfigAvroConfig, SubscriptionCloudStorageConfigAvroConfigArgs

    WriteMetadata bool
    When true, write the subscription name, messageId, publishTime, attributes, and orderingKey as additional fields in the output.
    WriteMetadata bool
    When true, write the subscription name, messageId, publishTime, attributes, and orderingKey as additional fields in the output.
    writeMetadata Boolean
    When true, write the subscription name, messageId, publishTime, attributes, and orderingKey as additional fields in the output.
    writeMetadata boolean
    When true, write the subscription name, messageId, publishTime, attributes, and orderingKey as additional fields in the output.
    write_metadata bool
    When true, write the subscription name, messageId, publishTime, attributes, and orderingKey as additional fields in the output.
    writeMetadata Boolean
    When true, write the subscription name, messageId, publishTime, attributes, and orderingKey as additional fields in the output.

    SubscriptionDeadLetterPolicy, SubscriptionDeadLetterPolicyArgs

    DeadLetterTopic string
    The name of the topic to which dead letter messages should be published. Format is projects/{project}/topics/{topic}. The Cloud Pub/Sub service account associated with the enclosing subscription's parent project (i.e., service-{project_number}@gcp-sa-pubsub.iam.gserviceaccount.com) must have permission to Publish() to this topic. The operation will fail if the topic does not exist. Users should ensure that there is a subscription attached to this topic since messages published to a topic with no subscriptions are lost.
    MaxDeliveryAttempts int
    The maximum number of delivery attempts for any message. The value must be between 5 and 100. The number of delivery attempts is defined as 1 + (the sum of number of NACKs and number of times the acknowledgement deadline has been exceeded for the message). A NACK is any call to ModifyAckDeadline with a 0 deadline. Note that client libraries may automatically extend ack_deadlines. This field will be honored on a best effort basis. If this parameter is 0, a default value of 5 is used.
    DeadLetterTopic string
    The name of the topic to which dead letter messages should be published. Format is projects/{project}/topics/{topic}. The Cloud Pub/Sub service account associated with the enclosing subscription's parent project (i.e., service-{project_number}@gcp-sa-pubsub.iam.gserviceaccount.com) must have permission to Publish() to this topic. The operation will fail if the topic does not exist. Users should ensure that there is a subscription attached to this topic since messages published to a topic with no subscriptions are lost.
    MaxDeliveryAttempts int
    The maximum number of delivery attempts for any message. The value must be between 5 and 100. The number of delivery attempts is defined as 1 + (the sum of number of NACKs and number of times the acknowledgement deadline has been exceeded for the message). A NACK is any call to ModifyAckDeadline with a 0 deadline. Note that client libraries may automatically extend ack_deadlines. This field will be honored on a best effort basis. If this parameter is 0, a default value of 5 is used.
    deadLetterTopic String
    The name of the topic to which dead letter messages should be published. Format is projects/{project}/topics/{topic}. The Cloud Pub/Sub service account associated with the enclosing subscription's parent project (i.e., service-{project_number}@gcp-sa-pubsub.iam.gserviceaccount.com) must have permission to Publish() to this topic. The operation will fail if the topic does not exist. Users should ensure that there is a subscription attached to this topic since messages published to a topic with no subscriptions are lost.
    maxDeliveryAttempts Integer
    The maximum number of delivery attempts for any message. The value must be between 5 and 100. The number of delivery attempts is defined as 1 + (the sum of number of NACKs and number of times the acknowledgement deadline has been exceeded for the message). A NACK is any call to ModifyAckDeadline with a 0 deadline. Note that client libraries may automatically extend ack_deadlines. This field will be honored on a best effort basis. If this parameter is 0, a default value of 5 is used.
    deadLetterTopic string
    The name of the topic to which dead letter messages should be published. Format is projects/{project}/topics/{topic}. The Cloud Pub/Sub service account associated with the enclosing subscription's parent project (i.e., service-{project_number}@gcp-sa-pubsub.iam.gserviceaccount.com) must have permission to Publish() to this topic. The operation will fail if the topic does not exist. Users should ensure that there is a subscription attached to this topic since messages published to a topic with no subscriptions are lost.
    maxDeliveryAttempts number
    The maximum number of delivery attempts for any message. The value must be between 5 and 100. The number of delivery attempts is defined as 1 + (the sum of number of NACKs and number of times the acknowledgement deadline has been exceeded for the message). A NACK is any call to ModifyAckDeadline with a 0 deadline. Note that client libraries may automatically extend ack_deadlines. This field will be honored on a best effort basis. If this parameter is 0, a default value of 5 is used.
    dead_letter_topic str
    The name of the topic to which dead letter messages should be published. Format is projects/{project}/topics/{topic}. The Cloud Pub/Sub service account associated with the enclosing subscription's parent project (i.e., service-{project_number}@gcp-sa-pubsub.iam.gserviceaccount.com) must have permission to Publish() to this topic. The operation will fail if the topic does not exist. Users should ensure that there is a subscription attached to this topic since messages published to a topic with no subscriptions are lost.
    max_delivery_attempts int
    The maximum number of delivery attempts for any message. The value must be between 5 and 100. The number of delivery attempts is defined as 1 + (the sum of number of NACKs and number of times the acknowledgement deadline has been exceeded for the message). A NACK is any call to ModifyAckDeadline with a 0 deadline. Note that client libraries may automatically extend ack_deadlines. This field will be honored on a best effort basis. If this parameter is 0, a default value of 5 is used.
    deadLetterTopic String
    The name of the topic to which dead letter messages should be published. Format is projects/{project}/topics/{topic}. The Cloud Pub/Sub service account associated with the enclosing subscription's parent project (i.e., service-{project_number}@gcp-sa-pubsub.iam.gserviceaccount.com) must have permission to Publish() to this topic. The operation will fail if the topic does not exist. Users should ensure that there is a subscription attached to this topic since messages published to a topic with no subscriptions are lost.
    maxDeliveryAttempts Number
    The maximum number of delivery attempts for any message. The value must be between 5 and 100. The number of delivery attempts is defined as 1 + (the sum of number of NACKs and number of times the acknowledgement deadline has been exceeded for the message). A NACK is any call to ModifyAckDeadline with a 0 deadline. Note that client libraries may automatically extend ack_deadlines. This field will be honored on a best effort basis. If this parameter is 0, a default value of 5 is used.

    SubscriptionExpirationPolicy, SubscriptionExpirationPolicyArgs

    Ttl string
    Specifies the "time-to-live" duration for an associated resource. The resource expires if it is not active for a period of ttl. If ttl is set to "", the associated resource never expires. A duration in seconds with up to nine fractional digits, terminated by 's'. Example - "3.5s".
    Ttl string
    Specifies the "time-to-live" duration for an associated resource. The resource expires if it is not active for a period of ttl. If ttl is set to "", the associated resource never expires. A duration in seconds with up to nine fractional digits, terminated by 's'. Example - "3.5s".
    ttl String
    Specifies the "time-to-live" duration for an associated resource. The resource expires if it is not active for a period of ttl. If ttl is set to "", the associated resource never expires. A duration in seconds with up to nine fractional digits, terminated by 's'. Example - "3.5s".
    ttl string
    Specifies the "time-to-live" duration for an associated resource. The resource expires if it is not active for a period of ttl. If ttl is set to "", the associated resource never expires. A duration in seconds with up to nine fractional digits, terminated by 's'. Example - "3.5s".
    ttl str
    Specifies the "time-to-live" duration for an associated resource. The resource expires if it is not active for a period of ttl. If ttl is set to "", the associated resource never expires. A duration in seconds with up to nine fractional digits, terminated by 's'. Example - "3.5s".
    ttl String
    Specifies the "time-to-live" duration for an associated resource. The resource expires if it is not active for a period of ttl. If ttl is set to "", the associated resource never expires. A duration in seconds with up to nine fractional digits, terminated by 's'. Example - "3.5s".

    SubscriptionPushConfig, SubscriptionPushConfigArgs

    PushEndpoint string
    A URL locating the endpoint to which messages should be pushed. For example, a Webhook endpoint might use "https://example.com/push".
    Attributes Dictionary<string, string>
    Endpoint configuration attributes. Every endpoint has a set of API supported attributes that can be used to control different aspects of the message delivery. The currently supported attribute is x-goog-version, which you can use to change the format of the pushed message. This attribute indicates the version of the data expected by the endpoint. This controls the shape of the pushed message (i.e., its fields and metadata). The endpoint version is based on the version of the Pub/Sub API. If not present during the subscriptions.create call, it will default to the version of the API used to make such call. If not present during a subscriptions.modifyPushConfig call, its value will not be changed. subscriptions.get calls will always return a valid version, even if the subscription was created without this attribute. The possible values for this attribute are:

    • v1beta1: uses the push format defined in the v1beta1 Pub/Sub API.
    • v1 or v1beta2: uses the push format defined in the v1 Pub/Sub API.
    NoWrapper SubscriptionPushConfigNoWrapper
    When set, the payload to the push endpoint is not wrapped.Sets the data field as the HTTP body for delivery. Structure is documented below.
    OidcToken SubscriptionPushConfigOidcToken
    If specified, Pub/Sub will generate and attach an OIDC JWT token as an Authorization header in the HTTP request for every pushed message. Structure is documented below.
    PushEndpoint string
    A URL locating the endpoint to which messages should be pushed. For example, a Webhook endpoint might use "https://example.com/push".
    Attributes map[string]string
    Endpoint configuration attributes. Every endpoint has a set of API supported attributes that can be used to control different aspects of the message delivery. The currently supported attribute is x-goog-version, which you can use to change the format of the pushed message. This attribute indicates the version of the data expected by the endpoint. This controls the shape of the pushed message (i.e., its fields and metadata). The endpoint version is based on the version of the Pub/Sub API. If not present during the subscriptions.create call, it will default to the version of the API used to make such call. If not present during a subscriptions.modifyPushConfig call, its value will not be changed. subscriptions.get calls will always return a valid version, even if the subscription was created without this attribute. The possible values for this attribute are:

    • v1beta1: uses the push format defined in the v1beta1 Pub/Sub API.
    • v1 or v1beta2: uses the push format defined in the v1 Pub/Sub API.
    NoWrapper SubscriptionPushConfigNoWrapper
    When set, the payload to the push endpoint is not wrapped.Sets the data field as the HTTP body for delivery. Structure is documented below.
    OidcToken SubscriptionPushConfigOidcToken
    If specified, Pub/Sub will generate and attach an OIDC JWT token as an Authorization header in the HTTP request for every pushed message. Structure is documented below.
    pushEndpoint String
    A URL locating the endpoint to which messages should be pushed. For example, a Webhook endpoint might use "https://example.com/push".
    attributes Map<String,String>
    Endpoint configuration attributes. Every endpoint has a set of API supported attributes that can be used to control different aspects of the message delivery. The currently supported attribute is x-goog-version, which you can use to change the format of the pushed message. This attribute indicates the version of the data expected by the endpoint. This controls the shape of the pushed message (i.e., its fields and metadata). The endpoint version is based on the version of the Pub/Sub API. If not present during the subscriptions.create call, it will default to the version of the API used to make such call. If not present during a subscriptions.modifyPushConfig call, its value will not be changed. subscriptions.get calls will always return a valid version, even if the subscription was created without this attribute. The possible values for this attribute are:

    • v1beta1: uses the push format defined in the v1beta1 Pub/Sub API.
    • v1 or v1beta2: uses the push format defined in the v1 Pub/Sub API.
    noWrapper SubscriptionPushConfigNoWrapper
    When set, the payload to the push endpoint is not wrapped.Sets the data field as the HTTP body for delivery. Structure is documented below.
    oidcToken SubscriptionPushConfigOidcToken
    If specified, Pub/Sub will generate and attach an OIDC JWT token as an Authorization header in the HTTP request for every pushed message. Structure is documented below.
    pushEndpoint string
    A URL locating the endpoint to which messages should be pushed. For example, a Webhook endpoint might use "https://example.com/push".
    attributes {[key: string]: string}
    Endpoint configuration attributes. Every endpoint has a set of API supported attributes that can be used to control different aspects of the message delivery. The currently supported attribute is x-goog-version, which you can use to change the format of the pushed message. This attribute indicates the version of the data expected by the endpoint. This controls the shape of the pushed message (i.e., its fields and metadata). The endpoint version is based on the version of the Pub/Sub API. If not present during the subscriptions.create call, it will default to the version of the API used to make such call. If not present during a subscriptions.modifyPushConfig call, its value will not be changed. subscriptions.get calls will always return a valid version, even if the subscription was created without this attribute. The possible values for this attribute are:

    • v1beta1: uses the push format defined in the v1beta1 Pub/Sub API.
    • v1 or v1beta2: uses the push format defined in the v1 Pub/Sub API.
    noWrapper SubscriptionPushConfigNoWrapper
    When set, the payload to the push endpoint is not wrapped.Sets the data field as the HTTP body for delivery. Structure is documented below.
    oidcToken SubscriptionPushConfigOidcToken
    If specified, Pub/Sub will generate and attach an OIDC JWT token as an Authorization header in the HTTP request for every pushed message. Structure is documented below.
    push_endpoint str
    A URL locating the endpoint to which messages should be pushed. For example, a Webhook endpoint might use "https://example.com/push".
    attributes Mapping[str, str]
    Endpoint configuration attributes. Every endpoint has a set of API supported attributes that can be used to control different aspects of the message delivery. The currently supported attribute is x-goog-version, which you can use to change the format of the pushed message. This attribute indicates the version of the data expected by the endpoint. This controls the shape of the pushed message (i.e., its fields and metadata). The endpoint version is based on the version of the Pub/Sub API. If not present during the subscriptions.create call, it will default to the version of the API used to make such call. If not present during a subscriptions.modifyPushConfig call, its value will not be changed. subscriptions.get calls will always return a valid version, even if the subscription was created without this attribute. The possible values for this attribute are:

    • v1beta1: uses the push format defined in the v1beta1 Pub/Sub API.
    • v1 or v1beta2: uses the push format defined in the v1 Pub/Sub API.
    no_wrapper SubscriptionPushConfigNoWrapper
    When set, the payload to the push endpoint is not wrapped.Sets the data field as the HTTP body for delivery. Structure is documented below.
    oidc_token SubscriptionPushConfigOidcToken
    If specified, Pub/Sub will generate and attach an OIDC JWT token as an Authorization header in the HTTP request for every pushed message. Structure is documented below.
    pushEndpoint String
    A URL locating the endpoint to which messages should be pushed. For example, a Webhook endpoint might use "https://example.com/push".
    attributes Map<String>
    Endpoint configuration attributes. Every endpoint has a set of API supported attributes that can be used to control different aspects of the message delivery. The currently supported attribute is x-goog-version, which you can use to change the format of the pushed message. This attribute indicates the version of the data expected by the endpoint. This controls the shape of the pushed message (i.e., its fields and metadata). The endpoint version is based on the version of the Pub/Sub API. If not present during the subscriptions.create call, it will default to the version of the API used to make such call. If not present during a subscriptions.modifyPushConfig call, its value will not be changed. subscriptions.get calls will always return a valid version, even if the subscription was created without this attribute. The possible values for this attribute are:

    • v1beta1: uses the push format defined in the v1beta1 Pub/Sub API.
    • v1 or v1beta2: uses the push format defined in the v1 Pub/Sub API.
    noWrapper Property Map
    When set, the payload to the push endpoint is not wrapped.Sets the data field as the HTTP body for delivery. Structure is documented below.
    oidcToken Property Map
    If specified, Pub/Sub will generate and attach an OIDC JWT token as an Authorization header in the HTTP request for every pushed message. Structure is documented below.

    SubscriptionPushConfigNoWrapper, SubscriptionPushConfigNoWrapperArgs

    WriteMetadata bool
    When true, writes the Pub/Sub message metadata to x-goog-pubsub-<KEY>:<VAL> headers of the HTTP request. Writes the Pub/Sub message attributes to <KEY>:<VAL> headers of the HTTP request.
    WriteMetadata bool
    When true, writes the Pub/Sub message metadata to x-goog-pubsub-<KEY>:<VAL> headers of the HTTP request. Writes the Pub/Sub message attributes to <KEY>:<VAL> headers of the HTTP request.
    writeMetadata Boolean
    When true, writes the Pub/Sub message metadata to x-goog-pubsub-<KEY>:<VAL> headers of the HTTP request. Writes the Pub/Sub message attributes to <KEY>:<VAL> headers of the HTTP request.
    writeMetadata boolean
    When true, writes the Pub/Sub message metadata to x-goog-pubsub-<KEY>:<VAL> headers of the HTTP request. Writes the Pub/Sub message attributes to <KEY>:<VAL> headers of the HTTP request.
    write_metadata bool
    When true, writes the Pub/Sub message metadata to x-goog-pubsub-<KEY>:<VAL> headers of the HTTP request. Writes the Pub/Sub message attributes to <KEY>:<VAL> headers of the HTTP request.
    writeMetadata Boolean
    When true, writes the Pub/Sub message metadata to x-goog-pubsub-<KEY>:<VAL> headers of the HTTP request. Writes the Pub/Sub message attributes to <KEY>:<VAL> headers of the HTTP request.

    SubscriptionPushConfigOidcToken, SubscriptionPushConfigOidcTokenArgs

    ServiceAccountEmail string
    Service account email to be used for generating the OIDC token. The caller (for subscriptions.create, subscriptions.patch, and subscriptions.modifyPushConfig RPCs) must have the iam.serviceAccounts.actAs permission for the service account.
    Audience string
    Audience to be used when generating OIDC token. The audience claim identifies the recipients that the JWT is intended for. The audience value is a single case-sensitive string. Having multiple values (array) for the audience field is not supported. More info about the OIDC JWT token audience here: https://tools.ietf.org/html/rfc7519#section-4.1.3 Note: if not specified, the Push endpoint URL will be used.
    ServiceAccountEmail string
    Service account email to be used for generating the OIDC token. The caller (for subscriptions.create, subscriptions.patch, and subscriptions.modifyPushConfig RPCs) must have the iam.serviceAccounts.actAs permission for the service account.
    Audience string
    Audience to be used when generating OIDC token. The audience claim identifies the recipients that the JWT is intended for. The audience value is a single case-sensitive string. Having multiple values (array) for the audience field is not supported. More info about the OIDC JWT token audience here: https://tools.ietf.org/html/rfc7519#section-4.1.3 Note: if not specified, the Push endpoint URL will be used.
    serviceAccountEmail String
    Service account email to be used for generating the OIDC token. The caller (for subscriptions.create, subscriptions.patch, and subscriptions.modifyPushConfig RPCs) must have the iam.serviceAccounts.actAs permission for the service account.
    audience String
    Audience to be used when generating OIDC token. The audience claim identifies the recipients that the JWT is intended for. The audience value is a single case-sensitive string. Having multiple values (array) for the audience field is not supported. More info about the OIDC JWT token audience here: https://tools.ietf.org/html/rfc7519#section-4.1.3 Note: if not specified, the Push endpoint URL will be used.
    serviceAccountEmail string
    Service account email to be used for generating the OIDC token. The caller (for subscriptions.create, subscriptions.patch, and subscriptions.modifyPushConfig RPCs) must have the iam.serviceAccounts.actAs permission for the service account.
    audience string
    Audience to be used when generating OIDC token. The audience claim identifies the recipients that the JWT is intended for. The audience value is a single case-sensitive string. Having multiple values (array) for the audience field is not supported. More info about the OIDC JWT token audience here: https://tools.ietf.org/html/rfc7519#section-4.1.3 Note: if not specified, the Push endpoint URL will be used.
    service_account_email str
    Service account email to be used for generating the OIDC token. The caller (for subscriptions.create, subscriptions.patch, and subscriptions.modifyPushConfig RPCs) must have the iam.serviceAccounts.actAs permission for the service account.
    audience str
    Audience to be used when generating OIDC token. The audience claim identifies the recipients that the JWT is intended for. The audience value is a single case-sensitive string. Having multiple values (array) for the audience field is not supported. More info about the OIDC JWT token audience here: https://tools.ietf.org/html/rfc7519#section-4.1.3 Note: if not specified, the Push endpoint URL will be used.
    serviceAccountEmail String
    Service account email to be used for generating the OIDC token. The caller (for subscriptions.create, subscriptions.patch, and subscriptions.modifyPushConfig RPCs) must have the iam.serviceAccounts.actAs permission for the service account.
    audience String
    Audience to be used when generating OIDC token. The audience claim identifies the recipients that the JWT is intended for. The audience value is a single case-sensitive string. Having multiple values (array) for the audience field is not supported. More info about the OIDC JWT token audience here: https://tools.ietf.org/html/rfc7519#section-4.1.3 Note: if not specified, the Push endpoint URL will be used.

    SubscriptionRetryPolicy, SubscriptionRetryPolicyArgs

    MaximumBackoff string
    The maximum delay between consecutive deliveries of a given message. Value should be between 0 and 600 seconds. Defaults to 600 seconds. A duration in seconds with up to nine fractional digits, terminated by 's'. Example: "3.5s".
    MinimumBackoff string
    The minimum delay between consecutive deliveries of a given message. Value should be between 0 and 600 seconds. Defaults to 10 seconds. A duration in seconds with up to nine fractional digits, terminated by 's'. Example: "3.5s".
    MaximumBackoff string
    The maximum delay between consecutive deliveries of a given message. Value should be between 0 and 600 seconds. Defaults to 600 seconds. A duration in seconds with up to nine fractional digits, terminated by 's'. Example: "3.5s".
    MinimumBackoff string
    The minimum delay between consecutive deliveries of a given message. Value should be between 0 and 600 seconds. Defaults to 10 seconds. A duration in seconds with up to nine fractional digits, terminated by 's'. Example: "3.5s".
    maximumBackoff String
    The maximum delay between consecutive deliveries of a given message. Value should be between 0 and 600 seconds. Defaults to 600 seconds. A duration in seconds with up to nine fractional digits, terminated by 's'. Example: "3.5s".
    minimumBackoff String
    The minimum delay between consecutive deliveries of a given message. Value should be between 0 and 600 seconds. Defaults to 10 seconds. A duration in seconds with up to nine fractional digits, terminated by 's'. Example: "3.5s".
    maximumBackoff string
    The maximum delay between consecutive deliveries of a given message. Value should be between 0 and 600 seconds. Defaults to 600 seconds. A duration in seconds with up to nine fractional digits, terminated by 's'. Example: "3.5s".
    minimumBackoff string
    The minimum delay between consecutive deliveries of a given message. Value should be between 0 and 600 seconds. Defaults to 10 seconds. A duration in seconds with up to nine fractional digits, terminated by 's'. Example: "3.5s".
    maximum_backoff str
    The maximum delay between consecutive deliveries of a given message. Value should be between 0 and 600 seconds. Defaults to 600 seconds. A duration in seconds with up to nine fractional digits, terminated by 's'. Example: "3.5s".
    minimum_backoff str
    The minimum delay between consecutive deliveries of a given message. Value should be between 0 and 600 seconds. Defaults to 10 seconds. A duration in seconds with up to nine fractional digits, terminated by 's'. Example: "3.5s".
    maximumBackoff String
    The maximum delay between consecutive deliveries of a given message. Value should be between 0 and 600 seconds. Defaults to 600 seconds. A duration in seconds with up to nine fractional digits, terminated by 's'. Example: "3.5s".
    minimumBackoff String
    The minimum delay between consecutive deliveries of a given message. Value should be between 0 and 600 seconds. Defaults to 10 seconds. A duration in seconds with up to nine fractional digits, terminated by 's'. Example: "3.5s".

    Import

    Subscription can be imported using any of these accepted formats:

    • projects/{{project}}/subscriptions/{{name}}

    • {{project}}/{{name}}

    • {{name}}

    When using the pulumi import command, Subscription can be imported using one of the formats above. For example:

    $ pulumi import gcp:pubsub/subscription:Subscription default projects/{{project}}/subscriptions/{{name}}
    
    $ pulumi import gcp:pubsub/subscription:Subscription default {{project}}/{{name}}
    
    $ pulumi import gcp:pubsub/subscription:Subscription default {{name}}
    

    To learn more about importing existing cloud resources, see Importing resources.

    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 Classic v7.20.0 published on Wednesday, Apr 24, 2024 by Pulumi