Index

A B C D E F G H I J K L M N O P Q R S T U V W X Y Z _ 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form

A

ABNORMAL_TERMINATION_FIELD_NUMBER - Static variable in class io.deephaven.proto.backplane.grpc.TerminationNotificationResponse
 
abort() - Method in class io.deephaven.engine.table.impl.perf.QueryPerformanceNugget
 
AbortableRangeConsumer - Interface in io.deephaven.engine.rowset.impl.rsp.container
Results comprised of multiple, ordered ranges are provided via this interface.
abortQuery() - Method in interface io.deephaven.engine.table.impl.perf.QueryPerformanceRecorder
Abort a query.
abortQuery() - Method in class io.deephaven.engine.table.impl.perf.QueryPerformanceRecorderImpl
 
abs(byte) - Static method in class io.deephaven.function.Numeric
Returns the absolute value.
abs(byte) - Static method in class io.deephaven.libs.GroovyStaticImports
 
abs(double) - Static method in class io.deephaven.function.Numeric
Returns the absolute value.
abs(double) - Static method in class io.deephaven.libs.GroovyStaticImports
 
abs(float) - Static method in class io.deephaven.function.Numeric
Returns the absolute value.
abs(float) - Static method in class io.deephaven.libs.GroovyStaticImports
 
abs(int) - Static method in class io.deephaven.function.Numeric
Returns the absolute value.
abs(int) - Static method in class io.deephaven.libs.GroovyStaticImports
 
abs(long) - Static method in class io.deephaven.function.Numeric
Returns the absolute value.
abs(long) - Static method in class io.deephaven.libs.GroovyStaticImports
 
abs(short) - Static method in class io.deephaven.function.Numeric
Returns the absolute value.
abs(short) - Static method in class io.deephaven.libs.GroovyStaticImports
 
ABS_SUM - Enum constant in enum class io.deephaven.proto.backplane.grpc.AggSpec.TypeCase
 
ABS_SUM - Enum constant in enum class io.deephaven.proto.backplane.grpc.ComboAggregateRequest.AggType
Deprecated.
ABS_SUM = 1;
ABS_SUM_FIELD_NUMBER - Static variable in class io.deephaven.proto.backplane.grpc.AggSpec
 
ABS_SUM_VALUE - Static variable in enum class io.deephaven.proto.backplane.grpc.ComboAggregateRequest.AggType
Deprecated.
ABS_SUM = 1;
absAvg(byte...) - Static method in class io.deephaven.function.Numeric
Returns the mean of the absolute values of values.
absAvg(byte...) - Static method in class io.deephaven.libs.GroovyStaticImports
 
absAvg(double...) - Static method in class io.deephaven.function.Numeric
Returns the mean of the absolute values of values.
absAvg(double...) - Static method in class io.deephaven.libs.GroovyStaticImports
 
absAvg(float...) - Static method in class io.deephaven.function.Numeric
Returns the mean of the absolute values of values.
absAvg(float...) - Static method in class io.deephaven.libs.GroovyStaticImports
 
absAvg(int...) - Static method in class io.deephaven.function.Numeric
Returns the mean of the absolute values of values.
absAvg(int...) - Static method in class io.deephaven.libs.GroovyStaticImports
 
absAvg(long...) - Static method in class io.deephaven.function.Numeric
Returns the mean of the absolute values of values.
absAvg(long...) - Static method in class io.deephaven.libs.GroovyStaticImports
 
absAvg(short...) - Static method in class io.deephaven.function.Numeric
Returns the mean of the absolute values of values.
absAvg(short...) - Static method in class io.deephaven.libs.GroovyStaticImports
 
absAvg(ByteVector) - Static method in class io.deephaven.function.Numeric
Returns the mean of the absolute values of values.
absAvg(ByteVector) - Static method in class io.deephaven.libs.GroovyStaticImports
 
absAvg(DoubleVector) - Static method in class io.deephaven.function.Numeric
Returns the mean of the absolute values of values.
absAvg(DoubleVector) - Static method in class io.deephaven.libs.GroovyStaticImports
 
absAvg(FloatVector) - Static method in class io.deephaven.function.Numeric
Returns the mean of the absolute values of values.
absAvg(FloatVector) - Static method in class io.deephaven.libs.GroovyStaticImports
 
absAvg(IntVector) - Static method in class io.deephaven.function.Numeric
Returns the mean of the absolute values of values.
absAvg(IntVector) - Static method in class io.deephaven.libs.GroovyStaticImports
 
absAvg(LongVector) - Static method in class io.deephaven.function.Numeric
Returns the mean of the absolute values of values.
absAvg(LongVector) - Static method in class io.deephaven.libs.GroovyStaticImports
 
absAvg(ShortVector) - Static method in class io.deephaven.function.Numeric
Returns the mean of the absolute values of values.
absAvg(ShortVector) - Static method in class io.deephaven.libs.GroovyStaticImports
 
absAvg(Byte[]) - Static method in class io.deephaven.function.Numeric
Returns the mean of the absolute values of values.
absAvg(Byte[]) - Static method in class io.deephaven.libs.GroovyStaticImports
 
absAvg(Double[]) - Static method in class io.deephaven.function.Numeric
Returns the mean of the absolute values of values.
absAvg(Double[]) - Static method in class io.deephaven.libs.GroovyStaticImports
 
absAvg(Float[]) - Static method in class io.deephaven.function.Numeric
Returns the mean of the absolute values of values.
absAvg(Float[]) - Static method in class io.deephaven.libs.GroovyStaticImports
 
absAvg(Integer[]) - Static method in class io.deephaven.function.Numeric
Returns the mean of the absolute values of values.
absAvg(Integer[]) - Static method in class io.deephaven.libs.GroovyStaticImports
 
absAvg(Long[]) - Static method in class io.deephaven.function.Numeric
Returns the mean of the absolute values of values.
absAvg(Long[]) - Static method in class io.deephaven.libs.GroovyStaticImports
 
absAvg(Short[]) - Static method in class io.deephaven.function.Numeric
Returns the mean of the absolute values of values.
absAvg(Short[]) - Static method in class io.deephaven.libs.GroovyStaticImports
 
absoluteColumnNameToBaseName(String) - Static method in class io.deephaven.engine.table.impl.AbsoluteSortColumnConventions
 
AbsoluteSortColumnConventions - Class in io.deephaven.engine.table.impl
Encapsulate some hacky conventions we use to "standardize" absolute value sorting directives from the UI.
AbsoluteSortColumnConventions() - Constructor for class io.deephaven.engine.table.impl.AbsoluteSortColumnConventions
 
absoluteTokenBegin - Variable in class io.deephaven.lang.generated.SimpleCharStream
 
absPackedGet(int) - Method in class io.deephaven.engine.rowset.impl.sortedranges.SortedRanges
 
absSum() - Static method in interface io.deephaven.api.agg.spec.AggSpec
 
AbsSum - Enum constant in enum class io.deephaven.engine.util.TotalsTableBuilder.AggType
Return the sum of absolute values in each group.
absSumBy() - Method in interface io.deephaven.api.TableOperations
Produces a single row table with the absolute sum of each column.
absSumBy() - Method in interface io.deephaven.api.TableOperationsDefaults
 
absSumBy(ColumnName...) - Method in interface io.deephaven.api.TableOperations
Groups the data column according to groupByColumns and computes the sum of the absolute values for the rest of the fields
absSumBy(ColumnName...) - Method in interface io.deephaven.api.TableOperationsDefaults
 
absSumBy(String...) - Method in interface io.deephaven.api.TableOperations
Groups the data column according to groupByColumns and computes the sum of the absolute values for the rest of the fields
absSumBy(String...) - Method in interface io.deephaven.api.TableOperationsDefaults
 
absSumBy(Collection<String>) - Method in interface io.deephaven.api.TableOperations
Groups the data column according to groupByColumns and computes the sum of the absolute values for the rest of the fields
absSumBy(Collection<String>) - Method in interface io.deephaven.api.TableOperationsDefaults
 
AbstractArrowColumnSource<T> - Class in io.deephaven.extensions.arrow.sources
Base class for arrow column sources
AbstractArrowColumnSource(Class<T>, int, Field, ArrowWrapperTools.ArrowTableContext) - Constructor for class io.deephaven.extensions.arrow.sources.AbstractArrowColumnSource
 
AbstractCategoryDataSeries - Class in io.deephaven.plot.datasets.category
Common class for CategoryDataSeriesInternal.
AbstractCategoryDataSeries(AxesImpl, int, Comparable) - Constructor for class io.deephaven.plot.datasets.category.AbstractCategoryDataSeries
 
AbstractCategoryDataSeries(AxesImpl, int, Comparable, AbstractCategoryDataSeries) - Constructor for class io.deephaven.plot.datasets.category.AbstractCategoryDataSeries
Creates an AbstractCategoryDataSeries instance.
AbstractCategoryDataSeries(AbstractCategoryDataSeries, AxesImpl) - Constructor for class io.deephaven.plot.datasets.category.AbstractCategoryDataSeries
Creates a copy of a series using a different Axes.
AbstractChunkerInvokable - Class in io.deephaven.lang.api
 
AbstractChunkerInvokable(int) - Constructor for class io.deephaven.lang.api.AbstractChunkerInvokable
 
AbstractChunkerInvokable(Chunker, int) - Constructor for class io.deephaven.lang.api.AbstractChunkerInvokable
 
AbstractColumnLocation - Class in io.deephaven.engine.table.impl.locations.impl
Partial ColumnLocation implementation for use by TableDataService implementations.
AbstractColumnLocation(TableLocation, String) - Constructor for class io.deephaven.engine.table.impl.locations.impl.AbstractColumnLocation
 
AbstractColumnSource<T> - Class in io.deephaven.engine.table.impl
 
AbstractColumnSource(Class<T>) - Constructor for class io.deephaven.engine.table.impl.AbstractColumnSource
 
AbstractColumnSource(Class<T>, Class<?>) - Constructor for class io.deephaven.engine.table.impl.AbstractColumnSource
 
AbstractColumnSource.DefaultedImmutable<DATA_TYPE> - Class in io.deephaven.engine.table.impl
 
AbstractColumnSource.DefaultedMutable<DATA_TYPE> - Class in io.deephaven.engine.table.impl
 
AbstractCompressedString<TYPE extends AbstractCompressedString> - Class in io.deephaven.base.string.cache
Base class for immutable byte[]-backed String replacements.
AbstractConditionFilter - Class in io.deephaven.engine.table.impl.select
 
AbstractConditionFilter(String, boolean) - Constructor for class io.deephaven.engine.table.impl.select.AbstractConditionFilter
 
AbstractConditionFilter(String, Map<String, String>, boolean) - Constructor for class io.deephaven.engine.table.impl.select.AbstractConditionFilter
 
AbstractConditionFilter.Filter - Interface in io.deephaven.engine.table.impl.select
 
AbstractDataIndex - Class in io.deephaven.engine.table.impl.dataindex
Abstract base implementation of DataIndex that provides common functionality.
AbstractDataIndex() - Constructor for class io.deephaven.engine.table.impl.dataindex.AbstractDataIndex
 
AbstractDataSeries - Class in io.deephaven.plot.datasets
Base class for DataSeriesInternal.
AbstractDataSeries(AxesImpl, int, Comparable, AbstractDataSeries) - Constructor for class io.deephaven.plot.datasets.AbstractDataSeries
Creates an AbstractDataSeries instance.
AbstractDataSeries(AbstractDataSeries, AxesImpl) - Constructor for class io.deephaven.plot.datasets.AbstractDataSeries
Creates a copy of a series using a different Axes.
AbstractExpressionFactory<T> - Class in io.deephaven.api.expression
 
AbstractExpressionFactory(String) - Constructor for class io.deephaven.api.expression.AbstractExpressionFactory
 
AbstractFormulaColumn - Class in io.deephaven.engine.table.impl.select
A SelectColumn that implements a formula computed from the existing columns in the table and a query scope.
AbstractFormulaColumn(String, String) - Constructor for class io.deephaven.engine.table.impl.select.AbstractFormulaColumn
Create a formula column for the given formula string.
AbstractJoinKeyState - Class in io.deephaven.engine.table.impl.join
 
AbstractMa - Class in io.deephaven.numerics.movingaverages
Base class for computing moving averages.
AbstractMa() - Constructor for class io.deephaven.numerics.movingaverages.AbstractMa
empty constructor needed for externalizable
AbstractMa(AbstractMa.Type, AbstractMa.Mode, double) - Constructor for class io.deephaven.numerics.movingaverages.AbstractMa
Constructs a new MA which use the given timescale.
AbstractMa.Mode - Enum Class in io.deephaven.numerics.movingaverages
 
AbstractMa.Type - Enum Class in io.deephaven.numerics.movingaverages
 
AbstractMapBasedCategoryDataSeries - Class in io.deephaven.plot.datasets.category
 
AbstractMapBasedCategoryDataSeries(AxesImpl, int, Comparable) - Constructor for class io.deephaven.plot.datasets.category.AbstractMapBasedCategoryDataSeries
 
AbstractMapBasedCategoryDataSeries(AxesImpl, int, Comparable, AbstractCategoryDataSeries) - Constructor for class io.deephaven.plot.datasets.category.AbstractMapBasedCategoryDataSeries
 
AbstractMapBasedCategoryDataSeries(AbstractCategoryDataSeries, AxesImpl) - Constructor for class io.deephaven.plot.datasets.category.AbstractMapBasedCategoryDataSeries
 
AbstractMatrix() - Constructor for class io.deephaven.numerics.suanshu.SuanShuIntegration.AbstractMatrix
 
AbstractMtlsClientCertificateInterceptor - Class in io.deephaven.grpc
Base class for server implementations to offer their own hook to read the current certificates
AbstractMtlsClientCertificateInterceptor() - Constructor for class io.deephaven.grpc.AbstractMtlsClientCertificateInterceptor
 
AbstractMultiSeries<SERIES extends DataSeriesInternal> - Class in io.deephaven.plot.datasets.multiseries
Creates and holds a DataSeriesInternal for every key in a PartitionedTable.
AbstractNormalizeFilters - Class in io.deephaven.server.table.ops.filter
 
AbstractNormalizeFilters() - Constructor for class io.deephaven.server.table.ops.filter.AbstractNormalizeFilters
 
AbstractNotification - Class in io.deephaven.engine.updategraph
Common base class for notifications.
AbstractNotification(boolean) - Constructor for class io.deephaven.engine.updategraph.AbstractNotification
 
AbstractPartitionedTableHandleMultiSeries<SERIES extends DataSeriesInternal> - Class in io.deephaven.plot.datasets.multiseries
 
AbstractRangeFilter - Class in io.deephaven.engine.table.impl.select
A filter that determines if a column value is between an upper and lower bound (which each may either be inclusive or exclusive).
AbstractScriptSession<S extends AbstractScriptSession.Snapshot> - Class in io.deephaven.engine.util
This class exists to make all script sessions to be liveness artifacts, and provide a default implementation for evaluateScript which handles liveness and diffs in a consistent way.
AbstractScriptSession(UpdateGraph, OperationInitializer, ObjectTypeLookup, ScriptSession.Listener) - Constructor for class io.deephaven.engine.util.AbstractScriptSession
 
AbstractScriptSession(UpdateGraph, OperationInitializer, ObjectTypeLookup, ScriptSession.Listener, File, ClassLoader) - Constructor for class io.deephaven.engine.util.AbstractScriptSession
 
AbstractScriptSession.ScriptSessionQueryScope - Class in io.deephaven.engine.util
 
AbstractScriptSession.Snapshot - Interface in io.deephaven.engine.util
 
AbstractSeriesInternal - Class in io.deephaven.plot
Abstract implementation of the base series that all data series inherit from.
AbstractSeriesInternal(AbstractSeriesInternal, AxesImpl) - Constructor for class io.deephaven.plot.AbstractSeriesInternal
 
AbstractSeriesInternal(AxesImpl, int, Comparable) - Constructor for class io.deephaven.plot.AbstractSeriesInternal
 
abstractServerStreamSink() - Method in class io.grpc.servlet.web.websocket.MultiplexedWebsocketStreamImpl
 
abstractServerStreamSink() - Method in class io.grpc.servlet.web.websocket.WebsocketStreamImpl
 
AbstractSwappableMultiSeries<SERIES extends DataSeriesInternal> - Class in io.deephaven.plot.datasets.multiseries
 
AbstractSwappableTableBasedCategoryDataSeries - Class in io.deephaven.plot.datasets.category
 
AbstractSwappableTableBasedCategoryDataSeries(AxesImpl, int, Comparable) - Constructor for class io.deephaven.plot.datasets.category.AbstractSwappableTableBasedCategoryDataSeries
 
AbstractSwappableTableBasedCategoryDataSeries(AxesImpl, int, Comparable, AbstractCategoryDataSeries) - Constructor for class io.deephaven.plot.datasets.category.AbstractSwappableTableBasedCategoryDataSeries
 
AbstractSwappableTableBasedCategoryDataSeries(AbstractCategoryDataSeries, AxesImpl) - Constructor for class io.deephaven.plot.datasets.category.AbstractSwappableTableBasedCategoryDataSeries
 
AbstractTableBasedCategoryDataSeries - Class in io.deephaven.plot.datasets.category
 
AbstractTableBasedCategoryDataSeries(AxesImpl, int, Comparable) - Constructor for class io.deephaven.plot.datasets.category.AbstractTableBasedCategoryDataSeries
 
AbstractTableBasedCategoryDataSeries(AxesImpl, int, Comparable, AbstractCategoryDataSeries) - Constructor for class io.deephaven.plot.datasets.category.AbstractTableBasedCategoryDataSeries
 
AbstractTableBasedCategoryDataSeries(AbstractCategoryDataSeries, AxesImpl) - Constructor for class io.deephaven.plot.datasets.category.AbstractTableBasedCategoryDataSeries
 
AbstractTableDataService - Class in io.deephaven.engine.table.impl.locations.impl
Partial TableDataService implementation.
AbstractTableDataService(String) - Constructor for class io.deephaven.engine.table.impl.locations.impl.AbstractTableDataService
Construct an AbstractTableDataService.
AbstractTableLocation - Class in io.deephaven.engine.table.impl.locations.impl
Partial TableLocation implementation for use by TableDataService implementations.
AbstractTableLocation(TableKey, TableLocationKey, boolean) - Constructor for class io.deephaven.engine.table.impl.locations.impl.AbstractTableLocation
 
AbstractTableLocationProvider - Class in io.deephaven.engine.table.impl.locations.impl
Partial TableLocationProvider implementation for standalone use or as part of a TableDataService.
AbstractTableLocationProvider(boolean) - Constructor for class io.deephaven.engine.table.impl.locations.impl.AbstractTableLocationProvider
Construct a standalone provider.
AbstractTableLocationProvider(TableKey, boolean) - Constructor for class io.deephaven.engine.table.impl.locations.impl.AbstractTableLocationProvider
Construct a provider as part of a service.
AbstractTupleSource<TUPLE_TYPE> - Class in io.deephaven.engine.table.impl.tuplesource
 
AbstractTupleSource(ColumnSource<?>...) - Constructor for class io.deephaven.engine.table.impl.tuplesource.AbstractTupleSource
 
AbstractVector() - Constructor for class io.deephaven.numerics.suanshu.SuanShuIntegration.AbstractVector
 
AbstractWebSocketServerStream - Class in io.grpc.servlet.web.websocket
 
AbstractWebSocketServerStream(ServerTransportListener, List<? extends ServerStreamTracer.Factory>, int, Attributes) - Constructor for class io.grpc.servlet.web.websocket.AbstractWebSocketServerStream
 
AbstractWebsocketStreamImpl - Class in io.grpc.servlet.web.websocket
 
AbstractWebsocketStreamImpl(WritableBufferAllocator, StatsTraceContext, int, Session, InternalLogId, Attributes, Logger) - Constructor for class io.grpc.servlet.web.websocket.AbstractWebsocketStreamImpl
 
AbstractWebsocketStreamImpl.WebsocketTransportState - Class in io.grpc.servlet.web.websocket
 
AbstractXYDataSeries - Class in io.deephaven.plot.datasets.xy
Base class for the XYDataSeriesInternal.
AbstractXYDataSeries(AxesImpl, int, Comparable, AbstractXYDataSeries) - Constructor for class io.deephaven.plot.datasets.xy.AbstractXYDataSeries
Creates an AbstractXYDataSeries instance.
AbstractXYDataSeries(AbstractXYDataSeries, AxesImpl) - Constructor for class io.deephaven.plot.datasets.xy.AbstractXYDataSeries
Creates a copy of a series using a different Axes.
absUnpackedGet(int) - Method in class io.deephaven.engine.rowset.impl.sortedranges.SortedRanges
 
absUnpackedGet(int) - Method in class io.deephaven.engine.rowset.impl.sortedranges.SortedRangesInt
 
absUnpackedGet(int) - Method in class io.deephaven.engine.rowset.impl.sortedranges.SortedRangesLong
 
absUnpackedGet(int) - Method in class io.deephaven.engine.rowset.impl.sortedranges.SortedRangesShort
 
accept(byte) - Method in interface io.deephaven.engine.primitive.function.ByteConsumer
Apply this operation to value.
accept(char) - Method in interface io.deephaven.engine.primitive.function.CharConsumer
Apply this operation to value.
accept(double, int) - Method in interface io.deephaven.plot.datasets.xy.DoubleIntegerConsumer
 
accept(float) - Method in interface io.deephaven.engine.primitive.function.FloatConsumer
Apply this operation to value.
accept(int, int) - Method in interface io.deephaven.engine.rowset.impl.rsp.container.AbortableRangeConsumer
Deliver a single range.
accept(int, int) - Method in interface io.deephaven.engine.rowset.impl.rsp.container.RangeConsumer
Deliver a single range.
accept(int, long[], byte[]) - Method in interface io.deephaven.engine.table.impl.MultiJoinModifiedSlotTracker.ModifiedSlotConsumer
 
accept(long) - Method in class io.deephaven.chunk.util.LongChunkAppender
 
accept(long) - Method in class io.deephaven.engine.table.WritableColumnSource.ByteFiller
 
accept(long) - Method in class io.deephaven.engine.table.WritableColumnSource.CharFiller
 
accept(long) - Method in class io.deephaven.engine.table.WritableColumnSource.DoubleFiller
 
accept(long) - Method in class io.deephaven.engine.table.WritableColumnSource.FloatFiller
 
accept(long) - Method in class io.deephaven.engine.table.WritableColumnSource.IntFiller
 
accept(long) - Method in class io.deephaven.engine.table.WritableColumnSource.LongFiller
 
accept(long) - Method in class io.deephaven.engine.table.WritableColumnSource.ObjectFiller
 
accept(long) - Method in class io.deephaven.engine.table.WritableColumnSource.ShortFiller
 
accept(long) - Method in interface io.deephaven.util.datastructures.LongAbortableConsumer
Provides a value to this consumer.
accept(long) - Method in interface io.deephaven.util.metrics.LongMetric
 
accept(long, int, boolean) - Method in interface io.deephaven.engine.table.impl.perf.QueryPerformanceRecorder.QueryDataConsumer
 
accept(long, long) - Method in interface io.deephaven.engine.rowset.impl.OrderedLongSet.BuilderRandom
 
accept(long, long) - Method in interface io.deephaven.engine.rowset.impl.OrderedLongSet.BuilderSequential
 
accept(long, long) - Method in interface io.deephaven.util.datastructures.LongRangeAbortableConsumer
Provides a range to this consumer.
accept(long, long) - Method in interface io.deephaven.util.datastructures.LongRangeConsumer
Provides a range to this consumer.
accept(short) - Method in interface io.deephaven.engine.primitive.function.ShortConsumer
Apply this operation to value.
accept(short) - Method in interface io.deephaven.engine.rowset.impl.rsp.container.ShortConsumer
Provides a value to this consumer.
accept(short, short) - Method in interface io.deephaven.engine.rowset.impl.rsp.container.ShortRangeConsumer
Provides a value to this consumer.
accept(WritableChunk<Values>...) - Method in interface io.deephaven.stream.StreamConsumer
Accept a batch of rows splayed across per-column chunks of values.
accept(WritableChunk<Values>...) - Method in class io.deephaven.stream.StreamToBlinkTableAdapter
 
accept(TableLocationKey) - Method in interface io.deephaven.engine.table.impl.locations.impl.FilteredTableDataService.LocationKeyFilter
Determine whether a TableLocationKey should be visible via this service.
accept(Logger, CleanupReference<?>, Exception) - Method in interface io.deephaven.util.reference.CleanupReferenceProcessor.ExceptionHandler
 
accept(Collection<WritableChunk<Values>[]>) - Method in interface io.deephaven.stream.StreamConsumer
Accept a collection of batches of rows splayed across per-column chunks of values.
accept(Collection<WritableChunk<Values>[]>) - Method in class io.deephaven.stream.StreamToBlinkTableAdapter
Accept a collection of batches of rows splayed across per-column chunks of values.
accept(LogSink, LogBuffer) - Method in interface io.deephaven.internal.log.InitSink
 
accept(LogSink, LogBuffer) - Method in class io.deephaven.internal.log.LogToLogBuffer
 
accept(ParquetSchemaReader.ParquetMessageDefinition) - Method in interface io.deephaven.parquet.table.ParquetSchemaReader.ColumnDefinitionConsumer
 
accept(Condition, FilterVisitor<R>) - Static method in interface io.deephaven.server.table.ops.filter.FilterVisitor
 
accept(TableSpec) - Method in class io.deephaven.qst.table.LinkDescriber
 
accept(TableSpec) - Method in class io.deephaven.qst.table.TableLabelVisitor
 
accept(TableSpec) - Method in class io.deephaven.qst.table.TableVisitorGeneric
 
accept(String, T) - Method in interface io.deephaven.engine.context.QueryScope.ParamFilter
 
accept(T) - Method in interface io.deephaven.util.function.ThrowingConsumer
accept(TLK) - Method in class io.deephaven.engine.table.impl.locations.impl.RecordingLocationKeyFinder
 
accept(T, U) - Method in interface io.deephaven.util.function.ThrowingBiConsumer
acceptAppend(BooleanChunk<ATTR>, int) - Method in class io.deephaven.generic.page.ChunkHolderPageBoolean
Accept an appended slice of data to the currently-visible range for this page.
acceptAppend(ByteChunk<ATTR>, int) - Method in class io.deephaven.generic.page.ChunkHolderPageByte
Accept an appended slice of data to the currently-visible range for this page.
acceptAppend(CharChunk<ATTR>, int) - Method in class io.deephaven.generic.page.ChunkHolderPageChar
Accept an appended slice of data to the currently-visible range for this page.
acceptAppend(DoubleChunk<ATTR>, int) - Method in class io.deephaven.generic.page.ChunkHolderPageDouble
Accept an appended slice of data to the currently-visible range for this page.
acceptAppend(FloatChunk<ATTR>, int) - Method in class io.deephaven.generic.page.ChunkHolderPageFloat
Accept an appended slice of data to the currently-visible range for this page.
acceptAppend(IntChunk<ATTR>, int) - Method in class io.deephaven.generic.page.ChunkHolderPageInt
Accept an appended slice of data to the currently-visible range for this page.
acceptAppend(LongChunk<ATTR>, int) - Method in class io.deephaven.generic.page.ChunkHolderPageLong
Accept an appended slice of data to the currently-visible range for this page.
acceptAppend(ObjectChunk<T, ATTR>, int) - Method in class io.deephaven.generic.page.ChunkHolderPageObject
Accept an appended slice of data to the currently-visible range for this page.
acceptAppend(ShortChunk<ATTR>, int) - Method in class io.deephaven.generic.page.ChunkHolderPageShort
Accept an appended slice of data to the currently-visible range for this page.
acceptBuffer(ByteBuffer, int) - Method in class io.deephaven.io.streams.CurrentByteBufferSink.Adapter
 
acceptBuffer(ByteBuffer, int) - Method in class io.deephaven.io.log.impl.LogOutputBaseImpl
 
acceptBuffer(ByteBuffer, int) - Method in interface io.deephaven.io.streams.ByteBufferSink
Dispose of the contents of the buffer b, probably by writing them to a channel, and return a new buffer in which writing can continue.
acceptBuffer(ByteBuffer, int) - Method in interface io.deephaven.io.streams.ByteBufferStreams.Sink
Dispose of the contents of the buffer b, probably by writing them to a channel, and return a new buffer in which writing can continue.
acceptBuffer(ByteBuffer, int) - Method in class io.deephaven.io.streams.NullByteBufferSink
 
acceptBuffer(ByteBuffer, int) - Method in class io.deephaven.io.streams.SimpleByteBufferSink
 
acceptEither(CompletionStage<? extends T>, Consumer<? super T>) - Method in class io.deephaven.util.CompletionStageFutureImpl
 
acceptEither(CompletionStage<? extends T>, Consumer<? super T>) - Method in interface io.deephaven.util.CompletionStageFuture
 
acceptEitherAsync(CompletionStage<? extends T>, Consumer<? super T>) - Method in class io.deephaven.util.CompletionStageFutureImpl
 
acceptEitherAsync(CompletionStage<? extends T>, Consumer<? super T>, Executor) - Method in class io.deephaven.util.CompletionStageFutureImpl
 
acceptEitherAsync(CompletionStage<? extends T>, Consumer<? super T>) - Method in interface io.deephaven.util.CompletionStageFuture
 
acceptEitherAsync(CompletionStage<? extends T>, Consumer<? super T>, Executor) - Method in interface io.deephaven.util.CompletionStageFuture
 
acceptFailure(Throwable) - Method in interface io.deephaven.stream.StreamFailureConsumer
Report an error while processing the stream.
acceptFailure(Throwable) - Method in class io.deephaven.stream.StreamToBlinkTableAdapter
 
acceptLocation(Collection<String>) - Method in interface io.deephaven.engine.table.impl.locations.local.KeyValuePartitionLayout.LocationTableBuilder
Accept an ordered collection of strings representing partition values for a particular table location, parallel to a previously registered collection of partition keys.
acceptLocation(Collection<String>) - Method in class io.deephaven.engine.table.impl.locations.local.LocationTableBuilderDefinition
 
acceptLocation(Collection<String>) - Method in class io.deephaven.parquet.table.layout.LocationTableBuilderCsv
 
ACCESS - Static variable in interface io.deephaven.lang.generated.ChunkerConstants
RegularExpression Id.
accumulate(BasePerformanceEntry) - Method in class io.deephaven.engine.table.impl.perf.BasePerformanceEntry
Accumulate the values from another entry into this one.
accumulate(QueryPerformanceRecorder) - Method in interface io.deephaven.engine.table.impl.perf.QueryPerformanceRecorder
Accumulate performance information from another recorder into this one.
accumulate(QueryPerformanceRecorder) - Method in class io.deephaven.engine.table.impl.perf.QueryPerformanceRecorderImpl
 
accumulate(PerformanceEntry) - Method in class io.deephaven.engine.table.impl.perf.PerformanceEntry
 
accumulateCumulative(RowSequence, Chunk<? extends Values>[], LongChunk<? extends Values>, int) - Method in class io.deephaven.engine.table.impl.updateby.em.BigIntegerEMOperator.Context
 
accumulateCumulative(RowSequence, Chunk<? extends Values>[], LongChunk<? extends Values>, int) - Method in class io.deephaven.engine.table.impl.updateby.emstd.BigDecimalEmStdOperator.Context
 
accumulateCumulative(RowSequence, Chunk<? extends Values>[], LongChunk<? extends Values>, int) - Method in class io.deephaven.engine.table.impl.updateby.emstd.BigIntegerEmStdOperator.Context
 
accumulateCumulative(RowSequence, Chunk<? extends Values>[], LongChunk<? extends Values>, int) - Method in class io.deephaven.engine.table.impl.updateby.internal.BaseByteUpdateByOperator.Context
 
accumulateCumulative(RowSequence, Chunk<? extends Values>[], LongChunk<? extends Values>, int) - Method in class io.deephaven.engine.table.impl.updateby.internal.BaseCharUpdateByOperator.Context
 
accumulateCumulative(RowSequence, Chunk<? extends Values>[], LongChunk<? extends Values>, int) - Method in class io.deephaven.engine.table.impl.updateby.internal.BaseDoubleUpdateByOperator.Context
 
accumulateCumulative(RowSequence, Chunk<? extends Values>[], LongChunk<? extends Values>, int) - Method in class io.deephaven.engine.table.impl.updateby.internal.BaseFloatUpdateByOperator.Context
 
accumulateCumulative(RowSequence, Chunk<? extends Values>[], LongChunk<? extends Values>, int) - Method in class io.deephaven.engine.table.impl.updateby.internal.BaseIntUpdateByOperator.Context
 
accumulateCumulative(RowSequence, Chunk<? extends Values>[], LongChunk<? extends Values>, int) - Method in class io.deephaven.engine.table.impl.updateby.internal.BaseLongUpdateByOperator.Context
 
accumulateCumulative(RowSequence, Chunk<? extends Values>[], LongChunk<? extends Values>, int) - Method in class io.deephaven.engine.table.impl.updateby.internal.BaseObjectUpdateByOperator.Context
 
