Codota Logo
EventHubClient.create
Code IndexAdd Codota to your IDE (free)

How to use
create
method
in
com.microsoft.azure.eventhubs.EventHubClient

Best Java code snippets using com.microsoft.azure.eventhubs.EventHubClient.create (Showing top 4 results out of 315)

  • Add the Codota plugin to your IDE and get smart completions
private void myMethod () {
DateTime d =
  • Codota Iconnew DateTime()
  • Codota IconDateTimeFormatter formatter;String text;formatter.parseDateTime(text)
  • Codota IconObject instant;new DateTime(instant)
  • Smart code suggestions by Codota
}
origin: Azure/azure-event-hubs-java

/**
 * Factory method to create an instance of {@link EventHubClient} using the supplied connectionString.
 * In a normal scenario (when re-direct is not enabled) - one EventHubClient instance maps to one Connection to the Azure ServiceBus EventHubs service.
 * <p>The {@link EventHubClient} created from this method creates a Sender instance internally, which is used by the {@link #send(EventData)} methods.
 *
 * @param connectionString The connection string to be used. See {@link ConnectionStringBuilder} to construct a connectionString.
 * @param executor         An {@link ScheduledExecutorService} to run all tasks performed by {@link EventHubClient}.
 * @return CompletableFuture{@literal <EventHubClient>} which can be used to create Senders and Receivers to EventHub
 * @throws EventHubException If Service Bus service encountered problems during connection creation.
 * @throws IOException       If the underlying Proton-J layer encounter network errors.
 */
static CompletableFuture<EventHubClient> create(final String connectionString, final ScheduledExecutorService executor)
    throws EventHubException, IOException {
  return EventHubClient.create(connectionString, null, executor);
}
origin: Azure/azure-event-hubs-java

  startOpeningFuture = EventHubClient.create(this.hostContext.getEventHubConnectionString(),
      this.hostContext.getRetryPolicy(), this.hostContext.getExecutor());
} catch (EventHubException | IOException e2) {
origin: Azure/azure-event-hubs-java

/**
 * Synchronous version of {@link #create(String, ScheduledExecutorService)}.
 *
 * @param connectionString The connection string to be used. See {@link ConnectionStringBuilder} to construct a connectionString.
 * @param retryPolicy      A custom {@link RetryPolicy} to be used when communicating with EventHub.
 * @param executor         An {@link ScheduledExecutorService} to run all tasks performed by {@link EventHubClient}.
 * @return EventHubClient which can be used to create Senders and Receivers to EventHub
 * @throws EventHubException If Service Bus service encountered problems during connection creation.
 * @throws IOException       If the underlying Proton-J layer encounter network errors.
 */
static EventHubClient createSync(final String connectionString, final RetryPolicy retryPolicy, final ScheduledExecutorService executor)
    throws EventHubException, IOException {
  return ExceptionUtil.syncWithIOException(() -> create(connectionString, retryPolicy, executor).get());
}
origin: Azure/azure-event-hubs-java

retval = EventHubClient.create(this.hostContext.getEventHubConnectionString(), this.hostContext.getRetryPolicy(), this.hostContext.getExecutor())
com.microsoft.azure.eventhubsEventHubClientcreate

Javadoc

Factory method to create an instance of EventHubClient using the supplied connectionString. In a normal scenario (when re-direct is not enabled) - one EventHubClient instance maps to one Connection to the Azure ServiceBus EventHubs service.

The EventHubClient created from this method creates a Sender instance internally, which is used by the #send(EventData) methods.

Popular methods of EventHubClient

  • createSync
  • createPartitionSenderSync
  • send
  • close
  • closeSync
  • sendSync
    Synchronous version of #send(Iterable,String).
  • createReceiver
  • getRuntimeInformation
    Retrieves general information about an event hub (see EventHubRuntimeInformation for details). Retri
  • createEpochReceiver
    Create a Epoch based EventHub receiver with given partition id and start receiving from the beginnin
  • createReceiverSync
    Synchronous version of #createReceiver(String,String,EventPosition).
  • getPartitionRuntimeInformation
    Retrieves dynamic information about a partition of an event hub (see PartitionRuntimeInformation for
  • createBatch
  • getPartitionRuntimeInformation,
  • createBatch,
  • createEpochReceiverSync,
  • createFromConnectionString,
  • createFromConnectionStringSync,
  • createPartitionSender

Popular in Java

  • Making http requests using okhttp
  • scheduleAtFixedRate (ScheduledExecutorService)
  • compareTo (BigDecimal)
    Compares this BigDecimal with the specified BigDecimal. Two BigDecimal objects that are equal in val
  • orElseThrow (Optional)
  • HttpServer (com.sun.net.httpserver)
    This class implements a simple HTTP server. A HttpServer is bound to an IP address and port number a
  • BufferedReader (java.io)
    Reads text from a character-input stream, buffering characters so as to provide for the efficient re
  • EOFException (java.io)
    Thrown when a program encounters the end of a file or stream during an input operation.
  • MessageFormat (java.text)
    MessageFormat provides a means to produce concatenated messages in language-neutral way. Use this to
  • AtomicInteger (java.util.concurrent.atomic)
    An int value that may be updated atomically. See the java.util.concurrent.atomic package specificati
  • Option (scala)
Codota Logo
  • Products

    Search for Java codeSearch for JavaScript codeEnterprise
  • IDE Plugins

    IntelliJ IDEAWebStormAndroid StudioEclipseVisual Studio CodePyCharmSublime TextPhpStormVimAtomGoLandRubyMineEmacsJupyter
  • Company

    About UsContact UsCareers
  • Resources

    FAQBlogCodota Academy Plugin user guide Terms of usePrivacy policyJava Code IndexJavascript Code Index
Get Codota for your IDE now