Package-level declarations

Types

Link copied to clipboard
class AuthorizationRule : KotlinCustomResource

Manages a Event Hubs authorization Rule within an Event Hub.

Link copied to clipboard
data class AuthorizationRuleArgs(val eventhubName: Output<String>? = null, val listen: Output<Boolean>? = null, val manage: Output<Boolean>? = null, val name: Output<String>? = null, val namespaceName: Output<String>? = null, val resourceGroupName: Output<String>? = null, val send: Output<Boolean>? = null) : ConvertibleToJava<AuthorizationRuleArgs>

Manages a Event Hubs authorization Rule within an Event Hub.

Link copied to clipboard
object AuthorizationRuleMapper : ResourceMapper<AuthorizationRule>
Link copied to clipboard
class Cluster : KotlinCustomResource

Manages an EventHub Cluster

Link copied to clipboard
data class ClusterArgs(val location: Output<String>? = null, val name: Output<String>? = null, val resourceGroupName: Output<String>? = null, val skuName: Output<String>? = null, val tags: Output<Map<String, String>>? = null) : ConvertibleToJava<ClusterArgs>

Manages an EventHub Cluster

Link copied to clipboard
Link copied to clipboard
object ClusterMapper : ResourceMapper<Cluster>
Link copied to clipboard
Link copied to clipboard
class ConsumerGroup : KotlinCustomResource

Manages a Event Hubs Consumer Group as a nested resource within an Event Hub.

Link copied to clipboard
data class ConsumerGroupArgs(val eventhubName: Output<String>? = null, val name: Output<String>? = null, val namespaceName: Output<String>? = null, val resourceGroupName: Output<String>? = null, val userMetadata: Output<String>? = null) : ConvertibleToJava<ConsumerGroupArgs>

Manages a Event Hubs Consumer Group as a nested resource within an Event Hub.

Link copied to clipboard
Link copied to clipboard
object ConsumerGroupMapper : ResourceMapper<ConsumerGroup>
Link copied to clipboard
Link copied to clipboard
class Domain : KotlinCustomResource

Manages an EventGrid Domain

Link copied to clipboard
data class DomainArgs constructor(val autoCreateTopicWithFirstSubscription: Output<Boolean>? = null, val autoDeleteTopicWithLastSubscription: Output<Boolean>? = null, val identity: Output<DomainIdentityArgs>? = null, val inboundIpRules: Output<List<DomainInboundIpRuleArgs>>? = null, val inputMappingDefaultValues: Output<DomainInputMappingDefaultValuesArgs>? = null, val inputMappingFields: Output<DomainInputMappingFieldsArgs>? = null, val inputSchema: Output<String>? = null, val localAuthEnabled: Output<Boolean>? = null, val location: Output<String>? = null, val name: Output<String>? = null, val publicNetworkAccessEnabled: Output<Boolean>? = null, val resourceGroupName: Output<String>? = null, val tags: Output<Map<String, String>>? = null) : ConvertibleToJava<DomainArgs>

Manages an EventGrid Domain

Link copied to clipboard

Builder for DomainArgs.

Link copied to clipboard
object DomainMapper : ResourceMapper<Domain>
Link copied to clipboard

Builder for Domain.

Link copied to clipboard
class EventGridTopic : KotlinCustomResource

Manages an EventGrid Topic

Link copied to clipboard
data class EventGridTopicArgs constructor(val identity: Output<EventGridTopicIdentityArgs>? = null, val inboundIpRules: Output<List<EventGridTopicInboundIpRuleArgs>>? = null, val inputMappingDefaultValues: Output<EventGridTopicInputMappingDefaultValuesArgs>? = null, val inputMappingFields: Output<EventGridTopicInputMappingFieldsArgs>? = null, val inputSchema: Output<String>? = null, val localAuthEnabled: Output<Boolean>? = null, val location: Output<String>? = null, val name: Output<String>? = null, val publicNetworkAccessEnabled: Output<Boolean>? = null, val resourceGroupName: Output<String>? = null, val tags: Output<Map<String, String>>? = null) : ConvertibleToJava<EventGridTopicArgs>

