azure logo
Azure Classic v5.38.0, Mar 21 23

azure.eventhub.EventSubscription

Deprecated:

azure.eventhub.EventSubscription has been deprecated in favor of azure.eventgrid.EventSubscription

Manages an EventGrid Event Subscription

Example Usage

using System.Collections.Generic;
using Pulumi;
using Azure = Pulumi.Azure;

return await Deployment.RunAsync(() => 
{
    var exampleResourceGroup = new Azure.Core.ResourceGroup("exampleResourceGroup", new()
    {
        Location = "West Europe",
    });

    var exampleAccount = new Azure.Storage.Account("exampleAccount", new()
    {
        ResourceGroupName = exampleResourceGroup.Name,
        Location = exampleResourceGroup.Location,
        AccountTier = "Standard",
        AccountReplicationType = "LRS",
        Tags = 
        {
            { "environment", "staging" },
        },
    });

    var exampleQueue = new Azure.Storage.Queue("exampleQueue", new()
    {
        StorageAccountName = exampleAccount.Name,
    });

    var exampleEventSubscription = new Azure.EventGrid.EventSubscription("exampleEventSubscription", new()
    {
        Scope = exampleResourceGroup.Id,
        StorageQueueEndpoint = new Azure.EventGrid.Inputs.EventSubscriptionStorageQueueEndpointArgs
        {
            StorageAccountId = exampleAccount.Id,
            QueueName = exampleQueue.Name,
        },
    });

});
package main

import (
	"github.com/pulumi/pulumi-azure/sdk/v5/go/azure/core"
	"github.com/pulumi/pulumi-azure/sdk/v5/go/azure/eventgrid"
	"github.com/pulumi/pulumi-azure/sdk/v5/go/azure/storage"
	"github.com/pulumi/pulumi/sdk/v3/go/pulumi"
)

func main() {
	pulumi.Run(func(ctx *pulumi.Context) error {
		exampleResourceGroup, err := core.NewResourceGroup(ctx, "exampleResourceGroup", &core.ResourceGroupArgs{
			Location: pulumi.String("West Europe"),
		})
		if err != nil {
			return err
		}
		exampleAccount, err := storage.NewAccount(ctx, "exampleAccount", &storage.AccountArgs{
			ResourceGroupName:      exampleResourceGroup.Name,
			Location:               exampleResourceGroup.Location,
			AccountTier:            pulumi.String("Standard"),
			AccountReplicationType: pulumi.String("LRS"),
			Tags: pulumi.StringMap{
				"environment": pulumi.String("staging"),
			},
		})
		if err != nil {
			return err
		}
		exampleQueue, err := storage.NewQueue(ctx, "exampleQueue", &storage.QueueArgs{
			StorageAccountName: exampleAccount.Name,
		})
		if err != nil {
			return err
		}
		_, err = eventgrid.NewEventSubscription(ctx, "exampleEventSubscription", &eventgrid.EventSubscriptionArgs{
			Scope: exampleResourceGroup.ID(),
			StorageQueueEndpoint: &eventgrid.EventSubscriptionStorageQueueEndpointArgs{
				StorageAccountId: exampleAccount.ID(),
				QueueName:        exampleQueue.Name,
			},
		})
		if err != nil {
			return err
		}
		return nil
	})
}
package generated_program;

import com.pulumi.Context;
import com.pulumi.Pulumi;
import com.pulumi.core.Output;
import com.pulumi.azure.core.ResourceGroup;
import com.pulumi.azure.core.ResourceGroupArgs;
import com.pulumi.azure.storage.Account;
import com.pulumi.azure.storage.AccountArgs;
import com.pulumi.azure.storage.Queue;
import com.pulumi.azure.storage.QueueArgs;
import com.pulumi.azure.eventgrid.EventSubscription;
import com.pulumi.azure.eventgrid.EventSubscriptionArgs;
import com.pulumi.azure.eventgrid.inputs.EventSubscriptionStorageQueueEndpointArgs;
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", ResourceGroupArgs.builder()        
            .location("West Europe")
            .build());

        var exampleAccount = new Account("exampleAccount", AccountArgs.builder()        
            .resourceGroupName(exampleResourceGroup.name())
            .location(exampleResourceGroup.location())
            .accountTier("Standard")
            .accountReplicationType("LRS")
            .tags(Map.of("environment", "staging"))
            .build());

        var exampleQueue = new Queue("exampleQueue", QueueArgs.builder()        
            .storageAccountName(exampleAccount.name())
            .build());

        var exampleEventSubscription = new EventSubscription("exampleEventSubscription", EventSubscriptionArgs.builder()        
            .scope(exampleResourceGroup.id())
            .storageQueueEndpoint(EventSubscriptionStorageQueueEndpointArgs.builder()
                .storageAccountId(exampleAccount.id())
                .queueName(exampleQueue.name())
                .build())
            .build());

    }
}
import pulumi
import pulumi_azure as azure

example_resource_group = azure.core.ResourceGroup("exampleResourceGroup", location="West Europe")
example_account = azure.storage.Account("exampleAccount",
    resource_group_name=example_resource_group.name,
    location=example_resource_group.location,
    account_tier="Standard",
    account_replication_type="LRS",
    tags={
        "environment": "staging",
    })
example_queue = azure.storage.Queue("exampleQueue", storage_account_name=example_account.name)
example_event_subscription = azure.eventgrid.EventSubscription("exampleEventSubscription",
    scope=example_resource_group.id,
    storage_queue_endpoint=azure.eventgrid.EventSubscriptionStorageQueueEndpointArgs(
        storage_account_id=example_account.id,
        queue_name=example_queue.name,
    ))
import * as pulumi from "@pulumi/pulumi";
import * as azure from "@pulumi/azure";

const exampleResourceGroup = new azure.core.ResourceGroup("exampleResourceGroup", {location: "West Europe"});
const exampleAccount = new azure.storage.Account("exampleAccount", {
    resourceGroupName: exampleResourceGroup.name,
    location: exampleResourceGroup.location,
    accountTier: "Standard",
    accountReplicationType: "LRS",
    tags: {
        environment: "staging",
    },
});
const exampleQueue = new azure.storage.Queue("exampleQueue", {storageAccountName: exampleAccount.name});
const exampleEventSubscription = new azure.eventgrid.EventSubscription("exampleEventSubscription", {
    scope: exampleResourceGroup.id,
    storageQueueEndpoint: {
        storageAccountId: exampleAccount.id,
        queueName: exampleQueue.name,
    },
});
resources:
  exampleResourceGroup:
    type: azure:core:ResourceGroup
    properties:
      location: West Europe
  exampleAccount:
    type: azure:storage:Account
    properties:
      resourceGroupName: ${exampleResourceGroup.name}
      location: ${exampleResourceGroup.location}
      accountTier: Standard
      accountReplicationType: LRS
      tags:
        environment: staging
  exampleQueue:
    type: azure:storage:Queue
    properties:
      storageAccountName: ${exampleAccount.name}
  exampleEventSubscription:
    type: azure:eventgrid:EventSubscription
    properties:
      scope: ${exampleResourceGroup.id}
      storageQueueEndpoint:
        storageAccountId: ${exampleAccount.id}
        queueName: ${exampleQueue.name}

Create EventSubscription Resource

new EventSubscription(name: string, args: EventSubscriptionArgs, opts?: CustomResourceOptions);
@overload
def EventSubscription(resource_name: str,
                      opts: Optional[ResourceOptions] = None,
                      advanced_filter: Optional[EventSubscriptionAdvancedFilterArgs] = None,
                      advanced_filtering_on_arrays_enabled: Optional[bool] = None,
                      azure_function_endpoint: Optional[EventSubscriptionAzureFunctionEndpointArgs] = None,
                      dead_letter_identity: Optional[EventSubscriptionDeadLetterIdentityArgs] = None,
                      delivery_identity: Optional[EventSubscriptionDeliveryIdentityArgs] = None,
                      delivery_properties: Optional[Sequence[EventSubscriptionDeliveryPropertyArgs]] = None,
                      event_delivery_schema: Optional[str] = None,
                      eventhub_endpoint_id: Optional[str] = None,
                      expiration_time_utc: Optional[str] = None,
                      hybrid_connection_endpoint_id: Optional[str] = None,
                      included_event_types: Optional[Sequence[str]] = None,
                      labels: Optional[Sequence[str]] = None,
                      name: Optional[str] = None,
                      retry_policy: Optional[EventSubscriptionRetryPolicyArgs] = None,
                      scope: Optional[str] = None,
                      service_bus_queue_endpoint_id: Optional[str] = None,
                      service_bus_topic_endpoint_id: Optional[str] = None,
                      storage_blob_dead_letter_destination: Optional[EventSubscriptionStorageBlobDeadLetterDestinationArgs] = None,
                      storage_queue_endpoint: Optional[EventSubscriptionStorageQueueEndpointArgs] = None,
                      subject_filter: Optional[EventSubscriptionSubjectFilterArgs] = None,
                      webhook_endpoint: Optional[EventSubscriptionWebhookEndpointArgs] = None)
@overload
def EventSubscription(resource_name: str,
                      args: EventSubscriptionArgs,
                      opts: Optional[ResourceOptions] = None)
func NewEventSubscription(ctx *Context, name string, args EventSubscriptionArgs, opts ...ResourceOption) (*EventSubscription, error)
public EventSubscription(string name, EventSubscriptionArgs args, CustomResourceOptions? opts = null)
public EventSubscription(String name, EventSubscriptionArgs args)
public EventSubscription(String name, EventSubscriptionArgs args, CustomResourceOptions options)
type: azure:eventhub:EventSubscription
properties: # The arguments to resource properties.
options: # Bag of options to control resource's behavior.

