Uses of Class
org.apache.storm.tuple.Fields
Package
Description
ElasticSearch Trident example classes.
-
Uses of Fields in org.apache.storm.daemon
-
Uses of Fields in org.apache.storm.daemon.worker
-
Uses of Fields in org.apache.storm.drpc
Modifier and TypeMethodDescriptionLinearDRPCInputDeclarer.fieldsGrouping
(String streamId, Fields fields) LinearDRPCInputDeclarer.fieldsGrouping
(Fields fields) LinearDRPCInputDeclarer.partialKeyGrouping
(String streamId, Fields fields) LinearDRPCInputDeclarer.partialKeyGrouping
(Fields fields) -
Uses of Fields in org.apache.storm.elasticsearch
-
Uses of Fields in org.apache.storm.elasticsearch.trident
Modifier and TypeMethodDescriptionTridentEsTopology.FixedBatchSpout.getOutputFields()
Gets the output fields. -
Uses of Fields in org.apache.storm.flux.examples
-
Uses of Fields in org.apache.storm.grouping
ModifierConstructorDescriptionPartialKeyGrouping
(Fields fields) PartialKeyGrouping
(Fields fields, PartialKeyGrouping.AssignmentCreator assignmentCreator) PartialKeyGrouping
(Fields fields, PartialKeyGrouping.AssignmentCreator assignmentCreator, PartialKeyGrouping.TargetSelector targetSelector) -
Uses of Fields in org.apache.storm.hdfs.bolt.format
Modifier and TypeMethodDescriptionDelimitedRecordFormat.withFields
(Fields fields) Only output the specified fields. -
Uses of Fields in org.apache.storm.hdfs.trident
ModifierConstructorDescriptionFixedBatchSpout
(Fields fields, int maxBatchSize, List<Object>... outputs) -
Uses of Fields in org.apache.storm.hdfs.trident.format
Modifier and TypeMethodDescriptionDelimitedRecordFormat.withFields
(Fields fields) Only output the specified fields. -
Uses of Fields in org.apache.storm.hive.bolt.mapper
Modifier and TypeMethodDescriptionDelimitedRecordHiveMapper.withColumnFields
(Fields columnFields) JsonRecordHiveMapper.withColumnFields
(Fields columnFields) DelimitedRecordHiveMapper.withPartitionFields
(Fields partitionFields) JsonRecordHiveMapper.withPartitionFields
(Fields partitionFields) -
Uses of Fields in org.apache.storm.hive.trident
-
Uses of Fields in org.apache.storm.jdbc.mapper
ModifierConstructorDescriptionSimpleJdbcLookupMapper
(Fields outputFields, List<Column> queryColumns) -
Uses of Fields in org.apache.storm.jms.example
ModifierConstructorDescriptionGenericBolt
(String name, boolean autoAck, boolean autoAnchor, Fields declaredFields) Constructs a newGenericBolt
instance. -
Uses of Fields in org.apache.storm.jms.trident
-
Uses of Fields in org.apache.storm.kafka.spout
Modifier and TypeMethodDescriptionByTopicRecordTranslator.getFieldsFor
(String stream) DefaultRecordTranslator.getFieldsFor
(String stream) RecordTranslator.getFieldsFor
(String stream) Get the fields associated with a stream.SimpleRecordTranslator.getFieldsFor
(String stream) Modifier and TypeMethodDescriptionByTopicRecordTranslator.forTopic
(String topic, Func<org.apache.kafka.clients.consumer.ConsumerRecord<K, V>, List<Object>> func, Fields fields) Configure a translator for a given topic with tuples to be emitted to the default stream.ByTopicRecordTranslator.forTopic
(String topic, Func<org.apache.kafka.clients.consumer.ConsumerRecord<K, V>, List<Object>> func, Fields fields, String stream) Configure a translator for a given topic.ModifierConstructorDescriptionByTopicRecordTranslator
(Func<org.apache.kafka.clients.consumer.ConsumerRecord<K, V>, List<Object>> func, Fields fields) Create a simple record translator that will use func to extract the fields of the tuple, named by fields, and emit them to the default stream.ByTopicRecordTranslator
(Func<org.apache.kafka.clients.consumer.ConsumerRecord<K, V>, List<Object>> func, Fields fields, String stream) Create a simple record translator that will use func to extract the fields of the tuple, named by fields, and emit them to stream.SimpleRecordTranslator
(Func<org.apache.kafka.clients.consumer.ConsumerRecord<K, V>, List<Object>> func, Fields fields) SimpleRecordTranslator
(Func<org.apache.kafka.clients.consumer.ConsumerRecord<K, V>, List<Object>> func, Fields fields, String stream) Creates a SimpleRecordTranslator. -
Uses of Fields in org.apache.storm.kafka.spout.internal
Modifier and TypeMethodDescriptionCommonKafkaSpoutConfig.Builder.setRecordTranslator
(Func<org.apache.kafka.clients.consumer.ConsumerRecord<K, V>, List<Object>> func, Fields fields) Configure a translator with tuples to be emitted on the default stream.CommonKafkaSpoutConfig.Builder.setRecordTranslator
(Func<org.apache.kafka.clients.consumer.ConsumerRecord<K, V>, List<Object>> func, Fields fields, String stream) Configure a translator with tuples to be emitted to a given stream. -
Uses of Fields in org.apache.storm.kafka.spout.trident
Modifier and TypeMethodDescriptionKafkaTridentSpoutOpaque.getOutputFields()
KafkaTridentSpoutTransactional.getOutputFields()
-
Uses of Fields in org.apache.storm.kafka.spout.trident.internal
Modifier and TypeMethodDescription<K,
V> Fields OutputFieldsExtractor.getOutputFields
(KafkaTridentSpoutConfig<K, V> kafkaSpoutConfig) Extract the output fields from the config. -
Uses of Fields in org.apache.storm.spout
Modifier and TypeMethodDescriptionMultiScheme.getOutputFields()
RawMultiScheme.getOutputFields()
RawScheme.getOutputFields()
Scheme.getOutputFields()
SchemeAsMultiScheme.getOutputFields()
-
Uses of Fields in org.apache.storm.sql.kafka
-
Uses of Fields in org.apache.storm.sql.runtime.serde.avro
-
Uses of Fields in org.apache.storm.sql.runtime.serde.csv
-
Uses of Fields in org.apache.storm.sql.runtime.serde.json
-
Uses of Fields in org.apache.storm.sql.runtime.serde.tsv
-
Uses of Fields in org.apache.storm.st.topology.window.data
-
Uses of Fields in org.apache.storm.starter.bolt
-
Uses of Fields in org.apache.storm.starter.spout
ModifierConstructorDescriptionRandomNumberGeneratorSpout
(Fields fields, int batchSize, int maxNumber) -
Uses of Fields in org.apache.storm.streams
Modifier and TypeFieldDescriptionprotected static final Fields
Stream.KEY
protected static final Fields
Stream.KEY_VALUE
protected final Fields
Node.outputFields
protected final Fields
Node.outputFields
protected static final Fields
Stream.VALUE
ModifierConstructorDescriptionProcessorNode
(Processor<?> processor, String outputStream, Fields outputFields) ProcessorNode
(Processor<?> processor, String outputStream, Fields outputFields, boolean preservesKey) -
Uses of Fields in org.apache.storm.task
Modifier and TypeMethodDescriptionGeneralTopologyContext.getComponentOutputFields
(String componentId, String streamId) Gets the declared output fields for the specified component/stream.GeneralTopologyContext.getComponentOutputFields
(GlobalStreamId id) Gets the declared output fields for the specified global stream id.TopologyContext.getThisOutputFields
(String streamId) Gets the declared output fields for the specified stream id for the component this task is a part of. -
Uses of Fields in org.apache.storm.testing
Modifier and TypeMethodDescriptionTestEventOrderCheckBolt.getOutputFields()
TestGlobalCount.getOutputFields()
TestPlannerBolt.getOutputFields()
TestPlannerSpout.getOutputFields()
ModifierConstructorDescriptionFeederSpout
(Fields outFields) FixedTupleSpout
(List tuples, Fields fields) IdentityBolt
(Fields fields) PrepareBatchBolt
(Fields outFields) TestPlannerSpout
(Fields outFields) TestPlannerSpout
(Fields outFields, boolean isDistributed) -
Uses of Fields in org.apache.storm.topology
Modifier and TypeMethodDescriptionvoid
void
Uses default stream id.void
void
void
OutputFieldsDeclarer.declareStream
(String streamId, boolean direct, Fields fields) void
OutputFieldsDeclarer.declareStream
(String streamId, Fields fields) void
OutputFieldsGetter.declareStream
(String streamId, boolean direct, Fields fields) void
OutputFieldsGetter.declareStream
(String streamId, Fields fields) InputDeclarer.fieldsGrouping
(String componentId, String streamId, Fields fields) The stream is partitioned by the fields specified in the grouping.InputDeclarer.fieldsGrouping
(String componentId, Fields fields) The stream is partitioned by the fields specified in the grouping.TopologyBuilder.BoltGetter.fieldsGrouping
(String componentId, String streamId, Fields fields) TopologyBuilder.BoltGetter.fieldsGrouping
(String componentId, Fields fields) InputDeclarer.partialKeyGrouping
(String componentId, String streamId, Fields fields) Tuples are passed to two hashing functions and each target task is decided based on the comparison of the state of candidate nodes.InputDeclarer.partialKeyGrouping
(String componentId, Fields fields) Tuples are passed to two hashing functions and each target task is decided based on the comparison of the state of candidate nodes.TopologyBuilder.BoltGetter.partialKeyGrouping
(String componentId, String streamId, Fields fields) TopologyBuilder.BoltGetter.partialKeyGrouping
(String componentId, Fields fields) -
Uses of Fields in org.apache.storm.trident
Modifier and TypeMethodDescriptionStream.aggregate
(Aggregator agg, Fields functionFields) Stream.aggregate
(CombinerAggregator agg, Fields functionFields) Stream.aggregate
(ReducerAggregator agg, Fields functionFields) Stream.aggregate
(Fields inputFields, Aggregator agg, Fields functionFields) Stream.aggregate
(Fields inputFields, CombinerAggregator agg, Fields functionFields) Stream.aggregate
(Fields inputFields, ReducerAggregator agg, Fields functionFields) Returns a stream consisting of the elements of this stream that match the given filter.Stream.flatMap
(FlatMapFunction function, Fields outputFields) Returns a stream consisting of the results of replacing each value of this stream with the contents produced by applying the provided mapping function to each value.## Grouping Operation.TridentTopology.join
(List<Stream> streams, List<Fields> joinFields, Fields outFields, List<JoinType> mixed) TridentTopology.join
(List<Stream> streams, List<Fields> joinFields, Fields outFields, List<JoinType> mixed, JoinOutFieldsMode mode) TridentTopology.join
(List<Stream> streams, List<Fields> joinFields, Fields outFields, JoinOutFieldsMode mode) TridentTopology.join
(List<Stream> streams, List<Fields> joinFields, Fields outFields, JoinType type) TridentTopology.join
(List<Stream> streams, List<Fields> joinFields, Fields outFields, JoinType type, JoinOutFieldsMode mode) TridentTopology.join
(Stream s1, Fields joinFields1, Stream s2, Fields joinFields2, Fields outFields) TridentTopology.join
(Stream s1, Fields joinFields1, Stream s2, Fields joinFields2, Fields outFields, List<JoinType> mixed) TridentTopology.join
(Stream s1, Fields joinFields1, Stream s2, Fields joinFields2, Fields outFields, List<JoinType> mixed, JoinOutFieldsMode mode) TridentTopology.join
(Stream s1, Fields joinFields1, Stream s2, Fields joinFields2, Fields outFields, JoinOutFieldsMode mode) TridentTopology.join
(Stream s1, Fields joinFields1, Stream s2, Fields joinFields2, Fields outFields, JoinType type) TridentTopology.join
(Stream s1, Fields joinFields1, Stream s2, Fields joinFields2, Fields outFields, JoinType type, JoinOutFieldsMode mode) Stream.map
(MapFunction function, Fields outputFields) Returns a stream consisting of the result of applying the given mapping function to the values of this stream.TridentTopology.multiReduce
(List<GroupedStream> streams, GroupedMultiReducer function, Fields outputFields) TridentTopology.multiReduce
(List<Stream> streams, MultiReducer function, Fields outputFields) TridentTopology.multiReduce
(List<Fields> inputFields, List<GroupedStream> groupedStreams, GroupedMultiReducer function, Fields outputFields) TridentTopology.multiReduce
(List<Fields> inputFields, List<Stream> streams, MultiReducer function, Fields outputFields) TridentTopology.multiReduce
(GroupedStream s1, GroupedStream s2, GroupedMultiReducer function, Fields outputFields) TridentTopology.multiReduce
(Stream s1, Stream s2, MultiReducer function, Fields outputFields) TridentTopology.multiReduce
(Fields inputFields1, GroupedStream s1, Fields inputFields2, GroupedStream s2, GroupedMultiReducer function, Fields outputFields) TridentTopology.multiReduce
(Fields inputFields1, Stream s1, Fields inputFields2, Stream s2, MultiReducer function, Fields outputFields) Stream.partitionAggregate
(Aggregator agg, Fields functionFields) Stream.partitionAggregate
(CombinerAggregator agg, Fields functionFields) Stream.partitionAggregate
(ReducerAggregator agg, Fields functionFields) Stream.partitionAggregate
(Fields inputFields, Aggregator agg, Fields functionFields) Stream.partitionAggregate
(Fields inputFields, CombinerAggregator agg, Fields functionFields) Stream.partitionAggregate
(Fields inputFields, ReducerAggregator agg, Fields functionFields) Stream.partitionBy
(Fields fields) ## Repartitioning Operation.Stream.partitionPersist
(StateFactory stateFactory, StateUpdater updater, Fields functionFields) Stream.partitionPersist
(StateFactory stateFactory, Fields inputFields, StateUpdater updater) Stream.partitionPersist
(StateFactory stateFactory, Fields inputFields, StateUpdater updater, Fields functionFields) Stream.partitionPersist
(StateSpec stateSpec, StateUpdater updater, Fields functionFields) Stream.partitionPersist
(StateSpec stateSpec, Fields inputFields, StateUpdater updater) Stream.partitionPersist
(StateSpec stateSpec, Fields inputFields, StateUpdater updater, Fields functionFields) Stream.persistentAggregate
(StateFactory stateFactory, CombinerAggregator agg, Fields functionFields) Stream.persistentAggregate
(StateFactory stateFactory, ReducerAggregator agg, Fields functionFields) Stream.persistentAggregate
(StateFactory stateFactory, Fields inputFields, CombinerAggregator agg, Fields functionFields) Stream.persistentAggregate
(StateFactory stateFactory, Fields inputFields, ReducerAggregator agg, Fields functionFields) Stream.persistentAggregate
(StateSpec spec, CombinerAggregator agg, Fields functionFields) Stream.persistentAggregate
(StateSpec spec, ReducerAggregator agg, Fields functionFields) Stream.persistentAggregate
(StateSpec spec, Fields inputFields, CombinerAggregator agg, Fields functionFields) Stream.persistentAggregate
(StateSpec spec, Fields inputFields, ReducerAggregator agg, Fields functionFields) Filters out fields from a stream, resulting in a Stream containing only the fields specified by `keepFields`.Stream.slidingWindow
(int windowCount, int slideCount, WindowsStoreFactory windowStoreFactory, Fields inputFields, Aggregator aggregator, Fields functionFields) Returns a stream of tuples which are aggregated results of a sliding window with everywindowCount
of tuples and slides the window afterslideCount
.Stream.slidingWindow
(BaseWindowedBolt.Duration windowDuration, BaseWindowedBolt.Duration slidingInterval, WindowsStoreFactory windowStoreFactory, Fields inputFields, Aggregator aggregator, Fields functionFields) Returns a stream of tuples which are aggregated results of a window which slides at duration ofslidingInterval
and completes a window atwindowDuration
.Stream.stateQuery
(TridentState state, QueryFunction function, Fields functionFields) Stream.stateQuery
(TridentState state, Fields inputFields, QueryFunction function, Fields functionFields) Stream.tumblingWindow
(int windowCount, WindowsStoreFactory windowStoreFactory, Fields inputFields, Aggregator aggregator, Fields functionFields) Returns a stream of tuples which are aggregated results of a tumbling window with everywindowCount
of tuples.Stream.tumblingWindow
(BaseWindowedBolt.Duration windowDuration, WindowsStoreFactory windowStoreFactory, Fields inputFields, Aggregator aggregator, Fields functionFields) Returns a stream of tuples which are aggregated results of a window that tumbles at duration ofwindowDuration
.Stream.window
(WindowConfig windowConfig, WindowsStoreFactory windowStoreFactory, Fields inputFields, Aggregator aggregator, Fields functionFields) Returns stream of aggregated results based on the given window configuration.Stream.window
(WindowConfig windowConfig, Fields inputFields, Aggregator aggregator, Fields functionFields) Returns a stream of aggregated results based on the given window configuration which uses inmemory windowing tuple store.Modifier and TypeMethodDescriptionTridentTopology.multiReduce
(List<Fields> inputFields, List<GroupedStream> groupedStreams, GroupedMultiReducer function, Fields outputFields) TridentTopology.multiReduce
(List<Fields> inputFields, List<Stream> streams, MultiReducer function, Fields outputFields) -
Uses of Fields in org.apache.storm.trident.fluent
Modifier and TypeMethodDescriptionGroupedStream.getGroupFields()
GroupedStream.getOutputFields()
IAggregatableStream.getOutputFields()
Modifier and TypeMethodDescriptionChainedAggregatorDeclarer.aggregate
(Aggregator agg, Fields functionFields) ChainedAggregatorDeclarer.aggregate
(CombinerAggregator agg, Fields functionFields) ChainedAggregatorDeclarer.aggregate
(ReducerAggregator agg, Fields functionFields) ChainedAggregatorDeclarer.aggregate
(Fields inputFields, Aggregator agg, Fields functionFields) ChainedAggregatorDeclarer.aggregate
(Fields inputFields, CombinerAggregator agg, Fields functionFields) ChainedAggregatorDeclarer.aggregate
(Fields inputFields, ReducerAggregator agg, Fields functionFields) ChainedFullAggregatorDeclarer.aggregate
(Aggregator agg, Fields functionFields) ChainedFullAggregatorDeclarer.aggregate
(CombinerAggregator agg, Fields functionFields) ChainedFullAggregatorDeclarer.aggregate
(ReducerAggregator agg, Fields functionFields) ChainedFullAggregatorDeclarer.aggregate
(Fields inputFields, Aggregator agg, Fields functionFields) ChainedFullAggregatorDeclarer.aggregate
(Fields inputFields, CombinerAggregator agg, Fields functionFields) ChainedFullAggregatorDeclarer.aggregate
(Fields inputFields, ReducerAggregator agg, Fields functionFields) GroupedStream.aggregate
(Aggregator agg, Fields functionFields) GroupedStream.aggregate
(CombinerAggregator agg, Fields functionFields) GroupedStream.aggregate
(ReducerAggregator agg, Fields functionFields) GroupedStream.aggregate
(Fields inputFields, Aggregator agg, Fields functionFields) GroupedStream.aggregate
(Fields inputFields, CombinerAggregator agg, Fields functionFields) GroupedStream.aggregate
(Fields inputFields, ReducerAggregator agg, Fields functionFields) ChainedAggregatorDeclarer.partitionAggregate
(Aggregator agg, Fields functionFields) ChainedAggregatorDeclarer.partitionAggregate
(CombinerAggregator agg, Fields functionFields) ChainedAggregatorDeclarer.partitionAggregate
(ReducerAggregator agg, Fields functionFields) ChainedAggregatorDeclarer.partitionAggregate
(Fields inputFields, Aggregator agg, Fields functionFields) ChainedAggregatorDeclarer.partitionAggregate
(Fields inputFields, CombinerAggregator agg, Fields functionFields) ChainedAggregatorDeclarer.partitionAggregate
(Fields inputFields, ReducerAggregator agg, Fields functionFields) ChainedPartitionAggregatorDeclarer.partitionAggregate
(Aggregator agg, Fields functionFields) ChainedPartitionAggregatorDeclarer.partitionAggregate
(CombinerAggregator agg, Fields functionFields) ChainedPartitionAggregatorDeclarer.partitionAggregate
(ReducerAggregator agg, Fields functionFields) ChainedPartitionAggregatorDeclarer.partitionAggregate
(Fields inputFields, Aggregator agg, Fields functionFields) ChainedPartitionAggregatorDeclarer.partitionAggregate
(Fields inputFields, CombinerAggregator agg, Fields functionFields) ChainedPartitionAggregatorDeclarer.partitionAggregate
(Fields inputFields, ReducerAggregator agg, Fields functionFields) GroupedStream.partitionAggregate
(Fields inputFields, Aggregator agg, Fields functionFields) IAggregatableStream.partitionAggregate
(Fields inputFields, Aggregator agg, Fields functionFields) GroupedStream.persistentAggregate
(StateFactory stateFactory, CombinerAggregator agg, Fields functionFields) GroupedStream.persistentAggregate
(StateFactory stateFactory, ReducerAggregator agg, Fields functionFields) GroupedStream.persistentAggregate
(StateFactory stateFactory, Fields inputFields, CombinerAggregator agg, Fields functionFields) GroupedStream.persistentAggregate
(StateFactory stateFactory, Fields inputFields, ReducerAggregator agg, Fields functionFields) GroupedStream.persistentAggregate
(StateSpec spec, CombinerAggregator agg, Fields functionFields) GroupedStream.persistentAggregate
(StateSpec spec, ReducerAggregator agg, Fields functionFields) GroupedStream.persistentAggregate
(StateSpec spec, Fields inputFields, CombinerAggregator agg, Fields functionFields) GroupedStream.persistentAggregate
(StateSpec spec, Fields inputFields, ReducerAggregator agg, Fields functionFields) GroupedStream.stateQuery
(TridentState state, QueryFunction function, Fields functionFields) GroupedStream.stateQuery
(TridentState state, Fields inputFields, QueryFunction function, Fields functionFields) -
Uses of Fields in org.apache.storm.trident.operation
Modifier and TypeMethodDescriptionTridentMultiReducerContext.makeProjectionFactory
(int streamIndex, Fields fields) TridentOperationContext.makeProjectionFactory
(Fields fields) -
Uses of Fields in org.apache.storm.trident.operation.impl
ModifierConstructorDescriptionChainedAggregatorImpl
(Aggregator[] aggs, Fields[] inputFields, ComboList.Factory fact) GroupedAggregator
(Aggregator agg, Fields group, Fields input, int outSize) ModifierConstructorDescriptionGroupedMultiReducerExecutor
(GroupedMultiReducer reducer, List<Fields> groupFields, List<Fields> inputFields) -
Uses of Fields in org.apache.storm.trident.planner
ModifierConstructorDescriptionInitialReceiver
(String stream, Fields allFields) PartitionNode
(String streamId, String name, Fields allOutputFields, Grouping grouping) ProcessorNode
(String streamId, String name, Fields allOutputFields, Fields selfOutFields, TridentProcessor processor) SpoutNode
(String streamId, Fields allOutputFields, String txid, Object spout, SpoutNode.SpoutType type) -
Uses of Fields in org.apache.storm.trident.planner.processor
ModifierConstructorDescriptionAggregateProcessor
(Fields inputFields, Aggregator agg) EachProcessor
(Fields inputFields, Function function) MapProcessor
(Fields inputFields, Function function) PartitionPersistProcessor
(String stateId, Fields inputFields, StateUpdater updater) ProjectedProcessor
(Fields projectFields) StateQueryProcessor
(String stateId, Fields inputFields, QueryFunction function) TridentContext
(Fields selfFields, List<TridentTuple.Factory> parentFactories, List<String> parentStreams, List<TupleReceiver> receivers, String outStreamId, int stateIndex, BatchOutputCollector collector) ModifierConstructorDescriptionMultiReducerProcessor
(List<Fields> inputFields, MultiReducer reducer) -
Uses of Fields in org.apache.storm.trident.spout
Modifier and TypeMethodDescriptionBatchSpoutExecutor.getOutputFields()
IBatchSpout.getOutputFields()
IOpaquePartitionedTridentSpout.getOutputFields()
IPartitionedTridentSpout.getOutputFields()
ITridentSpout.getOutputFields()
OpaquePartitionedTridentSpoutExecutor.getOutputFields()
PartitionedTridentSpoutExecutor.getOutputFields()
RichSpoutBatchExecutor.getOutputFields()
-
Uses of Fields in org.apache.storm.trident.state.map
ModifierConstructorDescriptionMapCombinerAggStateUpdater
(CombinerAggregator agg, Fields groupFields, Fields inputFields) MapReducerAggStateUpdater
(ReducerAggregator agg, Fields groupFields, Fields inputFields) -
Uses of Fields in org.apache.storm.trident.testing
Modifier and TypeMethodDescriptionFeederBatchSpout.getOutputFields()
FeederCommitterBatchSpout.getOutputFields()
FixedBatchSpout.getOutputFields()
ModifierConstructorDescriptionFixedBatchSpout
(Fields fields, int maxBatchSize, List<Object>... outputs) -
Uses of Fields in org.apache.storm.trident.tuple
Modifier and TypeMethodDescriptionstatic ValuePointer[]
ValuePointer.buildIndex
(Fields fieldsOrder, Map<String, ValuePointer> pointers) static TridentTuple
TridentTupleView.createFreshTuple
(Fields fields, Object... values) static TridentTuple
TridentTupleView.createFreshTuple
(Fields fields, List<Object> values) ModifierConstructorDescriptionFreshOutputFactory
(Fields selfFields) OperationOutputFactory
(TridentTuple.Factory parent, Fields selfFields) ProjectionFactory
(TridentTuple.Factory parent, Fields projectFields) RootFactory
(Fields inputFields) -
Uses of Fields in org.apache.storm.trident.util
Modifier and TypeMethodDescriptionstatic Fields
TridentUtils.fieldsConcat
(Fields... fields) static Fields
TridentUtils.fieldsSubtract
(Fields all, Fields minus) static Fields
TridentUtils.fieldsUnion
(Fields... fields) static Fields
TridentUtils.getSingleOutputStreamFields
(IComponent component) Modifier and TypeMethodDescriptionstatic Fields
TridentUtils.fieldsConcat
(Fields... fields) static Fields
TridentUtils.fieldsSubtract
(Fields all, Fields minus) static Fields
TridentUtils.fieldsUnion
(Fields... fields) -
Uses of Fields in org.apache.storm.trident.windowing
ModifierConstructorDescriptionStoreBasedTridentWindowManager
(WindowConfig windowConfig, String windowTaskId, WindowsStore windowStore, Aggregator aggregator, BatchOutputCollector delegateCollector, Long maxTuplesCacheSize, Fields inputFields) WindowTridentProcessor
(WindowConfig windowConfig, String uniqueWindowId, WindowsStoreFactory windowStoreFactory, Fields inputFields, Aggregator aggregator, boolean storeTuplesInStore) -
Uses of Fields in org.apache.storm.tuple
Modifier and TypeMethodDescriptionITuple.getFields()
Gets the names of the fields in this tuple.TupleImpl.getFields()
Modifier and TypeMethodDescriptionSelect values out of tuple given a Fields selector Note that this function can throw a NullPointerException if the fields in selector are not found in the index.Returns a subset of the tuple based on the fields selector.