1. Packages
  2. Redpanda Provider
  3. API Docs
  4. getCluster
redpanda 0.15.0 published on Friday, Apr 11, 2025 by redpanda-data

redpanda.getCluster

Explore with Pulumi AI

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",
});
Copy
import pulumi
import pulumi_redpanda as redpanda

example = redpanda.get_cluster(id="cluster_id")
Copy
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
	})
}
Copy
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",
    });

});
Copy
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());

    }
}
Copy
variables:
  example:
    fn::invoke:
      function: redpanda:getCluster
      arguments:
        id: cluster_id
Copy

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";
Copy
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"
Copy
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
	})
}
Copy
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";
});
Copy
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");
    }
}
Copy
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}
Copy

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>
Copy
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]
Copy
func LookupCluster(ctx *Context, args *LookupClusterArgs, opts ...InvokeOption) (*LookupClusterResult, error)
func LookupClusterOutput(ctx *Context, args *LookupClusterOutputArgs, opts ...InvokeOption) LookupClusterResultOutput
Copy

> 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)
}
Copy
public static CompletableFuture<GetClusterResult> getCluster(GetClusterArgs args, InvokeOptions options)
public static Output<GetClusterResult> getCluster(GetClusterArgs args, InvokeOptions options)
Copy
fn::invoke:
  function: redpanda:index/getCluster:getCluster
  arguments:
    # arguments dictionary
Copy

The following arguments are supported:

Id This property is required. string
ID of the cluster. ID is an output from the Create Cluster endpoint and cannot be set by the caller.
Id This property is required. string
ID of the cluster. ID is an output from the Create Cluster endpoint and cannot be set by the caller.
id This property is required. String
ID of the cluster. ID is an output from the Create Cluster endpoint and cannot be set by the caller.
id This property is required. string
ID of the cluster. ID is an output from the Create Cluster endpoint and cannot be set by the caller.
id This property is required. str
ID of the cluster. ID is an output from the Create Cluster endpoint and cannot be set by the caller.
id This property is required. 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 This property is required. List<string>
The ARN of the principals that can access the Redpanda AWS PrivateLink Endpoint Service.
ConnectConsole This property is required. bool
Whether Console is connected via PrivateLink.
Enabled This property is required. bool
Whether AWS PrivateLink is enabled.
Status This property is required. GetClusterAwsPrivateLinkStatus
Current status of the PrivateLink configuration.
AllowedPrincipals This property is required. []string
The ARN of the principals that can access the Redpanda AWS PrivateLink Endpoint Service.
ConnectConsole This property is required. bool
Whether Console is connected via PrivateLink.
Enabled This property is required. bool
Whether AWS PrivateLink is enabled.
Status This property is required. GetClusterAwsPrivateLinkStatus
Current status of the PrivateLink configuration.
allowedPrincipals This property is required. List<String>
The ARN of the principals that can access the Redpanda AWS PrivateLink Endpoint Service.
connectConsole This property is required. Boolean
Whether Console is connected via PrivateLink.
enabled This property is required. Boolean
Whether AWS PrivateLink is enabled.
status This property is required. GetClusterAwsPrivateLinkStatus
Current status of the PrivateLink configuration.
allowedPrincipals This property is required. string[]
The ARN of the principals that can access the Redpanda AWS PrivateLink Endpoint Service.
connectConsole This property is required. boolean
Whether Console is connected via PrivateLink.
enabled This property is required. boolean
Whether AWS PrivateLink is enabled.
status This property is required. GetClusterAwsPrivateLinkStatus
Current status of the PrivateLink configuration.
allowed_principals This property is required. Sequence[str]
The ARN of the principals that can access the Redpanda AWS PrivateLink Endpoint Service.
connect_console This property is required. bool
Whether Console is connected via PrivateLink.
enabled This property is required. bool
Whether AWS PrivateLink is enabled.
status This property is required. GetClusterAwsPrivateLinkStatus
Current status of the PrivateLink configuration.
allowedPrincipals This property is required. List<String>
The ARN of the principals that can access the Redpanda AWS PrivateLink Endpoint Service.
connectConsole This property is required. Boolean
Whether Console is connected via PrivateLink.
enabled This property is required. Boolean
Whether AWS PrivateLink is enabled.
status This property is required. Property Map
Current status of the PrivateLink configuration.

