Documentation ¶
Index ¶
- Constants
- func NewBindingsReadResponseFromEventData(e *azeventhubs.ReceivedEventData, topic string, getAllProperties bool) (*bindings.ReadResponse, error)
- func NewBulkMessageEntryFromEventData(e *azeventhubs.ReceivedEventData, topic string, getAllProperties bool) (pubsub.BulkMessageEntry, error)
- func NewPubsubMessageFromEventData(e *azeventhubs.ReceivedEventData, topic string, getAllProperties bool) (*pubsub.NewMessage, error)
- type AzureEventHubs
- func (aeh *AzureEventHubs) Close() (err error)
- func (aeh *AzureEventHubs) EventHubName() string
- func (aeh *AzureEventHubs) GetBindingsHandlerFunc(topic string, getAllProperties bool, handler bindings.Handler) HandlerFn
- func (aeh *AzureEventHubs) GetBulkPubSubHandlerFunc(topic string, getAllProperties bool, handler pubsub.BulkHandler) HandlerFn
- func (aeh *AzureEventHubs) GetPubSubHandlerFunc(topic string, getAllProperties bool, handler pubsub.Handler) HandlerFn
- func (aeh *AzureEventHubs) Init(metadata map[string]string) error
- func (aeh *AzureEventHubs) Publish(ctx context.Context, topic string, messages []*azeventhubs.EventData, ...) error
- func (aeh *AzureEventHubs) Subscribe(subscribeCtx context.Context, config SubscribeConfig) error
- type AzureEventHubsMetadata
- type HandlerFn
- type HandlerResponseItem
- type SubscribeConfig
- type SubscribeHandler
Constants ¶
const ( DefaultMaxBulkSubCount = 100 DefaultMaxBulkSubAwaitDurationMs = 10000 DefaultCheckpointFrequencyPerPartition = 1 )
Variables ¶
This section is empty.
Functions ¶
func NewBindingsReadResponseFromEventData ¶
func NewBindingsReadResponseFromEventData(e *azeventhubs.ReceivedEventData, topic string, getAllProperties bool) (*bindings.ReadResponse, error)
Returns bindings read response message from azure eventhub message
func NewBulkMessageEntryFromEventData ¶
func NewBulkMessageEntryFromEventData(e *azeventhubs.ReceivedEventData, topic string, getAllProperties bool) (pubsub.BulkMessageEntry, error)
Returns a new bulk pubsub message entry from azure eventhub message
func NewPubsubMessageFromEventData ¶
func NewPubsubMessageFromEventData(e *azeventhubs.ReceivedEventData, topic string, getAllProperties bool) (*pubsub.NewMessage, error)
Returns a new pubsub message from azure eventhub message
Types ¶
type AzureEventHubs ¶
type AzureEventHubs struct {
// contains filtered or unexported fields
}
AzureEventHubs allows sending/receiving Azure Event Hubs events. This is an abstract class used by both the pubsub and binding components.
func NewAzureEventHubs ¶
func NewAzureEventHubs(logger logger.Logger, isBinding bool) *AzureEventHubs
NewAzureEventHubs returns a new Azure Event hubs instance.
func (*AzureEventHubs) Close ¶
func (aeh *AzureEventHubs) Close() (err error)
func (*AzureEventHubs) EventHubName ¶
func (aeh *AzureEventHubs) EventHubName() string
EventHubName returns the parsed eventHub property from the metadata. It's used by the binding only.
func (*AzureEventHubs) GetBindingsHandlerFunc ¶
func (aeh *AzureEventHubs) GetBindingsHandlerFunc(topic string, getAllProperties bool, handler bindings.Handler) HandlerFn
GetBindingsHandlerFunc returns the handler function for bindings messages
func (*AzureEventHubs) GetBulkPubSubHandlerFunc ¶
func (aeh *AzureEventHubs) GetBulkPubSubHandlerFunc(topic string, getAllProperties bool, handler pubsub.BulkHandler) HandlerFn
GetPubSubHandlerFunc returns the handler function for bulk pubsub messages.
func (*AzureEventHubs) GetPubSubHandlerFunc ¶
func (aeh *AzureEventHubs) GetPubSubHandlerFunc(topic string, getAllProperties bool, handler pubsub.Handler) HandlerFn
GetPubSubHandlerFunc returns the handler function for pubsub messages
func (*AzureEventHubs) Init ¶
func (aeh *AzureEventHubs) Init(metadata map[string]string) error
Init connects to Azure Event Hubs.
func (*AzureEventHubs) Publish ¶
func (aeh *AzureEventHubs) Publish(ctx context.Context, topic string, messages []*azeventhubs.EventData, batchOpts *azeventhubs.EventDataBatchOptions) error
Publish a batch of messages.
func (*AzureEventHubs) Subscribe ¶
func (aeh *AzureEventHubs) Subscribe(subscribeCtx context.Context, config SubscribeConfig) error
Subscribe receives data from Azure Event Hubs in background.
type AzureEventHubsMetadata ¶
type AzureEventHubsMetadata struct { ConnectionString string `json:"connectionString" mapstructure:"connectionString"` EventHubNamespace string `json:"eventHubNamespace" mapstructure:"eventHubNamespace"` ConsumerID string `json:"consumerID" mapstructure:"consumerID"` StorageConnectionString string `json:"storageConnectionString" mapstructure:"storageConnectionString"` StorageAccountName string `json:"storageAccountName" mapstructure:"storageAccountName"` StorageAccountKey string `json:"storageAccountKey" mapstructure:"storageAccountKey"` StorageContainerName string `json:"storageContainerName" mapstructure:"storageContainerName"` EnableEntityManagement bool `json:"enableEntityManagement,string" mapstructure:"enableEntityManagement"` MessageRetentionInDays int32 `json:"messageRetentionInDays,string" mapstructure:"messageRetentionInDays"` PartitionCount int32 `json:"partitionCount,string" mapstructure:"partitionCount"` SubscriptionID string `json:"subscriptionID" mapstructure:"subscriptionID"` ResourceGroupName string `json:"resourceGroupName" mapstructure:"resourceGroupName"` // Binding only EventHub string `json:"eventHub" mapstructure:"eventHub" mdonly:"bindings"` ConsumerGroup string `json:"consumerGroup" mapstructure:"consumerGroup" mdonly:"bindings"` // Alias for ConsumerID // contains filtered or unexported fields }
type HandlerFn ¶
type HandlerFn = func(context.Context, []*azeventhubs.ReceivedEventData) ([]HandlerResponseItem, error)
type HandlerResponseItem ¶
HandlerResponseItem represents a response from the handler for each message.