Manages an EventGrid Topic

Link copied to clipboard
Link copied to clipboard
object EventGridTopicMapper : ResourceMapper<EventGridTopic>
Link copied to clipboard
class EventHub : KotlinCustomResource

Manages a Event Hubs as a nested resource within a Event Hubs namespace.

Link copied to clipboard
data class EventHubArgs(val captureDescription: Output<EventHubCaptureDescriptionArgs>? = null, val messageRetention: Output<Int>? = null, val name: Output<String>? = null, val namespaceId: Output<String>? = null, val namespaceName: Output<String>? = null, val partitionCount: Output<Int>? = null, val resourceGroupName: Output<String>? = null, val status: Output<String>? = null) : ConvertibleToJava<EventHubArgs>

Manages a Event Hubs as a nested resource within a Event Hubs namespace.

Link copied to clipboard
Link copied to clipboard
class EventHubAuthorizationRule : KotlinCustomResource

Manages a Event Hubs authorization Rule within an Event Hub.

Link copied to clipboard
data class EventHubAuthorizationRuleArgs constructor(val eventhubName: Output<String>? = null, val listen: Output<Boolean>? = null, val manage: Output<Boolean>? = null, val name: Output<String>? = null, val namespaceName: Output<String>? = null, val resourceGroupName: Output<String>? = null, val send: Output<Boolean>? = null) : ConvertibleToJava<EventHubAuthorizationRuleArgs>

Manages a Event Hubs authorization Rule within an Event Hub.

Link copied to clipboard
class EventHubConsumerGroup : KotlinCustomResource

Manages a Event Hubs Consumer Group as a nested resource within an Event Hub.

Link copied to clipboard
data class EventHubConsumerGroupArgs constructor(val eventhubName: Output<String>? = null, val name: Output<String>? = null, val namespaceName: Output<String>? = null, val resourceGroupName: Output<String>? = null, val userMetadata: Output<String>? = null) : ConvertibleToJava<EventHubConsumerGroupArgs>

Manages a Event Hubs Consumer Group as a nested resource within an Event Hub.

Link copied to clipboard
Link copied to clipboard
Link copied to clipboard
object EventHubMapper : ResourceMapper<EventHub>
Link copied to clipboard
class EventHubNamespace : KotlinCustomResource

Manages an EventHub Namespace.

Link copied to clipboard
data class EventHubNamespaceArgs(val autoInflateEnabled: Output<Boolean>? = null, val capacity: Output<Int>? = null, val dedicatedClusterId: Output<String>? = null, val identity: Output<EventHubNamespaceIdentityArgs>? = null, val localAuthenticationEnabled: Output<Boolean>? = null, val location: Output<String>? = null, val maximumThroughputUnits: Output<Int>? = null, val minimumTlsVersion: Output<String>? = null, val name: Output<String>? = null, val networkRulesets: Output<EventHubNamespaceNetworkRulesetsArgs>? = null, val publicNetworkAccessEnabled: Output<Boolean>? = null, val resourceGroupName: Output<String>? = null, val sku: Output<String>? = null, val tags: Output<Map<String, String>>? = null) : ConvertibleToJava<EventHubNamespaceArgs>

Manages an EventHub Namespace.

Link copied to clipboard
class EventHubNamespaceAuthorizationRule : KotlinCustomResource

Manages an Authorization Rule for an Event Hub Namespace.

Link copied to clipboard
data class EventHubNamespaceAuthorizationRuleArgs(val listen: Output<Boolean>? = null, val manage: Output<Boolean>? = null, val name: Output<String>? = null, val namespaceName: Output<String>? = null, val resourceGroupName: Output<String>? = null, val send: Output<Boolean>? = null) : ConvertibleToJava<EventHubNamespaceAuthorizationRuleArgs>

Manages an Authorization Rule for an Event Hub Namespace.

Link copied to clipboard
class EventhubNamespaceDisasterRecoveryConfig : KotlinCustomResource

Manages an Disaster Recovery Config for an Event Hub Namespace.