GetClusterAwsPrivateLinkStatus

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

GetClusterAwsPrivateLinkStatusVpcEndpointConnection

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

GetClusterAwsPrivateLinkStatusVpcEndpointConnectionDnsEntry

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

GetClusterAzurePrivateLinkStatus

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

GetClusterAzurePrivateLinkStatusPrivateEndpointConnection

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

GetClusterConnectivity

Gcp This property is required. GetClusterConnectivityGcp
GCP-specific connectivity settings.
Gcp This property is required. GetClusterConnectivityGcp
GCP-specific connectivity settings.
gcp This property is required. GetClusterConnectivityGcp
GCP-specific connectivity settings.
gcp This property is required. GetClusterConnectivityGcp
GCP-specific connectivity settings.
gcp This property is required. GetClusterConnectivityGcp
GCP-specific connectivity settings.
gcp This property is required. Property Map
GCP-specific connectivity settings.

GetClusterConnectivityGcp

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

GetClusterCustomerManagedResources

Aws This property is required. GetClusterCustomerManagedResourcesAws
Gcp This property is required. GetClusterCustomerManagedResourcesGcp
GCP-specific connectivity settings.
Aws This property is required. GetClusterCustomerManagedResourcesAws
Gcp This property is required. GetClusterCustomerManagedResourcesGcp
GCP-specific connectivity settings.
aws This property is required. GetClusterCustomerManagedResourcesAws
gcp This property is required. GetClusterCustomerManagedResourcesGcp
GCP-specific connectivity settings.
aws This property is required. GetClusterCustomerManagedResourcesAws
gcp This property is required. GetClusterCustomerManagedResourcesGcp
GCP-specific connectivity settings.
aws This property is required. GetClusterCustomerManagedResourcesAws
gcp This property is required. GetClusterCustomerManagedResourcesGcp
GCP-specific connectivity settings.
aws This property is required. Property Map
gcp This property is required. Property Map
GCP-specific connectivity settings.

GetClusterCustomerManagedResourcesAws

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

GetClusterCustomerManagedResourcesAwsAgentInstanceProfile

Arn This property is required. string
ARN for the agent instance profile
Arn This property is required. string
ARN for the agent instance profile
arn This property is required. String
ARN for the agent instance profile
arn This property is required. string
ARN for the agent instance profile
arn This property is required. str
ARN for the agent instance profile
arn This property is required. String
ARN for the agent instance profile

GetClusterCustomerManagedResourcesAwsCloudStorageBucket

Arn This property is required. string
ARN for the cloud storage bucket
Arn This property is required. string
ARN for the cloud storage bucket
arn This property is required. String
ARN for the cloud storage bucket
arn This property is required. string
ARN for the cloud storage bucket
arn This property is required. str
ARN for the cloud storage bucket
arn This property is required. String
ARN for the cloud storage bucket

GetClusterCustomerManagedResourcesAwsClusterSecurityGroup

Arn This property is required. string
ARN for the cluster security group
Arn This property is required. string
ARN for the cluster security group
arn This property is required. String
ARN for the cluster security group
arn This property is required. string
ARN for the cluster security group
arn This property is required. str
ARN for the cluster security group
arn This property is required. String
ARN for the cluster security group

GetClusterCustomerManagedResourcesAwsConnectorsNodeGroupInstanceProfile

