Search in sources :

Example 1 with IPartitionManagerFactory

use of org.apache.storm.eventhubs.spout.IPartitionManagerFactory in project storm by apache.

the class AtMostOnceEventCount method createEventHubSpout.

@Override
protected EventHubSpout createEventHubSpout() {
    IPartitionManagerFactory pmFactory = new IPartitionManagerFactory() {

        private static final long serialVersionUID = 1L;

        @Override
        public IPartitionManager create(EventHubSpoutConfig spoutConfig, String partitionId, IStateStore stateStore, IEventHubReceiver receiver) {
            return new SimplePartitionManager(spoutConfig, partitionId, stateStore, receiver);
        }
    };
    EventHubSpout eventHubSpout = new EventHubSpout(spoutConfig, null, pmFactory, null);
    return eventHubSpout;
}
Also used : IPartitionManagerFactory(org.apache.storm.eventhubs.spout.IPartitionManagerFactory) IStateStore(org.apache.storm.eventhubs.spout.IStateStore) SimplePartitionManager(org.apache.storm.eventhubs.spout.SimplePartitionManager) EventHubSpoutConfig(org.apache.storm.eventhubs.spout.EventHubSpoutConfig) EventHubSpout(org.apache.storm.eventhubs.spout.EventHubSpout) IEventHubReceiver(org.apache.storm.eventhubs.spout.IEventHubReceiver)

Aggregations

EventHubSpout (org.apache.storm.eventhubs.spout.EventHubSpout)1 EventHubSpoutConfig (org.apache.storm.eventhubs.spout.EventHubSpoutConfig)1 IEventHubReceiver (org.apache.storm.eventhubs.spout.IEventHubReceiver)1 IPartitionManagerFactory (org.apache.storm.eventhubs.spout.IPartitionManagerFactory)1 IStateStore (org.apache.storm.eventhubs.spout.IStateStore)1 SimplePartitionManager (org.apache.storm.eventhubs.spout.SimplePartitionManager)1