accumulateCumulative(RowSequence, Chunk<? extends Values>[], LongChunk<? extends Values>, int) - Method in class io.deephaven.engine.table.impl.updateby.internal.BaseShortUpdateByOperator.Context
 
accumulateCumulative(RowSequence, Chunk<? extends Values>[], LongChunk<? extends Values>, int) - Method in class io.deephaven.engine.table.impl.updateby.rollingformula.ByteRollingFormulaOperator.Context
 
accumulateCumulative(RowSequence, Chunk<? extends Values>[], LongChunk<? extends Values>, int) - Method in class io.deephaven.engine.table.impl.updateby.em.BigDecimalEMOperator.Context
 
accumulateCumulative(RowSequence, Chunk<? extends Values>[], LongChunk<? extends Values>, int) - Method in class io.deephaven.engine.table.impl.updateby.em.DoubleEMOperator.Context
 
accumulateCumulative(RowSequence, Chunk<? extends Values>[], LongChunk<? extends Values>, int) - Method in class io.deephaven.engine.table.impl.updateby.em.FloatEMOperator.Context
 
accumulateCumulative(RowSequence, Chunk<? extends Values>[], LongChunk<? extends Values>, int) - Method in class io.deephaven.engine.table.impl.updateby.em.ByteEMOperator.Context
 
accumulateCumulative(RowSequence, Chunk<? extends Values>[], LongChunk<? extends Values>, int) - Method in class io.deephaven.engine.table.impl.updateby.em.CharEMOperator.Context
 
accumulateCumulative(RowSequence, Chunk<? extends Values>[], LongChunk<? extends Values>, int) - Method in class io.deephaven.engine.table.impl.updateby.em.IntEMOperator.Context
 
accumulateCumulative(RowSequence, Chunk<? extends Values>[], LongChunk<? extends Values>, int) - Method in class io.deephaven.engine.table.impl.updateby.em.LongEMOperator.Context
 
accumulateCumulative(RowSequence, Chunk<? extends Values>[], LongChunk<? extends Values>, int) - Method in class io.deephaven.engine.table.impl.updateby.em.ShortEMOperator.Context
 
accumulateCumulative(RowSequence, Chunk<? extends Values>[], LongChunk<? extends Values>, int) - Method in class io.deephaven.engine.table.impl.updateby.emstd.ByteEmStdOperator.Context
 
accumulateCumulative(RowSequence, Chunk<? extends Values>[], LongChunk<? extends Values>, int) - Method in class io.deephaven.engine.table.impl.updateby.emstd.CharEmStdOperator.Context
 
accumulateCumulative(RowSequence, Chunk<? extends Values>[], LongChunk<? extends Values>, int) - Method in class io.deephaven.engine.table.impl.updateby.emstd.DoubleEmStdOperator.Context
 
accumulateCumulative(RowSequence, Chunk<? extends Values>[], LongChunk<? extends Values>, int) - Method in class io.deephaven.engine.table.impl.updateby.emstd.FloatEmStdOperator.Context
 
accumulateCumulative(RowSequence, Chunk<? extends Values>[], LongChunk<? extends Values>, int) - Method in class io.deephaven.engine.table.impl.updateby.emstd.IntEmStdOperator.Context
 
accumulateCumulative(RowSequence, Chunk<? extends Values>[], LongChunk<? extends Values>, int) - Method in class io.deephaven.engine.table.impl.updateby.emstd.LongEmStdOperator.Context
 
accumulateCumulative(RowSequence, Chunk<? extends Values>[], LongChunk<? extends Values>, int) - Method in class io.deephaven.engine.table.impl.updateby.emstd.ShortEmStdOperator.Context
 
accumulateCumulative(RowSequence, Chunk<? extends Values>[], LongChunk<? extends Values>, int) - Method in class io.deephaven.engine.table.impl.updateby.rollinggroup.RollingGroupOperator.Context
 
accumulateCumulative(RowSequence, Chunk<? extends Values>[], LongChunk<? extends Values>, int) - Method in class io.deephaven.engine.table.impl.updateby.UpdateByOperator.Context
 
accumulatedCycleStats - Variable in class io.deephaven.engine.updategraph.impl.BaseUpdateGraph
 
AccumulatedCycleStats() - Constructor for class io.deephaven.engine.updategraph.impl.BaseUpdateGraph.AccumulatedCycleStats
 
accumulateDigests(ObjectVector<TDigest>) - Static method in class io.deephaven.engine.table.impl.by.ApproximatePercentile
Accumulate a Vector of TDigests into a single new TDigest.
accumulatePeformanceEntry(BasePerformanceEntry) - Method in class io.deephaven.engine.table.impl.MergedListener
 
accumulateRolling(RowSequence, Chunk<? extends Values>[], LongChunk<OrderedRowKeys>, LongChunk<OrderedRowKeys>, IntChunk<? extends Values>, IntChunk<? extends Values>, int) - Method in class io.deephaven.engine.table.impl.updateby.internal.BaseByteUpdateByOperator.Context
 
accumulateRolling(RowSequence, Chunk<? extends Values>[], LongChunk<OrderedRowKeys>, LongChunk<OrderedRowKeys>, IntChunk<? extends Values>, IntChunk<? extends Values>, int) - Method in class io.deephaven.engine.table.impl.updateby.internal.BaseCharUpdateByOperator.Context
 
accumulateRolling(RowSequence, Chunk<? extends Values>[], LongChunk<OrderedRowKeys>, LongChunk<OrderedRowKeys>, IntChunk<? extends Values>, IntChunk<? extends Values>, int) - Method in class io.deephaven.engine.table.impl.updateby.internal.BaseDoubleUpdateByOperator.Context
 
accumulateRolling(RowSequence, Chunk<? extends Values>[], LongChunk<OrderedRowKeys>, LongChunk<OrderedRowKeys>, IntChunk<? extends Values>, IntChunk<? extends Values>, int) - Method in class io.deephaven.engine.table.impl.updateby.internal.BaseFloatUpdateByOperator.Context
 
accumulateRolling(RowSequence, Chunk<? extends Values>[], LongChunk<OrderedRowKeys>, LongChunk<OrderedRowKeys>, IntChunk<? extends Values>, IntChunk<? extends Values>, int) - Method in class io.deephaven.engine.table.impl.updateby.internal.BaseIntUpdateByOperator.Context
 
accumulateRolling(RowSequence, Chunk<? extends Values>[], LongChunk<OrderedRowKeys>, LongChunk<OrderedRowKeys>, IntChunk<? extends Values>, IntChunk<? extends Values>, int) - Method in class io.deephaven.engine.table.impl.updateby.internal.BaseLongUpdateByOperator.Context
 
accumulateRolling(RowSequence, Chunk<? extends Values>[], LongChunk<OrderedRowKeys>, LongChunk<OrderedRowKeys>, IntChunk<? extends Values>, IntChunk<? extends Values>, int) - Method in class io.deephaven.engine.table.impl.updateby.internal.BaseObjectUpdateByOperator.Context
 
accumulateRolling(RowSequence, Chunk<? extends Values>[], LongChunk<OrderedRowKeys>, LongChunk<OrderedRowKeys>, IntChunk<? extends Values>, IntChunk<? extends Values>, int) - Method in class io.deephaven.engine.table.impl.updateby.internal.BaseShortUpdateByOperator.Context
 
accumulateRolling(RowSequence, Chunk<? extends Values>[], LongChunk<OrderedRowKeys>, LongChunk<OrderedRowKeys>, IntChunk<? extends Values>, IntChunk<? extends Values>, int) - Method in class io.deephaven.engine.table.impl.updateby.rollingformula.BooleanRollingFormulaOperator.Context
 
accumulateRolling(RowSequence, Chunk<? extends Values>[], LongChunk<OrderedRowKeys>, LongChunk<OrderedRowKeys>, IntChunk<? extends Values>, IntChunk<? extends Values>, int) - Method in class io.deephaven.engine.table.impl.updateby.rollingformula.ByteRollingFormulaOperator.Context
 
accumulateRolling(RowSequence, Chunk<? extends Values>[], LongChunk<OrderedRowKeys>, LongChunk<OrderedRowKeys>, IntChunk<? extends Values>, IntChunk<? extends Values>, int) - Method in class io.deephaven.engine.table.impl.updateby.rollingformula.CharRollingFormulaOperator.Context
 
accumulateRolling(RowSequence, Chunk<? extends Values>[], LongChunk<OrderedRowKeys>, LongChunk<OrderedRowKeys>, IntChunk<? extends Values>, IntChunk<? extends Values>, int) - Method in class io.deephaven.engine.table.impl.updateby.rollingformula.DoubleRollingFormulaOperator.Context
 
accumulateRolling(RowSequence, Chunk<? extends Values>[], LongChunk<OrderedRowKeys>, LongChunk<OrderedRowKeys>, IntChunk<? extends Values>, IntChunk<? extends Values>, int) - Method in class io.deephaven.engine.table.impl.updateby.rollingformula.FloatRollingFormulaOperator.Context
 
accumulateRolling(RowSequence, Chunk<? extends Values>[], LongChunk<OrderedRowKeys>, LongChunk<OrderedRowKeys>, IntChunk<? extends Values>, IntChunk<? extends Values>, int) - Method in class io.deephaven.engine.table.impl.updateby.rollingformula.IntRollingFormulaOperator.Context
 
accumulateRolling(RowSequence, Chunk<? extends Values>[], LongChunk<OrderedRowKeys>, LongChunk<OrderedRowKeys>, IntChunk<? extends Values>, IntChunk<? extends Values>, int) - Method in class io.deephaven.engine.table.impl.updateby.rollingformula.LongRollingFormulaOperator.Context
 
accumulateRolling(RowSequence, Chunk<? extends Values>[], LongChunk<OrderedRowKeys>, LongChunk<OrderedRowKeys>, IntChunk<? extends Values>, IntChunk<? extends Values>, int) - Method in class io.deephaven.engine.table.impl.updateby.rollingformula.ObjectRollingFormulaOperator.Context
 
accumulateRolling(RowSequence, Chunk<? extends Values>[], LongChunk<OrderedRowKeys>, LongChunk<OrderedRowKeys>, IntChunk<? extends Values>, IntChunk<? extends Values>, int) - Method in class io.deephaven.engine.table.impl.updateby.rollingformula.ShortRollingFormulaOperator.Context
 
accumulateRolling(RowSequence, Chunk<? extends Values>[], LongChunk<OrderedRowKeys>, LongChunk<OrderedRowKeys>, IntChunk<? extends Values>, IntChunk<? extends Values>, int) - Method in class io.deephaven.engine.table.impl.updateby.rollinggroup.RollingGroupOperator.Context
 
accumulateRolling(RowSequence, Chunk<? extends Values>[], LongChunk<OrderedRowKeys>, LongChunk<OrderedRowKeys>, IntChunk<? extends Values>, IntChunk<? extends Values>, int) - Method in class io.deephaven.engine.table.impl.updateby.UpdateByOperator.Context
 
acos(byte) - Static method in class io.deephaven.function.Numeric
Returns the arc cosine.
acos(byte) - Static method in class io.deephaven.libs.GroovyStaticImports
 
acos(double) - Static method in class io.deephaven.function.Numeric
Returns the arc cosine.
acos(double) - Static method in class io.deephaven.libs.GroovyStaticImports
 
acos(float) - Static method in class io.deephaven.function.Numeric
Returns the arc cosine.
acos(float) - Static method in class io.deephaven.libs.GroovyStaticImports
 
acos(int) - Static method in class io.deephaven.function.Numeric
Returns the arc cosine.
acos(int) - Static method in class io.deephaven.libs.GroovyStaticImports
 
acos(long) - Static method in class io.deephaven.function.Numeric
Returns the arc cosine.
acos(long) - Static method in class io.deephaven.libs.GroovyStaticImports
 
acos(short) - Static method in class io.deephaven.function.Numeric
Returns the arc cosine.
acos(short) - Static method in class io.deephaven.libs.GroovyStaticImports
 
acquire() - Method in class io.deephaven.base.reference.PooledObjectReference
Acquire an active use permit.
acquire() - Method in class io.deephaven.engine.rowset.impl.RefCountedCow
Increase our reference count.
acquire() - Method in class io.deephaven.engine.table.impl.TableUpdateImpl
 
acquire() - Method in interface io.deephaven.engine.table.TableUpdate
Increment the reference count on this object.
acquire(int) - Method in class io.deephaven.base.FIFOSemaphore
 
acquire(int) - Method in class io.deephaven.base.UnfairSemaphore
 
acquireAll() - Method in class io.deephaven.base.FIFOSemaphore
 
acquireAll() - Method in class io.deephaven.base.UnfairSemaphore
 
acquireAndGet() - Method in class io.deephaven.base.reference.PooledObjectReference
Acquire an active use permit and return the referent, if possible.
acquireIfAvailable() - Method in class io.deephaven.base.reference.PooledObjectReference
Acquire an active use permit if this has not been cleared.
activate() - Method in class io.deephaven.util.datastructures.SubscriptionSet.Entry
Activate this subscription entry.
activateAllOptionals(String) - Method in class io.deephaven.engine.table.impl.util.codegen.CodeGenerator
 
activateOptional(String) - Method in class io.deephaven.engine.table.impl.util.codegen.CodeGenerator
 
activateUnderlyingDataSource() - Method in class io.deephaven.engine.table.impl.locations.impl.PollingTableLocationProvider
 
activateUnderlyingDataSource() - Method in class io.deephaven.engine.table.impl.locations.impl.SubscriptionAggregator
Refresh and activate update pushing from the implementing class.
activationFailed(T, TableDataException) - Method in class io.deephaven.engine.table.impl.locations.impl.SubscriptionAggregator
Deliver an exception triggered while activating or maintaining the underlying data source.
activationSuccessful(T) - Method in class io.deephaven.engine.table.impl.locations.impl.SubscriptionAggregator
Notify the implementation that activation has completed.
ACTIVE_PARAMETER_FIELD_NUMBER - Static variable in class io.deephaven.proto.backplane.script.grpc.GetSignatureHelpResponse
 
ACTIVE_PARAMETER_FIELD_NUMBER - Static variable in class io.deephaven.proto.backplane.script.grpc.SignatureInformation
 
ACTIVE_SIGNATURE_FIELD_NUMBER - Static variable in class io.deephaven.proto.backplane.script.grpc.GetSignatureHelpResponse
 
ACTIVE_SIGNATURE_HELP_FIELD_NUMBER - Static variable in class io.deephaven.proto.backplane.script.grpc.SignatureHelpContext
 
adapt(Runnable) - Static method in class io.deephaven.util.process.OnetimeShutdownTask
 
adapt(TableHandle) - Method in class io.deephaven.client.impl.TableHandle
 
adapt(Aggregation) - Static method in class io.deephaven.server.table.ops.AggregationAdapter
 
adapt(Aggregation.AggregationColumns) - Static method in class io.deephaven.server.table.ops.AggregationAdapter
 
adapt(Aggregation.AggregationCount) - Static method in class io.deephaven.server.table.ops.AggregationAdapter
 
adapt(Aggregation.AggregationPartition) - Static method in class io.deephaven.server.table.ops.AggregationAdapter
 
adapt(StackTraceMixIn<TOPS, TABLE>) - Method in class io.deephaven.qst.table.StackTraceMixIn
 
adapt(TableSpec) - Method in class io.deephaven.client.impl.TableHandle
 
adapt(IntToLongFunction) - Static method in interface io.deephaven.kafka.KafkaTools.InitialOffsetLookup
Creates a implementation based solely on the topic partition.
adapt(T) - Method in interface io.deephaven.server.barrage.BarrageMessageProducer.Adapter
 
adapt(TABLE_1) - Method in class io.deephaven.api.TableOperationsAdapter
 
adapt(TOPS) - Method in class io.deephaven.qst.table.StackTraceMixIn
 
adapt(TOPS) - Method in class io.deephaven.qst.table.StackTraceMixInCreator
 
adapt(TOPS_2) - Method in class io.deephaven.api.TableOperationsAdapter
 
Adapter() - Constructor for class io.deephaven.util.datastructures.intrusive.IntrusiveSoftLRU.Node.Adapter
 
Adapter(ByteBufferSink, ByteBuffer) - Constructor for class io.deephaven.io.streams.CurrentByteBufferSink.Adapter
 
adaptFirst(Aggregation.AggregationRowKey) - Static method in class io.deephaven.server.table.ops.AggregationAdapter
 
AdaptiveOrderedLongSetBuilderRandom - Class in io.deephaven.engine.rowset.impl
 
AdaptiveOrderedLongSetBuilderRandom() - Constructor for class io.deephaven.engine.rowset.impl.AdaptiveOrderedLongSetBuilderRandom
 
AdaptiveRowSetBuilderRandom - Class in io.deephaven.engine.rowset.impl
RowSetBuilderRandom implementation that uses an adaptive pattern based on workload.
AdaptiveRowSetBuilderRandom() - Constructor for class io.deephaven.engine.rowset.impl.AdaptiveRowSetBuilderRandom
 
adaptLast(Aggregation.AggregationRowKey) - Static method in class io.deephaven.server.table.ops.AggregationAdapter
 
adaptToOfDouble(FloatToDoubleFunction) - Method in interface io.deephaven.engine.primitive.iterator.CloseablePrimitiveIteratorOfFloat
Adapt this CloseablePrimitiveIteratorOfFloat to a CloseablePrimitiveIteratorOfDouble, applying adapter to each element.
adaptToOfInt(ByteToIntFunction) - Method in interface io.deephaven.engine.primitive.iterator.CloseablePrimitiveIteratorOfByte
Adapt this CloseablePrimitiveIteratorOfByte to a CloseablePrimitiveIteratorOfInt, applying adapter to each element.
adaptToOfInt(CharToIntFunction) - Method in interface io.deephaven.engine.primitive.iterator.CloseablePrimitiveIteratorOfChar
Adapt this CloseablePrimitiveIteratorOfChar to a CloseablePrimitiveIteratorOfInt, applying adapter to each element.
adaptToOfInt(ShortToIntFunction) - Method in interface io.deephaven.engine.primitive.iterator.CloseablePrimitiveIteratorOfShort
Adapt this CloseablePrimitiveIteratorOfShort to a CloseablePrimitiveIteratorOfInt, applying adapter to each element.
add(boolean) - Method in class io.deephaven.base.array.FastBooleanArray
 
add(boolean) - Method in class io.deephaven.chunk.WritableBooleanChunk
 
add(boolean[], int, int) - Method in class io.deephaven.base.array.FastBooleanArray
 
add(boolean, SafeCloseable, RowSequence, ColumnSource<?>[], MutableInt, WritableIntChunk<RowKeys>) - Method in class io.deephaven.engine.table.impl.updateby.hashing.UpdateByStateManager
 
add(boolean, SafeCloseable, RowSequence, ColumnSource<?>[], MutableInt, WritableIntChunk<RowKeys>) - Method in class io.deephaven.engine.table.impl.updateby.hashing.UpdateByStateManagerTypedBase
 
add(byte) - Method in class io.deephaven.base.array.FastByteArray
 
add(byte) - Method in class io.deephaven.base.ringbuffer.AggregatingByteRingBuffer
Adds an entry to the ring buffer.
add(byte) - Method in class io.deephaven.base.ringbuffer.ByteRingBuffer
Adds an entry to the ring buffer, will throw an exception if buffer is full.
add(byte) - Method in class io.deephaven.chunk.WritableByteChunk
 
add(byte) - Method in class io.deephaven.qst.array.BooleanArray.Builder
 
add(byte) - Method in class io.deephaven.qst.array.ByteArray.Builder
 
add(byte...) - Method in class io.deephaven.qst.array.BooleanArray.Builder
 
add(byte...) - Method in class io.deephaven.qst.array.ByteArray.Builder
 
add(byte[], int, int) - Method in class io.deephaven.base.array.FastByteArray
 
add(char) - Method in class io.deephaven.base.array.FastCharArray
 
add(char) - Method in class io.deephaven.base.ringbuffer.AggregatingCharRingBuffer
Adds an entry to the ring buffer.
add(char) - Method in class io.deephaven.base.ringbuffer.CharRingBuffer
Adds an entry to the ring buffer, will throw an exception if buffer is full.
add(char) - Method in class io.deephaven.chunk.WritableCharChunk
 
add(char) - Method in class io.deephaven.qst.array.CharArray.Builder
 
add(char...) - Method in class io.deephaven.qst.array.CharArray.Builder
 
add(char[], int, int) - Method in class io.deephaven.base.array.FastCharArray
 
add(double) - Method in class io.deephaven.base.array.FastDoubleArray
 
add(double) - Method in class io.deephaven.base.ringbuffer.AggregatingDoubleRingBuffer
Adds an entry to the ring buffer.
add(double) - Method in class io.deephaven.base.ringbuffer.DoubleRingBuffer
Adds an entry to the ring buffer, will throw an exception if buffer is full.
add(double) - Method in class io.deephaven.chunk.WritableDoubleChunk
 
add(double) - Method in class io.deephaven.numerics.suanshu.SuanShuIntegration.AbstractVector
 
add(double) - Method in class io.deephaven.qst.array.DoubleArray.Builder
 
add(double...) - Method in class io.deephaven.qst.array.DoubleArray.Builder
 
add(double[], int, int) - Method in class io.deephaven.base.array.FastDoubleArray
 
add(float) - Method in class io.deephaven.base.array.FastFloatArray
 
add(float) - Method in class io.deephaven.base.ringbuffer.AggregatingFloatRingBuffer
Adds an entry to the ring buffer.
add(float) - Method in class io.deephaven.base.ringbuffer.FloatRingBuffer
Adds an entry to the ring buffer, will throw an exception if buffer is full.
add(float) - Method in class io.deephaven.chunk.WritableFloatChunk
 
add(float) - Method in class io.deephaven.qst.array.FloatArray.Builder
 
add(float...) - Method in class io.deephaven.qst.array.FloatArray.Builder
 
add(float[], int, int) - Method in class io.deephaven.base.array.FastFloatArray
 
add(int) - Method in class io.deephaven.base.array.FastIntArray
 
add(int) - Method in class io.deephaven.base.ringbuffer.AggregatingIntRingBuffer
Adds an entry to the ring buffer.
add(int) - Method in class io.deephaven.base.ringbuffer.IntRingBuffer
Adds an entry to the ring buffer, will throw an exception if buffer is full.
add(int) - Method in class io.deephaven.chunk.WritableIntChunk
 
add(int) - Method in class io.deephaven.qst.array.IntArray.Builder
 
add(int) - Method in class io.deephaven.util.mutable.MutableInt
 
add(int...) - Method in class io.deephaven.qst.array.IntArray.Builder
 
add(int[], int, int) - Method in class io.deephaven.base.array.FastIntArray
 
add(int, int) - Method in class io.deephaven.engine.rowset.impl.rsp.container.ArrayContainer
 
add(int, int) - Method in class io.deephaven.engine.rowset.impl.rsp.container.BitmapContainer
 
add(int, int) - Method in class io.deephaven.engine.rowset.impl.rsp.container.Container
Return a new container with all shorts in [begin,end) added using an unsigned interpretation.
add(int, int) - Method in class io.deephaven.engine.rowset.impl.rsp.container.EmptyContainer
 
add(int, int) - Method in class io.deephaven.engine.rowset.impl.rsp.container.RunContainer
 
add(int, int) - Method in class io.deephaven.engine.rowset.impl.rsp.container.SingleRangeContainer
 
add(int, int) - Method in class io.deephaven.engine.rowset.impl.rsp.container.SingletonContainer
 
add(int, int) - Method in class io.deephaven.engine.rowset.impl.rsp.container.TwoValuesContainer
 
add(long) - Method in class io.deephaven.base.array.FastLongArray
 
add(long) - Method in class io.deephaven.base.ringbuffer.AggregatingLongRingBuffer
Adds an entry to the ring buffer.
add(long) - Method in class io.deephaven.base.ringbuffer.LongRingBuffer
Adds an entry to the ring buffer, will throw an exception if buffer is full.
add(long) - Method in class io.deephaven.chunk.WritableLongChunk
 
add(long) - Method in class io.deephaven.engine.rowset.impl.rsp.RspBitmap
 
add(long) - Method in class io.deephaven.engine.rowset.impl.sortedranges.SortedRanges
 
add(long) - Method in class io.deephaven.qst.array.LongArray.Builder
 
add(long) - Method in class io.deephaven.util.mutable.MutableLong
 
add(long...) - Method in class io.deephaven.qst.array.LongArray.Builder
 
add(long[], int, int) - Method in class io.deephaven.base.array.FastLongArray
 
add(short) - Method in class io.deephaven.base.array.FastShortArray
 
add(short) - Method in class io.deephaven.base.ringbuffer.AggregatingShortRingBuffer
Adds an entry to the ring buffer.
add(short) - Method in class io.deephaven.base.ringbuffer.ShortRingBuffer
Adds an entry to the ring buffer, will throw an exception if buffer is full.
add(short) - Method in class io.deephaven.chunk.WritableShortChunk
 
add(short) - Method in class io.deephaven.qst.array.ShortArray.Builder
 
add(short...) - Method in class io.deephaven.qst.array.ShortArray.Builder
 
add(short[], int, int) - Method in class io.deephaven.base.array.FastShortArray
 
add(SafeCloseable, RowSequence, ColumnSource<?>[], MutableInt, WritableIntChunk<RowKeys>) - Method in class io.deephaven.engine.table.impl.by.IncrementalChunkedOperatorAggregationStateManagerOpenAddressedBase
 
add(Object) - Method in class io.deephaven.engine.table.impl.select.setinclusion.ByteSetInclusionKernel
 
add(Object) - Method in class io.deephaven.engine.table.impl.select.setinclusion.CharSetInclusionKernel
 
add(Object) - Method in class io.deephaven.engine.table.impl.select.setinclusion.DoubleSetInclusionKernel
 
add(Object) - Method in class io.deephaven.engine.table.impl.select.setinclusion.FloatSetInclusionKernel
 
add(Object) - Method in class io.deephaven.engine.table.impl.select.setinclusion.IntSetInclusionKernel
 
add(Object) - Method in class io.deephaven.engine.table.impl.select.setinclusion.LongSetInclusionKernel
 
add(Object) - Method in class io.deephaven.engine.table.impl.select.setinclusion.ObjectSetInclusionKernel
 
add(Object) - Method in class io.deephaven.engine.table.impl.select.setinclusion.ShortSetInclusionKernel
 
add(Matrix) - Method in class io.deephaven.numerics.suanshu.SuanShuIntegration.AbstractMatrix
 
add(Vector) - Method in class io.deephaven.numerics.suanshu.SuanShuIntegration.AbstractVector
 
add(E) - Method in class io.deephaven.base.RingBuffer
 
add(RspBitmap, boolean) - Method in class io.deephaven.engine.rowset.impl.AdaptiveOrderedLongSetBuilderRandom
 
add(RspBitmap, boolean) - Method in class io.deephaven.engine.rowset.impl.MixedBuilderRandom
 
add(RspBitmap, boolean) - Method in interface io.deephaven.engine.rowset.impl.OrderedLongSet.BuilderRandom
 
add(RspBitmap, boolean) - Method in class io.deephaven.engine.rowset.impl.rsp.RspBitmap.BuilderRandom
 
add(SingleRange) - Method in interface io.deephaven.engine.rowset.impl.OrderedLongSet.BuilderRandom
 
add(SortedRanges, boolean) - Method in class io.deephaven.engine.rowset.impl.AdaptiveOrderedLongSetBuilderRandom
 
add(SortedRanges, boolean) - Method in class io.deephaven.engine.rowset.impl.MixedBuilderRandom
 
add(SortedRanges, boolean) - Method in interface io.deephaven.engine.rowset.impl.OrderedLongSet.BuilderRandom
 
add(SortedRanges, boolean) - Method in class io.deephaven.engine.rowset.impl.rsp.RspBitmap.BuilderRandom
 
add(Table) - Method in interface io.deephaven.engine.util.input.InputTableUpdater
Write newData to this table.
add(Table) - Method in class io.deephaven.stream.TablePublisher
Adds a snapshot of the data from table into the blink table.
add(SeriesCollection.SeriesType, boolean, SeriesInternal) - Method in class io.deephaven.plot.SeriesCollection
Add a new Series.
add(LabeledValue<T>) - Method in interface io.deephaven.qst.LabeledValues.Builder
 
add(SafeCloseable, RowSequence, ColumnSource<?>[], MutableInt, WritableIntChunk<RowKeys>) - Method in interface io.deephaven.engine.table.impl.by.IncrementalOperatorAggregationStateManager
 
add(SafeCloseable, RowSequence, ColumnSource<?>[], MutableInt, WritableIntChunk<RowKeys>) - Method in class io.deephaven.engine.table.impl.by.StaticChunkedOperatorAggregationStateManagerOpenAddressedBase
 
add(SafeCloseable, RowSequence, ColumnSource<?>[], MutableInt, WritableIntChunk<RowKeys>) - Method in class io.deephaven.engine.table.impl.by.StaticSymbolTableChunkedOperatorAggregationStateManager
 
add(Boolean) - Method in class io.deephaven.qst.array.BooleanArray.Builder
 
add(Boolean...) - Method in class io.deephaven.qst.array.BooleanArray.Builder
 
add(Byte) - Method in class io.deephaven.qst.array.ByteArray.Builder
 
add(Byte...) - Method in class io.deephaven.qst.array.ByteArray.Builder
 
add(Character) - Method in class io.deephaven.qst.array.CharArray.Builder
 
add(Character...) - Method in class io.deephaven.qst.array.CharArray.Builder
 
add(Comparable, PlotInfo) - Method in class io.deephaven.plot.datasets.DynamicSeriesNamer
Adds a new series name to the namer.
add(Double) - Method in class io.deephaven.qst.array.DoubleArray.Builder
 
add(Double...) - Method in class io.deephaven.qst.array.DoubleArray.Builder
 
add(Float) - Method in class io.deephaven.qst.array.FloatArray.Builder
 
add(Float...) - Method in class io.deephaven.qst.array.FloatArray.Builder
 
add(Integer) - Method in class io.deephaven.qst.array.IntArray.Builder
 
add(Integer...) - Method in class io.deephaven.qst.array.IntArray.Builder
 
add(Iterable<Boolean>) - Method in class io.deephaven.qst.array.BooleanArray.Builder
 
add(Iterable<Byte>) - Method in class io.deephaven.qst.array.ByteArray.Builder
 
add(Iterable<Character>) - Method in class io.deephaven.qst.array.CharArray.Builder
 
add(Iterable<Double>) - Method in class io.deephaven.qst.array.DoubleArray.Builder
 
add(Iterable<Float>) - Method in class io.deephaven.qst.array.FloatArray.Builder
 
add(Iterable<Integer>) - Method in class io.deephaven.qst.array.IntArray.Builder
 
add(Iterable<Long>) - Method in class io.deephaven.qst.array.LongArray.Builder
 
add(Iterable<Short>) - Method in class io.deephaven.qst.array.ShortArray.Builder
 
add(Iterable<T>) - Method in class io.deephaven.qst.array.GenericArray.Builder
 
add(Iterable<TYPE>) - Method in interface io.deephaven.qst.array.ArrayBuilder
 
add(Long) - Method in class io.deephaven.qst.array.LongArray.Builder
 
add(Long...) - Method in class io.deephaven.qst.array.LongArray.Builder
 
add(Object) - Method in interface io.deephaven.engine.table.impl.dataindex.DataIndexKeySet
 
add(Object) - Method in interface io.deephaven.engine.table.impl.select.setinclusion.SetInclusionKernel
 
add(Short) - Method in class io.deephaven.qst.array.ShortArray.Builder
 
add(Short...) - Method in class io.deephaven.qst.array.ShortArray.Builder
 
add(String) - Method in class io.deephaven.parquet.table.transfer.StringDictionary
Add a string key to the dictionary if it's not already present.
add(String, Class) - Method in class io.deephaven.engine.util.ColumnsSpecHelper
 
add(String, T) - Method in class io.deephaven.lang.completion.results.FuzzyList
 
add(String, T) - Method in interface io.deephaven.qst.LabeledValues.Builder
 
add(LISTENER_TYPE, SubscriptionSet.Entry) - Method in class io.deephaven.util.datastructures.SubscriptionSet
Add a listener to the set, if it's not already present.
add(T) - Method in class io.deephaven.base.array.FastArray
 
add(T) - Method in class io.deephaven.base.LowGarbageArraySet
 
add(T) - Method in class io.deephaven.base.ringbuffer.AggregatingObjectRingBuffer
Adds an entry to the ring buffer.
add(T) - Method in class io.deephaven.base.ringbuffer.ObjectRingBuffer
Adds an entry to the ring buffer, will throw an exception if buffer is full.
add(T) - Method in class io.deephaven.base.WeakReferenceManager
Add the specified item to the list.
add(T) - Method in class io.deephaven.chunk.WritableObjectChunk
 
add(T) - Method in class io.deephaven.qst.array.GenericArray.Builder
 
add(T) - Method in class io.deephaven.util.datastructures.intrusive.IntrusiveArraySet
 
add(T) - Method in class io.deephaven.util.datastructures.RandomAccessDeque
 
add(T) - Method in class io.deephaven.util.datastructures.SimpleReferenceManager
Add the specified item to the list.
add(T) - Method in class io.deephaven.util.SafeCloseableList
 