Arn This property is required. string
ARN for the connectors node group instance profile
Arn This property is required. string
ARN for the connectors node group instance profile
arn This property is required. String
ARN for the connectors node group instance profile
arn This property is required. string
ARN for the connectors node group instance profile
arn This property is required. str
ARN for the connectors node group instance profile
arn This property is required. String
ARN for the connectors node group instance profile

GetClusterCustomerManagedResourcesAwsConnectorsSecurityGroup

Arn This property is required. string
ARN for the connectors security group
Arn This property is required. string
ARN for the connectors security group
arn This property is required. String
ARN for the connectors security group
arn This property is required. string
ARN for the connectors security group
arn This property is required. str
ARN for the connectors security group
arn This property is required. String
ARN for the connectors security group

GetClusterCustomerManagedResourcesAwsK8sClusterRole

Arn This property is required. string
ARN for the Kubernetes cluster role
Arn This property is required. string
ARN for the Kubernetes cluster role
arn This property is required. String
ARN for the Kubernetes cluster role
arn This property is required. string
ARN for the Kubernetes cluster role
arn This property is required. str
ARN for the Kubernetes cluster role
arn This property is required. String
ARN for the Kubernetes cluster role

GetClusterCustomerManagedResourcesAwsNodeSecurityGroup

Arn This property is required. string
ARN for the node security group
Arn This property is required. string
ARN for the node security group
arn This property is required. String
ARN for the node security group
arn This property is required. string
ARN for the node security group
arn This property is required. str
ARN for the node security group
arn This property is required. String
ARN for the node security group

GetClusterCustomerManagedResourcesAwsPermissionsBoundaryPolicy

Arn This property is required. string
ARN for the permissions boundary policy
Arn This property is required. string
ARN for the permissions boundary policy
arn This property is required. String
ARN for the permissions boundary policy
arn This property is required. string
ARN for the permissions boundary policy
arn This property is required. str
ARN for the permissions boundary policy
arn This property is required. String
ARN for the permissions boundary policy

GetClusterCustomerManagedResourcesAwsRedpandaAgentSecurityGroup

Arn This property is required. string
ARN for the redpanda agent security group
Arn This property is required. string
ARN for the redpanda agent security group
arn This property is required. String
ARN for the redpanda agent security group
arn This property is required. string
ARN for the redpanda agent security group
arn This property is required. str
ARN for the redpanda agent security group
arn This property is required. String
ARN for the redpanda agent security group

GetClusterCustomerManagedResourcesAwsRedpandaNodeGroupInstanceProfile

Arn This property is required. string
ARN for the redpanda node group instance profile
Arn This property is required. string
ARN for the redpanda node group instance profile
arn This property is required. String
ARN for the redpanda node group instance profile
arn This property is required. string
ARN for the redpanda node group instance profile
arn This property is required. str
ARN for the redpanda node group instance profile
arn This property is required. String
ARN for the redpanda node group instance profile

GetClusterCustomerManagedResourcesAwsRedpandaNodeGroupSecurityGroup

Arn This property is required. string
ARN for the redpanda node group security group
Arn This property is required. string
ARN for the redpanda node group security group
arn This property is required. String
ARN for the redpanda node group security group
arn This property is required. string
ARN for the redpanda node group security group
arn This property is required. str
ARN for the redpanda node group security group
arn This property is required. String
ARN for the redpanda node group security group

GetClusterCustomerManagedResourcesAwsUtilityNodeGroupInstanceProfile

Arn This property is required. string
ARN for the utility node group instance profile
Arn This property is required. string
ARN for the utility node group instance profile
arn This property is required. String
ARN for the utility node group instance profile
arn This property is required. string
ARN for the utility node group instance profile
arn This property is required. str
ARN for the utility node group instance profile
arn This property is required. String
ARN for the utility node group instance profile

GetClusterCustomerManagedResourcesAwsUtilitySecurityGroup

