azure logo
Azure Classic v5.38.0, Mar 21 23

azure.eventhub.EventHub

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

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 exampleEventHubNamespace = new Azure.EventHub.EventHubNamespace("exampleEventHubNamespace", new()
    {
        Location = exampleResourceGroup.Location,
        ResourceGroupName = exampleResourceGroup.Name,
        Sku = "Standard",
        Capacity = 1,
        Tags = 
        {
            { "environment", "Production" },
        },
    });

    var exampleEventHub = new Azure.EventHub.EventHub("exampleEventHub", new()
    {
        NamespaceName = exampleEventHubNamespace.Name,
        ResourceGroupName = exampleResourceGroup.Name,
        PartitionCount = 2,
        MessageRetention = 1,
    });

});
package main

import (
	"github.com/pulumi/pulumi-azure/sdk/v5/go/azure/core"
	"github.com/pulumi/pulumi-azure/sdk/v5/go/azure/eventhub"
	"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
		}
		exampleEventHubNamespace, err := eventhub.NewEventHubNamespace(ctx, "exampleEventHubNamespace", &eventhub.EventHubNamespaceArgs{
			Location:          exampleResourceGroup.Location,
			ResourceGroupName: exampleResourceGroup.Name,
			Sku:               pulumi.String("Standard"),
			Capacity:          pulumi.Int(1),
			Tags: pulumi.StringMap{
				"environment": pulumi.String("Production"),
			},
		})
		if err != nil {
			return err
		}
		_, err = eventhub.NewEventHub(ctx, "exampleEventHub", &eventhub.EventHubArgs{
			NamespaceName:     exampleEventHubNamespace.Name,
			ResourceGroupName: exampleResourceGroup.Name,
			PartitionCount:    pulumi.Int(2),
			MessageRetention:  pulumi.Int(1),
		})
		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.eventhub.EventHubNamespace;
import com.pulumi.azure.eventhub.EventHubNamespaceArgs;
import com.pulumi.azure.eventhub.EventHub;
import com.pulumi.azure.eventhub.EventHubArgs;
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 exampleEventHubNamespace = new EventHubNamespace("exampleEventHubNamespace", EventHubNamespaceArgs.builder()        
            .location(exampleResourceGroup.location())
            .resourceGroupName(exampleResourceGroup.name())
            .sku("Standard")
            .capacity(1)
            .tags(Map.of("environment", "Production"))
            .build());

        var exampleEventHub = new EventHub("exampleEventHub", EventHubArgs.builder()        
            .namespaceName(exampleEventHubNamespace.name())
            .resourceGroupName(exampleResourceGroup.name())
            .partitionCount(2)
            .messageRetention(1)
            .build());

    }
}
import pulumi
import pulumi_azure as azure

example_resource_group = azure.core.ResourceGroup("exampleResourceGroup", location="West Europe")
example_event_hub_namespace = azure.eventhub.EventHubNamespace("exampleEventHubNamespace",
    location=example_resource_group.location,
    resource_group_name=example_resource_group.name,
    sku="Standard",
    capacity=1,
    tags={
        "environment": "Production",
    })
example_event_hub = azure.eventhub.EventHub("exampleEventHub",
    namespace_name=example_event_hub_namespace.name,
    resource_group_name=example_resource_group.name,
    partition_count=2,
    message_retention=1)
import * as pulumi from "@pulumi/pulumi";
import * as azure from "@pulumi/azure";

