azure-native.eventhub.EventHub

Explore with Pulumi AI

Single item in List or Get Event Hub operation API Version: 2017-04-01.

Example Usage

EventHubCreate

using System.Collections.Generic;
using System.Linq;
using Pulumi;
using AzureNative = Pulumi.AzureNative;

return await Deployment.RunAsync(() => 
{
    var eventHub = new AzureNative.EventHub.EventHub("eventHub", new()
    {
        CaptureDescription = new AzureNative.EventHub.Inputs.CaptureDescriptionArgs
        {
            Destination = new AzureNative.EventHub.Inputs.DestinationArgs
            {
                ArchiveNameFormat = "{Namespace}/{EventHub}/{PartitionId}/{Year}/{Month}/{Day}/{Hour}/{Minute}/{Second}",
                BlobContainer = "container",
                Name = "EventHubArchive.AzureBlockBlob",
                StorageAccountResourceId = "/subscriptions/e2f361f0-3b27-4503-a9cc-21cfba380093/resourceGroups/Default-Storage-SouthCentralUS/providers/Microsoft.ClassicStorage/storageAccounts/arjunteststorage",
            },
            Enabled = true,
            Encoding = AzureNative.EventHub.EncodingCaptureDescription.Avro,
            IntervalInSeconds = 120,
            SizeLimitInBytes = 10485763,
        },
        EventHubName = "sdk-EventHub-6547",
        MessageRetentionInDays = 4,
        NamespaceName = "sdk-Namespace-5357",
        PartitionCount = 4,
        ResourceGroupName = "Default-NotificationHubs-AustraliaEast",
        Status = AzureNative.EventHub.EntityStatus.Active,
    });

});
package main

import (
	eventhub "github.com/pulumi/pulumi-azure-native-sdk/eventhub"
	"github.com/pulumi/pulumi/sdk/v3/go/pulumi"
)