name string
The unique name of the resource.
args EventSubscriptionArgs
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 EventSubscriptionArgs
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 EventSubscriptionArgs
The arguments to resource properties.
opts ResourceOption
Bag of options to control resource's behavior.
name string
The unique name of the resource.
args EventSubscriptionArgs
The arguments to resource properties.
opts CustomResourceOptions
Bag of options to control resource's behavior.
name String
The unique name of the resource.
args EventSubscriptionArgs
The arguments to resource properties.
options CustomResourceOptions
Bag of options to control resource's behavior.

EventSubscription Resource Properties

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

Inputs

The EventSubscription resource accepts the following input properties:

Scope string

Specifies the scope at which the EventGrid Event Subscription should be created. Changing this forces a new resource to be created.

AdvancedFilter EventSubscriptionAdvancedFilterArgs

A advanced_filter block as defined below.

AdvancedFilteringOnArraysEnabled bool

Specifies whether advanced filters should be evaluated against an array of values instead of expecting a singular value. Defaults to false.

AzureFunctionEndpoint EventSubscriptionAzureFunctionEndpointArgs

An azure_function_endpoint block as defined below.

DeadLetterIdentity EventSubscriptionDeadLetterIdentityArgs

A dead_letter_identity block as defined below.

DeliveryIdentity EventSubscriptionDeliveryIdentityArgs

A delivery_identity block as defined below.

DeliveryProperties List<EventSubscriptionDeliveryPropertyArgs>

One or more delivery_property blocks as defined below.

EventDeliverySchema string

Specifies the event delivery schema for the event subscription. Possible values include: EventGridSchema, CloudEventSchemaV1_0, CustomInputSchema. Defaults to EventGridSchema. Changing this forces a new resource to be created.

EventhubEndpointId string

Specifies the id where the Event Hub is located.

ExpirationTimeUtc string

Specifies the expiration time of the event subscription (Datetime Format RFC 3339).

HybridConnectionEndpointId string

Specifies the id where the Hybrid Connection is located.

IncludedEventTypes List<string>

A list of applicable event types that need to be part of the event subscription.

Labels List<string>

A list of labels to assign to the event subscription.

Name string

Specifies the name of the EventGrid Event Subscription resource. Changing this forces a new resource to be created.

RetryPolicy EventSubscriptionRetryPolicyArgs

A retry_policy block as defined below.

ServiceBusQueueEndpointId string

Specifies the id where the Service Bus Queue is located.

ServiceBusTopicEndpointId string

Specifies the id where the Service Bus Topic is located.

StorageBlobDeadLetterDestination EventSubscriptionStorageBlobDeadLetterDestinationArgs

A storage_blob_dead_letter_destination block as defined below.

StorageQueueEndpoint EventSubscriptionStorageQueueEndpointArgs

A storage_queue_endpoint block as defined below.

SubjectFilter EventSubscriptionSubjectFilterArgs

A subject_filter block as defined below.

WebhookEndpoint EventSubscriptionWebhookEndpointArgs

A webhook_endpoint block as defined below.

Scope string

Specifies the scope at which the EventGrid Event Subscription should be created. Changing this forces a new resource to be created.

AdvancedFilter EventSubscriptionAdvancedFilterArgs

A advanced_filter block as defined below.

AdvancedFilteringOnArraysEnabled bool

Specifies whether advanced filters should be evaluated against an array of values instead of expecting a singular value. Defaults to false.

AzureFunctionEndpoint EventSubscriptionAzureFunctionEndpointArgs

An azure_function_endpoint block as defined below.

DeadLetterIdentity EventSubscriptionDeadLetterIdentityArgs

A dead_letter_identity block as defined below.

DeliveryIdentity EventSubscriptionDeliveryIdentityArgs

A delivery_identity block as defined below.

DeliveryProperties []EventSubscriptionDeliveryPropertyArgs

One or more delivery_property blocks as defined below.

EventDeliverySchema string

Specifies the event delivery schema for the event subscription. Possible values include: EventGridSchema, CloudEventSchemaV1_0, CustomInputSchema. Defaults to EventGridSchema. Changing this forces a new resource to be created.

EventhubEndpointId string

Specifies the id where the Event Hub is located.

ExpirationTimeUtc string

Specifies the expiration time of the event subscription (Datetime Format RFC 3339).

HybridConnectionEndpointId string

Specifies the id where the Hybrid Connection is located.

IncludedEventTypes []string

A list of applicable event types that need to be part of the event subscription.

Labels []string

A list of labels to assign to the event subscription.

Name string

Specifies the name of the EventGrid Event Subscription resource. Changing this forces a new resource to be created.

RetryPolicy EventSubscriptionRetryPolicyArgs

A retry_policy block as defined below.

ServiceBusQueueEndpointId string

Specifies the id where the Service Bus Queue is located.

ServiceBusTopicEndpointId string

Specifies the id where the Service Bus Topic is located.

StorageBlobDeadLetterDestination EventSubscriptionStorageBlobDeadLetterDestinationArgs

A storage_blob_dead_letter_destination block as defined below.

StorageQueueEndpoint EventSubscriptionStorageQueueEndpointArgs

A storage_queue_endpoint block as defined below.

SubjectFilter EventSubscriptionSubjectFilterArgs

A subject_filter block as defined below.

WebhookEndpoint EventSubscriptionWebhookEndpointArgs

A webhook_endpoint block as defined below.

scope String

Specifies the scope at which the EventGrid Event Subscription should be created. Changing this forces a new resource to be created.

advancedFilter EventSubscriptionAdvancedFilterArgs

A advanced_filter block as defined below.

advancedFilteringOnArraysEnabled Boolean

Specifies whether advanced filters should be evaluated against an array of values instead of expecting a singular value. Defaults to false.

azureFunctionEndpoint EventSubscriptionAzureFunctionEndpointArgs

An azure_function_endpoint block as defined below.

deadLetterIdentity EventSubscriptionDeadLetterIdentityArgs

A dead_letter_identity block as defined below.

deliveryIdentity EventSubscriptionDeliveryIdentityArgs

A delivery_identity block as defined below.

deliveryProperties List<EventSubscriptionDeliveryPropertyArgs>

One or more delivery_property blocks as defined below.

eventDeliverySchema String

Specifies the event delivery schema for the event subscription. Possible values include: EventGridSchema, CloudEventSchemaV1_0, CustomInputSchema. Defaults to EventGridSchema. Changing this forces a new resource to be created.

eventhubEndpointId String

Specifies the id where the Event Hub is located.

expirationTimeUtc String

Specifies the expiration time of the event subscription (Datetime Format RFC 3339).

hybridConnectionEndpointId String

Specifies the id where the Hybrid Connection is located.

includedEventTypes List<String>

A list of applicable event types that need to be part of the event subscription.

labels List<String>

A list of labels to assign to the event subscription.

name String

Specifies the name of the EventGrid Event Subscription resource. Changing this forces a new resource to be created.

retryPolicy EventSubscriptionRetryPolicyArgs

A retry_policy block as defined below.

serviceBusQueueEndpointId String

Specifies the id where the Service Bus Queue is located.

serviceBusTopicEndpointId String

Specifies the id where the Service Bus Topic is located.

storageBlobDeadLetterDestination EventSubscriptionStorageBlobDeadLetterDestinationArgs

A storage_blob_dead_letter_destination block as defined below.

storageQueueEndpoint EventSubscriptionStorageQueueEndpointArgs

A storage_queue_endpoint block as defined below.

subjectFilter EventSubscriptionSubjectFilterArgs

A subject_filter block as defined below.

webhookEndpoint EventSubscriptionWebhookEndpointArgs

A webhook_endpoint block as defined below.

scope string

Specifies the scope at which the EventGrid Event Subscription should be created. Changing this forces a new resource to be created.

advancedFilter EventSubscriptionAdvancedFilterArgs

A advanced_filter block as defined below.

advancedFilteringOnArraysEnabled boolean

Specifies whether advanced filters should be evaluated against an array of values instead of expecting a singular value. Defaults to false.

azureFunctionEndpoint EventSubscriptionAzureFunctionEndpointArgs

An azure_function_endpoint block as defined below.

deadLetterIdentity EventSubscriptionDeadLetterIdentityArgs

A dead_letter_identity block as defined below.

deliveryIdentity EventSubscriptionDeliveryIdentityArgs

A delivery_identity block as defined below.

deliveryProperties EventSubscriptionDeliveryPropertyArgs[]

One or more delivery_property blocks as defined below.

eventDeliverySchema string

Specifies the event delivery schema for the event subscription. Possible values include: EventGridSchema, CloudEventSchemaV1_0, CustomInputSchema. Defaults to EventGridSchema. Changing this forces a new resource to be created.

eventhubEndpointId string

Specifies the id where the Event Hub is located.

expirationTimeUtc string

Specifies the expiration time of the event subscription (Datetime Format RFC 3339).

hybridConnectionEndpointId string

Specifies the id where the Hybrid Connection is located.

includedEventTypes string[]

A list of applicable event types that need to be part of the event subscription.

labels string[]

A list of labels to assign to the event subscription.

name string

Specifies the name of the EventGrid Event Subscription resource. Changing this forces a new resource to be created.

retryPolicy EventSubscriptionRetryPolicyArgs

A retry_policy block as defined below.

serviceBusQueueEndpointId string

Specifies the id where the Service Bus Queue is located.

serviceBusTopicEndpointId string

Specifies the id where the Service Bus Topic is located.

storageBlobDeadLetterDestination EventSubscriptionStorageBlobDeadLetterDestinationArgs

A storage_blob_dead_letter_destination block as defined below.

storageQueueEndpoint EventSubscriptionStorageQueueEndpointArgs

A storage_queue_endpoint block as defined below.

subjectFilter EventSubscriptionSubjectFilterArgs

A subject_filter block as defined below.

webhookEndpoint EventSubscriptionWebhookEndpointArgs

A webhook_endpoint block as defined below.

scope str

Specifies the scope at which the EventGrid Event Subscription should be created. Changing this forces a new resource to be created.

