Modifier and Type | Method and Description |
---|---|
BaseCassandraBolt |
BaseCassandraBolt.withOutputFields(Fields fields)
Configures this bolt with the given
fields as outputfields with stream id as Utils.DEFAULT_STREAM_ID . |
BaseCassandraBolt |
BaseCassandraBolt.withStreamOutputFields(String stream,
Fields fields)
Configures this bolt given
fields as outputfields for the given stream . |
Modifier and Type | Method and Description |
---|---|
Fields |
SimpleTuple.getFields() |
Fields |
OpaqueTupleStateMapper.getStateFields() |
Fields |
NonTransactionalTupleStateMapper.getStateFields() |
Fields |
SimpleStateMapper.getStateFields() |
Fields |
StateMapper.getStateFields() |
Fields |
TransactionalTupleStateMapper.getStateFields() |
Fields |
SerializedStateMapper.getStateFields() |
Modifier and Type | Method and Description |
---|---|
List<Object> |
SimpleTuple.select(Fields selector) |
CassandraBackingMap.Options<T> |
CassandraBackingMap.Options.withKeys(Fields keyFields) |
Constructor and Description |
---|
NonTransactionalTupleStateMapper(Fields fields) |
OpaqueTupleStateMapper(String currTxIdField,
String currPrefix,
String prevPrefix,
Fields fields) |
SimpleStateMapper(Fields fields,
StateType stateType) |
SimpleTuple(Fields keyFields,
List<Object>... values) |
SimpleTuple(Fields keyFields,
List<Object> values) |
TransactionalTupleStateMapper(String txIdField,
Fields fields) |
TridentAyncCQLResultSetValuesMapper(Fields outputDeclaredFields,
Semaphore throttle) |
TridentResultSetValuesMapper(Fields outputDeclaredFields) |
Modifier and Type | Method and Description |
---|---|
static LoadAwareCustomStreamGrouping |
GrouperFactory.mkGrouper(WorkerTopologyContext context,
String componentId,
String streamId,
Fields outFields,
Grouping thriftGrouping,
List<Integer> unsortedTargetTasks,
Map<String,Object> topoConf) |
Constructor and Description |
---|
FieldsGrouper(Fields outFields,
Grouping thriftGrouping) |
Modifier and Type | Method and Description |
---|---|
Map<String,Map<String,Fields>> |
WorkerState.getComponentToStreamToFields() |
Modifier and Type | Method and Description |
---|---|
LinearDRPCInputDeclarer |
LinearDRPCInputDeclarer.fieldsGrouping(Fields fields) |
LinearDRPCInputDeclarer |
LinearDRPCInputDeclarer.fieldsGrouping(String streamId,
Fields fields) |
LinearDRPCInputDeclarer |
LinearDRPCInputDeclarer.partialKeyGrouping(Fields fields) |
LinearDRPCInputDeclarer |
LinearDRPCInputDeclarer.partialKeyGrouping(String streamId,
Fields fields) |
Modifier and Type | Method and Description |
---|---|
Fields |
DefaultEsLookupResultOutput.fields() |
Fields |
EsLookupResultOutput.fields()
Fields to be declared for output. |
Modifier and Type | Method and Description |
---|---|
Fields |
TridentEsTopology.FixedBatchSpout.getOutputFields()
Gets the output fields.
|
Modifier and Type | Method and Description |
---|---|
Fields |
EventDataScheme.getOutputFields() |
Fields |
BinaryEventDataScheme.getOutputFields() |
Fields |
IEventDataScheme.getOutputFields()
Retrieve the Fields that are present on tuples created by this object.
|
Fields |
StringEventDataScheme.getOutputFields() |
Modifier and Type | Method and Description |
---|---|
Fields |
TransactionalTridentEventHubSpout.getOutputFields() |
Fields |
OpaqueTridentEventHubSpout.getOutputFields() |
Modifier and Type | Method and Description |
---|---|
Fields |
OnlyValueRecordTranslator.getFieldsFor(String stream) |
Constructor and Description |
---|
PartialKeyGrouping(Fields fields) |
PartialKeyGrouping(Fields fields,
PartialKeyGrouping.AssignmentCreator assignmentCreator) |
PartialKeyGrouping(Fields fields,
PartialKeyGrouping.AssignmentCreator assignmentCreator,
PartialKeyGrouping.TargetSelector targetSelector) |
Modifier and Type | Method and Description |
---|---|
SimpleHBaseMapper |
SimpleHBaseMapper.withColumnFields(Fields columnFields) |
SimpleHBaseMapper |
SimpleHBaseMapper.withCounterFields(Fields counterFields) |
Modifier and Type | Method and Description |
---|---|
SimpleTridentHBaseMapper |
SimpleTridentHBaseMapper.withColumnFields(Fields columnFields) |
SimpleTridentHBaseMapper |
SimpleTridentHBaseMapper.withCounterFields(Fields counterFields) |
Modifier and Type | Method and Description |
---|---|
DelimitedRecordFormat |
DelimitedRecordFormat.withFields(Fields fields)
Only output the specified fields.
|
Modifier and Type | Method and Description |
---|---|
Fields |
FixedBatchSpout.getOutputFields() |
Constructor and Description |
---|
FixedBatchSpout(Fields fields,
int maxBatchSize,
List<Object>... outputs) |
Modifier and Type | Method and Description |
---|---|
DelimitedRecordFormat |
DelimitedRecordFormat.withFields(Fields fields)
Only output the specified fields.
|
Modifier and Type | Method and Description |
---|---|
DelimitedRecordHiveMapper |
DelimitedRecordHiveMapper.withColumnFields(Fields columnFields) |
JsonRecordHiveMapper |
JsonRecordHiveMapper.withColumnFields(Fields columnFields) |
DelimitedRecordHiveMapper |
DelimitedRecordHiveMapper.withPartitionFields(Fields partitionFields) |
JsonRecordHiveMapper |
JsonRecordHiveMapper.withPartitionFields(Fields partitionFields) |
Modifier and Type | Method and Description |
---|---|
Fields |
TridentHiveTopology.FixedBatchSpout.getOutputFields() |
Constructor and Description |
---|
SimpleJdbcLookupMapper(Fields outputFields,
List<Column> queryColumns) |
Constructor and Description |
---|
GenericBolt(String name,
boolean autoAck,
boolean autoAnchor,
Fields declaredFields)
Constructs a new
GenericBolt instance. |
Modifier and Type | Method and Description |
---|---|
Fields |
TridentJmsSpout.getOutputFields() |
Modifier and Type | Field and Description |
---|---|
static Fields |
DefaultRecordTranslator.FIELDS |
Modifier and Type | Method and Description |
---|---|
Fields |
ByTopicRecordTranslator.getFieldsFor(String stream) |
Fields |
SimpleRecordTranslator.getFieldsFor(String stream) |
Fields |
DefaultRecordTranslator.getFieldsFor(String stream) |
Fields |
RecordTranslator.getFieldsFor(String stream)
Get the fields associated with a stream.
|
Modifier and Type | Method and 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.
|
Constructor and 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.
|
Modifier and Type | Method and 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.
|
Modifier and Type | Method and Description |
---|---|
Fields |
KafkaTridentSpoutOpaque.getOutputFields() |
Fields |
KafkaTridentSpoutTransactional.getOutputFields() |
Modifier and Type | Method and Description |
---|---|
<K,V> Fields |
OutputFieldsExtractor.getOutputFields(KafkaTridentSpoutConfig<K,V> kafkaSpoutConfig)
Extract the output fields from the config.
|
Modifier and Type | Method and Description |
---|---|
Fields |
RecordToTupleMapper.getOutputFields()
Retrieve the names of fields.
|
Modifier and Type | Method and Description |
---|---|
Fields |
MqttMessageMapper.outputFields()
Returns the list of output fields this Mapper produces.
|
Modifier and Type | Method and Description |
---|---|
Fields |
CustomMessageMapper.outputFields()
Gets the output fields.
|
Modifier and Type | Method and Description |
---|---|
Fields |
StringMessageMapper.outputFields() |
Fields |
ByteArrayMessageMapper.outputFields() |
Modifier and Type | Field and Description |
---|---|
static Fields |
MetricGenSpout.DEFAULT_METRIC_FIELDS |
Modifier and Type | Method and Description |
---|---|
Fields |
MetricGenBatchSpout.getOutputFields() |
Modifier and Type | Method and Description |
---|---|
Map<String,? extends Fields> |
ModelOutputs.streamFields()
Stream fields.
|
Modifier and Type | Method and Description |
---|---|
Map<String,? extends Fields> |
JpmmlModelOutputs.streamFields() |
Constructor and Description |
---|
JpmmlModelOutputs(Map<String,? extends Fields> declaredFields) |
Modifier and Type | Method and Description |
---|---|
Fields |
StringScheme.getOutputFields() |
Modifier and Type | Method and Description |
---|---|
Fields |
SolrFieldsSpout.getOutputFields() |
Fields |
SolrJsonSpout.getOutputFields() |
Modifier and Type | Method and Description |
---|---|
Fields |
RawMultiScheme.getOutputFields() |
Fields |
MultiScheme.getOutputFields() |
Fields |
SchemeAsMultiScheme.getOutputFields() |
Fields |
RawScheme.getOutputFields() |
Fields |
Scheme.getOutputFields() |
Modifier and Type | Method and Description |
---|---|
Fields |
RecordTranslatorSchemeAdapter.getFieldsFor(String stream) |
Modifier and Type | Method and Description |
---|---|
Fields |
AvroScheme.getOutputFields() |
Modifier and Type | Method and Description |
---|---|
Fields |
CsvScheme.getOutputFields() |
Modifier and Type | Method and Description |
---|---|
Fields |
JsonScheme.getOutputFields() |
Modifier and Type | Method and Description |
---|---|
Fields |
TsvScheme.getOutputFields() |
Modifier and Type | Method and Description |
---|---|
static Fields |
TimeData.getFields() |
Constructor and Description |
---|
SingleJoinBolt(Fields outFields) |
Modifier and Type | Method and Description |
---|---|
Fields |
RandomNumberGeneratorSpout.getOutputFields() |
Constructor and Description |
---|
RandomNumberGeneratorSpout(Fields fields,
int batchSize,
int maxNumber) |
Modifier and Type | Field and Description |
---|---|
protected static Fields |
Stream.KEY |
protected static Fields |
Stream.KEY_VALUE |
protected static Fields |
Stream.VALUE |
Modifier and Type | Method and Description |
---|---|
static Fields |
StreamUtil.getPunctuationFields() |
Modifier and Type | Method and Description |
---|---|
protected Stream<T> |
Stream.partitionBy(Fields fields,
int parallelism) |
Constructor and Description |
---|
ProcessorNode(Processor<?> processor,
String outputStream,
Fields outputFields) |
ProcessorNode(Processor<?> processor,
String outputStream,
Fields outputFields,
boolean preservesKey) |
Modifier and Type | Method and Description |
---|---|
Fields |
GeneralTopologyContext.getComponentOutputFields(GlobalStreamId id)
Gets the declared output fields for the specified global stream id.
|
Fields |
GeneralTopologyContext.getComponentOutputFields(String componentId,
String streamId)
Gets the declared output fields for the specified component/stream.
|
Fields |
TopologyContext.getThisOutputFields(String streamId)
Gets the declared output fields for the specified stream id for the component this task is a part of.
|
Constructor and Description |
---|
GeneralTopologyContext(StormTopology topology,
Map<String,Object> topoConf,
Map<Integer,String> taskToComponent,
Map<String,List<Integer>> componentToSortedTasks,
Map<String,Map<String,Fields>> componentToStreamToFields,
String stormId) |
TopologyContext(StormTopology topology,
Map<String,Object> topoConf,
Map<Integer,String> taskToComponent,
Map<String,List<Integer>> componentToSortedTasks,
Map<String,Map<String,Fields>> componentToStreamToFields,
Map<String,Long> blobToLastKnownVersionShared,
String stormId,
String codeDir,
String pidDir,
Integer taskId,
Integer workerPort,
List<Integer> workerTasks,
Map<String,Object> defaultResources,
Map<String,Object> userResources,
Map<String,Object> executorData,
Map<Integer,Map<Integer,Map<String,IMetric>>> registeredMetrics,
AtomicBoolean openOrPrepareWasCalled,
StormMetricRegistry metricRegistry) |
WorkerTopologyContext(StormTopology topology,
Map<String,Object> topoConf,
Map<Integer,String> taskToComponent,
Map<String,List<Integer>> componentToSortedTasks,
Map<String,Map<String,Fields>> componentToStreamToFields,
String stormId,
String codeDir,
String pidDir,
Integer workerPort,
List<Integer> workerTasks,
Map<String,Object> defaultResources,
Map<String,Object> userResources) |
WorkerTopologyContext(StormTopology topology,
Map<String,Object> topoConf,
Map<Integer,String> taskToComponent,
Map<String,List<Integer>> componentToSortedTasks,
Map<String,Map<String,Fields>> componentToStreamToFields,
String stormId,
String codeDir,
String pidDir,
Integer workerPort,
List<Integer> workerTasks,
Map<String,Object> defaultResources,
Map<String,Object> userResources,
AtomicReference<Map<Integer,NodeInfo>> taskToNodePort,
String assignmentId) |
Modifier and Type | Method and Description |
---|---|
Fields |
TestPlannerSpout.getOutputFields() |
Fields |
TestPlannerBolt.getOutputFields() |
Fields |
TestGlobalCount.getOutputFields() |
Fields |
TestEventOrderCheckBolt.getOutputFields() |
Constructor and Description |
---|
FeederSpout(Fields outFields) |
FixedTupleSpout(List tuples,
Fields fields) |
IdentityBolt(Fields fields) |
PrepareBatchBolt(Fields outFields) |
TestPlannerSpout(Fields outFields) |
TestPlannerSpout(Fields outFields,
boolean isDistributed) |
Modifier and Type | Method and Description |
---|---|
void |
OutputFieldsGetter.declare(boolean direct,
Fields fields) |
void |
OutputFieldsDeclarer.declare(boolean direct,
Fields fields) |
void |
OutputFieldsGetter.declare(Fields fields) |
void |
OutputFieldsDeclarer.declare(Fields fields)
Uses default stream id.
|
void |
OutputFieldsGetter.declareStream(String streamId,
boolean direct,
Fields fields) |
void |
OutputFieldsDeclarer.declareStream(String streamId,
boolean direct,
Fields fields) |
void |
OutputFieldsGetter.declareStream(String streamId,
Fields fields) |
void |
OutputFieldsDeclarer.declareStream(String streamId,
Fields fields) |
T |
InputDeclarer.fieldsGrouping(String componentId,
Fields fields)
The stream is partitioned by the fields specified in the grouping.
|
BoltDeclarer |
TopologyBuilder.BoltGetter.fieldsGrouping(String componentId,
Fields fields) |
T |
InputDeclarer.fieldsGrouping(String componentId,
String streamId,
Fields fields)
The stream is partitioned by the fields specified in the grouping.
|
BoltDeclarer |
TopologyBuilder.BoltGetter.fieldsGrouping(String componentId,
String streamId,
Fields fields) |
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,
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.
|
BoltDeclarer |
TopologyBuilder.BoltGetter.partialKeyGrouping(String componentId,
String streamId,
Fields fields) |
Modifier and Type | Method and Description |
---|---|
Fields |
Stream.getOutputFields() |
Modifier and Type | Method and Description |
---|---|
Stream |
Stream.aggregate(Aggregator agg,
Fields functionFields) |
Stream |
Stream.aggregate(CombinerAggregator 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.aggregate(ReducerAggregator agg,
Fields functionFields) |
Stream |
Stream.each(Fields inputFields,
Filter filter) |
Stream |
Stream.each(Fields inputFields,
Function function,
Fields functionFields) |
Stream |
Stream.each(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,
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(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(Stream s1,
Fields joinFields1,
Stream s2,
Fields joinFields2,
Fields outFields) |
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 |
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 |
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(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 |
TridentTopology.multiReduce(GroupedStream s1,
GroupedStream s2,
GroupedMultiReducer 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(List<GroupedStream> streams,
GroupedMultiReducer function,
Fields outputFields) |
Stream |
TridentTopology.multiReduce(List<Stream> streams,
MultiReducer function,
Fields outputFields) |
Stream |
TridentTopology.multiReduce(Stream s1,
Stream s2,
MultiReducer function,
Fields outputFields) |
Stream |
Stream.partitionAggregate(Aggregator agg,
Fields functionFields) |
Stream |
Stream.partitionAggregate(CombinerAggregator 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.partitionAggregate(ReducerAggregator agg,
Fields functionFields) |
Stream |
Stream.partitionBy(Fields fields)
Repartitioning Operation.
|
TridentState |
Stream.partitionPersist(StateFactory stateFactory,
Fields inputFields,
StateUpdater updater) |
TridentState |
Stream.partitionPersist(StateFactory stateFactory,
Fields inputFields,
StateUpdater updater,
Fields functionFields) |
TridentState |
Stream.partitionPersist(StateFactory stateFactory,
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.partitionPersist(StateSpec stateSpec,
StateUpdater updater,
Fields functionFields) |
TridentState |
Stream.persistentAggregate(StateFactory stateFactory,
CombinerAggregator 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(StateFactory stateFactory,
ReducerAggregator agg,
Fields functionFields) |
TridentState |
Stream.persistentAggregate(StateSpec spec,
CombinerAggregator 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) |
TridentState |
Stream.persistentAggregate(StateSpec spec,
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(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 of
slidingInterval and completes a window at windowDuration . |
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 every
windowCount of tuples and slides the window after slideCount . |
Stream |
Stream.stateQuery(TridentState state,
Fields inputFields,
QueryFunction function,
Fields functionFields) |
Stream |
Stream.stateQuery(TridentState state,
QueryFunction function,
Fields functionFields) |
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 of
windowDuration . |
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 every
windowCount of tuples. |
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.
|
Stream |
Stream.window(WindowConfig windowConfig,
WindowsStoreFactory windowStoreFactory,
Fields inputFields,
Aggregator aggregator,
Fields functionFields)
Returns stream of aggregated results based on the given window configuration.
|
Modifier and Type | Method and Description |
---|---|
Stream |
TridentTopology.join(List<Stream> streams,
List<Fields> joinFields,
Fields outFields) |
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(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.multiReduce(List<Fields> inputFields,
List<GroupedStream> groupedStreams,
GroupedMultiReducer function,
Fields outputFields) |
Stream |
TridentTopology.multiReduce(List<Fields> inputFields,
List<Stream> streams,
MultiReducer function,
Fields outputFields) |
Modifier and Type | Method and Description |
---|---|
Fields |
GroupedStream.getGroupFields() |
Fields |
IAggregatableStream.getOutputFields() |
Fields |
GroupedStream.getOutputFields() |
Constructor and Description |
---|
GroupedStream(Stream stream,
Fields groupFields) |
Modifier and Type | Method and Description |
---|---|
TridentTupleView.ProjectionFactory |
TridentOperationContext.makeProjectionFactory(Fields fields) |
TridentTupleView.ProjectionFactory |
TridentMultiReducerContext.makeProjectionFactory(int streamIndex,
Fields fields) |
Constructor and Description |
---|
ChainedAggregatorImpl(Aggregator[] aggs,
Fields[] inputFields,
ComboList.Factory fact) |
GroupedAggregator(Aggregator agg,
Fields group,
Fields input,
int outSize) |
Constructor and Description |
---|
GroupedMultiReducerExecutor(GroupedMultiReducer reducer,
List<Fields> groupFields,
List<Fields> inputFields) |
GroupedMultiReducerExecutor(GroupedMultiReducer reducer,
List<Fields> groupFields,
List<Fields> inputFields) |
JoinerMultiReducer(List<JoinType> types,
int numGroupFields,
List<Fields> sides) |
PreservingFieldsOrderJoinerMultiReducer(List<JoinType> types,
int numGroupFields,
List<Fields> origins,
List<Fields> joins,
List<Fields> sides) |
PreservingFieldsOrderJoinerMultiReducer(List<JoinType> types,
int numGroupFields,
List<Fields> origins,
List<Fields> joins,
List<Fields> sides) |
PreservingFieldsOrderJoinerMultiReducer(List<JoinType> types,
int numGroupFields,
List<Fields> origins,
List<Fields> joins,
List<Fields> sides) |
Modifier and Type | Field and Description |
---|---|
Fields |
Node.allOutputFields |
Fields |
ProcessorNode.selfOutFields |
Constructor and 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) |
Modifier and Type | Method and Description |
---|---|
Fields |
TridentContext.getSelfOutputFields() |
Constructor and 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 and Description |
---|
MultiReducerProcessor(List<Fields> inputFields,
MultiReducer reducer) |
Modifier and Type | Method and Description |
---|---|
Fields |
IBatchSpout.getOutputFields() |
Fields |
PartitionedTridentSpoutExecutor.getOutputFields() |
Fields |
ITridentSpout.getOutputFields() |
Fields |
IPartitionedTridentSpout.getOutputFields() |
Fields |
OpaquePartitionedTridentSpoutExecutor.getOutputFields() |
Fields |
BatchSpoutExecutor.getOutputFields() |
Fields |
RichSpoutBatchExecutor.getOutputFields() |
Fields |
IOpaquePartitionedTridentSpout.getOutputFields() |
Constructor and Description |
---|
MapCombinerAggStateUpdater(CombinerAggregator agg,
Fields groupFields,
Fields inputFields) |
MapReducerAggStateUpdater(ReducerAggregator agg,
Fields groupFields,
Fields inputFields) |
Modifier and Type | Method and Description |
---|---|
Fields |
FixedBatchSpout.getOutputFields() |
Fields |
FeederCommitterBatchSpout.getOutputFields() |
Fields |
FeederBatchSpout.getOutputFields() |
Constructor and Description |
---|
FixedBatchSpout(Fields fields,
int maxBatchSize,
List<Object>... outputs) |
Modifier and Type | Method and Description |
---|---|
Fields |
TridentTupleView.getFields() |
Modifier and Type | Method and Description |
---|---|
static ValuePointer[] |
ValuePointer.buildIndex(Fields fieldsOrder,
Map<String,ValuePointer> pointers) |
static TridentTuple |
TridentTupleView.createFreshTuple(Fields fields,
List<Object> values) |
static TridentTuple |
TridentTupleView.createFreshTuple(Fields fields,
Object... values) |
List<Object> |
TridentTupleView.select(Fields selector) |
Constructor and Description |
---|
FreshOutputFactory(Fields selfFields) |
OperationOutputFactory(TridentTuple.Factory parent,
Fields selfFields) |
ProjectionFactory(TridentTuple.Factory parent,
Fields projectFields) |
RootFactory(Fields inputFields) |
Modifier and Type | Method and 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) |
Modifier and Type | Method and Description |
---|---|
static Fields |
TridentUtils.fieldsConcat(Fields... fields) |
static Fields |
TridentUtils.fieldsSubtract(Fields all,
Fields minus) |
static Fields |
TridentUtils.fieldsUnion(Fields... fields) |
Constructor and 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) |
Modifier and Type | Method and Description |
---|---|
Fields |
ITuple.getFields()
Gets the names of the fields in this tuple.
|
Fields |
TupleImpl.getFields() |
Modifier and Type | Method and Description |
---|---|
List<Object> |
ITuple.select(Fields selector)
Returns a subset of the tuple based on the fields selector.
|
List<Object> |
TupleImpl.select(Fields selector) |
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.
|
Copyright © 2022 The Apache Software Foundation. All rights reserved.