add(T...) - Method in class io.deephaven.qst.array.GenericArray.Builder
 
add(T[], int, int) - Method in class io.deephaven.base.array.FastArray
 
add(TYPE) - Method in interface io.deephaven.qst.array.ArrayBuilder
 
add(TYPE) - Method in class io.deephaven.util.datastructures.WeakIdentityHashSet
Add a value to the set if its not already present.
add(TYPE) - Method in class io.deephaven.util.datastructures.WeakIdentityHashSet.Synchronized
 
add(TYPE...) - Method in interface io.deephaven.qst.array.ArrayBuilder
 
add(TYPE, WeakReference<? extends TYPE>) - Method in class io.deephaven.util.datastructures.WeakIdentityHashSet
Add a value to the set if its not already present.
add(TYPE, WeakReference<? extends TYPE>) - Method in class io.deephaven.util.datastructures.WeakIdentityHashSet.Synchronized
 
ADD_ONLY_TABLE_ATTRIBUTE - Static variable in interface io.deephaven.engine.table.Table
If this attribute is set, we can only add new row keys, we can never shift them, modify them, or remove them.
addAdditionalTextEdits(int, TextEdit) - Method in class io.deephaven.proto.backplane.script.grpc.CompletionItem.Builder
repeated .io.deephaven.proto.backplane.script.grpc.TextEdit additional_text_edits = 13;
addAdditionalTextEdits(int, TextEdit.Builder) - Method in class io.deephaven.proto.backplane.script.grpc.CompletionItem.Builder
repeated .io.deephaven.proto.backplane.script.grpc.TextEdit additional_text_edits = 13;
addAdditionalTextEdits(TextEdit) - Method in class io.deephaven.proto.backplane.script.grpc.CompletionItem.Builder
repeated .io.deephaven.proto.backplane.script.grpc.TextEdit additional_text_edits = 13;
addAdditionalTextEdits(TextEdit.Builder) - Method in class io.deephaven.proto.backplane.script.grpc.CompletionItem.Builder
repeated .io.deephaven.proto.backplane.script.grpc.TextEdit additional_text_edits = 13;
addAdditionalTextEditsBuilder() - Method in class io.deephaven.proto.backplane.script.grpc.CompletionItem.Builder
repeated .io.deephaven.proto.backplane.script.grpc.TextEdit additional_text_edits = 13;
addAdditionalTextEditsBuilder(int) - Method in class io.deephaven.proto.backplane.script.grpc.CompletionItem.Builder
repeated .io.deephaven.proto.backplane.script.grpc.TextEdit additional_text_edits = 13;
addAdditions(JoinAddition) - Method in interface io.deephaven.qst.table.Join.Builder
 
addAdditions(JoinAddition) - Method in interface io.deephaven.qst.table.MultiJoinInput.Builder
 
addAdditions(JoinAddition...) - Method in interface io.deephaven.qst.table.Join.Builder
 
addAdditions(JoinAddition...) - Method in interface io.deephaven.qst.table.MultiJoinInput.Builder
 
addAggregates(int, ComboAggregateRequest.Aggregate) - Method in class io.deephaven.proto.backplane.grpc.ComboAggregateRequest.Builder
Deprecated.
repeated .io.deephaven.proto.backplane.grpc.ComboAggregateRequest.Aggregate aggregates = 3;
addAggregates(int, ComboAggregateRequest.Aggregate.Builder) - Method in class io.deephaven.proto.backplane.grpc.ComboAggregateRequest.Builder
Deprecated.
repeated .io.deephaven.proto.backplane.grpc.ComboAggregateRequest.Aggregate aggregates = 3;
addAggregates(ComboAggregateRequest.Aggregate) - Method in class io.deephaven.proto.backplane.grpc.ComboAggregateRequest.Builder
Deprecated.
repeated .io.deephaven.proto.backplane.grpc.ComboAggregateRequest.Aggregate aggregates = 3;
addAggregates(ComboAggregateRequest.Aggregate.Builder) - Method in class io.deephaven.proto.backplane.grpc.ComboAggregateRequest.Builder
Deprecated.
repeated .io.deephaven.proto.backplane.grpc.ComboAggregateRequest.Aggregate aggregates = 3;
addAggregatesBuilder() - Method in class io.deephaven.proto.backplane.grpc.ComboAggregateRequest.Builder
Deprecated.
repeated .io.deephaven.proto.backplane.grpc.ComboAggregateRequest.Aggregate aggregates = 3;
addAggregatesBuilder(int) - Method in class io.deephaven.proto.backplane.grpc.ComboAggregateRequest.Builder
Deprecated.
repeated .io.deephaven.proto.backplane.grpc.ComboAggregateRequest.Aggregate aggregates = 3;
addAggregations(int, Aggregation) - Method in class io.deephaven.proto.backplane.grpc.AggregateRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.Aggregation aggregations = 5;
addAggregations(int, Aggregation) - Method in class io.deephaven.proto.backplane.grpc.RangeJoinTablesRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.Aggregation aggregations = 10;
addAggregations(int, Aggregation) - Method in class io.deephaven.proto.backplane.grpc.RollupRequest.Builder
The aggregations that should be applied at each level of the rollup
addAggregations(int, Aggregation.Builder) - Method in class io.deephaven.proto.backplane.grpc.AggregateRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.Aggregation aggregations = 5;
addAggregations(int, Aggregation.Builder) - Method in class io.deephaven.proto.backplane.grpc.RangeJoinTablesRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.Aggregation aggregations = 10;
addAggregations(int, Aggregation.Builder) - Method in class io.deephaven.proto.backplane.grpc.RollupRequest.Builder
The aggregations that should be applied at each level of the rollup
addAggregations(Aggregation) - Method in interface io.deephaven.api.agg.Aggregations.Builder
 
addAggregations(Aggregation) - Method in interface io.deephaven.qst.table.AggregateTable.Builder
 
addAggregations(Aggregation) - Method in interface io.deephaven.qst.table.RangeJoinTable.Builder
 
addAggregations(Aggregation...) - Method in interface io.deephaven.api.agg.Aggregations.Builder
 
addAggregations(Aggregation...) - Method in interface io.deephaven.qst.table.AggregateTable.Builder
 
addAggregations(Aggregation...) - Method in interface io.deephaven.qst.table.RangeJoinTable.Builder
 
addAggregations(Aggregation) - Method in class io.deephaven.proto.backplane.grpc.AggregateRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.Aggregation aggregations = 5;
addAggregations(Aggregation) - Method in class io.deephaven.proto.backplane.grpc.RangeJoinTablesRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.Aggregation aggregations = 10;
addAggregations(Aggregation) - Method in class io.deephaven.proto.backplane.grpc.RollupRequest.Builder
The aggregations that should be applied at each level of the rollup
addAggregations(Aggregation.Builder) - Method in class io.deephaven.proto.backplane.grpc.AggregateRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.Aggregation aggregations = 5;
addAggregations(Aggregation.Builder) - Method in class io.deephaven.proto.backplane.grpc.RangeJoinTablesRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.Aggregation aggregations = 10;
addAggregations(Aggregation.Builder) - Method in class io.deephaven.proto.backplane.grpc.RollupRequest.Builder
The aggregations that should be applied at each level of the rollup
addAggregationsBuilder() - Method in class io.deephaven.proto.backplane.grpc.AggregateRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.Aggregation aggregations = 5;
addAggregationsBuilder() - Method in class io.deephaven.proto.backplane.grpc.RangeJoinTablesRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.Aggregation aggregations = 10;
addAggregationsBuilder() - Method in class io.deephaven.proto.backplane.grpc.RollupRequest.Builder
The aggregations that should be applied at each level of the rollup
addAggregationsBuilder(int) - Method in class io.deephaven.proto.backplane.grpc.AggregateRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.Aggregation aggregations = 5;
addAggregationsBuilder(int) - Method in class io.deephaven.proto.backplane.grpc.RangeJoinTablesRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.Aggregation aggregations = 10;
addAggregationsBuilder(int) - Method in class io.deephaven.proto.backplane.grpc.RollupRequest.Builder
The aggregations that should be applied at each level of the rollup
addAlias(String, String) - Static method in class io.deephaven.time.TimeZoneAliases
Adds a new time zone alias.
addAliases(String) - Method in interface io.deephaven.json.ObjectField.Builder
 
addAliases(String...) - Method in interface io.deephaven.json.ObjectField.Builder
 
addAll(Collection<? extends T>) - Method in class io.deephaven.util.datastructures.intrusive.IntrusiveArraySet
 
addAll(Collection<? extends T>) - Method in class io.deephaven.util.datastructures.RandomAccessDeque
 
addAll(List<AutoCloseable>) - Method in class io.deephaven.util.SafeCloseableList
 
addAllAdditionalTextEdits(Iterable<? extends TextEdit>) - Method in class io.deephaven.proto.backplane.script.grpc.CompletionItem.Builder
repeated .io.deephaven.proto.backplane.script.grpc.TextEdit additional_text_edits = 13;
addAllAdditions(Iterable<? extends JoinAddition>) - Method in interface io.deephaven.qst.table.Join.Builder
 
addAllAdditions(Iterable<? extends JoinAddition>) - Method in interface io.deephaven.qst.table.MultiJoinInput.Builder
 
addAllAggregates(Iterable<? extends ComboAggregateRequest.Aggregate>) - Method in class io.deephaven.proto.backplane.grpc.ComboAggregateRequest.Builder
Deprecated.
repeated .io.deephaven.proto.backplane.grpc.ComboAggregateRequest.Aggregate aggregates = 3;
addAllAggregations(Iterable<? extends Aggregation>) - Method in interface io.deephaven.api.agg.Aggregations.Builder
 
addAllAggregations(Iterable<? extends Aggregation>) - Method in interface io.deephaven.qst.table.AggregateTable.Builder
 
addAllAggregations(Iterable<? extends Aggregation>) - Method in interface io.deephaven.qst.table.RangeJoinTable.Builder
 
addAllAggregations(Iterable<? extends Aggregation>) - Method in class io.deephaven.proto.backplane.grpc.AggregateRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.Aggregation aggregations = 5;
addAllAggregations(Iterable<? extends Aggregation>) - Method in class io.deephaven.proto.backplane.grpc.RangeJoinTablesRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.Aggregation aggregations = 10;
addAllAggregations(Iterable<? extends Aggregation>) - Method in class io.deephaven.proto.backplane.grpc.RollupRequest.Builder
The aggregations that should be applied at each level of the rollup
addAllAliases(Iterable<String>) - Method in interface io.deephaven.json.ObjectField.Builder
 
addAllArguments(Iterable<? extends Expression>) - Method in interface io.deephaven.api.expression.Function.Builder
 
addAllArguments(Iterable<? extends Expression>) - Method in interface io.deephaven.api.expression.Method.Builder
 
addAllArguments(Iterable<? extends Value>) - Method in class io.deephaven.proto.backplane.grpc.InvokeCondition.Builder
repeated .io.deephaven.proto.backplane.grpc.Value arguments = 3;
addAllAxes(Iterable<? extends FigureDescriptor.AxisDescriptor>) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.ChartDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.AxisDescriptor axes = 5;
addAllBusinessDays(Iterable<? extends FigureDescriptor.BusinessCalendarDescriptor.DayOfWeek>) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BusinessCalendarDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BusinessCalendarDescriptor.DayOfWeek business_days = 3;
addAllBusinessDaysValue(Iterable<Integer>) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BusinessCalendarDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BusinessCalendarDescriptor.DayOfWeek business_days = 3;
addAllBusinessPeriods(Iterable<? extends FigureDescriptor.BusinessCalendarDescriptor.BusinessPeriod>) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BusinessCalendarDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BusinessCalendarDescriptor.BusinessPeriod business_periods = 4;
addAllBusinessPeriods(Iterable<? extends FigureDescriptor.BusinessCalendarDescriptor.BusinessPeriod>) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BusinessCalendarDescriptor.Holiday.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BusinessCalendarDescriptor.BusinessPeriod business_periods = 2;
addAllCandidates(Iterable<? extends Value>) - Method in class io.deephaven.proto.backplane.grpc.InCondition.Builder
repeated .io.deephaven.proto.backplane.grpc.Value candidates = 2;
addAllCertificates(Iterable<? extends Certificate>) - Method in interface io.deephaven.ssl.config.TrustCustom.Builder
 
addAllCharts(Iterable<? extends FigureDescriptor.ChartDescriptor>) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.ChartDescriptor charts = 10;
addAllColumnNames(Iterable<String>) - Method in class io.deephaven.proto.backplane.grpc.DropColumnsRequest.Builder
repeated string column_names = 3;
addAllColumnNames(Iterable<String>) - Method in class io.deephaven.proto.backplane.grpc.SelectDistinctRequest.Builder
repeated string column_names = 3;
addAllColumns(Iterable<? extends Pair>) - Method in interface io.deephaven.api.updateby.ColumnUpdateOperation.Builder
 
addAllColumns(Iterable<? extends Selectable>) - Method in interface io.deephaven.qst.table.SelectableTable.Builder
 
addAllColumns(Iterable<? extends SortColumn>) - Method in interface io.deephaven.api.agg.spec.AggSpecSortedFirst.Builder
 
addAllColumns(Iterable<? extends SortColumn>) - Method in interface io.deephaven.api.agg.spec.AggSpecSortedLast.Builder
 
addAllColumns(Iterable<? extends SortColumn>) - Method in interface io.deephaven.qst.table.SortTable.Builder
 
addAllColumns(Iterable<? extends AggSpec.AggSpecSortedColumn>) - Method in class io.deephaven.proto.backplane.grpc.AggSpec.AggSpecSorted.Builder
Using a message instead of string to support backwards-compatibility in the future
addAllColumns(Iterable<Column<?>>) - Method in interface io.deephaven.qst.table.NewTable.Builder
 
addAllColumns(Iterable<String>) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.OneClickDescriptor.Builder
repeated string columns = 1;
addAllColumnSpecs(Iterable<String>) - Method in class io.deephaven.proto.backplane.grpc.SelectOrUpdateRequest.Builder
repeated string column_specs = 3;
addAllColumnsToAdd(Iterable<String>) - Method in class io.deephaven.proto.backplane.grpc.AjRajTablesRequest.Builder
repeated string columns_to_add = 6;
addAllColumnsToAdd(Iterable<String>) - Method in class io.deephaven.proto.backplane.grpc.AsOfJoinTablesRequest.Builder
Deprecated.
repeated string columns_to_add = 5;
addAllColumnsToAdd(Iterable<String>) - Method in class io.deephaven.proto.backplane.grpc.CrossJoinTablesRequest.Builder
repeated string columns_to_add = 5;
addAllColumnsToAdd(Iterable<String>) - Method in class io.deephaven.proto.backplane.grpc.ExactJoinTablesRequest.Builder
repeated string columns_to_add = 5;
addAllColumnsToAdd(Iterable<String>) - Method in class io.deephaven.proto.backplane.grpc.LeftJoinTablesRequest.Builder
repeated string columns_to_add = 5;
addAllColumnsToAdd(Iterable<String>) - Method in class io.deephaven.proto.backplane.grpc.MultiJoinInput.Builder
The columns from the source table to include; if not provided, all columns are included.
addAllColumnsToAdd(Iterable<String>) - Method in class io.deephaven.proto.backplane.grpc.NaturalJoinTablesRequest.Builder
repeated string columns_to_add = 5;
addAllColumnsToMatch(Iterable<String>) - Method in class io.deephaven.proto.backplane.grpc.AsOfJoinTablesRequest.Builder
Deprecated.
repeated string columns_to_match = 4;
addAllColumnsToMatch(Iterable<String>) - Method in class io.deephaven.proto.backplane.grpc.CrossJoinTablesRequest.Builder
repeated string columns_to_match = 4;
addAllColumnsToMatch(Iterable<String>) - Method in class io.deephaven.proto.backplane.grpc.ExactJoinTablesRequest.Builder
repeated string columns_to_match = 4;
addAllColumnsToMatch(Iterable<String>) - Method in class io.deephaven.proto.backplane.grpc.LeftJoinTablesRequest.Builder
repeated string columns_to_match = 4;
addAllColumnsToMatch(Iterable<String>) - Method in class io.deephaven.proto.backplane.grpc.MultiJoinInput.Builder
The key columns to match; may be renamed to match other source table key columns.
addAllColumnsToMatch(Iterable<String>) - Method in class io.deephaven.proto.backplane.grpc.NaturalJoinTablesRequest.Builder
repeated string columns_to_match = 4;
addAllColumnsToMatch(Iterable<String>) - Method in class io.deephaven.proto.backplane.grpc.WhereInRequest.Builder
repeated string columns_to_match = 5;
addAllColumnsToUngroup(Iterable<String>) - Method in class io.deephaven.proto.backplane.grpc.UngroupRequest.Builder
repeated string columns_to_ungroup = 4;
addAllColumnTypes(Iterable<? extends ColumnTypeInfo>) - Method in interface io.deephaven.parquet.table.metadata.TableInfo.Builder
 
addAllColumnTypes(Iterable<String>) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.OneClickDescriptor.Builder
repeated string column_types = 2;
addAllCommitCharacters(Iterable<String>) - Method in class io.deephaven.proto.backplane.script.grpc.CompletionItem.Builder
repeated string commit_characters = 14;
addAllConsoleTypes(Iterable<String>) - Method in class io.deephaven.proto.backplane.script.grpc.GetConsoleTypesResponse.Builder
repeated string console_types = 1;
addAllContentChanges(Iterable<? extends ChangeDocumentRequest.TextDocumentContentChangeEvent>) - Method in class io.deephaven.proto.backplane.script.grpc.ChangeDocumentRequest.Builder
repeated .io.deephaven.proto.backplane.script.grpc.ChangeDocumentRequest.TextDocumentContentChangeEvent content_changes = 3;
addAllCreated(Iterable<? extends FieldInfo>) - Method in class io.deephaven.proto.backplane.grpc.FieldsChangeUpdate.Builder
repeated .io.deephaven.proto.backplane.grpc.FieldInfo created = 1;
addAllDataIndexes(Iterable<? extends DataIndexInfo>) - Method in interface io.deephaven.parquet.table.metadata.TableInfo.Builder
 
addAllDataSources(Iterable<? extends FigureDescriptor.MultiSeriesSourceDescriptor>) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.MultiSeriesDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.MultiSeriesSourceDescriptor data_sources = 14;
addAllDataSources(Iterable<? extends FigureDescriptor.SourceDescriptor>) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.SeriesDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.SourceDescriptor data_sources = 15;
addAllDiagnostics(Iterable<? extends Diagnostic>) - Method in class io.deephaven.proto.backplane.script.grpc.GetPublishDiagnosticResponse.Builder
repeated .io.deephaven.proto.backplane.script.grpc.Diagnostic diagnostics = 3;
addAllDropColumns(Iterable<? extends ColumnName>) - Method in interface io.deephaven.qst.table.DropColumnsTable.Builder
 
addAllElements(Iterable<String>) - Method in class io.deephaven.proto.backplane.grpc.TerminationNotificationResponse.StackTrace.Builder
repeated string elements = 3;
addAllErrors(Iterable<String>) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.Builder
repeated string errors = 13;
addAllExactMatchColumns(Iterable<String>) - Method in class io.deephaven.proto.backplane.grpc.AjRajTablesRequest.Builder
repeated string exact_match_columns = 4;
addAllExactMatchColumns(Iterable<String>) - Method in class io.deephaven.proto.backplane.grpc.RangeJoinTablesRequest.Builder
repeated string exact_match_columns = 4;
addAllExactMatches(Iterable<? extends JoinMatch>) - Method in interface io.deephaven.qst.table.RangeJoinTable.Builder
 
addAllExportedReferences(Iterable<? extends TypedTicket>) - Method in class io.deephaven.proto.backplane.grpc.ServerData.Builder
The exported references, may be empty.
addAllFields(Iterable<? extends ObjectField>) - Method in interface io.deephaven.json.ObjectValue.Builder
 
addAllFields(Collection<Field<?>>) - Method in interface io.deephaven.appmode.Fields.Builder
 
addAllFilters(Iterable<? extends Filter>) - Method in interface io.deephaven.api.filter.FilterAnd.Builder
 
addAllFilters(Iterable<? extends Filter>) - Method in interface io.deephaven.api.filter.FilterOr.Builder
 
addAllFilters(Iterable<? extends Condition>) - Method in class io.deephaven.proto.backplane.grpc.AndCondition.Builder
repeated .io.deephaven.proto.backplane.grpc.Condition filters = 1;
addAllFilters(Iterable<? extends Condition>) - Method in class io.deephaven.proto.backplane.grpc.FilterTableRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.Condition filters = 3;
addAllFilters(Iterable<? extends Condition>) - Method in class io.deephaven.proto.backplane.grpc.HierarchicalTableApplyRequest.Builder
Filters to apply to the input HierarchicalTable to produce the result HierarchicalTable.
addAllFilters(Iterable<? extends Condition>) - Method in class io.deephaven.proto.backplane.grpc.OrCondition.Builder
repeated .io.deephaven.proto.backplane.grpc.Condition filters = 1;
addAllFilters(Iterable<String>) - Method in class io.deephaven.proto.backplane.grpc.UnstructuredFilterTableRequest.Builder
repeated string filters = 3;
addAllFlags(Iterable<SnapshotWhenOptions.Flag>) - Method in interface io.deephaven.api.snapshot.SnapshotWhenOptions.Builder
 
addAllFunctions(Iterable<? extends ProtobufFunction>) - Method in interface io.deephaven.protobuf.ProtobufFunctions.Builder
 
addAllGroupByColumns(Iterable<? extends ColumnName>) - Method in interface io.deephaven.qst.table.UpdateByTable.Builder
 
addAllGroupByColumns(Iterable<String>) - Method in class io.deephaven.proto.backplane.grpc.AggregateAllRequest.Builder
repeated string group_by_columns = 4;
addAllGroupByColumns(Iterable<String>) - Method in class io.deephaven.proto.backplane.grpc.AggregateRequest.Builder
repeated string group_by_columns = 6;
addAllGroupByColumns(Iterable<String>) - Method in class io.deephaven.proto.backplane.grpc.ComboAggregateRequest.Builder
Deprecated.
repeated string group_by_columns = 4;
addAllGroupByColumns(Iterable<String>) - Method in class io.deephaven.proto.backplane.grpc.RollupRequest.Builder
The names of the columns to rollup by
addAllGroupByColumns(Iterable<String>) - Method in class io.deephaven.proto.backplane.grpc.UpdateByRequest.Builder
repeated string group_by_columns = 5;
addAllGroupByColumnSpecs(Iterable<String>) - Method in class io.deephaven.proto.backplane.grpc.HeadOrTailByRequest.Builder
repeated string group_by_column_specs = 4;
addAllGroupingColumns(Iterable<? extends GroupingColumnInfo>) - Method in interface io.deephaven.parquet.table.metadata.TableInfo.Builder
 
addAllHeaders(Iterable<ColumnHeader<?>>) - Method in interface io.deephaven.qst.table.TableHeader.Builder
 
addAllHolidays(Iterable<? extends FigureDescriptor.BusinessCalendarDescriptor.Holiday>) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BusinessCalendarDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BusinessCalendarDescriptor.Holiday holidays = 5;
addAllIndexColumns(Iterable<List<String>>) - Method in class io.deephaven.parquet.table.ParquetInstructions.Builder
Adds provided lists of columns to persist together as indexes.
addAllInputs(Iterable<? extends MultiJoinInput<TableSpec>>) - Method in interface io.deephaven.qst.table.MultiJoinTable.Builder
 
addAllItems(Iterable<? extends ItemInfo>) - Method in class io.deephaven.proto.backplane.grpc.ListItemsResponse.Builder
List of items found in the specified directory.
addAllItems(Iterable<? extends CompletionItem>) - Method in class io.deephaven.proto.backplane.script.grpc.GetCompletionItemsResponse.Builder
repeated .io.deephaven.proto.backplane.script.grpc.CompletionItem items = 1;
addAllItems(Iterable<? extends Diagnostic>) - Method in class io.deephaven.proto.backplane.script.grpc.GetPullDiagnosticResponse.Builder
repeated .io.deephaven.proto.backplane.script.grpc.Diagnostic items = 3;
addAllKeyColumnNames(Iterable<String>) - Method in class io.deephaven.proto.backplane.grpc.PartitionByRequest.Builder
repeated string key_column_names = 3;
addAllKeyColumnNames(Iterable<String>) - Method in class io.deephaven.proto.backplane.grpc.PartitionedTableDescriptor.Builder
The names of the key columns.
addAllKeyColumns(Iterable<String>) - Method in class io.deephaven.proto.backplane.grpc.CreateInputTableRequest.InputTableKind.InMemoryKeyBacked.Builder
repeated string key_columns = 1;
addAllKeys(Iterable<String>) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BoolMapWithDefault.Builder
repeated string keys = 2;
addAllKeys(Iterable<String>) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.DoubleMapWithDefault.Builder
repeated string keys = 2;
addAllKeys(Iterable<String>) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.StringMapWithDefault.Builder
repeated string keys = 2;
addAllLevels(Iterable<String>) - Method in class io.deephaven.proto.backplane.script.grpc.LogSubscriptionRequest.Builder
repeated string levels = 2;
addAllMajorTickLocations(Iterable<? extends Double>) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.AxisDescriptor.Builder
repeated double major_tick_locations = 17;
addAllMatches(Iterable<? extends JoinMatch>) - Method in interface io.deephaven.qst.table.Join.Builder
 
addAllMatches(Iterable<? extends JoinMatch>) - Method in interface io.deephaven.qst.table.MultiJoinInput.Builder
 
addAllMatches(Iterable<? extends JoinMatch>) - Method in interface io.deephaven.qst.table.WhereInTable.Builder
 
addAllMatchPairs(Iterable<String>) - Method in class io.deephaven.proto.backplane.grpc.Aggregation.AggregationColumns.Builder
repeated string match_pairs = 2;
addAllMatchPairs(Iterable<String>) - Method in class io.deephaven.proto.backplane.grpc.ComboAggregateRequest.Aggregate.Builder
Deprecated.
used in all aggregates except countBy
addAllMatchPairs(Iterable<String>) - Method in class io.deephaven.proto.backplane.grpc.UpdateByRequest.UpdateByOperation.UpdateByColumn.Builder
repeated string match_pairs = 2;
addAllMultiJoinInputs(Iterable<? extends MultiJoinInput>) - Method in class io.deephaven.proto.backplane.grpc.MultiJoinTablesRequest.Builder
The source table input specifications.
addAllMultiSeries(Iterable<? extends FigureDescriptor.MultiSeriesDescriptor>) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.ChartDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.MultiSeriesDescriptor multi_series = 4;
addAllNames(Iterable<String>) - Method in interface io.deephaven.processor.NamedObjectProcessor.Builder
 
addAllOperations(Iterable<? extends UpdateByOperation>) - Method in interface io.deephaven.qst.table.UpdateByTable.Builder
 
addAllOperations(Iterable<? extends UpdateByRequest.UpdateByOperation>) - Method in class io.deephaven.proto.backplane.grpc.UpdateByRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.UpdateByRequest.UpdateByOperation operations = 4;
addAllOps(Iterable<? extends BatchTableRequest.Operation>) - Method in class io.deephaven.proto.backplane.grpc.BatchTableRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.BatchTableRequest.Operation ops = 1;
addAllOptionalReferences(Iterable<? extends Reference>) - Method in class io.deephaven.proto.backplane.grpc.SearchCondition.Builder
repeated .io.deephaven.proto.backplane.grpc.Reference optional_references = 2;
addAllPairs(Iterable<? extends Pair>) - Method in interface io.deephaven.api.agg.ColumnAggregations.Builder
 
addAllParameters(Iterable<? extends ParameterInformation>) - Method in class io.deephaven.proto.backplane.script.grpc.SignatureInformation.Builder
repeated .io.deephaven.proto.backplane.script.grpc.ParameterInformation parameters = 3;
addAllReferences(Iterable<? extends TypedTicket>) - Method in class io.deephaven.proto.backplane.grpc.ClientData.Builder
The typed references, may be empty.
addAllRemoved(Iterable<? extends FieldInfo>) - Method in class io.deephaven.proto.backplane.grpc.FieldsChangeUpdate.Builder
repeated .io.deephaven.proto.backplane.grpc.FieldInfo removed = 3;
addAllSeries(Iterable<? extends FigureDescriptor.SeriesDescriptor>) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.ChartDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.SeriesDescriptor series = 3;
addAllSharedFields(Iterable<? extends ObjectField>) - Method in interface io.deephaven.json.TypedObjectValue.Builder
 
addAllSignatures(Iterable<? extends SignatureInformation>) - Method in class io.deephaven.proto.backplane.script.grpc.GetSignatureHelpResponse.Builder
repeated .io.deephaven.proto.backplane.script.grpc.SignatureInformation signatures = 1;
addAllSortingColumns(Iterable<? extends SortColumnInfo>) - Method in interface io.deephaven.parquet.table.metadata.TableInfo.Builder
 
addAllSorts(Iterable<? extends SortDescriptor>) - Method in class io.deephaven.proto.backplane.grpc.HierarchicalTableApplyRequest.Builder
Sorts to apply to the input HierarchicalTable to produce the result HierarchicalTable.
addAllSorts(Iterable<? extends SortDescriptor>) - Method in class io.deephaven.proto.backplane.grpc.SortTableRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor sorts = 3;
addAllSourceIds(Iterable<? extends TableReference>) - Method in class io.deephaven.proto.backplane.grpc.MergeTablesRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.TableReference source_ids = 2;
addAllStackTraces(Iterable<? extends TerminationNotificationResponse.StackTrace>) - Method in class io.deephaven.proto.backplane.grpc.TerminationNotificationResponse.Builder
if applicable, the list of stack traces in reverse causal order
addAllStampColumns(Iterable<? extends JoinAddition>) - Method in interface io.deephaven.api.snapshot.SnapshotWhenOptions.Builder
 
addAllStampColumns(Iterable<String>) - Method in class io.deephaven.proto.backplane.grpc.SnapshotWhenTableRequest.Builder
Which columns to stamp from the trigger table.
addAllTables(Iterable<? extends TableSpec>) - Method in interface io.deephaven.qst.table.MergeTable.Builder
 
addAllTables(Iterable<? extends TableInformation>) - Method in interface io.deephaven.sql.ScopeStaticImpl.Builder
 
addAllTables(Iterable<LabeledTable>) - Method in interface io.deephaven.qst.table.LabeledTables.Builder
 
addAllTags(Iterable<? extends Diagnostic.DiagnosticTag>) - Method in class io.deephaven.proto.backplane.script.grpc.Diagnostic.Builder
repeated .io.deephaven.proto.backplane.script.grpc.Diagnostic.DiagnosticTag tags = 7;
addAllTagsValue(Iterable<Integer>) - Method in class io.deephaven.proto.backplane.script.grpc.Diagnostic.Builder
repeated .io.deephaven.proto.backplane.script.grpc.Diagnostic.DiagnosticTag tags = 7;
addAllTypedExportIds(Iterable<? extends TypedTicket>) - Method in class io.deephaven.proto.backplane.grpc.FetchObjectResponse.Builder
repeated .io.deephaven.proto.backplane.grpc.TypedTicket typed_export_ids = 3;
addAllUngroupColumns(Iterable<? extends ColumnName>) - Method in interface io.deephaven.qst.table.UngroupTable.Builder
 
addAllUpdated(Iterable<? extends FieldInfo>) - Method in class io.deephaven.proto.backplane.grpc.FieldsChangeUpdate.Builder
repeated .io.deephaven.proto.backplane.grpc.FieldInfo updated = 2;
addAllValues(Iterable<? extends Expression>) - Method in interface io.deephaven.api.filter.FilterIn.Builder
 
addAllValues(Iterable<? extends Boolean>) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BoolMapWithDefault.Builder
repeated bool values = 3;
addAllValues(Iterable<? extends Double>) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.DoubleMapWithDefault.Builder
repeated double values = 3;
addAllValues(Iterable<? extends T>) - Method in class io.deephaven.qst.array.GenericArray.Builder
 
addAllValues(Iterable<String>) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.StringMapWithDefault.Builder
repeated string values = 3;
addAllYColumnNames(Iterable<String>) - Method in class io.deephaven.proto.backplane.grpc.RunChartDownsampleRequest.Builder
repeated string y_column_names = 6;
addAlternateLeftKey(long, long, byte) - Method in class io.deephaven.engine.table.impl.asofjoin.RightIncrementalAsOfJoinStateManagerTypedBase
 
addAlternateRightKey(long, long, byte) - Method in class io.deephaven.engine.table.impl.asofjoin.RightIncrementalAsOfJoinStateManagerTypedBase
 
addAndGet(int) - Method in class io.deephaven.util.mutable.MutableInt
 
addAndGet(long) - Method in class io.deephaven.util.mutable.MutableLong
 
addArgument(Node) - Method in class io.deephaven.lang.api.AbstractChunkerInvokable
 
addArgument(Node) - Method in interface io.deephaven.lang.api.ChunkerInvokable
 
