| Package | Description | 
|---|---|
| org.apache.storm.eventhubs.spout | |
| org.apache.storm.eventhubs.trident | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | EventHubReceiverImpl | 
| Modifier and Type | Field and Description | 
|---|---|
| protected IEventHubReceiver | SimplePartitionManager. receiver | 
| Modifier and Type | Method and Description | 
|---|---|
| IEventHubReceiver | IEventHubReceiverFactory. create(EventHubSpoutConfig config,
      String partitionId) | 
| Modifier and Type | Method and Description | 
|---|---|
| IPartitionManager | IPartitionManagerFactory. create(EventHubSpoutConfig spoutConfig,
      String partitionId,
      IStateStore stateStore,
      IEventHubReceiver receiver) | 
| Constructor and Description | 
|---|
| PartitionManager(EventHubSpoutConfig spoutConfig,
                String partitionId,
                IStateStore stateStore,
                IEventHubReceiver receiver) | 
| SimplePartitionManager(EventHubSpoutConfig spoutConfig,
                      String partitionId,
                      IStateStore stateStore,
                      IEventHubReceiver receiver) | 
| Modifier and Type | Method and Description | 
|---|---|
| ITridentPartitionManager | ITridentPartitionManagerFactory. create(IEventHubReceiver receiver) | 
| Constructor and Description | 
|---|
| TridentPartitionManager(EventHubSpoutConfig spoutConfig,
                       IEventHubReceiver receiver) | 
Copyright © 2019 The Apache Software Foundation. All rights reserved.