const exampleResourceGroup = new azure.core.ResourceGroup("exampleResourceGroup", {location: "West Europe"});
const exampleEventHubNamespace = new azure.eventhub.EventHubNamespace("exampleEventHubNamespace", {
    location: exampleResourceGroup.location,
    resourceGroupName: exampleResourceGroup.name,
    sku: "Standard",
    capacity: 1,
    tags: {
        environment: "Production",
    },
});
const exampleEventHub = new azure.eventhub.EventHub("exampleEventHub", {
    namespaceName: exampleEventHubNamespace.name,
    resourceGroupName: exampleResourceGroup.name,
    partitionCount: 2,
    messageRetention: 1,
});
resources:
  exampleResourceGroup:
    type: azure:core:ResourceGroup
    properties:
      location: West Europe
  exampleEventHubNamespace:
    type: azure:eventhub:EventHubNamespace
    properties:
      location: ${exampleResourceGroup.location}
      resourceGroupName: ${exampleResourceGroup.name}
      sku: Standard
      capacity: 1
      tags:
        environment: Production
  exampleEventHub:
    type: azure:eventhub:EventHub
    properties:
      namespaceName: ${exampleEventHubNamespace.name}
      resourceGroupName: ${exampleResourceGroup.name}
      partitionCount: 2
      messageRetention: 1

Create EventHub Resource

new EventHub(name: string, args: EventHubArgs, opts?: CustomResourceOptions);
@overload
def EventHub(resource_name: str,
             opts: Optional[ResourceOptions] = None,
             capture_description: Optional[EventHubCaptureDescriptionArgs] = None,
             message_retention: Optional[int] = None,
             name: Optional[str] = None,
             namespace_name: Optional[str] = None,
             partition_count: Optional[int] = None,
             resource_group_name: Optional[str] = None,
             status: Optional[str] = None)
@overload
def EventHub(resource_name: str,
             args: EventHubArgs,
             opts: Optional[ResourceOptions] = None)
func NewEventHub(ctx *Context, name string, args EventHubArgs, opts ...ResourceOption) (*EventHub, error)
public EventHub(string name, EventHubArgs args, CustomResourceOptions? opts = null)
public EventHub(String name, EventHubArgs args)
public EventHub(String name, EventHubArgs args, CustomResourceOptions options)
type: azure:eventhub:EventHub
properties: # The arguments to resource properties.
options: # Bag of options to control resource's behavior.

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

EventHub 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 EventHub resource accepts the following input properties:

MessageRetention int

Specifies the number of days to retain the events for this Event Hub.

NamespaceName string

Specifies the name of the EventHub Namespace. Changing this forces a new resource to be created.

PartitionCount int

Specifies the current number of shards on the Event Hub. Changing this will force-recreate the resource.

ResourceGroupName string

The name of the resource group in which the EventHub's parent Namespace exists. Changing this forces a new resource to be created.

CaptureDescription EventHubCaptureDescriptionArgs

A capture_description block as defined below.

Name string

Specifies the name of the EventHub resource. Changing this forces a new resource to be created.

Status string

Specifies the status of the Event Hub resource. Possible values are Active, Disabled and SendDisabled. Defaults to Active.

MessageRetention int

Specifies the number of days to retain the events for this Event Hub.

NamespaceName string

Specifies the name of the EventHub Namespace. Changing this forces a new resource to be created.

PartitionCount int

Specifies the current number of shards on the Event Hub. Changing this will force-recreate the resource.

ResourceGroupName string

The name of the resource group in which the EventHub's parent Namespace exists. Changing this forces a new resource to be created.

CaptureDescription EventHubCaptureDescriptionArgs

A capture_description block as defined below.

Name string

Specifies the name of the EventHub resource. Changing this forces a new resource to be created.

Status string

Specifies the status of the Event Hub resource. Possible values are Active, Disabled and SendDisabled. Defaults to Active.

messageRetention Integer

Specifies the number of days to retain the events for this Event Hub.

namespaceName String

Specifies the name of the EventHub Namespace. Changing this forces a new resource to be created.

partitionCount Integer

Specifies the current number of shards on the Event Hub. Changing this will force-recreate the resource.

resourceGroupName String

The name of the resource group in which the EventHub's parent Namespace exists. Changing this forces a new resource to be created.

captureDescription EventHubCaptureDescriptionArgs

A capture_description block as defined below.

name String

Specifies the name of the EventHub resource. Changing this forces a new resource to be created.

status String

Specifies the status of the Event Hub resource. Possible values are Active, Disabled and SendDisabled. Defaults to Active.

messageRetention number

Specifies the number of days to retain the events for this Event Hub.

namespaceName string

Specifies the name of the EventHub Namespace. Changing this forces a new resource to be created.