data class EventhubNamespaceDisasterRecoveryConfigArgs(val name: Output<String>? = null, val namespaceName: Output<String>? = null, val partnerNamespaceId: Output<String>? = null, val resourceGroupName: Output<String>? = null) : ConvertibleToJava<EventhubNamespaceDisasterRecoveryConfigArgs>

Manages an Disaster Recovery Config for an Event Hub Namespace.

Link copied to clipboard
object EventHubNamespaceMapper : ResourceMapper<EventHubNamespace>
Link copied to clipboard
Link copied to clipboard
class EventSubscription : KotlinCustomResource

Manages an EventGrid Event Subscription

Link copied to clipboard
data class EventSubscriptionArgs constructor(val advancedFilter: Output<EventSubscriptionAdvancedFilterArgs>? = null, val advancedFilteringOnArraysEnabled: Output<Boolean>? = null, val azureFunctionEndpoint: Output<EventSubscriptionAzureFunctionEndpointArgs>? = null, val deadLetterIdentity: Output<EventSubscriptionDeadLetterIdentityArgs>? = null, val deliveryIdentity: Output<EventSubscriptionDeliveryIdentityArgs>? = null, val deliveryProperties: Output<List<EventSubscriptionDeliveryPropertyArgs>>? = null, val eventDeliverySchema: Output<String>? = null, val eventhubEndpointId: Output<String>? = null, val expirationTimeUtc: Output<String>? = null, val hybridConnectionEndpointId: Output<String>? = null, val includedEventTypes: Output<List<String>>? = null, val labels: Output<List<String>>? = null, val name: Output<String>? = null, val retryPolicy: Output<EventSubscriptionRetryPolicyArgs>? = null, val scope: Output<String>? = null, val serviceBusQueueEndpointId: Output<String>? = null, val serviceBusTopicEndpointId: Output<String>? = null, val storageBlobDeadLetterDestination: Output<EventSubscriptionStorageBlobDeadLetterDestinationArgs>? = null, val storageQueueEndpoint: Output<EventSubscriptionStorageQueueEndpointArgs>? = null, val subjectFilter: Output<EventSubscriptionSubjectFilterArgs>? = null, val webhookEndpoint: Output<EventSubscriptionWebhookEndpointArgs>? = null) : ConvertibleToJava<EventSubscriptionArgs>

Manages an EventGrid Event Subscription

Link copied to clipboard
object EventSubscriptionMapper : ResourceMapper<EventSubscription>
Link copied to clipboard
class Namespace : KotlinCustomResource

Manages a ServiceBus Namespace.

Link copied to clipboard
data class NamespaceArgs constructor(val capacity: Output<Int>? = null, val customerManagedKey: Output<NamespaceCustomerManagedKeyArgs>? = null, val identity: Output<NamespaceIdentityArgs>? = null, val localAuthEnabled: Output<Boolean>? = null, val location: Output<String>? = null, val minimumTlsVersion: Output<String>? = null, val name: Output<String>? = null, val networkRuleSet: Output<NamespaceNetworkRuleSetArgs>? = null, val premiumMessagingPartitions: Output<Int>? = null, val publicNetworkAccessEnabled: Output<Boolean>? = null, val resourceGroupName: Output<String>? = null, val sku: Output<String>? = null, val tags: Output<Map<String, String>>? = null) : ConvertibleToJava<NamespaceArgs>

Manages a ServiceBus Namespace.

Link copied to clipboard
Link copied to clipboard
class NamespaceAuthorizationRule : KotlinCustomResource

Manages a ServiceBus Namespace authorization Rule within a ServiceBus.

Link copied to clipboard
data class NamespaceAuthorizationRuleArgs constructor(val listen: Output<Boolean>? = null, val manage: Output<Boolean>? = null, val name: Output<String>? = null, val namespaceId: Output<String>? = null, val send: Output<Boolean>? = null) : ConvertibleToJava<NamespaceAuthorizationRuleArgs>

Manages a ServiceBus Namespace authorization Rule within a ServiceBus.

Link copied to clipboard
class NamespaceCustomerManagedKey : KotlinCustomResource

