redpanda 0.15.0 published on Friday, Apr 11, 2025 by redpanda-data
redpanda.getCluster
Explore with Pulumi AI
redpanda 0.15.0 published on Friday, Apr 11, 2025 by redpanda-data
Data source for a Redpanda Cloud cluster
Usage
import * as pulumi from "@pulumi/pulumi";
import * as redpanda from "@pulumi/redpanda";
const example = redpanda.getCluster({
id: "cluster_id",
});
import pulumi
import pulumi_redpanda as redpanda
example = redpanda.get_cluster(id="cluster_id")
package main
import (
"github.com/pulumi/pulumi-terraform-provider/sdks/go/redpanda/redpanda"
"github.com/pulumi/pulumi/sdk/v3/go/pulumi"
)
func main() {
pulumi.Run(func(ctx *pulumi.Context) error {
_, err := redpanda.LookupCluster(ctx, &redpanda.LookupClusterArgs{
Id: "cluster_id",
}, nil)
if err != nil {
return err
}
return nil
})
}
using System.Collections.Generic;
using System.Linq;
using Pulumi;
using Redpanda = Pulumi.Redpanda;
return await Deployment.RunAsync(() =>
{
var example = Redpanda.GetCluster.Invoke(new()
{
Id = "cluster_id",
});
});
package generated_program;
import com.pulumi.Context;
import com.pulumi.Pulumi;
import com.pulumi.core.Output;
import com.pulumi.redpanda.RedpandaFunctions;
import com.pulumi.redpanda.inputs.GetClusterArgs;
import java.util.List;
import java.util.ArrayList;
import java.util.Map;
import java.io.File;
import java.nio.file.Files;
import java.nio.file.Paths;
public class App {
public static void main(String[] args) {
Pulumi.run(App::stack);
}
public static void stack(Context ctx) {
final var example = RedpandaFunctions.getCluster(GetClusterArgs.builder()
.id("cluster_id")
.build());
}
}
variables:
example:
fn::invoke:
function: redpanda:getCluster
arguments:
id: cluster_id
Example Usage of a data source BYOC to manage users and ACLs
import * as pulumi from "@pulumi/pulumi";
import * as redpanda from "@pulumi/redpanda";
const config = new pulumi.Config();
const clusterId = config.get("clusterId") || "";
const testCluster = redpanda.getCluster({
id: clusterId,
});
const topicConfig = config.getObject("topicConfig") || {
"cleanup.policy": "compact",
"flush.ms": 100,
"compression.type": "snappy",
};
const partitionCount = config.getNumber("partitionCount") || 3;
const replicationFactor = config.getNumber("replicationFactor") || 3;
const testTopic = new redpanda.Topic("testTopic", {
partitionCount: partitionCount,
replicationFactor: replicationFactor,
clusterApiUrl: testCluster.then(testCluster => testCluster.clusterApiUrl),
allowDeletion: true,
configuration: topicConfig,
});
const userPw = config.get("userPw") || "password";
const mechanism = config.get("mechanism") || "scram-sha-256";
const testUser = new redpanda.User("testUser", {
password: userPw,
mechanism: mechanism,
clusterApiUrl: testCluster.then(testCluster => testCluster.clusterApiUrl),
});
const testAcl = new redpanda.Acl("testAcl", {
resourceType: "CLUSTER",
resourceName: "kafka-cluster",
resourcePatternType: "LITERAL",
principal: pulumi.interpolate`User:${testUser.name}`,
host: "*",
operation: "ALTER",
permissionType: "ALLOW",
clusterApiUrl: testCluster.then(testCluster => testCluster.clusterApiUrl),
});
const userName = config.get("userName") || "data-test-username";
const topicName = config.get("topicName") || "data-test-topic";
import pulumi
import pulumi_redpanda as redpanda
config = pulumi.Config()
cluster_id = config.get("clusterId")
if cluster_id is None:
cluster_id = ""
test_cluster = redpanda.get_cluster(id=cluster_id)
topic_config = config.get_object("topicConfig")
if topic_config is None:
topic_config = {
"cleanup.policy": "compact",
"flush.ms": 100,
"compression.type": "snappy",
}
partition_count = config.get_float("partitionCount")
if partition_count is None:
partition_count = 3
replication_factor = config.get_float("replicationFactor")
if replication_factor is None:
replication_factor = 3
test_topic = redpanda.Topic("testTopic",
partition_count=partition_count,
replication_factor=replication_factor,
cluster_api_url=test_cluster.cluster_api_url,
allow_deletion=True,
configuration=topic_config)
user_pw = config.get("userPw")
if user_pw is None:
user_pw = "password"
mechanism = config.get("mechanism")
if mechanism is None:
mechanism = "scram-sha-256"
test_user = redpanda.User("testUser",
password=user_pw,
mechanism=mechanism,
cluster_api_url=test_cluster.cluster_api_url)
test_acl = redpanda.Acl("testAcl",
resource_type="CLUSTER",
resource_name_="kafka-cluster",
resource_pattern_type="LITERAL",
principal=test_user.name.apply(lambda name: f"User:{name}"),
host="*",
operation="ALTER",
permission_type="ALLOW",
cluster_api_url=test_cluster.cluster_api_url)
user_name = config.get("userName")
if user_name is None:
user_name = "data-test-username"
topic_name = config.get("topicName")
if topic_name is None:
topic_name = "data-test-topic"
package main
import (
"fmt"
"github.com/pulumi/pulumi-terraform-provider/sdks/go/redpanda/redpanda"
"github.com/pulumi/pulumi/sdk/v3/go/pulumi"
"github.com/pulumi/pulumi/sdk/v3/go/pulumi/config"
)
func main() {
pulumi.Run(func(ctx *pulumi.Context) error {
cfg := config.New(ctx, "")
clusterId := ""
if param := cfg.Get("clusterId"); param != "" {
clusterId = param
}
testCluster, err := redpanda.LookupCluster(ctx, &redpanda.LookupClusterArgs{
Id: clusterId,
}, nil)
if err != nil {
return err
}
topicConfig := map[string]interface{}{
"cleanup.policy": "compact",
"flush.ms": 100,
"compression.type": "snappy",
}
if param := cfg.GetObject("topicConfig"); param != nil {
topicConfig = param
}
partitionCount := float64(3)
if param := cfg.GetFloat64("partitionCount"); param != 0 {
partitionCount = param
}
replicationFactor := float64(3)
if param := cfg.GetFloat64("replicationFactor"); param != 0 {
replicationFactor = param
}
_, err = redpanda.NewTopic(ctx, "testTopic", &redpanda.TopicArgs{
PartitionCount: pulumi.Float64(partitionCount),
ReplicationFactor: pulumi.Float64(replicationFactor),
ClusterApiUrl: pulumi.String(testCluster.ClusterApiUrl),
AllowDeletion: pulumi.Bool(true),
Configuration: pulumi.Any(topicConfig),
})
if err != nil {
return err
}
userPw := "password"
if param := cfg.Get("userPw"); param != "" {
userPw = param
}
mechanism := "scram-sha-256"
if param := cfg.Get("mechanism"); param != "" {
mechanism = param
}
testUser, err := redpanda.NewUser(ctx, "testUser", &redpanda.UserArgs{
Password: pulumi.String(userPw),
Mechanism: pulumi.String(mechanism),
ClusterApiUrl: pulumi.String(testCluster.ClusterApiUrl),
})
if err != nil {
return err
}
_, err = redpanda.NewAcl(ctx, "testAcl", &redpanda.AclArgs{
ResourceType: pulumi.String("CLUSTER"),
ResourceName: pulumi.String("kafka-cluster"),
ResourcePatternType: pulumi.String("LITERAL"),
Principal: testUser.Name.ApplyT(func(name string) (string, error) {
return fmt.Sprintf("User:%v", name), nil
}).(pulumi.StringOutput),
Host: pulumi.String("*"),
Operation: pulumi.String("ALTER"),
PermissionType: pulumi.String("ALLOW"),
ClusterApiUrl: pulumi.String(testCluster.ClusterApiUrl),
})
if err != nil {
return err
}
userName := "data-test-username"
if param := cfg.Get("userName"); param != "" {
userName = param
}
topicName := "data-test-topic"
if param := cfg.Get("topicName"); param != "" {
topicName = param
}
return nil
})
}
using System.Collections.Generic;
using System.Linq;
using Pulumi;
using Redpanda = Pulumi.Redpanda;
return await Deployment.RunAsync(() =>
{
var config = new Config();
var clusterId = config.Get("clusterId") ?? "";
var testCluster = Redpanda.GetCluster.Invoke(new()
{
Id = clusterId,
});
var topicConfig = config.GetObject<dynamic>("topicConfig") ??
{
{ "cleanup.policy", "compact" },
{ "flush.ms", 100 },
{ "compression.type", "snappy" },
};
var partitionCount = config.GetDouble("partitionCount") ?? 3;
var replicationFactor = config.GetDouble("replicationFactor") ?? 3;
var testTopic = new Redpanda.Topic("testTopic", new()
{
PartitionCount = partitionCount,
ReplicationFactor = replicationFactor,
ClusterApiUrl = testCluster.Apply(getClusterResult => getClusterResult.ClusterApiUrl),
AllowDeletion = true,
Configuration = topicConfig,
});
var userPw = config.Get("userPw") ?? "password";
var mechanism = config.Get("mechanism") ?? "scram-sha-256";
var testUser = new Redpanda.User("testUser", new()
{
Password = userPw,
Mechanism = mechanism,
ClusterApiUrl = testCluster.Apply(getClusterResult => getClusterResult.ClusterApiUrl),
});
var testAcl = new Redpanda.Acl("testAcl", new()
{
ResourceType = "CLUSTER",
ResourceName = "kafka-cluster",
ResourcePatternType = "LITERAL",
Principal = testUser.Name.Apply(name => $"User:{name}"),
Host = "*",
Operation = "ALTER",
PermissionType = "ALLOW",
ClusterApiUrl = testCluster.Apply(getClusterResult => getClusterResult.ClusterApiUrl),
});
var userName = config.Get("userName") ?? "data-test-username";
var topicName = config.Get("topicName") ?? "data-test-topic";
});
package generated_program;
import com.pulumi.Context;
import com.pulumi.Pulumi;
import com.pulumi.core.Output;
import com.pulumi.redpanda.RedpandaFunctions;
import com.pulumi.redpanda.inputs.GetClusterArgs;
import com.pulumi.redpanda.Topic;
import com.pulumi.redpanda.TopicArgs;
import com.pulumi.redpanda.User;
import com.pulumi.redpanda.UserArgs;
import com.pulumi.redpanda.Acl;
import com.pulumi.redpanda.AclArgs;
import java.util.List;
import java.util.ArrayList;
import java.util.Map;
import java.io.File;
import java.nio.file.Files;
import java.nio.file.Paths;
public class App {
public static void main(String[] args) {
Pulumi.run(App::stack);
}
public static void stack(Context ctx) {
final var config = ctx.config();
final var clusterId = config.get("clusterId").orElse("");
final var testCluster = RedpandaFunctions.getCluster(GetClusterArgs.builder()
.id(clusterId)
.build());
final var topicConfig = config.get("topicConfig").orElse(%!v(PANIC=Format method: runtime error: invalid memory address or nil pointer dereference));
final var partitionCount = config.get("partitionCount").orElse(3);
final var replicationFactor = config.get("replicationFactor").orElse(3);
var testTopic = new Topic("testTopic", TopicArgs.builder()
.partitionCount(partitionCount)
.replicationFactor(replicationFactor)
.clusterApiUrl(testCluster.applyValue(getClusterResult -> getClusterResult.clusterApiUrl()))
.allowDeletion(true)
.configuration(topicConfig)
.build());
final var userPw = config.get("userPw").orElse("password");
final var mechanism = config.get("mechanism").orElse("scram-sha-256");
var testUser = new User("testUser", UserArgs.builder()
.password(userPw)
.mechanism(mechanism)
.clusterApiUrl(testCluster.applyValue(getClusterResult -> getClusterResult.clusterApiUrl()))
.build());
var testAcl = new Acl("testAcl", AclArgs.builder()
.resourceType("CLUSTER")
.resourceName("kafka-cluster")
.resourcePatternType("LITERAL")
.principal(testUser.name().applyValue(name -> String.format("User:%s", name)))
.host("*")
.operation("ALTER")
.permissionType("ALLOW")
.clusterApiUrl(testCluster.applyValue(getClusterResult -> getClusterResult.clusterApiUrl()))
.build());
final var userName = config.get("userName").orElse("data-test-username");
final var topicName = config.get("topicName").orElse("data-test-topic");
}
}
configuration:
clusterId:
type: string
default: ""
topicConfig:
type: dynamic
default:
cleanup.policy: compact
flush.ms: 100
compression.type: snappy
userName:
type: string
default: data-test-username
userPw:
type: string
default: password
mechanism:
type: string
default: scram-sha-256
topicName:
type: string
default: data-test-topic
partitionCount:
type: number
default: 3
replicationFactor:
type: number
default: 3
resources:
testTopic:
type: redpanda:Topic
properties:
partitionCount: ${partitionCount}
replicationFactor: ${replicationFactor}
clusterApiUrl: ${testCluster.clusterApiUrl}
allowDeletion: true
configuration: ${topicConfig}
testUser:
type: redpanda:User
properties:
password: ${userPw}
mechanism: ${mechanism}
clusterApiUrl: ${testCluster.clusterApiUrl}
testAcl:
type: redpanda:Acl
properties:
resourceType: CLUSTER
resourceName: kafka-cluster
resourcePatternType: LITERAL
principal: User:${testUser.name}
host: '*'
operation: ALTER
permissionType: ALLOW
clusterApiUrl: ${testCluster.clusterApiUrl}
variables:
testCluster:
fn::invoke:
function: redpanda:getCluster
arguments:
id: ${clusterId}
Limitations
Can only be used with Redpanda Cloud Dedicated and BYOC clusters.
Using getCluster
Two invocation forms are available. The direct form accepts plain arguments and either blocks until the result value is available, or returns a Promise-wrapped result. The output form accepts Input-wrapped arguments and returns an Output-wrapped result.
function getCluster(args: GetClusterArgs, opts?: InvokeOptions): Promise<GetClusterResult>
function getClusterOutput(args: GetClusterOutputArgs, opts?: InvokeOptions): Output<GetClusterResult>
def get_cluster(id: Optional[str] = None,
opts: Optional[InvokeOptions] = None) -> GetClusterResult
def get_cluster_output(id: Optional[pulumi.Input[str]] = None,
opts: Optional[InvokeOptions] = None) -> Output[GetClusterResult]
func LookupCluster(ctx *Context, args *LookupClusterArgs, opts ...InvokeOption) (*LookupClusterResult, error)
func LookupClusterOutput(ctx *Context, args *LookupClusterOutputArgs, opts ...InvokeOption) LookupClusterResultOutput
> Note: This function is named LookupCluster
in the Go SDK.
public static class GetCluster
{
public static Task<GetClusterResult> InvokeAsync(GetClusterArgs args, InvokeOptions? opts = null)
public static Output<GetClusterResult> Invoke(GetClusterInvokeArgs args, InvokeOptions? opts = null)
}
public static CompletableFuture<GetClusterResult> getCluster(GetClusterArgs args, InvokeOptions options)
public static Output<GetClusterResult> getCluster(GetClusterArgs args, InvokeOptions options)
fn::invoke:
function: redpanda:index/getCluster:getCluster
arguments:
# arguments dictionary
The following arguments are supported:
- Id
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:
- Allow
Deletion bool - Whether cluster deletion is allowed.
- Aws
Private GetLink Cluster Aws Private Link - AWS PrivateLink configuration.
- Azure
Private GetLink Cluster Azure Private Link - Azure Private Link configuration.
- Cloud
Provider string - Cloud provider where resources are created.
- Cluster
Api stringUrl - The URL of the cluster API.
- Cluster
Type string - Cluster type. Type is immutable and can only be set on cluster creation.
- Connection
Type string - Cluster connection type. Private clusters are not exposed to the internet. For BYOC clusters, Private is best-practice.
- Connectivity
Get
Cluster Connectivity - Cloud provider-specific connectivity configuration.
- Created
At string - Timestamp when the cluster was created.
- Customer
Managed GetResources Cluster Customer Managed Resources - Customer managed resources configuration for the cluster.
- Gcp
Private GetService Connect Cluster Gcp Private Service Connect - GCP Private Service Connect configuration.
- Http
Proxy GetCluster Http Proxy - HTTP Proxy properties.
- Id string
- ID of the cluster. ID is an output from the Create Cluster endpoint and cannot be set by the caller.
- Kafka
Api GetCluster Kafka Api - Cluster's Kafka API properties.
- Kafka
Connect GetCluster Kafka Connect - Kafka Connect configuration.
- Maintenance
Window GetConfig Cluster Maintenance Window Config - Maintenance window configuration for the cluster.
- Name string
- Unique name of the cluster.
- Network
Id string - Network ID where cluster is placed.
- Prometheus
Get
Cluster Prometheus - Prometheus metrics endpoint properties.
- Read
Replica List<string>Cluster Ids - IDs of clusters that can create read-only topics from this cluster.
- Redpanda
Console GetCluster Redpanda Console - Redpanda Console properties.
- Redpanda
Version string - Current Redpanda version of the cluster.
- Region string
- Cloud provider region.
- Resource
Group stringId - Resource group ID of the cluster.
- Schema
Registry GetCluster Schema Registry - Schema Registry properties.
- State string
- Current state of the cluster.
- State
Description GetCluster State Description - Detailed state description when cluster is in a non-ready state.
- Dictionary<string, string>
- Tags placed on cloud resources.
- Throughput
Tier 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.
- Allow
Deletion bool - Whether cluster deletion is allowed.
- Aws
Private GetLink Cluster Aws Private Link - AWS PrivateLink configuration.
- Azure
Private GetLink Cluster Azure Private Link - Azure Private Link configuration.
- Cloud
Provider string - Cloud provider where resources are created.
- Cluster
Api stringUrl - The URL of the cluster API.
- Cluster
Type string - Cluster type. Type is immutable and can only be set on cluster creation.
- Connection
Type string - Cluster connection type. Private clusters are not exposed to the internet. For BYOC clusters, Private is best-practice.
- Connectivity
Get
Cluster Connectivity - Cloud provider-specific connectivity configuration.
- Created
At string - Timestamp when the cluster was created.
- Customer
Managed GetResources Cluster Customer Managed Resources - Customer managed resources configuration for the cluster.
- Gcp
Private GetService Connect Cluster Gcp Private Service Connect - GCP Private Service Connect configuration.
- Http
Proxy GetCluster Http Proxy - HTTP Proxy properties.
- Id string
- ID of the cluster. ID is an output from the Create Cluster endpoint and cannot be set by the caller.
- Kafka
Api GetCluster Kafka Api - Cluster's Kafka API properties.
- Kafka
Connect GetCluster Kafka Connect - Kafka Connect configuration.
- Maintenance
Window GetConfig Cluster Maintenance Window Config - Maintenance window configuration for the cluster.
- Name string
- Unique name of the cluster.
- Network
Id string - Network ID where cluster is placed.
- Prometheus
Get
Cluster Prometheus - Prometheus metrics endpoint properties.
- Read
Replica []stringCluster Ids - IDs of clusters that can create read-only topics from this cluster.
- Redpanda
Console GetCluster Redpanda Console - Redpanda Console properties.
- Redpanda
Version string - Current Redpanda version of the cluster.
- Region string
- Cloud provider region.
- Resource
Group stringId - Resource group ID of the cluster.
- Schema
Registry GetCluster Schema Registry - Schema Registry properties.
- State string
- Current state of the cluster.
- State
Description GetCluster State Description - Detailed state description when cluster is in a non-ready state.
- map[string]string
- Tags placed on cloud resources.
- Throughput
Tier 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 Boolean - Whether cluster deletion is allowed.
- aws
Private GetLink Cluster Aws Private Link - AWS PrivateLink configuration.
- azure
Private GetLink Cluster Azure Private Link - Azure Private Link configuration.
- cloud
Provider String - Cloud provider where resources are created.
- cluster
Api StringUrl - The URL of the cluster API.
- cluster
Type String - Cluster type. Type is immutable and can only be set on cluster creation.
- connection
Type String - Cluster connection type. Private clusters are not exposed to the internet. For BYOC clusters, Private is best-practice.
- connectivity
Get
Cluster Connectivity - Cloud provider-specific connectivity configuration.
- created
At String - Timestamp when the cluster was created.
- customer
Managed GetResources Cluster Customer Managed Resources - Customer managed resources configuration for the cluster.
- gcp
Private GetService Connect Cluster Gcp Private Service Connect - GCP Private Service Connect configuration.
- http
Proxy GetCluster Http Proxy - HTTP Proxy properties.
- id String
- ID of the cluster. ID is an output from the Create Cluster endpoint and cannot be set by the caller.
- kafka
Api GetCluster Kafka Api - Cluster's Kafka API properties.
- kafka
Connect GetCluster Kafka Connect - Kafka Connect configuration.
- maintenance
Window GetConfig Cluster Maintenance Window Config - Maintenance window configuration for the cluster.
- name String
- Unique name of the cluster.
- network
Id String - Network ID where cluster is placed.
- prometheus
Get
Cluster Prometheus - Prometheus metrics endpoint properties.
- read
Replica List<String>Cluster Ids - IDs of clusters that can create read-only topics from this cluster.
- redpanda
Console GetCluster Redpanda Console - Redpanda Console properties.
- redpanda
Version String - Current Redpanda version of the cluster.
- region String
- Cloud provider region.
- resource
Group StringId - Resource group ID of the cluster.
- schema
Registry GetCluster Schema Registry - Schema Registry properties.
- state String
- Current state of the cluster.
- state
Description GetCluster State Description - Detailed state description when cluster is in a non-ready state.
- Map<String,String>
- Tags placed on cloud resources.
- throughput
Tier 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.
- allow
Deletion boolean - Whether cluster deletion is allowed.
- aws
Private GetLink Cluster Aws Private Link - AWS PrivateLink configuration.
- azure
Private GetLink Cluster Azure Private Link - Azure Private Link configuration.
- cloud
Provider string - Cloud provider where resources are created.
- cluster
Api stringUrl - The URL of the cluster API.
- cluster
Type string - Cluster type. Type is immutable and can only be set on cluster creation.
- connection
Type string - Cluster connection type. Private clusters are not exposed to the internet. For BYOC clusters, Private is best-practice.
- connectivity
Get
Cluster Connectivity - Cloud provider-specific connectivity configuration.
- created
At string - Timestamp when the cluster was created.
- customer
Managed GetResources Cluster Customer Managed Resources - Customer managed resources configuration for the cluster.
- gcp
Private GetService Connect Cluster Gcp Private Service Connect - GCP Private Service Connect configuration.
- http
Proxy GetCluster Http Proxy - HTTP Proxy properties.
- id string
- ID of the cluster. ID is an output from the Create Cluster endpoint and cannot be set by the caller.
- kafka
Api GetCluster Kafka Api - Cluster's Kafka API properties.
- kafka
Connect GetCluster Kafka Connect - Kafka Connect configuration.
- maintenance
Window GetConfig Cluster Maintenance Window Config - Maintenance window configuration for the cluster.
- name string
- Unique name of the cluster.
- network
Id string - Network ID where cluster is placed.
- prometheus
Get
Cluster Prometheus - Prometheus metrics endpoint properties.
- read
Replica string[]Cluster Ids - IDs of clusters that can create read-only topics from this cluster.
- redpanda
Console GetCluster Redpanda Console - Redpanda Console properties.
- redpanda
Version string - Current Redpanda version of the cluster.
- region string
- Cloud provider region.
- resource
Group stringId - Resource group ID of the cluster.
- schema
Registry GetCluster Schema Registry - Schema Registry properties.
- state string
- Current state of the cluster.
- state
Description GetCluster State Description - Detailed state description when cluster is in a non-ready state.
- {[key: string]: string}
- Tags placed on cloud resources.
- throughput
Tier string - Throughput tier of the cluster.
- zones string[]
- Zones of the cluster. Must be valid zones within the selected region. If multiple zones are used, the cluster is a multi-AZ cluster.
- allow_
deletion bool - Whether cluster deletion is allowed.
- aws_
private_ Getlink Cluster Aws Private Link - AWS PrivateLink configuration.
- azure_
private_ Getlink Cluster Azure Private Link - Azure Private Link configuration.
- cloud_
provider str - Cloud provider where resources are created.
- cluster_
api_ strurl - The URL of the cluster API.
- cluster_
type str - Cluster type. Type is immutable and can only be set on cluster creation.
- connection_
type str - Cluster connection type. Private clusters are not exposed to the internet. For BYOC clusters, Private is best-practice.
- connectivity
Get
Cluster Connectivity - Cloud provider-specific connectivity configuration.
- created_
at str - Timestamp when the cluster was created.
- customer_
managed_ Getresources Cluster Customer Managed Resources - Customer managed resources configuration for the cluster.
- gcp_
private_ Getservice_ connect Cluster Gcp Private Service Connect - GCP Private Service Connect configuration.
- http_
proxy GetCluster Http Proxy - HTTP Proxy properties.
- id str
- ID of the cluster. ID is an output from the Create Cluster endpoint and cannot be set by the caller.
- kafka_
api GetCluster Kafka Api - Cluster's Kafka API properties.
- kafka_
connect GetCluster Kafka Connect - Kafka Connect configuration.
- maintenance_
window_ Getconfig Cluster Maintenance Window Config - Maintenance window configuration for the cluster.
- name str
- Unique name of the cluster.
- network_
id str - Network ID where cluster is placed.
- prometheus
Get
Cluster Prometheus - Prometheus metrics endpoint properties.
- read_
replica_ Sequence[str]cluster_ ids - IDs of clusters that can create read-only topics from this cluster.
- redpanda_
console GetCluster Redpanda Console - Redpanda Console properties.
- redpanda_
version str - Current Redpanda version of the cluster.
- region str
- Cloud provider region.
- resource_
group_ strid - Resource group ID of the cluster.
- schema_
registry GetCluster Schema Registry - Schema Registry properties.
- state str
- Current state of the cluster.
- state_
description GetCluster State Description - Detailed state description when cluster is in a non-ready state.
- Mapping[str, str]
- Tags placed on cloud resources.
- throughput_
tier str - Throughput tier of the cluster.
- zones Sequence[str]
- Zones of the cluster. Must be valid zones within the selected region. If multiple zones are used, the cluster is a multi-AZ cluster.
- allow
Deletion Boolean - Whether cluster deletion is allowed.
- aws
Private Property MapLink - AWS PrivateLink configuration.
- azure
Private Property MapLink - Azure Private Link configuration.
- cloud
Provider String - Cloud provider where resources are created.
- cluster
Api StringUrl - The URL of the cluster API.
- cluster
Type String - Cluster type. Type is immutable and can only be set on cluster creation.
- connection
Type 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.
- created
At String - Timestamp when the cluster was created.
- customer
Managed Property MapResources - Customer managed resources configuration for the cluster.
- gcp
Private Property MapService Connect - GCP Private Service Connect configuration.
- http
Proxy 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.
- kafka
Api Property Map - Cluster's Kafka API properties.
- kafka
Connect Property Map - Kafka Connect configuration.
- maintenance
Window Property MapConfig - Maintenance window configuration for the cluster.
- name String
- Unique name of the cluster.
- network
Id String - Network ID where cluster is placed.
- prometheus Property Map
- Prometheus metrics endpoint properties.
- read
Replica List<String>Cluster Ids - IDs of clusters that can create read-only topics from this cluster.
- redpanda
Console Property Map - Redpanda Console properties.
- redpanda
Version String - Current Redpanda version of the cluster.
- region String
- Cloud provider region.
- resource
Group StringId - Resource group ID of the cluster.
- schema
Registry Property Map - Schema Registry properties.
- state String
- Current state of the cluster.
- state
Description Property Map - Detailed state description when cluster is in a non-ready state.
- Map<String>
- Tags placed on cloud resources.
- throughput
Tier String - Throughput tier of the cluster.
- zones List<String>
- Zones of the cluster. Must be valid zones within the selected region. If multiple zones are used, the cluster is a multi-AZ cluster.
Supporting Types
GetClusterAwsPrivateLink
- Allowed
Principals This property is required. List<string> - 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. GetCluster Aws Private Link Status - Current status of the PrivateLink configuration.
- Allowed
Principals This property is required. []string - 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. GetCluster Aws Private Link Status - Current status of the PrivateLink configuration.
- allowed
Principals This property is required. List<String> - The ARN of the principals that can access the Redpanda AWS PrivateLink Endpoint Service.
- connect
Console 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. GetCluster Aws Private Link Status - Current status of the PrivateLink configuration.
- allowed
Principals This property is required. string[] - The ARN of the principals that can access the Redpanda AWS PrivateLink Endpoint Service.
- connect
Console 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. GetCluster Aws Private Link Status - 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. GetCluster Aws Private Link Status - Current status of the PrivateLink configuration.
- allowed
Principals This property is required. List<String> - The ARN of the principals that can access the Redpanda AWS PrivateLink Endpoint Service.
- connect
Console 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
- Console
Port This property is required. double - Port for Redpanda Console.
- Created
At This property is required. string - When the PrivateLink service was created.
- Deleted
At This property is required. string - When the PrivateLink service was deleted.
- Kafka
Api Node Base Port This property is required. double - Base port for Kafka API nodes.
- Kafka
Api Seed Port This property is required. double - Port for Kafka API seed brokers.
- Redpanda
Proxy Node Base Port This property is required. double - Base port for HTTP proxy nodes.
- Redpanda
Proxy Seed Port This property is required. double - Port for HTTP proxy.
- Schema
Registry Seed Port This property is required. double - Port for Schema Registry.
- Service
Id This property is required. string - The PrivateLink service ID.
- Service
Name This property is required. string - The PrivateLink service name.
- Service
State This property is required. string - Current state of the PrivateLink service.
- Vpc
Endpoint Connections This property is required. List<GetCluster Aws Private Link Status Vpc Endpoint Connection> - List of VPC endpoint connections.
- Console
Port This property is required. float64 - Port for Redpanda Console.
- Created
At This property is required. string - When the PrivateLink service was created.
- Deleted
At This property is required. string - When the PrivateLink service was deleted.
- Kafka
Api Node Base Port This property is required. float64 - Base port for Kafka API nodes.
- Kafka
Api Seed Port This property is required. float64 - Port for Kafka API seed brokers.
- Redpanda
Proxy Node Base Port This property is required. float64 - Base port for HTTP proxy nodes.
- Redpanda
Proxy Seed Port This property is required. float64 - Port for HTTP proxy.
- Schema
Registry Seed Port This property is required. float64 - Port for Schema Registry.
- Service
Id This property is required. string - The PrivateLink service ID.
- Service
Name This property is required. string - The PrivateLink service name.
- Service
State This property is required. string - Current state of the PrivateLink service.
- Vpc
Endpoint Connections This property is required. []GetCluster Aws Private Link Status Vpc Endpoint Connection - List of VPC endpoint connections.
- console
Port This property is required. Double - Port for Redpanda Console.
- created
At This property is required. String - When the PrivateLink service was created.
- deleted
At This property is required. String - When the PrivateLink service was deleted.
- kafka
Api Node Base Port This property is required. Double - Base port for Kafka API nodes.
- kafka
Api Seed Port This property is required. Double - Port for Kafka API seed brokers.
- redpanda
Proxy Node Base Port This property is required. Double - Base port for HTTP proxy nodes.
- redpanda
Proxy Seed Port This property is required. Double - Port for HTTP proxy.
- schema
Registry Seed Port This property is required. Double - Port for Schema Registry.
- service
Id This property is required. String - The PrivateLink service ID.
- service
Name This property is required. String - The PrivateLink service name.
- service
State This property is required. String - Current state of the PrivateLink service.
- vpc
Endpoint Connections This property is required. List<GetCluster Aws Private Link Status Vpc Endpoint Connection> - List of VPC endpoint connections.
- console
Port This property is required. number - Port for Redpanda Console.
- created
At This property is required. string - When the PrivateLink service was created.
- deleted
At This property is required. string - When the PrivateLink service was deleted.
- kafka
Api Node Base Port This property is required. number - Base port for Kafka API nodes.
- kafka
Api Seed Port This property is required. number - Port for Kafka API seed brokers.
- redpanda
Proxy Node Base Port This property is required. number - Base port for HTTP proxy nodes.
- redpanda
Proxy Seed Port This property is required. number - Port for HTTP proxy.
- schema
Registry Seed Port This property is required. number - Port for Schema Registry.
- service
Id This property is required. string - The PrivateLink service ID.
- service
Name This property is required. string - The PrivateLink service name.
- service
State This property is required. string - Current state of the PrivateLink service.
- vpc
Endpoint Connections This property is required. GetCluster Aws Private Link Status Vpc Endpoint Connection[] - 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[GetCluster Aws Private Link Status Vpc Endpoint Connection] - List of VPC endpoint connections.
- console
Port This property is required. Number - Port for Redpanda Console.
- created
At This property is required. String - When the PrivateLink service was created.
- deleted
At This property is required. String - When the PrivateLink service was deleted.
- kafka
Api Node Base Port This property is required. Number - Base port for Kafka API nodes.
- kafka
Api Seed Port This property is required. Number - Port for Kafka API seed brokers.
- redpanda
Proxy Node Base Port This property is required. Number - Base port for HTTP proxy nodes.
- redpanda
Proxy Seed Port This property is required. Number - Port for HTTP proxy.
- schema
Registry Seed Port This property is required. Number - Port for Schema Registry.
- service
Id This property is required. String - The PrivateLink service ID.
- service
Name This property is required. String - The PrivateLink service name.
- service
State This property is required. String - Current state of the PrivateLink service.
- vpc
Endpoint Connections This property is required. List<Property Map> - List of VPC endpoint connections.
GetClusterAwsPrivateLinkStatusVpcEndpointConnection
- Connection
Id This property is required. string - The connection ID.
- Created
At This property is required. string - When the endpoint connection was created.
- Dns
Entries This property is required. List<GetCluster Aws Private Link Status Vpc Endpoint Connection Dns Entry> - DNS entries for the endpoint.
- Id
This property is required. string - The endpoint connection ID.
- Load
Balancer Arns 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.
- Connection
Id This property is required. string - The connection ID.
- Created
At This property is required. string - When the endpoint connection was created.
- Dns
Entries This property is required. []GetCluster Aws Private Link Status Vpc Endpoint Connection Dns Entry - DNS entries for the endpoint.
- Id
This property is required. string - The endpoint connection ID.
- Load
Balancer Arns 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. String - The connection ID.
- created
At This property is required. String - When the endpoint connection was created.
- dns
Entries This property is required. List<GetCluster Aws Private Link Status Vpc Endpoint Connection Dns Entry> - DNS entries for the endpoint.
- id
This property is required. String - The endpoint connection ID.
- load
Balancer Arns 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.
- connection
Id This property is required. string - The connection ID.
- created
At This property is required. string - When the endpoint connection was created.
- dns
Entries This property is required. GetCluster Aws Private Link Status Vpc Endpoint Connection Dns Entry[] - DNS entries for the endpoint.
- id
This property is required. string - The endpoint connection ID.
- load
Balancer Arns 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[GetCluster Aws Private Link Status Vpc Endpoint Connection Dns Entry] - 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.
- connection
Id This property is required. String - The connection ID.
- created
At This property is required. String - When the endpoint connection was created.
- dns
Entries This property is required. List<Property Map> - DNS entries for the endpoint.
- id
This property is required. String - The endpoint connection ID.
- load
Balancer Arns 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
- Dns
Name This property is required. string - The DNS name.
- Hosted
Zone Id This property is required. string - The hosted zone ID.
- Dns
Name This property is required. string - The DNS name.
- Hosted
Zone Id This property is required. string - The hosted zone ID.
- dns
Name This property is required. String - The DNS name.
- hosted
Zone Id This property is required. String - The hosted zone ID.
- dns
Name This property is required. string - The DNS name.
- hosted
Zone Id 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.
- dns
Name This property is required. String - The DNS name.
- hosted
Zone Id This property is required. String - The hosted zone ID.
GetClusterAzurePrivateLink
- Allowed
Subscriptions This property is required. List<string> - 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. GetCluster Azure Private Link Status - Current status of the Private Link configuration.
- Allowed
Subscriptions This property is required. []string - 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. GetCluster Azure Private Link Status - Current status of the Private Link configuration.
- allowed
Subscriptions This property is required. List<String> - The subscriptions that can access the Redpanda Azure PrivateLink Endpoint Service.
- connect
Console 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. GetCluster Azure Private Link Status - Current status of the Private Link configuration.
- allowed
Subscriptions This property is required. string[] - The subscriptions that can access the Redpanda Azure PrivateLink Endpoint Service.
- connect
Console 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. GetCluster Azure Private Link Status - 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. GetCluster Azure Private Link Status - Current status of the Private Link configuration.
- allowed
Subscriptions This property is required. List<String> - The subscriptions that can access the Redpanda Azure PrivateLink Endpoint Service.
- connect
Console 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
- Approved
Subscriptions This property is required. List<string> - List of approved Azure subscription IDs.
- Console
Port This property is required. double - Port for Redpanda Console.
- Created
At This property is required. string - When the Private Link service was created.
- Deleted
At This property is required. string - When the Private Link service was deleted.
- Dns
ARecord This property is required. string - DNS A record for the service.
- Kafka
Api Node Base Port This property is required. double - Base port for Kafka API nodes.
- Kafka
Api Seed Port This property is required. double - Port for Kafka API seed brokers.
- Private
Endpoint Connections This property is required. List<GetCluster Azure Private Link Status Private Endpoint Connection> - List of private endpoint connections.
- Redpanda
Proxy Node Base Port This property is required. double - Base port for HTTP proxy nodes.
- Redpanda
Proxy Seed Port This property is required. double - Port for HTTP proxy.
- Schema
Registry Seed Port This property is required. double - Port for Schema Registry.
- Service
Id This property is required. string - The Private Link service ID.
- Service
Name This property is required. string - The Private Link service name.
- Approved
Subscriptions This property is required. []string - List of approved Azure subscription IDs.
- Console
Port This property is required. float64 - Port for Redpanda Console.
- Created
At This property is required. string - When the Private Link service was created.
- Deleted
At This property is required. string - When the Private Link service was deleted.
- Dns
ARecord This property is required. string - DNS A record for the service.
- Kafka
Api Node Base Port This property is required. float64 - Base port for Kafka API nodes.
- Kafka
Api Seed Port This property is required. float64 - Port for Kafka API seed brokers.
- Private
Endpoint Connections This property is required. []GetCluster Azure Private Link Status Private Endpoint Connection - List of private endpoint connections.
- Redpanda
Proxy Node Base Port This property is required. float64 - Base port for HTTP proxy nodes.
- Redpanda
Proxy Seed Port This property is required. float64 - Port for HTTP proxy.
- Schema
Registry Seed Port This property is required. float64 - Port for Schema Registry.
- Service
Id This property is required. string - The Private Link service ID.
- Service
Name This property is required. string - The Private Link service name.
- approved
Subscriptions This property is required. List<String> - List of approved Azure subscription IDs.
- console
Port This property is required. Double - Port for Redpanda Console.
- created
At This property is required. String - When the Private Link service was created.
- deleted
At This property is required. String - When the Private Link service was deleted.
- dns
ARecord This property is required. String - DNS A record for the service.
- kafka
Api Node Base Port This property is required. Double - Base port for Kafka API nodes.
- kafka
Api Seed Port This property is required. Double - Port for Kafka API seed brokers.
- private
Endpoint Connections This property is required. List<GetCluster Azure Private Link Status Private Endpoint Connection> - List of private endpoint connections.
- redpanda
Proxy Node Base Port This property is required. Double - Base port for HTTP proxy nodes.
- redpanda
Proxy Seed Port This property is required. Double - Port for HTTP proxy.
- schema
Registry Seed Port This property is required. Double - Port for Schema Registry.
- service
Id This property is required. String - The Private Link service ID.
- service
Name This property is required. String - The Private Link service name.
- approved
Subscriptions This property is required. string[] - List of approved Azure subscription IDs.
- console
Port This property is required. number - Port for Redpanda Console.
- created
At This property is required. string - When the Private Link service was created.
- deleted
At This property is required. string - When the Private Link service was deleted.
- dns
ARecord This property is required. string - DNS A record for the service.
- kafka
Api Node Base Port This property is required. number - Base port for Kafka API nodes.
- kafka
Api Seed Port This property is required. number - Port for Kafka API seed brokers.
- private
Endpoint Connections This property is required. GetCluster Azure Private Link Status Private Endpoint Connection[] - List of private endpoint connections.
- redpanda
Proxy Node Base Port This property is required. number - Base port for HTTP proxy nodes.
- redpanda
Proxy Seed Port This property is required. number - Port for HTTP proxy.
- schema
Registry Seed Port This property is required. number - Port for Schema Registry.
- service
Id This property is required. string - The Private Link service ID.
- service
Name 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[GetCluster Azure Private Link Status Private Endpoint Connection] - 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.
- approved
Subscriptions This property is required. List<String> - List of approved Azure subscription IDs.
- console
Port This property is required. Number - Port for Redpanda Console.
- created
At This property is required. String - When the Private Link service was created.
- deleted
At This property is required. String - When the Private Link service was deleted.
- dns
ARecord This property is required. String - DNS A record for the service.
- kafka
Api Node Base Port This property is required. Number - Base port for Kafka API nodes.
- kafka
Api Seed Port This property is required. Number - Port for Kafka API seed brokers.
- private
Endpoint Connections This property is required. List<Property Map> - List of private endpoint connections.
- redpanda
Proxy Node Base Port This property is required. Number - Base port for HTTP proxy nodes.
- redpanda
Proxy Seed Port This property is required. Number - Port for HTTP proxy.
- schema
Registry Seed Port This property is required. Number - Port for Schema Registry.
- service
Id This property is required. String - The Private Link service ID.
- service
Name This property is required. String - The Private Link service name.
GetClusterAzurePrivateLinkStatusPrivateEndpointConnection
- Connection
Id This property is required. string - ID of the connection.
- Connection
Name This property is required. string - Name of the connection.
- Created
At This property is required. string - When the endpoint connection was created.
- Private
Endpoint Id This property is required. string - ID of the private endpoint.
- Private
Endpoint Name 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. string - ID of the connection.
- Connection
Name This property is required. string - Name of the connection.
- Created
At This property is required. string - When the endpoint connection was created.
- Private
Endpoint Id This property is required. string - ID of the private endpoint.
- Private
Endpoint Name 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. String - ID of the connection.
- connection
Name This property is required. String - Name of the connection.
- created
At This property is required. String - When the endpoint connection was created.
- private
Endpoint Id This property is required. String - ID of the private endpoint.
- private
Endpoint Name 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. string - ID of the connection.
- connection
Name This property is required. string - Name of the connection.
- created
At This property is required. string - When the endpoint connection was created.
- private
Endpoint Id This property is required. string - ID of the private endpoint.
- private
Endpoint Name 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.
- connection
Id This property is required. String - ID of the connection.
- connection
Name This property is required. String - Name of the connection.
- created
At This property is required. String - When the endpoint connection was created.
- private
Endpoint Id This property is required. String - ID of the private endpoint.
- private
Endpoint Name 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. GetCluster Connectivity Gcp - GCP-specific connectivity settings.
- Gcp
This property is required. GetCluster Connectivity Gcp - GCP-specific connectivity settings.
- gcp
This property is required. GetCluster Connectivity Gcp - GCP-specific connectivity settings.
- gcp
This property is required. GetCluster Connectivity Gcp - GCP-specific connectivity settings.
- gcp
This property is required. GetCluster Connectivity Gcp - GCP-specific connectivity settings.
- gcp
This property is required. Property Map - GCP-specific connectivity settings.
GetClusterConnectivityGcp
- Enable
Global Access This property is required. bool - Whether global access is enabled.
- Enable
Global Access This property is required. bool - Whether global access is enabled.
- enable
Global Access This property is required. Boolean - Whether global access is enabled.
- enable
Global Access This property is required. boolean - Whether global access is enabled.
- enable_
global_ access This property is required. bool - Whether global access is enabled.
- enable
Global Access This property is required. Boolean - Whether global access is enabled.
GetClusterCustomerManagedResources
- Aws
This property is required. GetCluster Customer Managed Resources Aws - Gcp
This property is required. GetCluster Customer Managed Resources Gcp - GCP-specific connectivity settings.
- Aws
This property is required. GetCluster Customer Managed Resources Aws - Gcp
This property is required. GetCluster Customer Managed Resources Gcp - GCP-specific connectivity settings.
- aws
This property is required. GetCluster Customer Managed Resources Aws - gcp
This property is required. GetCluster Customer Managed Resources Gcp - GCP-specific connectivity settings.
- aws
This property is required. GetCluster Customer Managed Resources Aws - gcp
This property is required. GetCluster Customer Managed Resources Gcp - GCP-specific connectivity settings.
- aws
This property is required. GetCluster Customer Managed Resources Aws - gcp
This property is required. GetCluster Customer Managed Resources Gcp - GCP-specific connectivity settings.
- aws
This property is required. Property Map - gcp
This property is required. Property Map - GCP-specific connectivity settings.
GetClusterCustomerManagedResourcesAws
- Agent
Instance Profile This property is required. GetCluster Customer Managed Resources Aws Agent Instance Profile - Cloud
Storage Bucket This property is required. GetCluster Customer Managed Resources Aws Cloud Storage Bucket - Cluster
Security Group This property is required. GetCluster Customer Managed Resources Aws Cluster Security Group - Connectors
Node Group Instance Profile This property is required. GetCluster Customer Managed Resources Aws Connectors Node Group Instance Profile - Connectors
Security Group This property is required. GetCluster Customer Managed Resources Aws Connectors Security Group - K8s
Cluster Role This property is required. GetCluster Customer Managed Resources Aws K8s Cluster Role - Node
Security Group This property is required. GetCluster Customer Managed Resources Aws Node Security Group - Permissions
Boundary Policy This property is required. GetCluster Customer Managed Resources Aws Permissions Boundary Policy - Redpanda
Agent Security Group This property is required. GetCluster Customer Managed Resources Aws Redpanda Agent Security Group - Redpanda
Node Group Instance Profile This property is required. GetCluster Customer Managed Resources Aws Redpanda Node Group Instance Profile - Redpanda
Node Group Security Group This property is required. GetCluster Customer Managed Resources Aws Redpanda Node Group Security Group - Utility
Node Group Instance Profile This property is required. GetCluster Customer Managed Resources Aws Utility Node Group Instance Profile - Utility
Security Group This property is required. GetCluster Customer Managed Resources Aws Utility Security Group
- Agent
Instance Profile This property is required. GetCluster Customer Managed Resources Aws Agent Instance Profile - Cloud
Storage Bucket This property is required. GetCluster Customer Managed Resources Aws Cloud Storage Bucket - Cluster
Security Group This property is required. GetCluster Customer Managed Resources Aws Cluster Security Group - Connectors
Node Group Instance Profile This property is required. GetCluster Customer Managed Resources Aws Connectors Node Group Instance Profile - Connectors
Security Group This property is required. GetCluster Customer Managed Resources Aws Connectors Security Group - K8s
Cluster Role This property is required. GetCluster Customer Managed Resources Aws K8s Cluster Role - Node
Security Group This property is required. GetCluster Customer Managed Resources Aws Node Security Group - Permissions
Boundary Policy This property is required. GetCluster Customer Managed Resources Aws Permissions Boundary Policy - Redpanda
Agent Security Group This property is required. GetCluster Customer Managed Resources Aws Redpanda Agent Security Group - Redpanda
Node Group Instance Profile This property is required. GetCluster Customer Managed Resources Aws Redpanda Node Group Instance Profile - Redpanda
Node Group Security Group This property is required. GetCluster Customer Managed Resources Aws Redpanda Node Group Security Group - Utility
Node Group Instance Profile This property is required. GetCluster Customer Managed Resources Aws Utility Node Group Instance Profile - Utility
Security Group This property is required. GetCluster Customer Managed Resources Aws Utility Security Group
- agent
Instance Profile This property is required. GetCluster Customer Managed Resources Aws Agent Instance Profile - cloud
Storage Bucket This property is required. GetCluster Customer Managed Resources Aws Cloud Storage Bucket - cluster
Security Group This property is required. GetCluster Customer Managed Resources Aws Cluster Security Group - connectors
Node Group Instance Profile This property is required. GetCluster Customer Managed Resources Aws Connectors Node Group Instance Profile - connectors
Security Group This property is required. GetCluster Customer Managed Resources Aws Connectors Security Group - k8s
Cluster Role This property is required. GetCluster Customer Managed Resources Aws K8s Cluster Role - node
Security Group This property is required. GetCluster Customer Managed Resources Aws Node Security Group - permissions
Boundary Policy This property is required. GetCluster Customer Managed Resources Aws Permissions Boundary Policy - redpanda
Agent Security Group This property is required. GetCluster Customer Managed Resources Aws Redpanda Agent Security Group - redpanda
Node Group Instance Profile This property is required. GetCluster Customer Managed Resources Aws Redpanda Node Group Instance Profile - redpanda
Node Group Security Group This property is required. GetCluster Customer Managed Resources Aws Redpanda Node Group Security Group - utility
Node Group Instance Profile This property is required. GetCluster Customer Managed Resources Aws Utility Node Group Instance Profile - utility
Security Group This property is required. GetCluster Customer Managed Resources Aws Utility Security Group
- agent
Instance Profile This property is required. GetCluster Customer Managed Resources Aws Agent Instance Profile - cloud
Storage Bucket This property is required. GetCluster Customer Managed Resources Aws Cloud Storage Bucket - cluster
Security Group This property is required. GetCluster Customer Managed Resources Aws Cluster Security Group - connectors
Node Group Instance Profile This property is required. GetCluster Customer Managed Resources Aws Connectors Node Group Instance Profile - connectors
Security Group This property is required. GetCluster Customer Managed Resources Aws Connectors Security Group - k8s
Cluster Role This property is required. GetCluster Customer Managed Resources Aws K8s Cluster Role - node
Security Group This property is required. GetCluster Customer Managed Resources Aws Node Security Group - permissions
Boundary Policy This property is required. GetCluster Customer Managed Resources Aws Permissions Boundary Policy - redpanda
Agent Security Group This property is required. GetCluster Customer Managed Resources Aws Redpanda Agent Security Group - redpanda
Node Group Instance Profile This property is required. GetCluster Customer Managed Resources Aws Redpanda Node Group Instance Profile - redpanda
Node Group Security Group This property is required. GetCluster Customer Managed Resources Aws Redpanda Node Group Security Group - utility
Node Group Instance Profile This property is required. GetCluster Customer Managed Resources Aws Utility Node Group Instance Profile - utility
Security Group This property is required. GetCluster Customer Managed Resources Aws Utility Security Group
- agent_
instance_ profile This property is required. GetCluster Customer Managed Resources Aws Agent Instance Profile - cloud_
storage_ bucket This property is required. GetCluster Customer Managed Resources Aws Cloud Storage Bucket - cluster_
security_ group This property is required. GetCluster Customer Managed Resources Aws Cluster Security Group - connectors_
node_ group_ instance_ profile This property is required. GetCluster Customer Managed Resources Aws Connectors Node Group Instance Profile - connectors_
security_ group This property is required. GetCluster Customer Managed Resources Aws Connectors Security Group - k8s_
cluster_ role This property is required. GetCluster Customer Managed Resources Aws K8s Cluster Role - node_
security_ group This property is required. GetCluster Customer Managed Resources Aws Node Security Group - permissions_
boundary_ policy This property is required. GetCluster Customer Managed Resources Aws Permissions Boundary Policy - redpanda_
agent_ security_ group This property is required. GetCluster Customer Managed Resources Aws Redpanda Agent Security Group - redpanda_
node_ group_ instance_ profile This property is required. GetCluster Customer Managed Resources Aws Redpanda Node Group Instance Profile - redpanda_
node_ group_ security_ group This property is required. GetCluster Customer Managed Resources Aws Redpanda Node Group Security Group - utility_
node_ group_ instance_ profile This property is required. GetCluster Customer Managed Resources Aws Utility Node Group Instance Profile - utility_
security_ group This property is required. GetCluster Customer Managed Resources Aws Utility Security Group
- agent
Instance Profile This property is required. Property Map - cloud
Storage Bucket This property is required. Property Map - cluster
Security Group This property is required. Property Map - connectors
Node Group Instance Profile This property is required. Property Map - connectors
Security Group This property is required. Property Map - k8s
Cluster Role This property is required. Property Map - node
Security Group This property is required. Property Map - permissions
Boundary Policy This property is required. Property Map - redpanda
Agent Security Group This property is required. Property Map - redpanda
Node Group Instance Profile This property is required. Property Map - redpanda
Node Group Security Group This property is required. Property Map - utility
Node Group Instance Profile This property is required. Property Map - utility
Security Group 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
- Agent
Service Account This property is required. GetCluster Customer Managed Resources Gcp Agent Service Account - GCP service account for the agent.
- Connector
Service Account This property is required. GetCluster Customer Managed Resources Gcp Connector Service Account - GCP service account for managed connectors.
- Console
Service Account This property is required. GetCluster Customer Managed Resources Gcp Console Service Account - GCP service account for Redpanda Console.
- Gke
Service Account This property is required. GetCluster Customer Managed Resources Gcp Gke Service Account - GCP service account for GCP Kubernetes Engine (GKE).
- Psc
Nat Subnet Name This property is required. string - NAT subnet name if GCP Private Service Connect is enabled.
- Redpanda
Cluster Service Account This property is required. GetCluster Customer Managed Resources Gcp Redpanda Cluster Service Account - GCP service account for the Redpanda cluster.
- Subnet
This property is required. GetCluster Customer Managed Resources Gcp Subnet - GCP subnet where Redpanda cluster is deployed.
- Tiered
Storage Bucket This property is required. GetCluster Customer Managed Resources Gcp Tiered Storage Bucket - GCP storage bucket for Tiered storage.
- Agent
Service Account This property is required. GetCluster Customer Managed Resources Gcp Agent Service Account - GCP service account for the agent.
- Connector
Service Account This property is required. GetCluster Customer Managed Resources Gcp Connector Service Account - GCP service account for managed connectors.
- Console
Service Account This property is required. GetCluster Customer Managed Resources Gcp Console Service Account - GCP service account for Redpanda Console.
- Gke
Service Account This property is required. GetCluster Customer Managed Resources Gcp Gke Service Account - GCP service account for GCP Kubernetes Engine (GKE).
- Psc
Nat Subnet Name This property is required. string - NAT subnet name if GCP Private Service Connect is enabled.
- Redpanda
Cluster Service Account This property is required. GetCluster Customer Managed Resources Gcp Redpanda Cluster Service Account - GCP service account for the Redpanda cluster.
- Subnet
This property is required. GetCluster Customer Managed Resources Gcp Subnet - GCP subnet where Redpanda cluster is deployed.
- Tiered
Storage Bucket This property is required. GetCluster Customer Managed Resources Gcp Tiered Storage Bucket - GCP storage bucket for Tiered storage.
- agent
Service Account This property is required. GetCluster Customer Managed Resources Gcp Agent Service Account - GCP service account for the agent.
- connector
Service Account This property is required. GetCluster Customer Managed Resources Gcp Connector Service Account - GCP service account for managed connectors.
- console
Service Account This property is required. GetCluster Customer Managed Resources Gcp Console Service Account - GCP service account for Redpanda Console.
- gke
Service Account This property is required. GetCluster Customer Managed Resources Gcp Gke Service Account - GCP service account for GCP Kubernetes Engine (GKE).
- psc
Nat Subnet Name This property is required. String - NAT subnet name if GCP Private Service Connect is enabled.
- redpanda
Cluster Service Account This property is required. GetCluster Customer Managed Resources Gcp Redpanda Cluster Service Account - GCP service account for the Redpanda cluster.
- subnet
This property is required. GetCluster Customer Managed Resources Gcp Subnet - GCP subnet where Redpanda cluster is deployed.
- tiered
Storage Bucket This property is required. GetCluster Customer Managed Resources Gcp Tiered Storage Bucket - GCP storage bucket for Tiered storage.
- agent
Service Account This property is required. GetCluster Customer Managed Resources Gcp Agent Service Account - GCP service account for the agent.
- connector
Service Account This property is required. GetCluster Customer Managed Resources Gcp Connector Service Account - GCP service account for managed connectors.
- console
Service Account This property is required. GetCluster Customer Managed Resources Gcp Console Service Account - GCP service account for Redpanda Console.
- gke
Service Account This property is required. GetCluster Customer Managed Resources Gcp Gke Service Account - GCP service account for GCP Kubernetes Engine (GKE).
- psc
Nat Subnet Name This property is required. string - NAT subnet name if GCP Private Service Connect is enabled.
- redpanda
Cluster Service Account This property is required. GetCluster Customer Managed Resources Gcp Redpanda Cluster Service Account - GCP service account for the Redpanda cluster.
- subnet
This property is required. GetCluster Customer Managed Resources Gcp Subnet - GCP subnet where Redpanda cluster is deployed.
- tiered
Storage Bucket This property is required. GetCluster Customer Managed Resources Gcp Tiered Storage Bucket - GCP storage bucket for Tiered storage.
- agent_
service_ account This property is required. GetCluster Customer Managed Resources Gcp Agent Service Account - GCP service account for the agent.
- connector_
service_ account This property is required. GetCluster Customer Managed Resources Gcp Connector Service Account - GCP service account for managed connectors.
- console_
service_ account This property is required. GetCluster Customer Managed Resources Gcp Console Service Account - GCP service account for Redpanda Console.
- gke_
service_ account This property is required. GetCluster Customer Managed Resources Gcp Gke Service Account - 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. GetCluster Customer Managed Resources Gcp Redpanda Cluster Service Account - GCP service account for the Redpanda cluster.
- subnet
This property is required. GetCluster Customer Managed Resources Gcp Subnet - GCP subnet where Redpanda cluster is deployed.
- tiered_
storage_ bucket This property is required. GetCluster Customer Managed Resources Gcp Tiered Storage Bucket - GCP storage bucket for Tiered storage.
- agent
Service Account This property is required. Property Map - GCP service account for the agent.
- connector
Service Account This property is required. Property Map - GCP service account for managed connectors.
- console
Service Account This property is required. Property Map - GCP service account for Redpanda Console.
- gke
Service Account This property is required. Property Map - GCP service account for GCP Kubernetes Engine (GKE).
- psc
Nat Subnet Name This property is required. String - NAT subnet name if GCP Private Service Connect is enabled.
- redpanda
Cluster Service Account 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.
- tiered
Storage Bucket 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
- K8s
Master Ipv4Range 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.
- Secondary
Ipv4Range Pods This property is required. GetCluster Customer Managed Resources Gcp Subnet Secondary Ipv4Range Pods - Secondary IPv4 range for pods.
- Secondary
Ipv4Range Services This property is required. GetCluster Customer Managed Resources Gcp Subnet Secondary Ipv4Range Services - Secondary IPv4 range for services.
- K8s
Master Ipv4Range 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.
- Secondary
Ipv4Range Pods This property is required. GetCluster Customer Managed Resources Gcp Subnet Secondary Ipv4Range Pods - Secondary IPv4 range for pods.
- Secondary
Ipv4Range Services This property is required. GetCluster Customer Managed Resources Gcp Subnet Secondary Ipv4Range Services - Secondary IPv4 range for services.
- k8s
Master Ipv4Range 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.
- secondary
Ipv4Range Pods This property is required. GetCluster Customer Managed Resources Gcp Subnet Secondary Ipv4Range Pods - Secondary IPv4 range for pods.
- secondary
Ipv4Range Services This property is required. GetCluster Customer Managed Resources Gcp Subnet Secondary Ipv4Range Services - Secondary IPv4 range for services.
- k8s
Master Ipv4Range 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.
- secondary
Ipv4Range Pods This property is required. GetCluster Customer Managed Resources Gcp Subnet Secondary Ipv4Range Pods - Secondary IPv4 range for pods.
- secondary
Ipv4Range Services This property is required. GetCluster Customer Managed Resources Gcp Subnet Secondary Ipv4Range Services - 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. GetCluster Customer Managed Resources Gcp Subnet Secondary Ipv4Range Pods - Secondary IPv4 range for pods.
- secondary_
ipv4_ range_ services This property is required. GetCluster Customer Managed Resources Gcp Subnet Secondary Ipv4Range Services - Secondary IPv4 range for services.
- k8s
Master Ipv4Range 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.
- secondary
Ipv4Range Pods This property is required. Property Map - Secondary IPv4 range for pods.
- secondary
Ipv4Range Services 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
- Consumer
Accept Lists This property is required. List<GetCluster Gcp Private Service Connect Consumer Accept List> - 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. GetCluster Gcp Private Service Connect Status - Current status of the Private Service Connect configuration.
- Consumer
Accept Lists This property is required. []GetCluster Gcp Private Service Connect Consumer Accept List - 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. GetCluster Gcp Private Service Connect Status - Current status of the Private Service Connect configuration.
- consumer
Accept Lists This property is required. List<GetCluster Gcp Private Service Connect Consumer Accept List> - 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.
- global
Access Enabled This property is required. Boolean - Whether global access is enabled.
- status
This property is required. GetCluster Gcp Private Service Connect Status - Current status of the Private Service Connect configuration.
- consumer
Accept Lists This property is required. GetCluster Gcp Private Service Connect Consumer Accept List[] - 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.
- global
Access Enabled This property is required. boolean - Whether global access is enabled.
- status
This property is required. GetCluster Gcp Private Service Connect Status - Current status of the Private Service Connect configuration.
- consumer_
accept_ lists This property is required. Sequence[GetCluster Gcp Private Service Connect Consumer Accept List] - 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. GetCluster Gcp Private Service Connect Status - Current status of the Private Service Connect configuration.
- consumer
Accept Lists 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.
- global
Access Enabled 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
- Connected
Endpoints This property is required. List<GetCluster Gcp Private Service Connect Status Connected Endpoint> - List of connected endpoints.
- Created
At This property is required. string - When the Private Service Connect service was created.
- Deleted
At This property is required. string - When the Private Service Connect service was deleted.
- Dns
ARecords This property is required. List<string> - DNS A records for the service.
- Kafka
Api Node Base Port This property is required. double - Base port for Kafka API nodes.
- Kafka
Api Seed Port This property is required. double - Port for Kafka API seed brokers.
- Redpanda
Proxy Node Base Port This property is required. double - Base port for HTTP proxy nodes.
- Redpanda
Proxy Seed Port This property is required. double - Port for HTTP proxy.
- Schema
Registry Seed Port This property is required. double - Port for Schema Registry.
- Seed
Hostname This property is required. string - Hostname for the seed brokers.
- Service
Attachment This property is required. string - The service attachment identifier.
- Connected
Endpoints This property is required. []GetCluster Gcp Private Service Connect Status Connected Endpoint - List of connected endpoints.
- Created
At This property is required. string - When the Private Service Connect service was created.
- Deleted
At This property is required. string - When the Private Service Connect service was deleted.
- Dns
ARecords This property is required. []string - DNS A records for the service.
- Kafka
Api Node Base Port This property is required. float64 - Base port for Kafka API nodes.
- Kafka
Api Seed Port This property is required. float64 - Port for Kafka API seed brokers.
- Redpanda
Proxy Node Base Port This property is required. float64 - Base port for HTTP proxy nodes.
- Redpanda
Proxy Seed Port This property is required. float64 - Port for HTTP proxy.
- Schema
Registry Seed Port This property is required. float64 - Port for Schema Registry.
- Seed
Hostname This property is required. string - Hostname for the seed brokers.
- Service
Attachment This property is required. string - The service attachment identifier.
- connected
Endpoints This property is required. List<GetCluster Gcp Private Service Connect Status Connected Endpoint> - List of connected endpoints.
- created
At This property is required. String - When the Private Service Connect service was created.
- deleted
At This property is required. String - When the Private Service Connect service was deleted.
- dns
ARecords This property is required. List<String> - DNS A records for the service.
- kafka
Api Node Base Port This property is required. Double - Base port for Kafka API nodes.
- kafka
Api Seed Port This property is required. Double - Port for Kafka API seed brokers.
- redpanda
Proxy Node Base Port This property is required. Double - Base port for HTTP proxy nodes.
- redpanda
Proxy Seed Port This property is required. Double - Port for HTTP proxy.
- schema
Registry Seed Port This property is required. Double - Port for Schema Registry.
- seed
Hostname This property is required. String - Hostname for the seed brokers.
- service
Attachment This property is required. String - The service attachment identifier.
- connected
Endpoints This property is required. GetCluster Gcp Private Service Connect Status Connected Endpoint[] - List of connected endpoints.
- created
At This property is required. string - When the Private Service Connect service was created.
- deleted
At This property is required. string - When the Private Service Connect service was deleted.
- dns
ARecords This property is required. string[] - DNS A records for the service.
- kafka
Api Node Base Port This property is required. number - Base port for Kafka API nodes.
- kafka
Api Seed Port This property is required. number - Port for Kafka API seed brokers.
- redpanda
Proxy Node Base Port This property is required. number - Base port for HTTP proxy nodes.
- redpanda
Proxy Seed Port This property is required. number - Port for HTTP proxy.
- schema
Registry Seed Port This property is required. number - Port for Schema Registry.
- seed
Hostname This property is required. string - Hostname for the seed brokers.
- service
Attachment This property is required. string - The service attachment identifier.
- connected_
endpoints This property is required. Sequence[GetCluster Gcp Private Service Connect Status Connected Endpoint] - 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.
- connected
Endpoints This property is required. List<Property Map> - List of connected endpoints.
- created
At This property is required. String - When the Private Service Connect service was created.
- deleted
At This property is required. String - When the Private Service Connect service was deleted.
- dns
ARecords This property is required. List<String> - DNS A records for the service.
- kafka
Api Node Base Port This property is required. Number - Base port for Kafka API nodes.
- kafka
Api Seed Port This property is required. Number - Port for Kafka API seed brokers.
- redpanda
Proxy Node Base Port This property is required. Number - Base port for HTTP proxy nodes.
- redpanda
Proxy Seed Port This property is required. Number - Port for HTTP proxy.
- schema
Registry Seed Port This property is required. Number - Port for Schema Registry.
- seed
Hostname This property is required. String - Hostname for the seed brokers.
- service
Attachment This property is required. String - The service attachment identifier.
GetClusterGcpPrivateServiceConnectStatusConnectedEndpoint
- Connection
Id This property is required. string - The connection ID.
- Consumer
Network 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. string - The connection ID.
- Consumer
Network 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. String - The connection ID.
- consumer
Network 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. string - The connection ID.
- consumer
Network 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.
- connection
Id This property is required. String - The connection ID.
- consumer
Network 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. GetCluster Http Proxy Mtls - mTLS configuration.
- Url
This property is required. string - The HTTP Proxy URL.
- Mtls
This property is required. GetCluster Http Proxy Mtls - mTLS configuration.
- Url
This property is required. string - The HTTP Proxy URL.
- mtls
This property is required. GetCluster Http Proxy Mtls - mTLS configuration.
- url
This property is required. String - The HTTP Proxy URL.
- mtls
This property is required. GetCluster Http Proxy Mtls - mTLS configuration.
- url
This property is required. string - The HTTP Proxy URL.
- mtls
This property is required. GetCluster Http Proxy Mtls - 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
- Ca
Certificates Pems This property is required. List<string> - CA certificate in PEM format.
- Enabled
This property is required. bool - Whether mTLS is enabled.
- Principal
Mapping Rules This property is required. List<string> - Principal mapping rules for mTLS authentication.
- Ca
Certificates Pems This property is required. []string - CA certificate in PEM format.
- Enabled
This property is required. bool - Whether mTLS is enabled.
- Principal
Mapping Rules This property is required. []string - Principal mapping rules for mTLS authentication.
- ca
Certificates Pems This property is required. List<String> - CA certificate in PEM format.
- enabled
This property is required. Boolean - Whether mTLS is enabled.
- principal
Mapping Rules This property is required. List<String> - Principal mapping rules for mTLS authentication.
- ca
Certificates Pems This property is required. string[] - CA certificate in PEM format.
- enabled
This property is required. boolean - Whether mTLS is enabled.
- principal
Mapping Rules 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.
- ca
Certificates Pems This property is required. List<String> - CA certificate in PEM format.
- enabled
This property is required. Boolean - Whether mTLS is enabled.
- principal
Mapping Rules This property is required. List<String> - Principal mapping rules for mTLS authentication.
GetClusterKafkaApi
- Mtls
This property is required. GetCluster Kafka Api Mtls - mTLS configuration.
- Seed
Brokers This property is required. List<string> - List of Kafka broker addresses.
- Mtls
This property is required. GetCluster Kafka Api Mtls - mTLS configuration.
- Seed
Brokers This property is required. []string - List of Kafka broker addresses.
- mtls
This property is required. GetCluster Kafka Api Mtls - mTLS configuration.
- seed
Brokers This property is required. List<String> - List of Kafka broker addresses.
- mtls
This property is required. GetCluster Kafka Api Mtls - mTLS configuration.
- seed
Brokers This property is required. string[] - List of Kafka broker addresses.
- mtls
This property is required. GetCluster Kafka Api Mtls - mTLS configuration.
- seed_
brokers This property is required. Sequence[str] - List of Kafka broker addresses.
- mtls
This property is required. Property Map - mTLS configuration.
- seed
Brokers This property is required. List<String> - List of Kafka broker addresses.
GetClusterKafkaApiMtls
- Ca
Certificates Pems This property is required. List<string> - CA certificate in PEM format.
- Enabled
This property is required. bool - Whether mTLS is enabled.
- Principal
Mapping Rules This property is required. List<string> - Principal mapping rules for mTLS authentication.
- Ca
Certificates Pems This property is required. []string - CA certificate in PEM format.
- Enabled
This property is required. bool - Whether mTLS is enabled.
- Principal
Mapping Rules This property is required. []string - Principal mapping rules for mTLS authentication.
- ca
Certificates Pems This property is required. List<String> - CA certificate in PEM format.
- enabled
This property is required. Boolean - Whether mTLS is enabled.
- principal
Mapping Rules This property is required. List<String> - Principal mapping rules for mTLS authentication.
- ca
Certificates Pems This property is required. string[] - CA certificate in PEM format.
- enabled
This property is required. boolean - Whether mTLS is enabled.
- principal
Mapping Rules 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.
- ca
Certificates Pems This property is required. List<String> - CA certificate in PEM format.
- enabled
This property is required. Boolean - Whether mTLS is enabled.
- principal
Mapping Rules 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.
- Day
Hour This property is required. GetCluster Maintenance Window Config Day Hour - 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.
- Day
Hour This property is required. GetCluster Maintenance Window Config Day Hour - 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.
- day
Hour This property is required. GetCluster Maintenance Window Config Day Hour - 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.
- day
Hour This property is required. GetCluster Maintenance Window Config Day Hour - 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. GetCluster Maintenance Window Config Day Hour - 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.
- day
Hour This property is required. Property Map - unspecified
This property is required. Boolean - If true, maintenance window is unspecified.
GetClusterMaintenanceWindowConfigDayHour
- day_
of_ week This property is required. str - Day of week.
- hour_
of_ day This property is required. float - 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. GetCluster Schema Registry Mtls - mTLS configuration.
- Url
This property is required. string - The Schema Registry URL.
- Mtls
This property is required. GetCluster Schema Registry Mtls - mTLS configuration.
- Url
This property is required. string - The Schema Registry URL.
- mtls
This property is required. GetCluster Schema Registry Mtls - mTLS configuration.
- url
This property is required. String - The Schema Registry URL.
- mtls
This property is required. GetCluster Schema Registry Mtls - mTLS configuration.
- url
This property is required. string - The Schema Registry URL.
- mtls
This property is required. GetCluster Schema Registry Mtls - 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
- Ca
Certificates Pems This property is required. List<string> - CA certificate in PEM format.
- Enabled
This property is required. bool - Whether mTLS is enabled.
- Principal
Mapping Rules This property is required. List<string> - Principal mapping rules for mTLS authentication.
- Ca
Certificates Pems This property is required. []string - CA certificate in PEM format.
- Enabled
This property is required. bool - Whether mTLS is enabled.
- Principal
Mapping Rules This property is required. []string - Principal mapping rules for mTLS authentication.
- ca
Certificates Pems This property is required. List<String> - CA certificate in PEM format.
- enabled
This property is required. Boolean - Whether mTLS is enabled.
- principal
Mapping Rules This property is required. List<String> - Principal mapping rules for mTLS authentication.
- ca
Certificates Pems This property is required. string[] - CA certificate in PEM format.
- enabled
This property is required. boolean - Whether mTLS is enabled.
- principal
Mapping Rules 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.
- ca
Certificates Pems This property is required. List<String> - CA certificate in PEM format.
- enabled
This property is required. Boolean - Whether mTLS is enabled.
- principal
Mapping Rules This property is required. List<String> - Principal mapping rules for mTLS authentication.
GetClusterStateDescription
Package Details
- Repository
- redpanda redpanda-data/terraform-provider-redpanda
- License
- Notes
- This Pulumi package is based on the
redpanda
Terraform Provider.
redpanda 0.15.0 published on Friday, Apr 11, 2025 by redpanda-data