- AbstractApplication - Class in quarks.samples.apps
-
An Application base class.
- AbstractApplication(String) - Constructor for class quarks.samples.apps.AbstractApplication
-
- AbstractContext<I,O> - Class in quarks.runtime.etiao
-
Provides a skeletal implementation of the
OpletContext
interface.
- AbstractContext(JobContext, RuntimeServices) - Constructor for class quarks.runtime.etiao.AbstractContext
-
- AbstractMqttApplication - Class in quarks.samples.apps.mqtt
-
An MQTT Application base class.
- AbstractMqttApplication(String) - Constructor for class quarks.samples.apps.mqtt.AbstractMqttApplication
-
- AbstractOplet<I,O> - Class in quarks.oplet.core
-
- AbstractOplet() - Constructor for class quarks.oplet.core.AbstractOplet
-
- accept(T) - Method in class quarks.connectors.wsclient.javax.websocket.runtime.WebSocketClientBinarySender
-
- accept(Consumer<T>) - Method in class quarks.connectors.wsclient.javax.websocket.runtime.WebSocketClientReceiver
-
- accept(T) - Method in class quarks.connectors.wsclient.javax.websocket.runtime.WebSocketClientSender
-
- accept(T, U) - Method in interface quarks.function.BiConsumer
-
Consume the two arguments.
- accept(T) - Method in interface quarks.function.Consumer
-
Apply the function to value
.
- accept(T) - Method in class quarks.oplet.core.FanOut
-
- accept(T) - Method in class quarks.oplet.core.Peek
-
- accept(T) - Method in class quarks.oplet.core.Split
-
- accept(T) - Method in class quarks.oplet.functional.Events
-
- accept(T) - Method in class quarks.oplet.functional.Filter
-
- accept(I) - Method in class quarks.oplet.functional.FlatMap
-
- accept(I) - Method in class quarks.oplet.functional.Map
-
- accept(T) - Method in class quarks.oplet.plumbing.Isolate
-
- accept(T) - Method in class quarks.oplet.plumbing.PressureReliever
-
- accept(T) - Method in class quarks.oplet.plumbing.UnorderedIsolate
-
- accept(T) - Method in class quarks.oplet.window.Aggregate
-
- accept(T) - Method in class quarks.runtime.etiao.SettableForwarder
-
- add(T) - Method in class quarks.window.InsertionTimeList
-
- addAnalytics() - Method in class quarks.samples.apps.sensorAnalytics.Sensor1
-
Add the sensor's analytics to the topology.
- addCleaner(BiConsumer<String, String>) - Method in class quarks.execution.services.ServiceContainer
-
Registers a new cleaner.
- addHandler(String, Function<String, T>) - Method in class quarks.samples.connectors.Options
-
- addHandler(String, Function<String, T>, T) - Method in class quarks.samples.connectors.Options
-
- additionalNameKeys(Hashtable<String, String>) - Method in class quarks.runtime.jmxcontrol.JMXControlService
-
- addKeyProperties(String, Map<String, String>) - Method in class quarks.metrics.MetricObjectNameFactory
-
- addOpletInvocation(T, int, int) - Method in class quarks.runtime.etiao.Executable
-
Creates a new Invocation
associated with the specified oplet.
- addOutput() - Method in interface quarks.graph.Vertex
-
Add an output port to the vertex.
- addOutput() - Method in class quarks.runtime.etiao.graph.ExecutableVertex
-
- addOutput() - Method in class quarks.runtime.etiao.Invocation
-
Adds a new output.
- addService(Class<T>, T) - Method in class quarks.execution.services.ServiceContainer
-
Adds the specified service to this ServiceContainer
.
- addSubscriber(String, Class<T>, Consumer<T>) - Method in class quarks.connectors.pubsub.service.ProviderPubSub
-
- addSubscriber(String, Class<T>, Consumer<T>) - Method in interface quarks.connectors.pubsub.service.PublishSubscribeService
-
Add a subscriber to a published topic.
- afterExecute(Runnable, Throwable) - Method in class quarks.runtime.etiao.TrackingScheduledExecutor
-
Invoked by the super class after each task execution.
- aggregate(TWindow<JsonObject, K>, String, String, JsonUnivariateAggregate...) - Static method in class quarks.analytics.math3.json.JsonAnalytics
-
Aggregate against a single Numeric
variable contained in an JSON object.
- aggregate(TWindow<JsonObject, K>, String, String, ToDoubleFunction<JsonObject>, JsonUnivariateAggregate...) - Static method in class quarks.analytics.math3.json.JsonAnalytics
-
Aggregate against a single Numeric
variable contained in an JSON object.
- Aggregate<T,U,K> - Class in quarks.oplet.window
-
Aggregate a window.
- Aggregate(Window<T, K, ? extends List<T>>, BiFunction<List<T>, K, U>) - Constructor for class quarks.oplet.window.Aggregate
-
- aggregate(BiFunction<List<T>, K, U>) - Method in interface quarks.topology.TWindow
-
Declares a stream that is a continuous aggregation of
partitions in this window.
- aggregateList(String, String, ToDoubleFunction<JsonObject>, JsonUnivariateAggregate...) - Static method in class quarks.analytics.math3.json.JsonAnalytics
-
Create a Function that aggregates against a single Numeric
variable contained in an JSON object.
- alertFilter(TStream<JsonObject>, int, boolean) - Static method in class quarks.samples.console.ConsoleWaterDetector
-
Look through the stream and check to see if any of the measurements cause concern.
- ALIAS_KEY - Static variable in class quarks.runtime.jsoncontrol.JsonControlService
-
Key for the alias of the control MBean in a JSON request.
- alwaysFalse() - Static method in class quarks.function.Functions
-
A Predicate that is always false
- alwaysInsert() - Static method in class quarks.window.Policies
-
Returns an insertion policy that indicates the tuple
is to be inserted into the partition.
- alwaysTrue() - Static method in class quarks.function.Functions
-
A Predicate that is always true
- and(Condition<?>...) - Method in interface quarks.topology.tester.Tester
-
Return a condition that is valid only if all of conditions
are valid.
- ApplicationUtilities - Class in quarks.samples.apps
-
Some general purpose application configuration driven utilities.
- ApplicationUtilities(Properties) - Constructor for class quarks.samples.apps.ApplicationUtilities
-
- apply(T) - Method in interface quarks.connectors.jdbc.CheckedFunction
-
Apply a function to t
and return the result.
- apply(T, U) - Method in interface quarks.function.BiFunction
-
Apply a function to t
and u
.
- apply(T) - Method in interface quarks.function.Function
-
Apply a function to value
.
- applyAsDouble(T) - Method in interface quarks.function.ToDoubleFunction
-
Apply a function to value
.
- applyAsInt(T) - Method in interface quarks.function.ToIntFunction
-
Apply a function to value
.
- ARGS_KEY - Static variable in class quarks.runtime.jsoncontrol.JsonControlService
-
Key for the argument list.
- asBytes() - Static method in class quarks.topology.json.JsonFunctions
-
Get the UTF-8 bytes representation of the JSON for a JsonObject.
- asString() - Static method in class quarks.topology.json.JsonFunctions
-
Get the JSON for a JsonObject.
- asString() - Method in interface quarks.topology.TStream
-
Convert this stream to a stream of String
tuples by calling
toString()
on each tuple.
- AT_LEAST_ONCE - Static variable in interface quarks.connectors.iot.QoS
-
The message containing the event arrives at the message hub at least once.
- AT_MOST_ONCE - Static variable in interface quarks.connectors.iot.QoS
-
The message containing the event arrives at the message hub either once or not at all.
- atLeast(T) - Static method in class quarks.samples.apps.Range
-
[a..+INF) (inclusive)
- atLeastTupleCount(TStream<?>, long) - Method in interface quarks.topology.tester.Tester
-
Return a condition that evaluates if stream
has submitted at
least expectedCount
number of tuples.
- atMost(T) - Static method in class quarks.samples.apps.Range
-
(-INF..b] (inclusive)
- awaitState(Job, Job.State, long, TimeUnit) - Static method in class quarks.samples.connectors.Util
-
Wait for the job to reach the specified state.
- CheckedFunction<T,R> - Interface in quarks.connectors.jdbc
-
Function to apply a funtion to an input value and return a result.
- CheckedSupplier<T> - Interface in quarks.connectors.jdbc
-
Function that supplies a result and may throw an Exception.
- cleanOplet(String, String) - Method in class quarks.execution.services.ServiceContainer
-
Invokes all the registered cleaners in the context of the specified
job and element.
- clear(JsonElement, int) - Method in interface quarks.analytics.math3.json.JsonUnivariateAggregator
-
Clear the aggregator to prepare for a new aggregation.
- clear(JsonElement, int) - Method in class quarks.analytics.math3.stat.JsonStorelessStatistic
-
- clear() - Method in class quarks.window.InsertionTimeList
-
- close() - Method in class quarks.connectors.file.FileWriterPolicy
-
- close() - Method in class quarks.connectors.wsclient.javax.websocket.runtime.WebSocketClientReceiver
-
- close() - Method in class quarks.connectors.wsclient.javax.websocket.runtime.WebSocketClientSender
-
- close() - Method in class quarks.metrics.oplets.SingleMetricAbstractOplet
-
- close() - Method in class quarks.oplet.core.FanOut
-
- close() - Method in class quarks.oplet.core.Sink
-
- close() - Method in class quarks.oplet.core.Split
-
- close() - Method in class quarks.oplet.core.Union
-
- close() - Method in class quarks.oplet.functional.Events
-
- close() - Method in class quarks.oplet.functional.Filter
-
- close() - Method in class quarks.oplet.functional.FlatMap
-
- close() - Method in class quarks.oplet.functional.Map
-
- close() - Method in class quarks.oplet.functional.Peek
-
- close() - Method in class quarks.oplet.functional.SupplierPeriodicSource
-
- close() - Method in class quarks.oplet.functional.SupplierSource
-
- close() - Method in class quarks.oplet.plumbing.Isolate
-
- close() - Method in class quarks.oplet.plumbing.PressureReliever
-
- close() - Method in class quarks.oplet.plumbing.UnorderedIsolate
-
- close() - Method in class quarks.oplet.window.Aggregate
-
- close() - Method in class quarks.runtime.etiao.Executable
-
Shutdown the user scheduler and thread factory, close all
invocations, then shutdown the control scheduler.
- close() - Method in class quarks.runtime.etiao.Invocation
-
- closeActiveFile(Path) - Method in class quarks.connectors.file.FileWriterPolicy
-
- closed(T, T) - Static method in class quarks.samples.apps.Range
-
[a..b] (both inclusive)
- closedOpen(T, T) - Static method in class quarks.samples.apps.Range
-
[a..b) (inclusive,exclusive)
- closeFunction(Object) - Static method in class quarks.function.Functions
-
Close the function.
- collect() - Static method in class quarks.samples.apps.JsonTuples
-
Create a function that creates a new sample containing the collection
of input sample readings.
- collection(Collection<T>) - Method in interface quarks.topology.Topology
-
Declare a stream of constants from a collection.
- commandId(String, String) - Method in class quarks.samples.apps.mqtt.AbstractMqttApplication
-
Compose a MqttDevice commandId for the sensor
- commands(String...) - Method in interface quarks.connectors.iot.IotDevice
-
Create a stream of device commands as JSON objects.
- commands(String...) - Method in class quarks.connectors.iotf.IotfDevice
-
Create a stream of device commands as JSON objects.
- commands(String...) - Method in class quarks.connectors.mqtt.iot.MqttDevice
-
- commandTopic(String) - Method in class quarks.connectors.mqtt.iot.MqttDevice
-
Get the MQTT topic for a command.
- complete() - Method in interface quarks.execution.Job
-
Waits for any outstanding job work to complete.
- complete(long, TimeUnit) - Method in interface quarks.execution.Job
-
Waits for at most the specified time for the job to complete.
- complete() - Method in class quarks.runtime.etiao.EtiaoJob
-
- complete(long, TimeUnit) - Method in class quarks.runtime.etiao.EtiaoJob
-
- complete(Submitter<Topology, ? extends Job>, JsonObject, Condition<?>, long, TimeUnit) - Method in interface quarks.topology.tester.Tester
-
Submit the topology for this tester and wait for it to complete, or reach
an end condition.
- Condition<T> - Interface in quarks.topology.tester
-
Function representing if a condition is valid or not.
- config() - Method in class quarks.samples.apps.AbstractApplication
-
Get the application's raw configuration information.
- Configs - Interface in quarks.execution
-
Configuration property names.
- connect(Vertex<?, T, ?>, int) - Method in interface quarks.graph.Connector
-
Connect this Connector
to the specified target's input.
- connector - Variable in class quarks.connectors.wsclient.javax.websocket.runtime.WebSocketClientReceiver
-
- connector - Variable in class quarks.connectors.wsclient.javax.websocket.runtime.WebSocketClientSender
-
- Connector<T> - Interface in quarks.graph
-
A Connector
represents an output port of a Vertex
.
- ConsoleWaterDetector - Class in quarks.samples.console
-
Demonstrates some of the features of the console.
- ConsoleWaterDetector() - Constructor for class quarks.samples.console.ConsoleWaterDetector
-
- Consumer<T> - Interface in quarks.function
-
Function that consumes a value.
- contains(T, Comparator<T>) - Method in class quarks.samples.apps.Range
-
Determine if the Region contains the value.
- contains(T) - Method in class quarks.samples.apps.Range
-
Determine if the Region contains the value.
- contentsUnordered(TStream<T>, T...) - Method in interface quarks.topology.tester.Tester
-
Return a condition that evaluates if stream
has submitted
tuples matching values
in any order.
- controlRequest(JsonObject) - Method in class quarks.runtime.jsoncontrol.JsonControlService
-
Handle a JSON control request.
- Controls - Class in quarks.execution.services
-
Utilities for the control service.
- Controls() - Constructor for class quarks.execution.services.Controls
-
- ControlService - Interface in quarks.execution.services
-
Service that provides a control mechanism.
- countContentsPolicy(int) - Static method in class quarks.window.Policies
-
Returns a count-based contents policy.
- counter(TStream<T>) - Static method in class quarks.metrics.Metrics
-
Increment a counter metric when peeking at each tuple.
- counter(Topology) - Static method in class quarks.metrics.Metrics
-
Add counter metrics to all the topology's streams.
- CounterOp<T> - Class in quarks.metrics.oplets
-
A metrics oplet which counts the number of tuples peeked at.
- CounterOp() - Constructor for class quarks.metrics.oplets.CounterOp
-
- createName(String, String, String) - Method in class quarks.metrics.MetricObjectNameFactory
-
Creates a JMX ObjectName
from the given domain, metric type,
and metric name.
- Edge - Interface in quarks.graph
-
Represents an edge between two Vertices.
- EdgeType - Class in quarks.runtime.etiao.graph.model
-
- EdgeType() - Constructor for class quarks.runtime.etiao.graph.model.EdgeType
-
- EdgeType(Edge, IdMapper<String>) - Constructor for class quarks.runtime.etiao.graph.model.EdgeType
-
- EtiaoJob - Class in quarks.runtime.etiao
-
Etiao runtime implementation of the
Job
interface.
- EtiaoJob(DirectGraph, String, ServiceContainer) - Constructor for class quarks.runtime.etiao.EtiaoJob
-
Creates a new EtiaoJob
instance which controls the lifecycle
of the specified graph.
- EtiaoJobBean - Class in quarks.runtime.etiao.mbeans
-
Implementation of a JMX control interface for a job.
- EtiaoJobBean(EtiaoJob) - Constructor for class quarks.runtime.etiao.mbeans.EtiaoJobBean
-
- evaluate(long, int, T) - Method in class quarks.connectors.file.FileWriterCycleConfig
-
Evaluate if the specified values indicate that a cycling of
the active file should be performed.
- evaluate(int, T) - Method in class quarks.connectors.file.FileWriterFlushConfig
-
Evaluate if the specified values indicate that a flush should be
performed.
- evaluate(int, long) - Method in class quarks.connectors.file.FileWriterRetentionConfig
-
Evaluate if the specified values indicate that a final file should
be removed.
- eventHandler - Variable in class quarks.connectors.wsclient.javax.websocket.runtime.WebSocketClientReceiver
-
- events(TStream<JsonObject>, Function<JsonObject, String>, UnaryOperator<JsonObject>, Function<JsonObject, Integer>) - Method in interface quarks.connectors.iot.IotDevice
-
Publish a stream's tuples as device events.
- events(TStream<JsonObject>, String, int) - Method in interface quarks.connectors.iot.IotDevice
-
Publish a stream's tuples as device events.
- events(TStream<JsonObject>, Function<JsonObject, String>, UnaryOperator<JsonObject>, Function<JsonObject, Integer>) - Method in class quarks.connectors.iotf.IotfDevice
-
Publish a stream's tuples as device events.
- events(TStream<JsonObject>, String, int) - Method in class quarks.connectors.iotf.IotfDevice
-
Publish a stream's tuples as device events.
- events(TStream<JsonObject>, Function<JsonObject, String>, UnaryOperator<JsonObject>, Function<JsonObject, Integer>) - Method in class quarks.connectors.mqtt.iot.MqttDevice
-
- events(TStream<JsonObject>, String, int) - Method in class quarks.connectors.mqtt.iot.MqttDevice
-
- Events<T> - Class in quarks.oplet.functional
-
Generate tuples from events.
- Events(Consumer<Consumer<T>>) - Constructor for class quarks.oplet.functional.Events
-
- events(Consumer<Consumer<T>>) - Method in interface quarks.topology.Topology
-
Declare a stream populated by an event system.
- eventTopic(String) - Method in class quarks.connectors.mqtt.iot.MqttDevice
-
Get the MQTT topic for an device event.
- evict() - Method in interface quarks.window.Partition
-
Calls the partition's evictDeterminer.
- evictAll() - Static method in class quarks.window.Policies
-
Returns a Consumer representing an evict determiner that evict all tuples
from the window.
- evictAllAndScheduleEvictWithProcess(long, TimeUnit) - Static method in class quarks.window.Policies
-
An eviction policy which processes the window, evicts all tuples, and
schedules the next eviction after the appropriate interval.
- evictOlderWithProcess(long, TimeUnit) - Static method in class quarks.window.Policies
-
An eviction policy which evicts all tuples that are older than a specified time.
- evictOldest() - Static method in class quarks.window.Policies
-
Returns an evict determiner that evicts the oldest tuple.
- EXACTLY_ONCE - Static variable in interface quarks.connectors.iot.QoS
-
The message containing the event arrives at the message hub exactly once.
- Executable - Class in quarks.runtime.etiao
-
Executes and provides runtime services to the executable graph
elements (oplets and functions).
- Executable(EtiaoJob) - Constructor for class quarks.runtime.etiao.Executable
-
Creates a new Executable
for the specified job.
- Executable(EtiaoJob, ThreadFactory) - Constructor for class quarks.runtime.etiao.Executable
-
Creates a new Executable
for the specified job, which uses the
provided thread factory to create new threads for executing the oplets.
- executable() - Method in class quarks.runtime.etiao.graph.DirectGraph
-
Returns the Executable
running this graph.
- ExecutableVertex<N extends Oplet<C,P>,C,P> - Class in quarks.runtime.etiao.graph
-
- executeStatement(TStream<T>, Supplier<String>, ParameterSetter<T>, ResultsHandler<T, R>) - Method in class quarks.connectors.jdbc.JdbcStreams
-
For each tuple on stream
execute an SQL statement and
add 0 or more resulting tuples to a result stream.
- executeStatement(TStream<T>, StatementSupplier, ParameterSetter<T>, ResultsHandler<T, R>) - Method in class quarks.connectors.jdbc.JdbcStreams
-
For each tuple on stream
execute an SQL statement and
add 0 or more resulting tuples to a result stream.
- executeStatement(TStream<T>, Supplier<String>, ParameterSetter<T>) - Method in class quarks.connectors.jdbc.JdbcStreams
-
For each tuple on stream
execute an SQL statement.
- executeStatement(TStream<T>, StatementSupplier, ParameterSetter<T>) - Method in class quarks.connectors.jdbc.JdbcStreams
-
For each tuple on stream
execute an SQL statement.
- generate(Supplier<T>) - Method in interface quarks.topology.Topology
-
Declare an endless source stream.
- get() - Method in enum quarks.analytics.math3.stat.Statistic
-
Return a new instance of this statistic implementation.
- get() - Method in interface quarks.connectors.jdbc.CheckedSupplier
-
Get a result.
- get(Connection) - Method in interface quarks.connectors.jdbc.StatementSupplier
-
Create a JDBC SQL PreparedStatement containing 0 or more parameters.
- get() - Method in interface quarks.function.Supplier
-
Supply a value, each call to this function may return
a different value.
- get() - Method in class quarks.samples.connectors.MsgSupplier
-
- get(String) - Method in class quarks.samples.connectors.Options
-
- get(String, T) - Method in class quarks.samples.connectors.Options
-
- getActionTimeToWaitMillis() - Method in class quarks.connectors.mqtt.MqttConfig
-
Get the maximum time to wait for an action (e.g., publish message) to complete.
- getAgeSec() - Method in class quarks.connectors.file.FileWriterRetentionConfig
-
Get the file age configuration value.
- getAggregateFileSize() - Method in class quarks.connectors.file.FileWriterRetentionConfig
-
Get the aggregate file size configuration value.
- getAll() - Method in class quarks.samples.connectors.Options
-
- getClassName() - Method in class quarks.runtime.etiao.graph.model.InvocationType
-
- getClientId() - Method in class quarks.connectors.mqtt.MqttConfig
-
Get the connection Client Id.
- getCntTuples() - Method in class quarks.connectors.file.FileWriterCycleConfig
-
Get the tuple count configuration value.
- getCntTuples() - Method in class quarks.connectors.file.FileWriterFlushConfig
-
Get the tuple count configuration value.
- getCommandValueString(JsonObject) - Method in class quarks.samples.apps.mqtt.AbstractMqttApplication
-
- getConnectionTimeout() - Method in class quarks.connectors.mqtt.MqttConfig
-
Get the connection timeout.
- getConnectors() - Method in interface quarks.graph.Vertex
-
Get the vertice's collection of output connectors.
- getConnectors() - Method in class quarks.runtime.etiao.graph.ExecutableVertex
-
- getContents() - Method in interface quarks.window.Partition
-
Retrieves the window contents.
- getContentsPolicy() - Method in interface quarks.window.Window
-
Returns the contents policy of the window.
- getCurrentState() - Method in interface quarks.execution.Job
-
Retrieves the current state of this job.
- getCurrentState() - Method in interface quarks.execution.mbeans.JobMXBean
-
Retrieves the current state of the job.
- getCurrentState() - Method in class quarks.runtime.etiao.mbeans.EtiaoJobBean
-
- getCycleConfig() - Method in class quarks.connectors.file.FileWriterPolicy
-
Get the policy's active file cycle configuration
- getDataSource(Properties) - Static method in class quarks.samples.connectors.jdbc.DbUtils
-
Get the JDBC DataSource
for the database.
- getDestination() - Method in class quarks.oplet.core.Pipe
-
- getDestination() - Method in class quarks.oplet.core.Source
-
- getDestination() - Method in class quarks.runtime.etiao.SettableForwarder
-
Get the current destination.
- getDomain() - Method in class quarks.runtime.jmxcontrol.JMXControlService
-
Get the JMX domain being used by this control service.
- getEdges() - Method in interface quarks.graph.Graph
-
Return an unmodifiable view of all edges in this graph.
- getEdges() - Method in class quarks.runtime.etiao.graph.DirectGraph
-
- getEdges() - Method in class quarks.runtime.etiao.graph.model.GraphType
-
- getEvictDeterminer() - Method in interface quarks.window.Window
-
Returns the window's eviction determiner.
- getFeed() - Method in interface quarks.topology.TSink
-
Get the stream feeding this sink.
- getFileCount() - Method in class quarks.connectors.file.FileWriterRetentionConfig
-
Get the file count configuration value.
- getFileSize() - Method in class quarks.connectors.file.FileWriterCycleConfig
-
Get the file size configuration value.
- getFlushConfig() - Method in class quarks.connectors.file.FileWriterPolicy
-
Get the policy's active file flush configuration
- getId() - Method in interface quarks.execution.Job
-
Returns the identifier of this job.
- getId() - Method in interface quarks.execution.mbeans.JobMXBean
-
Returns the identifier of the job.
- getId() - Method in interface quarks.oplet.JobContext
-
Get the runtime identifier for the job containing this
Oplet
.
- getId() - Method in interface quarks.oplet.OpletContext
-
Get the unique identifier (within the running job)
for this oplet.
- getId() - Method in class quarks.runtime.etiao.EtiaoJob
-
- getId() - Method in class quarks.runtime.etiao.graph.model.VertexType
-
- getId() - Method in class quarks.runtime.etiao.Invocation
-
Returns the unique identifier associated with this Invocation
.
- getId() - Method in class quarks.runtime.etiao.InvocationContext
-
- getId() - Method in class quarks.runtime.etiao.mbeans.EtiaoJobBean
-
- getIdleTimeout() - Method in class quarks.connectors.mqtt.MqttConfig
-
Get the idle connection timeout.
- getInput() - Method in interface quarks.connectors.serial.SerialPort
-
Get the input stream for this serial port.
- getInputCount() - Method in interface quarks.oplet.OpletContext
-
Get the number of connected inputs to this oplet.
- getInputCount() - Method in class quarks.runtime.etiao.InvocationContext
-
- getInputs() - Method in class quarks.oplet.core.FanOut
-
- getInputs() - Method in class quarks.oplet.core.Pipe
-
- getInputs() - Method in class quarks.oplet.core.Sink
-
- getInputs() - Method in class quarks.oplet.core.Source
-
- getInputs() - Method in class quarks.oplet.core.Split
-
- getInputs() - Method in class quarks.oplet.core.Union
-
For each input set the output directly to the only output.
- getInputs() - Method in interface quarks.oplet.Oplet
-
Get the input stream data handlers for this oplet.
- getInputs() - Method in class quarks.runtime.etiao.Invocation
-
Returns the list of input stream forwarders for this invocation.
- getInsertionPolicy() - Method in interface quarks.window.Window
-
Returns the insertion policy of the window.
- getInstance() - Method in interface quarks.graph.Vertex
-
Get the instance of the oplet that will be executed.
- getInstance() - Method in class quarks.runtime.etiao.graph.ExecutableVertex
-
- getInvocation() - Method in class quarks.runtime.etiao.graph.model.VertexType
-
- getInvocationId() - Method in class quarks.runtime.etiao.graph.ExecutableVertex
-
- getJob() - Method in interface quarks.topology.tester.Tester
-
Get the Job
reference for the topology submitted by complete()
.
- getJobContext() - Method in interface quarks.oplet.OpletContext
-
Get the job hosting this oplet.
- getJobContext() - Method in class quarks.runtime.etiao.AbstractContext
-
- getJson(TStream<JsonObject>, Supplier<CloseableHttpClient>, Function<JsonObject, String>) - Static method in class quarks.connectors.http.HttpStreams
-
- getKeepAliveInterval() - Method in class quarks.connectors.mqtt.MqttConfig
-
Get the connection Keep alive interval.
- getKey() - Method in interface quarks.window.Partition
-
Returns the key associated with this partition
- getKeyFunction() - Method in interface quarks.topology.TWindow
-
Returns the key function used to map tuples to partitions.
- getKeyFunction() - Method in interface quarks.window.Window
-
Returns the keyFunction of the window
- getLastError() - Method in class quarks.runtime.etiao.Executable
-
- getLogger() - Method in class quarks.connectors.wsclient.javax.websocket.runtime.WebSocketClientConnector
-
- getMbs() - Method in class quarks.runtime.jmxcontrol.JMXControlService
-
Get the MBean server being used by this control service.
- getMetric() - Method in class quarks.metrics.oplets.CounterOp
-
- getMetric() - Method in class quarks.metrics.oplets.RateMeter
-
- getMetric() - Method in class quarks.metrics.oplets.SingleMetricAbstractOplet
-
- getMetricName() - Method in class quarks.metrics.oplets.SingleMetricAbstractOplet
-
Returns the name of the metric used by this oplet for registration.
- getMqttConfig() - Method in class quarks.connectors.mqtt.iot.MqttDevice
-
- getName() - Method in interface quarks.execution.Job
-
Returns the name of this job.
- getName() - Method in interface quarks.execution.mbeans.JobMXBean
-
Returns the name of the job.
- getName() - Method in interface quarks.oplet.JobContext
-
Get the name of the job containing this
Oplet
.
- getName() - Method in class quarks.runtime.etiao.EtiaoJob
-
Get the name of the job containing this
Oplet
.
- getName() - Method in class quarks.runtime.etiao.mbeans.EtiaoJobBean
-
- getName() - Method in interface quarks.topology.Topology
-
Name of this topology.
- getNextActiveFilePath() - Method in class quarks.connectors.file.FileWriterPolicy
-
- getNextState() - Method in interface quarks.execution.Job
-
Retrieves the next execution state when this job makes a state
transition.
- getNextState() - Method in interface quarks.execution.mbeans.JobMXBean
-
Retrieves the next execution state when the job makes a state
transition.
- getNextState() - Method in class quarks.runtime.etiao.mbeans.EtiaoJobBean
-
- getOplet() - Method in class quarks.runtime.etiao.Invocation
-
Returns the oplet associated with this Invocation
.
- getOpletContext() - Method in class quarks.oplet.core.AbstractOplet
-
- getOutput() - Method in interface quarks.connectors.serial.SerialPort
-
Get the output stream for this serial port.
- getOutputCount() - Method in interface quarks.oplet.OpletContext
-
Get the number of connected outputs to this oplet.
- getOutputCount() - Method in class quarks.runtime.etiao.Invocation
-
Returns the number of outputs for this invocation.
- getOutputCount() - Method in class quarks.runtime.etiao.InvocationContext
-
- getOutputs() - Method in interface quarks.oplet.OpletContext
-
Get the mechanism to submit tuples on an output port.
- getOutputs() - Method in class quarks.runtime.etiao.InvocationContext
-
- getPartitionProcessor() - Method in interface quarks.window.Window
-
Returns the partition processor associated with the window.
- getPassword() - Method in class quarks.connectors.mqtt.MqttConfig
-
Get the the password to use for authentication with the server.
- getPeriod() - Method in interface quarks.oplet.core.mbeans.PeriodicMXBean
-
Get the period.
- getPeriod() - Method in class quarks.oplet.core.PeriodicSource
-
- getPeriodMsec() - Method in class quarks.connectors.file.FileWriterCycleConfig
-
Get the time period configuration value.
- getPeriodMsec() - Method in class quarks.connectors.file.FileWriterFlushConfig
-
Get the time period configuration value.
- getPeriodMsec() - Method in class quarks.connectors.file.FileWriterRetentionConfig
-
Get the time period configuration value.
- getPersistence() - Method in class quarks.connectors.mqtt.MqttConfig
-
Get the QoS 1 and 2 in-flight message persistence handler.
- getPublishDestination(String, Class<? super T>) - Method in class quarks.connectors.pubsub.service.ProviderPubSub
-
- getPublishDestination(String, Class<? super T>) - Method in interface quarks.connectors.pubsub.service.PublishSubscribeService
-
Get the destination for a publisher.
- getRange(String, String, Class<T>) - Method in class quarks.samples.apps.ApplicationUtilities
-
Get the Range for a sensor range configuration item.
- getResult() - Method in interface quarks.topology.tester.Condition
-
- getRetentionConfig() - Method in class quarks.connectors.file.FileWriterPolicy
-
Get the policy's retention configuration
- getRunnable() - Method in class quarks.oplet.core.PeriodicSource
-
- getRunnable() - Method in class quarks.oplet.core.ProcessSource
-
- getRuntimeServiceSupplier() - Method in class quarks.providers.direct.DirectTopology
-
- getRuntimeServiceSupplier() - Method in interface quarks.topology.Topology
-
Return a function that at execution time
will return a
RuntimeServices
instance
a stream function can use.
- getScheduledExecutorService() - Method in interface quarks.window.Window
-
Returns the ScheduledExecutorService associated with the window.
- getScheduler() - Method in class quarks.runtime.etiao.Executable
-
Returns the ScheduledExecutorService
used for running
executable graph elements.
- getSensorPropertyName(String, String, String) - Method in class quarks.samples.apps.ApplicationUtilities
-
Get the property name for a sensor's configuration item.
- getServerURLs() - Method in class quarks.connectors.mqtt.MqttConfig
-
Get the MQTT Server URLs
- getService(Class<T>) - Method in interface quarks.execution.services.RuntimeServices
-
Get a service for this invocation.
- getService(Class<T>) - Method in class quarks.execution.services.ServiceContainer
-
Returns the service to which the specified service class key is
mapped, or null
if this ServiceContainer
contains no
service for that key.
- getService(Class<T>) - Method in interface quarks.oplet.OpletContext
-
Get a service for this invocation.
- getService(Class<T>) - Method in class quarks.runtime.etiao.AbstractContext
-
- getService(Class<T>) - Method in class quarks.runtime.etiao.Executable
-
Acts as a service provider for executable elements in the graph, first
looking for a service specific to this job, and then one from the
container.
- getServices() - Method in interface quarks.execution.DirectSubmitter
-
Access to services.
- getServices() - Method in class quarks.providers.direct.DirectProvider
-
Access to services.
- getSinker() - Method in class quarks.oplet.core.Sink
-
Get the sink function that processes each tuple.
- getSource(Function<SerialPort, T>) - Method in interface quarks.connectors.serial.SerialDevice
-
Create a function that can be used to source a
stream from a serial port device.
- getSource() - Method in interface quarks.graph.Edge
-
Returns the source vertex.
- getSourceId() - Method in class quarks.runtime.etiao.graph.model.EdgeType
-
- getSourceOutputPort() - Method in interface quarks.graph.Edge
-
Returns the source output port index.
- getSourceOutputPort() - Method in class quarks.runtime.etiao.graph.model.EdgeType
-
- getSslContainer(Properties) - Method in class quarks.javax.websocket.impl.QuarksSslContainerProviderImpl
-
- getSslContainer(Properties) - Method in class quarks.javax.websocket.QuarksSslContainerProvider
-
Create a WebSocketContainer setup for SSL.
- getSslWebSocketContainer(Properties) - Static method in class quarks.javax.websocket.QuarksSslContainerProvider
-
Create a WebSocketContainer setup for SSL.
- getState(K) - Method in class quarks.window.PartitionedState
-
Get the current state for key
.
- getStatistic(JsonObject, Statistic) - Static method in class quarks.samples.apps.JsonTuples
-
Get a statistic value from a sample.
- getStatistic(JsonObject, String, Statistic) - Static method in class quarks.samples.apps.JsonTuples
-
Get a statistic value from a sample.
- getSubscriberIdleReconnectInterval() - Method in class quarks.connectors.mqtt.MqttConfig
-
Get the subscriber idle reconnect interval.
- getTags() - Method in interface quarks.graph.Connector
-
Returns the set of tags associated with this connector.
- getTags() - Method in interface quarks.graph.Edge
-
Returns the set of tags associated with this edge.
- getTags() - Method in class quarks.runtime.etiao.graph.model.EdgeType
-
- getTags() - Method in interface quarks.topology.TStream
-
Returns the set of tags associated with this stream.
- getTarget() - Method in interface quarks.graph.Edge
-
Returns the target vertex.
- getTargetId() - Method in class quarks.runtime.etiao.graph.model.EdgeType
-
- getTargetInputPort() - Method in interface quarks.graph.Edge
-
Returns the target input port index.
- getTargetInputPort() - Method in class quarks.runtime.etiao.graph.model.EdgeType
-
- getTester() - Method in interface quarks.topology.Topology
-
Get the tester for this topology.
- getTriggerPolicy() - Method in interface quarks.window.Window
-
Returns the window's trigger policy.
- getTuplePredicate() - Method in class quarks.connectors.file.FileWriterCycleConfig
-
Get the tuple predicate configuration value.
- getTuplePredicate() - Method in class quarks.connectors.file.FileWriterFlushConfig
-
Get the tuple predicate configuration value.
- getUnit() - Method in interface quarks.oplet.core.mbeans.PeriodicMXBean
-
- getUnit() - Method in class quarks.oplet.core.PeriodicSource
-
- getUserName() - Method in class quarks.connectors.mqtt.MqttConfig
-
Get the username to use for authentication with the server.
- getVertices() - Method in interface quarks.graph.Graph
-
Return an unmodifiable view of all vertices in this graph.
- getVertices() - Method in class quarks.runtime.etiao.graph.DirectGraph
-
- getVertices() - Method in class quarks.runtime.etiao.graph.model.GraphType
-
- getWillDestination() - Method in class quarks.connectors.mqtt.MqttConfig
-
Get a Last Will and Testament message's destination topic.
- getWillPayload() - Method in class quarks.connectors.mqtt.MqttConfig
-
Get a Last Will and Testament message's payload.
- getWillQOS() - Method in class quarks.connectors.mqtt.MqttConfig
-
Get a Last Will and Testament message's QOS.
- getWillRetained() - Method in class quarks.connectors.mqtt.MqttConfig
-
Get a Last Will and Testament message's "retained" setting.
- getWindow() - Method in interface quarks.window.Partition
-
Return the window in which this partition is contained.
- graph() - Method in interface quarks.graph.Connector
-
Gets the Graph
for this Connector
.
- Graph - Interface in quarks.graph
-
A generic directed graph of vertices, connectors and edges.
- graph() - Method in interface quarks.graph.Vertex
-
- graph() - Method in class quarks.providers.direct.DirectTopology
-
- graph() - Method in class quarks.runtime.etiao.EtiaoJob
-
- graph() - Method in class quarks.runtime.etiao.graph.ExecutableVertex
-
- graph() - Method in interface quarks.topology.Topology
-
Get the underlying graph.
- graphSnapshot() - Method in interface quarks.execution.mbeans.JobMXBean
-
Takes a current snapshot of the running graph and returns it in JSON format.
- graphSnapshot() - Method in class quarks.runtime.etiao.mbeans.EtiaoJobBean
-
- GraphType - Class in quarks.runtime.etiao.graph.model
-
A generic directed graph of vertices, connectors and edges.
- GraphType(Graph) - Constructor for class quarks.runtime.etiao.graph.model.GraphType
-
- GraphType(Graph, IdMapper<String>) - Constructor for class quarks.runtime.etiao.graph.model.GraphType
-
Create an instance of
GraphType
using the specified
IdMapper
to generate unique object identifiers.
- GraphType() - Constructor for class quarks.runtime.etiao.graph.model.GraphType
-
- greaterThan(T) - Static method in class quarks.samples.apps.Range
-
(a..+INF) (exclusive)
- id() - Method in class quarks.connectors.wsclient.javax.websocket.runtime.WebSocketClientConnector
-
- ID_PREFIX - Static variable in class quarks.runtime.etiao.EtiaoJob
-
Prefix used by job unique identifiers.
- ID_PREFIX - Static variable in class quarks.runtime.etiao.Invocation
-
Prefix used by oplet unique identifiers.
- identity() - Static method in class quarks.function.Functions
-
Returns the identity function that returns its single argument.
- increment(double) - Method in interface quarks.analytics.math3.json.JsonUnivariateAggregator
-
Add a value to the aggregation.
- increment(double) - Method in class quarks.analytics.math3.stat.JsonStorelessStatistic
-
- initDb(DataSource) - Static method in class quarks.samples.connectors.jdbc.DbUtils
-
Initialize the sample's database.
- initialize(String, Flushable, Closeable) - Method in class quarks.connectors.file.FileWriterPolicy
-
- initialize(OpletContext<T, Void>) - Method in class quarks.connectors.pubsub.oplets.Publish
-
- initialize(OpletContext<T, T>) - Method in class quarks.metrics.oplets.SingleMetricAbstractOplet
-
- initialize(OpletContext<I, O>) - Method in class quarks.oplet.core.AbstractOplet
-
- initialize(OpletContext<Void, T>) - Method in class quarks.oplet.core.PeriodicSource
-
- initialize(OpletContext<I, O>) - Method in class quarks.oplet.core.Pipe
-
- initialize(OpletContext<Void, T>) - Method in class quarks.oplet.core.Source
-
- initialize(OpletContext<T, T>) - Method in class quarks.oplet.core.Split
-
- initialize(OpletContext<Void, T>) - Method in class quarks.oplet.functional.SupplierPeriodicSource
-
- initialize(OpletContext<Void, T>) - Method in class quarks.oplet.functional.SupplierSource
-
- initialize(OpletContext<I, O>) - Method in interface quarks.oplet.Oplet
-
Initialize the oplet.
- initialize(OpletContext<T, T>) - Method in class quarks.oplet.plumbing.Isolate
-
- initialize(OpletContext<T, T>) - Method in class quarks.oplet.plumbing.PressureReliever
-
- initialize(OpletContext<T, T>) - Method in class quarks.oplet.plumbing.UnorderedIsolate
-
- initialize(OpletContext<T, U>) - Method in class quarks.oplet.window.Aggregate
-
- initialize() - Method in class quarks.runtime.etiao.Executable
-
Initializes the
- initialize(JobContext, RuntimeServices) - Method in class quarks.runtime.etiao.Invocation
-
Initialize the invocation.
- inputOn(Integer...) - Static method in class quarks.connectors.http.HttpResponders
-
Return the input tuple on specified codes.
- inputOn200() - Static method in class quarks.connectors.http.HttpResponders
-
Return the input tuple on OK.
- insert(N, int, int) - Method in interface quarks.graph.Graph
-
Add a new unconnected Vertex
into the graph.
- insert(OP, int, int) - Method in class quarks.runtime.etiao.graph.DirectGraph
-
- insert(T) - Method in interface quarks.window.Partition
-
Offers a tuple to be inserted into the partition.
- insert(T) - Method in interface quarks.window.Window
-
Attempts to insert the tuple into its partition.
- InsertionTimeList<T> - Class in quarks.window
-
A window contents list that maintains insertion time.
- InsertionTimeList() - Constructor for class quarks.window.InsertionTimeList
-
- insertionTimeList() - Static method in class quarks.window.Policies
-
- Invocation<T extends Oplet<I,O>,I,O> - Class in quarks.runtime.etiao
-
An
Oplet
invocation in the context of the
ETIAO runtime.
- Invocation(String, T, int, int) - Constructor for class quarks.runtime.etiao.Invocation
-
- InvocationContext<I,O> - Class in quarks.runtime.etiao
-
Context information for the Oplet
's execution context.
- InvocationContext(String, JobContext, RuntimeServices, int, List<? extends Consumer<O>>) - Constructor for class quarks.runtime.etiao.InvocationContext
-
Creates an InvocationContext
with the specified parameters.
- InvocationType<I,O> - Class in quarks.runtime.etiao.graph.model
-
Generic type for an oplet invocation instance.
- InvocationType(Oplet<I, O>) - Constructor for class quarks.runtime.etiao.graph.model.InvocationType
-
- IotDevice - Interface in quarks.connectors.iot
-
Generic Internet of Things device connector.
- IotfDevice - Class in quarks.connectors.iotf
-
Connector for IBM Watson IoT Platform.
- IotfDevice(Topology, Properties) - Constructor for class quarks.connectors.iotf.IotfDevice
-
Create a connector to the IBM Watson IoT Platform Bluemix service with the device
specified by options
.
- IotfDevice(Topology, File) - Constructor for class quarks.connectors.iotf.IotfDevice
-
- IotfQuickstart - Class in quarks.samples.connectors.iotf
-
IBM Watson IoT Platform Quickstart sample.
- IotfQuickstart() - Constructor for class quarks.samples.connectors.iotf.IotfQuickstart
-
- IotfSensors - Class in quarks.samples.connectors.iotf
-
Sample sending sensor device events to IBM Watson IoT Platform.
- IotfSensors() - Constructor for class quarks.samples.connectors.iotf.IotfSensors
-
- isCleanSession() - Method in class quarks.connectors.mqtt.MqttConfig
-
Get the clean session setting.
- isConnected() - Method in interface quarks.graph.Connector
-
Is my output port connected to any input port.
- isControlServiceMBean(Class<?>) - Static method in class quarks.execution.services.Controls
-
Test to see if an interface represents a valid
control service MBean.
- isImmutable(Object) - Static method in class quarks.function.Functions
-
See if the functional logic is immutable.
- isImmutableClass(Class<?>) - Static method in class quarks.function.Functions
-
See if a function class is immutable.
- Isolate<T> - Class in quarks.oplet.plumbing
-
Isolate upstream processing from downstream
processing guaranteeing tuple order.
- Isolate() - Constructor for class quarks.oplet.plumbing.Isolate
-
- isolate(TStream<T>, boolean) - Static method in class quarks.topology.plumbing.PlumbingStreams
-
Isolate upstream processing from downstream processing.
- N - Static variable in interface quarks.analytics.math3.json.JsonUnivariateAggregate
-
JSON key used for representation of the number
of tuples that were aggregated.
- name() - Method in interface quarks.analytics.math3.json.JsonUnivariateAggregate
-
Name of the aggregate.
- newAgeBasedConfig(long, long) - Static method in class quarks.connectors.file.FileWriterRetentionConfig
-
same as newConfig(0, 0, ageSe, periodMsecc)
- newAggregateFileSizeBasedConfig(long) - Static method in class quarks.connectors.file.FileWriterRetentionConfig
-
same as newConfig(0, aggregateFileSize, 0, 0)
- newBoolean(Topology, long) - Method in class quarks.samples.utils.sensor.PeriodicRandomSensor
-
Create a periodic sensor stream with readings from Random.nextBoolean()
.
- newBytes(Topology, long, int) - Method in class quarks.samples.utils.sensor.PeriodicRandomSensor
-
Create a periodic sensor stream with readings from Random.nextBytes(byte[])
.
- newConfig(long, int, long, Predicate<T>) - Static method in class quarks.connectors.file.FileWriterCycleConfig
-
Create a new configuration.
- newConfig(int, long, Predicate<T>) - Static method in class quarks.connectors.file.FileWriterFlushConfig
-
Create a new configuration.
- newConfig(int, long, long, long) - Static method in class quarks.connectors.file.FileWriterRetentionConfig
-
Create a new configuration.
- newCountBasedConfig(int) - Static method in class quarks.connectors.file.FileWriterCycleConfig
-
same as newConfig0, cntTuples, 0, null)
- newCountBasedConfig(int) - Static method in class quarks.connectors.file.FileWriterFlushConfig
-
same as newConfig(cntTuples, 0, null)
- newDouble(Topology, long) - Method in class quarks.samples.utils.sensor.PeriodicRandomSensor
-
Create a periodic sensor stream with readings from Random.nextDouble()
.
- newFileCountBasedConfig(int) - Static method in class quarks.connectors.file.FileWriterRetentionConfig
-
same as newConfig(fileCount, 0, 0, 0)
- newFileSizeBasedConfig(long) - Static method in class quarks.connectors.file.FileWriterCycleConfig
-
same as newConfig(fileSize, 0, 0, null)
- newFloat(Topology, long) - Method in class quarks.samples.utils.sensor.PeriodicRandomSensor
-
Create a periodic sensor stream with readings from Random.nextFloat()
.
- newGaussian(Topology, long) - Method in class quarks.samples.utils.sensor.PeriodicRandomSensor
-
Create a periodic sensor stream with readings from Random.nextGaussian()
.
- newImplicitConfig() - Static method in class quarks.connectors.file.FileWriterFlushConfig
-
Create a new configuration.
- newInteger(Topology, long) - Method in class quarks.samples.utils.sensor.PeriodicRandomSensor
-
Create a periodic sensor stream with readings from Random.nextInt()
.
- newInteger(Topology, long, int) - Method in class quarks.samples.utils.sensor.PeriodicRandomSensor
-
Create a periodic sensor stream with readings from Random.nextInt(int)
.
- newLong(Topology, long) - Method in class quarks.samples.utils.sensor.PeriodicRandomSensor
-
Create a periodic sensor stream with readings from Random.nextLong()
.
- newPredicateBasedConfig(Predicate<T>) - Static method in class quarks.connectors.file.FileWriterCycleConfig
-
same as newConfig(0, 0, 0, tuplePredicate)
- newPredicateBasedConfig(Predicate<T>) - Static method in class quarks.connectors.file.FileWriterFlushConfig
-
same as newConfig(0, 0, tuplePredicate)
- newProvider() - Method in class quarks.samples.apps.TopologyProviderFactory
-
Get a new topology provider.
- newScheduler(ThreadFactory, BiConsumer<Object, Throwable>) - Static method in class quarks.runtime.etiao.TrackingScheduledExecutor
-
Creates an TrackingScheduledExecutor
using the supplied thread
factory and a completion handler.
- newTester() - Method in class quarks.providers.direct.DirectTopology
-
- newThread(Runnable) - Method in class quarks.runtime.etiao.ThreadFactoryTracker
-
Return a thread.
- newTimeBasedConfig(long) - Static method in class quarks.connectors.file.FileWriterCycleConfig
-
same as newConfig(0, 0, periodMsec, null)
- newTimeBasedConfig(long) - Static method in class quarks.connectors.file.FileWriterFlushConfig
-
same as newConfig(0, periodMsec, null)
- newTopology(String) - Method in class quarks.providers.direct.DirectProvider
-
- newTopology(String) - Method in interface quarks.topology.TopologyProvider
-
Create a new topology with a given name.
- newTopology() - Method in interface quarks.topology.TopologyProvider
-
Create a new topology with a generated name.
- noAuthentication() - Static method in class quarks.connectors.http.HttpClients
-
Create HTTP client with no authentication.
- ParameterSetter<T> - Interface in quarks.connectors.jdbc
-
Function that sets parameters in a JDBC SQL PreparedStatement
.
- partition() - Method in interface quarks.connectors.kafka.KafkaConsumer.ConsumerRecord
-
- Partition<T,K,L extends java.util.List<T>> - Interface in quarks.window
-
A partition within a Window
.
- PartitionedState<K,S> - Class in quarks.window
-
Maintain partitioned state.
- PartitionedState(Supplier<S>) - Constructor for class quarks.window.PartitionedState
-
Construct with an initial state function.
- peek(N) - Method in interface quarks.graph.Connector
-
Inserts a Peek
oplet between an output port and its
connections.
- peek(T) - Method in class quarks.metrics.oplets.CounterOp
-
- peek(T) - Method in class quarks.metrics.oplets.RateMeter
-
- Peek<T> - Class in quarks.oplet.core
-
Oplet that allows a peek at each tuple and always forwards a tuple onto
its single output port.
- Peek() - Constructor for class quarks.oplet.core.Peek
-
- peek(T) - Method in class quarks.oplet.core.Peek
-
- Peek<T> - Class in quarks.oplet.functional
-
Functional peek oplet.
- Peek(Consumer<T>) - Constructor for class quarks.oplet.functional.Peek
-
Peek oplet using a function to peek.
- peek(T) - Method in class quarks.oplet.functional.Peek
-
- peek(Consumer<T>) - Method in interface quarks.topology.TStream
-
Declare a stream that contains the same contents as this stream while
peeking at each element using peeker
.
- peekAll(Supplier<? extends Peek<?>>, Predicate<Vertex<?, ?, ?>>) - Method in interface quarks.graph.Graph
-
Insert Peek oplets returned by the specified Supplier
into
the outputs of all of the oplets which satisfy the specified
Predicate
.
- PeriodicMXBean - Interface in quarks.oplet.core.mbeans
-
Control interface for a periodic oplet.
- PeriodicRandomSensor - Class in quarks.samples.utils.sensor
-
A factory of simple periodic random sensor reading streams.
- PeriodicRandomSensor() - Constructor for class quarks.samples.utils.sensor.PeriodicRandomSensor
-
Create a new random periodic sensor factory configured
to use Random.Random()
.
- PeriodicRandomSensor(long) - Constructor for class quarks.samples.utils.sensor.PeriodicRandomSensor
-
Create a new random periodic sensor factory configured
to use Random.Random(long)
.
- PeriodicSource<T> - Class in quarks.oplet.core
-
- PeriodicSource(long, TimeUnit) - Constructor for class quarks.oplet.core.PeriodicSource
-
- PeriodicSource - Class in quarks.samples.topology
-
Periodic polling of source data.
- PeriodicSource() - Constructor for class quarks.samples.topology.PeriodicSource
-
- PeriodicSourceWithMetrics - Class in quarks.samples.utils.metrics
-
- PeriodicSourceWithMetrics() - Constructor for class quarks.samples.utils.metrics.PeriodicSourceWithMetrics
-
- Person - Class in quarks.samples.connectors.jdbc
-
A Person object for the sample.
- PersonData - Class in quarks.samples.connectors.jdbc
-
Utilities for loading the sample's person data.
- PersonData() - Constructor for class quarks.samples.connectors.jdbc.PersonData
-
- PersonId - Class in quarks.samples.connectors.jdbc
-
Another class containing a person id for the sample.
- pipe(Connector<C>, N) - Method in interface quarks.graph.Graph
-
Create a new connected
Vertex
associated with the
specified
Oplet
.
- Pipe<I,O> - Class in quarks.oplet.core
-
Pipe oplet with a single input and output.
- Pipe() - Constructor for class quarks.oplet.core.Pipe
-
- pipe(Pipe<T, U>) - Method in interface quarks.topology.TStream
-
Declare a stream that contains the output of the specified
Pipe
oplet applied to this stream.
- PlumbingStreams - Class in quarks.topology.plumbing
-
- PlumbingStreams() - Constructor for class quarks.topology.plumbing.PlumbingStreams
-
- Policies - Class in quarks.window
-
Common window policies.
- Policies() - Constructor for class quarks.window.Policies
-
- poll(Supplier<T>, long, TimeUnit) - Method in interface quarks.topology.Topology
-
Declare a new source stream that calls data.get()
periodically.
- preBuildTopology(Topology) - Method in class quarks.samples.apps.AbstractApplication
-
- preBuildTopology(Topology) - Method in class quarks.samples.apps.mqtt.AbstractMqttApplication
-
- Predicate<T> - Interface in quarks.function
-
Predicate function.
- PREFIX_JOBID - Static variable in class quarks.metrics.MetricObjectNameFactory
-
The prefix of the job id as serialized in the metric name.
- PREFIX_OPID - Static variable in class quarks.metrics.MetricObjectNameFactory
-
The prefix of the oplet id as serialized in the metric name.
- PressureReliever<T,K> - Class in quarks.oplet.plumbing
-
Relieve pressure on upstream oplets by discarding tuples.
- PressureReliever(int, Function<T, K>) - Constructor for class quarks.oplet.plumbing.PressureReliever
-
Pressure reliever that maintains up to count
most recent tuples per key.
- pressureReliever(TStream<T>, Function<T, K>, int) - Static method in class quarks.topology.plumbing.PlumbingStreams
-
Relieve pressure on upstream processing by discarding tuples.
- print() - Method in interface quarks.topology.TStream
-
Utility method to print the contents of this stream
to System.out
at runtime.
- process() - Method in class quarks.oplet.core.ProcessSource
-
- process() - Method in class quarks.oplet.functional.SupplierSource
-
- process() - Method in interface quarks.window.Partition
-
Invoke the WindowProcessor's processWindow method.
- processArgs(String[]) - Method in class quarks.samples.connectors.Options
-
- processOnInsert() - Static method in class quarks.window.Policies
-
Returns a trigger policy that triggers
processing on every insert.
- ProcessSource<T> - Class in quarks.oplet.core
-
- ProcessSource() - Constructor for class quarks.oplet.core.ProcessSource
-
- processWhenFullAndEvict(int) - Static method in class quarks.window.Policies
-
Returns a trigger policy that triggers when the size of a partition
equals or exceeds a value, and then evicts its contents.
- props - Variable in class quarks.samples.apps.AbstractApplication
-
- propsPath - Variable in class quarks.samples.apps.AbstractApplication
-
- ProviderPubSub - Class in quarks.connectors.pubsub.service
-
Publish subscribe service allowing exchange of streams between jobs in a provider.
- ProviderPubSub() - Constructor for class quarks.connectors.pubsub.service.ProviderPubSub
-
- publish(TStream<T>, Function<T, String>, Function<T, String>, Function<T, String>, Function<T, Integer>) - Method in class quarks.connectors.kafka.KafkaProducer
-
Publish the stream of tuples as Kafka key/value records
to the specified partitions of the specified topics.
- publish(TStream<String>, String) - Method in class quarks.connectors.kafka.KafkaProducer
-
Publish the stream of tuples as Kafka key/value records
to the specified partitions of the specified topics.
- publish(TStream<T>, Function<T, String>, Function<T, byte[]>, Function<T, Integer>, Function<T, Boolean>) - Method in class quarks.connectors.mqtt.MqttStreams
-
Publish a stream's tuples as MQTT messages.
- publish(TStream<String>, String, int, boolean) - Method in class quarks.connectors.mqtt.MqttStreams
-
Publish a TStream<String>
stream's tuples as MQTT messages.
- Publish<T> - Class in quarks.connectors.pubsub.oplets
-
Publish a stream to a PublishSubscribeService service.
- Publish(String, Class<? super T>) - Constructor for class quarks.connectors.pubsub.oplets.Publish
-
- publish(TStream<T>, String, Class<? super T>) - Static method in class quarks.connectors.pubsub.PublishSubscribe
-
Publish this stream to a topic.
- publishBytes(TStream<T>, Function<T, byte[]>, Function<T, byte[]>, Function<T, String>, Function<T, Integer>) - Method in class quarks.connectors.kafka.KafkaProducer
-
Publish the stream of tuples as Kafka key/value records
to the specified topic partitions.
- PublisherApp - Class in quarks.samples.connectors.kafka
-
A Kafka producer/publisher topology application.
- PublisherApp - Class in quarks.samples.connectors.mqtt
-
A MQTT publisher topology application.
- PublishSubscribe - Class in quarks.connectors.pubsub
-
Publish subscribe model.
- PublishSubscribe() - Constructor for class quarks.connectors.pubsub.PublishSubscribe
-
- PublishSubscribeService - Interface in quarks.connectors.pubsub.service
-
Publish subscribe service.
- purgeTables(DataSource) - Static method in class quarks.samples.connectors.jdbc.DbUtils
-
Purge the sample's tables
- put(String, Object) - Method in class quarks.samples.connectors.Options
-
- QoS - Interface in quarks.connectors.iot
-
Device event quality of service levels.
- quarks.analytics.math3.json - package quarks.analytics.math3.json
-
JSON analytics using Apache Commons Math.
- quarks.analytics.math3.stat - package quarks.analytics.math3.stat
-
Statistical algorithms using Apache Commons Math.
- quarks.analytics.sensors - package quarks.analytics.sensors
-
Analytics focused on handling sensor data.
- quarks.connectors.file - package quarks.connectors.file
-
File stream connector.
- quarks.connectors.http - package quarks.connectors.http
-
HTTP stream connector.
- quarks.connectors.iot - package quarks.connectors.iot
-
Quarks device connector API to a message hub.
- quarks.connectors.iotf - package quarks.connectors.iotf
-
IBM Watson IoT Platform stream connector.
- quarks.connectors.jdbc - package quarks.connectors.jdbc
-
JDBC based database stream connector.
- quarks.connectors.kafka - package quarks.connectors.kafka
-
Apache Kafka enterprise messing hub stream connector.
- quarks.connectors.mqtt - package quarks.connectors.mqtt
-
MQTT (lightweight messaging protocol for small sensors and mobile devices) stream connector.
- quarks.connectors.mqtt.iot - package quarks.connectors.mqtt.iot
-
An MQTT based IotDevice connector.
- quarks.connectors.pubsub - package quarks.connectors.pubsub
-
Publish subscribe model between jobs.
- quarks.connectors.pubsub.oplets - package quarks.connectors.pubsub.oplets
-
Oplets supporting publish subscribe service.
- quarks.connectors.pubsub.service - package quarks.connectors.pubsub.service
-
Publish subscribe service.
- quarks.connectors.serial - package quarks.connectors.serial
-
Serial port connector API.
- quarks.connectors.wsclient - package quarks.connectors.wsclient
-
WebSocket Client Connector API for sending and receiving messages to a WebSocket Server.
- quarks.connectors.wsclient.javax.websocket - package quarks.connectors.wsclient.javax.websocket
-
WebSocket Client Connector for sending and receiving messages to a WebSocket Server.
- quarks.connectors.wsclient.javax.websocket.runtime - package quarks.connectors.wsclient.javax.websocket.runtime
-
- quarks.execution - package quarks.execution
-
Execution of Quarks topologies and graphs.
- quarks.execution.mbeans - package quarks.execution.mbeans
-
Management MBeans for execution.
- quarks.execution.services - package quarks.execution.services
-
Execution services.
- quarks.function - package quarks.function
-
Functional interfaces for lambda expressions.
- quarks.graph - package quarks.graph
-
Low-level graph building API.
- quarks.javax.websocket - package quarks.javax.websocket
-
Support for working around JSR356 limitations for SSL client container/sockets.
- quarks.javax.websocket.impl - package quarks.javax.websocket.impl
-
Support for working around JSR356 limitations for SSL client container/sockets.
- quarks.metrics - package quarks.metrics
-
Metric utility methods, oplets, and reporters which allow an
application to expose metric values, for example via JMX.
- quarks.metrics.oplets - package quarks.metrics.oplets
-
- quarks.oplet - package quarks.oplet
-
Oplets API.
- quarks.oplet.core - package quarks.oplet.core
-
Core primitive oplets.
- quarks.oplet.core.mbeans - package quarks.oplet.core.mbeans
-
Management beans for core oplets.
- quarks.oplet.functional - package quarks.oplet.functional
-
Oplets that process tuples using functions.
- quarks.oplet.plumbing - package quarks.oplet.plumbing
-
Oplets that control the flow of tuples.
- quarks.oplet.window - package quarks.oplet.window
-
Oplets using windows.
- quarks.providers.development - package quarks.providers.development
-
Execution of a streaming topology in a development environment .
- quarks.providers.direct - package quarks.providers.direct
-
Direct execution of a streaming topology.
- quarks.runtime.etiao - package quarks.runtime.etiao
-
A runtime for executing a Quarks streaming topology, designed as an embeddable library
so that it can be executed in a simple Java application.
- quarks.runtime.etiao.graph - package quarks.runtime.etiao.graph
-
- quarks.runtime.etiao.graph.model - package quarks.runtime.etiao.graph.model
-
- quarks.runtime.etiao.mbeans - package quarks.runtime.etiao.mbeans
-
- quarks.runtime.jmxcontrol - package quarks.runtime.jmxcontrol
-
- quarks.runtime.jsoncontrol - package quarks.runtime.jsoncontrol
-
- quarks.samples.apps - package quarks.samples.apps
-
Support for some more complex Quarks application samples.
- quarks.samples.apps.mqtt - package quarks.samples.apps.mqtt
-
Base support for Quarks MQTT based application samples.
- quarks.samples.apps.sensorAnalytics - package quarks.samples.apps.sensorAnalytics
-
The Sensor Analytics sample application demonstrates some common
continuous sensor analytic application themes.
- quarks.samples.connectors - package quarks.samples.connectors
-
General support for connector samples.
- quarks.samples.connectors.file - package quarks.samples.connectors.file
-
- quarks.samples.connectors.iotf - package quarks.samples.connectors.iotf
-
Samples showing device events and commands with IBM Watson IoT Platform.
- quarks.samples.connectors.jdbc - package quarks.samples.connectors.jdbc
-
- quarks.samples.connectors.kafka - package quarks.samples.connectors.kafka
-
- quarks.samples.connectors.mqtt - package quarks.samples.connectors.mqtt
-
- quarks.samples.console - package quarks.samples.console
-
- quarks.samples.topology - package quarks.samples.topology
-
Samples showing creating and executing basic topologies .
- quarks.samples.utils.metrics - package quarks.samples.utils.metrics
-
- quarks.samples.utils.sensor - package quarks.samples.utils.sensor
-
- quarks.test.svt - package quarks.test.svt
-
- quarks.topology - package quarks.topology
-
Functional api to build a streaming topology.
- quarks.topology.json - package quarks.topology.json
-
Utilities for use of JSON in a streaming topology.
- quarks.topology.plumbing - package quarks.topology.plumbing
-
Plumbing for a streaming topology.
- quarks.topology.tester - package quarks.topology.tester
-
Testing for a streaming topology.
- quarks.window - package quarks.window
-
Window API.
- QuarksSslContainerProvider - Class in quarks.javax.websocket
-
A WebSocketContainer
provider for dealing with javax.websocket
SSL issues.
- QuarksSslContainerProvider() - Constructor for class quarks.javax.websocket.QuarksSslContainerProvider
-
- QuarksSslContainerProviderImpl - Class in quarks.javax.websocket.impl
-
- QuarksSslContainerProviderImpl() - Constructor for class quarks.javax.websocket.impl.QuarksSslContainerProviderImpl
-
- quickstart(Topology, String) - Static method in class quarks.connectors.iotf.IotfDevice
-
- QUICKSTART_DEVICE_TYPE - Static variable in class quarks.connectors.iotf.IotfDevice
-
- Range<T> - Class in quarks.samples.apps
-
A range of values and and a way to check for containment.
- rateMeter(TStream<T>) - Static method in class quarks.metrics.Metrics
-
Measure current tuple throughput and calculate one-, five-, and
fifteen-minute exponentially-weighted moving averages.
- RateMeter<T> - Class in quarks.metrics.oplets
-
A metrics oplet which measures current tuple throughput and one-, five-,
and fifteen-minute exponentially-weighted moving averages.
- RateMeter() - Constructor for class quarks.metrics.oplets.RateMeter
-
- receive() - Method in class quarks.connectors.wsclient.javax.websocket.Jsr356WebSocketClient
-
Create a stream of JsonObject tuples from received JSON WebSocket text messages.
- receive() - Method in interface quarks.connectors.wsclient.WebSocketClient
-
Create a stream of JsonObject tuples from received JSON WebSocket text messages.
- receiveBytes() - Method in class quarks.connectors.wsclient.javax.websocket.Jsr356WebSocketClient
-
Create a stream of byte[] tuples from received WebSocket binary messages.
- receiveBytes() - Method in interface quarks.connectors.wsclient.WebSocketClient
-
Create a stream of byte[] tuples from received WebSocket binary messages.
- receiveString() - Method in class quarks.connectors.wsclient.javax.websocket.Jsr356WebSocketClient
-
Create a stream of String tuples from received WebSocket text messages.
- receiveString() - Method in interface quarks.connectors.wsclient.WebSocketClient
-
Create a stream of String tuples from received WebSocket text messages.
- registerControl(String, String, String, Class<T>, T) - Method in interface quarks.execution.services.ControlService
-
Register a control server MBean for an oplet.
- registerControl(String, String, String, Class<T>, T) - Method in class quarks.runtime.jmxcontrol.JMXControlService
-
Register a control object as an MBean.
- registerControl(String, String, String, Class<T>, T) - Method in class quarks.runtime.jsoncontrol.JsonControlService
-
Register a control server MBean for an oplet.
- registerPartitionProcessor(BiConsumer<List<T>, K>) - Method in interface quarks.window.Window
-
Register a WindowProcessor.
- registerScheduledExecutorService(ScheduledExecutorService) - Method in interface quarks.window.Window
-
Register a ScheduledExecutorService.
- registerWith(MBeanServer) - Method in class quarks.metrics.MetricsSetup
-
Use the specified MBeanServer
with this metric setup.
- Regression - Enum in quarks.analytics.math3.stat
-
Univariate regression aggregates.
- removeService(Class<T>) - Method in class quarks.execution.services.ServiceContainer
-
Removes the specified service from this ServiceContainer
.
- removeState(K) - Method in class quarks.window.PartitionedState
-
- removeSubscriber(String, Consumer<?>) - Method in class quarks.connectors.pubsub.service.ProviderPubSub
-
- removeSubscriber(String, Consumer<?>) - Method in interface quarks.connectors.pubsub.service.PublishSubscribeService
-
- requests(TStream<T>, Supplier<CloseableHttpClient>, Function<T, String>, Function<T, String>, BiFunction<T, CloseableHttpResponse, R>) - Static method in class quarks.connectors.http.HttpStreams
-
Make an HTTP request for each tuple on a stream.
- result(JsonElement, JsonObject) - Method in interface quarks.analytics.math3.json.JsonUnivariateAggregator
-
Place the result of the aggregation into the result
object.
- result(JsonElement, JsonObject) - Method in class quarks.analytics.math3.stat.JsonStorelessStatistic
-
- ResultsHandler<T,R> - Interface in quarks.connectors.jdbc
-
Handle the results of executing an SQL statement.
- run() - Method in class quarks.oplet.core.PeriodicSource
-
- run() - Method in class quarks.oplet.core.ProcessSource
-
- run() - Method in class quarks.oplet.plumbing.Isolate
-
- run() - Method in class quarks.samples.apps.AbstractApplication
-
Construct and run the application's topology.
- run() - Method in class quarks.samples.connectors.file.FileReaderApp
-
- run() - Method in class quarks.samples.connectors.file.FileWriterApp
-
- run(Options) - Static method in class quarks.samples.connectors.kafka.Runner
-
Build and run the publisher or subscriber application.
- run(Options) - Static method in class quarks.samples.connectors.mqtt.Runner
-
Build and run the publisher or subscriber application.
- Runner - Class in quarks.samples.connectors.kafka
-
Build and run the publisher or subscriber application.
- Runner() - Constructor for class quarks.samples.connectors.kafka.Runner
-
- Runner - Class in quarks.samples.connectors.mqtt
-
Build and run the publisher or subscriber application.
- Runner() - Constructor for class quarks.samples.connectors.mqtt.Runner
-
- RuntimeServices - Interface in quarks.execution.services
-
At runtime a container provides services to
executing elements such as oplets and functions.
- runWithFinal(Runnable, Runnable) - Static method in class quarks.function.Functions
-
Wrap a Runnable
with a final action that
is always called when action.run()
completes.
- scheduleEvictIfEmpty(long, TimeUnit) - Static method in class quarks.window.Policies
-
A policy which schedules a future partition eviction if the partition is empty.
- scheduleEvictOnFirstInsert(long, TimeUnit) - Static method in class quarks.window.Policies
-
A policy which schedules a future partition eviction on the first insert.
- send(TStream<JsonObject>) - Method in class quarks.connectors.wsclient.javax.websocket.Jsr356WebSocketClient
-
Send a stream's JsonObject tuples as JSON in a WebSocket text message.
- send(TStream<JsonObject>) - Method in interface quarks.connectors.wsclient.WebSocketClient
-
Send a stream's JsonObject tuples as JSON in a WebSocket text message.
- sendBytes(TStream<byte[]>) - Method in class quarks.connectors.wsclient.javax.websocket.Jsr356WebSocketClient
-
Send a stream's byte[] tuples in a WebSocket binary message.
- sendBytes(TStream<byte[]>) - Method in interface quarks.connectors.wsclient.WebSocketClient
-
Send a stream's byte[] tuples in a WebSocket binary message.
- sendString(TStream<String>) - Method in class quarks.connectors.wsclient.javax.websocket.Jsr356WebSocketClient
-
Send a stream's String tuples in a WebSocket text message.
- sendString(TStream<String>) - Method in interface quarks.connectors.wsclient.WebSocketClient
-
Send a stream's String tuples in a WebSocket text message.
- Sensor1 - Class in quarks.samples.apps.sensorAnalytics
-
Analytics for "Sensor1".
- Sensor1(Topology, SensorAnalyticsApplication) - Constructor for class quarks.samples.apps.sensorAnalytics.Sensor1
-
- SensorAnalyticsApplication - Class in quarks.samples.apps.sensorAnalytics
-
A sample application demonstrating some common sensor analytic processing
themes.
- sensorEventId(String, String) - Method in class quarks.samples.apps.mqtt.AbstractMqttApplication
-
Compose a MqttDevice eventId for the sensor.
- sensorsAB(Topology) - Static method in class quarks.samples.topology.SensorsAggregates
-
Create a stream containing two aggregates from two bursty
sensors A and B that only produces output when the sensors
(independently) are having a burst period out of their normal range.
- SensorsAggregates - Class in quarks.samples.topology
-
Aggregation of sensor readings.
- SensorsAggregates() - Constructor for class quarks.samples.topology.SensorsAggregates
-
- SerialDevice - Interface in quarks.connectors.serial
-
Access to a device (or devices) connected by a serial port.
- SerialPort - Interface in quarks.connectors.serial
-
Serial port runtime access.
- ServiceContainer - Class in quarks.execution.services
-
Provides a container for services.
- ServiceContainer() - Constructor for class quarks.execution.services.ServiceContainer
-
- setActionTimeToWaitMillis(long) - Method in class quarks.connectors.mqtt.MqttConfig
-
Maximum time to wait for an action (e.g., publish message) to complete.
- setCleanSession(boolean) - Method in class quarks.connectors.mqtt.MqttConfig
-
Clean Session.
- setClientId(String) - Method in class quarks.connectors.mqtt.MqttConfig
-
Connection Client Id.
- setConnectionTimeout(int) - Method in class quarks.connectors.mqtt.MqttConfig
-
Connection timeout.
- setD1(Double) - Method in class quarks.test.svt.MyClass1
-
- setD1(Double) - Method in class quarks.test.svt.MyClass2
-
- setDestination(Consumer<T>) - Method in class quarks.runtime.etiao.SettableForwarder
-
Change the destination.
- setIdleTimeout(int) - Method in class quarks.connectors.mqtt.MqttConfig
-
Idle connection timeout.
- setInitializer(Consumer<SerialPort>) - Method in interface quarks.connectors.serial.SerialDevice
-
Set the initialization function for this port.
- setKeepAliveInterval(int) - Method in class quarks.connectors.mqtt.MqttConfig
-
Connection Keep alive.
- setMc1(MyClass1) - Method in class quarks.test.svt.MyClass2
-
- setMc2(MyClass1) - Method in class quarks.test.svt.MyClass2
-
- setName(String) - Method in class quarks.runtime.etiao.EtiaoJob
-
- setParameters(T, PreparedStatement) - Method in interface quarks.connectors.jdbc.ParameterSetter
-
Set 0 or more parameters in a JDBC PreparedStatement.
- setPassword(char[]) - Method in class quarks.connectors.mqtt.MqttConfig
-
Set the password to use for authentication with the server.
- setPeriod(long) - Method in interface quarks.oplet.core.mbeans.PeriodicMXBean
-
Set the period.
- setPeriod(long) - Method in class quarks.oplet.core.PeriodicSource
-
- setPersistence(MqttClientPersistence) - Method in class quarks.connectors.mqtt.MqttConfig
-
QoS 1 and 2 in-flight message persistence.
- setS1(String) - Method in class quarks.test.svt.MyClass1
-
- setS1(String) - Method in class quarks.test.svt.MyClass2
-
- setS2(String) - Method in class quarks.test.svt.MyClass1
-
- setSeed(long) - Method in class quarks.samples.utils.sensor.PeriodicRandomSensor
-
Set the seed to be used by subsequently created sensor streams.
- setServerURLs(String[]) - Method in class quarks.connectors.mqtt.MqttConfig
-
MQTT Server URLs
- setSinker(Consumer<T>) - Method in class quarks.oplet.core.Sink
-
Set the sink function.
- setState(K, S) - Method in class quarks.window.PartitionedState
-
Set the current state for key
.
- setSubscriberIdleReconnectInterval(int) - Method in class quarks.connectors.mqtt.MqttConfig
-
Subscriber idle reconnect interval.
- SettableForwarder<T> - Class in quarks.runtime.etiao
-
A forwarding Streamer whose destination
can be changed.
- SettableForwarder() - Constructor for class quarks.runtime.etiao.SettableForwarder
-
- SettableForwarder(Consumer<T>) - Constructor for class quarks.runtime.etiao.SettableForwarder
-
Create with the specified destination.
- setTarget(int, Consumer<O>) - Method in class quarks.runtime.etiao.Invocation
-
Disconnects the specified port and reconnects it to the specified target.
- setUserName(String) - Method in class quarks.connectors.mqtt.MqttConfig
-
Set the username to use for authentication with the server.
- setWill(String, byte[], int, boolean) - Method in class quarks.connectors.mqtt.MqttConfig
-
Last Will and Testament.
- shouldCycle() - Method in class quarks.connectors.file.FileWriterPolicy
-
- shouldFlush() - Method in class quarks.connectors.file.FileWriterPolicy
-
- shutdown() - Method in class quarks.runtime.etiao.ThreadFactoryTracker
-
This initiates an orderly shutdown in which no new tasks will be
accepted but previously submitted tasks continue to be executed.
- shutdownNow() - Method in class quarks.runtime.etiao.ThreadFactoryTracker
-
Interrupts all user treads and briefly waits for each thread to finish
execution.
- SimpleFilterTransform - Class in quarks.samples.topology
-
- SimpleFilterTransform() - Constructor for class quarks.samples.topology.SimpleFilterTransform
-
- SimplePublisherApp - Class in quarks.samples.connectors.kafka
-
A simple Kafka publisher topology application.
- SimplePublisherApp - Class in quarks.samples.connectors.mqtt
-
A simple MQTT publisher topology application.
- SimpleReaderApp - Class in quarks.samples.connectors.jdbc
-
A simple JDBC connector sample demonstrating streaming read access
of a dbms table and creating stream tuples from the results.
- SimpleSubscriberApp - Class in quarks.samples.connectors.kafka
-
A simple Kafka subscriber topology application.
- SimpleSubscriberApp - Class in quarks.samples.connectors.mqtt
-
A simple MQTT subscriber topology application.
- simpleTS() - Static method in class quarks.samples.connectors.Util
-
Generate a simple timestamp with the form HH:mm:ss.SSS
- SimpleWriterApp - Class in quarks.samples.connectors.jdbc
-
A simple JDBC connector sample demonstrating streaming write access
of a dbms to add stream tuples to a table.
- simulatedSensors(IotDevice, boolean) - Static method in class quarks.samples.connectors.iotf.IotfSensors
-
Simulate two bursty sensors and send the readings as IoTF device events
with an identifier of sensors
.
- SimulatedSensors - Class in quarks.samples.utils.sensor
-
Streams of simulated sensors.
- SimulatedSensors() - Constructor for class quarks.samples.utils.sensor.SimulatedSensors
-
- SingleMetricAbstractOplet<T> - Class in quarks.metrics.oplets
-
Base for metrics oplets which use a single metric object.
- SingleMetricAbstractOplet(String) - Constructor for class quarks.metrics.oplets.SingleMetricAbstractOplet
-
- Sink<T> - Class in quarks.oplet.core
-
Sink a stream by processing each tuple through
a
Consumer
.
- Sink() - Constructor for class quarks.oplet.core.Sink
-
Create a Sink
that discards all tuples.
- Sink(Consumer<T>) - Constructor for class quarks.oplet.core.Sink
-
Create a Sink
oplet.
- sink(Consumer<T>) - Method in interface quarks.topology.TStream
-
Sink (terminate) this stream using a function.
- sink(Sink<T>) - Method in interface quarks.topology.TStream
-
Sink (terminate) this stream using a oplet.
- size() - Method in class quarks.window.InsertionTimeList
-
- source(N) - Method in interface quarks.graph.Graph
-
Create a new unconnected
Vertex
associated with the
specified source
Oplet
.
- Source<T> - Class in quarks.oplet.core
-
- Source() - Constructor for class quarks.oplet.core.Source
-
- source(Supplier<Iterable<T>>) - Method in interface quarks.topology.Topology
-
Declare a new source stream that iterates over the return of
Iterable<T> get()
from data
.
- Split<T> - Class in quarks.oplet.core
-
Split a stream into multiple streams depending
on the result of a splitter function.
- Split(ToIntFunction<T>) - Constructor for class quarks.oplet.core.Split
-
- split(int, ToIntFunction<T>) - Method in interface quarks.topology.TStream
-
Split a stream's tuples among n
streams as specified by
splitter
.
- splitAlert(TStream<JsonObject>, int) - Static method in class quarks.samples.console.ConsoleWaterDetector
-
Splits the incoming TStream<JsonObject> into individual TStreams based on the sensor type
- SplitWithMetrics - Class in quarks.samples.utils.metrics
-
Instruments a topology with a tuple counter on a specified stream.
- SplitWithMetrics() - Constructor for class quarks.samples.utils.metrics.SplitWithMetrics
-
- start() - Method in class quarks.oplet.core.FanOut
-
- start() - Method in class quarks.oplet.core.PeriodicSource
-
- start() - Method in class quarks.oplet.core.Pipe
-
- start() - Method in class quarks.oplet.core.ProcessSource
-
- start() - Method in class quarks.oplet.core.Sink
-
- start() - Method in class quarks.oplet.core.Split
-
- start() - Method in class quarks.oplet.core.Union
-
- start() - Method in class quarks.oplet.functional.Events
-
- start() - Method in interface quarks.oplet.Oplet
-
Start the oplet.
- start() - Method in class quarks.oplet.plumbing.Isolate
-
- start() - Method in class quarks.runtime.etiao.Executable
-
Starts all the invocations.
- start() - Method in class quarks.runtime.etiao.Invocation
-
Start the oplet.
- startConsoleReporter() - Method in class quarks.metrics.MetricsSetup
-
Starts the metric ConsoleReporter
polling every second.
- startJMXReporter(String) - Method in class quarks.metrics.MetricsSetup
-
Starts the metric JMXReporter
.
- stateChange(Job.Action) - Method in interface quarks.execution.Job
-
Initiates a
State
change.
- stateChange(Job.Action) - Method in class quarks.runtime.etiao.EtiaoJob
-
- StatementSupplier - Interface in quarks.connectors.jdbc
-
Function that supplies a JDBC SQL PreparedStatement
.
- Statistic - Enum in quarks.analytics.math3.stat
-
Statistic implementations.
- statistics(Statistic...) - Static method in class quarks.samples.apps.JsonTuples
-
Create a function that computes the specified statistics on the list of
samples and returns a new sample containing the result.
- streamContents(TStream<T>, T...) - Method in interface quarks.topology.tester.Tester
-
Return a condition that evaluates if stream
has submitted
tuples matching values
in the same order.
- StreamTags - Class in quarks.samples.topology
-
Illustrates tagging TStreams with string labels.
- StreamTags() - Constructor for class quarks.samples.topology.StreamTags
-
- strings(String...) - Method in interface quarks.topology.Topology
-
Declare a stream of strings.
- submit(E) - Method in interface quarks.execution.Submitter
-
Submit an executable.
- submit(E, JsonObject) - Method in interface quarks.execution.Submitter
-
Submit an executable.
- submit(O) - Method in class quarks.oplet.core.Pipe
-
Submit a tuple to single output.
- submit(T) - Method in class quarks.oplet.core.Source
-
Submit a tuple to single output.
- submit(Topology, JsonObject) - Method in class quarks.providers.development.DevelopmentProvider
-
- submit(Topology) - Method in class quarks.providers.direct.DirectProvider
-
- submit(Topology, JsonObject) - Method in class quarks.providers.direct.DirectProvider
-
- Submitter<E,J extends Job> - Interface in quarks.execution
-
An interface for submission of an executable.
- subscribe(Function<KafkaConsumer.StringConsumerRecord, T>, String...) - Method in class quarks.connectors.kafka.KafkaConsumer
-
Subscribe to the specified topics and yield a stream of tuples
from the published Kafka records.
- subscribe(String, int, BiFunction<String, byte[], T>) - Method in class quarks.connectors.mqtt.MqttStreams
-
Subscribe to the MQTT topic(s) and create a stream of tuples of type T
.
- subscribe(String, int) - Method in class quarks.connectors.mqtt.MqttStreams
-
Subscribe to the MQTT topic(s) and create a TStream<String>
.
- subscribe(TopologyElement, String, Class<T>) - Static method in class quarks.connectors.pubsub.PublishSubscribe
-
Subscribe to a published topic.
- subscribeBytes(Function<KafkaConsumer.ByteConsumerRecord, T>, String...) - Method in class quarks.connectors.kafka.KafkaConsumer
-
Subscribe to the specified topics and yield a stream of tuples
from the published Kafka records.
- SubscriberApp - Class in quarks.samples.connectors.kafka
-
A Kafka consumer/subscriber topology application.
- SubscriberApp - Class in quarks.samples.connectors.mqtt
-
A MQTT subscriber topology application.
- Supplier<T> - Interface in quarks.function
-
Function that supplies a value.
- SupplierPeriodicSource<T> - Class in quarks.oplet.functional
-
- SupplierPeriodicSource(long, TimeUnit, Supplier<T>) - Constructor for class quarks.oplet.functional.SupplierPeriodicSource
-
- SupplierSource<T> - Class in quarks.oplet.functional
-
- SupplierSource() - Constructor for class quarks.oplet.functional.SupplierSource
-
- SupplierSource(Supplier<Iterable<T>>) - Constructor for class quarks.oplet.functional.SupplierSource
-
- synchronizedBiFunction(BiFunction<T, U, R>) - Static method in class quarks.function.Functions
-
Return a thread-safe version of a BiFunction
function.
- synchronizedConsumer(Consumer<T>) - Static method in class quarks.function.Functions
-
Return a thread-safe version of a Consumer
function.
- synchronizedFunction(Function<T, R>) - Static method in class quarks.function.Functions
-
Return a thread-safe version of a Function
function.
- synchronizedSupplier(Supplier<T>) - Static method in class quarks.function.Functions
-
Return a thread-safe version of a Supplier
function.
- t - Variable in class quarks.samples.apps.AbstractApplication
-
- tag(String...) - Method in interface quarks.graph.Connector
-
Adds the specified tags to the connector.
- tag(String...) - Method in interface quarks.topology.TStream
-
Adds the specified tags to the stream.
- test(T) - Method in interface quarks.function.Predicate
-
Test a value against a predicate.
- Tester - Interface in quarks.topology.tester
-
A Tester
adds the ability to test a topology in a test framework such
as JUnit.
- textFileReader(TStream<String>) - Static method in class quarks.connectors.file.FileStreams
-
Declare a stream containing the lines read from the files
whose pathnames correspond to each tuple on the pathnames
stream.
- textFileReader(TStream<String>, Function<String, String>, BiFunction<String, Exception, String>) - Static method in class quarks.connectors.file.FileStreams
-
Declare a stream containing the lines read from the files
whose pathnames correspond to each tuple on the pathnames
stream.
- textFileWriter(TStream<String>, Supplier<String>) - Static method in class quarks.connectors.file.FileStreams
-
Write the contents of a stream to files.
- textFileWriter(TStream<String>, Supplier<String>, Supplier<IFileWriterPolicy<String>>) - Static method in class quarks.connectors.file.FileStreams
-
Write the contents of a stream to files subject to the control
of a file writer policy.
- ThreadFactoryTracker - Class in quarks.runtime.etiao
-
Tracks threads created for executing user tasks.
- ToDoubleFunction<T> - Interface in quarks.function
-
Function that returns a double primitive.
- ToIntFunction<T> - Interface in quarks.function
-
Function that returns a int primitive.
- toPayload - Variable in class quarks.connectors.wsclient.javax.websocket.runtime.WebSocketClientSender
-
- toPersonIds(List<Person>) - Static method in class quarks.samples.connectors.jdbc.PersonData
-
Convert a List<Person>
to a List<PersonId>
- topic() - Method in interface quarks.connectors.kafka.KafkaConsumer.ConsumerRecord
-
- topology() - Method in class quarks.connectors.iotf.IotfDevice
-
- topology() - Method in class quarks.connectors.mqtt.iot.MqttDevice
-
- topology() - Method in class quarks.connectors.mqtt.MqttStreams
-
Get the
Topology
the connector is associated with.
- topology() - Method in class quarks.connectors.wsclient.javax.websocket.Jsr356WebSocketClient
-
- Topology - Interface in quarks.topology
-
A declaration of a topology of streaming data.
- topology() - Method in interface quarks.topology.TopologyElement
-
Topology this element is contained in.
- TopologyElement - Interface in quarks.topology
-
An element of a Topology
.
- TopologyProvider - Interface in quarks.topology
-
Provider (factory) for creating topologies.
- TopologyProviderFactory - Class in quarks.samples.apps
-
A configuration driven factory for a Quarks topology provider.
- TopologyProviderFactory(Properties) - Constructor for class quarks.samples.apps.TopologyProviderFactory
-
Construct a factory
- TopologyTestBasic - Class in quarks.test.svt
-
- TopologyTestBasic() - Constructor for class quarks.test.svt.TopologyTestBasic
-
- toString() - Method in class quarks.connectors.file.FileWriterCycleConfig
-
- toString() - Method in class quarks.connectors.file.FileWriterFlushConfig
-
- toString() - Method in class quarks.connectors.file.FileWriterPolicy
-
- toString() - Method in class quarks.connectors.file.FileWriterRetentionConfig
-
- toString() - Method in class quarks.samples.apps.Range
-
Yields <lowerBoundMarker><lowerBound>..<upperBound><upperBoundMarker>
.
- toString() - Method in class quarks.samples.connectors.jdbc.Person
-
- toString() - Method in class quarks.samples.connectors.jdbc.PersonId
-
- toString() - Method in class quarks.test.svt.MyClass1
-
- toString() - Method in class quarks.test.svt.MyClass2
-
- traceStream(TStream<T>, String, Supplier<String>) - Method in class quarks.samples.apps.ApplicationUtilities
-
Trace a stream to System.out if the sensor id's "label" has been configured
to enable tracing.
- traceStream(TStream<T>, Supplier<String>) - Method in class quarks.samples.apps.ApplicationUtilities
-
Trace a stream to System.out if the "label" has been configured
to enable tracing.
- TrackingScheduledExecutor - Class in quarks.runtime.etiao
-
Extends a ScheduledThreadPoolExecutor
with the ability to track
scheduled tasks and cancel them in case a task completes abruptly due to
an exception.
- TSink<T> - Interface in quarks.topology
-
Termination point (sink) for a stream.
- TStream<T> - Interface in quarks.topology
-
A TStream
is a declaration of a continuous sequence of tuples.
- tupleCount(TStream<?>, long) - Method in interface quarks.topology.tester.Tester
-
Return a condition that evaluates if stream
has submitted exactly
expectedCount
number of tuples.
- TWindow<T,K> - Interface in quarks.topology
-
Partitioned window of tuples.
- TYPE - Static variable in interface quarks.execution.mbeans.JobMXBean
-
TYPE is used to identify this bean as a job bean when building the bean's ObjectName
.
- TYPE_KEY - Static variable in class quarks.runtime.jsoncontrol.JsonControlService
-
Key for the type of the control MBean in a JSON request.
- TYPE_PREFIX - Static variable in class quarks.metrics.MetricObjectNameFactory
-
Prefix of all metric types.