addArguments(int, Value) - Method in class io.deephaven.proto.backplane.grpc.InvokeCondition.Builder
repeated .io.deephaven.proto.backplane.grpc.Value arguments = 3;
addArguments(int, Value.Builder) - Method in class io.deephaven.proto.backplane.grpc.InvokeCondition.Builder
repeated .io.deephaven.proto.backplane.grpc.Value arguments = 3;
addArguments(Expression) - Method in interface io.deephaven.api.expression.Function.Builder
 
addArguments(Expression) - Method in interface io.deephaven.api.expression.Method.Builder
 
addArguments(Expression...) - Method in interface io.deephaven.api.expression.Function.Builder
 
addArguments(Expression...) - Method in interface io.deephaven.api.expression.Method.Builder
 
addArguments(Value) - Method in class io.deephaven.proto.backplane.grpc.InvokeCondition.Builder
repeated .io.deephaven.proto.backplane.grpc.Value arguments = 3;
addArguments(Value.Builder) - Method in class io.deephaven.proto.backplane.grpc.InvokeCondition.Builder
repeated .io.deephaven.proto.backplane.grpc.Value arguments = 3;
addArgumentsBuilder() - Method in class io.deephaven.proto.backplane.grpc.InvokeCondition.Builder
repeated .io.deephaven.proto.backplane.grpc.Value arguments = 3;
addArgumentsBuilder(int) - Method in class io.deephaven.proto.backplane.grpc.InvokeCondition.Builder
repeated .io.deephaven.proto.backplane.grpc.Value arguments = 3;
addArray(T[]) - Method in class io.deephaven.util.SafeCloseableList
 
addAsync(Table, InputTableStatusListener) - Method in interface io.deephaven.engine.util.input.InputTableUpdater
Write newData to this table.
addAxes(int, FigureDescriptor.AxisDescriptor) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.ChartDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.AxisDescriptor axes = 5;
addAxes(int, FigureDescriptor.AxisDescriptor.Builder) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.ChartDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.AxisDescriptor axes = 5;
addAxes(FigureDescriptor.AxisDescriptor) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.ChartDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.AxisDescriptor axes = 5;
addAxes(FigureDescriptor.AxisDescriptor.Builder) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.ChartDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.AxisDescriptor axes = 5;
addAxesBuilder() - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.ChartDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.AxisDescriptor axes = 5;
addAxesBuilder(int) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.ChartDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.AxisDescriptor axes = 5;
addBackLinks() - Method in class io.deephaven.lang.generated.BaseToken
 
addBackLinks(Token) - Method in class io.deephaven.lang.generated.BaseToken
 
addBuild(HasherConfig.BuildSpec) - Method in class io.deephaven.engine.table.impl.by.typed.HasherConfig.Builder
 
addBusinessDays(FigureDescriptor.BusinessCalendarDescriptor.DayOfWeek) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BusinessCalendarDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BusinessCalendarDescriptor.DayOfWeek business_days = 3;
addBusinessDaysValue(int) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BusinessCalendarDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BusinessCalendarDescriptor.DayOfWeek business_days = 3;
addBusinessPeriods(int, FigureDescriptor.BusinessCalendarDescriptor.BusinessPeriod) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BusinessCalendarDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BusinessCalendarDescriptor.BusinessPeriod business_periods = 4;
addBusinessPeriods(int, FigureDescriptor.BusinessCalendarDescriptor.BusinessPeriod) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BusinessCalendarDescriptor.Holiday.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BusinessCalendarDescriptor.BusinessPeriod business_periods = 2;
addBusinessPeriods(int, FigureDescriptor.BusinessCalendarDescriptor.BusinessPeriod.Builder) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BusinessCalendarDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BusinessCalendarDescriptor.BusinessPeriod business_periods = 4;
addBusinessPeriods(int, FigureDescriptor.BusinessCalendarDescriptor.BusinessPeriod.Builder) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BusinessCalendarDescriptor.Holiday.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BusinessCalendarDescriptor.BusinessPeriod business_periods = 2;
addBusinessPeriods(FigureDescriptor.BusinessCalendarDescriptor.BusinessPeriod) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BusinessCalendarDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BusinessCalendarDescriptor.BusinessPeriod business_periods = 4;
addBusinessPeriods(FigureDescriptor.BusinessCalendarDescriptor.BusinessPeriod) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BusinessCalendarDescriptor.Holiday.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BusinessCalendarDescriptor.BusinessPeriod business_periods = 2;
addBusinessPeriods(FigureDescriptor.BusinessCalendarDescriptor.BusinessPeriod.Builder) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BusinessCalendarDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BusinessCalendarDescriptor.BusinessPeriod business_periods = 4;
addBusinessPeriods(FigureDescriptor.BusinessCalendarDescriptor.BusinessPeriod.Builder) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BusinessCalendarDescriptor.Holiday.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BusinessCalendarDescriptor.BusinessPeriod business_periods = 2;
addBusinessPeriodsBuilder() - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BusinessCalendarDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BusinessCalendarDescriptor.BusinessPeriod business_periods = 4;
addBusinessPeriodsBuilder() - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BusinessCalendarDescriptor.Holiday.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BusinessCalendarDescriptor.BusinessPeriod business_periods = 2;
addBusinessPeriodsBuilder(int) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BusinessCalendarDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BusinessCalendarDescriptor.BusinessPeriod business_periods = 4;
addBusinessPeriodsBuilder(int) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BusinessCalendarDescriptor.Holiday.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BusinessCalendarDescriptor.BusinessPeriod business_periods = 2;
addCalendar(BusinessCalendar) - Static method in class io.deephaven.time.calendar.Calendars
Adds a calendar to the collection.
addCalendarFromFile(File) - Static method in class io.deephaven.time.calendar.Calendars
Adds a calendar to the collection from a file.
addCalendarFromFile(String) - Static method in class io.deephaven.time.calendar.Calendars
Adds a calendar to the collection from a file.
addCandidates(int, Value) - Method in class io.deephaven.proto.backplane.grpc.InCondition.Builder
repeated .io.deephaven.proto.backplane.grpc.Value candidates = 2;
addCandidates(int, Value.Builder) - Method in class io.deephaven.proto.backplane.grpc.InCondition.Builder
repeated .io.deephaven.proto.backplane.grpc.Value candidates = 2;
addCandidates(Value) - Method in class io.deephaven.proto.backplane.grpc.InCondition.Builder
repeated .io.deephaven.proto.backplane.grpc.Value candidates = 2;
addCandidates(Value.Builder) - Method in class io.deephaven.proto.backplane.grpc.InCondition.Builder
repeated .io.deephaven.proto.backplane.grpc.Value candidates = 2;
addCandidatesBuilder() - Method in class io.deephaven.proto.backplane.grpc.InCondition.Builder
repeated .io.deephaven.proto.backplane.grpc.Value candidates = 2;
addCandidatesBuilder(int) - Method in class io.deephaven.proto.backplane.grpc.InCondition.Builder
repeated .io.deephaven.proto.backplane.grpc.Value candidates = 2;
addCertificates(Certificate) - Method in interface io.deephaven.ssl.config.TrustCustom.Builder
 
addCertificates(Certificate...) - Method in interface io.deephaven.ssl.config.TrustCustom.Builder
 
addCharts(int, FigureDescriptor.ChartDescriptor) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.ChartDescriptor charts = 10;
addCharts(int, FigureDescriptor.ChartDescriptor.Builder) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.ChartDescriptor charts = 10;
addCharts(FigureDescriptor.ChartDescriptor) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.ChartDescriptor charts = 10;
addCharts(FigureDescriptor.ChartDescriptor.Builder) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.ChartDescriptor charts = 10;
addChartsBuilder() - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.ChartDescriptor charts = 10;
addChartsBuilder(int) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.ChartDescriptor charts = 10;
addChild(ParseState) - Method in class io.deephaven.lang.api.ParseState
 
addChild(Node) - Method in interface io.deephaven.lang.generated.Node
 
addChild(Node, int) - Method in interface io.deephaven.lang.generated.Node
 
addChunk(WritableByteChunk<? extends Values>) - Method in class io.deephaven.engine.table.impl.sources.chunkcolumnsource.ByteChunkColumnSource
Append a chunk of data to this column source.
addChunk(WritableCharChunk<? extends Values>) - Method in class io.deephaven.engine.table.impl.sources.chunkcolumnsource.CharChunkColumnSource
Append a chunk of data to this column source.
addChunk(WritableChunk<? extends Values>) - Method in class io.deephaven.engine.table.impl.sources.chunkcolumnsource.ByteChunkColumnSource
 
addChunk(WritableChunk<? extends Values>) - Method in class io.deephaven.engine.table.impl.sources.chunkcolumnsource.CharChunkColumnSource
 
addChunk(WritableChunk<? extends Values>) - Method in interface io.deephaven.engine.table.impl.sources.chunkcolumnsource.ChunkColumnSource
Append a chunk of data to this column source.
addChunk(WritableChunk<? extends Values>) - Method in class io.deephaven.engine.table.impl.sources.chunkcolumnsource.DoubleChunkColumnSource
 
addChunk(WritableChunk<? extends Values>) - Method in class io.deephaven.engine.table.impl.sources.chunkcolumnsource.FloatChunkColumnSource
 
addChunk(WritableChunk<? extends Values>) - Method in class io.deephaven.engine.table.impl.sources.chunkcolumnsource.IntChunkColumnSource
 
addChunk(WritableChunk<? extends Values>) - Method in class io.deephaven.engine.table.impl.sources.chunkcolumnsource.LongChunkColumnSource
 
addChunk(WritableChunk<? extends Values>) - Method in class io.deephaven.engine.table.impl.sources.chunkcolumnsource.ObjectChunkColumnSource
 
addChunk(WritableChunk<? extends Values>) - Method in class io.deephaven.engine.table.impl.sources.chunkcolumnsource.ShortChunkColumnSource
 
addChunk(WritableDoubleChunk<? extends Values>) - Method in class io.deephaven.engine.table.impl.sources.chunkcolumnsource.DoubleChunkColumnSource
Append a chunk of data to this column source.
addChunk(WritableFloatChunk<? extends Values>) - Method in class io.deephaven.engine.table.impl.sources.chunkcolumnsource.FloatChunkColumnSource
Append a chunk of data to this column source.
addChunk(WritableIntChunk<? extends Values>) - Method in class io.deephaven.engine.table.impl.sources.chunkcolumnsource.IntChunkColumnSource
Append a chunk of data to this column source.
addChunk(WritableLongChunk<? extends Values>) - Method in class io.deephaven.engine.table.impl.sources.chunkcolumnsource.LongChunkColumnSource
Append a chunk of data to this column source.
addChunk(WritableObjectChunk<T, ? extends Values>) - Method in class io.deephaven.engine.table.impl.sources.chunkcolumnsource.ObjectChunkColumnSource
Append a chunk of data to this column source.
addChunk(WritableShortChunk<? extends Values>) - Method in class io.deephaven.engine.table.impl.sources.chunkcolumnsource.ShortChunkColumnSource
Append a chunk of data to this column source.
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ByteAddOnlySortedFirstOrLastChunkedOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ByteBlinkSortedFirstOrLastChunkedOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.CharAddOnlySortedFirstOrLastChunkedOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.CharBlinkSortedFirstOrLastChunkedOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.DoubleAddOnlySortedFirstOrLastChunkedOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.DoubleBlinkSortedFirstOrLastChunkedOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.FloatAddOnlySortedFirstOrLastChunkedOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.FloatBlinkSortedFirstOrLastChunkedOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.IntAddOnlySortedFirstOrLastChunkedOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.IntBlinkSortedFirstOrLastChunkedOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.LongAddOnlySortedFirstOrLastChunkedOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.LongBlinkSortedFirstOrLastChunkedOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ObjectAddOnlySortedFirstOrLastChunkedOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ObjectBlinkSortedFirstOrLastChunkedOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ShortAddOnlySortedFirstOrLastChunkedOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ShortBlinkSortedFirstOrLastChunkedOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.BlinkLastChunkedOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.GroupByChunkedOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.PartitionByChunkedOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.BlinkFirstChunkedOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.AddOnlyFirstOrLastChunkedOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.BigDecimalChunkedSumOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.BigIntegerChunkedSumOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.BooleanChunkedSumOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ByteChunkedSumOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.CharChunkedSumOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.FirstOrLastChunkedOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.IntChunkedSumOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in interface io.deephaven.engine.table.impl.by.IterativeChunkedAggregationOperator
Aggregate a chunk of data into the result columns.
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.LongChunkedSumOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ShortChunkedSumOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.SortedFirstOrLastChunkedOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.count.ByteChunkedCountDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.count.ByteRollupCountDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.count.CharChunkedCountDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.count.CharRollupCountDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.count.DoubleChunkedCountDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.count.DoubleRollupCountDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.count.FloatChunkedCountDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.count.FloatRollupCountDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.count.IntChunkedCountDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.count.IntRollupCountDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.count.LongChunkedCountDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.count.LongRollupCountDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.count.ObjectChunkedCountDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.count.ObjectRollupCountDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.count.ShortChunkedCountDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.count.ShortRollupCountDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.distinct.ByteChunkedDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.distinct.ByteRollupDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.distinct.CharChunkedDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.distinct.CharRollupDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.distinct.DoubleChunkedDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.distinct.DoubleRollupDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.distinct.FloatChunkedDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.distinct.FloatRollupDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.distinct.IntChunkedDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.distinct.IntRollupDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.distinct.LongChunkedDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.distinct.LongRollupDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.distinct.ObjectChunkedDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.distinct.ObjectRollupDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.distinct.ShortChunkedDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.distinct.ShortRollupDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.unique.ByteChunkedUniqueOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.unique.ByteRollupUniqueOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.unique.CharChunkedUniqueOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.unique.CharRollupUniqueOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.unique.DoubleChunkedUniqueOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.unique.DoubleRollupUniqueOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.unique.FloatChunkedUniqueOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.unique.FloatRollupUniqueOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.unique.IntChunkedUniqueOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.unique.IntRollupUniqueOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.unique.LongChunkedUniqueOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.unique.LongRollupUniqueOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.unique.ObjectChunkedUniqueOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.unique.ObjectRollupUniqueOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.unique.ShortChunkedUniqueOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.unique.ShortRollupUniqueOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ssmminmax.SsmChunkedMinMaxOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.ssmpercentile.SsmChunkedPercentileOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.StaticFirstOrLastChunkedOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.TDigestPercentileOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.by.UniqueRowKeyChunkedOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.util.freezeby.FreezeByCountOperator
 
addChunk(IterativeChunkedAggregationOperator.BucketedContext, Chunk<? extends Values>, LongChunk<? extends RowKeys>, IntChunk<RowKeys>, IntChunk<ChunkPositions>, IntChunk<ChunkLengths>, WritableBooleanChunk<Values>) - Method in class io.deephaven.engine.table.impl.util.freezeby.FreezeByOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ByteAddOnlySortedFirstOrLastChunkedOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ByteBlinkSortedFirstOrLastChunkedOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.CharAddOnlySortedFirstOrLastChunkedOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.CharBlinkSortedFirstOrLastChunkedOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.DoubleAddOnlySortedFirstOrLastChunkedOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.DoubleBlinkSortedFirstOrLastChunkedOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.FloatAddOnlySortedFirstOrLastChunkedOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.FloatBlinkSortedFirstOrLastChunkedOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.IntAddOnlySortedFirstOrLastChunkedOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.IntBlinkSortedFirstOrLastChunkedOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.LongAddOnlySortedFirstOrLastChunkedOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.LongBlinkSortedFirstOrLastChunkedOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ObjectAddOnlySortedFirstOrLastChunkedOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ObjectBlinkSortedFirstOrLastChunkedOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ShortAddOnlySortedFirstOrLastChunkedOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ShortBlinkSortedFirstOrLastChunkedOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.BlinkFirstChunkedOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.BlinkLastChunkedOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.GroupByChunkedOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.PartitionByChunkedOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.AddOnlyFirstOrLastChunkedOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.BigDecimalChunkedSumOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.BigIntegerChunkedSumOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.BooleanChunkedSumOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ByteChunkedSumOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.CharChunkedSumOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.FirstOrLastChunkedOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.IntChunkedSumOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in interface io.deephaven.engine.table.impl.by.IterativeChunkedAggregationOperator
Aggregate a chunk of data into the result columns.
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.LongChunkedSumOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ShortChunkedSumOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.SortedFirstOrLastChunkedOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.count.ByteChunkedCountDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.count.ByteRollupCountDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.count.CharChunkedCountDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.count.CharRollupCountDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.count.DoubleChunkedCountDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.count.DoubleRollupCountDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.count.FloatChunkedCountDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.count.FloatRollupCountDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.count.IntChunkedCountDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.count.IntRollupCountDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.count.LongChunkedCountDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.count.LongRollupCountDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.count.ObjectChunkedCountDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.count.ObjectRollupCountDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.count.ShortChunkedCountDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.count.ShortRollupCountDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.distinct.ByteChunkedDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.distinct.ByteRollupDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.distinct.CharChunkedDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.distinct.CharRollupDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.distinct.DoubleChunkedDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.distinct.DoubleRollupDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.distinct.FloatChunkedDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.distinct.FloatRollupDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.distinct.IntChunkedDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.distinct.IntRollupDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.distinct.LongChunkedDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.distinct.LongRollupDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.distinct.ObjectChunkedDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.distinct.ObjectRollupDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.distinct.ShortChunkedDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.distinct.ShortRollupDistinctOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.unique.ByteChunkedUniqueOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.unique.ByteRollupUniqueOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.unique.CharChunkedUniqueOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.unique.CharRollupUniqueOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.unique.DoubleChunkedUniqueOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.unique.DoubleRollupUniqueOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.unique.FloatChunkedUniqueOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.unique.FloatRollupUniqueOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.unique.IntChunkedUniqueOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.unique.IntRollupUniqueOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.unique.LongChunkedUniqueOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.unique.LongRollupUniqueOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.unique.ObjectChunkedUniqueOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.unique.ObjectRollupUniqueOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.unique.ShortChunkedUniqueOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ssmcountdistinct.unique.ShortRollupUniqueOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ssmminmax.SsmChunkedMinMaxOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.ssmpercentile.SsmChunkedPercentileOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.StaticFirstOrLastChunkedOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.TDigestPercentileOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.by.UniqueRowKeyChunkedOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.util.freezeby.FreezeByCountOperator
 
addChunk(IterativeChunkedAggregationOperator.SingletonContext, int, Chunk<? extends Values>, LongChunk<? extends RowKeys>, long) - Method in class io.deephaven.engine.table.impl.util.freezeby.FreezeByOperator
 
addChunkArgument(PyCallableWrapper.ChunkArgument) - Method in interface io.deephaven.engine.util.PyCallableWrapper
 
addChunkArgument(PyCallableWrapper.ChunkArgument) - Method in class io.deephaven.engine.util.PyCallableWrapperJpyImpl
 
addClassData(String, byte[]) - Method in class io.deephaven.base.classloaders.MapBackedClassLoader
 
addColumn(String) - Method in interface io.deephaven.parquet.base.RowGroupWriter
 
addColumn(String) - Method in class io.deephaven.plot.util.tables.PartitionedTableHandle
 
addColumn(String) - Method in class io.deephaven.plot.util.tables.SwappableTable
Adds a column to the underlying table structures.
addColumn(String) - Method in class io.deephaven.plot.util.tables.SwappableTableOneClickAbstract
 
addColumn(String) - Method in class io.deephaven.plot.util.tables.TableHandle
 
addColumnCodec(String, String) - Method in class io.deephaven.parquet.table.ParquetInstructions.Builder
 
addColumnCodec(String, String, String) - Method in class io.deephaven.parquet.table.ParquetInstructions.Builder
 
addColumnData - Variable in class io.deephaven.engine.table.impl.util.BarrageMessage
 
AddColumnData() - Constructor for class io.deephaven.engine.table.impl.util.BarrageMessage.AddColumnData
 
addColumnNameMapping(String, String) - Method in class io.deephaven.parquet.table.ParquetInstructions.Builder
 
addColumnNames(String) - Method in class io.deephaven.proto.backplane.grpc.DropColumnsRequest.Builder
repeated string column_names = 3;
addColumnNames(String) - Method in class io.deephaven.proto.backplane.grpc.SelectDistinctRequest.Builder
repeated string column_names = 3;
addColumnNamesBytes(ByteString) - Method in class io.deephaven.proto.backplane.grpc.DropColumnsRequest.Builder
repeated string column_names = 3;
addColumnNamesBytes(ByteString) - Method in class io.deephaven.proto.backplane.grpc.SelectDistinctRequest.Builder
repeated string column_names = 3;
addColumns(int, AggSpec.AggSpecSortedColumn) - Method in class io.deephaven.proto.backplane.grpc.AggSpec.AggSpecSorted.Builder
Using a message instead of string to support backwards-compatibility in the future
addColumns(int, AggSpec.AggSpecSortedColumn.Builder) - Method in class io.deephaven.proto.backplane.grpc.AggSpec.AggSpecSorted.Builder
Using a message instead of string to support backwards-compatibility in the future
addColumns(Pair) - Method in interface io.deephaven.api.updateby.ColumnUpdateOperation.Builder
 
addColumns(Pair...) - Method in interface io.deephaven.api.updateby.ColumnUpdateOperation.Builder
 
addColumns(Selectable) - Method in interface io.deephaven.qst.table.SelectableTable.Builder
 
addColumns(Selectable...) - Method in interface io.deephaven.qst.table.SelectableTable.Builder
 
addColumns(SortColumn) - Method in interface io.deephaven.api.agg.spec.AggSpecSortedFirst.Builder
 
addColumns(SortColumn) - Method in interface io.deephaven.api.agg.spec.AggSpecSortedLast.Builder
 
addColumns(SortColumn) - Method in interface io.deephaven.qst.table.SortTable.Builder
 
addColumns(SortColumn...) - Method in interface io.deephaven.api.agg.spec.AggSpecSortedFirst.Builder
 
addColumns(SortColumn...) - Method in interface io.deephaven.api.agg.spec.AggSpecSortedLast.Builder
 
addColumns(SortColumn...) - Method in interface io.deephaven.qst.table.SortTable.Builder
 
addColumns(AggSpec.AggSpecSortedColumn) - Method in class io.deephaven.proto.backplane.grpc.AggSpec.AggSpecSorted.Builder
Using a message instead of string to support backwards-compatibility in the future
addColumns(AggSpec.AggSpecSortedColumn.Builder) - Method in class io.deephaven.proto.backplane.grpc.AggSpec.AggSpecSorted.Builder
Using a message instead of string to support backwards-compatibility in the future
addColumns(Column<?>) - Method in interface io.deephaven.qst.table.NewTable.Builder
 
addColumns(Column<?>...) - Method in interface io.deephaven.qst.table.NewTable.Builder
 
addColumns(String) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.OneClickDescriptor.Builder
repeated string columns = 1;
addColumnsBuilder() - Method in class io.deephaven.proto.backplane.grpc.AggSpec.AggSpecSorted.Builder
Using a message instead of string to support backwards-compatibility in the future
addColumnsBuilder(int) - Method in class io.deephaven.proto.backplane.grpc.AggSpec.AggSpecSorted.Builder
Using a message instead of string to support backwards-compatibility in the future
addColumnsBytes(ByteString) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.OneClickDescriptor.Builder
repeated string columns = 1;
addColumnSpecs(String) - Method in class io.deephaven.proto.backplane.grpc.SelectOrUpdateRequest.Builder
repeated string column_specs = 3;
addColumnSpecsBytes(ByteString) - Method in class io.deephaven.proto.backplane.grpc.SelectOrUpdateRequest.Builder
repeated string column_specs = 3;
addColumnsToAdd(String) - Method in class io.deephaven.proto.backplane.grpc.AjRajTablesRequest.Builder
repeated string columns_to_add = 6;
addColumnsToAdd(String) - Method in class io.deephaven.proto.backplane.grpc.AsOfJoinTablesRequest.Builder
Deprecated.
repeated string columns_to_add = 5;
addColumnsToAdd(String) - Method in class io.deephaven.proto.backplane.grpc.CrossJoinTablesRequest.Builder
repeated string columns_to_add = 5;
addColumnsToAdd(String) - Method in class io.deephaven.proto.backplane.grpc.ExactJoinTablesRequest.Builder
repeated string columns_to_add = 5;
addColumnsToAdd(String) - Method in class io.deephaven.proto.backplane.grpc.LeftJoinTablesRequest.Builder
repeated string columns_to_add = 5;
addColumnsToAdd(String) - Method in class io.deephaven.proto.backplane.grpc.MultiJoinInput.Builder
The columns from the source table to include; if not provided, all columns are included.
addColumnsToAdd(String) - Method in class io.deephaven.proto.backplane.grpc.NaturalJoinTablesRequest.Builder
repeated string columns_to_add = 5;
addColumnsToAddBytes(ByteString) - Method in class io.deephaven.proto.backplane.grpc.AjRajTablesRequest.Builder
repeated string columns_to_add = 6;
addColumnsToAddBytes(ByteString) - Method in class io.deephaven.proto.backplane.grpc.AsOfJoinTablesRequest.Builder
Deprecated.
repeated string columns_to_add = 5;
addColumnsToAddBytes(ByteString) - Method in class io.deephaven.proto.backplane.grpc.CrossJoinTablesRequest.Builder
repeated string columns_to_add = 5;
addColumnsToAddBytes(ByteString) - Method in class io.deephaven.proto.backplane.grpc.ExactJoinTablesRequest.Builder
repeated string columns_to_add = 5;
addColumnsToAddBytes(ByteString) - Method in class io.deephaven.proto.backplane.grpc.LeftJoinTablesRequest.Builder
repeated string columns_to_add = 5;
addColumnsToAddBytes(ByteString) - Method in class io.deephaven.proto.backplane.grpc.MultiJoinInput.Builder
The columns from the source table to include; if not provided, all columns are included.
addColumnsToAddBytes(ByteString) - Method in class io.deephaven.proto.backplane.grpc.NaturalJoinTablesRequest.Builder
repeated string columns_to_add = 5;
addColumnsToMatch(String) - Method in class io.deephaven.proto.backplane.grpc.AsOfJoinTablesRequest.Builder
Deprecated.
repeated string columns_to_match = 4;
addColumnsToMatch(String) - Method in class io.deephaven.proto.backplane.grpc.CrossJoinTablesRequest.Builder
repeated string columns_to_match = 4;
addColumnsToMatch(String) - Method in class io.deephaven.proto.backplane.grpc.ExactJoinTablesRequest.Builder
repeated string columns_to_match = 4;
addColumnsToMatch(String) - Method in class io.deephaven.proto.backplane.grpc.LeftJoinTablesRequest.Builder
repeated string columns_to_match = 4;
addColumnsToMatch(String) - Method in class io.deephaven.proto.backplane.grpc.MultiJoinInput.Builder
The key columns to match; may be renamed to match other source table key columns.
addColumnsToMatch(String) - Method in class io.deephaven.proto.backplane.grpc.NaturalJoinTablesRequest.Builder
repeated string columns_to_match = 4;
addColumnsToMatch(String) - Method in class io.deephaven.proto.backplane.grpc.WhereInRequest.Builder
repeated string columns_to_match = 5;
addColumnsToMatchBytes(ByteString) - Method in class io.deephaven.proto.backplane.grpc.AsOfJoinTablesRequest.Builder
Deprecated.
repeated string columns_to_match = 4;
addColumnsToMatchBytes(ByteString) - Method in class io.deephaven.proto.backplane.grpc.CrossJoinTablesRequest.Builder
repeated string columns_to_match = 4;
addColumnsToMatchBytes(ByteString) - Method in class io.deephaven.proto.backplane.grpc.ExactJoinTablesRequest.Builder
repeated string columns_to_match = 4;
addColumnsToMatchBytes(ByteString) - Method in class io.deephaven.proto.backplane.grpc.LeftJoinTablesRequest.Builder
repeated string columns_to_match = 4;
addColumnsToMatchBytes(ByteString) - Method in class io.deephaven.proto.backplane.grpc.MultiJoinInput.Builder
The key columns to match; may be renamed to match other source table key columns.
addColumnsToMatchBytes(ByteString) - Method in class io.deephaven.proto.backplane.grpc.NaturalJoinTablesRequest.Builder
repeated string columns_to_match = 4;
addColumnsToMatchBytes(ByteString) - Method in class io.deephaven.proto.backplane.grpc.WhereInRequest.Builder
repeated string columns_to_match = 5;
addColumnsToUngroup(String) - Method in class io.deephaven.proto.backplane.grpc.UngroupRequest.Builder
repeated string columns_to_ungroup = 4;
addColumnsToUngroupBytes(ByteString) - Method in class io.deephaven.proto.backplane.grpc.UngroupRequest.Builder
repeated string columns_to_ungroup = 4;
addColumnTypes(ColumnTypeInfo) - Method in interface io.deephaven.parquet.table.metadata.TableInfo.Builder
 
addColumnTypes(ColumnTypeInfo...) - Method in interface io.deephaven.parquet.table.metadata.TableInfo.Builder
 
addColumnTypes(String) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.OneClickDescriptor.Builder
repeated string column_types = 2;
addColumnTypesBytes(ByteString) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.OneClickDescriptor.Builder
repeated string column_types = 2;
addCommitCharacters(String) - Method in class io.deephaven.proto.backplane.script.grpc.CompletionItem.Builder
repeated string commit_characters = 14;
addCommitCharactersBytes(ByteString) - Method in class io.deephaven.proto.backplane.script.grpc.CompletionItem.Builder
repeated string commit_characters = 14;
addCompressionExtensionIfNeeded(String) - Static method in class io.deephaven.io.CompressedFileUtil
If the given file doesn't exist, looks to see if a compressed version of the file exists.
addConsoleTypes(String) - Method in class io.deephaven.proto.backplane.script.grpc.GetConsoleTypesResponse.Builder
repeated string console_types = 1;
addConsoleTypesBytes(ByteString) - Method in class io.deephaven.proto.backplane.script.grpc.GetConsoleTypesResponse.Builder
repeated string console_types = 1;
addContentChanges(int, ChangeDocumentRequest.TextDocumentContentChangeEvent) - Method in class io.deephaven.proto.backplane.script.grpc.ChangeDocumentRequest.Builder
repeated .io.deephaven.proto.backplane.script.grpc.ChangeDocumentRequest.TextDocumentContentChangeEvent content_changes = 3;
addContentChanges(int, ChangeDocumentRequest.TextDocumentContentChangeEvent.Builder) - Method in class io.deephaven.proto.backplane.script.grpc.ChangeDocumentRequest.Builder
repeated .io.deephaven.proto.backplane.script.grpc.ChangeDocumentRequest.TextDocumentContentChangeEvent content_changes = 3;
addContentChanges(ChangeDocumentRequest.TextDocumentContentChangeEvent) - Method in class io.deephaven.proto.backplane.script.grpc.ChangeDocumentRequest.Builder
repeated .io.deephaven.proto.backplane.script.grpc.ChangeDocumentRequest.TextDocumentContentChangeEvent content_changes = 3;
addContentChanges(ChangeDocumentRequest.TextDocumentContentChangeEvent.Builder) - Method in class io.deephaven.proto.backplane.script.grpc.ChangeDocumentRequest.Builder
repeated .io.deephaven.proto.backplane.script.grpc.ChangeDocumentRequest.TextDocumentContentChangeEvent content_changes = 3;
addContentChangesBuilder() - Method in class io.deephaven.proto.backplane.script.grpc.ChangeDocumentRequest.Builder
repeated .io.deephaven.proto.backplane.script.grpc.ChangeDocumentRequest.TextDocumentContentChangeEvent content_changes = 3;
addContentChangesBuilder(int) - Method in class io.deephaven.proto.backplane.script.grpc.ChangeDocumentRequest.Builder
repeated .io.deephaven.proto.backplane.script.grpc.ChangeDocumentRequest.TextDocumentContentChangeEvent content_changes = 3;
addCreated(int, FieldInfo) - Method in class io.deephaven.proto.backplane.grpc.FieldsChangeUpdate.Builder
repeated .io.deephaven.proto.backplane.grpc.FieldInfo created = 1;
addCreated(int, FieldInfo.Builder) - Method in class io.deephaven.proto.backplane.grpc.FieldsChangeUpdate.Builder
repeated .io.deephaven.proto.backplane.grpc.FieldInfo created = 1;
addCreated(FieldInfo) - Method in class io.deephaven.proto.backplane.grpc.FieldsChangeUpdate.Builder
repeated .io.deephaven.proto.backplane.grpc.FieldInfo created = 1;
addCreated(FieldInfo.Builder) - Method in class io.deephaven.proto.backplane.grpc.FieldsChangeUpdate.Builder
repeated .io.deephaven.proto.backplane.grpc.FieldInfo created = 1;
addCreatedBuilder() - Method in class io.deephaven.proto.backplane.grpc.FieldsChangeUpdate.Builder
repeated .io.deephaven.proto.backplane.grpc.FieldInfo created = 1;
addCreatedBuilder(int) - Method in class io.deephaven.proto.backplane.grpc.FieldsChangeUpdate.Builder
repeated .io.deephaven.proto.backplane.grpc.FieldInfo created = 1;
addDataIndex(DataIndex) - Method in class io.deephaven.engine.table.impl.indexer.DataIndexer
Add a DataIndex to this DataIndexer.
addDataIndexes(DataIndexInfo) - Method in interface io.deephaven.parquet.table.metadata.TableInfo.Builder
 
