- adaptiveRange(boolean) - Static method in class org.epics.pvmanager.extra.WaterfallPlotParameters
-
True if the range for the display should be the automatically
determined or should be desumed by the data.
- add(DesiredRateExpression<?>) - Method in class org.epics.pvmanager.extra.DynamicGroup
-
Adds the expression at the end.
- addAll(DataRecipeBuilder) - Method in class org.epics.pvmanager.DataRecipeBuilder
-
Add all elements from another builder.
- addBuffer(WriteBufferBuilder) - Method in class org.epics.pvmanager.WriteBufferBuilder
-
Adds another builder
- addCaches(Map<String, WriteCache<?>>) - Method in class org.epics.pvmanager.WriteBufferBuilder
-
Adds a set of channel/write caches.
- addCollector(Collector<?>, Map<String, ValueCache>) - Method in class org.epics.pvmanager.DataRecipeBuilder
-
Add a collector and the channel/caches this collector will get values from.
- additiveExpression() - Method in class org.epics.pvmanager.formula.FormulaParser
-
- addMonitor(ChannelHandlerReadSubscription) - Method in class org.epics.pvmanager.ChannelHandler
-
Used by the data source to add a read request on the channel managed
by this handler.
- addMonitor(ChannelHandlerReadSubscription) - Method in class org.epics.pvmanager.MultiplexedChannelHandler
-
Used by the data source to add a read request on the channel managed
by this handler.
- addMonitor(ChannelHandlerReadSubscription) - Method in class org.epics.pvmanager.pva.PVAChannelHandler
-
- addPVReaderListener(PVReaderListener) - Method in class org.epics.pvmanager.PV
-
- addPVReaderListener(Class<?>, PVReaderListener) - Method in class org.epics.pvmanager.PV
-
- addPVReaderListener(PVReaderListener) - Method in interface org.epics.pvmanager.PVReader
-
Adds a listener to the value.
- addPVReaderListener(Class<?>, PVReaderListener) - Method in interface org.epics.pvmanager.PVReader
-
Adds a listener to the value, which is notified only if the value is
of a given type.
- addPVWriterListener(PVWriterListener) - Method in class org.epics.pvmanager.PV
-
- addPVWriterListener(PVWriterListener) - Method in interface org.epics.pvmanager.PVWriter
-
Adds a listener to the value.
- addTypeSupport(TypeSupport<?>) - Static method in class org.epics.pvmanager.TypeSupport
-
Adds type support for the given class.
- addWriter(WriteCache<?>, ExceptionHandler) - Method in class org.epics.pvmanager.ChannelHandler
-
Used by the data source to prepare the channel managed by this handler
for write.
- addWriter(WriteCache<?>, ExceptionHandler) - Method in class org.epics.pvmanager.MultiplexedChannelHandler
-
Used by the data source to prepare the channel managed by this handler
for write.
- after(String...) - Method in class org.epics.pvmanager.expression.ChannelExpression
-
For writes only, marks that this channel should be written only after the
given channels.
- after(String...) - Method in class org.epics.pvmanager.expression.ChannelExpressionList
-
For writes only, marks that these channels should be written only after the
given channels.
- after(TimeStamp) - Method in class org.epics.pvmanager.util.TimeDuration
-
Deprecated.
Returns a time interval that lasts this duration and starts from the
given timestamp.
- Aggregator<R,A> - Class in org.epics.pvmanager
-
Aggregates the data out of a Collector into a new data type.
- Aggregator(Function<List<A>>) - Constructor for class org.epics.pvmanager.Aggregator
-
Creates a new aggregator.
- Alarm - Interface in org.epics.pvmanager.data
-
Alarm information.
- alarmNone() - Static method in class org.epics.pvmanager.data.ValueFactory
-
No alarm.
- alarmOf(Object) - Static method in class org.epics.pvmanager.data.ValueUtil
-
Extracts the alarm information if present.
- AlarmSeverity - Enum in org.epics.pvmanager.data
-
Severity of an alarm.
- AlarmStatus - Enum in org.epics.pvmanager.data
-
Source of the alarm.
- and(DesiredRateExpressionList<? extends R>) - Method in interface org.epics.pvmanager.expression.DesiredRateExpressionList
-
Adds the given expressions to this list.
- and(DesiredRateExpressionList<? extends R>) - Method in class org.epics.pvmanager.expression.DesiredRateExpressionListImpl
-
- and(DesiredRateReadWriteExpressionList<? extends R, ? extends W>) - Method in interface org.epics.pvmanager.expression.DesiredRateReadWriteExpressionList
-
Adds the given expressions to this list.
- and(DesiredRateReadWriteExpressionList<? extends R, ? extends W>) - Method in class org.epics.pvmanager.expression.DesiredRateReadWriteExpressionListImpl
-
- and(DesiredRateExpressionList<? extends R>) - Method in class org.epics.pvmanager.expression.DesiredRateReadWriteExpressionListImpl
-
- and(WriteExpressionList<? extends W>) - Method in class org.epics.pvmanager.expression.DesiredRateReadWriteExpressionListImpl
-
- and(SourceRateExpressionList<? extends R>) - Method in interface org.epics.pvmanager.expression.SourceRateExpressionList
-
Adds the given expressions to this list.
- and(SourceRateExpressionList<? extends R>) - Method in class org.epics.pvmanager.expression.SourceRateExpressionListImpl
-
- and(SourceRateReadWriteExpressionList<? extends R, ? extends W>) - Method in interface org.epics.pvmanager.expression.SourceRateReadWriteExpressionList
-
Adds the given expressions to this list.
- and(SourceRateReadWriteExpressionList<? extends R, ? extends W>) - Method in class org.epics.pvmanager.expression.SourceRateReadWriteExpressionListImpl
-
- and(SourceRateExpressionList<? extends R>) - Method in class org.epics.pvmanager.expression.SourceRateReadWriteExpressionListImpl
-
- and(WriteExpressionList<? extends W>) - Method in class org.epics.pvmanager.expression.SourceRateReadWriteExpressionListImpl
-
- and(WriteExpressionList<? extends W>) - Method in interface org.epics.pvmanager.expression.WriteExpressionList
-
Adds the given expressions to this list.
- and(WriteExpressionList<? extends W>) - Method in class org.epics.pvmanager.expression.WriteExpressionListImpl
-
- and(ExpressionLanguage.Filter<?>) - Method in class org.epics.pvmanager.ExpressionLanguage.Filter
-
Returns a new filter that is the logical AND of this and the given
one.
- around(TimeStamp) - Method in class org.epics.pvmanager.util.TimeDuration
-
Deprecated.
Returns a time interval that lasts this duration and is centered
around the given timestamp.
- Array<T> - Interface in org.epics.pvmanager.data
-
Multi dimensional array, which can be used for waveforms or more rich data.
- as(String) - Method in interface org.epics.pvmanager.expression.DesiredRateExpression
-
Changes the name for this expression
- as(String) - Method in class org.epics.pvmanager.expression.DesiredRateExpressionImpl
-
- as(String) - Method in interface org.epics.pvmanager.expression.DesiredRateReadWriteExpression
-
- as(String) - Method in class org.epics.pvmanager.expression.DesiredRateReadWriteExpressionImpl
-
- as(String) - Method in interface org.epics.pvmanager.expression.SourceRateExpression
-
Changes the name for this expression
- as(String) - Method in class org.epics.pvmanager.expression.SourceRateExpressionImpl
-
- as(String) - Method in interface org.epics.pvmanager.expression.SourceRateReadWriteExpression
-
- as(String) - Method in class org.epics.pvmanager.expression.SourceRateReadWriteExpressionImpl
-
- as(String) - Method in class org.epics.pvmanager.expression.WriteExpressionImpl
-
Changes the name for this expression
- asDate() - Method in class org.epics.pvmanager.util.TimeStamp
-
Deprecated.
Converts the time stamp to a standard Date.
- asTimeDuration(TimeDuration) - Static method in class org.epics.pvmanager.util.TimeDuration
-
Deprecated.
- asTimestamp() - Method in class org.epics.pvmanager.util.TimeStamp
-
Deprecated.
Converts to the epics common definition of time.
- asTimestamp(TimeStamp) - Static method in class org.epics.pvmanager.util.TimeStamp
-
Deprecated.
Null safe way of converting to the epics common definition of time.
- async() - Method in class org.epics.pvmanager.PVWriterConfiguration
-
- asynchWriteAndMaxReadRate(TimeDuration) - Method in class org.epics.pvmanager.PVConfiguration
-
Creates the pv such that writes are asynchronous and read notifications
comes at most at the rate specified.
- asynchWriteAndReadEvery(TimeDuration) - Method in class org.epics.pvmanager.PVConfiguration
-
Deprecated.
- averageOf(SourceRateExpression<VDouble>) - Static method in class org.epics.pvmanager.data.ExpressionLanguage
-
Aggregates the sample at the scan rate and takes the average.
- calculate(List<A>) - Method in class org.epics.pvmanager.Aggregator
-
Calculates the new value from a set of collected value.
- calculate(A) - Method in interface org.epics.pvmanager.ExpressionLanguage.OneArgFunction
-
Calculates the new value.
- calculate(A1, A2) - Method in interface org.epics.pvmanager.ExpressionLanguage.TwoArgFunction
-
Calculates the new value.
- channel(String) - Static method in class org.epics.pvmanager.ExpressionLanguage
-
A channel with the given name of any type.
- channel(String, Class<R>, Class<W>) - Static method in class org.epics.pvmanager.ExpressionLanguage
-
A channel with the given name and type.
- ChannelExpression<R,W> - Class in org.epics.pvmanager.expression
-
Represents a channel, which can be both read or written.
- ChannelExpression(String, Class<R>, Class<W>) - Constructor for class org.epics.pvmanager.expression.ChannelExpression
-
An expression for a channel with the given name, which is expected to
provide a read payload of readClass
and accept a write payload
of writeClass
.
- ChannelExpression(Class<R>, Class<W>) - Constructor for class org.epics.pvmanager.expression.ChannelExpression
-
Constructor for the null channel.
- ChannelExpressionList<R,W> - Class in org.epics.pvmanager.expression
-
Represents a list of channel, which can be both read or written.
- ChannelExpressionList(Collection<String>, Class<R>, Class<W>) - Constructor for class org.epics.pvmanager.expression.ChannelExpressionList
-
An expression for a list of channels with the given names, which are expected to
provide a read payload of readClass
and accept a write payload
of writeClass
.
- ChannelHandler - Class in org.epics.pvmanager
-
Manages the connection for each channel of a data source.
- ChannelHandler(String) - Constructor for class org.epics.pvmanager.ChannelHandler
-
Creates a new channel handler.
- ChannelHandlerReadSubscription - Class in org.epics.pvmanager
-
Groups all the parameters required to add a reader to a ChannelHandler.
- ChannelHandlerReadSubscription(Collector<?>, ValueCache<?>, ExceptionHandler, Collector<Boolean>, ValueCache<Boolean>) - Constructor for class org.epics.pvmanager.ChannelHandlerReadSubscription
-
- ChannelRecipe - Class in org.epics.pvmanager
-
- ChannelRecipe(String, ChannelHandlerReadSubscription) - Constructor for class org.epics.pvmanager.ChannelRecipe
-
- channels(String...) - Static method in class org.epics.pvmanager.ExpressionLanguage
-
A list of channels with the given names of any type.
- channels(Collection<String>, Class<R>, Class<W>) - Static method in class org.epics.pvmanager.ExpressionLanguage
-
A list of channels with the given names and type.
- channels(Collection<String>) - Static method in class org.epics.pvmanager.ExpressionLanguage
-
A list of channels with the given names of any type.
- ChannelWriteCallback - Interface in org.epics.pvmanager
-
Called by the ChannelHandler once a write is completed.
- channelWritten(Exception) - Method in interface org.epics.pvmanager.ChannelWriteCallback
-
Called when a write is completed.
- clear() - Method in class org.epics.pvmanager.extra.DynamicGroup
-
Removes all the expressions currently in the group.
- close() - Method in class org.epics.pvmanager.CompositeDataSource
-
Closes all DataSources that are registered in the composite.
- close() - Method in class org.epics.pvmanager.DataSource
-
Closes the DataSource and the resources associated with it.
- close() - Method in class org.epics.pvmanager.jca.JCADataSource
-
- close() - Method in class org.epics.pvmanager.PV
-
- close() - Method in class org.epics.pvmanager.pva.PVADataSource
-
- close() - Method in interface org.epics.pvmanager.PVReader
-
De-registers all listeners, stops all notifications and closes all
connections from the data sources needed by this.
- close() - Method in interface org.epics.pvmanager.PVWriter
-
De-registers all listeners, stops all notifications and closes all
connections from the data sources needed by this.
- collect() - Method in class org.epics.pvmanager.Collector
-
Calculates the next value and puts it in the queue.
- Collector<T> - Class in org.epics.pvmanager
-
Collects the data at the CA rate and allows a client to get all values
since last check.
- Collector() - Constructor for class org.epics.pvmanager.Collector
-
- color(double, Display) - Method in class org.epics.pvmanager.extra.ColorScheme
-
Calculate the color for the value according to the ranges and puts it
into the colors buffer.
- ColorScheme - Class in org.epics.pvmanager.extra
-
- ColorScheme() - Constructor for class org.epics.pvmanager.extra.ColorScheme
-
- colorScheme(ColorScheme) - Static method in class org.epics.pvmanager.extra.WaterfallPlotParameters
-
The color scheme to convert a value to an rgb pixel in the plot.
- column(String, DesiredRateExpressionList<?>) - Static method in class org.epics.pvmanager.data.ExpressionLanguage
-
A column for an aggregated vTable.
- compareTo(TimeStamp) - Method in class org.epics.pvmanager.util.TimeStamp
-
Deprecated.
Defines the natural ordering for timestamp as forward in time.
- CompositeDataSource - Class in org.epics.pvmanager
-
A data source that can dispatch a request to multiple different
data sources.
- CompositeDataSource() - Constructor for class org.epics.pvmanager.CompositeDataSource
-
Creates a new CompositeDataSource.
- concludeWrite(WriteBuffer, ExceptionHandler) - Method in class org.epics.pvmanager.CompositeDataSource
-
- concludeWrite(WriteBuffer, ExceptionHandler) - Method in class org.epics.pvmanager.DataSource
-
Releases the resources associated with the given write buffer.
- connect(DataRecipe) - Method in class org.epics.pvmanager.CompositeDataSource
-
- connect(DataRecipe) - Method in class org.epics.pvmanager.DataSource
-
Connects to a set of channels based on the given recipe.
- connect() - Method in class org.epics.pvmanager.MultiplexedChannelHandler
-
Used by the handler to open the connection.
- connect() - Method in class org.epics.pvmanager.pva.PVAChannelHandler
-
- constant(T) - Static method in class org.epics.pvmanager.ExpressionLanguage
-
Creates a constant expression that always return that object.
- constant(T, String) - Static method in class org.epics.pvmanager.ExpressionLanguage
-
Creates a constant expression that always return that object, with the
given name for the expression.
- contains(TimeStamp) - Method in class org.epics.pvmanager.util.TimeInterval
-
Deprecated.
True if the given time stamp is inside the interval.
- convertValue(PVStructure, Object, boolean) - Method in interface org.epics.pvmanager.pva.PVATypeConverter
-
Creates an instance of Value from the data in pvStructure.
- createChannel(String) - Method in class org.epics.pvmanager.CompositeDataSource
-
- createChannel(String) - Method in class org.epics.pvmanager.DataSource
-
Creates a channel handler for the given name.
- createChannel(String) - Method in class org.epics.pvmanager.jca.JCADataSource
-
- createChannel(String) - Method in class org.epics.pvmanager.loc.LocalDataSource
-
- createChannel(String) - Method in class org.epics.pvmanager.pva.PVADataSource
-
- createChannel(String) - Method in class org.epics.pvmanager.sim.SimulationDataSource
-
- createChannel(String) - Method in class org.epics.pvmanager.test.TestDataSource
-
- createValue(DBR, DBR, boolean) - Method in class org.epics.pvmanager.jca.JCATypeAdapter
-
Given the value and the (optional) metadata, will create the new value.
- createWriteBuffer() - Method in class org.epics.pvmanager.expression.DesiredRateReadWriteExpressionImpl
-
- createWriteBuffer() - Method in class org.epics.pvmanager.expression.SourceRateReadWriteExpressionImpl
-
- createWriteBuffer() - Method in interface org.epics.pvmanager.expression.WriteExpression
-
The buffer that will contain the data to write.
- createWriteBuffer() - Method in class org.epics.pvmanager.expression.WriteExpressionImpl
-
Creates a data recipe for the given expression.
- Gaussian - Class in org.epics.pvmanager.sim
-
Function to simulate a signal that has a gaussian distribution.
- Gaussian() - Constructor for class org.epics.pvmanager.sim.Gaussian
-
Creates a signal with a normal distribution (average zero and
standard deviation one), updating every 100ms (10Hz).
- Gaussian(Double, Double, Double) - Constructor for class org.epics.pvmanager.sim.Gaussian
-
Creates a signal with a gaussian distribution, updating at the rate
specified.
- gaussian(double, double, double) - Static method in class org.epics.pvmanager.sim.GaussianWaveform
-
1D gaussian, centered on centerX and with the specified width.
- GaussianWaveform - Class in org.epics.pvmanager.sim
-
Function to simulate a waveform containing a gaussian that moves to the
right.
- GaussianWaveform() - Constructor for class org.epics.pvmanager.sim.GaussianWaveform
-
Creates a gaussian waveform with a normal distribution (average zero and
standard deviation one), updating every 100ms (10Hz).
- GaussianWaveform(Double, Double, Double) - Constructor for class org.epics.pvmanager.sim.GaussianWaveform
-
Creates a gaussian waveform signal with a gaussian distribution, updating at the rate
specified.
- getAdapters() - Method in interface org.epics.pvmanager.DataSourceTypeAdapterSet
-
Returns a collation of adapters.
- getAdapters() - Method in interface org.epics.pvmanager.jca.JCATypeAdapterSet
-
- getAdapters() - Method in class org.epics.pvmanager.jca.JCAVTypeAdapterSet
-
- getAlarmSeverity() - Method in interface org.epics.pvmanager.data.Alarm
-
Returns the alarm severity, which describes the quality of the
value returned.
- getAlarmStatus() - Method in interface org.epics.pvmanager.data.Alarm
-
Returns the alarm status of the highest currently active alarm.
- getArray() - Method in interface org.epics.pvmanager.data.Array
-
- getArray() - Method in interface org.epics.pvmanager.data.VByteArray
- getArray() - Method in interface org.epics.pvmanager.data.VDoubleArray
- getArray() - Method in interface org.epics.pvmanager.data.VEnumArray
-
- getArray() - Method in interface org.epics.pvmanager.data.VFloatArray
-
- getArray() - Method in interface org.epics.pvmanager.data.VIntArray
-
- getArray() - Method in interface org.epics.pvmanager.data.VShortArray
-
- getArray() - Method in interface org.epics.pvmanager.data.VStringArray
-
- getArray(int) - Method in interface org.epics.pvmanager.extra.DoubleArrayTimeCache.Data
-
- getArray(int) - Method in class org.epics.pvmanager.extra.DoubleArrayTimeCacheFromVDoubleArray.Data
-
- getArray(int) - Method in class org.epics.pvmanager.extra.DoubleArrayTimeCacheFromVDoubles.Data
-
- getAsyncWriteExecutor() - Static method in class org.epics.pvmanager.PVManager
-
Returns the current executor on which the asynchronous calls are executed.
- getAverage() - Method in interface org.epics.pvmanager.data.Statistics
-
The average.
- getBegin() - Method in interface org.epics.pvmanager.extra.DoubleArrayTimeCache.Data
-
- getBegin() - Method in class org.epics.pvmanager.extra.DoubleArrayTimeCacheFromVDoubleArray.Data
-
- getBegin() - Method in class org.epics.pvmanager.extra.DoubleArrayTimeCacheFromVDoubles.Data
-
- getCache() - Method in class org.epics.pvmanager.ChannelHandlerReadSubscription
-
The cache to update when a new value is available.
- getChannelName() - Method in class org.epics.pvmanager.ChannelHandler
-
Returns the name of the channel.
- getChannelName() - Method in class org.epics.pvmanager.ChannelRecipe
-
- getChannelName() - Method in class org.epics.pvmanager.WriteCache
-
The channel associated to this cache
- getChannelRecipes() - Method in class org.epics.pvmanager.DataRecipe
-
- getChannels() - Method in class org.epics.pvmanager.CompositeDataSource
-
- getChannels() - Method in class org.epics.pvmanager.DataSource
-
Returns the channel handlers for this data source.
- getChannelsPerCollectors() - Method in class org.epics.pvmanager.DataRecipe
-
Returns all channels that need to be connected, organized by the collector
that needs them.
- getCollector() - Method in class org.epics.pvmanager.ChannelHandlerReadSubscription
-
The collector to lock and notify when a new value is available.
- getColorScheme() - Method in class org.epics.pvmanager.extra.WaterfallPlotParameters
-
Color scheme used for the plot.
- getColumnArray(int) - Method in interface org.epics.pvmanager.data.VTable
-
The data for the given column.
- getColumnCount() - Method in interface org.epics.pvmanager.data.VTable
-
The number of columns in the table.
- getColumnName(int) - Method in interface org.epics.pvmanager.data.VTable
-
The name of the given column.
- getColumnType(int) - Method in interface org.epics.pvmanager.data.VTable
-
The type of the elements in the column.
- getConditions() - Method in interface org.epics.pvmanager.data.VExtendedAlarm
-
All the possible alarm conditions for the device, and
whether they are on or off.
- getConnCache() - Method in class org.epics.pvmanager.ChannelHandlerReadSubscription
-
The cache to update whenever the connection state changes.
- getConnCollector() - Method in class org.epics.pvmanager.ChannelHandlerReadSubscription
-
The collector to lock and notify whenever the connection state changes.
- getConnectionCaches() - Method in class org.epics.pvmanager.DataRecipe
-
- getConnectionCollector() - Method in class org.epics.pvmanager.DataRecipe
-
- getConnectionPayload() - Method in class org.epics.pvmanager.MultiplexedChannelHandler
-
The last processes connection payload.
- getContext() - Method in class org.epics.pvmanager.jca.JCADataSource
-
The context used by the data source.
- getContext() - Method in class org.epics.pvmanager.pva.PVADataSource
-
- getData() - Method in interface org.epics.pvmanager.data.VByteArray
- getData() - Method in interface org.epics.pvmanager.data.VDoubleArray
- getData() - Method in interface org.epics.pvmanager.data.VFloatArray
-
- getData() - Method in interface org.epics.pvmanager.data.VImage
-
Image buffer;
- getData() - Method in interface org.epics.pvmanager.data.VIntArray
-
- getData() - Method in interface org.epics.pvmanager.data.VNumberArray
-
- getData() - Method in interface org.epics.pvmanager.data.VShortArray
-
- getData(Timestamp, Timestamp) - Method in interface org.epics.pvmanager.extra.DoubleArrayTimeCache
-
- getData(Timestamp, Timestamp) - Method in class org.epics.pvmanager.extra.DoubleArrayTimeCacheFromVDoubleArray
-
- getData(Timestamp, Timestamp) - Method in class org.epics.pvmanager.extra.DoubleArrayTimeCacheFromVDoubles
-
- getDataRecipe() - Method in interface org.epics.pvmanager.expression.DesiredRateExpression
-
The recipe for connect the channels for this expression.
- getDataRecipe() - Method in class org.epics.pvmanager.expression.DesiredRateExpressionImpl
-
The recipe for connect the channels for this expression.
- getDataRecipe() - Method in class org.epics.pvmanager.expression.DesiredRateReadWriteExpressionImpl
-
- getDataSources() - Method in class org.epics.pvmanager.CompositeDataSource
-
Returns the data sources registered to this composite data source.
- getDefaultDataSource() - Method in class org.epics.pvmanager.CompositeDataSource
-
Returns which data source is used if no data source is specified in the
channel name.
- getDefaultDataSource() - Static method in class org.epics.pvmanager.PVManager
-
Returns the current default data source.
- getDefaultNotificationExecutor() - Static method in class org.epics.pvmanager.PVManager
-
Returns the current default executor that will execute all notifications.
- getDefaultPriority() - Method in class org.epics.pvmanager.pva.PVADataSource
-
- getDelegates() - Method in class org.epics.pvmanager.formula.FormulaLexer
-
- getDelegates() - Method in class org.epics.pvmanager.formula.FormulaParser
-
- getDelimiter() - Method in class org.epics.pvmanager.CompositeDataSource
-
Returns the delimeter that divides the data source name from the
channel name.
- getDesiredRateExpressionImpl() - Method in interface org.epics.pvmanager.expression.DesiredRateExpression
-
The implementation of this expression.
- getDesiredRateExpressionImpl() - Method in class org.epics.pvmanager.expression.DesiredRateExpressionImpl
-
The implementation for this expression.
- getDesiredRateExpressionImpl() - Method in class org.epics.pvmanager.expression.DesiredRateReadWriteExpressionImpl
-
- getDesiredRateExpressions() - Method in interface org.epics.pvmanager.expression.DesiredRateExpressionList
-
The expressions of this list.
- getDesiredRateExpressions() - Method in class org.epics.pvmanager.expression.DesiredRateExpressionListImpl
-
- getDesiredRateExpressions() - Method in class org.epics.pvmanager.expression.DesiredRateReadWriteExpressionListImpl
-
- getDesiredRateReadWriteExpressions() - Method in interface org.epics.pvmanager.expression.DesiredRateReadWriteExpressionList
-
The expressions of this list.
- getDesiredRateReadWriteExpressions() - Method in class org.epics.pvmanager.expression.DesiredRateReadWriteExpressionListImpl
-
- getDisplay() - Method in interface org.epics.pvmanager.extra.DoubleArrayTimeCache
-
- getDisplay() - Method in class org.epics.pvmanager.extra.DoubleArrayTimeCacheFromVDoubleArray
-
- getDisplay() - Method in class org.epics.pvmanager.extra.DoubleArrayTimeCacheFromVDoubles
-
- getEnd() - Method in interface org.epics.pvmanager.extra.DoubleArrayTimeCache.Data
-
- getEnd() - Method in class org.epics.pvmanager.extra.DoubleArrayTimeCacheFromVDoubleArray.Data
-
- getEnd() - Method in class org.epics.pvmanager.extra.DoubleArrayTimeCacheFromVDoubles.Data
-
- getEnd() - Method in class org.epics.pvmanager.util.TimeInterval
-
Deprecated.
Final value of the interval.
- getEvent() - Method in class org.epics.pvmanager.jca.JCAMessagePayload
-
The event returned by the monitor.
- getExceptionHandler() - Method in class org.epics.pvmanager.DataRecipe
-
Returns the exception handler to be used for this PV.
- getFormat() - Method in interface org.epics.pvmanager.data.Display
-
Returns a NumberFormat that creates a String with just the value (no units).
- getFunction() - Method in interface org.epics.pvmanager.expression.DesiredRateExpression
-
The function that calculates this expression.
- getFunction() - Method in class org.epics.pvmanager.expression.DesiredRateExpressionImpl
-
The function that calculates new values for this expression.
- getFunction() - Method in class org.epics.pvmanager.expression.DesiredRateReadWriteExpressionImpl
-
- getFunction() - Method in interface org.epics.pvmanager.expression.SourceRateExpression
-
The function that calculates this expression.
- getFunction() - Method in class org.epics.pvmanager.expression.SourceRateExpressionImpl
-
- getFunction() - Method in class org.epics.pvmanager.expression.SourceRateReadWriteExpressionImpl
-
- getGrammarFileName() - Method in class org.epics.pvmanager.formula.FormulaLexer
-
- getGrammarFileName() - Method in class org.epics.pvmanager.formula.FormulaParser
-
- getHandler() - Method in class org.epics.pvmanager.ChannelHandlerReadSubscription
-
The handler to notify whenever an exception is thrown.
- getHeight() - Method in interface org.epics.pvmanager.data.VImage
-
Height of the image in pixels.
- getHeight() - Method in class org.epics.pvmanager.extra.WaterfallPlotParameters
-
The height of the plot in pixels.
- getIndex() - Method in interface org.epics.pvmanager.data.VEnum
-
Return the index of the value in the list of labels.
- getIndexes() - Method in interface org.epics.pvmanager.data.VEnumArray
-
Returns the indexes instead of the labels.
- getLabels() - Method in interface org.epics.pvmanager.data.Enum
-
All the possible labels.
- getLastMessagePayload() - Method in class org.epics.pvmanager.MultiplexedChannelHandler
-
The last processed message payload.
- getLowerAlarmLimit() - Method in interface org.epics.pvmanager.data.Display
-
Lowest value before the alarm region.
- getLowerCtrlLimit() - Method in interface org.epics.pvmanager.data.Display
-
Lowest possible value (included).
- getLowerDisplayLimit() - Method in interface org.epics.pvmanager.data.Display
-
Lowest possible value to be displayed.
- getLowerWarningLimit() - Method in interface org.epics.pvmanager.data.Display
-
Lowest value before the warning region.
- getMax() - Method in interface org.epics.pvmanager.data.Statistics
-
The maximum value.
- getMessage() - Method in interface org.epics.pvmanager.data.VExtendedAlarm
-
A human readable error message associated to the error(s).
- getMetadata() - Method in class org.epics.pvmanager.jca.JCAMessagePayload
-
The data taken with a GET at connection time.
- getMin() - Method in interface org.epics.pvmanager.data.Statistics
-
The minimum value.
- getMonitorMask() - Method in class org.epics.pvmanager.jca.JCADataSource
-
The monitor mask used for this data source.
- getName() - Method in interface org.epics.pvmanager.data.VExtendedAlarm.Condition
-
A short name for the alarm condition.
- getName() - Method in interface org.epics.pvmanager.expression.DesiredRateExpression
-
Name of this expression.
- getName() - Method in class org.epics.pvmanager.expression.DesiredRateExpressionImpl
-
The default name for a PV of this expression.
- getName() - Method in class org.epics.pvmanager.expression.DesiredRateReadWriteExpressionImpl
-
- getName() - Method in interface org.epics.pvmanager.expression.SourceRateExpression
-
Name of the expression.
- getName() - Method in class org.epics.pvmanager.expression.SourceRateExpressionImpl
-
- getName() - Method in class org.epics.pvmanager.expression.SourceRateReadWriteExpressionImpl
-
- getName() - Method in interface org.epics.pvmanager.expression.WriteExpression
-
Name of this expression.
- getName() - Method in class org.epics.pvmanager.expression.WriteExpressionImpl
-
Name representation of the expression.
- getName() - Method in class org.epics.pvmanager.PV
-
- getName() - Method in interface org.epics.pvmanager.PVReader
-
Returns the name of the PVReader.
- getNanoSec() - Method in class org.epics.pvmanager.util.TimeDuration
-
Deprecated.
Duration in nanoseconds.
- getNanoSec() - Method in class org.epics.pvmanager.util.TimeStamp
-
Deprecated.
Nanoseconds within the given second.
- getNArrays() - Method in interface org.epics.pvmanager.extra.DoubleArrayTimeCache.Data
-
- getNArrays() - Method in class org.epics.pvmanager.extra.DoubleArrayTimeCacheFromVDoubleArray.Data
-
- getNArrays() - Method in class org.epics.pvmanager.extra.DoubleArrayTimeCacheFromVDoubles.Data
-
- getNewValue() - Method in class org.epics.pvmanager.Notification
-
The value to be sent if the notification is needed.
- getNSamples() - Method in interface org.epics.pvmanager.data.Statistics
-
The number of samples.
- getNumberFormat() - Method in class org.epics.pvmanager.data.ValueFormat
-
Returns the NumberFormat used to format the numeric values.
- getParameters() - Method in class org.epics.pvmanager.extra.Parameters
-
- getParameters() - Method in class org.epics.pvmanager.extra.WaterfallPlot
-
Returns the full set of parameters currently being used.
- getPixelDuration() - Method in class org.epics.pvmanager.extra.WaterfallPlotParameters
-
Time interval for each line.
- getPrecedingChannels() - Method in class org.epics.pvmanager.WriteCache
-
Returns all the channels in the same buffer that should be written
before writing the channel for this cache.
- getProperties() - Method in class org.epics.pvmanager.ChannelHandler
-
Returns extra information about the channel, typically
useful for debugging.
- getPVField() - Method in interface org.epics.pvmanager.pva.PVATypeConverter
-
The introspection information for the pvData serialization for this
type factory.
- getReadScannerExecutorService() - Static method in class org.epics.pvmanager.PVManager
-
Returns the executor service used to schedule and run the
periodic reading scan for new values.
- getReadSubscription() - Method in class org.epics.pvmanager.ChannelRecipe
-
- getReadUsageCounter() - Method in class org.epics.pvmanager.ChannelHandler
-
Returns how many read PVs are open on this channel.
- getReadUsageCounter() - Method in class org.epics.pvmanager.MultiplexedChannelHandler
-
Returns how many read PVs are open on this channel.
- getRowCount() - Method in interface org.epics.pvmanager.data.VTable
-
The number of rows in the table.
- getSec() - Method in class org.epics.pvmanager.util.TimeStamp
-
Deprecated.
Unix time; seconds from midnight 1/1/1970.
- getSeverity() - Method in interface org.epics.pvmanager.data.VExtendedAlarm.Condition
-
The severity associated with the alarm.
- getSizes() - Method in interface org.epics.pvmanager.data.Array
-
- getSourceRateExpressionImpl() - Method in interface org.epics.pvmanager.expression.SourceRateExpression
-
The implementation of this expression.
- getSourceRateExpressionImpl() - Method in class org.epics.pvmanager.expression.SourceRateExpressionImpl
-
- getSourceRateExpressionImpl() - Method in class org.epics.pvmanager.expression.SourceRateReadWriteExpressionImpl
-
- getSourceRateExpressions() - Method in interface org.epics.pvmanager.expression.SourceRateExpressionList
-
The expressions of this list.
- getSourceRateExpressions() - Method in class org.epics.pvmanager.expression.SourceRateExpressionListImpl
-
- getSourceRateExpressions() - Method in class org.epics.pvmanager.expression.SourceRateReadWriteExpressionListImpl
-
- getSourceRateReadWriteExpressions() - Method in interface org.epics.pvmanager.expression.SourceRateReadWriteExpressionList
-
The expressions of this list.
- getSourceRateReadWriteExpressions() - Method in class org.epics.pvmanager.expression.SourceRateReadWriteExpressionListImpl
-
- getStart() - Method in class org.epics.pvmanager.util.TimeInterval
-
Deprecated.
Initial value of the interval.
- getStdDev() - Method in interface org.epics.pvmanager.data.Statistics
-
The standard deviation.
- getSubscriptionParameter(ValueCache<?>, ConnectionPayload) - Method in interface org.epics.pvmanager.DataSourceTypeAdapter
-
The parameters required to open a monitor for the channel.
- getSubscriptionParameter(ValueCache, Channel) - Method in class org.epics.pvmanager.jca.JCATypeAdapter
-
- getTimeStamp() - Method in interface org.epics.pvmanager.data.Time
-
- getTimestamp() - Method in interface org.epics.pvmanager.data.Time
-
The timestamp of the value, typically indicating when it was
generated.
- getTimestamp(int) - Method in interface org.epics.pvmanager.extra.DoubleArrayTimeCache.Data
-
- getTimestamp(int) - Method in class org.epics.pvmanager.extra.DoubleArrayTimeCacheFromVDoubleArray.Data
-
- getTimestamp(int) - Method in class org.epics.pvmanager.extra.DoubleArrayTimeCacheFromVDoubles.Data
-
- getTimeUserTag() - Method in interface org.epics.pvmanager.data.Time
-
Returns a user defined tag, that can be used to store extra
time information, such as beam shot.
- getTimeZone() - Method in class org.epics.pvmanager.util.TimeStampFormat
-
Deprecated.
Returns the time zone used to format the timestamp.
- getTokenNames() - Method in class org.epics.pvmanager.formula.FormulaParser
-
- getType() - Method in class org.epics.pvmanager.TypeSupport
-
Defines on which class the support is defined.
- getType() - Method in class org.epics.pvmanager.ValueCache
-
The type of objects that this cache can contain.
- getTypeSupportFamily() - Method in class org.epics.pvmanager.TypeSupport
-
Defines which type of support is implementing, notification or time.
- getUnits() - Method in interface org.epics.pvmanager.data.Display
-
String representation of the units using for all values.
- getUpperAlarmLimit() - Method in interface org.epics.pvmanager.data.Display
-
Highest value before the alarm region.
- getUpperCtrlLimit() - Method in interface org.epics.pvmanager.data.Display
-
Highest possible value (included).
- getUpperDisplayLimit() - Method in interface org.epics.pvmanager.data.Display
-
Highest possible value to be displayed.
- getUpperWarningLimit() - Method in interface org.epics.pvmanager.data.Display
-
Highest value before the warning region.
- getUsageCounter() - Method in class org.epics.pvmanager.ChannelHandler
-
Returns how many read or write PVs are open on
this channel.
- getUsageCounter() - Method in class org.epics.pvmanager.MultiplexedChannelHandler
-
Returns how many read or write PVs are open on
this channel.
- getValue() - Method in class org.epics.pvmanager.Aggregator
-
- getValue() - Method in class org.epics.pvmanager.Collector
-
Returns all values since last check and removes values from the queue.
- getValue() - Method in interface org.epics.pvmanager.data.Scalar
-
Returns the value.
- getValue() - Method in interface org.epics.pvmanager.data.VDouble
-
Returns the value.
- getValue() - Method in interface org.epics.pvmanager.data.VEnum
-
Returns the value.
- getValue() - Method in interface org.epics.pvmanager.data.VInt
-
Returns the value.
- getValue() - Method in interface org.epics.pvmanager.data.VNumber
-
The numeric value.
- getValue() - Method in interface org.epics.pvmanager.data.VString
-
Returns the value.
- getValue() - Method in class org.epics.pvmanager.Function
-
Calculates, if needed, and then returns the value for this function.
- getValue() - Method in class org.epics.pvmanager.PV
-
- getValue() - Method in interface org.epics.pvmanager.PVReader
-
Returns the value of the PVReader.
- getValue() - Method in class org.epics.pvmanager.ValueCache
-
Returns the value in the cache.
- getValue() - Method in class org.epics.pvmanager.WriteCache
-
Returns the value in the cache.
- getValues() - Method in interface org.epics.pvmanager.data.MultiScalar
-
The list of values for all the different channels.
- getValueType() - Method in interface org.epics.pvmanager.pva.PVATypeConverter
-
The normative type for this type factory.
- getWidth() - Method in interface org.epics.pvmanager.data.VImage
-
Width of the image in pixels.
- getWriteCaches() - Method in class org.epics.pvmanager.WriteBuffer
-
Returns the write caches used by this buffer.
- getWriteExpressionImpl() - Method in class org.epics.pvmanager.expression.DesiredRateReadWriteExpressionImpl
-
- getWriteExpressionImpl() - Method in class org.epics.pvmanager.expression.SourceRateReadWriteExpressionImpl
-
- getWriteExpressionImpl() - Method in interface org.epics.pvmanager.expression.WriteExpression
-
The implementation of this expression.
- getWriteExpressionImpl() - Method in class org.epics.pvmanager.expression.WriteExpressionImpl
-
- getWriteExpressions() - Method in class org.epics.pvmanager.expression.DesiredRateReadWriteExpressionListImpl
-
- getWriteExpressions() - Method in class org.epics.pvmanager.expression.SourceRateReadWriteExpressionListImpl
-
- getWriteExpressions() - Method in interface org.epics.pvmanager.expression.WriteExpressionList
-
The expressions of this list.
- getWriteExpressions() - Method in class org.epics.pvmanager.expression.WriteExpressionListImpl
-
- getWriteFunction() - Method in class org.epics.pvmanager.expression.DesiredRateReadWriteExpressionImpl
-
- getWriteFunction() - Method in class org.epics.pvmanager.expression.SourceRateReadWriteExpressionImpl
-
- getWriteFunction() - Method in interface org.epics.pvmanager.expression.WriteExpression
-
The function that implements this expression.
- getWriteFunction() - Method in class org.epics.pvmanager.expression.WriteExpressionImpl
-
Returns the function represented by this expression.
- getWriteUsageCounter() - Method in class org.epics.pvmanager.ChannelHandler
-
Returns how many write PVs are open on this channel.
- getWriteUsageCounter() - Method in class org.epics.pvmanager.MultiplexedChannelHandler
-
Returns how many write PVs are open on this channel.
- group() - Static method in class org.epics.pvmanager.extra.ExpressionLanguage
-
Creates a group of dynamically managed expressions.
- namedPool(String) - Static method in class org.epics.pvmanager.util.Executors
-
A thread factory where each new thread starts with the given name.
- nanos(long) - Static method in class org.epics.pvmanager.util.TimeDuration
-
Deprecated.
A new duration in nanoseconds.
- newAlarm(AlarmSeverity, AlarmStatus) - Static method in class org.epics.pvmanager.data.ValueFactory
-
New alarm with the given severity and status.
- newAlarm(Number, Display) - Static method in class org.epics.pvmanager.data.ValueFactory
-
Alarm based on the value and the display ranges.
- newData(Timestamp, Timestamp, Timestamp, Timestamp) - Method in interface org.epics.pvmanager.extra.DoubleArrayTimeCache
-
Each segment of the new data ends with an array of old data.
- newData(Timestamp, Timestamp, Timestamp, Timestamp) - Method in class org.epics.pvmanager.extra.DoubleArrayTimeCacheFromVDoubleArray
-
- newData(Timestamp, Timestamp, Timestamp, Timestamp) - Method in class org.epics.pvmanager.extra.DoubleArrayTimeCacheFromVDoubles
-
- newDisplay(Double, Double, Double, String, NumberFormat, Double, Double, Double, Double, Double) - Static method in class org.epics.pvmanager.data.ValueFactory
-
Creates a new display
- newEInt(Integer, AlarmSeverity, AlarmStatus, TimeStamp, Integer, Double, Double, Double, String, NumberFormat, Double, Double, Double, Double, Double) - Static method in class org.epics.pvmanager.data.ValueFactory
-
- newEInt(Integer, AlarmSeverity, AlarmStatus, Integer, TimeStamp, VInt) - Static method in class org.epics.pvmanager.data.ValueFactory
-
- newTime(Timestamp, Integer, boolean) - Static method in class org.epics.pvmanager.data.ValueFactory
-
Creates a new time.
- newTime(Timestamp) - Static method in class org.epics.pvmanager.data.ValueFactory
-
New time, with no user tag and valid data.
- newValuesOf(SourceRateExpressionList<T>) - Static method in class org.epics.pvmanager.ExpressionLanguage
-
Returns all the new values generated by the expression source rate.
- newValuesOf(SourceRateExpression<T>) - Static method in class org.epics.pvmanager.ExpressionLanguage
-
Returns all the new values generated by the expression source rate.
- newValuesOf(SourceRateExpression<T>, int) - Static method in class org.epics.pvmanager.ExpressionLanguage
-
Returns up to maxValues new values generated by the expression source rate.
- newVDouble(Double, Alarm, Time, Display) - Static method in class org.epics.pvmanager.data.ValueFactory
-
Creates a new VDouble.
- newVDouble(Double, AlarmSeverity, AlarmStatus, TimeStamp, Integer, Double, Double, Double, String, NumberFormat, Double, Double, Double, Double, Double) - Static method in class org.epics.pvmanager.data.ValueFactory
-
Deprecated.
- newVDouble(Double, AlarmSeverity, AlarmStatus, Integer, TimeStamp, Display) - Static method in class org.epics.pvmanager.data.ValueFactory
-
Deprecated.
- newVDouble(double, TimeStamp, Display) - Static method in class org.epics.pvmanager.data.ValueFactory
-
Deprecated.
- newVDouble(Double, Time, Display) - Static method in class org.epics.pvmanager.data.ValueFactory
-
Creates a new VDouble using the given value, time, display and
generating the alarm from the value and display information.
- newVDouble(double, Display) - Static method in class org.epics.pvmanager.data.ValueFactory
-
Deprecated.
- newVDouble(Double, Display) - Static method in class org.epics.pvmanager.data.ValueFactory
-
Creates new immutable VDouble by using metadata from the old value,
now as timestamp and computing alarm from the metadata range.
- newVDouble(Double) - Static method in class org.epics.pvmanager.data.ValueFactory
-
Creates a new VDouble, no alarm, time now, no display.
- newVDouble(Double, Time) - Static method in class org.epics.pvmanager.data.ValueFactory
-
Creates a new VDouble, no alarm, no display.
- newVDoubleArray(double[], List<Integer>, Alarm, Time, Display) - Static method in class org.epics.pvmanager.data.ValueFactory
-
Creates a new VDoubleArray.
- newVDoubleArray(double[], Alarm, Time, Display) - Static method in class org.epics.pvmanager.data.ValueFactory
-
Creates a new VDoubleArray.
- newVDoubleArray(ListDouble, Alarm, Time, Display) - Static method in class org.epics.pvmanager.data.ValueFactory
-
Creates a new VDoubleArray.
- newVDoubleArray(double[], Display) - Static method in class org.epics.pvmanager.data.ValueFactory
-
Creates a new VDoubleArray.
- newVDoubleArray(double[], List<Integer>, AlarmSeverity, AlarmStatus, TimeStamp, Integer, Double, Double, Double, String, NumberFormat, Double, Double, Double, Double, Double) - Static method in class org.epics.pvmanager.data.ValueFactory
-
Deprecated.
- newVImage(int, int, byte[]) - Static method in class org.epics.pvmanager.data.ValueFactory
-
- newVInt(Integer, AlarmSeverity, AlarmStatus, TimeStamp, Integer, Double, Double, Double, String, NumberFormat, Double, Double, Double, Double, Double) - Static method in class org.epics.pvmanager.data.ValueFactory
-
Deprecated.
- newVInt(Integer, Alarm, Time, Display) - Static method in class org.epics.pvmanager.data.ValueFactory
-
Creates a new VInt.
- newVIntArray(int[], List<Integer>, Alarm, Time, Display) - Static method in class org.epics.pvmanager.data.ValueFactory
-
- newVIntArray(int[], Alarm, Time, Display) - Static method in class org.epics.pvmanager.data.ValueFactory
-
- newVIntArray(ListInt, Alarm, Time, Display) - Static method in class org.epics.pvmanager.data.ValueFactory
-
- newVIntArray(int[], Display) - Static method in class org.epics.pvmanager.data.ValueFactory
-
- newVMultiDouble(List<VDouble>, AlarmSeverity, AlarmStatus, TimeStamp, Integer, Double, Double, Double, Double, String, NumberFormat, Double, Double, Double, Double) - Static method in class org.epics.pvmanager.data.ValueFactory
-
Deprecated.
- newVMultiDouble(List<VDouble>, Alarm, Time, Display) - Static method in class org.epics.pvmanager.data.ValueFactory
-
Creates a new VMultiDouble.
- newVStatistics(double, double, double, double, int, AlarmSeverity, AlarmStatus, TimeStamp, Integer, Double, Double, Double, String, NumberFormat, Double, Double, Double, Double, Double) - Static method in class org.epics.pvmanager.data.ValueFactory
-
Deprecated.
- newVStatistics(double, double, double, double, int, Alarm, Time, Display) - Static method in class org.epics.pvmanager.data.ValueFactory
-
Creates a new VStatistics.
- newVString(String, AlarmSeverity, AlarmStatus, TimeStamp, Integer) - Static method in class org.epics.pvmanager.data.ValueFactory
-
Deprecated.
- newVString(String, Alarm, Time) - Static method in class org.epics.pvmanager.data.ValueFactory
-
Creates a new VString.
- noInterpolation() - Static method in class org.epics.pvmanager.extra.Interpolations
-
- Noise - Class in org.epics.pvmanager.sim
-
Function to simulate a signal that has a uniform distribution.
- Noise() - Constructor for class org.epics.pvmanager.sim.Noise
-
Creates a signal uniformly distributed between -5.0 and 5.0, updating
every 100ms (10Hz).
- Noise(Double, Double, Double, Double) - Constructor for class org.epics.pvmanager.sim.Noise
-
Do not use: only provided to provide some sort of error message
for people migrating from utility.pv.
- Noise(Double, Double, Double) - Constructor for class org.epics.pvmanager.sim.Noise
-
Creates a signal uniformly distributed between min and max, updating
every interval seconds.
- NoiseWaveform - Class in org.epics.pvmanager.sim
-
Function to simulate a waveform containing a uniformly distributed
random data.
- NoiseWaveform() - Constructor for class org.epics.pvmanager.sim.NoiseWaveform
-
Creates a waveform with samples from a uniform distribution from -5 to 5,
updating every second.
- NoiseWaveform(Double, Double, Double) - Constructor for class org.epics.pvmanager.sim.NoiseWaveform
-
Creates a gaussian waveform signal with a gaussian distribution, updating at the rate
specified.
- NoiseWaveform(Double, Double, Double, Double) - Constructor for class org.epics.pvmanager.sim.NoiseWaveform
-
Creates a gaussian waveform signal with a gaussian distribution, updating at the rate
specified.
- normalize(Number, Display) - Static method in class org.epics.pvmanager.data.ValueUtil
-
Normalizes the given value according to the given display information.
- normalize(Number, Number, Number) - Static method in class org.epics.pvmanager.data.ValueUtil
-
Normalizes the given value according to the given range;
- normalizedNumericValueOf(Object) - Static method in class org.epics.pvmanager.data.ValueUtil
-
Extracts the numericValueOf the object and normalizes according
to the display range.
- Notification<T> - Class in org.epics.pvmanager
-
Used by
NotificationSupport
to communicate whether a new notification
is needed, and what should be the type to be notified.
- Notification(boolean, T) - Constructor for class org.epics.pvmanager.Notification
-
Creates a new notification.
- notification(T, T) - Static method in class org.epics.pvmanager.NotificationSupport
-
Returns the final value by using the appropriate type support.
- NotificationSupport<T> - Class in org.epics.pvmanager
-
Dedicated notification type support.
- NotificationSupport(Class<T>) - Constructor for class org.epics.pvmanager.NotificationSupport
-
Creates a new notification type support.
- notifyOn(Executor) - Method in class org.epics.pvmanager.PVConfiguration
-
- notifyOn(Executor) - Method in class org.epics.pvmanager.PVReaderConfiguration
-
- notifyOn(Executor) - Method in class org.epics.pvmanager.PVWriterConfiguration
-
- now() - Static method in class org.epics.pvmanager.util.TimeStamp
-
Deprecated.
Returns a new timestamp for the current instant.
- NullUtils - Class in org.epics.pvmanager.util
-
Utility class to handle null values.
- NullUtils() - Constructor for class org.epics.pvmanager.util.NullUtils
-
- NumberFormats - Class in org.epics.pvmanager.util
-
NumberFormat factory.
- NumberFormats() - Constructor for class org.epics.pvmanager.util.NumberFormats
-
- numericLiteral() - Method in class org.epics.pvmanager.formula.FormulaParser
-
- numericValueOf(Object) - Static method in class org.epics.pvmanager.data.ValueUtil
-
Extracts a numeric value for the object.
- Ramp - Class in org.epics.pvmanager.sim
-
Function to simulate a signal that increases constantly within a range
(saw-tooth shape).
- Ramp(Double, Double, Double, Double) - Constructor for class org.epics.pvmanager.sim.Ramp
-
Creates a ramp shaped signal between min and max, updating a step amount
every interval seconds.
- Ramp(Double, Double, Double) - Constructor for class org.epics.pvmanager.sim.Ramp
-
Creates a ramp shaped signal between min and max, incrementing 1
every interval seconds.
- Ramp() - Constructor for class org.epics.pvmanager.sim.Ramp
-
Creates a ramp shaped signal between -5 and +5, incrementing 1 every second.
- read(SourceRateExpression<T>) - Static method in class org.epics.pvmanager.PVManager
-
Reads the given expression, and returns an object to configure the parameters
for the read.
- read(DesiredRateExpression<T>) - Static method in class org.epics.pvmanager.PVManager
-
Reads the given expression, and returns an object to configure the parameters
for the read.
- readAndWrite(SourceRateReadWriteExpression<R, W>) - Static method in class org.epics.pvmanager.PVManager
-
Both reads and writes the given expression, and returns an object to configure the parameters
for the both read and write.
- readAndWrite(DesiredRateReadWriteExpression<R, W>) - Static method in class org.epics.pvmanager.PVManager
-
Both reads and writes the given expression, and returns an object to configure the parameters
for the both read and write.
- ReadFailException - Exception in org.epics.pvmanager
-
Exception thrown when a
PVReader
is trying to read a channel or
data source that cannot be read from.
- ReadFailException() - Constructor for exception org.epics.pvmanager.ReadFailException
-
- remove(int) - Method in class org.epics.pvmanager.extra.DynamicGroup
-
Removes the expression at the given location.
- removeMonitor(Collector<?>) - Method in class org.epics.pvmanager.ChannelHandler
-
Used by the data source to remove a read request.
- removeMonitor(Collector<?>) - Method in class org.epics.pvmanager.MultiplexedChannelHandler
-
Used by the data source to remove a read request.
- removePVReaderListener(PVReaderListener) - Method in class org.epics.pvmanager.PV
-
- removePVReaderListener(PVReaderListener) - Method in interface org.epics.pvmanager.PVReader
-
Removes a listener to the value.
- removePVWriterListener(PVWriterListener) - Method in class org.epics.pvmanager.PV
-
- removePVWriterListener(PVWriterListener) - Method in interface org.epics.pvmanager.PVWriter
-
Removes a listener to the value.
- removeWrite(WriteCache<?>, ExceptionHandler) - Method in class org.epics.pvmanager.ChannelHandler
-
Used by the data source to conclude writes to the channel managed by this handler.
- removeWrite(WriteCache<?>, ExceptionHandler) - Method in class org.epics.pvmanager.MultiplexedChannelHandler
-
Used by the data source to conclude writes to the channel managed by this handler.
- Replay - Class in org.epics.pvmanager.sim
-
Function that reads an xml file and simulates a pv by replaying it.
- Replay(String) - Constructor for class org.epics.pvmanager.sim.Replay
-
The URI of the file.
- reportExceptionToAllReadersAndWriters(Exception) - Method in class org.epics.pvmanager.MultiplexedChannelHandler
-
Notifies all readers and writers of an error condition.
- resultOf(ExpressionLanguage.OneArgFunction<R, A>, DesiredRateExpression<A>) - Static method in class org.epics.pvmanager.ExpressionLanguage
-
An expression that represents the result of a user provided function.
- resultOf(ExpressionLanguage.TwoArgFunction<R, A1, A2>, DesiredRateExpression<? extends A1>, DesiredRateExpression<? extends A2>) - Static method in class org.epics.pvmanager.ExpressionLanguage
-
An expression that represents the result of a user provided function.
- resultOf(ExpressionLanguage.TwoArgFunction<R, A1, A2>, DesiredRateExpression<? extends A1>, DesiredRateExpression<? extends A2>, String) - Static method in class org.epics.pvmanager.ExpressionLanguage
-
An expression that represents the result of a user provided function.
- routeExceptionsTo(ExceptionHandler) - Method in class org.epics.pvmanager.PVConfiguration
-
Forwards exception to the given exception handler.
- routeExceptionsTo(ExceptionHandler) - Method in class org.epics.pvmanager.PVReaderConfiguration
-
Forwards exception to the given exception handler.
- routeExceptionsTo(ExceptionHandler) - Method in class org.epics.pvmanager.PVWriterConfiguration
-
Forwards exception to the given exception handler.
- Scalar - Interface in org.epics.pvmanager.data
-
Basic type definition for all scalar types.
- scrollDown(boolean) - Static method in class org.epics.pvmanager.extra.WaterfallPlotParameters
-
Whether the plot should scroll down or up.
- sec(double) - Static method in class org.epics.pvmanager.util.TimeDuration
-
Deprecated.
A new duration in seconds.
- set(int, DesiredRateExpression<?>) - Method in class org.epics.pvmanager.extra.DynamicGroup
-
Changes the expression to the given location.
- setAsyncWriteExecutor(ScheduledExecutorService) - Static method in class org.epics.pvmanager.PVManager
-
Changes the executor used for the asynchronous write calls.
- setDefaultDataSource(String) - Method in class org.epics.pvmanager.CompositeDataSource
-
Sets the data source to be used if the channel does not specify
one explicitely.
- setDefaultDataSource(DataSource) - Static method in class org.epics.pvmanager.PVManager
-
Changes the default source for data.
- setDefaultNotificationExecutor(Executor) - Static method in class org.epics.pvmanager.PVManager
-
Changes the default executor on which all notifications are going to be posted.
- setDelimiter(String) - Method in class org.epics.pvmanager.CompositeDataSource
-
Changes the data source delimiter.
- setNumberFormat(NumberFormat) - Method in class org.epics.pvmanager.data.ValueFormat
-
Changes the NumberFormat used to format the numeric values.
- setPaused(boolean) - Method in class org.epics.pvmanager.PV
-
- setPaused(boolean) - Method in interface org.epics.pvmanager.PVReader
-
Pauses or resumes the reader notifications.
- setPrecedingChannels(List<String>) - Method in class org.epics.pvmanager.WriteCache
-
Changes which channels need to be written before the channel
for this cache can be written.
- setReadScannerExecutorService(ScheduledExecutorService) - Static method in class org.epics.pvmanager.PVManager
-
Changes the executor service to use for executing the periodic read
scan.
- setTimeZome(TimeZone) - Method in class org.epics.pvmanager.util.TimeStampFormat
-
Deprecated.
Changes the time zone used to format the timestamp.
- setValue(Object) - Method in class org.epics.pvmanager.ValueCache
-
Changes the value in the cache.
- setValue(T) - Method in class org.epics.pvmanager.WriteCache
-
Changes the value in the cache.
- setValue(A) - Method in class org.epics.pvmanager.WriteFunction
-
Takes the value and consumes it.
- SimpleValueFormat - Class in org.epics.pvmanager.data
-
Default implementation for formatting.
- SimpleValueFormat(int) - Constructor for class org.epics.pvmanager.data.SimpleValueFormat
-
Formats any scalar and array, by using the server side formatting
and limiting the elements of the array displayed to maxElements.
- simulatedData() - Static method in class org.epics.pvmanager.sim.SimulationDataSource
-
Data source instance.
- SimulationDataSource - Class in org.epics.pvmanager.sim
-
Data source to produce simulated signals that can be using during development
and testing.
- SimulationDataSource() - Constructor for class org.epics.pvmanager.sim.SimulationDataSource
-
- Sine - Class in org.epics.pvmanager.sim
-
Function to simulate a signal shaped like a sine.
- Sine(Double, Double, Double, Double) - Constructor for class org.epics.pvmanager.sim.Sine
-
Creates a sine shaped signal between min and max, updating
every interval seconds with samplesPerCycles samples every full sine cycle.
- Sine(Double, Double, Double) - Constructor for class org.epics.pvmanager.sim.Sine
-
Creates a sine shaped signal between min and max, updating
every interval seconds with 10 samples every full sine cycle.
- Sine() - Constructor for class org.epics.pvmanager.sim.Sine
-
Creates a sine shaped signal between -5 and 5, updating
every second with 10 samples every full sine cycle.
- singleRangeGradient(Color, Color) - Static method in class org.epics.pvmanager.extra.ColorScheme
-
A simple color scheme that uses only one gradient for the whole
display range.
- singleRangeGradient(Color, Color, Color) - Static method in class org.epics.pvmanager.extra.ColorScheme
-
- size() - Method in class org.epics.pvmanager.extra.DynamicGroup
-
Returns the number of expressions in the group.
- SourceRateExpression<R> - Interface in org.epics.pvmanager.expression
-
An expression to read at the rate of the source.
- SourceRateExpressionImpl<R> - Class in org.epics.pvmanager.expression
-
- SourceRateExpressionImpl(String, Class<R>) - Constructor for class org.epics.pvmanager.expression.SourceRateExpressionImpl
-
Constructor that represents a single pv of a particular type.
- SourceRateExpressionImpl(SourceRateExpressionList<?>, Function<R>, String) - Constructor for class org.epics.pvmanager.expression.SourceRateExpressionImpl
-
Creates a new source rate expression.
- SourceRateExpressionList<R> - Interface in org.epics.pvmanager.expression
-
A list of expressions to read at the rate of the source.
- SourceRateExpressionListImpl<R> - Class in org.epics.pvmanager.expression
-
- SourceRateExpressionListImpl() - Constructor for class org.epics.pvmanager.expression.SourceRateExpressionListImpl
-
Creates a new empty expression list.
- SourceRateReadWriteExpression<R,W> - Interface in org.epics.pvmanager.expression
-
An expression to write and to read at the rate of the source.
- SourceRateReadWriteExpressionImpl<R,W> - Class in org.epics.pvmanager.expression
-
- SourceRateReadWriteExpressionImpl(SourceRateExpression<R>, WriteExpression<W>) - Constructor for class org.epics.pvmanager.expression.SourceRateReadWriteExpressionImpl
-
Creates an expression that can be both read and written.
- SourceRateReadWriteExpressionList<R,W> - Interface in org.epics.pvmanager.expression
-
A list of expressions to write and to read at the rate of the source.
- SourceRateReadWriteExpressionListImpl<R,W> - Class in org.epics.pvmanager.expression
-
- SourceRateReadWriteExpressionListImpl() - Constructor for class org.epics.pvmanager.expression.SourceRateReadWriteExpressionListImpl
-
- Statistics - Interface in org.epics.pvmanager.data
-
Basic type for statistical information of numeric types.
- statisticsOf(SourceRateExpression<VDouble>) - Static method in class org.epics.pvmanager.data.ExpressionLanguage
-
Aggregates the sample at the scan rate and calculates statistical information.
- statisticsOf(SourceRateExpressionList<VDouble>) - Static method in class org.epics.pvmanager.data.ExpressionLanguage
-
- STRING - Static variable in class org.epics.pvmanager.formula.FormulaLexer
-
- STRING - Static variable in class org.epics.pvmanager.formula.FormulaParser
-
- stringLiteral() - Method in class org.epics.pvmanager.formula.FormulaParser
-
- Strings - Class in org.epics.pvmanager.sim
-
Function to simulate a signal that generates Strings.
- Strings() - Constructor for class org.epics.pvmanager.sim.Strings
-
Creates a signal uniformly distributed between -5.0 and 5.0, updating
every 100ms (10Hz).
- Strings(Double) - Constructor for class org.epics.pvmanager.sim.Strings
-
Creates a signal uniformly distributed between min and max, updating
every interval seconds.
- swingEDT() - Static method in class org.epics.pvmanager.util.Executors
-
Executes tasks on the Swing Event Dispatch Thread using
SwingUtilities.invokeLater().
- sync() - Method in class org.epics.pvmanager.PVWriterConfiguration
-
- synchronizedArrayOf(TimeDuration, SourceRateExpressionList<VDouble>) - Static method in class org.epics.pvmanager.data.ExpressionLanguage
-
A synchronized array from the given expression.
- synchronizedArrayOf(TimeDuration, TimeDuration, SourceRateExpressionList<VDouble>) - Static method in class org.epics.pvmanager.data.ExpressionLanguage
-
A synchronized array from the given expression.
- synchronizedArrayOf(TimeDuration, SourceRateExpressionList<VDouble>) - Static method in class org.epics.pvmanager.data.ExpressionLanguage
-
- synchronizedArrayOf(TimeDuration, TimeDuration, SourceRateExpressionList<VDouble>) - Static method in class org.epics.pvmanager.data.ExpressionLanguage
-
- synchWriteAndMaxReadRate(TimeDuration) - Method in class org.epics.pvmanager.PVConfiguration
-
Creates the pv such that writes are synchronous and read notifications
comes at most at the rate specified.
- synchWriteAndReadEvery(TimeDuration) - Method in class org.epics.pvmanager.PVConfiguration
-
Deprecated.
- T__15 - Static variable in class org.epics.pvmanager.formula.FormulaLexer
-
- T__15 - Static variable in class org.epics.pvmanager.formula.FormulaParser
-
- T__16 - Static variable in class org.epics.pvmanager.formula.FormulaLexer
-
- T__16 - Static variable in class org.epics.pvmanager.formula.FormulaParser
-
- T__17 - Static variable in class org.epics.pvmanager.formula.FormulaLexer
-
- T__17 - Static variable in class org.epics.pvmanager.formula.FormulaParser
-
- T__18 - Static variable in class org.epics.pvmanager.formula.FormulaLexer
-
- T__18 - Static variable in class org.epics.pvmanager.formula.FormulaParser
-
- T__19 - Static variable in class org.epics.pvmanager.formula.FormulaLexer
-
- T__19 - Static variable in class org.epics.pvmanager.formula.FormulaParser
-
- T__20 - Static variable in class org.epics.pvmanager.formula.FormulaLexer
-
- T__20 - Static variable in class org.epics.pvmanager.formula.FormulaParser
-
- T__21 - Static variable in class org.epics.pvmanager.formula.FormulaLexer
-
- T__21 - Static variable in class org.epics.pvmanager.formula.FormulaParser
-
- TestDataSource - Class in org.epics.pvmanager.test
-
Data source for testing, error conditions in particular.
- TestDataSource() - Constructor for class org.epics.pvmanager.test.TestDataSource
-
Creates a new data source.
- Time - Interface in org.epics.pvmanager.data
-
Time information.
- time(long, int) - Static method in class org.epics.pvmanager.util.TimeStamp
-
Deprecated.
Returns a new timestamp from UNIX time.
- timeComparator() - Static method in class org.epics.pvmanager.data.ValueUtil
-
Returns a comparator with the order defined by the timestamp.
- timedCacheOf(SourceRateExpression<T>, TimeDuration) - Static method in class org.epics.pvmanager.ExpressionLanguage
-
Returns all the values starting the latest value and older up to
the time different given by the interval.
- timedCacheOf(SourceRateExpression<T>, TimeDuration) - Static method in class org.epics.pvmanager.ExpressionLanguage
-
Returns all the values starting the latest value and older up to
the time different given by the interval.
- TimeDuration - Class in org.epics.pvmanager.util
-
Deprecated.
This class is being retired in favor of TimeDuration
- TimeInterval - Class in org.epics.pvmanager.util
-
Deprecated.
This class is being retired in favor of TimeInterval
- timeNow() - Static method in class org.epics.pvmanager.data.ValueFactory
-
New time with the current timestamp, no user tag and valid data.
- timeOf(Object) - Static method in class org.epics.pvmanager.data.ValueUtil
-
Extracts the time information if present.
- timeout(TimeDuration) - Method in class org.epics.pvmanager.PVConfiguration
-
- timeout(TimeDuration, String) - Method in class org.epics.pvmanager.PVConfiguration
-
- timeout(TimeDuration) - Method in class org.epics.pvmanager.PVConfiguration
-
Deprecated.
- timeout(TimeDuration, String) - Method in class org.epics.pvmanager.PVConfiguration
-
Deprecated.
- timeout(TimeDuration, String, String) - Method in class org.epics.pvmanager.PVConfiguration
-
Specifies a timeout, with a different message for the read and the write.
- timeout(TimeDuration) - Method in class org.epics.pvmanager.PVReaderConfiguration
-
- timeout(TimeDuration, String) - Method in class org.epics.pvmanager.PVReaderConfiguration
-
- timeout(TimeDuration) - Method in class org.epics.pvmanager.PVReaderConfiguration
-
Deprecated.
- timeout(TimeDuration, String) - Method in class org.epics.pvmanager.PVReaderConfiguration
-
Deprecated.
- timeout(TimeDuration) - Method in class org.epics.pvmanager.PVWriterConfiguration
-
- timeout(TimeDuration, String) - Method in class org.epics.pvmanager.PVWriterConfiguration
-
- timeout(TimeDuration) - Method in class org.epics.pvmanager.PVWriterConfiguration
-
Deprecated.
- timeout(TimeDuration, String) - Method in class org.epics.pvmanager.PVWriterConfiguration
-
Deprecated.
- TimeoutException - Exception in org.epics.pvmanager
-
- TimeStamp - Class in org.epics.pvmanager.util
-
Deprecated.
This class is being retired in favor of Timestamp
- TimeStampFormat - Class in org.epics.pvmanager.util
-
Deprecated.
This class is being retired in favor of TimestampFormat
- TimeStampFormat() - Constructor for class org.epics.pvmanager.util.TimeStampFormat
-
Deprecated.
Creates a new TimeStampFormat using the current Locale.
- TimeStampFormat(String) - Constructor for class org.epics.pvmanager.util.TimeStampFormat
-
Deprecated.
Creates a new TimeStampFormat using the given pattern and the symbols
from the current Locale.
- TimeStampFormat(String, DateFormatSymbols) - Constructor for class org.epics.pvmanager.util.TimeStampFormat
-
Deprecated.
Creates a new TimeStampFormat using the given pattern and symbols.
- TimeStampFormat(String, Locale) - Constructor for class org.epics.pvmanager.util.TimeStampFormat
-
Deprecated.
Creates a new TimeStampFormat using the given pattern and the symbols
from the current Locale.
- timestampOf(T) - Static method in class org.epics.pvmanager.TimeSupport
-
Deprecated.
Extracts the TimeStamp of the value using the appropriate type support.
- timestampOf(Date) - Static method in class org.epics.pvmanager.util.TimeStamp
-
Deprecated.
Converts a
Date
to a timestamp.
- timestampOf(Timestamp) - Static method in class org.epics.pvmanager.util.TimeStamp
-
Deprecated.
- TimeSupport<T> - Class in org.epics.pvmanager
-
Deprecated.
generic type support is being removed: was too intrusive and little used.
being replaced by used of generic function that expect T extends Time.
- TimeSupport(Class<T>) - Constructor for class org.epics.pvmanager.TimeSupport
-
Deprecated.
Creates a new support for extracting time information from the given
class.
- toImage(VImage) - Static method in class org.epics.pvmanager.data.ValueUtil
-
Converts a VImage to an AWT BufferedImage, so that it can be displayed.
- tokenNames - Static variable in class org.epics.pvmanager.formula.FormulaParser
-
- toString() - Method in class org.epics.pvmanager.util.TimeDuration
-
Deprecated.
- toString() - Method in class org.epics.pvmanager.util.TimeInterval
-
Deprecated.
- toString() - Method in class org.epics.pvmanager.util.TimeStamp
-
Deprecated.
- toStringFormat() - Static method in class org.epics.pvmanager.util.NumberFormats
-
Returns the NumberFormat that uses the standard text representation
(toString) for numbers.
- toTimestamp(T) - Static method in class org.epics.pvmanager.TimeSupport
-
Deprecated.
Extracts the TimeStamp of the value using the appropriate type support.
- toVImage(BufferedImage) - Static method in class org.epics.pvmanager.data.ValueUtil
-
Converts an AWT BufferedImage to a VImage.
- typeOf(Object) - Static method in class org.epics.pvmanager.data.ValueUtil
-
Returns the type of the object by returning the class object of one
of the VXxx interfaces.
- TypeSupport<T> - Class in org.epics.pvmanager
-
Implements the mechanism for registering different types so that the library
knows how to handle them.
- TypeSupport(Class<T>, Class<? extends TypeSupport>) - Constructor for class org.epics.pvmanager.TypeSupport
-
Creates a new type support of the given type
- typeSupportsFor(Class<T>) - Static method in class org.epics.pvmanager.TypeSupport
-
- ValueCache<T> - Class in org.epics.pvmanager
-
Represent a building block that can store a particular value
- ValueCache(Class<T>) - Constructor for class org.epics.pvmanager.ValueCache
-
Creates a new cache for the given data type.
- ValueFactory - Class in org.epics.pvmanager.data
-
Factory class for all concrete implementation of the types.
- ValueFactory() - Constructor for class org.epics.pvmanager.data.ValueFactory
-
- ValueFormat - Class in org.epics.pvmanager.data
-
Formats a data type to a String representation.
- ValueFormat() - Constructor for class org.epics.pvmanager.data.ValueFormat
-
- valueOf(String) - Static method in enum org.epics.pvmanager.data.AlarmSeverity
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.epics.pvmanager.data.AlarmStatus
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum org.epics.pvmanager.data.AlarmSeverity
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.epics.pvmanager.data.AlarmStatus
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- ValueUtil - Class in org.epics.pvmanager.data
-
Various utility methods for runtime handling of the types defined in
this package.
- vByteArray(String) - Static method in class org.epics.pvmanager.data.ExpressionLanguage
-
A channel with the given name of type VByteArray.
- VByteArray - Interface in org.epics.pvmanager.data
-
Byte array with alarm, timestamp, display and control information.
- vConst(double) - Static method in class org.epics.pvmanager.data.ExpressionLanguage
-
A constant representing a double.
- vConst(int) - Static method in class org.epics.pvmanager.data.ExpressionLanguage
-
A constant representing an int.
- vConst(double...) - Static method in class org.epics.pvmanager.data.ExpressionLanguage
-
A constant representing a double array.
- vConst(ListDouble) - Static method in class org.epics.pvmanager.data.ExpressionLanguage
-
A constant representing a double array.
- vConst(int...) - Static method in class org.epics.pvmanager.data.ExpressionLanguage
-
A constant representing an int array.
- vConst(ListInt) - Static method in class org.epics.pvmanager.data.ExpressionLanguage
-
A constant representing an int array.
- vDouble(String) - Static method in class org.epics.pvmanager.data.ExpressionLanguage
-
A channel with the given name of type VDouble.
- VDouble - Interface in org.epics.pvmanager.data
-
Scalar double with alarm, timestamp, display and control information.
- vDoubleArray(String) - Static method in class org.epics.pvmanager.data.ExpressionLanguage
-
A channel with the given name of type VDoubleArray.
- VDoubleArray - Interface in org.epics.pvmanager.data
-
Double array with alarm, timestamp, display and control information.
- vDoubleArrayOf(SourceRateExpression<?>) - Static method in class org.epics.pvmanager.data.ExpressionLanguage
-
- vDoubleArrayOf(DesiredRateExpressionList<? extends VNumber>) - Static method in class org.epics.pvmanager.data.ExpressionLanguage
-
- vDoubleConstants(List<Double>) - Static method in class org.epics.pvmanager.data.ExpressionLanguage
-
A list of constant expressions of type VDouble.
- vDoubleOf(SourceRateExpression<?>) - Static method in class org.epics.pvmanager.data.ExpressionLanguage
-
- vDoubles(List<String>) - Static method in class org.epics.pvmanager.data.ExpressionLanguage
-
A list of channels with the given names, all of type VDouble.
- vEnum(String) - Static method in class org.epics.pvmanager.data.ExpressionLanguage
-
A channel with the given name of type VEnum.
- VEnum - Interface in org.epics.pvmanager.data
-
Scalar enum with alarm and timestamp.
- VEnumArray - Interface in org.epics.pvmanager.data
-
- VExtendedAlarm - Interface in org.epics.pvmanager.data
-
Extended alarm information.
- VExtendedAlarm.Condition - Interface in org.epics.pvmanager.data
-
A single alarm condition that can be on or off.
- vFloatArray(String) - Static method in class org.epics.pvmanager.data.ExpressionLanguage
-
A channel with the given name of type VFloatArray.
- VFloatArray - Interface in org.epics.pvmanager.data
-
Float array with alarm, timestamp, display and control information.
- VImage - Interface in org.epics.pvmanager.data
-
Represent a buffered image.
- vInt(String) - Static method in class org.epics.pvmanager.data.ExpressionLanguage
-
A channel with the given name of type VInt.
- VInt - Interface in org.epics.pvmanager.data
-
Scalar integer with alarm, timestamp, display and control information.
- vIntArray(String) - Static method in class org.epics.pvmanager.data.ExpressionLanguage
-
A channel with the given name of type VIntArray.
- VIntArray - Interface in org.epics.pvmanager.data
-
Int array with alarm, timestamp, display and control information.
- vIntConstants(List<Integer>) - Static method in class org.epics.pvmanager.data.ExpressionLanguage
-
A list of constant expressions of type VDouble.
- VMultiDouble - Interface in org.epics.pvmanager.data
-
Multi channel array of VDouble.
- VMultiEnum - Interface in org.epics.pvmanager.data
-
- VMultiInt - Interface in org.epics.pvmanager.data
-
- VMultiString - Interface in org.epics.pvmanager.data
-
- vNumber(String) - Static method in class org.epics.pvmanager.data.ExpressionLanguage
-
A channel with the given name of type VNumber.
- VNumber - Interface in org.epics.pvmanager.data
-
Scalar number with alarm, timestamp, display and control information.
- vNumberArray(String) - Static method in class org.epics.pvmanager.data.ExpressionLanguage
-
A channel with the given name of type VNumberArray.
- VNumberArray - Interface in org.epics.pvmanager.data
-
Numeric array with alarm, timestamp, display and control information.
- vNumbers(List<String>) - Static method in class org.epics.pvmanager.data.ExpressionLanguage
-
A list of channels with the given names, all of type VNumber.
- vShortArray(String) - Static method in class org.epics.pvmanager.data.ExpressionLanguage
-
A channel with the given name of type VShortArray.
- VShortArray - Interface in org.epics.pvmanager.data
-
Short array with alarm, timestamp, display and control information.
- VStatistics - Interface in org.epics.pvmanager.data
-
Statistics for double with alarm, timestamp and display information.
- vString(String) - Static method in class org.epics.pvmanager.data.ExpressionLanguage
-
A channel with the given name of type VString.
- VString - Interface in org.epics.pvmanager.data
-
Scalar string with alarm and timestamp.
- vStringArray(String) - Static method in class org.epics.pvmanager.data.ExpressionLanguage
-
A channel with the given name of type VStringArray.
- VStringArray - Interface in org.epics.pvmanager.data
-
- vStringConstants(List<String>) - Static method in class org.epics.pvmanager.data.ExpressionLanguage
-
A list of constant expressions of type VString.
- vTable(VTableColumn...) - Static method in class org.epics.pvmanager.data.ExpressionLanguage
-
Creates a vTable by aggregating different values from different pvs.
- VTable - Interface in org.epics.pvmanager.data
-
A table.
- VTableColumn - Class in org.epics.pvmanager.data
-
An expression to build a column for an aggregated vTable.
- vType(String) - Static method in class org.epics.pvmanager.data.ExpressionLanguage
-
A channel with the given name that returns any of the value type.
- VType - Interface in org.epics.pvmanager.data
-
Tag interface to mark all the members of the value classes.
- vTypes(List<String>) - Static method in class org.epics.pvmanager.data.ExpressionLanguage
-
A list of channels with the given names that return any of the value type.