azure-native.eventhub.getEventHub

Explore with Pulumi AI

Gets an Event Hubs description for the specified Event Hub. API Version: 2017-04-01.

Using getEventHub

Two invocation forms are available. The direct form accepts plain arguments and either blocks until the result value is available, or returns a Promise-wrapped result. The output form accepts Input-wrapped arguments and returns an Output-wrapped result.

function getEventHub(args: GetEventHubArgs, opts?: InvokeOptions): Promise<GetEventHubResult>
function getEventHubOutput(args: GetEventHubOutputArgs, opts?: InvokeOptions): Output<GetEventHubResult>
def get_event_hub(event_hub_name: Optional[str] = None,
                  namespace_name: Optional[str] = None,
                  resource_group_name: Optional[str] = None,
                  opts: Optional[InvokeOptions] = None) -> GetEventHubResult
def get_event_hub_output(event_hub_name: Optional[pulumi.Input[str]] = None,
                  namespace_name: Optional[pulumi.Input[str]] = None,
                  resource_group_name: Optional[pulumi.Input[str]] = None,
                  opts: Optional[InvokeOptions] = None) -> Output[GetEventHubResult]
func LookupEventHub(ctx *Context, args *LookupEventHubArgs, opts ...InvokeOption) (*LookupEventHubResult, error)
func LookupEventHubOutput(ctx *Context, args *LookupEventHubOutputArgs, opts ...InvokeOption) LookupEventHubResultOutput

> Note: This function is named LookupEventHub in the Go SDK.

public static class GetEventHub 
{
    public static Task<GetEventHubResult> InvokeAsync(GetEventHubArgs args, InvokeOptions? opts = null)
    public static Output<GetEventHubResult> Invoke(GetEventHubInvokeArgs args, InvokeOptions? opts = null)
}
public static CompletableFuture<GetEventHubResult> getEventHub(GetEventHubArgs args, InvokeOptions options)
// Output-based functions aren't available in Java yet
fn::invoke:
  function: azure-native:eventhub:getEventHub
  arguments:
    # arguments dictionary

The following arguments are supported:

EventHubName string

The Event Hub name

NamespaceName string

The Namespace name

ResourceGroupName string

Name of the resource group within the azure subscription.

EventHubName string

The Event Hub name

NamespaceName string

The Namespace name

ResourceGroupName string

Name of the resource group within the azure subscription.

eventHubName String

The Event Hub name

namespaceName String

The Namespace name

resourceGroupName String

Name of the resource group within the azure subscription.

eventHubName string

The Event Hub name

namespaceName string

The Namespace name

resourceGroupName string

Name of the resource group within the azure subscription.

event_hub_name str

The Event Hub name

namespace_name str

The Namespace name

resource_group_name str

Name of the resource group within the azure subscription.

eventHubName String

The Event Hub name

namespaceName String

The Namespace name

resourceGroupName String

Name of the resource group within the azure subscription.

getEventHub Result

The following output properties are available:

CreatedAt string

Exact time the Event Hub was created.

Id string

Fully qualified resource ID for the resource. Ex - /subscriptions/{subscriptionId}/resourceGroups/{resourceGroupName}/providers/{resourceProviderNamespace}/{resourceType}/{resourceName}

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.

CaptureDescription Pulumi.AzureNative.EventHub.Outputs.CaptureDescriptionResponse

Properties of capture description

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 string

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

CreatedAt string

Exact time the Event Hub was created.

Id string

Fully qualified resource ID for the resource. Ex - /subscriptions/{subscriptionId}/resourceGroups/{resourceGroupName}/providers/{resourceProviderNamespace}/{resourceType}/{resourceName}

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.

CaptureDescription CaptureDescriptionResponse

Properties of capture description

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 string

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

createdAt String

Exact time the Event Hub was created.

id String

Fully qualified resource ID for the resource. Ex - /subscriptions/{subscriptionId}/resourceGroups/{resourceGroupName}/providers/{resourceProviderNamespace}/{resourceType}/{resourceName}

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.

captureDescription CaptureDescriptionResponse

Properties of capture description

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 String

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

createdAt string

Exact time the Event Hub was created.

id string

Fully qualified resource ID for the resource. Ex - /subscriptions/{subscriptionId}/resourceGroups/{resourceGroupName}/providers/{resourceProviderNamespace}/{resourceType}/{resourceName}

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.

captureDescription CaptureDescriptionResponse

Properties of capture description

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 string

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

created_at str

Exact time the Event Hub was created.

id str

Fully qualified resource ID for the resource. Ex - /subscriptions/{subscriptionId}/resourceGroups/{resourceGroupName}/providers/{resourceProviderNamespace}/{resourceType}/{resourceName}

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.

capture_description CaptureDescriptionResponse

Properties of capture description

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 str

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

createdAt String

Exact time the Event Hub was created.

id String

Fully qualified resource ID for the resource. Ex - /subscriptions/{subscriptionId}/resourceGroups/{resourceGroupName}/providers/{resourceProviderNamespace}/{resourceType}/{resourceName}

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.

captureDescription Property Map

Properties of capture description

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 String

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

Supporting Types

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

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

Package Details

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