redpanda 0.13.0 published on Monday, Mar 17, 2025 by redpanda-data
redpanda.getCluster
Explore with Pulumi AI
redpanda 0.13.0 published on Monday, Mar 17, 2025 by redpanda-data
Data source for a Redpanda Cloud cluster
Usage
import * as pulumi from "@pulumi/pulumi";
import * as redpanda from "@pulumi/redpanda";
const example = redpanda.getCluster({
id: "cluster_id",
});
import pulumi
import pulumi_redpanda as redpanda
example = redpanda.get_cluster(id="cluster_id")
package main
import (
"github.com/pulumi/pulumi-terraform-provider/sdks/go/redpanda/redpanda"
"github.com/pulumi/pulumi/sdk/v3/go/pulumi"
)
func main() {
pulumi.Run(func(ctx *pulumi.Context) error {
_, err := redpanda.LookupCluster(ctx, &redpanda.LookupClusterArgs{
Id: "cluster_id",
}, nil)
if err != nil {
return err
}
return nil
})
}
using System.Collections.Generic;
using System.Linq;
using Pulumi;
using Redpanda = Pulumi.Redpanda;
return await Deployment.RunAsync(() =>
{
var example = Redpanda.GetCluster.Invoke(new()
{
Id = "cluster_id",
});
});
package generated_program;
import com.pulumi.Context;
import com.pulumi.Pulumi;
import com.pulumi.core.Output;
import com.pulumi.redpanda.RedpandaFunctions;
import com.pulumi.redpanda.inputs.GetClusterArgs;
import java.util.List;
import java.util.ArrayList;
import java.util.Map;
import java.io.File;
import java.nio.file.Files;
import java.nio.file.Paths;
public class App {
public static void main(String[] args) {
Pulumi.run(App::stack);
}
public static void stack(Context ctx) {
final var example = RedpandaFunctions.getCluster(GetClusterArgs.builder()
.id("cluster_id")
.build());
}
}
variables:
example:
fn::invoke:
function: redpanda:getCluster
arguments:
id: cluster_id
Example Usage of a data source BYOC to manage users and ACLs
import * as pulumi from "@pulumi/pulumi";
import * as redpanda from "@pulumi/redpanda";
const config = new pulumi.Config();
const clusterId = config.get("clusterId") || "";
const testCluster = redpanda.getCluster({
id: clusterId,
});
const topicConfig = config.getObject("topicConfig") || {
"cleanup.policy": "compact",
"flush.ms": 100,
"compression.type": "snappy",
};
const partitionCount = config.getNumber("partitionCount") || 3;
const replicationFactor = config.getNumber("replicationFactor") || 3;
const testTopic = new redpanda.Topic("testTopic", {
partitionCount: partitionCount,
replicationFactor: replicationFactor,
clusterApiUrl: testCluster.then(testCluster => testCluster.clusterApiUrl),
allowDeletion: true,
configuration: topicConfig,
});
const userPw = config.get("userPw") || "password";
const mechanism = config.get("mechanism") || "scram-sha-256";
const testUser = new redpanda.User("testUser", {
password: userPw,
mechanism: mechanism,
clusterApiUrl: testCluster.then(testCluster => testCluster.clusterApiUrl),
});
const testAcl = new redpanda.Acl("testAcl", {
resourceType: "CLUSTER",
resourceName: "kafka-cluster",
resourcePatternType: "LITERAL",
principal: pulumi.interpolate`User:${testUser.name}`,
host: "*",
operation: "ALTER",
permissionType: "ALLOW",
clusterApiUrl: testCluster.then(testCluster => testCluster.clusterApiUrl),
});
const userName = config.get("userName") || "data-test-username";
const topicName = config.get("topicName") || "data-test-topic";
import pulumi
import pulumi_redpanda as redpanda
config = pulumi.Config()
cluster_id = config.get("clusterId")
if cluster_id is None:
cluster_id = ""
test_cluster = redpanda.get_cluster(id=cluster_id)
topic_config = config.get_object("topicConfig")
if topic_config is None:
topic_config = {
"cleanup.policy": "compact",
"flush.ms": 100,
"compression.type": "snappy",
}
partition_count = config.get_float("partitionCount")
if partition_count is None:
partition_count = 3
replication_factor = config.get_float("replicationFactor")
if replication_factor is None:
replication_factor = 3
test_topic = redpanda.Topic("testTopic",
partition_count=partition_count,
replication_factor=replication_factor,
cluster_api_url=test_cluster.cluster_api_url,
allow_deletion=True,
configuration=topic_config)
user_pw = config.get("userPw")
if user_pw is None:
user_pw = "password"
mechanism = config.get("mechanism")
if mechanism is None:
mechanism = "scram-sha-256"
test_user = redpanda.User("testUser",
password=user_pw,
mechanism=mechanism,
cluster_api_url=test_cluster.cluster_api_url)
test_acl = redpanda.Acl("testAcl",
resource_type="CLUSTER",
resource_name_="kafka-cluster",
resource_pattern_type="LITERAL",
principal=test_user.name.apply(lambda name: f"User:{name}"),
host="*",
operation="ALTER",
permission_type="ALLOW",
cluster_api_url=test_cluster.cluster_api_url)
user_name = config.get("userName")
if user_name is None:
user_name = "data-test-username"
topic_name = config.get("topicName")
if topic_name is None:
topic_name = "data-test-topic"
package main
import (
"fmt"
"github.com/pulumi/pulumi-terraform-provider/sdks/go/redpanda/redpanda"
"github.com/pulumi/pulumi/sdk/v3/go/pulumi"
"github.com/pulumi/pulumi/sdk/v3/go/pulumi/config"
)
func main() {
pulumi.Run(func(ctx *pulumi.Context) error {
cfg := config.New(ctx, "")
clusterId := ""
if param := cfg.Get("clusterId"); param != "" {
clusterId = param
}
testCluster, err := redpanda.LookupCluster(ctx, &redpanda.LookupClusterArgs{
Id: clusterId,
}, nil)
if err != nil {
return err
}
topicConfig := map[string]interface{}{
"cleanup.policy": "compact",
"flush.ms": 100,
"compression.type": "snappy",
}
if param := cfg.GetObject("topicConfig"); param != nil {
topicConfig = param
}
partitionCount := float64(3)
if param := cfg.GetFloat64("partitionCount"); param != 0 {
partitionCount = param
}
replicationFactor := float64(3)
if param := cfg.GetFloat64("replicationFactor"); param != 0 {
replicationFactor = param
}
_, err = redpanda.NewTopic(ctx, "testTopic", &redpanda.TopicArgs{
PartitionCount: pulumi.Float64(partitionCount),
ReplicationFactor: pulumi.Float64(replicationFactor),
ClusterApiUrl: pulumi.String(testCluster.ClusterApiUrl),
AllowDeletion: pulumi.Bool(true),
Configuration: pulumi.Any(topicConfig),
})
if err != nil {
return err
}
userPw := "password"
if param := cfg.Get("userPw"); param != "" {
userPw = param
}
mechanism := "scram-sha-256"
if param := cfg.Get("mechanism"); param != "" {
mechanism = param
}
testUser, err := redpanda.NewUser(ctx, "testUser", &redpanda.UserArgs{
Password: pulumi.String(userPw),
Mechanism: pulumi.String(mechanism),
ClusterApiUrl: pulumi.String(testCluster.ClusterApiUrl),
})
if err != nil {
return err
}
_, err = redpanda.NewAcl(ctx, "testAcl", &redpanda.AclArgs{
ResourceType: pulumi.String("CLUSTER"),
ResourceName: pulumi.String("kafka-cluster"),
ResourcePatternType: pulumi.String("LITERAL"),
Principal: testUser.Name.ApplyT(func(name string) (string, error) {
return fmt.Sprintf("User:%v", name), nil
}).(pulumi.StringOutput),
Host: pulumi.String("*"),
Operation: pulumi.String("ALTER"),
PermissionType: pulumi.String("ALLOW"),
ClusterApiUrl: pulumi.String(testCluster.ClusterApiUrl),
})
if err != nil {
return err
}
userName := "data-test-username"
if param := cfg.Get("userName"); param != "" {
userName = param
}
topicName := "data-test-topic"
if param := cfg.Get("topicName"); param != "" {
topicName = param
}
return nil
})
}
using System.Collections.Generic;
using System.Linq;
using Pulumi;
using Redpanda = Pulumi.Redpanda;
return await Deployment.RunAsync(() =>
{
var config = new Config();
var clusterId = config.Get("clusterId") ?? "";
var testCluster = Redpanda.GetCluster.Invoke(new()
{
Id = clusterId,
});
var topicConfig = config.GetObject<dynamic>("topicConfig") ??
{
{ "cleanup.policy", "compact" },
{ "flush.ms", 100 },
{ "compression.type", "snappy" },
};
var partitionCount = config.GetDouble("partitionCount") ?? 3;
var replicationFactor = config.GetDouble("replicationFactor") ?? 3;
var testTopic = new Redpanda.Topic("testTopic", new()
{
PartitionCount = partitionCount,
ReplicationFactor = replicationFactor,
ClusterApiUrl = testCluster.Apply(getClusterResult => getClusterResult.ClusterApiUrl),
AllowDeletion = true,
Configuration = topicConfig,
});
var userPw = config.Get("userPw") ?? "password";
var mechanism = config.Get("mechanism") ?? "scram-sha-256";
var testUser = new Redpanda.User("testUser", new()
{
Password = userPw,
Mechanism = mechanism,
ClusterApiUrl = testCluster.Apply(getClusterResult => getClusterResult.ClusterApiUrl),
});
var testAcl = new Redpanda.Acl("testAcl", new()
{
ResourceType = "CLUSTER",
ResourceName = "kafka-cluster",
ResourcePatternType = "LITERAL",
Principal = testUser.Name.Apply(name => $"User:{name}"),
Host = "*",
Operation = "ALTER",
PermissionType = "ALLOW",
ClusterApiUrl = testCluster.Apply(getClusterResult => getClusterResult.ClusterApiUrl),
});
var userName = config.Get("userName") ?? "data-test-username";
var topicName = config.Get("topicName") ?? "data-test-topic";
});
package generated_program;
import com.pulumi.Context;
import com.pulumi.Pulumi;
import com.pulumi.core.Output;
import com.pulumi.redpanda.RedpandaFunctions;
import com.pulumi.redpanda.inputs.GetClusterArgs;
import com.pulumi.redpanda.Topic;
import com.pulumi.redpanda.TopicArgs;
import com.pulumi.redpanda.User;
import com.pulumi.redpanda.UserArgs;
import com.pulumi.redpanda.Acl;
import com.pulumi.redpanda.AclArgs;
import java.util.List;
import java.util.ArrayList;
import java.util.Map;
import java.io.File;
import java.nio.file.Files;
import java.nio.file.Paths;
public class App {
public static void main(String[] args) {
Pulumi.run(App::stack);
}
public static void stack(Context ctx) {
final var config = ctx.config();
final var clusterId = config.get("clusterId").orElse("");
final var testCluster = RedpandaFunctions.getCluster(GetClusterArgs.builder()
.id(clusterId)
.build());
final var topicConfig = config.get("topicConfig").orElse(%!v(PANIC=Format method: runtime error: invalid memory address or nil pointer dereference));
final var partitionCount = config.get("partitionCount").orElse(3);
final var replicationFactor = config.get("replicationFactor").orElse(3);
var testTopic = new Topic("testTopic", TopicArgs.builder()
.partitionCount(partitionCount)
.replicationFactor(replicationFactor)
.clusterApiUrl(testCluster.applyValue(getClusterResult -> getClusterResult.clusterApiUrl()))
.allowDeletion(true)
.configuration(topicConfig)
.build());
final var userPw = config.get("userPw").orElse("password");
final var mechanism = config.get("mechanism").orElse("scram-sha-256");
var testUser = new User("testUser", UserArgs.builder()
.password(userPw)
.mechanism(mechanism)
.clusterApiUrl(testCluster.applyValue(getClusterResult -> getClusterResult.clusterApiUrl()))
.build());
var testAcl = new Acl("testAcl", AclArgs.builder()
.resourceType("CLUSTER")
.resourceName("kafka-cluster")
.resourcePatternType("LITERAL")
.principal(testUser.name().applyValue(name -> String.format("User:%s", name)))
.host("*")
.operation("ALTER")
.permissionType("ALLOW")
.clusterApiUrl(testCluster.applyValue(getClusterResult -> getClusterResult.clusterApiUrl()))
.build());
final var userName = config.get("userName").orElse("data-test-username");
final var topicName = config.get("topicName").orElse("data-test-topic");
}
}
configuration:
clusterId:
type: string
default: ""
topicConfig:
type: dynamic
default:
cleanup.policy: compact
flush.ms: 100
compression.type: snappy
userName:
type: string
default: data-test-username
userPw:
type: string
default: password
mechanism:
type: string
default: scram-sha-256
topicName:
type: string
default: data-test-topic
partitionCount:
type: number
default: 3
replicationFactor:
type: number
default: 3
resources:
testTopic:
type: redpanda:Topic
properties:
partitionCount: ${partitionCount}
replicationFactor: ${replicationFactor}
clusterApiUrl: ${testCluster.clusterApiUrl}
allowDeletion: true
configuration: ${topicConfig}
testUser:
type: redpanda:User
properties:
password: ${userPw}
mechanism: ${mechanism}
clusterApiUrl: ${testCluster.clusterApiUrl}
testAcl:
type: redpanda:Acl
properties:
resourceType: CLUSTER
resourceName: kafka-cluster
resourcePatternType: LITERAL
principal: User:${testUser.name}
host: '*'
operation: ALTER
permissionType: ALLOW
clusterApiUrl: ${testCluster.clusterApiUrl}
variables:
testCluster:
fn::invoke:
function: redpanda:getCluster
arguments:
id: ${clusterId}
Limitations
Can only be used with Redpanda Cloud Dedicated and BYOC clusters.
Using getCluster
Two invocation forms are available. The direct form accepts plain arguments and either blocks until the result value is available, or returns a Promise-wrapped result. The output form accepts Input-wrapped arguments and returns an Output-wrapped result.
function getCluster(args: GetClusterArgs, opts?: InvokeOptions): Promise<GetClusterResult>
function getClusterOutput(args: GetClusterOutputArgs, opts?: InvokeOptions): Output<GetClusterResult>
def get_cluster(id: Optional[str] = None,
opts: Optional[InvokeOptions] = None) -> GetClusterResult
def get_cluster_output(id: Optional[pulumi.Input[str]] = None,
opts: Optional[InvokeOptions] = None) -> Output[GetClusterResult]
func LookupCluster(ctx *Context, args *LookupClusterArgs, opts ...InvokeOption) (*LookupClusterResult, error)
func LookupClusterOutput(ctx *Context, args *LookupClusterOutputArgs, opts ...InvokeOption) LookupClusterResultOutput
> Note: This function is named LookupCluster
in the Go SDK.
public static class GetCluster
{
public static Task<GetClusterResult> InvokeAsync(GetClusterArgs args, InvokeOptions? opts = null)
public static Output<GetClusterResult> Invoke(GetClusterInvokeArgs args, InvokeOptions? opts = null)
}
public static CompletableFuture<GetClusterResult> getCluster(GetClusterArgs args, InvokeOptions options)
public static Output<GetClusterResult> getCluster(GetClusterArgs args, InvokeOptions options)
fn::invoke:
function: redpanda:index/getCluster:getCluster
arguments:
# arguments dictionary
The following arguments are supported:
- Id string
- ID of the cluster. ID is an output from the Create Cluster endpoint and cannot be set by the caller.
- Id string
- ID of the cluster. ID is an output from the Create Cluster endpoint and cannot be set by the caller.
- id String
- ID of the cluster. ID is an output from the Create Cluster endpoint and cannot be set by the caller.
- id string
- ID of the cluster. ID is an output from the Create Cluster endpoint and cannot be set by the caller.
- id str
- ID of the cluster. ID is an output from the Create Cluster endpoint and cannot be set by the caller.
- id String
- ID of the cluster. ID is an output from the Create Cluster endpoint and cannot be set by the caller.
getCluster Result
The following output properties are available:
- 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 List<string> - The ARN of the principals that can access the Redpanda AWS PrivateLink Endpoint Service.
- Connect
Console bool - Whether Console is connected via PrivateLink.
- Enabled bool
- Whether AWS PrivateLink is enabled.
- Status
Get
Cluster Aws Private Link Status - Current status of the PrivateLink configuration.
- Allowed
Principals []string - The ARN of the principals that can access the Redpanda AWS PrivateLink Endpoint Service.
- Connect
Console bool - Whether Console is connected via PrivateLink.
- Enabled bool
- Whether AWS PrivateLink is enabled.
- Status
Get
Cluster Aws Private Link Status - Current status of the PrivateLink configuration.
- allowed
Principals List<String> - The ARN of the principals that can access the Redpanda AWS PrivateLink Endpoint Service.
- connect
Console Boolean - Whether Console is connected via PrivateLink.
- enabled Boolean
- Whether AWS PrivateLink is enabled.
- status
Get
Cluster Aws Private Link Status - Current status of the PrivateLink configuration.
- allowed
Principals string[] - The ARN of the principals that can access the Redpanda AWS PrivateLink Endpoint Service.
- connect
Console boolean - Whether Console is connected via PrivateLink.
- enabled boolean
- Whether AWS PrivateLink is enabled.
- status
Get
Cluster Aws Private Link Status - Current status of the PrivateLink configuration.
- allowed_
principals Sequence[str] - The ARN of the principals that can access the Redpanda AWS PrivateLink Endpoint Service.
- connect_
console bool - Whether Console is connected via PrivateLink.
- enabled bool
- Whether AWS PrivateLink is enabled.
- status
Get
Cluster Aws Private Link Status - Current status of the PrivateLink configuration.
- allowed
Principals List<String> - The ARN of the principals that can access the Redpanda AWS PrivateLink Endpoint Service.
- connect
Console Boolean - Whether Console is connected via PrivateLink.
- enabled Boolean
- Whether AWS PrivateLink is enabled.
- status Property Map
- Current status of the PrivateLink configuration.
GetClusterAwsPrivateLinkStatus
- Console
Port double - Port for Redpanda Console.
- Created
At string - When the PrivateLink service was created.
- Deleted
At string - When the PrivateLink service was deleted.
- Kafka
Api doubleNode Base Port - Base port for Kafka API nodes.
- Kafka
Api doubleSeed Port - Port for Kafka API seed brokers.
- Redpanda
Proxy doubleNode Base Port - Base port for HTTP proxy nodes.
- Redpanda
Proxy doubleSeed Port - Port for HTTP proxy.
- Schema
Registry doubleSeed Port - Port for Schema Registry.
- Service
Id string - The PrivateLink service ID.
- Service
Name string - The PrivateLink service name.
- Service
State string - Current state of the PrivateLink service.
- Vpc
Endpoint List<GetConnections Cluster Aws Private Link Status Vpc Endpoint Connection> - List of VPC endpoint connections.
- Console
Port float64 - Port for Redpanda Console.
- Created
At string - When the PrivateLink service was created.
- Deleted
At string - When the PrivateLink service was deleted.
- Kafka
Api float64Node Base Port - Base port for Kafka API nodes.
- Kafka
Api float64Seed Port - Port for Kafka API seed brokers.
- Redpanda
Proxy float64Node Base Port - Base port for HTTP proxy nodes.
- Redpanda
Proxy float64Seed Port - Port for HTTP proxy.
- Schema
Registry float64Seed Port - Port for Schema Registry.
- Service
Id string - The PrivateLink service ID.
- Service
Name string - The PrivateLink service name.
- Service
State string - Current state of the PrivateLink service.
- Vpc
Endpoint []GetConnections Cluster Aws Private Link Status Vpc Endpoint Connection - List of VPC endpoint connections.
- console
Port Double - Port for Redpanda Console.
- created
At String - When the PrivateLink service was created.
- deleted
At String - When the PrivateLink service was deleted.
- kafka
Api DoubleNode Base Port - Base port for Kafka API nodes.
- kafka
Api DoubleSeed Port - Port for Kafka API seed brokers.
- redpanda
Proxy DoubleNode Base Port - Base port for HTTP proxy nodes.
- redpanda
Proxy DoubleSeed Port - Port for HTTP proxy.
- schema
Registry DoubleSeed Port - Port for Schema Registry.
- service
Id String - The PrivateLink service ID.
- service
Name String - The PrivateLink service name.
- service
State String - Current state of the PrivateLink service.
- vpc
Endpoint List<GetConnections Cluster Aws Private Link Status Vpc Endpoint Connection> - List of VPC endpoint connections.
- console
Port number - Port for Redpanda Console.
- created
At string - When the PrivateLink service was created.
- deleted
At string - When the PrivateLink service was deleted.
- kafka
Api numberNode Base Port - Base port for Kafka API nodes.
- kafka
Api numberSeed Port - Port for Kafka API seed brokers.
- redpanda
Proxy numberNode Base Port - Base port for HTTP proxy nodes.
- redpanda
Proxy numberSeed Port - Port for HTTP proxy.
- schema
Registry numberSeed Port - Port for Schema Registry.
- service
Id string - The PrivateLink service ID.
- service
Name string - The PrivateLink service name.
- service
State string - Current state of the PrivateLink service.
- vpc
Endpoint GetConnections Cluster Aws Private Link Status Vpc Endpoint Connection[] - List of VPC endpoint connections.
- console_
port float - Port for Redpanda Console.
- created_
at str - When the PrivateLink service was created.
- deleted_
at str - When the PrivateLink service was deleted.
- kafka_
api_ floatnode_ base_ port - Base port for Kafka API nodes.
- kafka_
api_ floatseed_ port - Port for Kafka API seed brokers.
- redpanda_
proxy_ floatnode_ base_ port - Base port for HTTP proxy nodes.
- redpanda_
proxy_ floatseed_ port - Port for HTTP proxy.
- schema_
registry_ floatseed_ port - Port for Schema Registry.
- service_
id str - The PrivateLink service ID.
- service_
name str - The PrivateLink service name.
- service_
state str - Current state of the PrivateLink service.
- vpc_
endpoint_ Sequence[Getconnections Cluster Aws Private Link Status Vpc Endpoint Connection] - List of VPC endpoint connections.
- console
Port Number - Port for Redpanda Console.
- created
At String - When the PrivateLink service was created.
- deleted
At String - When the PrivateLink service was deleted.
- kafka
Api NumberNode Base Port - Base port for Kafka API nodes.
- kafka
Api NumberSeed Port - Port for Kafka API seed brokers.
- redpanda
Proxy NumberNode Base Port - Base port for HTTP proxy nodes.
- redpanda
Proxy NumberSeed Port - Port for HTTP proxy.
- schema
Registry NumberSeed Port - Port for Schema Registry.
- service
Id String - The PrivateLink service ID.
- service
Name String - The PrivateLink service name.
- service
State String - Current state of the PrivateLink service.
- vpc
Endpoint List<Property Map>Connections - List of VPC endpoint connections.
GetClusterAwsPrivateLinkStatusVpcEndpointConnection
- Connection
Id string - The connection ID.
- Created
At string - When the endpoint connection was created.
- Dns
Entries List<GetCluster Aws Private Link Status Vpc Endpoint Connection Dns Entry> - DNS entries for the endpoint.
- Id string
- The endpoint connection ID.
- Load
Balancer List<string>Arns - ARNs of associated load balancers.
- Owner string
- Owner of the endpoint connection.
- State string
- State of the endpoint connection.
- Connection
Id string - The connection ID.
- Created
At string - When the endpoint connection was created.
- Dns
Entries []GetCluster Aws Private Link Status Vpc Endpoint Connection Dns Entry - DNS entries for the endpoint.
- Id string
- The endpoint connection ID.
- Load
Balancer []stringArns - ARNs of associated load balancers.
- Owner string
- Owner of the endpoint connection.
- State string
- State of the endpoint connection.
- connection
Id String - The connection ID.
- created
At String - When the endpoint connection was created.
- dns
Entries List<GetCluster Aws Private Link Status Vpc Endpoint Connection Dns Entry> - DNS entries for the endpoint.
- id String
- The endpoint connection ID.
- load
Balancer List<String>Arns - ARNs of associated load balancers.
- owner String
- Owner of the endpoint connection.
- state String
- State of the endpoint connection.
- connection
Id string - The connection ID.
- created
At string - When the endpoint connection was created.
- dns
Entries GetCluster Aws Private Link Status Vpc Endpoint Connection Dns Entry[] - DNS entries for the endpoint.
- id string
- The endpoint connection ID.
- load
Balancer string[]Arns - ARNs of associated load balancers.
- owner string
- Owner of the endpoint connection.
- state string
- State of the endpoint connection.
- connection_
id str - The connection ID.
- created_
at str - When the endpoint connection was created.
- dns_
entries Sequence[GetCluster Aws Private Link Status Vpc Endpoint Connection Dns Entry] - DNS entries for the endpoint.
- id str
- The endpoint connection ID.
- load_
balancer_ Sequence[str]arns - ARNs of associated load balancers.
- owner str
- Owner of the endpoint connection.
- state str
- State of the endpoint connection.
- connection
Id String - The connection ID.
- created
At String - When the endpoint connection was created.
- dns
Entries List<Property Map> - DNS entries for the endpoint.
- id String
- The endpoint connection ID.
- load
Balancer List<String>Arns - ARNs of associated load balancers.
- owner String
- Owner of the endpoint connection.
- state String
- State of the endpoint connection.
GetClusterAwsPrivateLinkStatusVpcEndpointConnectionDnsEntry
- Dns
Name string - The DNS name.
- Hosted
Zone stringId - The hosted zone ID.
- Dns
Name string - The DNS name.
- Hosted
Zone stringId - The hosted zone ID.
- dns
Name String - The DNS name.
- hosted
Zone StringId - The hosted zone ID.
- dns
Name string - The DNS name.
- hosted
Zone stringId - The hosted zone ID.
- dns_
name str - The DNS name.
- hosted_
zone_ strid - The hosted zone ID.
- dns
Name String - The DNS name.
- hosted
Zone StringId - The hosted zone ID.
GetClusterAzurePrivateLink
- Allowed
Subscriptions List<string> - The subscriptions that can access the Redpanda Azure PrivateLink Endpoint Service.
- Connect
Console bool - Whether Console is connected in Redpanda Azure Private Link Service.
- Enabled bool
- Whether Redpanda Azure Private Link Endpoint Service is enabled.
- Status
Get
Cluster Azure Private Link Status - Current status of the Private Link configuration.
- Allowed
Subscriptions []string - The subscriptions that can access the Redpanda Azure PrivateLink Endpoint Service.
- Connect
Console bool - Whether Console is connected in Redpanda Azure Private Link Service.
- Enabled bool
- Whether Redpanda Azure Private Link Endpoint Service is enabled.
- Status
Get
Cluster Azure Private Link Status - Current status of the Private Link configuration.
- allowed
Subscriptions List<String> - The subscriptions that can access the Redpanda Azure PrivateLink Endpoint Service.
- connect
Console Boolean - Whether Console is connected in Redpanda Azure Private Link Service.
- enabled Boolean
- Whether Redpanda Azure Private Link Endpoint Service is enabled.
- status
Get
Cluster Azure Private Link Status - Current status of the Private Link configuration.
- allowed
Subscriptions string[] - The subscriptions that can access the Redpanda Azure PrivateLink Endpoint Service.
- connect
Console boolean - Whether Console is connected in Redpanda Azure Private Link Service.
- enabled boolean
- Whether Redpanda Azure Private Link Endpoint Service is enabled.
- status
Get
Cluster Azure Private Link Status - Current status of the Private Link configuration.
- allowed_
subscriptions Sequence[str] - The subscriptions that can access the Redpanda Azure PrivateLink Endpoint Service.
- connect_
console bool - Whether Console is connected in Redpanda Azure Private Link Service.
- enabled bool
- Whether Redpanda Azure Private Link Endpoint Service is enabled.
- status
Get
Cluster Azure Private Link Status - Current status of the Private Link configuration.
- allowed
Subscriptions List<String> - The subscriptions that can access the Redpanda Azure PrivateLink Endpoint Service.
- connect
Console Boolean - Whether Console is connected in Redpanda Azure Private Link Service.
- enabled Boolean
- Whether Redpanda Azure Private Link Endpoint Service is enabled.
- status Property Map
- Current status of the Private Link configuration.
GetClusterAzurePrivateLinkStatus
- Approved
Subscriptions List<string> - List of approved Azure subscription IDs.
- Console
Port double - Port for Redpanda Console.
- Created
At string - When the Private Link service was created.
- Deleted
At string - When the Private Link service was deleted.
- Dns
ARecord string - DNS A record for the service.
- Kafka
Api doubleNode Base Port - Base port for Kafka API nodes.
- Kafka
Api doubleSeed Port - Port for Kafka API seed brokers.
- Private
Endpoint List<GetConnections Cluster Azure Private Link Status Private Endpoint Connection> - List of private endpoint connections.
- Redpanda
Proxy doubleNode Base Port - Base port for HTTP proxy nodes.
- Redpanda
Proxy doubleSeed Port - Port for HTTP proxy.
- Schema
Registry doubleSeed Port - Port for Schema Registry.
- Service
Id string - The Private Link service ID.
- Service
Name string - The Private Link service name.
- Approved
Subscriptions []string - List of approved Azure subscription IDs.
- Console
Port float64 - Port for Redpanda Console.
- Created
At string - When the Private Link service was created.
- Deleted
At string - When the Private Link service was deleted.
- Dns
ARecord string - DNS A record for the service.
- Kafka
Api float64Node Base Port - Base port for Kafka API nodes.
- Kafka
Api float64Seed Port - Port for Kafka API seed brokers.
- Private
Endpoint []GetConnections Cluster Azure Private Link Status Private Endpoint Connection - List of private endpoint connections.
- Redpanda
Proxy float64Node Base Port - Base port for HTTP proxy nodes.
- Redpanda
Proxy float64Seed Port - Port for HTTP proxy.
- Schema
Registry float64Seed Port - Port for Schema Registry.
- Service
Id string - The Private Link service ID.
- Service
Name string - The Private Link service name.
- approved
Subscriptions List<String> - List of approved Azure subscription IDs.
- console
Port Double - Port for Redpanda Console.
- created
At String - When the Private Link service was created.
- deleted
At String - When the Private Link service was deleted.
- dns
ARecord String - DNS A record for the service.
- kafka
Api DoubleNode Base Port - Base port for Kafka API nodes.
- kafka
Api DoubleSeed Port - Port for Kafka API seed brokers.
- private
Endpoint List<GetConnections Cluster Azure Private Link Status Private Endpoint Connection> - List of private endpoint connections.
- redpanda
Proxy DoubleNode Base Port - Base port for HTTP proxy nodes.
- redpanda
Proxy DoubleSeed Port - Port for HTTP proxy.
- schema
Registry DoubleSeed Port - Port for Schema Registry.
- service
Id String - The Private Link service ID.
- service
Name String - The Private Link service name.
- approved
Subscriptions string[] - List of approved Azure subscription IDs.
- console
Port number - Port for Redpanda Console.
- created
At string - When the Private Link service was created.
- deleted
At string - When the Private Link service was deleted.
- dns
ARecord string - DNS A record for the service.
- kafka
Api numberNode Base Port - Base port for Kafka API nodes.
- kafka
Api numberSeed Port - Port for Kafka API seed brokers.
- private
Endpoint GetConnections Cluster Azure Private Link Status Private Endpoint Connection[] - List of private endpoint connections.
- redpanda
Proxy numberNode Base Port - Base port for HTTP proxy nodes.
- redpanda
Proxy numberSeed Port - Port for HTTP proxy.
- schema
Registry numberSeed Port - Port for Schema Registry.
- service
Id string - The Private Link service ID.
- service
Name string - The Private Link service name.
- approved_
subscriptions Sequence[str] - List of approved Azure subscription IDs.
- console_
port float - Port for Redpanda Console.
- created_
at str - When the Private Link service was created.
- deleted_
at str - When the Private Link service was deleted.
- dns_
a_ strrecord - DNS A record for the service.
- kafka_
api_ floatnode_ base_ port - Base port for Kafka API nodes.
- kafka_
api_ floatseed_ port - Port for Kafka API seed brokers.
- private_
endpoint_ Sequence[Getconnections Cluster Azure Private Link Status Private Endpoint Connection] - List of private endpoint connections.
- redpanda_
proxy_ floatnode_ base_ port - Base port for HTTP proxy nodes.
- redpanda_
proxy_ floatseed_ port - Port for HTTP proxy.
- schema_
registry_ floatseed_ port - Port for Schema Registry.
- service_
id str - The Private Link service ID.
- service_
name str - The Private Link service name.
- approved
Subscriptions List<String> - List of approved Azure subscription IDs.
- console
Port Number - Port for Redpanda Console.
- created
At String - When the Private Link service was created.
- deleted
At String - When the Private Link service was deleted.
- dns
ARecord String - DNS A record for the service.
- kafka
Api NumberNode Base Port - Base port for Kafka API nodes.
- kafka
Api NumberSeed Port - Port for Kafka API seed brokers.
- private
Endpoint List<Property Map>Connections - List of private endpoint connections.
- redpanda
Proxy NumberNode Base Port - Base port for HTTP proxy nodes.
- redpanda
Proxy NumberSeed Port - Port for HTTP proxy.
- schema
Registry NumberSeed Port - Port for Schema Registry.
- service
Id String - The Private Link service ID.
- service
Name String - The Private Link service name.
GetClusterAzurePrivateLinkStatusPrivateEndpointConnection
- Connection
Id string - ID of the connection.
- Connection
Name string - Name of the connection.
- Created
At string - When the endpoint connection was created.
- Private
Endpoint stringId - ID of the private endpoint.
- Private
Endpoint stringName - Name of the private endpoint.
- Status string
- Status of the endpoint connection.
- Connection
Id string - ID of the connection.
- Connection
Name string - Name of the connection.
- Created
At string - When the endpoint connection was created.
- Private
Endpoint stringId - ID of the private endpoint.
- Private
Endpoint stringName - Name of the private endpoint.
- Status string
- Status of the endpoint connection.
- connection
Id String - ID of the connection.
- connection
Name String - Name of the connection.
- created
At String - When the endpoint connection was created.
- private
Endpoint StringId - ID of the private endpoint.
- private
Endpoint StringName - Name of the private endpoint.
- status String
- Status of the endpoint connection.
- connection
Id string - ID of the connection.
- connection
Name string - Name of the connection.
- created
At string - When the endpoint connection was created.
- private
Endpoint stringId - ID of the private endpoint.
- private
Endpoint stringName - Name of the private endpoint.
- status string
- Status of the endpoint connection.
- connection_
id str - ID of the connection.
- connection_
name str - Name of the connection.
- created_
at str - When the endpoint connection was created.
- private_
endpoint_ strid - ID of the private endpoint.
- private_
endpoint_ strname - Name of the private endpoint.
- status str
- Status of the endpoint connection.
- connection
Id String - ID of the connection.
- connection
Name String - Name of the connection.
- created
At String - When the endpoint connection was created.
- private
Endpoint StringId - ID of the private endpoint.
- private
Endpoint StringName - Name of the private endpoint.
- status String
- Status of the endpoint connection.
GetClusterConnectivity
- Gcp
Get
Cluster Connectivity Gcp - GCP-specific connectivity settings.
- Gcp
Get
Cluster Connectivity Gcp - GCP-specific connectivity settings.
- gcp
Get
Cluster Connectivity Gcp - GCP-specific connectivity settings.
- gcp
Get
Cluster Connectivity Gcp - GCP-specific connectivity settings.
- gcp
Get
Cluster Connectivity Gcp - GCP-specific connectivity settings.
- gcp Property Map
- GCP-specific connectivity settings.
GetClusterConnectivityGcp
- Enable
Global boolAccess - Whether global access is enabled.
- Enable
Global boolAccess - Whether global access is enabled.
- enable
Global BooleanAccess - Whether global access is enabled.
- enable
Global booleanAccess - Whether global access is enabled.
- enable_
global_ boolaccess - Whether global access is enabled.
- enable
Global BooleanAccess - Whether global access is enabled.
GetClusterCustomerManagedResources
GetClusterCustomerManagedResourcesAws
- Agent
Instance GetProfile Cluster Customer Managed Resources Aws Agent Instance Profile - Cloud
Storage GetBucket Cluster Customer Managed Resources Aws Cloud Storage Bucket - Cluster
Security GetGroup Cluster Customer Managed Resources Aws Cluster Security Group - Connectors
Node GetGroup Instance Profile Cluster Customer Managed Resources Aws Connectors Node Group Instance Profile - Connectors
Security GetGroup Cluster Customer Managed Resources Aws Connectors Security Group - K8s
Cluster GetRole Cluster Customer Managed Resources Aws K8s Cluster Role - Node
Security GetGroup Cluster Customer Managed Resources Aws Node Security Group - Permissions
Boundary GetPolicy Cluster Customer Managed Resources Aws Permissions Boundary Policy - Redpanda
Agent GetSecurity Group Cluster Customer Managed Resources Aws Redpanda Agent Security Group - Redpanda
Node GetGroup Instance Profile Cluster Customer Managed Resources Aws Redpanda Node Group Instance Profile - Redpanda
Node GetGroup Security Group Cluster Customer Managed Resources Aws Redpanda Node Group Security Group - Utility
Node GetGroup Instance Profile Cluster Customer Managed Resources Aws Utility Node Group Instance Profile - Utility
Security GetGroup Cluster Customer Managed Resources Aws Utility Security Group
- Agent
Instance GetProfile Cluster Customer Managed Resources Aws Agent Instance Profile - Cloud
Storage GetBucket Cluster Customer Managed Resources Aws Cloud Storage Bucket - Cluster
Security GetGroup Cluster Customer Managed Resources Aws Cluster Security Group - Connectors
Node GetGroup Instance Profile Cluster Customer Managed Resources Aws Connectors Node Group Instance Profile - Connectors
Security GetGroup Cluster Customer Managed Resources Aws Connectors Security Group - K8s
Cluster GetRole Cluster Customer Managed Resources Aws K8s Cluster Role - Node
Security GetGroup Cluster Customer Managed Resources Aws Node Security Group - Permissions
Boundary GetPolicy Cluster Customer Managed Resources Aws Permissions Boundary Policy - Redpanda
Agent GetSecurity Group Cluster Customer Managed Resources Aws Redpanda Agent Security Group - Redpanda
Node GetGroup Instance Profile Cluster Customer Managed Resources Aws Redpanda Node Group Instance Profile - Redpanda
Node GetGroup Security Group Cluster Customer Managed Resources Aws Redpanda Node Group Security Group - Utility
Node GetGroup Instance Profile Cluster Customer Managed Resources Aws Utility Node Group Instance Profile - Utility
Security GetGroup Cluster Customer Managed Resources Aws Utility Security Group
- agent
Instance GetProfile Cluster Customer Managed Resources Aws Agent Instance Profile - cloud
Storage GetBucket Cluster Customer Managed Resources Aws Cloud Storage Bucket - cluster
Security GetGroup Cluster Customer Managed Resources Aws Cluster Security Group - connectors
Node GetGroup Instance Profile Cluster Customer Managed Resources Aws Connectors Node Group Instance Profile - connectors
Security GetGroup Cluster Customer Managed Resources Aws Connectors Security Group - k8s
Cluster GetRole Cluster Customer Managed Resources Aws K8s Cluster Role - node
Security GetGroup Cluster Customer Managed Resources Aws Node Security Group - permissions
Boundary GetPolicy Cluster Customer Managed Resources Aws Permissions Boundary Policy - redpanda
Agent GetSecurity Group Cluster Customer Managed Resources Aws Redpanda Agent Security Group - redpanda
Node GetGroup Instance Profile Cluster Customer Managed Resources Aws Redpanda Node Group Instance Profile - redpanda
Node GetGroup Security Group Cluster Customer Managed Resources Aws Redpanda Node Group Security Group - utility
Node GetGroup Instance Profile Cluster Customer Managed Resources Aws Utility Node Group Instance Profile - utility
Security GetGroup Cluster Customer Managed Resources Aws Utility Security Group
- agent
Instance GetProfile Cluster Customer Managed Resources Aws Agent Instance Profile - cloud
Storage GetBucket Cluster Customer Managed Resources Aws Cloud Storage Bucket - cluster
Security GetGroup Cluster Customer Managed Resources Aws Cluster Security Group - connectors
Node GetGroup Instance Profile Cluster Customer Managed Resources Aws Connectors Node Group Instance Profile - connectors
Security GetGroup Cluster Customer Managed Resources Aws Connectors Security Group - k8s
Cluster GetRole Cluster Customer Managed Resources Aws K8s Cluster Role - node
Security GetGroup Cluster Customer Managed Resources Aws Node Security Group - permissions
Boundary GetPolicy Cluster Customer Managed Resources Aws Permissions Boundary Policy - redpanda
Agent GetSecurity Group Cluster Customer Managed Resources Aws Redpanda Agent Security Group - redpanda
Node GetGroup Instance Profile Cluster Customer Managed Resources Aws Redpanda Node Group Instance Profile - redpanda
Node GetGroup Security Group Cluster Customer Managed Resources Aws Redpanda Node Group Security Group - utility
Node GetGroup Instance Profile Cluster Customer Managed Resources Aws Utility Node Group Instance Profile - utility
Security GetGroup Cluster Customer Managed Resources Aws Utility Security Group
- agent_
instance_ Getprofile Cluster Customer Managed Resources Aws Agent Instance Profile - cloud_
storage_ Getbucket Cluster Customer Managed Resources Aws Cloud Storage Bucket - cluster_
security_ Getgroup Cluster Customer Managed Resources Aws Cluster Security Group - connectors_
node_ Getgroup_ instance_ profile Cluster Customer Managed Resources Aws Connectors Node Group Instance Profile - connectors_
security_ Getgroup Cluster Customer Managed Resources Aws Connectors Security Group - k8s_
cluster_ Getrole Cluster Customer Managed Resources Aws K8s Cluster Role - node_
security_ Getgroup Cluster Customer Managed Resources Aws Node Security Group - permissions_
boundary_ Getpolicy Cluster Customer Managed Resources Aws Permissions Boundary Policy - redpanda_
agent_ Getsecurity_ group Cluster Customer Managed Resources Aws Redpanda Agent Security Group - redpanda_
node_ Getgroup_ instance_ profile Cluster Customer Managed Resources Aws Redpanda Node Group Instance Profile - redpanda_
node_ Getgroup_ security_ group Cluster Customer Managed Resources Aws Redpanda Node Group Security Group - utility_
node_ Getgroup_ instance_ profile Cluster Customer Managed Resources Aws Utility Node Group Instance Profile - utility_
security_ Getgroup Cluster Customer Managed Resources Aws Utility Security Group
- agent
Instance Property MapProfile - cloud
Storage Property MapBucket - cluster
Security Property MapGroup - connectors
Node Property MapGroup Instance Profile - connectors
Security Property MapGroup - k8s
Cluster Property MapRole - node
Security Property MapGroup - permissions
Boundary Property MapPolicy - redpanda
Agent Property MapSecurity Group - redpanda
Node Property MapGroup Instance Profile - redpanda
Node Property MapGroup Security Group - utility
Node Property MapGroup Instance Profile - utility
Security Property MapGroup
GetClusterCustomerManagedResourcesAwsAgentInstanceProfile
- Arn string
- ARN for the agent instance profile
- Arn string
- ARN for the agent instance profile
- arn String
- ARN for the agent instance profile
- arn string
- ARN for the agent instance profile
- arn str
- ARN for the agent instance profile
- arn String
- ARN for the agent instance profile
GetClusterCustomerManagedResourcesAwsCloudStorageBucket
- Arn string
- ARN for the cloud storage bucket
- Arn string
- ARN for the cloud storage bucket
- arn String
- ARN for the cloud storage bucket
- arn string
- ARN for the cloud storage bucket
- arn str
- ARN for the cloud storage bucket
- arn String
- ARN for the cloud storage bucket
GetClusterCustomerManagedResourcesAwsClusterSecurityGroup
- Arn string
- ARN for the cluster security group
- Arn string
- ARN for the cluster security group
- arn String
- ARN for the cluster security group
- arn string
- ARN for the cluster security group
- arn str
- ARN for the cluster security group
- arn String
- ARN for the cluster security group
GetClusterCustomerManagedResourcesAwsConnectorsNodeGroupInstanceProfile
- Arn string
- ARN for the connectors node group instance profile
- Arn string
- ARN for the connectors node group instance profile
- arn String
- ARN for the connectors node group instance profile
- arn string
- ARN for the connectors node group instance profile
- arn str
- ARN for the connectors node group instance profile
- arn String
- ARN for the connectors node group instance profile
GetClusterCustomerManagedResourcesAwsConnectorsSecurityGroup
- Arn string
- ARN for the connectors security group
- Arn string
- ARN for the connectors security group
- arn String
- ARN for the connectors security group
- arn string
- ARN for the connectors security group
- arn str
- ARN for the connectors security group
- arn String
- ARN for the connectors security group
GetClusterCustomerManagedResourcesAwsK8sClusterRole
- Arn string
- ARN for the Kubernetes cluster role
- Arn string
- ARN for the Kubernetes cluster role
- arn String
- ARN for the Kubernetes cluster role
- arn string
- ARN for the Kubernetes cluster role
- arn str
- ARN for the Kubernetes cluster role
- arn String
- ARN for the Kubernetes cluster role
GetClusterCustomerManagedResourcesAwsNodeSecurityGroup
- Arn string
- ARN for the node security group
- Arn string
- ARN for the node security group
- arn String
- ARN for the node security group
- arn string
- ARN for the node security group
- arn str
- ARN for the node security group
- arn String
- ARN for the node security group
GetClusterCustomerManagedResourcesAwsPermissionsBoundaryPolicy
- Arn string
- ARN for the permissions boundary policy
- Arn string
- ARN for the permissions boundary policy
- arn String
- ARN for the permissions boundary policy
- arn string
- ARN for the permissions boundary policy
- arn str
- ARN for the permissions boundary policy
- arn String
- ARN for the permissions boundary policy
GetClusterCustomerManagedResourcesAwsRedpandaAgentSecurityGroup
- Arn string
- ARN for the redpanda agent security group
- Arn string
- ARN for the redpanda agent security group
- arn String
- ARN for the redpanda agent security group
- arn string
- ARN for the redpanda agent security group
- arn str
- ARN for the redpanda agent security group
- arn String
- ARN for the redpanda agent security group
GetClusterCustomerManagedResourcesAwsRedpandaNodeGroupInstanceProfile
- Arn string
- ARN for the redpanda node group instance profile
- Arn string
- ARN for the redpanda node group instance profile
- arn String
- ARN for the redpanda node group instance profile
- arn string
- ARN for the redpanda node group instance profile
- arn str
- ARN for the redpanda node group instance profile
- arn String
- ARN for the redpanda node group instance profile
GetClusterCustomerManagedResourcesAwsRedpandaNodeGroupSecurityGroup
- Arn string
- ARN for the redpanda node group security group
- Arn string
- ARN for the redpanda node group security group
- arn String
- ARN for the redpanda node group security group
- arn string
- ARN for the redpanda node group security group
- arn str
- ARN for the redpanda node group security group
- arn String
- ARN for the redpanda node group security group
GetClusterCustomerManagedResourcesAwsUtilityNodeGroupInstanceProfile
- Arn string
- ARN for the utility node group instance profile
- Arn string
- ARN for the utility node group instance profile
- arn String
- ARN for the utility node group instance profile
- arn string
- ARN for the utility node group instance profile
- arn str
- ARN for the utility node group instance profile
- arn String
- ARN for the utility node group instance profile
GetClusterCustomerManagedResourcesAwsUtilitySecurityGroup
- Arn string
- ARN for the utility security group
- Arn string
- ARN for the utility security group
- arn String
- ARN for the utility security group
- arn string
- ARN for the utility security group
- arn str
- ARN for the utility security group
- arn String
- ARN for the utility security group
GetClusterGcpPrivateServiceConnect
- Consumer
Accept List<GetLists Cluster Gcp Private Service Connect Consumer Accept List> - List of consumers that are allowed to connect to Redpanda GCP PSC service attachment.
- Enabled bool
- Whether Redpanda GCP Private Service Connect is enabled.
- Global
Access boolEnabled - Whether global access is enabled.
- Status
Get
Cluster Gcp Private Service Connect Status - Current status of the Private Service Connect configuration.
- Consumer
Accept []GetLists Cluster Gcp Private Service Connect Consumer Accept List - List of consumers that are allowed to connect to Redpanda GCP PSC service attachment.
- Enabled bool
- Whether Redpanda GCP Private Service Connect is enabled.
- Global
Access boolEnabled - Whether global access is enabled.
- Status
Get
Cluster Gcp Private Service Connect Status - Current status of the Private Service Connect configuration.
- consumer
Accept List<GetLists Cluster Gcp Private Service Connect Consumer Accept List> - List of consumers that are allowed to connect to Redpanda GCP PSC service attachment.
- enabled Boolean
- Whether Redpanda GCP Private Service Connect is enabled.
- global
Access BooleanEnabled - Whether global access is enabled.
- status
Get
Cluster Gcp Private Service Connect Status - Current status of the Private Service Connect configuration.
- consumer
Accept GetLists Cluster Gcp Private Service Connect Consumer Accept List[] - List of consumers that are allowed to connect to Redpanda GCP PSC service attachment.
- enabled boolean
- Whether Redpanda GCP Private Service Connect is enabled.
- global
Access booleanEnabled - Whether global access is enabled.
- status
Get
Cluster Gcp Private Service Connect Status - Current status of the Private Service Connect configuration.
- consumer_
accept_ Sequence[Getlists Cluster Gcp Private Service Connect Consumer Accept List] - List of consumers that are allowed to connect to Redpanda GCP PSC service attachment.
- enabled bool
- Whether Redpanda GCP Private Service Connect is enabled.
- global_
access_ boolenabled - Whether global access is enabled.
- status
Get
Cluster Gcp Private Service Connect Status - Current status of the Private Service Connect configuration.
- consumer
Accept List<Property Map>Lists - List of consumers that are allowed to connect to Redpanda GCP PSC service attachment.
- enabled Boolean
- Whether Redpanda GCP Private Service Connect is enabled.
- global
Access BooleanEnabled - Whether global access is enabled.
- status Property Map
- Current status of the Private Service Connect configuration.
GetClusterGcpPrivateServiceConnectConsumerAcceptList
- Source string
- Either the GCP project number or its alphanumeric ID.
- Source string
- Either the GCP project number or its alphanumeric ID.
- source String
- Either the GCP project number or its alphanumeric ID.
- source string
- Either the GCP project number or its alphanumeric ID.
- source str
- Either the GCP project number or its alphanumeric ID.
- source String
- Either the GCP project number or its alphanumeric ID.
GetClusterGcpPrivateServiceConnectStatus
- Connected
Endpoints List<GetCluster Gcp Private Service Connect Status Connected Endpoint> - List of connected endpoints.
- Created
At string - When the Private Service Connect service was created.
- Deleted
At string - When the Private Service Connect service was deleted.
- Dns
ARecords List<string> - DNS A records for the service.
- Kafka
Api doubleNode Base Port - Base port for Kafka API nodes.
- Kafka
Api doubleSeed Port - Port for Kafka API seed brokers.
- Redpanda
Proxy doubleNode Base Port - Base port for HTTP proxy nodes.
- Redpanda
Proxy doubleSeed Port - Port for HTTP proxy.
- Schema
Registry doubleSeed Port - Port for Schema Registry.
- Seed
Hostname string - Hostname for the seed brokers.
- Service
Attachment string - The service attachment identifier.
- Connected
Endpoints []GetCluster Gcp Private Service Connect Status Connected Endpoint - List of connected endpoints.
- Created
At string - When the Private Service Connect service was created.
- Deleted
At string - When the Private Service Connect service was deleted.
- Dns
ARecords []string - DNS A records for the service.
- Kafka
Api float64Node Base Port - Base port for Kafka API nodes.
- Kafka
Api float64Seed Port - Port for Kafka API seed brokers.
- Redpanda
Proxy float64Node Base Port - Base port for HTTP proxy nodes.
- Redpanda
Proxy float64Seed Port - Port for HTTP proxy.
- Schema
Registry float64Seed Port - Port for Schema Registry.
- Seed
Hostname string - Hostname for the seed brokers.
- Service
Attachment string - The service attachment identifier.
- connected
Endpoints List<GetCluster Gcp Private Service Connect Status Connected Endpoint> - List of connected endpoints.
- created
At String - When the Private Service Connect service was created.
- deleted
At String - When the Private Service Connect service was deleted.
- dns
ARecords List<String> - DNS A records for the service.
- kafka
Api DoubleNode Base Port - Base port for Kafka API nodes.
- kafka
Api DoubleSeed Port - Port for Kafka API seed brokers.
- redpanda
Proxy DoubleNode Base Port - Base port for HTTP proxy nodes.
- redpanda
Proxy DoubleSeed Port - Port for HTTP proxy.
- schema
Registry DoubleSeed Port - Port for Schema Registry.
- seed
Hostname String - Hostname for the seed brokers.
- service
Attachment String - The service attachment identifier.
- connected
Endpoints GetCluster Gcp Private Service Connect Status Connected Endpoint[] - List of connected endpoints.
- created
At string - When the Private Service Connect service was created.
- deleted
At string - When the Private Service Connect service was deleted.
- dns
ARecords string[] - DNS A records for the service.
- kafka
Api numberNode Base Port - Base port for Kafka API nodes.
- kafka
Api numberSeed Port - Port for Kafka API seed brokers.
- redpanda
Proxy numberNode Base Port - Base port for HTTP proxy nodes.
- redpanda
Proxy numberSeed Port - Port for HTTP proxy.
- schema
Registry numberSeed Port - Port for Schema Registry.
- seed
Hostname string - Hostname for the seed brokers.
- service
Attachment string - The service attachment identifier.
- connected_
endpoints Sequence[GetCluster Gcp Private Service Connect Status Connected Endpoint] - List of connected endpoints.
- created_
at str - When the Private Service Connect service was created.
- deleted_
at str - When the Private Service Connect service was deleted.
- dns_
a_ Sequence[str]records - DNS A records for the service.
- kafka_
api_ floatnode_ base_ port - Base port for Kafka API nodes.
- kafka_
api_ floatseed_ port - Port for Kafka API seed brokers.
- redpanda_
proxy_ floatnode_ base_ port - Base port for HTTP proxy nodes.
- redpanda_
proxy_ floatseed_ port - Port for HTTP proxy.
- schema_
registry_ floatseed_ port - Port for Schema Registry.
- seed_
hostname str - Hostname for the seed brokers.
- service_
attachment str - The service attachment identifier.
- connected
Endpoints List<Property Map> - List of connected endpoints.
- created
At String - When the Private Service Connect service was created.
- deleted
At String - When the Private Service Connect service was deleted.
- dns
ARecords List<String> - DNS A records for the service.
- kafka
Api NumberNode Base Port - Base port for Kafka API nodes.
- kafka
Api NumberSeed Port - Port for Kafka API seed brokers.
- redpanda
Proxy NumberNode Base Port - Base port for HTTP proxy nodes.
- redpanda
Proxy NumberSeed Port - Port for HTTP proxy.
- schema
Registry NumberSeed Port - Port for Schema Registry.
- seed
Hostname String - Hostname for the seed brokers.
- service
Attachment String - The service attachment identifier.
GetClusterGcpPrivateServiceConnectStatusConnectedEndpoint
- Connection
Id string - The connection ID.
- Consumer
Network string - The consumer network.
- Endpoint string
- The endpoint address.
- Status string
- Status of the endpoint connection.
- Connection
Id string - The connection ID.
- Consumer
Network string - The consumer network.
- Endpoint string
- The endpoint address.
- Status string
- Status of the endpoint connection.
- connection
Id String - The connection ID.
- consumer
Network String - The consumer network.
- endpoint String
- The endpoint address.
- status String
- Status of the endpoint connection.
- connection
Id string - The connection ID.
- consumer
Network string - The consumer network.
- endpoint string
- The endpoint address.
- status string
- Status of the endpoint connection.
- connection_
id str - The connection ID.
- consumer_
network str - The consumer network.
- endpoint str
- The endpoint address.
- status str
- Status of the endpoint connection.
- connection
Id String - The connection ID.
- consumer
Network String - The consumer network.
- endpoint String
- The endpoint address.
- status String
- Status of the endpoint connection.
GetClusterHttpProxy
- Mtls
Get
Cluster Http Proxy Mtls - mTLS configuration.
- Url string
- The HTTP Proxy URL.
- Mtls
Get
Cluster Http Proxy Mtls - mTLS configuration.
- Url string
- The HTTP Proxy URL.
- mtls
Get
Cluster Http Proxy Mtls - mTLS configuration.
- url String
- The HTTP Proxy URL.
- mtls
Get
Cluster Http Proxy Mtls - mTLS configuration.
- url string
- The HTTP Proxy URL.
- mtls
Get
Cluster Http Proxy Mtls - mTLS configuration.
- url str
- The HTTP Proxy URL.
- mtls Property Map
- mTLS configuration.
- url String
- The HTTP Proxy URL.
GetClusterHttpProxyMtls
- Ca
Certificates List<string>Pems - CA certificate in PEM format.
- Enabled bool
- Whether mTLS is enabled.
- Principal
Mapping List<string>Rules - Principal mapping rules for mTLS authentication.
- Ca
Certificates []stringPems - CA certificate in PEM format.
- Enabled bool
- Whether mTLS is enabled.
- Principal
Mapping []stringRules - Principal mapping rules for mTLS authentication.
- ca
Certificates List<String>Pems - CA certificate in PEM format.
- enabled Boolean
- Whether mTLS is enabled.
- principal
Mapping List<String>Rules - Principal mapping rules for mTLS authentication.
- ca
Certificates string[]Pems - CA certificate in PEM format.
- enabled boolean
- Whether mTLS is enabled.
- principal
Mapping string[]Rules - Principal mapping rules for mTLS authentication.
- ca_
certificates_ Sequence[str]pems - CA certificate in PEM format.
- enabled bool
- Whether mTLS is enabled.
- principal_
mapping_ Sequence[str]rules - Principal mapping rules for mTLS authentication.
- ca
Certificates List<String>Pems - CA certificate in PEM format.
- enabled Boolean
- Whether mTLS is enabled.
- principal
Mapping List<String>Rules - Principal mapping rules for mTLS authentication.
GetClusterKafkaApi
- Mtls
Get
Cluster Kafka Api Mtls - mTLS configuration.
- Seed
Brokers List<string> - List of Kafka broker addresses.
- Mtls
Get
Cluster Kafka Api Mtls - mTLS configuration.
- Seed
Brokers []string - List of Kafka broker addresses.
- mtls
Get
Cluster Kafka Api Mtls - mTLS configuration.
- seed
Brokers List<String> - List of Kafka broker addresses.
- mtls
Get
Cluster Kafka Api Mtls - mTLS configuration.
- seed
Brokers string[] - List of Kafka broker addresses.
- mtls
Get
Cluster Kafka Api Mtls - mTLS configuration.
- seed_
brokers Sequence[str] - List of Kafka broker addresses.
- mtls Property Map
- mTLS configuration.
- seed
Brokers List<String> - List of Kafka broker addresses.
GetClusterKafkaApiMtls
- Ca
Certificates List<string>Pems - CA certificate in PEM format.
- Enabled bool
- Whether mTLS is enabled.
- Principal
Mapping List<string>Rules - Principal mapping rules for mTLS authentication.
- Ca
Certificates []stringPems - CA certificate in PEM format.
- Enabled bool
- Whether mTLS is enabled.
- Principal
Mapping []stringRules - Principal mapping rules for mTLS authentication.
- ca
Certificates List<String>Pems - CA certificate in PEM format.
- enabled Boolean
- Whether mTLS is enabled.
- principal
Mapping List<String>Rules - Principal mapping rules for mTLS authentication.
- ca
Certificates string[]Pems - CA certificate in PEM format.
- enabled boolean
- Whether mTLS is enabled.
- principal
Mapping string[]Rules - Principal mapping rules for mTLS authentication.
- ca_
certificates_ Sequence[str]pems - CA certificate in PEM format.
- enabled bool
- Whether mTLS is enabled.
- principal_
mapping_ Sequence[str]rules - Principal mapping rules for mTLS authentication.
- ca
Certificates List<String>Pems - CA certificate in PEM format.
- enabled Boolean
- Whether mTLS is enabled.
- principal
Mapping List<String>Rules - Principal mapping rules for mTLS authentication.
GetClusterKafkaConnect
- Enabled bool
- Whether Kafka Connect is enabled.
- Enabled bool
- Whether Kafka Connect is enabled.
- enabled Boolean
- Whether Kafka Connect is enabled.
- enabled boolean
- Whether Kafka Connect is enabled.
- enabled bool
- Whether Kafka Connect is enabled.
- enabled Boolean
- Whether Kafka Connect is enabled.
GetClusterMaintenanceWindowConfig
- Anytime bool
- If true, maintenance can occur at any time.
- Day
Hour GetCluster Maintenance Window Config Day Hour - Unspecified bool
- If true, maintenance window is unspecified.
- Anytime bool
- If true, maintenance can occur at any time.
- Day
Hour GetCluster Maintenance Window Config Day Hour - Unspecified bool
- If true, maintenance window is unspecified.
- anytime Boolean
- If true, maintenance can occur at any time.
- day
Hour GetCluster Maintenance Window Config Day Hour - unspecified Boolean
- If true, maintenance window is unspecified.
- anytime boolean
- If true, maintenance can occur at any time.
- day
Hour GetCluster Maintenance Window Config Day Hour - unspecified boolean
- If true, maintenance window is unspecified.
- anytime bool
- If true, maintenance can occur at any time.
- day_
hour GetCluster Maintenance Window Config Day Hour - unspecified bool
- If true, maintenance window is unspecified.
- anytime Boolean
- If true, maintenance can occur at any time.
- day
Hour Property Map - unspecified Boolean
- If true, maintenance window is unspecified.
GetClusterMaintenanceWindowConfigDayHour
- day_
of_ strweek - Day of week.
- hour_
of_ floatday - Hour of day.
GetClusterPrometheus
- Url string
- The Prometheus metrics endpoint URL.
- Url string
- The Prometheus metrics endpoint URL.
- url String
- The Prometheus metrics endpoint URL.
- url string
- The Prometheus metrics endpoint URL.
- url str
- The Prometheus metrics endpoint URL.
- url String
- The Prometheus metrics endpoint URL.
GetClusterRedpandaConsole
- Url string
- The Redpanda Console URL.
- Url string
- The Redpanda Console URL.
- url String
- The Redpanda Console URL.
- url string
- The Redpanda Console URL.
- url str
- The Redpanda Console URL.
- url String
- The Redpanda Console URL.
GetClusterSchemaRegistry
- Mtls
Get
Cluster Schema Registry Mtls - mTLS configuration.
- Url string
- The Schema Registry URL.
- Mtls
Get
Cluster Schema Registry Mtls - mTLS configuration.
- Url string
- The Schema Registry URL.
- mtls
Get
Cluster Schema Registry Mtls - mTLS configuration.
- url String
- The Schema Registry URL.
- mtls
Get
Cluster Schema Registry Mtls - mTLS configuration.
- url string
- The Schema Registry URL.
- mtls
Get
Cluster Schema Registry Mtls - mTLS configuration.
- url str
- The Schema Registry URL.
- mtls Property Map
- mTLS configuration.
- url String
- The Schema Registry URL.
GetClusterSchemaRegistryMtls
- Ca
Certificates List<string>Pems - CA certificate in PEM format.
- Enabled bool
- Whether mTLS is enabled.
- Principal
Mapping List<string>Rules - Principal mapping rules for mTLS authentication.
- Ca
Certificates []stringPems - CA certificate in PEM format.
- Enabled bool
- Whether mTLS is enabled.
- Principal
Mapping []stringRules - Principal mapping rules for mTLS authentication.
- ca
Certificates List<String>Pems - CA certificate in PEM format.
- enabled Boolean
- Whether mTLS is enabled.
- principal
Mapping List<String>Rules - Principal mapping rules for mTLS authentication.
- ca
Certificates string[]Pems - CA certificate in PEM format.
- enabled boolean
- Whether mTLS is enabled.
- principal
Mapping string[]Rules - Principal mapping rules for mTLS authentication.
- ca_
certificates_ Sequence[str]pems - CA certificate in PEM format.
- enabled bool
- Whether mTLS is enabled.
- principal_
mapping_ Sequence[str]rules - Principal mapping rules for mTLS authentication.
- ca
Certificates List<String>Pems - CA certificate in PEM format.
- enabled Boolean
- Whether mTLS is enabled.
- principal
Mapping List<String>Rules - Principal mapping rules for mTLS authentication.
GetClusterStateDescription
Package Details
- Repository
- redpanda redpanda-data/terraform-provider-redpanda
- License
- Notes
- This Pulumi package is based on the
redpanda
Terraform Provider.
redpanda 0.13.0 published on Monday, Mar 17, 2025 by redpanda-data