addDataIndexes(DataIndexInfo...) - Method in interface io.deephaven.parquet.table.metadata.TableInfo.Builder
 
addDataSources(int, FigureDescriptor.MultiSeriesSourceDescriptor) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.MultiSeriesDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.MultiSeriesSourceDescriptor data_sources = 14;
addDataSources(int, FigureDescriptor.MultiSeriesSourceDescriptor.Builder) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.MultiSeriesDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.MultiSeriesSourceDescriptor data_sources = 14;
addDataSources(int, FigureDescriptor.SourceDescriptor) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.SeriesDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.SourceDescriptor data_sources = 15;
addDataSources(int, FigureDescriptor.SourceDescriptor.Builder) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.SeriesDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.SourceDescriptor data_sources = 15;
addDataSources(FigureDescriptor.MultiSeriesSourceDescriptor) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.MultiSeriesDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.MultiSeriesSourceDescriptor data_sources = 14;
addDataSources(FigureDescriptor.MultiSeriesSourceDescriptor.Builder) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.MultiSeriesDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.MultiSeriesSourceDescriptor data_sources = 14;
addDataSources(FigureDescriptor.SourceDescriptor) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.SeriesDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.SourceDescriptor data_sources = 15;
addDataSources(FigureDescriptor.SourceDescriptor.Builder) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.SeriesDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.SourceDescriptor data_sources = 15;
addDataSourcesBuilder() - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.MultiSeriesDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.MultiSeriesSourceDescriptor data_sources = 14;
addDataSourcesBuilder() - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.SeriesDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.SourceDescriptor data_sources = 15;
addDataSourcesBuilder(int) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.MultiSeriesDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.MultiSeriesSourceDescriptor data_sources = 14;
addDataSourcesBuilder(int) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.SeriesDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.SourceDescriptor data_sources = 15;
addDependent(KeyHolder) - Method in interface io.deephaven.engine.table.impl.util.KeyHolder
 
addDependent(KeyHolder) - Method in class io.deephaven.engine.table.impl.util.KeyHolder.Base
 
addDiagnostics(int, Diagnostic) - Method in class io.deephaven.proto.backplane.script.grpc.GetPublishDiagnosticResponse.Builder
repeated .io.deephaven.proto.backplane.script.grpc.Diagnostic diagnostics = 3;
addDiagnostics(int, Diagnostic.Builder) - Method in class io.deephaven.proto.backplane.script.grpc.GetPublishDiagnosticResponse.Builder
repeated .io.deephaven.proto.backplane.script.grpc.Diagnostic diagnostics = 3;
addDiagnostics(Diagnostic) - Method in class io.deephaven.proto.backplane.script.grpc.GetPublishDiagnosticResponse.Builder
repeated .io.deephaven.proto.backplane.script.grpc.Diagnostic diagnostics = 3;
addDiagnostics(Diagnostic.Builder) - Method in class io.deephaven.proto.backplane.script.grpc.GetPublishDiagnosticResponse.Builder
repeated .io.deephaven.proto.backplane.script.grpc.Diagnostic diagnostics = 3;
addDiagnosticsBuilder() - Method in class io.deephaven.proto.backplane.script.grpc.GetPublishDiagnosticResponse.Builder
repeated .io.deephaven.proto.backplane.script.grpc.Diagnostic diagnostics = 3;
addDiagnosticsBuilder(int) - Method in class io.deephaven.proto.backplane.script.grpc.GetPublishDiagnosticResponse.Builder
repeated .io.deephaven.proto.backplane.script.grpc.Diagnostic diagnostics = 3;
addDictionaryPage(Object, int) - Method in interface io.deephaven.parquet.base.ColumnWriter
Add a dictionary page to the file.
addDropColumns(ColumnName) - Method in interface io.deephaven.qst.table.DropColumnsTable.Builder
 
addDropColumns(ColumnName...) - Method in interface io.deephaven.qst.table.DropColumnsTable.Builder
 
added - Variable in class io.deephaven.engine.table.impl.remote.DeltaUpdates
 
added - Variable in class io.deephaven.engine.table.impl.TableUpdateImpl
 
added - Variable in class io.deephaven.engine.table.impl.util.UpdateCoalescer
 
added() - Method in class io.deephaven.engine.table.impl.TableUpdateImpl
 
added() - Method in interface io.deephaven.engine.table.TableUpdate
rows added (post-shift keyspace)
ADDED - Enum constant in enum class io.deephaven.engine.table.impl.KeyedTableListener.KeyEvent
 
addElements(String) - Method in class io.deephaven.proto.backplane.grpc.TerminationNotificationResponse.StackTrace.Builder
repeated string elements = 3;
addElementsBytes(ByteString) - Method in class io.deephaven.proto.backplane.grpc.TerminationNotificationResponse.StackTrace.Builder
repeated string elements = 3;
addErrors(String) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.Builder
repeated string errors = 13;
addErrorsBytes(ByteString) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.Builder
repeated string errors = 13;
addEscapes(String) - Static method in exception io.deephaven.lang.generated.TokenMgrException
Replaces unprintable characters by their escaped (or unicode escaped) equivalents in the given string
addExactFileWatch(String, String, BiConsumer<Path, WatchEvent.Kind>) - Method in class io.deephaven.util.files.DirWatchService
Adds an exact match file pattern to watch for; equivalent to adding with the EXACT_MATCH_WITH_SEPARATOR MatcherType
addExactMatchColumns(String) - Method in class io.deephaven.proto.backplane.grpc.AjRajTablesRequest.Builder
repeated string exact_match_columns = 4;
addExactMatchColumns(String) - Method in class io.deephaven.proto.backplane.grpc.RangeJoinTablesRequest.Builder
repeated string exact_match_columns = 4;
addExactMatchColumnsBytes(ByteString) - Method in class io.deephaven.proto.backplane.grpc.AjRajTablesRequest.Builder
repeated string exact_match_columns = 4;
addExactMatchColumnsBytes(ByteString) - Method in class io.deephaven.proto.backplane.grpc.RangeJoinTablesRequest.Builder
repeated string exact_match_columns = 4;
addExactMatches(JoinMatch) - Method in interface io.deephaven.qst.table.RangeJoinTable.Builder
 
addExactMatches(JoinMatch...) - Method in interface io.deephaven.qst.table.RangeJoinTable.Builder
 
addExactToArray(T, T[], Class<T>) - Static method in class io.deephaven.base.ArrayUtil
 
addExportedReferences(int, TypedTicket) - Method in class io.deephaven.proto.backplane.grpc.ServerData.Builder
The exported references, may be empty.
addExportedReferences(int, TypedTicket.Builder) - Method in class io.deephaven.proto.backplane.grpc.ServerData.Builder
The exported references, may be empty.
addExportedReferences(TypedTicket) - Method in class io.deephaven.proto.backplane.grpc.ServerData.Builder
The exported references, may be empty.
addExportedReferences(TypedTicket.Builder) - Method in class io.deephaven.proto.backplane.grpc.ServerData.Builder
The exported references, may be empty.
addExportedReferencesBuilder() - Method in class io.deephaven.proto.backplane.grpc.ServerData.Builder
The exported references, may be empty.
addExportedReferencesBuilder(int) - Method in class io.deephaven.proto.backplane.grpc.ServerData.Builder
The exported references, may be empty.
addExportListener(StreamObserver<ExportNotification>) - Method in class io.deephaven.server.session.SessionState
 
addExtraMethod(BiFunction<HasherConfig<T>, ChunkType[], MethodSpec>) - Method in class io.deephaven.engine.table.impl.by.typed.HasherConfig.Builder
 
addExtraPartialRehashParameter(ParameterSpec) - Method in class io.deephaven.engine.table.impl.by.typed.HasherConfig.Builder
 
addFields(Field<?>) - Method in interface io.deephaven.appmode.Fields.Builder
 
addFields(Field<?>...) - Method in interface io.deephaven.appmode.Fields.Builder
 
addFields(ObjectField) - Method in interface io.deephaven.json.ObjectValue.Builder
 
addFields(ObjectField...) - Method in interface io.deephaven.json.ObjectValue.Builder
 
addFiles(Path) - Method in interface io.deephaven.appmode.ScriptApplication.Builder
 
addFiles(Path...) - Method in interface io.deephaven.appmode.ScriptApplication.Builder
 
addFileWatchAtEnd(Predicate<String>, BiConsumer<Path, WatchEvent.Kind>) - Method in class io.deephaven.util.files.DirWatchService
Adds a file pattern to watch for at the end of the ordered watch list
addFileWatchAtStart(Predicate<String>, BiConsumer<Path, WatchEvent.Kind>) - Method in class io.deephaven.util.files.DirWatchService
Adds a file pattern to watch for at the start of the ordered watch list
addFilters(int, Condition) - Method in class io.deephaven.proto.backplane.grpc.AndCondition.Builder
repeated .io.deephaven.proto.backplane.grpc.Condition filters = 1;
addFilters(int, Condition) - Method in class io.deephaven.proto.backplane.grpc.FilterTableRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.Condition filters = 3;
addFilters(int, Condition) - Method in class io.deephaven.proto.backplane.grpc.HierarchicalTableApplyRequest.Builder
Filters to apply to the input HierarchicalTable to produce the result HierarchicalTable.
addFilters(int, Condition) - Method in class io.deephaven.proto.backplane.grpc.OrCondition.Builder
repeated .io.deephaven.proto.backplane.grpc.Condition filters = 1;
addFilters(int, Condition.Builder) - Method in class io.deephaven.proto.backplane.grpc.AndCondition.Builder
repeated .io.deephaven.proto.backplane.grpc.Condition filters = 1;
addFilters(int, Condition.Builder) - Method in class io.deephaven.proto.backplane.grpc.FilterTableRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.Condition filters = 3;
addFilters(int, Condition.Builder) - Method in class io.deephaven.proto.backplane.grpc.HierarchicalTableApplyRequest.Builder
Filters to apply to the input HierarchicalTable to produce the result HierarchicalTable.
addFilters(int, Condition.Builder) - Method in class io.deephaven.proto.backplane.grpc.OrCondition.Builder
repeated .io.deephaven.proto.backplane.grpc.Condition filters = 1;
addFilters(Filter) - Method in interface io.deephaven.api.filter.FilterAnd.Builder
 
addFilters(Filter) - Method in interface io.deephaven.api.filter.FilterOr.Builder
 
addFilters(Filter...) - Method in interface io.deephaven.api.filter.FilterAnd.Builder
 
addFilters(Filter...) - Method in interface io.deephaven.api.filter.FilterOr.Builder
 
addFilters(Condition) - Method in class io.deephaven.proto.backplane.grpc.AndCondition.Builder
repeated .io.deephaven.proto.backplane.grpc.Condition filters = 1;
addFilters(Condition) - Method in class io.deephaven.proto.backplane.grpc.FilterTableRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.Condition filters = 3;
addFilters(Condition) - Method in class io.deephaven.proto.backplane.grpc.HierarchicalTableApplyRequest.Builder
Filters to apply to the input HierarchicalTable to produce the result HierarchicalTable.
addFilters(Condition) - Method in class io.deephaven.proto.backplane.grpc.OrCondition.Builder
repeated .io.deephaven.proto.backplane.grpc.Condition filters = 1;
addFilters(Condition.Builder) - Method in class io.deephaven.proto.backplane.grpc.AndCondition.Builder
repeated .io.deephaven.proto.backplane.grpc.Condition filters = 1;
addFilters(Condition.Builder) - Method in class io.deephaven.proto.backplane.grpc.FilterTableRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.Condition filters = 3;
addFilters(Condition.Builder) - Method in class io.deephaven.proto.backplane.grpc.HierarchicalTableApplyRequest.Builder
Filters to apply to the input HierarchicalTable to produce the result HierarchicalTable.
addFilters(Condition.Builder) - Method in class io.deephaven.proto.backplane.grpc.OrCondition.Builder
repeated .io.deephaven.proto.backplane.grpc.Condition filters = 1;
addFilters(String) - Method in class io.deephaven.proto.backplane.grpc.UnstructuredFilterTableRequest.Builder
repeated string filters = 3;
addFiltersBuilder() - Method in class io.deephaven.proto.backplane.grpc.AndCondition.Builder
repeated .io.deephaven.proto.backplane.grpc.Condition filters = 1;
addFiltersBuilder() - Method in class io.deephaven.proto.backplane.grpc.FilterTableRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.Condition filters = 3;
addFiltersBuilder() - Method in class io.deephaven.proto.backplane.grpc.HierarchicalTableApplyRequest.Builder
Filters to apply to the input HierarchicalTable to produce the result HierarchicalTable.
addFiltersBuilder() - Method in class io.deephaven.proto.backplane.grpc.OrCondition.Builder
repeated .io.deephaven.proto.backplane.grpc.Condition filters = 1;
addFiltersBuilder(int) - Method in class io.deephaven.proto.backplane.grpc.AndCondition.Builder
repeated .io.deephaven.proto.backplane.grpc.Condition filters = 1;
addFiltersBuilder(int) - Method in class io.deephaven.proto.backplane.grpc.FilterTableRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.Condition filters = 3;
addFiltersBuilder(int) - Method in class io.deephaven.proto.backplane.grpc.HierarchicalTableApplyRequest.Builder
Filters to apply to the input HierarchicalTable to produce the result HierarchicalTable.
addFiltersBuilder(int) - Method in class io.deephaven.proto.backplane.grpc.OrCondition.Builder
repeated .io.deephaven.proto.backplane.grpc.Condition filters = 1;
addFiltersBytes(ByteString) - Method in class io.deephaven.proto.backplane.grpc.UnstructuredFilterTableRequest.Builder
repeated string filters = 3;
addFirst(E) - Method in class io.deephaven.base.RingBuffer
 
addFirst(T) - Method in class io.deephaven.util.datastructures.RandomAccessDeque
 
addFlags(SnapshotWhenOptions.Flag) - Method in interface io.deephaven.api.snapshot.SnapshotWhenOptions.Builder
 
addFlags(SnapshotWhenOptions.Flag...) - Method in interface io.deephaven.api.snapshot.SnapshotWhenOptions.Builder
 
addFunctions(ProtobufFunction) - Method in interface io.deephaven.protobuf.ProtobufFunctions.Builder
 
addFunctions(ProtobufFunction...) - Method in interface io.deephaven.protobuf.ProtobufFunctions.Builder
 
addGroupByColumns(ColumnName) - Method in interface io.deephaven.qst.table.UpdateByTable.Builder
 
addGroupByColumns(ColumnName...) - Method in interface io.deephaven.qst.table.UpdateByTable.Builder
 
addGroupByColumns(String) - Method in class io.deephaven.proto.backplane.grpc.AggregateAllRequest.Builder
repeated string group_by_columns = 4;
addGroupByColumns(String) - Method in class io.deephaven.proto.backplane.grpc.AggregateRequest.Builder
repeated string group_by_columns = 6;
addGroupByColumns(String) - Method in class io.deephaven.proto.backplane.grpc.ComboAggregateRequest.Builder
Deprecated.
repeated string group_by_columns = 4;
addGroupByColumns(String) - Method in class io.deephaven.proto.backplane.grpc.RollupRequest.Builder
The names of the columns to rollup by
addGroupByColumns(String) - Method in class io.deephaven.proto.backplane.grpc.UpdateByRequest.Builder
repeated string group_by_columns = 5;
addGroupByColumnsBytes(ByteString) - Method in class io.deephaven.proto.backplane.grpc.AggregateAllRequest.Builder
repeated string group_by_columns = 4;
addGroupByColumnsBytes(ByteString) - Method in class io.deephaven.proto.backplane.grpc.AggregateRequest.Builder
repeated string group_by_columns = 6;
addGroupByColumnsBytes(ByteString) - Method in class io.deephaven.proto.backplane.grpc.ComboAggregateRequest.Builder
Deprecated.
repeated string group_by_columns = 4;
addGroupByColumnsBytes(ByteString) - Method in class io.deephaven.proto.backplane.grpc.RollupRequest.Builder
The names of the columns to rollup by
addGroupByColumnsBytes(ByteString) - Method in class io.deephaven.proto.backplane.grpc.UpdateByRequest.Builder
repeated string group_by_columns = 5;
addGroupByColumnSpecs(String) - Method in class io.deephaven.proto.backplane.grpc.HeadOrTailByRequest.Builder
repeated string group_by_column_specs = 4;
addGroupByColumnSpecsBytes(ByteString) - Method in class io.deephaven.proto.backplane.grpc.HeadOrTailByRequest.Builder
repeated string group_by_column_specs = 4;
addGroupingColumns(GroupingColumnInfo) - Method in interface io.deephaven.parquet.table.metadata.TableInfo.Builder
 
addGroupingColumns(GroupingColumnInfo...) - Method in interface io.deephaven.parquet.table.metadata.TableInfo.Builder
 
addHeader(String, String) - Method in interface io.deephaven.auth.AuthenticationRequestHandler.MetadataResponseListener
 
addHeaders(ColumnHeader<?>) - Method in interface io.deephaven.qst.table.TableHeader.Builder
 
addHeaders(ColumnHeader<?>...) - Method in interface io.deephaven.qst.table.TableHeader.Builder
 
addHolidays(int, FigureDescriptor.BusinessCalendarDescriptor.Holiday) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BusinessCalendarDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BusinessCalendarDescriptor.Holiday holidays = 5;
addHolidays(int, FigureDescriptor.BusinessCalendarDescriptor.Holiday.Builder) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BusinessCalendarDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BusinessCalendarDescriptor.Holiday holidays = 5;
addHolidays(FigureDescriptor.BusinessCalendarDescriptor.Holiday) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BusinessCalendarDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BusinessCalendarDescriptor.Holiday holidays = 5;
addHolidays(FigureDescriptor.BusinessCalendarDescriptor.Holiday.Builder) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BusinessCalendarDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BusinessCalendarDescriptor.Holiday holidays = 5;
addHolidaysBuilder() - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BusinessCalendarDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BusinessCalendarDescriptor.Holiday holidays = 5;
addHolidaysBuilder(int) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BusinessCalendarDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BusinessCalendarDescriptor.Holiday holidays = 5;
addIdentityValue() - Method in class io.deephaven.base.ringbuffer.AggregatingByteRingBuffer
Adds the identity element to the ring buffer.
addIdentityValue() - Method in class io.deephaven.base.ringbuffer.AggregatingCharRingBuffer
Adds the identity element to the ring buffer.
addIdentityValue() - Method in class io.deephaven.base.ringbuffer.AggregatingDoubleRingBuffer
Adds the identity element to the ring buffer.
addIdentityValue() - Method in class io.deephaven.base.ringbuffer.AggregatingFloatRingBuffer
Adds the identity element to the ring buffer.
addIdentityValue() - Method in class io.deephaven.base.ringbuffer.AggregatingIntRingBuffer
Adds the identity element to the ring buffer.
addIdentityValue() - Method in class io.deephaven.base.ringbuffer.AggregatingLongRingBuffer
Adds the identity element to the ring buffer.
addIdentityValue() - Method in class io.deephaven.base.ringbuffer.AggregatingObjectRingBuffer
Adds the identity element to the ring buffer.
addIdentityValue() - Method in class io.deephaven.base.ringbuffer.AggregatingShortRingBuffer
Adds the identity element to the ring buffer.
addIndexColumns(String...) - Method in class io.deephaven.parquet.table.ParquetInstructions.Builder
Add a list of columns to persist together as indexes.
addInputs(MultiJoinInput<TableSpec>) - Method in interface io.deephaven.qst.table.MultiJoinTable.Builder
 
addInputs(MultiJoinInput<TableSpec>...) - Method in interface io.deephaven.qst.table.MultiJoinTable.Builder
 
addInterceptor(FatalErrorReporter.Interceptor) - Method in interface io.deephaven.util.process.FatalErrorReporter
 
addInterceptor(FatalErrorReporter.Interceptor) - Method in class io.deephaven.util.process.FatalErrorReporterBase
 
addInterceptor(LogSink.Interceptor) - Method in class io.deephaven.io.log.LogSink.Null
 
addInterceptor(LogSink.Interceptor<T>) - Method in class io.deephaven.io.log.impl.LogSinkImpl
Add an interceptor
addInterceptor(LogSink.Interceptor<T>) - Method in interface io.deephaven.io.log.LogSink
You can add as many interceptors to a log sink as you like.
addInternal(long, boolean) - Method in class io.deephaven.engine.rowset.impl.sortedranges.SortedRanges
 
addInternal(long, boolean) - Method in class io.deephaven.engine.rowset.impl.sortedranges.SortedRangesLong
 
addInternal(long, boolean) - Method in class io.deephaven.engine.rowset.impl.sortedranges.SortedRangesPacked
 
addItem(Item) - Method in class io.deephaven.base.stats.Group
 
addItems(int, ItemInfo) - Method in class io.deephaven.proto.backplane.grpc.ListItemsResponse.Builder
List of items found in the specified directory.
addItems(int, ItemInfo.Builder) - Method in class io.deephaven.proto.backplane.grpc.ListItemsResponse.Builder
List of items found in the specified directory.
addItems(int, CompletionItem) - Method in class io.deephaven.proto.backplane.script.grpc.GetCompletionItemsResponse.Builder
repeated .io.deephaven.proto.backplane.script.grpc.CompletionItem items = 1;
addItems(int, CompletionItem.Builder) - Method in class io.deephaven.proto.backplane.script.grpc.GetCompletionItemsResponse.Builder
repeated .io.deephaven.proto.backplane.script.grpc.CompletionItem items = 1;
addItems(int, Diagnostic) - Method in class io.deephaven.proto.backplane.script.grpc.GetPullDiagnosticResponse.Builder
repeated .io.deephaven.proto.backplane.script.grpc.Diagnostic items = 3;
addItems(int, Diagnostic.Builder) - Method in class io.deephaven.proto.backplane.script.grpc.GetPullDiagnosticResponse.Builder
repeated .io.deephaven.proto.backplane.script.grpc.Diagnostic items = 3;
addItems(ItemInfo) - Method in class io.deephaven.proto.backplane.grpc.ListItemsResponse.Builder
List of items found in the specified directory.
addItems(ItemInfo.Builder) - Method in class io.deephaven.proto.backplane.grpc.ListItemsResponse.Builder
List of items found in the specified directory.
addItems(CompletionItem) - Method in class io.deephaven.proto.backplane.script.grpc.GetCompletionItemsResponse.Builder
repeated .io.deephaven.proto.backplane.script.grpc.CompletionItem items = 1;
addItems(CompletionItem.Builder) - Method in class io.deephaven.proto.backplane.script.grpc.GetCompletionItemsResponse.Builder
repeated .io.deephaven.proto.backplane.script.grpc.CompletionItem items = 1;
addItems(Diagnostic) - Method in class io.deephaven.proto.backplane.script.grpc.GetPullDiagnosticResponse.Builder
repeated .io.deephaven.proto.backplane.script.grpc.Diagnostic items = 3;
addItems(Diagnostic.Builder) - Method in class io.deephaven.proto.backplane.script.grpc.GetPullDiagnosticResponse.Builder
repeated .io.deephaven.proto.backplane.script.grpc.Diagnostic items = 3;
addItemsBuilder() - Method in class io.deephaven.proto.backplane.grpc.ListItemsResponse.Builder
List of items found in the specified directory.
addItemsBuilder() - Method in class io.deephaven.proto.backplane.script.grpc.GetCompletionItemsResponse.Builder
repeated .io.deephaven.proto.backplane.script.grpc.CompletionItem items = 1;
addItemsBuilder() - Method in class io.deephaven.proto.backplane.script.grpc.GetPullDiagnosticResponse.Builder
repeated .io.deephaven.proto.backplane.script.grpc.Diagnostic items = 3;
addItemsBuilder(int) - Method in class io.deephaven.proto.backplane.grpc.ListItemsResponse.Builder
List of items found in the specified directory.
addItemsBuilder(int) - Method in class io.deephaven.proto.backplane.script.grpc.GetCompletionItemsResponse.Builder
repeated .io.deephaven.proto.backplane.script.grpc.CompletionItem items = 1;
addItemsBuilder(int) - Method in class io.deephaven.proto.backplane.script.grpc.GetPullDiagnosticResponse.Builder
repeated .io.deephaven.proto.backplane.script.grpc.Diagnostic items = 3;
ADDITIONAL_TEXT_EDITS_FIELD_NUMBER - Static variable in class io.deephaven.proto.backplane.script.grpc.CompletionItem
 
additions() - Method in interface io.deephaven.qst.table.Join
 
additions() - Method in class io.deephaven.qst.table.MultiJoinInput
 
addJunk(Token) - Method in interface io.deephaven.lang.generated.Node
 
addJunk(Token) - Method in class io.deephaven.lang.generated.SimpleNode
 
addKey(long) - Method in class io.deephaven.engine.rowset.impl.AdaptiveOrderedLongSetBuilderRandom
 
addKey(long) - Method in class io.deephaven.engine.rowset.impl.AdaptiveRowSetBuilderRandom
 
addKey(long) - Method in class io.deephaven.engine.rowset.impl.MixedBuilderRandom
 
addKey(long) - Method in interface io.deephaven.engine.rowset.impl.OrderedLongSet.BuilderRandom
 
addKey(long) - Method in class io.deephaven.engine.rowset.impl.RangePriorityQueueBuilder
 
addKey(long) - Method in class io.deephaven.engine.rowset.impl.rsp.RspBitmap.BuilderRandom
 
addKey(long) - Method in interface io.deephaven.engine.rowset.RowSetBuilderRandom
 
addKey(long) - Method in class io.deephaven.engine.table.impl.by.BitmapRandomBuilder
 
addKey(long) - Method in class io.deephaven.engine.table.impl.PrecomputedRowSetBuilderRandom
 
addKeyColumnNames(String) - Method in class io.deephaven.proto.backplane.grpc.PartitionByRequest.Builder
repeated string key_column_names = 3;
addKeyColumnNames(String) - Method in class io.deephaven.proto.backplane.grpc.PartitionedTableDescriptor.Builder
The names of the key columns.
addKeyColumnNamesBytes(ByteString) - Method in class io.deephaven.proto.backplane.grpc.PartitionByRequest.Builder
repeated string key_column_names = 3;
addKeyColumnNamesBytes(ByteString) - Method in class io.deephaven.proto.backplane.grpc.PartitionedTableDescriptor.Builder
The names of the key columns.
addKeyColumns(String) - Method in class io.deephaven.proto.backplane.grpc.CreateInputTableRequest.InputTableKind.InMemoryKeyBacked.Builder
repeated string key_columns = 1;
addKeyColumnsBytes(ByteString) - Method in class io.deephaven.proto.backplane.grpc.CreateInputTableRequest.InputTableKind.InMemoryKeyBacked.Builder
repeated string key_columns = 1;
addKeys(String) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BoolMapWithDefault.Builder
repeated string keys = 2;
addKeys(String) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.DoubleMapWithDefault.Builder
repeated string keys = 2;
addKeys(String) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.StringMapWithDefault.Builder
repeated string keys = 2;
addKeys(PrimitiveIterator.OfLong) - Method in class io.deephaven.engine.rowset.impl.AdaptiveOrderedLongSetBuilderRandom
 
addKeys(PrimitiveIterator.OfLong) - Method in interface io.deephaven.engine.rowset.RowSetBuilderRandom
 
addKeysBytes(ByteString) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BoolMapWithDefault.Builder
repeated string keys = 2;
addKeysBytes(ByteString) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.DoubleMapWithDefault.Builder
repeated string keys = 2;
addKeysBytes(ByteString) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.StringMapWithDefault.Builder
repeated string keys = 2;
addLast(T) - Method in class io.deephaven.util.datastructures.RandomAccessDeque
 
addLeftIndices(RowSet) - Method in class io.deephaven.engine.table.impl.join.AbstractJoinKeyState
 
addLeftKey(int, long) - Method in class io.deephaven.engine.table.impl.asofjoin.StaticAsOfJoinStateManagerTypedBase
Returns true if this is the first left row key added to this slot.
addLeftKey(long, long, byte) - Method in class io.deephaven.engine.table.impl.asofjoin.RightIncrementalAsOfJoinStateManagerTypedBase
 
addLeftSide(RowSequence, Chunk[], LongArraySource, long) - Method in class io.deephaven.engine.table.impl.naturaljoin.IncrementalNaturalJoinStateManagerTypedBase
 
addLeftSide(Context, RowSequence, ColumnSource<?>[], LongArraySource, NaturalJoinModifiedSlotTracker) - Method in class io.deephaven.engine.table.impl.naturaljoin.IncrementalNaturalJoinStateManagerTypedBase
 
addLeftSide(Context, RowSequence, ColumnSource<?>[], LongArraySource, NaturalJoinModifiedSlotTracker) - Method in interface io.deephaven.engine.table.impl.BothIncrementalNaturalJoinStateManager
 
addLevels(String) - Method in class io.deephaven.proto.backplane.script.grpc.LogSubscriptionRequest.Builder
repeated string levels = 2;
addLevelsBytes(ByteString) - Method in class io.deephaven.proto.backplane.script.grpc.LogSubscriptionRequest.Builder
repeated string levels = 2;
addListener(AsyncListener) - Method in class io.grpc.servlet.jakarta.web.DelegatingAsyncContext
 
addListener(AsyncListener, ServletRequest, ServletResponse) - Method in class io.grpc.servlet.jakarta.web.DelegatingAsyncContext
 
addLocation(TableLocation) - Method in interface io.deephaven.engine.table.impl.ColumnSourceManager
Add a table location to the list to be checked in run().
addLocation(TableLocation) - Method in class io.deephaven.engine.table.impl.sources.regioned.RegionedColumnSourceManager
 
addLogSink(LogSinkImpl<?>) - Method in class io.deephaven.io.log.impl.LogSinkImpl.BigWriterThread
 
addLogSink(S) - Method in interface io.deephaven.io.log.LogSink.LogSinkWriter
 
addMain(long, int, long, byte) - Method in class io.deephaven.engine.table.impl.NaturalJoinModifiedSlotTracker
Add a slot in the main table.
addMajorTickLocations(double) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.AxisDescriptor.Builder
repeated double major_tick_locations = 17;
addMatch(Collection<CompletionItem.Builder>, Node, String, CompletionRequest, String...) - Method in class io.deephaven.lang.completion.ChunkerCompleter
Deprecated.
addMatch(Collection<CompletionItem.Builder>, Token, Token, String, CompletionRequest, CompletionOptions) - Method in class io.deephaven.lang.completion.results.CompletionBuilder
 
addMatches(JoinMatch) - Method in interface io.deephaven.qst.table.Join.Builder
 
addMatches(JoinMatch) - Method in interface io.deephaven.qst.table.MultiJoinInput.Builder
 
addMatches(JoinMatch) - Method in interface io.deephaven.qst.table.WhereInTable.Builder
 
addMatches(JoinMatch...) - Method in interface io.deephaven.qst.table.Join.Builder
 
addMatches(JoinMatch...) - Method in interface io.deephaven.qst.table.MultiJoinInput.Builder
 
addMatches(JoinMatch...) - Method in interface io.deephaven.qst.table.WhereInTable.Builder
 
addMatchPairs(String) - Method in class io.deephaven.proto.backplane.grpc.Aggregation.AggregationColumns.Builder
repeated string match_pairs = 2;
addMatchPairs(String) - Method in class io.deephaven.proto.backplane.grpc.ComboAggregateRequest.Aggregate.Builder
Deprecated.
used in all aggregates except countBy
addMatchPairs(String) - Method in class io.deephaven.proto.backplane.grpc.UpdateByRequest.UpdateByOperation.UpdateByColumn.Builder
repeated string match_pairs = 2;
addMatchPairsBytes(ByteString) - Method in class io.deephaven.proto.backplane.grpc.Aggregation.AggregationColumns.Builder
repeated string match_pairs = 2;
addMatchPairsBytes(ByteString) - Method in class io.deephaven.proto.backplane.grpc.ComboAggregateRequest.Aggregate.Builder
Deprecated.
used in all aggregates except countBy
addMatchPairsBytes(ByteString) - Method in class io.deephaven.proto.backplane.grpc.UpdateByRequest.UpdateByOperation.UpdateByColumn.Builder
repeated string match_pairs = 2;
addMultiJoinInputs(int, MultiJoinInput) - Method in class io.deephaven.proto.backplane.grpc.MultiJoinTablesRequest.Builder
The source table input specifications.
addMultiJoinInputs(int, MultiJoinInput.Builder) - Method in class io.deephaven.proto.backplane.grpc.MultiJoinTablesRequest.Builder
The source table input specifications.
addMultiJoinInputs(MultiJoinInput) - Method in class io.deephaven.proto.backplane.grpc.MultiJoinTablesRequest.Builder
The source table input specifications.
addMultiJoinInputs(MultiJoinInput.Builder) - Method in class io.deephaven.proto.backplane.grpc.MultiJoinTablesRequest.Builder
The source table input specifications.
addMultiJoinInputsBuilder() - Method in class io.deephaven.proto.backplane.grpc.MultiJoinTablesRequest.Builder
The source table input specifications.
addMultiJoinInputsBuilder(int) - Method in class io.deephaven.proto.backplane.grpc.MultiJoinTablesRequest.Builder
The source table input specifications.
addMultiSeries(int, FigureDescriptor.MultiSeriesDescriptor) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.ChartDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.MultiSeriesDescriptor multi_series = 4;
addMultiSeries(int, FigureDescriptor.MultiSeriesDescriptor.Builder) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.ChartDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.MultiSeriesDescriptor multi_series = 4;
addMultiSeries(FigureDescriptor.MultiSeriesDescriptor) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.ChartDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.MultiSeriesDescriptor multi_series = 4;
addMultiSeries(FigureDescriptor.MultiSeriesDescriptor.Builder) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.ChartDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.MultiSeriesDescriptor multi_series = 4;
addMultiSeriesBuilder() - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.ChartDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.MultiSeriesDescriptor multi_series = 4;
addMultiSeriesBuilder(int) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.ChartDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.MultiSeriesDescriptor multi_series = 4;
addNames(String) - Method in interface io.deephaven.processor.NamedObjectProcessor.Builder
 
