Uses of Class
org.apache.storm.trident.Stream
Package
Description
-
Uses of Stream in org.apache.storm.trident
Modifier and TypeMethodDescriptionprotected Stream
Stream.addSharedMemory
(SharedMemory request) protected Stream
TridentTopology.addSourcedNode
(List<Stream> sources, Node newNode) protected Stream
TridentTopology.addSourcedNode
(Stream source, Node newNode) Stream.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) Stream.applyAssembly
(Assembly assembly) Applies an `Assembly` to this `Stream`.Stream.batchGlobal()
## Repartitioning Operation.Stream.broadcast()
## Repartitioning Operation.Returns a stream consisting of the elements of this stream that match the given filter.Returns a stream consisting of the elements of this stream that match the given filter.Stream.flatMap
(FlatMapFunction function) 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.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.Stream.global()
## Repartitioning Operation.Stream.identityPartition()
## Repartitioning 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.localOrShuffle()
## Repartitioning Operation.Stream.map
(MapFunction function) Returns a stream consisting of the result of applying the given mapping function to the values of this 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.max
(Comparator<TridentTuple> comparator) This aggregator operation computes the maximum of tuples in a stream by using the givencomparator
withTridentTuple
s.This aggregator operation computes the maximum of tuples by the giveninputFieldName
and it is assumed that its value is an instance ofComparable
.<T> Stream
Stream.maxBy
(String inputFieldName, Comparator<T> comparator) This aggregator operation computes the maximum of tuples by the giveninputFieldName
in a stream by using the givencomparator
.Stream.min
(Comparator<TridentTuple> comparator) This aggregator operation computes the minimum of tuples in a stream by using the givencomparator
withTridentTuple
s.This aggregator operation computes the minimum of tuples by the giveninputFieldName
and it is assumed that its value is an instance ofComparable
.<T> Stream
Stream.minBy
(String inputFieldName, Comparator<T> comparator) This aggregator operation computes the minimum of tuples by the giveninputFieldName
in a stream by using the givencomparator
.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) Applies a label to the stream.TridentTopology.newDRPCStream
(String function) TridentTopology.newDRPCStream
(String function, ILocalDRPC server) TridentTopology.newStream
(String txId, IRichSpout spout) TridentTopology.newStream
(String txId, IBatchSpout spout) TridentTopology.newStream
(String txId, IOpaquePartitionedTridentSpout spout) TridentTopology.newStream
(String txId, IPartitionedTridentSpout spout) TridentTopology.newStream
(String txId, ITridentDataSource dataSource) TridentTopology.newStream
(String txId, ITridentSpout spout) TridentState.newValuesStream()
Stream.parallelismHint
(int hint) Applies a parallelism hint to a stream.## Repartitioning Operation.Stream.partition
(CustomStreamGrouping partitioner) ## Repartitioning Operation.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.Returns a stream consisting of the trident tuples of this stream, additionally performing the provided action on each trident tuple as they are consumed from the resulting stream.Filters out fields from a stream, resulting in a Stream containing only the fields specified by `keepFields`.Stream.setCPULoad
(Number load) Sets the CPU Load resource for the current operation.Stream.setMemoryLoad
(Number onHeap) Sets the Memory Load resources for the current operation. offHeap becomes default.Stream.setMemoryLoad
(Number onHeap, Number offHeap) Sets the Memory Load resources for the current operation.Stream.shuffle()
## Repartitioning Operation.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.toStream()
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 TypeMethodDescriptionprotected Stream
TridentTopology.addSourcedNode
(Stream source, Node newNode) protected TridentState
TridentTopology.addSourcedStateNode
(Stream source, Node newNode) 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) TridentTopology.multiReduce
(Stream s1, Stream s2, MultiReducer function, Fields outputFields) TridentTopology.multiReduce
(Fields inputFields1, Stream s1, Fields inputFields2, Stream s2, MultiReducer function, Fields outputFields) Modifier and TypeMethodDescriptionprotected Stream
TridentTopology.addSourcedNode
(List<Stream> sources, Node newNode) protected TridentState
TridentTopology.addSourcedStateNode
(List<Stream> sources, Node newNode) 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.multiReduce
(List<Stream> streams, MultiReducer function, Fields outputFields) protected void
TridentTopology.registerSourcedNode
(List<Stream> sources, Node newNode) -
Uses of Stream in org.apache.storm.trident.fluent
Modifier and TypeMethodDescriptionGroupedStream.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.chainEnd()
IChainedAggregatorDeclarer.chainEnd()
GroupedStream.stateQuery
(TridentState state, QueryFunction function, Fields functionFields) GroupedStream.stateQuery
(TridentState state, Fields inputFields, QueryFunction function, Fields functionFields) GroupedStream.toStream()
IAggregatableStream.toStream()
Modifier and TypeMethodDescription -
Uses of Stream in org.apache.storm.trident.operation
-
Uses of Stream in org.apache.storm.trident.operation.builtin