com.microsoft.azure.eventhubs.IEventHubClient Maven / Gradle / Ivy
/*
* Copyright (c) Microsoft. All rights reserved.
* Licensed under the MIT license. See LICENSE file in the project root for full license information.
*/
package com.microsoft.azure.eventhubs;
import com.microsoft.azure.servicebus.ServiceBusException;
import java.time.Instant;
import java.util.concurrent.CompletableFuture;
public interface IEventHubClient {
void sendSync(EventData data)
throws ServiceBusException;
CompletableFuture send(EventData data);
void sendSync(Iterable eventDatas)
throws ServiceBusException;
CompletableFuture send(Iterable eventDatas);
void sendSync(EventData eventData, String partitionKey)
throws ServiceBusException;
CompletableFuture send(EventData eventData, String partitionKey);
void sendSync(Iterable eventDatas, String partitionKey)
throws ServiceBusException;
CompletableFuture send(Iterable eventDatas, String partitionKey);
PartitionSender createPartitionSenderSync(String partitionId)
throws ServiceBusException, IllegalArgumentException;
CompletableFuture createPartitionSender(String partitionId)
throws ServiceBusException;
PartitionReceiver createReceiverSync(String consumerGroupName, String partitionId, String startingOffset)
throws ServiceBusException;
CompletableFuture createReceiver(String consumerGroupName, String partitionId, String startingOffset)
throws ServiceBusException;
PartitionReceiver createReceiverSync(String consumerGroupName, String partitionId, String startingOffset, boolean offsetInclusive)
throws ServiceBusException;
CompletableFuture createReceiver(String consumerGroupName, String partitionId, String startingOffset, boolean offsetInclusive)
throws ServiceBusException;
PartitionReceiver createReceiverSync(String consumerGroupName, String partitionId, Instant dateTime)
throws ServiceBusException;
CompletableFuture createReceiver(String consumerGroupName, String partitionId, Instant dateTime)
throws ServiceBusException;
PartitionReceiver createReceiverSync(String consumerGroupName, String partitionId, String startingOffset, ReceiverOptions receiverOptions)
throws ServiceBusException;
CompletableFuture createReceiver(String consumerGroupName, String partitionId, String startingOffset, ReceiverOptions receiverOptions)
throws ServiceBusException;
PartitionReceiver createReceiverSync(String consumerGroupName, String partitionId, String startingOffset, boolean offsetInclusive, ReceiverOptions receiverOptions)
throws ServiceBusException;
CompletableFuture createReceiver(String consumerGroupName, String partitionId, String startingOffset, boolean offsetInclusive, ReceiverOptions receiverOptions)
throws ServiceBusException;
PartitionReceiver createReceiverSync(String consumerGroupName, String partitionId, Instant dateTime, ReceiverOptions receiverOptions)
throws ServiceBusException;
CompletableFuture createReceiver(String consumerGroupName, String partitionId, Instant dateTime, ReceiverOptions receiverOptions)
throws ServiceBusException;
PartitionReceiver createEpochReceiverSync(String consumerGroupName, String partitionId, String startingOffset, long epoch)
throws ServiceBusException;
CompletableFuture createEpochReceiver(String consumerGroupName, String partitionId, String startingOffset, long epoch)
throws ServiceBusException;
PartitionReceiver createEpochReceiverSync(String consumerGroupName, String partitionId, String startingOffset, boolean offsetInclusive, long epoch)
throws ServiceBusException;
CompletableFuture createEpochReceiver(String consumerGroupName, String partitionId, String startingOffset, boolean offsetInclusive, long epoch)
throws ServiceBusException;
PartitionReceiver createEpochReceiverSync(String consumerGroupName, String partitionId, Instant dateTime, long epoch)
throws ServiceBusException;
CompletableFuture createEpochReceiver(String consumerGroupName, String partitionId, Instant dateTime, long epoch)
throws ServiceBusException;
PartitionReceiver createEpochReceiverSync(String consumerGroupName, String partitionId, String startingOffset, long epoch, ReceiverOptions receiverOptions)
throws ServiceBusException;
CompletableFuture createEpochReceiver(String consumerGroupName, String partitionId, String startingOffset, long epoch, ReceiverOptions receiverOptions)
throws ServiceBusException;
PartitionReceiver createEpochReceiverSync(String consumerGroupName, String partitionId, String startingOffset, boolean offsetInclusive, long epoch, ReceiverOptions receiverOptions)
throws ServiceBusException;
CompletableFuture createEpochReceiver(String consumerGroupName, String partitionId, String startingOffset, boolean offsetInclusive, long epoch, ReceiverOptions receiverOptions)
throws ServiceBusException;
PartitionReceiver createEpochReceiverSync(String consumerGroupName, String partitionId, Instant dateTime, long epoch, ReceiverOptions receiverOptions)
throws ServiceBusException;
CompletableFuture createEpochReceiver(String consumerGroupName, String partitionId, Instant dateTime, long epoch, ReceiverOptions receiverOptions)
throws ServiceBusException;
CompletableFuture onClose();
CompletableFuture getRuntimeInformation();
CompletableFuture getPartitionRuntimeInformation(String partitionId);
}
© 2015 - 2025 Weber Informatics LLC | Privacy Policy