1. Packages
  2. Redpanda Provider
  3. API Docs
  4. getCluster
redpanda 0.13.0 published on Monday, Mar 17, 2025 by redpanda-data

redpanda.getCluster

Explore with Pulumi AI

redpanda logo
redpanda 0.13.0 published on Monday, Mar 17, 2025 by redpanda-data

    Data source for a Redpanda Cloud cluster

    Usage

    import * as pulumi from "@pulumi/pulumi";
    import * as redpanda from "@pulumi/redpanda";
    
    const example = redpanda.getCluster({
        id: "cluster_id",
    });
    
    import pulumi
    import pulumi_redpanda as redpanda
    
    example = redpanda.get_cluster(id="cluster_id")
    
    package main
    
    import (
    	"github.com/pulumi/pulumi-terraform-provider/sdks/go/redpanda/redpanda"
    	"github.com/pulumi/pulumi/sdk/v3/go/pulumi"
    )
    
    func main() {
    	pulumi.Run(func(ctx *pulumi.Context) error {
    		_, err := redpanda.LookupCluster(ctx, &redpanda.LookupClusterArgs{
    			Id: "cluster_id",
    		}, nil)
    		if err != nil {
    			return err
    		}
    		return nil
    	})
    }
    
    using System.Collections.Generic;
    using System.Linq;
    using Pulumi;
    using Redpanda = Pulumi.Redpanda;
    
    return await Deployment.RunAsync(() => 
    {
        var example = Redpanda.GetCluster.Invoke(new()
        {
            Id = "cluster_id",
        });
    
    });
    
    package generated_program;
    
    import com.pulumi.Context;
    import com.pulumi.Pulumi;
    import com.pulumi.core.Output;
    import com.pulumi.redpanda.RedpandaFunctions;
    import com.pulumi.redpanda.inputs.GetClusterArgs;
    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 example = RedpandaFunctions.getCluster(GetClusterArgs.builder()
                .id("cluster_id")
                .build());
    
        }
    }
    
    variables:
      example:
        fn::invoke:
          function: redpanda:getCluster
          arguments:
            id: cluster_id
    

    Example Usage of a data source BYOC to manage users and ACLs

    import * as pulumi from "@pulumi/pulumi";
    import * as redpanda from "@pulumi/redpanda";
    
    const config = new pulumi.Config();
    const clusterId = config.get("clusterId") || "";
    const testCluster = redpanda.getCluster({
        id: clusterId,
    });
    const topicConfig = config.getObject("topicConfig") || {
        "cleanup.policy": "compact",
        "flush.ms": 100,
        "compression.type": "snappy",
    };
    const partitionCount = config.getNumber("partitionCount") || 3;
    const replicationFactor = config.getNumber("replicationFactor") || 3;
    const testTopic = new redpanda.Topic("testTopic", {
        partitionCount: partitionCount,
        replicationFactor: replicationFactor,
        clusterApiUrl: testCluster.then(testCluster => testCluster.clusterApiUrl),
        allowDeletion: true,
        configuration: topicConfig,
    });
    const userPw = config.get("userPw") || "password";
    const mechanism = config.get("mechanism") || "scram-sha-256";
    const testUser = new redpanda.User("testUser", {
        password: userPw,
        mechanism: mechanism,
        clusterApiUrl: testCluster.then(testCluster => testCluster.clusterApiUrl),
    });
    const testAcl = new redpanda.Acl("testAcl", {
        resourceType: "CLUSTER",
        resourceName: "kafka-cluster",
        resourcePatternType: "LITERAL",
        principal: pulumi.interpolate`User:${testUser.name}`,
        host: "*",
        operation: "ALTER",
        permissionType: "ALLOW",
        clusterApiUrl: testCluster.then(testCluster => testCluster.clusterApiUrl),
    });
    const userName = config.get("userName") || "data-test-username";
    const topicName = config.get("topicName") || "data-test-topic";
    
    import pulumi
    import pulumi_redpanda as redpanda
    
    config = pulumi.Config()
    cluster_id = config.get("clusterId")
    if cluster_id is None:
        cluster_id = ""
    test_cluster = redpanda.get_cluster(id=cluster_id)
    topic_config = config.get_object("topicConfig")
    if topic_config is None:
        topic_config = {
            "cleanup.policy": "compact",
            "flush.ms": 100,
            "compression.type": "snappy",
        }
    partition_count = config.get_float("partitionCount")
    if partition_count is None:
        partition_count = 3
    replication_factor = config.get_float("replicationFactor")
    if replication_factor is None:
        replication_factor = 3
    test_topic = redpanda.Topic("testTopic",
        partition_count=partition_count,
        replication_factor=replication_factor,
        cluster_api_url=test_cluster.cluster_api_url,
        allow_deletion=True,
        configuration=topic_config)
    user_pw = config.get("userPw")
    if user_pw is None:
        user_pw = "password"
    mechanism = config.get("mechanism")
    if mechanism is None:
        mechanism = "scram-sha-256"
    test_user = redpanda.User("testUser",
        password=user_pw,
        mechanism=mechanism,
        cluster_api_url=test_cluster.cluster_api_url)
    test_acl = redpanda.Acl("testAcl",
        resource_type="CLUSTER",
        resource_name_="kafka-cluster",
        resource_pattern_type="LITERAL",
        principal=test_user.name.apply(lambda name: f"User:{name}"),
        host="*",
        operation="ALTER",
        permission_type="ALLOW",
        cluster_api_url=test_cluster.cluster_api_url)
    user_name = config.get("userName")
    if user_name is None:
        user_name = "data-test-username"
    topic_name = config.get("topicName")
    if topic_name is None:
        topic_name = "data-test-topic"
    
    package main
    
    import (
    	"fmt"
    
    	"github.com/pulumi/pulumi-terraform-provider/sdks/go/redpanda/redpanda"
    	"github.com/pulumi/pulumi/sdk/v3/go/pulumi"
    	"github.com/pulumi/pulumi/sdk/v3/go/pulumi/config"
    )
    
    func main() {
    	pulumi.Run(func(ctx *pulumi.Context) error {
    		cfg := config.New(ctx, "")
    		clusterId := ""
    		if param := cfg.Get("clusterId"); param != "" {
    			clusterId = param
    		}
    		testCluster, err := redpanda.LookupCluster(ctx, &redpanda.LookupClusterArgs{
    			Id: clusterId,
    		}, nil)
    		if err != nil {
    			return err
    		}
    		topicConfig := map[string]interface{}{
    			"cleanup.policy":   "compact",
    			"flush.ms":         100,
    			"compression.type": "snappy",
    		}
    		if param := cfg.GetObject("topicConfig"); param != nil {
    			topicConfig = param
    		}
    		partitionCount := float64(3)
    		if param := cfg.GetFloat64("partitionCount"); param != 0 {
    			partitionCount = param
    		}
    		replicationFactor := float64(3)
    		if param := cfg.GetFloat64("replicationFactor"); param != 0 {
    			replicationFactor = param
    		}
    		_, err = redpanda.NewTopic(ctx, "testTopic", &redpanda.TopicArgs{
    			PartitionCount:    pulumi.Float64(partitionCount),
    			ReplicationFactor: pulumi.Float64(replicationFactor),
    			ClusterApiUrl:     pulumi.String(testCluster.ClusterApiUrl),
    			AllowDeletion:     pulumi.Bool(true),
    			Configuration:     pulumi.Any(topicConfig),
    		})
    		if err != nil {
    			return err
    		}
    		userPw := "password"
    		if param := cfg.Get("userPw"); param != "" {
    			userPw = param
    		}
    		mechanism := "scram-sha-256"
    		if param := cfg.Get("mechanism"); param != "" {
    			mechanism = param
    		}
    		testUser, err := redpanda.NewUser(ctx, "testUser", &redpanda.UserArgs{
    			Password:      pulumi.String(userPw),
    			Mechanism:     pulumi.String(mechanism),
    			ClusterApiUrl: pulumi.String(testCluster.ClusterApiUrl),
    		})
    		if err != nil {
    			return err
    		}
    		_, err = redpanda.NewAcl(ctx, "testAcl", &redpanda.AclArgs{
    			ResourceType:        pulumi.String("CLUSTER"),
    			ResourceName:        pulumi.String("kafka-cluster"),
    			ResourcePatternType: pulumi.String("LITERAL"),
    			Principal: testUser.Name.ApplyT(func(name string) (string, error) {
    				return fmt.Sprintf("User:%v", name), nil
    			}).(pulumi.StringOutput),
    			Host:           pulumi.String("*"),
    			Operation:      pulumi.String("ALTER"),
    			PermissionType: pulumi.String("ALLOW"),
    			ClusterApiUrl:  pulumi.String(testCluster.ClusterApiUrl),
    		})
    		if err != nil {
    			return err
    		}
    		userName := "data-test-username"
    		if param := cfg.Get("userName"); param != "" {
    			userName = param
    		}
    		topicName := "data-test-topic"
    		if param := cfg.Get("topicName"); param != "" {
    			topicName = param
    		}
    		return nil
    	})
    }
    
    using System.Collections.Generic;
    using System.Linq;
    using Pulumi;
    using Redpanda = Pulumi.Redpanda;
    
    return await Deployment.RunAsync(() => 
    {
        var config = new Config();
        var clusterId = config.Get("clusterId") ?? "";
        var testCluster = Redpanda.GetCluster.Invoke(new()
        {
            Id = clusterId,
        });
    
        var topicConfig = config.GetObject<dynamic>("topicConfig") ?? 
        {
            { "cleanup.policy", "compact" },
            { "flush.ms", 100 },
            { "compression.type", "snappy" },
        };
        var partitionCount = config.GetDouble("partitionCount") ?? 3;
        var replicationFactor = config.GetDouble("replicationFactor") ?? 3;
        var testTopic = new Redpanda.Topic("testTopic", new()
        {
            PartitionCount = partitionCount,
            ReplicationFactor = replicationFactor,
            ClusterApiUrl = testCluster.Apply(getClusterResult => getClusterResult.ClusterApiUrl),
            AllowDeletion = true,
            Configuration = topicConfig,
        });
    
        var userPw = config.Get("userPw") ?? "password";
        var mechanism = config.Get("mechanism") ?? "scram-sha-256";
        var testUser = new Redpanda.User("testUser", new()
        {
            Password = userPw,
            Mechanism = mechanism,
            ClusterApiUrl = testCluster.Apply(getClusterResult => getClusterResult.ClusterApiUrl),
        });
    
        var testAcl = new Redpanda.Acl("testAcl", new()
        {
            ResourceType = "CLUSTER",
            ResourceName = "kafka-cluster",
            ResourcePatternType = "LITERAL",
            Principal = testUser.Name.Apply(name => $"User:{name}"),
            Host = "*",
            Operation = "ALTER",
            PermissionType = "ALLOW",
            ClusterApiUrl = testCluster.Apply(getClusterResult => getClusterResult.ClusterApiUrl),
        });
    
        var userName = config.Get("userName") ?? "data-test-username";
        var topicName = config.Get("topicName") ?? "data-test-topic";
    });
    
    package generated_program;
    
    import com.pulumi.Context;
    import com.pulumi.Pulumi;
    import com.pulumi.core.Output;
    import com.pulumi.redpanda.RedpandaFunctions;
    import com.pulumi.redpanda.inputs.GetClusterArgs;
    import com.pulumi.redpanda.Topic;
    import com.pulumi.redpanda.TopicArgs;
    import com.pulumi.redpanda.User;
    import com.pulumi.redpanda.UserArgs;
    import com.pulumi.redpanda.Acl;
    import com.pulumi.redpanda.AclArgs;
    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 config = ctx.config();
            final var clusterId = config.get("clusterId").orElse("");
            final var testCluster = RedpandaFunctions.getCluster(GetClusterArgs.builder()
                .id(clusterId)
                .build());
    
            final var topicConfig = config.get("topicConfig").orElse(%!v(PANIC=Format method: runtime error: invalid memory address or nil pointer dereference));
            final var partitionCount = config.get("partitionCount").orElse(3);
            final var replicationFactor = config.get("replicationFactor").orElse(3);
            var testTopic = new Topic("testTopic", TopicArgs.builder()
                .partitionCount(partitionCount)
                .replicationFactor(replicationFactor)
                .clusterApiUrl(testCluster.applyValue(getClusterResult -> getClusterResult.clusterApiUrl()))
                .allowDeletion(true)
                .configuration(topicConfig)
                .build());
    
            final var userPw = config.get("userPw").orElse("password");
            final var mechanism = config.get("mechanism").orElse("scram-sha-256");
            var testUser = new User("testUser", UserArgs.builder()
                .password(userPw)
                .mechanism(mechanism)
                .clusterApiUrl(testCluster.applyValue(getClusterResult -> getClusterResult.clusterApiUrl()))
                .build());
    
            var testAcl = new Acl("testAcl", AclArgs.builder()
                .resourceType("CLUSTER")
                .resourceName("kafka-cluster")
                .resourcePatternType("LITERAL")
                .principal(testUser.name().applyValue(name -> String.format("User:%s", name)))
                .host("*")
                .operation("ALTER")
                .permissionType("ALLOW")
                .clusterApiUrl(testCluster.applyValue(getClusterResult -> getClusterResult.clusterApiUrl()))
                .build());
    
            final var userName = config.get("userName").orElse("data-test-username");
            final var topicName = config.get("topicName").orElse("data-test-topic");
        }
    }
    
    configuration:
      clusterId:
        type: string
        default: ""
      topicConfig:
        type: dynamic
        default:
          cleanup.policy: compact
          flush.ms: 100
          compression.type: snappy
      userName:
        type: string
        default: data-test-username
      userPw:
        type: string
        default: password
      mechanism:
        type: string
        default: scram-sha-256
      topicName:
        type: string
        default: data-test-topic
      partitionCount:
        type: number
        default: 3
      replicationFactor:
        type: number
        default: 3
    resources:
      testTopic:
        type: redpanda:Topic
        properties:
          partitionCount: ${partitionCount}
          replicationFactor: ${replicationFactor}
          clusterApiUrl: ${testCluster.clusterApiUrl}
          allowDeletion: true
          configuration: ${topicConfig}
      testUser:
        type: redpanda:User
        properties:
          password: ${userPw}
          mechanism: ${mechanism}
          clusterApiUrl: ${testCluster.clusterApiUrl}
      testAcl:
        type: redpanda:Acl
        properties:
          resourceType: CLUSTER
          resourceName: kafka-cluster
          resourcePatternType: LITERAL
          principal: User:${testUser.name}
          host: '*'
          operation: ALTER
          permissionType: ALLOW
          clusterApiUrl: ${testCluster.clusterApiUrl}
    variables:
      testCluster:
        fn::invoke:
          function: redpanda:getCluster
          arguments:
            id: ${clusterId}
    

    Limitations

    Can only be used with Redpanda Cloud Dedicated and BYOC clusters.

    Using getCluster

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

    function getCluster(args: GetClusterArgs, opts?: InvokeOptions): Promise<GetClusterResult>
    function getClusterOutput(args: GetClusterOutputArgs, opts?: InvokeOptions): Output<GetClusterResult>
    def get_cluster(id: Optional[str] = None,
                    opts: Optional[InvokeOptions] = None) -> GetClusterResult
    def get_cluster_output(id: Optional[pulumi.Input[str]] = None,
                    opts: Optional[InvokeOptions] = None) -> Output[GetClusterResult]
    func LookupCluster(ctx *Context, args *LookupClusterArgs, opts ...InvokeOption) (*LookupClusterResult, error)
    func LookupClusterOutput(ctx *Context, args *LookupClusterOutputArgs, opts ...InvokeOption) LookupClusterResultOutput

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

    public static class GetCluster 
    {
        public static Task<GetClusterResult> InvokeAsync(GetClusterArgs args, InvokeOptions? opts = null)
        public static Output<GetClusterResult> Invoke(GetClusterInvokeArgs args, InvokeOptions? opts = null)
    }
    public static CompletableFuture<GetClusterResult> getCluster(GetClusterArgs args, InvokeOptions options)
    public static Output<GetClusterResult> getCluster(GetClusterArgs args, InvokeOptions options)
    
    fn::invoke:
      function: redpanda:index/getCluster:getCluster
      arguments:
        # arguments dictionary

    The following arguments are supported:

    Id string
    ID of the cluster. ID is an output from the Create Cluster endpoint and cannot be set by the caller.
    Id string
    ID of the cluster. ID is an output from the Create Cluster endpoint and cannot be set by the caller.
    id String
    ID of the cluster. ID is an output from the Create Cluster endpoint and cannot be set by the caller.
    id string
    ID of the cluster. ID is an output from the Create Cluster endpoint and cannot be set by the caller.
    id str
    ID of the cluster. ID is an output from the Create Cluster endpoint and cannot be set by the caller.
    id String
    ID of the cluster. ID is an output from the Create Cluster endpoint and cannot be set by the caller.

    getCluster Result

    The following output properties are available:

    AllowDeletion bool
    Whether cluster deletion is allowed.
    AwsPrivateLink GetClusterAwsPrivateLink
    AWS PrivateLink configuration.
    AzurePrivateLink GetClusterAzurePrivateLink
    Azure Private Link configuration.
    CloudProvider string
    Cloud provider where resources are created.
    ClusterApiUrl string
    The URL of the cluster API.
    ClusterType string
    Cluster type. Type is immutable and can only be set on cluster creation.
    ConnectionType string
    Cluster connection type. Private clusters are not exposed to the internet. For BYOC clusters, Private is best-practice.
    Connectivity GetClusterConnectivity
    Cloud provider-specific connectivity configuration.
    CreatedAt string
    Timestamp when the cluster was created.
    CustomerManagedResources GetClusterCustomerManagedResources
    Customer managed resources configuration for the cluster.
    GcpPrivateServiceConnect GetClusterGcpPrivateServiceConnect
    GCP Private Service Connect configuration.
    HttpProxy GetClusterHttpProxy
    HTTP Proxy properties.
    Id string
    ID of the cluster. ID is an output from the Create Cluster endpoint and cannot be set by the caller.
    KafkaApi GetClusterKafkaApi
    Cluster's Kafka API properties.
    KafkaConnect GetClusterKafkaConnect
    Kafka Connect configuration.
    MaintenanceWindowConfig GetClusterMaintenanceWindowConfig
    Maintenance window configuration for the cluster.
    Name string
    Unique name of the cluster.
    NetworkId string
    Network ID where cluster is placed.
    Prometheus GetClusterPrometheus
    Prometheus metrics endpoint properties.
    ReadReplicaClusterIds List<string>
    IDs of clusters that can create read-only topics from this cluster.
    RedpandaConsole GetClusterRedpandaConsole
    Redpanda Console properties.
    RedpandaVersion string
    Current Redpanda version of the cluster.
    Region string
    Cloud provider region.
    ResourceGroupId string
    Resource group ID of the cluster.
    SchemaRegistry GetClusterSchemaRegistry
    Schema Registry properties.
    State string
    Current state of the cluster.
    StateDescription GetClusterStateDescription
    Detailed state description when cluster is in a non-ready state.
    Tags Dictionary<string, string>
    Tags placed on cloud resources.
    ThroughputTier string
    Throughput tier of the cluster.
    Zones List<string>
    Zones of the cluster. Must be valid zones within the selected region. If multiple zones are used, the cluster is a multi-AZ cluster.
    AllowDeletion bool
    Whether cluster deletion is allowed.
    AwsPrivateLink GetClusterAwsPrivateLink
    AWS PrivateLink configuration.
    AzurePrivateLink GetClusterAzurePrivateLink
    Azure Private Link configuration.
    CloudProvider string
    Cloud provider where resources are created.
    ClusterApiUrl string
    The URL of the cluster API.
    ClusterType string
    Cluster type. Type is immutable and can only be set on cluster creation.
    ConnectionType string
    Cluster connection type. Private clusters are not exposed to the internet. For BYOC clusters, Private is best-practice.
    Connectivity GetClusterConnectivity
    Cloud provider-specific connectivity configuration.
    CreatedAt string
    Timestamp when the cluster was created.
    CustomerManagedResources GetClusterCustomerManagedResources
    Customer managed resources configuration for the cluster.
    GcpPrivateServiceConnect GetClusterGcpPrivateServiceConnect
    GCP Private Service Connect configuration.
    HttpProxy GetClusterHttpProxy
    HTTP Proxy properties.
    Id string
    ID of the cluster. ID is an output from the Create Cluster endpoint and cannot be set by the caller.
    KafkaApi GetClusterKafkaApi
    Cluster's Kafka API properties.
    KafkaConnect GetClusterKafkaConnect
    Kafka Connect configuration.
    MaintenanceWindowConfig GetClusterMaintenanceWindowConfig
    Maintenance window configuration for the cluster.
    Name string
    Unique name of the cluster.
    NetworkId string
    Network ID where cluster is placed.
    Prometheus GetClusterPrometheus
    Prometheus metrics endpoint properties.
    ReadReplicaClusterIds []string
    IDs of clusters that can create read-only topics from this cluster.
    RedpandaConsole GetClusterRedpandaConsole
    Redpanda Console properties.
    RedpandaVersion string
    Current Redpanda version of the cluster.
    Region string
    Cloud provider region.
    ResourceGroupId string
    Resource group ID of the cluster.
    SchemaRegistry GetClusterSchemaRegistry
    Schema Registry properties.
    State string
    Current state of the cluster.
    StateDescription GetClusterStateDescription
    Detailed state description when cluster is in a non-ready state.
    Tags map[string]string
    Tags placed on cloud resources.
    ThroughputTier string
    Throughput tier of the cluster.
    Zones []string
    Zones of the cluster. Must be valid zones within the selected region. If multiple zones are used, the cluster is a multi-AZ cluster.
    allowDeletion Boolean
    Whether cluster deletion is allowed.
    awsPrivateLink GetClusterAwsPrivateLink
    AWS PrivateLink configuration.
    azurePrivateLink GetClusterAzurePrivateLink
    Azure Private Link configuration.
    cloudProvider String
    Cloud provider where resources are created.
    clusterApiUrl String
    The URL of the cluster API.
    clusterType String
    Cluster type. Type is immutable and can only be set on cluster creation.
    connectionType String
    Cluster connection type. Private clusters are not exposed to the internet. For BYOC clusters, Private is best-practice.
    connectivity GetClusterConnectivity
    Cloud provider-specific connectivity configuration.
    createdAt String
    Timestamp when the cluster was created.
    customerManagedResources GetClusterCustomerManagedResources
    Customer managed resources configuration for the cluster.
    gcpPrivateServiceConnect GetClusterGcpPrivateServiceConnect
    GCP Private Service Connect configuration.
    httpProxy GetClusterHttpProxy
    HTTP Proxy properties.
    id String
    ID of the cluster. ID is an output from the Create Cluster endpoint and cannot be set by the caller.
    kafkaApi GetClusterKafkaApi
    Cluster's Kafka API properties.
    kafkaConnect GetClusterKafkaConnect
    Kafka Connect configuration.
    maintenanceWindowConfig GetClusterMaintenanceWindowConfig
    Maintenance window configuration for the cluster.
    name String
    Unique name of the cluster.
    networkId String
    Network ID where cluster is placed.
    prometheus GetClusterPrometheus
    Prometheus metrics endpoint properties.
    readReplicaClusterIds List<String>
    IDs of clusters that can create read-only topics from this cluster.
    redpandaConsole GetClusterRedpandaConsole
    Redpanda Console properties.
    redpandaVersion String
    Current Redpanda version of the cluster.
    region String
    Cloud provider region.
    resourceGroupId String
    Resource group ID of the cluster.
    schemaRegistry GetClusterSchemaRegistry
    Schema Registry properties.
    state String
    Current state of the cluster.
    stateDescription GetClusterStateDescription
    Detailed state description when cluster is in a non-ready state.
    tags Map<String,String>
    Tags placed on cloud resources.
    throughputTier String
    Throughput tier of the cluster.
    zones List<String>
    Zones of the cluster. Must be valid zones within the selected region. If multiple zones are used, the cluster is a multi-AZ cluster.
    allowDeletion boolean
    Whether cluster deletion is allowed.
    awsPrivateLink GetClusterAwsPrivateLink
    AWS PrivateLink configuration.
    azurePrivateLink GetClusterAzurePrivateLink
    Azure Private Link configuration.
    cloudProvider string
    Cloud provider where resources are created.
    clusterApiUrl string
    The URL of the cluster API.
    clusterType string
    Cluster type. Type is immutable and can only be set on cluster creation.
    connectionType string
    Cluster connection type. Private clusters are not exposed to the internet. For BYOC clusters, Private is best-practice.
    connectivity GetClusterConnectivity
    Cloud provider-specific connectivity configuration.
    createdAt string
    Timestamp when the cluster was created.
    customerManagedResources GetClusterCustomerManagedResources
    Customer managed resources configuration for the cluster.
    gcpPrivateServiceConnect GetClusterGcpPrivateServiceConnect
    GCP Private Service Connect configuration.
    httpProxy GetClusterHttpProxy
    HTTP Proxy properties.
    id string
    ID of the cluster. ID is an output from the Create Cluster endpoint and cannot be set by the caller.
    kafkaApi GetClusterKafkaApi
    Cluster's Kafka API properties.
    kafkaConnect GetClusterKafkaConnect
    Kafka Connect configuration.
    maintenanceWindowConfig GetClusterMaintenanceWindowConfig
    Maintenance window configuration for the cluster.
    name string
    Unique name of the cluster.
    networkId string
    Network ID where cluster is placed.
    prometheus GetClusterPrometheus
    Prometheus metrics endpoint properties.
    readReplicaClusterIds string[]
    IDs of clusters that can create read-only topics from this cluster.
    redpandaConsole GetClusterRedpandaConsole
    Redpanda Console properties.
    redpandaVersion string
    Current Redpanda version of the cluster.
    region string
    Cloud provider region.
    resourceGroupId string
    Resource group ID of the cluster.
    schemaRegistry GetClusterSchemaRegistry
    Schema Registry properties.
    state string
    Current state of the cluster.
    stateDescription GetClusterStateDescription
    Detailed state description when cluster is in a non-ready state.
    tags {[key: string]: string}
    Tags placed on cloud resources.
    throughputTier string
    Throughput tier of the cluster.
    zones string[]
    Zones of the cluster. Must be valid zones within the selected region. If multiple zones are used, the cluster is a multi-AZ cluster.
    allow_deletion bool
    Whether cluster deletion is allowed.
    aws_private_link GetClusterAwsPrivateLink
    AWS PrivateLink configuration.
    azure_private_link GetClusterAzurePrivateLink
    Azure Private Link configuration.
    cloud_provider str
    Cloud provider where resources are created.
    cluster_api_url str
    The URL of the cluster API.
    cluster_type str
    Cluster type. Type is immutable and can only be set on cluster creation.
    connection_type str
    Cluster connection type. Private clusters are not exposed to the internet. For BYOC clusters, Private is best-practice.
    connectivity GetClusterConnectivity
    Cloud provider-specific connectivity configuration.
    created_at str
    Timestamp when the cluster was created.
    customer_managed_resources GetClusterCustomerManagedResources
    Customer managed resources configuration for the cluster.
    gcp_private_service_connect GetClusterGcpPrivateServiceConnect
    GCP Private Service Connect configuration.
    http_proxy GetClusterHttpProxy
    HTTP Proxy properties.
    id str
    ID of the cluster. ID is an output from the Create Cluster endpoint and cannot be set by the caller.
    kafka_api GetClusterKafkaApi
    Cluster's Kafka API properties.
    kafka_connect GetClusterKafkaConnect
    Kafka Connect configuration.
    maintenance_window_config GetClusterMaintenanceWindowConfig
    Maintenance window configuration for the cluster.
    name str
    Unique name of the cluster.
    network_id str
    Network ID where cluster is placed.
    prometheus GetClusterPrometheus
    Prometheus metrics endpoint properties.
    read_replica_cluster_ids Sequence[str]
    IDs of clusters that can create read-only topics from this cluster.
    redpanda_console GetClusterRedpandaConsole
    Redpanda Console properties.
    redpanda_version str
    Current Redpanda version of the cluster.
    region str
    Cloud provider region.
    resource_group_id str
    Resource group ID of the cluster.
    schema_registry GetClusterSchemaRegistry
    Schema Registry properties.
    state str
    Current state of the cluster.
    state_description GetClusterStateDescription
    Detailed state description when cluster is in a non-ready state.
    tags Mapping[str, str]
    Tags placed on cloud resources.
    throughput_tier str
    Throughput tier of the cluster.
    zones Sequence[str]
    Zones of the cluster. Must be valid zones within the selected region. If multiple zones are used, the cluster is a multi-AZ cluster.
    allowDeletion Boolean
    Whether cluster deletion is allowed.
    awsPrivateLink Property Map
    AWS PrivateLink configuration.
    azurePrivateLink Property Map
    Azure Private Link configuration.
    cloudProvider String
    Cloud provider where resources are created.
    clusterApiUrl String
    The URL of the cluster API.
    clusterType String
    Cluster type. Type is immutable and can only be set on cluster creation.
    connectionType String
    Cluster connection type. Private clusters are not exposed to the internet. For BYOC clusters, Private is best-practice.
    connectivity Property Map
    Cloud provider-specific connectivity configuration.
    createdAt String
    Timestamp when the cluster was created.
    customerManagedResources Property Map
    Customer managed resources configuration for the cluster.
    gcpPrivateServiceConnect Property Map
    GCP Private Service Connect configuration.
    httpProxy Property Map
    HTTP Proxy properties.
    id String
    ID of the cluster. ID is an output from the Create Cluster endpoint and cannot be set by the caller.
    kafkaApi Property Map
    Cluster's Kafka API properties.
    kafkaConnect Property Map
    Kafka Connect configuration.
    maintenanceWindowConfig Property Map
    Maintenance window configuration for the cluster.
    name String
    Unique name of the cluster.
    networkId String
    Network ID where cluster is placed.
    prometheus Property Map
    Prometheus metrics endpoint properties.
    readReplicaClusterIds List<String>
    IDs of clusters that can create read-only topics from this cluster.
    redpandaConsole Property Map
    Redpanda Console properties.
    redpandaVersion String
    Current Redpanda version of the cluster.
    region String
    Cloud provider region.
    resourceGroupId String
    Resource group ID of the cluster.
    schemaRegistry Property Map
    Schema Registry properties.
    state String
    Current state of the cluster.
    stateDescription Property Map
    Detailed state description when cluster is in a non-ready state.
    tags Map<String>
    Tags placed on cloud resources.
    throughputTier String
    Throughput tier of the cluster.
    zones List<String>
    Zones of the cluster. Must be valid zones within the selected region. If multiple zones are used, the cluster is a multi-AZ cluster.

    Supporting Types

    AllowedPrincipals List<string>
    The ARN of the principals that can access the Redpanda AWS PrivateLink Endpoint Service.
    ConnectConsole bool
    Whether Console is connected via PrivateLink.
    Enabled bool
    Whether AWS PrivateLink is enabled.
    Status GetClusterAwsPrivateLinkStatus
    Current status of the PrivateLink configuration.
    AllowedPrincipals []string
    The ARN of the principals that can access the Redpanda AWS PrivateLink Endpoint Service.
    ConnectConsole bool
    Whether Console is connected via PrivateLink.
    Enabled bool
    Whether AWS PrivateLink is enabled.
    Status GetClusterAwsPrivateLinkStatus
    Current status of the PrivateLink configuration.
    allowedPrincipals List<String>
    The ARN of the principals that can access the Redpanda AWS PrivateLink Endpoint Service.
    connectConsole Boolean
    Whether Console is connected via PrivateLink.
    enabled Boolean
    Whether AWS PrivateLink is enabled.
    status GetClusterAwsPrivateLinkStatus
    Current status of the PrivateLink configuration.
    allowedPrincipals string[]
    The ARN of the principals that can access the Redpanda AWS PrivateLink Endpoint Service.
    connectConsole boolean
    Whether Console is connected via PrivateLink.
    enabled boolean
    Whether AWS PrivateLink is enabled.
    status GetClusterAwsPrivateLinkStatus
    Current status of the PrivateLink configuration.
    allowed_principals Sequence[str]
    The ARN of the principals that can access the Redpanda AWS PrivateLink Endpoint Service.
    connect_console bool
    Whether Console is connected via PrivateLink.
    enabled bool
    Whether AWS PrivateLink is enabled.
    status GetClusterAwsPrivateLinkStatus
    Current status of the PrivateLink configuration.
    allowedPrincipals List<String>
    The ARN of the principals that can access the Redpanda AWS PrivateLink Endpoint Service.
    connectConsole Boolean
    Whether Console is connected via PrivateLink.
    enabled Boolean
    Whether AWS PrivateLink is enabled.
    status Property Map
    Current status of the PrivateLink configuration.

    GetClusterAwsPrivateLinkStatus

    ConsolePort double
    Port for Redpanda Console.
    CreatedAt string
    When the PrivateLink service was created.
    DeletedAt string
    When the PrivateLink service was deleted.
    KafkaApiNodeBasePort double
    Base port for Kafka API nodes.
    KafkaApiSeedPort double
    Port for Kafka API seed brokers.
    RedpandaProxyNodeBasePort double
    Base port for HTTP proxy nodes.
    RedpandaProxySeedPort double
    Port for HTTP proxy.
    SchemaRegistrySeedPort double
    Port for Schema Registry.
    ServiceId string
    The PrivateLink service ID.
    ServiceName string
    The PrivateLink service name.
    ServiceState string
    Current state of the PrivateLink service.
    VpcEndpointConnections List<GetClusterAwsPrivateLinkStatusVpcEndpointConnection>
    List of VPC endpoint connections.
    ConsolePort float64
    Port for Redpanda Console.
    CreatedAt string
    When the PrivateLink service was created.
    DeletedAt string
    When the PrivateLink service was deleted.
    KafkaApiNodeBasePort float64
    Base port for Kafka API nodes.
    KafkaApiSeedPort float64
    Port for Kafka API seed brokers.
    RedpandaProxyNodeBasePort float64
    Base port for HTTP proxy nodes.
    RedpandaProxySeedPort float64
    Port for HTTP proxy.
    SchemaRegistrySeedPort float64
    Port for Schema Registry.
    ServiceId string
    The PrivateLink service ID.
    ServiceName string
    The PrivateLink service name.
    ServiceState string
    Current state of the PrivateLink service.
    VpcEndpointConnections []GetClusterAwsPrivateLinkStatusVpcEndpointConnection
    List of VPC endpoint connections.
    consolePort Double
    Port for Redpanda Console.
    createdAt String
    When the PrivateLink service was created.
    deletedAt String
    When the PrivateLink service was deleted.
    kafkaApiNodeBasePort Double
    Base port for Kafka API nodes.
    kafkaApiSeedPort Double
    Port for Kafka API seed brokers.
    redpandaProxyNodeBasePort Double
    Base port for HTTP proxy nodes.
    redpandaProxySeedPort Double
    Port for HTTP proxy.
    schemaRegistrySeedPort Double
    Port for Schema Registry.
    serviceId String
    The PrivateLink service ID.
    serviceName String
    The PrivateLink service name.
    serviceState String
    Current state of the PrivateLink service.
    vpcEndpointConnections List<GetClusterAwsPrivateLinkStatusVpcEndpointConnection>
    List of VPC endpoint connections.
    consolePort number
    Port for Redpanda Console.
    createdAt string
    When the PrivateLink service was created.
    deletedAt string
    When the PrivateLink service was deleted.
    kafkaApiNodeBasePort number
    Base port for Kafka API nodes.
    kafkaApiSeedPort number
    Port for Kafka API seed brokers.
    redpandaProxyNodeBasePort number
    Base port for HTTP proxy nodes.
    redpandaProxySeedPort number
    Port for HTTP proxy.
    schemaRegistrySeedPort number
    Port for Schema Registry.
    serviceId string
    The PrivateLink service ID.
    serviceName string
    The PrivateLink service name.
    serviceState string
    Current state of the PrivateLink service.
    vpcEndpointConnections GetClusterAwsPrivateLinkStatusVpcEndpointConnection[]
    List of VPC endpoint connections.
    console_port float
    Port for Redpanda Console.
    created_at str
    When the PrivateLink service was created.
    deleted_at str
    When the PrivateLink service was deleted.
    kafka_api_node_base_port float
    Base port for Kafka API nodes.
    kafka_api_seed_port float
    Port for Kafka API seed brokers.
    redpanda_proxy_node_base_port float
    Base port for HTTP proxy nodes.
    redpanda_proxy_seed_port float
    Port for HTTP proxy.
    schema_registry_seed_port float
    Port for Schema Registry.
    service_id str
    The PrivateLink service ID.
    service_name str
    The PrivateLink service name.
    service_state str
    Current state of the PrivateLink service.
    vpc_endpoint_connections Sequence[GetClusterAwsPrivateLinkStatusVpcEndpointConnection]
    List of VPC endpoint connections.
    consolePort Number
    Port for Redpanda Console.
    createdAt String
    When the PrivateLink service was created.
    deletedAt String
    When the PrivateLink service was deleted.
    kafkaApiNodeBasePort Number
    Base port for Kafka API nodes.
    kafkaApiSeedPort Number
    Port for Kafka API seed brokers.
    redpandaProxyNodeBasePort Number
    Base port for HTTP proxy nodes.
    redpandaProxySeedPort Number
    Port for HTTP proxy.
    schemaRegistrySeedPort Number
    Port for Schema Registry.
    serviceId String
    The PrivateLink service ID.
    serviceName String
    The PrivateLink service name.
    serviceState String
    Current state of the PrivateLink service.
    vpcEndpointConnections List<Property Map>
    List of VPC endpoint connections.

    GetClusterAwsPrivateLinkStatusVpcEndpointConnection

    ConnectionId string
    The connection ID.
    CreatedAt string
    When the endpoint connection was created.
    DnsEntries List<GetClusterAwsPrivateLinkStatusVpcEndpointConnectionDnsEntry>
    DNS entries for the endpoint.
    Id string
    The endpoint connection ID.
    LoadBalancerArns List<string>
    ARNs of associated load balancers.
    Owner string
    Owner of the endpoint connection.
    State string
    State of the endpoint connection.
    ConnectionId string
    The connection ID.
    CreatedAt string
    When the endpoint connection was created.
    DnsEntries []GetClusterAwsPrivateLinkStatusVpcEndpointConnectionDnsEntry
    DNS entries for the endpoint.
    Id string
    The endpoint connection ID.
    LoadBalancerArns []string
    ARNs of associated load balancers.
    Owner string
    Owner of the endpoint connection.
    State string
    State of the endpoint connection.
    connectionId String
    The connection ID.
    createdAt String
    When the endpoint connection was created.
    dnsEntries List<GetClusterAwsPrivateLinkStatusVpcEndpointConnectionDnsEntry>
    DNS entries for the endpoint.
    id String
    The endpoint connection ID.
    loadBalancerArns List<String>
    ARNs of associated load balancers.
    owner String
    Owner of the endpoint connection.
    state String
    State of the endpoint connection.
    connectionId string
    The connection ID.
    createdAt string
    When the endpoint connection was created.
    dnsEntries GetClusterAwsPrivateLinkStatusVpcEndpointConnectionDnsEntry[]
    DNS entries for the endpoint.
    id string
    The endpoint connection ID.
    loadBalancerArns string[]
    ARNs of associated load balancers.
    owner string
    Owner of the endpoint connection.
    state string
    State of the endpoint connection.
    connection_id str
    The connection ID.
    created_at str
    When the endpoint connection was created.
    dns_entries Sequence[GetClusterAwsPrivateLinkStatusVpcEndpointConnectionDnsEntry]
    DNS entries for the endpoint.
    id str
    The endpoint connection ID.
    load_balancer_arns Sequence[str]
    ARNs of associated load balancers.
    owner str
    Owner of the endpoint connection.
    state str
    State of the endpoint connection.
    connectionId String
    The connection ID.
    createdAt String
    When the endpoint connection was created.
    dnsEntries List<Property Map>
    DNS entries for the endpoint.
    id String
    The endpoint connection ID.
    loadBalancerArns List<String>
    ARNs of associated load balancers.
    owner String
    Owner of the endpoint connection.
    state String
    State of the endpoint connection.

    GetClusterAwsPrivateLinkStatusVpcEndpointConnectionDnsEntry

    DnsName string
    The DNS name.
    HostedZoneId string
    The hosted zone ID.
    DnsName string
    The DNS name.
    HostedZoneId string
    The hosted zone ID.
    dnsName String
    The DNS name.
    hostedZoneId String
    The hosted zone ID.
    dnsName string
    The DNS name.
    hostedZoneId string
    The hosted zone ID.
    dns_name str
    The DNS name.
    hosted_zone_id str
    The hosted zone ID.
    dnsName String
    The DNS name.
    hostedZoneId String
    The hosted zone ID.
    AllowedSubscriptions List<string>
    The subscriptions that can access the Redpanda Azure PrivateLink Endpoint Service.
    ConnectConsole bool
    Whether Console is connected in Redpanda Azure Private Link Service.
    Enabled bool
    Whether Redpanda Azure Private Link Endpoint Service is enabled.
    Status GetClusterAzurePrivateLinkStatus
    Current status of the Private Link configuration.
    AllowedSubscriptions []string
    The subscriptions that can access the Redpanda Azure PrivateLink Endpoint Service.
    ConnectConsole bool
    Whether Console is connected in Redpanda Azure Private Link Service.
    Enabled bool
    Whether Redpanda Azure Private Link Endpoint Service is enabled.
    Status GetClusterAzurePrivateLinkStatus
    Current status of the Private Link configuration.
    allowedSubscriptions List<String>
    The subscriptions that can access the Redpanda Azure PrivateLink Endpoint Service.
    connectConsole Boolean
    Whether Console is connected in Redpanda Azure Private Link Service.
    enabled Boolean
    Whether Redpanda Azure Private Link Endpoint Service is enabled.
    status GetClusterAzurePrivateLinkStatus
    Current status of the Private Link configuration.
    allowedSubscriptions string[]
    The subscriptions that can access the Redpanda Azure PrivateLink Endpoint Service.
    connectConsole boolean
    Whether Console is connected in Redpanda Azure Private Link Service.
    enabled boolean
    Whether Redpanda Azure Private Link Endpoint Service is enabled.
    status GetClusterAzurePrivateLinkStatus
    Current status of the Private Link configuration.
    allowed_subscriptions Sequence[str]
    The subscriptions that can access the Redpanda Azure PrivateLink Endpoint Service.
    connect_console bool
    Whether Console is connected in Redpanda Azure Private Link Service.
    enabled bool
    Whether Redpanda Azure Private Link Endpoint Service is enabled.
    status GetClusterAzurePrivateLinkStatus
    Current status of the Private Link configuration.
    allowedSubscriptions List<String>
    The subscriptions that can access the Redpanda Azure PrivateLink Endpoint Service.
    connectConsole Boolean
    Whether Console is connected in Redpanda Azure Private Link Service.
    enabled Boolean
    Whether Redpanda Azure Private Link Endpoint Service is enabled.
    status Property Map
    Current status of the Private Link configuration.

    GetClusterAzurePrivateLinkStatus

    ApprovedSubscriptions List<string>
    List of approved Azure subscription IDs.
    ConsolePort double
    Port for Redpanda Console.
    CreatedAt string
    When the Private Link service was created.
    DeletedAt string
    When the Private Link service was deleted.
    DnsARecord string
    DNS A record for the service.
    KafkaApiNodeBasePort double
    Base port for Kafka API nodes.
    KafkaApiSeedPort double
    Port for Kafka API seed brokers.
    PrivateEndpointConnections List<GetClusterAzurePrivateLinkStatusPrivateEndpointConnection>
    List of private endpoint connections.
    RedpandaProxyNodeBasePort double
    Base port for HTTP proxy nodes.
    RedpandaProxySeedPort double
    Port for HTTP proxy.
    SchemaRegistrySeedPort double
    Port for Schema Registry.
    ServiceId string
    The Private Link service ID.
    ServiceName string
    The Private Link service name.
    ApprovedSubscriptions []string
    List of approved Azure subscription IDs.
    ConsolePort float64
    Port for Redpanda Console.
    CreatedAt string
    When the Private Link service was created.
    DeletedAt string
    When the Private Link service was deleted.
    DnsARecord string
    DNS A record for the service.
    KafkaApiNodeBasePort float64
    Base port for Kafka API nodes.
    KafkaApiSeedPort float64
    Port for Kafka API seed brokers.
    PrivateEndpointConnections []GetClusterAzurePrivateLinkStatusPrivateEndpointConnection
    List of private endpoint connections.
    RedpandaProxyNodeBasePort float64
    Base port for HTTP proxy nodes.
    RedpandaProxySeedPort float64
    Port for HTTP proxy.
    SchemaRegistrySeedPort float64
    Port for Schema Registry.
    ServiceId string
    The Private Link service ID.
    ServiceName string
    The Private Link service name.
    approvedSubscriptions List<String>
    List of approved Azure subscription IDs.
    consolePort Double
    Port for Redpanda Console.
    createdAt String
    When the Private Link service was created.
    deletedAt String
    When the Private Link service was deleted.
    dnsARecord String
    DNS A record for the service.
    kafkaApiNodeBasePort Double
    Base port for Kafka API nodes.
    kafkaApiSeedPort Double
    Port for Kafka API seed brokers.
    privateEndpointConnections List<GetClusterAzurePrivateLinkStatusPrivateEndpointConnection>
    List of private endpoint connections.
    redpandaProxyNodeBasePort Double
    Base port for HTTP proxy nodes.
    redpandaProxySeedPort Double
    Port for HTTP proxy.
    schemaRegistrySeedPort Double
    Port for Schema Registry.
    serviceId String
    The Private Link service ID.
    serviceName String
    The Private Link service name.
    approvedSubscriptions string[]
    List of approved Azure subscription IDs.
    consolePort number
    Port for Redpanda Console.
    createdAt string
    When the Private Link service was created.
    deletedAt string
    When the Private Link service was deleted.
    dnsARecord string
    DNS A record for the service.
    kafkaApiNodeBasePort number
    Base port for Kafka API nodes.
    kafkaApiSeedPort number
    Port for Kafka API seed brokers.
    privateEndpointConnections GetClusterAzurePrivateLinkStatusPrivateEndpointConnection[]
    List of private endpoint connections.
    redpandaProxyNodeBasePort number
    Base port for HTTP proxy nodes.
    redpandaProxySeedPort number
    Port for HTTP proxy.
    schemaRegistrySeedPort number
    Port for Schema Registry.
    serviceId string
    The Private Link service ID.
    serviceName string
    The Private Link service name.
    approved_subscriptions Sequence[str]
    List of approved Azure subscription IDs.
    console_port float
    Port for Redpanda Console.
    created_at str
    When the Private Link service was created.
    deleted_at str
    When the Private Link service was deleted.
    dns_a_record str
    DNS A record for the service.
    kafka_api_node_base_port float
    Base port for Kafka API nodes.
    kafka_api_seed_port float
    Port for Kafka API seed brokers.
    private_endpoint_connections Sequence[GetClusterAzurePrivateLinkStatusPrivateEndpointConnection]
    List of private endpoint connections.
    redpanda_proxy_node_base_port float
    Base port for HTTP proxy nodes.
    redpanda_proxy_seed_port float
    Port for HTTP proxy.
    schema_registry_seed_port float
    Port for Schema Registry.
    service_id str
    The Private Link service ID.
    service_name str
    The Private Link service name.
    approvedSubscriptions List<String>
    List of approved Azure subscription IDs.
    consolePort Number
    Port for Redpanda Console.
    createdAt String
    When the Private Link service was created.
    deletedAt String
    When the Private Link service was deleted.
    dnsARecord String
    DNS A record for the service.
    kafkaApiNodeBasePort Number
    Base port for Kafka API nodes.
    kafkaApiSeedPort Number
    Port for Kafka API seed brokers.
    privateEndpointConnections List<Property Map>
    List of private endpoint connections.
    redpandaProxyNodeBasePort Number
    Base port for HTTP proxy nodes.
    redpandaProxySeedPort Number
    Port for HTTP proxy.
    schemaRegistrySeedPort Number
    Port for Schema Registry.
    serviceId String
    The Private Link service ID.
    serviceName String
    The Private Link service name.

    GetClusterAzurePrivateLinkStatusPrivateEndpointConnection

    ConnectionId string
    ID of the connection.
    ConnectionName string
    Name of the connection.
    CreatedAt string
    When the endpoint connection was created.
    PrivateEndpointId string
    ID of the private endpoint.
    PrivateEndpointName string
    Name of the private endpoint.
    Status string
    Status of the endpoint connection.
    ConnectionId string
    ID of the connection.
    ConnectionName string
    Name of the connection.
    CreatedAt string
    When the endpoint connection was created.
    PrivateEndpointId string
    ID of the private endpoint.
    PrivateEndpointName string
    Name of the private endpoint.
    Status string
    Status of the endpoint connection.
    connectionId String
    ID of the connection.
    connectionName String
    Name of the connection.
    createdAt String
    When the endpoint connection was created.
    privateEndpointId String
    ID of the private endpoint.
    privateEndpointName String
    Name of the private endpoint.
    status String
    Status of the endpoint connection.
    connectionId string
    ID of the connection.
    connectionName string
    Name of the connection.
    createdAt string
    When the endpoint connection was created.
    privateEndpointId string
    ID of the private endpoint.
    privateEndpointName string
    Name of the private endpoint.
    status string
    Status of the endpoint connection.
    connection_id str
    ID of the connection.
    connection_name str
    Name of the connection.
    created_at str
    When the endpoint connection was created.
    private_endpoint_id str
    ID of the private endpoint.
    private_endpoint_name str
    Name of the private endpoint.
    status str
    Status of the endpoint connection.
    connectionId String
    ID of the connection.
    connectionName String
    Name of the connection.
    createdAt String
    When the endpoint connection was created.
    privateEndpointId String
    ID of the private endpoint.
    privateEndpointName String
    Name of the private endpoint.
    status String
    Status of the endpoint connection.

    GetClusterConnectivity

    Gcp GetClusterConnectivityGcp
    GCP-specific connectivity settings.
    Gcp GetClusterConnectivityGcp
    GCP-specific connectivity settings.
    gcp GetClusterConnectivityGcp
    GCP-specific connectivity settings.
    gcp GetClusterConnectivityGcp
    GCP-specific connectivity settings.
    gcp GetClusterConnectivityGcp
    GCP-specific connectivity settings.
    gcp Property Map
    GCP-specific connectivity settings.

    GetClusterConnectivityGcp

    EnableGlobalAccess bool
    Whether global access is enabled.
    EnableGlobalAccess bool
    Whether global access is enabled.
    enableGlobalAccess Boolean
    Whether global access is enabled.
    enableGlobalAccess boolean
    Whether global access is enabled.
    enable_global_access bool
    Whether global access is enabled.
    enableGlobalAccess Boolean
    Whether global access is enabled.

    GetClusterCustomerManagedResources

    GetClusterCustomerManagedResourcesAws

    AgentInstanceProfile GetClusterCustomerManagedResourcesAwsAgentInstanceProfile
    CloudStorageBucket GetClusterCustomerManagedResourcesAwsCloudStorageBucket
    ClusterSecurityGroup GetClusterCustomerManagedResourcesAwsClusterSecurityGroup
    ConnectorsNodeGroupInstanceProfile GetClusterCustomerManagedResourcesAwsConnectorsNodeGroupInstanceProfile
    ConnectorsSecurityGroup GetClusterCustomerManagedResourcesAwsConnectorsSecurityGroup
    K8sClusterRole GetClusterCustomerManagedResourcesAwsK8sClusterRole
    NodeSecurityGroup GetClusterCustomerManagedResourcesAwsNodeSecurityGroup
    PermissionsBoundaryPolicy GetClusterCustomerManagedResourcesAwsPermissionsBoundaryPolicy
    RedpandaAgentSecurityGroup GetClusterCustomerManagedResourcesAwsRedpandaAgentSecurityGroup
    RedpandaNodeGroupInstanceProfile GetClusterCustomerManagedResourcesAwsRedpandaNodeGroupInstanceProfile
    RedpandaNodeGroupSecurityGroup GetClusterCustomerManagedResourcesAwsRedpandaNodeGroupSecurityGroup
    UtilityNodeGroupInstanceProfile GetClusterCustomerManagedResourcesAwsUtilityNodeGroupInstanceProfile
    UtilitySecurityGroup GetClusterCustomerManagedResourcesAwsUtilitySecurityGroup
    AgentInstanceProfile GetClusterCustomerManagedResourcesAwsAgentInstanceProfile
    CloudStorageBucket GetClusterCustomerManagedResourcesAwsCloudStorageBucket
    ClusterSecurityGroup GetClusterCustomerManagedResourcesAwsClusterSecurityGroup
    ConnectorsNodeGroupInstanceProfile GetClusterCustomerManagedResourcesAwsConnectorsNodeGroupInstanceProfile
    ConnectorsSecurityGroup GetClusterCustomerManagedResourcesAwsConnectorsSecurityGroup
    K8sClusterRole GetClusterCustomerManagedResourcesAwsK8sClusterRole
    NodeSecurityGroup GetClusterCustomerManagedResourcesAwsNodeSecurityGroup
    PermissionsBoundaryPolicy GetClusterCustomerManagedResourcesAwsPermissionsBoundaryPolicy
    RedpandaAgentSecurityGroup GetClusterCustomerManagedResourcesAwsRedpandaAgentSecurityGroup
    RedpandaNodeGroupInstanceProfile GetClusterCustomerManagedResourcesAwsRedpandaNodeGroupInstanceProfile
    RedpandaNodeGroupSecurityGroup GetClusterCustomerManagedResourcesAwsRedpandaNodeGroupSecurityGroup
    UtilityNodeGroupInstanceProfile GetClusterCustomerManagedResourcesAwsUtilityNodeGroupInstanceProfile
    UtilitySecurityGroup GetClusterCustomerManagedResourcesAwsUtilitySecurityGroup
    agentInstanceProfile GetClusterCustomerManagedResourcesAwsAgentInstanceProfile
    cloudStorageBucket GetClusterCustomerManagedResourcesAwsCloudStorageBucket
    clusterSecurityGroup GetClusterCustomerManagedResourcesAwsClusterSecurityGroup
    connectorsNodeGroupInstanceProfile GetClusterCustomerManagedResourcesAwsConnectorsNodeGroupInstanceProfile
    connectorsSecurityGroup GetClusterCustomerManagedResourcesAwsConnectorsSecurityGroup
    k8sClusterRole GetClusterCustomerManagedResourcesAwsK8sClusterRole
    nodeSecurityGroup GetClusterCustomerManagedResourcesAwsNodeSecurityGroup
    permissionsBoundaryPolicy GetClusterCustomerManagedResourcesAwsPermissionsBoundaryPolicy
    redpandaAgentSecurityGroup GetClusterCustomerManagedResourcesAwsRedpandaAgentSecurityGroup
    redpandaNodeGroupInstanceProfile GetClusterCustomerManagedResourcesAwsRedpandaNodeGroupInstanceProfile
    redpandaNodeGroupSecurityGroup GetClusterCustomerManagedResourcesAwsRedpandaNodeGroupSecurityGroup
    utilityNodeGroupInstanceProfile GetClusterCustomerManagedResourcesAwsUtilityNodeGroupInstanceProfile
    utilitySecurityGroup GetClusterCustomerManagedResourcesAwsUtilitySecurityGroup
    agentInstanceProfile GetClusterCustomerManagedResourcesAwsAgentInstanceProfile
    cloudStorageBucket GetClusterCustomerManagedResourcesAwsCloudStorageBucket
    clusterSecurityGroup GetClusterCustomerManagedResourcesAwsClusterSecurityGroup
    connectorsNodeGroupInstanceProfile GetClusterCustomerManagedResourcesAwsConnectorsNodeGroupInstanceProfile
    connectorsSecurityGroup GetClusterCustomerManagedResourcesAwsConnectorsSecurityGroup
    k8sClusterRole GetClusterCustomerManagedResourcesAwsK8sClusterRole
    nodeSecurityGroup GetClusterCustomerManagedResourcesAwsNodeSecurityGroup
    permissionsBoundaryPolicy GetClusterCustomerManagedResourcesAwsPermissionsBoundaryPolicy
    redpandaAgentSecurityGroup GetClusterCustomerManagedResourcesAwsRedpandaAgentSecurityGroup
    redpandaNodeGroupInstanceProfile GetClusterCustomerManagedResourcesAwsRedpandaNodeGroupInstanceProfile
    redpandaNodeGroupSecurityGroup GetClusterCustomerManagedResourcesAwsRedpandaNodeGroupSecurityGroup
    utilityNodeGroupInstanceProfile GetClusterCustomerManagedResourcesAwsUtilityNodeGroupInstanceProfile
    utilitySecurityGroup GetClusterCustomerManagedResourcesAwsUtilitySecurityGroup
    agent_instance_profile GetClusterCustomerManagedResourcesAwsAgentInstanceProfile
    cloud_storage_bucket GetClusterCustomerManagedResourcesAwsCloudStorageBucket
    cluster_security_group GetClusterCustomerManagedResourcesAwsClusterSecurityGroup
    connectors_node_group_instance_profile GetClusterCustomerManagedResourcesAwsConnectorsNodeGroupInstanceProfile
    connectors_security_group GetClusterCustomerManagedResourcesAwsConnectorsSecurityGroup
    k8s_cluster_role GetClusterCustomerManagedResourcesAwsK8sClusterRole
    node_security_group GetClusterCustomerManagedResourcesAwsNodeSecurityGroup
    permissions_boundary_policy GetClusterCustomerManagedResourcesAwsPermissionsBoundaryPolicy
    redpanda_agent_security_group GetClusterCustomerManagedResourcesAwsRedpandaAgentSecurityGroup
    redpanda_node_group_instance_profile GetClusterCustomerManagedResourcesAwsRedpandaNodeGroupInstanceProfile
    redpanda_node_group_security_group GetClusterCustomerManagedResourcesAwsRedpandaNodeGroupSecurityGroup
    utility_node_group_instance_profile GetClusterCustomerManagedResourcesAwsUtilityNodeGroupInstanceProfile
    utility_security_group GetClusterCustomerManagedResourcesAwsUtilitySecurityGroup

    GetClusterCustomerManagedResourcesAwsAgentInstanceProfile

    Arn string
    ARN for the agent instance profile
    Arn string
    ARN for the agent instance profile
    arn String
    ARN for the agent instance profile
    arn string
    ARN for the agent instance profile
    arn str
    ARN for the agent instance profile
    arn String
    ARN for the agent instance profile

    GetClusterCustomerManagedResourcesAwsCloudStorageBucket

    Arn string
    ARN for the cloud storage bucket
    Arn string
    ARN for the cloud storage bucket
    arn String
    ARN for the cloud storage bucket
    arn string
    ARN for the cloud storage bucket
    arn str
    ARN for the cloud storage bucket
    arn String
    ARN for the cloud storage bucket

    GetClusterCustomerManagedResourcesAwsClusterSecurityGroup

    Arn string
    ARN for the cluster security group
    Arn string
    ARN for the cluster security group
    arn String
    ARN for the cluster security group
    arn string
    ARN for the cluster security group
    arn str
    ARN for the cluster security group
    arn String
    ARN for the cluster security group

    GetClusterCustomerManagedResourcesAwsConnectorsNodeGroupInstanceProfile

    Arn string
    ARN for the connectors node group instance profile
    Arn string
    ARN for the connectors node group instance profile
    arn String
    ARN for the connectors node group instance profile
    arn string
    ARN for the connectors node group instance profile
    arn str
    ARN for the connectors node group instance profile
    arn String
    ARN for the connectors node group instance profile

    GetClusterCustomerManagedResourcesAwsConnectorsSecurityGroup

    Arn string
    ARN for the connectors security group
    Arn string
    ARN for the connectors security group
    arn String
    ARN for the connectors security group
    arn string
    ARN for the connectors security group
    arn str
    ARN for the connectors security group
    arn String
    ARN for the connectors security group

    GetClusterCustomerManagedResourcesAwsK8sClusterRole

    Arn string
    ARN for the Kubernetes cluster role
    Arn string
    ARN for the Kubernetes cluster role
    arn String
    ARN for the Kubernetes cluster role
    arn string
    ARN for the Kubernetes cluster role
    arn str
    ARN for the Kubernetes cluster role
    arn String
    ARN for the Kubernetes cluster role

    GetClusterCustomerManagedResourcesAwsNodeSecurityGroup

    Arn string
    ARN for the node security group
    Arn string
    ARN for the node security group
    arn String
    ARN for the node security group
    arn string
    ARN for the node security group
    arn str
    ARN for the node security group
    arn String
    ARN for the node security group

    GetClusterCustomerManagedResourcesAwsPermissionsBoundaryPolicy

    Arn string
    ARN for the permissions boundary policy
    Arn string
    ARN for the permissions boundary policy
    arn String
    ARN for the permissions boundary policy
    arn string
    ARN for the permissions boundary policy
    arn str
    ARN for the permissions boundary policy
    arn String
    ARN for the permissions boundary policy

    GetClusterCustomerManagedResourcesAwsRedpandaAgentSecurityGroup

    Arn string
    ARN for the redpanda agent security group
    Arn string
    ARN for the redpanda agent security group
    arn String
    ARN for the redpanda agent security group
    arn string
    ARN for the redpanda agent security group
    arn str
    ARN for the redpanda agent security group
    arn String
    ARN for the redpanda agent security group

    GetClusterCustomerManagedResourcesAwsRedpandaNodeGroupInstanceProfile

    Arn string
    ARN for the redpanda node group instance profile
    Arn string
    ARN for the redpanda node group instance profile
    arn String
    ARN for the redpanda node group instance profile
    arn string
    ARN for the redpanda node group instance profile
    arn str
    ARN for the redpanda node group instance profile
    arn String
    ARN for the redpanda node group instance profile

    GetClusterCustomerManagedResourcesAwsRedpandaNodeGroupSecurityGroup

    Arn string
    ARN for the redpanda node group security group
    Arn string
    ARN for the redpanda node group security group
    arn String
    ARN for the redpanda node group security group
    arn string
    ARN for the redpanda node group security group
    arn str
    ARN for the redpanda node group security group
    arn String
    ARN for the redpanda node group security group

    GetClusterCustomerManagedResourcesAwsUtilityNodeGroupInstanceProfile

    Arn string
    ARN for the utility node group instance profile
    Arn string
    ARN for the utility node group instance profile
    arn String
    ARN for the utility node group instance profile
    arn string
    ARN for the utility node group instance profile
    arn str
    ARN for the utility node group instance profile
    arn String
    ARN for the utility node group instance profile

    GetClusterCustomerManagedResourcesAwsUtilitySecurityGroup

    Arn string
    ARN for the utility security group
    Arn string
    ARN for the utility security group
    arn String
    ARN for the utility security group
    arn string
    ARN for the utility security group
    arn str
    ARN for the utility security group
    arn String
    ARN for the utility security group

    GetClusterGcpPrivateServiceConnect

    ConsumerAcceptLists List<GetClusterGcpPrivateServiceConnectConsumerAcceptList>
    List of consumers that are allowed to connect to Redpanda GCP PSC service attachment.
    Enabled bool
    Whether Redpanda GCP Private Service Connect is enabled.
    GlobalAccessEnabled bool
    Whether global access is enabled.
    Status GetClusterGcpPrivateServiceConnectStatus
    Current status of the Private Service Connect configuration.
    ConsumerAcceptLists []GetClusterGcpPrivateServiceConnectConsumerAcceptList
    List of consumers that are allowed to connect to Redpanda GCP PSC service attachment.
    Enabled bool
    Whether Redpanda GCP Private Service Connect is enabled.
    GlobalAccessEnabled bool
    Whether global access is enabled.
    Status GetClusterGcpPrivateServiceConnectStatus
    Current status of the Private Service Connect configuration.
    consumerAcceptLists List<GetClusterGcpPrivateServiceConnectConsumerAcceptList>
    List of consumers that are allowed to connect to Redpanda GCP PSC service attachment.
    enabled Boolean
    Whether Redpanda GCP Private Service Connect is enabled.
    globalAccessEnabled Boolean
    Whether global access is enabled.
    status GetClusterGcpPrivateServiceConnectStatus
    Current status of the Private Service Connect configuration.
    consumerAcceptLists GetClusterGcpPrivateServiceConnectConsumerAcceptList[]
    List of consumers that are allowed to connect to Redpanda GCP PSC service attachment.
    enabled boolean
    Whether Redpanda GCP Private Service Connect is enabled.
    globalAccessEnabled boolean
    Whether global access is enabled.
    status GetClusterGcpPrivateServiceConnectStatus
    Current status of the Private Service Connect configuration.
    consumer_accept_lists Sequence[GetClusterGcpPrivateServiceConnectConsumerAcceptList]
    List of consumers that are allowed to connect to Redpanda GCP PSC service attachment.
    enabled bool
    Whether Redpanda GCP Private Service Connect is enabled.
    global_access_enabled bool
    Whether global access is enabled.
    status GetClusterGcpPrivateServiceConnectStatus
    Current status of the Private Service Connect configuration.
    consumerAcceptLists List<Property Map>
    List of consumers that are allowed to connect to Redpanda GCP PSC service attachment.
    enabled Boolean
    Whether Redpanda GCP Private Service Connect is enabled.
    globalAccessEnabled Boolean
    Whether global access is enabled.
    status Property Map
    Current status of the Private Service Connect configuration.

    GetClusterGcpPrivateServiceConnectConsumerAcceptList

    Source string
    Either the GCP project number or its alphanumeric ID.
    Source string
    Either the GCP project number or its alphanumeric ID.
    source String
    Either the GCP project number or its alphanumeric ID.
    source string
    Either the GCP project number or its alphanumeric ID.
    source str
    Either the GCP project number or its alphanumeric ID.
    source String
    Either the GCP project number or its alphanumeric ID.

    GetClusterGcpPrivateServiceConnectStatus

    ConnectedEndpoints List<GetClusterGcpPrivateServiceConnectStatusConnectedEndpoint>
    List of connected endpoints.
    CreatedAt string
    When the Private Service Connect service was created.
    DeletedAt string
    When the Private Service Connect service was deleted.
    DnsARecords List<string>
    DNS A records for the service.
    KafkaApiNodeBasePort double
    Base port for Kafka API nodes.
    KafkaApiSeedPort double
    Port for Kafka API seed brokers.
    RedpandaProxyNodeBasePort double
    Base port for HTTP proxy nodes.
    RedpandaProxySeedPort double
    Port for HTTP proxy.
    SchemaRegistrySeedPort double
    Port for Schema Registry.
    SeedHostname string
    Hostname for the seed brokers.
    ServiceAttachment string
    The service attachment identifier.
    ConnectedEndpoints []GetClusterGcpPrivateServiceConnectStatusConnectedEndpoint
    List of connected endpoints.
    CreatedAt string
    When the Private Service Connect service was created.
    DeletedAt string
    When the Private Service Connect service was deleted.
    DnsARecords []string
    DNS A records for the service.
    KafkaApiNodeBasePort float64
    Base port for Kafka API nodes.
    KafkaApiSeedPort float64
    Port for Kafka API seed brokers.
    RedpandaProxyNodeBasePort float64
    Base port for HTTP proxy nodes.
    RedpandaProxySeedPort float64
    Port for HTTP proxy.
    SchemaRegistrySeedPort float64
    Port for Schema Registry.
    SeedHostname string
    Hostname for the seed brokers.
    ServiceAttachment string
    The service attachment identifier.
    connectedEndpoints List<GetClusterGcpPrivateServiceConnectStatusConnectedEndpoint>
    List of connected endpoints.
    createdAt String
    When the Private Service Connect service was created.
    deletedAt String
    When the Private Service Connect service was deleted.
    dnsARecords List<String>
    DNS A records for the service.
    kafkaApiNodeBasePort Double
    Base port for Kafka API nodes.
    kafkaApiSeedPort Double
    Port for Kafka API seed brokers.
    redpandaProxyNodeBasePort Double
    Base port for HTTP proxy nodes.
    redpandaProxySeedPort Double
    Port for HTTP proxy.
    schemaRegistrySeedPort Double
    Port for Schema Registry.
    seedHostname String
    Hostname for the seed brokers.
    serviceAttachment String
    The service attachment identifier.
    connectedEndpoints GetClusterGcpPrivateServiceConnectStatusConnectedEndpoint[]
    List of connected endpoints.
    createdAt string
    When the Private Service Connect service was created.
    deletedAt string
    When the Private Service Connect service was deleted.
    dnsARecords string[]
    DNS A records for the service.
    kafkaApiNodeBasePort number
    Base port for Kafka API nodes.
    kafkaApiSeedPort number
    Port for Kafka API seed brokers.
    redpandaProxyNodeBasePort number
    Base port for HTTP proxy nodes.
    redpandaProxySeedPort number
    Port for HTTP proxy.
    schemaRegistrySeedPort number
    Port for Schema Registry.
    seedHostname string
    Hostname for the seed brokers.
    serviceAttachment string
    The service attachment identifier.
    connected_endpoints Sequence[GetClusterGcpPrivateServiceConnectStatusConnectedEndpoint]
    List of connected endpoints.
    created_at str
    When the Private Service Connect service was created.
    deleted_at str
    When the Private Service Connect service was deleted.
    dns_a_records Sequence[str]
    DNS A records for the service.
    kafka_api_node_base_port float
    Base port for Kafka API nodes.
    kafka_api_seed_port float
    Port for Kafka API seed brokers.
    redpanda_proxy_node_base_port float
    Base port for HTTP proxy nodes.
    redpanda_proxy_seed_port float
    Port for HTTP proxy.
    schema_registry_seed_port float
    Port for Schema Registry.
    seed_hostname str
    Hostname for the seed brokers.
    service_attachment str
    The service attachment identifier.
    connectedEndpoints List<Property Map>
    List of connected endpoints.
    createdAt String
    When the Private Service Connect service was created.
    deletedAt String
    When the Private Service Connect service was deleted.
    dnsARecords List<String>
    DNS A records for the service.
    kafkaApiNodeBasePort Number
    Base port for Kafka API nodes.
    kafkaApiSeedPort Number
    Port for Kafka API seed brokers.
    redpandaProxyNodeBasePort Number
    Base port for HTTP proxy nodes.
    redpandaProxySeedPort Number
    Port for HTTP proxy.
    schemaRegistrySeedPort Number
    Port for Schema Registry.
    seedHostname String
    Hostname for the seed brokers.
    serviceAttachment String
    The service attachment identifier.

    GetClusterGcpPrivateServiceConnectStatusConnectedEndpoint

    ConnectionId string
    The connection ID.
    ConsumerNetwork string
    The consumer network.
    Endpoint string
    The endpoint address.
    Status string
    Status of the endpoint connection.
    ConnectionId string
    The connection ID.
    ConsumerNetwork string
    The consumer network.
    Endpoint string
    The endpoint address.
    Status string
    Status of the endpoint connection.
    connectionId String
    The connection ID.
    consumerNetwork String
    The consumer network.
    endpoint String
    The endpoint address.
    status String
    Status of the endpoint connection.
    connectionId string
    The connection ID.
    consumerNetwork string
    The consumer network.
    endpoint string
    The endpoint address.
    status string
    Status of the endpoint connection.
    connection_id str
    The connection ID.
    consumer_network str
    The consumer network.
    endpoint str
    The endpoint address.
    status str
    Status of the endpoint connection.
    connectionId String
    The connection ID.
    consumerNetwork String
    The consumer network.
    endpoint String
    The endpoint address.
    status String
    Status of the endpoint connection.

    GetClusterHttpProxy

    Mtls GetClusterHttpProxyMtls
    mTLS configuration.
    Url string
    The HTTP Proxy URL.
    Mtls GetClusterHttpProxyMtls
    mTLS configuration.
    Url string
    The HTTP Proxy URL.
    mtls GetClusterHttpProxyMtls
    mTLS configuration.
    url String
    The HTTP Proxy URL.
    mtls GetClusterHttpProxyMtls
    mTLS configuration.
    url string
    The HTTP Proxy URL.
    mtls GetClusterHttpProxyMtls
    mTLS configuration.
    url str
    The HTTP Proxy URL.
    mtls Property Map
    mTLS configuration.
    url String
    The HTTP Proxy URL.

    GetClusterHttpProxyMtls

    CaCertificatesPems List<string>
    CA certificate in PEM format.
    Enabled bool
    Whether mTLS is enabled.
    PrincipalMappingRules List<string>
    Principal mapping rules for mTLS authentication.
    CaCertificatesPems []string
    CA certificate in PEM format.
    Enabled bool
    Whether mTLS is enabled.
    PrincipalMappingRules []string
    Principal mapping rules for mTLS authentication.
    caCertificatesPems List<String>
    CA certificate in PEM format.
    enabled Boolean
    Whether mTLS is enabled.
    principalMappingRules List<String>
    Principal mapping rules for mTLS authentication.
    caCertificatesPems string[]
    CA certificate in PEM format.
    enabled boolean
    Whether mTLS is enabled.
    principalMappingRules string[]
    Principal mapping rules for mTLS authentication.
    ca_certificates_pems Sequence[str]
    CA certificate in PEM format.
    enabled bool
    Whether mTLS is enabled.
    principal_mapping_rules Sequence[str]
    Principal mapping rules for mTLS authentication.
    caCertificatesPems List<String>
    CA certificate in PEM format.
    enabled Boolean
    Whether mTLS is enabled.
    principalMappingRules List<String>
    Principal mapping rules for mTLS authentication.

    GetClusterKafkaApi

    Mtls GetClusterKafkaApiMtls
    mTLS configuration.
    SeedBrokers List<string>
    List of Kafka broker addresses.
    Mtls GetClusterKafkaApiMtls
    mTLS configuration.
    SeedBrokers []string
    List of Kafka broker addresses.
    mtls GetClusterKafkaApiMtls
    mTLS configuration.
    seedBrokers List<String>
    List of Kafka broker addresses.
    mtls GetClusterKafkaApiMtls
    mTLS configuration.
    seedBrokers string[]
    List of Kafka broker addresses.
    mtls GetClusterKafkaApiMtls
    mTLS configuration.
    seed_brokers Sequence[str]
    List of Kafka broker addresses.
    mtls Property Map
    mTLS configuration.
    seedBrokers List<String>
    List of Kafka broker addresses.

    GetClusterKafkaApiMtls

    CaCertificatesPems List<string>
    CA certificate in PEM format.
    Enabled bool
    Whether mTLS is enabled.
    PrincipalMappingRules List<string>
    Principal mapping rules for mTLS authentication.
    CaCertificatesPems []string
    CA certificate in PEM format.
    Enabled bool
    Whether mTLS is enabled.
    PrincipalMappingRules []string
    Principal mapping rules for mTLS authentication.
    caCertificatesPems List<String>
    CA certificate in PEM format.
    enabled Boolean
    Whether mTLS is enabled.
    principalMappingRules List<String>
    Principal mapping rules for mTLS authentication.
    caCertificatesPems string[]
    CA certificate in PEM format.
    enabled boolean
    Whether mTLS is enabled.
    principalMappingRules string[]
    Principal mapping rules for mTLS authentication.
    ca_certificates_pems Sequence[str]
    CA certificate in PEM format.
    enabled bool
    Whether mTLS is enabled.
    principal_mapping_rules Sequence[str]
    Principal mapping rules for mTLS authentication.
    caCertificatesPems List<String>
    CA certificate in PEM format.
    enabled Boolean
    Whether mTLS is enabled.
    principalMappingRules List<String>
    Principal mapping rules for mTLS authentication.

    GetClusterKafkaConnect

    Enabled bool
    Whether Kafka Connect is enabled.
    Enabled bool
    Whether Kafka Connect is enabled.
    enabled Boolean
    Whether Kafka Connect is enabled.
    enabled boolean
    Whether Kafka Connect is enabled.
    enabled bool
    Whether Kafka Connect is enabled.
    enabled Boolean
    Whether Kafka Connect is enabled.

    GetClusterMaintenanceWindowConfig

    Anytime bool
    If true, maintenance can occur at any time.
    DayHour GetClusterMaintenanceWindowConfigDayHour
    Unspecified bool
    If true, maintenance window is unspecified.
    Anytime bool
    If true, maintenance can occur at any time.
    DayHour GetClusterMaintenanceWindowConfigDayHour
    Unspecified bool
    If true, maintenance window is unspecified.
    anytime Boolean
    If true, maintenance can occur at any time.
    dayHour GetClusterMaintenanceWindowConfigDayHour
    unspecified Boolean
    If true, maintenance window is unspecified.
    anytime boolean
    If true, maintenance can occur at any time.
    dayHour GetClusterMaintenanceWindowConfigDayHour
    unspecified boolean
    If true, maintenance window is unspecified.
    anytime bool
    If true, maintenance can occur at any time.
    day_hour GetClusterMaintenanceWindowConfigDayHour
    unspecified bool
    If true, maintenance window is unspecified.
    anytime Boolean
    If true, maintenance can occur at any time.
    dayHour Property Map
    unspecified Boolean
    If true, maintenance window is unspecified.

    GetClusterMaintenanceWindowConfigDayHour

    DayOfWeek string
    Day of week.
    HourOfDay double
    Hour of day.
    DayOfWeek string
    Day of week.
    HourOfDay float64
    Hour of day.
    dayOfWeek String
    Day of week.
    hourOfDay Double
    Hour of day.
    dayOfWeek string
    Day of week.
    hourOfDay number
    Hour of day.
    day_of_week str
    Day of week.
    hour_of_day float
    Hour of day.
    dayOfWeek String
    Day of week.
    hourOfDay Number
    Hour of day.

    GetClusterPrometheus

    Url string
    The Prometheus metrics endpoint URL.
    Url string
    The Prometheus metrics endpoint URL.
    url String
    The Prometheus metrics endpoint URL.
    url string
    The Prometheus metrics endpoint URL.
    url str
    The Prometheus metrics endpoint URL.
    url String
    The Prometheus metrics endpoint URL.

    GetClusterRedpandaConsole

    Url string
    The Redpanda Console URL.
    Url string
    The Redpanda Console URL.
    url String
    The Redpanda Console URL.
    url string
    The Redpanda Console URL.
    url str
    The Redpanda Console URL.
    url String
    The Redpanda Console URL.

    GetClusterSchemaRegistry

    Mtls GetClusterSchemaRegistryMtls
    mTLS configuration.
    Url string
    The Schema Registry URL.
    Mtls GetClusterSchemaRegistryMtls
    mTLS configuration.
    Url string
    The Schema Registry URL.
    mtls GetClusterSchemaRegistryMtls
    mTLS configuration.
    url String
    The Schema Registry URL.
    mtls GetClusterSchemaRegistryMtls
    mTLS configuration.
    url string
    The Schema Registry URL.
    mtls GetClusterSchemaRegistryMtls
    mTLS configuration.
    url str
    The Schema Registry URL.
    mtls Property Map
    mTLS configuration.
    url String
    The Schema Registry URL.

    GetClusterSchemaRegistryMtls

    CaCertificatesPems List<string>
    CA certificate in PEM format.
    Enabled bool
    Whether mTLS is enabled.
    PrincipalMappingRules List<string>
    Principal mapping rules for mTLS authentication.
    CaCertificatesPems []string
    CA certificate in PEM format.
    Enabled bool
    Whether mTLS is enabled.
    PrincipalMappingRules []string
    Principal mapping rules for mTLS authentication.
    caCertificatesPems List<String>
    CA certificate in PEM format.
    enabled Boolean
    Whether mTLS is enabled.
    principalMappingRules List<String>
    Principal mapping rules for mTLS authentication.
    caCertificatesPems string[]
    CA certificate in PEM format.
    enabled boolean
    Whether mTLS is enabled.
    principalMappingRules string[]
    Principal mapping rules for mTLS authentication.
    ca_certificates_pems Sequence[str]
    CA certificate in PEM format.
    enabled bool
    Whether mTLS is enabled.
    principal_mapping_rules Sequence[str]
    Principal mapping rules for mTLS authentication.
    caCertificatesPems List<String>
    CA certificate in PEM format.
    enabled Boolean
    Whether mTLS is enabled.
    principalMappingRules List<String>
    Principal mapping rules for mTLS authentication.

    GetClusterStateDescription

    Code double
    Error code if cluster is in error state.
    Message string
    Detailed error message if cluster is in error state.
    Code float64
    Error code if cluster is in error state.
    Message string
    Detailed error message if cluster is in error state.
    code Double
    Error code if cluster is in error state.
    message String
    Detailed error message if cluster is in error state.
    code number
    Error code if cluster is in error state.
    message string
    Detailed error message if cluster is in error state.
    code float
    Error code if cluster is in error state.
    message str
    Detailed error message if cluster is in error state.
    code Number
    Error code if cluster is in error state.
    message String
    Detailed error message if cluster is in error state.

    Package Details

    Repository
    redpanda redpanda-data/terraform-provider-redpanda
    License
    Notes
    This Pulumi package is based on the redpanda Terraform Provider.
    redpanda logo
    redpanda 0.13.0 published on Monday, Mar 17, 2025 by redpanda-data