func main() {
	pulumi.Run(func(ctx *pulumi.Context) error {
		_, err := eventhub.NewEventHub(ctx, "eventHub", &eventhub.EventHubArgs{
			CaptureDescription: eventhub.CaptureDescriptionResponse{
				Destination: &eventhub.DestinationArgs{
					ArchiveNameFormat:        pulumi.String("{Namespace}/{EventHub}/{PartitionId}/{Year}/{Month}/{Day}/{Hour}/{Minute}/{Second}"),
					BlobContainer:            pulumi.String("container"),
					Name:                     pulumi.String("EventHubArchive.AzureBlockBlob"),
					StorageAccountResourceId: pulumi.String("/subscriptions/e2f361f0-3b27-4503-a9cc-21cfba380093/resourceGroups/Default-Storage-SouthCentralUS/providers/Microsoft.ClassicStorage/storageAccounts/arjunteststorage"),
				},
				Enabled:           pulumi.Bool(true),
				Encoding:          eventhub.EncodingCaptureDescriptionAvro,
				IntervalInSeconds: pulumi.Int(120),
				SizeLimitInBytes:  pulumi.Int(10485763),
			},
			EventHubName:           pulumi.String("sdk-EventHub-6547"),
			MessageRetentionInDays: pulumi.Float64(4),
			NamespaceName:          pulumi.String("sdk-Namespace-5357"),
			PartitionCount:         pulumi.Float64(4),
			ResourceGroupName:      pulumi.String("Default-NotificationHubs-AustraliaEast"),
			Status:                 eventhub.EntityStatusActive,
		})
		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.azurenative.eventhub.EventHub;
import com.pulumi.azurenative.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 eventHub = new EventHub("eventHub", EventHubArgs.builder()        
            .captureDescription(Map.ofEntries(
                Map.entry("destination", Map.ofEntries(
                    Map.entry("archiveNameFormat", "{Namespace}/{EventHub}/{PartitionId}/{Year}/{Month}/{Day}/{Hour}/{Minute}/{Second}"),
                    Map.entry("blobContainer", "container"),
                    Map.entry("name", "EventHubArchive.AzureBlockBlob"),
                    Map.entry("storageAccountResourceId", "/subscriptions/e2f361f0-3b27-4503-a9cc-21cfba380093/resourceGroups/Default-Storage-SouthCentralUS/providers/Microsoft.ClassicStorage/storageAccounts/arjunteststorage")
                )),
                Map.entry("enabled", true),
                Map.entry("encoding", "Avro"),
                Map.entry("intervalInSeconds", 120),
                Map.entry("sizeLimitInBytes", 10485763)
            ))
            .eventHubName("sdk-EventHub-6547")
            .messageRetentionInDays(4)
            .namespaceName("sdk-Namespace-5357")
            .partitionCount(4)
            .resourceGroupName("Default-NotificationHubs-AustraliaEast")
            .status("Active")
            .build());

    }
}
import pulumi
import pulumi_azure_native as azure_native

event_hub = azure_native.eventhub.EventHub("eventHub",
    capture_description=azure_native.eventhub.CaptureDescriptionResponseArgs(
        destination=azure_native.eventhub.DestinationArgs(
            archive_name_format="{Namespace}/{EventHub}/{PartitionId}/{Year}/{Month}/{Day}/{Hour}/{Minute}/{Second}",
            blob_container="container",
            name="EventHubArchive.AzureBlockBlob",
            storage_account_resource_id="/subscriptions/e2f361f0-3b27-4503-a9cc-21cfba380093/resourceGroups/Default-Storage-SouthCentralUS/providers/Microsoft.ClassicStorage/storageAccounts/arjunteststorage",
        ),
        enabled=True,
        encoding=azure_native.eventhub.EncodingCaptureDescription.AVRO,
        interval_in_seconds=120,
        size_limit_in_bytes=10485763,
    ),
    event_hub_name="sdk-EventHub-6547",
    message_retention_in_days=4,
    namespace_name="sdk-Namespace-5357",
    partition_count=4,
    resource_group_name="Default-NotificationHubs-AustraliaEast",
    status=azure_native.eventhub.EntityStatus.ACTIVE)
import * as pulumi from "@pulumi/pulumi";
import * as azure_native from "@pulumi/azure-native";

const eventHub = new azure_native.eventhub.EventHub("eventHub", {
    captureDescription: {
        destination: {
            archiveNameFormat: "{Namespace}/{EventHub}/{PartitionId}/{Year}/{Month}/{Day}/{Hour}/{Minute}/{Second}",
            blobContainer: "container",
            name: "EventHubArchive.AzureBlockBlob",
            storageAccountResourceId: "/subscriptions/e2f361f0-3b27-4503-a9cc-21cfba380093/resourceGroups/Default-Storage-SouthCentralUS/providers/Microsoft.ClassicStorage/storageAccounts/arjunteststorage",
        },
        enabled: true,
        encoding: azure_native.eventhub.EncodingCaptureDescription.Avro,
        intervalInSeconds: 120,
        sizeLimitInBytes: 10485763,
    },
    eventHubName: "sdk-EventHub-6547",
    messageRetentionInDays: 4,
    namespaceName: "sdk-Namespace-5357",
    partitionCount: 4,
    resourceGroupName: "Default-NotificationHubs-AustraliaEast",
    status: azure_native.eventhub.EntityStatus.Active,
});
resources:
  eventHub:
    type: azure-native:eventhub:EventHub
    properties:
      captureDescription:
        destination:
          archiveNameFormat: '{Namespace}/{EventHub}/{PartitionId}/{Year}/{Month}/{Day}/{Hour}/{Minute}/{Second}'
          blobContainer: container
          name: EventHubArchive.AzureBlockBlob
          storageAccountResourceId: /subscriptions/e2f361f0-3b27-4503-a9cc-21cfba380093/resourceGroups/Default-Storage-SouthCentralUS/providers/Microsoft.ClassicStorage/storageAccounts/arjunteststorage
        enabled: true
        encoding: Avro
        intervalInSeconds: 120
        sizeLimitInBytes: 1.0485763e+07
      eventHubName: sdk-EventHub-6547
      messageRetentionInDays: 4
      namespaceName: sdk-Namespace-5357
      partitionCount: 4
      resourceGroupName: Default-NotificationHubs-AustraliaEast
      status: Active

Create EventHub Resource

new EventHub(name: string, args: EventHubArgs, opts?: CustomResourceOptions);
@overload
def EventHub(resource_name: str,
             opts: Optional[ResourceOptions] = None,
             capture_description: Optional[CaptureDescriptionArgs] = None,
             event_hub_name: Optional[str] = None,
             message_retention_in_days: Optional[float] = None,
             namespace_name: Optional[str] = None,
             partition_count: Optional[float] = None,
             resource_group_name: Optional[str] = None,
             status: Optional[EntityStatus] = 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-native: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:

NamespaceName string

The Namespace name

ResourceGroupName string

Name of the resource group within the azure subscription.

CaptureDescription Pulumi.AzureNative.EventHub.Inputs.CaptureDescriptionArgs

Properties of capture description

EventHubName string

The Event Hub name

MessageRetentionInDays double

Number of days to retain the events for this Event Hub, value should be 1 to 7 days

PartitionCount double

Number of partitions created for the Event Hub, allowed values are from 1 to 32 partitions.

Status Pulumi.AzureNative.EventHub.EntityStatus

Enumerates the possible values for the status of the Event Hub.

NamespaceName string

The Namespace name

ResourceGroupName string

Name of the resource group within the azure subscription.

CaptureDescription CaptureDescriptionArgs

Properties of capture description

EventHubName string

The Event Hub name

MessageRetentionInDays float64

Number of days to retain the events for this Event Hub, value should be 1 to 7 days

PartitionCount float64

Number of partitions created for the Event Hub, allowed values are from 1 to 32 partitions.

Status EntityStatus

Enumerates the possible values for the status of the Event Hub.

namespaceName String

The Namespace name

resourceGroupName String

Name of the resource group within the azure subscription.

captureDescription CaptureDescriptionArgs

Properties of capture description

eventHubName String

The Event Hub name

messageRetentionInDays Double

Number of days to retain the events for this Event Hub, value should be 1 to 7 days

partitionCount Double

Number of partitions created for the Event Hub, allowed values are from 1 to 32 partitions.

status EntityStatus

Enumerates the possible values for the status of the Event Hub.

namespaceName string

The Namespace name

resourceGroupName string

Name of the resource group within the azure subscription.

captureDescription CaptureDescriptionArgs

Properties of capture description

eventHubName string

The Event Hub name

messageRetentionInDays number

Number of days to retain the events for this Event Hub, value should be 1 to 7 days

partitionCount number

Number of partitions created for the Event Hub, allowed values are from 1 to 32 partitions.

status EntityStatus

Enumerates the possible values for the status of the Event Hub.

namespace_name str

The Namespace name

resource_group_name str

Name of the resource group within the azure subscription.

capture_description CaptureDescriptionArgs

Properties of capture description

event_hub_name str

The Event Hub name

message_retention_in_days float

Number of days to retain the events for this Event Hub, value should be 1 to 7 days

partition_count float

Number of partitions created for the Event Hub, allowed values are from 1 to 32 partitions.

status EntityStatus

Enumerates the possible values for the status of the Event Hub.

namespaceName String

The Namespace name

resourceGroupName String

Name of the resource group within the azure subscription.

captureDescription Property Map

Properties of capture description

eventHubName String

The Event Hub name

messageRetentionInDays Number

Number of days to retain the events for this Event Hub, value should be 1 to 7 days

partitionCount Number

Number of partitions created for the Event Hub, allowed values are from 1 to 32 partitions.

status "Active" | "Disabled" | "Restoring" | "SendDisabled" | "ReceiveDisabled" | "Creating" | "Deleting" | "Renaming" | "Unknown"

Enumerates the possible values for the status of the Event Hub.

Outputs

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

CreatedAt string

Exact time the Event Hub was created.

Id string

The provider-assigned unique ID for this managed resource.

Name string

The name of the resource

PartitionIds List<string>

Current number of shards on the Event Hub.

Type string

The type of the resource. E.g. "Microsoft.Compute/virtualMachines" or "Microsoft.Storage/storageAccounts"

UpdatedAt string

The exact time the message was updated.

CreatedAt string

Exact time the Event Hub was created.

Id string

The provider-assigned unique ID for this managed resource.

Name string

The name of the resource

PartitionIds []string

Current number of shards on the Event Hub.

Type string

The type of the resource. E.g. "Microsoft.Compute/virtualMachines" or "Microsoft.Storage/storageAccounts"

UpdatedAt string

The exact time the message was updated.

createdAt String

Exact time the Event Hub was created.

id String

The provider-assigned unique ID for this managed resource.

name String

The name of the resource

partitionIds List<String>

Current number of shards on the Event Hub.

type String

The type of the resource. E.g. "Microsoft.Compute/virtualMachines" or "Microsoft.Storage/storageAccounts"

updatedAt String

The exact time the message was updated.

createdAt string

Exact time the Event Hub was created.

id string

The provider-assigned unique ID for this managed resource.

name string

The name of the resource

partitionIds string[]

Current number of shards on the Event Hub.

type string

The type of the resource. E.g. "Microsoft.Compute/virtualMachines" or "Microsoft.Storage/storageAccounts"

updatedAt string

The exact time the message was updated.

created_at str

Exact time the Event Hub was created.

id str

The provider-assigned unique ID for this managed resource.

name str

The name of the resource

partition_ids Sequence[str]

Current number of shards on the Event Hub.

type str

The type of the resource. E.g. "Microsoft.Compute/virtualMachines" or "Microsoft.Storage/storageAccounts"

updated_at str

The exact time the message was updated.

createdAt String

Exact time the Event Hub was created.

id String

The provider-assigned unique ID for this managed resource.

name String

The name of the resource

partitionIds List<String>

Current number of shards on the Event Hub.

type String

The type of the resource. E.g. "Microsoft.Compute/virtualMachines" or "Microsoft.Storage/storageAccounts"

updatedAt String

The exact time the message was updated.

Supporting Types

CaptureDescription

Destination Pulumi.AzureNative.EventHub.Inputs.Destination

Properties of Destination where capture will be stored. (Storage Account, Blob Names)

Enabled bool

A value that indicates whether capture description is enabled.

Encoding Pulumi.AzureNative.EventHub.EncodingCaptureDescription

Enumerates the possible values for the encoding format of capture description. Note: 'AvroDeflate' will be deprecated in New API Version

IntervalInSeconds int

The time window allows you to set the frequency with which the capture to Azure Blobs will happen, value should between 60 to 900 seconds

SizeLimitInBytes int

The size window defines the amount of data built up in your Event Hub before an capture operation, value should be between 10485760 to 524288000 bytes

SkipEmptyArchives bool

A value that indicates whether to Skip Empty Archives

Destination Destination

Properties of Destination where capture will be stored. (Storage Account, Blob Names)

Enabled bool

A value that indicates whether capture description is enabled.

Encoding EncodingCaptureDescription

Enumerates the possible values for the encoding format of capture description. Note: 'AvroDeflate' will be deprecated in New API Version

IntervalInSeconds int

The time window allows you to set the frequency with which the capture to Azure Blobs will happen, value should between 60 to 900 seconds

SizeLimitInBytes int

The size window defines the amount of data built up in your Event Hub before an capture operation, value should be between 10485760 to 524288000 bytes

SkipEmptyArchives bool

A value that indicates whether to Skip Empty Archives

destination Destination

Properties of Destination where capture will be stored. (Storage Account, Blob Names)

enabled Boolean

A value that indicates whether capture description is enabled.

encoding EncodingCaptureDescription

Enumerates the possible values for the encoding format of capture description. Note: 'AvroDeflate' will be deprecated in New API Version

intervalInSeconds Integer

The time window allows you to set the frequency with which the capture to Azure Blobs will happen, value should between 60 to 900 seconds

sizeLimitInBytes Integer

The size window defines the amount of data built up in your Event Hub before an capture operation, value should be between 10485760 to 524288000 bytes

skipEmptyArchives Boolean

A value that indicates whether to Skip Empty Archives

destination Destination

Properties of Destination where capture will be stored. (Storage Account, Blob Names)

enabled boolean

A value that indicates whether capture description is enabled.

encoding EncodingCaptureDescription

Enumerates the possible values for the encoding format of capture description. Note: 'AvroDeflate' will be deprecated in New API Version

intervalInSeconds number

The time window allows you to set the frequency with which the capture to Azure Blobs will happen, value should between 60 to 900 seconds

sizeLimitInBytes number

The size window defines the amount of data built up in your Event Hub before an capture operation, value should be between 10485760 to 524288000 bytes

skipEmptyArchives boolean

A value that indicates whether to Skip Empty Archives

destination Destination

Properties of Destination where capture will be stored. (Storage Account, Blob Names)

enabled bool

A value that indicates whether capture description is enabled.

encoding EncodingCaptureDescription

Enumerates the possible values for the encoding format of capture description. Note: 'AvroDeflate' will be deprecated in New API Version

interval_in_seconds int

The time window allows you to set the frequency with which the capture to Azure Blobs will happen, value should between 60 to 900 seconds

size_limit_in_bytes int

The size window defines the amount of data built up in your Event Hub before an capture operation, value should be between 10485760 to 524288000 bytes

skip_empty_archives bool

A value that indicates whether to Skip Empty Archives

destination Property Map

Properties of Destination where capture will be stored. (Storage Account, Blob Names)

enabled Boolean

A value that indicates whether capture description is enabled.

encoding "Avro" | "AvroDeflate"

Enumerates the possible values for the encoding format of capture description. Note: 'AvroDeflate' will be deprecated in New API Version

intervalInSeconds Number

The time window allows you to set the frequency with which the capture to Azure Blobs will happen, value should between 60 to 900 seconds

sizeLimitInBytes Number

The size window defines the amount of data built up in your Event Hub before an capture operation, value should be between 10485760 to 524288000 bytes

skipEmptyArchives Boolean

A value that indicates whether to Skip Empty Archives

CaptureDescriptionResponse

Destination Pulumi.AzureNative.EventHub.Inputs.DestinationResponse

Properties of Destination where capture will be stored. (Storage Account, Blob Names)

Enabled bool

A value that indicates whether capture description is enabled.

Encoding string

Enumerates the possible values for the encoding format of capture description. Note: 'AvroDeflate' will be deprecated in New API Version

IntervalInSeconds int

The time window allows you to set the frequency with which the capture to Azure Blobs will happen, value should between 60 to 900 seconds

SizeLimitInBytes int

The size window defines the amount of data built up in your Event Hub before an capture operation, value should be between 10485760 to 524288000 bytes

SkipEmptyArchives bool

A value that indicates whether to Skip Empty Archives

Destination DestinationResponse

Properties of Destination where capture will be stored. (Storage Account, Blob Names)

Enabled bool

A value that indicates whether capture description is enabled.

Encoding string

Enumerates the possible values for the encoding format of capture description. Note: 'AvroDeflate' will be deprecated in New API Version

IntervalInSeconds int

The time window allows you to set the frequency with which the capture to Azure Blobs will happen, value should between 60 to 900 seconds

SizeLimitInBytes int

The size window defines the amount of data built up in your Event Hub before an capture operation, value should be between 10485760 to 524288000 bytes

SkipEmptyArchives bool

A value that indicates whether to Skip Empty Archives

destination DestinationResponse

Properties of Destination where capture will be stored. (Storage Account, Blob Names)

enabled Boolean

A value that indicates whether capture description is enabled.

encoding String

Enumerates the possible values for the encoding format of capture description. Note: 'AvroDeflate' will be deprecated in New API Version

intervalInSeconds Integer

The time window allows you to set the frequency with which the capture to Azure Blobs will happen, value should between 60 to 900 seconds

sizeLimitInBytes Integer

The size window defines the amount of data built up in your Event Hub before an capture operation, value should be between 10485760 to 524288000 bytes

skipEmptyArchives Boolean

A value that indicates whether to Skip Empty Archives

destination DestinationResponse

Properties of Destination where capture will be stored. (Storage Account, Blob Names)

enabled boolean

A value that indicates whether capture description is enabled.

encoding string

Enumerates the possible values for the encoding format of capture description. Note: 'AvroDeflate' will be deprecated in New API Version

intervalInSeconds number

The time window allows you to set the frequency with which the capture to Azure Blobs will happen, value should between 60 to 900 seconds

sizeLimitInBytes number

The size window defines the amount of data built up in your Event Hub before an capture operation, value should be between 10485760 to 524288000 bytes

skipEmptyArchives boolean

A value that indicates whether to Skip Empty Archives

destination DestinationResponse

Properties of Destination where capture will be stored. (Storage Account, Blob Names)

enabled bool

A value that indicates whether capture description is enabled.

encoding str

Enumerates the possible values for the encoding format of capture description. Note: 'AvroDeflate' will be deprecated in New API Version

interval_in_seconds int

The time window allows you to set the frequency with which the capture to Azure Blobs will happen, value should between 60 to 900 seconds

size_limit_in_bytes int

The size window defines the amount of data built up in your Event Hub before an capture operation, value should be between 10485760 to 524288000 bytes

skip_empty_archives bool

A value that indicates whether to Skip Empty Archives

destination Property Map

Properties of Destination where capture will be stored. (Storage Account, Blob Names)

enabled Boolean

A value that indicates whether capture description is enabled.

encoding String

Enumerates the possible values for the encoding format of capture description. Note: 'AvroDeflate' will be deprecated in New API Version

intervalInSeconds Number

The time window allows you to set the frequency with which the capture to Azure Blobs will happen, value should between 60 to 900 seconds

sizeLimitInBytes Number

The size window defines the amount of data built up in your Event Hub before an capture operation, value should be between 10485760 to 524288000 bytes

skipEmptyArchives Boolean

A value that indicates whether to Skip Empty Archives

Destination

ArchiveNameFormat string

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

BlobContainer string

Blob container Name

Name string

Name for capture destination

StorageAccountResourceId string

Resource id of the storage account to be used to create the blobs

ArchiveNameFormat string

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

BlobContainer string

Blob container Name

Name string

Name for capture destination

StorageAccountResourceId string

Resource id of the storage account to be used to create the blobs

archiveNameFormat String

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

blobContainer String

Blob container Name

name String

Name for capture destination

storageAccountResourceId String

Resource id of the storage account to be used to create the blobs

archiveNameFormat string

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

blobContainer string

Blob container Name

name string

Name for capture destination

storageAccountResourceId string

Resource id of the storage account to be used to create the blobs

archive_name_format str

Blob naming convention for archive, 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 str

Blob container Name

name str

Name for capture destination

storage_account_resource_id str

Resource id of the storage account to be used to create the blobs

archiveNameFormat String

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

blobContainer String

Blob container Name

name String

Name for capture destination

storageAccountResourceId String

Resource id of the storage account to be used to create the blobs

DestinationResponse

ArchiveNameFormat string

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

BlobContainer string

Blob container Name

Name string

Name for capture destination

StorageAccountResourceId string

Resource id of the storage account to be used to create the blobs

ArchiveNameFormat string

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

BlobContainer string

Blob container Name

Name string

Name for capture destination

StorageAccountResourceId string

Resource id of the storage account to be used to create the blobs

archiveNameFormat String

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

blobContainer String

Blob container Name

name String

Name for capture destination

storageAccountResourceId String

Resource id of the storage account to be used to create the blobs

archiveNameFormat string

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

blobContainer string

Blob container Name

name string

Name for capture destination

storageAccountResourceId string

Resource id of the storage account to be used to create the blobs

archive_name_format str

Blob naming convention for archive, 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 str

Blob container Name

name str

Name for capture destination

storage_account_resource_id str

Resource id of the storage account to be used to create the blobs

archiveNameFormat String

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

blobContainer String

Blob container Name

name String

Name for capture destination

storageAccountResourceId String

Resource id of the storage account to be used to create the blobs

EncodingCaptureDescription

Avro
Avro
AvroDeflate
AvroDeflate
EncodingCaptureDescriptionAvro
Avro
EncodingCaptureDescriptionAvroDeflate
AvroDeflate
Avro
Avro
AvroDeflate
AvroDeflate
Avro
Avro
AvroDeflate
AvroDeflate
AVRO
Avro
AVRO_DEFLATE
AvroDeflate
"Avro"
Avro
"AvroDeflate"
AvroDeflate

EntityStatus

Active
Active
Disabled
Disabled
Restoring
Restoring
SendDisabled
SendDisabled
ReceiveDisabled
ReceiveDisabled
Creating
Creating
Deleting
Deleting
Renaming
Renaming
Unknown
Unknown
EntityStatusActive
Active
EntityStatusDisabled
Disabled
EntityStatusRestoring
Restoring
EntityStatusSendDisabled
SendDisabled
EntityStatusReceiveDisabled
ReceiveDisabled
EntityStatusCreating
Creating
EntityStatusDeleting
Deleting
EntityStatusRenaming
Renaming
EntityStatusUnknown
Unknown
Active
Active
Disabled
Disabled
Restoring
Restoring
SendDisabled
SendDisabled
ReceiveDisabled
ReceiveDisabled
Creating
Creating
Deleting
Deleting
Renaming
Renaming
Unknown
Unknown
Active
Active
Disabled
Disabled
Restoring
Restoring
SendDisabled
SendDisabled
ReceiveDisabled
ReceiveDisabled
Creating
Creating
Deleting
Deleting
Renaming
Renaming
Unknown
Unknown
ACTIVE
Active
DISABLED
Disabled
RESTORING
Restoring
SEND_DISABLED
SendDisabled
RECEIVE_DISABLED
ReceiveDisabled
CREATING
Creating
DELETING
Deleting
RENAMING
Renaming
UNKNOWN
Unknown
"Active"
Active
"Disabled"
Disabled
"Restoring"
Restoring
"SendDisabled"
SendDisabled
"ReceiveDisabled"
ReceiveDisabled
"Creating"
Creating
"Deleting"
Deleting
"Renaming"
Renaming
"Unknown"
Unknown

Import

An existing resource can be imported using its type token, name, and identifier, e.g.

$ pulumi import azure-native:eventhub:EventHub sdk-EventHub-10 /subscriptions/e2f361f0-3b27-4503-a9cc-21cfba380093/resourceGroups/Default-NotificationHubs-AustraliaEast/providers/Microsoft.EventHub/namespaces/sdk-Namespace-716/eventhubs/sdk-EventHub-10 

Package Details

Repository
Azure Native pulumi/pulumi-azure-native
License
Apache-2.0