| Package | Description | 
|---|---|
| org.apache.storm.eventhubs.samples | |
| org.apache.storm.eventhubs.spout | |
| org.apache.storm.eventhubs.trident | 
| Modifier and Type | Field and Description | 
|---|---|
| protected EventHubSpoutConfig | EventCount. spoutConfig | 
| Modifier and Type | Field and Description | 
|---|---|
| protected EventHubSpoutConfig | StaticPartitionCoordinator. config | 
| protected EventHubSpoutConfig | SimplePartitionManager. config | 
| Modifier and Type | Method and Description | 
|---|---|
| EventHubSpoutConfig | EventHubSpoutConfig. withCheckpointIntervalInSeconds(int value) | 
| EventHubSpoutConfig | EventHubSpoutConfig. withConsumerGroupName(String value) | 
| EventHubSpoutConfig | EventHubSpoutConfig. withEnqueueTimeFilter(long value) | 
| EventHubSpoutConfig | EventHubSpoutConfig. withEventDataScheme(IEventDataScheme value) | 
| EventHubSpoutConfig | EventHubSpoutConfig. withMaxPendingMsgsPerPartition(int value) | 
| EventHubSpoutConfig | EventHubSpoutConfig. withReceiverCredits(int value) | 
| EventHubSpoutConfig | EventHubSpoutConfig. withTargetAddress(String targetFqnAddress) | 
| EventHubSpoutConfig | EventHubSpoutConfig. withTopologyName(String value) | 
| EventHubSpoutConfig | EventHubSpoutConfig. withZkConnectionString(String value) | 
| Modifier and Type | Method and Description | 
|---|---|
| IEventHubReceiver | IEventHubReceiverFactory. create(EventHubSpoutConfig config,
      String partitionId) | 
| IPartitionManager | IPartitionManagerFactory. create(EventHubSpoutConfig spoutConfig,
      String partitionId,
      IStateStore stateStore,
      IEventHubReceiver receiver) | 
| Constructor and Description | 
|---|
| EventHubReceiverImpl(EventHubSpoutConfig config,
                    String partitionId) | 
| EventHubSpout(EventHubSpoutConfig spoutConfig) | 
| EventHubSpout(EventHubSpoutConfig spoutConfig,
             IStateStore store,
             IPartitionManagerFactory pmFactory,
             IEventHubReceiverFactory recvFactory) | 
| PartitionManager(EventHubSpoutConfig spoutConfig,
                String partitionId,
                IStateStore stateStore,
                IEventHubReceiver receiver) | 
| SimplePartitionManager(EventHubSpoutConfig spoutConfig,
                      String partitionId,
                      IStateStore stateStore,
                      IEventHubReceiver receiver) | 
| StaticPartitionCoordinator(EventHubSpoutConfig spoutConfig,
                          int taskIndex,
                          int totalTasks,
                          IStateStore stateStore,
                          IPartitionManagerFactory pmFactory,
                          IEventHubReceiverFactory recvFactory) | 
| Constructor and Description | 
|---|
| Coordinator(EventHubSpoutConfig spoutConfig) | 
| OpaqueTridentEventHubEmitter(EventHubSpoutConfig spoutConfig) | 
| OpaqueTridentEventHubEmitter(EventHubSpoutConfig spoutConfig,
                            int batchSize,
                            ITridentPartitionManagerFactory pmFactory,
                            IEventHubReceiverFactory recvFactory) | 
| OpaqueTridentEventHubSpout(EventHubSpoutConfig config) | 
| Partition(EventHubSpoutConfig config,
         String partitionId) | 
| TransactionalTridentEventHubEmitter(EventHubSpoutConfig spoutConfig) | 
| TransactionalTridentEventHubEmitter(EventHubSpoutConfig spoutConfig,
                                   int batchSize,
                                   ITridentPartitionManagerFactory pmFactory,
                                   IEventHubReceiverFactory recvFactory) | 
| TransactionalTridentEventHubSpout(EventHubSpoutConfig config) | 
| TridentPartitionManager(EventHubSpoutConfig spoutConfig,
                       IEventHubReceiver receiver) | 
Copyright © 2019 The Apache Software Foundation. All Rights Reserved.