Arn This property is required. string
ARN for the utility security group
Arn This property is required. string
ARN for the utility security group
arn This property is required. String
ARN for the utility security group
arn This property is required. string
ARN for the utility security group
arn This property is required. str
ARN for the utility security group
arn This property is required. String
ARN for the utility security group

GetClusterCustomerManagedResourcesGcp

AgentServiceAccount This property is required. GetClusterCustomerManagedResourcesGcpAgentServiceAccount
GCP service account for the agent.
ConnectorServiceAccount This property is required. GetClusterCustomerManagedResourcesGcpConnectorServiceAccount
GCP service account for managed connectors.
ConsoleServiceAccount This property is required. GetClusterCustomerManagedResourcesGcpConsoleServiceAccount
GCP service account for Redpanda Console.
GkeServiceAccount This property is required. GetClusterCustomerManagedResourcesGcpGkeServiceAccount
GCP service account for GCP Kubernetes Engine (GKE).
PscNatSubnetName This property is required. string
NAT subnet name if GCP Private Service Connect is enabled.
RedpandaClusterServiceAccount This property is required. GetClusterCustomerManagedResourcesGcpRedpandaClusterServiceAccount
GCP service account for the Redpanda cluster.
Subnet This property is required. GetClusterCustomerManagedResourcesGcpSubnet
GCP subnet where Redpanda cluster is deployed.
TieredStorageBucket This property is required. GetClusterCustomerManagedResourcesGcpTieredStorageBucket
GCP storage bucket for Tiered storage.
AgentServiceAccount This property is required. GetClusterCustomerManagedResourcesGcpAgentServiceAccount
GCP service account for the agent.
ConnectorServiceAccount This property is required. GetClusterCustomerManagedResourcesGcpConnectorServiceAccount
GCP service account for managed connectors.
ConsoleServiceAccount This property is required. GetClusterCustomerManagedResourcesGcpConsoleServiceAccount
GCP service account for Redpanda Console.
GkeServiceAccount This property is required. GetClusterCustomerManagedResourcesGcpGkeServiceAccount
GCP service account for GCP Kubernetes Engine (GKE).
PscNatSubnetName This property is required. string
NAT subnet name if GCP Private Service Connect is enabled.
RedpandaClusterServiceAccount This property is required. GetClusterCustomerManagedResourcesGcpRedpandaClusterServiceAccount
GCP service account for the Redpanda cluster.
Subnet This property is required. GetClusterCustomerManagedResourcesGcpSubnet
GCP subnet where Redpanda cluster is deployed.
TieredStorageBucket This property is required. GetClusterCustomerManagedResourcesGcpTieredStorageBucket
GCP storage bucket for Tiered storage.
agentServiceAccount This property is required. GetClusterCustomerManagedResourcesGcpAgentServiceAccount
GCP service account for the agent.
connectorServiceAccount This property is required. GetClusterCustomerManagedResourcesGcpConnectorServiceAccount
GCP service account for managed connectors.
consoleServiceAccount This property is required. GetClusterCustomerManagedResourcesGcpConsoleServiceAccount
GCP service account for Redpanda Console.
gkeServiceAccount This property is required. GetClusterCustomerManagedResourcesGcpGkeServiceAccount
GCP service account for GCP Kubernetes Engine (GKE).
pscNatSubnetName This property is required. String
NAT subnet name if GCP Private Service Connect is enabled.
redpandaClusterServiceAccount This property is required. GetClusterCustomerManagedResourcesGcpRedpandaClusterServiceAccount
GCP service account for the Redpanda cluster.
subnet This property is required. GetClusterCustomerManagedResourcesGcpSubnet
GCP subnet where Redpanda cluster is deployed.
tieredStorageBucket This property is required. GetClusterCustomerManagedResourcesGcpTieredStorageBucket
GCP storage bucket for Tiered storage.
agentServiceAccount This property is required. GetClusterCustomerManagedResourcesGcpAgentServiceAccount
GCP service account for the agent.
connectorServiceAccount This property is required. GetClusterCustomerManagedResourcesGcpConnectorServiceAccount
GCP service account for managed connectors.
consoleServiceAccount This property is required. GetClusterCustomerManagedResourcesGcpConsoleServiceAccount
GCP service account for Redpanda Console.
gkeServiceAccount This property is required. GetClusterCustomerManagedResourcesGcpGkeServiceAccount
GCP service account for GCP Kubernetes Engine (GKE).
pscNatSubnetName This property is required. string
NAT subnet name if GCP Private Service Connect is enabled.
redpandaClusterServiceAccount This property is required. GetClusterCustomerManagedResourcesGcpRedpandaClusterServiceAccount
GCP service account for the Redpanda cluster.
subnet This property is required. GetClusterCustomerManagedResourcesGcpSubnet
GCP subnet where Redpanda cluster is deployed.
tieredStorageBucket This property is required. GetClusterCustomerManagedResourcesGcpTieredStorageBucket
GCP storage bucket for Tiered storage.
agent_service_account This property is required. GetClusterCustomerManagedResourcesGcpAgentServiceAccount
GCP service account for the agent.
connector_service_account This property is required. GetClusterCustomerManagedResourcesGcpConnectorServiceAccount
GCP service account for managed connectors.
console_service_account This property is required. GetClusterCustomerManagedResourcesGcpConsoleServiceAccount
GCP service account for Redpanda Console.
gke_service_account This property is required. GetClusterCustomerManagedResourcesGcpGkeServiceAccount
GCP service account for GCP Kubernetes Engine (GKE).
psc_nat_subnet_name This property is required. str
NAT subnet name if GCP Private Service Connect is enabled.
redpanda_cluster_service_account This property is required. GetClusterCustomerManagedResourcesGcpRedpandaClusterServiceAccount
GCP service account for the Redpanda cluster.
subnet This property is required. GetClusterCustomerManagedResourcesGcpSubnet
GCP subnet where Redpanda cluster is deployed.
tiered_storage_bucket This property is required. GetClusterCustomerManagedResourcesGcpTieredStorageBucket
GCP storage bucket for Tiered storage.
agentServiceAccount This property is required. Property Map
GCP service account for the agent.
connectorServiceAccount This property is required. Property Map
GCP service account for managed connectors.
consoleServiceAccount This property is required. Property Map
GCP service account for Redpanda Console.
gkeServiceAccount This property is required. Property Map
GCP service account for GCP Kubernetes Engine (GKE).
pscNatSubnetName This property is required. String
NAT subnet name if GCP Private Service Connect is enabled.
redpandaClusterServiceAccount This property is required. Property Map
GCP service account for the Redpanda cluster.
subnet This property is required. Property Map
GCP subnet where Redpanda cluster is deployed.
tieredStorageBucket This property is required. Property Map
GCP storage bucket for Tiered storage.

