public class TransactionalTridentEventHubSpout extends Object implements IPartitionedTridentSpout<Partitions,Partition,Map<String,Object>>
Transactional Trident EventHub Spout.
IPartitionedTridentSpout.Coordinator<PartitionsT>, IPartitionedTridentSpout.Emitter<PartitionsT,PartitionT extends ISpoutPartition,X>
Constructor and Description |
---|
TransactionalTridentEventHubSpout(EventHubSpoutConfig config) |
Modifier and Type | Method and Description |
---|---|
Map<String,Object> |
getComponentConfiguration() |
IPartitionedTridentSpout.Coordinator<Partitions> |
getCoordinator(Map<String,Object> conf,
TopologyContext context) |
IPartitionedTridentSpout.Emitter<Partitions,Partition,Map<String,Object>> |
getEmitter(Map<String,Object> conf,
TopologyContext context) |
Fields |
getOutputFields() |
public TransactionalTridentEventHubSpout(EventHubSpoutConfig config)
public Map<String,Object> getComponentConfiguration()
getComponentConfiguration
in interface IPartitionedTridentSpout<Partitions,Partition,Map<String,Object>>
public IPartitionedTridentSpout.Coordinator<Partitions> getCoordinator(Map<String,Object> conf, TopologyContext context)
getCoordinator
in interface IPartitionedTridentSpout<Partitions,Partition,Map<String,Object>>
public IPartitionedTridentSpout.Emitter<Partitions,Partition,Map<String,Object>> getEmitter(Map<String,Object> conf, TopologyContext context)
getEmitter
in interface IPartitionedTridentSpout<Partitions,Partition,Map<String,Object>>
public Fields getOutputFields()
getOutputFields
in interface IPartitionedTridentSpout<Partitions,Partition,Map<String,Object>>
Copyright © 2022 The Apache Software Foundation. All rights reserved.