- AbstractApplication - Class in org.apache.edgent.samples.apps
-
An Application base class.
- AbstractApplication(String) - Constructor for class org.apache.edgent.samples.apps.AbstractApplication
-
- AbstractContext<I,O> - Class in org.apache.edgent.runtime.etiao
-
Provides a skeletal implementation of the
OpletContext
interface.
- AbstractContext(JobContext, RuntimeServices) - Constructor for class org.apache.edgent.runtime.etiao.AbstractContext
-
- AbstractGraph<G> - Class in org.apache.edgent.graph.spi
-
A skeletal implementation of the
Graph
interface,
to minimize the effort required to implement the interface.
- AbstractGraph() - Constructor for class org.apache.edgent.graph.spi.AbstractGraph
-
- AbstractGraphJob - Class in org.apache.edgent.graph.spi.execution
-
Placeholder for a skeletal implementation of the
Job
interface,
to minimize the effort required to implement the interface.
- AbstractGraphJob() - Constructor for class org.apache.edgent.graph.spi.execution.AbstractGraphJob
-
- AbstractIotpApplication - Class in org.apache.edgent.test.svt.apps.iotp
-
An IotF Application base class.
- AbstractIotpApplication(String) - Constructor for class org.apache.edgent.test.svt.apps.iotp.AbstractIotpApplication
-
- AbstractMqttApplication - Class in org.apache.edgent.samples.apps.mqtt
-
An MQTT Application base class.
- AbstractMqttApplication(String) - Constructor for class org.apache.edgent.samples.apps.mqtt.AbstractMqttApplication
-
- AbstractOplet<I,O> - Class in org.apache.edgent.oplet.core
-
- AbstractOplet() - Constructor for class org.apache.edgent.oplet.core.AbstractOplet
-
- AbstractTester - Class in org.apache.edgent.topology.spi.tester
-
- AbstractTester() - Constructor for class org.apache.edgent.topology.spi.tester.AbstractTester
-
- AbstractTopology<X extends Tester> - Class in org.apache.edgent.topology.spi
-
Topology implementation that uses the basic functions to implement most
sources streams.
- AbstractTopology(String) - Constructor for class org.apache.edgent.topology.spi.AbstractTopology
-
- AbstractTopologyProvider<T extends Topology> - Class in org.apache.edgent.topology.spi
-
- AbstractTopologyProvider() - Constructor for class org.apache.edgent.topology.spi.AbstractTopologyProvider
-
- AbstractTStream<G extends Topology,T> - Class in org.apache.edgent.topology.spi
-
Abstract stream that uses the functional primitives to implement most
methods.
- AbstractTStream(G) - Constructor for class org.apache.edgent.topology.spi.AbstractTStream
-
- AbstractTWindow<T,K> - Class in org.apache.edgent.topology.spi.graph
-
- AbstractVertex<OP extends Oplet<I,O>,I,O> - Class in org.apache.edgent.graph.spi
-
Placeholder for a skeletal implementation of the
Vertex
interface,
to minimize the effort required to implement the interface.
- AbstractVertex() - Constructor for class org.apache.edgent.graph.spi.AbstractVertex
-
- accept(T, U) - Method in interface org.apache.edgent.function.BiConsumer
-
Consume the two arguments.
- accept(T) - Method in interface org.apache.edgent.function.Consumer
-
Apply the function to value
.
- accept(T) - Method in class org.apache.edgent.oplet.core.FanOut
-
- accept(T) - Method in class org.apache.edgent.oplet.core.Peek
-
- accept(T) - Method in class org.apache.edgent.oplet.core.Split
-
- accept(T) - Method in class org.apache.edgent.oplet.functional.Events
-
- accept(T) - Method in class org.apache.edgent.oplet.functional.Filter
-
- accept(I) - Method in class org.apache.edgent.oplet.functional.FlatMap
-
- accept(I) - Method in class org.apache.edgent.oplet.functional.Map
-
- accept(T, int) - Method in class org.apache.edgent.oplet.plumbing.Barrier
-
- accept(T) - Method in class org.apache.edgent.oplet.plumbing.Isolate
-
- accept(T) - Method in class org.apache.edgent.oplet.plumbing.PressureReliever
-
- accept(T) - Method in class org.apache.edgent.oplet.plumbing.UnorderedIsolate
-
- accept(T) - Method in class org.apache.edgent.oplet.window.Aggregate
-
- accept(T) - Method in class org.apache.edgent.runtime.etiao.SettableForwarder
-
- accept(T) - Method in class org.apache.edgent.streamscope.StreamScope
-
- add(T) - Method in class org.apache.edgent.window.InsertionTimeList
-
- addAnalytics() - Method in class org.apache.edgent.samples.apps.sensorAnalytics.Sensor1
-
Add the sensor's analytics to the topology.
- addAnalytics() - Method in class org.apache.edgent.test.svt.apps.GpsAnalyticsApplication
-
Add the GPS sensor analytics to the topology.
- addAnalytics() - Method in class org.apache.edgent.test.svt.apps.ObdAnalyticsApplication
-
Add the ODB sensor's analytics to the topology.
- addCleaner(BiConsumer<String, String>) - Method in class org.apache.edgent.execution.services.ServiceContainer
-
Registers a new cleaner.
- addHandler(String, Function<String, T>) - Method in class org.apache.edgent.samples.connectors.Options
-
- addHandler(String, Function<String, T>, T) - Method in class org.apache.edgent.samples.connectors.Options
-
- addHeartBeat(IotDevice, long, TimeUnit, String) - Static method in class org.apache.edgent.connectors.iot.HeartBeat
-
Add IoT device heart beat processing to a topology.
- addIotDevice(TopologyElement) - Static method in class org.apache.edgent.apps.iot.IotDevicePubSub
-
Add a proxy IotDevice
for the topology containing te
.
- additionalNameKeys(Hashtable<String, String>) - Method in class org.apache.edgent.runtime.jmxcontrol.JMXControlService
-
- addJob(Job) - Method in interface org.apache.edgent.execution.services.JobRegistryService
-
Adds the specified job.
- addJob(Job) - Method in class org.apache.edgent.runtime.jobregistry.JobRegistry
-
- addKeyProperties(String, Map<String, String>) - Method in class org.apache.edgent.metrics.MetricObjectNameFactory
-
- addListener(BiConsumer<JobRegistryService.EventType, Job>) - Method in interface org.apache.edgent.execution.services.JobRegistryService
-
Adds a handler to a collection of listeners that will be notified
on job registration and state changes.
- addListener(BiConsumer<JobRegistryService.EventType, Job>) - Method in class org.apache.edgent.runtime.jobregistry.JobRegistry
-
- addOpletInvocation(T, int, int) - Method in class org.apache.edgent.runtime.etiao.Executable
-
Creates a new Invocation
associated with the specified oplet.
- addOutput() - Method in interface org.apache.edgent.graph.Vertex
-
Add an output port to the vertex.
- addOutput() - Method in class org.apache.edgent.runtime.etiao.graph.ExecutableVertex
-
- addOutput() - Method in class org.apache.edgent.runtime.etiao.Invocation
-
Adds a new output.
- addService(Class<T>, T) - Method in class org.apache.edgent.execution.services.ServiceContainer
-
Adds the specified service to this ServiceContainer
.
- addStreamScopes(Topology) - Static method in class org.apache.edgent.streamscope.StreamScopeSetup
-
Add StreamScope instances to the topology
- addSubscriber(String, Class<T>, Consumer<T>) - Method in class org.apache.edgent.connectors.pubsub.service.ProviderPubSub
-
- addSubscriber(String, Class<T>, Consumer<T>) - Method in interface org.apache.edgent.connectors.pubsub.service.PublishSubscribeService
-
Add a subscriber to a published topic.
- afterExecute(Runnable, Throwable) - Method in class org.apache.edgent.runtime.etiao.TrackingScheduledExecutor
-
Invoked by the super class after each task execution.
- aggregate(TWindow<JsonObject, K>, String, String, JsonUnivariateAggregate...) - Static method in class org.apache.edgent.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 org.apache.edgent.analytics.math3.json.JsonAnalytics
-
Aggregate against a single Numeric
variable contained in an JSON object.
- Aggregate<T,U,K> - Class in org.apache.edgent.oplet.window
-
Aggregate a window.
- Aggregate(Window<T, K, ? extends List<T>>, BiFunction<List<T>, K, U>) - Constructor for class org.apache.edgent.oplet.window.Aggregate
-
- aggregate(BiFunction<List<T>, K, U>) - Method in class org.apache.edgent.topology.spi.graph.TWindowImpl
-
- aggregate(BiFunction<List<T>, K, U>) - Method in class org.apache.edgent.topology.spi.graph.TWindowTimeImpl
-
Window behaviour here is that:
Tuples are always inserted into the partition.
- aggregate(BiFunction<List<T>, K, U>) - Method in interface org.apache.edgent.topology.TWindow
-
Declares a stream that is a continuous, sliding, aggregation of
partitions in this window.
- aggregateList(String, String, ToDoubleFunction<JsonObject>, JsonUnivariateAggregate...) - Static method in class org.apache.edgent.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 org.apache.edgent.samples.console.ConsoleWaterDetector
-
Look through the stream and check to see if any of the measurements cause concern.
- alias(String) - Method in interface org.apache.edgent.graph.Connector
-
Set the alias for the connector.
- ALIAS - Static variable in interface org.apache.edgent.topology.services.ApplicationService
-
Default alias a service registers its control MBean as.
- alias(String) - Method in class org.apache.edgent.topology.spi.graph.ConnectorStream
-
- alias(String) - Method in interface org.apache.edgent.topology.TStream
-
Set an alias for the stream.
- ALIAS_KEY - Static variable in class org.apache.edgent.runtime.jsoncontrol.JsonControlService
-
Key for the alias of the control MBean in a JSON request.
- alwaysFalse() - Static method in class org.apache.edgent.function.Functions
-
A Predicate that is always false
- alwaysInsert() - Static method in class org.apache.edgent.window.Policies
-
Returns an insertion policy that indicates the tuple
is to be inserted into the partition.
- alwaysTrue() - Static method in class org.apache.edgent.function.Functions
-
A Predicate that is always true
- and(Condition<?>...) - Method in class org.apache.edgent.topology.spi.tester.AbstractTester
-
- and(Condition<?>...) - Method in interface org.apache.edgent.topology.tester.Tester
-
Return a condition that is valid only if all of conditions
are valid.
- APP_NAME - Static variable in class org.apache.edgent.apps.iot.IotDevicePubSub
-
IotDevicePubSub application name.
- APP_NAME - Static variable in class org.apache.edgent.apps.runtime.JobMonitorApp
-
Job monitoring application name.
- ApplicationService - Interface in org.apache.edgent.topology.services
-
Application registration service.
- ApplicationServiceMXBean - Interface in org.apache.edgent.topology.mbeans
-
Control MBean for the application service.
- ApplicationUtilities - Class in org.apache.edgent.samples.apps
-
Some general purpose application configuration driven utilities.
- ApplicationUtilities(Properties) - Constructor for class org.apache.edgent.samples.apps.ApplicationUtilities
-
- apply(T) - Method in interface org.apache.edgent.connectors.jdbc.CheckedFunction
-
Apply a function to t
and return the result.
- apply(T, U) - Method in interface org.apache.edgent.function.BiFunction
-
Apply a function to t
and u
.
- apply(T) - Method in interface org.apache.edgent.function.Function
-
Apply a function to value
.
- applyAsDouble(T) - Method in interface org.apache.edgent.function.ToDoubleFunction
-
Apply a function to value
.
- applyAsInt(T) - Method in interface org.apache.edgent.function.ToIntFunction
-
Apply a function to value
.
- applyAsInt(T) - Method in class org.apache.edgent.topology.plumbing.LoadBalancedSplitter
-
- AppService - Class in org.apache.edgent.runtime.appservice
-
Application service for a TopologyProvider
.
- AppService(TopologyProvider, DirectSubmitter<Topology, Job>, String) - Constructor for class org.apache.edgent.runtime.appservice.AppService
-
Create an ApplicationService
instance.
- AppServiceControl - Class in org.apache.edgent.runtime.appservice
-
- ARGS_KEY - Static variable in class org.apache.edgent.runtime.jsoncontrol.JsonControlService
-
Key for the argument list.
- asBytes() - Static method in class org.apache.edgent.topology.json.JsonFunctions
-
Get the UTF-8 bytes representation of the JSON for a JsonObject.
- asString() - Static method in class org.apache.edgent.topology.json.JsonFunctions
-
Get the JSON for a JsonObject.
- asString() - Method in class org.apache.edgent.topology.spi.AbstractTStream
-
Convert this stream to a stream of String
tuples by calling
toString()
on each tuple.
- asString() - Method in interface org.apache.edgent.topology.TStream
-
Convert this stream to a stream of String
tuples by calling
toString()
on each tuple.
- AT_LEAST_ONCE - Static variable in interface org.apache.edgent.connectors.iot.QoS
-
The message containing the event arrives at the message hub at least once.
- AT_MOST_ONCE - Static variable in interface org.apache.edgent.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 org.apache.edgent.analytics.sensors.Ranges
-
Create a Range [lowerEndpoint..*) (inclusive/CLOSED)
- atLeastTupleCount(TStream<?>, long) - Method in interface org.apache.edgent.topology.tester.Tester
-
Return a condition that evaluates if stream
has submitted at
least expectedCount
number of tuples.
- atMost(T) - Static method in class org.apache.edgent.analytics.sensors.Ranges
-
Create a Range (*..upperEndpoint] (inclusive/CLOSED)
- awaitState(Job, Job.State, long, TimeUnit) - Static method in class org.apache.edgent.samples.connectors.Util
-
Wait for the job to reach the specified state.
- channelDone(int) - Method in class org.apache.edgent.topology.plumbing.LoadBalancedSplitter
-
Signal that the channel is done processing the splitter supplied tuple.
- CheckedFunction<T,R> - Interface in org.apache.edgent.connectors.jdbc
-
Function to apply a funtion to an input value and return a result.
- CheckedSupplier<T> - Interface in org.apache.edgent.connectors.jdbc
-
Function that supplies a result and may throw an Exception.
- cleanOplet(String, String) - Method in class org.apache.edgent.execution.services.ServiceContainer
-
Invokes all the registered cleaners in the context of the specified
job and element.
- clear(JsonElement, int) - Method in interface org.apache.edgent.analytics.math3.json.JsonUnivariateAggregator
-
Clear the aggregator to prepare for a new aggregation.
- clear(JsonElement, int) - Method in class org.apache.edgent.analytics.math3.stat.JsonStorelessStatistic
-
- clear() - Method in class org.apache.edgent.window.InsertionTimeList
-
- close() - Method in class org.apache.edgent.connectors.file.FileWriterPolicy
-
- close() - Method in class org.apache.edgent.metrics.oplets.SingleMetricAbstractOplet
-
- close() - Method in class org.apache.edgent.oplet.core.FanIn
-
- close() - Method in class org.apache.edgent.oplet.core.FanOut
-
- close() - Method in class org.apache.edgent.oplet.core.Sink
-
- close() - Method in class org.apache.edgent.oplet.core.Split
-
- close() - Method in class org.apache.edgent.oplet.core.Union
-
- close() - Method in class org.apache.edgent.oplet.functional.Events
-
- close() - Method in class org.apache.edgent.oplet.functional.Filter
-
- close() - Method in class org.apache.edgent.oplet.functional.FlatMap
-
- close() - Method in class org.apache.edgent.oplet.functional.Map
-
- close() - Method in class org.apache.edgent.oplet.functional.Peek
-
- close() - Method in class org.apache.edgent.oplet.functional.SupplierPeriodicSource
-
- close() - Method in class org.apache.edgent.oplet.functional.SupplierSource
-
- close() - Method in class org.apache.edgent.oplet.plumbing.Barrier
-
- close() - Method in class org.apache.edgent.oplet.plumbing.Isolate
-
- close() - Method in class org.apache.edgent.oplet.plumbing.PressureReliever
-
- close() - Method in class org.apache.edgent.oplet.plumbing.UnorderedIsolate
-
- close() - Method in class org.apache.edgent.oplet.window.Aggregate
-
- close() - Method in class org.apache.edgent.runtime.etiao.Executable
-
Shuts down the user scheduler and thread factory, close all
invocations, then shutdown the control scheduler.
- close() - Method in class org.apache.edgent.runtime.etiao.Invocation
-
- closeActiveFile(Path) - Method in class org.apache.edgent.connectors.file.FileWriterPolicy
-
- closed(T, T) - Static method in class org.apache.edgent.analytics.sensors.Ranges
-
Create a Range [lowerEndpoint..upperEndpoint] (both inclusive/CLOSED)
- closedOpen(T, T) - Static method in class org.apache.edgent.analytics.sensors.Ranges
-
Create a Range [lowerEndpoint..upperEndpoint) (inclusive/CLOSED,exclusive/OPEN)
- closeFunction(Object) - Static method in class org.apache.edgent.function.Functions
-
Close the function.
- closeJob(String, ControlService) - Static method in class org.apache.edgent.apps.runtime.JobMonitorApp
-
Closes a job using a JobMXBean
control registered with the
specified ControlService
.
- Cmd - Interface in org.apache.edgent.samples.connectors.elm327
-
ELM327 and OBD-II command interface.
- CMD_FORMAT - Static variable in interface org.apache.edgent.connectors.iot.IotDevice
-
Command format key.
- CMD_ID - Static variable in interface org.apache.edgent.connectors.iot.IotDevice
-
Command identifier key.
- CMD_PAYLOAD - Static variable in interface org.apache.edgent.connectors.iot.IotDevice
-
Command payload key.
- CMD_TS - Static variable in interface org.apache.edgent.connectors.iot.IotDevice
-
Command timestamp (in milliseconds) key.
- collection(Collection<T>) - Method in class org.apache.edgent.topology.spi.AbstractTopology
-
- collection(Collection<T>) - Method in interface org.apache.edgent.topology.Topology
-
Declare a stream of constants from a collection.
- CombiningStreamsProcessingResults - Class in org.apache.edgent.samples.topology
-
Applying different processing against a set of streams and combining the
resulting streams into a single stream.
- CombiningStreamsProcessingResults() - Constructor for class org.apache.edgent.samples.topology.CombiningStreamsProcessingResults
-
- CommandExecutor - Class in org.apache.edgent.samples.connectors.elm327.runtime
-
Runtime execution of ELM327 & OBD-II commands.
- CommandExecutor() - Constructor for class org.apache.edgent.samples.connectors.elm327.runtime.CommandExecutor
-
- commandId(String, String) - Method in class org.apache.edgent.samples.apps.mqtt.AbstractMqttApplication
-
Compose a MqttDevice commandId for the sensor
- commandId(String, String) - Method in class org.apache.edgent.test.svt.apps.iotp.AbstractIotpApplication
-
Compose a IotpDevice commandId for the sensor
- commandReaderList(ProcessBuilder) - Static method in class org.apache.edgent.connectors.command.CommandStreams
-
Create a Supplier<List<String>>
to ingest a command's output.
- Commands - Interface in org.apache.edgent.connectors.iot
-
Devic command identifiers used by Edgent.
- commands(String...) - Method in interface org.apache.edgent.connectors.iot.IotDevice
-
Create a stream of device commands as JSON objects.
- commands(String...) - Method in class org.apache.edgent.connectors.iotp.IotpDevice
-
Create a stream of device commands as JSON objects.
- commands(String...) - Method in class org.apache.edgent.connectors.mqtt.iot.MqttDevice
-
- COMMANDS_TOPIC - Static variable in class org.apache.edgent.apps.iot.IotDevicePubSub
-
Device commands are published to "edgent/iot/commands" by
this application.
- CommandStreams - Class in org.apache.edgent.connectors.command
-
Connector for creating a TStream from a Command's / OS Process's output
and sinking a TStream to a Command's / OS Process's input.
- commandTopic(String) - Method in class org.apache.edgent.connectors.mqtt.iot.MqttDevice
-
Get the MQTT topic for a command.
- commandWriter(ProcessBuilder) - Static method in class org.apache.edgent.connectors.command.CommandStreams
-
Create a Consumer<String>
to write UTF8 string data to a command's input.
- complete() - Method in interface org.apache.edgent.execution.Job
-
Waits for any outstanding job work to complete.
- complete(long, TimeUnit) - Method in interface org.apache.edgent.execution.Job
-
Waits for at most the specified time for the job to complete.
- complete() - Method in class org.apache.edgent.runtime.etiao.EtiaoJob
-
- complete(long, TimeUnit) - Method in class org.apache.edgent.runtime.etiao.EtiaoJob
-
- complete(Submitter<Topology, ? extends Job>, JsonObject, Condition<?>, long, TimeUnit) - Method in class org.apache.edgent.topology.spi.tester.AbstractTester
-
- complete(Submitter<Topology, ? extends Job>, JsonObject, Condition<?>, long, TimeUnit) - Method in interface org.apache.edgent.topology.tester.Tester
-
Submit the topology for this tester and wait for it to complete, or reach
an end condition.
- completeClosing(long, TimeUnit) - Method in class org.apache.edgent.runtime.etiao.EtiaoJob
-
Complete job closing.
- completeTransition() - Method in class org.apache.edgent.graph.spi.execution.AbstractGraphJob
-
- completeTransition() - Method in class org.apache.edgent.runtime.etiao.EtiaoJob
-
- CompressedFileWriterPolicy<T> - Class in org.apache.edgent.connectors.file
-
- CompressedFileWriterPolicy() - Constructor for class org.apache.edgent.connectors.file.CompressedFileWriterPolicy
-
- CompressedFileWriterPolicy(FileWriterFlushConfig<T>, FileWriterCycleConfig<T>, FileWriterRetentionConfig) - Constructor for class org.apache.edgent.connectors.file.CompressedFileWriterPolicy
-
- compressFile(Path, Path) - Method in class org.apache.edgent.connectors.file.CompressedFileWriterPolicy
-
- concurrent(TStream<T>, List<Function<TStream<T>, TStream<U>>>, Function<List<U>, R>) - Static method in class org.apache.edgent.topology.plumbing.PlumbingStreams
-
Perform analytics concurrently.
- concurrentMap(TStream<T>, List<Function<T, U>>, Function<List<U>, R>) - Static method in class org.apache.edgent.topology.plumbing.PlumbingStreams
-
Perform analytics concurrently.
- Condition<T> - Interface in org.apache.edgent.topology.tester
-
Function representing if a condition is valid or not.
- config() - Method in class org.apache.edgent.samples.apps.AbstractApplication
-
Get the application's raw configuration information.
- Configs - Interface in org.apache.edgent.execution
-
Configuration property names.
- connect(Vertex<?, T, ?>, int) - Method in interface org.apache.edgent.graph.Connector
-
Connect this Connector
to the specified target's input.
- Connector<T> - Interface in org.apache.edgent.graph
-
A Connector
represents an output port of a Vertex
.
- ConnectorStream<G extends Topology,T> - Class in org.apache.edgent.topology.spi.graph
-
A stream that directly adds oplets to the graph.
- ConnectorStream(G, Connector<T>) - Constructor for class org.apache.edgent.topology.spi.graph.ConnectorStream
-
- connectPipe(N) - Method in class org.apache.edgent.topology.spi.graph.ConnectorStream
-
- ConsoleWaterDetector - Class in org.apache.edgent.samples.console
-
Demonstrates some of the features of the console.
- ConsoleWaterDetector() - Constructor for class org.apache.edgent.samples.console.ConsoleWaterDetector
-
- Consumer<T> - Interface in org.apache.edgent.function
-
Function that consumes a value.
- consumer(int) - Method in class org.apache.edgent.oplet.core.FanIn
-
Create a Consumer for the input port that invokes the
receiver and submits a generated tuple, if any, to the output.
- contains(T, Comparator<T>) - Method in class org.apache.edgent.analytics.sensors.Range
-
Determine if the Region contains the value.
- contains(T) - Method in class org.apache.edgent.analytics.sensors.Range
-
Determine if the Region contains the value.
- contentsUnordered(TStream<T>, T...) - Method in interface org.apache.edgent.topology.tester.Tester
-
Return a condition that evaluates if stream
has submitted
tuples matching values
in any order.
- CONTROL_APP_NAME - Static variable in class org.apache.edgent.providers.iot.IotProvider
-
IoT control using device commands application name.
- CONTROL_SERVICE - Static variable in interface org.apache.edgent.connectors.iot.Commands
-
Command identifier used for the control service.
- controlRequest(JsonObject) - Method in class org.apache.edgent.runtime.jsoncontrol.JsonControlService
-
Handle a JSON control request.
- Controls - Class in org.apache.edgent.execution.services
-
Utilities for the control service.
- Controls() - Constructor for class org.apache.edgent.execution.services.Controls
-
- ControlService - Interface in org.apache.edgent.execution.services
-
Service that provides a control mechanism.
- countContentsPolicy(int) - Static method in class org.apache.edgent.window.Policies
-
Returns a count-based contents policy.
- counter(TStream<T>) - Static method in class org.apache.edgent.metrics.Metrics
-
Increment a counter metric when peeking at each tuple.
- counter(Topology) - Static method in class org.apache.edgent.metrics.Metrics
-
Add counter metrics to all the topology's streams.
- CounterOp<T> - Class in org.apache.edgent.metrics.oplets
-
A metrics oplet which counts the number of tuples peeked at.
- CounterOp() - Constructor for class org.apache.edgent.metrics.oplets.CounterOp
-
- createAndRegister(TopologyProvider, DirectSubmitter<Topology, Job>) - Static method in class org.apache.edgent.runtime.appservice.AppService
-
- createAndRegister(ServiceContainer) - Static method in class org.apache.edgent.runtime.jobregistry.JobRegistry
-
Creates and registers a
JobRegistry
with the given service
container.
- createApplication(IotDevice) - Static method in class org.apache.edgent.apps.iot.IotDevicePubSub
-
Create an instance of this application using device
as the device
connection to a message hub.
- createIotCommandToControlApp() - Method in class org.apache.edgent.providers.iot.IotProvider
-
Create application connects edgentControl
device commands
to the control service.
- createIotDeviceApp() - Method in class org.apache.edgent.providers.iot.IotProvider
-
Create application that connects to the message hub.
- createJob(Graph, String, String) - Method in class org.apache.edgent.runtime.etiao.Executable
-
- createJobMonitorApp() - Method in class org.apache.edgent.providers.iot.IotProvider
-
Create Job monitor application.
- createMessageHubDevice(Topology) - Method in class org.apache.edgent.providers.iot.IotProvider
-
Create the connection to the message hub.
- createName(String, String, String) - Method in class org.apache.edgent.metrics.MetricObjectNameFactory
-
Creates a JMX ObjectName
from the given domain, metric type,
and metric name.
- Csv - Class in org.apache.edgent.connectors.csv
-
Utilities for working with CSV strings.
- currentDiastolic - Variable in class org.apache.edgent.samples.utils.sensor.HeartMonitorSensor
-
- currentSystolic - Variable in class org.apache.edgent.samples.utils.sensor.HeartMonitorSensor
-
- gate(TStream<T>, Semaphore) - Static method in class org.apache.edgent.topology.plumbing.PlumbingStreams
-
Control the flow of tuples to an output stream.
- geAltitude() - Method in class org.apache.edgent.test.svt.utils.sensor.gps.GpsSensor
-
- generate(Topology, ProcessBuilder) - Static method in class org.apache.edgent.connectors.command.CommandStreams
-
Create an endless TStream<String>
from a long running command's output.
- generate(Supplier<T>) - Method in class org.apache.edgent.topology.spi.AbstractTopology
-
- generate(Supplier<T>) - Method in interface org.apache.edgent.topology.Topology
-
Declare an endless source stream.
- GEOFENCE_LATITUDE_MAX - Static variable in class org.apache.edgent.test.svt.utils.sensor.gps.SimulatedGeofence
-
- GEOFENCE_LATITUDE_MIN - Static variable in class org.apache.edgent.test.svt.utils.sensor.gps.SimulatedGeofence
-
- GEOFENCE_LONGITUDE_MAX - Static variable in class org.apache.edgent.test.svt.utils.sensor.gps.SimulatedGeofence
-
- GEOFENCE_LONGITUDE_MIN - Static variable in class org.apache.edgent.test.svt.utils.sensor.gps.SimulatedGeofence
-
- get() - Method in enum org.apache.edgent.analytics.math3.stat.Statistic
-
Return a new instance of this statistic implementation.
- get() - Method in interface org.apache.edgent.connectors.jdbc.CheckedSupplier
-
Get a result.
- get(Connection) - Method in interface org.apache.edgent.connectors.jdbc.StatementSupplier
-
Create a JDBC SQL PreparedStatement containing 0 or more parameters.
- get() - Method in interface org.apache.edgent.function.Supplier
-
Supply a value, each call to this function may return
a different value.
- get() - Method in class org.apache.edgent.samples.connectors.MsgSupplier
-
- get(String) - Method in class org.apache.edgent.samples.connectors.Options
-
- get(String, T) - Method in class org.apache.edgent.samples.connectors.Options
-
- get() - Method in class org.apache.edgent.samples.utils.sensor.HeartMonitorSensor
-
Every call to this method returns a map containing a random systolic
pressure and a random diastolic pressure.
- get() - Method in class org.apache.edgent.samples.utils.sensor.SimpleSimulatedSensor
-
Get the next sensor value as described in the class documentation.
- get() - Method in class org.apache.edgent.samples.utils.sensor.SimulatedTemperatureSensor
-
Get the next sensor value.
- get() - Method in class org.apache.edgent.topology.spi.functions.EndlessSupplier
-
- getActionTimeToWaitMillis() - Method in class org.apache.edgent.connectors.mqtt.MqttConfig
-
Get the maximum time to wait for an action (e.g., publish message) to complete.
- getAgeSec() - Method in class org.apache.edgent.connectors.file.FileWriterRetentionConfig
-
Get the file age configuration value.
- getAggregateFileSize() - Method in class org.apache.edgent.connectors.file.FileWriterRetentionConfig
-
Get the aggregate file size configuration value.
- getAlias() - Method in interface org.apache.edgent.graph.Connector
-
Returns the alias for the connector if any.
- getAlias() - Method in interface org.apache.edgent.graph.Edge
-
Returns the alias associated with this edge.
- getAlias() - Method in class org.apache.edgent.graph.spi.DirectEdge
-
- getAlias() - Method in interface org.apache.edgent.oplet.OutputPortContext
-
Get the alias of the output port if any.
- getAlias() - Method in class org.apache.edgent.runtime.etiao.graph.model.EdgeType
-
- getAlias() - Method in class org.apache.edgent.topology.spi.graph.ConnectorStream
-
- getAlias() - Method in interface org.apache.edgent.topology.TStream
-
Returns the stream's alias if any.
- getAll() - Method in class org.apache.edgent.samples.connectors.Options
-
- getApplicationNames() - Method in class org.apache.edgent.runtime.appservice.AppService
-
- getApplicationNames() - Method in interface org.apache.edgent.topology.services.ApplicationService
-
Returns the names of applications registered with this service.
- getApplicationService() - Method in class org.apache.edgent.providers.iot.IotProvider
-
Get the application service.
- getBuilder() - Method in interface org.apache.edgent.topology.services.TopologyBuilder
-
How the application is built.
- getClassName() - Method in class org.apache.edgent.runtime.etiao.graph.model.InvocationType
-
- getClientId() - Method in class org.apache.edgent.connectors.mqtt.MqttConfig
-
Get the connection Client Id.
- getCntTuples() - Method in class org.apache.edgent.connectors.file.FileWriterCycleConfig
-
Get the tuple count configuration value.
- getCntTuples() - Method in class org.apache.edgent.connectors.file.FileWriterFlushConfig
-
Get the tuple count configuration value.
- getCommandValueString(JsonObject) - Method in class org.apache.edgent.samples.apps.mqtt.AbstractMqttApplication
-
- getConnectionTimeout() - Method in class org.apache.edgent.connectors.mqtt.MqttConfig
-
Get the connection timeout.
- getConnectors() - Method in interface org.apache.edgent.graph.Vertex
-
Get the vertice's collection of output connectors.
- getConnectors() - Method in class org.apache.edgent.runtime.etiao.graph.ExecutableVertex
-
- getContents() - Method in interface org.apache.edgent.window.Partition
-
Retrieves the window contents.
- getContentsPolicy() - Method in interface org.apache.edgent.window.Window
-
Returns the contents policy of the window.
- getControl(String, String, Class<T>) - Method in interface org.apache.edgent.execution.services.ControlService
-
Return a control Mbean registered with this service.
- getControl(String, String, Class<T>) - Method in class org.apache.edgent.runtime.jmxcontrol.JMXControlService
-
- getControl(String, String, Class<T>) - Method in class org.apache.edgent.runtime.jsoncontrol.JsonControlService
-
- getControlId(String, String, Class<T>) - Method in interface org.apache.edgent.execution.services.ControlService
-
Return the unique identifier for a control Mbean registered with
this service.
- getControlId() - Method in class org.apache.edgent.runtime.etiao.mbeans.EtiaoJobBean
-
- getControlId(String, String, Class<T>) - Method in class org.apache.edgent.runtime.jmxcontrol.JMXControlService
-
- getControlId(String, String, Class<T>) - Method in class org.apache.edgent.runtime.jsoncontrol.JsonControlService
-
- getControlService() - Method in class org.apache.edgent.providers.iot.IotProvider
-
- getCourse() - Method in class org.apache.edgent.test.svt.utils.sensor.gps.GpsSensor
-
- getCurrentState() - Method in interface org.apache.edgent.execution.Job
-
Retrieves the current state of this job.
- getCurrentState() - Method in interface org.apache.edgent.execution.mbeans.JobMXBean
-
Retrieves the current state of the job.
- getCurrentState() - Method in class org.apache.edgent.graph.spi.execution.AbstractGraphJob
-
- getCurrentState() - Method in class org.apache.edgent.runtime.etiao.mbeans.EtiaoJobBean
-
- getCycleConfig() - Method in class org.apache.edgent.connectors.file.FileWriterPolicy
-
Get the policy's active file cycle configuration
- getDataSource(Properties) - Static method in class org.apache.edgent.samples.connectors.jdbc.DbUtils
-
Get the JDBC DataSource
for the database.
- getDeltaFactor() - Method in class org.apache.edgent.samples.utils.sensor.SimpleSimulatedSensor
-
Get the deltaFactor setting
- getDeltaFactor() - Method in class org.apache.edgent.samples.utils.sensor.SimulatedTemperatureSensor
-
Get the deltaFactor setting
- getDestination() - Method in class org.apache.edgent.oplet.core.FanIn
-
- getDestination() - Method in class org.apache.edgent.oplet.core.Pipe
-
- getDestination() - Method in class org.apache.edgent.oplet.core.Source
-
- getDestination() - Method in class org.apache.edgent.runtime.etiao.SettableForwarder
-
Get the destination.
- getDomain() - Method in class org.apache.edgent.runtime.jmxcontrol.JMXControlService
-
Get the JMX domain being used by this control service.
- getDouble(JsonElement, String) - Static method in class org.apache.edgent.samples.connectors.obd2.Obd2Streams
-
Utility method to simplify accessing a number as a double.
- getEdges() - Method in interface org.apache.edgent.graph.Graph
-
Return an unmodifiable view of all edges in this graph.
- getEdges() - Method in class org.apache.edgent.runtime.etiao.graph.DirectGraph
-
- getEdges() - Method in class org.apache.edgent.runtime.etiao.graph.model.GraphType
-
- getEvictDeterminer() - Method in interface org.apache.edgent.window.Window
-
Returns the window's eviction determiner.
- getFeed() - Method in interface org.apache.edgent.topology.TSink
-
Get the stream feeding this sink.
- getFileCount() - Method in class org.apache.edgent.connectors.file.FileWriterRetentionConfig
-
Get the file count configuration value.
- getFileSize() - Method in class org.apache.edgent.connectors.file.FileWriterCycleConfig
-
Get the file size configuration value.
- getFlushConfig() - Method in class org.apache.edgent.connectors.file.FileWriterPolicy
-
Get the policy's active file flush configuration
- getHealth() - Method in interface org.apache.edgent.execution.Job
-
Returns the summarized health indicator of the graph nodes.
- getHealth() - Method in interface org.apache.edgent.execution.mbeans.JobMXBean
-
Returns the summarized health indicator of the job.
- getHealth() - Method in class org.apache.edgent.graph.spi.execution.AbstractGraphJob
-
- getHealth() - Method in class org.apache.edgent.runtime.etiao.mbeans.EtiaoJobBean
-
- getId() - Method in interface org.apache.edgent.execution.Job
-
Returns the identifier of this job.
- getId() - Method in interface org.apache.edgent.execution.mbeans.JobMXBean
-
Returns the identifier of the job.
- getId() - Method in interface org.apache.edgent.oplet.JobContext
-
Get the runtime identifier for the job containing this
Oplet
.
- getId() - Method in interface org.apache.edgent.oplet.OpletContext
-
Get the unique identifier (within the running job)
for this oplet.
- getId() - Method in class org.apache.edgent.runtime.etiao.EtiaoJob
-
- getId() - Method in class org.apache.edgent.runtime.etiao.graph.model.VertexType
-
- getId() - Method in class org.apache.edgent.runtime.etiao.Invocation
-
Returns the unique identifier associated with this Invocation
.
- getId() - Method in class org.apache.edgent.runtime.etiao.InvocationContext
-
- getId() - Method in class org.apache.edgent.runtime.etiao.mbeans.EtiaoJobBean
-
- getIdleTimeout() - Method in class org.apache.edgent.connectors.mqtt.MqttConfig
-
Get the idle connection timeout.
- getInput() - Method in interface org.apache.edgent.connectors.serial.SerialPort
-
Get the input stream for this serial port.
- getInputCount() - Method in interface org.apache.edgent.oplet.OpletContext
-
Get the number of connected inputs to this oplet.
- getInputCount() - Method in class org.apache.edgent.runtime.etiao.InvocationContext
-
- getInputs() - Method in class org.apache.edgent.oplet.core.FanIn
-
- getInputs() - Method in class org.apache.edgent.oplet.core.FanOut
-
- getInputs() - Method in class org.apache.edgent.oplet.core.Pipe
-
- getInputs() - Method in class org.apache.edgent.oplet.core.Sink
-
- getInputs() - Method in class org.apache.edgent.oplet.core.Source
-
- getInputs() - Method in class org.apache.edgent.oplet.core.Split
-
- getInputs() - Method in interface org.apache.edgent.oplet.Oplet
-
Get the input stream data handlers for this oplet.
- getInputs() - Method in class org.apache.edgent.runtime.etiao.Invocation
-
Returns the list of input stream forwarders for this invocation.
- getInsertionPolicy() - Method in interface org.apache.edgent.window.Window
-
Returns the insertion policy of the window.
- getInstance() - Method in interface org.apache.edgent.graph.Vertex
-
Get the instance of the oplet that will be executed.
- getInstance() - Method in class org.apache.edgent.runtime.etiao.graph.ExecutableVertex
-
- getInvocation() - Method in class org.apache.edgent.runtime.etiao.graph.model.VertexType
-
- getInvocationId() - Method in class org.apache.edgent.runtime.etiao.graph.ExecutableVertex
-
- getJob(String) - Method in interface org.apache.edgent.execution.services.JobRegistryService
-
Returns a job given its identifier.
- getJob(String) - Method in class org.apache.edgent.runtime.jobregistry.JobRegistry
-
- getJob() - Method in class org.apache.edgent.topology.spi.tester.AbstractTester
-
- getJob() - Method in interface org.apache.edgent.topology.tester.Tester
-
Get the Job
reference for the topology submitted by complete()
.
- getJobContext() - Method in interface org.apache.edgent.oplet.OpletContext
-
Get the job hosting this oplet.
- getJobContext() - Method in class org.apache.edgent.runtime.etiao.AbstractContext
-
- getJobIds() - Method in interface org.apache.edgent.execution.services.JobRegistryService
-
Returns a set of all the registered job identifiers.
- getJobIds() - Method in class org.apache.edgent.runtime.jobregistry.JobRegistry
-
- getJson(TStream<JsonObject>, Supplier<CloseableHttpClient>, Function<JsonObject, String>) - Static method in class org.apache.edgent.connectors.http.HttpStreams
-
Make an HTTP GET request with JsonObject.
- getKeepAliveInterval() - Method in class org.apache.edgent.connectors.mqtt.MqttConfig
-
Get the connection Keep alive interval.
- getKey() - Method in interface org.apache.edgent.window.Partition
-
Returns the key associated with this partition
- getKeyFunction() - Method in class org.apache.edgent.topology.spi.graph.AbstractTWindow
-
- getKeyFunction() - Method in interface org.apache.edgent.topology.TWindow
-
Returns the key function used to map tuples to partitions.
- getKeyFunction() - Method in interface org.apache.edgent.window.Window
-
Returns the keyFunction of the window
- getKeyStore() - Method in class org.apache.edgent.connectors.mqtt.MqttConfig
-
Get the SSL trust store path.
- getKeyStorePassword() - Method in class org.apache.edgent.connectors.mqtt.MqttConfig
-
Get the SSL key store path password.
- getLastError() - Method in interface org.apache.edgent.execution.Job
-
Returns the last error message caught by the current job execution.
- getLastError() - Method in interface org.apache.edgent.execution.mbeans.JobMXBean
-
Returns the last error message caught by the current job execution.
- getLastError() - Method in class org.apache.edgent.graph.spi.execution.AbstractGraphJob
-
- getLastError() - Method in class org.apache.edgent.runtime.etiao.Executable
-
- getLastError() - Method in class org.apache.edgent.runtime.etiao.mbeans.EtiaoJobBean
-
- getLatitude() - Method in class org.apache.edgent.test.svt.utils.sensor.gps.GpsSensor
-
- getLongitude() - Method in class org.apache.edgent.test.svt.utils.sensor.gps.GpsSensor
-
- getMbs() - Method in class org.apache.edgent.runtime.jmxcontrol.JMXControlService
-
Get the MBean server being used by this control service.
- getMetric() - Method in class org.apache.edgent.metrics.oplets.CounterOp
-
- getMetric() - Method in class org.apache.edgent.metrics.oplets.RateMeter
-
- getMetric() - Method in class org.apache.edgent.metrics.oplets.SingleMetricAbstractOplet
-
- getMetricName() - Method in class org.apache.edgent.metrics.oplets.SingleMetricAbstractOplet
-
Returns the name of the metric used by this oplet for registration.
- getMqttConfig() - Method in class org.apache.edgent.connectors.mqtt.iot.MqttDevice
-
- getMvAggregate(JsonObject, String, String, JsonUnivariateAggregate) - Static method in class org.apache.edgent.analytics.math3.json.JsonAnalytics
-
Get the value of an aggregate computed by a multi-variable aggregation.
- getName() - Method in interface org.apache.edgent.execution.Job
-
Returns the name of this job.
- getName() - Method in interface org.apache.edgent.execution.mbeans.JobMXBean
-
Returns the name of the job.
- getName() - Method in interface org.apache.edgent.oplet.JobContext
-
Get the name of the job containing this
Oplet
.
- getName() - Method in class org.apache.edgent.providers.iot.IotProvider
-
Return the name of this provider.
- getName() - Method in class org.apache.edgent.runtime.etiao.EtiaoJob
-
Get the name of the job containing this
Oplet
.
- getName() - Method in class org.apache.edgent.runtime.etiao.mbeans.EtiaoJobBean
-
- getName() - Method in interface org.apache.edgent.topology.services.TopologyBuilder
-
Name the application will be known as.
- getName() - Method in class org.apache.edgent.topology.spi.AbstractTopology
-
- getName() - Method in interface org.apache.edgent.topology.Topology
-
Name of this topology.
- getNames() - Method in class org.apache.edgent.streamscope.StreamScopeRegistry
-
Get the registered names.
- getNextActiveFilePath() - Method in class org.apache.edgent.connectors.file.FileWriterPolicy
-
- getNextState() - Method in interface org.apache.edgent.execution.Job
-
Retrieves the next execution state when this job makes a state
transition.
- getNextState() - Method in interface org.apache.edgent.execution.mbeans.JobMXBean
-
Retrieves the next execution state when the job makes a state
transition.
- getNextState() - Method in class org.apache.edgent.graph.spi.execution.AbstractGraphJob
-
- getNextState() - Method in class org.apache.edgent.runtime.etiao.mbeans.EtiaoJobBean
-
- getNumberFractionalDigits() - Method in class org.apache.edgent.samples.utils.sensor.SimpleSimulatedSensor
-
Get the number of fractional digits setting
- getObject(JsonObject, String) - Static method in class org.apache.edgent.samples.connectors.obd2.Obd2Streams
-
Utility method to simplify accessing a JSON object.
- getOplet() - Method in class org.apache.edgent.runtime.etiao.Invocation
-
Returns the oplet associated with this Invocation
.
- getOpletContext() - Method in class org.apache.edgent.oplet.core.AbstractOplet
-
- getOutput() - Method in interface org.apache.edgent.connectors.serial.SerialPort
-
Get the output stream for this serial port.
- getOutputContext() - Method in interface org.apache.edgent.oplet.OpletContext
-
Get the oplet's output port context information.
- getOutputContext() - Method in class org.apache.edgent.runtime.etiao.InvocationContext
-
- getOutputCount() - Method in interface org.apache.edgent.oplet.OpletContext
-
Get the number of connected outputs to this oplet.
- getOutputCount() - Method in class org.apache.edgent.runtime.etiao.Invocation
-
Returns the number of outputs for this invocation.
- getOutputCount() - Method in class org.apache.edgent.runtime.etiao.InvocationContext
-
- getOutputs() - Method in interface org.apache.edgent.oplet.OpletContext
-
Get the mechanism to submit tuples on an output port.
- getOutputs() - Method in class org.apache.edgent.runtime.etiao.InvocationContext
-
- getPartitionProcessor() - Method in interface org.apache.edgent.window.Window
-
Returns the partition processor associated with the window.
- getPartitions() - Method in interface org.apache.edgent.window.Window
-
Retrieves the partitions in the window.
- getPassword() - Method in class org.apache.edgent.connectors.mqtt.MqttConfig
-
Get the the password to use for authentication with the server.
- getPeeker() - Method in class org.apache.edgent.oplet.functional.Peek
-
- getPeriod() - Method in interface org.apache.edgent.execution.mbeans.PeriodMXBean
-
Get the period.
- getPeriod() - Method in class org.apache.edgent.oplet.core.PeriodicSource
-
- getPeriodMsec() - Method in class org.apache.edgent.connectors.file.FileWriterCycleConfig
-
Get the time period configuration value.
- getPeriodMsec() - Method in class org.apache.edgent.connectors.file.FileWriterFlushConfig
-
Get the time period configuration value.
- getPeriodMsec() - Method in class org.apache.edgent.connectors.file.FileWriterRetentionConfig
-
Get the time period configuration value.
- getPersistence() - Method in class org.apache.edgent.connectors.mqtt.MqttConfig
-
Get the QoS 1 and 2 in-flight message persistence handler.
- getPublishDestination(String, Class<? super T>) - Method in class org.apache.edgent.connectors.pubsub.service.ProviderPubSub
-
- getPublishDestination(String, Class<? super T>) - Method in interface org.apache.edgent.connectors.pubsub.service.PublishSubscribeService
-
Get the destination for a publisher.
- getRange() - Method in class org.apache.edgent.samples.utils.sensor.SimpleSimulatedSensor
-
Get the range setting
- getRangeByte(String, String) - Method in class org.apache.edgent.samples.apps.ApplicationUtilities
-
Get the Range for a sensor range configuration item.
- getRangeDouble(String, String) - Method in class org.apache.edgent.samples.apps.ApplicationUtilities
-
Get the Range for a sensor range configuration item.
- getRangeFloat(String, String) - Method in class org.apache.edgent.samples.apps.ApplicationUtilities
-
Get the Range for a sensor range configuration item.
- getRangeInteger(String, String) - Method in class org.apache.edgent.samples.apps.ApplicationUtilities
-
Get the Range for a sensor range configuration item.
- getRangeShort(String, String) - Method in class org.apache.edgent.samples.apps.ApplicationUtilities
-
Get the Range for a sensor range configuration item.
- getResult() - Method in interface org.apache.edgent.topology.tester.Condition
-
- getRetentionConfig() - Method in class org.apache.edgent.connectors.file.FileWriterPolicy
-
Get the policy's retention configuration
- getRunnable() - Method in class org.apache.edgent.oplet.core.PeriodicSource
-
- getRunnable() - Method in class org.apache.edgent.oplet.core.ProcessSource
-
- getRuntimeServiceSupplier() - Method in class org.apache.edgent.providers.direct.DirectTopology
-
- getRuntimeServiceSupplier() - Method in interface org.apache.edgent.topology.Topology
-
Return a function that at execution time
will return a
RuntimeServices
instance
a stream function can use.
- getSampleCount() - Method in interface org.apache.edgent.streamscope.mbeans.StreamScopeMXBean
-
Get the number of Samples currently captured
- getSampleCount() - Method in class org.apache.edgent.streamscope.StreamScope
-
Get the number of Samples currently captured
- getSampleCount() - Method in class org.apache.edgent.streamscope.StreamScopeBean
-
- getSamples() - Method in interface org.apache.edgent.streamscope.mbeans.StreamScopeMXBean
-
Get all captured tuples as JSON.
- getSamples() - Method in class org.apache.edgent.streamscope.StreamScope
-
Get all captured tuples.
- getSamples() - Method in class org.apache.edgent.streamscope.StreamScopeBean
-
- getScheduledExecutorService() - Method in interface org.apache.edgent.window.Window
-
Returns the ScheduledExecutorService associated with the window.
- getScheduler() - Method in class org.apache.edgent.runtime.etiao.Executable
-
Returns the ScheduledExecutorService
used for running
executable graph elements.
- getSensorPropertyName(String, String, String) - Method in class org.apache.edgent.samples.apps.ApplicationUtilities
-
Get the property name for a sensor's configuration item.
- getServerURLs() - Method in class org.apache.edgent.connectors.mqtt.MqttConfig
-
Get the MQTT Server URLs
- getService(Class<T>) - Method in interface org.apache.edgent.execution.services.RuntimeServices
-
Get a service for this invocation.
- getService(Class<T>) - Method in class org.apache.edgent.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 org.apache.edgent.oplet.OpletContext
-
Get a service for this invocation.
- getService(Class<T>) - Method in class org.apache.edgent.runtime.etiao.AbstractContext
-
- getService(Class<T>) - Method in class org.apache.edgent.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 org.apache.edgent.execution.DirectSubmitter
-
Access to services.
- getServices() - Method in class org.apache.edgent.providers.direct.DirectProvider
-
Access to services.
- getServices() - Method in class org.apache.edgent.providers.iot.IotProvider
-
Access to services.
- getSinker() - Method in class org.apache.edgent.oplet.core.Sink
-
Get the sink function that processes each tuple.
- getSize() - Method in class org.apache.edgent.topology.spi.graph.TWindowImpl
-
- getSource(Function<SerialPort, T>) - Method in interface org.apache.edgent.connectors.serial.SerialDevice
-
Create a function that can be used to source a
stream from a serial port device.
- getSource() - Method in interface org.apache.edgent.graph.Edge
-
Returns the source vertex.
- getSource() - Method in class org.apache.edgent.graph.spi.DirectEdge
-
- getSourceId() - Method in class org.apache.edgent.runtime.etiao.graph.model.EdgeType
-
- getSourceOutputPort() - Method in interface org.apache.edgent.graph.Edge
-
Returns the source output port index.
- getSourceOutputPort() - Method in class org.apache.edgent.graph.spi.DirectEdge
-
- getSourceOutputPort() - Method in class org.apache.edgent.runtime.etiao.graph.model.EdgeType
-
- getSpeedMetersPerSec() - Method in class org.apache.edgent.test.svt.utils.sensor.gps.GpsSensor
-
- getSslContainer(Properties) - Method in class org.apache.edgent.javax.websocket.EdgentSslContainerProvider
-
Create a WebSocketContainer setup for SSL.
- getSslContainer(Properties) - Method in class org.apache.edgent.javax.websocket.impl.EdgentSslContainerProviderImpl
-
- getSslWebSocketContainer(Properties) - Static method in class org.apache.edgent.javax.websocket.EdgentSslContainerProvider
-
Create a WebSocketContainer setup for SSL.
- getState(K) - Method in class org.apache.edgent.window.PartitionedState
-
Get the current state for key
.
- getStatistic(JsonObject, Statistic) - Static method in class org.apache.edgent.samples.apps.JsonTuples
-
Get a statistic value from a sample.
- getStatistic(JsonObject, String, Statistic) - Static method in class org.apache.edgent.samples.apps.JsonTuples
-
Get a statistic value from a sample.
- getStreamScopes() - Method in class org.apache.edgent.streamscope.StreamScopeRegistry
-
Get registered StreamScopes and the name(s) each is registered with.
- getSubscriberIdleReconnectInterval() - Method in class org.apache.edgent.connectors.mqtt.MqttConfig
-
Get the subscriber idle reconnect interval.
- getTags() - Method in interface org.apache.edgent.graph.Connector
-
Returns the set of tags associated with this connector.
- getTags() - Method in interface org.apache.edgent.graph.Edge
-
Returns the set of tags associated with this edge.
- getTags() - Method in class org.apache.edgent.graph.spi.DirectEdge
-
- getTags() - Method in class org.apache.edgent.runtime.etiao.graph.model.EdgeType
-
- getTags() - Method in class org.apache.edgent.topology.spi.graph.ConnectorStream
-
- getTags() - Method in interface org.apache.edgent.topology.TStream
-
Returns the set of tags associated with this stream.
- getTarget() - Method in interface org.apache.edgent.graph.Edge
-
Returns the target vertex.
- getTarget() - Method in class org.apache.edgent.graph.spi.DirectEdge
-
- getTargetId() - Method in class org.apache.edgent.runtime.etiao.graph.model.EdgeType
-
- getTargetInputPort() - Method in interface org.apache.edgent.graph.Edge
-
Returns the target input port index.
- getTargetInputPort() - Method in class org.apache.edgent.graph.spi.DirectEdge
-
- getTargetInputPort() - Method in class org.apache.edgent.runtime.etiao.graph.model.EdgeType
-
- getTempRange() - Method in class org.apache.edgent.samples.utils.sensor.SimulatedTemperatureSensor
-
Get the tempRange setting
- getTester() - Method in class org.apache.edgent.topology.spi.AbstractTopology
-
- getTester() - Method in interface org.apache.edgent.topology.Topology
-
Get the tester for this topology.
- getTime() - Method in class org.apache.edgent.test.svt.utils.sensor.gps.GpsSensor
-
- getTime() - Method in class org.apache.edgent.topology.spi.graph.TWindowTimeImpl
-
- getTriggerPolicy() - Method in interface org.apache.edgent.window.Window
-
Returns the window's trigger policy.
- getTrustStore() - Method in class org.apache.edgent.connectors.mqtt.MqttConfig
-
Get the SSL trust store path.
- getTrustStorePassword() - Method in class org.apache.edgent.connectors.mqtt.MqttConfig
-
Get the SSL trust store path password.
- getTuplePredicate() - Method in class org.apache.edgent.connectors.file.FileWriterCycleConfig
-
Get the tuple predicate configuration value.
- getTuplePredicate() - Method in class org.apache.edgent.connectors.file.FileWriterFlushConfig
-
Get the tuple predicate configuration value.
- getUnit() - Method in interface org.apache.edgent.execution.mbeans.PeriodMXBean
-
- getUnit() - Method in class org.apache.edgent.oplet.core.PeriodicSource
-
- getUnit() - Method in class org.apache.edgent.topology.spi.graph.TWindowTimeImpl
-
- getUserName() - Method in class org.apache.edgent.connectors.mqtt.MqttConfig
-
Get the username to use for authentication with the server.
- getVertices() - Method in interface org.apache.edgent.graph.Graph
-
Return an unmodifiable view of all vertices in this graph.
- getVertices() - Method in class org.apache.edgent.runtime.etiao.graph.DirectGraph
-
- getVertices() - Method in class org.apache.edgent.runtime.etiao.graph.model.GraphType
-
- getWillDestination() - Method in class org.apache.edgent.connectors.mqtt.MqttConfig
-
Get a Last Will and Testament message's destination topic.
- getWillPayload() - Method in class org.apache.edgent.connectors.mqtt.MqttConfig
-
Get a Last Will and Testament message's payload.
- getWillQOS() - Method in class org.apache.edgent.connectors.mqtt.MqttConfig
-
Get a Last Will and Testament message's QOS.
- getWillRetained() - Method in class org.apache.edgent.connectors.mqtt.MqttConfig
-
Get a Last Will and Testament message's "retained" setting.
- getWindow() - Method in interface org.apache.edgent.window.Partition
-
Return the window in which this partition is contained.
- GpsAnalyticsApplication - Class in org.apache.edgent.test.svt.apps
-
GPS analytics
- GpsAnalyticsApplication(Topology, FleetManagementAnalyticsClientApplication) - Constructor for class org.apache.edgent.test.svt.apps.GpsAnalyticsApplication
-
- GpsSensor - Class in org.apache.edgent.test.svt.utils.sensor.gps
-
- GpsSensor(double, double, double, double, long, double) - Constructor for class org.apache.edgent.test.svt.utils.sensor.gps.GpsSensor
-
- graph() - Method in interface org.apache.edgent.graph.Connector
-
Gets the Graph
for this Connector
.
- Graph - Interface in org.apache.edgent.graph
-
A generic directed graph of vertices, connectors and edges.
- graph() - Method in interface org.apache.edgent.graph.Vertex
-
- graph() - Method in class org.apache.edgent.providers.direct.DirectTopology
-
- graph() - Method in class org.apache.edgent.runtime.etiao.EtiaoJob
-
- graph() - Method in class org.apache.edgent.runtime.etiao.graph.ExecutableVertex
-
- graph() - Method in class org.apache.edgent.topology.spi.graph.ConnectorStream
-
- graph() - Method in interface org.apache.edgent.topology.Topology
-
Get the underlying graph.
- graphSnapshot() - Method in interface org.apache.edgent.execution.mbeans.JobMXBean
-
Takes a current snapshot of the running graph and returns it in JSON format.
- graphSnapshot() - Method in class org.apache.edgent.runtime.etiao.mbeans.EtiaoJobBean
-
- GraphTopology<X extends Tester> - Class in org.apache.edgent.topology.spi.graph
-
Topology implementation that provides basic functions for implementing
source streams backed by a
Graph
.
- GraphTopology(String) - Constructor for class org.apache.edgent.topology.spi.graph.GraphTopology
-
- GraphType - Class in org.apache.edgent.runtime.etiao.graph.model
-
A generic directed graph of vertices, connectors and edges.
- GraphType(Graph) - Constructor for class org.apache.edgent.runtime.etiao.graph.model.GraphType
-
- GraphType(Graph, IdMapper<String>) - Constructor for class org.apache.edgent.runtime.etiao.graph.model.GraphType
-
Create an instance of
GraphType
using the specified
IdMapper
to generate unique object identifiers.
- GraphType() - Constructor for class org.apache.edgent.runtime.etiao.graph.model.GraphType
-
- greaterThan(T) - Static method in class org.apache.edgent.analytics.sensors.Ranges
-
Create a Range (lowerEndpoint..*) (exclusive/OPEN)
- id() - Method in interface org.apache.edgent.samples.connectors.elm327.Cmd
-
Unique identifier of the command.
- id() - Method in enum org.apache.edgent.samples.connectors.elm327.Elm327Cmds
-
- id() - Method in enum org.apache.edgent.samples.connectors.elm327.Pids01
-
- ID_PREFIX - Static variable in class org.apache.edgent.runtime.etiao.EtiaoJob
-
Prefix used by job unique identifiers.
- ID_PREFIX - Static variable in class org.apache.edgent.runtime.etiao.Invocation
-
Prefix used by oplet unique identifiers.
- identity() - Static method in class org.apache.edgent.function.Functions
-
Returns the identity function that returns its single argument.
- increasingTemps(SerialDevice) - Static method in class org.apache.edgent.samples.connectors.obd2.Obd2Streams
-
Get a stream of temperature readings which
are increasing over the last minute.
- increment(double) - Method in interface org.apache.edgent.analytics.math3.json.JsonUnivariateAggregator
-
Add a value to the aggregation.
- increment(double) - Method in class org.apache.edgent.analytics.math3.stat.JsonStorelessStatistic
-
- initDb(DataSource) - Static method in class org.apache.edgent.samples.connectors.jdbc.DbUtils
-
Initialize the sample's database.
- initialize(String, Flushable, Closeable) - Method in class org.apache.edgent.connectors.file.FileWriterPolicy
-
- initialize(OpletContext<T, Void>) - Method in class org.apache.edgent.connectors.pubsub.oplets.Publish
-
- initialize(OpletContext<T, T>) - Method in class org.apache.edgent.metrics.oplets.SingleMetricAbstractOplet
-
- initialize(OpletContext<I, O>) - Method in class org.apache.edgent.oplet.core.AbstractOplet
-
- initialize(OpletContext<T, U>) - Method in class org.apache.edgent.oplet.core.FanIn
-
- initialize(OpletContext<Void, T>) - Method in class org.apache.edgent.oplet.core.PeriodicSource
-
- initialize(OpletContext<I, O>) - Method in class org.apache.edgent.oplet.core.Pipe
-
- initialize(OpletContext<Void, T>) - Method in class org.apache.edgent.oplet.core.Source
-
- initialize(OpletContext<T, T>) - Method in class org.apache.edgent.oplet.core.Split
-
- initialize(OpletContext<T, T>) - Method in class org.apache.edgent.oplet.core.Union
-
- initialize(OpletContext<Void, T>) - Method in class org.apache.edgent.oplet.functional.SupplierPeriodicSource
-
- initialize(OpletContext<Void, T>) - Method in class org.apache.edgent.oplet.functional.SupplierSource
-
- initialize(OpletContext<I, O>) - Method in interface org.apache.edgent.oplet.Oplet
-
Initialize the oplet.
- initialize(OpletContext<T, List<T>>) - Method in class org.apache.edgent.oplet.plumbing.Barrier
-
- initialize(OpletContext<T, T>) - Method in class org.apache.edgent.oplet.plumbing.Isolate
-
- initialize(OpletContext<T, T>) - Method in class org.apache.edgent.oplet.plumbing.PressureReliever
-
- initialize(OpletContext<T, T>) - Method in class org.apache.edgent.oplet.plumbing.UnorderedIsolate
-
- initialize(OpletContext<T, U>) - Method in class org.apache.edgent.oplet.window.Aggregate
-
- initialize() - Method in class org.apache.edgent.runtime.etiao.Executable
-
Initializes the invocations.
- initialize(JobContext, RuntimeServices) - Method in class org.apache.edgent.runtime.etiao.Invocation
-
Initialize the invocation.
- initialize(Cmd, OutputStream, InputStream) - Static method in class org.apache.edgent.samples.connectors.elm327.runtime.CommandExecutor
-
- initialize(OpletContext<T, T>) - Method in class org.apache.edgent.streamscope.oplets.StreamScope
-
- initializeProtocol(SerialDevice, Elm327Cmds) - Static method in enum org.apache.edgent.samples.connectors.elm327.Elm327Cmds
-
Initialize the ELM327 to a specific protocol.
- inputOn(Integer...) - Static method in class org.apache.edgent.connectors.http.HttpResponders
-
Return the input tuple on specified codes.
- inputOn200() - Static method in class org.apache.edgent.connectors.http.HttpResponders
-
Return the input tuple on OK.
- insert(N, int, int) - Method in interface org.apache.edgent.graph.Graph
-
Add a new unconnected Vertex
into the graph.
- insert(OP, int, int) - Method in class org.apache.edgent.runtime.etiao.graph.DirectGraph
-
- insert(T) - Method in interface org.apache.edgent.window.Partition
-
Offers a tuple to be inserted into the partition.
- insert(T) - Method in interface org.apache.edgent.window.Window
-
Attempts to insert the tuple into its partition.
- InsertionTimeList<T> - Class in org.apache.edgent.window
-
A window contents list that maintains insertion time.
- InsertionTimeList() - Constructor for class org.apache.edgent.window.InsertionTimeList
-
- insertionTimeList() - Static method in class org.apache.edgent.window.Policies
-
- inTransition() - Method in class org.apache.edgent.graph.spi.execution.AbstractGraphJob
-
- Invocation<T extends Oplet<I,O>,I,O> - Class in org.apache.edgent.runtime.etiao
-
An
Oplet
invocation in the context of the
ETIAO runtime.
- Invocation(String, T, int, int) - Constructor for class org.apache.edgent.runtime.etiao.Invocation
-
- InvocationContext<I,O> - Class in org.apache.edgent.runtime.etiao
-
Context information for the Oplet
's execution context.
- InvocationContext(String, JobContext, RuntimeServices, int, List<? extends Consumer<O>>, List<OutputPortContext>) - Constructor for class org.apache.edgent.runtime.etiao.InvocationContext
-
Creates an InvocationContext
with the specified parameters.
- InvocationType<I,O> - Class in org.apache.edgent.runtime.etiao.graph.model
-
Generic type for an oplet invocation instance.
- InvocationType(Oplet<I, O>) - Constructor for class org.apache.edgent.runtime.etiao.graph.model.InvocationType
-
- IOT_START - Static variable in interface org.apache.edgent.connectors.iot.Events
-
An IotProvider has started.
- IotDevice - Interface in org.apache.edgent.connectors.iot
-
Generic Internet of Things device connector.
- iotDevice() - Method in class org.apache.edgent.test.svt.apps.iotp.AbstractIotpApplication
-
Get the application's IotDevice
- IotDevicePubSub - Class in org.apache.edgent.apps.iot
-
Application sharing an IotDevice
through publish-subscribe.
- IotDevicePubSub() - Constructor for class org.apache.edgent.apps.iot.IotDevicePubSub
-
- IotpDevice - Class in org.apache.edgent.connectors.iotp
-
Connector for IBM Watson IoT Platform.
- IotpDevice(Topology, Properties) - Constructor for class org.apache.edgent.connectors.iotp.IotpDevice
-
Create a connector to the IBM Watson IoT Platform Bluemix service with the device
specified by options
.
- IotpDevice(Topology, File) - Constructor for class org.apache.edgent.connectors.iotp.IotpDevice
-
Create a connector to the IBM Watson IoT Platform Bluemix service.
- IotpFullScenario - Class in org.apache.edgent.samples.scenarios.iotp
-
Sample IotProvider scenario using IBM Watson IoT Platform.
- IotpFullScenario() - Constructor for class org.apache.edgent.samples.scenarios.iotp.IotpFullScenario
-
- IotpQuickstart - Class in org.apache.edgent.samples.connectors.iotp
-
IBM Watson IoT Platform Quickstart sample.
- IotpQuickstart() - Constructor for class org.apache.edgent.samples.connectors.iotp.IotpQuickstart
-
- IotProvider - Class in org.apache.edgent.providers.iot
-
IoT provider supporting multiple topologies with a single connection to a
message hub.
- IotProvider(Function<Topology, IotDevice>) - Constructor for class org.apache.edgent.providers.iot.IotProvider
-
Create an IotProvider
that uses its own DirectProvider
.
- IotProvider(String, Function<Topology, IotDevice>) - Constructor for class org.apache.edgent.providers.iot.IotProvider
-
Create an IotProvider
that uses its own DirectProvider
.
- IotProvider(String, DirectProvider, Function<Topology, IotDevice>) - Constructor for class org.apache.edgent.providers.iot.IotProvider
-
Create an IotProvider
that uses the passed in DirectProvider
.
- IotProvider(String, TopologyProvider, DirectSubmitter<Topology, Job>, Function<Topology, IotDevice>) - Constructor for class org.apache.edgent.providers.iot.IotProvider
-
Create an IotProvider
.
- IotpSensors - Class in org.apache.edgent.samples.connectors.iotp
-
Sample sending sensor device events to IBM Watson IoT Platform.
- IotpSensors() - Constructor for class org.apache.edgent.samples.connectors.iotp.IotpSensors
-
- isCleanSession() - Method in class org.apache.edgent.connectors.mqtt.MqttConfig
-
Get the clean session setting.
- isConnected() - Method in interface org.apache.edgent.graph.Connector
-
Was connect() called on this connector?
- isControlServiceMBean(Class<?>) - Static method in class org.apache.edgent.execution.services.Controls
-
Test to see if an interface represents a valid
control service MBean.
- isEnabled() - Method in interface org.apache.edgent.streamscope.mbeans.StreamScopeMXBean
-
Is tuple capture enabled?
- isEnabled() - Method in class org.apache.edgent.streamscope.StreamScope
-
Is tuple capture enabled?
- isEnabled() - Method in class org.apache.edgent.streamscope.StreamScopeBean
-
- isImmutable(Object) - Static method in class org.apache.edgent.function.Functions
-
See if the functional logic is immutable.
- isImmutableClass(Class<?>) - Static method in class org.apache.edgent.function.Functions
-
See if a function class is immutable.
- Isolate<T> - Class in org.apache.edgent.oplet.plumbing
-
Isolate upstream processing from downstream
processing guaranteeing tuple order.
- Isolate() - Constructor for class org.apache.edgent.oplet.plumbing.Isolate
-
Create a new Isolate oplet.
- Isolate(int) - Constructor for class org.apache.edgent.oplet.plumbing.Isolate
-
Create a new Isolate oplet.
- isolate(TStream<T>, boolean) - Static method in class org.apache.edgent.topology.plumbing.PlumbingStreams
-
Isolate upstream processing from downstream processing.
- isolate(TStream<T>, int) - Static method in class org.apache.edgent.topology.plumbing.PlumbingStreams
-
Isolate upstream processing from downstream processing.
- isOpen() - Method in class org.apache.edgent.topology.plumbing.Valve
-
Get the valve state
- isPaused() - Method in interface org.apache.edgent.streamscope.mbeans.StreamScopeMXBean
-
Is capture paused?
- isPaused() - Method in class org.apache.edgent.streamscope.StreamScope.TriggerManager
-
Is capture paused?
- isPaused() - Method in class org.apache.edgent.streamscope.StreamScopeBean
-
- N - Static variable in interface org.apache.edgent.analytics.math3.json.JsonUnivariateAggregate
-
JSON key used for representation of the number
of tuples that were aggregated.
- name() - Method in interface org.apache.edgent.analytics.math3.json.JsonUnivariateAggregate
-
Name of the aggregate.
- nameForStreamAlias(String) - Static method in class org.apache.edgent.streamscope.StreamScopeRegistry
-
create a registration name for a stream alias
- nameForStreamId(String) - Static method in class org.apache.edgent.streamscope.StreamScopeRegistry
-
Create a registration name for a stream id.
- nanoTime() - Method in class org.apache.edgent.streamscope.StreamScope.Sample
-
Capture time in nanoTime.
- newAgeBasedConfig(long, long) - Static method in class org.apache.edgent.connectors.file.FileWriterRetentionConfig
-
same as newConfig(0, 0, ageSe, periodMsecc)
- newAggregateFileSizeBasedConfig(long) - Static method in class org.apache.edgent.connectors.file.FileWriterRetentionConfig
-
same as newConfig(0, aggregateFileSize, 0, 0)
- newBoolean(Topology, long) - Method in class org.apache.edgent.samples.utils.sensor.PeriodicRandomSensor
-
Create a periodic sensor stream with readings from Random.nextBoolean()
.
- newBytes(Topology, long, int) - Method in class org.apache.edgent.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 org.apache.edgent.connectors.file.FileWriterCycleConfig
-
Create a new configuration.
- newConfig(int, long, Predicate<T>) - Static method in class org.apache.edgent.connectors.file.FileWriterFlushConfig
-
Create a new configuration.
- newConfig(int, long, long, long) - Static method in class org.apache.edgent.connectors.file.FileWriterRetentionConfig
-
Create a new configuration.
- newCountBasedConfig(int) - Static method in class org.apache.edgent.connectors.file.FileWriterCycleConfig
-
same as newConfig(0, cntTuples, 0, null)
- newCountBasedConfig(int) - Static method in class org.apache.edgent.connectors.file.FileWriterFlushConfig
-
same as newConfig(cntTuples, 0, null)
- newDouble(Topology, long) - Method in class org.apache.edgent.samples.utils.sensor.PeriodicRandomSensor
-
Create a periodic sensor stream with readings from Random.nextDouble()
.
- newFileCountBasedConfig(int) - Static method in class org.apache.edgent.connectors.file.FileWriterRetentionConfig
-
same as newConfig(fileCount, 0, 0, 0)
- newFileSizeBasedConfig(long) - Static method in class org.apache.edgent.connectors.file.FileWriterCycleConfig
-
same as newConfig(fileSize, 0, 0, null)
- newFloat(Topology, long) - Method in class org.apache.edgent.samples.utils.sensor.PeriodicRandomSensor
-
Create a periodic sensor stream with readings from Random.nextFloat()
.
- newGaussian(Topology, long) - Method in class org.apache.edgent.samples.utils.sensor.PeriodicRandomSensor
-
Create a periodic sensor stream with readings from Random.nextGaussian()
.
- newImplicitConfig() - Static method in class org.apache.edgent.connectors.file.FileWriterFlushConfig
-
Create a new configuration.
- newInteger(Topology, long) - Method in class org.apache.edgent.samples.utils.sensor.PeriodicRandomSensor
-
Create a periodic sensor stream with readings from Random.nextInt()
.
- newInteger(Topology, long, int) - Method in class org.apache.edgent.samples.utils.sensor.PeriodicRandomSensor
-
Create a periodic sensor stream with readings from Random.nextInt(int)
.
- newLong(Topology, long) - Method in class org.apache.edgent.samples.utils.sensor.PeriodicRandomSensor
-
Create a periodic sensor stream with readings from Random.nextLong()
.
- newPredicateBasedConfig(Predicate<T>) - Static method in class org.apache.edgent.connectors.file.FileWriterCycleConfig
-
same as newConfig(0, 0, 0, tuplePredicate)
- newPredicateBasedConfig(Predicate<T>) - Static method in class org.apache.edgent.connectors.file.FileWriterFlushConfig
-
same as newConfig(0, 0, tuplePredicate)
- newProvider() - Method in class org.apache.edgent.samples.apps.TopologyProviderFactory
-
Get a new topology provider.
- newScheduler(ThreadFactory, BiConsumer<Object, Throwable>) - Static method in class org.apache.edgent.runtime.etiao.TrackingScheduledExecutor
-
Creates an TrackingScheduledExecutor
using the supplied thread
factory and a completion handler.
- newTester() - Method in class org.apache.edgent.providers.direct.DirectTopology
-
- newTester() - Method in class org.apache.edgent.topology.spi.AbstractTopology
-
- newThread(Runnable) - Method in class org.apache.edgent.runtime.etiao.ThreadFactoryTracker
-
Return a thread.
- newTimeBasedConfig(long) - Static method in class org.apache.edgent.connectors.file.FileWriterCycleConfig
-
same as newConfig(0, 0, periodMsec, null)
- newTimeBasedConfig(long) - Static method in class org.apache.edgent.connectors.file.FileWriterFlushConfig
-
same as newConfig(0, periodMsec, null)
- newTopology(String) - Method in class org.apache.edgent.providers.direct.DirectProvider
-
- newTopology() - Method in class org.apache.edgent.providers.iot.IotProvider
-
Create a new topology with a generated name.
- newTopology(String) - Method in class org.apache.edgent.providers.iot.IotProvider
-
Create a new topology with a given name.
- newTopology(String) - Method in class org.apache.edgent.topology.spi.AbstractTopologyProvider
-
- newTopology() - Method in class org.apache.edgent.topology.spi.AbstractTopologyProvider
-
- newTopology(String) - Method in interface org.apache.edgent.topology.TopologyProvider
-
Create a new topology with a given name.
- newTopology() - Method in interface org.apache.edgent.topology.TopologyProvider
-
Create a new topology with a generated name.
- nextGps() - Method in class org.apache.edgent.test.svt.utils.sensor.gps.SimulatedGpsSensor
-
- noAuthentication() - Static method in class org.apache.edgent.connectors.http.HttpClients
-
Create HTTP client with no authentication.
- Obd2Streams - Class in org.apache.edgent.samples.connectors.obd2
-
Sample OBD-II streams.
- Obd2Streams() - Constructor for class org.apache.edgent.samples.connectors.obd2.Obd2Streams
-
- ObdAnalyticsApplication - Class in org.apache.edgent.test.svt.apps
-
- ObdAnalyticsApplication(Topology, FleetManagementAnalyticsClientApplication) - Constructor for class org.apache.edgent.test.svt.apps.ObdAnalyticsApplication
-
- of(T...) - Method in class org.apache.edgent.topology.spi.AbstractTopology
-
- of(T...) - Method in interface org.apache.edgent.topology.Topology
-
Declare a stream of objects.
- offset() - Method in interface org.apache.edgent.connectors.kafka.KafkaConsumer.ConsumerRecord
-
- OP_KEY - Static variable in class org.apache.edgent.runtime.jsoncontrol.JsonControlService
-
Key for the operation name.
- open(T, T) - Static method in class org.apache.edgent.analytics.sensors.Ranges
-
Create a Range (lowerEndpoint..upperEndpoint) (both exclusive/OPEN)
- openClosed(T, T) - Static method in class org.apache.edgent.analytics.sensors.Ranges
-
Create a Range (lowerEndpoint..upperEndpoint] (exclusive/OPEN,inclusive/CLOSED)
- Oplet<I,O> - Interface in org.apache.edgent.oplet
-
Generic API for an oplet that processes streaming data on 0-N input ports
and produces 0-M output streams on its output ports.
- OpletContext<I,O> - Interface in org.apache.edgent.oplet
-
Context information for the Oplet
's invocation context.
- options() - Method in class org.apache.edgent.connectors.mqtt.MqttConfig
-
INTERNAL USE ONLY.
- Options - Class in org.apache.edgent.samples.connectors
-
Simple command option processor.
- Options() - Constructor for class org.apache.edgent.samples.connectors.Options
-
- org.apache.edgent.analytics.math3.json - package org.apache.edgent.analytics.math3.json
-
JSON analytics using Apache Commons Math.
- org.apache.edgent.analytics.math3.stat - package org.apache.edgent.analytics.math3.stat
-
Statistical algorithms using Apache Commons Math.
- org.apache.edgent.analytics.sensors - package org.apache.edgent.analytics.sensors
-
Analytics focused on handling sensor data.
- org.apache.edgent.apps.iot - package org.apache.edgent.apps.iot
-
Applications for use in an Internet of Things environment.
- org.apache.edgent.apps.runtime - package org.apache.edgent.apps.runtime
-
Applications which provide monitoring and failure recovery to other
Edgent applications.
- org.apache.edgent.connectors.command - package org.apache.edgent.connectors.command
-
Command / OS Process connector.
- org.apache.edgent.connectors.csv - package org.apache.edgent.connectors.csv
-
Utilities for handling Comma Separated Value strings.
- org.apache.edgent.connectors.file - package org.apache.edgent.connectors.file
-
File stream connector.
- org.apache.edgent.connectors.http - package org.apache.edgent.connectors.http
-
HTTP stream connector.
- org.apache.edgent.connectors.iot - package org.apache.edgent.connectors.iot
-
Edgent device connector API to a message hub.
- org.apache.edgent.connectors.iotp - package org.apache.edgent.connectors.iotp
-
IBM Watson IoT Platform stream connector.
- org.apache.edgent.connectors.jdbc - package org.apache.edgent.connectors.jdbc
-
JDBC based database stream connector.
- org.apache.edgent.connectors.kafka - package org.apache.edgent.connectors.kafka
-
Apache Kafka enterprise messing hub stream connector.
- org.apache.edgent.connectors.mqtt - package org.apache.edgent.connectors.mqtt
-
MQTT (lightweight messaging protocol for small sensors and mobile devices) stream connector.
- org.apache.edgent.connectors.mqtt.iot - package org.apache.edgent.connectors.mqtt.iot
-
An MQTT based IotDevice connector.
- org.apache.edgent.connectors.pubsub - package org.apache.edgent.connectors.pubsub
-
Publish subscribe model between jobs.
- org.apache.edgent.connectors.pubsub.oplets - package org.apache.edgent.connectors.pubsub.oplets
-
Oplets supporting publish subscribe service.
- org.apache.edgent.connectors.pubsub.service - package org.apache.edgent.connectors.pubsub.service
-
Publish subscribe service.
- org.apache.edgent.connectors.serial - package org.apache.edgent.connectors.serial
-
Serial port connector API.
- org.apache.edgent.connectors.wsclient - package org.apache.edgent.connectors.wsclient
-
WebSocket Client Connector API for sending and receiving messages to a WebSocket Server.
- org.apache.edgent.connectors.wsclient.javax.websocket - package org.apache.edgent.connectors.wsclient.javax.websocket
-
WebSocket Client Connector for sending and receiving messages to a WebSocket Server.
- org.apache.edgent.execution - package org.apache.edgent.execution
-
Execution of Edgent topologies and graphs.
- org.apache.edgent.execution.mbeans - package org.apache.edgent.execution.mbeans
-
Management MBeans for execution.
- org.apache.edgent.execution.services - package org.apache.edgent.execution.services
-
Execution services.
- org.apache.edgent.function - package org.apache.edgent.function
-
Functional interfaces for lambda expressions.
- org.apache.edgent.graph - package org.apache.edgent.graph
-
Low-level graph building API.
- org.apache.edgent.graph.spi - package org.apache.edgent.graph.spi
-
- org.apache.edgent.graph.spi.execution - package org.apache.edgent.graph.spi.execution
-
- org.apache.edgent.javax.websocket - package org.apache.edgent.javax.websocket
-
Support for working around JSR356 limitations for SSL client container/sockets.
- org.apache.edgent.javax.websocket.impl - package org.apache.edgent.javax.websocket.impl
-
Support for working around JSR356 limitations for SSL client container/sockets.
- org.apache.edgent.metrics - package org.apache.edgent.metrics
-
Metric utility methods, oplets, and reporters which allow an
application to expose metric values, for example via JMX.
- org.apache.edgent.metrics.oplets - package org.apache.edgent.metrics.oplets
-
- org.apache.edgent.oplet - package org.apache.edgent.oplet
-
Oplets API.
- org.apache.edgent.oplet.core - package org.apache.edgent.oplet.core
-
Core primitive oplets.
- org.apache.edgent.oplet.functional - package org.apache.edgent.oplet.functional
-
Oplets that process tuples using functions.
- org.apache.edgent.oplet.plumbing - package org.apache.edgent.oplet.plumbing
-
Oplets that control the flow of tuples.
- org.apache.edgent.oplet.window - package org.apache.edgent.oplet.window
-
Oplets using windows.
- org.apache.edgent.providers.development - package org.apache.edgent.providers.development
-
Execution of a streaming topology in a development environment .
- org.apache.edgent.providers.direct - package org.apache.edgent.providers.direct
-
Direct execution of a streaming topology.
- org.apache.edgent.providers.iot - package org.apache.edgent.providers.iot
-
Iot provider that allows multiple applications to
share an IotDevice
.
- org.apache.edgent.runtime.appservice - package org.apache.edgent.runtime.appservice
-
- org.apache.edgent.runtime.etiao - package org.apache.edgent.runtime.etiao
-
A runtime for executing an Edgent streaming topology, designed as an embeddable library
so that it can be executed in a simple Java application.
- org.apache.edgent.runtime.etiao.graph - package org.apache.edgent.runtime.etiao.graph
-
- org.apache.edgent.runtime.etiao.graph.model - package org.apache.edgent.runtime.etiao.graph.model
-
- org.apache.edgent.runtime.etiao.mbeans - package org.apache.edgent.runtime.etiao.mbeans
-
- org.apache.edgent.runtime.jmxcontrol - package org.apache.edgent.runtime.jmxcontrol
-
- org.apache.edgent.runtime.jobregistry - package org.apache.edgent.runtime.jobregistry
-
- org.apache.edgent.runtime.jsoncontrol - package org.apache.edgent.runtime.jsoncontrol
-
Control service that takes a Json message and invokes
an operation on a control service MBean.
- org.apache.edgent.samples.apps - package org.apache.edgent.samples.apps
-
Support for some more complex Edgent application samples.
- org.apache.edgent.samples.apps.mqtt - package org.apache.edgent.samples.apps.mqtt
-
Base support for Edgent MQTT based application samples.
- org.apache.edgent.samples.apps.sensorAnalytics - package org.apache.edgent.samples.apps.sensorAnalytics
-
The Sensor Analytics sample application demonstrates some common
continuous sensor analytic application themes.
- org.apache.edgent.samples.connectors - package org.apache.edgent.samples.connectors
-
General support for connector samples.
- org.apache.edgent.samples.connectors.elm327 - package org.apache.edgent.samples.connectors.elm327
-
OBD-II protocol sample using ELM327.
- org.apache.edgent.samples.connectors.elm327.runtime - package org.apache.edgent.samples.connectors.elm327.runtime
-
- org.apache.edgent.samples.connectors.file - package org.apache.edgent.samples.connectors.file
-
- org.apache.edgent.samples.connectors.iotp - package org.apache.edgent.samples.connectors.iotp
-
Samples showing device events and commands with IBM Watson IoT Platform.
- org.apache.edgent.samples.connectors.jdbc - package org.apache.edgent.samples.connectors.jdbc
-
- org.apache.edgent.samples.connectors.kafka - package org.apache.edgent.samples.connectors.kafka
-
- org.apache.edgent.samples.connectors.mqtt - package org.apache.edgent.samples.connectors.mqtt
-
- org.apache.edgent.samples.connectors.obd2 - package org.apache.edgent.samples.connectors.obd2
-
- org.apache.edgent.samples.console - package org.apache.edgent.samples.console
-
- org.apache.edgent.samples.scenarios.iotp - package org.apache.edgent.samples.scenarios.iotp
-
- org.apache.edgent.samples.topology - package org.apache.edgent.samples.topology
-
Samples showing creating and executing basic topologies .
- org.apache.edgent.samples.utils.metrics - package org.apache.edgent.samples.utils.metrics
-
- org.apache.edgent.samples.utils.sensor - package org.apache.edgent.samples.utils.sensor
-
- org.apache.edgent.streamscope - package org.apache.edgent.streamscope
-
Stream Oscilloscope - package for instrumenting streams to capture tuples.
- org.apache.edgent.streamscope.mbeans - package org.apache.edgent.streamscope.mbeans
-
- org.apache.edgent.streamscope.oplets - package org.apache.edgent.streamscope.oplets
-
Stream Oscilloscope underlying implementation oplets.
- org.apache.edgent.test.svt - package org.apache.edgent.test.svt
-
- org.apache.edgent.test.svt.apps - package org.apache.edgent.test.svt.apps
-
- org.apache.edgent.test.svt.apps.iotp - package org.apache.edgent.test.svt.apps.iotp
-
- org.apache.edgent.test.svt.utils.sensor.gps - package org.apache.edgent.test.svt.utils.sensor.gps
-
- org.apache.edgent.topology - package org.apache.edgent.topology
-
Functional api to build a streaming topology.
- org.apache.edgent.topology.json - package org.apache.edgent.topology.json
-
Utilities for use of JSON in a streaming topology.
- org.apache.edgent.topology.mbeans - package org.apache.edgent.topology.mbeans
-
Controls for executing topologies.
- org.apache.edgent.topology.plumbing - package org.apache.edgent.topology.plumbing
-
Plumbing for a streaming topology.
- org.apache.edgent.topology.services - package org.apache.edgent.topology.services
-
Services for topologies.
- org.apache.edgent.topology.spi - package org.apache.edgent.topology.spi
-
- org.apache.edgent.topology.spi.functions - package org.apache.edgent.topology.spi.functions
-
- org.apache.edgent.topology.spi.graph - package org.apache.edgent.topology.spi.graph
-
- org.apache.edgent.topology.spi.tester - package org.apache.edgent.topology.spi.tester
-
- org.apache.edgent.topology.tester - package org.apache.edgent.topology.tester
-
Testing for a streaming topology.
- org.apache.edgent.window - package org.apache.edgent.window
-
Window API.
- OutputPortContext - Interface in org.apache.edgent.oplet
-
Information about an oplet output port.
- outsideGeofence(double, double) - Static method in class org.apache.edgent.test.svt.utils.sensor.gps.SimulatedGeofence
-
- parallel(TStream<T>, int, ToIntFunction<T>, BiFunction<TStream<T>, Integer, TStream<R>>) - Static method in class org.apache.edgent.topology.plumbing.PlumbingStreams
-
Perform an analytic pipeline on tuples in parallel.
- parallelBalanced(TStream<T>, int, BiFunction<TStream<T>, Integer, TStream<R>>) - Static method in class org.apache.edgent.topology.plumbing.PlumbingStreams
-
Perform an analytic pipeline on tuples in parallel.
- parallelMap(TStream<T>, int, ToIntFunction<T>, BiFunction<T, Integer, U>) - Static method in class org.apache.edgent.topology.plumbing.PlumbingStreams
-
Perform an analytic function on tuples in parallel.
- ParameterSetter<T> - Interface in org.apache.edgent.connectors.jdbc
-
Function that sets parameters in a JDBC SQL PreparedStatement
.
- parseCsv(String) - Static method in class org.apache.edgent.connectors.csv.Csv
-
Parse a CSV string into its fields using comma for the field separator.
- parseCsv(String, char) - Static method in class org.apache.edgent.connectors.csv.Csv
-
Parse a CSV string into its fields using the specified field separator.
- partition() - Method in interface org.apache.edgent.connectors.kafka.KafkaConsumer.ConsumerRecord
-
- Partition<T,K,L extends java.util.List<T>> - Interface in org.apache.edgent.window
-
A partition within a Window
.
- PartitionedState<K,S> - Class in org.apache.edgent.window
-
Maintain partitioned state.
- PartitionedState(Supplier<S>) - Constructor for class org.apache.edgent.window.PartitionedState
-
Construct with an initial state function.
- peek(N) - Method in interface org.apache.edgent.graph.Connector
-
Inserts a Peek
oplet between an output port and its
connections.
- peek(T) - Method in class org.apache.edgent.metrics.oplets.CounterOp
-
- peek(T) - Method in class org.apache.edgent.metrics.oplets.RateMeter
-
- Peek<T> - Class in org.apache.edgent.oplet.core
-
Oplet that allows a peek at each tuple and always forwards a tuple onto
its single output port.
- Peek() - Constructor for class org.apache.edgent.oplet.core.Peek
-
- peek(T) - Method in class org.apache.edgent.oplet.core.Peek
-
- Peek<T> - Class in org.apache.edgent.oplet.functional
-
Functional peek oplet.
- Peek(Consumer<T>) - Constructor for class org.apache.edgent.oplet.functional.Peek
-
Peek oplet using a function to peek.
- peek(T) - Method in class org.apache.edgent.oplet.functional.Peek
-
- peek(Consumer<T>) - Method in class org.apache.edgent.topology.spi.graph.ConnectorStream
-
- peek(Consumer<T>) - Method in interface org.apache.edgent.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 org.apache.edgent.graph.Graph
-
Insert Peek oplets returned by the specified
Supplier
into
the outputs of all of the oplets which satisfy the specified
Predicate
and where the output's
Connector.isConnected()
is true.
- peekAll(Supplier<? extends Peek<?>>, Predicate<Vertex<?, ?, ?>>) - Method in class org.apache.edgent.graph.spi.AbstractGraph
-
- PeriodicRandomSensor - Class in org.apache.edgent.samples.utils.sensor
-
A factory of simple periodic random sensor reading streams.
- PeriodicRandomSensor() - Constructor for class org.apache.edgent.samples.utils.sensor.PeriodicRandomSensor
-
Create a new random periodic sensor factory configured
to use Random.Random()
.
- PeriodicRandomSensor(long) - Constructor for class org.apache.edgent.samples.utils.sensor.PeriodicRandomSensor
-
Create a new random periodic sensor factory configured
to use Random.Random(long)
.
- periodicSource(Topology, ProcessBuilder, long, TimeUnit) - Static method in class org.apache.edgent.connectors.command.CommandStreams
-
Create a TStream<String>
from a periodically run command's output.
- PeriodicSource<T> - Class in org.apache.edgent.oplet.core
-
- PeriodicSource(long, TimeUnit) - Constructor for class org.apache.edgent.oplet.core.PeriodicSource
-
- PeriodicSource - Class in org.apache.edgent.samples.topology
-
Periodic polling of source data.
- PeriodicSource() - Constructor for class org.apache.edgent.samples.topology.PeriodicSource
-
- PeriodicSourceWithMetrics - Class in org.apache.edgent.samples.utils.metrics
-
- PeriodicSourceWithMetrics() - Constructor for class org.apache.edgent.samples.utils.metrics.PeriodicSourceWithMetrics
-
- PeriodMXBean - Interface in org.apache.edgent.execution.mbeans
-
Control mbean interface for an entity having an a time period control.
- Person - Class in org.apache.edgent.samples.connectors.jdbc
-
A Person object for the sample.
- PersonData - Class in org.apache.edgent.samples.connectors.jdbc
-
Utilities for loading the sample's person data.
- PersonData() - Constructor for class org.apache.edgent.samples.connectors.jdbc.PersonData
-
- PersonId - Class in org.apache.edgent.samples.connectors.jdbc
-
Another class containing a person id for the sample.
- PID - Static variable in interface org.apache.edgent.samples.connectors.elm327.Cmd
-
Key ("pid") for PID identifier in JSON result.
- Pids01 - Enum in org.apache.edgent.samples.connectors.elm327
-
OBD-II Standard Mode 01 Pids.
- pipe(Connector<C>, N) - Method in interface org.apache.edgent.graph.Graph
-
Create a new connected
Vertex
associated with the
specified
Oplet
.
- pipe(Connector<C>, N) - Method in class org.apache.edgent.graph.spi.AbstractGraph
-
- Pipe<I,O> - Class in org.apache.edgent.oplet.core
-
Pipe oplet with a single input and output.
- Pipe() - Constructor for class org.apache.edgent.oplet.core.Pipe
-
- pipe(Pipe<T, U>) - Method in class org.apache.edgent.topology.spi.graph.ConnectorStream
-
- pipe(Pipe<T, U>) - Method in interface org.apache.edgent.topology.TStream
-
Declare a stream that contains the output of the specified
Pipe
oplet applied to this stream.
- PlumbingStreams - Class in org.apache.edgent.topology.plumbing
-
- PlumbingStreams() - Constructor for class org.apache.edgent.topology.plumbing.PlumbingStreams
-
- Policies - Class in org.apache.edgent.window
-
Common window policies.
- Policies() - Constructor for class org.apache.edgent.window.Policies
-
- poll(SerialDevice, long, TimeUnit, Cmd...) - Static method in class org.apache.edgent.samples.connectors.elm327.Elm327Streams
-
Periodically execute a number of ELM327 commands.
- poll(Supplier<T>, long, TimeUnit) - Method in class org.apache.edgent.topology.spi.graph.GraphTopology
-
- poll(Supplier<T>, long, TimeUnit) - Method in interface org.apache.edgent.topology.Topology
-
Declare a new source stream that calls data.get()
periodically.
- postJson(TStream<JsonObject>, Supplier<CloseableHttpClient>, Function<JsonObject, String>, UnaryOperator<JsonObject>) - Static method in class org.apache.edgent.connectors.http.HttpStreams
-
Make an HTTP POST request with JsonObject.
- preBuildTopology(Topology) - Method in class org.apache.edgent.samples.apps.AbstractApplication
-
- preBuildTopology(Topology) - Method in class org.apache.edgent.samples.apps.mqtt.AbstractMqttApplication
-
- preBuildTopology(Topology) - Method in class org.apache.edgent.test.svt.apps.iotp.AbstractIotpApplication
-
- Predicate<T> - Interface in org.apache.edgent.function
-
Predicate function.
- PREFIX_JOBID - Static variable in class org.apache.edgent.metrics.MetricObjectNameFactory
-
The prefix of the job id as serialized in the metric name.
- PREFIX_OPID - Static variable in class org.apache.edgent.metrics.MetricObjectNameFactory
-
The prefix of the oplet id as serialized in the metric name.
- PressureReliever<T,K> - Class in org.apache.edgent.oplet.plumbing
-
Relieve pressure on upstream oplets by discarding tuples.
- PressureReliever(int, Function<T, K>) - Constructor for class org.apache.edgent.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 org.apache.edgent.topology.plumbing.PlumbingStreams
-
Relieve pressure on upstream processing by discarding tuples.
- print() - Method in class org.apache.edgent.topology.spi.AbstractTStream
-
Utility method to print the contents of this stream to System.out
at runtime.
- print() - Method in interface org.apache.edgent.topology.TStream
-
Utility method to print the contents of this stream
to System.out
at runtime.
- process() - Method in class org.apache.edgent.oplet.core.ProcessSource
-
- process() - Method in class org.apache.edgent.oplet.functional.SupplierSource
-
- process() - Method in interface org.apache.edgent.window.Partition
-
Invoke the WindowProcessor's processWindow method.
- processArgs(String[]) - Method in class org.apache.edgent.samples.connectors.Options
-
- processOnInsert() - Static method in class org.apache.edgent.window.Policies
-
Returns a trigger policy that triggers
processing on every insert.
- ProcessSource<T> - Class in org.apache.edgent.oplet.core
-
- ProcessSource() - Constructor for class org.apache.edgent.oplet.core.ProcessSource
-
- processWhenFullAndEvict(int) - Static method in class org.apache.edgent.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 org.apache.edgent.samples.apps.AbstractApplication
-
- propsPath - Variable in class org.apache.edgent.samples.apps.AbstractApplication
-
- ProviderPubSub - Class in org.apache.edgent.connectors.pubsub.service
-
Publish subscribe service allowing exchange of streams between jobs in a provider.
- ProviderPubSub() - Constructor for class org.apache.edgent.connectors.pubsub.service.ProviderPubSub
-
- publish(TStream<T>, Function<T, String>, Function<T, String>, Function<T, String>, Function<T, Integer>) - Method in class org.apache.edgent.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 org.apache.edgent.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 org.apache.edgent.connectors.mqtt.MqttStreams
-
Publish a stream's tuples as MQTT messages.
- publish(TStream<String>, String, int, boolean) - Method in class org.apache.edgent.connectors.mqtt.MqttStreams
-
Publish a TStream<String>
stream's tuples as MQTT messages.
- Publish<T> - Class in org.apache.edgent.connectors.pubsub.oplets
-
Publish a stream to a PublishSubscribeService service.
- Publish(String, Class<? super T>) - Constructor for class org.apache.edgent.connectors.pubsub.oplets.Publish
-
- publish(TStream<T>, String, Class<? super T>) - Static method in class org.apache.edgent.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 org.apache.edgent.connectors.kafka.KafkaProducer
-
Publish the stream of tuples as Kafka key/value records
to the specified topic partitions.
- PublisherApp - Class in org.apache.edgent.samples.connectors.kafka
-
A Kafka producer/publisher topology application.
- PublisherApp - Class in org.apache.edgent.samples.connectors.mqtt
-
A MQTT publisher topology application.
- PublishSubscribe - Class in org.apache.edgent.connectors.pubsub
-
Publish subscribe model.
- PublishSubscribe() - Constructor for class org.apache.edgent.connectors.pubsub.PublishSubscribe
-
- PublishSubscribeService - Interface in org.apache.edgent.connectors.pubsub.service
-
Publish subscribe service.
- purgeTables(DataSource) - Static method in class org.apache.edgent.samples.connectors.jdbc.DbUtils
-
Purge the sample's tables
- put(String, Object) - Method in class org.apache.edgent.samples.connectors.Options
-
- putJson(TStream<JsonObject>, Supplier<CloseableHttpClient>, Function<JsonObject, String>, UnaryOperator<JsonObject>) - Static method in class org.apache.edgent.connectors.http.HttpStreams
-
Make an HTTP PUT request with JsonObject.
- Range<T extends java.lang.Comparable<?>> - Class in org.apache.edgent.analytics.sensors
-
A generic immutable range of values and a way to
check a value for containment in the range.
- range(T, Range.BoundType, T, Range.BoundType) - Static method in class org.apache.edgent.analytics.sensors.Range
-
Create a new Range<T>
- Range.BoundType - Enum in org.apache.edgent.analytics.sensors
-
Exclude or include an endpoint value in the range.
- Ranges - Class in org.apache.edgent.analytics.sensors
-
Convenience functions and utility operations on
Range
.
- Ranges() - Constructor for class org.apache.edgent.analytics.sensors.Ranges
-
- rateMeter(TStream<T>) - Static method in class org.apache.edgent.metrics.Metrics
-
Measure current tuple throughput and calculate one-, five-, and
fifteen-minute exponentially-weighted moving averages.
- RateMeter<T> - Class in org.apache.edgent.metrics.oplets
-
A metrics oplet which measures current tuple throughput and one-, five-,
and fifteen-minute exponentially-weighted moving averages.
- RateMeter() - Constructor for class org.apache.edgent.metrics.oplets.RateMeter
-
- receive() - Method in class org.apache.edgent.connectors.wsclient.javax.websocket.Jsr356WebSocketClient
-
Create a stream of JsonObject tuples from received JSON WebSocket text messages.
- receive() - Method in interface org.apache.edgent.connectors.wsclient.WebSocketClient
-
Create a stream of JsonObject tuples from received JSON WebSocket text messages.
- receiveBytes() - Method in class org.apache.edgent.connectors.wsclient.javax.websocket.Jsr356WebSocketClient
-
Create a stream of byte[] tuples from received WebSocket binary messages.
- receiveBytes() - Method in interface org.apache.edgent.connectors.wsclient.WebSocketClient
-
Create a stream of byte[] tuples from received WebSocket binary messages.
- receiver() - Method in class org.apache.edgent.oplet.plumbing.Barrier
-
- receiveString() - Method in class org.apache.edgent.connectors.wsclient.javax.websocket.Jsr356WebSocketClient
-
Create a stream of String tuples from received WebSocket text messages.
- receiveString() - Method in interface org.apache.edgent.connectors.wsclient.WebSocketClient
-
Create a stream of String tuples from received WebSocket text messages.
- register(String, StreamScope<?>) - Method in class org.apache.edgent.streamscope.StreamScopeRegistry
-
Register a StreamScope by name
- register(ServiceContainer) - Static method in class org.apache.edgent.streamscope.StreamScopeSetup
-
Perform the registrations needed to use the streamscope package.
- registerApplicationService() - Method in class org.apache.edgent.providers.iot.IotProvider
-
- registerControl(String, String, String, Class<T>, T) - Method in interface org.apache.edgent.execution.services.ControlService
-
Register a control MBean.
- registerControl(ControlService, EtiaoJob) - Static method in class org.apache.edgent.runtime.etiao.mbeans.EtiaoJobBean
-
Factory method which creates an EtiaoJobBean
instance to
control the specified EtiaoJob
and registers it with the
specified ControlService
.
- registerControl(String, String, String, Class<T>, T) - Method in class org.apache.edgent.runtime.jmxcontrol.JMXControlService
-
Register a control object as an MBean.
- registerControl(String, String, String, Class<T>, T) - Method in class org.apache.edgent.runtime.jsoncontrol.JsonControlService
-
Register a control MBean.
- registerControlService() - Method in class org.apache.edgent.providers.iot.IotProvider
-
- registerDisplay(IotProvider) - Static method in class org.apache.edgent.samples.scenarios.iotp.IotpFullScenario
-
- registerHeartbeat(IotProvider) - Static method in class org.apache.edgent.samples.scenarios.iotp.IotpFullScenario
-
- registerJar(String, String) - Method in class org.apache.edgent.runtime.appservice.AppService
-
Create a new class loader for the jar and register any
topology application that is registered as a service provider.
- registerJar(String, String) - Method in class org.apache.edgent.runtime.appservice.AppServiceControl
-
- registerJar(String, String) - Method in interface org.apache.edgent.topology.mbeans.ApplicationServiceMXBean
-
Register a jar file containing applications with
the application service.
- registerJar(String, String) - Method in interface org.apache.edgent.topology.services.ApplicationService
-
Register a jar file containing new applications.
- registerPartitionProcessor(BiConsumer<List<T>, K>) - Method in interface org.apache.edgent.window.Window
-
Register a WindowProcessor.
- registerPreferencesService() - Method in class org.apache.edgent.providers.iot.IotProvider
-
- registerPublishSubscribeService() - Method in class org.apache.edgent.providers.iot.IotProvider
-
- registerScheduledExecutorService(ScheduledExecutorService) - Method in interface org.apache.edgent.window.Window
-
Register a ScheduledExecutorService.
- registerSensors(IotProvider) - Static method in class org.apache.edgent.samples.scenarios.iotp.IotpFullScenario
-
- registerTopology(String, BiConsumer<IotDevice, JsonObject>) - Method in class org.apache.edgent.providers.iot.IotProvider
-
Register an application that uses an IotDevice
.
- registerTopology(String, BiConsumer<Topology, JsonObject>) - Method in class org.apache.edgent.runtime.appservice.AppService
-
- registerTopology(String, BiConsumer<Topology, JsonObject>) - Method in interface org.apache.edgent.topology.services.ApplicationService
-
Add a topology that can be started though a control mbean.
- registerWith(MBeanServer) - Method in class org.apache.edgent.metrics.MetricsSetup
-
Use the specified MBeanServer
with this metric setup.
- Regression - Enum in org.apache.edgent.analytics.math3.stat
-
Univariate regression aggregates.
- removeJob(String) - Method in interface org.apache.edgent.execution.services.JobRegistryService
-
Removes the job specified by the given identifier.
- removeJob(String) - Method in class org.apache.edgent.runtime.jobregistry.JobRegistry
-
- removeListener(BiConsumer<JobRegistryService.EventType, Job>) - Method in interface org.apache.edgent.execution.services.JobRegistryService
-
Removes a handler from this registry's collection of listeners.
- removeListener(BiConsumer<JobRegistryService.EventType, Job>) - Method in class org.apache.edgent.runtime.jobregistry.JobRegistry
-
- removeService(Class<T>) - Method in class org.apache.edgent.execution.services.ServiceContainer
-
Removes the specified service from this ServiceContainer
.
- removeState(K) - Method in class org.apache.edgent.window.PartitionedState
-
- removeSubscriber(String, Consumer<?>) - Method in class org.apache.edgent.connectors.pubsub.service.ProviderPubSub
-
- removeSubscriber(String, Consumer<?>) - Method in interface org.apache.edgent.connectors.pubsub.service.PublishSubscribeService
-
- requests(TStream<T>, Supplier<CloseableHttpClient>, Function<T, String>, Function<T, String>, BiFunction<T, CloseableHttpResponse, R>) - Static method in class org.apache.edgent.connectors.http.HttpStreams
-
Make an HTTP request for each tuple on a stream.
- requestsWithBody(TStream<T>, Supplier<CloseableHttpClient>, Function<T, String>, Function<T, String>, Function<T, HttpEntity>, BiFunction<T, CloseableHttpResponse, R>) - Static method in class org.apache.edgent.connectors.http.HttpStreams
-
Make an HTTP request with body for each tuple.
- RESERVED_ID_PREFIX - Static variable in interface org.apache.edgent.connectors.iot.IotDevice
-
Device event and command identifiers starting with "edgent" are reserved for use by Edgent.
- RESERVED_TOPIC_PREFIX - Static variable in class org.apache.edgent.connectors.pubsub.PublishSubscribe
-
Topics that start with "edgent/" are reserved for use by Edgent.
- result(JsonElement, JsonObject) - Method in interface org.apache.edgent.analytics.math3.json.JsonUnivariateAggregator
-
Place the result of the aggregation into the result
object.
- result(JsonElement, JsonObject) - Method in class org.apache.edgent.analytics.math3.stat.JsonStorelessStatistic
-
- result(JsonObject, byte[]) - Method in interface org.apache.edgent.samples.connectors.elm327.Cmd
-
Process the reply into a result.
- result(JsonObject, byte[]) - Method in enum org.apache.edgent.samples.connectors.elm327.Elm327Cmds
-
- result(JsonObject, byte[]) - Method in enum org.apache.edgent.samples.connectors.elm327.Pids01
-
- ResultsHandler<T,R> - Interface in org.apache.edgent.connectors.jdbc
-
Handle the results of executing an SQL statement.
- roundRobinSplitter(int) - Static method in class org.apache.edgent.topology.plumbing.PlumbingStreams
-
A round-robin splitter ToIntFunction
- run() - Method in class org.apache.edgent.oplet.core.PeriodicSource
-
- run() - Method in class org.apache.edgent.oplet.core.ProcessSource
-
- run() - Method in class org.apache.edgent.samples.apps.AbstractApplication
-
Construct and run the application's topology.
- run() - Method in class org.apache.edgent.samples.connectors.file.FileReaderApp
-
- run() - Method in class org.apache.edgent.samples.connectors.file.FileWriterApp
-
- run(Options) - Static method in class org.apache.edgent.samples.connectors.kafka.Runner
-
Build and run the publisher or subscriber application.
- run(Options) - Static method in class org.apache.edgent.samples.connectors.mqtt.Runner
-
Build and run the publisher or subscriber application.
- Runner - Class in org.apache.edgent.samples.connectors.kafka
-
Build and run the publisher or subscriber application.
- Runner() - Constructor for class org.apache.edgent.samples.connectors.kafka.Runner
-
- Runner - Class in org.apache.edgent.samples.connectors.mqtt
-
Build and run the publisher or subscriber application.
- Runner() - Constructor for class org.apache.edgent.samples.connectors.mqtt.Runner
-
- RuntimeServices - Interface in org.apache.edgent.execution.services
-
At runtime a container provides services to
executing elements such as oplets and functions.
- runWithFinal(Runnable, Runnable) - Static method in class org.apache.edgent.function.Functions
-
Wrap a Runnable
with a final action that
is always called when action.run()
completes.
- scheduleEvictIfEmpty(long, TimeUnit) - Static method in class org.apache.edgent.window.Policies
-
A policy which schedules a future partition eviction if the partition is empty.
- scheduleEvictOnFirstInsert(long, TimeUnit) - Static method in class org.apache.edgent.window.Policies
-
A policy which schedules a future partition eviction on the first insert.
- send(TStream<JsonObject>) - Method in class org.apache.edgent.connectors.wsclient.javax.websocket.Jsr356WebSocketClient
-
Send a stream's JsonObject tuples as JSON in a WebSocket text message.
- send(TStream<JsonObject>) - Method in interface org.apache.edgent.connectors.wsclient.WebSocketClient
-
Send a stream's JsonObject tuples as JSON in a WebSocket text message.
- sendBytes(TStream<byte[]>) - Method in class org.apache.edgent.connectors.wsclient.javax.websocket.Jsr356WebSocketClient
-
Send a stream's byte[] tuples in a WebSocket binary message.
- sendBytes(TStream<byte[]>) - Method in interface org.apache.edgent.connectors.wsclient.WebSocketClient
-
Send a stream's byte[] tuples in a WebSocket binary message.
- sendString(TStream<String>) - Method in class org.apache.edgent.connectors.wsclient.javax.websocket.Jsr356WebSocketClient
-
Send a stream's String tuples in a WebSocket text message.
- sendString(TStream<String>) - Method in interface org.apache.edgent.connectors.wsclient.WebSocketClient
-
Send a stream's String tuples in a WebSocket text message.
- Sensor1 - Class in org.apache.edgent.samples.apps.sensorAnalytics
-
Analytics for "Sensor1".
- Sensor1(Topology, SensorAnalyticsApplication) - Constructor for class org.apache.edgent.samples.apps.sensorAnalytics.Sensor1
-
- SensorAnalyticsApplication - Class in org.apache.edgent.samples.apps.sensorAnalytics
-
A sample application demonstrating some common sensor analytic processing
themes.
- sensorEventId(String, String) - Method in class org.apache.edgent.samples.apps.mqtt.AbstractMqttApplication
-
Compose a MqttDevice eventId for the sensor.
- sensorEventId(String, String) - Method in class org.apache.edgent.test.svt.apps.iotp.AbstractIotpApplication
-
Compose a IotDevice eventId for the sensor.
- sensorsAB(Topology) - Static method in class org.apache.edgent.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 org.apache.edgent.samples.topology
-
Aggregation of sensor readings.
- SensorsAggregates() - Constructor for class org.apache.edgent.samples.topology.SensorsAggregates
-
- SerialDevice - Interface in org.apache.edgent.connectors.serial
-
Access to a device (or devices) connected by a serial port.
- SerialPort - Interface in org.apache.edgent.connectors.serial
-
Serial port runtime access.
- ServiceContainer - Class in org.apache.edgent.execution.services
-
Provides a container for services.
- ServiceContainer() - Constructor for class org.apache.edgent.execution.services.ServiceContainer
-
- setActionTimeToWaitMillis(long) - Method in class org.apache.edgent.connectors.mqtt.MqttConfig
-
Maximum time to wait for an action (e.g., publish message) to complete.
- setCaptureByCount(int) - Method in interface org.apache.edgent.streamscope.mbeans.StreamScopeMXBean
-
Capture the first and every nth tuple
- setCaptureByCount(int) - Method in class org.apache.edgent.streamscope.StreamScope.TriggerManager
-
Capture the first and every nth tuple
- setCaptureByCount(int) - Method in class org.apache.edgent.streamscope.StreamScopeBean
-
- setCaptureByPredicate(Predicate<T>) - Method in class org.apache.edgent.streamscope.StreamScope.TriggerManager
-
Capture a tuple if the predicate
test of the tuple returns true.
- setCaptureByTime(long, TimeUnit) - Method in interface org.apache.edgent.streamscope.mbeans.StreamScopeMXBean
-
Capture the 1st tuple and then the next tuple after period
unit
time has elapsed since the previous captured tuple.
- setCaptureByTime(long, TimeUnit) - Method in class org.apache.edgent.streamscope.StreamScope.TriggerManager
-
Capture the 1st tuple and then the next tuple after period
unit
time has elapsed since the previous captured tuple.
- setCaptureByTime(long, TimeUnit) - Method in class org.apache.edgent.streamscope.StreamScopeBean
-
- setCleanSession(boolean) - Method in class org.apache.edgent.connectors.mqtt.MqttConfig
-
Clean Session.
- setClientId(String) - Method in class org.apache.edgent.connectors.mqtt.MqttConfig
-
Connection Client Id.
- setConnectionTimeout(int) - Method in class org.apache.edgent.connectors.mqtt.MqttConfig
-
Connection timeout.
- setContext(int, OutputPortContext) - Method in class org.apache.edgent.runtime.etiao.Invocation
-
Set the specified output port's context.
- setD1(Double) - Method in class org.apache.edgent.test.svt.MyClass1
-
- setD1(Double) - Method in class org.apache.edgent.test.svt.MyClass2
-
- setDestination(Consumer<T>) - Method in class org.apache.edgent.runtime.etiao.SettableForwarder
-
Change the destination.
- setEnabled(boolean) - Method in interface org.apache.edgent.streamscope.mbeans.StreamScopeMXBean
-
Enable or disable tuple capture.
- setEnabled(boolean) - Method in class org.apache.edgent.streamscope.StreamScope
-
Enable or disable tuple capture.
- setEnabled(boolean) - Method in class org.apache.edgent.streamscope.StreamScopeBean
-
- setHealth(Job.Health) - Method in class org.apache.edgent.graph.spi.execution.AbstractGraphJob
-
- setIdleTimeout(int) - Method in class org.apache.edgent.connectors.mqtt.MqttConfig
-
Idle connection timeout.
- setInitializer(Consumer<SerialPort>) - Method in interface org.apache.edgent.connectors.serial.SerialDevice
-
Set the initialization function for this port.
- setKeepAliveInterval(int) - Method in class org.apache.edgent.connectors.mqtt.MqttConfig
-
Connection Keep alive.
- setKeyStore(String) - Method in class org.apache.edgent.connectors.mqtt.MqttConfig
-
Set the SSL key store path.
- setKeyStorePassword(char[]) - Method in class org.apache.edgent.connectors.mqtt.MqttConfig
-
Set the SSL key store password.
- setLastError(String) - Method in class org.apache.edgent.graph.spi.execution.AbstractGraphJob
-
- setMaxRetentionCount(int) - Method in interface org.apache.edgent.streamscope.mbeans.StreamScopeMXBean
-
Set the maximum number of tuples to retain.
- setMaxRetentionCount(int) - Method in class org.apache.edgent.streamscope.StreamScope.BufferManager
-
Set the maximum number of tuples to retain.
- setMaxRetentionCount(int) - Method in class org.apache.edgent.streamscope.StreamScopeBean
-
- setMaxRetentionTime(long, TimeUnit) - Method in interface org.apache.edgent.streamscope.mbeans.StreamScopeMXBean
-
Set the maximum retention time of a tuple.
- setMaxRetentionTime(long, TimeUnit) - Method in class org.apache.edgent.streamscope.StreamScope.BufferManager
-
Set the maximum retention time of a tuple.
- setMaxRetentionTime(long, TimeUnit) - Method in class org.apache.edgent.streamscope.StreamScopeBean
-
- setMc1(MyClass1) - Method in class org.apache.edgent.test.svt.MyClass2
-
- setMc2(MyClass1) - Method in class org.apache.edgent.test.svt.MyClass2
-
- setNextState(Job.State) - Method in class org.apache.edgent.graph.spi.execution.AbstractGraphJob
-
- setNumberFractionalDigits(int) - Method in class org.apache.edgent.samples.utils.sensor.SimpleSimulatedSensor
-
Set number of fractional digits to round sensor values to.
- setOpen(boolean) - Method in class org.apache.edgent.topology.plumbing.Valve
-
Set the valve state
- setParameters(T, PreparedStatement) - Method in interface org.apache.edgent.connectors.jdbc.ParameterSetter
-
Set 0 or more parameters in a JDBC PreparedStatement.
- setPassword(char[]) - Method in class org.apache.edgent.connectors.mqtt.MqttConfig
-
Set the password to use for authentication with the server.
- setPaused(boolean) - Method in interface org.apache.edgent.streamscope.mbeans.StreamScopeMXBean
-
Set capture paused control
- setPaused(boolean) - Method in class org.apache.edgent.streamscope.StreamScope.TriggerManager
-
Set capture paused control
- setPaused(boolean) - Method in class org.apache.edgent.streamscope.StreamScopeBean
-
- setPauseOn(Predicate<T>) - Method in class org.apache.edgent.streamscope.StreamScope.TriggerManager
-
Set a pause-on predicate.
- setPeriod(long, TimeUnit) - Method in class org.apache.edgent.analytics.sensors.Deadtime
-
Set the deadtime period
- setPeriod(long) - Method in interface org.apache.edgent.execution.mbeans.PeriodMXBean
-
Set the period.
- setPeriod(long, TimeUnit) - Method in interface org.apache.edgent.execution.mbeans.PeriodMXBean
-
Set the period and unit
- setPeriod(long) - Method in class org.apache.edgent.oplet.core.PeriodicSource
-
- setPeriod(long, TimeUnit) - Method in class org.apache.edgent.oplet.core.PeriodicSource
-
- setPersistence(MqttClientPersistence) - Method in class org.apache.edgent.connectors.mqtt.MqttConfig
-
QoS 1 and 2 in-flight message persistence.
- setReceiver(BiFunction<T, Integer, U>) - Method in class org.apache.edgent.oplet.core.FanIn
-
Set the receiver function.
- setS1(String) - Method in class org.apache.edgent.test.svt.MyClass1
-
- setS1(String) - Method in class org.apache.edgent.test.svt.MyClass2
-
- setS2(String) - Method in class org.apache.edgent.test.svt.MyClass1
-
- setSeed(long) - Method in class org.apache.edgent.samples.utils.sensor.PeriodicRandomSensor
-
Set the seed to be used by subsequently created sensor streams.
- setServerURLs(String[]) - Method in class org.apache.edgent.connectors.mqtt.MqttConfig
-
MQTT Server URLs
- setSinker(Consumer<T>) - Method in class org.apache.edgent.oplet.core.Sink
-
Set the sink function.
- setState(K, S) - Method in class org.apache.edgent.window.PartitionedState
-
Set the current state for key
.
- setSubscriberIdleReconnectInterval(int) - Method in class org.apache.edgent.connectors.mqtt.MqttConfig
-
Subscriber idle reconnect interval.
- SettableForwarder<T> - Class in org.apache.edgent.runtime.etiao
-
A forwarding Streamer whose destination
can be changed.
- SettableForwarder() - Constructor for class org.apache.edgent.runtime.etiao.SettableForwarder
-
- SettableForwarder(Consumer<T>) - Constructor for class org.apache.edgent.runtime.etiao.SettableForwarder
-
Create with the specified destination.
- setTarget(int, Consumer<O>) - Method in class org.apache.edgent.runtime.etiao.Invocation
-
Disconnects the specified port and reconnects it to the specified target.
- setTrustStore(String) - Method in class org.apache.edgent.connectors.mqtt.MqttConfig
-
Set the SSL trust store path.
- setTrustStorePassword(char[]) - Method in class org.apache.edgent.connectors.mqtt.MqttConfig
-
Set the SSL trust store password.
- setUserName(String) - Method in class org.apache.edgent.connectors.mqtt.MqttConfig
-
Set the username to use for authentication with the server.
- setWill(String, byte[], int, boolean) - Method in class org.apache.edgent.connectors.mqtt.MqttConfig
-
Last Will and Testament.
- shouldCycle() - Method in class org.apache.edgent.connectors.file.FileWriterPolicy
-
- shouldFlush() - Method in class org.apache.edgent.connectors.file.FileWriterPolicy
-
- shutdown() - Method in class org.apache.edgent.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 org.apache.edgent.runtime.etiao.ThreadFactoryTracker
-
Interrupts all user treads and briefly waits for each thread to finish
execution.
- SimpleFilterTransform - Class in org.apache.edgent.samples.topology
-
- SimpleFilterTransform() - Constructor for class org.apache.edgent.samples.topology.SimpleFilterTransform
-
- SimplePublisherApp - Class in org.apache.edgent.samples.connectors.kafka
-
A simple Kafka publisher topology application.
- SimplePublisherApp - Class in org.apache.edgent.samples.connectors.mqtt
-
A simple MQTT publisher topology application.
- SimpleReaderApp - Class in org.apache.edgent.samples.connectors.jdbc
-
A simple JDBC connector sample demonstrating streaming read access
of a dbms table and creating stream tuples from the results.
- SimpleSimulatedSensor - Class in org.apache.edgent.samples.utils.sensor
-
A simple simulated sensor.
- SimpleSimulatedSensor() - Constructor for class org.apache.edgent.samples.utils.sensor.SimpleSimulatedSensor
-
Create a sensor.
- SimpleSimulatedSensor(double) - Constructor for class org.apache.edgent.samples.utils.sensor.SimpleSimulatedSensor
-
Create a sensor.
- SimpleSimulatedSensor(double, double) - Constructor for class org.apache.edgent.samples.utils.sensor.SimpleSimulatedSensor
-
Create a sensor.
- SimpleSimulatedSensor(double, double, Range<Double>) - Constructor for class org.apache.edgent.samples.utils.sensor.SimpleSimulatedSensor
-
Create a sensor.
- SimpleSubscriberApp - Class in org.apache.edgent.samples.connectors.kafka
-
A simple Kafka subscriber topology application.
- SimpleSubscriberApp - Class in org.apache.edgent.samples.connectors.mqtt
-
A simple MQTT subscriber topology application.
- simpleTS() - Static method in class org.apache.edgent.samples.connectors.Util
-
Generate a simple timestamp with the form HH:mm:ss.SSS
- SimpleWriterApp - Class in org.apache.edgent.samples.connectors.jdbc
-
A simple JDBC connector sample demonstrating streaming write access
of a dbms to add stream tuples to a table.
- SimulatedGeofence - Class in org.apache.edgent.test.svt.utils.sensor.gps
-
- SimulatedGeofence() - Constructor for class org.apache.edgent.test.svt.utils.sensor.gps.SimulatedGeofence
-
- SimulatedGpsSensor - Class in org.apache.edgent.test.svt.utils.sensor.gps
-
- SimulatedGpsSensor() - Constructor for class org.apache.edgent.test.svt.utils.sensor.gps.SimulatedGpsSensor
-
- simulatedSensors(IotDevice, boolean) - Static method in class org.apache.edgent.samples.connectors.iotp.IotpSensors
-
Simulate two bursty sensors and send the readings as IoTF device events
with an identifier of sensors
.
- SimulatedSensors - Class in org.apache.edgent.samples.utils.sensor
-
Streams of simulated sensors.
- SimulatedSensors() - Constructor for class org.apache.edgent.samples.utils.sensor.SimulatedSensors
-
- SimulatedTemperatureSensor - Class in org.apache.edgent.samples.utils.sensor
-
A Simulated temperature sensor.
- SimulatedTemperatureSensor() - Constructor for class org.apache.edgent.samples.utils.sensor.SimulatedTemperatureSensor
-
Create a temperature sensor.
- SimulatedTemperatureSensor(double, Range<Double>, double) - Constructor for class org.apache.edgent.samples.utils.sensor.SimulatedTemperatureSensor
-
Create a temperature sensor.
- SingleMetricAbstractOplet<T> - Class in org.apache.edgent.metrics.oplets
-
Base for metrics oplets which use a single metric object.
- SingleMetricAbstractOplet(String) - Constructor for class org.apache.edgent.metrics.oplets.SingleMetricAbstractOplet
-
- singleton(T) - Static method in class org.apache.edgent.analytics.sensors.Ranges
-
Create a Range [endpoint..endpoint] (both inclusive/CLOSED)
- sink(TStream<String>, ProcessBuilder) - Static method in class org.apache.edgent.connectors.command.CommandStreams
-
Sink a TStream<String>
to a command's input.
- Sink<T> - Class in org.apache.edgent.oplet.core
-
Sink a stream by processing each tuple through
a
Consumer
.
- Sink() - Constructor for class org.apache.edgent.oplet.core.Sink
-
Create a Sink
that discards all tuples.
- Sink(Consumer<T>) - Constructor for class org.apache.edgent.oplet.core.Sink
-
Create a Sink
oplet.
- sink(Consumer<T>) - Method in class org.apache.edgent.topology.spi.AbstractTStream
-
- sink(Sink<T>) - Method in class org.apache.edgent.topology.spi.graph.ConnectorStream
-
- sink(Consumer<T>) - Method in interface org.apache.edgent.topology.TStream
-
Sink (terminate) this stream using a function.
- sink(Sink<T>) - Method in interface org.apache.edgent.topology.TStream
-
Sink (terminate) this stream using a oplet.
- size() - Method in class org.apache.edgent.window.InsertionTimeList
-
- source(N) - Method in interface org.apache.edgent.graph.Graph
-
Create a new unconnected
Vertex
associated with the
specified source
Oplet
.
- source(N) - Method in class org.apache.edgent.graph.spi.AbstractGraph
-
- Source<T> - Class in org.apache.edgent.oplet.core
-
- Source() - Constructor for class org.apache.edgent.oplet.core.Source
-
- source(Topology, BiFunction<JobRegistryService.EventType, Job, T>) - Static method in class org.apache.edgent.runtime.jobregistry.JobEvents
-
- source(Supplier<Iterable<T>>) - Method in class org.apache.edgent.topology.spi.graph.GraphTopology
-
- source(Supplier<Iterable<T>>) - Method in interface org.apache.edgent.topology.Topology
-
Declare a new source stream that iterates over the return of
Iterable<T> get()
from data
.
- sourceStream(N) - Method in class org.apache.edgent.topology.spi.graph.GraphTopology
-
- Split<T> - Class in org.apache.edgent.oplet.core
-
Split a stream into multiple streams depending
on the result of a splitter function.
- Split(ToIntFunction<T>) - Constructor for class org.apache.edgent.oplet.core.Split
-
- split(int, ToIntFunction<T>) - Method in class org.apache.edgent.topology.spi.graph.ConnectorStream
-
- split(Class<E>, Function<T, E>) - Method in class org.apache.edgent.topology.spi.graph.ConnectorStream
-
- split(int, ToIntFunction<T>) - Method in interface org.apache.edgent.topology.TStream
-
Split a stream's tuples among n
streams as specified by
splitter
.
- split(Class<E>, Function<T, E>) - Method in interface org.apache.edgent.topology.TStream
-
Split a stream's tuples among enumClass.size
streams as specified by
splitter
.
- splitAlert(TStream<JsonObject>, int) - Static method in class org.apache.edgent.samples.console.ConsoleWaterDetector
-
Splits the incoming TStream<JsonObject> into individual TStreams based on the sensor type
- SplitWithEnumSample - Class in org.apache.edgent.samples.topology
-
- SplitWithEnumSample() - Constructor for class org.apache.edgent.samples.topology.SplitWithEnumSample
-
- SplitWithEnumSample.LogSeverityEnum - Enum in org.apache.edgent.samples.topology
-
- SplitWithMetrics - Class in org.apache.edgent.samples.utils.metrics
-
Instruments a topology with a tuple counter on a specified stream.
- SplitWithMetrics() - Constructor for class org.apache.edgent.samples.utils.metrics.SplitWithMetrics
-
- start() - Method in class org.apache.edgent.oplet.core.FanIn
-
- start() - Method in class org.apache.edgent.oplet.core.FanOut
-
- start() - Method in class org.apache.edgent.oplet.core.PeriodicSource
-
- start() - Method in class org.apache.edgent.oplet.core.Pipe
-
- start() - Method in class org.apache.edgent.oplet.core.ProcessSource
-
- start() - Method in class org.apache.edgent.oplet.core.Sink
-
- start() - Method in class org.apache.edgent.oplet.core.Split
-
- start() - Method in class org.apache.edgent.oplet.core.Union
-
- start() - Method in class org.apache.edgent.oplet.functional.Events
-
- start() - Method in interface org.apache.edgent.oplet.Oplet
-
Start the oplet.
- start() - Method in class org.apache.edgent.oplet.plumbing.Barrier
-
- start() - Method in class org.apache.edgent.oplet.plumbing.Isolate
-
- start() - Method in class org.apache.edgent.providers.iot.IotProvider
-
Start this provider by starting its system applications.
- start() - Method in class org.apache.edgent.runtime.etiao.Executable
-
Starts all the invocations.
- start() - Method in class org.apache.edgent.runtime.etiao.Invocation
-
Start the oplet.
- startConsoleReporter() - Method in class org.apache.edgent.metrics.MetricsSetup
-
Starts the metric ConsoleReporter
polling every second.
- startJMXReporter(String) - Method in class org.apache.edgent.metrics.MetricsSetup
-
Starts the metric JMXReporter
.
- stateChange(Job.Action) - Method in interface org.apache.edgent.execution.Job
-
Initiates an execution state change.
- stateChange(Job.Action) - Method in interface org.apache.edgent.execution.mbeans.JobMXBean
-
Initiates an execution state change.
- stateChange(Job.Action) - Method in class org.apache.edgent.graph.spi.execution.AbstractGraphJob
-
- stateChange(Job.Action) - Method in class org.apache.edgent.runtime.etiao.EtiaoJob
-
- stateChange(Job.Action) - Method in class org.apache.edgent.runtime.etiao.mbeans.EtiaoJobBean
-
- StatementSupplier - Interface in org.apache.edgent.connectors.jdbc
-
Function that supplies a JDBC SQL PreparedStatement
.
- Statistic - Enum in org.apache.edgent.analytics.math3.stat
-
Statistic implementations.
- statistics(Statistic...) - Static method in class org.apache.edgent.samples.apps.JsonTuples
-
Create a function that computes the specified statistics on the list of
samples and returns a new sample containing the result.
- streamAliasFromName(String) - Static method in class org.apache.edgent.streamscope.StreamScopeRegistry
-
Extract the stream alias from a name
- streamContents(TStream<T>, T...) - Method in interface org.apache.edgent.topology.tester.Tester
-
Return a condition that evaluates if stream
has submitted
tuples matching values
in the same order.
- streamIdFromName(String) - Static method in class org.apache.edgent.streamscope.StreamScopeRegistry
-
Extract the streamId from the name.
- StreamScope<T> - Class in org.apache.edgent.streamscope.oplets
-
A Stream "oscilloscope" oplet.
- StreamScope(Consumer<T>) - Constructor for class org.apache.edgent.streamscope.oplets.StreamScope
-
Create a new instance.
- StreamScope<T> - Class in org.apache.edgent.streamscope
-
A Stream "oscilloscope" for capturing stream tuples for analysis / debug.
- StreamScope() - Constructor for class org.apache.edgent.streamscope.StreamScope
-
Create a new instance.
- StreamScope.BufferManager<T> - Class in org.apache.edgent.streamscope
-
Control the retention of captured tuples.
- StreamScope.Sample<T> - Class in org.apache.edgent.streamscope
-
A captured tuple.
- StreamScope.TriggerManager<T> - Class in org.apache.edgent.streamscope
-
Control what triggers capturing of tuples.
- StreamScopeBean - Class in org.apache.edgent.streamscope
-
- StreamScopeBean(StreamScope<?>) - Constructor for class org.apache.edgent.streamscope.StreamScopeBean
-
- StreamScopeMXBean - Interface in org.apache.edgent.streamscope.mbeans
-
A Stream "oscilloscope" for capturing stream tuples for analysis / debug.
- StreamScopeRegistry - Class in org.apache.edgent.streamscope
-
A registry for Stream "oscilloscope"
StreamScope
instances.
- StreamScopeRegistry() - Constructor for class org.apache.edgent.streamscope.StreamScopeRegistry
-
- StreamScopeRegistryBean - Class in org.apache.edgent.streamscope
-
- StreamScopeRegistryBean(StreamScopeRegistry, ControlService) - Constructor for class org.apache.edgent.streamscope.StreamScopeRegistryBean
-
- StreamScopeRegistryMXBean - Interface in org.apache.edgent.streamscope.mbeans
-
- StreamScopeSetup - Class in org.apache.edgent.streamscope
-
Utility helpers for StreamScope setup and management.
- StreamTags - Class in org.apache.edgent.samples.topology
-
Illustrates tagging TStreams with string labels.
- StreamTags() - Constructor for class org.apache.edgent.samples.topology.StreamTags
-
- strings(String...) - Method in class org.apache.edgent.topology.spi.AbstractTopology
-
- strings(String...) - Method in interface org.apache.edgent.topology.Topology
-
Declare a stream of strings.
- submit() - Method in class org.apache.edgent.apps.runtime.JobMonitorApp
-
Submits the application topology.
- submit(E) - Method in interface org.apache.edgent.execution.Submitter
-
Submit an executable.
- submit(E, JsonObject) - Method in interface org.apache.edgent.execution.Submitter
-
Submit an executable.
- submit(U) - Method in class org.apache.edgent.oplet.core.FanIn
-
Submit a tuple to single output.
- submit(O) - Method in class org.apache.edgent.oplet.core.Pipe
-
Submit a tuple to single output.
- submit(T) - Method in class org.apache.edgent.oplet.core.Source
-
Submit a tuple to single output.
- submit(Topology, JsonObject) - Method in class org.apache.edgent.providers.development.DevelopmentProvider
-
- submit(Topology) - Method in class org.apache.edgent.providers.direct.DirectProvider
-
- submit(Topology, JsonObject) - Method in class org.apache.edgent.providers.direct.DirectProvider
-
- submit(Topology) - Method in class org.apache.edgent.providers.iot.IotProvider
-
Submit an executable.
- submit(Topology, JsonObject) - Method in class org.apache.edgent.providers.iot.IotProvider
-
Submit an executable.
- submit(String, String) - Method in class org.apache.edgent.runtime.appservice.AppServiceControl
-
- submit(String, String) - Method in interface org.apache.edgent.topology.mbeans.ApplicationServiceMXBean
-
Submit an application registered with the application service.
- submitApplication(String, ControlService) - Static method in class org.apache.edgent.apps.runtime.JobMonitorApp
-
Submits an application using an ApplicationServiceMXBean
control
registered with the specified ControlService
.
- Submitter<E,J extends Job> - Interface in org.apache.edgent.execution
-
An interface for submission of an executable.
- subscribe(Function<KafkaConsumer.StringConsumerRecord, T>, String...) - Method in class org.apache.edgent.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 org.apache.edgent.connectors.mqtt.MqttStreams
-
Subscribe to the MQTT topic(s) and create a stream of tuples of type T
.
- subscribe(String, int) - Method in class org.apache.edgent.connectors.mqtt.MqttStreams
-
Subscribe to the MQTT topic(s) and create a TStream<String>
.
- subscribe(TopologyElement, String, Class<T>) - Static method in class org.apache.edgent.connectors.pubsub.PublishSubscribe
-
Subscribe to a published topic.
- subscribeBytes(Function<KafkaConsumer.ByteConsumerRecord, T>, String...) - Method in class org.apache.edgent.connectors.kafka.KafkaConsumer
-
Subscribe to the specified topics and yield a stream of tuples
from the published Kafka records.
- SubscriberApp - Class in org.apache.edgent.samples.connectors.kafka
-
A Kafka consumer/subscriber topology application.
- SubscriberApp - Class in org.apache.edgent.samples.connectors.mqtt
-
A MQTT subscriber topology application.
- Supplier<T> - Interface in org.apache.edgent.function
-
Function that supplies a value.
- SupplierPeriodicSource<T> - Class in org.apache.edgent.oplet.functional
-
- SupplierPeriodicSource(long, TimeUnit, Supplier<T>) - Constructor for class org.apache.edgent.oplet.functional.SupplierPeriodicSource
-
- SupplierSource<T> - Class in org.apache.edgent.oplet.functional
-
- SupplierSource() - Constructor for class org.apache.edgent.oplet.functional.SupplierSource
-
- SupplierSource(Supplier<Iterable<T>>) - Constructor for class org.apache.edgent.oplet.functional.SupplierSource
-
- synchronizedBiFunction(BiFunction<T, U, R>) - Static method in class org.apache.edgent.function.Functions
-
Return a thread-safe version of a BiFunction
function.
- synchronizedConsumer(Consumer<T>) - Static method in class org.apache.edgent.function.Functions
-
Return a thread-safe version of a Consumer
function.
- synchronizedFunction(Function<T, R>) - Static method in class org.apache.edgent.function.Functions
-
Return a thread-safe version of a Function
function.
- synchronizedSupplier(Supplier<T>) - Static method in class org.apache.edgent.function.Functions
-
Return a thread-safe version of a Supplier
function.
- SYSTEM_APP_PREFIX - Static variable in interface org.apache.edgent.topology.services.ApplicationService
-
Prefix ("edgent") reserved for system application names.
- t - Variable in class org.apache.edgent.samples.apps.AbstractApplication
-
- tach(SerialDevice) - Static method in class org.apache.edgent.samples.connectors.obd2.Obd2Streams
-
Get a stream containing vehicle speed (km/h)
and engine revs (rpm).
- tag(String...) - Method in interface org.apache.edgent.graph.Connector
-
Adds the specified tags to the connector.
- tag(String...) - Method in class org.apache.edgent.topology.spi.graph.ConnectorStream
-
- tag(String...) - Method in interface org.apache.edgent.topology.TStream
-
Adds the specified tags to the stream.
- TERMINATE_COUNT - Static variable in class org.apache.edgent.samples.topology.TerminateAfterNTuples
-
The application will terminate the JVM after this tuple count
- TerminateAfterNTuples - Class in org.apache.edgent.samples.topology
-
This application simulates a crash and terminates the JVM after processing
a preset number of tuples.
- TerminateAfterNTuples() - Constructor for class org.apache.edgent.samples.topology.TerminateAfterNTuples
-
- test(T) - Method in class org.apache.edgent.analytics.sensors.Deadtime
-
Test the deadtime predicate.
- test(T) - Method in class org.apache.edgent.analytics.sensors.Range
-
Predicate.test() implementation.
- test(T) - Method in interface org.apache.edgent.function.Predicate
-
Test a value against a predicate.
- test(T) - Method in class org.apache.edgent.topology.plumbing.Valve
-
Test the state of the valve, value
is ignored.
- Tester - Interface in org.apache.edgent.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 org.apache.edgent.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 org.apache.edgent.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 org.apache.edgent.connectors.file.FileStreams
-
Write the contents of a stream to files.
- textFileWriter(TStream<String>, Supplier<String>, Supplier<IFileWriterPolicy<String>>) - Static method in class org.apache.edgent.connectors.file.FileStreams
-
Write the contents of a stream to files subject to the control
of a file writer policy.
- ThreadFactoryTracker - Class in org.apache.edgent.runtime.etiao
-
Tracks threads created for executing user tasks.
- timestamp() - Method in class org.apache.edgent.streamscope.StreamScope.Sample
-
Capture time in msec since the epoch.
- ToDoubleFunction<T> - Interface in org.apache.edgent.function
-
Function that returns a double primitive.
- ToIntFunction<T> - Interface in org.apache.edgent.function
-
Function that returns a int primitive.
- toJson(List<String>, String...) - Static method in class org.apache.edgent.connectors.csv.Csv
-
Create a JsonObject
containing the specified fieldNames
properties each with its corresponding value from fields
.
- tokenize(String) - Static method in class org.apache.edgent.connectors.command.CommandStreams
-
Tokenize the specified cmdString
in the exact same manner as
done by Runtime.exec(String)
.
- toPersonIds(List<Person>) - Static method in class org.apache.edgent.samples.connectors.jdbc.PersonData
-
Convert a List<Person>
to a List<PersonId>
- topic() - Method in interface org.apache.edgent.connectors.kafka.KafkaConsumer.ConsumerRecord
-
- topology() - Method in class org.apache.edgent.connectors.iotp.IotpDevice
-
- topology() - Method in class org.apache.edgent.connectors.mqtt.iot.MqttDevice
-
- topology() - Method in class org.apache.edgent.connectors.mqtt.MqttStreams
-
Get the
Topology
the connector is associated with.
- topology() - Method in class org.apache.edgent.connectors.wsclient.javax.websocket.Jsr356WebSocketClient
-
- topology() - Method in class org.apache.edgent.topology.spi.AbstractTopology
-
- topology() - Method in class org.apache.edgent.topology.spi.AbstractTStream
-
- topology() - Method in class org.apache.edgent.topology.spi.graph.AbstractTWindow
-
- Topology - Interface in org.apache.edgent.topology
-
A declaration of a topology of streaming data.
- topology() - Method in interface org.apache.edgent.topology.TopologyElement
-
Topology this element is contained in.
- TopologyBuilder - Interface in org.apache.edgent.topology.services
-
Represents an topology that can be built.
- TopologyElement - Interface in org.apache.edgent.topology
-
An element of a Topology
.
- TopologyProvider - Interface in org.apache.edgent.topology
-
Provider (factory) for creating topologies.
- TopologyProviderFactory - Class in org.apache.edgent.samples.apps
-
A configuration driven factory for an Edgent topology provider.
- TopologyProviderFactory(Properties) - Constructor for class org.apache.edgent.samples.apps.TopologyProviderFactory
-
Construct a factory
- TopologyTestBasic - Class in org.apache.edgent.test.svt
-
- TopologyTestBasic() - Constructor for class org.apache.edgent.test.svt.TopologyTestBasic
-
- toString() - Method in class org.apache.edgent.analytics.sensors.Deadtime
-
Returns a String for development/debug support.
- toString() - Method in class org.apache.edgent.analytics.sensors.Range
-
Yields "<lowerBoundType><lowerEndpoint>..<upperEndpoint><upperBoundType>"
.
- toString() - Method in class org.apache.edgent.connectors.file.FileWriterCycleConfig
-
- toString() - Method in class org.apache.edgent.connectors.file.FileWriterFlushConfig
-
- toString() - Method in class org.apache.edgent.connectors.file.FileWriterPolicy
-
- toString() - Method in class org.apache.edgent.connectors.file.FileWriterRetentionConfig
-
- toString() - Method in class org.apache.edgent.runtime.etiao.graph.ExecutableVertex
-
For debug.
- toString() - Method in class org.apache.edgent.runtime.etiao.Invocation
-
For debug.
- toString() - Method in class org.apache.edgent.samples.connectors.jdbc.Person
-
- toString() - Method in class org.apache.edgent.samples.connectors.jdbc.PersonId
-
- toString() - Method in class org.apache.edgent.streamscope.StreamScope.BufferManager
-
- toString() - Method in class org.apache.edgent.streamscope.StreamScope.Sample
-
- toString() - Method in class org.apache.edgent.streamscope.StreamScope
-
- toString() - Method in class org.apache.edgent.streamscope.StreamScope.TriggerManager
-
- toString() - Method in class org.apache.edgent.test.svt.MyClass1
-
- toString() - Method in class org.apache.edgent.test.svt.MyClass2
-
- toString() - Method in class org.apache.edgent.test.svt.utils.sensor.gps.GpsSensor
-
- toString() - Method in class org.apache.edgent.topology.plumbing.Valve
-
Returns a String for development/debug support.
- toString() - Method in class org.apache.edgent.topology.spi.graph.ConnectorStream
-
Intended only as a debug aid and content is not guaranteed.
- toStringUnsigned() - Method in class org.apache.edgent.analytics.sensors.Range
-
Return a String treating the endpoints as an unsigned value.
- traceStream(TStream<T>, String, Supplier<String>) - Method in class org.apache.edgent.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 org.apache.edgent.samples.apps.ApplicationUtilities
-
Trace a stream to System.out if the "label" has been configured
to enable tracing.
- TrackingScheduledExecutor - Class in org.apache.edgent.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.
- TriggerManager() - Constructor for class org.apache.edgent.streamscope.StreamScope.TriggerManager
-
- triggerMgr() - Method in class org.apache.edgent.streamscope.StreamScope
-
- TS - Static variable in interface org.apache.edgent.samples.connectors.elm327.Cmd
-
Key ("ts") for timestamp in JSON result.
- TSink<T> - Interface in org.apache.edgent.topology
-
Termination point (sink) for a stream.
- TStream<T> - Interface in org.apache.edgent.topology
-
A TStream
is a declaration of a continuous sequence of tuples.
- tuple() - Method in class org.apache.edgent.streamscope.StreamScope.Sample
-
The captured tuple.
- tupleCount(TStream<?>, long) - Method in interface org.apache.edgent.topology.tester.Tester
-
Return a condition that evaluates if stream
has submitted exactly
expectedCount
number of tuples.
- TWindow<T,K> - Interface in org.apache.edgent.topology
-
Partitioned window of tuples.
- TWindowImpl<T,K> - Class in org.apache.edgent.topology.spi.graph
-
- TWindowTimeImpl<T,K> - Class in org.apache.edgent.topology.spi.graph
-
- TYPE - Static variable in interface org.apache.edgent.execution.mbeans.JobMXBean
-
TYPE is used to identify this bean as a job bean when building the bean's ObjectName
.
- TYPE - Static variable in interface org.apache.edgent.streamscope.mbeans.StreamScopeMXBean
-
TYPE is used to identify this bean as a StreamScope bean when building the bean's ObjectName
.
- TYPE - Static variable in interface org.apache.edgent.streamscope.mbeans.StreamScopeRegistryMXBean
-
TYPE is used to identify this bean as a StreamScopeRegistry bean when building the bean's ObjectName
.
- TYPE - Static variable in interface org.apache.edgent.topology.mbeans.ApplicationServiceMXBean
-
- TYPE - Static variable in interface org.apache.edgent.topology.TStream
-
TYPE is used to identify
ControlService
mbeans registered for
for a TStream.
- TYPE_KEY - Static variable in class org.apache.edgent.runtime.jsoncontrol.JsonControlService
-
Key for the type of the control MBean in a JSON request.
- TYPE_PREFIX - Static variable in class org.apache.edgent.metrics.MetricObjectNameFactory
-
Prefix of all metric types.
- valid() - Method in interface org.apache.edgent.topology.tester.Condition
-
- value() - Method in interface org.apache.edgent.connectors.kafka.KafkaConsumer.ConsumerRecord
-
- VALUE - Static variable in interface org.apache.edgent.samples.connectors.elm327.Cmd
-
Key ("value") for the returned value in JSON result.
- valueOf(String) - Static method in enum org.apache.edgent.analytics.math3.stat.Regression
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.edgent.analytics.math3.stat.Statistic
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.edgent.analytics.sensors.Range.BoundType
-
Returns the enum constant of this type with the specified name.
- valueOf(String, Function<String, T>) - Static method in class org.apache.edgent.analytics.sensors.Range
-
Create a Range from a String produced by toString().
- valueOf(String) - Static method in enum org.apache.edgent.execution.Job.Action
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.edgent.execution.Job.Health
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.edgent.execution.Job.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.edgent.execution.services.JobRegistryService.EventType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.edgent.samples.connectors.elm327.Elm327Cmds
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.edgent.samples.connectors.elm327.Pids01
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.edgent.samples.topology.SplitWithEnumSample.LogSeverityEnum
-
Returns the enum constant of this type with the specified name.
- valueOfBigDecimal(String) - Static method in class org.apache.edgent.analytics.sensors.Ranges
-
Create a Range from a Range<BigDecimal>.toString() value.
- valueOfBigInteger(String) - Static method in class org.apache.edgent.analytics.sensors.Ranges
-
Create a Range from a Range<BigInteger>.toString() value.
- valueOfByte(String) - Static method in class org.apache.edgent.analytics.sensors.Ranges
-
Create a Range from a Range<Byte>.toString() value.
- valueOfCharacter(String) - Static method in class org.apache.edgent.analytics.sensors.Ranges
-
Create a Range from a Range<Character>.toString() value.
- valueOfDouble(String) - Static method in class org.apache.edgent.analytics.sensors.Ranges
-
Create a Range from a Range<Double>.toString() value.
- valueOfFloat(String) - Static method in class org.apache.edgent.analytics.sensors.Ranges
-
Create a Range from a Range<Float>.toString() value.
- valueOfInteger(String) - Static method in class org.apache.edgent.analytics.sensors.Ranges
-
Create a Range from a Range<Integer>.toString() value.
- valueOfLong(String) - Static method in class org.apache.edgent.analytics.sensors.Ranges
-
Create a Range from a Range<Long>.toString() value.
- valueOfShort(String) - Static method in class org.apache.edgent.analytics.sensors.Ranges
-
Create a Range from a Range<Short>.toString() value.
- valueOfString(String) - Static method in class org.apache.edgent.analytics.sensors.Ranges
-
Create a Range from a Range<String>.toString() value.
- values() - Static method in enum org.apache.edgent.analytics.math3.stat.Regression
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.edgent.analytics.math3.stat.Statistic
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.edgent.analytics.sensors.Range.BoundType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.edgent.execution.Job.Action
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.edgent.execution.Job.Health
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.edgent.execution.Job.State
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.edgent.execution.services.JobRegistryService.EventType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.edgent.samples.connectors.elm327.Elm327Cmds
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.edgent.samples.connectors.elm327.Pids01
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.edgent.samples.topology.SplitWithEnumSample.LogSeverityEnum
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- Valve<T> - Class in org.apache.edgent.topology.plumbing
-
- Valve() - Constructor for class org.apache.edgent.topology.plumbing.Valve
-
Create a new Valve Predicate
- Valve(boolean) - Constructor for class org.apache.edgent.topology.plumbing.Valve
-
Create a new Valve Predicate
- verify(TStream<T>) - Method in class org.apache.edgent.topology.spi.AbstractTStream
-
- Vertex<N extends Oplet<C,P>,C,P> - Interface in org.apache.edgent.graph
-
A Vertex
in a graph.
- VertexType<I,O> - Class in org.apache.edgent.runtime.etiao.graph.model
-
A VertexType
in a graph.
- VertexType(Vertex<? extends Oplet<?, ?>, ?, ?>, IdMapper<String>) - Constructor for class org.apache.edgent.runtime.etiao.graph.model.VertexType
-
- VertexType() - Constructor for class org.apache.edgent.runtime.etiao.graph.model.VertexType
-