GetClusterCustomerManagedResourcesGcpAgentServiceAccount

Email This property is required. string
GCP service account email.
Email This property is required. string
GCP service account email.
email This property is required. String
GCP service account email.
email This property is required. string
GCP service account email.
email This property is required. str
GCP service account email.
email This property is required. String
GCP service account email.

GetClusterCustomerManagedResourcesGcpConnectorServiceAccount

Email This property is required. string
GCP service account email.
Email This property is required. string
GCP service account email.
email This property is required. String
GCP service account email.
email This property is required. string
GCP service account email.
email This property is required. str
GCP service account email.
email This property is required. String
GCP service account email.

GetClusterCustomerManagedResourcesGcpConsoleServiceAccount

Email This property is required. string
GCP service account email.
Email This property is required. string
GCP service account email.
email This property is required. String
GCP service account email.
email This property is required. string
GCP service account email.
email This property is required. str
GCP service account email.
email This property is required. String
GCP service account email.

GetClusterCustomerManagedResourcesGcpGkeServiceAccount

Email This property is required. string
GCP service account email.
Email This property is required. string
GCP service account email.
email This property is required. String
GCP service account email.
email This property is required. string
GCP service account email.
email This property is required. str
GCP service account email.
email This property is required. String
GCP service account email.

GetClusterCustomerManagedResourcesGcpRedpandaClusterServiceAccount

