gcp.pubsub.LiteTopic
Explore with Pulumi AI
A named resource to which messages are sent by publishers.
To get more information about Topic, see:
- API documentation
- How-to Guides
Example Usage
Pubsub Lite Topic Basic
import * as pulumi from "@pulumi/pulumi";
import * as gcp from "@pulumi/gcp";
const project = gcp.organizations.getProject({});
const example = new gcp.pubsub.LiteReservation("example", {
    name: "example-reservation",
    project: project.then(project => project.number),
    throughputCapacity: 2,
});
const exampleLiteTopic = new gcp.pubsub.LiteTopic("example", {
    name: "example-topic",
    project: project.then(project => project.number),
    partitionConfig: {
        count: 1,
        capacity: {
            publishMibPerSec: 4,
            subscribeMibPerSec: 8,
        },
    },
    retentionConfig: {
        perPartitionBytes: "32212254720",
    },
    reservationConfig: {
        throughputReservation: example.name,
    },
});
import pulumi
import pulumi_gcp as gcp
project = gcp.organizations.get_project()
example = gcp.pubsub.LiteReservation("example",
    name="example-reservation",
    project=project.number,
    throughput_capacity=2)
example_lite_topic = gcp.pubsub.LiteTopic("example",
    name="example-topic",
    project=project.number,
    partition_config={
        "count": 1,
        "capacity": {
            "publish_mib_per_sec": 4,
            "subscribe_mib_per_sec": 8,
        },
    },
    retention_config={
        "per_partition_bytes": "32212254720",
    },
    reservation_config={
        "throughput_reservation": example.name,
    })
