Tabnine Logo
EventHubClient.create
Code IndexAdd Tabnine 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)

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
    Synchronous version of #create(String,ScheduledExecutorService).
  • 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

  • Start an intent from android
  • onCreateOptionsMenu (Activity)
  • getExternalFilesDir (Context)
  • runOnUiThread (Activity)
  • Runnable (java.lang)
    Represents a command that can be executed. Often used to run code in a different Thread.
  • MessageDigest (java.security)
    Uses a one-way hash function to turn an arbitrary number of bytes into a fixed-length byte sequence.
  • NumberFormat (java.text)
    The abstract base class for all number formats. This class provides the interface for formatting and
  • Executors (java.util.concurrent)
    Factory and utility methods for Executor, ExecutorService, ScheduledExecutorService, ThreadFactory,
  • Cipher (javax.crypto)
    This class provides access to implementations of cryptographic ciphers for encryption and decryption
  • JOptionPane (javax.swing)
  • Best plugins for Eclipse
Tabnine Logo
  • Products

    Search for Java codeSearch for JavaScript code
  • IDE Plugins

    IntelliJ IDEAWebStormVisual StudioAndroid StudioEclipseVisual Studio CodePyCharmSublime TextPhpStormVimGoLandRubyMineEmacsJupyter NotebookJupyter LabRiderDataGripAppCode
  • Company

    About UsContact UsCareers
  • Resources

    FAQBlogTabnine AcademyTerms of usePrivacy policyJava Code IndexJavascript Code Index
Get Tabnine for your IDE now