advanced_filter EventSubscriptionAdvancedFilterArgs

A advanced_filter block as defined below.

advanced_filtering_on_arrays_enabled bool

Specifies whether advanced filters should be evaluated against an array of values instead of expecting a singular value. Defaults to false.

azure_function_endpoint EventSubscriptionAzureFunctionEndpointArgs

An azure_function_endpoint block as defined below.

dead_letter_identity EventSubscriptionDeadLetterIdentityArgs

A dead_letter_identity block as defined below.

delivery_identity EventSubscriptionDeliveryIdentityArgs

A delivery_identity block as defined below.

delivery_properties Sequence[EventSubscriptionDeliveryPropertyArgs]

One or more delivery_property blocks as defined below.

event_delivery_schema str

Specifies the event delivery schema for the event subscription. Possible values include: EventGridSchema, CloudEventSchemaV1_0, CustomInputSchema. Defaults to EventGridSchema. Changing this forces a new resource to be created.

eventhub_endpoint_id str

Specifies the id where the Event Hub is located.

expiration_time_utc str

Specifies the expiration time of the event subscription (Datetime Format RFC 3339).

hybrid_connection_endpoint_id str

Specifies the id where the Hybrid Connection is located.

included_event_types Sequence[str]

A list of applicable event types that need to be part of the event subscription.

labels Sequence[str]

A list of labels to assign to the event subscription.

name str

Specifies the name of the EventGrid Event Subscription resource. Changing this forces a new resource to be created.

retry_policy EventSubscriptionRetryPolicyArgs

A retry_policy block as defined below.

service_bus_queue_endpoint_id str

Specifies the id where the Service Bus Queue is located.

service_bus_topic_endpoint_id str

Specifies the id where the Service Bus Topic is located.

storage_blob_dead_letter_destination EventSubscriptionStorageBlobDeadLetterDestinationArgs

A storage_blob_dead_letter_destination block as defined below.

storage_queue_endpoint EventSubscriptionStorageQueueEndpointArgs

A storage_queue_endpoint block as defined below.

subject_filter EventSubscriptionSubjectFilterArgs

A subject_filter block as defined below.

webhook_endpoint EventSubscriptionWebhookEndpointArgs

A webhook_endpoint block as defined below.

scope String

Specifies the scope at which the EventGrid Event Subscription should be created. Changing this forces a new resource to be created.

advancedFilter Property Map

A advanced_filter block as defined below.

advancedFilteringOnArraysEnabled Boolean

Specifies whether advanced filters should be evaluated against an array of values instead of expecting a singular value. Defaults to false.

azureFunctionEndpoint Property Map

An azure_function_endpoint block as defined below.

deadLetterIdentity Property Map

A dead_letter_identity block as defined below.

deliveryIdentity Property Map

A delivery_identity block as defined below.

deliveryProperties List<Property Map>

One or more delivery_property blocks as defined below.

eventDeliverySchema String

Specifies the event delivery schema for the event subscription. Possible values include: EventGridSchema, CloudEventSchemaV1_0, CustomInputSchema. Defaults to EventGridSchema. Changing this forces a new resource to be created.

eventhubEndpointId String

Specifies the id where the Event Hub is located.

expirationTimeUtc String

Specifies the expiration time of the event subscription (Datetime Format RFC 3339).

hybridConnectionEndpointId String

Specifies the id where the Hybrid Connection is located.

includedEventTypes List<String>

A list of applicable event types that need to be part of the event subscription.

labels List<String>

A list of labels to assign to the event subscription.

name String

Specifies the name of the EventGrid Event Subscription resource. Changing this forces a new resource to be created.

retryPolicy Property Map

A retry_policy block as defined below.

serviceBusQueueEndpointId String

Specifies the id where the Service Bus Queue is located.

serviceBusTopicEndpointId String

Specifies the id where the Service Bus Topic is located.

storageBlobDeadLetterDestination Property Map

A storage_blob_dead_letter_destination block as defined below.

storageQueueEndpoint Property Map

A storage_queue_endpoint block as defined below.

subjectFilter Property Map

A subject_filter block as defined below.

webhookEndpoint Property Map

A webhook_endpoint block as defined below.

Outputs

All input properties are implicitly available as output properties. Additionally, the EventSubscription 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 EventSubscription Resource

Get an existing EventSubscription 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?: EventSubscriptionState, opts?: CustomResourceOptions): EventSubscription
@staticmethod
def get(resource_name: str,
        id: str,
        opts: Optional[ResourceOptions] = None,
        advanced_filter: Optional[EventSubscriptionAdvancedFilterArgs] = None,
        advanced_filtering_on_arrays_enabled: Optional[bool] = None,
        azure_function_endpoint: Optional[EventSubscriptionAzureFunctionEndpointArgs] = None,
        dead_letter_identity: Optional[EventSubscriptionDeadLetterIdentityArgs] = None,
        delivery_identity: Optional[EventSubscriptionDeliveryIdentityArgs] = None,
        delivery_properties: Optional[Sequence[EventSubscriptionDeliveryPropertyArgs]] = None,
        event_delivery_schema: Optional[str] = None,
        eventhub_endpoint_id: Optional[str] = None,
        expiration_time_utc: Optional[str] = None,
        hybrid_connection_endpoint_id: Optional[str] = None,
        included_event_types: Optional[Sequence[str]] = None,
        labels: Optional[Sequence[str]] = None,
        name: Optional[str] = None,
        retry_policy: Optional[EventSubscriptionRetryPolicyArgs] = None,
        scope: Optional[str] = None,
        service_bus_queue_endpoint_id: Optional[str] = None,
        service_bus_topic_endpoint_id: Optional[str] = None,
        storage_blob_dead_letter_destination: Optional[EventSubscriptionStorageBlobDeadLetterDestinationArgs] = None,
        storage_queue_endpoint: Optional[EventSubscriptionStorageQueueEndpointArgs] = None,
        subject_filter: Optional[EventSubscriptionSubjectFilterArgs] = None,
        webhook_endpoint: Optional[EventSubscriptionWebhookEndpointArgs] = None) -> EventSubscription
func GetEventSubscription(ctx *Context, name string, id IDInput, state *EventSubscriptionState, opts ...ResourceOption) (*EventSubscription, error)
public static EventSubscription Get(string name, Input<string> id, EventSubscriptionState? state, CustomResourceOptions? opts = null)
public static EventSubscription get(String name, Output<String> id, EventSubscriptionState state, CustomResourceOptions options)
Resource lookup is not supported in YAML
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:
AdvancedFilter EventSubscriptionAdvancedFilterArgs

A advanced_filter block as defined below.

AdvancedFilteringOnArraysEnabled bool

Specifies whether advanced filters should be evaluated against an array of values instead of expecting a singular value. Defaults to false.

AzureFunctionEndpoint EventSubscriptionAzureFunctionEndpointArgs

An azure_function_endpoint block as defined below.

DeadLetterIdentity EventSubscriptionDeadLetterIdentityArgs

A dead_letter_identity block as defined below.

DeliveryIdentity EventSubscriptionDeliveryIdentityArgs

A delivery_identity block as defined below.

DeliveryProperties List<EventSubscriptionDeliveryPropertyArgs>

One or more delivery_property blocks as defined below.

EventDeliverySchema string

Specifies the event delivery schema for the event subscription. Possible values include: EventGridSchema, CloudEventSchemaV1_0, CustomInputSchema. Defaults to EventGridSchema. Changing this forces a new resource to be created.

EventhubEndpointId string

Specifies the id where the Event Hub is located.

ExpirationTimeUtc string

Specifies the expiration time of the event subscription (Datetime Format RFC 3339).

HybridConnectionEndpointId string

Specifies the id where the Hybrid Connection is located.

IncludedEventTypes List<string>

A list of applicable event types that need to be part of the event subscription.

Labels List<string>

A list of labels to assign to the event subscription.

Name string

Specifies the name of the EventGrid Event Subscription resource. Changing this forces a new resource to be created.

RetryPolicy EventSubscriptionRetryPolicyArgs

A retry_policy block as defined below.

Scope string

Specifies the scope at which the EventGrid Event Subscription should be created. Changing this forces a new resource to be created.

ServiceBusQueueEndpointId string

Specifies the id where the Service Bus Queue is located.

ServiceBusTopicEndpointId string

Specifies the id where the Service Bus Topic is located.

StorageBlobDeadLetterDestination EventSubscriptionStorageBlobDeadLetterDestinationArgs

A storage_blob_dead_letter_destination block as defined below.

StorageQueueEndpoint EventSubscriptionStorageQueueEndpointArgs

A storage_queue_endpoint block as defined below.

SubjectFilter EventSubscriptionSubjectFilterArgs

A subject_filter block as defined below.

WebhookEndpoint EventSubscriptionWebhookEndpointArgs

A webhook_endpoint block as defined below.

AdvancedFilter EventSubscriptionAdvancedFilterArgs

A advanced_filter block as defined below.

AdvancedFilteringOnArraysEnabled bool

Specifies whether advanced filters should be evaluated against an array of values instead of expecting a singular value. Defaults to false.

AzureFunctionEndpoint EventSubscriptionAzureFunctionEndpointArgs

An azure_function_endpoint block as defined below.

DeadLetterIdentity EventSubscriptionDeadLetterIdentityArgs

A dead_letter_identity block as defined below.

DeliveryIdentity EventSubscriptionDeliveryIdentityArgs

A delivery_identity block as defined below.

DeliveryProperties []EventSubscriptionDeliveryPropertyArgs

One or more delivery_property blocks as defined below.

EventDeliverySchema string

Specifies the event delivery schema for the event subscription. Possible values include: EventGridSchema, CloudEventSchemaV1_0, CustomInputSchema. Defaults to EventGridSchema. Changing this forces a new resource to be created.

EventhubEndpointId string

Specifies the id where the Event Hub is located.

ExpirationTimeUtc string