partitionCount number

Specifies the current number of shards on the Event Hub. Changing this will force-recreate the resource.

resourceGroupName string

The name of the resource group in which the EventHub's parent Namespace exists. Changing this forces a new resource to be created.

captureDescription EventHubCaptureDescriptionArgs

A capture_description block as defined below.

name string

Specifies the name of the EventHub resource. Changing this forces a new resource to be created.

status string

Specifies the status of the Event Hub resource. Possible values are Active, Disabled and SendDisabled. Defaults to Active.

message_retention int

Specifies the number of days to retain the events for this Event Hub.

namespace_name str

Specifies the name of the EventHub Namespace. Changing this forces a new resource to be created.

partition_count int

Specifies the current number of shards on the Event Hub. Changing this will force-recreate the resource.

resource_group_name str

The name of the resource group in which the EventHub's parent Namespace exists. Changing this forces a new resource to be created.

capture_description EventHubCaptureDescriptionArgs

A capture_description block as defined below.

name str

Specifies the name of the EventHub resource. Changing this forces a new resource to be created.

status str

Specifies the status of the Event Hub resource. Possible values are Active, Disabled and SendDisabled. Defaults to Active.

messageRetention Number

Specifies the number of days to retain the events for this Event Hub.

namespaceName String

Specifies the name of the EventHub Namespace. Changing this forces a new resource to be created.

partitionCount Number

Specifies the current number of shards on the Event Hub. Changing this will force-recreate the resource.

resourceGroupName String

The name of the resource group in which the EventHub's parent Namespace exists. Changing this forces a new resource to be created.

captureDescription Property Map

A capture_description block as defined below.

name String

Specifies the name of the EventHub resource. Changing this forces a new resource to be created.

status String

Specifies the status of the Event Hub resource. Possible values are Active, Disabled and SendDisabled. Defaults to Active.

Outputs

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

Id string

The provider-assigned unique ID for this managed resource.

PartitionIds List<string>

The identifiers for partitions created for Event Hubs.

Id string

The provider-assigned unique ID for this managed resource.

PartitionIds []string

The identifiers for partitions created for Event Hubs.

id String

The provider-assigned unique ID for this managed resource.

partitionIds List<String>

The identifiers for partitions created for Event Hubs.

id string

The provider-assigned unique ID for this managed resource.

partitionIds string[]

The identifiers for partitions created for Event Hubs.

id str

The provider-assigned unique ID for this managed resource.

partition_ids Sequence[str]

The identifiers for partitions created for Event Hubs.

id String

The provider-assigned unique ID for this managed resource.

partitionIds List<String>

The identifiers for partitions created for Event Hubs.

Look up Existing EventHub Resource

Get an existing EventHub 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?: EventHubState, opts?: CustomResourceOptions): EventHub
@staticmethod
def get(resource_name: str,
        id: str,
        opts: Optional[ResourceOptions] = None,
        capture_description: Optional[EventHubCaptureDescriptionArgs] = None,
        message_retention: Optional[int] = None,
        name: Optional[str] = None,
        namespace_name: Optional[str] = None,
        partition_count: Optional[int] = None,
        partition_ids: Optional[Sequence[str]] = None,
        resource_group_name: Optional[str] = None,
        status: Optional[str] = None) -> EventHub