package main
import (
	"github.com/pulumi/pulumi-gcp/sdk/v8/go/gcp/organizations"
	"github.com/pulumi/pulumi-gcp/sdk/v8/go/gcp/pubsub"
	"github.com/pulumi/pulumi/sdk/v3/go/pulumi"
)
func main() {
	pulumi.Run(func(ctx *pulumi.Context) error {
		project, err := organizations.LookupProject(ctx, &organizations.LookupProjectArgs{}, nil)
		if err != nil {
			return err
		}
		example, err := pubsub.NewLiteReservation(ctx, "example", &pubsub.LiteReservationArgs{
			Name:               pulumi.String("example-reservation"),
			Project:            pulumi.String(project.Number),
			ThroughputCapacity: pulumi.Int(2),
		})
		if err != nil {
			return err
		}
		_, err = pubsub.NewLiteTopic(ctx, "example", &pubsub.LiteTopicArgs{
			Name:    pulumi.String("example-topic"),
			Project: pulumi.String(project.Number),
			PartitionConfig: &pubsub.LiteTopicPartitionConfigArgs{
				Count: pulumi.Int(1),
				Capacity: &pubsub.LiteTopicPartitionConfigCapacityArgs{
					PublishMibPerSec:   pulumi.Int(4),
					SubscribeMibPerSec: pulumi.Int(8),
				},
			},
			RetentionConfig: &pubsub.LiteTopicRetentionConfigArgs{
				PerPartitionBytes: pulumi.String("32212254720"),
			},
			ReservationConfig: &pubsub.LiteTopicReservationConfigArgs{
				ThroughputReservation: example.Name,
			},
		})
		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 project = Gcp.Organizations.GetProject.Invoke();
    var example = new Gcp.PubSub.LiteReservation("example", new()
    {
        Name = "example-reservation",
        Project = project.Apply(getProjectResult => getProjectResult.Number),
        ThroughputCapacity = 2,
    });
    var exampleLiteTopic = new Gcp.PubSub.LiteTopic("example", new()
    {
        Name = "example-topic",
        Project = project.Apply(getProjectResult => getProjectResult.Number),
        PartitionConfig = new Gcp.PubSub.Inputs.LiteTopicPartitionConfigArgs
        {
            Count = 1,
            Capacity = new Gcp.PubSub.Inputs.LiteTopicPartitionConfigCapacityArgs
            {
                PublishMibPerSec = 4,
                SubscribeMibPerSec = 8,
            },
        },
        RetentionConfig = new Gcp.PubSub.Inputs.LiteTopicRetentionConfigArgs
        {
            PerPartitionBytes = "32212254720",
        },
        ReservationConfig = new Gcp.PubSub.Inputs.LiteTopicReservationConfigArgs
        {
            ThroughputReservation = example.Name,
        },
    });
});
package generated_program;
import com.pulumi.Context;
import com.pulumi.Pulumi;
import com.pulumi.core.Output;
import com.pulumi.gcp.organizations.OrganizationsFunctions;
import com.pulumi.gcp.organizations.inputs.GetProjectArgs;
import com.pulumi.gcp.pubsub.LiteReservation;
import com.pulumi.gcp.pubsub.LiteReservationArgs;
import com.pulumi.gcp.pubsub.LiteTopic;
import com.pulumi.gcp.pubsub.LiteTopicArgs;
import com.pulumi.gcp.pubsub.inputs.LiteTopicPartitionConfigArgs;
import com.pulumi.gcp.pubsub.inputs.LiteTopicPartitionConfigCapacityArgs;
import com.pulumi.gcp.pubsub.inputs.LiteTopicRetentionConfigArgs;
import com.pulumi.gcp.pubsub.inputs.LiteTopicReservationConfigArgs;
import java.util.List;
import java.util.ArrayList;
import java.util.Map;
import java.io.File;
import java.nio.file.Files;
import java.nio.file.Paths;
public class App {
    public static void main(String[] args) {
        Pulumi.run(App::stack);
    }
    public static void stack(Context ctx) {
        final var project = OrganizationsFunctions.getProject(GetProjectArgs.builder()
            .build());
        var example = new LiteReservation("example", LiteReservationArgs.builder()
            .name("example-reservation")
            .project(project.number())
            .throughputCapacity(2)
            .build());
        var exampleLiteTopic = new LiteTopic("exampleLiteTopic", LiteTopicArgs.builder()
            .name("example-topic")
            .project(project.number())
            .partitionConfig(LiteTopicPartitionConfigArgs.builder()
                .count(1)
                .capacity(LiteTopicPartitionConfigCapacityArgs.builder()
                    .publishMibPerSec(4)
                    .subscribeMibPerSec(8)
                    .build())
                .build())
            .retentionConfig(LiteTopicRetentionConfigArgs.builder()
                .perPartitionBytes("32212254720")
                .build())
            .reservationConfig(LiteTopicReservationConfigArgs.builder()
                .throughputReservation(example.name())
                .build())
            .build());
    }
}
resources:
  example:
    type: gcp:pubsub:LiteReservation
    properties:
      name: example-reservation
      project: ${project.number}
      throughputCapacity: 2
  exampleLiteTopic:
    type: gcp:pubsub:LiteTopic
    name: example
    properties:
      name: example-topic
      project: ${project.number}
      partitionConfig:
        count: 1
        capacity:
          publishMibPerSec: 4
          subscribeMibPerSec: 8
      retentionConfig:
        perPartitionBytes: 3.221225472e+10
      reservationConfig:
        throughputReservation: ${example.name}
variables:
  project:
    fn::invoke:
      function: gcp:organizations:getProject
      arguments: {}
Create LiteTopic Resource
Resources are created with functions called constructors. To learn more about declaring and configuring resources, see Resources.
Constructor syntax
new LiteTopic(name: string, args?: LiteTopicArgs, opts?: CustomResourceOptions);@overload
def LiteTopic(resource_name: str,
              args: Optional[LiteTopicArgs] = None,
              opts: Optional[ResourceOptions] = None)
@overload
def LiteTopic(resource_name: str,
              opts: Optional[ResourceOptions] = None,
              name: Optional[str] = None,
              partition_config: Optional[LiteTopicPartitionConfigArgs] = None,
              project: Optional[str] = None,
              region: Optional[str] = None,
              reservation_config: Optional[LiteTopicReservationConfigArgs] = None,
              retention_config: Optional[LiteTopicRetentionConfigArgs] = None,
              zone: Optional[str] = None)func NewLiteTopic(ctx *Context, name string, args *LiteTopicArgs, opts ...ResourceOption) (*LiteTopic, error)public LiteTopic(string name, LiteTopicArgs? args = null, CustomResourceOptions? opts = null)
public LiteTopic(String name, LiteTopicArgs args)
public LiteTopic(String name, LiteTopicArgs args, CustomResourceOptions options)
type: gcp:pubsub:LiteTopic
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 LiteTopicArgs
- 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 LiteTopicArgs
- 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 LiteTopicArgs
- The arguments to resource properties.
- opts ResourceOption
- Bag of options to control resource's behavior.
- name string
- The unique name of the resource.
- args LiteTopicArgs
- The arguments to resource properties.
- opts CustomResourceOptions
- Bag of options to control resource's behavior.
- name String
- The unique name of the resource.
- args LiteTopicArgs
- The arguments to resource properties.
- options CustomResourceOptions
- Bag of options to control resource's behavior.
Constructor example
The following reference example uses placeholder values for all input properties.
var liteTopicResource = new Gcp.PubSub.LiteTopic("liteTopicResource", new()
{
    Name = "string",
    PartitionConfig = new Gcp.PubSub.Inputs.LiteTopicPartitionConfigArgs
    {
        Count = 0,
        Capacity = new Gcp.PubSub.Inputs.LiteTopicPartitionConfigCapacityArgs
        {
            PublishMibPerSec = 0,
            SubscribeMibPerSec = 0,
        },
    },
    Project = "string",
    Region = "string",
    ReservationConfig = new Gcp.PubSub.Inputs.LiteTopicReservationConfigArgs
    {
        ThroughputReservation = "string",
    },
    RetentionConfig = new Gcp.PubSub.Inputs.LiteTopicRetentionConfigArgs
    {
        PerPartitionBytes = "string",
        Period = "string",
    },
    Zone = "string",
});
example, err := pubsub.NewLiteTopic(ctx, "liteTopicResource", &pubsub.LiteTopicArgs{
	Name: pulumi.String("string"),
	PartitionConfig: &pubsub.LiteTopicPartitionConfigArgs{
		Count: pulumi.Int(0),
		Capacity: &pubsub.LiteTopicPartitionConfigCapacityArgs{
			PublishMibPerSec:   pulumi.Int(0),
			SubscribeMibPerSec: pulumi.Int(0),
		},
	},
	Project: pulumi.String("string"),
	Region:  pulumi.String("string"),
	ReservationConfig: &pubsub.LiteTopicReservationConfigArgs{
		ThroughputReservation: pulumi.String("string"),
	},
	RetentionConfig: &pubsub.LiteTopicRetentionConfigArgs{
		PerPartitionBytes: pulumi.String("string"),
		Period:            pulumi.String("string"),
	},
	Zone: pulumi.String("string"),
})
var liteTopicResource = new LiteTopic("liteTopicResource", LiteTopicArgs.builder()
    .name("string")
    .partitionConfig(LiteTopicPartitionConfigArgs.builder()
        .count(0)
        .capacity(LiteTopicPartitionConfigCapacityArgs.builder()
            .publishMibPerSec(0)
            .subscribeMibPerSec(0)
            .build())
        .build())
    .project("string")
    .region("string")
    .reservationConfig(LiteTopicReservationConfigArgs.builder()
        .throughputReservation("string")
        .build())
    .retentionConfig(LiteTopicRetentionConfigArgs.builder()
        .perPartitionBytes("string")
        .period("string")
        .build())
    .zone("string")
    .build());
lite_topic_resource = gcp.pubsub.LiteTopic("liteTopicResource",
    name="string",
    partition_config={
        "count": 0,
        "capacity": {
            "publish_mib_per_sec": 0,
            "subscribe_mib_per_sec": 0,
        },
    },
    project="string",
    region="string",
    reservation_config={
        "throughput_reservation": "string",
    },
    retention_config={
        "per_partition_bytes": "string",
        "period": "string",
    },
    zone="string")
const liteTopicResource = new gcp.pubsub.LiteTopic("liteTopicResource", {
    name: "string",
    partitionConfig: {
        count: 0,
        capacity: {
            publishMibPerSec: 0,
            subscribeMibPerSec: 0,
        },
    },
    project: "string",
    region: "string",
    reservationConfig: {
        throughputReservation: "string",
    },
    retentionConfig: {
        perPartitionBytes: "string",
        period: "string",
    },
    zone: "string",
});
type: gcp:pubsub:LiteTopic
properties:
    name: string
    partitionConfig:
        capacity:
            publishMibPerSec: 0
            subscribeMibPerSec: 0
        count: 0
    project: string
    region: string
    reservationConfig:
        throughputReservation: string
    retentionConfig:
        perPartitionBytes: string
        period: string
    zone: string
LiteTopic Resource Properties
To learn more about resource properties and how to use them, see Inputs and Outputs in the Architecture and Concepts docs.
Inputs
In Python, inputs that are objects can be passed either as argument classes or as dictionary literals.
The LiteTopic resource accepts the following input properties:
- Name string
- Name of the topic.
- PartitionConfig LiteTopic Partition Config 
- The settings for this topic's partitions. Structure is documented below.
- Project string
- The ID of the project in which the resource belongs. If it is not provided, the provider project is used.
- Region string
- The region of the pubsub lite topic.
- ReservationConfig LiteTopic Reservation Config 
- The settings for this topic's Reservation usage. Structure is documented below.
- RetentionConfig LiteTopic Retention Config 
- The settings for a topic's message retention. Structure is documented below.
- Zone string
- The zone of the pubsub lite topic.
- Name string
- Name of the topic.
- PartitionConfig LiteTopic Partition Config Args 
- The settings for this topic's partitions. Structure is documented below.
- Project string
- The ID of the project in which the resource belongs. If it is not provided, the provider project is used.
- Region string
- The region of the pubsub lite topic.
- ReservationConfig LiteTopic Reservation Config Args 
- The settings for this topic's Reservation usage. Structure is documented below.
- RetentionConfig LiteTopic Retention Config Args 
- The settings for a topic's message retention. Structure is documented below.
- Zone string
- The zone of the pubsub lite topic.
- name String
- Name of the topic.
- partitionConfig LiteTopic Partition Config 
- The settings for this topic's partitions. Structure is documented below.
- project String
- The ID of the project in which the resource belongs. If it is not provided, the provider project is used.
- region String
- The region of the pubsub lite topic.
- reservationConfig LiteTopic Reservation Config 
- The settings for this topic's Reservation usage. Structure is documented below.
- retentionConfig LiteTopic Retention Config 
- The settings for a topic's message retention. Structure is documented below.
- zone String
- The zone of the pubsub lite topic.
- name string
- Name of the topic.
- partitionConfig LiteTopic Partition Config 
- The settings for this topic's partitions. Structure is documented below.
- project string
- The ID of the project in which the resource belongs. If it is not provided, the provider project is used.
- region string
- The region of the pubsub lite topic.
- reservationConfig LiteTopic Reservation Config 
- The settings for this topic's Reservation usage. Structure is documented below.
- retentionConfig LiteTopic Retention Config 
- The settings for a topic's message retention. Structure is documented below.
- zone string
- The zone of the pubsub lite topic.
- name str
- Name of the topic.
- partition_config LiteTopic Partition Config Args 
- The settings for this topic's partitions. Structure is documented below.
- project str
- The ID of the project in which the resource belongs. If it is not provided, the provider project is used.
- region str
- The region of the pubsub lite topic.
- reservation_config LiteTopic Reservation Config Args 
- The settings for this topic's Reservation usage. Structure is documented below.
- retention_config LiteTopic Retention Config Args 
- The settings for a topic's message retention. Structure is documented below.
- zone str
- The zone of the pubsub lite topic.
- name String
- Name of the topic.
- partitionConfig Property Map
- The settings for this topic's partitions. Structure is documented below.
- project String
- The ID of the project in which the resource belongs. If it is not provided, the provider project is used.
- region String
- The region of the pubsub lite topic.
- reservationConfig Property Map
- The settings for this topic's Reservation usage. Structure is documented below.
- retentionConfig Property Map
- The settings for a topic's message retention. Structure is documented below.
- zone String
- The zone of the pubsub lite topic.
Outputs
All input properties are implicitly available as output properties. Additionally, the LiteTopic resource produces the following output properties:
- Id string
- The provider-assigned unique ID for this managed resource.
- Id string
- The provider-assigned unique ID for this managed resource.
- id String
- The provider-assigned unique ID for this managed resource.
- id string
- The provider-assigned unique ID for this managed resource.
- id str
- The provider-assigned unique ID for this managed resource.
- id String
- The provider-assigned unique ID for this managed resource.
Look up Existing LiteTopic Resource
Get an existing LiteTopic 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?: LiteTopicState, opts?: CustomResourceOptions): LiteTopic@staticmethod
def get(resource_name: str,
        id: str,
        opts: Optional[ResourceOptions] = None,
        name: Optional[str] = None,
        partition_config: Optional[LiteTopicPartitionConfigArgs] = None,
        project: Optional[str] = None,
        region: Optional[str] = None,
        reservation_config: Optional[LiteTopicReservationConfigArgs] = None,
        retention_config: Optional[LiteTopicRetentionConfigArgs] = None,
        zone: Optional[str] = None) -> LiteTopicfunc GetLiteTopic(ctx *Context, name string, id IDInput, state *LiteTopicState, opts ...ResourceOption) (*LiteTopic, error)public static LiteTopic Get(string name, Input<string> id, LiteTopicState? state, CustomResourceOptions? opts = null)public static LiteTopic get(String name, Output<String> id, LiteTopicState state, CustomResourceOptions options)resources:  _:    type: gcp:pubsub:LiteTopic    get:      id: ${id}- 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.