Specifies the expiration time of the event subscription (Datetime Format RFC 3339).

HybridConnectionEndpointId string

Specifies the id where the Hybrid Connection is located.

IncludedEventTypes []string

A list of applicable event types that need to be part of the event subscription.

Labels []string

A list of labels to assign to the event subscription.

Name string

Specifies the name of the EventGrid Event Subscription resource. Changing this forces a new resource to be created.

RetryPolicy EventSubscriptionRetryPolicyArgs

A retry_policy block as defined below.

Scope string

Specifies the scope at which the EventGrid Event Subscription should be created. Changing this forces a new resource to be created.

ServiceBusQueueEndpointId string

Specifies the id where the Service Bus Queue is located.

ServiceBusTopicEndpointId string

Specifies the id where the Service Bus Topic is located.

StorageBlobDeadLetterDestination EventSubscriptionStorageBlobDeadLetterDestinationArgs

A storage_blob_dead_letter_destination block as defined below.

StorageQueueEndpoint EventSubscriptionStorageQueueEndpointArgs

A storage_queue_endpoint block as defined below.

SubjectFilter EventSubscriptionSubjectFilterArgs

A subject_filter block as defined below.

WebhookEndpoint EventSubscriptionWebhookEndpointArgs

A webhook_endpoint block as defined below.

advancedFilter EventSubscriptionAdvancedFilterArgs

A advanced_filter block as defined below.

advancedFilteringOnArraysEnabled Boolean

Specifies whether advanced filters should be evaluated against an array of values instead of expecting a singular value. Defaults to false.

azureFunctionEndpoint EventSubscriptionAzureFunctionEndpointArgs

An azure_function_endpoint block as defined below.

deadLetterIdentity EventSubscriptionDeadLetterIdentityArgs

A dead_letter_identity block as defined below.

deliveryIdentity EventSubscriptionDeliveryIdentityArgs

A delivery_identity block as defined below.

deliveryProperties List<EventSubscriptionDeliveryPropertyArgs>

One or more delivery_property blocks as defined below.

eventDeliverySchema String

Specifies the event delivery schema for the event subscription. Possible values include: EventGridSchema, CloudEventSchemaV1_0, CustomInputSchema. Defaults to EventGridSchema. Changing this forces a new resource to be created.

eventhubEndpointId String

Specifies the id where the Event Hub is located.

expirationTimeUtc String

Specifies the expiration time of the event subscription (Datetime Format RFC 3339).

hybridConnectionEndpointId String

Specifies the id where the Hybrid Connection is located.

includedEventTypes List<String>

A list of applicable event types that need to be part of the event subscription.

labels List<String>

A list of labels to assign to the event subscription.

name String

Specifies the name of the EventGrid Event Subscription resource. Changing this forces a new resource to be created.

retryPolicy EventSubscriptionRetryPolicyArgs

A retry_policy block as defined below.

scope String

Specifies the scope at which the EventGrid Event Subscription should be created. Changing this forces a new resource to be created.

serviceBusQueueEndpointId String

Specifies the id where the Service Bus Queue is located.

serviceBusTopicEndpointId String

Specifies the id where the Service Bus Topic is located.

storageBlobDeadLetterDestination EventSubscriptionStorageBlobDeadLetterDestinationArgs

A storage_blob_dead_letter_destination block as defined below.

storageQueueEndpoint EventSubscriptionStorageQueueEndpointArgs

A storage_queue_endpoint block as defined below.

subjectFilter EventSubscriptionSubjectFilterArgs

A subject_filter block as defined below.

webhookEndpoint EventSubscriptionWebhookEndpointArgs

A webhook_endpoint block as defined below.

advancedFilter EventSubscriptionAdvancedFilterArgs

A advanced_filter block as defined below.

advancedFilteringOnArraysEnabled boolean

Specifies whether advanced filters should be evaluated against an array of values instead of expecting a singular value. Defaults to false.

azureFunctionEndpoint EventSubscriptionAzureFunctionEndpointArgs

An azure_function_endpoint block as defined below.

deadLetterIdentity EventSubscriptionDeadLetterIdentityArgs

A dead_letter_identity block as defined below.

deliveryIdentity EventSubscriptionDeliveryIdentityArgs

A delivery_identity block as defined below.

deliveryProperties EventSubscriptionDeliveryPropertyArgs[]

One or more delivery_property blocks as defined below.

eventDeliverySchema string

Specifies the event delivery schema for the event subscription. Possible values include: EventGridSchema, CloudEventSchemaV1_0, CustomInputSchema. Defaults to EventGridSchema. Changing this forces a new resource to be created.

eventhubEndpointId string

Specifies the id where the Event Hub is located.

expirationTimeUtc string

Specifies the expiration time of the event subscription (Datetime Format RFC 3339).

hybridConnectionEndpointId string

Specifies the id where the Hybrid Connection is located.

includedEventTypes string[]

A list of applicable event types that need to be part of the event subscription.

labels string[]

A list of labels to assign to the event subscription.

name string

Specifies the name of the EventGrid Event Subscription resource. Changing this forces a new resource to be created.

retryPolicy EventSubscriptionRetryPolicyArgs

A retry_policy block as defined below.

scope string

Specifies the scope at which the EventGrid Event Subscription should be created. Changing this forces a new resource to be created.

serviceBusQueueEndpointId string

Specifies the id where the Service Bus Queue is located.

serviceBusTopicEndpointId string

Specifies the id where the Service Bus Topic is located.

storageBlobDeadLetterDestination EventSubscriptionStorageBlobDeadLetterDestinationArgs

A storage_blob_dead_letter_destination block as defined below.

storageQueueEndpoint EventSubscriptionStorageQueueEndpointArgs

A storage_queue_endpoint block as defined below.

subjectFilter EventSubscriptionSubjectFilterArgs

A subject_filter block as defined below.

webhookEndpoint EventSubscriptionWebhookEndpointArgs

A webhook_endpoint block as defined below.

advanced_filter EventSubscriptionAdvancedFilterArgs

A advanced_filter block as defined below.

advanced_filtering_on_arrays_enabled bool

Specifies whether advanced filters should be evaluated against an array of values instead of expecting a singular value. Defaults to false.

azure_function_endpoint EventSubscriptionAzureFunctionEndpointArgs

An azure_function_endpoint block as defined below.

dead_letter_identity EventSubscriptionDeadLetterIdentityArgs

A dead_letter_identity block as defined below.

delivery_identity EventSubscriptionDeliveryIdentityArgs

A delivery_identity block as defined below.

delivery_properties Sequence[EventSubscriptionDeliveryPropertyArgs]

One or more delivery_property blocks as defined below.

event_delivery_schema str

Specifies the event delivery schema for the event subscription. Possible values include: EventGridSchema, CloudEventSchemaV1_0, CustomInputSchema. Defaults to EventGridSchema. Changing this forces a new resource to be created.

eventhub_endpoint_id str

Specifies the id where the Event Hub is located.

expiration_time_utc str

Specifies the expiration time of the event subscription (Datetime Format RFC 3339).

hybrid_connection_endpoint_id str

Specifies the id where the Hybrid Connection is located.

included_event_types Sequence[str]

A list of applicable event types that need to be part of the event subscription.

labels Sequence[str]

A list of labels to assign to the event subscription.

name str

Specifies the name of the EventGrid Event Subscription resource. Changing this forces a new resource to be created.

retry_policy EventSubscriptionRetryPolicyArgs

A retry_policy block as defined below.

scope str

Specifies the scope at which the EventGrid Event Subscription should be created. Changing this forces a new resource to be created.

service_bus_queue_endpoint_id str

Specifies the id where the Service Bus Queue is located.

service_bus_topic_endpoint_id str

Specifies the id where the Service Bus Topic is located.

storage_blob_dead_letter_destination EventSubscriptionStorageBlobDeadLetterDestinationArgs

A storage_blob_dead_letter_destination block as defined below.

storage_queue_endpoint EventSubscriptionStorageQueueEndpointArgs

A storage_queue_endpoint block as defined below.

subject_filter EventSubscriptionSubjectFilterArgs

A subject_filter block as defined below.

webhook_endpoint EventSubscriptionWebhookEndpointArgs

A webhook_endpoint block as defined below.

advancedFilter Property Map

A advanced_filter block as defined below.

advancedFilteringOnArraysEnabled Boolean

Specifies whether advanced filters should be evaluated against an array of values instead of expecting a singular value. Defaults to false.

azureFunctionEndpoint Property Map

An azure_function_endpoint block as defined below.

deadLetterIdentity Property Map

A dead_letter_identity block as defined below.

deliveryIdentity Property Map

A delivery_identity block as defined below.

deliveryProperties List<Property Map>

One or more delivery_property blocks as defined below.

eventDeliverySchema String

Specifies the event delivery schema for the event subscription. Possible values include: EventGridSchema, CloudEventSchemaV1_0, CustomInputSchema. Defaults to EventGridSchema. Changing this forces a new resource to be created.

eventhubEndpointId String

Specifies the id where the Event Hub is located.

expirationTimeUtc String

Specifies the expiration time of the event subscription (Datetime Format RFC 3339).

hybridConnectionEndpointId String

Specifies the id where the Hybrid Connection is located.

includedEventTypes List<String>

A list of applicable event types that need to be part of the event subscription.

labels List<String>

A list of labels to assign to the event subscription.

name String

Specifies the name of the EventGrid Event Subscription resource. Changing this forces a new resource to be created.

retryPolicy Property Map

A retry_policy block as defined below.

scope String

Specifies the scope at which the EventGrid Event Subscription should be created. Changing this forces a new resource to be created.

serviceBusQueueEndpointId String

Specifies the id where the Service Bus Queue is located.

serviceBusTopicEndpointId String

Specifies the id where the Service Bus Topic is located.

storageBlobDeadLetterDestination Property Map

A storage_blob_dead_letter_destination block as defined below.

