A B C D E F G H I L N O P R S U V
All Classes All Packages
All Classes All Packages
All Classes All Packages
A
- acquireLease(CompleteLease) - Method in interface com.microsoft.azure.eventprocessorhost.ILeaseManager
-
Acquire the lease on the desired partition for this EventProcessorHost.
- acquireLease(CompleteLease) - Method in class com.microsoft.azure.eventprocessorhost.InMemoryLeaseManager
- ACQUIRING_LEASE - Static variable in class com.microsoft.azure.eventprocessorhost.EventProcessorHostActionStrings
- apply(String) - Method in class com.microsoft.azure.eventprocessorhost.EventProcessorOptions.EndOfStreamInitialPositionProvider
- apply(String) - Method in class com.microsoft.azure.eventprocessorhost.EventProcessorOptions.StartOfStreamInitialPositionProvider
- AzureStoragePartitionManagerOptions - Class in com.microsoft.azure.eventprocessorhost
- AzureStoragePartitionManagerOptions() - Constructor for class com.microsoft.azure.eventprocessorhost.AzureStoragePartitionManagerOptions
B
- BaseLease - Class in com.microsoft.azure.eventprocessorhost
-
BaseLease class is public so that advanced users can implement an ILeaseManager.
- BaseLease() - Constructor for class com.microsoft.azure.eventprocessorhost.BaseLease
-
Do not use; added only for GSon deserializer
- BaseLease(BaseLease) - Constructor for class com.microsoft.azure.eventprocessorhost.BaseLease
-
Create a BaseLease by duplicating the given Lease.
- BaseLease(String) - Constructor for class com.microsoft.azure.eventprocessorhost.BaseLease
-
Create a BaseLease for the given partition.
- BaseLease(String, String, boolean) - Constructor for class com.microsoft.azure.eventprocessorhost.BaseLease
-
Create and populate a BaseLease for the given partition.
- build() - Method in interface com.microsoft.azure.eventprocessorhost.EventProcessorHost.EventProcessorHostBuilder.OptionalStep
-
After setting all desired optional values, call this method to build an EventProcessorHost instance.
C
- CHECKING_CHECKPOINT_STORE - Static variable in class com.microsoft.azure.eventprocessorhost.EventProcessorHostActionStrings
- CHECKING_LEASE_STORE - Static variable in class com.microsoft.azure.eventprocessorhost.EventProcessorHostActionStrings
- CHECKING_LEASES - Static variable in class com.microsoft.azure.eventprocessorhost.EventProcessorHostActionStrings
- checkpoint() - Method in class com.microsoft.azure.eventprocessorhost.PartitionContext
-
Writes the position of the last event in the current batch to the checkpoint store via the checkpoint manager.
- checkpoint(EventData) - Method in class com.microsoft.azure.eventprocessorhost.PartitionContext
-
Writes the position of the provided EventData instance to the checkpoint store via the checkpoint manager.
- checkpoint(Checkpoint) - Method in class com.microsoft.azure.eventprocessorhost.PartitionContext
-
Writes the position of the provided Checkpoint instance to the checkpoint store via the checkpoint manager.
- Checkpoint - Class in com.microsoft.azure.eventprocessorhost
-
Checkpoint class is public so that advanced users can implement an ICheckpointManager.
- Checkpoint(Checkpoint) - Constructor for class com.microsoft.azure.eventprocessorhost.Checkpoint
-
Create a checkpoint which is a duplicate of the given checkpoint.
- Checkpoint(String) - Constructor for class com.microsoft.azure.eventprocessorhost.Checkpoint
-
Create a checkpoint with offset/sequenceNumber set to the start of the stream.
- Checkpoint(String, String, long) - Constructor for class com.microsoft.azure.eventprocessorhost.Checkpoint
-
Create a checkpoint with the given offset and sequenceNumber.
- checkpointStoreExists() - Method in interface com.microsoft.azure.eventprocessorhost.ICheckpointManager
-
Does the checkpoint store exist? The returned CompletableFuture completes with true if the checkpoint store exists or false if it does not.
- checkpointStoreExists() - Method in class com.microsoft.azure.eventprocessorhost.InMemoryCheckpointManager
- checkpointTimeoutInSeconds - Variable in class com.microsoft.azure.eventprocessorhost.PartitionManagerOptions
- CloseReason - Enum in com.microsoft.azure.eventprocessorhost
-
Used when implementing IEventProcessor.
- CLOSING_EVENT_PROCESSOR - Static variable in class com.microsoft.azure.eventprocessorhost.EventProcessorHostActionStrings
- com.microsoft.azure.eventprocessorhost - package com.microsoft.azure.eventprocessorhost
- compareTo(BaseLease) - Method in class com.microsoft.azure.eventprocessorhost.BaseLease
- CompleteLease - Class in com.microsoft.azure.eventprocessorhost
-
CompleteLease class is public so that advanced users can implement an ILeaseManager.
- CompleteLease() - Constructor for class com.microsoft.azure.eventprocessorhost.CompleteLease
-
Do not use; added only for GSon deserializer
- CompleteLease(CompleteLease) - Constructor for class com.microsoft.azure.eventprocessorhost.CompleteLease
-
Create a Lease by duplicating the given Lease.
- CompleteLease(String) - Constructor for class com.microsoft.azure.eventprocessorhost.CompleteLease
-
Create a CompleteLease for the given partition.
- createAllCheckpointsIfNotExists(List<String>) - Method in interface com.microsoft.azure.eventprocessorhost.ICheckpointManager
-
Creates the checkpoint HOLDERs for the given partitions.
- createAllCheckpointsIfNotExists(List<String>) - Method in class com.microsoft.azure.eventprocessorhost.InMemoryCheckpointManager
- createAllLeasesIfNotExists(List<String>) - Method in interface com.microsoft.azure.eventprocessorhost.ILeaseManager
-
Create in the store a lease for each of the given partitions, if it does not exist.
- createAllLeasesIfNotExists(List<String>) - Method in class com.microsoft.azure.eventprocessorhost.InMemoryLeaseManager
- createCheckpointStoreIfNotExists() - Method in interface com.microsoft.azure.eventprocessorhost.ICheckpointManager
-
Create the checkpoint store if it doesn't exist.
- createCheckpointStoreIfNotExists() - Method in class com.microsoft.azure.eventprocessorhost.InMemoryCheckpointManager
- createEventProcessor(PartitionContext) - Method in interface com.microsoft.azure.eventprocessorhost.IEventProcessorFactory
-
Called to create an event processor for the given partition.
- createHostName(String) - Static method in class com.microsoft.azure.eventprocessorhost.EventProcessorHost
-
Convenience method for generating unique host names, safe to pass to the EventProcessorHost constructors that take a hostName argument.
- createLeaseStoreIfNotExists() - Method in interface com.microsoft.azure.eventprocessorhost.ILeaseManager
-
Create the lease store if it does not exist, do nothing if it does exist.
- createLeaseStoreIfNotExists() - Method in class com.microsoft.azure.eventprocessorhost.InMemoryLeaseManager
- CREATING_CHECKPOINT_STORE - Static variable in class com.microsoft.azure.eventprocessorhost.EventProcessorHostActionStrings
- CREATING_CHECKPOINTS - Static variable in class com.microsoft.azure.eventprocessorhost.EventProcessorHostActionStrings
- CREATING_EVENT_HUB_CLIENT - Static variable in class com.microsoft.azure.eventprocessorhost.EventProcessorHostActionStrings
- CREATING_EVENT_PROCESSOR - Static variable in class com.microsoft.azure.eventprocessorhost.EventProcessorHostActionStrings
- CREATING_LEASE_STORE - Static variable in class com.microsoft.azure.eventprocessorhost.EventProcessorHostActionStrings
- CREATING_LEASES - Static variable in class com.microsoft.azure.eventprocessorhost.EventProcessorHostActionStrings
D
- DefaultCheckpointTimeoutInSeconds - Static variable in class com.microsoft.azure.eventprocessorhost.PartitionManagerOptions
-
The default timeout for checkpoint operations.
- DefaultFastScanIntervalInSeconds - Static variable in class com.microsoft.azure.eventprocessorhost.PartitionManagerOptions
- DefaultLeaseDurationInSeconds - Static variable in class com.microsoft.azure.eventprocessorhost.PartitionManagerOptions
-
The default duration after which a partition lease will expire unless renewed.
- DefaultLeaseRenewIntervalInSeconds - Static variable in class com.microsoft.azure.eventprocessorhost.PartitionManagerOptions
-
The default duration between lease renewals.
- DefaultSlowScanIntervalInSeconds - Static variable in class com.microsoft.azure.eventprocessorhost.PartitionManagerOptions
- DefaultStartupScanDelayInSeconds - Static variable in class com.microsoft.azure.eventprocessorhost.PartitionManagerOptions
- deleteCheckpoint(String) - Method in interface com.microsoft.azure.eventprocessorhost.ICheckpointManager
-
Delete the stored checkpoint data for the given partition.
- deleteCheckpoint(String) - Method in class com.microsoft.azure.eventprocessorhost.InMemoryCheckpointManager
- deleteCheckpointStore() - Method in interface com.microsoft.azure.eventprocessorhost.ICheckpointManager
-
Deletes the checkpoint store.
- deleteCheckpointStore() - Method in class com.microsoft.azure.eventprocessorhost.InMemoryCheckpointManager
- deleteLease(CompleteLease) - Method in interface com.microsoft.azure.eventprocessorhost.ILeaseManager
-
Delete the lease info for a partition from the store.
- deleteLease(CompleteLease) - Method in class com.microsoft.azure.eventprocessorhost.InMemoryLeaseManager
- deleteLeaseStore() - Method in interface com.microsoft.azure.eventprocessorhost.ILeaseManager
-
Deletes the lease store.
- deleteLeaseStore() - Method in class com.microsoft.azure.eventprocessorhost.InMemoryLeaseManager
- DELETING_LEASE - Static variable in class com.microsoft.azure.eventprocessorhost.EventProcessorHostActionStrings
E
- EndOfStreamInitialPositionProvider() - Constructor for class com.microsoft.azure.eventprocessorhost.EventProcessorOptions.EndOfStreamInitialPositionProvider
- epoch - Variable in class com.microsoft.azure.eventprocessorhost.CompleteLease
- equals(Object) - Method in class com.microsoft.azure.eventprocessorhost.BaseLease
- equals(Object) - Method in class com.microsoft.azure.eventprocessorhost.CompleteLease
- EventProcessorHost - Class in com.microsoft.azure.eventprocessorhost
-
The main class of event processor host.
- EventProcessorHost.EventProcessorHostBuilder - Class in com.microsoft.azure.eventprocessorhost
-
Builder class to create EventProcessorHost instances.
- EventProcessorHost.EventProcessorHostBuilder.AADAuthStep - Interface in com.microsoft.azure.eventprocessorhost
- EventProcessorHost.EventProcessorHostBuilder.AuthStep - Interface in com.microsoft.azure.eventprocessorhost
- EventProcessorHost.EventProcessorHostBuilder.ManagerStep - Interface in com.microsoft.azure.eventprocessorhost
- EventProcessorHost.EventProcessorHostBuilder.OptionalStep - Interface in com.microsoft.azure.eventprocessorhost
- EventProcessorHostActionStrings - Class in com.microsoft.azure.eventprocessorhost
-
The action string of ExceptionReceivedEventArts will be one of this.
- EventProcessorHostActionStrings() - Constructor for class com.microsoft.azure.eventprocessorhost.EventProcessorHostActionStrings
- EventProcessorOptions - Class in com.microsoft.azure.eventprocessorhost
-
Options affecting the behavior of the event processor host instance in general.
- EventProcessorOptions() - Constructor for class com.microsoft.azure.eventprocessorhost.EventProcessorOptions
- EventProcessorOptions.EndOfStreamInitialPositionProvider - Class in com.microsoft.azure.eventprocessorhost
-
A prefab initial position provider that starts from the next event that becomes available.
- EventProcessorOptions.StartOfStreamInitialPositionProvider - Class in com.microsoft.azure.eventprocessorhost
-
A prefab initial position provider that starts from the first event available.
- ExceptionReceivedEventArgs - Class in com.microsoft.azure.eventprocessorhost
-
Passed as an argument to the general exception handler that can be set via EventProcessorOptions.
F
- fastScanIntervalInSeconds - Variable in class com.microsoft.azure.eventprocessorhost.PartitionManagerOptions
G
- getAction() - Method in class com.microsoft.azure.eventprocessorhost.ExceptionReceivedEventArgs
-
See EventProcessorHostActionString for a list of possible values.
- getAllLeases() - Method in interface com.microsoft.azure.eventprocessorhost.ILeaseManager
-
Returns lightweight BaseLease for all leases, which includes name of owning host and whether lease is expired.
- getAllLeases() - Method in class com.microsoft.azure.eventprocessorhost.InMemoryLeaseManager
- getCheckpoint(String) - Method in interface com.microsoft.azure.eventprocessorhost.ICheckpointManager
-
Get the checkpoint data associated with the given partition.
- getCheckpoint(String) - Method in class com.microsoft.azure.eventprocessorhost.InMemoryCheckpointManager
- getCheckpointTimeoutInSeconds() - Method in class com.microsoft.azure.eventprocessorhost.PartitionManagerOptions
-
Gets the timeout for checkpoint operations.
- getConsumerGroupName() - Method in class com.microsoft.azure.eventprocessorhost.PartitionContext
-
Get the name of the consumer group that is being received from.
- getDefaultOptions() - Static method in class com.microsoft.azure.eventprocessorhost.EventProcessorOptions
-
Returns an EventProcessorOptions instance with all options set to the default values.
- getEpoch() - Method in class com.microsoft.azure.eventprocessorhost.CompleteLease
-
Epoch is a concept used by Event Hub receivers.
- getEventHubPath() - Method in class com.microsoft.azure.eventprocessorhost.PartitionContext
-
Get the path of the event hub that is being received from.
- getException() - Method in class com.microsoft.azure.eventprocessorhost.ExceptionReceivedEventArgs
-
Returns the exception that was thrown.
- getFastScanIntervalInSeconds() - Method in class com.microsoft.azure.eventprocessorhost.PartitionManagerOptions
-
There are two possible interval times between scans for available partitions, fast and slow.
- getHostname() - Method in class com.microsoft.azure.eventprocessorhost.ExceptionReceivedEventArgs
-
Allows distinguishing the error source if multiple hosts in a single process.
- getHostName() - Method in class com.microsoft.azure.eventprocessorhost.EventProcessorHost
-
The processor host name is supplied by the user at constructor time, but being able to get it is useful because it means not having to carry both the host object and the name around.
- getInitialPositionProvider() - Method in class com.microsoft.azure.eventprocessorhost.EventProcessorOptions
-
If there is no checkpoint for a partition, the initialPositionProvider function is used to determine the position at which to start receiving events for that partition.
- getInvokeProcessorAfterReceiveTimeout() - Method in class com.microsoft.azure.eventprocessorhost.EventProcessorOptions
-
Returns whether the EventProcessorHost will call IEventProcessor.onEvents() with an empty iterable when a receive timeout occurs (true) or not (false).
- getIsOwned() - Method in class com.microsoft.azure.eventprocessorhost.BaseLease
-
Get the owned state of the lease.
- getLease(String) - Method in interface com.microsoft.azure.eventprocessorhost.ILeaseManager
-
Returns the lease info for the given partition..
- getLease(String) - Method in class com.microsoft.azure.eventprocessorhost.InMemoryLeaseManager
- getLeaseDurationInMilliseconds() - Method in interface com.microsoft.azure.eventprocessorhost.ILeaseManager
-
The lease duration is mostly internal to the lease manager implementation but may be needed by other parts of the event processor host.
- getLeaseDurationInMilliseconds() - Method in class com.microsoft.azure.eventprocessorhost.InMemoryLeaseManager
- getLeaseDurationInSeconds() - Method in class com.microsoft.azure.eventprocessorhost.PartitionManagerOptions
-
Gets the duration after which a partition lease will expire unless renewed.
- getLeaseRenewIntervalInSeconds() - Method in class com.microsoft.azure.eventprocessorhost.PartitionManagerOptions
-
Gets the duration between lease renewals.
- getMaxBatchSize() - Method in class com.microsoft.azure.eventprocessorhost.EventProcessorOptions
-
Returns the maximum number of events that will be passed to one call to IEventProcessor.onEvents
- getOffset() - Method in class com.microsoft.azure.eventprocessorhost.Checkpoint
-
Return the offset.
- getOwner() - Method in class com.microsoft.azure.eventprocessorhost.BaseLease
-
The owner of a lease is the name of the EventProcessorHost instance which currently holds the lease.
- getOwner() - Method in class com.microsoft.azure.eventprocessorhost.PartitionContext
-
Get the name of the event processor host instance.
- getPartitionId() - Method in class com.microsoft.azure.eventprocessorhost.BaseLease
-
Returns the id of the partition that this Lease is for.
- getPartitionId() - Method in class com.microsoft.azure.eventprocessorhost.Checkpoint
-
Get the partition id.
- getPartitionId() - Method in class com.microsoft.azure.eventprocessorhost.ExceptionReceivedEventArgs
-
If the error is associated with a particular partition (for example, failed to open the event processor for the partition), the id of the partition.
- getPartitionId() - Method in exception com.microsoft.azure.eventprocessorhost.LeaseLostException
- getPartitionId() - Method in class com.microsoft.azure.eventprocessorhost.PartitionContext
-
Get the id of the partition being received from.
- getPartitionManagerOptions() - Method in class com.microsoft.azure.eventprocessorhost.EventProcessorHost
-
Returns the existing partition manager options object.
- getPrefetchCount() - Method in class com.microsoft.azure.eventprocessorhost.EventProcessorOptions
-
Returns the current prefetch count for the underlying event hub client.
- getReceiverRuntimeMetricEnabled() - Method in class com.microsoft.azure.eventprocessorhost.EventProcessorOptions
-
Knob to enable/disable runtime metric of the receiver.
- getReceiveTimeOut() - Method in class com.microsoft.azure.eventprocessorhost.EventProcessorOptions
-
Returns the timeout for receive operations.
- getRuntimeInformation() - Method in class com.microsoft.azure.eventprocessorhost.PartitionContext
-
If receiver runtime metrics have been enabled in EventProcessorHost, this method gets the metrics as they come in.
- getSequenceNumber() - Method in class com.microsoft.azure.eventprocessorhost.Checkpoint
-
Get the sequence number.
- getSlowScanIntervalInSeconds() - Method in class com.microsoft.azure.eventprocessorhost.PartitionManagerOptions
-
The slow (long) interval is used after a scan in which lease stealing did not occur, to reduce unnecessary scanning when the system is in steady state.
- getStartupScanDelayInSeconds() - Method in class com.microsoft.azure.eventprocessorhost.PartitionManagerOptions
-
Gets the delay time between the first scan for available partitions and the second.
- GETTING_CHECKPOINT - Static variable in class com.microsoft.azure.eventprocessorhost.EventProcessorHostActionStrings
- GETTING_LEASE - Static variable in class com.microsoft.azure.eventprocessorhost.EventProcessorHostActionStrings
H
- hashCode() - Method in class com.microsoft.azure.eventprocessorhost.BaseLease
- hashCode() - Method in class com.microsoft.azure.eventprocessorhost.CompleteLease
I
- ICheckpointManager - Interface in com.microsoft.azure.eventprocessorhost
-
If you wish to have EventProcessorHost store checkpoints somewhere other than Azure Storage, you can write your own checkpoint manager using this interface.
- IEventProcessor - Interface in com.microsoft.azure.eventprocessorhost
-
Interface that must be implemented by event processor classes.
- IEventProcessorFactory<T extends IEventProcessor> - Interface in com.microsoft.azure.eventprocessorhost
-
Interface that must be implemented by an event processor factory class.
- ILeaseManager - Interface in com.microsoft.azure.eventprocessorhost
-
If you wish to have EventProcessorHost store leases somewhere other than Azure Storage, you can write your own lease manager using this interface.
- incrementEpoch() - Method in class com.microsoft.azure.eventprocessorhost.CompleteLease
-
The most common operation on the epoch value is incrementing it after stealing a lease.
- initialize(HostContext) - Method in class com.microsoft.azure.eventprocessorhost.InMemoryCheckpointManager
- initialize(HostContext) - Method in class com.microsoft.azure.eventprocessorhost.InMemoryLeaseManager
- INITIALIZING_STORES - Static variable in class com.microsoft.azure.eventprocessorhost.EventProcessorHostActionStrings
- InMemoryCheckpointManager - Class in com.microsoft.azure.eventprocessorhost
-
An ICheckpointManager implementation based on an in-memory store.
- InMemoryCheckpointManager() - Constructor for class com.microsoft.azure.eventprocessorhost.InMemoryCheckpointManager
- InMemoryLeaseManager - Class in com.microsoft.azure.eventprocessorhost
-
An ILeaseManager implementation based on an in-memory store.
- InMemoryLeaseManager() - Constructor for class com.microsoft.azure.eventprocessorhost.InMemoryLeaseManager
- isOwnedBy(String) - Method in class com.microsoft.azure.eventprocessorhost.BaseLease
-
Convenience function for comparing possibleOwner against this.owner
L
- leaseDurationInSeconds - Variable in class com.microsoft.azure.eventprocessorhost.PartitionManagerOptions
- LeaseLost - com.microsoft.azure.eventprocessorhost.CloseReason
-
The IEventProcessor is closing because the lease on the partition has been lost.
- LeaseLostException - Exception in com.microsoft.azure.eventprocessorhost
- leaseRenewIntervalInSeconds - Variable in class com.microsoft.azure.eventprocessorhost.PartitionManagerOptions
- leaseStoreExists() - Method in interface com.microsoft.azure.eventprocessorhost.ILeaseManager
-
Does the lease store exist?
- leaseStoreExists() - Method in class com.microsoft.azure.eventprocessorhost.InMemoryLeaseManager
- LoggingUtils - Class in com.microsoft.azure.eventprocessorhost
-
Centralize log message generation
- LoggingUtils() - Constructor for class com.microsoft.azure.eventprocessorhost.LoggingUtils
N
- newBuilder(String, String) - Static method in class com.microsoft.azure.eventprocessorhost.EventProcessorHost.EventProcessorHostBuilder
-
The process of building starts here, with arguments that are always required.
- NO_ASSOCIATED_PARTITION - Static variable in class com.microsoft.azure.eventprocessorhost.ExceptionReceivedEventArgs
- notifyOnSteal(String, String, Callable<?>) - Method in class com.microsoft.azure.eventprocessorhost.InMemoryLeaseManager
O
- onClose(PartitionContext, CloseReason) - Method in interface com.microsoft.azure.eventprocessorhost.IEventProcessor
-
Called by processor host to indicate that the event processor is being stopped.
- onError(PartitionContext, Throwable) - Method in interface com.microsoft.azure.eventprocessorhost.IEventProcessor
-
Called when the underlying client experiences an error while receiving.
- onEvents(PartitionContext, Iterable<EventData>) - Method in interface com.microsoft.azure.eventprocessorhost.IEventProcessor
-
Called by the processor host when a batch of events has arrived.
- onOpen(PartitionContext) - Method in interface com.microsoft.azure.eventprocessorhost.IEventProcessor
-
Called by processor host to initialize the event processor.
- OPENING_EVENT_PROCESSOR - Static variable in class com.microsoft.azure.eventprocessorhost.EventProcessorHostActionStrings
P
- PARTITION_MANAGER_CLEANUP - Static variable in class com.microsoft.azure.eventprocessorhost.EventProcessorHostActionStrings
- PARTITION_MANAGER_MAIN_LOOP - Static variable in class com.microsoft.azure.eventprocessorhost.EventProcessorHostActionStrings
- PartitionContext - Class in com.microsoft.azure.eventprocessorhost
-
PartitionContext is used to provide partition-related information to the methods of IEventProcessor, particularly onEvents where the user's event-processing logic lives.
- PartitionManagerOptions - Class in com.microsoft.azure.eventprocessorhost
-
Options affecting the operation of the partition manager within the event processor host.
- PartitionManagerOptions() - Constructor for class com.microsoft.azure.eventprocessorhost.PartitionManagerOptions
-
The base class automatically sets members to the static defaults.
R
- registerEventProcessor(Class<T>) - Method in class com.microsoft.azure.eventprocessorhost.EventProcessorHost
-
Register class for event processor and start processing.
- registerEventProcessor(Class<T>, EventProcessorOptions) - Method in class com.microsoft.azure.eventprocessorhost.EventProcessorHost
-
Register class for event processor and start processing.
- registerEventProcessorFactory(IEventProcessorFactory<?>) - Method in class com.microsoft.azure.eventprocessorhost.EventProcessorHost
-
Register a user-supplied event processor factory and start processing.
- registerEventProcessorFactory(IEventProcessorFactory<?>, EventProcessorOptions) - Method in class com.microsoft.azure.eventprocessorhost.EventProcessorHost
-
Register user-supplied event processor factory and start processing.
- releaseLease(CompleteLease) - Method in interface com.microsoft.azure.eventprocessorhost.ILeaseManager
-
Give up a lease currently held by this host.
- releaseLease(CompleteLease) - Method in class com.microsoft.azure.eventprocessorhost.InMemoryLeaseManager
- RELEASING_LEASE - Static variable in class com.microsoft.azure.eventprocessorhost.EventProcessorHostActionStrings
- RENEWING_LEASE - Static variable in class com.microsoft.azure.eventprocessorhost.EventProcessorHostActionStrings
- renewLease(CompleteLease) - Method in interface com.microsoft.azure.eventprocessorhost.ILeaseManager
-
Renew a lease currently held by this host instance.
- renewLease(CompleteLease) - Method in class com.microsoft.azure.eventprocessorhost.InMemoryLeaseManager
S
- safeCreateUUID() - Static method in class com.microsoft.azure.eventprocessorhost.EventProcessorHost
-
Synchronized string UUID generation convenience method.
- setCheckpointTimeoutInSeconds(int) - Method in class com.microsoft.azure.eventprocessorhost.PartitionManagerOptions
-
Sets the timeout for checkpoint operations.
- setEpoch(long) - Method in class com.microsoft.azure.eventprocessorhost.CompleteLease
-
Set the epoch value.
- setExceptionNotification(Consumer<ExceptionReceivedEventArgs>) - Method in class com.microsoft.azure.eventprocessorhost.EventProcessorOptions
-
Sets a handler which receives notification of general exceptions.
- setExecutor(ScheduledExecutorService) - Method in interface com.microsoft.azure.eventprocessorhost.EventProcessorHost.EventProcessorHostBuilder.OptionalStep
-
Event Processor Host runs tasks on the supplied threadpool, or creates an internal one.
- setFastScanIntervalInSeconds(int) - Method in class com.microsoft.azure.eventprocessorhost.PartitionManagerOptions
-
Sets the time for fast interval.
- setInitialPositionProvider(Function<String, EventPosition>) - Method in class com.microsoft.azure.eventprocessorhost.EventProcessorOptions
-
Sets the function used to determine the position at which to start receiving events for a partition if there is no checkpoint for that partition.
- setInvokeProcessorAfterReceiveTimeout(Boolean) - Method in class com.microsoft.azure.eventprocessorhost.EventProcessorOptions
-
Changes whether the EventProcessorHost will call IEventProcessor.onEvents() with an empty iterable when a receive timeout occurs (true) or not (false).
- setIsOwned(boolean) - Method in class com.microsoft.azure.eventprocessorhost.BaseLease
-
Set the owned state of the lease.
- setLatency(long) - Method in class com.microsoft.azure.eventprocessorhost.InMemoryLeaseManager
- setLeaseDurationInSeconds(int) - Method in class com.microsoft.azure.eventprocessorhost.AzureStoragePartitionManagerOptions
- setLeaseDurationInSeconds(int) - Method in class com.microsoft.azure.eventprocessorhost.PartitionManagerOptions
-
Sets the duration after which a partition lease will expire unless renewed.
- setLeaseRenewIntervalInSeconds(int) - Method in class com.microsoft.azure.eventprocessorhost.PartitionManagerOptions
-
Sets the duration between lease renewals.
- setMaxBatchSize(int) - Method in class com.microsoft.azure.eventprocessorhost.EventProcessorOptions
-
Sets the maximum number of events that will be passed to one call to IEventProcessor.onEvents
- setOffset(String) - Method in class com.microsoft.azure.eventprocessorhost.Checkpoint
-
Set the offset.
- setOperationTimeout(Duration) - Method in interface com.microsoft.azure.eventprocessorhost.EventProcessorHost.EventProcessorHostBuilder.OptionalStep
-
The timeout for Event Hubs operations.
- setOwner(String) - Method in class com.microsoft.azure.eventprocessorhost.BaseLease
-
Set the owner string.
- setPartitionManagerOptions(PartitionManagerOptions) - Method in class com.microsoft.azure.eventprocessorhost.EventProcessorHost
-
Set the partition manager options all at once.
- setPrefetchCount(int) - Method in class com.microsoft.azure.eventprocessorhost.EventProcessorOptions
-
Sets the prefetch count for the underlying event hub client.
- setReceiverRuntimeMetricEnabled(boolean) - Method in class com.microsoft.azure.eventprocessorhost.EventProcessorOptions
-
Knob to enable/disable runtime metric of the receiver.
- setReceiveTimeOut(Duration) - Method in class com.microsoft.azure.eventprocessorhost.EventProcessorOptions
-
Sets the timeout for receive operations.
- setRetryPolicy(RetryPolicy) - Method in interface com.microsoft.azure.eventprocessorhost.EventProcessorHost.EventProcessorHostBuilder.OptionalStep
-
RetryPolicy
for Event Hubs operations. - setSequenceNumber(long) - Method in class com.microsoft.azure.eventprocessorhost.Checkpoint
-
Set the sequence number.
- setSlowScanIntervalInSeconds(int) - Method in class com.microsoft.azure.eventprocessorhost.PartitionManagerOptions
-
Sets the time for slow interval.
- setStartupScanDelayInSeconds(int) - Method in class com.microsoft.azure.eventprocessorhost.PartitionManagerOptions
-
Sets the delay time in seconds between the first scan and the second.
- setTransportType(TransportType) - Method in interface com.microsoft.azure.eventprocessorhost.EventProcessorHost.EventProcessorHostBuilder.OptionalStep
-
TransportType
for connections to the Event Hubs service. - Shutdown - com.microsoft.azure.eventprocessorhost.CloseReason
-
The IEventProcessor is closing because the event processor host is being shut down, or because an error has occurred.
- slowScanIntervalInSeconds - Variable in class com.microsoft.azure.eventprocessorhost.PartitionManagerOptions
- StartOfStreamInitialPositionProvider() - Constructor for class com.microsoft.azure.eventprocessorhost.EventProcessorOptions.StartOfStreamInitialPositionProvider
- startupScanDelayInSeconds - Variable in class com.microsoft.azure.eventprocessorhost.PartitionManagerOptions
- STEALING_LEASE - Static variable in class com.microsoft.azure.eventprocessorhost.EventProcessorHostActionStrings
U
- unregisterEventProcessor() - Method in class com.microsoft.azure.eventprocessorhost.EventProcessorHost
-
Stop processing events and shut down this host instance.
- updateCheckpoint(CompleteLease, Checkpoint) - Method in interface com.microsoft.azure.eventprocessorhost.ICheckpointManager
-
Update the checkpoint in the store with the offset/sequenceNumber in the provided checkpoint.
- updateCheckpoint(CompleteLease, Checkpoint) - Method in class com.microsoft.azure.eventprocessorhost.InMemoryCheckpointManager
- updateLease(CompleteLease) - Method in interface com.microsoft.azure.eventprocessorhost.ILeaseManager
-
Update the store with the information in the provided lease.
- updateLease(CompleteLease) - Method in class com.microsoft.azure.eventprocessorhost.InMemoryLeaseManager
- UPDATING_CHECKPOINT - Static variable in class com.microsoft.azure.eventprocessorhost.EventProcessorHostActionStrings
- UPDATING_LEASE - Static variable in class com.microsoft.azure.eventprocessorhost.EventProcessorHostActionStrings
- useAADAuthentication(URI, String) - Method in interface com.microsoft.azure.eventprocessorhost.EventProcessorHost.EventProcessorHostBuilder.AuthStep
-
When using AAD auth, call this method to specify the Event Hub, then add AAD-based auth information in the next step.
- useAuthenticationCallback(AzureActiveDirectoryTokenProvider.AuthenticationCallback, String) - Method in interface com.microsoft.azure.eventprocessorhost.EventProcessorHost.EventProcessorHostBuilder.AADAuthStep
-
Provide a callback which will be called when a token is needed.
- useAzureStorageCheckpointLeaseManager(StorageCredentials, String, String) - Method in interface com.microsoft.azure.eventprocessorhost.EventProcessorHost.EventProcessorHostBuilder.ManagerStep
-
Use the built-in Azure Storage-based lease and checkpoint managers.
- useAzureStorageCheckpointLeaseManager(String, String, String) - Method in interface com.microsoft.azure.eventprocessorhost.EventProcessorHost.EventProcessorHostBuilder.ManagerStep
-
Use the built-in Azure Storage-based lease and checkpoint managers.
- useEventHubConnectionString(String) - Method in interface com.microsoft.azure.eventprocessorhost.EventProcessorHost.EventProcessorHostBuilder.AuthStep
-
Azure Portal can provide a connection string with auth information that applies only to one individual Event Hub.
- useEventHubConnectionString(String, String) - Method in interface com.microsoft.azure.eventprocessorhost.EventProcessorHost.EventProcessorHostBuilder.AuthStep
-
Azure Portal can provide a connection string with auth information that applies to the entire namespace instead of an individual Event Hub.
- useTokenProvider(ITokenProvider) - Method in interface com.microsoft.azure.eventprocessorhost.EventProcessorHost.EventProcessorHostBuilder.AADAuthStep
-
Provide a user-implemented token provider which will be called when a token is needed.
- useUserCheckpointAndLeaseManagers(ICheckpointManager, ILeaseManager) - Method in interface com.microsoft.azure.eventprocessorhost.EventProcessorHost.EventProcessorHostBuilder.ManagerStep
-
Use user-implemented lease and checkpoint managers.
V
- valueOf(String) - Static method in enum com.microsoft.azure.eventprocessorhost.CloseReason
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum com.microsoft.azure.eventprocessorhost.CloseReason
-
Returns an array containing the constants of this enum type, in the order they are declared.
All Classes All Packages