- Name string
- Name of the topic.
- PartitionConfig LiteTopic Partition Config 
- The settings for this topic's partitions. Structure is documented below.
- Project string
- The ID of the project in which the resource belongs. If it is not provided, the provider project is used.
- Region string
- The region of the pubsub lite topic.
- ReservationConfig LiteTopic Reservation Config 
- The settings for this topic's Reservation usage. Structure is documented below.
- RetentionConfig LiteTopic Retention Config 
- The settings for a topic's message retention. Structure is documented below.
- Zone string
- The zone of the pubsub lite topic.
- Name string
- Name of the topic.
- PartitionConfig LiteTopic Partition Config Args 
- The settings for this topic's partitions. Structure is documented below.
- Project string
- The ID of the project in which the resource belongs. If it is not provided, the provider project is used.
- Region string
- The region of the pubsub lite topic.
- ReservationConfig LiteTopic Reservation Config Args 
- The settings for this topic's Reservation usage. Structure is documented below.
- RetentionConfig LiteTopic Retention Config Args 
- The settings for a topic's message retention. Structure is documented below.
- Zone string
- The zone of the pubsub lite topic.
- name String
- Name of the topic.
- partitionConfig LiteTopic Partition Config 
- The settings for this topic's partitions. Structure is documented below.
- project String
- The ID of the project in which the resource belongs. If it is not provided, the provider project is used.
- region String
- The region of the pubsub lite topic.
- reservationConfig LiteTopic Reservation Config 
- The settings for this topic's Reservation usage. Structure is documented below.
- retentionConfig LiteTopic Retention Config 
- The settings for a topic's message retention. Structure is documented below.
- zone String
- The zone of the pubsub lite topic.
- name string
- Name of the topic.
- partitionConfig LiteTopic Partition Config 
- The settings for this topic's partitions. Structure is documented below.
- project string
- The ID of the project in which the resource belongs. If it is not provided, the provider project is used.
- region string
- The region of the pubsub lite topic.
- reservationConfig LiteTopic Reservation Config 
- The settings for this topic's Reservation usage. Structure is documented below.
- retentionConfig LiteTopic Retention Config 
- The settings for a topic's message retention. Structure is documented below.
- zone string
- The zone of the pubsub lite topic.
- name str
- Name of the topic.
- partition_config LiteTopic Partition Config Args 
- The settings for this topic's partitions. Structure is documented below.
- project str
- The ID of the project in which the resource belongs. If it is not provided, the provider project is used.
- region str
- The region of the pubsub lite topic.
- reservation_config LiteTopic Reservation Config Args 
- The settings for this topic's Reservation usage. Structure is documented below.
- retention_config LiteTopic Retention Config Args 
- The settings for a topic's message retention. Structure is documented below.
- zone str
- The zone of the pubsub lite topic.
- name String
- Name of the topic.
- partitionConfig Property Map
- The settings for this topic's partitions. Structure is documented below.
- project String
- The ID of the project in which the resource belongs. If it is not provided, the provider project is used.
- region String
- The region of the pubsub lite topic.
- reservationConfig Property Map
- The settings for this topic's Reservation usage. Structure is documented below.
- retentionConfig Property Map
- The settings for a topic's message retention. Structure is documented below.
- zone String
- The zone of the pubsub lite topic.
Supporting Types
LiteTopicPartitionConfig, LiteTopicPartitionConfigArgs        
- Count int
- The number of partitions in the topic. Must be at least 1.
- Capacity
LiteTopic Partition Config Capacity 
- The capacity configuration. Structure is documented below.
- Count int
- The number of partitions in the topic. Must be at least 1.
- Capacity
LiteTopic Partition Config Capacity 
- The capacity configuration. Structure is documented below.
- count Integer
- The number of partitions in the topic. Must be at least 1.
- capacity
LiteTopic Partition Config Capacity 
- The capacity configuration. Structure is documented below.
- count number
- The number of partitions in the topic. Must be at least 1.
- capacity
LiteTopic Partition Config Capacity 
- The capacity configuration. Structure is documented below.
- count int
- The number of partitions in the topic. Must be at least 1.
- capacity
LiteTopic Partition Config Capacity 
- The capacity configuration. Structure is documented below.
- count Number
- The number of partitions in the topic. Must be at least 1.
- capacity Property Map
- The capacity configuration. Structure is documented below.
LiteTopicPartitionConfigCapacity, LiteTopicPartitionConfigCapacityArgs          
- PublishMib intPer Sec 
- Subscribe throughput capacity per partition in MiB/s. Must be >= 4 and <= 16.
- SubscribeMib intPer Sec 
- Publish throughput capacity per partition in MiB/s. Must be >= 4 and <= 16.
- PublishMib intPer Sec 
- Subscribe throughput capacity per partition in MiB/s. Must be >= 4 and <= 16.
- SubscribeMib intPer Sec 
- Publish throughput capacity per partition in MiB/s. Must be >= 4 and <= 16.
- publishMib IntegerPer Sec 
- Subscribe throughput capacity per partition in MiB/s. Must be >= 4 and <= 16.
- subscribeMib IntegerPer Sec 
- Publish throughput capacity per partition in MiB/s. Must be >= 4 and <= 16.
- publishMib numberPer Sec 
- Subscribe throughput capacity per partition in MiB/s. Must be >= 4 and <= 16.
- subscribeMib numberPer Sec 
- Publish throughput capacity per partition in MiB/s. Must be >= 4 and <= 16.
- publish_mib_ intper_ sec 
- Subscribe throughput capacity per partition in MiB/s. Must be >= 4 and <= 16.
- subscribe_mib_ intper_ sec 
- Publish throughput capacity per partition in MiB/s. Must be >= 4 and <= 16.
- publishMib NumberPer Sec 
- Subscribe throughput capacity per partition in MiB/s. Must be >= 4 and <= 16.
- subscribeMib NumberPer Sec 
- Publish throughput capacity per partition in MiB/s. Must be >= 4 and <= 16.
LiteTopicReservationConfig, LiteTopicReservationConfigArgs        
- ThroughputReservation string
- The Reservation to use for this topic's throughput capacity.
- ThroughputReservation string
- The Reservation to use for this topic's throughput capacity.
- throughputReservation String
- The Reservation to use for this topic's throughput capacity.
- throughputReservation string
- The Reservation to use for this topic's throughput capacity.
- throughput_reservation str
- The Reservation to use for this topic's throughput capacity.
- throughputReservation String
- The Reservation to use for this topic's throughput capacity.
LiteTopicRetentionConfig, LiteTopicRetentionConfigArgs        
- PerPartition stringBytes 
- The provisioned storage, in bytes, per partition. If the number of bytes stored in any of the topic's partitions grows beyond this value, older messages will be dropped to make room for newer ones, regardless of the value of period.
- Period string
- How long a published message is retained. If unset, messages will be retained as long as the bytes retained for each partition is below perPartitionBytes. A duration in seconds with up to nine fractional digits, terminated by 's'. Example: "3.5s".
- PerPartition stringBytes 
- The provisioned storage, in bytes, per partition. If the number of bytes stored in any of the topic's partitions grows beyond this value, older messages will be dropped to make room for newer ones, regardless of the value of period.
- Period string
- How long a published message is retained. If unset, messages will be retained as long as the bytes retained for each partition is below perPartitionBytes. A duration in seconds with up to nine fractional digits, terminated by 's'. Example: "3.5s".
- perPartition StringBytes 
- The provisioned storage, in bytes, per partition. If the number of bytes stored in any of the topic's partitions grows beyond this value, older messages will be dropped to make room for newer ones, regardless of the value of period.
- period String
- How long a published message is retained. If unset, messages will be retained as long as the bytes retained for each partition is below perPartitionBytes. A duration in seconds with up to nine fractional digits, terminated by 's'. Example: "3.5s".
- perPartition stringBytes 
- The provisioned storage, in bytes, per partition. If the number of bytes stored in any of the topic's partitions grows beyond this value, older messages will be dropped to make room for newer ones, regardless of the value of period.
- period string
- How long a published message is retained. If unset, messages will be retained as long as the bytes retained for each partition is below perPartitionBytes. A duration in seconds with up to nine fractional digits, terminated by 's'. Example: "3.5s".
- per_partition_ strbytes 
- The provisioned storage, in bytes, per partition. If the number of bytes stored in any of the topic's partitions grows beyond this value, older messages will be dropped to make room for newer ones, regardless of the value of period.
- period str
- How long a published message is retained. If unset, messages will be retained as long as the bytes retained for each partition is below perPartitionBytes. A duration in seconds with up to nine fractional digits, terminated by 's'. Example: "3.5s".
- perPartition StringBytes 
- The provisioned storage, in bytes, per partition. If the number of bytes stored in any of the topic's partitions grows beyond this value, older messages will be dropped to make room for newer ones, regardless of the value of period.
- period String
- How long a published message is retained. If unset, messages will be retained as long as the bytes retained for each partition is below perPartitionBytes. A duration in seconds with up to nine fractional digits, terminated by 's'. Example: "3.5s".
Import
Topic can be imported using any of these accepted formats:
- projects/{{project}}/locations/{{zone}}/topics/{{name}}
- {{project}}/{{zone}}/{{name}}
- {{zone}}/{{name}}
- {{name}}
When using the pulumi import command, Topic can be imported using one of the formats above. For example:
$ pulumi import gcp:pubsub/liteTopic:LiteTopic default projects/{{project}}/locations/{{zone}}/topics/{{name}}
$ pulumi import gcp:pubsub/liteTopic:LiteTopic default {{project}}/{{zone}}/{{name}}
$ pulumi import gcp:pubsub/liteTopic:LiteTopic default {{zone}}/{{name}}
$ pulumi import gcp:pubsub/liteTopic:LiteTopic 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-betaTerraform Provider.