- cancel() - Method in class com.ibm.streamsx.rest.Job
-
Cancels this job.
- checkMaximumVersion(String, int...) - Method in class com.ibm.streamsx.topology.tester.junit.AbstractTestClass
-
Only run a test at a specific maximum version or lower.
- checkMinimumVersion(String, int...) - Method in class com.ibm.streamsx.topology.tester.junit.AbstractTestClass
-
Only run a test at a specific minimum version or higher.
- checkpointPeriod(long, TimeUnit) - Method in class com.ibm.streamsx.topology.Topology
-
Checkpoint the state of the graph periodically.
- checkStatus(boolean) - Method in interface com.ibm.streamsx.rest.StreamingAnalyticsService
-
Check the status of this Streaming Analytics Service.
- CollectionStreams - Class in com.ibm.streamsx.topology.streams
-
Utilities for streams tuples that are collections of values.
- CollectionStreams() - Constructor for class com.ibm.streamsx.topology.streams.CollectionStreams
-
- CollectionStreams.FlattenCollection<C extends java.util.Collection<T>,T> - Class in com.ibm.streamsx.topology.streams
-
- CollectionStreams.FlattenMap<M extends java.util.Map<K,V>,K,V> - Class in com.ibm.streamsx.topology.streams
-
- colocate(Placeable<?>...) - Method in interface com.ibm.streamsx.topology.context.Placeable
-
Colocate this element with other topology elements so that
at runtime they all execute within the same processing element
(PE or operating system process).
- colocate(Placeable<?>...) - Method in interface com.ibm.streamsx.topology.spl.SPLStream
-
Colocate this element with other topology elements so that
at runtime they all execute within the same processing element
(PE or operating system process).
- com.ibm.streamsx.rest - package com.ibm.streamsx.rest
-
Java bindings for the REST APIs of IBM Streams and Streaming Analytics service.
- com.ibm.streamsx.rest.build - package com.ibm.streamsx.rest.build
-
Java binding for the Build REST APIs of IBM Cloud Pak for Data.
- com.ibm.streamsx.rest.internal - package com.ibm.streamsx.rest.internal
-
- com.ibm.streamsx.rest.internal.icp4d - package com.ibm.streamsx.rest.internal.icp4d
-
- com.ibm.streamsx.topology - package com.ibm.streamsx.topology
-
Java application API for IBM Streams.
- com.ibm.streamsx.topology.consistent - package com.ibm.streamsx.topology.consistent
-
At least once processing using consistent regions.
- com.ibm.streamsx.topology.context - package com.ibm.streamsx.topology.context
-
Context for executing IBM Streams Java topologies.
- com.ibm.streamsx.topology.context.local - package com.ibm.streamsx.topology.context.local
-
- com.ibm.streamsx.topology.file - package com.ibm.streamsx.topology.file
-
File related streams.
- com.ibm.streamsx.topology.function - package com.ibm.streamsx.topology.function
-
Classes that provide the mechanisms to
implement functional transformations on streams.
- com.ibm.streamsx.topology.inet - package com.ibm.streamsx.topology.inet
-
Network access to streaming data.
- com.ibm.streamsx.topology.jobconfig - package com.ibm.streamsx.topology.jobconfig
-
- com.ibm.streamsx.topology.json - package com.ibm.streamsx.topology.json
-
JSON streams.
- com.ibm.streamsx.topology.logic - package com.ibm.streamsx.topology.logic
-
Utilities and implementations of functional logic.
- com.ibm.streamsx.topology.messaging.kafka - package com.ibm.streamsx.topology.messaging.kafka
-
- com.ibm.streamsx.topology.messaging.mqtt - package com.ibm.streamsx.topology.messaging.mqtt
-
- com.ibm.streamsx.topology.spi - package com.ibm.streamsx.topology.spi
-
SPI for adding extensions to the functional api.
- com.ibm.streamsx.topology.spi.builder - package com.ibm.streamsx.topology.spi.builder
-
- com.ibm.streamsx.topology.spi.runtime - package com.ibm.streamsx.topology.spi.runtime
-
- com.ibm.streamsx.topology.spl - package com.ibm.streamsx.topology.spl
-
Integration between Streams SPL and Java applications.
- com.ibm.streamsx.topology.streams - package com.ibm.streamsx.topology.streams
-
Utilities to create and transform streams.
- com.ibm.streamsx.topology.tester - package com.ibm.streamsx.topology.tester
-
Support for testing of topologies.
- com.ibm.streamsx.topology.tester.junit - package com.ibm.streamsx.topology.tester.junit
-
- com.ibm.streamsx.topology.tester.spl - package com.ibm.streamsx.topology.tester.spl
-
- com.ibm.streamsx.topology.tuple - package com.ibm.streamsx.topology.tuple
-
Interfaces for tuple types.
- compareTo(BeaconTuple) - Method in class com.ibm.streamsx.topology.tuple.BeaconTuple
-
- COMPILE_INSTALL_DIR - Static variable in interface com.ibm.streamsx.topology.context.ContextProperties
-
Override IBM Streams install directory for
bundle compilation, defaults to $STREAMS_INSTALL.
- complete(Tester, Condition<?>, long, TimeUnit) - Method in class com.ibm.streamsx.topology.tester.junit.AbstractTestClass
-
Test a topology that may run forever.
- complete(StreamsContext<?>) - Method in interface com.ibm.streamsx.topology.tester.Tester
-
Submit the topology for this tester and wait for it to complete.
- complete(StreamsContext<?>, Condition<?>, long, TimeUnit) - Method in interface com.ibm.streamsx.topology.tester.Tester
-
Submit the topology for this tester and wait for it to complete,
or reach an end condition.
- complete(StreamsContext<?>, Map<String, Object>, Condition<?>, long, TimeUnit) - Method in interface com.ibm.streamsx.topology.tester.Tester
-
- completeAndTestStringOutput(StreamsContext<?>, TStream<?>, long, TimeUnit, String...) - Method in interface com.ibm.streamsx.topology.tester.Tester
-
- completeAndTestStringOutput(StreamsContext<?>, Map<String, Object>, TStream<?>, long, TimeUnit, String...) - Method in interface com.ibm.streamsx.topology.tester.Tester
-
- Condition<T> - Interface in com.ibm.streamsx.topology.tester
-
A test condition on a stream or application under test.
- config(boolean) - Method in class com.ibm.streamsx.rest.internal.ICP4DAuthenticator
-
- config(boolean, boolean) - Method in class com.ibm.streamsx.rest.internal.ICP4DAuthenticator
-
- config(boolean) - Method in class com.ibm.streamsx.rest.internal.StandaloneAuthenticator
-
Configure the authenticator and create service definition information.
- CONFIG - Static variable in interface com.ibm.streamsx.topology.context.JobProperties
-
Configuration for a submitted application.
- CONFIG - Static variable in interface com.ibm.streamsx.topology.spi.builder.Properties.Graph
-
Graph wide configuration.
- CONNECT_TIMEOUT_MILLISECONDS - Static variable in interface com.ibm.streamsx.rest.internal.RestUtils
-
- connectTo(BOperatorInvocation, boolean, BInputPort) - Method in interface com.ibm.streamsx.topology.TStream
-
Internal method.
- ConsistentRegionConfig - Class in com.ibm.streamsx.topology.consistent
-
Immutable consistent region configuration.
- ConsistentRegionConfig() - Constructor for class com.ibm.streamsx.topology.consistent.ConsistentRegionConfig
-
- ConsistentRegionConfig(int) - Constructor for class com.ibm.streamsx.topology.consistent.ConsistentRegionConfig
-
- ConsistentRegionConfig.Trigger - Enum in com.ibm.streamsx.topology.consistent
-
Defines how the drain-checkpoint cycle of a consistent region is triggered.
- constants(List<T>) - Method in class com.ibm.streamsx.topology.Topology
-
Create a stream containing all the tuples in data
.
- consume(InputStream) - Method in interface com.ibm.streamsx.rest.internal.InputStreamConsumer
-
consumes the input stream.
- Consumer<T> - Interface in com.ibm.streamsx.topology.function
-
A function that takes an argument and returns nothing.
- contains(TStream<String>, String) - Static method in class com.ibm.streamsx.topology.streams.StringStreams
-
Create a filtered stream that contains String
tuples containing a
specific term.
- contents(SPLStream) - Method in class com.ibm.streamsx.topology.tester.spl.ExpectedTuples
-
- ContextProperties - Interface in com.ibm.streamsx.topology.context
-
Properties that can be specified when submitting the topology to a context.
- convert(Function<Tuple, T>) - Method in interface com.ibm.streamsx.topology.spl.SPLStream
-
Convert SPL tuples into Java objects.
- convertStream(TStream<T>, BiFunction<T, OutputTuple, OutputTuple>, StreamSchema) - Static method in class com.ibm.streamsx.topology.spl.SPLStreams
-
Convert a Stream
to an SPLStream
.
- create(int, String) - Static method in exception com.ibm.streamsx.rest.RESTException
-
Customized exception that can provide more information on REST errors
- createBasicAuth(JsonObject) - Static method in interface com.ibm.streamsx.rest.internal.RestUtils
-
Create an encoded Basic auth header for the given credentials.
- createBasicAuth(String, String) - Static method in interface com.ibm.streamsx.rest.internal.RestUtils
-
Create an encoded Basic auth header for the given userName and authToken
- createBearerAuth(String) - Static method in interface com.ibm.streamsx.rest.internal.RestUtils
-
Create an encoded Bearer auth header for the given token.
- createBuild(String, JsonObject) - Method in interface com.ibm.streamsx.rest.build.BuildService
-
Submit an archive to build using the IBM Streams build service.
- createCustomMetric(String, String, String, LongSupplier) - Method in interface com.ibm.streamsx.topology.function.FunctionContext
-
Create a custom metric.
- createExecutor() - Static method in interface com.ibm.streamsx.rest.internal.RestUtils
-
- createExecutor(boolean) - Static method in interface com.ibm.streamsx.rest.internal.RestUtils
-
- createHttpClient() - Static method in interface com.ibm.streamsx.rest.internal.RestUtils
-
- createHttpClient(boolean) - Static method in interface com.ibm.streamsx.rest.internal.RestUtils
-
- createInstance(String, String, String) - Static method in class com.ibm.streamsx.rest.StreamsConnection
-
Create a connection to IBM Streams REST API.
- createJobRun(JobDescription, String, JsonArray) - Method in interface com.ibm.streamsx.rest.internal.icp4d.ICP4DService
-
Creates a Job run for a job description
- createJobRun(JobDescription, String, JsonArray) - Method in class com.ibm.streamsx.rest.internal.icp4d.ICP4DServiceImpl
-
Creates a Job run for a job description via REST.
- createList(AbstractConnection, String, Class<A>) - Static method in class com.ibm.streamsx.rest.build.Element
-
- createNullValue() - Static method in class com.ibm.streamsx.topology.spl.SPL
-
Create an SPL value wrapper object for an SPL null value.
- createSubmissionParameter(Topology, String, Object, boolean) - Static method in class com.ibm.streamsx.topology.spl.SPL
-
Create a submission parameter with or without a default value.
- createSubmissionParameter(String, Class<T>) - Method in class com.ibm.streamsx.topology.Topology
-
Create a submission parameter without a default value.
- createSubmissionParameter(String, T) - Method in class com.ibm.streamsx.topology.Topology
-
Create a submission parameter with a default value.
- createValue(T, Type.MetaType) - Static method in class com.ibm.streamsx.topology.spl.SPL
-
Create an SPL value wrapper object for the
specified SPL MetaType
.
- csvCompressedReader(TStream<String>, StreamSchema, FileSPLStreams.Compression) - Static method in class com.ibm.streamsx.topology.spl.FileSPLStreams
-
Create an
SPLStream
using the
spl.adapter::FileSource
operator that reads CSV records from compressed files with names
delivered by
fileNames
.
- csvReader(TStream<String>, StreamSchema) - Static method in class com.ibm.streamsx.topology.spl.FileSPLStreams
-
Create an
SPLStream
using the
spl.adapter::FileSource
operator that reads CSV records from files with names delivered by
fileNames
.
- get() - Method in interface com.ibm.streamsx.topology.function.Supplier
-
- get() - Method in class com.ibm.streamsx.topology.logic.Value
-
Return the constant value.
- getActiveVersion() - Method in class com.ibm.streamsx.rest.Instance
-
Gets information about the IBM Streams Installation that was used to
start this instance
- getApplication() - Method in class com.ibm.streamsx.rest.internal.icp4d.JobRunConfiguration
-
get the link to the SAB; note that the build is deleted when topology.keepArtifacts is not set to True.
- getApplicationConfiguration(String) - Method in interface com.ibm.streamsx.topology.function.FunctionContainer
-
Get the application configuration specified by name.
- getApplicationConsoleURL() - Method in class com.ibm.streamsx.rest.Instance
-
Streams application console URL.
- getApplicationName() - Method in class com.ibm.streamsx.rest.Job
-
Gets the name of the streams processing application that this job is
running
- getArchitecture() - Method in class com.ibm.streamsx.rest.ActiveVersion
-
- getArtifacts() - Method in class com.ibm.streamsx.rest.build.Build
-
- getAsJson() - Method in class com.ibm.streamsx.rest.RESTErrorMessage
-
Gets the json object of this error message
- getAsset_id() - Method in class com.ibm.streamsx.rest.internal.icp4d.JobDescription.MetaData
-
- getAssetId() - Method in class com.ibm.streamsx.rest.internal.icp4d.JobDescription
-
Returns the asset_id of the job, something like "19561431-e6bd-4bfa-8f71-630821ed4e14"
Convenience method for getMetadata().getAsset_id();
- getAuthenticator() - Method in class com.ibm.streamsx.rest.StreamsConnection
-
- getAuthorization() - Method in class com.ibm.streamsx.rest.internal.AbstractConnection
-
Returns the Authorization header without the Authorization: keyword.
- getAuthorization() - Method in class com.ibm.streamsx.rest.internal.icp4d.ICP4DServiceImpl
-
Returns the Authorization header without the Authorization: keyword.
- getBaseImages() - Method in interface com.ibm.streamsx.rest.build.BuildService
-
Gets a list of
baseImages
for EDGE applications available in the build service.
- getBuildVersion() - Method in class com.ibm.streamsx.rest.ActiveVersion
-
- getChannel() - Method in interface com.ibm.streamsx.topology.function.FunctionContext
-
Get the index of the parallel channel the function is on.
- getComposite() - Method in class com.ibm.streamsx.rest.JobSubmitParameters
-
- getConfig() - Method in class com.ibm.streamsx.topology.messaging.kafka.KafkaConsumer
-
Get the connector's KafkaConsumer
configuration information.
- getConfig() - Method in class com.ibm.streamsx.topology.messaging.kafka.KafkaProducer
-
Get the connector's KafkaProducer
configuration information.
- getConfig() - Method in class com.ibm.streamsx.topology.messaging.mqtt.MqttStreams
-
Get the connector's configuration information.
- getConfig() - Method in class com.ibm.streamsx.topology.tester.junit.AbstractTestClass
-
- getConfig() - Method in class com.ibm.streamsx.topology.Topology
-
- getConfiguredHost() - Method in interface com.ibm.streamsx.topology.function.FunctionContainer
-
Get the host this container is executing on.
- getContainer() - Method in interface com.ibm.streamsx.topology.function.FunctionContext
-
Get the container hosting a function
- getCreationTime() - Method in class com.ibm.streamsx.rest.build.Build
-
Gets the time in milliseconds when this domain was created.
- getCreationTime() - Method in class com.ibm.streamsx.rest.Domain
-
Gets the time in milliseconds when this domain was created.
- getCreationTime() - Method in class com.ibm.streamsx.rest.Instance
-
Gets the time in milliseconds when this instance was created
- getCreationUser() - Method in class com.ibm.streamsx.rest.build.Build
-
Gets the user ID that created this build.
- getCreationUser() - Method in class com.ibm.streamsx.rest.Domain
-
Gets the user ID that created this instance.
- getCreationUser() - Method in class com.ibm.streamsx.rest.Instance
-
Gets the user ID that created this instance
- getCurrentWorkingPath() - Method in class com.ibm.streamsx.rest.ProcessingElement
-
Gets the current working path of the processing element
- getCustomMetricNames() - Method in interface com.ibm.streamsx.topology.function.FunctionContext
-
Get the set of custom metric names created in this context.
- getDataDirectory() - Method in class com.ibm.streamsx.topology.jobconfig.JobConfig
-
Get the data directory.
- getDefaultDomainId() - Static method in class com.ibm.streamsx.topology.context.StreamsContextFactory
-
Get the default Streams domain identifier.
- getDefaultInstanceId() - Static method in class com.ibm.streamsx.topology.context.StreamsContextFactory
-
Get the default Streams instance identifier.
- getDefaultStreamsInstall() - Static method in class com.ibm.streamsx.topology.context.StreamsContextFactory
-
Get the default Streams install location.
- getDefaultTesterType() - Method in class com.ibm.streamsx.topology.tester.junit.AbstractTestClass
-
- getDefaultTimeout() - Method in class com.ibm.streamsx.topology.tester.junit.AbstractTestClass
-
- getDefaultValue() - Method in class com.ibm.streamsx.rest.JobSubmitParameters
-
- getDependencies() - Method in class com.ibm.streamsx.rest.build.Toolkit
-
- getDependencyResolver() - Method in class com.ibm.streamsx.topology.Topology
-
Internal use only.
- getDescription() - Method in class com.ibm.streamsx.rest.internal.icp4d.DeploymentSpace.Entity
-
- getDescription() - Method in class com.ibm.streamsx.rest.internal.icp4d.JobDescription.MetaData
-
- getDescription() - Method in class com.ibm.streamsx.rest.Metric
-
Gets the description for this metric
- getDirectory() - Method in class com.ibm.streamsx.topology.file.DirectoryWatcher
-
- getDisplayName() - Method in class com.ibm.streamsx.rest.Resource
-
Get the display name for this resource.
- getDomain() - Method in class com.ibm.streamsx.rest.Instance
-
Get the Streams domain for this instance.
- getDomainId() - Method in interface com.ibm.streamsx.topology.function.FunctionContainer
-
Return the IBM Streams domain identifier for this container.
- getDrainTimeout() - Method in class com.ibm.streamsx.topology.consistent.ConsistentRegionConfig
-
Get the drain timeout for this configuration.
- getEditionName() - Method in class com.ibm.streamsx.rest.ActiveVersion
-
- getElement() - Method in interface com.ibm.streamsx.rest.Result
-
Get the element associated with the request.
- getEmbedded() - Static method in class com.ibm.streamsx.topology.context.StreamsContextFactory
-
Get an EMBEDDED context
.
- getEncoding() - Method in class com.ibm.streamsx.topology.file.TextFileReader
-
- getEntity() - Method in class com.ibm.streamsx.rest.internal.icp4d.DeploymentSpace
-
- getEntity() - Method in class com.ibm.streamsx.rest.internal.icp4d.JobDescription
-
- getExecutor() - Method in class com.ibm.streamsx.rest.internal.AbstractConnection
-
access to the Executor.
- getFailureReason() - Method in class com.ibm.streamsx.rest.build.Build
-
- getFullProductVersion() - Method in class com.ibm.streamsx.rest.ActiveVersion
-
- getGsonResponse(Executor, String, String) - Static method in interface com.ibm.streamsx.rest.internal.RestUtils
-
Gets a JSON response to an HTTP GET call
- getGsonResponse(Executor, String, URL) - Static method in interface com.ibm.streamsx.rest.internal.RestUtils
-
- getHealth() - Method in class com.ibm.streamsx.rest.Instance
-
Gets the summarized status of jobs in this instance
- getHealth() - Method in class com.ibm.streamsx.rest.Job
-
Gets the health indicator for this job
- getHealth() - Method in class com.ibm.streamsx.rest.ProcessingElement
-
Gets the health indicator for this processing element
- getId() - Method in class com.ibm.streamsx.rest.build.Artifact
-
Gets the IBM Streams unique identifier for this build artifact.
- getId() - Method in class com.ibm.streamsx.rest.build.BaseImage
-
- getId() - Method in class com.ibm.streamsx.rest.build.Build
-
Gets the IBM Streams unique identifier for this build.
- getId() - Method in class com.ibm.streamsx.rest.build.Toolkit
-
Gets the id of this toolkit.
- getId() - Method in class com.ibm.streamsx.rest.Domain
-
Gets the IBM Streams unique identifier for this domain.
- getId() - Method in class com.ibm.streamsx.rest.Instance
-
Gets the IBM Streams unique identifier for this instance
- getId() - Method in class com.ibm.streamsx.rest.internal.icp4d.DeploymentSpace
-
Convenience method for getMetadata().getId().
- getId() - Method in class com.ibm.streamsx.rest.internal.icp4d.DeploymentSpace.MetaData
-
- getId() - Method in class com.ibm.streamsx.rest.Job
-
Gets the id of this job
- getId() - Method in class com.ibm.streamsx.rest.ProcessingElement
-
Gets the id of this processing element
- getId() - Method in class com.ibm.streamsx.rest.Resource
-
Get the unique Streams identifier for this resource.
- getId() - Method in interface com.ibm.streamsx.rest.Result
-
Get the object identifier associated with the request.
- getId() - Method in interface com.ibm.streamsx.topology.function.FunctionContainer
-
Get the runtime identifier for this container.
- getImageDigest() - Method in class com.ibm.streamsx.rest.build.Artifact
-
- getIndex() - Method in class com.ibm.streamsx.rest.build.Toolkit
-
Gets the index of this toolkit.
- getIndexWithinJob() - Method in class com.ibm.streamsx.rest.Operator
-
Gets the index of this operator within the
Job
- getIndexWithinJob() - Method in class com.ibm.streamsx.rest.ProcessingElement
-
Gets the index of this processing element within the
Job
- getIndexWithinOperator() - Method in class com.ibm.streamsx.rest.InputPort
-
Gets the index of this input port within the
Operator
- getIndexWithinOperator() - Method in class com.ibm.streamsx.rest.OutputPort
-
Gets the index of this output port within the
operator
- getIndexWithinPE() - Method in class com.ibm.streamsx.rest.PEInputPort
-
- getIndexWithinPE() - Method in class com.ibm.streamsx.rest.PEOutputPort
-
- getInputPorts() - Method in class com.ibm.streamsx.rest.Operator
-
- getInputPorts() - Method in class com.ibm.streamsx.rest.ProcessingElement
-
- getInstance() - Method in class com.ibm.streamsx.rest.ResourceAllocation
-
Obtain the Instance
this resource is allocated to.
- getInstance() - Method in interface com.ibm.streamsx.rest.StreamingAnalyticsService
-
- getInstance(String) - Method in class com.ibm.streamsx.rest.StreamsConnection
-
Gets a specific
instance
identified by the instanceId at
this IBM Streams connection
- getInstanceId() - Method in interface com.ibm.streamsx.topology.function.FunctionContainer
-
Return the IBM Streams instance identifier for this container.
- getInstances() - Method in class com.ibm.streamsx.rest.StreamsConnection
-
Gets a list of
instances
that are available to this IBM
Streams connection
- getInvocationName() - Method in interface com.ibm.streamsx.topology.context.Placeable
-
Return the invocation name of this element.
- getIpAddress() - Method in class com.ibm.streamsx.rest.Resource
-
Get the IP address for this resource.
- getJob(String) - Method in class com.ibm.streamsx.rest.Instance
-
Gets the
Job
for a given jobId in this instance
- getJob() - Method in class com.ibm.streamsx.rest.internal.icp4d.JobDescription.Entity
-
- getJobGroup() - Method in class com.ibm.streamsx.rest.Job
-
Gets the group this job belongs to
- getJobGroup() - Method in class com.ibm.streamsx.topology.jobconfig.JobConfig
-
Get the job group.
- getJobId() - Method in class com.ibm.streamsx.rest.internal.icp4d.JobRunConfiguration
-
- getJobId() - Method in interface com.ibm.streamsx.topology.function.FunctionContainer
-
Get the runtime identifier for this container's running job.
- getJobName() - Method in interface com.ibm.streamsx.topology.function.FunctionContainer
-
Return the name of this job.
- getJobName() - Method in class com.ibm.streamsx.topology.jobconfig.JobConfig
-
Get the job name.
- getJobs() - Method in class com.ibm.streamsx.rest.Instance
-
Gets a list of
jobs
that this instance knows about
- getJobs() - Method in class com.ibm.streamsx.rest.ResourceAllocation
-
Gets a list of jobs running on this resource in this instance.
- getJobsRestUrl() - Method in interface com.ibm.streamsx.rest.internal.icp4d.ICP4DService
-
Returns the REST URl for the jobs REST API, for example https://host.com/v2/jobs
- getJobsRestUrl() - Method in class com.ibm.streamsx.rest.internal.icp4d.ICP4DServiceImpl
-
- getJSON(TopologyElement, String, long, TimeUnit) - Static method in class com.ibm.streamsx.topology.inet.HTTPStreams
-
Periodically poll a web service using HTTP GET
for
application/json
data.
- getJsonValue() - Method in enum com.ibm.streamsx.rest.internal.BuildType
-
- getKey() - Method in class com.ibm.streamsx.topology.tuple.BeaconTuple
-
Get the key (sequence identifier) of this tuple.
- getKey() - Method in interface com.ibm.streamsx.topology.tuple.Keyable
-
Returns the partition key for this tuple.
- getKey() - Method in interface com.ibm.streamsx.topology.tuple.Message
-
Get the message key for this object.
- getKey() - Method in class com.ibm.streamsx.topology.tuple.SimpleMessage
-
- getLastTimeRetrieved() - Method in class com.ibm.streamsx.rest.Metric
-
Gets the Epoch time when the metric was most recently retrieved
- getLaunchCount() - Method in class com.ibm.streamsx.rest.ProcessingElement
-
Gets the number of times this processing element was started manually or
automatically because of failures
- getLogicalName() - Method in class com.ibm.streamsx.rest.Operator
-
The logical name of this operator.
- getLogMessages() - Method in class com.ibm.streamsx.rest.build.Build
-
- getMaxChannels() - Method in interface com.ibm.streamsx.topology.function.FunctionContext
-
Get the total number of parallel channels for the parallel region that
the function is in.
- getMaxConsecutiveResetAttempts() - Method in class com.ibm.streamsx.topology.consistent.ConsistentRegionConfig
-
Get the maximum number of consecutive reset attempts.
- getMessage() - Method in class com.ibm.streamsx.rest.RESTErrorMessage
-
Gets the error message
- getMessage() - Method in interface com.ibm.streamsx.topology.tuple.Message
-
Get the message content for this object.
- getMessage() - Method in class com.ibm.streamsx.topology.tuple.SimpleMessage
-
- getMessageId() - Method in class com.ibm.streamsx.rest.RESTErrorMessage
-
Gets the id of this error message
- getMetadata() - Method in class com.ibm.streamsx.rest.internal.icp4d.DeploymentSpace
-
- getMetaData() - Method in class com.ibm.streamsx.rest.internal.icp4d.JobDescription
-
- getMetricKind() - Method in class com.ibm.streamsx.rest.Metric
-
Describes the kind of metric that has been retrieved
- getMetrics() - Method in class com.ibm.streamsx.rest.build.Build
-
- getMetrics() - Method in class com.ibm.streamsx.rest.InputPort
-
Gets the
metrics
for this input port
- getMetrics() - Method in class com.ibm.streamsx.rest.Operator
-
Gets a list of
metrics
for this operator
- getMetrics() - Method in class com.ibm.streamsx.rest.OutputPort
-
Gets the
metrics
for this output port
- getMetrics() - Method in class com.ibm.streamsx.rest.PEInputPort
-
Gets the
metrics
for this processing element input port
- getMetrics() - Method in class com.ibm.streamsx.rest.PEOutputPort
-
Gets the
metrics
for this output port
- getMetrics() - Method in class com.ibm.streamsx.rest.ProcessingElement
-
Gets a list of
metrics
for this processing element
- getMetrics() - Method in class com.ibm.streamsx.rest.Resource
-
Gets the
metrics
for this resource.
- getMetricType() - Method in class com.ibm.streamsx.rest.Metric
-
Describes the type of metric that has been retrieved
- getMinimumOSBaseVersion() - Method in class com.ibm.streamsx.rest.ActiveVersion
-
- getMinimumOSPatchVersion() - Method in class com.ibm.streamsx.rest.ActiveVersion
-
- getMinimumOSVersion() - Method in class com.ibm.streamsx.rest.ActiveVersion
-
- getName() - Method in class com.ibm.streamsx.rest.build.Artifact
-
Gets the name for this build artifact.
- getName() - Method in class com.ibm.streamsx.rest.build.BaseImage
-
- getName() - Method in class com.ibm.streamsx.rest.build.Build
-
Gets the name for this build.
- getName() - Method in class com.ibm.streamsx.rest.build.BuildPool
-
- getName() - Method in class com.ibm.streamsx.rest.build.Toolkit.Dependency
-
Gets the name of the dependent
toolkit
.
- getName() - Method in class com.ibm.streamsx.rest.build.Toolkit
-
Gets the name of this toolkit.
- getName() - Method in class com.ibm.streamsx.rest.InputPort
-
Gets the name for this input port
- getName() - Method in class com.ibm.streamsx.rest.internal.icp4d.DeploymentSpace.Entity
-
- getName() - Method in class com.ibm.streamsx.rest.internal.icp4d.DeploymentSpace
-
Convenience method for getEntity().getName().
- getName() - Method in class com.ibm.streamsx.rest.internal.icp4d.JobDescription
-
Returns the name of the job.
- getName() - Method in class com.ibm.streamsx.rest.internal.icp4d.JobDescription.MetaData
-
- getName() - Method in class com.ibm.streamsx.rest.Job
-
Gets the name of this job
- getName() - Method in class com.ibm.streamsx.rest.JobSubmitParameters
-
- getName() - Method in class com.ibm.streamsx.rest.Metric
-
Gets the name of this metric
- getName() - Method in class com.ibm.streamsx.rest.Operator
-
Name of this operator
- getName() - Method in class com.ibm.streamsx.rest.OutputPort
-
Gets the name for this output port
- getName() - Method in interface com.ibm.streamsx.rest.StreamingAnalyticsService
-
Get the service name.
- getName() - Method in class com.ibm.streamsx.topology.jobconfig.SubmissionParameter
-
- getName() - Method in class com.ibm.streamsx.topology.Topology
-
Name of this topology.
- getNamespace() - Method in class com.ibm.streamsx.topology.Topology
-
Namespace of this topology.
- getOperatorKind() - Method in class com.ibm.streamsx.rest.Operator
-
SPL primitive operator type for this operator
- getOperators() - Method in class com.ibm.streamsx.rest.Job
-
- getOperators() - Method in class com.ibm.streamsx.rest.ProcessingElement
-
Gets a list of
operators
for this processing element
- getOptionalConnections() - Method in class com.ibm.streamsx.rest.ProcessingElement
-
Gets the status of optional connections for this processing element.
- getOrCreateJobDescription(String, String, String) - Method in interface com.ibm.streamsx.rest.internal.icp4d.ICP4DService
-
Gets or creates a CP4D job description associated with either a project or a deployment space.
- getOrCreateJobDescription(String, String, String) - Method in class com.ibm.streamsx.rest.internal.icp4d.ICP4DServiceImpl
-
Gets or creates a CP4D job description associated with either a project or a deployment space.
- getOrCreateSpace(String) - Method in interface com.ibm.streamsx.rest.internal.icp4d.ICP4DService
-
Gets or creates a CP4D deployment space.
- getOrCreateSpace(String) - Method in class com.ibm.streamsx.rest.internal.icp4d.ICP4DServiceImpl
-
Gets or creates a CP4D deployment space.
- getOsCapabilities() - Method in class com.ibm.streamsx.rest.ProcessingElement
-
Gets a list of the operating system capabilities
- getOutputPorts() - Method in class com.ibm.streamsx.rest.Operator
-
- getOutputPorts() - Method in class com.ibm.streamsx.rest.ProcessingElement
-
- getOverrideResourceLoadProtection() - Method in class com.ibm.streamsx.topology.jobconfig.JobConfig
-
- getOwner() - Method in class com.ibm.streamsx.rest.Instance
-
Gets the user ID that represents the owner of this instance
- getOwner_id() - Method in class com.ibm.streamsx.rest.internal.icp4d.JobDescription.MetaData
-
- getParameterKind() - Method in class com.ibm.streamsx.rest.JobSubmitParameters
-
- getPath() - Method in class com.ibm.streamsx.rest.build.Toolkit
-
Gets the path to the toolkit on the build service.
- getPE() - Method in class com.ibm.streamsx.rest.Operator
-
Get the PE for this operator.
- getPendingTracingLevel() - Method in class com.ibm.streamsx.rest.ProcessingElement
-
Describes a pending change to the granularity of the trace information
that is stored for this processing element.
- getPeriod() - Method in class com.ibm.streamsx.topology.consistent.ConsistentRegionConfig
-
Get the trigger period.
- getPes() - Method in class com.ibm.streamsx.rest.Instance
-
- getPes() - Method in class com.ibm.streamsx.rest.Job
-
- getPes() - Method in class com.ibm.streamsx.rest.ResourceAllocation
-
Gets a list of processing elements running on this resource in this instance.
- getPrefix() - Method in class com.ibm.streamsx.rest.build.BaseImage
-
- getPreloadApplicationBundles() - Method in class com.ibm.streamsx.topology.jobconfig.JobConfig
-
- getProcessId() - Method in class com.ibm.streamsx.rest.ProcessingElement
-
Gets the operating system process ID for this processing element
- getProductName() - Method in class com.ibm.streamsx.rest.ActiveVersion
-
- getProductVersion() - Method in class com.ibm.streamsx.rest.ActiveVersion
-
- getProductVersion() - Method in class com.ibm.streamsx.rest.Instance
-
Gets the product version, please note that this is null for Streams version < 5.2
- getProject_id() - Method in class com.ibm.streamsx.rest.internal.icp4d.JobDescription.MetaData
-
- getRawResult() - Method in interface com.ibm.streamsx.rest.Result
-
Get the raw result from the request.
- getRegistry() - Method in class com.ibm.streamsx.rest.build.BaseImage
-
- getRelaunchCount() - Method in interface com.ibm.streamsx.topology.function.FunctionContainer
-
Return the number of times this container has been relaunched.
- getRelocatable() - Method in class com.ibm.streamsx.rest.ProcessingElement
-
Indicates whether or not this processing element can be relocated to a
different resource
- getRequiredConnections() - Method in class com.ibm.streamsx.rest.ProcessingElement
-
Status of the required connections for this processing element.
- getRequiredProductVersion() - Method in class com.ibm.streamsx.rest.build.Toolkit
-
Gets the minimum version of IBM Streams required to use this toolkit.
- getResetTimeout() - Method in class com.ibm.streamsx.topology.consistent.ConsistentRegionConfig
-
Get the reset timeout for this configuration.
- getResource() - Method in class com.ibm.streamsx.rest.ResourceAllocation
-
Obtain the Resource
object for detailed information
on the resource.
- getResourceAllocation() - Method in class com.ibm.streamsx.rest.ProcessingElement
-
- getResourceAllocations() - Method in class com.ibm.streamsx.rest.Instance
-
- getResourceAllocations() - Method in class com.ibm.streamsx.rest.Job
-
- getResourceTags() - Method in class com.ibm.streamsx.rest.ProcessingElement
-
Gets a list of resource tags for this processing element
- getResourceTags() - Method in interface com.ibm.streamsx.topology.context.Placeable
-
Get the set of resource tags this element requires.
- getResourceType() - Method in class com.ibm.streamsx.rest.build.Toolkit
-
Identifies the Build REST resource type.
- getResourceType() - Method in class com.ibm.streamsx.rest.InputPort
-
Identifies the REST resource type
- getResourceType() - Method in class com.ibm.streamsx.rest.Instance
-
Identifies the REST resource type
- getResourceType() - Method in class com.ibm.streamsx.rest.Job
-
Identifies the REST resource type
- getResourceType() - Method in class com.ibm.streamsx.rest.Metric
-
Identifies the REST resource type
- getResourceType() - Method in class com.ibm.streamsx.rest.Operator
-
Identifies the REST resource type
- getResourceType() - Method in class com.ibm.streamsx.rest.OutputPort
-
Identifies the REST resource type
- getResourceType() - Method in class com.ibm.streamsx.rest.PEInputPort
-
Identifies the REST resource type
- getResourceType() - Method in class com.ibm.streamsx.rest.PEOutputPort
-
Identifies the REST resource type
- getResourceType() - Method in class com.ibm.streamsx.rest.ProcessingElement
-
Identifies the REST resource type
- getResourceType() - Method in class com.ibm.streamsx.rest.Resource
-
Identifies the REST resource type
- getResourceType() - Method in class com.ibm.streamsx.rest.ResourceAllocation
-
Identifies the REST resource type
- getResponseString(String) - Method in class com.ibm.streamsx.rest.internal.AbstractConnection
-
Gets a response to an HTTP call
- getResponseString(Executor, String, String) - Static method in interface com.ibm.streamsx.rest.internal.RestUtils
-
Gets a response to an HTTP GET call as a string
- getRestartable() - Method in class com.ibm.streamsx.rest.ProcessingElement
-
Indicates whether or not this processing element can be restarted
- getRestid() - Method in class com.ibm.streamsx.rest.build.BaseImage
-
- getRestid() - Method in class com.ibm.streamsx.rest.build.BuildPool
-
- getResult() - Method in interface com.ibm.streamsx.rest.internal.InputStreamConsumer
-
Gets the Object created after consuming the InputStream
- getResult() - Method in interface com.ibm.streamsx.topology.tester.Condition
-
- getScheduledExecutorService() - Method in interface com.ibm.streamsx.topology.function.FunctionContext
-
Return a scheduler to execute background tasks.
- getSchedulerStatus() - Method in class com.ibm.streamsx.rest.ResourceAllocation
-
Status of the resource.
- getSchema() - Method in interface com.ibm.streamsx.topology.spl.SPLStream
-
SPL schema of this stream.
- getSchema() - Method in class com.ibm.streamsx.topology.tester.spl.ExpectedTuples
-
Get the schema of the tuples.
- getSequence() - Method in class com.ibm.streamsx.topology.tuple.BeaconTuple
-
Get the sequence identifier of this tuple.
- getSize() - Method in class com.ibm.streamsx.rest.build.Artifact
-
- getSpace_id() - Method in class com.ibm.streamsx.rest.internal.icp4d.JobDescription.MetaData
-
- getSpaceIdForName(String) - Method in interface com.ibm.streamsx.rest.internal.icp4d.ICP4DService
-
Gets the spaceId for a deployment space given by its name.
- getSpaceIdForName(String) - Method in class com.ibm.streamsx.rest.internal.icp4d.ICP4DServiceImpl
-
Gets the spaceId for a deployment space given by its name.
- getSpacesRestUrl() - Method in interface com.ibm.streamsx.rest.internal.icp4d.ICP4DService
-
Returns the REST URl for the spaces REST API, for example https://host.com/v2/spaces
- getSpacesRestUrl() - Method in class com.ibm.streamsx.rest.internal.icp4d.ICP4DServiceImpl
-
- getStartedBy() - Method in class com.ibm.streamsx.rest.Job
-
Identifies the user ID that started this job
- getStartTime() - Method in class com.ibm.streamsx.rest.Instance
-
Gets the time in milliseconds when the instance was started.
- getStatus() - Method in class com.ibm.streamsx.rest.build.Build
-
Gets the status of the build.
- getStatus() - Method in class com.ibm.streamsx.rest.Domain
-
Gets the status of the domain.
- getStatus() - Method in class com.ibm.streamsx.rest.Instance
-
Gets the status of the instance
- getStatus() - Method in class com.ibm.streamsx.rest.Job
-
Describes the status of this job
- getStatus() - Method in class com.ibm.streamsx.rest.ProcessingElement
-
Gets the status of this processing element
- getStatus() - Method in class com.ibm.streamsx.rest.Resource
-
Status of the resource.
- getStatus() - Method in class com.ibm.streamsx.rest.ResourceAllocation
-
Scheduler status of the resource.
- getStatusCode() - Method in exception com.ibm.streamsx.rest.RESTException
-
Gets the error status code for this exception
- getStatusReason() - Method in class com.ibm.streamsx.rest.ProcessingElement
-
Gets additional status for this processing element
- getStream() - Method in interface com.ibm.streamsx.topology.spl.SPLInput
-
- getStream() - Method in interface com.ibm.streamsx.topology.spl.SPLWindow
-
SPL stream for this window.
- getStream() - Method in interface com.ibm.streamsx.topology.TWindow
-
Get this window's stream.
- getStreamName() - Method in class com.ibm.streamsx.rest.OutputPort
-
Identifies the name of the output stream associated with this output port
- getStreamsConnection() - Method in class com.ibm.streamsx.rest.Element
-
- getStreamsContext(String) - Static method in class com.ibm.streamsx.topology.context.StreamsContextFactory
-
Get a StreamsContext
from its type name.
- getStreamsContext(StreamsContext.Type) - Static method in class com.ibm.streamsx.topology.context.StreamsContextFactory
-
Get a StreamsContext
from its type.
- getStreamsErrorMessageAsJson() - Method in exception com.ibm.streamsx.rest.RESTException
-
Gets the IBM Streams message for this exception as a Json Object
- getStreamsErrorMessageId() - Method in exception com.ibm.streamsx.rest.RESTException
-
Gets the IBM Streams message ID for this exception
- getStreamsInstance() - Method in class com.ibm.streamsx.rest.internal.icp4d.JobRunConfiguration
-
Returns the Streams instance name
- getStreamsTracing() - Method in class com.ibm.streamsx.topology.jobconfig.JobConfig
-
- getSubmissionParameters() - Method in class com.ibm.streamsx.topology.jobconfig.JobConfig
-
Get the submission parameters.
- getSubmitParameters() - Method in class com.ibm.streamsx.rest.Job
-
Gets the list of
parameters
that were
submitted to this job
- getSubmitTime() - Method in class com.ibm.streamsx.rest.Job
-
Gets the Epoch time when this job was submitted
- getTag() - Method in class com.ibm.streamsx.rest.build.BaseImage
-
- getTester() - Method in class com.ibm.streamsx.topology.Topology
-
Get the tester for this topology.
- getTesterContext() - Method in class com.ibm.streamsx.topology.tester.junit.AbstractTestClass
-
Return the default context for tests.
- getTesterType() - Method in class com.ibm.streamsx.topology.tester.junit.AbstractTestClass
-
- getThreadFactory() - Method in interface com.ibm.streamsx.topology.function.FunctionContext
-
Return a ThreadFactory that can be used by the function with the thread context
class loader set correctly.
- getTime() - Method in class com.ibm.streamsx.topology.tuple.BeaconTuple
-
Get the time of this tuple.
- getTimeUnit() - Method in class com.ibm.streamsx.topology.consistent.ConsistentRegionConfig
-
- getToolkit(String) - Method in interface com.ibm.streamsx.rest.build.BuildService
-
Gets a
toolkit
installed on the IBM Streams build
service.
- getToolkits() - Method in class com.ibm.streamsx.rest.build.BuildPool
-
- getToolkits() - Method in interface com.ibm.streamsx.rest.build.BuildService
-
Gets a list of
toolkits
installed on the IBM Streams
build service.
- getTopic() - Method in interface com.ibm.streamsx.topology.tuple.Message
-
Get the message topic for this object.
- getTopic() - Method in class com.ibm.streamsx.topology.tuple.SimpleMessage
-
- getTopology() - Method in interface com.ibm.streamsx.topology.tester.Tester
-
Get the topology for this tester.
- getTracing() - Method in class com.ibm.streamsx.topology.jobconfig.JobConfig
-
- getTracingLevel() - Method in class com.ibm.streamsx.rest.ProcessingElement
-
Gets the granularity of the tracing level for this processing element
- getTransportType() - Method in class com.ibm.streamsx.rest.PEInputPort
-
Gets the transport type for this processing element input port
- getTransportType() - Method in class com.ibm.streamsx.rest.PEOutputPort
-
Gets the transport type for this processing element output port
- getTrigger() - Method in class com.ibm.streamsx.topology.consistent.ConsistentRegionConfig
-
Get the trigger type.
- getTupleClass() - Method in interface com.ibm.streamsx.topology.TStream
-
Class of the tuples on this stream, if known.
- getTupleClass() - Method in interface com.ibm.streamsx.topology.TWindow
-
Class of the tuples in this window.
- getTuples() - Method in class com.ibm.streamsx.topology.tester.spl.ExpectedTuples
-
Get the expected tuples.
- getTupleType() - Method in interface com.ibm.streamsx.topology.TStream
-
Type of the tuples on this stream.
- getTupleType() - Method in interface com.ibm.streamsx.topology.TWindow
-
Type of the tuples in this window.
- getType() - Method in class com.ibm.streamsx.rest.build.BuildPool
-
- getType() - Method in interface com.ibm.streamsx.topology.context.StreamsContext
-
The type of this context.
- getUriPath() - Method in class com.ibm.streamsx.rest.internal.icp4d.DeploymentSpace
-
Convenience method for getMetadata().getUrl().
- getURL() - Method in class com.ibm.streamsx.rest.build.Artifact
-
- getUrl() - Method in class com.ibm.streamsx.rest.internal.icp4d.DeploymentSpace.MetaData
-
- getValue() - Method in class com.ibm.streamsx.rest.JobSubmitParameters
-
- getValue() - Method in class com.ibm.streamsx.rest.Metric
-
Gets the value for this metric
- getValue() - Method in class com.ibm.streamsx.topology.jobconfig.SubmissionParameter
-
- getValues() - Method in class com.ibm.streamsx.rest.JobSubmitParameters
-
- getVersion() - Method in class com.ibm.streamsx.rest.build.Toolkit.Dependency
-
Gets the range of versions of the dependent
toolkit
.
- getVersion() - Method in class com.ibm.streamsx.rest.build.Toolkit
-
Gets the version of this toolkit.
- getVersion() - Method in class com.ibm.streamsx.rest.internal.icp4d.JobDescription.MetaData
-
- getZooKeeperConnectionString() - Method in class com.ibm.streamsx.rest.Domain
-
Gets the ZooKeeper connection string for this domain.
- graph(Topology) - Static method in class com.ibm.streamsx.topology.spi.builder.Builder
-
- GROUP - Static variable in interface com.ibm.streamsx.topology.context.JobProperties
-
Group name for a submitted application.
- group(JsonObject, String, String, String) - Static method in class com.ibm.streamsx.topology.spi.builder.LayoutInfo
-
Provide a hint that that an operator invocation should be
grouped with other operator invocations.
- group(JsonObject, JsonObject...) - Static method in class com.ibm.streamsx.topology.spi.builder.LayoutInfo
-
Group multiple operators together.
- gsonFromResponse(HttpResponse) - Static method in interface com.ibm.streamsx.rest.internal.RestUtils
-
- sample(double) - Method in interface com.ibm.streamsx.topology.spl.SPLStream
-
Return a stream that is a random sample of this stream.
- sample(double) - Method in interface com.ibm.streamsx.topology.TStream
-
Return a stream that is a random sample of this stream.
- SC_OPTIONS - Static variable in interface com.ibm.streamsx.topology.context.ContextProperties
-
Options to be passed to IBM Streams sc command.
- serialize(TStream<JSONObject>) - Static method in class com.ibm.streamsx.topology.json.JSONStreams
-
Create a stream of serialized JSON objects as String tuples.
- serialize(Object, OutputStream) - Method in interface com.ibm.streamsx.topology.spi.runtime.TupleSerializer
-
- SerializeJSON() - Constructor for class com.ibm.streamsx.topology.json.JSONStreams.SerializeJSON
-
- SERVICE_DEFINITION - Static variable in interface com.ibm.streamsx.topology.context.AnalyticsServiceProperties
-
Definition of a Streaming Analytics service.
- SERVICE_NAME - Static variable in interface com.ibm.streamsx.topology.context.AnalyticsServiceProperties
-
Name of the service to use as a String
.
- setBuildConfig(Topology, JsonObject) - Static method in interface com.ibm.streamsx.topology.spi.builder.Invoker
-
Set the build configuration.
- setConsistent(ConsistentRegionConfig) - Method in interface com.ibm.streamsx.topology.spl.SPLStream
-
Set the operator that is the source of this stream to be the start of a
consistent region to support at least once and exactly once
processing.
- setConsistent(ConsistentRegionConfig) - Method in interface com.ibm.streamsx.topology.TStream
-
Set the operator that is the source of this stream to be the start of a
consistent region to support at least once and exactly once
processing.
- setDataDirectory(String) - Method in class com.ibm.streamsx.topology.jobconfig.JobConfig
-
Set the data directory.
- setDirectory(String) - Method in class com.ibm.streamsx.topology.file.DirectoryWatcher
-
- setEncoding(String) - Method in class com.ibm.streamsx.topology.file.TextFileReader
-
- setFunctionalNamespace(Topology, String) - Static method in interface com.ibm.streamsx.topology.spi.builder.Invoker
-
Set the functional namespace for Java functional operators
for a topology.
- setJobGroup(String) - Method in class com.ibm.streamsx.topology.jobconfig.JobConfig
-
Set the job group.
- setJobName(String) - Method in class com.ibm.streamsx.topology.jobconfig.JobConfig
-
Set the job name.
- setOverrideResourceLoadProtection(Boolean) - Method in class com.ibm.streamsx.topology.jobconfig.JobConfig
-
- setParallel(Supplier<Integer>) - Method in interface com.ibm.streamsx.topology.spl.SPLStream
-
Sets the current stream as the start of a parallel region.
- setParallel(Supplier<Integer>) - Method in interface com.ibm.streamsx.topology.TStream
-
Sets the current stream as the start of a parallel region.
- setPreloadApplicationBundles(Boolean) - Method in class com.ibm.streamsx.topology.jobconfig.JobConfig
-
- setProject_id(String) - Method in class com.ibm.streamsx.rest.internal.icp4d.JobDescription.MetaData
-
- setSpace_id(String) - Method in class com.ibm.streamsx.rest.internal.icp4d.JobDescription.MetaData
-
- setTesterType() - Method in class com.ibm.streamsx.topology.tester.junit.AbstractTestClass
-
- setTracing(Level) - Method in class com.ibm.streamsx.topology.jobconfig.JobConfig
-
- setValue(String) - Method in class com.ibm.streamsx.topology.jobconfig.SubmissionParameter
-
- setValue(Number) - Method in class com.ibm.streamsx.topology.jobconfig.SubmissionParameter
-
- SimpleMessage - Class in com.ibm.streamsx.topology.tuple
-
A Simple implementation of an immutable
Message
.
- SimpleMessage(String) - Constructor for class com.ibm.streamsx.topology.tuple.SimpleMessage
-
Create a SimpleMessage
that lacks a key and topic.
- SimpleMessage(String, String) - Constructor for class com.ibm.streamsx.topology.tuple.SimpleMessage
-
Create a SimpleMessage
that lacks a topic.
- SimpleMessage(String, String, String) - Constructor for class com.ibm.streamsx.topology.tuple.SimpleMessage
-
Create a SimpleMessage
.
- single(TopologyElement) - Static method in class com.ibm.streamsx.topology.streams.BeaconStreams
-
Produce a source stream declaring a single tuple, with the value 0.
- sink(Consumer<T>) - Method in interface com.ibm.streamsx.topology.TStream
-
Terminate this stream.
- skipVersion(String, int...) - Method in class com.ibm.streamsx.topology.tester.junit.AbstractTestClass
-
Allow a test to be skipped for a specific version.
- sortAndSubmit(List<File>) - Method in class com.ibm.streamsx.topology.file.DirectoryWatcher
-
- source(Supplier<Iterable<T>>) - Method in class com.ibm.streamsx.topology.Topology
-
Declare a new source stream that iterates over the return of
Iterable<T> get()
from data
.
- SOURCE_LOCATIONS - Static variable in interface com.ibm.streamsx.topology.spi.builder.SourceInfo
-
- SourceInfo - Interface in com.ibm.streamsx.topology.spi.builder
-
Add the ability to add source location information to an operator invocation.
- SPL - Class in com.ibm.streamsx.topology.spl
-
Integration between Java topologies and SPL operator invocations.
- SPL() - Constructor for class com.ibm.streamsx.topology.spl.SPL
-
- splHandler(SPLStream, T) - Method in interface com.ibm.streamsx.topology.tester.Tester
-
- SPLInput - Interface in com.ibm.streamsx.topology.spl
-
Interface that can be connected to an SPL input port.
- split(int, ToIntFunction<T>) - Method in interface com.ibm.streamsx.topology.TStream
-
Distribute a stream's tuples among n
streams
as specified by a splitter
.
- splOK() - Method in class com.ibm.streamsx.topology.tester.junit.AbstractTestClass
-
- SPLSchemas - Interface in com.ibm.streamsx.topology.spl
-
Interchangeable SPL types.
- SPLStream - Interface in com.ibm.streamsx.topology.spl
-
A SPLStream
is a declaration of a continuous sequence of tuples with
a defined SPL schema.
- SPLStreams - Class in com.ibm.streamsx.topology.spl
-
Utilities for SPL attribute schema streams.
- SPLStreams() - Constructor for class com.ibm.streamsx.topology.spl.SPLStreams
-
- SPLWindow - Interface in com.ibm.streamsx.topology.spl
-
An SPL window, that has an SPL eviction policy and an SPL trigger policy.
- SSL_VERIFY - Static variable in interface com.ibm.streamsx.topology.context.ContextProperties
-
Set SSL certification verification state.
- StandaloneAuthenticator - Class in com.ibm.streamsx.rest.internal
-
Authenticator which uses the Cloud Pak for Data standalone configuration
security service.
- startsWith(TStream<String>, String) - Static method in class com.ibm.streamsx.topology.streams.StringStreams
-
Create a filtered stream that contains String
tuples starting
with a specific term.
- StreamingAnalyticsService - Interface in com.ibm.streamsx.rest
-
Access to a Streaming Analytics service on IBM Cloud.
- STREAMS_ASSET_REF_TYPE - Static variable in class com.ibm.streamsx.rest.internal.icp4d.JobDescription
-
Streams jobs must have this asset refernce type.
- STREAMS_CONNECTION - Static variable in interface com.ibm.streamsx.topology.context.ContextProperties
-
- STREAMS_INSTANCE - Static variable in interface com.ibm.streamsx.topology.context.ContextProperties
-
Instance connection to IBM Streams REST api to be used for submission.
- StreamsConnection - Class in com.ibm.streamsx.rest
-
Connection to IBM Streams.
- StreamsContext<T> - Interface in com.ibm.streamsx.topology.context
-
A
StreamsContext
provides the ability to turn
a
Topology
into an executable.
- StreamsContext.Type - Enum in com.ibm.streamsx.topology.context
-
- StreamsContextFactory - Class in com.ibm.streamsx.topology.context
-
Factory for creating StreamsContext
instances.
- StreamsContextFactory() - Constructor for class com.ibm.streamsx.topology.context.StreamsContextFactory
-
- StreamsContextSubmit - Class in com.ibm.streamsx.topology.context.local
-
Given the path of a file containing the JSON representation of a graph,
read the file, generate the SPL, and write it to the specified file.
- StreamsContextSubmit() - Constructor for class com.ibm.streamsx.topology.context.local.StreamsContextSubmit
-
- STRING - Static variable in interface com.ibm.streamsx.topology.spl.SPLSchemas
-
SPL schema used by
TStream<String>
streams.
- stringContents(TStream<String>, String...) - Method in interface com.ibm.streamsx.topology.tester.Tester
-
Return a condition that evaluates if stream
has submitted
at tuples matching values
in the same order.
- stringContentsUnordered(TStream<String>, String...) - Method in interface com.ibm.streamsx.topology.tester.Tester
-
Return a condition that evaluates if stream
has submitted
at tuples matching values
in any order.
- strings(String...) - Method in class com.ibm.streamsx.topology.Topology
-
Create a stream of String
tuples.
- StringStreams - Class in com.ibm.streamsx.topology.streams
-
Utilities for streams containing String
tuples.
- StringStreams() - Constructor for class com.ibm.streamsx.topology.streams.StringStreams
-
- stringToSPLStream(TStream<String>) - Static method in class com.ibm.streamsx.topology.spl.SPLStreams
-
- stringTupleTester(TStream<String>, Predicate<String>) - Method in interface com.ibm.streamsx.topology.tester.Tester
-
Return a condition that evaluates if every tuple on stream
evaluates to true
with tester
.
- SUBMISSION_PARAMS - Static variable in interface com.ibm.streamsx.topology.context.ContextProperties
-
Submission parameters to be supplied to the topology when
submitted for DISTRIBUTED
, STANDALONE
or ANALYTIC_SERVICE
execution.
- SubmissionParameter - Class in com.ibm.streamsx.topology.jobconfig
-
- SubmissionParameter(String, boolean) - Constructor for class com.ibm.streamsx.topology.jobconfig.SubmissionParameter
-
- SubmissionParameter(String, String) - Constructor for class com.ibm.streamsx.topology.jobconfig.SubmissionParameter
-
- SubmissionParameter(String, Number) - Constructor for class com.ibm.streamsx.topology.jobconfig.SubmissionParameter
-
- submit(String, JsonObject) - Method in class com.ibm.streamsx.rest.build.Build
-
- submit() - Method in class com.ibm.streamsx.rest.build.Build
-
- submit(Topology) - Method in interface com.ibm.streamsx.topology.context.StreamsContext
-
Submit topology
to this Streams context.
- submit(Topology, Map<String, Object>) - Method in interface com.ibm.streamsx.topology.context.StreamsContext
-
Submit topology
to this Streams context with a specific configuration.
- submit(JsonObject) - Method in interface com.ibm.streamsx.topology.context.StreamsContext
-
Submit a topology} to this Streams context as a JSON object.
- submitJob(JsonObject) - Method in class com.ibm.streamsx.rest.ApplicationBundle
-
- submitJob(File, JsonObject) - Method in class com.ibm.streamsx.rest.Instance
-
Submit a Streams bundle to run on the Streaming Analytics Service.
- submitJob(File, JsonObject) - Method in interface com.ibm.streamsx.rest.StreamingAnalyticsService
-
Submit a Streams bundle to run on the Streaming Analytics Service.
- subscribe(Supplier<String>) - Method in class com.ibm.streamsx.topology.messaging.kafka.KafkaConsumer
-
Subscribe to a topic and create a stream of messages.
- subscribe(Supplier<Integer>, Supplier<String>) - Method in class com.ibm.streamsx.topology.messaging.kafka.KafkaConsumer
-
Subscribe to a topic and create a stream of messages.
- subscribe(Supplier<String>) - Method in class com.ibm.streamsx.topology.messaging.mqtt.MqttStreams
-
Subscribe to a MQTT topic and create a stream of messages.
- subscribe(TopologyElement, String, StreamSchema) - Static method in class com.ibm.streamsx.topology.spl.SPLStreams
-
Subscribe to an
SPLStream
published by topic.
- subscribe(TopologyElement, Supplier<String>, StreamSchema) - Static method in class com.ibm.streamsx.topology.spl.SPLStreams
-
Subscribe to an
SPLStream
published by topic.
- subscribe(String, Class<T>) - Method in class com.ibm.streamsx.topology.Topology
-
Declare a stream that is a subscription to topic
.
- subscribe(Supplier<String>, Class<T>) - Method in class com.ibm.streamsx.topology.Topology
-
Declare a stream that is a subscription to topic
.
- suffixFilter(TStream<String>, String...) - Static method in class com.ibm.streamsx.topology.file.FileStreams
-
Filter a Stream<String>
containing file names by suffix values.
- Supplier<T> - Interface in com.ibm.streamsx.topology.function
-
A function that supplies a value.