Manages a Customer Managed Key for a EventHub Namespace. !>Note: In 2.x versions of the Azure Provider during deletion this resource will delete and recreate the parent EventHub Namespace which may involve data loss as it's not possible to remove the Customer Managed Key from the EventHub Namespace once it's been added. Version 3.0 of the Azure Provider will change this so that the Delete operation is a noop, requiring the parent EventHub Namespace is deleted/recreated to remove the Customer Managed Key.

Link copied to clipboard
data class NamespaceCustomerManagedKeyArgs(val eventhubNamespaceId: Output<String>? = null, val infrastructureEncryptionEnabled: Output<Boolean>? = null, val keyVaultKeyIds: Output<List<String>>? = null, val userAssignedIdentityId: Output<String>? = null) : ConvertibleToJava<NamespaceCustomerManagedKeyArgs>

Manages a Customer Managed Key for a EventHub Namespace. !>Note: In 2.x versions of the Azure Provider during deletion this resource will delete and recreate the parent EventHub Namespace which may involve data loss as it's not possible to remove the Customer Managed Key from the EventHub Namespace once it's been added. Version 3.0 of the Azure Provider will change this so that the Delete operation is a noop, requiring the parent EventHub Namespace is deleted/recreated to remove the Customer Managed Key.

Link copied to clipboard
object NamespaceMapper : ResourceMapper<Namespace>
Link copied to clipboard
Link copied to clipboard
class NamespaceSchemaGroup : KotlinCustomResource
Link copied to clipboard
data class NamespaceSchemaGroupArgs(val name: Output<String>? = null, val namespaceId: Output<String>? = null, val schemaCompatibility: Output<String>? = null, val schemaType: Output<String>? = null) : ConvertibleToJava<NamespaceSchemaGroupArgs>
Link copied to clipboard
Link copied to clipboard
class Queue : KotlinCustomResource

Manages a ServiceBus Queue.

Link copied to clipboard
data class QueueArgs constructor(val autoDeleteOnIdle: Output<String>? = null, val batchedOperationsEnabled: Output<Boolean>? = null, val deadLetteringOnMessageExpiration: Output<Boolean>? = null, val defaultMessageTtl: Output<String>? = null, val duplicateDetectionHistoryTimeWindow: Output<String>? = null, val expressEnabled: Output<Boolean>? = null, val forwardDeadLetteredMessagesTo: Output<String>? = null, val forwardTo: Output<String>? = null, val lockDuration: Output<String>? = null, val maxDeliveryCount: Output<Int>? = null, val maxMessageSizeInKilobytes: Output<Int>? = null, val maxSizeInMegabytes: Output<Int>? = null, val name: Output<String>? = null, val namespaceId: Output<String>? = null, val partitioningEnabled: Output<Boolean>? = null, val requiresDuplicateDetection: Output<Boolean>? = null, val requiresSession: Output<Boolean>? = null, val status: Output<String>? = null) : ConvertibleToJava<QueueArgs>

Manages a ServiceBus Queue.

Link copied to clipboard

Builder for QueueArgs.

Link copied to clipboard
class QueueAuthorizationRule : KotlinCustomResource

Manages an Authorization Rule for a ServiceBus Queue.

Link copied to clipboard
data class QueueAuthorizationRuleArgs constructor(val listen: Output<Boolean>? = null, val manage: Output<Boolean>? = null, val name: Output<String>? = null, val queueId: Output<String>? = null, val send: Output<Boolean>? = null) : ConvertibleToJava<QueueAuthorizationRuleArgs>

Manages an Authorization Rule for a ServiceBus Queue.

Link copied to clipboard
Link copied to clipboard
object QueueMapper : ResourceMapper<Queue>
Link copied to clipboard

Builder for Queue.

Link copied to clipboard
class Subscription : KotlinCustomResource

Manages a ServiceBus Subscription.