storageQueueEndpoint Property Map

A storage_queue_endpoint block as defined below.

subjectFilter Property Map

A subject_filter block as defined below.

webhookEndpoint Property Map

A webhook_endpoint block as defined below.

Supporting Types

EventSubscriptionAdvancedFilter

BoolEquals List<EventSubscriptionAdvancedFilterBoolEqual>

Compares a value of an event using a single boolean value.

IsNotNulls List<EventSubscriptionAdvancedFilterIsNotNull>

Evaluates if a value of an event isn't NULL or undefined.

IsNullOrUndefineds List<EventSubscriptionAdvancedFilterIsNullOrUndefined>

Evaluates if a value of an event is NULL or undefined.

NumberGreaterThanOrEquals List<EventSubscriptionAdvancedFilterNumberGreaterThanOrEqual>

Compares a value of an event using a single floating point number.

NumberGreaterThans List<EventSubscriptionAdvancedFilterNumberGreaterThan>

Compares a value of an event using a single floating point number.

NumberInRanges List<EventSubscriptionAdvancedFilterNumberInRange>

Compares a value of an event using multiple floating point number ranges.

NumberIns List<EventSubscriptionAdvancedFilterNumberIn>

Compares a value of an event using multiple floating point numbers.

NumberLessThanOrEquals List<EventSubscriptionAdvancedFilterNumberLessThanOrEqual>

Compares a value of an event using a single floating point number.

NumberLessThans List<EventSubscriptionAdvancedFilterNumberLessThan>

Compares a value of an event using a single floating point number.

NumberNotInRanges List<EventSubscriptionAdvancedFilterNumberNotInRange>

Compares a value of an event using multiple floating point number ranges.

NumberNotIns List<EventSubscriptionAdvancedFilterNumberNotIn>

Compares a value of an event using multiple floating point numbers.

StringBeginsWiths List<EventSubscriptionAdvancedFilterStringBeginsWith>

Compares a value of an event using multiple string values.

StringContains List<EventSubscriptionAdvancedFilterStringContain>

Compares a value of an event using multiple string values.

StringEndsWiths List<EventSubscriptionAdvancedFilterStringEndsWith>

Compares a value of an event using multiple string values.

StringIns List<EventSubscriptionAdvancedFilterStringIn>

Compares a value of an event using multiple string values.

StringNotBeginsWiths List<EventSubscriptionAdvancedFilterStringNotBeginsWith>

Compares a value of an event using multiple string values.

StringNotContains List<EventSubscriptionAdvancedFilterStringNotContain>

Compares a value of an event using multiple string values.

StringNotEndsWiths List<EventSubscriptionAdvancedFilterStringNotEndsWith>

Compares a value of an event using multiple string values.

StringNotIns List<EventSubscriptionAdvancedFilterStringNotIn>

Compares a value of an event using multiple string values.

BoolEquals []EventSubscriptionAdvancedFilterBoolEqual

Compares a value of an event using a single boolean value.

IsNotNulls []EventSubscriptionAdvancedFilterIsNotNull

Evaluates if a value of an event isn't NULL or undefined.

IsNullOrUndefineds []EventSubscriptionAdvancedFilterIsNullOrUndefined

Evaluates if a value of an event is NULL or undefined.

NumberGreaterThanOrEquals []EventSubscriptionAdvancedFilterNumberGreaterThanOrEqual

Compares a value of an event using a single floating point number.

NumberGreaterThans []EventSubscriptionAdvancedFilterNumberGreaterThan

Compares a value of an event using a single floating point number.

NumberInRanges []EventSubscriptionAdvancedFilterNumberInRange

Compares a value of an event using multiple floating point number ranges.

NumberIns []EventSubscriptionAdvancedFilterNumberIn

Compares a value of an event using multiple floating point numbers.

NumberLessThanOrEquals []EventSubscriptionAdvancedFilterNumberLessThanOrEqual

Compares a value of an event using a single floating point number.

NumberLessThans []EventSubscriptionAdvancedFilterNumberLessThan

Compares a value of an event using a single floating point number.

NumberNotInRanges []EventSubscriptionAdvancedFilterNumberNotInRange

Compares a value of an event using multiple floating point number ranges.

NumberNotIns []EventSubscriptionAdvancedFilterNumberNotIn

Compares a value of an event using multiple floating point numbers.

StringBeginsWiths []EventSubscriptionAdvancedFilterStringBeginsWith

Compares a value of an event using multiple string values.

StringContains []EventSubscriptionAdvancedFilterStringContain

Compares a value of an event using multiple string values.

StringEndsWiths []EventSubscriptionAdvancedFilterStringEndsWith

Compares a value of an event using multiple string values.

StringIns []EventSubscriptionAdvancedFilterStringIn

Compares a value of an event using multiple string values.

StringNotBeginsWiths []EventSubscriptionAdvancedFilterStringNotBeginsWith

Compares a value of an event using multiple string values.

StringNotContains []EventSubscriptionAdvancedFilterStringNotContain

Compares a value of an event using multiple string values.

StringNotEndsWiths []EventSubscriptionAdvancedFilterStringNotEndsWith

Compares a value of an event using multiple string values.

StringNotIns []EventSubscriptionAdvancedFilterStringNotIn

Compares a value of an event using multiple string values.

boolEquals List<EventSubscriptionAdvancedFilterBoolEqual>

Compares a value of an event using a single boolean value.

isNotNulls List<EventSubscriptionAdvancedFilterIsNotNull>

Evaluates if a value of an event isn't NULL or undefined.

isNullOrUndefineds List<EventSubscriptionAdvancedFilterIsNullOrUndefined>

Evaluates if a value of an event is NULL or undefined.

numberGreaterThanOrEquals List<EventSubscriptionAdvancedFilterNumberGreaterThanOrEqual>

Compares a value of an event using a single floating point number.

numberGreaterThans List<EventSubscriptionAdvancedFilterNumberGreaterThan>

Compares a value of an event using a single floating point number.

numberInRanges List<EventSubscriptionAdvancedFilterNumberInRange>

Compares a value of an event using multiple floating point number ranges.

numberIns List<EventSubscriptionAdvancedFilterNumberIn>

Compares a value of an event using multiple floating point numbers.

numberLessThanOrEquals List<EventSubscriptionAdvancedFilterNumberLessThanOrEqual>

Compares a value of an event using a single floating point number.

numberLessThans List<EventSubscriptionAdvancedFilterNumberLessThan>

Compares a value of an event using a single floating point number.

numberNotInRanges List<EventSubscriptionAdvancedFilterNumberNotInRange>

Compares a value of an event using multiple floating point number ranges.

numberNotIns List<EventSubscriptionAdvancedFilterNumberNotIn>

Compares a value of an event using multiple floating point numbers.

stringBeginsWiths List<EventSubscriptionAdvancedFilterStringBeginsWith>

Compares a value of an event using multiple string values.

stringContains List<EventSubscriptionAdvancedFilterStringContain>

Compares a value of an event using multiple string values.

stringEndsWiths List<EventSubscriptionAdvancedFilterStringEndsWith>

Compares a value of an event using multiple string values.

stringIns List<EventSubscriptionAdvancedFilterStringIn>

Compares a value of an event using multiple string values.

stringNotBeginsWiths List<EventSubscriptionAdvancedFilterStringNotBeginsWith>

Compares a value of an event using multiple string values.

stringNotContains List<EventSubscriptionAdvancedFilterStringNotContain>

Compares a value of an event using multiple string values.

stringNotEndsWiths List<EventSubscriptionAdvancedFilterStringNotEndsWith>

Compares a value of an event using multiple string values.

stringNotIns List<EventSubscriptionAdvancedFilterStringNotIn>

Compares a value of an event using multiple string values.

boolEquals EventSubscriptionAdvancedFilterBoolEqual[]

Compares a value of an event using a single boolean value.

isNotNulls EventSubscriptionAdvancedFilterIsNotNull[]

Evaluates if a value of an event isn't NULL or undefined.

isNullOrUndefineds EventSubscriptionAdvancedFilterIsNullOrUndefined[]

Evaluates if a value of an event is NULL or undefined.

numberGreaterThanOrEquals EventSubscriptionAdvancedFilterNumberGreaterThanOrEqual[]

Compares a value of an event using a single floating point number.

numberGreaterThans EventSubscriptionAdvancedFilterNumberGreaterThan[]

Compares a value of an event using a single floating point number.

numberInRanges EventSubscriptionAdvancedFilterNumberInRange[]

Compares a value of an event using multiple floating point number ranges.

numberIns EventSubscriptionAdvancedFilterNumberIn[]

Compares a value of an event using multiple floating point numbers.

numberLessThanOrEquals EventSubscriptionAdvancedFilterNumberLessThanOrEqual[]

Compares a value of an event using a single floating point number.

numberLessThans EventSubscriptionAdvancedFilterNumberLessThan[]

Compares a value of an event using a single floating point number.

numberNotInRanges EventSubscriptionAdvancedFilterNumberNotInRange[]

Compares a value of an event using multiple floating point number ranges.

numberNotIns EventSubscriptionAdvancedFilterNumberNotIn[]

Compares a value of an event using multiple floating point numbers.

stringBeginsWiths EventSubscriptionAdvancedFilterStringBeginsWith[]

Compares a value of an event using multiple string values.

stringContains EventSubscriptionAdvancedFilterStringContain[]

Compares a value of an event using multiple string values.

stringEndsWiths EventSubscriptionAdvancedFilterStringEndsWith[]

Compares a value of an event using multiple string values.

stringIns EventSubscriptionAdvancedFilterStringIn[]

Compares a value of an event using multiple string values.

stringNotBeginsWiths EventSubscriptionAdvancedFilterStringNotBeginsWith[]

Compares a value of an event using multiple string values.

stringNotContains EventSubscriptionAdvancedFilterStringNotContain[]

Compares a value of an event using multiple string values.