Email This property is required. string
GCP service account email.
Email This property is required. string
GCP service account email.
email This property is required. String
GCP service account email.
email This property is required. string
GCP service account email.
email This property is required. str
GCP service account email.
email This property is required. String
GCP service account email.

GetClusterCustomerManagedResourcesGcpSubnet

K8sMasterIpv4Range This property is required. string
Kubernetes Master IPv4 range, e.g. 10.0.0.0/24.
Name This property is required. string
Unique name of the cluster.
SecondaryIpv4RangePods This property is required. GetClusterCustomerManagedResourcesGcpSubnetSecondaryIpv4RangePods
Secondary IPv4 range for pods.
SecondaryIpv4RangeServices This property is required. GetClusterCustomerManagedResourcesGcpSubnetSecondaryIpv4RangeServices
Secondary IPv4 range for services.
K8sMasterIpv4Range This property is required. string
Kubernetes Master IPv4 range, e.g. 10.0.0.0/24.
Name This property is required. string
Unique name of the cluster.
SecondaryIpv4RangePods This property is required. GetClusterCustomerManagedResourcesGcpSubnetSecondaryIpv4RangePods
Secondary IPv4 range for pods.
SecondaryIpv4RangeServices This property is required. GetClusterCustomerManagedResourcesGcpSubnetSecondaryIpv4RangeServices
Secondary IPv4 range for services.
k8sMasterIpv4Range This property is required. String
Kubernetes Master IPv4 range, e.g. 10.0.0.0/24.
name This property is required. String
Unique name of the cluster.
secondaryIpv4RangePods This property is required. GetClusterCustomerManagedResourcesGcpSubnetSecondaryIpv4RangePods
Secondary IPv4 range for pods.
secondaryIpv4RangeServices This property is required. GetClusterCustomerManagedResourcesGcpSubnetSecondaryIpv4RangeServices
Secondary IPv4 range for services.
k8sMasterIpv4Range This property is required. string
Kubernetes Master IPv4 range, e.g. 10.0.0.0/24.
name This property is required. string
Unique name of the cluster.
secondaryIpv4RangePods This property is required. GetClusterCustomerManagedResourcesGcpSubnetSecondaryIpv4RangePods
Secondary IPv4 range for pods.
secondaryIpv4RangeServices This property is required. GetClusterCustomerManagedResourcesGcpSubnetSecondaryIpv4RangeServices
Secondary IPv4 range for services.
k8s_master_ipv4_range This property is required. str
Kubernetes Master IPv4 range, e.g. 10.0.0.0/24.
name This property is required. str
Unique name of the cluster.
secondary_ipv4_range_pods This property is required. GetClusterCustomerManagedResourcesGcpSubnetSecondaryIpv4RangePods
Secondary IPv4 range for pods.
secondary_ipv4_range_services This property is required. GetClusterCustomerManagedResourcesGcpSubnetSecondaryIpv4RangeServices
Secondary IPv4 range for services.
k8sMasterIpv4Range This property is required. String
Kubernetes Master IPv4 range, e.g. 10.0.0.0/24.
name This property is required. String
Unique name of the cluster.
secondaryIpv4RangePods This property is required. Property Map
Secondary IPv4 range for pods.
secondaryIpv4RangeServices This property is required. Property Map
Secondary IPv4 range for services.

GetClusterCustomerManagedResourcesGcpSubnetSecondaryIpv4RangePods

