IBM Streams 4.2.1

Operators: SPL standard and specialized toolkits

Operators

ARIMA
DEPRECATED: The com.ibm.streams.timeseries.modeling.ARIMA operator is deprecated and is replaced by the com.ibm.streams.timeseries.modeling.ARIMA2 operator. The deprecated operator might be removed in a future release.
ARIMA2
The ARIMA2 operator implements the autoregressive integrated moving average (ARIMA) modeling algorithm.
ASN1Encode
The ASN1Encode operator creates ASN.1 DER-encoded data from XML documents that fit to the provided ASN.1 specification.
ASN1Parse
The ASN1Parse operator parses a binary data stream that contains ASN.1-encoded data, extracts parts of the data, and sends the data as tuples to downstream operators.
Aggregate
The Aggregate operator is used to compute user-specified aggregations over tuples that are gathered in a window.
AllDevices
Composite that produces streams for all devices in an organization.
AmericanOptionValue
The AmericanOptionValue type-specific operator is for computing the value of "American-style" options.
AnomalyDetector
The AnomalyDetector operator can detect anomalous subsequences in an incoming data stream.
Associations
Association rules are represented as [x] => [y] where [x] is the rule body or antecedent, and [y] is the rule head or consequent.
AutoForecaster
DEPRECATED: The com.ibm.streams.timeseries.modeling.AutoForecaster operator is deprecated and is replaced by the com.ibm.streams.timeseries.modeling.AutoForecaster2 operator. The deprecated operator might be removed in a future release.
AutoForecaster2
The AutoForecaster2 operator is a forecasting operator, which detects the algorithm that best suits the input time series data in real time and forecasts future time series.
BWListTagger
The BWListTagger operator loads lists of domains and IP addresses into a lookup table.
Barrier
The Barrier operator is used to synchronize tuples from two or more streams.
Beacon
The Beacon operator is a utility source that generates tuples on an ad hoc basis.
BloomFilter
The BloomFilter operator detects duplicate tuples in a memory-efficient way.
CSVParse
The CSVParse operator parses an input line of comma-separated values (CSV) that is received in an rstring type input tuple attribute, splits the line into fields (also called items), and assigns the field values to attributes in the output port schema.
CharacterTransform
The CharacterTransform operator is used to convert from one encoding in blob to another encoding in blob.
Classification
The Classification operator calculates the predicted class and the confidence for each tuple in the input stream and automatically assigns those values to output stream attributes.
Clustering
The Clustering operator calculates the cluster index and clustering score for each tuple in the input stream and automatically assigns those values to output stream attributes.
CommandPublish
Publish an event to be sent to a device.
CommandTupleToPayload
Convert tuples to device commands.
CommandsSubscribe
Subscribe to device commands published under the streams topic streamsx/iotdevice/commands/sent.
Compress
The Compress operator is used to compress data in a blob and generate blob output.
ControlNotificationSource
The ControlNotificationSource operator provides a connector between control events and data streams by turning control notifications into tuples.
CrossCorrelate
DEPRECATED: The com.ibm.streams.timeseries.analysis.CrossCorrelate operator is deprecated and is replaced by the com.ibm.streams.timeseries.analysis.CrossCorrelate2 operator. The deprecated operator might be removed in a future release.
CrossCorrelate2
In signal processing, cross-correlation is a measure of similarity of two time series as a function of a time-lag applied to one of them.
CrossCorrelateMulti
In signal processing, cross-correlation is a measure of similarity of two time series as a function of a time-lag applied to one of them.
Custom
The Custom operator is a special logic-related operator that can receive and send any number of streams and does not do anything by itself.
DB2PartitionedAppend
The DB2PartitionedAppend operator writes data to a table in the specified partition of a partitioned DB2 database.
DB2SplitDB
The DB2SplitDB operator determines the partition to use when you are writing input tuples to a partitioned DB2 database.
DHCPMessageParser
DHCPMessageParser is an operator for the IBM InfoSphere Streams product that parses individual fields of DHCP messages received in input tuples, and emits tuples containing message data.
DNSMessageParser
DNSMessageParser is an operator for the IBM InfoSphere Streams product that parses individual fields of DNS messages received in input tuples, and emits tuples containing message data.
DNSPacketDPDKSource
introduction : DNSPacketDPDKSource is an operator for the IBM Streams product that captures live network packets from one of the network interfaces attached to the machine where it executes.
DNSPacketFileSource
DNSPacketFileSource is an operator for the IBM Streams product that reads prerecorded DNS packets from 'packet capture (PCAP)' files, parses the network headers and the fields of the DNS message, and emits tuples containing packet data.
DNSPacketLiveSource
DNSPacketLiveSource is an operator for the IBM Streams product that captures live DNS packets from an ethernet interface, parses their network headers and the fields of the DNS message, and emits tuples containing packet data.
DNSTunneling
The DNSTunneling operator analyzes DNS response traffic and reports suspicious behaviour that may indicate the presence of DNS tunneling in the network.
DPSAux
The DPSAux operator's purpose is to support primitive Java operators that desire to use the DPS toolkit Java APIs.
DSPFilter
DEPRECATED: The com.ibm.streams.timeseries.analysis.DSPFilter operator is deprecated and is replaced by the com.ibm.streams.timeseries.analysis.DSPFilter2 operator. The deprecated operator might be removed in a future release.
DSPFilter2
The Digital Signal Processing (DSP) filter operator performs a digital filtering operation on an input time series.
DSPFilterFinite
The Digital Signal Processing (DSP) filter operator performs a digital filtering operation on an input time series.
DWT
DEPRECATED: The com.ibm.streams.timeseries.analysis.DWT operator is deprecated and is replaced by the com.ibm.streams.timeseries.analysis.DWT2 operator. The deprecated operator might be removed in a future release.
DWT2
The DWT2 operator applies a discrete wavelet transform (DWT) on a vector time series.
DataExplorerPush
The DataExplorerPush operator pushes data from InfoSphere Streams into IBM InfoSphere Data Explorer.
DeDuplicate
The DeDuplicate operator suppresses duplicate tuples that are seen within a specified time period.
Decompress
The Decompress operator decompresses data in blob input and generates blob output that contains the decompressed data.
Delay
The Delay operator is used to delay a stream by an amount while it keeps the inter-arrival times of tuples and punctuation intact.
DeviceCommands
Subscribe to device commands for an IBM Watson IoT Platform organization.
DeviceEventExtractData
Extract application event data into an SPL tuple from the JSON.
DeviceEvents
Subscribe to device events for an IBM Watson IoT Platform organization.
DeviceStatuses
Subscribe to device status events for an IBM Watson IoT Platform organization.
DirectoryScan
The DirectoryScan operator watches a directory, and generates file names on the output, one for each file that is found in the directory.
DirectoryWatch
The DirectoryWatch operator monitors configured directories and reports changes in them.
Distribution
The Distribution operator calculates the quartile distribution for an input time series.
DomainProfiling
The DomainProfiling operator analyzes DNS response traffic and reports whether or not the behaviour of the domain is suspicious.
DynamicFilter
The DynamicFilter is a version of the Filter operator that can decide at run time which input tuples are passed through, based on control input it receives.
EuropeanOptionValue
The EuropeanOptionValue type-specific operator is for computing the value of "European-style" options.
EventsSubscribe
Subscribe to device events published under the streams topic streamsx/iot/device/events.
ExceptionCatcher
The ExceptionCatcher operator catches exceptions from fused downstream operators and reports these exceptions via tuples that are sent to its optional second output port.
Export
The Export operator sends a stream from the current application, making it available to Import operators of applications that are running in the same streaming middleware instance.
FFT
The FFT operator applies a Fast Fourier transform (FFT) algorithm to a time series.
FIXAcceptor
The FixAcceptor operator functions as the Financial Information eXchange (FIX) Acceptor.
FIXInitiator
The FIXInitiator operator functions as the Financial Information Exchange (FIX) Initiator.
FIXMessageToStream
The FIXMessageToStream operator takes a valid Financial Information eXchange (FIX) Message and converts it to a stream for processing.
FMPFilter
The FMPFilter operator is an adaptive faded-memory polynomial filter.
FileSink
The FileSink operator writes tuples to a file.
FileSource
The FileSource operator reads data from a file and produces tuples as a result.
Filter
The Filter operator removes tuples from a stream by passing along only those tuples that satisfy a user-specified condition.
FilteredSubscribe
Filtered subscribe to a topic.
Format
The Format operator is similar to the FileSink, TCPSink, and UDPSink operators, in that it converts SPL tuples into formatted data.
FunctionEvaluator
The FunctionEvaluator operator applies a function to each value in a time series.
Functor
The Functor operator is used to transform input tuples into output ones, and optionally filter them as in a Filter operator.
GAMLearner
The GAMLearner operator applies the generalized additive model (GAM) algorithm to categorical or continuous time series data.
GAMScorer
The GAMScorer operator applies a generalized additive model to score the input time series values.
GMM
The GMM operator uses a Gaussian mixture model to estimate the probability density function (a smoothed histogram) of a time series.
Gate
The Gate operator is used to control the rate at which tuples are passed through.
Generator
The Generator operator generates a sine, triangular, sawtooth, or a pulse train representation of a time series.
Geofence
The Geofence operator is used to manage user-defined geographical regions called geofences and provide information as entities move in and out of of these regions.
HBASEDelete
The HBASEDelete operator deletes an entry, an entire row, a columnFamily in a row, or a columnFamily, columnQualifier pair in a row from HBASE.
HBASEGet
The HBASEGet operator gets tuples from HBASE.
HBASEIncrement
The HBASEIncrement operator increments the specified HBASE entry.
HBASEPut
The HBASEPut operator puts tuples in HBASE.
HBASEScan
The HBASEScan operator scans an HBASE table.
HDFS2DirectoryScan
The HDFS2DirectoryScan operator scans a Hadoop Distributed File System directory for new or modified files.
HDFS2FileSink
The HDFS2FileSink operator writes files to a Hadoop Distributed File System.
HDFS2FileSource
The HDFS2FileSource operator reads files from a Hadoop Distributed File System (HDFS).
HTTPGetStream
Connects to an HTTP endpoint, reads "chunks" of data and sends it to the output port.
HTTPPost
This operator sends incoming tuples to the specified HTTP server as part of a POST request.
Hangout
The Hangout operator is used to detect a basic pattern about a moving entity's location called a hangout.
HoltWinters
DEPRECATED: The com.ibm.streams.timeseries.modeling.HoltWinters operator is deprecated and is replaced by the com.ibm.streams.timeseries.modeling.HoltWinters2 operator. The deprecated operator might be removed in a future release.
HoltWinters2
The HoltWinters2 operator is a forecasting operator, which uses the Holt-Winters algorithm to do long-term forecasting.
HostProfiling
The HostProfiling operator analyzes DNS response traffic and reports whether or not the behaviour of the hosts are suspicious.
IPASNEnricher
This operator enriches IPv4 and IPv6 addresses with ASN data.
IPAddressLocation
IPAddressLocation is an operator for the IBM InfoSphere Streams product that finds the geographical location of IP addresses received in input tuples, based on the subnets they are part of, and emits output tuples containing the country, state or province, city, latitude, and longitude of the subnets.
IPFIXMessageParser
IPFIXMessageParser is an operator for the IBM InfoSphere Streams product that parses individual fields of IPFIX messages received in input tuples, and emits tuples containing message data.
IPSpatialEnricher
This operator enriches IPv4 and IPv6 addresses with geospatial data.
Import
The Import operator receives tuples from streams that are made available by Export operators of applications that are running in the same streaming middleware instance.
IncrementalInterpolate
The IncrementalInterpolate operator calculates missing values in a time series.
InetSource
The InetSource operator periodically retrieves data from network servers and generates a stream from those contents.
IotPlatform
Application providing integration with an IBM Watson IoT Platform organization.
IotPlatformBluemix
Application providing integration with an IBM Watson IoT Platform Bluemix service.
JDBCRun
The JDBCRun operator runs a user-defined SQL statement that is based on an input tuple.
JMSSink
The JMSSink operator creates messages from InfoSphere Streams tuples and writes the messages to a WebSphere MQ or an Apache Active MQ queue or topic.
JMSSource
The JMSSource operator reads data from a WebSphere MQ or an Apache Active MQ queue or a topic and creates tuples from the read data.
JSONToTuple
This operator converts JSON strings into SPL Tuples.
JavaOp
The JavaOp operator is used to call out to operators implemented in Java by using the Java Operator API.
JobControlPlane
The JobControlPlane composite operator must be added to any application with a consistent region.
Join
The Join operator is used to correlate tuples from two streams that are based on user-specified match predicates and window configurations.
KMeansClustering
Cluster analysis is a popular technique used to find natural grouping of a set of objects.
KafkaConsumer
This operator acts as a Kafka consumer receiving messages for one or more topics.
KafkaProducer
This operator acts as a Kafka producer sending tuples as messages to a Kafka broker.
Kalman
The Kalman operator runs an adaptive filter on a time series and can used for tracking, smoothing, adaptation.
LPC
The Linear Predictive Coding (LPC) operator uses an autoregressive (AR) model to predict values in a time series.
MQTTSink
The MQTTSink operator creates a message for every tuple it receives on its input port and publishes the message to an MQTT server.
MQTTSource
The MQTTSource operator subscribes to MQTT topics and receives messages when they are published to subscribed topics.
MapStore
The MapStore operator stores geometry data for the edge network in a shared map store, which the PointMapMatcher operator can access.
MatchRegex
The MatchRegex operator matches a regular expression pattern over the sequence of input tuples to detect composite events.
MetricsSink
The MetricsSink operator reads tuples and populates metrics with the values.
NetezzaLoad
The NetezzaLoad operator performs high speed loads into a Netezza database.
NetezzaPrepareLoad
The NetezzaPrepareLoad operator converts an incoming tuple to a delimited string, which can be written to Netezza with its external table interface.
NetflowMessageParser
NetflowMessageParser is an operator for the IBM InfoSphere Streams product that parses individual fields of Netflow messages received in input tuples, and emits tuples containing message data.
Normalize
The Normalize operator incrementally estimates the means and variance and can normalize the time series to zero means and unit variance.
ODBCAppend
The ODBCAppend operator stores an input stream into a database management system table.
ODBCEnrich
The ODBCEnrich operator generates a stream from an input tuple and the result set of an SQL SELECT statement.
ODBCRun
The ODBCRun operator runs a user-defined SQL statement that is based on an input tuple.
ODBCSource
The ODBCSource operator generates an output stream from the result set of an SQL SELECT statement.
ODMCompiledRuleset
This operator is for internal use only by the ODM rules compiler.
ODMCompiledRulesetUpdateRouter
This operator is for internal use only by the ODM rules compiler.
ODMRulesetExecutor
The ODMRulesetExecutor operator creates input ruleset parameters from IBM InfoSphere Streams tuples and converts the output ruleset parameters that are generated by the ODM Rules Execution Server to tuples.
OSMCorrelator
The OSMCorrelator correlates information read by the OSMXMLGeometrySource to map generated edge IDs back to the original Way ID from the OpenStreetMaps map (.osm file).
OSMPointMatcher
The OSMPointMapMatcher composite analyzes time based object location data to heuristically project points on a network of roads specified by an OpenStreetMaps XML map file.
OSMXMLGeometrySource
OSMXMLGeometrySource reads in an OSM XML map file (.osm file) and generates geometry tuples for consumption by the PointMapMatcher and PathMapMatcher operators.
OpportunityRater
The OpportunityRater operator uses use a fairly simple analytic for identifying opportunities.
PSAX
The PSAX operator is capable of providing a symbolic representation of real-valued time series data.
PacketContentAssembler
PacketContentAssembler is an operator for the IBM InfoSphere Streams product that reassembles application flows (such as SMTP, FTP, HTTP, and SIP) and files (such as GIF, JPEG, HTML, and and PDF) from raw network packets received in input tuples, and emits tuples containing the reassembled content.
PacketDPDKSource
PacketDPDKSource is an operator for the IBM InfoSphere Streams product that captures live network packets from one of the network interfaces attached to the machine where it executes.
PacketFileSource
PacketFileSource is an operator for the IBM InfoSphere Streams product that reads prerecorded network packets from 'packet capture (PCAP)' files, parses the network headers, and emits tuples containing packet data.
PacketLiveSource
PacketLiveSource is an operator for the IBM InfoSphere Streams product that captures live network packets from an ethernet interface, parses their network headers, and emits tuples containing packet data.
Pair
The Pair operator is used to pair tuples from two or more streams.
Parse
The Parse operator is similar to the FileSource, TCPSource, and UDPSource operators, in that it transforms input data in a raw form into well-structured SPL tuples.
PointMapMatcher
The PointMapMatcher operator analyzes time based object location data to heuristically project points on a network of edges, as the original data may be imprecise.
PredictiveBlacklisting
The PredictiveBlacklisting operator analyzes the feature vector produced by the PredictiveBlacklistingFE operator using an SPSS model.
PredictiveBlacklistingFE
The PredictiveBlacklistingFE operator ingests DNS response traffic and outputs a feature vector that is used by the PredictiveBlacklisting operator.
Publish
Publish a stream to a topic.
PublishDeviceCommands
Publishes all device commands for an organization.
PublishDeviceEvents
Publishes all device events for an organization.
PublishDeviceStatuses
Publishes all device statuses for an organization.
Punctor
The Punctor operator is used to transform input tuples into output ones and add window punctuation to the output.
QRadarSink
This operator allows Streams applications to send syslog messages to a QRadar host.
Quickstart
Quickstart application that subscribes to a single quickstart device's events.
QuickstartDeviceEvents
Subscribe to a device's events for Quickstart.
RLSFilter
The Recursive Least Squares (RLS) is linear regression estimation algorithm that learns to predict a target time series, given inputs.
RScript
The RScript operator maps input tuple attributes to objects that can be used in R commands.
RabbitMQSink
This operator acts as a RabbitMQ producer, sending messages to a RabbitMQ broker.
RabbitMQSource
This operator acts as a RabbitMQ consumer, pulling messages from a RabbitMQ broker.
ReSample
The ReSample operator changes the sampling rate of a time series.
Regression
The Regression operator calculates the predicted value and the predicted standard deviation for each tuple in the input stream and automatically assigns those values to output stream attributes.
ReplayableStart
The ReplayableStart operator forwards tuples and punctuations from its input port to its output port.
STD
DEPRECATED: The com.ibm.streams.timeseries.analysis.STD operator is deprecated and is replaced by the com.ibm.streams.timeseries.analysis.STD2 operator. The deprecated operator might be removed in a future release.
STD2
The Seasonal Trend Decomposition (STD) operator uses the Loess algorithm to decompose an input time series into three components: the season, the trend and the residuals.
ScheduledBeacon
The ScheduledBeacon operator is a utility source that generates tuples on-the-fly.
SendCommandToDevice
Send commands to devices registered for an IBM Watson IoT Platform organization.
SentimentExtractor
This operator analyzes a portion of text and determines what kind of sentiment the text expresses.
Sort
The Sort operator is used to order tuples that are based on user-specified ordering expressions and window configurations.
SparkClusteringKMeans
This operator provides support for analysis of incoming tuple data against Apache Spark's kmeans clustering machine learning library.
SparkCollaborativeFilteringALS
This operator provides support for analysis of incoming tuple data against Apache Spark's collaborative filtering machine learning library.
SparkDecisionTree
This operator provides support for analysis of incoming tuple data against Apache Spark's decision tree machine learning library.
SparkEnsembleGradientBoostedTrees
This operator provides support for analysis of incoming tuple data against Apache Spark's decision tree ensembles machine learning library.
SparkEnsembleRandomForest
This operator provides support for analysis of incoming tuple data against Apache Spark's decision tree ensembles machine learning library.
SparkIsotonicRegression
This operator provides support for analysis of incoming tuple data against Apache Spark's isotonic regression machine learning library.
SparkLinearRegression
This operator provides support for analysis of incoming tuple data against Apache Spark's linear regression machine learning library.
SparkLinearSVM
This operator provides support for analysis of incoming tuple data against Apache Spark's SVM machine learning library.
SparkLogisticRegression
This operator provides support for analysis of incoming tuple data against Apache Spark's logistic regression machine learning library.
SparkNaiveBayes
This operator provides support for analysis of incoming tuple data against Apache Spark's naive bayes machine learning library.
SpatialGridIndex
The SpatialGridIndex operator stores objects and their location.
SpatialRouter
The SpatialRouter operator is used to split an input stream that contains geographical data into two or more output streams, based on the geographic location specified by each tuple.
Split
The Split operator is used to split a stream into one or more output streams, which are based on a user-specified split condition.
StatusesSubscribe
Subscribe to device status updates published under the streams topic streamsx/iot/device/statuses.
StreamToFIXMessage
The StreamToFixMessage operator takes a stream of attributes and converts it to a valid Financial Information eXchange (FIX) message.
StructureParse
The StructureParse operator parses a binary data stream, which contains fixed-size structures; therefore, the data is passed in using a blob attribute.
Subscribe
Subscribe to topics using a topic filter.
SubscribeDeviceCommands
Subsribes to device commands to be sent to devices for an organization.
Switch
The Switch operator is used to temporarily stop tuples from flowing.
TCPSink
The TCPSink operator writes data to a TCP socket in the form of tuples.
TCPSource
The TCPSource operator reads data from a TCP socket and creates tuples out of it.
TSWindowing
The TSWindowing operator can be used to isolate a portion of the signal in a specified duration.
TextExtract
The TextExtract operator facilitates the use of the Text Analytics component of IBM InfoSphere BigInsights in IBM InfoSphere Streams.
ThreadedSplit
The ThreadedSplit operator splits tuples across multiple output ports to improve concurrency.
Throttle
The Throttle operator is used to pace a stream to make it flow at a specified rate.
TrailingPriceStatsCalculator
The TrailingPriceStatsCalculator operator computes the volume-weighted average price (VWAP) of the equities streamed into it, each over a range of the three most-recent trading prices for that equity.
TupleToJSON
This operator converts incoming tuples to JSON String.
UDPSink
The UDPSink operator writes data to a UDP socket in the form of tuples (and punctuation).
UDPSource
The UDPSource operator reads data from a UDP socket and creates tuples and punctuation out of it.
Union
The Union operator merges the streams that are connected to multiple input ports into a single stream.
V1TCPSink
The V1TCPSink operator writes binary data to a TCP socket that is connected to an InfoSphere Streams Version 1.2 TCP Source operator. It can be configured as a TCP server, which listens for a client connection, or as a TCP client, which initiates a connection to a server.
V1TCPSource
The V1TCPSource operator reads binary data from a TCP socket that is connected to a InfoSphere Streams Version 1.2 TCP Sink operator and creates tuples from that data.
VAR
DEPRECATED: The com.ibm.streams.timeseries.modeling.VAR operator is deprecated and is replaced by the com.ibm.streams.timeseries.modeling.VAR2 operator. The deprecated operator might be removed in a future release.
VAR2
The VAR2 operator tracks data movement and predicts the next expected time series by using a multivariate autoregressive model.
VWAPDeltaAggressive
The VWAPDeltaAggressive operator examines the opportunity levels that are coming in from the OpportunityRater operator.
VWAPDeltaConservative
The VWAPDeltaConservative operator examines the opportunity levels that are coming in from the OpportunityRater operator.
ViewAllDevices
Simple application that subscribes to all information for all devices.
WatsonS2T
The WatsonSpeech2Text operator is designed to ingest audio data in the form of a .wav file or RAW audio and output transcriptions of speech in the form of utterances.
XMLParse
The XMLParse operator accepts a single input stream and generates tuples as a result.
XMSSink
The XMSSink operator takes messages from IBM InfoSphere Streams and can send them to a WebSphere MQ queue or topic.
XMSSource
The XMSSource operator reads data from a WebSphere MQ queue or topic and creates tuples out of it.