stringNotEndsWiths EventSubscriptionAdvancedFilterStringNotEndsWith[]

Compares a value of an event using multiple string values.

stringNotIns EventSubscriptionAdvancedFilterStringNotIn[]

Compares a value of an event using multiple string values.

bool_equals Sequence[EventSubscriptionAdvancedFilterBoolEqual]

Compares a value of an event using a single boolean value.

is_not_nulls Sequence[EventSubscriptionAdvancedFilterIsNotNull]

Evaluates if a value of an event isn't NULL or undefined.

is_null_or_undefineds Sequence[EventSubscriptionAdvancedFilterIsNullOrUndefined]

Evaluates if a value of an event is NULL or undefined.

number_greater_than_or_equals Sequence[EventSubscriptionAdvancedFilterNumberGreaterThanOrEqual]

Compares a value of an event using a single floating point number.

number_greater_thans Sequence[EventSubscriptionAdvancedFilterNumberGreaterThan]

Compares a value of an event using a single floating point number.

number_in_ranges Sequence[EventSubscriptionAdvancedFilterNumberInRange]

Compares a value of an event using multiple floating point number ranges.

number_ins Sequence[EventSubscriptionAdvancedFilterNumberIn]

Compares a value of an event using multiple floating point numbers.

number_less_than_or_equals Sequence[EventSubscriptionAdvancedFilterNumberLessThanOrEqual]

Compares a value of an event using a single floating point number.

number_less_thans Sequence[EventSubscriptionAdvancedFilterNumberLessThan]

Compares a value of an event using a single floating point number.

number_not_in_ranges Sequence[EventSubscriptionAdvancedFilterNumberNotInRange]

Compares a value of an event using multiple floating point number ranges.

number_not_ins Sequence[EventSubscriptionAdvancedFilterNumberNotIn]

Compares a value of an event using multiple floating point numbers.

string_begins_withs Sequence[EventSubscriptionAdvancedFilterStringBeginsWith]

Compares a value of an event using multiple string values.

string_contains Sequence[EventSubscriptionAdvancedFilterStringContain]

Compares a value of an event using multiple string values.

string_ends_withs Sequence[EventSubscriptionAdvancedFilterStringEndsWith]

Compares a value of an event using multiple string values.

string_ins Sequence[EventSubscriptionAdvancedFilterStringIn]

Compares a value of an event using multiple string values.

string_not_begins_withs Sequence[EventSubscriptionAdvancedFilterStringNotBeginsWith]

Compares a value of an event using multiple string values.

string_not_contains Sequence[EventSubscriptionAdvancedFilterStringNotContain]

Compares a value of an event using multiple string values.

string_not_ends_withs Sequence[EventSubscriptionAdvancedFilterStringNotEndsWith]

Compares a value of an event using multiple string values.

string_not_ins Sequence[EventSubscriptionAdvancedFilterStringNotIn]

Compares a value of an event using multiple string values.

boolEquals List<Property Map>

Compares a value of an event using a single boolean value.

isNotNulls List<Property Map>

Evaluates if a value of an event isn't NULL or undefined.

isNullOrUndefineds List<Property Map>

Evaluates if a value of an event is NULL or undefined.

numberGreaterThanOrEquals List<Property Map>

Compares a value of an event using a single floating point number.

numberGreaterThans List<Property Map>

Compares a value of an event using a single floating point number.

numberInRanges List<Property Map>

Compares a value of an event using multiple floating point number ranges.

numberIns List<Property Map>

Compares a value of an event using multiple floating point numbers.

numberLessThanOrEquals List<Property Map>

Compares a value of an event using a single floating point number.

numberLessThans List<Property Map>

Compares a value of an event using a single floating point number.

numberNotInRanges List<Property Map>

Compares a value of an event using multiple floating point number ranges.

numberNotIns List<Property Map>

Compares a value of an event using multiple floating point numbers.

stringBeginsWiths List<Property Map>

Compares a value of an event using multiple string values.

stringContains List<Property Map>

Compares a value of an event using multiple string values.

stringEndsWiths List<Property Map>

Compares a value of an event using multiple string values.

stringIns List<Property Map>

Compares a value of an event using multiple string values.

stringNotBeginsWiths List<Property Map>

Compares a value of an event using multiple string values.

stringNotContains List<Property Map>

Compares a value of an event using multiple string values.

stringNotEndsWiths List<Property Map>

Compares a value of an event using multiple string values.

stringNotIns List<Property Map>

Compares a value of an event using multiple string values.

EventSubscriptionAdvancedFilterBoolEqual

Key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

Value bool

Specifies a single value to compare to when using a single value operator.

Key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

Value bool

Specifies a single value to compare to when using a single value operator.

key String

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

value Boolean

Specifies a single value to compare to when using a single value operator.

key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

value boolean

Specifies a single value to compare to when using a single value operator.

key str

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

value bool

Specifies a single value to compare to when using a single value operator.

key String

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

value Boolean

Specifies a single value to compare to when using a single value operator.

EventSubscriptionAdvancedFilterIsNotNull

Key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

Key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

key String

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

key str

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

key String

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

EventSubscriptionAdvancedFilterIsNullOrUndefined

Key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

Key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

key String

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

key str

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

key String

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

EventSubscriptionAdvancedFilterNumberGreaterThan

Key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

Value double

Specifies a single value to compare to when using a single value operator.

Key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

Value float64

Specifies a single value to compare to when using a single value operator.

key String

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

value Double

Specifies a single value to compare to when using a single value operator.

key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

value number

Specifies a single value to compare to when using a single value operator.

key str

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

value float

Specifies a single value to compare to when using a single value operator.

key String

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

value Number

Specifies a single value to compare to when using a single value operator.

EventSubscriptionAdvancedFilterNumberGreaterThanOrEqual

Key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

Value double

Specifies a single value to compare to when using a single value operator.

Key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

Value float64

Specifies a single value to compare to when using a single value operator.

key String

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

value Double

Specifies a single value to compare to when using a single value operator.

key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

value number

Specifies a single value to compare to when using a single value operator.

key str

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

value float

Specifies a single value to compare to when using a single value operator.

key String

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

value Number

Specifies a single value to compare to when using a single value operator.

EventSubscriptionAdvancedFilterNumberIn

Key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

Values List<double>

Specifies an array of values to compare to when using a multiple values operator.

Key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

Values []float64

Specifies an array of values to compare to when using a multiple values operator.

key String

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

values List<Double>

Specifies an array of values to compare to when using a multiple values operator.

key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

values number[]

Specifies an array of values to compare to when using a multiple values operator.

key str

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

values Sequence[float]

Specifies an array of values to compare to when using a multiple values operator.

key String

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

values List<Number>

Specifies an array of values to compare to when using a multiple values operator.

EventSubscriptionAdvancedFilterNumberInRange

Key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

Values List<ImmutableArray<double>>

Specifies an array of values to compare to when using a multiple values operator.

Key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

Values [][]float64

Specifies an array of values to compare to when using a multiple values operator.

key String

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

values List<List<Double>>

Specifies an array of values to compare to when using a multiple values operator.

key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

values number[][]

Specifies an array of values to compare to when using a multiple values operator.

key str

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

values Sequence[Sequence[float]]

Specifies an array of values to compare to when using a multiple values operator.

key String

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

values List<List<Number>>

Specifies an array of values to compare to when using a multiple values operator.

EventSubscriptionAdvancedFilterNumberLessThan

Key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

Value double

Specifies a single value to compare to when using a single value operator.

Key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

Value float64

Specifies a single value to compare to when using a single value operator.

key String

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

value Double

Specifies a single value to compare to when using a single value operator.

key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

value number

Specifies a single value to compare to when using a single value operator.

key str

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

value float

Specifies a single value to compare to when using a single value operator.

key String

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

value Number

Specifies a single value to compare to when using a single value operator.

EventSubscriptionAdvancedFilterNumberLessThanOrEqual

Key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

Value double

Specifies a single value to compare to when using a single value operator.

Key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

Value float64

Specifies a single value to compare to when using a single value operator.

key String

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

value Double

Specifies a single value to compare to when using a single value operator.

key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

value number

Specifies a single value to compare to when using a single value operator.

key str

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

value float

Specifies a single value to compare to when using a single value operator.

key String

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

value Number

Specifies a single value to compare to when using a single value operator.

EventSubscriptionAdvancedFilterNumberNotIn

Key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

Values List<double>

Specifies an array of values to compare to when using a multiple values operator.

Key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

Values []float64

Specifies an array of values to compare to when using a multiple values operator.

key String

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

values List<Double>

Specifies an array of values to compare to when using a multiple values operator.

key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

values number[]

Specifies an array of values to compare to when using a multiple values operator.

key str

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

values Sequence[float]

Specifies an array of values to compare to when using a multiple values operator.

key String

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

values List<Number>

Specifies an array of values to compare to when using a multiple values operator.

EventSubscriptionAdvancedFilterNumberNotInRange

Key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

Values List<ImmutableArray<double>>

Specifies an array of values to compare to when using a multiple values operator.

Key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

Values [][]float64

Specifies an array of values to compare to when using a multiple values operator.

key String

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

values List<List<Double>>

Specifies an array of values to compare to when using a multiple values operator.

key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

values number[][]

Specifies an array of values to compare to when using a multiple values operator.

key str

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

values Sequence[Sequence[float]]

Specifies an array of values to compare to when using a multiple values operator.

key String

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

values List<List<Number>>

Specifies an array of values to compare to when using a multiple values operator.

EventSubscriptionAdvancedFilterStringBeginsWith

Key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

Values List<string>

Specifies an array of values to compare to when using a multiple values operator.

Key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

Values []string

Specifies an array of values to compare to when using a multiple values operator.

key String

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

values List<String>

Specifies an array of values to compare to when using a multiple values operator.

key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

values string[]

Specifies an array of values to compare to when using a multiple values operator.