addNames(String...) - Method in interface io.deephaven.processor.NamedObjectProcessor.Builder
 
addNotification(NotificationQueue.Notification) - Method in class io.deephaven.engine.context.PoisonedUpdateGraph
 
addNotification(NotificationQueue.Notification) - Method in class io.deephaven.engine.updategraph.impl.BaseUpdateGraph
Enqueue a notification to be flushed according to its priority.
addNotification(NotificationQueue.Notification) - Method in class io.deephaven.engine.updategraph.impl.PeriodicUpdateGraph
Enqueue a notification to be flushed according to its priority.
addNotification(NotificationQueue.Notification) - Method in interface io.deephaven.engine.updategraph.NotificationQueue
Add a notification for this NotificationQueue to deliver (by invoking its run() method).
addNotifications(Collection<? extends NotificationQueue.Notification>) - Method in class io.deephaven.engine.context.PoisonedUpdateGraph
 
addNotifications(Collection<? extends NotificationQueue.Notification>) - Method in class io.deephaven.engine.updategraph.impl.BaseUpdateGraph
Enqueue a collection of notifications to be flushed.
addNotifications(Collection<? extends NotificationQueue.Notification>) - Method in interface io.deephaven.engine.updategraph.NotificationQueue
Enqueue a collection of notifications to be flushed.
addOnCloseCallback(Closeable) - Method in class io.deephaven.server.session.SessionState
Attach an on-close callback bound to the life of the session.
addOneClickChartModifier(OneClickChartModifier) - Method in class io.deephaven.plot.AxisImpl
 
AddOnlyFirstOrLastChunkedOperator - Class in io.deephaven.engine.table.impl.by
 
AddOnlyToBlinkTableAdapter - Class in io.deephaven.engine.table.impl
This class provides a single method to adapt an add-only or append-only table to a blink table.
AddOnlyToBlinkTableAdapter() - Constructor for class io.deephaven.engine.table.impl.AddOnlyToBlinkTableAdapter
 
addOperation(String, TotalsTableBuilder.AggType) - Method in class io.deephaven.engine.util.TotalsTableBuilder
Adds an operation for a column.
addOperation(String, TotalsTableBuilder.AggType, String) - Method in class io.deephaven.engine.util.TotalsTableBuilder
Adds an operation for a column.
addOperation(String, String) - Method in class io.deephaven.engine.util.TotalsTableBuilder
Adds an operation for a column.
addOperation(String, String, String) - Method in class io.deephaven.engine.util.TotalsTableBuilder
Adds an operation for a column.
addOperations(int, UpdateByRequest.UpdateByOperation) - Method in class io.deephaven.proto.backplane.grpc.UpdateByRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.UpdateByRequest.UpdateByOperation operations = 4;
addOperations(int, UpdateByRequest.UpdateByOperation.Builder) - Method in class io.deephaven.proto.backplane.grpc.UpdateByRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.UpdateByRequest.UpdateByOperation operations = 4;
addOperations(UpdateByOperation) - Method in interface io.deephaven.qst.table.UpdateByTable.Builder
 
addOperations(UpdateByOperation...) - Method in interface io.deephaven.qst.table.UpdateByTable.Builder
 
addOperations(UpdateByRequest.UpdateByOperation) - Method in class io.deephaven.proto.backplane.grpc.UpdateByRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.UpdateByRequest.UpdateByOperation operations = 4;
addOperations(UpdateByRequest.UpdateByOperation.Builder) - Method in class io.deephaven.proto.backplane.grpc.UpdateByRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.UpdateByRequest.UpdateByOperation operations = 4;
addOperationsBuilder() - Method in class io.deephaven.proto.backplane.grpc.UpdateByRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.UpdateByRequest.UpdateByOperation operations = 4;
addOperationsBuilder(int) - Method in class io.deephaven.proto.backplane.grpc.UpdateByRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.UpdateByRequest.UpdateByOperation operations = 4;
addOps(int, BatchTableRequest.Operation) - Method in class io.deephaven.proto.backplane.grpc.BatchTableRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.BatchTableRequest.Operation ops = 1;
addOps(int, BatchTableRequest.Operation.Builder) - Method in class io.deephaven.proto.backplane.grpc.BatchTableRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.BatchTableRequest.Operation ops = 1;
addOps(BatchTableRequest.Operation) - Method in class io.deephaven.proto.backplane.grpc.BatchTableRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.BatchTableRequest.Operation ops = 1;
addOps(BatchTableRequest.Operation.Builder) - Method in class io.deephaven.proto.backplane.grpc.BatchTableRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.BatchTableRequest.Operation ops = 1;
addOpsBuilder() - Method in class io.deephaven.proto.backplane.grpc.BatchTableRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.BatchTableRequest.Operation ops = 1;
addOpsBuilder(int) - Method in class io.deephaven.proto.backplane.grpc.BatchTableRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.BatchTableRequest.Operation ops = 1;
addOptionalReferences(int, Reference) - Method in class io.deephaven.proto.backplane.grpc.SearchCondition.Builder
repeated .io.deephaven.proto.backplane.grpc.Reference optional_references = 2;
addOptionalReferences(int, Reference.Builder) - Method in class io.deephaven.proto.backplane.grpc.SearchCondition.Builder
repeated .io.deephaven.proto.backplane.grpc.Reference optional_references = 2;
addOptionalReferences(Reference) - Method in class io.deephaven.proto.backplane.grpc.SearchCondition.Builder
repeated .io.deephaven.proto.backplane.grpc.Reference optional_references = 2;
addOptionalReferences(Reference.Builder) - Method in class io.deephaven.proto.backplane.grpc.SearchCondition.Builder
repeated .io.deephaven.proto.backplane.grpc.Reference optional_references = 2;
addOptionalReferencesBuilder() - Method in class io.deephaven.proto.backplane.grpc.SearchCondition.Builder
repeated .io.deephaven.proto.backplane.grpc.Reference optional_references = 2;
addOptionalReferencesBuilder(int) - Method in class io.deephaven.proto.backplane.grpc.SearchCondition.Builder
repeated .io.deephaven.proto.backplane.grpc.Reference optional_references = 2;
addOrderedRowKeysChunk(IntChunk<? extends OrderedRowKeys>) - Method in interface io.deephaven.engine.rowset.RowSetBuilderRandom
 
addOrderedRowKeysChunk(LongChunk<? extends OrderedRowKeys>) - Method in interface io.deephaven.engine.rowset.RowSetBuilderRandom
 
addOrderedRowKeysChunk(LongChunk<OrderedRowKeys>, int, int) - Method in interface io.deephaven.engine.rowset.RowSetBuilderRandom
 
addOverwrite(byte, byte) - Method in class io.deephaven.base.ringbuffer.AggregatingByteRingBuffer
Adds an entry to the ring buffer.
addOverwrite(byte, byte) - Method in class io.deephaven.base.ringbuffer.ByteRingBuffer
Add an entry to the ring buffer.
addOverwrite(char, char) - Method in class io.deephaven.base.ringbuffer.AggregatingCharRingBuffer
Adds an entry to the ring buffer.
addOverwrite(char, char) - Method in class io.deephaven.base.ringbuffer.CharRingBuffer
Add an entry to the ring buffer.
addOverwrite(double, double) - Method in class io.deephaven.base.ringbuffer.AggregatingDoubleRingBuffer
Adds an entry to the ring buffer.
addOverwrite(double, double) - Method in class io.deephaven.base.ringbuffer.DoubleRingBuffer
Add an entry to the ring buffer.
addOverwrite(float, float) - Method in class io.deephaven.base.ringbuffer.AggregatingFloatRingBuffer
Adds an entry to the ring buffer.
addOverwrite(float, float) - Method in class io.deephaven.base.ringbuffer.FloatRingBuffer
Add an entry to the ring buffer.
addOverwrite(int, int) - Method in class io.deephaven.base.ringbuffer.AggregatingIntRingBuffer
Adds an entry to the ring buffer.
addOverwrite(int, int) - Method in class io.deephaven.base.ringbuffer.IntRingBuffer
Add an entry to the ring buffer.
addOverwrite(long, long) - Method in class io.deephaven.base.ringbuffer.AggregatingLongRingBuffer
Adds an entry to the ring buffer.
addOverwrite(long, long) - Method in class io.deephaven.base.ringbuffer.LongRingBuffer
Add an entry to the ring buffer.
addOverwrite(short, short) - Method in class io.deephaven.base.ringbuffer.AggregatingShortRingBuffer
Adds an entry to the ring buffer.
addOverwrite(short, short) - Method in class io.deephaven.base.ringbuffer.ShortRingBuffer
Add an entry to the ring buffer.
addOverwrite(E) - Method in class io.deephaven.base.RingBuffer
 
addOverwrite(T, T) - Method in class io.deephaven.base.ringbuffer.AggregatingObjectRingBuffer
Adds an entry to the ring buffer.
addOverwrite(T, T) - Method in class io.deephaven.base.ringbuffer.ObjectRingBuffer
Add an entry to the ring buffer.
addPacked(SortedRanges, long, long, boolean) - Static method in class io.deephaven.engine.rowset.impl.sortedranges.SortedRanges
 
addPackedWithStart(SortedRanges, int, long, long, MutableInt, boolean) - Static method in class io.deephaven.engine.rowset.impl.sortedranges.SortedRanges
 
addPage(Object, int, Statistics<?>) - Method in interface io.deephaven.parquet.base.ColumnWriter
Add a page (potentially containing nulls) to the file.
addPageNoNulls(Object, int, Statistics<?>) - Method in interface io.deephaven.parquet.base.ColumnWriter
Add a page with no nulls to the file.
addPairs(Pair) - Method in interface io.deephaven.api.agg.ColumnAggregations.Builder
 
addPairs(Pair...) - Method in interface io.deephaven.api.agg.ColumnAggregations.Builder
 
addParam(String, T) - Static method in interface io.deephaven.engine.context.QueryScope
Adds a parameter to the default instance QueryScope, or updates the value of an existing parameter.
addParameters(int, ParameterInformation) - Method in class io.deephaven.proto.backplane.script.grpc.SignatureInformation.Builder
repeated .io.deephaven.proto.backplane.script.grpc.ParameterInformation parameters = 3;
addParameters(int, ParameterInformation.Builder) - Method in class io.deephaven.proto.backplane.script.grpc.SignatureInformation.Builder
repeated .io.deephaven.proto.backplane.script.grpc.ParameterInformation parameters = 3;
addParameters(ParameterInformation) - Method in class io.deephaven.proto.backplane.script.grpc.SignatureInformation.Builder
repeated .io.deephaven.proto.backplane.script.grpc.ParameterInformation parameters = 3;
addParameters(ParameterInformation.Builder) - Method in class io.deephaven.proto.backplane.script.grpc.SignatureInformation.Builder
repeated .io.deephaven.proto.backplane.script.grpc.ParameterInformation parameters = 3;
addParametersBuilder() - Method in class io.deephaven.proto.backplane.script.grpc.SignatureInformation.Builder
repeated .io.deephaven.proto.backplane.script.grpc.ParameterInformation parameters = 3;
addParametersBuilder(int) - Method in class io.deephaven.proto.backplane.script.grpc.SignatureInformation.Builder
repeated .io.deephaven.proto.backplane.script.grpc.ParameterInformation parameters = 3;
addParentReference(Object) - Method in class io.deephaven.engine.table.impl.BaseTable
 
addParentReference(Object) - Method in interface io.deephaven.engine.table.impl.TableAdapter
 
addParentReference(Object) - Method in interface io.deephaven.engine.updategraph.DynamicNode
Called on a dependent node to ensure that a strong reference is maintained to any parent object that is required for the proper maintenance and functioning of the dependent.
addParentReference(Object) - Method in class io.deephaven.server.barrage.BarrageMessageProducer
 
addParquetFileMetadata(URI, ParquetMetadata) - Method in enum class io.deephaven.parquet.base.NullParquetMetadataFileWriter
 
addParquetFileMetadata(URI, ParquetMetadata) - Method in interface io.deephaven.parquet.base.ParquetMetadataFileWriter
Add the parquet metadata for the provided parquet file to the list of metadata to be written to combined metadata files.
addPartitionedTableHandle(PartitionedTableHandle) - Method in class io.deephaven.plot.AbstractSeriesInternal
 
addPartitionedTableHandle(PartitionedTableHandle) - Method in class io.deephaven.plot.AxisImpl
 
addPartitionedTableHandle(PartitionedTableHandle) - Method in interface io.deephaven.plot.SeriesInternal
Add a partitioned table that drives this series.
addPath(String) - Method in class io.deephaven.server.jetty.ControlledCacheResource
 
addPrefixed(String, LabeledValues<T>) - Method in interface io.deephaven.qst.LabeledValues.Builder
 
addPreview(Class<S>, Class<D>, Function<S, D>) - Static method in class io.deephaven.engine.table.impl.preview.ColumnPreviewManager
Adds a data type to be converted to a Preview Type.
addProbe(HasherConfig.ProbeSpec) - Method in class io.deephaven.engine.table.impl.by.typed.HasherConfig.Builder
 
addRange(long, long) - Method in class io.deephaven.engine.rowset.impl.AdaptiveOrderedLongSetBuilderRandom
 
addRange(long, long) - Method in class io.deephaven.engine.rowset.impl.AdaptiveRowSetBuilderRandom
 
addRange(long, long) - Method in class io.deephaven.engine.rowset.impl.MixedBuilderRandom
 
addRange(long, long) - Method in interface io.deephaven.engine.rowset.impl.OrderedLongSet.BuilderRandom
 
addRange(long, long) - Method in class io.deephaven.engine.rowset.impl.RangePriorityQueueBuilder
 
addRange(long, long) - Method in class io.deephaven.engine.rowset.impl.rsp.RspBitmap
 
addRange(long, long) - Method in class io.deephaven.engine.rowset.impl.rsp.RspBitmap.BuilderRandom
 
addRange(long, long) - Method in class io.deephaven.engine.rowset.impl.sortedranges.SortedRanges
 
addRange(long, long) - Method in interface io.deephaven.engine.rowset.RowSetBuilderRandom
 
addRange(long, long) - Method in class io.deephaven.engine.table.impl.by.BitmapRandomBuilder
 
addRange(long, long) - Method in class io.deephaven.engine.table.impl.PrecomputedRowSetBuilderRandom
 
addRangeExclusiveEnd(long, long) - Method in class io.deephaven.engine.rowset.impl.rsp.RspBitmap
 
addRangeInternal(long, long, boolean) - Method in class io.deephaven.engine.rowset.impl.sortedranges.SortedRanges
 
addRangeInternal(long, long, boolean) - Method in class io.deephaven.engine.rowset.impl.sortedranges.SortedRangesLong
 
addRangeInternal(long, long, boolean) - Method in class io.deephaven.engine.rowset.impl.sortedranges.SortedRangesPacked
 
addRangePacked(SortedRanges, long, long, long, long, boolean) - Static method in class io.deephaven.engine.rowset.impl.sortedranges.SortedRanges
 
addRangePackedWithStart(SortedRanges, int, long, long, long, long, long, MutableInt, boolean) - Static method in class io.deephaven.engine.rowset.impl.sortedranges.SortedRanges
 
addRanges(LongRangeIterator) - Method in class io.deephaven.engine.rowset.impl.AdaptiveOrderedLongSetBuilderRandom
 
addRanges(LongRangeIterator) - Method in interface io.deephaven.engine.rowset.RowSetBuilderRandom
 
addRangesUnsafeNoWriteCheck(RowSet.RangeIterator) - Method in class io.deephaven.engine.rowset.impl.rsp.RspBitmap
 
addRangeUnsafe(long, long) - Method in class io.deephaven.engine.rowset.impl.rsp.RspBitmap
 
addRangeUnsafe(long, long) - Method in class io.deephaven.engine.rowset.impl.sortedranges.SortedRanges
 
addRangeUnsafeNoWriteCheck(int, long, long) - Method in class io.deephaven.engine.rowset.impl.rsp.RspBitmap
 
addRangeUnsafeNoWriteCheck(long, long) - Method in class io.deephaven.engine.rowset.impl.rsp.RspBitmap
 
addRecordBatch(ByteBuffer) - Method in class io.deephaven.extensions.barrage.util.ArrowToTableConverter
 
addRecordBatches(ByteBuffer...) - Method in class io.deephaven.extensions.barrage.util.ArrowToTableConverter
 
addReferences(int, TypedTicket) - Method in class io.deephaven.proto.backplane.grpc.ClientData.Builder
The typed references, may be empty.
addReferences(int, TypedTicket.Builder) - Method in class io.deephaven.proto.backplane.grpc.ClientData.Builder
The typed references, may be empty.
addReferences(TypedTicket) - Method in class io.deephaven.proto.backplane.grpc.ClientData.Builder
The typed references, may be empty.
addReferences(TypedTicket.Builder) - Method in class io.deephaven.proto.backplane.grpc.ClientData.Builder
The typed references, may be empty.
addReferencesBuilder() - Method in class io.deephaven.proto.backplane.grpc.ClientData.Builder
The typed references, may be empty.
addReferencesBuilder(int) - Method in class io.deephaven.proto.backplane.grpc.ClientData.Builder
The typed references, may be empty.
addRegion(ColumnDefinition<?>, ColumnLocation) - Method in interface io.deephaven.engine.table.impl.sources.regioned.RegionedColumnSource
Add a region to this regioned column source.
addRemoved(int, FieldInfo) - Method in class io.deephaven.proto.backplane.grpc.FieldsChangeUpdate.Builder
repeated .io.deephaven.proto.backplane.grpc.FieldInfo removed = 3;
addRemoved(int, FieldInfo.Builder) - Method in class io.deephaven.proto.backplane.grpc.FieldsChangeUpdate.Builder
repeated .io.deephaven.proto.backplane.grpc.FieldInfo removed = 3;
addRemoved(FieldInfo) - Method in class io.deephaven.proto.backplane.grpc.FieldsChangeUpdate.Builder
repeated .io.deephaven.proto.backplane.grpc.FieldInfo removed = 3;
addRemoved(FieldInfo.Builder) - Method in class io.deephaven.proto.backplane.grpc.FieldsChangeUpdate.Builder
repeated .io.deephaven.proto.backplane.grpc.FieldInfo removed = 3;
addRemovedBuilder() - Method in class io.deephaven.proto.backplane.grpc.FieldsChangeUpdate.Builder
repeated .io.deephaven.proto.backplane.grpc.FieldInfo removed = 3;
addRemovedBuilder(int) - Method in class io.deephaven.proto.backplane.grpc.FieldsChangeUpdate.Builder
repeated .io.deephaven.proto.backplane.grpc.FieldInfo removed = 3;
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.flightjs.protocol.BrowserFlight.BrowserNextResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.AddTableRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.AddTableResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.AggregateAllRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.AggregateRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.Aggregation.AggregationColumns.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.Aggregation.AggregationCount.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.Aggregation.AggregationPartition.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.Aggregation.AggregationRowKey.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.Aggregation.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.AggSpec.AggSpecAbsSum.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.AggSpec.AggSpecApproximatePercentile.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.AggSpec.AggSpecAvg.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.AggSpec.AggSpecCountDistinct.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.AggSpec.AggSpecDistinct.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.AggSpec.AggSpecFirst.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.AggSpec.AggSpecFormula.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.AggSpec.AggSpecFreeze.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.AggSpec.AggSpecGroup.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.AggSpec.AggSpecLast.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.AggSpec.AggSpecMax.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.AggSpec.AggSpecMedian.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.AggSpec.AggSpecMin.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.AggSpec.AggSpecNonUniqueSentinel.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.AggSpec.AggSpecPercentile.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.AggSpec.AggSpecSorted.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.AggSpec.AggSpecSortedColumn.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.AggSpec.AggSpecStd.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.AggSpec.AggSpecSum.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.AggSpec.AggSpecTDigest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.AggSpec.AggSpecUnique.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.AggSpec.AggSpecVar.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.AggSpec.AggSpecWeighted.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.AggSpec.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.AjRajTablesRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.AndCondition.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.ApplyPreviewColumnsRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.AsOfJoinTablesRequest.Builder
Deprecated.
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.AuthenticationConstantsRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.AuthenticationConstantsResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.BatchTableRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.BatchTableRequest.Operation.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.BrowserNextResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.ClientData.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.CloseSessionResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.ColumnStatisticsRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.ComboAggregateRequest.Aggregate.Builder
Deprecated.
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.ComboAggregateRequest.Builder
Deprecated.
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.CompareCondition.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.Condition.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.ConfigurationConstantsRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.ConfigurationConstantsResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.ConfigValue.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.ConnectRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.ContainsCondition.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.CreateDirectoryRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.CreateDirectoryResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.CreateInputTableRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.CreateInputTableRequest.InputTableKind.Blink.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.CreateInputTableRequest.InputTableKind.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.CreateInputTableRequest.InputTableKind.InMemoryAppendOnly.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.CreateInputTableRequest.InputTableKind.InMemoryKeyBacked.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.CrossJoinTablesRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.DeleteItemRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.DeleteItemResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.DeleteTableRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.DeleteTableResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.DropColumnsRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.EmptyTableRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.ExactJoinTablesRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.ExportedTableCreationResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.ExportedTableUpdateMessage.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.ExportedTableUpdatesRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.ExportNotification.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.ExportNotificationRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.ExportRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.ExportResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.FetchFileRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.FetchFileResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.FetchObjectRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.FetchObjectResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.FetchTableRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.FieldInfo.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.FieldsChangeUpdate.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.FilterTableRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.FlattenRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.GetTableRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.HandshakeRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.HandshakeResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.HeadOrTailByRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.HeadOrTailRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.HierarchicalTableApplyRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.HierarchicalTableApplyResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.HierarchicalTableDescriptor.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.HierarchicalTableSourceExportRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.HierarchicalTableViewKeyTableDescriptor.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.HierarchicalTableViewRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.HierarchicalTableViewResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.InCondition.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.InvokeCondition.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.IsNullCondition.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.ItemInfo.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.LeftJoinTablesRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.ListFieldsRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.ListItemsRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.ListItemsResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.Literal.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.MatchesCondition.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.MathContext.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.MergeRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.MergeTablesRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.MetaTableRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.MoveItemRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.MoveItemResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.MultiJoinInput.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.MultiJoinTablesRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.NaturalJoinTablesRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.NotCondition.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.OrCondition.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.PartitionByRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.PartitionByResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.PartitionedTableDescriptor.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.PublishRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.PublishResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.RangeJoinTablesRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.Reference.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.ReleaseRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.ReleaseResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.RollupRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.RollupResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.RunChartDownsampleRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.RunChartDownsampleRequest.ZoomRange.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.SaveFileRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.SaveFileResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.SearchCondition.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.SeekRowRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.SeekRowResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.SelectDistinctRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.SelectOrUpdateRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.ServerData.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.SnapshotTableRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.SnapshotWhenTableRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.SortDescriptor.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.SortTableRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.StreamRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.StreamResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.TableReference.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.TerminationNotificationRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.TerminationNotificationResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.TerminationNotificationResponse.StackTrace.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.Ticket.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.TimeTableRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.TreeRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.TreeResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.TypedTicket.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.UngroupRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.UnstructuredFilterTableRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.UpdateByDeltaOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.UpdateByEmOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.UpdateByRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.UpdateByRequest.UpdateByOperation.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.UpdateByRequest.UpdateByOperation.UpdateByColumn.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.UpdateByRequest.UpdateByOperation.UpdateByColumn.UpdateBySpec.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.UpdateByRequest.UpdateByOperation.UpdateByColumn.UpdateBySpec.UpdateByCumulativeMax.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.UpdateByRequest.UpdateByOperation.UpdateByColumn.UpdateBySpec.UpdateByCumulativeMin.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.UpdateByRequest.UpdateByOperation.UpdateByColumn.UpdateBySpec.UpdateByCumulativeProduct.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.UpdateByRequest.UpdateByOperation.UpdateByColumn.UpdateBySpec.UpdateByCumulativeSum.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.UpdateByRequest.UpdateByOperation.UpdateByColumn.UpdateBySpec.UpdateByDelta.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.UpdateByRequest.UpdateByOperation.UpdateByColumn.UpdateBySpec.UpdateByEma.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.UpdateByRequest.UpdateByOperation.UpdateByColumn.UpdateBySpec.UpdateByEmMax.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.UpdateByRequest.UpdateByOperation.UpdateByColumn.UpdateBySpec.UpdateByEmMin.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.UpdateByRequest.UpdateByOperation.UpdateByColumn.UpdateBySpec.UpdateByEms.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.UpdateByRequest.UpdateByOperation.UpdateByColumn.UpdateBySpec.UpdateByEmStd.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.UpdateByRequest.UpdateByOperation.UpdateByColumn.UpdateBySpec.UpdateByFill.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.UpdateByRequest.UpdateByOperation.UpdateByColumn.UpdateBySpec.UpdateByRollingAvg.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.UpdateByRequest.UpdateByOperation.UpdateByColumn.UpdateBySpec.UpdateByRollingCount.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.UpdateByRequest.UpdateByOperation.UpdateByColumn.UpdateBySpec.UpdateByRollingFormula.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.UpdateByRequest.UpdateByOperation.UpdateByColumn.UpdateBySpec.UpdateByRollingGroup.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.UpdateByRequest.UpdateByOperation.UpdateByColumn.UpdateBySpec.UpdateByRollingMax.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.UpdateByRequest.UpdateByOperation.UpdateByColumn.UpdateBySpec.UpdateByRollingMin.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.UpdateByRequest.UpdateByOperation.UpdateByColumn.UpdateBySpec.UpdateByRollingProduct.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.UpdateByRequest.UpdateByOperation.UpdateByColumn.UpdateBySpec.UpdateByRollingStd.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.UpdateByRequest.UpdateByOperation.UpdateByColumn.UpdateBySpec.UpdateByRollingSum.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.UpdateByRequest.UpdateByOperation.UpdateByColumn.UpdateBySpec.UpdateByRollingWAvg.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.UpdateByRequest.UpdateByOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.UpdateByWindowScale.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.UpdateByWindowScale.UpdateByWindowTicks.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.UpdateByWindowScale.UpdateByWindowTime.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.Value.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.WhereInRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.grpc.WrappedAuthenticationRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.AutoCompleteRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.AutoCompleteResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.BindTableToVariableRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.BindTableToVariableResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.BrowserNextResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.CancelAutoCompleteRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.CancelAutoCompleteResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.CancelCommandRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.CancelCommandResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.ChangeDocumentRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.ChangeDocumentRequest.TextDocumentContentChangeEvent.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.CloseDocumentRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.CompletionContext.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.CompletionItem.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.Diagnostic.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.Diagnostic.CodeDescription.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.DocumentRange.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.ExecuteCommandRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.ExecuteCommandResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.AxisDescriptor.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BoolMapWithDefault.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BusinessCalendarDescriptor.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BusinessCalendarDescriptor.BusinessPeriod.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BusinessCalendarDescriptor.Holiday.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BusinessCalendarDescriptor.LocalDate.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.ChartDescriptor.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.DoubleMapWithDefault.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.MultiSeriesDescriptor.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.MultiSeriesSourceDescriptor.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.OneClickDescriptor.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.SeriesDescriptor.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.SourceDescriptor.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.StringMapWithDefault.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.GetCompletionItemsRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.GetCompletionItemsResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.GetConsoleTypesRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.GetConsoleTypesResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.GetDiagnosticRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.GetHeapInfoRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.GetHeapInfoResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.GetHoverRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.GetHoverResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.GetPublishDiagnosticResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.GetPullDiagnosticResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.GetSignatureHelpRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.GetSignatureHelpResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.LogSubscriptionData.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.LogSubscriptionRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.MarkupContent.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.OpenDocumentRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.ParameterInformation.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.Position.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.SignatureHelpContext.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.SignatureInformation.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.StartConsoleRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.StartConsoleResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.TextDocumentItem.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.TextEdit.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.backplane.script.grpc.VersionedTextDocumentIdentifier.Builder
 
addRightIndices(RowSet) - Method in class io.deephaven.engine.table.impl.join.AbstractJoinKeyState
 
addRightKey(int, long) - Method in class io.deephaven.engine.table.impl.asofjoin.StaticAsOfJoinStateManagerTypedBase
 
addRightKey(long, long, byte) - Method in class io.deephaven.engine.table.impl.asofjoin.RightIncrementalAsOfJoinStateManagerTypedBase
 
addRightSide(RowSequence, Chunk[]) - Method in class io.deephaven.engine.table.impl.naturaljoin.RightIncrementalNaturalJoinStateManagerTypedBase
 
addRightSide(RowSequence, Chunk[], NaturalJoinModifiedSlotTracker) - Method in class io.deephaven.engine.table.impl.naturaljoin.IncrementalNaturalJoinStateManagerTypedBase
 
addRightSide(RowSequence, Chunk[], NaturalJoinModifiedSlotTracker) - Method in class io.deephaven.engine.table.impl.naturaljoin.RightIncrementalNaturalJoinStateManagerTypedBase
 
addRightSide(RowSequence, ColumnSource<?>[]) - Method in class io.deephaven.engine.table.impl.naturaljoin.RightIncrementalNaturalJoinStateManagerTypedBase
 
addRightSide(RowSequence, ColumnSource<?>[]) - Method in class io.deephaven.engine.table.impl.RightIncrementalNaturalJoinStateManager
 
addRightSide(Context, RowSequence, ColumnSource<?>[], NaturalJoinModifiedSlotTracker) - Method in interface io.deephaven.engine.table.impl.BothIncrementalNaturalJoinStateManager
 
addRightSide(Context, RowSequence, ColumnSource<?>[], NaturalJoinModifiedSlotTracker) - Method in class io.deephaven.engine.table.impl.naturaljoin.IncrementalNaturalJoinStateManagerTypedBase
 
addRightSide(Context, RowSequence, ColumnSource<?>[], NaturalJoinModifiedSlotTracker) - Method in class io.deephaven.engine.table.impl.naturaljoin.RightIncrementalNaturalJoinStateManagerTypedBase
 
addRightSide(Context, RowSequence, ColumnSource<?>[], NaturalJoinModifiedSlotTracker) - Method in class io.deephaven.engine.table.impl.RightIncrementalNaturalJoinStateManager
 
addRow(Object...) - Method in class io.deephaven.engine.table.impl.util.TableBuilder
Deprecated.
Adds a row to the table.
addRowGroup(long) - Method in class io.deephaven.parquet.base.ParquetFileWriter
 
addRowKey(long) - Method in interface io.deephaven.engine.table.impl.UpdatableTable.RowSetChangeRecorder
Flag key as an addition (or a modification if previously removed in this cycle).
addRowKey(long) - Method in class io.deephaven.engine.table.impl.UpdateSourceQueryTable
 
addRowKeyRange(long, long) - Method in class io.deephaven.engine.table.impl.UpdateSourceQueryTable
 
addRowKeysChunk(IntChunk<? extends RowKeys>) - Method in interface io.deephaven.engine.rowset.RowSetBuilderRandom
 
addRowKeysChunk(LongChunk<? extends RowKeys>) - Method in interface io.deephaven.engine.rowset.RowSetBuilderRandom
 
addRowOffsets() - Method in interface io.deephaven.extensions.barrage.BarrageStreamGeneratorImpl.RecordBatchMessageView
 
addRowSet(IterativeChunkedAggregationOperator.SingletonContext, RowSet, long) - Method in class io.deephaven.engine.table.impl.by.UniqueRowKeyChunkedOperator
 
addRowSet(RowSet) - Method in class io.deephaven.engine.rowset.impl.AdaptiveOrderedLongSetBuilderRandom
 
addRowSet(RowSet) - Method in interface io.deephaven.engine.rowset.RowSetBuilderRandom
 
addRowSet(IterativeChunkedAggregationOperator.SingletonContext, RowSet, long) - Method in class io.deephaven.engine.table.impl.by.BlinkFirstChunkedOperator
 
addRowSet(IterativeChunkedAggregationOperator.SingletonContext, RowSet, long) - Method in class io.deephaven.engine.table.impl.by.BlinkLastChunkedOperator
 
addRowSet(IterativeChunkedAggregationOperator.SingletonContext, RowSet, long) - Method in class io.deephaven.engine.table.impl.by.AddOnlyFirstOrLastChunkedOperator
 
