Index
All Classes and Interfaces|All Packages|Constant Field Values
A
- addBuilderCustomizer(AzureServiceClientBuilderCustomizer<EventHubClientBuilder>) - Method in class com.azure.spring.messaging.eventhubs.core.DefaultEventHubsNamespaceProducerFactory
-
Add a service client builder customizer to customize all the clients created from this factory.
- addBuilderCustomizer(AzureServiceClientBuilderCustomizer<EventProcessorClientBuilder>) - Method in class com.azure.spring.messaging.eventhubs.core.DefaultEventHubsNamespaceProcessorFactory
-
Add a service client builder customizer to customize all the clients created from this factory.
- addBuilderCustomizer(String, AzureServiceClientBuilderCustomizer<EventHubClientBuilder>) - Method in class com.azure.spring.messaging.eventhubs.core.DefaultEventHubsNamespaceProducerFactory
-
Add a service client builder customizer to customize the clients created from this factory with event hub name of value
eventHub
. - addBuilderCustomizer(String, String, AzureServiceClientBuilderCustomizer<EventProcessorClientBuilder>) - Method in class com.azure.spring.messaging.eventhubs.core.DefaultEventHubsNamespaceProcessorFactory
-
Add a service client builder customizer to customize the clients created from this factory with event hub name of value
eventHub
and consumer group of valueconsumerGroup
. - addListener(EventHubsProcessorFactory.Listener) - Method in class com.azure.spring.messaging.eventhubs.core.DefaultEventHubsNamespaceProcessorFactory
- addListener(EventHubsProcessorFactory.Listener) - Method in interface com.azure.spring.messaging.eventhubs.core.EventHubsProcessorFactory
-
Add a listener for this factory.
- addListener(EventHubsProducerFactory.Listener) - Method in class com.azure.spring.messaging.eventhubs.core.DefaultEventHubsNamespaceProducerFactory
- addListener(EventHubsProducerFactory.Listener) - Method in interface com.azure.spring.messaging.eventhubs.core.EventHubsProducerFactory
-
Add a listener for this factory.
B
- BATCH - Enum constant in enum com.azure.spring.messaging.eventhubs.core.checkpoint.CheckpointMode
-
Checkpoint after each processed batch of records.
- BATCH_CONVERTED_APPLICATION_PROPERTIES - Static variable in class com.azure.spring.messaging.eventhubs.support.EventHubsHeaders
-
Batch converted application properties.
- BATCH_CONVERTED_ENQUEUED_TIME - Static variable in class com.azure.spring.messaging.eventhubs.support.EventHubsHeaders
-
Batch converted enqueued time.
- BATCH_CONVERTED_OFFSET - Static variable in class com.azure.spring.messaging.eventhubs.support.EventHubsHeaders
-
Batch converted offset.
- BATCH_CONVERTED_SEQUENCE_NUMBER - Static variable in class com.azure.spring.messaging.eventhubs.support.EventHubsHeaders
-
Batch converted sequence number.
- BATCH_CONVERTED_SYSTEM_PROPERTIES - Static variable in class com.azure.spring.messaging.eventhubs.support.EventHubsHeaders
-
Batch converted system properties.
C
- CheckpointConfig - Class in com.azure.spring.messaging.eventhubs.core.checkpoint
-
Checkpoint config to describe different checkpoint strategies.
- CheckpointConfig() - Constructor for class com.azure.spring.messaging.eventhubs.core.checkpoint.CheckpointConfig
-
Construct a
CheckpointConfig
with theCheckpointMode.RECORD
mode. - CheckpointConfig(CheckpointMode) - Constructor for class com.azure.spring.messaging.eventhubs.core.checkpoint.CheckpointConfig
-
Construct a
CheckpointConfig
with the specifiedCheckpointMode
mode. - CheckpointConfig(CheckpointMode, Integer) - Constructor for class com.azure.spring.messaging.eventhubs.core.checkpoint.CheckpointConfig
-
Construct a
CheckpointConfig
with the specifiedCheckpointMode
mode and the amount of messages for each partition to do one checkpoint. - CheckpointConfig(CheckpointMode, Integer, Duration) - Constructor for class com.azure.spring.messaging.eventhubs.core.checkpoint.CheckpointConfig
-
Construct a
CheckpointConfig
with the specifiedCheckpointMode
mode, the amount of messages for each partition to do one checkpoint and the time interval to do one checkpoint. - CheckpointConfig(CheckpointMode, Duration) - Constructor for class com.azure.spring.messaging.eventhubs.core.checkpoint.CheckpointConfig
-
Construct a
CheckpointConfig
with the specifiedCheckpointMode
mode and the time interval to do one checkpoint. - CheckpointMode - Enum in com.azure.spring.messaging.eventhubs.core.checkpoint
-
The offset commit behavior enumeration.
- com.azure.spring.messaging.eventhubs.core - package com.azure.spring.messaging.eventhubs.core
-
Spring Messaging Event Hubs core package.
- com.azure.spring.messaging.eventhubs.core.checkpoint - package com.azure.spring.messaging.eventhubs.core.checkpoint
-
Event Hubs checkpoint configs.
- com.azure.spring.messaging.eventhubs.core.listener - package com.azure.spring.messaging.eventhubs.core.listener
-
Spring Messaging Event Hubs listener implementation.
- com.azure.spring.messaging.eventhubs.core.properties - package com.azure.spring.messaging.eventhubs.core.properties
-
Spring Messaging Event Hubs properties abstraction.
- com.azure.spring.messaging.eventhubs.support - package com.azure.spring.messaging.eventhubs.support
-
Spring Messaging Event Hubs support utility class.
- CommonProperties - Class in com.azure.spring.messaging.eventhubs.core.properties
-
Common properties shared by event hub namespace, a producer, and a consumer.
- CommonProperties() - Constructor for class com.azure.spring.messaging.eventhubs.core.properties.CommonProperties
-
Create an instance of
CommonProperties
. - ConsumerProperties - Class in com.azure.spring.messaging.eventhubs.core.properties
-
An event hub consumer related properties.
- ConsumerProperties() - Constructor for class com.azure.spring.messaging.eventhubs.core.properties.ConsumerProperties
-
Create an instance of
ConsumerProperties
- createProcessor(String, String, MessageListener<?>, EventHubsErrorHandler) - Method in class com.azure.spring.messaging.eventhubs.core.DefaultEventHubsNamespaceProcessorFactory
- createProcessor(String, String, MessageListener<?>, EventHubsErrorHandler) - Method in interface com.azure.spring.messaging.eventhubs.core.EventHubsProcessorFactory
-
Create an
EventProcessorClient
to consume events from the specified event hub in the context of the given consumer group. - createProcessor(String, String, EventHubsContainerProperties) - Method in class com.azure.spring.messaging.eventhubs.core.DefaultEventHubsNamespaceProcessorFactory
- createProcessor(String, String, EventHubsContainerProperties) - Method in interface com.azure.spring.messaging.eventhubs.core.EventHubsProcessorFactory
-
Create an
EventProcessorClient
to consume events from the specified event hub in the context of the given consumer group. - createProducer(String) - Method in class com.azure.spring.messaging.eventhubs.core.DefaultEventHubsNamespaceProducerFactory
- createProducer(String) - Method in interface com.azure.spring.messaging.eventhubs.core.EventHubsProducerFactory
-
Create
EventHubProducerAsyncClient
to send events to the event hub.
D
- DefaultEventHubsNamespaceProcessorFactory - Class in com.azure.spring.messaging.eventhubs.core
-
The
EventHubsProcessorFactory
implementation to produce newEventProcessorClient
instances for providedCheckpointStore
checkpointStore
and optionalNamespaceProperties
and processorPropertiesSupplier
on eachDefaultEventHubsNamespaceProcessorFactory.createProcessor(java.lang.String, java.lang.String, com.azure.spring.cloud.service.listener.MessageListener<?>, com.azure.spring.cloud.service.eventhubs.consumer.EventHubsErrorHandler)
invocation. - DefaultEventHubsNamespaceProcessorFactory(CheckpointStore) - Constructor for class com.azure.spring.messaging.eventhubs.core.DefaultEventHubsNamespaceProcessorFactory
-
Construct a factory with the provided
CheckpointStore
. - DefaultEventHubsNamespaceProcessorFactory(CheckpointStore, NamespaceProperties) - Constructor for class com.azure.spring.messaging.eventhubs.core.DefaultEventHubsNamespaceProcessorFactory
-
Construct a factory with the provided
CheckpointStore
and namespace level properties. - DefaultEventHubsNamespaceProcessorFactory(CheckpointStore, NamespaceProperties, PropertiesSupplier<ConsumerIdentifier, ProcessorProperties>) - Constructor for class com.azure.spring.messaging.eventhubs.core.DefaultEventHubsNamespaceProcessorFactory
-
Construct a factory with the provided
CheckpointStore
, namespace level properties and processorPropertiesSupplier
. - DefaultEventHubsNamespaceProcessorFactory(CheckpointStore, PropertiesSupplier<ConsumerIdentifier, ProcessorProperties>) - Constructor for class com.azure.spring.messaging.eventhubs.core.DefaultEventHubsNamespaceProcessorFactory
-
Construct a factory with the provided
CheckpointStore
and processorPropertiesSupplier
. - DefaultEventHubsNamespaceProducerFactory - Class in com.azure.spring.messaging.eventhubs.core
-
The
EventHubsProducerFactory
implementation to produce cachedEventHubProducerAsyncClient
instances for providedNamespaceProperties
and optional producerPropertiesSupplier
on eachDefaultEventHubsNamespaceProducerFactory.createProducer(java.lang.String)
invocation. - DefaultEventHubsNamespaceProducerFactory(NamespaceProperties) - Constructor for class com.azure.spring.messaging.eventhubs.core.DefaultEventHubsNamespaceProducerFactory
-
Construct a factory with the provided namespace level configuration.
- DefaultEventHubsNamespaceProducerFactory(NamespaceProperties, PropertiesSupplier<String, ProducerProperties>) - Constructor for class com.azure.spring.messaging.eventhubs.core.DefaultEventHubsNamespaceProducerFactory
-
Construct a factory with the provided namespace level configuration and producer
PropertiesSupplier
. - destroy() - Method in class com.azure.spring.messaging.eventhubs.core.DefaultEventHubsNamespaceProcessorFactory
- destroy() - Method in class com.azure.spring.messaging.eventhubs.core.DefaultEventHubsNamespaceProducerFactory
- doStart() - Method in class com.azure.spring.messaging.eventhubs.core.listener.EventHubsMessageListenerContainer
- doStop() - Method in class com.azure.spring.messaging.eventhubs.core.listener.EventHubsMessageListenerContainer
E
- ENQUEUED_TIME - Static variable in class com.azure.spring.messaging.eventhubs.support.EventHubsHeaders
-
Enqueued time.
- EventHubsContainerProperties - Class in com.azure.spring.messaging.eventhubs.core.properties
-
The properties to describe an Event Hubs listener container.
- EventHubsContainerProperties() - Constructor for class com.azure.spring.messaging.eventhubs.core.properties.EventHubsContainerProperties
-
Creates an instance of
EventHubsContainerProperties
. - EventHubsHeaders - Class in com.azure.spring.messaging.eventhubs.support
-
Azure Event Hubs internal headers for Spring Messaging messages.
- EventHubsMessageListenerContainer - Class in com.azure.spring.messaging.eventhubs.core.listener
-
EventHubs message listener container using
EventProcessorClient
to subscribe to event hubs and consume events from all the partitions of each event hub. - EventHubsMessageListenerContainer(EventHubsProcessorFactory, EventHubsContainerProperties) - Constructor for class com.azure.spring.messaging.eventhubs.core.listener.EventHubsMessageListenerContainer
-
Create an instance using the supplied processor factory and container properties.
- EventHubsProcessorFactory - Interface in com.azure.spring.messaging.eventhubs.core
-
The strategy to produce
EventProcessorClient
instance. - EventHubsProcessorFactory.Listener - Interface in com.azure.spring.messaging.eventhubs.core
-
Called whenever a processor is added or removed.
- EventHubsProducerFactory - Interface in com.azure.spring.messaging.eventhubs.core
-
The strategy to produce
EventHubProducerAsyncClient
instance. - EventHubsProducerFactory.Listener - Interface in com.azure.spring.messaging.eventhubs.core
-
Called whenever a producer is added or removed.
- EventHubsTemplate - Class in com.azure.spring.messaging.eventhubs.core
-
A template for executing sending operations asynchronously to Event Hubs.
- EventHubsTemplate(EventHubsProducerFactory) - Constructor for class com.azure.spring.messaging.eventhubs.core.EventHubsTemplate
-
Create an instance using the supplied producer factory.
G
- getBatch() - Method in class com.azure.spring.messaging.eventhubs.core.properties.ProcessorProperties
- getCheckpointConfig() - Method in class com.azure.spring.messaging.eventhubs.core.properties.EventHubsContainerProperties
-
Get the checkpoint config.
- getCloseContextConsumer() - Method in class com.azure.spring.messaging.eventhubs.core.properties.EventHubsContainerProperties
-
Get the consumer to consume close context.
- getConnectionString() - Method in class com.azure.spring.messaging.eventhubs.core.properties.CommonProperties
- getConsumerGroup() - Method in class com.azure.spring.messaging.eventhubs.core.properties.ConsumerProperties
- getContainerProperties() - Method in class com.azure.spring.messaging.eventhubs.core.listener.EventHubsMessageListenerContainer
- getCount() - Method in class com.azure.spring.messaging.eventhubs.core.checkpoint.CheckpointConfig
-
Get the amount of message for each partition to do one checkpoint.
- getCustomEndpointAddress() - Method in class com.azure.spring.messaging.eventhubs.core.properties.CommonProperties
- getDomainName() - Method in class com.azure.spring.messaging.eventhubs.core.properties.CommonProperties
- getErrorHandler() - Method in class com.azure.spring.messaging.eventhubs.core.properties.EventHubsContainerProperties
-
Get the error handler of the container.
- getEventHubName() - Method in class com.azure.spring.messaging.eventhubs.core.properties.CommonProperties
- getFullyQualifiedNamespace() - Method in class com.azure.spring.messaging.eventhubs.core.properties.CommonProperties
- getInitializationContextConsumer() - Method in class com.azure.spring.messaging.eventhubs.core.properties.EventHubsContainerProperties
-
Get the consumer to consume initialization context.
- getInitialPartitionEventPosition() - Method in class com.azure.spring.messaging.eventhubs.core.properties.ProcessorProperties
- getInterval() - Method in class com.azure.spring.messaging.eventhubs.core.checkpoint.CheckpointConfig
-
Get the time interval to do one checkpoint.
- getLoadBalancing() - Method in class com.azure.spring.messaging.eventhubs.core.properties.ProcessorProperties
- getMessageListener() - Method in class com.azure.spring.messaging.eventhubs.core.properties.EventHubsContainerProperties
-
Get the message listener of the container.
- getMode() - Method in class com.azure.spring.messaging.eventhubs.core.checkpoint.CheckpointConfig
-
Get the checkpoint mode.
- getNamespace() - Method in class com.azure.spring.messaging.eventhubs.core.properties.CommonProperties
- getPartitionId() - Method in class com.azure.spring.messaging.eventhubs.core.PartitionSupplier
-
Get the partition id.
- getPartitionKey() - Method in class com.azure.spring.messaging.eventhubs.core.PartitionSupplier
-
Get the partition key.
- getPrefetchCount() - Method in class com.azure.spring.messaging.eventhubs.core.properties.ConsumerProperties
- getSharedConnection() - Method in class com.azure.spring.messaging.eventhubs.core.properties.NamespaceProperties
- getTrackLastEnqueuedEventProperties() - Method in class com.azure.spring.messaging.eventhubs.core.properties.ProcessorProperties
L
- LAST_ENQUEUED_EVENT_PROPERTIES - Static variable in class com.azure.spring.messaging.eventhubs.support.EventHubsHeaders
-
Last enqueued event properties.
M
- MANUAL - Enum constant in enum com.azure.spring.messaging.eventhubs.core.checkpoint.CheckpointMode
-
User decide when to checkpoint manually
N
- NamespaceProperties - Class in com.azure.spring.messaging.eventhubs.core.properties
-
An event hub namespace related properties.
- NamespaceProperties() - Constructor for class com.azure.spring.messaging.eventhubs.core.properties.NamespaceProperties
-
The default constructor.
O
- OFFSET - Static variable in class com.azure.spring.messaging.eventhubs.support.EventHubsHeaders
-
Offset.
P
- PARTITION_COUNT - Enum constant in enum com.azure.spring.messaging.eventhubs.core.checkpoint.CheckpointMode
-
Checkpoint once for number of message specified by
CheckpointConfig.getCount()
()} in each partition - PartitionSupplier - Class in com.azure.spring.messaging.eventhubs.core
-
Represents a supplier of partition id or key.
- PartitionSupplier() - Constructor for class com.azure.spring.messaging.eventhubs.core.PartitionSupplier
-
Create an instance of
PartitionSupplier
. - processorAdded(String, String, EventProcessorClient) - Method in interface com.azure.spring.messaging.eventhubs.core.EventHubsProcessorFactory.Listener
-
The callback method that the processor has been added.
- ProcessorProperties - Class in com.azure.spring.messaging.eventhubs.core.properties
-
An event hub processor related properties.
- ProcessorProperties() - Constructor for class com.azure.spring.messaging.eventhubs.core.properties.ProcessorProperties
-
Create an instance of
ProcessorProperties
. - processorRemoved(String, String, EventProcessorClient) - Method in interface com.azure.spring.messaging.eventhubs.core.EventHubsProcessorFactory.Listener
-
The default callback method that the processor has been removed.
- producerAdded(String, EventHubProducerAsyncClient) - Method in interface com.azure.spring.messaging.eventhubs.core.EventHubsProducerFactory.Listener
-
The callback method that the producer has been added.
- ProducerProperties - Class in com.azure.spring.messaging.eventhubs.core.properties
-
An event hub producer related properties.
- ProducerProperties() - Constructor for class com.azure.spring.messaging.eventhubs.core.properties.ProducerProperties
-
Create an instance of
ProducerProperties
. - producerRemoved(String, EventHubProducerAsyncClient) - Method in interface com.azure.spring.messaging.eventhubs.core.EventHubsProducerFactory.Listener
-
The default callback method that the producer has been removed.
R
- RECORD - Enum constant in enum com.azure.spring.messaging.eventhubs.core.checkpoint.CheckpointMode
-
Checkpoint after each processed record.
- removeListener(EventHubsProcessorFactory.Listener) - Method in class com.azure.spring.messaging.eventhubs.core.DefaultEventHubsNamespaceProcessorFactory
- removeListener(EventHubsProcessorFactory.Listener) - Method in interface com.azure.spring.messaging.eventhubs.core.EventHubsProcessorFactory
-
Remove a listener from this factory.
- removeListener(EventHubsProducerFactory.Listener) - Method in class com.azure.spring.messaging.eventhubs.core.DefaultEventHubsNamespaceProducerFactory
- removeListener(EventHubsProducerFactory.Listener) - Method in interface com.azure.spring.messaging.eventhubs.core.EventHubsProducerFactory
-
Remove a listener
S
- send(String, Collection<Message<T>>) - Method in class com.azure.spring.messaging.eventhubs.core.EventHubsTemplate
-
Send a
Collection
<Message
> to the given destination synchronously. - send(String, Collection<Message<T>>, PartitionSupplier) - Method in class com.azure.spring.messaging.eventhubs.core.EventHubsTemplate
-
Send a
Collection
<Message
> to the given destination with a given partition supplier synchronously. - sendAsync(String, Collection<Message<T>>) - Method in class com.azure.spring.messaging.eventhubs.core.EventHubsTemplate
-
Send a
Collection
<Message
> to the given destination asynchronously. - sendAsync(String, Collection<Message<T>>, PartitionSupplier) - Method in class com.azure.spring.messaging.eventhubs.core.EventHubsTemplate
-
Send a
Collection
<Message
> to the given destination with a given partition supplier asynchronously. - sendAsync(String, Message<T>) - Method in class com.azure.spring.messaging.eventhubs.core.EventHubsTemplate
- SEQUENCE_NUMBER - Static variable in class com.azure.spring.messaging.eventhubs.support.EventHubsHeaders
-
Sequence number.
- setCheckpointConfig(CheckpointConfig) - Method in class com.azure.spring.messaging.eventhubs.core.properties.EventHubsContainerProperties
-
Set the checkpoint config.
- setCloseContextConsumer(Consumer<CloseContext>) - Method in class com.azure.spring.messaging.eventhubs.core.properties.EventHubsContainerProperties
-
Set the consumer to consume close context.
- setConnectionString(String) - Method in class com.azure.spring.messaging.eventhubs.core.properties.CommonProperties
-
Set the connection string.
- setConsumerGroup(String) - Method in class com.azure.spring.messaging.eventhubs.core.properties.ConsumerProperties
-
Set the custom endpoint address.
- setCount(Integer) - Method in class com.azure.spring.messaging.eventhubs.core.checkpoint.CheckpointConfig
-
Set the amount of message for each partition to do one checkpoint.
- setCustomEndpointAddress(String) - Method in class com.azure.spring.messaging.eventhubs.core.properties.CommonProperties
-
Set the custom endpoint address.
- setDefaultCredential(TokenCredential) - Method in class com.azure.spring.messaging.eventhubs.core.DefaultEventHubsNamespaceProcessorFactory
-
Set the default credential for all clients generated from this factory.
- setDefaultCredential(TokenCredential) - Method in class com.azure.spring.messaging.eventhubs.core.DefaultEventHubsNamespaceProducerFactory
-
Set the default credential for all clients generated from this factory.
- setDomainName(String) - Method in class com.azure.spring.messaging.eventhubs.core.properties.CommonProperties
-
Set the domain name.
- setErrorHandler(EventHubsErrorHandler) - Method in class com.azure.spring.messaging.eventhubs.core.listener.EventHubsMessageListenerContainer
-
Set the error handler to call when the listener throws an exception.
- setErrorHandler(EventHubsErrorHandler) - Method in class com.azure.spring.messaging.eventhubs.core.properties.EventHubsContainerProperties
-
Set the error handler for the container.
- setEventHubName(String) - Method in class com.azure.spring.messaging.eventhubs.core.properties.CommonProperties
-
Set the event hub name.
- setInitializationContextConsumer(Consumer<InitializationContext>) - Method in class com.azure.spring.messaging.eventhubs.core.properties.EventHubsContainerProperties
-
Set the consumer to consume initialization context.
- setInterval(Duration) - Method in class com.azure.spring.messaging.eventhubs.core.checkpoint.CheckpointConfig
-
Set the time interval to do one checkpoint.
- setMessageConverter(AzureMessageConverter<EventData, EventData>) - Method in class com.azure.spring.messaging.eventhubs.core.EventHubsTemplate
-
Set the message converter to use.
- setMessageListener(MessageListener<?>) - Method in class com.azure.spring.messaging.eventhubs.core.properties.EventHubsContainerProperties
-
Set the message listener for the container.
- setMode(CheckpointMode) - Method in class com.azure.spring.messaging.eventhubs.core.checkpoint.CheckpointConfig
-
Set the checkpoint mode.
- setNamespace(String) - Method in class com.azure.spring.messaging.eventhubs.core.properties.CommonProperties
-
Set the namespace.
- setPartitionId(String) - Method in class com.azure.spring.messaging.eventhubs.core.PartitionSupplier
-
Set the partition id.
- setPartitionKey(String) - Method in class com.azure.spring.messaging.eventhubs.core.PartitionSupplier
-
Set the partition key.
- setPrefetchCount(Integer) - Method in class com.azure.spring.messaging.eventhubs.core.properties.ConsumerProperties
-
Set the prefetch count.
- setSharedConnection(Boolean) - Method in class com.azure.spring.messaging.eventhubs.core.properties.NamespaceProperties
-
Set if to enable shared connection.
- setTokenCredentialResolver(AzureCredentialResolver<TokenCredential>) - Method in class com.azure.spring.messaging.eventhubs.core.DefaultEventHubsNamespaceProcessorFactory
-
Set the token credential resolver.
- setTokenCredentialResolver(AzureCredentialResolver<TokenCredential>) - Method in class com.azure.spring.messaging.eventhubs.core.DefaultEventHubsNamespaceProducerFactory
-
Set the token credential resolver.
- setTrackLastEnqueuedEventProperties(Boolean) - Method in class com.azure.spring.messaging.eventhubs.core.properties.ProcessorProperties
-
Set whether to track the last enqueued event properties.
- setupMessageListener(MessageListener<?>) - Method in class com.azure.spring.messaging.eventhubs.core.listener.EventHubsMessageListenerContainer
T
- TIME - Enum constant in enum com.azure.spring.messaging.eventhubs.core.checkpoint.CheckpointMode
-
Checkpoint once for each time interval specified by
CheckpointConfig.getInterval()
()}
V
- valueOf(String) - Static method in enum com.azure.spring.messaging.eventhubs.core.checkpoint.CheckpointMode
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum com.azure.spring.messaging.eventhubs.core.checkpoint.CheckpointMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
All Classes and Interfaces|All Packages|Constant Field Values