Modifier and Type | Method and Description |
---|---|
void |
CassandraQuery.execute(TridentTuple tuple,
List<Values> valuesList,
TridentCollector collector) |
Modifier and Type | Method and Description |
---|---|
List<List<Values>> |
CassandraQuery.batchRetrieve(CassandraState state,
List<TridentTuple> tridentTuples) |
List<List<Values>> |
CassandraState.batchRetrieve(List<TridentTuple> tridentTuples) |
void |
CassandraStateUpdater.updateState(CassandraState state,
List<TridentTuple> list,
TridentCollector collector) |
void |
CassandraState.updateState(List<TridentTuple> tuples,
TridentCollector collector) |
Modifier and Type | Method and Description |
---|---|
void |
EsUpdater.updateState(org.apache.storm.elasticsearch.trident.EsState state,
List<TridentTuple> tuples,
TridentCollector collector)
Each tuple should have relevant fields (source, index, type, id) for EsState’s tupleMapper to extract ES document.
|
Modifier and Type | Method and Description |
---|---|
void |
PrintFunction.execute(TridentTuple tuple,
TridentCollector tridentCollector) |
Modifier and Type | Method and Description |
---|---|
ColumnList |
SimpleTridentHBaseMapper.columns(TridentTuple tuple) |
ColumnList |
TridentHBaseMapper.columns(TridentTuple tuple)
Given a tuple, return a list of HBase columns to insert.
|
byte[] |
SimpleTridentHBaseMapper.rowKey(TridentTuple tuple) |
byte[] |
TridentHBaseMapper.rowKey(TridentTuple tuple)
Given a tuple, return the HBase rowkey.
|
Modifier and Type | Method and Description |
---|---|
void |
HBaseQuery.execute(TridentTuple tuples,
List<Values> values,
TridentCollector tridentCollector) |
Modifier and Type | Method and Description |
---|---|
List<List<Values>> |
HBaseQuery.batchRetrieve(HBaseState hBaseState,
List<TridentTuple> tridentTuples) |
List<List<Values>> |
HBaseState.batchRetrieve(List<TridentTuple> tridentTuples) |
void |
HBaseUpdater.updateState(HBaseState hBaseState,
List<TridentTuple> tuples,
TridentCollector collector) |
void |
HBaseState.updateState(List<TridentTuple> tuples,
TridentCollector collector) |
Modifier and Type | Method and Description |
---|---|
void |
HdfsState.HdfsFileOptions.execute(List<TridentTuple> tuples) |
void |
HdfsState.SequenceFileOptions.execute(List<TridentTuple> tuples) |
void |
HdfsUpdater.updateState(HdfsState state,
List<TridentTuple> tuples,
TridentCollector collector) |
void |
HdfsState.updateState(List<TridentTuple> tuples,
TridentCollector tridentCollector) |
Modifier and Type | Method and Description |
---|---|
byte[] |
DelimitedRecordFormat.format(TridentTuple tuple) |
byte[] |
RecordFormat.format(TridentTuple tuple) |
org.apache.hadoop.io.Writable |
DefaultSequenceFormat.key(TridentTuple tuple) |
org.apache.hadoop.io.Writable |
SequenceFormat.key(TridentTuple tuple)
Given a tuple, return the key that should be written to the sequence file.
|
org.apache.hadoop.io.Writable |
DefaultSequenceFormat.value(TridentTuple tuple) |
org.apache.hadoop.io.Writable |
SequenceFormat.value(TridentTuple tuple)
Given a tuple, return the value that should be written to the sequence file.
|
Modifier and Type | Method and Description |
---|---|
boolean |
TimedRotationPolicy.mark(TridentTuple tuple,
long offset)
Called for every tuple the HdfsBolt executes.
|
boolean |
NoRotationPolicy.mark(TridentTuple tuple,
long offset) |
boolean |
FileRotationPolicy.mark(TridentTuple tuple,
long offset)
Called for every tuple the HdfsBolt executes.
|
boolean |
FileSizeRotationPolicy.mark(TridentTuple tuple,
long offset) |
Modifier and Type | Method and Description |
---|---|
boolean |
CountSyncPolicy.mark(TridentTuple tuple,
long offset) |
boolean |
SyncPolicy.mark(TridentTuple tuple,
long offset)
Called for every tuple the HdfsBolt executes.
|
Modifier and Type | Method and Description |
---|---|
List<String> |
HiveMapper.mapPartitions(TridentTuple tuple)
Given a TridetnTuple, return a hive partition values list.
|
List<String> |
DelimitedRecordHiveMapper.mapPartitions(TridentTuple tuple) |
List<String> |
JsonRecordHiveMapper.mapPartitions(TridentTuple tuple) |
byte[] |
HiveMapper.mapRecord(TridentTuple tuple)
Given a TridentTuple, maps to a HiveRecord based on columnFields.
|
byte[] |
DelimitedRecordHiveMapper.mapRecord(TridentTuple tuple) |
byte[] |
JsonRecordHiveMapper.mapRecord(TridentTuple tuple) |
Modifier and Type | Method and Description |
---|---|
void |
HiveUpdater.updateState(HiveState state,
List<TridentTuple> tuples,
TridentCollector collector) |
void |
HiveState.updateState(List<TridentTuple> tuples,
TridentCollector collector) |
Modifier and Type | Method and Description |
---|---|
void |
JdbcQuery.execute(TridentTuple tuples,
List<Values> values,
TridentCollector tridentCollector) |
Modifier and Type | Method and Description |
---|---|
List<List<Values>> |
JdbcQuery.batchRetrieve(JdbcState jdbcState,
List<TridentTuple> tridentTuples) |
List<List<Values>> |
JdbcState.batchRetrieve(List<TridentTuple> tridentTuples) |
void |
JdbcUpdater.updateState(JdbcState jdbcState,
List<TridentTuple> tuples,
TridentCollector collector) |
void |
JdbcState.updateState(List<TridentTuple> tuples,
TridentCollector collector) |
Modifier and Type | Method and Description |
---|---|
void |
JmsUpdater.updateState(JmsState jmsState,
List<TridentTuple> tuples,
TridentCollector collector) |
void |
JmsState.updateState(List<TridentTuple> tuples,
TridentCollector collector) |
Modifier and Type | Method and Description |
---|---|
void |
TridentKafkaState.updateState(List<TridentTuple> tuples,
TridentCollector collector)
Write the given tuples to Kafka.
|
void |
TridentKafkaStateUpdater.updateState(TridentKafkaState<K,V> state,
List<TridentTuple> tuples,
TridentCollector collector) |
Modifier and Type | Method and Description |
---|---|
K |
FieldNameBasedTupleToKafkaMapper.getKeyFromTuple(TridentTuple tuple) |
K |
TridentTupleToKafkaMapper.getKeyFromTuple(TridentTuple tuple) |
V |
FieldNameBasedTupleToKafkaMapper.getMessageFromTuple(TridentTuple tuple) |
V |
TridentTupleToKafkaMapper.getMessageFromTuple(TridentTuple tuple) |
Modifier and Type | Method and Description |
---|---|
String |
KafkaTopicSelector.getTopic(TridentTuple tuple) |
String |
DefaultTopicSelector.getTopic(TridentTuple tuple) |
Modifier and Type | Method and Description |
---|---|
void |
PrintFunction.execute(TridentTuple tuple,
TridentCollector tridentCollector) |
Modifier and Type | Method and Description |
---|---|
void |
MongoStateQuery.execute(TridentTuple tuples,
List<Values> values,
TridentCollector tridentCollector) |
Modifier and Type | Method and Description |
---|---|
List<List<Values>> |
MongoState.batchRetrieve(List<TridentTuple> tridentTuples)
Batch retrieve values.
|
List<List<Values>> |
MongoStateQuery.batchRetrieve(MongoState mongoState,
List<TridentTuple> tridentTuples) |
void |
MongoState.updateState(List<TridentTuple> tuples,
TridentCollector collector)
Update Mongo state.
|
void |
MongoStateUpdater.updateState(MongoState state,
List<TridentTuple> tuples,
TridentCollector collector) |
Modifier and Type | Method and Description |
---|---|
void |
MqttPublishFunction.execute(TridentTuple tuple,
TridentCollector collector) |
Modifier and Type | Method and Description |
---|---|
void |
OpenTsdbState.update(List<TridentTuple> tridentTuples,
TridentCollector collector) |
void |
OpenTsdbStateUpdater.updateState(OpenTsdbState state,
List<TridentTuple> tuples,
TridentCollector collector) |
Modifier and Type | Method and Description |
---|---|
void |
PrintFunction.execute(TridentTuple tuple,
TridentCollector tridentCollector) |
Modifier and Type | Method and Description |
---|---|
void |
AbstractRedisStateQuerier.execute(TridentTuple tuple,
List<Values> values,
TridentCollector collector) |
Modifier and Type | Method and Description |
---|---|
List<List<Values>> |
AbstractRedisStateQuerier.batchRetrieve(T state,
List<TridentTuple> inputs) |
void |
AbstractRedisStateUpdater.updateState(T state,
List<TridentTuple> inputs,
TridentCollector collector) |
Modifier and Type | Method and Description |
---|---|
void |
RocketMqState.updateState(List<TridentTuple> tuples,
TridentCollector collector)
Update the RocketMQ state.
|
void |
RocketMqStateUpdater.updateState(RocketMqState state,
List<TridentTuple> tuples,
TridentCollector collector) |
Modifier and Type | Method and Description |
---|---|
void |
SolrState.updateState(List<TridentTuple> tuples) |
void |
SolrUpdater.updateState(SolrState solrState,
List<TridentTuple> tuples,
TridentCollector collector) |
Modifier and Type | Method and Description |
---|---|
void |
TridentWordCount.Split.execute(TridentTuple tuple,
TridentCollector collector) |
void |
TridentReach.ExpandList.execute(TridentTuple tuple,
TridentCollector collector) |
Integer |
TridentReach.One.init(TridentTuple tuple) |
Modifier and Type | Method and Description |
---|---|
Stream |
Stream.max(Comparator<TridentTuple> comparator)
This aggregator operation computes the maximum of tuples in a stream by using the given
comparator with TridentTuple s. |
Stream |
Stream.min(Comparator<TridentTuple> comparator)
This aggregator operation computes the minimum of tuples in a stream by using the given
comparator with TridentTuple s. |
Modifier and Type | Method and Description |
---|---|
void |
ReturnResultsReducer.execute(ReturnResultsReducer.ReturnResultsState state,
int streamIndex,
TridentTuple input,
TridentCollector collector) |
Modifier and Type | Method and Description |
---|---|
void |
Consumer.accept(TridentTuple input)
Performs the operation on the input trident tuple.
|
void |
Aggregator.aggregate(T val,
TridentTuple tuple,
TridentCollector collector) |
void |
GroupedMultiReducer.complete(T state,
TridentTuple group,
TridentCollector collector) |
void |
MultiReducer.execute(T state,
int streamIndex,
TridentTuple input,
TridentCollector collector) |
void |
GroupedMultiReducer.execute(T state,
int streamIndex,
TridentTuple group,
TridentTuple input,
TridentCollector collector) |
Iterable<Values> |
FlatMapFunction.execute(TridentTuple input)
Invoked by the framework for each trident tuple in a stream.
|
Values |
MapFunction.execute(TridentTuple input)
Invoked by the framework for each trident tuple in a stream.
|
void |
Function.execute(TridentTuple tuple,
TridentCollector collector)
Performs the function logic on an individual tuple and emits 0 or more tuples.
|
T |
GroupedMultiReducer.init(TridentCollector collector,
TridentTuple group) |
T |
CombinerAggregator.init(TridentTuple tuple) |
boolean |
Filter.isKeep(TridentTuple tuple)
Determines if a tuple should be filtered out of a stream.
|
T |
ReducerAggregator.reduce(T curr,
TridentTuple tuple) |
Modifier and Type | Method and Description |
---|---|
void |
ComparisonAggregator.aggregate(ComparisonAggregator.State state,
TridentTuple tuple,
TridentCollector collector) |
void |
FirstN.FirstNAgg.aggregate(org.apache.storm.trident.operation.builtin.FirstN.FirstNAgg.State val,
TridentTuple tuple,
TridentCollector collector) |
void |
FirstN.FirstNSortedAgg.aggregate(PriorityQueue state,
TridentTuple tuple,
TridentCollector collector) |
void |
TupleCollectionGet.execute(TridentTuple tuple,
Iterator<List<Object>> tuplesIterator,
TridentCollector collector) |
void |
MapGet.execute(TridentTuple tuple,
Object result,
TridentCollector collector) |
void |
SnapshotGet.execute(TridentTuple tuple,
Object result,
TridentCollector collector) |
Long |
Count.init(TridentTuple tuple) |
Number |
Sum.init(TridentTuple tuple) |
boolean |
Debug.isKeep(TridentTuple tuple) |
boolean |
Negate.isKeep(TridentTuple tuple) |
boolean |
Equals.isKeep(TridentTuple tuple) |
boolean |
FilterNull.isKeep(TridentTuple tuple) |
protected T |
ComparisonAggregator.valueFromTuple(TridentTuple tuple) |
Modifier and Type | Method and Description |
---|---|
List<Object> |
MapGet.batchRetrieve(ReadOnlyMapState map,
List<TridentTuple> keys) |
List<Object> |
SnapshotGet.batchRetrieve(ReadOnlySnapshottable state,
List<TridentTuple> args) |
List<Iterator<List<Object>>> |
TupleCollectionGet.batchRetrieve(State state,
List<TridentTuple> args) |
Modifier and Type | Method and Description |
---|---|
Map<TridentTuple,Object> |
GroupedMultiReducerExecutor.init(TridentCollector collector) |
Modifier and Type | Method and Description |
---|---|
void |
ChainedAggregatorImpl.aggregate(ChainedResult val,
TridentTuple tuple,
TridentCollector collector) |
void |
GroupedAggregator.aggregate(Object[] arr,
TridentTuple tuple,
TridentCollector collector) |
void |
ReducerAggregatorImpl.aggregate(Result val,
TridentTuple tuple,
TridentCollector collector) |
void |
CombinerAggregatorCombineImpl.aggregate(Result val,
TridentTuple tuple,
TridentCollector collector) |
void |
SingleEmitAggregator.aggregate(org.apache.storm.trident.operation.impl.SingleEmitAggregator.SingleEmitState val,
TridentTuple tuple,
TridentCollector collector) |
void |
JoinerMultiReducer.complete(JoinState state,
TridentTuple group,
TridentCollector collector) |
void |
PreservingFieldsOrderJoinerMultiReducer.complete(JoinState state,
TridentTuple group,
TridentCollector collector) |
void |
JoinerMultiReducer.execute(JoinState state,
int streamIndex,
TridentTuple group,
TridentTuple input,
TridentCollector collector) |
void |
PreservingFieldsOrderJoinerMultiReducer.execute(JoinState state,
int streamIndex,
TridentTuple group,
TridentTuple input,
TridentCollector collector) |
void |
GroupedMultiReducerExecutor.execute(Map<TridentTuple,Object> state,
int streamIndex,
TridentTuple full,
TridentCollector collector) |
void |
IdentityMultiReducer.execute(T state,
int streamIndex,
TridentTuple input,
TridentCollector collector) |
void |
CombinerAggregatorInitImpl.execute(TridentTuple tuple,
TridentCollector collector) |
void |
FilterExecutor.execute(TridentTuple tuple,
TridentCollector collector) |
void |
FlatMapFunctionExecutor.execute(TridentTuple tuple,
TridentCollector collector) |
void |
ConsumerExecutor.execute(TridentTuple tuple,
TridentCollector collector) |
void |
MapFunctionExecutor.execute(TridentTuple tuple,
TridentCollector collector) |
JoinState |
JoinerMultiReducer.init(TridentCollector collector,
TridentTuple group) |
JoinState |
PreservingFieldsOrderJoinerMultiReducer.init(TridentCollector collector,
TridentTuple group) |
boolean |
TrueFilter.isKeep(TridentTuple tuple) |
Modifier and Type | Method and Description |
---|---|
void |
GroupedMultiReducerExecutor.complete(Map<TridentTuple,Object> state,
TridentCollector collector) |
void |
GroupedMultiReducerExecutor.execute(Map<TridentTuple,Object> state,
int streamIndex,
TridentTuple full,
TridentCollector collector) |
void |
CombinerAggStateUpdater.updateState(Snapshottable state,
List<TridentTuple> tuples,
TridentCollector collector) |
void |
ReducerAggStateUpdater.updateState(Snapshottable state,
List<TridentTuple> tuples,
TridentCollector collector) |
Constructor and Description |
---|
JoinState(int numSides,
TridentTuple group) |
Modifier and Type | Method and Description |
---|---|
void |
BridgeReceiver.execute(ProcessorContext context,
String streamId,
TridentTuple tuple) |
void |
TupleReceiver.execute(ProcessorContext processorContext,
String streamId,
TridentTuple tuple) |
Modifier and Type | Method and Description |
---|---|
void |
MapProcessor.execute(ProcessorContext processorContext,
String streamId,
TridentTuple tuple) |
void |
AggregateProcessor.execute(ProcessorContext processorContext,
String streamId,
TridentTuple tuple) |
void |
PartitionPersistProcessor.execute(ProcessorContext processorContext,
String streamId,
TridentTuple tuple) |
void |
EachProcessor.execute(ProcessorContext processorContext,
String streamId,
TridentTuple tuple) |
void |
StateQueryProcessor.execute(ProcessorContext processorContext,
String streamId,
TridentTuple tuple) |
void |
ProjectedProcessor.execute(ProcessorContext processorContext,
String streamId,
TridentTuple tuple) |
void |
MultiReducerProcessor.execute(ProcessorContext processorContext,
String streamId,
TridentTuple tuple) |
void |
AppendCollector.setContext(ProcessorContext pc,
TridentTuple t) |
Modifier and Type | Method and Description |
---|---|
void |
QueryFunction.execute(TridentTuple tuple,
T result,
TridentCollector collector) |
Modifier and Type | Method and Description |
---|---|
List<T> |
QueryFunction.batchRetrieve(S state,
List<TridentTuple> args) |
void |
StateUpdater.updateState(S state,
List<TridentTuple> tuples,
TridentCollector collector) |
Constructor and Description |
---|
ReducerValueUpdater(ReducerAggregator agg,
List<TridentTuple> tuples) |
Modifier and Type | Method and Description |
---|---|
void |
MapReducerAggStateUpdater.updateState(MapState map,
List<TridentTuple> tuples,
TridentCollector collector) |
void |
MapCombinerAggStateUpdater.updateState(MapState map,
List<TridentTuple> tuples,
TridentCollector collector) |
Modifier and Type | Method and Description |
---|---|
void |
CountAsAggregator.aggregate(org.apache.storm.trident.testing.CountAsAggregator.State state,
TridentTuple tuple,
TridentCollector collector) |
void |
TuplifyArgs.execute(TridentTuple input,
TridentCollector collector) |
void |
Split.execute(TridentTuple tuple,
TridentCollector collector) |
void |
StringLength.execute(TridentTuple tuple,
TridentCollector collector) |
boolean |
TrueFilter.isKeep(TridentTuple tuple) |
Modifier and Type | Class and Description |
---|---|
class |
TridentTupleView
Extends AbstractList so that it can be emitted directly as Storm tuples.
|
Modifier and Type | Method and Description |
---|---|
TridentTuple |
TridentTupleView.FreshOutputFactory.create(List<Object> selfVals) |
TridentTuple |
TridentTupleView.ProjectionFactory.create(TridentTuple parent) |
TridentTuple |
TridentTupleView.OperationOutputFactory.create(TridentTupleView parent,
List<Object> selfVals) |
TridentTuple |
TridentTupleView.RootFactory.create(Tuple parent) |
static TridentTuple |
TridentTupleView.createFreshTuple(Fields fields,
List<Object> values) |
static TridentTuple |
TridentTupleView.createFreshTuple(Fields fields,
Object... values) |
Modifier and Type | Method and Description |
---|---|
TridentTuple |
TridentTupleView.ProjectionFactory.create(TridentTuple parent) |
Modifier and Type | Method and Description |
---|---|
TridentTuple |
StoreBasedTridentWindowManager.collectTridentTupleOrKey(TridentBatchTuple tridentBatchTuple,
List<String> keys) |
Modifier and Type | Method and Description |
---|---|
protected abstract List<TridentTuple> |
AbstractTridentWindowManager.getTridentTuples(List<T> tupleEvents)
Return
TridentTuple s from given tupleEvents . |
List<TridentTuple> |
StoreBasedTridentWindowManager.getTridentTuples(List<TridentBatchTuple> tridentBatchTuples) |
List<TridentTuple> |
InMemoryTridentWindowManager.getTridentTuples(List<TridentTuple> tridentBatchTuples) |
Modifier and Type | Method and Description |
---|---|
void |
WindowTridentProcessor.execute(ProcessorContext processorContext,
String streamId,
TridentTuple tuple) |
Modifier and Type | Method and Description |
---|---|
void |
InMemoryTridentWindowManager.addTuplesBatch(Object batchId,
List<TridentTuple> tuples) |
void |
ITridentWindowManager.addTuplesBatch(Object batchId,
List<TridentTuple> tuples)
Add received batch of tuples to cache/store and add them to
WindowManager . |
void |
StoreBasedTridentWindowManager.addTuplesBatch(Object batchId,
List<TridentTuple> tuples) |
List<TridentTuple> |
InMemoryTridentWindowManager.getTridentTuples(List<TridentTuple> tridentBatchTuples) |
void |
InMemoryTridentWindowManager.onTuplesExpired(List<TridentTuple> expiredTuples) |
void |
WindowsStateUpdater.updateState(WindowsState state,
List<TridentTuple> tuples,
TridentCollector collector) |
Constructor and Description |
---|
TridentBatchTuple(String effectiveBatchId,
long timeStamp,
int tupleIndex,
TridentTuple tridentTuple) |
Copyright © 2022 The Apache Software Foundation. All rights reserved.