addRowSet(IterativeChunkedAggregationOperator.SingletonContext, RowSet, long) - Method in class io.deephaven.engine.table.impl.by.FirstOrLastChunkedOperator
 
addRowSet(IterativeChunkedAggregationOperator.SingletonContext, RowSet, long) - Method in class io.deephaven.engine.table.impl.by.GroupByChunkedOperator
 
addRowSet(IterativeChunkedAggregationOperator.SingletonContext, RowSet, long) - Method in interface io.deephaven.engine.table.impl.by.IterativeChunkedAggregationOperator
 
addRowSet(IterativeChunkedAggregationOperator.SingletonContext, RowSet, long) - Method in class io.deephaven.engine.table.impl.by.PartitionByChunkedOperator
 
addRowSet(IterativeChunkedAggregationOperator.SingletonContext, RowSet, long) - Method in class io.deephaven.engine.table.impl.by.StaticFirstOrLastChunkedOperator
 
addScope(IsScope) - Method in interface io.deephaven.lang.generated.Node
 
addScope(List<IsScope>) - Method in interface io.deephaven.lang.api.HasScope
 
addScope(List<IsScope>) - Method in interface io.deephaven.lang.generated.Node
 
addScriptImportClass(Class<?>) - Method in class io.deephaven.engine.util.GroovyDeephavenSession
 
addScriptImportClass(String) - Method in class io.deephaven.engine.util.GroovyDeephavenSession
 
addScriptImportStatic(Class<?>) - Method in class io.deephaven.engine.util.GroovyDeephavenSession
 
addScriptImportStatic(String) - Method in class io.deephaven.engine.util.GroovyDeephavenSession
 
addSeries(int, FigureDescriptor.SeriesDescriptor) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.ChartDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.SeriesDescriptor series = 3;
addSeries(int, FigureDescriptor.SeriesDescriptor.Builder) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.ChartDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.SeriesDescriptor series = 3;
addSeries(FigureDescriptor.SeriesDescriptor) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.ChartDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.SeriesDescriptor series = 3;
addSeries(FigureDescriptor.SeriesDescriptor.Builder) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.ChartDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.SeriesDescriptor series = 3;
addSeries(SERIES, Object) - Method in class io.deephaven.plot.datasets.multiseries.AbstractMultiSeries
 
addSeries(T, Object) - Method in interface io.deephaven.plot.datasets.multiseries.MultiSeriesInternal
Add the given series to this MultiSeries
addSeriesBuilder() - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.ChartDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.SeriesDescriptor series = 3;
addSeriesBuilder(int) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.ChartDescriptor.Builder
repeated .io.deephaven.proto.backplane.script.grpc.FigureDescriptor.SeriesDescriptor series = 3;
addSharedFields(ObjectField) - Method in interface io.deephaven.json.TypedObjectValue.Builder
 
addSharedFields(ObjectField...) - Method in interface io.deephaven.json.TypedObjectValue.Builder
 
addShiftedColumns(Table, long, MatchPair...) - Static method in class io.deephaven.engine.table.impl.ShiftedColumnOperation
Creates a new table that has all the columns of the source table plus includes the new shifted column(s).
addShiftedColumns(Table, long, String...) - Static method in class io.deephaven.engine.table.impl.ShiftedColumnOperation
Creates a new table that has all the columns of the source table plus includes the new shifted column(s).
addShutdownHookToRuntime() - Method in interface io.deephaven.util.process.ShutdownManager
Add a shutdown hook to the runtime that will invoke all registered shutdown tasks, if they haven't previously been invoked.
addShutdownHookToRuntime() - Method in class io.deephaven.util.process.ShutdownManagerImpl
 
addSignatures(int, SignatureInformation) - Method in class io.deephaven.proto.backplane.script.grpc.GetSignatureHelpResponse.Builder
repeated .io.deephaven.proto.backplane.script.grpc.SignatureInformation signatures = 1;
addSignatures(int, SignatureInformation.Builder) - Method in class io.deephaven.proto.backplane.script.grpc.GetSignatureHelpResponse.Builder
repeated .io.deephaven.proto.backplane.script.grpc.SignatureInformation signatures = 1;
addSignatures(SignatureInformation) - Method in class io.deephaven.proto.backplane.script.grpc.GetSignatureHelpResponse.Builder
repeated .io.deephaven.proto.backplane.script.grpc.SignatureInformation signatures = 1;
addSignatures(SignatureInformation.Builder) - Method in class io.deephaven.proto.backplane.script.grpc.GetSignatureHelpResponse.Builder
repeated .io.deephaven.proto.backplane.script.grpc.SignatureInformation signatures = 1;
addSignaturesBuilder() - Method in class io.deephaven.proto.backplane.script.grpc.GetSignatureHelpResponse.Builder
repeated .io.deephaven.proto.backplane.script.grpc.SignatureInformation signatures = 1;
addSignaturesBuilder(int) - Method in class io.deephaven.proto.backplane.script.grpc.GetSignatureHelpResponse.Builder
repeated .io.deephaven.proto.backplane.script.grpc.SignatureInformation signatures = 1;
addSink(LogSink) - Static method in class io.deephaven.io.log.LogSink.Shutdown
 
addSlot(long, int, int, long, byte) - Method in class io.deephaven.engine.table.impl.MultiJoinModifiedSlotTracker
Add a slot in the tracker to mark an add/remove/shift of an output row.
addSortingColumns(SortColumnInfo) - Method in interface io.deephaven.parquet.table.metadata.TableInfo.Builder
 
addSortingColumns(SortColumnInfo...) - Method in interface io.deephaven.parquet.table.metadata.TableInfo.Builder
 
addSorts(int, SortDescriptor) - Method in class io.deephaven.proto.backplane.grpc.HierarchicalTableApplyRequest.Builder
Sorts to apply to the input HierarchicalTable to produce the result HierarchicalTable.
addSorts(int, SortDescriptor) - Method in class io.deephaven.proto.backplane.grpc.SortTableRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor sorts = 3;
addSorts(int, SortDescriptor.Builder) - Method in class io.deephaven.proto.backplane.grpc.HierarchicalTableApplyRequest.Builder
Sorts to apply to the input HierarchicalTable to produce the result HierarchicalTable.
addSorts(int, SortDescriptor.Builder) - Method in class io.deephaven.proto.backplane.grpc.SortTableRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor sorts = 3;
addSorts(SortDescriptor) - Method in class io.deephaven.proto.backplane.grpc.HierarchicalTableApplyRequest.Builder
Sorts to apply to the input HierarchicalTable to produce the result HierarchicalTable.
addSorts(SortDescriptor) - Method in class io.deephaven.proto.backplane.grpc.SortTableRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor sorts = 3;
addSorts(SortDescriptor.Builder) - Method in class io.deephaven.proto.backplane.grpc.HierarchicalTableApplyRequest.Builder
Sorts to apply to the input HierarchicalTable to produce the result HierarchicalTable.
addSorts(SortDescriptor.Builder) - Method in class io.deephaven.proto.backplane.grpc.SortTableRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor sorts = 3;
addSortsBuilder() - Method in class io.deephaven.proto.backplane.grpc.HierarchicalTableApplyRequest.Builder
Sorts to apply to the input HierarchicalTable to produce the result HierarchicalTable.
addSortsBuilder() - Method in class io.deephaven.proto.backplane.grpc.SortTableRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor sorts = 3;
addSortsBuilder(int) - Method in class io.deephaven.proto.backplane.grpc.HierarchicalTableApplyRequest.Builder
Sorts to apply to the input HierarchicalTable to produce the result HierarchicalTable.
addSortsBuilder(int) - Method in class io.deephaven.proto.backplane.grpc.SortTableRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor sorts = 3;
addSource(Runnable) - Method in class io.deephaven.engine.context.PoisonedUpdateGraph
 
addSource(Runnable) - Method in class io.deephaven.engine.updategraph.impl.BaseUpdateGraph
Add a table to the list of tables to run and mark it as refreshing if it was a DynamicNode.
addSource(Runnable) - Method in class io.deephaven.engine.updategraph.impl.PeriodicUpdateGraph
Add a table to the list of tables to run and mark it as refreshing if it was a DynamicNode.
addSource(Runnable) - Method in class io.deephaven.engine.updategraph.OneShotUpdateCombiner
 
addSource(Runnable) - Method in class io.deephaven.engine.updategraph.UpdateSourceCombiner
 
addSource(Runnable) - Method in interface io.deephaven.engine.updategraph.UpdateSourceRegistrar
Add a source to this registrar.
addSourceIds(int, TableReference) - Method in class io.deephaven.proto.backplane.grpc.MergeTablesRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.TableReference source_ids = 2;
addSourceIds(int, TableReference.Builder) - Method in class io.deephaven.proto.backplane.grpc.MergeTablesRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.TableReference source_ids = 2;
addSourceIds(TableReference) - Method in class io.deephaven.proto.backplane.grpc.MergeTablesRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.TableReference source_ids = 2;
addSourceIds(TableReference.Builder) - Method in class io.deephaven.proto.backplane.grpc.MergeTablesRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.TableReference source_ids = 2;
addSourceIdsBuilder() - Method in class io.deephaven.proto.backplane.grpc.MergeTablesRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.TableReference source_ids = 2;
addSourceIdsBuilder(int) - Method in class io.deephaven.proto.backplane.grpc.MergeTablesRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.TableReference source_ids = 2;
addSourceToRegistrar() - Method in class io.deephaven.extensions.barrage.table.BarrageTable
Add this table to the registrar so that it can be refreshed.
addStackTraces(int, TerminationNotificationResponse.StackTrace) - Method in class io.deephaven.proto.backplane.grpc.TerminationNotificationResponse.Builder
if applicable, the list of stack traces in reverse causal order
addStackTraces(int, TerminationNotificationResponse.StackTrace.Builder) - Method in class io.deephaven.proto.backplane.grpc.TerminationNotificationResponse.Builder
if applicable, the list of stack traces in reverse causal order
addStackTraces(TerminationNotificationResponse.StackTrace) - Method in class io.deephaven.proto.backplane.grpc.TerminationNotificationResponse.Builder
if applicable, the list of stack traces in reverse causal order
addStackTraces(TerminationNotificationResponse.StackTrace.Builder) - Method in class io.deephaven.proto.backplane.grpc.TerminationNotificationResponse.Builder
if applicable, the list of stack traces in reverse causal order
addStackTracesBuilder() - Method in class io.deephaven.proto.backplane.grpc.TerminationNotificationResponse.Builder
if applicable, the list of stack traces in reverse causal order
addStackTracesBuilder(int) - Method in class io.deephaven.proto.backplane.grpc.TerminationNotificationResponse.Builder
if applicable, the list of stack traces in reverse causal order
addStampColumns(JoinAddition) - Method in interface io.deephaven.api.snapshot.SnapshotWhenOptions.Builder
 
addStampColumns(JoinAddition...) - Method in interface io.deephaven.api.snapshot.SnapshotWhenOptions.Builder
 
addStampColumns(String) - Method in class io.deephaven.proto.backplane.grpc.SnapshotWhenTableRequest.Builder
Which columns to stamp from the trigger table.
addStampColumnsBytes(ByteString) - Method in class io.deephaven.proto.backplane.grpc.SnapshotWhenTableRequest.Builder
Which columns to stamp from the trigger table.
addStringToSet(String) - Method in class io.deephaven.stringset.HashStringSet
 
addSubscription(StreamObserver<BarrageStreamGenerator.MessageView>, BarrageSubscriptionOptions, BitSet, RowSet, boolean) - Method in class io.deephaven.server.barrage.BarrageMessageProducer
Add a subscription to this BarrageMessageProducer.
addSwappableTable(SwappableTable) - Method in class io.deephaven.plot.AbstractSeriesInternal
 
addSwappableTable(SwappableTable) - Method in class io.deephaven.plot.AxisImpl
 
addSwappableTable(SwappableTable) - Method in interface io.deephaven.plot.SeriesInternal
Adds a swappable table that drives this series.
addTable(String, Table) - Method in class io.deephaven.engine.table.impl.util.SyncTableFilter.Builder
Add a table to the set of tables to be synchronized, using this builder's default ID and key column names.
addTable(String, Table, String, String...) - Method in class io.deephaven.engine.table.impl.util.SyncTableFilter.Builder
Add a table to the set of tables to be synchronized.
addTableHandle(TableHandle) - Method in class io.deephaven.plot.AbstractSeriesInternal
 
addTableHandle(TableHandle) - Method in class io.deephaven.plot.datasets.multiseries.AbstractSwappableMultiSeries
 
addTableHandle(TableHandle) - Method in interface io.deephaven.plot.SeriesInternal
Add a table that drives this series.
AddTableRequest - Class in io.deephaven.proto.backplane.grpc
Protobuf type io.deephaven.proto.backplane.grpc.AddTableRequest
AddTableRequest.Builder - Class in io.deephaven.proto.backplane.grpc
Protobuf type io.deephaven.proto.backplane.grpc.AddTableRequest
AddTableRequestOrBuilder - Interface in io.deephaven.proto.backplane.grpc
 
AddTableResponse - Class in io.deephaven.proto.backplane.grpc
Protobuf type io.deephaven.proto.backplane.grpc.AddTableResponse
AddTableResponse.Builder - Class in io.deephaven.proto.backplane.grpc
Protobuf type io.deephaven.proto.backplane.grpc.AddTableResponse
AddTableResponseOrBuilder - Interface in io.deephaven.proto.backplane.grpc
 
addTables(LabeledTable) - Method in interface io.deephaven.qst.table.LabeledTables.Builder
 
addTables(LabeledTable...) - Method in interface io.deephaven.qst.table.LabeledTables.Builder
 
addTables(TableSpec) - Method in interface io.deephaven.qst.table.MergeTable.Builder
 
addTables(TableSpec...) - Method in interface io.deephaven.qst.table.MergeTable.Builder
 
addTables(TableInformation) - Method in interface io.deephaven.sql.ScopeStaticImpl.Builder
 
addTables(TableInformation...) - Method in interface io.deephaven.sql.ScopeStaticImpl.Builder
 
addTableToInputTable(AddTableRequest, StreamObserver<AddTableResponse>) - Method in class io.deephaven.server.table.inputtables.InputTableServiceGrpcImpl
 
addTableToInputTable(AddTableRequest) - Method in class io.deephaven.proto.backplane.grpc.InputTableServiceGrpc.InputTableServiceBlockingStub
Adds the provided table to the specified input table.
addTableToInputTable(AddTableRequest) - Method in class io.deephaven.proto.backplane.grpc.InputTableServiceGrpc.InputTableServiceFutureStub
Adds the provided table to the specified input table.
addTableToInputTable(AddTableRequest, StreamObserver<AddTableResponse>) - Method in interface io.deephaven.proto.backplane.grpc.InputTableServiceGrpc.AsyncService
Adds the provided table to the specified input table.
addTableToInputTable(AddTableRequest, StreamObserver<AddTableResponse>) - Method in class io.deephaven.proto.backplane.grpc.InputTableServiceGrpc.InputTableServiceStub
Adds the provided table to the specified input table.
addTags(Diagnostic.DiagnosticTag) - Method in class io.deephaven.proto.backplane.script.grpc.Diagnostic.Builder
repeated .io.deephaven.proto.backplane.script.grpc.Diagnostic.DiagnosticTag tags = 7;
addTagsValue(int) - Method in class io.deephaven.proto.backplane.script.grpc.Diagnostic.Builder
repeated .io.deephaven.proto.backplane.script.grpc.Diagnostic.DiagnosticTag tags = 7;
addTerminationListener(SessionState, StreamObserver<TerminationNotificationResponse>) - Method in class io.deephaven.server.session.SessionService
Add a listener who receives a single notification when this process is exiting and yet able to communicate with the observer.
addTimeWindow(QueryTable, String, long, String) - Static method in class io.deephaven.engine.util.WindowCheck
Adds a Boolean column that is false when a timestamp column is older than windowNanos.
addToArray(int, int[]) - Static method in class io.deephaven.base.ArrayUtil
 
addToArray(T, T[], Class<T>) - Static method in class io.deephaven.base.ArrayUtil
 
addToBuilder(ImmutableObjectArraySource<RowSetBuilderSequential>, long, long) - Static method in class io.deephaven.engine.table.impl.asofjoin.RightIncrementalAsOfJoinStateManagerTypedBase
 
addToBuilderFromImpl(OrderedLongSet.BuilderRandom, WritableRowSetImpl) - Static method in class io.deephaven.engine.rowset.impl.WritableRowSetImpl
 
addToFlatBuffer(FlatBufferBuilder) - Method in class io.deephaven.extensions.barrage.BarrageStreamGeneratorImpl.ByteArrayGenerator
 
addToFlatBuffer(RowSet, FlatBufferBuilder) - Method in class io.deephaven.extensions.barrage.BarrageStreamGeneratorImpl.RowSetGenerator
Appends the intersection of the viewport and the originally provided RowSet.
addToGrouping(DATA_TYPE, long, long) - Method in class io.deephaven.engine.table.impl.locations.impl.RandomGroupingBuilder
Add a mapping from value [firstRowKey, lastRowKey] to the groupings under construction.
addToInputTable(HasTicketId, HasTicketId) - Method in interface io.deephaven.client.impl.InputTableService
Add source to the input table destination.
addToInputTable(HasTicketId, HasTicketId) - Method in class io.deephaven.client.impl.SessionImpl
 
addToInputTable(HasTicketId, NewTable, BufferAllocator) - Method in class io.deephaven.client.impl.FlightSession
Add source to the input table destination.
addToInputTable(HasTicketId, FlightStream) - Method in class io.deephaven.client.impl.FlightSession
Add source to the input table destination.
addToken(Token) - Method in class io.deephaven.lang.api.AbstractChunkerInvokable
 
addToken(Token) - Method in interface io.deephaven.lang.api.ChunkerInvokable
 
addToken(Token) - Method in interface io.deephaven.lang.generated.Node
 
addToken(Token, Node) - Method in interface io.deephaven.lang.generated.Node
 
addToken(Token, Node) - Method in class io.deephaven.lang.generated.SimpleNode
 
addTokens(StringBuilder, Token, String...) - Method in class io.deephaven.lang.completion.results.CompletionBuilder
 
addToSequentialBuilder(long, ObjectArraySource<RowSetBuilderSequential>, long) - Method in class io.deephaven.engine.table.impl.asofjoin.RightIncrementalHashedAsOfJoinStateManager
 
addTypedExportIds(int, TypedTicket) - Method in class io.deephaven.proto.backplane.grpc.FetchObjectResponse.Builder
repeated .io.deephaven.proto.backplane.grpc.TypedTicket typed_export_ids = 3;
addTypedExportIds(int, TypedTicket.Builder) - Method in class io.deephaven.proto.backplane.grpc.FetchObjectResponse.Builder
repeated .io.deephaven.proto.backplane.grpc.TypedTicket typed_export_ids = 3;
addTypedExportIds(TypedTicket) - Method in class io.deephaven.proto.backplane.grpc.FetchObjectResponse.Builder
repeated .io.deephaven.proto.backplane.grpc.TypedTicket typed_export_ids = 3;
addTypedExportIds(TypedTicket.Builder) - Method in class io.deephaven.proto.backplane.grpc.FetchObjectResponse.Builder
repeated .io.deephaven.proto.backplane.grpc.TypedTicket typed_export_ids = 3;
addTypedExportIdsBuilder() - Method in class io.deephaven.proto.backplane.grpc.FetchObjectResponse.Builder
repeated .io.deephaven.proto.backplane.grpc.TypedTicket typed_export_ids = 3;
addTypedExportIdsBuilder(int) - Method in class io.deephaven.proto.backplane.grpc.FetchObjectResponse.Builder
repeated .io.deephaven.proto.backplane.grpc.TypedTicket typed_export_ids = 3;
addUngroupColumns(ColumnName) - Method in interface io.deephaven.qst.table.UngroupTable.Builder
 
addUngroupColumns(ColumnName...) - Method in interface io.deephaven.qst.table.UngroupTable.Builder
 
addUnique(T) - Method in class io.deephaven.base.array.FastArray
 
addUnless(T[], Class<T>, Predicate.Binary<T, A>, Function<A, T>, A) - Static method in class io.deephaven.base.ArrayUtil
 
addUnless(T[], Class<T>, Predicate.Unary<T>, Supplier<T>) - Static method in class io.deephaven.base.ArrayUtil
 
addUnsafe(byte) - Method in class io.deephaven.base.ringbuffer.AggregatingByteRingBuffer
Adds a value without overflow detection.
addUnsafe(byte) - Method in class io.deephaven.base.ringbuffer.ByteRingBuffer
Add values without overflow detection.
addUnsafe(char) - Method in class io.deephaven.base.ringbuffer.AggregatingCharRingBuffer
Adds a value without overflow detection.
addUnsafe(char) - Method in class io.deephaven.base.ringbuffer.CharRingBuffer
Add values without overflow detection.
addUnsafe(double) - Method in class io.deephaven.base.ringbuffer.AggregatingDoubleRingBuffer
Adds a value without overflow detection.
addUnsafe(double) - Method in class io.deephaven.base.ringbuffer.DoubleRingBuffer
Add values without overflow detection.
addUnsafe(float) - Method in class io.deephaven.base.ringbuffer.AggregatingFloatRingBuffer
Adds a value without overflow detection.
addUnsafe(float) - Method in class io.deephaven.base.ringbuffer.FloatRingBuffer
Add values without overflow detection.
addUnsafe(int) - Method in class io.deephaven.base.ringbuffer.AggregatingIntRingBuffer
Adds a value without overflow detection.
addUnsafe(int) - Method in class io.deephaven.base.ringbuffer.IntRingBuffer
Add values without overflow detection.
addUnsafe(long) - Method in class io.deephaven.base.ringbuffer.AggregatingLongRingBuffer
Adds a value without overflow detection.
addUnsafe(long) - Method in class io.deephaven.base.ringbuffer.LongRingBuffer
Add values without overflow detection.
addUnsafe(long) - Method in class io.deephaven.engine.rowset.impl.rsp.RspBitmap
 
addUnsafe(long) - Method in class io.deephaven.engine.rowset.impl.sortedranges.SortedRanges
 
addUnsafe(short) - Method in class io.deephaven.base.ringbuffer.AggregatingShortRingBuffer
Adds a value without overflow detection.
addUnsafe(short) - Method in class io.deephaven.base.ringbuffer.ShortRingBuffer
Add values without overflow detection.
addUnsafe(T) - Method in class io.deephaven.base.ringbuffer.AggregatingObjectRingBuffer
Adds a value without overflow detection.
addUnsafe(T) - Method in class io.deephaven.base.ringbuffer.ObjectRingBuffer
Add values without overflow detection.
addUnsafeNoWriteCheck(long) - Method in class io.deephaven.engine.rowset.impl.rsp.RspBitmap
 
addUpdated(int, FieldInfo) - Method in class io.deephaven.proto.backplane.grpc.FieldsChangeUpdate.Builder
repeated .io.deephaven.proto.backplane.grpc.FieldInfo updated = 2;
addUpdated(int, FieldInfo.Builder) - Method in class io.deephaven.proto.backplane.grpc.FieldsChangeUpdate.Builder
repeated .io.deephaven.proto.backplane.grpc.FieldInfo updated = 2;
addUpdated(FieldInfo) - Method in class io.deephaven.proto.backplane.grpc.FieldsChangeUpdate.Builder
repeated .io.deephaven.proto.backplane.grpc.FieldInfo updated = 2;
addUpdated(FieldInfo.Builder) - Method in class io.deephaven.proto.backplane.grpc.FieldsChangeUpdate.Builder
repeated .io.deephaven.proto.backplane.grpc.FieldInfo updated = 2;
addUpdatedBuilder() - Method in class io.deephaven.proto.backplane.grpc.FieldsChangeUpdate.Builder
repeated .io.deephaven.proto.backplane.grpc.FieldInfo updated = 2;
addUpdatedBuilder(int) - Method in class io.deephaven.proto.backplane.grpc.FieldsChangeUpdate.Builder
repeated .io.deephaven.proto.backplane.grpc.FieldInfo updated = 2;
addUpdateListener() - Method in class io.deephaven.engine.table.impl.KeyedTableListener
 
addUpdateListener(TableUpdateListener) - Method in class io.deephaven.engine.table.impl.BaseTable
 
addUpdateListener(TableUpdateListener) - Method in class io.deephaven.engine.table.impl.UncoalescedTable
 
addUpdateListener(TableUpdateListener, long) - Method in class io.deephaven.engine.table.impl.BaseTable
 
addUpdateListener(TableUpdateListener, long) - Method in class io.deephaven.engine.table.impl.UncoalescedTable
 
addUpdateListener(ShiftObliviousListener) - Method in interface io.deephaven.engine.table.impl.TableDefaults
 
addUpdateListener(ShiftObliviousListener) - Method in interface io.deephaven.engine.table.Table
Subscribe for updates to this table.
addUpdateListener(ShiftObliviousListener, boolean) - Method in class io.deephaven.engine.table.impl.BaseTable
 
addUpdateListener(ShiftObliviousListener, boolean) - Method in interface io.deephaven.engine.table.impl.TableAdapter
 
addUpdateListener(ShiftObliviousListener, boolean) - Method in class io.deephaven.engine.table.impl.UncoalescedTable
 
addUpdateListener(ShiftObliviousListener, boolean) - Method in interface io.deephaven.engine.table.Table
Subscribe for updates to this table.
addUpdateListener(TableUpdateListener) - Method in interface io.deephaven.engine.table.impl.TableAdapter
 
addUpdateListener(TableUpdateListener) - Method in interface io.deephaven.engine.table.Table
Subscribe for updates to this table.
addUpdateListener(TableUpdateListener, long) - Method in interface io.deephaven.engine.table.impl.TableAdapter
 
addUpdateListener(TableUpdateListener, long) - Method in interface io.deephaven.engine.table.Table
Subscribe for updates to this table if its last notification step matches requiredLastNotificationStep.
addUpdateListenerUncoalesced(TableUpdateListener) - Method in class io.deephaven.engine.table.impl.UncoalescedTable
 
addUpdateListenerUncoalesced(TableUpdateListener, long) - Method in class io.deephaven.engine.table.impl.UncoalescedTable
 
addValues(boolean) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.BoolMapWithDefault.Builder
repeated bool values = 3;
addValues(double) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.DoubleMapWithDefault.Builder
repeated double values = 3;
addValues(Expression) - Method in interface io.deephaven.api.filter.FilterIn.Builder
 
addValues(Expression...) - Method in interface io.deephaven.api.filter.FilterIn.Builder
 
addValues(String) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.StringMapWithDefault.Builder
repeated string values = 3;
addValues(T) - Method in class io.deephaven.qst.array.GenericArray.Builder
 
addValues(T...) - Method in class io.deephaven.qst.array.GenericArray.Builder
 
addValuesBytes(ByteString) - Method in class io.deephaven.proto.backplane.script.grpc.FigureDescriptor.StringMapWithDefault.Builder
repeated string values = 3;
addValuesUnsafe(LongChunk<OrderedRowKeys>, int, int) - Method in class io.deephaven.engine.rowset.impl.rsp.RspBitmap
 
addValuesUnsafeNoWriteCheck(LongChunk<OrderedRowKeys>, int, int) - Method in class io.deephaven.engine.rowset.impl.rsp.RspBitmap
 
addVectorPage(Object, IntBuffer, int, Statistics<?>) - Method in interface io.deephaven.parquet.base.ColumnWriter
Add a vector page to the file.
addYColumnNames(String) - Method in class io.deephaven.proto.backplane.grpc.RunChartDownsampleRequest.Builder
repeated string y_column_names = 6;
addYColumnNamesBytes(ByteString) - Method in class io.deephaven.proto.backplane.grpc.RunChartDownsampleRequest.Builder
repeated string y_column_names = 6;
addYColumnsOfInterest(int[]) - Method in class io.deephaven.clientsupport.plotdownsampling.DownsampleChunkContext
Indicates that any of these Y columns will actually be used, and should be pre-populated if not yet present
adjustBeginLineColumn(int, int) - Method in class io.deephaven.lang.generated.SimpleCharStream
Method to adjust line and column numbers for the start of a token.
adjustOrPutValue(long, long, long) - Method in class io.deephaven.util.datastructures.hash.HashMapBase
 
adjustValue(long, long) - Method in class io.deephaven.util.datastructures.hash.HashMapBase
 
adopt(Node) - Method in interface io.deephaven.lang.generated.Node
 
adopt(Node) - Method in class io.deephaven.lang.generated.SimpleNode
 
advance() - Method in class io.deephaven.engine.table.impl.select.SimulationClock
Advance the simulation.
advance(int) - Method in interface io.deephaven.engine.rowset.impl.rsp.container.SearchRangeIterator
Advance the iterator position forward until the current range end's (exclusive) position is bigger (not equal) than the argument, or the iterator is exhausted.
advance(int) - Method in interface io.deephaven.engine.rowset.impl.rsp.container.ShortAdvanceIterator
Advance the iterator position forward until the current value is smaller or equal to the argument, or the iterator is exhausted.
advance(int) - Method in class io.deephaven.engine.rowset.impl.rsp.container.SingletonContainer.ReverseIter
 
advance(int) - Method in class io.deephaven.engine.rowset.impl.rsp.container.SingletonContainer.SearchRangeIter
 
advance(int) - Method in class io.deephaven.engine.rowset.impl.rsp.container.TwoValuesContainer.ContainerShortBatchIter
 
advance(int) - Method in class io.deephaven.engine.rowset.impl.rsp.IndexRangeIteratorView
 
advance(int) - Method in class io.deephaven.engine.rowset.impl.rsp.RspRangeIterator.RangeIteratorView
 
advance(long) - Method in class io.deephaven.engine.rowset.impl.ComplementRangeIterator
 
advance(long) - Method in class io.deephaven.engine.rowset.impl.RowSetUtils.CombinedRangeIterator
 
advance(long) - Method in interface io.deephaven.engine.rowset.impl.rsp.RspArray.SpanCursor
Advances the pointer forward to the next span in the sequence whose interval could have it include the key argument.
advance(long) - Method in class io.deephaven.engine.rowset.impl.rsp.RspRangeIterator
Advance the current iterator position while the current range end is less than key.
advance(long) - Method in class io.deephaven.engine.rowset.impl.rsp.RspReverseIterator
 
advance(long) - Method in class io.deephaven.engine.rowset.impl.sortedranges.SortedRanges.RangeIterator
 
advance(long) - Method in interface io.deephaven.engine.rowset.RowSequence.Iterator
Advance this iterator's position to nextKey, or to the first present row key greater than nextKey if nextKey is not found.
advance(long) - Method in interface io.deephaven.engine.rowset.RowSet.RangeIterator
Advance the current iterator position until currentRangeStart() and currentRangeEnd() are both greater than or equal to v.
advance(long) - Method in interface io.deephaven.engine.rowset.RowSet.SearchIterator
Advance the current iterator position until currentValue() is greater than or equal to `v`.
advanceAndGetPositionDistance(long) - Method in interface io.deephaven.engine.rowset.RowSequence.Iterator
Advance this iterator's position as in RowSequence.Iterator.advance(long), returning the number of row keys thus consumed.
advanceImpl(long) - Method in class io.deephaven.engine.rowset.impl.sortedranges.SortedRanges.RangeIterator
 
