Uses of Class
org.apache.storm.tuple.Fields
-
-
Uses of Fields in org.apache.storm.daemon
Methods in org.apache.storm.daemon with parameters of type Fields Modifier and Type Method Description static LoadAwareCustomStreamGrouping
GrouperFactory. mkGrouper(WorkerTopologyContext context, String componentId, String streamId, Fields outFields, Grouping thriftGrouping, List<Integer> unsortedTargetTasks, Map<String,Object> topoConf)
Constructors in org.apache.storm.daemon with parameters of type Fields Constructor Description FieldsGrouper(Fields outFields, Grouping thriftGrouping)
-
Uses of Fields in org.apache.storm.daemon.worker
Methods in org.apache.storm.daemon.worker that return types with arguments of type Fields Modifier and Type Method Description Map<String,Map<String,Fields>>
WorkerState. getComponentToStreamToFields()
-
Uses of Fields in org.apache.storm.drpc
Methods in org.apache.storm.drpc with parameters of type Fields Modifier and Type Method Description LinearDRPCInputDeclarer
LinearDRPCInputDeclarer. fieldsGrouping(String streamId, Fields fields)
LinearDRPCInputDeclarer
LinearDRPCInputDeclarer. fieldsGrouping(Fields fields)
LinearDRPCInputDeclarer
LinearDRPCInputDeclarer. partialKeyGrouping(String streamId, Fields fields)
LinearDRPCInputDeclarer
LinearDRPCInputDeclarer. partialKeyGrouping(Fields fields)
-
Uses of Fields in org.apache.storm.flux.examples
Methods in org.apache.storm.flux.examples that return Fields Modifier and Type Method Description Fields
OnlyValueRecordTranslator. getFieldsFor(String stream)
-
Uses of Fields in org.apache.storm.grouping
Constructors in org.apache.storm.grouping with parameters of type Fields Constructor Description PartialKeyGrouping(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
Methods in org.apache.storm.hdfs.bolt.format with parameters of type Fields Modifier and Type Method Description DelimitedRecordFormat
DelimitedRecordFormat. withFields(Fields fields)
Only output the specified fields. -
Uses of Fields in org.apache.storm.hdfs.trident
Methods in org.apache.storm.hdfs.trident that return Fields Modifier and Type Method Description Fields
FixedBatchSpout. getOutputFields()
Constructors in org.apache.storm.hdfs.trident with parameters of type Fields Constructor Description FixedBatchSpout(Fields fields, int maxBatchSize, List<Object>... outputs)
-
Uses of Fields in org.apache.storm.hdfs.trident.format
Methods in org.apache.storm.hdfs.trident.format with parameters of type Fields Modifier and Type Method Description DelimitedRecordFormat
DelimitedRecordFormat. withFields(Fields fields)
Only output the specified fields. -
Uses of Fields in org.apache.storm.hive.bolt.mapper
Methods in org.apache.storm.hive.bolt.mapper with parameters of type Fields Modifier and Type Method Description DelimitedRecordHiveMapper
DelimitedRecordHiveMapper. withColumnFields(Fields columnFields)
Deprecated, for removal: This API element is subject to removal in a future version.JsonRecordHiveMapper
JsonRecordHiveMapper. withColumnFields(Fields columnFields)
Deprecated, for removal: This API element is subject to removal in a future version.DelimitedRecordHiveMapper
DelimitedRecordHiveMapper. withPartitionFields(Fields partitionFields)
Deprecated, for removal: This API element is subject to removal in a future version.JsonRecordHiveMapper
JsonRecordHiveMapper. withPartitionFields(Fields partitionFields)
Deprecated, for removal: This API element is subject to removal in a future version. -
Uses of Fields in org.apache.storm.hive.trident
Methods in org.apache.storm.hive.trident that return Fields Modifier and Type Method Description Fields
TridentHiveTopology.FixedBatchSpout. getOutputFields()
-
Uses of Fields in org.apache.storm.jdbc.mapper
Constructors in org.apache.storm.jdbc.mapper with parameters of type Fields Constructor Description SimpleJdbcLookupMapper(Fields outputFields, List<Column> queryColumns)
-
Uses of Fields in org.apache.storm.jms.example
Constructors in org.apache.storm.jms.example with parameters of type Fields Constructor Description GenericBolt(String name, boolean autoAck, boolean autoAnchor, Fields declaredFields)
Constructs a newGenericBolt
instance. -
Uses of Fields in org.apache.storm.jms.trident
Methods in org.apache.storm.jms.trident that return Fields Modifier and Type Method Description Fields
TridentJmsSpout. getOutputFields()
-
Uses of Fields in org.apache.storm.kafka.spout
Fields in org.apache.storm.kafka.spout declared as Fields Modifier and Type Field Description static Fields
DefaultRecordTranslator. FIELDS
Methods in org.apache.storm.kafka.spout that return Fields Modifier and Type Method Description Fields
ByTopicRecordTranslator. getFieldsFor(String stream)
Fields
DefaultRecordTranslator. getFieldsFor(String stream)
Fields
RecordTranslator. getFieldsFor(String stream)
Get the fields associated with a stream.Fields
SimpleRecordTranslator. getFieldsFor(String stream)
Methods in org.apache.storm.kafka.spout with parameters of type Fields Modifier and Type Method Description ByTopicRecordTranslator<K,V>
ByTopicRecordTranslator. 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<K,V>
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.Constructors in org.apache.storm.kafka.spout with parameters of type Fields Constructor Description ByTopicRecordTranslator(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
Methods in org.apache.storm.kafka.spout.internal with parameters of type Fields Modifier and Type Method Description T
CommonKafkaSpoutConfig.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.T
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
Methods in org.apache.storm.kafka.spout.trident that return Fields Modifier and Type Method Description Fields
KafkaTridentSpoutOpaque. getOutputFields()
Fields
KafkaTridentSpoutTransactional. getOutputFields()
-
Uses of Fields in org.apache.storm.kafka.spout.trident.internal
Methods in org.apache.storm.kafka.spout.trident.internal that return Fields Modifier and Type Method Description <K,V>
FieldsOutputFieldsExtractor. getOutputFields(KafkaTridentSpoutConfig<K,V> kafkaSpoutConfig)
Extract the output fields from the config. -
Uses of Fields in org.apache.storm.spout
Methods in org.apache.storm.spout that return Fields Modifier and Type Method Description Fields
MultiScheme. getOutputFields()
Fields
RawMultiScheme. getOutputFields()
Fields
RawScheme. getOutputFields()
Fields
Scheme. getOutputFields()
Fields
SchemeAsMultiScheme. getOutputFields()
-
Uses of Fields in org.apache.storm.sql.kafka
Methods in org.apache.storm.sql.kafka that return Fields Modifier and Type Method Description Fields
RecordTranslatorSchemeAdapter. getFieldsFor(String stream)
-
Uses of Fields in org.apache.storm.sql.runtime.serde.avro
Methods in org.apache.storm.sql.runtime.serde.avro that return Fields Modifier and Type Method Description Fields
AvroScheme. getOutputFields()
-
Uses of Fields in org.apache.storm.sql.runtime.serde.csv
Methods in org.apache.storm.sql.runtime.serde.csv that return Fields Modifier and Type Method Description Fields
CsvScheme. getOutputFields()
-
Uses of Fields in org.apache.storm.sql.runtime.serde.json
Methods in org.apache.storm.sql.runtime.serde.json that return Fields Modifier and Type Method Description Fields
JsonScheme. getOutputFields()
-
Uses of Fields in org.apache.storm.sql.runtime.serde.tsv
Methods in org.apache.storm.sql.runtime.serde.tsv that return Fields Modifier and Type Method Description Fields
TsvScheme. getOutputFields()
-
Uses of Fields in org.apache.storm.st.topology.window.data
Methods in org.apache.storm.st.topology.window.data that return Fields Modifier and Type Method Description static Fields
TimeData. getFields()
-
Uses of Fields in org.apache.storm.starter.bolt
Constructors in org.apache.storm.starter.bolt with parameters of type Fields Constructor Description SingleJoinBolt(Fields outFields)
-
Uses of Fields in org.apache.storm.starter.spout
Methods in org.apache.storm.starter.spout that return Fields Modifier and Type Method Description Fields
RandomNumberGeneratorSpout. getOutputFields()
Constructors in org.apache.storm.starter.spout with parameters of type Fields Constructor Description RandomNumberGeneratorSpout(Fields fields, int batchSize, int maxNumber)
-
Uses of Fields in org.apache.storm.streams
Fields in org.apache.storm.streams declared as Fields Modifier and Type Field Description protected static Fields
Stream. KEY
protected static Fields
Stream. KEY_VALUE
protected Fields
Node. outputFields
protected Fields
Node. outputFields
protected static Fields
Stream. VALUE
Methods in org.apache.storm.streams that return Fields Modifier and Type Method Description static Fields
StreamUtil. getPunctuationFields()
Methods in org.apache.storm.streams with parameters of type Fields Modifier and Type Method Description protected Stream<T>
Stream. partitionBy(Fields fields, int parallelism)
Constructors in org.apache.storm.streams with parameters of type Fields Constructor Description ProcessorNode(Processor<?> processor, String outputStream, Fields outputFields)
ProcessorNode(Processor<?> processor, String outputStream, Fields outputFields, boolean preservesKey)
-
Uses of Fields in org.apache.storm.task
Methods in org.apache.storm.task that return Fields Modifier and Type Method Description Fields
GeneralTopologyContext. getComponentOutputFields(String componentId, String streamId)
Gets the declared output fields for the specified component/stream.Fields
GeneralTopologyContext. getComponentOutputFields(GlobalStreamId id)
Gets the declared output fields for the specified global stream id.Fields
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
Methods in org.apache.storm.testing that return Fields Modifier and Type Method Description Fields
TestEventOrderCheckBolt. getOutputFields()
Fields
TestGlobalCount. getOutputFields()
Fields
TestPlannerBolt. getOutputFields()
Fields
TestPlannerSpout. getOutputFields()
Constructors in org.apache.storm.testing with parameters of type Fields Constructor Description FeederSpout(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
Methods in org.apache.storm.topology with parameters of type Fields Modifier and Type Method Description void
OutputFieldsDeclarer. declare(boolean direct, Fields fields)
void
OutputFieldsDeclarer. declare(Fields fields)
Uses default stream id.void
OutputFieldsGetter. declare(boolean direct, Fields fields)
void
OutputFieldsGetter. declare(Fields fields)
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)
T
InputDeclarer. fieldsGrouping(String componentId, String streamId, Fields fields)
The stream is partitioned by the fields specified in the grouping.T
InputDeclarer. fieldsGrouping(String componentId, Fields fields)
The stream is partitioned by the fields specified in the grouping.BoltDeclarer
TopologyBuilder.BoltGetter. fieldsGrouping(String componentId, String streamId, Fields fields)
BoltDeclarer
TopologyBuilder.BoltGetter. fieldsGrouping(String componentId, Fields fields)
T
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.T
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.BoltDeclarer
TopologyBuilder.BoltGetter. partialKeyGrouping(String componentId, String streamId, Fields fields)
BoltDeclarer
TopologyBuilder.BoltGetter. partialKeyGrouping(String componentId, Fields fields)
-
Uses of Fields in org.apache.storm.trident
Methods in org.apache.storm.trident that return Fields Modifier and Type Method Description Fields
Stream. getOutputFields()
Methods in org.apache.storm.trident with parameters of type Fields Modifier and Type Method Description Stream
Stream. aggregate(Aggregator agg, Fields functionFields)
Stream
Stream. aggregate(CombinerAggregator agg, Fields functionFields)
Stream
Stream. aggregate(ReducerAggregator agg, Fields functionFields)
Stream
Stream. aggregate(Fields inputFields, Aggregator agg, Fields functionFields)
Stream
Stream. aggregate(Fields inputFields, CombinerAggregator agg, Fields functionFields)
Stream
Stream. aggregate(Fields inputFields, ReducerAggregator agg, Fields functionFields)
Stream
Stream. each(Function function, Fields functionFields)
Stream
Stream. each(Fields inputFields, Filter filter)
Stream
Stream. each(Fields inputFields, Function function, Fields functionFields)
Stream
Stream. filter(Fields inputFields, Filter filter)
Returns a stream consisting of the elements of this stream that match the given filter.Stream
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.GroupedStream
Stream. groupBy(Fields fields)
## Grouping Operation.Stream
TridentTopology. join(List<Stream> streams, List<Fields> joinFields, Fields outFields)
Stream
TridentTopology. join(List<Stream> streams, List<Fields> joinFields, Fields outFields, List<JoinType> mixed)
Stream
TridentTopology. join(List<Stream> streams, List<Fields> joinFields, Fields outFields, List<JoinType> mixed, JoinOutFieldsMode mode)
Stream
TridentTopology. join(List<Stream> streams, List<Fields> joinFields, Fields outFields, JoinOutFieldsMode mode)
Stream
TridentTopology. join(List<Stream> streams, List<Fields> joinFields, Fields outFields, JoinType type)
Stream
TridentTopology. join(List<Stream> streams, List<Fields> joinFields, Fields outFields, JoinType type, JoinOutFieldsMode mode)
Stream
TridentTopology. join(Stream s1, Fields joinFields1, Stream s2, Fields joinFields2, Fields outFields)
Stream
TridentTopology. join(Stream s1, Fields joinFields1, Stream s2, Fields joinFields2, Fields outFields, List<JoinType> mixed)
Stream
TridentTopology. join(Stream s1, Fields joinFields1, Stream s2, Fields joinFields2, Fields outFields, List<JoinType> mixed, JoinOutFieldsMode mode)
Stream
TridentTopology. join(Stream s1, Fields joinFields1, Stream s2, Fields joinFields2, Fields outFields, JoinOutFieldsMode mode)
Stream
TridentTopology. join(Stream s1, Fields joinFields1, Stream s2, Fields joinFields2, Fields outFields, JoinType type)
Stream
TridentTopology. join(Stream s1, Fields joinFields1, Stream s2, Fields joinFields2, Fields outFields, JoinType type, JoinOutFieldsMode mode)
Stream
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.Stream
TridentTopology. merge(Fields outputFields, List<Stream> streams)
Stream
TridentTopology. merge(Fields outputFields, Stream... streams)
Stream
TridentTopology. multiReduce(List<GroupedStream> streams, GroupedMultiReducer function, Fields outputFields)
Stream
TridentTopology. multiReduce(List<Stream> streams, MultiReducer function, Fields outputFields)
Stream
TridentTopology. multiReduce(List<Fields> inputFields, List<GroupedStream> groupedStreams, GroupedMultiReducer function, Fields outputFields)
Stream
TridentTopology. multiReduce(List<Fields> inputFields, List<Stream> streams, MultiReducer function, Fields outputFields)
Stream
TridentTopology. multiReduce(GroupedStream s1, GroupedStream s2, GroupedMultiReducer function, Fields outputFields)
Stream
TridentTopology. multiReduce(Stream s1, Stream s2, MultiReducer function, Fields outputFields)
Stream
TridentTopology. multiReduce(Fields inputFields1, GroupedStream s1, Fields inputFields2, GroupedStream s2, GroupedMultiReducer function, Fields outputFields)
Stream
TridentTopology. multiReduce(Fields inputFields1, Stream s1, Fields inputFields2, Stream s2, MultiReducer function, Fields outputFields)
Stream
Stream. partitionAggregate(Aggregator agg, Fields functionFields)
Stream
Stream. partitionAggregate(CombinerAggregator agg, Fields functionFields)
Stream
Stream. partitionAggregate(ReducerAggregator agg, Fields functionFields)
Stream
Stream. partitionAggregate(Fields inputFields, Aggregator agg, Fields functionFields)
Stream
Stream. partitionAggregate(Fields inputFields, CombinerAggregator agg, Fields functionFields)
Stream
Stream. partitionAggregate(Fields inputFields, ReducerAggregator agg, Fields functionFields)
Stream
Stream. partitionBy(Fields fields)
## Repartitioning Operation.TridentState
Stream. partitionPersist(StateFactory stateFactory, StateUpdater updater, Fields functionFields)
TridentState
Stream. partitionPersist(StateFactory stateFactory, Fields inputFields, StateUpdater updater)
TridentState
Stream. partitionPersist(StateFactory stateFactory, Fields inputFields, StateUpdater updater, Fields functionFields)
TridentState
Stream. partitionPersist(StateSpec stateSpec, StateUpdater updater, Fields functionFields)
TridentState
Stream. partitionPersist(StateSpec stateSpec, Fields inputFields, StateUpdater updater)
TridentState
Stream. partitionPersist(StateSpec stateSpec, Fields inputFields, StateUpdater updater, Fields functionFields)
TridentState
Stream. persistentAggregate(StateFactory stateFactory, CombinerAggregator agg, Fields functionFields)
TridentState
Stream. persistentAggregate(StateFactory stateFactory, ReducerAggregator agg, Fields functionFields)
TridentState
Stream. persistentAggregate(StateFactory stateFactory, Fields inputFields, CombinerAggregator agg, Fields functionFields)
TridentState
Stream. persistentAggregate(StateFactory stateFactory, Fields inputFields, ReducerAggregator agg, Fields functionFields)
TridentState
Stream. persistentAggregate(StateSpec spec, CombinerAggregator agg, Fields functionFields)
TridentState
Stream. persistentAggregate(StateSpec spec, ReducerAggregator agg, Fields functionFields)
TridentState
Stream. persistentAggregate(StateSpec spec, Fields inputFields, CombinerAggregator agg, Fields functionFields)
TridentState
Stream. persistentAggregate(StateSpec spec, Fields inputFields, ReducerAggregator agg, Fields functionFields)
Stream
Stream. project(Fields keepFields)
Filters out fields from a stream, resulting in a Stream containing only the fields specified by `keepFields`.Stream
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
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
Stream. stateQuery(TridentState state, QueryFunction function, Fields functionFields)
Stream
Stream. stateQuery(TridentState state, Fields inputFields, QueryFunction function, Fields functionFields)
Stream
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
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
Stream. window(WindowConfig windowConfig, WindowsStoreFactory windowStoreFactory, Fields inputFields, Aggregator aggregator, Fields functionFields)
Returns stream of aggregated results based on the given window configuration.Stream
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.Method parameters in org.apache.storm.trident with type arguments of type Fields Modifier and Type Method Description Stream
TridentTopology. multiReduce(List<Fields> inputFields, List<GroupedStream> groupedStreams, GroupedMultiReducer function, Fields outputFields)
Stream
TridentTopology. multiReduce(List<Fields> inputFields, List<Stream> streams, MultiReducer function, Fields outputFields)
-
Uses of Fields in org.apache.storm.trident.fluent
Methods in org.apache.storm.trident.fluent that return Fields Modifier and Type Method Description Fields
GroupedStream. getGroupFields()
Fields
GroupedStream. getOutputFields()
Fields
IAggregatableStream. getOutputFields()
Constructors in org.apache.storm.trident.fluent with parameters of type Fields Constructor Description GroupedStream(Stream stream, Fields groupFields)
-
Uses of Fields in org.apache.storm.trident.operation
Methods in org.apache.storm.trident.operation with parameters of type Fields Modifier and Type Method Description TridentTupleView.ProjectionFactory
TridentMultiReducerContext. makeProjectionFactory(int streamIndex, Fields fields)
TridentTupleView.ProjectionFactory
TridentOperationContext. makeProjectionFactory(Fields fields)
-
Uses of Fields in org.apache.storm.trident.operation.impl
Constructors in org.apache.storm.trident.operation.impl with parameters of type Fields Constructor Description ChainedAggregatorImpl(Aggregator[] aggs, Fields[] inputFields, ComboList.Factory fact)
GroupedAggregator(Aggregator agg, Fields group, Fields input, int outSize)
Constructor parameters in org.apache.storm.trident.operation.impl with type arguments of type Fields Constructor Description GroupedMultiReducerExecutor(GroupedMultiReducer reducer, List<Fields> groupFields, List<Fields> inputFields)
-
Uses of Fields in org.apache.storm.trident.planner
Fields in org.apache.storm.trident.planner declared as Fields Modifier and Type Field Description Fields
Node. allOutputFields
Fields
ProcessorNode. selfOutFields
Constructors in org.apache.storm.trident.planner with parameters of type Fields Constructor Description InitialReceiver(String stream, Fields allFields)
Node(String streamId, String name, Fields allOutputFields)
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
Methods in org.apache.storm.trident.planner.processor that return Fields Modifier and Type Method Description Fields
TridentContext. getSelfOutputFields()
Constructors in org.apache.storm.trident.planner.processor with parameters of type Fields Constructor Description AggregateProcessor(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)
Constructor parameters in org.apache.storm.trident.planner.processor with type arguments of type Fields Constructor Description MultiReducerProcessor(List<Fields> inputFields, MultiReducer reducer)
-
Uses of Fields in org.apache.storm.trident.spout
Methods in org.apache.storm.trident.spout that return Fields Modifier and Type Method Description Fields
BatchSpoutExecutor. getOutputFields()
Fields
IBatchSpout. getOutputFields()
Fields
IOpaquePartitionedTridentSpout. getOutputFields()
Fields
IPartitionedTridentSpout. getOutputFields()
Fields
ITridentSpout. getOutputFields()
Fields
OpaquePartitionedTridentSpoutExecutor. getOutputFields()
Fields
PartitionedTridentSpoutExecutor. getOutputFields()
Fields
RichSpoutBatchExecutor. getOutputFields()
-
Uses of Fields in org.apache.storm.trident.state.map
Constructors in org.apache.storm.trident.state.map with parameters of type Fields Constructor Description MapCombinerAggStateUpdater(CombinerAggregator agg, Fields groupFields, Fields inputFields)
MapReducerAggStateUpdater(ReducerAggregator agg, Fields groupFields, Fields inputFields)
-
Uses of Fields in org.apache.storm.trident.testing
Methods in org.apache.storm.trident.testing that return Fields Modifier and Type Method Description Fields
FeederBatchSpout. getOutputFields()
Fields
FeederCommitterBatchSpout. getOutputFields()
Fields
FixedBatchSpout. getOutputFields()
Constructors in org.apache.storm.trident.testing with parameters of type Fields Constructor Description FixedBatchSpout(Fields fields, int maxBatchSize, List<Object>... outputs)
-
Uses of Fields in org.apache.storm.trident.tuple
Methods in org.apache.storm.trident.tuple that return Fields Modifier and Type Method Description Fields
TridentTupleView. getFields()
Methods in org.apache.storm.trident.tuple with parameters of type Fields Modifier and Type Method Description static 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)
List<Object>
TridentTupleView. select(Fields selector)
Constructors in org.apache.storm.trident.tuple with parameters of type Fields Constructor Description FreshOutputFactory(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
Methods in org.apache.storm.trident.util that return Fields Modifier and Type Method Description static 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)
Methods in org.apache.storm.trident.util with parameters of type Fields Modifier and Type Method Description static 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
Constructors in org.apache.storm.trident.windowing with parameters of type Fields Constructor Description StoreBasedTridentWindowManager(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
Methods in org.apache.storm.tuple that return Fields Modifier and Type Method Description Fields
ITuple. getFields()
Gets the names of the fields in this tuple.Fields
TupleImpl. getFields()
Methods in org.apache.storm.tuple with parameters of type Fields Modifier and Type Method Description List<Object>
Fields. select(Fields selector, List<Object> tuple)
Select 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.List<Object>
ITuple. select(Fields selector)
Returns a subset of the tuple based on the fields selector.List<Object>
TupleImpl. select(Fields selector)
-