Edit

Share via


EventHubDataAdapter Class

Definition

Default event hub data adapter. Users may subclass to override event data to stream mapping.

public class EventHubDataAdapter : Orleans.Providers.Streams.Common.ICacheDataAdapter<Microsoft.ServiceBus.Messaging.EventData,Orleans.ServiceBus.Providers.CachedEventHubMessage>
public class EventHubDataAdapter : Orleans.Providers.Streams.Common.ICacheDataAdapter<Microsoft.Azure.EventHubs.EventData,Orleans.ServiceBus.Providers.CachedEventHubMessage>
public class EventHubDataAdapter : Orleans.Providers.Streams.Common.ICacheDataAdapter, Orleans.ServiceBus.Providers.IEventHubDataAdapter, Orleans.Streams.IQueueDataAdapter<Azure.Messaging.EventHubs.EventData>
type EventHubDataAdapter = class
    interface ICacheDataAdapter<EventData, CachedEventHubMessage>
type EventHubDataAdapter = class
    interface IEventHubDataAdapter
    interface IQueueDataAdapter<EventData>
    interface ICacheDataAdapter
Public Class EventHubDataAdapter
Implements ICacheDataAdapter(Of EventData, CachedEventHubMessage)
Public Class EventHubDataAdapter
Implements ICacheDataAdapter, IEventHubDataAdapter, IQueueDataAdapter(Of EventData)
Inheritance
EventHubDataAdapter
Implements

Constructors

EventHubDataAdapter(SerializationManager)

Cache data adapter that adapts EventHub's EventData to CachedEventHubMessage used in cache

EventHubDataAdapter(SerializationManager, IObjectPool<FixedSizeBuffer>)

Cache data adapter that adapts EventHub's EventData to CachedEventHubMessage used in cache

Properties

OnBlockAllocated

Should be set to OnBlockAllocated method of the cache's EvicationStrategy

Methods

EncodeMessageIntoSegment(EventData, Func<Int32,ArraySegment<Byte>>)
FromQueueMessage(StreamPosition, EventData, DateTime, Func<Int32,ArraySegment<Byte>>)
GetBatchContainer(CachedEventHubMessage)

Converts a cached message to a batch container for delivery

GetBatchContainer(CachedMessage)

Converts a cached message to a batch container for delivery

GetBatchContainer(EventHubMessage)

Convert an EventHubMessage to a batch container

GetMessageDequeueTimeUtc(CachedEventHubMessage)

Pooled queue cache stores data in tightly packed structures that need to be transformed to various other formats quickly. Since the data formats may change by queue type and data format, this interface allows adapter developers to build custom data transforms appropriate for the various types of queue data.

GetMessageEnqueueTimeUtc(CachedEventHubMessage)

Pooled queue cache stores data in tightly packed structures that need to be transformed to various other formats quickly. Since the data formats may change by queue type and data format, this interface allows adapter developers to build custom data transforms appropriate for the various types of queue data.

GetOffset(CachedMessage)

Get offset from cached message. Left to derived class, as only it knows how to get this from the cached message.

GetPartitionKey(Guid, String)

Get the Event Hub partition key to use for a stream.

GetSequenceToken(CachedEventHubMessage)

Gets the stream sequence token from a cached message.

GetSequenceToken(CachedMessage)

Gets the stream sequence token from a cached message.

GetStreamIdentity(EventData)

Get the IStreamIdentity for an event message.

GetStreamPosition(EventData)

Gets the stream position from a queue message

GetStreamPosition(EventData)

Gets the stream position from a queue message

GetStreamPosition(String, EventData)
QueueMessageToCachedMessage(CachedEventHubMessage, EventData, DateTime)

Converts a TQueueMessage message from the queue to a TCachedMessage cachable structures.

QueueMessageToCachedMessage(CachedEventHubMessage, EventData, DateTime)

Converts a TQueueMessage message from the queue to a TCachedMessage cachable structures.

ToQueueMessage<T>(Guid, String, IEnumerable<T>, StreamSequenceToken, Dictionary<String,Object>)

Applies to