1. Packages
  2. Azure Native
  3. API Docs
  4. eventhub
  5. EventHub
This is the latest version of Azure Native. Use the Azure Native v1 docs if using the v1 version of this package.
Azure Native v2.37.0 published on Monday, Apr 15, 2024 by Pulumi

azure-native.eventhub.EventHub

Explore with Pulumi AI

azure-native logo
This is the latest version of Azure Native. Use the Azure Native v1 docs if using the v1 version of this package.
Azure Native v2.37.0 published on Monday, Apr 15, 2024 by Pulumi

    Single item in List or Get Event Hub operation Azure REST API version: 2022-10-01-preview. Prior API version in Azure Native 1.x: 2017-04-01.

    Other available API versions: 2015-08-01, 2023-01-01-preview, 2024-01-01, 2024-05-01-preview.

    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",
            RetentionDescription = new AzureNative.EventHub.Inputs.RetentionDescriptionArgs
            {
                CleanupPolicy = AzureNative.EventHub.CleanupPolicyRetentionDescription.Compact,
                RetentionTimeInHours = 96,
                TombstoneRetentionTimeInHours = 1,
            },
            Status = AzureNative.EventHub.EntityStatus.Active,
        });
    
    });
    
    package main
    
    import (
    	"github.com/pulumi/pulumi-azure-native-sdk/eventhub/v2"
    	"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.CaptureDescriptionArgs{
    				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"),
    			RetentionDescription: &eventhub.RetentionDescriptionArgs{
    				CleanupPolicy:                 pulumi.String(eventhub.CleanupPolicyRetentionDescriptionCompact),
    				RetentionTimeInHours:          pulumi.Float64(96),
    				TombstoneRetentionTimeInHours: pulumi.Int(1),
    			},
    			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 com.pulumi.azurenative.eventhub.inputs.CaptureDescriptionArgs;
    import com.pulumi.azurenative.eventhub.inputs.DestinationArgs;
    import com.pulumi.azurenative.eventhub.inputs.RetentionDescriptionArgs;
    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(CaptureDescriptionArgs.builder()
                    .destination(DestinationArgs.builder()
                        .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")
                        .build())
                    .enabled(true)
                    .encoding("Avro")
                    .intervalInSeconds(120)
                    .sizeLimitInBytes(10485763)
                    .build())
                .eventHubName("sdk-EventHub-6547")
                .messageRetentionInDays(4)
                .namespaceName("sdk-Namespace-5357")
                .partitionCount(4)
                .resourceGroupName("Default-NotificationHubs-AustraliaEast")
                .retentionDescription(RetentionDescriptionArgs.builder()
                    .cleanupPolicy("Compact")
                    .retentionTimeInHours(96)
                    .tombstoneRetentionTimeInHours(1)
                    .build())
                .status("Active")
                .build());
    
        }
    }
    
    import pulumi
    import pulumi_azure_native as azure_native
    
    event_hub = azure_native.eventhub.EventHub("eventHub",
        capture_description=azure_native.eventhub.CaptureDescriptionArgs(
            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",
        retention_description=azure_native.eventhub.RetentionDescriptionArgs(
            cleanup_policy=azure_native.eventhub.CleanupPolicyRetentionDescription.COMPACT,
            retention_time_in_hours=96,
            tombstone_retention_time_in_hours=1,
        ),
        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",
        retentionDescription: {
            cleanupPolicy: azure_native.eventhub.CleanupPolicyRetentionDescription.Compact,
            retentionTimeInHours: 96,
            tombstoneRetentionTimeInHours: 1,
        },
        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
          retentionDescription:
            cleanupPolicy: Compact
            retentionTimeInHours: 96
            tombstoneRetentionTimeInHours: 1
          status: Active
    

    Create EventHub Resource

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

    Constructor syntax

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

    Parameters

    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.

    Example

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

    var eventHubResource = new AzureNative.EventHub.EventHub("eventHubResource", new()
    {
        NamespaceName = "string",
        ResourceGroupName = "string",
        CaptureDescription = new AzureNative.EventHub.Inputs.CaptureDescriptionArgs
        {
            Destination = new AzureNative.EventHub.Inputs.DestinationArgs
            {
                ArchiveNameFormat = "string",
                BlobContainer = "string",
                DataLakeAccountName = "string",
                DataLakeFolderPath = "string",
                DataLakeSubscriptionId = "string",
                Name = "string",
                StorageAccountResourceId = "string",
            },
            Enabled = false,
            Encoding = AzureNative.EventHub.EncodingCaptureDescription.Avro,
            IntervalInSeconds = 0,
            SizeLimitInBytes = 0,
            SkipEmptyArchives = false,
        },
        EventHubName = "string",
        MessageRetentionInDays = 0,
        PartitionCount = 0,
        RetentionDescription = new AzureNative.EventHub.Inputs.RetentionDescriptionArgs
        {
            CleanupPolicy = "string",
            RetentionTimeInHours = 0,
            TombstoneRetentionTimeInHours = 0,
        },
        Status = AzureNative.EventHub.EntityStatus.Active,
    });
    
    example, err := eventhub.NewEventHub(ctx, "eventHubResource", &eventhub.EventHubArgs{
    NamespaceName: pulumi.String("string"),
    ResourceGroupName: pulumi.String("string"),
    CaptureDescription: &eventhub.CaptureDescriptionArgs{
    Destination: &eventhub.DestinationArgs{
    ArchiveNameFormat: pulumi.String("string"),
    BlobContainer: pulumi.String("string"),
    DataLakeAccountName: pulumi.String("string"),
    DataLakeFolderPath: pulumi.String("string"),
    DataLakeSubscriptionId: pulumi.String("string"),
    Name: pulumi.String("string"),
    StorageAccountResourceId: pulumi.String("string"),
    },
    Enabled: pulumi.Bool(false),
    Encoding: eventhub.EncodingCaptureDescriptionAvro,
    IntervalInSeconds: pulumi.Int(0),
    SizeLimitInBytes: pulumi.Int(0),
    SkipEmptyArchives: pulumi.Bool(false),
    },
    EventHubName: pulumi.String("string"),
    MessageRetentionInDays: pulumi.Float64(0),
    PartitionCount: pulumi.Float64(0),
    RetentionDescription: &eventhub.RetentionDescriptionArgs{
    CleanupPolicy: pulumi.String("string"),
    RetentionTimeInHours: pulumi.Float64(0),
    TombstoneRetentionTimeInHours: pulumi.Int(0),
    },
    Status: eventhub.EntityStatusActive,
    })
    
    var eventHubResource = new EventHub("eventHubResource", EventHubArgs.builder()        
        .namespaceName("string")
        .resourceGroupName("string")
        .captureDescription(CaptureDescriptionArgs.builder()
            .destination(DestinationArgs.builder()
                .archiveNameFormat("string")
                .blobContainer("string")
                .dataLakeAccountName("string")
                .dataLakeFolderPath("string")
                .dataLakeSubscriptionId("string")
                .name("string")
                .storageAccountResourceId("string")
                .build())
            .enabled(false)
            .encoding("Avro")
            .intervalInSeconds(0)
            .sizeLimitInBytes(0)
            .skipEmptyArchives(false)
            .build())
        .eventHubName("string")
        .messageRetentionInDays(0)
        .partitionCount(0)
        .retentionDescription(RetentionDescriptionArgs.builder()
            .cleanupPolicy("string")
            .retentionTimeInHours(0)
            .tombstoneRetentionTimeInHours(0)
            .build())
        .status("Active")
        .build());
    
    event_hub_resource = azure_native.eventhub.EventHub("eventHubResource",
        namespace_name="string",
        resource_group_name="string",
        capture_description=azure_native.eventhub.CaptureDescriptionArgs(
            destination=azure_native.eventhub.DestinationArgs(
                archive_name_format="string",
                blob_container="string",
                data_lake_account_name="string",
                data_lake_folder_path="string",
                data_lake_subscription_id="string",
                name="string",
                storage_account_resource_id="string",
            ),
            enabled=False,
            encoding=azure_native.eventhub.EncodingCaptureDescription.AVRO,
            interval_in_seconds=0,
            size_limit_in_bytes=0,
            skip_empty_archives=False,
        ),
        event_hub_name="string",
        message_retention_in_days=0,
        partition_count=0,
        retention_description=azure_native.eventhub.RetentionDescriptionArgs(
            cleanup_policy="string",
            retention_time_in_hours=0,
            tombstone_retention_time_in_hours=0,
        ),
        status=azure_native.eventhub.EntityStatus.ACTIVE)
    
    const eventHubResource = new azure_native.eventhub.EventHub("eventHubResource", {
        namespaceName: "string",
        resourceGroupName: "string",
        captureDescription: {
            destination: {
                archiveNameFormat: "string",
                blobContainer: "string",
                dataLakeAccountName: "string",
                dataLakeFolderPath: "string",
                dataLakeSubscriptionId: "string",
                name: "string",
                storageAccountResourceId: "string",
            },
            enabled: false,
            encoding: azure_native.eventhub.EncodingCaptureDescription.Avro,
            intervalInSeconds: 0,
            sizeLimitInBytes: 0,
            skipEmptyArchives: false,
        },
        eventHubName: "string",
        messageRetentionInDays: 0,
        partitionCount: 0,
        retentionDescription: {
            cleanupPolicy: "string",
            retentionTimeInHours: 0,
            tombstoneRetentionTimeInHours: 0,
        },
        status: azure_native.eventhub.EntityStatus.Active,
    });
    
    type: azure-native:eventhub:EventHub
    properties:
        captureDescription:
            destination:
                archiveNameFormat: string
                blobContainer: string
                dataLakeAccountName: string
                dataLakeFolderPath: string
                dataLakeSubscriptionId: string
                name: string
                storageAccountResourceId: string
            enabled: false
            encoding: Avro
            intervalInSeconds: 0
            sizeLimitInBytes: 0
            skipEmptyArchives: false
        eventHubName: string
        messageRetentionInDays: 0
        namespaceName: string
        partitionCount: 0
        resourceGroupName: string
        retentionDescription:
            cleanupPolicy: string
            retentionTimeInHours: 0
            tombstoneRetentionTimeInHours: 0
        status: Active
    

    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.CaptureDescription
    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.
    RetentionDescription Pulumi.AzureNative.EventHub.Inputs.RetentionDescription
    Event Hub retention settings
    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.
    RetentionDescription RetentionDescriptionArgs
    Event Hub retention settings
    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 CaptureDescription
    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.
    retentionDescription RetentionDescription
    Event Hub retention settings
    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 CaptureDescription
    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.
    retentionDescription RetentionDescription
    Event Hub retention settings
    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.
    retention_description RetentionDescriptionArgs
    Event Hub retention settings
    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.
    retentionDescription Property Map
    Event Hub retention settings
    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.
    Location string
    The geo-location where the resource lives
    Name string
    The name of the resource
    PartitionIds List<string>
    Current number of shards on the Event Hub.
    SystemData Pulumi.AzureNative.EventHub.Outputs.SystemDataResponse
    The system meta data relating to this resource.
    Type string
    The type of the resource. E.g. "Microsoft.EventHub/Namespaces" or "Microsoft.EventHub/Namespaces/EventHubs"
    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.
    Location string
    The geo-location where the resource lives
    Name string
    The name of the resource
    PartitionIds []string
    Current number of shards on the Event Hub.
    SystemData SystemDataResponse
    The system meta data relating to this resource.
    Type string
    The type of the resource. E.g. "Microsoft.EventHub/Namespaces" or "Microsoft.EventHub/Namespaces/EventHubs"
    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.
    location String
    The geo-location where the resource lives
    name String
    The name of the resource
    partitionIds List<String>
    Current number of shards on the Event Hub.
    systemData SystemDataResponse
    The system meta data relating to this resource.
    type String
    The type of the resource. E.g. "Microsoft.EventHub/Namespaces" or "Microsoft.EventHub/Namespaces/EventHubs"
    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.
    location string
    The geo-location where the resource lives
    name string
    The name of the resource
    partitionIds string[]
    Current number of shards on the Event Hub.
    systemData SystemDataResponse
    The system meta data relating to this resource.
    type string
    The type of the resource. E.g. "Microsoft.EventHub/Namespaces" or "Microsoft.EventHub/Namespaces/EventHubs"
    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.
    location str
    The geo-location where the resource lives
    name str
    The name of the resource
    partition_ids Sequence[str]
    Current number of shards on the Event Hub.
    system_data SystemDataResponse
    The system meta data relating to this resource.
    type str
    The type of the resource. E.g. "Microsoft.EventHub/Namespaces" or "Microsoft.EventHub/Namespaces/EventHubs"
    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.
    location String
    The geo-location where the resource lives
    name String
    The name of the resource
    partitionIds List<String>
    Current number of shards on the Event Hub.
    systemData Property Map
    The system meta data relating to this resource.
    type String
    The type of the resource. E.g. "Microsoft.EventHub/Namespaces" or "Microsoft.EventHub/Namespaces/EventHubs"
    updatedAt String
    The exact time the message was updated.

    Supporting Types

    CaptureDescription, CaptureDescriptionArgs

    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, CaptureDescriptionResponseArgs

    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

    CleanupPolicyRetentionDescription, CleanupPolicyRetentionDescriptionArgs

    Delete
    Delete
    Compact
    Compact
    CleanupPolicyRetentionDescriptionDelete
    Delete
    CleanupPolicyRetentionDescriptionCompact
    Compact
    Delete
    Delete
    Compact
    Compact
    Delete
    Delete
    Compact
    Compact
    DELETE
    Delete
    COMPACT
    Compact
    "Delete"
    Delete
    "Compact"
    Compact

    Destination, DestinationArgs

    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
    DataLakeAccountName string
    The Azure Data Lake Store name for the captured events
    DataLakeFolderPath string
    The destination folder path for the captured events
    DataLakeSubscriptionId string
    Subscription Id of Azure Data Lake Store
    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
    DataLakeAccountName string
    The Azure Data Lake Store name for the captured events
    DataLakeFolderPath string
    The destination folder path for the captured events
    DataLakeSubscriptionId string
    Subscription Id of Azure Data Lake Store
    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
    dataLakeAccountName String
    The Azure Data Lake Store name for the captured events
    dataLakeFolderPath String
    The destination folder path for the captured events
    dataLakeSubscriptionId String
    Subscription Id of Azure Data Lake Store
    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
    dataLakeAccountName string
    The Azure Data Lake Store name for the captured events
    dataLakeFolderPath string
    The destination folder path for the captured events
    dataLakeSubscriptionId string
    Subscription Id of Azure Data Lake Store
    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
    data_lake_account_name str
    The Azure Data Lake Store name for the captured events
    data_lake_folder_path str
    The destination folder path for the captured events
    data_lake_subscription_id str
    Subscription Id of Azure Data Lake Store
    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
    dataLakeAccountName String
    The Azure Data Lake Store name for the captured events
    dataLakeFolderPath String
    The destination folder path for the captured events
    dataLakeSubscriptionId String
    Subscription Id of Azure Data Lake Store
    name String
    Name for capture destination
    storageAccountResourceId String
    Resource id of the storage account to be used to create the blobs

    DestinationResponse, DestinationResponseArgs

    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
    DataLakeAccountName string
    The Azure Data Lake Store name for the captured events
    DataLakeFolderPath string
    The destination folder path for the captured events
    DataLakeSubscriptionId string
    Subscription Id of Azure Data Lake Store
    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
    DataLakeAccountName string
    The Azure Data Lake Store name for the captured events
    DataLakeFolderPath string
    The destination folder path for the captured events
    DataLakeSubscriptionId string
    Subscription Id of Azure Data Lake Store
    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
    dataLakeAccountName String
    The Azure Data Lake Store name for the captured events
    dataLakeFolderPath String
    The destination folder path for the captured events
    dataLakeSubscriptionId String
    Subscription Id of Azure Data Lake Store
    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
    dataLakeAccountName string
    The Azure Data Lake Store name for the captured events
    dataLakeFolderPath string
    The destination folder path for the captured events
    dataLakeSubscriptionId string
    Subscription Id of Azure Data Lake Store
    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
    data_lake_account_name str
    The Azure Data Lake Store name for the captured events
    data_lake_folder_path str
    The destination folder path for the captured events
    data_lake_subscription_id str
    Subscription Id of Azure Data Lake Store
    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
    dataLakeAccountName String
    The Azure Data Lake Store name for the captured events
    dataLakeFolderPath String
    The destination folder path for the captured events
    dataLakeSubscriptionId String
    Subscription Id of Azure Data Lake Store
    name String
    Name for capture destination
    storageAccountResourceId String
    Resource id of the storage account to be used to create the blobs

    EncodingCaptureDescription, EncodingCaptureDescriptionArgs

    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, EntityStatusArgs

    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

    RetentionDescription, RetentionDescriptionArgs

    CleanupPolicy string | Pulumi.AzureNative.EventHub.CleanupPolicyRetentionDescription
    Enumerates the possible values for cleanup policy
    RetentionTimeInHours double
    Number of hours to retain the events for this Event Hub. This value is only used when cleanupPolicy is Delete. If cleanupPolicy is Compact the returned value of this property is Long.MaxValue
    TombstoneRetentionTimeInHours int
    Number of hours to retain the tombstone markers of a compacted Event Hub. This value is only used when cleanupPolicy is Compact. Consumer must complete reading the tombstone marker within this specified amount of time if consumer begins from starting offset to ensure they get a valid snapshot for the specific key described by the tombstone marker within the compacted Event Hub
    CleanupPolicy string | CleanupPolicyRetentionDescription
    Enumerates the possible values for cleanup policy
    RetentionTimeInHours float64
    Number of hours to retain the events for this Event Hub. This value is only used when cleanupPolicy is Delete. If cleanupPolicy is Compact the returned value of this property is Long.MaxValue
    TombstoneRetentionTimeInHours int
    Number of hours to retain the tombstone markers of a compacted Event Hub. This value is only used when cleanupPolicy is Compact. Consumer must complete reading the tombstone marker within this specified amount of time if consumer begins from starting offset to ensure they get a valid snapshot for the specific key described by the tombstone marker within the compacted Event Hub
    cleanupPolicy String | CleanupPolicyRetentionDescription
    Enumerates the possible values for cleanup policy
    retentionTimeInHours Double
    Number of hours to retain the events for this Event Hub. This value is only used when cleanupPolicy is Delete. If cleanupPolicy is Compact the returned value of this property is Long.MaxValue
    tombstoneRetentionTimeInHours Integer
    Number of hours to retain the tombstone markers of a compacted Event Hub. This value is only used when cleanupPolicy is Compact. Consumer must complete reading the tombstone marker within this specified amount of time if consumer begins from starting offset to ensure they get a valid snapshot for the specific key described by the tombstone marker within the compacted Event Hub
    cleanupPolicy string | CleanupPolicyRetentionDescription
    Enumerates the possible values for cleanup policy
    retentionTimeInHours number
    Number of hours to retain the events for this Event Hub. This value is only used when cleanupPolicy is Delete. If cleanupPolicy is Compact the returned value of this property is Long.MaxValue
    tombstoneRetentionTimeInHours number
    Number of hours to retain the tombstone markers of a compacted Event Hub. This value is only used when cleanupPolicy is Compact. Consumer must complete reading the tombstone marker within this specified amount of time if consumer begins from starting offset to ensure they get a valid snapshot for the specific key described by the tombstone marker within the compacted Event Hub
    cleanup_policy str | CleanupPolicyRetentionDescription
    Enumerates the possible values for cleanup policy
    retention_time_in_hours float
    Number of hours to retain the events for this Event Hub. This value is only used when cleanupPolicy is Delete. If cleanupPolicy is Compact the returned value of this property is Long.MaxValue
    tombstone_retention_time_in_hours int
    Number of hours to retain the tombstone markers of a compacted Event Hub. This value is only used when cleanupPolicy is Compact. Consumer must complete reading the tombstone marker within this specified amount of time if consumer begins from starting offset to ensure they get a valid snapshot for the specific key described by the tombstone marker within the compacted Event Hub
    cleanupPolicy String | "Delete" | "Compact"
    Enumerates the possible values for cleanup policy
    retentionTimeInHours Number
    Number of hours to retain the events for this Event Hub. This value is only used when cleanupPolicy is Delete. If cleanupPolicy is Compact the returned value of this property is Long.MaxValue
    tombstoneRetentionTimeInHours Number
    Number of hours to retain the tombstone markers of a compacted Event Hub. This value is only used when cleanupPolicy is Compact. Consumer must complete reading the tombstone marker within this specified amount of time if consumer begins from starting offset to ensure they get a valid snapshot for the specific key described by the tombstone marker within the compacted Event Hub

    RetentionDescriptionResponse, RetentionDescriptionResponseArgs

    CleanupPolicy string
    Enumerates the possible values for cleanup policy
    RetentionTimeInHours double
    Number of hours to retain the events for this Event Hub. This value is only used when cleanupPolicy is Delete. If cleanupPolicy is Compact the returned value of this property is Long.MaxValue
    TombstoneRetentionTimeInHours int
    Number of hours to retain the tombstone markers of a compacted Event Hub. This value is only used when cleanupPolicy is Compact. Consumer must complete reading the tombstone marker within this specified amount of time if consumer begins from starting offset to ensure they get a valid snapshot for the specific key described by the tombstone marker within the compacted Event Hub
    CleanupPolicy string
    Enumerates the possible values for cleanup policy
    RetentionTimeInHours float64
    Number of hours to retain the events for this Event Hub. This value is only used when cleanupPolicy is Delete. If cleanupPolicy is Compact the returned value of this property is Long.MaxValue
    TombstoneRetentionTimeInHours int
    Number of hours to retain the tombstone markers of a compacted Event Hub. This value is only used when cleanupPolicy is Compact. Consumer must complete reading the tombstone marker within this specified amount of time if consumer begins from starting offset to ensure they get a valid snapshot for the specific key described by the tombstone marker within the compacted Event Hub
    cleanupPolicy String
    Enumerates the possible values for cleanup policy
    retentionTimeInHours Double
    Number of hours to retain the events for this Event Hub. This value is only used when cleanupPolicy is Delete. If cleanupPolicy is Compact the returned value of this property is Long.MaxValue
    tombstoneRetentionTimeInHours Integer
    Number of hours to retain the tombstone markers of a compacted Event Hub. This value is only used when cleanupPolicy is Compact. Consumer must complete reading the tombstone marker within this specified amount of time if consumer begins from starting offset to ensure they get a valid snapshot for the specific key described by the tombstone marker within the compacted Event Hub
    cleanupPolicy string
    Enumerates the possible values for cleanup policy
    retentionTimeInHours number
    Number of hours to retain the events for this Event Hub. This value is only used when cleanupPolicy is Delete. If cleanupPolicy is Compact the returned value of this property is Long.MaxValue
    tombstoneRetentionTimeInHours number
    Number of hours to retain the tombstone markers of a compacted Event Hub. This value is only used when cleanupPolicy is Compact. Consumer must complete reading the tombstone marker within this specified amount of time if consumer begins from starting offset to ensure they get a valid snapshot for the specific key described by the tombstone marker within the compacted Event Hub
    cleanup_policy str
    Enumerates the possible values for cleanup policy
    retention_time_in_hours float
    Number of hours to retain the events for this Event Hub. This value is only used when cleanupPolicy is Delete. If cleanupPolicy is Compact the returned value of this property is Long.MaxValue
    tombstone_retention_time_in_hours int
    Number of hours to retain the tombstone markers of a compacted Event Hub. This value is only used when cleanupPolicy is Compact. Consumer must complete reading the tombstone marker within this specified amount of time if consumer begins from starting offset to ensure they get a valid snapshot for the specific key described by the tombstone marker within the compacted Event Hub
    cleanupPolicy String
    Enumerates the possible values for cleanup policy
    retentionTimeInHours Number
    Number of hours to retain the events for this Event Hub. This value is only used when cleanupPolicy is Delete. If cleanupPolicy is Compact the returned value of this property is Long.MaxValue
    tombstoneRetentionTimeInHours Number
    Number of hours to retain the tombstone markers of a compacted Event Hub. This value is only used when cleanupPolicy is Compact. Consumer must complete reading the tombstone marker within this specified amount of time if consumer begins from starting offset to ensure they get a valid snapshot for the specific key described by the tombstone marker within the compacted Event Hub

    SystemDataResponse, SystemDataResponseArgs

    CreatedAt string
    The timestamp of resource creation (UTC).
    CreatedBy string
    The identity that created the resource.
    CreatedByType string
    The type of identity that created the resource.
    LastModifiedAt string
    The type of identity that last modified the resource.
    LastModifiedBy string
    The identity that last modified the resource.
    LastModifiedByType string
    The type of identity that last modified the resource.
    CreatedAt string
    The timestamp of resource creation (UTC).
    CreatedBy string
    The identity that created the resource.
    CreatedByType string
    The type of identity that created the resource.
    LastModifiedAt string
    The type of identity that last modified the resource.
    LastModifiedBy string
    The identity that last modified the resource.
    LastModifiedByType string
    The type of identity that last modified the resource.
    createdAt String
    The timestamp of resource creation (UTC).
    createdBy String
    The identity that created the resource.
    createdByType String
    The type of identity that created the resource.
    lastModifiedAt String
    The type of identity that last modified the resource.
    lastModifiedBy String
    The identity that last modified the resource.
    lastModifiedByType String
    The type of identity that last modified the resource.
    createdAt string
    The timestamp of resource creation (UTC).
    createdBy string
    The identity that created the resource.
    createdByType string
    The type of identity that created the resource.
    lastModifiedAt string
    The type of identity that last modified the resource.
    lastModifiedBy string
    The identity that last modified the resource.
    lastModifiedByType string
    The type of identity that last modified the resource.
    created_at str
    The timestamp of resource creation (UTC).
    created_by str
    The identity that created the resource.
    created_by_type str
    The type of identity that created the resource.
    last_modified_at str
    The type of identity that last modified the resource.
    last_modified_by str
    The identity that last modified the resource.
    last_modified_by_type str
    The type of identity that last modified the resource.
    createdAt String
    The timestamp of resource creation (UTC).
    createdBy String
    The identity that created the resource.
    createdByType String
    The type of identity that created the resource.
    lastModifiedAt String
    The type of identity that last modified the resource.
    lastModifiedBy String
    The identity that last modified the resource.
    lastModifiedByType String
    The type of identity that last modified the resource.

    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/{subscriptionId}/resourceGroups/{resourceGroupName}/providers/Microsoft.EventHub/namespaces/{namespaceName}/eventhubs/{eventHubName} 
    

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

    Package Details

    Repository
    Azure Native pulumi/pulumi-azure-native
    License
    Apache-2.0
    azure-native logo
    This is the latest version of Azure Native. Use the Azure Native v1 docs if using the v1 version of this package.
    Azure Native v2.37.0 published on Monday, Apr 15, 2024 by Pulumi