Link copied to clipboard
data class SubscriptionArgs constructor(val autoDeleteOnIdle: Output<String>? = null, val batchedOperationsEnabled: Output<Boolean>? = null, val clientScopedSubscription: Output<SubscriptionClientScopedSubscriptionArgs>? = null, val clientScopedSubscriptionEnabled: Output<Boolean>? = null, val deadLetteringOnFilterEvaluationError: Output<Boolean>? = null, val deadLetteringOnMessageExpiration: Output<Boolean>? = null, val defaultMessageTtl: Output<String>? = null, val forwardDeadLetteredMessagesTo: Output<String>? = null, val forwardTo: Output<String>? = null, val lockDuration: Output<String>? = null, val maxDeliveryCount: Output<Int>? = null, val name: Output<String>? = null, val requiresSession: Output<Boolean>? = null, val status: Output<String>? = null, val topicId: Output<String>? = null) : ConvertibleToJava<SubscriptionArgs>

Manages a ServiceBus Subscription.

Link copied to clipboard
Link copied to clipboard
object SubscriptionMapper : ResourceMapper<Subscription>
Link copied to clipboard
Link copied to clipboard
class SubscriptionRule : KotlinCustomResource

Manages a ServiceBus Subscription Rule.

Link copied to clipboard
data class SubscriptionRuleArgs constructor(val action: Output<String>? = null, val correlationFilter: Output<SubscriptionRuleCorrelationFilterArgs>? = null, val filterType: Output<String>? = null, val name: Output<String>? = null, val sqlFilter: Output<String>? = null, val subscriptionId: Output<String>? = null) : ConvertibleToJava<SubscriptionRuleArgs>

Manages a ServiceBus Subscription Rule.

Link copied to clipboard
object SubscriptionRuleMapper : ResourceMapper<SubscriptionRule>
Link copied to clipboard
class Topic : KotlinCustomResource

Manages a ServiceBus Topic.

Link copied to clipboard
data class TopicArgs constructor(val autoDeleteOnIdle: Output<String>? = null, val batchedOperationsEnabled: Output<Boolean>? = null, val defaultMessageTtl: Output<String>? = null, val duplicateDetectionHistoryTimeWindow: Output<String>? = null, val expressEnabled: Output<Boolean>? = null, val maxMessageSizeInKilobytes: Output<Int>? = null, val maxSizeInMegabytes: Output<Int>? = null, val name: Output<String>? = null, val namespaceId: Output<String>? = null, val partitioningEnabled: Output<Boolean>? = null, val requiresDuplicateDetection: Output<Boolean>? = null, val status: Output<String>? = null, val supportOrdering: Output<Boolean>? = null) : ConvertibleToJava<TopicArgs>

Manages a ServiceBus Topic.

Link copied to clipboard

Builder for TopicArgs.

Link copied to clipboard
class TopicAuthorizationRule : KotlinCustomResource

Manages a ServiceBus Topic authorization Rule within a ServiceBus Topic.

Link copied to clipboard
data class TopicAuthorizationRuleArgs constructor(val listen: Output<Boolean>? = null, val manage: Output<Boolean>? = null, val name: Output<String>? = null, val send: Output<Boolean>? = null, val topicId: Output<String>? = null) : ConvertibleToJava<TopicAuthorizationRuleArgs>

Manages a ServiceBus Topic authorization Rule within a ServiceBus Topic.

Link copied to clipboard
Link copied to clipboard
object TopicMapper : ResourceMapper<Topic>
Link copied to clipboard

Builder for Topic.

Functions

Link copied to clipboard
fun cluster(name: String): Cluster
suspend fun cluster(name: String, block: suspend ClusterResourceBuilder.() -> Unit): Cluster
Link copied to clipboard
Link copied to clipboard
fun domain(name: String): Domain
suspend fun domain(name: String, block: suspend DomainResourceBuilder.() -> Unit): Domain
Link copied to clipboard
Link copied to clipboard
suspend fun eventHub(name: String, block: suspend EventHubResourceBuilder.() -> Unit): EventHub
Link copied to clipboard
suspend fun namespace(name: String, block: suspend NamespaceResourceBuilder.() -> Unit): Namespace
Link copied to clipboard
fun queue(name: String): Queue
suspend fun queue(name: String, block: suspend QueueResourceBuilder.() -> Unit): Queue
Link copied to clipboard
Link copied to clipboard
Link copied to clipboard
fun topic(name: String): Topic
suspend fun topic(name: String, block: suspend TopicResourceBuilder.() -> Unit): Topic