key str

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

values Sequence[str]

Specifies an array of values to compare to when using a multiple values operator.

key String

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

values List<String>

Specifies an array of values to compare to when using a multiple values operator.

EventSubscriptionAdvancedFilterStringContain

Key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

Values List<string>

Specifies an array of values to compare to when using a multiple values operator.

Key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

Values []string

Specifies an array of values to compare to when using a multiple values operator.

key String

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

values List<String>

Specifies an array of values to compare to when using a multiple values operator.

key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

values string[]

Specifies an array of values to compare to when using a multiple values operator.

key str

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

values Sequence[str]

Specifies an array of values to compare to when using a multiple values operator.

key String

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

values List<String>

Specifies an array of values to compare to when using a multiple values operator.

EventSubscriptionAdvancedFilterStringEndsWith

Key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

Values List<string>

Specifies an array of values to compare to when using a multiple values operator.

Key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

Values []string

Specifies an array of values to compare to when using a multiple values operator.

key String

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

values List<String>

Specifies an array of values to compare to when using a multiple values operator.

key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

values string[]

Specifies an array of values to compare to when using a multiple values operator.

key str

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

values Sequence[str]

Specifies an array of values to compare to when using a multiple values operator.

key String

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

values List<String>

Specifies an array of values to compare to when using a multiple values operator.

EventSubscriptionAdvancedFilterStringIn

Key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

Values List<string>

Specifies an array of values to compare to when using a multiple values operator.

Key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

Values []string

Specifies an array of values to compare to when using a multiple values operator.

key String

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

values List<String>

Specifies an array of values to compare to when using a multiple values operator.

key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

values string[]

Specifies an array of values to compare to when using a multiple values operator.

key str

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

values Sequence[str]

Specifies an array of values to compare to when using a multiple values operator.

key String

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

values List<String>

Specifies an array of values to compare to when using a multiple values operator.

EventSubscriptionAdvancedFilterStringNotBeginsWith

Key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

Values List<string>

Specifies an array of values to compare to when using a multiple values operator.

Key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

Values []string

Specifies an array of values to compare to when using a multiple values operator.

key String

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

values List<String>

Specifies an array of values to compare to when using a multiple values operator.

key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

values string[]

Specifies an array of values to compare to when using a multiple values operator.

key str

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

values Sequence[str]

Specifies an array of values to compare to when using a multiple values operator.

key String

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

values List<String>

Specifies an array of values to compare to when using a multiple values operator.

EventSubscriptionAdvancedFilterStringNotContain

Key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

Values List<string>

Specifies an array of values to compare to when using a multiple values operator.

Key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

Values []string

Specifies an array of values to compare to when using a multiple values operator.

key String

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

values List<String>

Specifies an array of values to compare to when using a multiple values operator.

key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

values string[]

Specifies an array of values to compare to when using a multiple values operator.

key str

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

values Sequence[str]

Specifies an array of values to compare to when using a multiple values operator.

key String

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

values List<String>

Specifies an array of values to compare to when using a multiple values operator.

EventSubscriptionAdvancedFilterStringNotEndsWith

Key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

Values List<string>

Specifies an array of values to compare to when using a multiple values operator.

Key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

Values []string

Specifies an array of values to compare to when using a multiple values operator.

key String

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

values List<String>

Specifies an array of values to compare to when using a multiple values operator.

key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

values string[]

Specifies an array of values to compare to when using a multiple values operator.

key str

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

values Sequence[str]

Specifies an array of values to compare to when using a multiple values operator.

key String

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

values List<String>

Specifies an array of values to compare to when using a multiple values operator.

EventSubscriptionAdvancedFilterStringNotIn

Key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

Values List<string>

Specifies an array of values to compare to when using a multiple values operator.

Key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

Values []string

Specifies an array of values to compare to when using a multiple values operator.

key String

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

values List<String>

Specifies an array of values to compare to when using a multiple values operator.

key string

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

values string[]

Specifies an array of values to compare to when using a multiple values operator.

key str

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

values Sequence[str]

Specifies an array of values to compare to when using a multiple values operator.

key String

Specifies the field within the event data that you want to use for filtering. Type of the field can be a number, boolean, or string.

values List<String>

Specifies an array of values to compare to when using a multiple values operator.

EventSubscriptionAzureFunctionEndpoint

FunctionId string

Specifies the ID of the Function where the Event Subscription will receive events. This must be the functions ID in format {function_app.id}/functions/{name}.

MaxEventsPerBatch int

Maximum number of events per batch.

PreferredBatchSizeInKilobytes int

Preferred batch size in Kilobytes.

FunctionId string

Specifies the ID of the Function where the Event Subscription will receive events. This must be the functions ID in format {function_app.id}/functions/{name}.

MaxEventsPerBatch int

Maximum number of events per batch.

PreferredBatchSizeInKilobytes int

Preferred batch size in Kilobytes.

functionId String

Specifies the ID of the Function where the Event Subscription will receive events. This must be the functions ID in format {function_app.id}/functions/{name}.

maxEventsPerBatch Integer

Maximum number of events per batch.

preferredBatchSizeInKilobytes Integer

Preferred batch size in Kilobytes.

functionId string

Specifies the ID of the Function where the Event Subscription will receive events. This must be the functions ID in format {function_app.id}/functions/{name}.

maxEventsPerBatch number

Maximum number of events per batch.

preferredBatchSizeInKilobytes number

Preferred batch size in Kilobytes.

function_id str

Specifies the ID of the Function where the Event Subscription will receive events. This must be the functions ID in format {function_app.id}/functions/{name}.

max_events_per_batch int

Maximum number of events per batch.

preferred_batch_size_in_kilobytes int

Preferred batch size in Kilobytes.

functionId String

Specifies the ID of the Function where the Event Subscription will receive events. This must be the functions ID in format {function_app.id}/functions/{name}.

maxEventsPerBatch Number

Maximum number of events per batch.

preferredBatchSizeInKilobytes Number

Preferred batch size in Kilobytes.

EventSubscriptionDeadLetterIdentity

Type string

Specifies the type of Managed Service Identity that is used for dead lettering. Allowed value is SystemAssigned, UserAssigned.

UserAssignedIdentity string

The user identity associated with the resource.

Type string

Specifies the type of Managed Service Identity that is used for dead lettering. Allowed value is SystemAssigned, UserAssigned.

UserAssignedIdentity string

The user identity associated with the resource.

type String

Specifies the type of Managed Service Identity that is used for dead lettering. Allowed value is SystemAssigned, UserAssigned.

userAssignedIdentity String

The user identity associated with the resource.

type string

Specifies the type of Managed Service Identity that is used for dead lettering. Allowed value is SystemAssigned, UserAssigned.

userAssignedIdentity string

The user identity associated with the resource.

type str

Specifies the type of Managed Service Identity that is used for dead lettering. Allowed value is SystemAssigned, UserAssigned.

user_assigned_identity str

The user identity associated with the resource.

type String

Specifies the type of Managed Service Identity that is used for dead lettering. Allowed value is SystemAssigned, UserAssigned.

userAssignedIdentity String

The user identity associated with the resource.

EventSubscriptionDeliveryIdentity

Type string

Specifies the type of Managed Service Identity that is used for event delivery. Allowed value is SystemAssigned, UserAssigned.

UserAssignedIdentity string

The user identity associated with the resource.

Type string

Specifies the type of Managed Service Identity that is used for event delivery. Allowed value is SystemAssigned, UserAssigned.

UserAssignedIdentity string

The user identity associated with the resource.

type String

Specifies the type of Managed Service Identity that is used for event delivery. Allowed value is SystemAssigned, UserAssigned.

userAssignedIdentity String

The user identity associated with the resource.

type string

Specifies the type of Managed Service Identity that is used for event delivery. Allowed value is SystemAssigned, UserAssigned.

userAssignedIdentity string

The user identity associated with the resource.

type str

Specifies the type of Managed Service Identity that is used for event delivery. Allowed value is SystemAssigned, UserAssigned.

user_assigned_identity str

The user identity associated with the resource.

type String

Specifies the type of Managed Service Identity that is used for event delivery. Allowed value is SystemAssigned, UserAssigned.

userAssignedIdentity String

The user identity associated with the resource.

EventSubscriptionDeliveryProperty

HeaderName string

The name of the header to send on to the destination

Type string

Either Static or Dynamic

Secret bool

True if the value is a secret and should be protected, otherwise false. If True, then this value won't be returned from Azure API calls

SourceField string

If the type is Dynamic, then provide the payload field to be used as the value. Valid source fields differ by subscription type.

Value string

If the type is Static, then provide the value to use

HeaderName string

The name of the header to send on to the destination

Type string

Either Static or Dynamic

Secret bool

True if the value is a secret and should be protected, otherwise false. If True, then this value won't be returned from Azure API calls

SourceField string

If the type is Dynamic, then provide the payload field to be used as the value. Valid source fields differ by subscription type.

Value string

If the type is Static, then provide the value to use

headerName String

The name of the header to send on to the destination

type String

Either Static or Dynamic

secret Boolean

True if the value is a secret and should be protected, otherwise false. If True, then this value won't be returned from Azure API calls

sourceField String

If the type is Dynamic, then provide the payload field to be used as the value. Valid source fields differ by subscription type.

value String

If the type is Static, then provide the value to use

headerName string

The name of the header to send on to the destination

type string

Either Static or Dynamic

secret boolean

True if the value is a secret and should be protected, otherwise false. If True, then this value won't be returned from Azure API calls

sourceField string

If the type is Dynamic, then provide the payload field to be used as the value. Valid source fields differ by subscription type.

value string

If the type is Static, then provide the value to use

header_name str

The name of the header to send on to the destination

type str

Either Static or Dynamic

secret bool

True if the value is a secret and should be protected, otherwise false. If True, then this value won't be returned from Azure API calls

source_field str

