1. Packages
  2. Redpanda Provider
  3. API Docs
  4. SchemaRegistryAcl
redpanda 1.3.2 published on Friday, Oct 17, 2025 by redpanda-data

redpanda.SchemaRegistryAcl

Get Started
redpanda logo
redpanda 1.3.2 published on Friday, Oct 17, 2025 by redpanda-data

    Resource for managing Redpanda Schema Registry ACLs (Access Control Lists). This resource allows you to configure fine-grained access control for Schema Registry resources.

    Creates Access Control Lists (ACLs) for Redpanda Schema Registry resources. Schema Registry ACLs provide fine-grained access control over subjects and registry operations.

    Example Usage

    import * as pulumi from "@pulumi/pulumi";
    import * as redpanda from "@pulumi/redpanda";
    
    const exampleResourceGroup = new redpanda.ResourceGroup("exampleResourceGroup", {});
    const exampleNetwork = new redpanda.Network("exampleNetwork", {
        resourceGroupId: exampleResourceGroup.id,
        cloudProvider: "aws",
        region: "us-west-2",
        clusterType: "dedicated",
        cidrBlock: "10.0.0.0/20",
    });
    const exampleCluster = new redpanda.Cluster("exampleCluster", {
        resourceGroupId: exampleResourceGroup.id,
        networkId: exampleNetwork.id,
        cloudProvider: "aws",
        region: "us-west-2",
        clusterType: "dedicated",
        connectionType: "public",
        throughputTier: "tier-1-aws",
        zones: [
            "us-west-2a",
            "us-west-2b",
            "us-west-2c",
        ],
    });
    const exampleUser = new redpanda.User("exampleUser", {
        password: "secure-password-123",
        mechanism: "scram-sha-256",
        clusterApiUrl: exampleCluster.clusterApiUrl,
        allowDeletion: true,
    });
    const schemaRegistryAdmin = new redpanda.Acl("schemaRegistryAdmin", {
        resourceType: "CLUSTER",
        resourceName: "kafka-cluster",
        resourcePatternType: "LITERAL",
        principal: pulumi.interpolate`User:${exampleUser.name}`,
        host: "*",
        operation: "ALTER",
        permissionType: "ALLOW",
        clusterApiUrl: exampleCluster.clusterApiUrl,
    });
    const exampleSchemaRegistryAcl = new redpanda.SchemaRegistryAcl("exampleSchemaRegistryAcl", {
        clusterId: exampleCluster.id,
        principal: pulumi.interpolate`User:${exampleUser.name}`,
        resourceType: "SUBJECT",
        resourceName: "user-value",
        patternType: "LITERAL",
        host: "*",
        operation: "READ",
        permission: "ALLOW",
        username: exampleUser.name,
        password: "secure-password-123",
    }, {
        dependsOn: [schemaRegistryAdmin],
    });
    
    import pulumi
    import pulumi_redpanda as redpanda
    
    example_resource_group = redpanda.ResourceGroup("exampleResourceGroup")
    example_network = redpanda.Network("exampleNetwork",
        resource_group_id=example_resource_group.id,
        cloud_provider="aws",
        region="us-west-2",
        cluster_type="dedicated",
        cidr_block="10.0.0.0/20")
    example_cluster = redpanda.Cluster("exampleCluster",
        resource_group_id=example_resource_group.id,
        network_id=example_network.id,
        cloud_provider="aws",
        region="us-west-2",
        cluster_type="dedicated",
        connection_type="public",
        throughput_tier="tier-1-aws",
        zones=[
            "us-west-2a",
            "us-west-2b",
            "us-west-2c",
        ])
    example_user = redpanda.User("exampleUser",
        password="secure-password-123",
        mechanism="scram-sha-256",
        cluster_api_url=example_cluster.cluster_api_url,
        allow_deletion=True)
    schema_registry_admin = redpanda.Acl("schemaRegistryAdmin",
        resource_type="CLUSTER",
        resource_name_="kafka-cluster",
        resource_pattern_type="LITERAL",
        principal=example_user.name.apply(lambda name: f"User:{name}"),
        host="*",
        operation="ALTER",
        permission_type="ALLOW",
        cluster_api_url=example_cluster.cluster_api_url)
    example_schema_registry_acl = redpanda.SchemaRegistryAcl("exampleSchemaRegistryAcl",
        cluster_id=example_cluster.id,
        principal=example_user.name.apply(lambda name: f"User:{name}"),
        resource_type="SUBJECT",
        resource_name_="user-value",
        pattern_type="LITERAL",
        host="*",
        operation="READ",
        permission="ALLOW",
        username=example_user.name,
        password="secure-password-123",
        opts = pulumi.ResourceOptions(depends_on=[schema_registry_admin]))
    
    package main
    
    import (
    	"fmt"
    
    	"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 {
    		exampleResourceGroup, err := redpanda.NewResourceGroup(ctx, "exampleResourceGroup", nil)
    		if err != nil {
    			return err
    		}
    		exampleNetwork, err := redpanda.NewNetwork(ctx, "exampleNetwork", &redpanda.NetworkArgs{
    			ResourceGroupId: exampleResourceGroup.ID(),
    			CloudProvider:   pulumi.String("aws"),
    			Region:          pulumi.String("us-west-2"),
    			ClusterType:     pulumi.String("dedicated"),
    			CidrBlock:       pulumi.String("10.0.0.0/20"),
    		})
    		if err != nil {
    			return err
    		}
    		exampleCluster, err := redpanda.NewCluster(ctx, "exampleCluster", &redpanda.ClusterArgs{
    			ResourceGroupId: exampleResourceGroup.ID(),
    			NetworkId:       exampleNetwork.ID(),
    			CloudProvider:   pulumi.String("aws"),
    			Region:          pulumi.String("us-west-2"),
    			ClusterType:     pulumi.String("dedicated"),
    			ConnectionType:  pulumi.String("public"),
    			ThroughputTier:  pulumi.String("tier-1-aws"),
    			Zones: pulumi.StringArray{
    				pulumi.String("us-west-2a"),
    				pulumi.String("us-west-2b"),
    				pulumi.String("us-west-2c"),
    			},
    		})
    		if err != nil {
    			return err
    		}
    		exampleUser, err := redpanda.NewUser(ctx, "exampleUser", &redpanda.UserArgs{
    			Password:      pulumi.String("secure-password-123"),
    			Mechanism:     pulumi.String("scram-sha-256"),
    			ClusterApiUrl: exampleCluster.ClusterApiUrl,
    			AllowDeletion: pulumi.Bool(true),
    		})
    		if err != nil {
    			return err
    		}
    		schemaRegistryAdmin, err := redpanda.NewAcl(ctx, "schemaRegistryAdmin", &redpanda.AclArgs{
    			ResourceType:        pulumi.String("CLUSTER"),
    			ResourceName:        pulumi.String("kafka-cluster"),
    			ResourcePatternType: pulumi.String("LITERAL"),
    			Principal: exampleUser.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:  exampleCluster.ClusterApiUrl,
    		})
    		if err != nil {
    			return err
    		}
    		_, err = redpanda.NewSchemaRegistryAcl(ctx, "exampleSchemaRegistryAcl", &redpanda.SchemaRegistryAclArgs{
    			ClusterId: exampleCluster.ID(),
    			Principal: exampleUser.Name.ApplyT(func(name string) (string, error) {
    				return fmt.Sprintf("User:%v", name), nil
    			}).(pulumi.StringOutput),
    			ResourceType: pulumi.String("SUBJECT"),
    			ResourceName: pulumi.String("user-value"),
    			PatternType:  pulumi.String("LITERAL"),
    			Host:         pulumi.String("*"),
    			Operation:    pulumi.String("READ"),
    			Permission:   pulumi.String("ALLOW"),
    			Username:     exampleUser.Name,
    			Password:     pulumi.String("secure-password-123"),
    		}, pulumi.DependsOn([]pulumi.Resource{
    			schemaRegistryAdmin,
    		}))
    		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 exampleResourceGroup = new Redpanda.ResourceGroup("exampleResourceGroup");
    
        var exampleNetwork = new Redpanda.Network("exampleNetwork", new()
        {
            ResourceGroupId = exampleResourceGroup.Id,
            CloudProvider = "aws",
            Region = "us-west-2",
            ClusterType = "dedicated",
            CidrBlock = "10.0.0.0/20",
        });
    
        var exampleCluster = new Redpanda.Cluster("exampleCluster", new()
        {
            ResourceGroupId = exampleResourceGroup.Id,
            NetworkId = exampleNetwork.Id,
            CloudProvider = "aws",
            Region = "us-west-2",
            ClusterType = "dedicated",
            ConnectionType = "public",
            ThroughputTier = "tier-1-aws",
            Zones = new[]
            {
                "us-west-2a",
                "us-west-2b",
                "us-west-2c",
            },
        });
    
        var exampleUser = new Redpanda.User("exampleUser", new()
        {
            Password = "secure-password-123",
            Mechanism = "scram-sha-256",
            ClusterApiUrl = exampleCluster.ClusterApiUrl,
            AllowDeletion = true,
        });
    
        var schemaRegistryAdmin = new Redpanda.Acl("schemaRegistryAdmin", new()
        {
            ResourceType = "CLUSTER",
            ResourceName = "kafka-cluster",
            ResourcePatternType = "LITERAL",
            Principal = exampleUser.Name.Apply(name => $"User:{name}"),
            Host = "*",
            Operation = "ALTER",
            PermissionType = "ALLOW",
            ClusterApiUrl = exampleCluster.ClusterApiUrl,
        });
    
        var exampleSchemaRegistryAcl = new Redpanda.SchemaRegistryAcl("exampleSchemaRegistryAcl", new()
        {
            ClusterId = exampleCluster.Id,
            Principal = exampleUser.Name.Apply(name => $"User:{name}"),
            ResourceType = "SUBJECT",
            ResourceName = "user-value",
            PatternType = "LITERAL",
            Host = "*",
            Operation = "READ",
            Permission = "ALLOW",
            Username = exampleUser.Name,
            Password = "secure-password-123",
        }, new CustomResourceOptions
        {
            DependsOn =
            {
                schemaRegistryAdmin,
            },
        });
    
    });
    
    package generated_program;
    
    import com.pulumi.Context;
    import com.pulumi.Pulumi;
    import com.pulumi.core.Output;
    import com.pulumi.redpanda.ResourceGroup;
    import com.pulumi.redpanda.Network;
    import com.pulumi.redpanda.NetworkArgs;
    import com.pulumi.redpanda.Cluster;
    import com.pulumi.redpanda.ClusterArgs;
    import com.pulumi.redpanda.User;
    import com.pulumi.redpanda.UserArgs;
    import com.pulumi.redpanda.Acl;
    import com.pulumi.redpanda.AclArgs;
    import com.pulumi.redpanda.SchemaRegistryAcl;
    import com.pulumi.redpanda.SchemaRegistryAclArgs;
    import com.pulumi.resources.CustomResourceOptions;
    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) {
            var exampleResourceGroup = new ResourceGroup("exampleResourceGroup");
    
            var exampleNetwork = new Network("exampleNetwork", NetworkArgs.builder()
                .resourceGroupId(exampleResourceGroup.id())
                .cloudProvider("aws")
                .region("us-west-2")
                .clusterType("dedicated")
                .cidrBlock("10.0.0.0/20")
                .build());
    
            var exampleCluster = new Cluster("exampleCluster", ClusterArgs.builder()
                .resourceGroupId(exampleResourceGroup.id())
                .networkId(exampleNetwork.id())
                .cloudProvider("aws")
                .region("us-west-2")
                .clusterType("dedicated")
                .connectionType("public")
                .throughputTier("tier-1-aws")
                .zones(            
                    "us-west-2a",
                    "us-west-2b",
                    "us-west-2c")
                .build());
    
            var exampleUser = new User("exampleUser", UserArgs.builder()
                .password("secure-password-123")
                .mechanism("scram-sha-256")
                .clusterApiUrl(exampleCluster.clusterApiUrl())
                .allowDeletion(true)
                .build());
    
            var schemaRegistryAdmin = new Acl("schemaRegistryAdmin", AclArgs.builder()
                .resourceType("CLUSTER")
                .resourceName("kafka-cluster")
                .resourcePatternType("LITERAL")
                .principal(exampleUser.name().applyValue(name -> String.format("User:%s", name)))
                .host("*")
                .operation("ALTER")
                .permissionType("ALLOW")
                .clusterApiUrl(exampleCluster.clusterApiUrl())
                .build());
    
            var exampleSchemaRegistryAcl = new SchemaRegistryAcl("exampleSchemaRegistryAcl", SchemaRegistryAclArgs.builder()
                .clusterId(exampleCluster.id())
                .principal(exampleUser.name().applyValue(name -> String.format("User:%s", name)))
                .resourceType("SUBJECT")
                .resourceName("user-value")
                .patternType("LITERAL")
                .host("*")
                .operation("READ")
                .permission("ALLOW")
                .username(exampleUser.name())
                .password("secure-password-123")
                .build(), CustomResourceOptions.builder()
                    .dependsOn(schemaRegistryAdmin)
                    .build());
    
        }
    }
    
    resources:
      exampleResourceGroup:
        type: redpanda:ResourceGroup
      exampleNetwork:
        type: redpanda:Network
        properties:
          resourceGroupId: ${exampleResourceGroup.id}
          cloudProvider: aws
          region: us-west-2
          clusterType: dedicated
          cidrBlock: 10.0.0.0/20
      exampleCluster:
        type: redpanda:Cluster
        properties:
          resourceGroupId: ${exampleResourceGroup.id}
          networkId: ${exampleNetwork.id}
          cloudProvider: aws
          region: us-west-2
          clusterType: dedicated
          connectionType: public
          throughputTier: tier-1-aws
          zones:
            - us-west-2a
            - us-west-2b
            - us-west-2c
      exampleUser:
        type: redpanda:User
        properties:
          password: secure-password-123
          mechanism: scram-sha-256
          clusterApiUrl: ${exampleCluster.clusterApiUrl}
          allowDeletion: true
      schemaRegistryAdmin:
        type: redpanda:Acl
        properties:
          resourceType: CLUSTER
          resourceName: kafka-cluster
          resourcePatternType: LITERAL
          principal: User:${exampleUser.name}
          host: '*'
          operation: ALTER
          permissionType: ALLOW
          clusterApiUrl: ${exampleCluster.clusterApiUrl}
      exampleSchemaRegistryAcl:
        type: redpanda:SchemaRegistryAcl
        properties:
          clusterId: ${exampleCluster.id}
          principal: User:${exampleUser.name}
          resourceType: SUBJECT
          resourceName: user-value
          patternType: LITERAL
          host: '*'
          operation: READ
          permission: ALLOW
          username: ${exampleUser.name}
          password: secure-password-123
        options:
          dependsOn:
            - ${schemaRegistryAdmin}
    

    Resource Types

    Schema Registry ACLs support two resource types:

    SUBJECT

    Controls access to specific subjects or subject patterns in the Schema Registry. Use this for schema-level permissions.

    REGISTRY

    Controls access to registry-wide operations like listing subjects or getting compatibility settings.

    Operations

    Available operations depend on the resource type:

    • ALL: All operations (use with caution)
    • READ: Read schemas and subject metadata
    • WRITE: Create and update schemas
    • DELETE: Delete schemas and subjects
    • DESCRIBE: View subject and schema metadata
    • DESCRIBE_CONFIGS: View compatibility and other configuration settings
    • ALTER: Modify subject settings
    • ALTER_CONFIGS: Modify compatibility and other configuration settings

    Pattern Types

    • LITERAL: Exact match on resource name
    • PREFIXED: Match resources that start with the specified prefix

    Administrative Requirements

    To manage Schema Registry ACLs, the user must have cluster-level ALTER permissions. This is typically configured with a regular Kafka ACL granting ALTER operation on the CLUSTER resource.

    For more details about Schema Registry ACLs, see the Redpanda Schema Registry API documentation.

    Security Considerations

    We recommend storing Schema Registry credentials in environment variables or a secret store:

    • REDPANDA_SR_USERNAME for the username
    • REDPANDA_SR_PASSWORD for the password

    API Reference

    For more information, see the Redpanda Schema Registry API documentation and the Redpanda Cloud Data Plane API documentation.

    Create SchemaRegistryAcl Resource

    Resources are created with functions called constructors. To learn more about declaring and configuring resources, see Resources.

    Constructor syntax

    new SchemaRegistryAcl(name: string, args: SchemaRegistryAclArgs, opts?: CustomResourceOptions);
    @overload
    def SchemaRegistryAcl(resource_name: str,
                          args: SchemaRegistryAclArgs,
                          opts: Optional[ResourceOptions] = None)
    
    @overload
    def SchemaRegistryAcl(resource_name: str,
                          opts: Optional[ResourceOptions] = None,
                          cluster_id: Optional[str] = None,
                          host: Optional[str] = None,
                          operation: Optional[str] = None,
                          pattern_type: Optional[str] = None,
                          permission: Optional[str] = None,
                          principal: Optional[str] = None,
                          resource_name_: Optional[str] = None,
                          resource_type: Optional[str] = None,
                          allow_deletion: Optional[bool] = None,
                          password: Optional[str] = None,
                          username: Optional[str] = None)
    func NewSchemaRegistryAcl(ctx *Context, name string, args SchemaRegistryAclArgs, opts ...ResourceOption) (*SchemaRegistryAcl, error)
    public SchemaRegistryAcl(string name, SchemaRegistryAclArgs args, CustomResourceOptions? opts = null)
    public SchemaRegistryAcl(String name, SchemaRegistryAclArgs args)
    public SchemaRegistryAcl(String name, SchemaRegistryAclArgs args, CustomResourceOptions options)
    
    type: redpanda:SchemaRegistryAcl
    properties: # The arguments to resource properties.
    options: # Bag of options to control resource's behavior.
    
    

    Parameters

    name string
    The unique name of the resource.
    args SchemaRegistryAclArgs
    The arguments to resource properties.
    opts CustomResourceOptions
    Bag of options to control resource's behavior.
    resource_name str
    The unique name of the resource.
    args SchemaRegistryAclArgs
    The arguments to resource properties.
    opts ResourceOptions
    Bag of options to control resource's behavior.
    ctx Context
    Context object for the current deployment.
    name string
    The unique name of the resource.
    args SchemaRegistryAclArgs
    The arguments to resource properties.
    opts ResourceOption
    Bag of options to control resource's behavior.
    name string
    The unique name of the resource.
    args SchemaRegistryAclArgs
    The arguments to resource properties.
    opts CustomResourceOptions
    Bag of options to control resource's behavior.
    name String
    The unique name of the resource.
    args SchemaRegistryAclArgs
    The arguments to resource properties.
    options CustomResourceOptions
    Bag of options to control resource's behavior.

    Constructor example

    The following reference example uses placeholder values for all input properties.

    var schemaRegistryAclResource = new Redpanda.SchemaRegistryAcl("schemaRegistryAclResource", new()
    {
        ClusterId = "string",
        Host = "string",
        Operation = "string",
        PatternType = "string",
        Permission = "string",
        Principal = "string",
        ResourceName = "string",
        ResourceType = "string",
        AllowDeletion = false,
        Password = "string",
        Username = "string",
    });
    
    example, err := redpanda.NewSchemaRegistryAcl(ctx, "schemaRegistryAclResource", &redpanda.SchemaRegistryAclArgs{
    	ClusterId:     pulumi.String("string"),
    	Host:          pulumi.String("string"),
    	Operation:     pulumi.String("string"),
    	PatternType:   pulumi.String("string"),
    	Permission:    pulumi.String("string"),
    	Principal:     pulumi.String("string"),
    	ResourceName:  pulumi.String("string"),
    	ResourceType:  pulumi.String("string"),
    	AllowDeletion: pulumi.Bool(false),
    	Password:      pulumi.String("string"),
    	Username:      pulumi.String("string"),
    })
    
    var schemaRegistryAclResource = new SchemaRegistryAcl("schemaRegistryAclResource", SchemaRegistryAclArgs.builder()
        .clusterId("string")
        .host("string")
        .operation("string")
        .patternType("string")
        .permission("string")
        .principal("string")
        .resourceName("string")
        .resourceType("string")
        .allowDeletion(false)
        .password("string")
        .username("string")
        .build());
    
    schema_registry_acl_resource = redpanda.SchemaRegistryAcl("schemaRegistryAclResource",
        cluster_id="string",
        host="string",
        operation="string",
        pattern_type="string",
        permission="string",
        principal="string",
        resource_name_="string",
        resource_type="string",
        allow_deletion=False,
        password="string",
        username="string")
    
    const schemaRegistryAclResource = new redpanda.SchemaRegistryAcl("schemaRegistryAclResource", {
        clusterId: "string",
        host: "string",
        operation: "string",
        patternType: "string",
        permission: "string",
        principal: "string",
        resourceName: "string",
        resourceType: "string",
        allowDeletion: false,
        password: "string",
        username: "string",
    });
    
    type: redpanda:SchemaRegistryAcl
    properties:
        allowDeletion: false
        clusterId: string
        host: string
        operation: string
        password: string
        patternType: string
        permission: string
        principal: string
        resourceName: string
        resourceType: string
        username: string
    

    SchemaRegistryAcl Resource Properties

    To learn more about resource properties and how to use them, see Inputs and Outputs in the Architecture and Concepts docs.

    Inputs

    In Python, inputs that are objects can be passed either as argument classes or as dictionary literals.

    The SchemaRegistryAcl resource accepts the following input properties:

    ClusterId string
    The ID of the cluster where the Schema Registry ACL will be created
    Host string
    The host address to use for this ACL. Use '*' for wildcard
    Operation string
    The operation type that shall be allowed or denied: ALL, READ, WRITE, DELETE, DESCRIBE, DESCRIBECONFIGS, ALTER, ALTERCONFIGS
    PatternType string
    The pattern type of the resource: LITERAL or PREFIXED
    Permission string
    The permission type: ALLOW or DENY
    Principal string
    The principal to apply this ACL for (e.g., User:alice or RedpandaRole:admin)
    ResourceName string
    The name of the resource this ACL entry will be on. Use '*' for wildcard
    ResourceType string
    The type of the resource: SUBJECT or REGISTRY
    AllowDeletion bool
    When set to true, allows the resource to be removed from state even if deletion fails due to permission errors
    Password string
    Password for authentication. Can be set via REDPANDASRPASSWORD environment variable
    Username string
    Username for authentication. Can be set via REDPANDASRUSERNAME environment variable
    ClusterId string
    The ID of the cluster where the Schema Registry ACL will be created
    Host string
    The host address to use for this ACL. Use '*' for wildcard
    Operation string
    The operation type that shall be allowed or denied: ALL, READ, WRITE, DELETE, DESCRIBE, DESCRIBECONFIGS, ALTER, ALTERCONFIGS
    PatternType string
    The pattern type of the resource: LITERAL or PREFIXED
    Permission string
    The permission type: ALLOW or DENY
    Principal string
    The principal to apply this ACL for (e.g., User:alice or RedpandaRole:admin)
    ResourceName string
    The name of the resource this ACL entry will be on. Use '*' for wildcard
    ResourceType string
    The type of the resource: SUBJECT or REGISTRY
    AllowDeletion bool
    When set to true, allows the resource to be removed from state even if deletion fails due to permission errors
    Password string
    Password for authentication. Can be set via REDPANDASRPASSWORD environment variable
    Username string
    Username for authentication. Can be set via REDPANDASRUSERNAME environment variable
    clusterId String
    The ID of the cluster where the Schema Registry ACL will be created
    host String
    The host address to use for this ACL. Use '*' for wildcard
    operation String
    The operation type that shall be allowed or denied: ALL, READ, WRITE, DELETE, DESCRIBE, DESCRIBECONFIGS, ALTER, ALTERCONFIGS
    patternType String
    The pattern type of the resource: LITERAL or PREFIXED
    permission String
    The permission type: ALLOW or DENY
    principal String
    The principal to apply this ACL for (e.g., User:alice or RedpandaRole:admin)
    resourceName String
    The name of the resource this ACL entry will be on. Use '*' for wildcard
    resourceType String
    The type of the resource: SUBJECT or REGISTRY
    allowDeletion Boolean
    When set to true, allows the resource to be removed from state even if deletion fails due to permission errors
    password String
    Password for authentication. Can be set via REDPANDASRPASSWORD environment variable
    username String
    Username for authentication. Can be set via REDPANDASRUSERNAME environment variable
    clusterId string
    The ID of the cluster where the Schema Registry ACL will be created
    host string
    The host address to use for this ACL. Use '*' for wildcard
    operation string
    The operation type that shall be allowed or denied: ALL, READ, WRITE, DELETE, DESCRIBE, DESCRIBECONFIGS, ALTER, ALTERCONFIGS
    patternType string
    The pattern type of the resource: LITERAL or PREFIXED
    permission string
    The permission type: ALLOW or DENY
    principal string
    The principal to apply this ACL for (e.g., User:alice or RedpandaRole:admin)
    resourceName string
    The name of the resource this ACL entry will be on. Use '*' for wildcard
    resourceType string
    The type of the resource: SUBJECT or REGISTRY
    allowDeletion boolean
    When set to true, allows the resource to be removed from state even if deletion fails due to permission errors
    password string
    Password for authentication. Can be set via REDPANDASRPASSWORD environment variable
    username string
    Username for authentication. Can be set via REDPANDASRUSERNAME environment variable
    cluster_id str
    The ID of the cluster where the Schema Registry ACL will be created
    host str
    The host address to use for this ACL. Use '*' for wildcard
    operation str
    The operation type that shall be allowed or denied: ALL, READ, WRITE, DELETE, DESCRIBE, DESCRIBECONFIGS, ALTER, ALTERCONFIGS
    pattern_type str
    The pattern type of the resource: LITERAL or PREFIXED
    permission str
    The permission type: ALLOW or DENY
    principal str
    The principal to apply this ACL for (e.g., User:alice or RedpandaRole:admin)
    resource_name str
    The name of the resource this ACL entry will be on. Use '*' for wildcard
    resource_type str
    The type of the resource: SUBJECT or REGISTRY
    allow_deletion bool
    When set to true, allows the resource to be removed from state even if deletion fails due to permission errors
    password str
    Password for authentication. Can be set via REDPANDASRPASSWORD environment variable
    username str
    Username for authentication. Can be set via REDPANDASRUSERNAME environment variable
    clusterId String
    The ID of the cluster where the Schema Registry ACL will be created
    host String
    The host address to use for this ACL. Use '*' for wildcard
    operation String
    The operation type that shall be allowed or denied: ALL, READ, WRITE, DELETE, DESCRIBE, DESCRIBECONFIGS, ALTER, ALTERCONFIGS
    patternType String
    The pattern type of the resource: LITERAL or PREFIXED
    permission String
    The permission type: ALLOW or DENY
    principal String
    The principal to apply this ACL for (e.g., User:alice or RedpandaRole:admin)
    resourceName String
    The name of the resource this ACL entry will be on. Use '*' for wildcard
    resourceType String
    The type of the resource: SUBJECT or REGISTRY
    allowDeletion Boolean
    When set to true, allows the resource to be removed from state even if deletion fails due to permission errors
    password String
    Password for authentication. Can be set via REDPANDASRPASSWORD environment variable
    username String
    Username for authentication. Can be set via REDPANDASRUSERNAME environment variable

    Outputs

    All input properties are implicitly available as output properties. Additionally, the SchemaRegistryAcl resource produces the following output properties:

    Id string
    The provider-assigned unique ID for this managed resource.
    Id string
    The provider-assigned unique ID for this managed resource.
    id String
    The provider-assigned unique ID for this managed resource.
    id string
    The provider-assigned unique ID for this managed resource.
    id str
    The provider-assigned unique ID for this managed resource.
    id String
    The provider-assigned unique ID for this managed resource.

    Look up Existing SchemaRegistryAcl Resource

    Get an existing SchemaRegistryAcl resource’s state with the given name, ID, and optional extra properties used to qualify the lookup.

    public static get(name: string, id: Input<ID>, state?: SchemaRegistryAclState, opts?: CustomResourceOptions): SchemaRegistryAcl
    @staticmethod
    def get(resource_name: str,
            id: str,
            opts: Optional[ResourceOptions] = None,
            allow_deletion: Optional[bool] = None,
            cluster_id: Optional[str] = None,
            host: Optional[str] = None,
            operation: Optional[str] = None,
            password: Optional[str] = None,
            pattern_type: Optional[str] = None,
            permission: Optional[str] = None,
            principal: Optional[str] = None,
            resource_name: Optional[str] = None,
            resource_type: Optional[str] = None,
            username: Optional[str] = None) -> SchemaRegistryAcl
    func GetSchemaRegistryAcl(ctx *Context, name string, id IDInput, state *SchemaRegistryAclState, opts ...ResourceOption) (*SchemaRegistryAcl, error)
    public static SchemaRegistryAcl Get(string name, Input<string> id, SchemaRegistryAclState? state, CustomResourceOptions? opts = null)
    public static SchemaRegistryAcl get(String name, Output<String> id, SchemaRegistryAclState state, CustomResourceOptions options)
    resources:  _:    type: redpanda:SchemaRegistryAcl    get:      id: ${id}
    name
    The unique name of the resulting resource.
    id
    The unique provider ID of the resource to lookup.
    state
    Any extra arguments used during the lookup.
    opts
    A bag of options that control this resource's behavior.
    resource_name
    The unique name of the resulting resource.
    id
    The unique provider ID of the resource to lookup.
    name
    The unique name of the resulting resource.
    id
    The unique provider ID of the resource to lookup.
    state
    Any extra arguments used during the lookup.
    opts
    A bag of options that control this resource's behavior.
    name
    The unique name of the resulting resource.
    id
    The unique provider ID of the resource to lookup.
    state
    Any extra arguments used during the lookup.
    opts
    A bag of options that control this resource's behavior.
    name
    The unique name of the resulting resource.
    id
    The unique provider ID of the resource to lookup.
    state
    Any extra arguments used during the lookup.
    opts
    A bag of options that control this resource's behavior.
    The following state arguments are supported:
    AllowDeletion bool
    When set to true, allows the resource to be removed from state even if deletion fails due to permission errors
    ClusterId string
    The ID of the cluster where the Schema Registry ACL will be created
    Host string
    The host address to use for this ACL. Use '*' for wildcard
    Operation string
    The operation type that shall be allowed or denied: ALL, READ, WRITE, DELETE, DESCRIBE, DESCRIBECONFIGS, ALTER, ALTERCONFIGS
    Password string
    Password for authentication. Can be set via REDPANDASRPASSWORD environment variable
    PatternType string
    The pattern type of the resource: LITERAL or PREFIXED
    Permission string
    The permission type: ALLOW or DENY
    Principal string
    The principal to apply this ACL for (e.g., User:alice or RedpandaRole:admin)
    ResourceName string
    The name of the resource this ACL entry will be on. Use '*' for wildcard
    ResourceType string
    The type of the resource: SUBJECT or REGISTRY
    Username string
    Username for authentication. Can be set via REDPANDASRUSERNAME environment variable
    AllowDeletion bool
    When set to true, allows the resource to be removed from state even if deletion fails due to permission errors
    ClusterId string
    The ID of the cluster where the Schema Registry ACL will be created
    Host string
    The host address to use for this ACL. Use '*' for wildcard
    Operation string
    The operation type that shall be allowed or denied: ALL, READ, WRITE, DELETE, DESCRIBE, DESCRIBECONFIGS, ALTER, ALTERCONFIGS
    Password string
    Password for authentication. Can be set via REDPANDASRPASSWORD environment variable
    PatternType string
    The pattern type of the resource: LITERAL or PREFIXED
    Permission string
    The permission type: ALLOW or DENY
    Principal string
    The principal to apply this ACL for (e.g., User:alice or RedpandaRole:admin)
    ResourceName string
    The name of the resource this ACL entry will be on. Use '*' for wildcard
    ResourceType string
    The type of the resource: SUBJECT or REGISTRY
    Username string
    Username for authentication. Can be set via REDPANDASRUSERNAME environment variable
    allowDeletion Boolean
    When set to true, allows the resource to be removed from state even if deletion fails due to permission errors
    clusterId String
    The ID of the cluster where the Schema Registry ACL will be created
    host String
    The host address to use for this ACL. Use '*' for wildcard
    operation String
    The operation type that shall be allowed or denied: ALL, READ, WRITE, DELETE, DESCRIBE, DESCRIBECONFIGS, ALTER, ALTERCONFIGS
    password String
    Password for authentication. Can be set via REDPANDASRPASSWORD environment variable
    patternType String
    The pattern type of the resource: LITERAL or PREFIXED
    permission String
    The permission type: ALLOW or DENY
    principal String
    The principal to apply this ACL for (e.g., User:alice or RedpandaRole:admin)
    resourceName String
    The name of the resource this ACL entry will be on. Use '*' for wildcard
    resourceType String
    The type of the resource: SUBJECT or REGISTRY
    username String
    Username for authentication. Can be set via REDPANDASRUSERNAME environment variable
    allowDeletion boolean
    When set to true, allows the resource to be removed from state even if deletion fails due to permission errors
    clusterId string
    The ID of the cluster where the Schema Registry ACL will be created
    host string
    The host address to use for this ACL. Use '*' for wildcard
    operation string
    The operation type that shall be allowed or denied: ALL, READ, WRITE, DELETE, DESCRIBE, DESCRIBECONFIGS, ALTER, ALTERCONFIGS
    password string
    Password for authentication. Can be set via REDPANDASRPASSWORD environment variable
    patternType string
    The pattern type of the resource: LITERAL or PREFIXED
    permission string
    The permission type: ALLOW or DENY
    principal string
    The principal to apply this ACL for (e.g., User:alice or RedpandaRole:admin)
    resourceName string
    The name of the resource this ACL entry will be on. Use '*' for wildcard
    resourceType string
    The type of the resource: SUBJECT or REGISTRY
    username string
    Username for authentication. Can be set via REDPANDASRUSERNAME environment variable
    allow_deletion bool
    When set to true, allows the resource to be removed from state even if deletion fails due to permission errors
    cluster_id str
    The ID of the cluster where the Schema Registry ACL will be created
    host str
    The host address to use for this ACL. Use '*' for wildcard
    operation str
    The operation type that shall be allowed or denied: ALL, READ, WRITE, DELETE, DESCRIBE, DESCRIBECONFIGS, ALTER, ALTERCONFIGS
    password str
    Password for authentication. Can be set via REDPANDASRPASSWORD environment variable
    pattern_type str
    The pattern type of the resource: LITERAL or PREFIXED
    permission str
    The permission type: ALLOW or DENY
    principal str
    The principal to apply this ACL for (e.g., User:alice or RedpandaRole:admin)
    resource_name str
    The name of the resource this ACL entry will be on. Use '*' for wildcard
    resource_type str
    The type of the resource: SUBJECT or REGISTRY
    username str
    Username for authentication. Can be set via REDPANDASRUSERNAME environment variable
    allowDeletion Boolean
    When set to true, allows the resource to be removed from state even if deletion fails due to permission errors
    clusterId String
    The ID of the cluster where the Schema Registry ACL will be created
    host String
    The host address to use for this ACL. Use '*' for wildcard
    operation String
    The operation type that shall be allowed or denied: ALL, READ, WRITE, DELETE, DESCRIBE, DESCRIBECONFIGS, ALTER, ALTERCONFIGS
    password String
    Password for authentication. Can be set via REDPANDASRPASSWORD environment variable
    patternType String
    The pattern type of the resource: LITERAL or PREFIXED
    permission String
    The permission type: ALLOW or DENY
    principal String
    The principal to apply this ACL for (e.g., User:alice or RedpandaRole:admin)
    resourceName String
    The name of the resource this ACL entry will be on. Use '*' for wildcard
    resourceType String
    The type of the resource: SUBJECT or REGISTRY
    username String
    Username for authentication. Can be set via REDPANDASRUSERNAME environment variable

    Import

    We do not currently support importing Schema Registry ACLs.

    To learn more about importing existing cloud resources, see Importing resources.

    Package Details

    Repository
    redpanda redpanda-data/terraform-provider-redpanda
    License
    Notes
    This Pulumi package is based on the redpanda Terraform Provider.
    redpanda logo
    redpanda 1.3.2 published on Friday, Oct 17, 2025 by redpanda-data
      Meet Neo: Your AI Platform Teammate