redpanda 0.13.0 published on Monday, Mar 17, 2025 by redpanda-data
redpanda.getCluster
Explore with Pulumi AI
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 dictionaryThe 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.
- AwsPrivate GetLink Cluster Aws Private Link 
- AWS PrivateLink configuration.
- AzurePrivate GetLink Cluster Azure Private Link 
- Azure Private Link configuration.
- CloudProvider string
- Cloud provider where resources are created.
- ClusterApi stringUrl 
- 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
GetCluster Connectivity 
- Cloud provider-specific connectivity configuration.
- CreatedAt string
- Timestamp when the cluster was created.
- CustomerManaged GetResources Cluster Customer Managed Resources 
- Customer managed resources configuration for the cluster.
- GcpPrivate GetService Connect Cluster Gcp Private Service Connect 
- GCP Private Service Connect configuration.
- HttpProxy GetCluster Http Proxy 
- 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 GetCluster Kafka Api 
- Cluster's Kafka API properties.
- KafkaConnect GetCluster Kafka Connect 
- Kafka Connect configuration.
- MaintenanceWindow GetConfig Cluster Maintenance Window Config 
- Maintenance window configuration for the cluster.
- Name string
- Unique name of the cluster.
- NetworkId string
- Network ID where cluster is placed.
- Prometheus
GetCluster Prometheus 
- Prometheus metrics endpoint properties.
- ReadReplica List<string>Cluster Ids 
- IDs of clusters that can create read-only topics from this cluster.
- RedpandaConsole GetCluster Redpanda Console 
- Redpanda Console properties.
- RedpandaVersion string
- Current Redpanda version of the cluster.
- Region string
- Cloud provider region.
- ResourceGroup stringId 
- Resource group ID of the cluster.
- SchemaRegistry GetCluster Schema Registry 
- Schema Registry properties.
- State string
- Current state of the cluster.
- StateDescription GetCluster State Description 
- Detailed state description when cluster is in a non-ready state.
- 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.
- AwsPrivate GetLink Cluster Aws Private Link 
- AWS PrivateLink configuration.
- AzurePrivate GetLink Cluster Azure Private Link 
- Azure Private Link configuration.
- CloudProvider string
- Cloud provider where resources are created.
- ClusterApi stringUrl 
- 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
GetCluster Connectivity 
- Cloud provider-specific connectivity configuration.
- CreatedAt string
- Timestamp when the cluster was created.
- CustomerManaged GetResources Cluster Customer Managed Resources 
- Customer managed resources configuration for the cluster.
- GcpPrivate GetService Connect Cluster Gcp Private Service Connect 
- GCP Private Service Connect configuration.
- HttpProxy GetCluster Http Proxy 
- 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 GetCluster Kafka Api 
- Cluster's Kafka API properties.
- KafkaConnect GetCluster Kafka Connect 
- Kafka Connect configuration.
- MaintenanceWindow GetConfig Cluster Maintenance Window Config 
- Maintenance window configuration for the cluster.
- Name string
- Unique name of the cluster.
- NetworkId string
- Network ID where cluster is placed.
- Prometheus
GetCluster Prometheus 
- Prometheus metrics endpoint properties.
- ReadReplica []stringCluster Ids 
- IDs of clusters that can create read-only topics from this cluster.
- RedpandaConsole GetCluster Redpanda Console 
- Redpanda Console properties.
- RedpandaVersion string
- Current Redpanda version of the cluster.
- Region string
- Cloud provider region.
- ResourceGroup stringId 
- Resource group ID of the cluster.
- SchemaRegistry GetCluster Schema Registry 
- Schema Registry properties.
- State string
- Current state of the cluster.
- StateDescription GetCluster State Description 
- Detailed state description when cluster is in a non-ready state.
- 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.
- awsPrivate GetLink Cluster Aws Private Link 
- AWS PrivateLink configuration.
- azurePrivate GetLink Cluster Azure Private Link 
- Azure Private Link configuration.
- cloudProvider String
- Cloud provider where resources are created.
- clusterApi StringUrl 
- 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
GetCluster Connectivity 
- Cloud provider-specific connectivity configuration.
- createdAt String
- Timestamp when the cluster was created.
- customerManaged GetResources Cluster Customer Managed Resources 
- Customer managed resources configuration for the cluster.
- gcpPrivate GetService Connect Cluster Gcp Private Service Connect 
- GCP Private Service Connect configuration.
- httpProxy GetCluster Http Proxy 
- 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 GetCluster Kafka Api 
- Cluster's Kafka API properties.
- kafkaConnect GetCluster Kafka Connect 
- Kafka Connect configuration.
- maintenanceWindow GetConfig Cluster Maintenance Window Config 
- Maintenance window configuration for the cluster.
- name String
- Unique name of the cluster.
- networkId String
- Network ID where cluster is placed.
- prometheus
GetCluster Prometheus 
- Prometheus metrics endpoint properties.
- readReplica List<String>Cluster Ids 
- IDs of clusters that can create read-only topics from this cluster.
- redpandaConsole GetCluster Redpanda Console 
- Redpanda Console properties.
- redpandaVersion String
- Current Redpanda version of the cluster.
- region String
- Cloud provider region.
- resourceGroup StringId 
- Resource group ID of the cluster.
- schemaRegistry GetCluster Schema Registry 
- Schema Registry properties.
- state String
- Current state of the cluster.
- stateDescription GetCluster State Description 
- Detailed state description when cluster is in a non-ready state.
- 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.
- awsPrivate GetLink Cluster Aws Private Link 
- AWS PrivateLink configuration.
- azurePrivate GetLink Cluster Azure Private Link 
- Azure Private Link configuration.
- cloudProvider string
- Cloud provider where resources are created.
- clusterApi stringUrl 
- 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
GetCluster Connectivity 
- Cloud provider-specific connectivity configuration.
- createdAt string
- Timestamp when the cluster was created.
- customerManaged GetResources Cluster Customer Managed Resources 
- Customer managed resources configuration for the cluster.
- gcpPrivate GetService Connect Cluster Gcp Private Service Connect 
- GCP Private Service Connect configuration.
- httpProxy GetCluster Http Proxy 
- 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 GetCluster Kafka Api 
- Cluster's Kafka API properties.
- kafkaConnect GetCluster Kafka Connect 
- Kafka Connect configuration.
- maintenanceWindow GetConfig Cluster Maintenance Window Config 
- Maintenance window configuration for the cluster.
- name string
- Unique name of the cluster.
- networkId string
- Network ID where cluster is placed.
- prometheus
GetCluster Prometheus 
- Prometheus metrics endpoint properties.
- readReplica string[]Cluster Ids 
- IDs of clusters that can create read-only topics from this cluster.
- redpandaConsole GetCluster Redpanda Console 
- Redpanda Console properties.
- redpandaVersion string
- Current Redpanda version of the cluster.
- region string
- Cloud provider region.
- resourceGroup stringId 
- Resource group ID of the cluster.
- schemaRegistry GetCluster Schema Registry 
- Schema Registry properties.
- state string
- Current state of the cluster.
- stateDescription GetCluster State Description 
- Detailed state description when cluster is in a non-ready state.
- {[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_ Getlink Cluster Aws Private Link 
- AWS PrivateLink configuration.
- azure_private_ Getlink Cluster Azure Private Link 
- Azure Private Link configuration.
- cloud_provider str
- Cloud provider where resources are created.
- cluster_api_ strurl 
- 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
GetCluster Connectivity 
- Cloud provider-specific connectivity configuration.
- created_at str
- Timestamp when the cluster was created.
- customer_managed_ Getresources Cluster Customer Managed Resources 
- Customer managed resources configuration for the cluster.
- gcp_private_ Getservice_ connect Cluster Gcp Private Service Connect 
- GCP Private Service Connect configuration.
- http_proxy GetCluster Http Proxy 
- 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 GetCluster Kafka Api 
- Cluster's Kafka API properties.
- kafka_connect GetCluster Kafka Connect 
- Kafka Connect configuration.
- maintenance_window_ Getconfig Cluster Maintenance Window Config 
- Maintenance window configuration for the cluster.
- name str
- Unique name of the cluster.
- network_id str
- Network ID where cluster is placed.
- prometheus
GetCluster Prometheus 
- Prometheus metrics endpoint properties.
- read_replica_ Sequence[str]cluster_ ids 
- IDs of clusters that can create read-only topics from this cluster.
- redpanda_console GetCluster Redpanda Console 
- Redpanda Console properties.
- redpanda_version str
- Current Redpanda version of the cluster.
- region str
- Cloud provider region.
- resource_group_ strid 
- Resource group ID of the cluster.
- schema_registry GetCluster Schema Registry 
- Schema Registry properties.
- state str
- Current state of the cluster.
- state_description GetCluster State Description 
- Detailed state description when cluster is in a non-ready state.
- 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.
- awsPrivate Property MapLink 
- AWS PrivateLink configuration.
- azurePrivate Property MapLink 
- Azure Private Link configuration.
- cloudProvider String
- Cloud provider where resources are created.
- clusterApi StringUrl 
- 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.
- customerManaged Property MapResources 
- Customer managed resources configuration for the cluster.
- gcpPrivate Property MapService Connect 
- 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.
- maintenanceWindow Property MapConfig 
- 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.
- readReplica List<String>Cluster Ids 
- 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.
- resourceGroup StringId 
- 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.
- 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
GetClusterAwsPrivateLink    
- 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
GetCluster Aws Private Link Status 
- 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
GetCluster Aws Private Link Status 
- 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
GetCluster Aws Private Link Status 
- 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
GetCluster Aws Private Link Status 
- 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
GetCluster Aws Private Link Status 
- 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.
- KafkaApi doubleNode Base Port 
- Base port for Kafka API nodes.
- KafkaApi doubleSeed Port 
- Port for Kafka API seed brokers.
- RedpandaProxy doubleNode Base Port 
- Base port for HTTP proxy nodes.
- RedpandaProxy doubleSeed Port 
- Port for HTTP proxy.
- SchemaRegistry doubleSeed Port 
- Port for Schema Registry.
- ServiceId string
- The PrivateLink service ID.
- ServiceName string
- The PrivateLink service name.
- ServiceState string
- Current state of the PrivateLink service.
- VpcEndpoint List<GetConnections Cluster Aws Private Link Status Vpc Endpoint Connection> 
- 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.
- KafkaApi float64Node Base Port 
- Base port for Kafka API nodes.
- KafkaApi float64Seed Port 
- Port for Kafka API seed brokers.
- RedpandaProxy float64Node Base Port 
- Base port for HTTP proxy nodes.
- RedpandaProxy float64Seed Port 
- Port for HTTP proxy.
- SchemaRegistry float64Seed Port 
- Port for Schema Registry.
- ServiceId string
- The PrivateLink service ID.
- ServiceName string
- The PrivateLink service name.
- ServiceState string
- Current state of the PrivateLink service.
- VpcEndpoint []GetConnections Cluster Aws Private Link Status Vpc Endpoint Connection 
- 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.
- kafkaApi DoubleNode Base Port 
- Base port for Kafka API nodes.
- kafkaApi DoubleSeed Port 
- Port for Kafka API seed brokers.
- redpandaProxy DoubleNode Base Port 
- Base port for HTTP proxy nodes.
- redpandaProxy DoubleSeed Port 
- Port for HTTP proxy.
- schemaRegistry DoubleSeed Port 
- Port for Schema Registry.
- serviceId String
- The PrivateLink service ID.
- serviceName String
- The PrivateLink service name.
- serviceState String
- Current state of the PrivateLink service.
- vpcEndpoint List<GetConnections Cluster Aws Private Link Status Vpc Endpoint Connection> 
- 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.
- kafkaApi numberNode Base Port 
- Base port for Kafka API nodes.
- kafkaApi numberSeed Port 
- Port for Kafka API seed brokers.
- redpandaProxy numberNode Base Port 
- Base port for HTTP proxy nodes.
- redpandaProxy numberSeed Port 
- Port for HTTP proxy.
- schemaRegistry numberSeed Port 
- Port for Schema Registry.
- serviceId string
- The PrivateLink service ID.
- serviceName string
- The PrivateLink service name.
- serviceState string
- Current state of the PrivateLink service.
- vpcEndpoint GetConnections Cluster Aws Private Link Status Vpc Endpoint Connection[] 
- 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_ floatnode_ base_ port 
- Base port for Kafka API nodes.
- kafka_api_ floatseed_ port 
- Port for Kafka API seed brokers.
- redpanda_proxy_ floatnode_ base_ port 
- Base port for HTTP proxy nodes.
- redpanda_proxy_ floatseed_ port 
- Port for HTTP proxy.
- schema_registry_ floatseed_ port 
- 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_ Sequence[Getconnections Cluster Aws Private Link Status Vpc Endpoint Connection] 
- 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.
- kafkaApi NumberNode Base Port 
- Base port for Kafka API nodes.
- kafkaApi NumberSeed Port 
- Port for Kafka API seed brokers.
- redpandaProxy NumberNode Base Port 
- Base port for HTTP proxy nodes.
- redpandaProxy NumberSeed Port 
- Port for HTTP proxy.
- schemaRegistry NumberSeed Port 
- Port for Schema Registry.
- serviceId String
- The PrivateLink service ID.
- serviceName String
- The PrivateLink service name.
- serviceState String
- Current state of the PrivateLink service.
- vpcEndpoint List<Property Map>Connections 
- List of VPC endpoint connections.
GetClusterAwsPrivateLinkStatusVpcEndpointConnection        
- ConnectionId string
- The connection ID.
- CreatedAt string
- When the endpoint connection was created.
- DnsEntries List<GetCluster Aws Private Link Status Vpc Endpoint Connection Dns Entry> 
- DNS entries for the endpoint.
- Id string
- The endpoint connection ID.
- LoadBalancer List<string>Arns 
- 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 []GetCluster Aws Private Link Status Vpc Endpoint Connection Dns Entry 
- DNS entries for the endpoint.
- Id string
- The endpoint connection ID.
- LoadBalancer []stringArns 
- 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<GetCluster Aws Private Link Status Vpc Endpoint Connection Dns Entry> 
- DNS entries for the endpoint.
- id String
- The endpoint connection ID.
- loadBalancer List<String>Arns 
- 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 GetCluster Aws Private Link Status Vpc Endpoint Connection Dns Entry[] 
- DNS entries for the endpoint.
- id string
- The endpoint connection ID.
- loadBalancer string[]Arns 
- 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[GetCluster Aws Private Link Status Vpc Endpoint Connection Dns Entry] 
- DNS entries for the endpoint.
- id str
- The endpoint connection ID.
- load_balancer_ Sequence[str]arns 
- 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.
- loadBalancer List<String>Arns 
- 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.
- HostedZone stringId 
- The hosted zone ID.
- DnsName string
- The DNS name.
- HostedZone stringId 
- The hosted zone ID.
- dnsName String
- The DNS name.
- hostedZone StringId 
- The hosted zone ID.
- dnsName string
- The DNS name.
- hostedZone stringId 
- The hosted zone ID.
- dns_name str
- The DNS name.
- hosted_zone_ strid 
- The hosted zone ID.
- dnsName String
- The DNS name.
- hostedZone StringId 
- The hosted zone ID.
GetClusterAzurePrivateLink    
- 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
GetCluster Azure Private Link Status 
- 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
GetCluster Azure Private Link Status 
- 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
GetCluster Azure Private Link Status 
- 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
GetCluster Azure Private Link Status 
- 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
GetCluster Azure Private Link Status 
- 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.
- KafkaApi doubleNode Base Port 
- Base port for Kafka API nodes.
- KafkaApi doubleSeed Port 
- Port for Kafka API seed brokers.
- PrivateEndpoint List<GetConnections Cluster Azure Private Link Status Private Endpoint Connection> 
- List of private endpoint connections.
- RedpandaProxy doubleNode Base Port 
- Base port for HTTP proxy nodes.
- RedpandaProxy doubleSeed Port 
- Port for HTTP proxy.
- SchemaRegistry doubleSeed Port 
- 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.
- KafkaApi float64Node Base Port 
- Base port for Kafka API nodes.
- KafkaApi float64Seed Port 
- Port for Kafka API seed brokers.
- PrivateEndpoint []GetConnections Cluster Azure Private Link Status Private Endpoint Connection 
- List of private endpoint connections.
- RedpandaProxy float64Node Base Port 
- Base port for HTTP proxy nodes.
- RedpandaProxy float64Seed Port 
- Port for HTTP proxy.
- SchemaRegistry float64Seed Port 
- 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.
- kafkaApi DoubleNode Base Port 
- Base port for Kafka API nodes.
- kafkaApi DoubleSeed Port 
- Port for Kafka API seed brokers.
- privateEndpoint List<GetConnections Cluster Azure Private Link Status Private Endpoint Connection> 
- List of private endpoint connections.
- redpandaProxy DoubleNode Base Port 
- Base port for HTTP proxy nodes.
- redpandaProxy DoubleSeed Port 
- Port for HTTP proxy.
- schemaRegistry DoubleSeed Port 
- 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.
- kafkaApi numberNode Base Port 
- Base port for Kafka API nodes.
- kafkaApi numberSeed Port 
- Port for Kafka API seed brokers.
- privateEndpoint GetConnections Cluster Azure Private Link Status Private Endpoint Connection[] 
- List of private endpoint connections.
- redpandaProxy numberNode Base Port 
- Base port for HTTP proxy nodes.
- redpandaProxy numberSeed Port 
- Port for HTTP proxy.
- schemaRegistry numberSeed Port 
- 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_ strrecord 
- DNS A record for the service.
- kafka_api_ floatnode_ base_ port 
- Base port for Kafka API nodes.
- kafka_api_ floatseed_ port 
- Port for Kafka API seed brokers.
- private_endpoint_ Sequence[Getconnections Cluster Azure Private Link Status Private Endpoint Connection] 
- List of private endpoint connections.
- redpanda_proxy_ floatnode_ base_ port 
- Base port for HTTP proxy nodes.
- redpanda_proxy_ floatseed_ port 
- Port for HTTP proxy.
- schema_registry_ floatseed_ port 
- 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.
- kafkaApi NumberNode Base Port 
- Base port for Kafka API nodes.
- kafkaApi NumberSeed Port 
- Port for Kafka API seed brokers.
- privateEndpoint List<Property Map>Connections 
- List of private endpoint connections.
- redpandaProxy NumberNode Base Port 
- Base port for HTTP proxy nodes.
- redpandaProxy NumberSeed Port 
- Port for HTTP proxy.
- schemaRegistry NumberSeed Port 
- 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.
- PrivateEndpoint stringId 
- ID of the private endpoint.
- PrivateEndpoint stringName 
- 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.
- PrivateEndpoint stringId 
- ID of the private endpoint.
- PrivateEndpoint stringName 
- 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.
- privateEndpoint StringId 
- ID of the private endpoint.
- privateEndpoint StringName 
- 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.
- privateEndpoint stringId 
- ID of the private endpoint.
- privateEndpoint stringName 
- 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_ strid 
- ID of the private endpoint.
- private_endpoint_ strname 
- 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.
- privateEndpoint StringId 
- ID of the private endpoint.
- privateEndpoint StringName 
- Name of the private endpoint.
- status String
- Status of the endpoint connection.
GetClusterConnectivity  
- Gcp
GetCluster Connectivity Gcp 
- GCP-specific connectivity settings.
- Gcp
GetCluster Connectivity Gcp 
- GCP-specific connectivity settings.
- gcp
GetCluster Connectivity Gcp 
- GCP-specific connectivity settings.
- gcp
GetCluster Connectivity Gcp 
- GCP-specific connectivity settings.
- gcp
GetCluster Connectivity Gcp 
- GCP-specific connectivity settings.
- gcp Property Map
- GCP-specific connectivity settings.
GetClusterConnectivityGcp   
- EnableGlobal boolAccess 
- Whether global access is enabled.
- EnableGlobal boolAccess 
- Whether global access is enabled.
- enableGlobal BooleanAccess 
- Whether global access is enabled.
- enableGlobal booleanAccess 
- Whether global access is enabled.
- enable_global_ boolaccess 
- Whether global access is enabled.
- enableGlobal BooleanAccess 
- Whether global access is enabled.
GetClusterCustomerManagedResources    
GetClusterCustomerManagedResourcesAws     
- AgentInstance GetProfile Cluster Customer Managed Resources Aws Agent Instance Profile 
- CloudStorage GetBucket Cluster Customer Managed Resources Aws Cloud Storage Bucket 
- ClusterSecurity GetGroup Cluster Customer Managed Resources Aws Cluster Security Group 
- ConnectorsNode GetGroup Instance Profile Cluster Customer Managed Resources Aws Connectors Node Group Instance Profile 
- ConnectorsSecurity GetGroup Cluster Customer Managed Resources Aws Connectors Security Group 
- K8sCluster GetRole Cluster Customer Managed Resources Aws K8s Cluster Role 
- NodeSecurity GetGroup Cluster Customer Managed Resources Aws Node Security Group 
- PermissionsBoundary GetPolicy Cluster Customer Managed Resources Aws Permissions Boundary Policy 
- RedpandaAgent GetSecurity Group Cluster Customer Managed Resources Aws Redpanda Agent Security Group 
- RedpandaNode GetGroup Instance Profile Cluster Customer Managed Resources Aws Redpanda Node Group Instance Profile 
- RedpandaNode GetGroup Security Group Cluster Customer Managed Resources Aws Redpanda Node Group Security Group 
- UtilityNode GetGroup Instance Profile Cluster Customer Managed Resources Aws Utility Node Group Instance Profile 
- UtilitySecurity GetGroup Cluster Customer Managed Resources Aws Utility Security Group 
- AgentInstance GetProfile Cluster Customer Managed Resources Aws Agent Instance Profile 
- CloudStorage GetBucket Cluster Customer Managed Resources Aws Cloud Storage Bucket 
- ClusterSecurity GetGroup Cluster Customer Managed Resources Aws Cluster Security Group 
- ConnectorsNode GetGroup Instance Profile Cluster Customer Managed Resources Aws Connectors Node Group Instance Profile 
- ConnectorsSecurity GetGroup Cluster Customer Managed Resources Aws Connectors Security Group 
- K8sCluster GetRole Cluster Customer Managed Resources Aws K8s Cluster Role 
- NodeSecurity GetGroup Cluster Customer Managed Resources Aws Node Security Group 
- PermissionsBoundary GetPolicy Cluster Customer Managed Resources Aws Permissions Boundary Policy 
- RedpandaAgent GetSecurity Group Cluster Customer Managed Resources Aws Redpanda Agent Security Group 
- RedpandaNode GetGroup Instance Profile Cluster Customer Managed Resources Aws Redpanda Node Group Instance Profile 
- RedpandaNode GetGroup Security Group Cluster Customer Managed Resources Aws Redpanda Node Group Security Group 
- UtilityNode GetGroup Instance Profile Cluster Customer Managed Resources Aws Utility Node Group Instance Profile 
- UtilitySecurity GetGroup Cluster Customer Managed Resources Aws Utility Security Group 
- agentInstance GetProfile Cluster Customer Managed Resources Aws Agent Instance Profile 
- cloudStorage GetBucket Cluster Customer Managed Resources Aws Cloud Storage Bucket 
- clusterSecurity GetGroup Cluster Customer Managed Resources Aws Cluster Security Group 
- connectorsNode GetGroup Instance Profile Cluster Customer Managed Resources Aws Connectors Node Group Instance Profile 
- connectorsSecurity GetGroup Cluster Customer Managed Resources Aws Connectors Security Group 
- k8sCluster GetRole Cluster Customer Managed Resources Aws K8s Cluster Role 
- nodeSecurity GetGroup Cluster Customer Managed Resources Aws Node Security Group 
- permissionsBoundary GetPolicy Cluster Customer Managed Resources Aws Permissions Boundary Policy 
- redpandaAgent GetSecurity Group Cluster Customer Managed Resources Aws Redpanda Agent Security Group 
- redpandaNode GetGroup Instance Profile Cluster Customer Managed Resources Aws Redpanda Node Group Instance Profile 
- redpandaNode GetGroup Security Group Cluster Customer Managed Resources Aws Redpanda Node Group Security Group 
- utilityNode GetGroup Instance Profile Cluster Customer Managed Resources Aws Utility Node Group Instance Profile 
- utilitySecurity GetGroup Cluster Customer Managed Resources Aws Utility Security Group 
- agentInstance GetProfile Cluster Customer Managed Resources Aws Agent Instance Profile 
- cloudStorage GetBucket Cluster Customer Managed Resources Aws Cloud Storage Bucket 
- clusterSecurity GetGroup Cluster Customer Managed Resources Aws Cluster Security Group 
- connectorsNode GetGroup Instance Profile Cluster Customer Managed Resources Aws Connectors Node Group Instance Profile 
- connectorsSecurity GetGroup Cluster Customer Managed Resources Aws Connectors Security Group 
- k8sCluster GetRole Cluster Customer Managed Resources Aws K8s Cluster Role 
- nodeSecurity GetGroup Cluster Customer Managed Resources Aws Node Security Group 
- permissionsBoundary GetPolicy Cluster Customer Managed Resources Aws Permissions Boundary Policy 
- redpandaAgent GetSecurity Group Cluster Customer Managed Resources Aws Redpanda Agent Security Group 
- redpandaNode GetGroup Instance Profile Cluster Customer Managed Resources Aws Redpanda Node Group Instance Profile 
- redpandaNode GetGroup Security Group Cluster Customer Managed Resources Aws Redpanda Node Group Security Group 
- utilityNode GetGroup Instance Profile Cluster Customer Managed Resources Aws Utility Node Group Instance Profile 
- utilitySecurity GetGroup Cluster Customer Managed Resources Aws Utility Security Group 
- agent_instance_ Getprofile Cluster Customer Managed Resources Aws Agent Instance Profile 
- cloud_storage_ Getbucket Cluster Customer Managed Resources Aws Cloud Storage Bucket 
- cluster_security_ Getgroup Cluster Customer Managed Resources Aws Cluster Security Group 
- connectors_node_ Getgroup_ instance_ profile Cluster Customer Managed Resources Aws Connectors Node Group Instance Profile 
- connectors_security_ Getgroup Cluster Customer Managed Resources Aws Connectors Security Group 
- k8s_cluster_ Getrole Cluster Customer Managed Resources Aws K8s Cluster Role 
- node_security_ Getgroup Cluster Customer Managed Resources Aws Node Security Group 
- permissions_boundary_ Getpolicy Cluster Customer Managed Resources Aws Permissions Boundary Policy 
- redpanda_agent_ Getsecurity_ group Cluster Customer Managed Resources Aws Redpanda Agent Security Group 
- redpanda_node_ Getgroup_ instance_ profile Cluster Customer Managed Resources Aws Redpanda Node Group Instance Profile 
- redpanda_node_ Getgroup_ security_ group Cluster Customer Managed Resources Aws Redpanda Node Group Security Group 
- utility_node_ Getgroup_ instance_ profile Cluster Customer Managed Resources Aws Utility Node Group Instance Profile 
- utility_security_ Getgroup Cluster Customer Managed Resources Aws Utility Security Group 
- agentInstance Property MapProfile 
- cloudStorage Property MapBucket 
- clusterSecurity Property MapGroup 
- connectorsNode Property MapGroup Instance Profile 
- connectorsSecurity Property MapGroup 
- k8sCluster Property MapRole 
- nodeSecurity Property MapGroup 
- permissionsBoundary Property MapPolicy 
- redpandaAgent Property MapSecurity Group 
- redpandaNode Property MapGroup Instance Profile 
- redpandaNode Property MapGroup Security Group 
- utilityNode Property MapGroup Instance Profile 
- utilitySecurity Property MapGroup 
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     
- ConsumerAccept List<GetLists Cluster Gcp Private Service Connect Consumer Accept List> 
- List of consumers that are allowed to connect to Redpanda GCP PSC service attachment.
- Enabled bool
- Whether Redpanda GCP Private Service Connect is enabled.
- GlobalAccess boolEnabled 
- Whether global access is enabled.
- Status
GetCluster Gcp Private Service Connect Status 
- Current status of the Private Service Connect configuration.
- ConsumerAccept []GetLists Cluster Gcp Private Service Connect Consumer Accept List 
- List of consumers that are allowed to connect to Redpanda GCP PSC service attachment.
- Enabled bool
- Whether Redpanda GCP Private Service Connect is enabled.
- GlobalAccess boolEnabled 
- Whether global access is enabled.
- Status
GetCluster Gcp Private Service Connect Status 
- Current status of the Private Service Connect configuration.
- consumerAccept List<GetLists Cluster Gcp Private Service Connect Consumer Accept List> 
- List of consumers that are allowed to connect to Redpanda GCP PSC service attachment.
- enabled Boolean
- Whether Redpanda GCP Private Service Connect is enabled.
- globalAccess BooleanEnabled 
- Whether global access is enabled.
- status
GetCluster Gcp Private Service Connect Status 
- Current status of the Private Service Connect configuration.
- consumerAccept GetLists Cluster Gcp Private Service Connect Consumer Accept List[] 
- List of consumers that are allowed to connect to Redpanda GCP PSC service attachment.
- enabled boolean
- Whether Redpanda GCP Private Service Connect is enabled.
- globalAccess booleanEnabled 
- Whether global access is enabled.
- status
GetCluster Gcp Private Service Connect Status 
- Current status of the Private Service Connect configuration.
- consumer_accept_ Sequence[Getlists Cluster Gcp Private Service Connect Consumer Accept List] 
- 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_ boolenabled 
- Whether global access is enabled.
- status
GetCluster Gcp Private Service Connect Status 
- Current status of the Private Service Connect configuration.
- consumerAccept List<Property Map>Lists 
- List of consumers that are allowed to connect to Redpanda GCP PSC service attachment.
- enabled Boolean
- Whether Redpanda GCP Private Service Connect is enabled.
- globalAccess BooleanEnabled 
- 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<GetCluster Gcp Private Service Connect Status Connected Endpoint> 
- 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.
- KafkaApi doubleNode Base Port 
- Base port for Kafka API nodes.
- KafkaApi doubleSeed Port 
- Port for Kafka API seed brokers.
- RedpandaProxy doubleNode Base Port 
- Base port for HTTP proxy nodes.
- RedpandaProxy doubleSeed Port 
- Port for HTTP proxy.
- SchemaRegistry doubleSeed Port 
- Port for Schema Registry.
- SeedHostname string
- Hostname for the seed brokers.
- ServiceAttachment string
- The service attachment identifier.
- ConnectedEndpoints []GetCluster Gcp Private Service Connect Status Connected Endpoint 
- 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.
- KafkaApi float64Node Base Port 
- Base port for Kafka API nodes.
- KafkaApi float64Seed Port 
- Port for Kafka API seed brokers.
- RedpandaProxy float64Node Base Port 
- Base port for HTTP proxy nodes.
- RedpandaProxy float64Seed Port 
- Port for HTTP proxy.
- SchemaRegistry float64Seed Port 
- Port for Schema Registry.
- SeedHostname string
- Hostname for the seed brokers.
- ServiceAttachment string
- The service attachment identifier.
- connectedEndpoints List<GetCluster Gcp Private Service Connect Status Connected Endpoint> 
- 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.
- kafkaApi DoubleNode Base Port 
- Base port for Kafka API nodes.
- kafkaApi DoubleSeed Port 
- Port for Kafka API seed brokers.
- redpandaProxy DoubleNode Base Port 
- Base port for HTTP proxy nodes.
- redpandaProxy DoubleSeed Port 
- Port for HTTP proxy.
- schemaRegistry DoubleSeed Port 
- Port for Schema Registry.
- seedHostname String
- Hostname for the seed brokers.
- serviceAttachment String
- The service attachment identifier.
- connectedEndpoints GetCluster Gcp Private Service Connect Status Connected Endpoint[] 
- 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.
- kafkaApi numberNode Base Port 
- Base port for Kafka API nodes.
- kafkaApi numberSeed Port 
- Port for Kafka API seed brokers.
- redpandaProxy numberNode Base Port 
- Base port for HTTP proxy nodes.
- redpandaProxy numberSeed Port 
- Port for HTTP proxy.
- schemaRegistry numberSeed Port 
- Port for Schema Registry.
- seedHostname string
- Hostname for the seed brokers.
- serviceAttachment string
- The service attachment identifier.
- connected_endpoints Sequence[GetCluster Gcp Private Service Connect Status Connected Endpoint] 
- 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_ Sequence[str]records 
- DNS A records for the service.
- kafka_api_ floatnode_ base_ port 
- Base port for Kafka API nodes.
- kafka_api_ floatseed_ port 
- Port for Kafka API seed brokers.
- redpanda_proxy_ floatnode_ base_ port 
- Base port for HTTP proxy nodes.
- redpanda_proxy_ floatseed_ port 
- Port for HTTP proxy.
- schema_registry_ floatseed_ port 
- 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.
- kafkaApi NumberNode Base Port 
- Base port for Kafka API nodes.
- kafkaApi NumberSeed Port 
- Port for Kafka API seed brokers.
- redpandaProxy NumberNode Base Port 
- Base port for HTTP proxy nodes.
- redpandaProxy NumberSeed Port 
- Port for HTTP proxy.
- schemaRegistry NumberSeed Port 
- 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
GetCluster Http Proxy Mtls 
- mTLS configuration.
- Url string
- The HTTP Proxy URL.
- Mtls
GetCluster Http Proxy Mtls 
- mTLS configuration.
- Url string
- The HTTP Proxy URL.
- mtls
GetCluster Http Proxy Mtls 
- mTLS configuration.
- url String
- The HTTP Proxy URL.
- mtls
GetCluster Http Proxy Mtls 
- mTLS configuration.
- url string
- The HTTP Proxy URL.
- mtls
GetCluster Http Proxy Mtls 
- mTLS configuration.
- url str
- The HTTP Proxy URL.
- mtls Property Map
- mTLS configuration.
- url String
- The HTTP Proxy URL.
GetClusterHttpProxyMtls    
- CaCertificates List<string>Pems 
- CA certificate in PEM format.
- Enabled bool
- Whether mTLS is enabled.
- PrincipalMapping List<string>Rules 
- Principal mapping rules for mTLS authentication.
- CaCertificates []stringPems 
- CA certificate in PEM format.
- Enabled bool
- Whether mTLS is enabled.
- PrincipalMapping []stringRules 
- Principal mapping rules for mTLS authentication.
- caCertificates List<String>Pems 
- CA certificate in PEM format.
- enabled Boolean
- Whether mTLS is enabled.
- principalMapping List<String>Rules 
- Principal mapping rules for mTLS authentication.
- caCertificates string[]Pems 
- CA certificate in PEM format.
- enabled boolean
- Whether mTLS is enabled.
- principalMapping string[]Rules 
- Principal mapping rules for mTLS authentication.
- ca_certificates_ Sequence[str]pems 
- CA certificate in PEM format.
- enabled bool
- Whether mTLS is enabled.
- principal_mapping_ Sequence[str]rules 
- Principal mapping rules for mTLS authentication.
- caCertificates List<String>Pems 
- CA certificate in PEM format.
- enabled Boolean
- Whether mTLS is enabled.
- principalMapping List<String>Rules 
- Principal mapping rules for mTLS authentication.
GetClusterKafkaApi   
- Mtls
GetCluster Kafka Api Mtls 
- mTLS configuration.
- SeedBrokers List<string>
- List of Kafka broker addresses.
- Mtls
GetCluster Kafka Api Mtls 
- mTLS configuration.
- SeedBrokers []string
- List of Kafka broker addresses.
- mtls
GetCluster Kafka Api Mtls 
- mTLS configuration.
- seedBrokers List<String>
- List of Kafka broker addresses.
- mtls
GetCluster Kafka Api Mtls 
- mTLS configuration.
- seedBrokers string[]
- List of Kafka broker addresses.
- mtls
GetCluster Kafka Api Mtls 
- 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    
- CaCertificates List<string>Pems 
- CA certificate in PEM format.
- Enabled bool
- Whether mTLS is enabled.
- PrincipalMapping List<string>Rules 
- Principal mapping rules for mTLS authentication.
- CaCertificates []stringPems 
- CA certificate in PEM format.
- Enabled bool
- Whether mTLS is enabled.
- PrincipalMapping []stringRules 
- Principal mapping rules for mTLS authentication.
- caCertificates List<String>Pems 
- CA certificate in PEM format.
- enabled Boolean
- Whether mTLS is enabled.
- principalMapping List<String>Rules 
- Principal mapping rules for mTLS authentication.
- caCertificates string[]Pems 
- CA certificate in PEM format.
- enabled boolean
- Whether mTLS is enabled.
- principalMapping string[]Rules 
- Principal mapping rules for mTLS authentication.
- ca_certificates_ Sequence[str]pems 
- CA certificate in PEM format.
- enabled bool
- Whether mTLS is enabled.
- principal_mapping_ Sequence[str]rules 
- Principal mapping rules for mTLS authentication.
- caCertificates List<String>Pems 
- CA certificate in PEM format.
- enabled Boolean
- Whether mTLS is enabled.
- principalMapping List<String>Rules 
- 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 GetCluster Maintenance Window Config Day Hour 
- Unspecified bool
- If true, maintenance window is unspecified.
- Anytime bool
- If true, maintenance can occur at any time.
- DayHour GetCluster Maintenance Window Config Day Hour 
- Unspecified bool
- If true, maintenance window is unspecified.
- anytime Boolean
- If true, maintenance can occur at any time.
- dayHour GetCluster Maintenance Window Config Day Hour 
- unspecified Boolean
- If true, maintenance window is unspecified.
- anytime boolean
- If true, maintenance can occur at any time.
- dayHour GetCluster Maintenance Window Config Day Hour 
- unspecified boolean
- If true, maintenance window is unspecified.
- anytime bool
- If true, maintenance can occur at any time.
- day_hour GetCluster Maintenance Window Config Day Hour 
- 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      
- day_of_ strweek 
- Day of week.
- hour_of_ floatday 
- 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
GetCluster Schema Registry Mtls 
- mTLS configuration.
- Url string
- The Schema Registry URL.
- Mtls
GetCluster Schema Registry Mtls 
- mTLS configuration.
- Url string
- The Schema Registry URL.
- mtls
GetCluster Schema Registry Mtls 
- mTLS configuration.
- url String
- The Schema Registry URL.
- mtls
GetCluster Schema Registry Mtls 
- mTLS configuration.
- url string
- The Schema Registry URL.
- mtls
GetCluster Schema Registry Mtls 
- mTLS configuration.
- url str
- The Schema Registry URL.
- mtls Property Map
- mTLS configuration.
- url String
- The Schema Registry URL.
GetClusterSchemaRegistryMtls    
- CaCertificates List<string>Pems 
- CA certificate in PEM format.
- Enabled bool
- Whether mTLS is enabled.
- PrincipalMapping List<string>Rules 
- Principal mapping rules for mTLS authentication.
- CaCertificates []stringPems 
- CA certificate in PEM format.
- Enabled bool
- Whether mTLS is enabled.
- PrincipalMapping []stringRules 
- Principal mapping rules for mTLS authentication.
- caCertificates List<String>Pems 
- CA certificate in PEM format.
- enabled Boolean
- Whether mTLS is enabled.
- principalMapping List<String>Rules 
- Principal mapping rules for mTLS authentication.
- caCertificates string[]Pems 
- CA certificate in PEM format.
- enabled boolean
- Whether mTLS is enabled.
- principalMapping string[]Rules 
- Principal mapping rules for mTLS authentication.
- ca_certificates_ Sequence[str]pems 
- CA certificate in PEM format.
- enabled bool
- Whether mTLS is enabled.
- principal_mapping_ Sequence[str]rules 
- Principal mapping rules for mTLS authentication.
- caCertificates List<String>Pems 
- CA certificate in PEM format.
- enabled Boolean
- Whether mTLS is enabled.
- principalMapping List<String>Rules 
- Principal mapping rules for mTLS authentication.
GetClusterStateDescription   
Package Details
- Repository
- redpanda redpanda-data/terraform-provider-redpanda
- License
- Notes
- This Pulumi package is based on the redpandaTerraform Provider.
redpanda 0.13.0 published on Monday, Mar 17, 2025 by redpanda-data