Uses of Class
com.azure.messaging.eventhubs.EventProcessorClientBuilder
Packages that use EventProcessorClientBuilder
Package
Description
Azure Event Hubs is a highly scalable
publish-subscribe service that can ingest millions of events per second and stream them to multiple consumers.
-
Uses of EventProcessorClientBuilder in com.azure.messaging.eventhubs
Methods in com.azure.messaging.eventhubs that return EventProcessorClientBuilderModifier and TypeMethodDescriptionEventProcessorClientBuilder.checkpointStore(CheckpointStore checkpointStore) Sets theCheckpointStoretheEventProcessorClientwill use for storing partition ownership and checkpoint information.EventProcessorClientBuilder.clientOptions(com.azure.core.util.ClientOptions clientOptions) Sets the client options for the processor client.EventProcessorClientBuilder.configuration(com.azure.core.util.Configuration configuration) Sets the configuration store that is used during construction of the service client.EventProcessorClientBuilder.connectionString(String connectionString) Sets the credential information given a connection string to the Event Hub instance.EventProcessorClientBuilder.connectionString(String connectionString, String eventHubName) Sets the credential information given a connection string to the Event Hubs namespace and name to a specific Event Hub instance.EventProcessorClientBuilder.consumerGroup(String consumerGroup) Sets the consumer group name from which theEventProcessorClientshould consume events.EventProcessorClientBuilder.credential(com.azure.core.credential.AzureNamedKeyCredential credential) Sets the credential information for which Event Hub instance to connect to, and how to authorize against it.EventProcessorClientBuilder.credential(com.azure.core.credential.AzureSasCredential credential) Sets the credential information for which Event Hub instance to connect to, and how to authorize against it.EventProcessorClientBuilder.credential(com.azure.core.credential.TokenCredential credential) Sets theTokenCredentialused to authorize requests sent to the service.EventProcessorClientBuilder.credential(String fullyQualifiedNamespace, String eventHubName, com.azure.core.credential.AzureNamedKeyCredential credential) Sets the credential information for which Event Hub instance to connect to, and how to authorize against it.EventProcessorClientBuilder.credential(String fullyQualifiedNamespace, String eventHubName, com.azure.core.credential.AzureSasCredential credential) Sets the credential information for which Event Hub instance to connect to, and how to authorize against it.EventProcessorClientBuilder.credential(String fullyQualifiedNamespace, String eventHubName, com.azure.core.credential.TokenCredential credential) Sets the credential information for which Event Hub instance to connect to, and how to authorize against it.EventProcessorClientBuilder.customEndpointAddress(String customEndpointAddress) Sets a custom endpoint address when connecting to the Event Hubs service.EventProcessorClientBuilder.eventHubName(String eventHubName) Sets the name of the Event Hub to connect the client to.EventProcessorClientBuilder.fullyQualifiedNamespace(String fullyQualifiedNamespace) Sets the fully qualified name for the Event Hubs namespace.EventProcessorClientBuilder.initialPartitionEventPosition(Function<String, EventPosition> initialEventPositionProvider) Sets the default starting position for each partition if a checkpoint for that partition does not exist in theCheckpointStore.EventProcessorClientBuilder.initialPartitionEventPosition(Map<String, EventPosition> initialPartitionEventPosition) Sets the map containing the event position to use for each partition if a checkpoint for the partition does not exist inCheckpointStore.EventProcessorClientBuilder.loadBalancingStrategy(LoadBalancingStrategy loadBalancingStrategy) TheLoadBalancingStrategytheevent processorwill use for claiming partition ownership.EventProcessorClientBuilder.loadBalancingUpdateInterval(Duration loadBalancingUpdateInterval) The time interval between load balancing update cycles.EventProcessorClientBuilder.partitionOwnershipExpirationInterval(Duration partitionOwnershipExpirationInterval) The time duration after which the ownership of partition expires if it's not renewed by the owning processor instance.EventProcessorClientBuilder.prefetchCount(int prefetchCount) Sets the count used by the receivers to control the number of events each consumer will actively receive and queue locally without regard to whether a receive operation is currently active.EventProcessorClientBuilder.processError(Consumer<ErrorContext> processError) The function that is called when an error occurs while processing events.EventProcessorClientBuilder.processEvent(Consumer<EventContext> processEvent) The function that is called for each event received by thisEventProcessorClient.EventProcessorClientBuilder.processEvent(Consumer<EventContext> processEvent, Duration maxWaitTime) The function that is called for each event received by thisEventProcessorClient.EventProcessorClientBuilder.processEventBatch(Consumer<EventBatchContext> processEventBatch, int maxBatchSize) The function that is called for each event received by thisEventProcessorClient.EventProcessorClientBuilder.processEventBatch(Consumer<EventBatchContext> processEventBatch, int maxBatchSize, Duration maxWaitTime) The function that is called for each event received by thisEventProcessorClient.EventProcessorClientBuilder.processPartitionClose(Consumer<CloseContext> closePartition) The function that is called when a processing for a partition stops.EventProcessorClientBuilder.processPartitionInitialization(Consumer<InitializationContext> initializePartition) The function that is called before processing starts for a partition.EventProcessorClientBuilder.proxyOptions(com.azure.core.amqp.ProxyOptions proxyOptions) Sets the proxy configuration to use forEventHubAsyncClient.EventProcessorClientBuilder.retry(com.azure.core.amqp.AmqpRetryOptions retryOptions) Deprecated.EventProcessorClientBuilder.retryOptions(com.azure.core.amqp.AmqpRetryOptions retryOptions) Sets the retry policy forEventHubAsyncClient.EventProcessorClientBuilder.trackLastEnqueuedEventProperties(boolean trackLastEnqueuedEventProperties) Sets whether or not the event processor should request information on the last enqueued event on its associated partition, and track that information as events are received.EventProcessorClientBuilder.transportType(com.azure.core.amqp.AmqpTransportType transport) Sets the transport type by which all the communication with Azure Event Hubs occurs.
retryOptions(AmqpRetryOptions).