Name This property is required. string
Unique name of the cluster.
Name This property is required. string
Unique name of the cluster.
name This property is required. String
Unique name of the cluster.
name This property is required. string
Unique name of the cluster.
name This property is required. str
Unique name of the cluster.
name This property is required. String
Unique name of the cluster.

GetClusterCustomerManagedResourcesGcpSubnetSecondaryIpv4RangeServices

Name This property is required. string
Unique name of the cluster.
Name This property is required. string
Unique name of the cluster.
name This property is required. String
Unique name of the cluster.
name This property is required. string
Unique name of the cluster.
name This property is required. str
Unique name of the cluster.
name This property is required. String
Unique name of the cluster.

GetClusterCustomerManagedResourcesGcpTieredStorageBucket

Name This property is required. string
Unique name of the cluster.
Name This property is required. string
Unique name of the cluster.
name This property is required. String
Unique name of the cluster.
name This property is required. string
Unique name of the cluster.
name This property is required. str
Unique name of the cluster.
name This property is required. String
Unique name of the cluster.

GetClusterGcpPrivateServiceConnect

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

GetClusterGcpPrivateServiceConnectConsumerAcceptList

Source This property is required. string
Either the GCP project number or its alphanumeric ID.
Source This property is required. string
Either the GCP project number or its alphanumeric ID.
source This property is required. String
Either the GCP project number or its alphanumeric ID.
source This property is required. string
Either the GCP project number or its alphanumeric ID.
source This property is required. str
Either the GCP project number or its alphanumeric ID.
source This property is required. String
Either the GCP project number or its alphanumeric ID.

GetClusterGcpPrivateServiceConnectStatus

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

GetClusterGcpPrivateServiceConnectStatusConnectedEndpoint

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

GetClusterHttpProxy

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

GetClusterHttpProxyMtls

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

GetClusterKafkaApi

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

GetClusterKafkaApiMtls

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

GetClusterKafkaConnect

Enabled This property is required. bool
Whether Kafka Connect is enabled.
Enabled This property is required. bool
Whether Kafka Connect is enabled.
enabled This property is required. Boolean
Whether Kafka Connect is enabled.
enabled This property is required. boolean
Whether Kafka Connect is enabled.
enabled This property is required. bool
Whether Kafka Connect is enabled.
enabled This property is required. Boolean
Whether Kafka Connect is enabled.

GetClusterMaintenanceWindowConfig

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

GetClusterMaintenanceWindowConfigDayHour

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

GetClusterPrometheus

Url This property is required. string
The Prometheus metrics endpoint URL.
Url This property is required. string
The Prometheus metrics endpoint URL.
url This property is required. String
The Prometheus metrics endpoint URL.
url This property is required. string
The Prometheus metrics endpoint URL.
url This property is required. str
The Prometheus metrics endpoint URL.
url This property is required. String
The Prometheus metrics endpoint URL.

GetClusterRedpandaConsole

Url This property is required. string
The Redpanda Console URL.
Url This property is required. string
The Redpanda Console URL.
url This property is required. String
The Redpanda Console URL.
url This property is required. string
The Redpanda Console URL.
url This property is required. str
The Redpanda Console URL.
url This property is required. String
The Redpanda Console URL.

GetClusterSchemaRegistry

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

GetClusterSchemaRegistryMtls

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

GetClusterStateDescription

Code This property is required. double
Error code if cluster is in error state.
Message This property is required. string
Detailed error message if cluster is in error state.
Code This property is required. float64
Error code if cluster is in error state.
Message This property is required. string
Detailed error message if cluster is in error state.
code This property is required. Double
Error code if cluster is in error state.
message This property is required. String
Detailed error message if cluster is in error state.
code This property is required. number
Error code if cluster is in error state.
message This property is required. string
Detailed error message if cluster is in error state.
code This property is required. float
Error code if cluster is in error state.
message This property is required. str
Detailed error message if cluster is in error state.
code This property is required. Number
Error code if cluster is in error state.
message This property is required. 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.