| Package | Description | 
|---|---|
| org.apache.storm.eventhubs.spout | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
ZookeeperStateStore  | 
| Modifier and Type | Field and Description | 
|---|---|
protected IStateStore | 
StaticPartitionCoordinator.stateStore  | 
| Modifier and Type | Method and Description | 
|---|---|
IPartitionManager | 
IPartitionManagerFactory.create(EventHubSpoutConfig spoutConfig,
      String partitionId,
      IStateStore stateStore,
      IEventHubReceiver receiver)  | 
| Constructor and Description | 
|---|
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)  | 
Copyright © 2022 The Apache Software Foundation. All rights reserved.