func GetEventHub(ctx *Context, name string, id IDInput, state *EventHubState, opts ...ResourceOption) (*EventHub, error)
public static EventHub Get(string name, Input<string> id, EventHubState? state, CustomResourceOptions? opts = null)
public static EventHub get(String name, Output<String> id, EventHubState 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:
CaptureDescription EventHubCaptureDescriptionArgs

A capture_description block as defined below.

MessageRetention int

Specifies the number of days to retain the events for this Event Hub.

Name string

Specifies the name of the EventHub resource. Changing this forces a new resource to be created.

NamespaceName string

Specifies the name of the EventHub Namespace. Changing this forces a new resource to be created.

PartitionCount int

Specifies the current number of shards on the Event Hub. Changing this will force-recreate the resource.

PartitionIds List<string>

The identifiers for partitions created for Event Hubs.

ResourceGroupName string

The name of the resource group in which the EventHub's parent Namespace exists. Changing this forces a new resource to be created.

Status string

Specifies the status of the Event Hub resource. Possible values are Active, Disabled and SendDisabled. Defaults to Active.

CaptureDescription EventHubCaptureDescriptionArgs

A capture_description block as defined below.

MessageRetention int

Specifies the number of days to retain the events for this Event Hub.

Name string

Specifies the name of the EventHub resource. Changing this forces a new resource to be created.

NamespaceName string

Specifies the name of the EventHub Namespace. Changing this forces a new resource to be created.

PartitionCount int

Specifies the current number of shards on the Event Hub. Changing this will force-recreate the resource.

PartitionIds []string

The identifiers for partitions created for Event Hubs.

ResourceGroupName string

The name of the resource group in which the EventHub's parent Namespace exists. Changing this forces a new resource to be created.

Status string

Specifies the status of the Event Hub resource. Possible values are Active, Disabled and SendDisabled. Defaults to Active.

captureDescription EventHubCaptureDescriptionArgs

A capture_description block as defined below.

messageRetention Integer

Specifies the number of days to retain the events for this Event Hub.

name String

Specifies the name of the EventHub resource. Changing this forces a new resource to be created.

namespaceName String

Specifies the name of the EventHub Namespace. Changing this forces a new resource to be created.

partitionCount Integer

Specifies the current number of shards on the Event Hub. Changing this will force-recreate the resource.

partitionIds List<String>

The identifiers for partitions created for Event Hubs.

resourceGroupName String

The name of the resource group in which the EventHub's parent Namespace exists. Changing this forces a new resource to be created.

status String

Specifies the status of the Event Hub resource. Possible values are Active, Disabled and SendDisabled. Defaults to Active.

captureDescription EventHubCaptureDescriptionArgs

A capture_description block as defined below.

messageRetention number

Specifies the number of days to retain the events for this Event Hub.

name string

Specifies the name of the EventHub resource. Changing this forces a new resource to be created.

namespaceName string

Specifies the name of the EventHub Namespace. Changing this forces a new resource to be created.

partitionCount number

Specifies the current number of shards on the Event Hub. Changing this will force-recreate the resource.

partitionIds string[]

The identifiers for partitions created for Event Hubs.

resourceGroupName string

The name of the resource group in which the EventHub's parent Namespace exists. Changing this forces a new resource to be created.

status string

Specifies the status of the Event Hub resource. Possible values are Active, Disabled and SendDisabled. Defaults to Active.

capture_description EventHubCaptureDescriptionArgs

A capture_description block as defined below.

message_retention int

Specifies the number of days to retain the events for this Event Hub.

name str

Specifies the name of the EventHub resource. Changing this forces a new resource to be created.

namespace_name str

Specifies the name of the EventHub Namespace. Changing this forces a new resource to be created.

partition_count int

Specifies the current number of shards on the Event Hub. Changing this will force-recreate the resource.

partition_ids Sequence[str]

The identifiers for partitions created for Event Hubs.

resource_group_name str

The name of the resource group in which the EventHub's parent Namespace exists. Changing this forces a new resource to be created.

status str

Specifies the status of the Event Hub resource. Possible values are Active, Disabled and SendDisabled. Defaults to Active.

captureDescription Property Map

A capture_description block as defined below.

messageRetention Number

Specifies the number of days to retain the events for this Event Hub.

name String

Specifies the name of the EventHub resource. Changing this forces a new resource to be created.

namespaceName String

Specifies the name of the EventHub Namespace. Changing this forces a new resource to be created.

partitionCount Number

Specifies the current number of shards on the Event Hub. Changing this will force-recreate the resource.

partitionIds List<String>

The identifiers for partitions created for Event Hubs.

resourceGroupName String

The name of the resource group in which the EventHub's parent Namespace exists. Changing this forces a new resource to be created.

status String

Specifies the status of the Event Hub resource. Possible values are Active, Disabled and SendDisabled. Defaults to Active.

Supporting Types

EventHubCaptureDescription

Destination EventHubCaptureDescriptionDestination

A destination block as defined below.

Enabled bool

Specifies if the Capture Description is Enabled.

Encoding string

Specifies the Encoding used for the Capture Description. Possible values are Avro and AvroDeflate.

IntervalInSeconds int

Specifies the time interval in seconds at which the capture will happen. Values can be between 60 and 900 seconds. Defaults to 300 seconds.

SizeLimitInBytes int

Specifies the amount of data built up in your EventHub before a Capture Operation occurs. Value should be between 10485760 and 524288000 bytes. Defaults to 314572800 bytes.

SkipEmptyArchives bool

Specifies if empty files should not be emitted if no events occur during the Capture time window. Defaults to false.

Destination EventHubCaptureDescriptionDestination

A destination block as defined below.

Enabled bool

Specifies if the Capture Description is Enabled.

Encoding string

Specifies the Encoding used for the Capture Description. Possible values are Avro and AvroDeflate.

IntervalInSeconds int

Specifies the time interval in seconds at which the capture will happen. Values can be between 60 and 900 seconds. Defaults to 300 seconds.

SizeLimitInBytes int

Specifies the amount of data built up in your EventHub before a Capture Operation occurs. Value should be between 10485760 and 524288000 bytes. Defaults to 314572800 bytes.

SkipEmptyArchives bool

Specifies if empty files should not be emitted if no events occur during the Capture time window. Defaults to false.

destination EventHubCaptureDescriptionDestination

A destination block as defined below.

enabled Boolean

Specifies if the Capture Description is Enabled.

encoding String

Specifies the Encoding used for the Capture Description. Possible values are Avro and AvroDeflate.

intervalInSeconds Integer

Specifies the time interval in seconds at which the capture will happen. Values can be between 60 and 900 seconds. Defaults to 300 seconds.

sizeLimitInBytes Integer

Specifies the amount of data built up in your EventHub before a Capture Operation occurs. Value should be between 10485760 and 524288000 bytes. Defaults to 314572800 bytes.

skipEmptyArchives Boolean

Specifies if empty files should not be emitted if no events occur during the Capture time window. Defaults to false.

destination EventHubCaptureDescriptionDestination

A destination block as defined below.

enabled boolean

Specifies if the Capture Description is Enabled.

encoding string

Specifies the Encoding used for the Capture Description. Possible values are Avro and AvroDeflate.

intervalInSeconds number

Specifies the time interval in seconds at which the capture will happen. Values can be between 60 and 900 seconds. Defaults to 300 seconds.

sizeLimitInBytes number

Specifies the amount of data built up in your EventHub before a Capture Operation occurs. Value should be between 10485760 and 524288000 bytes. Defaults to 314572800 bytes.

skipEmptyArchives boolean

Specifies if empty files should not be emitted if no events occur during the Capture time window. Defaults to false.

destination EventHubCaptureDescriptionDestination

A destination block as defined below.

enabled bool

Specifies if the Capture Description is Enabled.

encoding str

Specifies the Encoding used for the Capture Description. Possible values are Avro and AvroDeflate.

interval_in_seconds int

Specifies the time interval in seconds at which the capture will happen. Values can be between 60 and 900 seconds. Defaults to 300 seconds.

size_limit_in_bytes int

Specifies the amount of data built up in your EventHub before a Capture Operation occurs. Value should be between 10485760 and 524288000 bytes. Defaults to 314572800 bytes.

skip_empty_archives bool

Specifies if empty files should not be emitted if no events occur during the Capture time window. Defaults to false.

destination Property Map

A destination block as defined below.

enabled Boolean

Specifies if the Capture Description is Enabled.

encoding String

Specifies the Encoding used for the Capture Description. Possible values are Avro and AvroDeflate.

intervalInSeconds Number

Specifies the time interval in seconds at which the capture will happen. Values can be between 60 and 900 seconds. Defaults to 300 seconds.

sizeLimitInBytes Number

Specifies the amount of data built up in your EventHub before a Capture Operation occurs. Value should be between 10485760 and 524288000 bytes. Defaults to 314572800 bytes.

skipEmptyArchives Boolean

Specifies if empty files should not be emitted if no events occur during the Capture time window. Defaults to false.

EventHubCaptureDescriptionDestination

ArchiveNameFormat string

The Blob naming convention for archiving. e.g. {Namespace}/{EventHub}/{PartitionId}/{Year}/{Month}/{Day}/{Hour}/{Minute}/{Second}. Here all the parameters (Namespace,EventHub .. etc) are mandatory irrespective of order

BlobContainerName string

The name of the Container within the Blob Storage Account where messages should be archived.

Name string

The Name of the Destination where the capture should take place. At this time the only supported value is EventHubArchive.AzureBlockBlob.

StorageAccountId string

The ID of the Blob Storage Account where messages should be archived.

ArchiveNameFormat string

The Blob naming convention for archiving. e.g. {Namespace}/{EventHub}/{PartitionId}/{Year}/{Month}/{Day}/{Hour}/{Minute}/{Second}. Here all the parameters (Namespace,EventHub .. etc) are mandatory irrespective of order

BlobContainerName string

The name of the Container within the Blob Storage Account where messages should be archived.

Name string

The Name of the Destination where the capture should take place. At this time the only supported value is EventHubArchive.AzureBlockBlob.

StorageAccountId string

The ID of the Blob Storage Account where messages should be archived.

archiveNameFormat String

The Blob naming convention for archiving. e.g. {Namespace}/{EventHub}/{PartitionId}/{Year}/{Month}/{Day}/{Hour}/{Minute}/{Second}. Here all the parameters (Namespace,EventHub .. etc) are mandatory irrespective of order

blobContainerName String

The name of the Container within the Blob Storage Account where messages should be archived.

name String

The Name of the Destination where the capture should take place. At this time the only supported value is EventHubArchive.AzureBlockBlob.

storageAccountId String

The ID of the Blob Storage Account where messages should be archived.

archiveNameFormat string

The Blob naming convention for archiving. e.g. {Namespace}/{EventHub}/{PartitionId}/{Year}/{Month}/{Day}/{Hour}/{Minute}/{Second}. Here all the parameters (Namespace,EventHub .. etc) are mandatory irrespective of order

blobContainerName string

The name of the Container within the Blob Storage Account where messages should be archived.

name string

The Name of the Destination where the capture should take place. At this time the only supported value is EventHubArchive.AzureBlockBlob.

storageAccountId string

The ID of the Blob Storage Account where messages should be archived.

archive_name_format str

The Blob naming convention for archiving. e.g. {Namespace}/{EventHub}/{PartitionId}/{Year}/{Month}/{Day}/{Hour}/{Minute}/{Second}. Here all the parameters (Namespace,EventHub .. etc) are mandatory irrespective of order

blob_container_name str

The name of the Container within the Blob Storage Account where messages should be archived.

name str

The Name of the Destination where the capture should take place. At this time the only supported value is EventHubArchive.AzureBlockBlob.

storage_account_id str

The ID of the Blob Storage Account where messages should be archived.

archiveNameFormat String

The Blob naming convention for archiving. e.g. {Namespace}/{EventHub}/{PartitionId}/{Year}/{Month}/{Day}/{Hour}/{Minute}/{Second}. Here all the parameters (Namespace,EventHub .. etc) are mandatory irrespective of order

blobContainerName String

The name of the Container within the Blob Storage Account where messages should be archived.

name String

The Name of the Destination where the capture should take place. At this time the only supported value is EventHubArchive.AzureBlockBlob.

storageAccountId String

The ID of the Blob Storage Account where messages should be archived.

Import

EventHubs can be imported using the resource id, e.g.

 $ pulumi import azure:eventhub/eventHub:EventHub eventhub1 /subscriptions/00000000-0000-0000-0000-000000000000/resourceGroups/group1/providers/Microsoft.EventHub/namespaces/namespace1/eventhubs/eventhub1

Package Details

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

This Pulumi package is based on the azurerm Terraform Provider.