advanceToBeforeFirst(byte) - Method in class io.deephaven.engine.table.impl.ssa.ByteReverseSegmentedSortedArray.Iterator
Advance this iterator to one position before the lowest value that is less than or equal to value.
advanceToBeforeFirst(byte) - Method in class io.deephaven.engine.table.impl.ssa.ByteSegmentedSortedArray.Iterator
Advance this iterator to one position before the lowest value that is less than or equal to value.
advanceToBeforeFirst(char) - Method in class io.deephaven.engine.table.impl.ssa.CharReverseSegmentedSortedArray.Iterator
Advance this iterator to one position before the lowest value that is less than or equal to value.
advanceToBeforeFirst(char) - Method in class io.deephaven.engine.table.impl.ssa.CharSegmentedSortedArray.Iterator
Advance this iterator to one position before the lowest value that is less than or equal to value.
advanceToBeforeFirst(char) - Method in class io.deephaven.engine.table.impl.ssa.NullAwareCharReverseSegmentedSortedArray.Iterator
Advance this iterator to one position before the lowest value that is less than or equal to value.
advanceToBeforeFirst(char) - Method in class io.deephaven.engine.table.impl.ssa.NullAwareCharSegmentedSortedArray.Iterator
Advance this iterator to one position before the lowest value that is less than or equal to value.
advanceToBeforeFirst(double) - Method in class io.deephaven.engine.table.impl.ssa.DoubleReverseSegmentedSortedArray.Iterator
Advance this iterator to one position before the lowest value that is less than or equal to value.
advanceToBeforeFirst(double) - Method in class io.deephaven.engine.table.impl.ssa.DoubleSegmentedSortedArray.Iterator
Advance this iterator to one position before the lowest value that is less than or equal to value.
advanceToBeforeFirst(float) - Method in class io.deephaven.engine.table.impl.ssa.FloatReverseSegmentedSortedArray.Iterator
Advance this iterator to one position before the lowest value that is less than or equal to value.
advanceToBeforeFirst(float) - Method in class io.deephaven.engine.table.impl.ssa.FloatSegmentedSortedArray.Iterator
Advance this iterator to one position before the lowest value that is less than or equal to value.
advanceToBeforeFirst(int) - Method in class io.deephaven.engine.table.impl.ssa.IntReverseSegmentedSortedArray.Iterator
Advance this iterator to one position before the lowest value that is less than or equal to value.
advanceToBeforeFirst(int) - Method in class io.deephaven.engine.table.impl.ssa.IntSegmentedSortedArray.Iterator
Advance this iterator to one position before the lowest value that is less than or equal to value.
advanceToBeforeFirst(long) - Method in class io.deephaven.engine.table.impl.ssa.LongReverseSegmentedSortedArray.Iterator
Advance this iterator to one position before the lowest value that is less than or equal to value.
advanceToBeforeFirst(long) - Method in class io.deephaven.engine.table.impl.ssa.LongSegmentedSortedArray.Iterator
Advance this iterator to one position before the lowest value that is less than or equal to value.
advanceToBeforeFirst(short) - Method in class io.deephaven.engine.table.impl.ssa.ShortReverseSegmentedSortedArray.Iterator
Advance this iterator to one position before the lowest value that is less than or equal to value.
advanceToBeforeFirst(short) - Method in class io.deephaven.engine.table.impl.ssa.ShortSegmentedSortedArray.Iterator
Advance this iterator to one position before the lowest value that is less than or equal to value.
advanceToBeforeFirst(Object) - Method in class io.deephaven.engine.table.impl.ssa.ObjectReverseSegmentedSortedArray.Iterator
Advance this iterator to one position before the lowest value that is less than or equal to value.
advanceToBeforeFirst(Object) - Method in class io.deephaven.engine.table.impl.ssa.ObjectSegmentedSortedArray.Iterator
Advance this iterator to one position before the lowest value that is less than or equal to value.
advanceToLast(byte) - Method in class io.deephaven.engine.table.impl.ssa.ByteReverseSegmentedSortedArray.Iterator
Advance this iterator to the highest value that is less than or equal to value.
advanceToLast(byte) - Method in class io.deephaven.engine.table.impl.ssa.ByteSegmentedSortedArray.Iterator
Advance this iterator to the highest value that is less than or equal to value.
advanceToLast(char) - Method in class io.deephaven.engine.table.impl.ssa.CharReverseSegmentedSortedArray.Iterator
Advance this iterator to the highest value that is less than or equal to value.
advanceToLast(char) - Method in class io.deephaven.engine.table.impl.ssa.CharSegmentedSortedArray.Iterator
Advance this iterator to the highest value that is less than or equal to value.
advanceToLast(char) - Method in class io.deephaven.engine.table.impl.ssa.NullAwareCharReverseSegmentedSortedArray.Iterator
Advance this iterator to the highest value that is less than or equal to value.
advanceToLast(char) - Method in class io.deephaven.engine.table.impl.ssa.NullAwareCharSegmentedSortedArray.Iterator
Advance this iterator to the highest value that is less than or equal to value.
advanceToLast(double) - Method in class io.deephaven.engine.table.impl.ssa.DoubleReverseSegmentedSortedArray.Iterator
Advance this iterator to the highest value that is less than or equal to value.
advanceToLast(double) - Method in class io.deephaven.engine.table.impl.ssa.DoubleSegmentedSortedArray.Iterator
Advance this iterator to the highest value that is less than or equal to value.
advanceToLast(float) - Method in class io.deephaven.engine.table.impl.ssa.FloatReverseSegmentedSortedArray.Iterator
Advance this iterator to the highest value that is less than or equal to value.
advanceToLast(float) - Method in class io.deephaven.engine.table.impl.ssa.FloatSegmentedSortedArray.Iterator
Advance this iterator to the highest value that is less than or equal to value.
advanceToLast(int) - Method in class io.deephaven.engine.table.impl.ssa.IntReverseSegmentedSortedArray.Iterator
Advance this iterator to the highest value that is less than or equal to value.
advanceToLast(int) - Method in class io.deephaven.engine.table.impl.ssa.IntSegmentedSortedArray.Iterator
Advance this iterator to the highest value that is less than or equal to value.
advanceToLast(long) - Method in class io.deephaven.engine.table.impl.ssa.LongReverseSegmentedSortedArray.Iterator
Advance this iterator to the highest value that is less than or equal to value.
advanceToLast(long) - Method in class io.deephaven.engine.table.impl.ssa.LongSegmentedSortedArray.Iterator
Advance this iterator to the highest value that is less than or equal to value.
advanceToLast(short) - Method in class io.deephaven.engine.table.impl.ssa.ShortReverseSegmentedSortedArray.Iterator
Advance this iterator to the highest value that is less than or equal to value.
advanceToLast(short) - Method in class io.deephaven.engine.table.impl.ssa.ShortSegmentedSortedArray.Iterator
Advance this iterator to the highest value that is less than or equal to value.
advanceToLast(Object) - Method in class io.deephaven.engine.table.impl.ssa.ObjectReverseSegmentedSortedArray.Iterator
Advance this iterator to the highest value that is less than or equal to value.
advanceToLast(Object) - Method in class io.deephaven.engine.table.impl.ssa.ObjectSegmentedSortedArray.Iterator
Advance this iterator to the highest value that is less than or equal to value.
advanceToNextPage(RowSequence.Iterator) - Method in interface io.deephaven.engine.page.Page
Assuming rowSequenceIterator is position at its first row key on this page, consume all keys on this page.
advanceToNextPage(RowSet.SearchIterator) - Method in interface io.deephaven.engine.page.Page
Assuming searchIterator is position at its first row key on this page, consume all keys on this page.
advanceToNextPageAndGetPositionDistance(RowSequence.Iterator) - Method in interface io.deephaven.engine.page.Page
Assuming rowSequenceIterator is position at its first row key on this page, consume all keys on this page and return the number of keys consumed.
advanceUntil(short[], int, int, short) - Static method in class io.deephaven.engine.rowset.impl.rsp.container.ContainerUtil
Find the smallest integer larger than pos such that array[pos]>= min.
advanceWhileEqual() - Method in class io.deephaven.engine.table.impl.ssa.ByteReverseSegmentedSortedArray.Iterator
Advance the iterator to the last value which is equal to the current value.
advanceWhileEqual() - Method in class io.deephaven.engine.table.impl.ssa.ByteSegmentedSortedArray.Iterator
Advance the iterator to the last value which is equal to the current value.
advanceWhileEqual() - Method in class io.deephaven.engine.table.impl.ssa.CharReverseSegmentedSortedArray.Iterator
Advance the iterator to the last value which is equal to the current value.
advanceWhileEqual() - Method in class io.deephaven.engine.table.impl.ssa.CharSegmentedSortedArray.Iterator
Advance the iterator to the last value which is equal to the current value.
advanceWhileEqual() - Method in class io.deephaven.engine.table.impl.ssa.DoubleReverseSegmentedSortedArray.Iterator
Advance the iterator to the last value which is equal to the current value.
advanceWhileEqual() - Method in class io.deephaven.engine.table.impl.ssa.DoubleSegmentedSortedArray.Iterator
Advance the iterator to the last value which is equal to the current value.
advanceWhileEqual() - Method in class io.deephaven.engine.table.impl.ssa.FloatReverseSegmentedSortedArray.Iterator
Advance the iterator to the last value which is equal to the current value.
advanceWhileEqual() - Method in class io.deephaven.engine.table.impl.ssa.FloatSegmentedSortedArray.Iterator
Advance the iterator to the last value which is equal to the current value.
advanceWhileEqual() - Method in class io.deephaven.engine.table.impl.ssa.IntReverseSegmentedSortedArray.Iterator
Advance the iterator to the last value which is equal to the current value.
advanceWhileEqual() - Method in class io.deephaven.engine.table.impl.ssa.IntSegmentedSortedArray.Iterator
Advance the iterator to the last value which is equal to the current value.
advanceWhileEqual() - Method in class io.deephaven.engine.table.impl.ssa.LongReverseSegmentedSortedArray.Iterator
Advance the iterator to the last value which is equal to the current value.
advanceWhileEqual() - Method in class io.deephaven.engine.table.impl.ssa.LongSegmentedSortedArray.Iterator
Advance the iterator to the last value which is equal to the current value.
advanceWhileEqual() - Method in class io.deephaven.engine.table.impl.ssa.NullAwareCharReverseSegmentedSortedArray.Iterator
Advance the iterator to the last value which is equal to the current value.
advanceWhileEqual() - Method in class io.deephaven.engine.table.impl.ssa.NullAwareCharSegmentedSortedArray.Iterator
Advance the iterator to the last value which is equal to the current value.
advanceWhileEqual() - Method in class io.deephaven.engine.table.impl.ssa.ObjectReverseSegmentedSortedArray.Iterator
Advance the iterator to the last value which is equal to the current value.
advanceWhileEqual() - Method in class io.deephaven.engine.table.impl.ssa.ObjectSegmentedSortedArray.Iterator
Advance the iterator to the last value which is equal to the current value.
advanceWhileEqual() - Method in class io.deephaven.engine.table.impl.ssa.ShortReverseSegmentedSortedArray.Iterator
Advance the iterator to the last value which is equal to the current value.
advanceWhileEqual() - Method in class io.deephaven.engine.table.impl.ssa.ShortSegmentedSortedArray.Iterator
Advance the iterator to the last value which is equal to the current value.
adviseNewAlternate() - Method in class io.deephaven.engine.table.impl.asofjoin.RightIncrementalAsOfJoinStateManagerTypedBase
After creating the new alternate key states, advise the derived classes, so they can cast them to the typed versions of the column source and adjust the derived class pointers.
adviseNewAlternate() - Method in class io.deephaven.engine.table.impl.by.IncrementalChunkedOperatorAggregationStateManagerOpenAddressedBase
After creating the new alternate key states, advise the derived classes, so they can cast them to the typed versions of the column source and adjust the derived class pointers.
adviseNewAlternate() - Method in class io.deephaven.engine.table.impl.multijoin.IncrementalMultiJoinStateManagerTypedBase
After creating the new alternate key states, advise the derived classes, so they can cast them to the typed versions of the column source and adjust the derived class pointers.
adviseNewAlternate() - Method in class io.deephaven.engine.table.impl.naturaljoin.IncrementalNaturalJoinStateManagerTypedBase
After creating the new alternate key states, advise the derived classes, so they can cast them to the typed versions of the column source and adjust the derived class pointers.
adviseNewAlternate() - Method in class io.deephaven.engine.table.impl.updateby.hashing.UpdateByStateManagerTypedBase
After creating the new alternate key states, advise the derived classes, so they can cast them to the typed versions of the column source and adjust the derived class pointers.
affectedPosChunk - Variable in class io.deephaven.engine.table.impl.updateby.UpdateByOperator.Context
 
affectingColumns - Variable in class io.deephaven.engine.table.impl.updateby.UpdateByOperator
 
afterPoll(KafkaConsumer<?, ?>, boolean) - Method in interface io.deephaven.kafka.KafkaTools.ConsumerLoopCallback
Called after the consumer is polled for records and they have been published to the downstream KafkaRecordConsumer.
AGG_BY_PRESERVE_EMPTY_DEFAULT - Static variable in interface io.deephaven.api.TableOperations
 
AggAbsSum(String...) - Static method in interface io.deephaven.api.agg.Aggregation
Create an absolute sum aggregation for the supplied column name pairs.
aggAllBy(AggSpec) - Method in interface io.deephaven.api.TableOperations
 
aggAllBy(AggSpec) - Method in interface io.deephaven.api.TableOperationsDefaults
 
aggAllBy(AggSpec, ColumnName...) - Method in interface io.deephaven.api.TableOperations
 
aggAllBy(AggSpec, ColumnName...) - Method in class io.deephaven.api.TableOperationsAdapter
 
aggAllBy(AggSpec, ColumnName...) - Method in class io.deephaven.engine.table.impl.QueryTable
 
aggAllBy(AggSpec, ColumnName...) - Method in interface io.deephaven.engine.table.impl.TableAdapter
 
aggAllBy(AggSpec, ColumnName...) - Method in class io.deephaven.engine.table.impl.UncoalescedTable
 
aggAllBy(AggSpec, ColumnName...) - Method in class io.deephaven.qst.table.TableBase
 
aggAllBy(AggSpec, String...) - Method in interface io.deephaven.api.TableOperations
 
aggAllBy(AggSpec, String...) - Method in interface io.deephaven.api.TableOperationsDefaults
 
aggAllBy(AggSpec, Collection<String>) - Method in interface io.deephaven.api.TableOperations
 
aggAllBy(AggSpec, Collection<String>) - Method in interface io.deephaven.api.TableOperationsDefaults
 
AggApproxPct(double, double, String...) - Static method in interface io.deephaven.api.agg.Aggregation
Create an approximate percentile aggregation for the supplied percentile, T-Digest compression factor, and column name pairs.
AggApproxPct(double, String...) - Static method in interface io.deephaven.api.agg.Aggregation
Create an approximate percentile aggregation for the supplied percentile and column name pairs with the default T-Digest compression factor.
AggApproxPct(String, double, PercentileOutput...) - Static method in interface io.deephaven.api.agg.Aggregation
Create an approximate percentile aggregation for the supplied input column name, T-Digest compression factor, and percentile/output column name pairs.
AggApproxPct(String, PercentileOutput...) - Static method in interface io.deephaven.api.agg.Aggregation
Create an approximate percentile aggregation for the supplied input column name and percentile/output column name pairs with the default T-Digest compression factor.
AggAvg(String...) - Static method in interface io.deephaven.api.agg.Aggregation
Create an average (arithmetic mean) aggregation for the supplied column name pairs.
aggBy(Aggregation) - Method in interface io.deephaven.api.TableOperations
Produce an aggregated result by grouping all rows from this into a single group of rows and applying aggregation to the result.
aggBy(Aggregation) - Method in interface io.deephaven.api.TableOperationsDefaults
 
aggBy(Aggregation, String...) - Method in interface io.deephaven.api.TableOperations
Produce an aggregated result by grouping this according to the groupByColumns and applying aggregation to each resulting group of rows.
aggBy(Aggregation, String...) - Method in interface io.deephaven.api.TableOperationsDefaults
 
aggBy(Aggregation, Collection<? extends ColumnName>) - Method in interface io.deephaven.api.TableOperations
Produce an aggregated result by grouping this according to the groupByColumns and applying aggregation to each resulting group of rows.
aggBy(Aggregation, Collection<? extends ColumnName>) - Method in interface io.deephaven.api.TableOperationsDefaults
 
aggBy(Collection<? extends Aggregation>) - Method in interface io.deephaven.api.TableOperations
Produce an aggregated result by grouping all rows from this into a single group of rows and applying aggregations to the result.
aggBy(Collection<? extends Aggregation>) - Method in interface io.deephaven.api.TableOperationsDefaults
 
aggBy(Collection<? extends Aggregation>, boolean) - Method in interface io.deephaven.api.TableOperations
Produce an aggregated result by grouping all rows from this into a single group of rows and applying aggregations to the result.
aggBy(Collection<? extends Aggregation>, boolean) - Method in interface io.deephaven.api.TableOperationsDefaults
 
aggBy(Collection<? extends Aggregation>, boolean, Table, Collection<? extends ColumnName>) - Static method in class io.deephaven.engine.table.impl.MemoizedOperationKey
 
aggBy(Collection<? extends Aggregation>, boolean, Table, Collection<? extends ColumnName>) - Method in class io.deephaven.engine.table.impl.QueryTable
 
aggBy(Collection<? extends Aggregation>, boolean, Table, Collection<? extends ColumnName>) - Method in interface io.deephaven.engine.table.impl.TableAdapter
 
aggBy(Collection<? extends Aggregation>, boolean, Table, Collection<? extends ColumnName>) - Method in class io.deephaven.engine.table.impl.UncoalescedTable
 
aggBy(Collection<? extends Aggregation>, boolean, TableSpec, Collection<? extends ColumnName>) - Method in class io.deephaven.qst.table.TableBase
 
aggBy(Collection<? extends Aggregation>, boolean, TABLE_1, Collection<? extends ColumnName>) - Method in class io.deephaven.api.TableOperationsAdapter
 
aggBy(Collection<? extends Aggregation>, boolean, TABLE, Collection<? extends ColumnName>) - Method in interface io.deephaven.api.TableOperations
Produce an aggregated result by grouping this according to the groupByColumns and applying aggregations to each resulting group of rows.
aggBy(Collection<? extends Aggregation>, String...) - Method in interface io.deephaven.api.TableOperations
Produce an aggregated result by grouping this according to the groupByColumns and applying aggregations to each resulting group of rows.
aggBy(Collection<? extends Aggregation>, String...) - Method in interface io.deephaven.api.TableOperationsDefaults
 
aggBy(Collection<? extends Aggregation>, Collection<? extends ColumnName>) - Method in interface io.deephaven.api.TableOperations
Produce an aggregated result by grouping this according to the groupByColumns and applying aggregations to each resulting group of rows.
aggBy(Collection<? extends Aggregation>, Collection<? extends ColumnName>) - Method in interface io.deephaven.api.TableOperationsDefaults
 
AggCount(String) - Static method in interface io.deephaven.api.agg.Aggregation
Create a count aggregation with the supplied output column name.
AggCountDistinct(boolean, String...) - Static method in interface io.deephaven.api.agg.Aggregation
Create a count distinct aggregation for the supplied column name pairs.
AggCountDistinct(String...) - Static method in interface io.deephaven.api.agg.Aggregation
Create a count distinct aggregation for the supplied column name pairs.
AggDistinct(boolean, String...) - Static method in interface io.deephaven.api.agg.Aggregation
Create a distinct aggregation for the supplied column name pairs.
AggDistinct(String...) - Static method in interface io.deephaven.api.agg.Aggregation
Create a distinct aggregation for the supplied column name pairs.
AggFirst(String...) - Static method in interface io.deephaven.api.agg.Aggregation
Create a first aggregation for the supplied column name pairs.
AggFirstRowKey(String) - Static method in interface io.deephaven.api.agg.Aggregation
Create a first row key aggregation with the supplied result column.
AggFormula(String, String, String...) - Static method in interface io.deephaven.api.agg.Aggregation
Create a formula aggregation with the supplied formula, paramToken, and column name pairs.
AggFreeze(String...) - Static method in interface io.deephaven.api.agg.Aggregation
Create a freeze aggregation for the supplied column name pairs.
AggGroup(String...) - Static method in interface io.deephaven.api.agg.Aggregation
Create a group aggregation for the supplied column name pairs.
AggLast(String...) - Static method in interface io.deephaven.api.agg.Aggregation
Create a last aggregation for the supplied column name pairs.
AggLastRowKey(String) - Static method in interface io.deephaven.api.agg.Aggregation
Create a last row key aggregation with the supplied result column.
AggMax(String...) - Static method in interface io.deephaven.api.agg.Aggregation
Create a max aggregation for the supplied column name pairs.
AggMed(boolean, String...) - Static method in interface io.deephaven.api.agg.Aggregation
Create a median aggregation for the supplied column name pairs.
AggMed(String...) - Static method in interface io.deephaven.api.agg.Aggregation
Create a median aggregation for the supplied column name pairs.
AggMin(String...) - Static method in interface io.deephaven.api.agg.Aggregation
Create a min aggregation for the supplied column name pairs.
aggMinMax - Variable in class io.deephaven.engine.table.impl.updateby.rollingminmax.ByteRollingMinMaxOperator.Context
 
aggMinMax - Variable in class io.deephaven.engine.table.impl.updateby.rollingminmax.CharRollingMinMaxOperator.Context
 
aggMinMax - Variable in class io.deephaven.engine.table.impl.updateby.rollingminmax.ComparableRollingMinMaxOperator.Context
 
aggMinMax - Variable in class io.deephaven.engine.table.impl.updateby.rollingminmax.DoubleRollingMinMaxOperator.Context
 
aggMinMax - Variable in class io.deephaven.engine.table.impl.updateby.rollingminmax.FloatRollingMinMaxOperator.Context
 
aggMinMax - Variable in class io.deephaven.engine.table.impl.updateby.rollingminmax.IntRollingMinMaxOperator.Context
 
aggMinMax - Variable in class io.deephaven.engine.table.impl.updateby.rollingminmax.LongRollingMinMaxOperator.Context
 
aggMinMax - Variable in class io.deephaven.engine.table.impl.updateby.rollingminmax.ShortRollingMinMaxOperator.Context
 
aggNoMemo(AggregationContextFactory, boolean, Table, Collection<? extends ColumnName>) - Method in class io.deephaven.engine.table.impl.QueryTable
 
AggPartition(String) - Static method in interface io.deephaven.api.agg.Aggregation
Create a partition aggregation with the supplied output column name and group-by columns included in the output sub-tables.
AggPartition(String, boolean) - Static method in interface io.deephaven.api.agg.Aggregation
Create a partition aggregation with the supplied output column name.
AggPct(double, boolean, String...) - Static method in interface io.deephaven.api.agg.Aggregation
Create a percentile aggregation for the supplied percentile and column name pairs.
AggPct(double, String...) - Static method in interface io.deephaven.api.agg.Aggregation
Create a percentile aggregation for the supplied percentile and column name pairs.
AggPct(String, boolean, PercentileOutput...) - Static method in interface io.deephaven.api.agg.Aggregation
Create a percentile aggregation for the supplied input column name and percentile/output column name pairs.
AggPct(String, PercentileOutput...) - Static method in interface io.deephaven.api.agg.Aggregation
Create a percentile aggregation for the supplied input column name and percentile/output column name pairs.
aggregate(AggregateRequest, StreamObserver<ExportedTableCreationResponse>) - Method in class io.deephaven.server.table.ops.TableServiceGrpcImpl
 
aggregate(AggregateRequest) - Method in class io.deephaven.proto.backplane.grpc.TableServiceGrpc.TableServiceBlockingStub
Produce an aggregated result by grouping the source_id table according to the group_by_columns and applying aggregations to each resulting group of rows.
aggregate(AggregateRequest) - Method in class io.deephaven.proto.backplane.grpc.TableServiceGrpc.TableServiceFutureStub
Produce an aggregated result by grouping the source_id table according to the group_by_columns and applying aggregations to each resulting group of rows.
aggregate(AggregateRequest, StreamObserver<ExportedTableCreationResponse>) - Method in interface io.deephaven.proto.backplane.grpc.TableServiceGrpc.AsyncService
Produce an aggregated result by grouping the source_id table according to the group_by_columns and applying aggregations to each resulting group of rows.
aggregate(AggregateRequest, StreamObserver<ExportedTableCreationResponse>) - Method in class io.deephaven.proto.backplane.grpc.TableServiceGrpc.TableServiceStub
Produce an aggregated result by grouping the source_id table according to the group_by_columns and applying aggregations to each resulting group of rows.
AGGREGATE - Enum constant in enum class io.deephaven.proto.backplane.grpc.BatchTableRequest.Operation.OpCase
 
AGGREGATE_ALL - Enum constant in enum class io.deephaven.proto.backplane.grpc.BatchTableRequest.Operation.OpCase
 
AGGREGATE_ALL_FIELD_NUMBER - Static variable in class io.deephaven.proto.backplane.grpc.BatchTableRequest.Operation
 
AGGREGATE_FIELD_NUMBER - Static variable in class io.deephaven.proto.backplane.grpc.BatchTableRequest.Operation
 
aggregateAll(AggregateAllRequest, StreamObserver<ExportedTableCreationResponse>) - Method in class io.deephaven.server.table.ops.TableServiceGrpcImpl
 
aggregateAll(AggregateAllRequest) - Method in class io.deephaven.proto.backplane.grpc.TableServiceGrpc.TableServiceBlockingStub
Aggregates all non-grouping columns against a single aggregation specification.
aggregateAll(AggregateAllRequest) - Method in class io.deephaven.proto.backplane.grpc.TableServiceGrpc.TableServiceFutureStub
Aggregates all non-grouping columns against a single aggregation specification.
aggregateAll(AggregateAllRequest, StreamObserver<ExportedTableCreationResponse>) - Method in interface io.deephaven.proto.backplane.grpc.TableServiceGrpc.AsyncService
Aggregates all non-grouping columns against a single aggregation specification.
aggregateAll(AggregateAllRequest, StreamObserver<ExportedTableCreationResponse>) - Method in class io.deephaven.proto.backplane.grpc.TableServiceGrpc.TableServiceStub
Aggregates all non-grouping columns against a single aggregation specification.
AggregateAllExclusions - Class in io.deephaven.engine.table.impl.by
Computes the columns to exclude from aggregation output
AggregateAllExclusions() - Constructor for class io.deephaven.engine.table.impl.by.AggregateAllExclusions
 
AggregateAllGrpcImpl - Class in io.deephaven.server.table.ops
 
AggregateAllGrpcImpl(TableServiceContextualAuthWiring) - Constructor for class io.deephaven.server.table.ops.AggregateAllGrpcImpl
 
AggregateAllRequest - Class in io.deephaven.proto.backplane.grpc
Protobuf type io.deephaven.proto.backplane.grpc.AggregateAllRequest
AggregateAllRequest.Builder - Class in io.deephaven.proto.backplane.grpc
Protobuf type io.deephaven.proto.backplane.grpc.AggregateAllRequest
AggregateAllRequestOrBuilder - Interface in io.deephaven.proto.backplane.grpc
 
AggregateAllTable - Class in io.deephaven.qst.table
 
AggregateAllTable() - Constructor for class io.deephaven.qst.table.AggregateAllTable
 
AggregateAllTable.Builder - Interface in io.deephaven.qst.table
 
AggregateColumnSource<VECTOR_TYPE extends Vector<VECTOR_TYPE>,COMPONENT_TYPE> - Interface in io.deephaven.engine.table.impl.sources.aggregate
ColumnSource and UngroupableColumnSource interface for aggregation result columns.
AggregateColumnSource.FactoryHelper - Class in io.deephaven.engine.table.impl.sources.aggregate
 
aggregated - Variable in class io.deephaven.engine.table.impl.sources.aggregate.RangeAggregateColumnSource
 
Aggregated - Enum constant in enum class io.deephaven.engine.table.hierarchical.RollupTable.NodeType
Nodes at one of the aggregated (rolled up) levels in the RollupTable.
aggregatedPrev - Variable in class io.deephaven.engine.table.impl.sources.aggregate.RangeAggregateColumnSource
 
aggregatedSource - Variable in class io.deephaven.engine.table.impl.sources.aggregate.BaseAggregateSlicedColumnSource
 
aggregatedSourcePrev - Variable in class io.deephaven.engine.table.impl.sources.aggregate.BaseAggregateSlicedColumnSource
 
AggregateGrpcImpl - Class in io.deephaven.server.table.ops
 
AggregateGrpcImpl(TableServiceContextualAuthWiring) - Constructor for class io.deephaven.server.table.ops.AggregateGrpcImpl
 
AggregateRequest - Class in io.deephaven.proto.backplane.grpc
Protobuf type io.deephaven.proto.backplane.grpc.AggregateRequest
AggregateRequest.Builder - Class in io.deephaven.proto.backplane.grpc
Protobuf type io.deephaven.proto.backplane.grpc.AggregateRequest
AggregateRequestOrBuilder - Interface in io.deephaven.proto.backplane.grpc
 
AGGREGATES_FIELD_NUMBER - Static variable in class io.deephaven.proto.backplane.grpc.ComboAggregateRequest
Deprecated.
 
AggregateTable - Class in io.deephaven.qst.table
 
AggregateTable() - Constructor for class io.deephaven.qst.table.AggregateTable
 
AggregateTable.Builder - Interface in io.deephaven.qst.table
 
AggregatingByteRingBuffer - Class in io.deephaven.base.ringbuffer
A ring buffer which aggregates its contents according to a user-defined aggregation function.
AggregatingByteRingBuffer(int, byte, AggregatingByteRingBuffer.ByteFunction) - Constructor for class io.deephaven.base.ringbuffer.AggregatingByteRingBuffer
Creates a ring buffer for byte values which aggregates its contents according to a user-defined aggregation function.
AggregatingByteRingBuffer(int, byte, AggregatingByteRingBuffer.ByteFunction, AggregatingByteRingBuffer.ByteFunction) - Constructor for class io.deephaven.base.ringbuffer.AggregatingByteRingBuffer
Creates a ring buffer for byte values which aggregates its contents according to a user-defined aggregation function.
AggregatingByteRingBuffer(int, byte, AggregatingByteRingBuffer.ByteFunction, AggregatingByteRingBuffer.ByteFunction, boolean) - Constructor for class io.deephaven.base.ringbuffer.AggregatingByteRingBuffer
Creates a ring buffer for byte values which aggregates its contents according to a user-defined aggregation function.
AggregatingByteRingBuffer.ByteFunction - Interface in io.deephaven.base.ringbuffer
 
AggregatingCharRingBuffer - Class in io.deephaven.base.ringbuffer
A ring buffer which aggregates its contents according to a user-defined aggregation function.
AggregatingCharRingBuffer(int, char, AggregatingCharRingBuffer.CharFunction) - Constructor for class io.deephaven.base.ringbuffer.AggregatingCharRingBuffer
Creates a ring buffer for char values which aggregates its contents according to a user-defined aggregation function.
AggregatingCharRingBuffer(int, char, AggregatingCharRingBuffer.CharFunction, AggregatingCharRingBuffer.CharFunction) - Constructor for class io.deephaven.base.ringbuffer.AggregatingCharRingBuffer
Creates a ring buffer for char values which aggregates its contents according to a user-defined aggregation function.
AggregatingCharRingBuffer(int, char, AggregatingCharRingBuffer.CharFunction, AggregatingCharRingBuffer.CharFunction, boolean) - Constructor for class io.deephaven.base.ringbuffer.AggregatingCharRingBuffer
Creates a ring buffer for char values which aggregates its contents according to a user-defined aggregation function.
AggregatingCharRingBuffer.CharFunction - Interface in io.deephaven.base.ringbuffer
 
AggregatingDoubleRingBuffer - Class in io.deephaven.base.ringbuffer
A ring buffer which aggregates its contents according to a user-defined aggregation function.
AggregatingDoubleRingBuffer(int, double, AggregatingDoubleRingBuffer.DoubleFunction) - Constructor for class io.deephaven.base.ringbuffer.AggregatingDoubleRingBuffer
Creates a ring buffer for double values which aggregates its contents according to a user-defined aggregation function.
AggregatingDoubleRingBuffer(int, double, AggregatingDoubleRingBuffer.DoubleFunction, AggregatingDoubleRingBuffer.DoubleFunction) - Constructor for class io.deephaven.base.ringbuffer.AggregatingDoubleRingBuffer
Creates a ring buffer for double values which aggregates its contents according to a user-defined aggregation function.
AggregatingDoubleRingBuffer(int, double, AggregatingDoubleRingBuffer.DoubleFunction, AggregatingDoubleRingBuffer.DoubleFunction, boolean) - Constructor for class io.deephaven.base.ringbuffer.AggregatingDoubleRingBuffer
Creates a ring buffer for double values which aggregates its contents according to a user-defined aggregation function.
AggregatingDoubleRingBuffer.DoubleFunction - Interface in io.deephaven.base.ringbuffer
 
AggregatingFloatRingBuffer - Class in io.deephaven.base.ringbuffer
A ring buffer which aggregates its contents according to a user-defined aggregation function.
AggregatingFloatRingBuffer(int, float, AggregatingFloatRingBuffer.FloatFunction) - Constructor for class io.deephaven.base.ringbuffer.AggregatingFloatRingBuffer
Creates a ring buffer for float values which aggregates its contents according to a user-defined aggregation function.
AggregatingFloatRingBuffer(int, float, AggregatingFloatRingBuffer.FloatFunction, AggregatingFloatRingBuffer.FloatFunction) - Constructor for class io.deephaven.base.ringbuffer.AggregatingFloatRingBuffer
Creates a ring buffer for float values which aggregates its contents according to a user-defined aggregation function.
AggregatingFloatRingBuffer(int, float, AggregatingFloatRingBuffer.FloatFunction, AggregatingFloatRingBuffer.FloatFunction, boolean) - Constructor for class io.deephaven.base.ringbuffer.AggregatingFloatRingBuffer
Creates a ring buffer for float values which aggregates its contents according to a user-defined aggregation function.
AggregatingFloatRingBuffer.FloatFunction - Interface in io.deephaven.base.ringbuffer
 
AggregatingIntRingBuffer - Class in io.deephaven.base.ringbuffer
A ring buffer which aggregates its contents according to a user-defined aggregation function.
AggregatingIntRingBuffer(int, int, AggregatingIntRingBuffer.IntFunction) - Constructor for class io.deephaven.base.ringbuffer.AggregatingIntRingBuffer
Creates a ring buffer for int values which aggregates its contents according to a user-defined aggregation function.
AggregatingIntRingBuffer(int, int, AggregatingIntRingBuffer.IntFunction, AggregatingIntRingBuffer.IntFunction) - Constructor for class io.deephaven.base.ringbuffer.AggregatingIntRingBuffer
Creates a ring buffer for int values which aggregates its contents according to a user-defined aggregation function.