If the type is Dynamic, then provide the payload field to be used as the value. Valid source fields differ by subscription type.

value str

If the type is Static, then provide the value to use

headerName String

The name of the header to send on to the destination

type String

Either Static or Dynamic

secret Boolean

True if the value is a secret and should be protected, otherwise false. If True, then this value won't be returned from Azure API calls

sourceField String

If the type is Dynamic, then provide the payload field to be used as the value. Valid source fields differ by subscription type.

value String

If the type is Static, then provide the value to use

EventSubscriptionRetryPolicy

EventTimeToLive int

Specifies the time to live (in minutes) for events. Supported range is 1 to 1440. See official documentation for more details.

MaxDeliveryAttempts int

Specifies the maximum number of delivery retry attempts for events.

EventTimeToLive int

Specifies the time to live (in minutes) for events. Supported range is 1 to 1440. See official documentation for more details.

MaxDeliveryAttempts int

Specifies the maximum number of delivery retry attempts for events.

eventTimeToLive Integer

Specifies the time to live (in minutes) for events. Supported range is 1 to 1440. See official documentation for more details.

maxDeliveryAttempts Integer

Specifies the maximum number of delivery retry attempts for events.

eventTimeToLive number

Specifies the time to live (in minutes) for events. Supported range is 1 to 1440. See official documentation for more details.

maxDeliveryAttempts number

Specifies the maximum number of delivery retry attempts for events.

event_time_to_live int

Specifies the time to live (in minutes) for events. Supported range is 1 to 1440. See official documentation for more details.

max_delivery_attempts int

Specifies the maximum number of delivery retry attempts for events.

eventTimeToLive Number

Specifies the time to live (in minutes) for events. Supported range is 1 to 1440. See official documentation for more details.

maxDeliveryAttempts Number

Specifies the maximum number of delivery retry attempts for events.

EventSubscriptionStorageBlobDeadLetterDestination

StorageAccountId string

Specifies the id of the storage account id where the storage blob is located.

StorageBlobContainerName string

Specifies the name of the Storage blob container that is the destination of the deadletter events.

StorageAccountId string

Specifies the id of the storage account id where the storage blob is located.

StorageBlobContainerName string

Specifies the name of the Storage blob container that is the destination of the deadletter events.

storageAccountId String

Specifies the id of the storage account id where the storage blob is located.

storageBlobContainerName String

Specifies the name of the Storage blob container that is the destination of the deadletter events.

storageAccountId string

Specifies the id of the storage account id where the storage blob is located.

storageBlobContainerName string

Specifies the name of the Storage blob container that is the destination of the deadletter events.

storage_account_id str

Specifies the id of the storage account id where the storage blob is located.

storage_blob_container_name str

Specifies the name of the Storage blob container that is the destination of the deadletter events.

storageAccountId String

Specifies the id of the storage account id where the storage blob is located.

storageBlobContainerName String

Specifies the name of the Storage blob container that is the destination of the deadletter events.

EventSubscriptionStorageQueueEndpoint

QueueName string

Specifies the name of the storage queue where the Event Subscription will receive events.

StorageAccountId string

Specifies the id of the storage account id where the storage queue is located.

QueueMessageTimeToLiveInSeconds int

Storage queue message time to live in seconds.

QueueName string

Specifies the name of the storage queue where the Event Subscription will receive events.

StorageAccountId string

Specifies the id of the storage account id where the storage queue is located.

QueueMessageTimeToLiveInSeconds int

Storage queue message time to live in seconds.

queueName String

Specifies the name of the storage queue where the Event Subscription will receive events.

storageAccountId String

Specifies the id of the storage account id where the storage queue is located.

queueMessageTimeToLiveInSeconds Integer

Storage queue message time to live in seconds.

queueName string

Specifies the name of the storage queue where the Event Subscription will receive events.

storageAccountId string

Specifies the id of the storage account id where the storage queue is located.

queueMessageTimeToLiveInSeconds number

Storage queue message time to live in seconds.

queue_name str

Specifies the name of the storage queue where the Event Subscription will receive events.

storage_account_id str

Specifies the id of the storage account id where the storage queue is located.

queue_message_time_to_live_in_seconds int

Storage queue message time to live in seconds.

queueName String

Specifies the name of the storage queue where the Event Subscription will receive events.

storageAccountId String

Specifies the id of the storage account id where the storage queue is located.

queueMessageTimeToLiveInSeconds Number

Storage queue message time to live in seconds.

EventSubscriptionSubjectFilter

CaseSensitive bool

Specifies if subject_begins_with and subject_ends_with case sensitive. This value

SubjectBeginsWith string

A string to filter events for an event subscription based on a resource path prefix.

SubjectEndsWith string

A string to filter events for an event subscription based on a resource path suffix.

CaseSensitive bool

Specifies if subject_begins_with and subject_ends_with case sensitive. This value

SubjectBeginsWith string

A string to filter events for an event subscription based on a resource path prefix.

SubjectEndsWith string

A string to filter events for an event subscription based on a resource path suffix.

caseSensitive Boolean

Specifies if subject_begins_with and subject_ends_with case sensitive. This value

subjectBeginsWith String

A string to filter events for an event subscription based on a resource path prefix.

subjectEndsWith String

A string to filter events for an event subscription based on a resource path suffix.

caseSensitive boolean

Specifies if subject_begins_with and subject_ends_with case sensitive. This value

subjectBeginsWith string

A string to filter events for an event subscription based on a resource path prefix.

subjectEndsWith string

A string to filter events for an event subscription based on a resource path suffix.

case_sensitive bool

Specifies if subject_begins_with and subject_ends_with case sensitive. This value

subject_begins_with str

A string to filter events for an event subscription based on a resource path prefix.

subject_ends_with str

A string to filter events for an event subscription based on a resource path suffix.

caseSensitive Boolean

Specifies if subject_begins_with and subject_ends_with case sensitive. This value

subjectBeginsWith String

A string to filter events for an event subscription based on a resource path prefix.

subjectEndsWith String

A string to filter events for an event subscription based on a resource path suffix.

EventSubscriptionWebhookEndpoint

Url string

Specifies the url of the webhook where the Event Subscription will receive events.

ActiveDirectoryAppIdOrUri string

The Azure Active Directory Application ID or URI to get the access token that will be included as the bearer token in delivery requests.

ActiveDirectoryTenantId string

The Azure Active Directory Tenant ID to get the access token that will be included as the bearer token in delivery requests.

BaseUrl string

The base url of the webhook where the Event Subscription will receive events.

MaxEventsPerBatch int

Maximum number of events per batch.

PreferredBatchSizeInKilobytes int

Preferred batch size in Kilobytes.

Url string

Specifies the url of the webhook where the Event Subscription will receive events.

ActiveDirectoryAppIdOrUri string

The Azure Active Directory Application ID or URI to get the access token that will be included as the bearer token in delivery requests.

ActiveDirectoryTenantId string

The Azure Active Directory Tenant ID to get the access token that will be included as the bearer token in delivery requests.

BaseUrl string

The base url of the webhook where the Event Subscription will receive events.

MaxEventsPerBatch int

Maximum number of events per batch.

PreferredBatchSizeInKilobytes int

Preferred batch size in Kilobytes.

url String

Specifies the url of the webhook where the Event Subscription will receive events.

activeDirectoryAppIdOrUri String

The Azure Active Directory Application ID or URI to get the access token that will be included as the bearer token in delivery requests.

activeDirectoryTenantId String

The Azure Active Directory Tenant ID to get the access token that will be included as the bearer token in delivery requests.

baseUrl String

The base url of the webhook where the Event Subscription will receive events.

maxEventsPerBatch Integer

Maximum number of events per batch.

preferredBatchSizeInKilobytes Integer

Preferred batch size in Kilobytes.

url string

Specifies the url of the webhook where the Event Subscription will receive events.

activeDirectoryAppIdOrUri string

The Azure Active Directory Application ID or URI to get the access token that will be included as the bearer token in delivery requests.

activeDirectoryTenantId string

The Azure Active Directory Tenant ID to get the access token that will be included as the bearer token in delivery requests.

baseUrl string

The base url of the webhook where the Event Subscription will receive events.

maxEventsPerBatch number

Maximum number of events per batch.

preferredBatchSizeInKilobytes number

Preferred batch size in Kilobytes.

url str

Specifies the url of the webhook where the Event Subscription will receive events.

active_directory_app_id_or_uri str

The Azure Active Directory Application ID or URI to get the access token that will be included as the bearer token in delivery requests.

active_directory_tenant_id str

The Azure Active Directory Tenant ID to get the access token that will be included as the bearer token in delivery requests.

base_url str

The base url of the webhook where the Event Subscription will receive events.

max_events_per_batch int

Maximum number of events per batch.

preferred_batch_size_in_kilobytes int

Preferred batch size in Kilobytes.

url String

Specifies the url of the webhook where the Event Subscription will receive events.

activeDirectoryAppIdOrUri String

The Azure Active Directory Application ID or URI to get the access token that will be included as the bearer token in delivery requests.

activeDirectoryTenantId String

The Azure Active Directory Tenant ID to get the access token that will be included as the bearer token in delivery requests.

baseUrl String

The base url of the webhook where the Event Subscription will receive events.

maxEventsPerBatch Number

Maximum number of events per batch.

preferredBatchSizeInKilobytes Number

Preferred batch size in Kilobytes.

Import

EventGrid Event Subscription’s can be imported using the resource id, e.g.

 $ pulumi import azure:eventhub/eventSubscription:EventSubscription eventSubscription1 /subscriptions/00000000-0000-0000-0000-000000000000/resourceGroups/group1/providers/Microsoft.EventGrid/topics/topic1/providers/Microsoft.EventGrid/eventSubscriptions/eventSubscription1

Package Details

Repository
Azure Classic pulumi/pulumi-azure
License
Apache-2.0
Notes

This Pulumi package is based on the azurerm Terraform Provider.