Package io.deephaven.engine.table.impl
-
Interface Summary Interface Description AsOfJoinHelper.SsaFactory BaseTable.SwapListenerFactory<T extends SwapListenerBase<?>> BothIncrementalNaturalJoinStateManager BothIncrementalNaturalJoinStateManager.InitialBuildContext ColumnComparatorFactory.IComparator ColumnSourceGetDefaults.ForBoolean Default interface for BooleanColumnSource
implementations.ColumnSourceGetDefaults.ForByte Default interface for byteColumnSource
implementations.ColumnSourceGetDefaults.ForChar Default interface for charColumnSource
implementations.ColumnSourceGetDefaults.ForDouble Default interface for doubleColumnSource
implementations.ColumnSourceGetDefaults.ForFloat Default interface for floatColumnSource
implementations.ColumnSourceGetDefaults.ForInt Default interface for intColumnSource
implementations.ColumnSourceGetDefaults.ForLong Default interface for longColumnSource
implementations.ColumnSourceGetDefaults.ForLongAsDateTime Default interface forDateTime
ColumnSource
implementations.ColumnSourceGetDefaults.ForObject<DATA_TYPE> Default interface for ObjectColumnSource
implementations.ColumnSourceGetDefaults.ForShort Default interface for shortColumnSource
implementations.ColumnSourceGetDefaults.LongBacked<DATA_TYPE> Default interface for long-backedColumnSource
implementations.ColumnSourceManager Manager for ColumnSources in a Table.ColumnToCodecMappings CrossJoinStateManager DefaultChunkSource<ATTR extends Any> DefaultChunkSource.SupportsContiguousGet<ATTR extends Any> An alternative set of defaults which may typically be used byChunkSource
s which support a get method which only works for contiguous ranges.DefaultChunkSource.WithPrev<ATTR extends Any> DependencyStreamProvider An interface for things that provide a stream of dependencies.HierarchicalTableInfo A class that contains information required for a particular Hierarchical table type, for exampletree tables
orrollups
.ImmutableColumnSource<DATA_TYPE> Sub-interface ofColumnSource
for implementations that always use returntrue
fromImmutableColumnSource.isImmutable()
and delegate allgetPrev*
methods to their current (non-previous) equivalents.ImmutableColumnSourceGetDefaults.ForBoolean Default interface for immutable BooleanColumnSource
implementations.ImmutableColumnSourceGetDefaults.ForByte Default interface for immutable byteColumnSource
implementations.ImmutableColumnSourceGetDefaults.ForChar Default interface for immutable charColumnSource
implementations.ImmutableColumnSourceGetDefaults.ForDouble Default interface for immutable doubleColumnSource
implementations.ImmutableColumnSourceGetDefaults.ForFloat Default interface for immutable floatColumnSource
implementations.ImmutableColumnSourceGetDefaults.ForInt Default interface for immutable intColumnSource
implementations.ImmutableColumnSourceGetDefaults.ForLong Default interface for immutable longColumnSource
implementations.ImmutableColumnSourceGetDefaults.ForLongAsDateTime Default interface for immutableDateTime
ColumnSource
implementations.ImmutableColumnSourceGetDefaults.ForObject<DATA_TYPE> Default interface for immutable ObjectColumnSource
implementations.ImmutableColumnSourceGetDefaults.ForShort Default interface for immutable shortColumnSource
implementations.ImmutableColumnSourceGetDefaults.LongBacked<DATA_TYPE> Default interface for immutable long-backedColumnSource
implementations.IncrementalNaturalJoinStateManager KeyedTableListener.KeyUpdateListener LazySnapshotTable This interface represents a table that will not update itself on the run cycle, but instead run itself when the run for snapshot is called.LazySnapshotTableProvider The right hand side table of a V2 snapshot must be an QueryTable (otherwise it fails with a class cast exception), but there are certain cases where we may not want that to be true (e.g., a WnUnsubscribedTable).MemoizedOperationKey.Provider MutableColumnSource<DATA_TYPE> Sub-interface ofColumnSource
for implementations that always use returnfalse
fromMutableColumnSource.isImmutable()
.MutableColumnSourceGetDefaults.ForBoolean Default interface for mutable BooleanColumnSource
implementations.MutableColumnSourceGetDefaults.ForByte Default interface for mutable byteColumnSource
implementations.MutableColumnSourceGetDefaults.ForChar Default interface for mutable charColumnSource
implementations.MutableColumnSourceGetDefaults.ForDouble Default interface for mutable doubleColumnSource
implementations.MutableColumnSourceGetDefaults.ForFloat Default interface for mutable floatColumnSource
implementations.MutableColumnSourceGetDefaults.ForInt Default interface for mutable intColumnSource
implementations.MutableColumnSourceGetDefaults.ForLong Default interface for mutable longColumnSource
implementations.MutableColumnSourceGetDefaults.ForLongAsDateTime Default interface for mutableDateTime
ColumnSource
implementations.MutableColumnSourceGetDefaults.ForObject<DATA_TYPE> Default interface for mutable ObjectColumnSource
implementations.MutableColumnSourceGetDefaults.ForShort Default interface for mutable shortColumnSource
implementations.MutableColumnSourceGetDefaults.LongBacked<DATA_TYPE> Default interface for mutable long-backedColumnSource
implementations.NotificationStepReceiver Used byswap listeners
to set the notification step of elements in our DAG.NotificationStepSource Elements of a Deephaven query DAG that can supply their notification step.QueryTable.MemoizableOperation<T extends DynamicNode & NotificationStepReceiver> QueryTable.Operation<T extends DynamicNode & NotificationStepReceiver> ReverseLookup For hierarchical table display, identify the row key that corresponds to a given logical key.RightIncrementalNaturalJoinStateManager.InitialBuildContext SourceTableComponentFactory Factory for source table components.TableWithDefaults Sub-interface to capture default methods romTable
.TupleSourceFactory.TupleSourceCreator TupleSourceFactory.TupleSourceCreatorProvider UpdatableTable.RowSetChangeRecorder Interface provided to updater functions that allows RowSet changes to be recorded for propagation.UpdatableTable.Updater Updater function interface.UpdateByOperator An operator that performs a specific computation forTable.updateBy(io.deephaven.api.updateby.UpdateByOperation)
.UpdateByOperator.UpdateContext A context item for use withTable#updateBy(UpdateByControl, Collection, String...)
for non-bucketed updates.UpdateErrorReporter -
Class Summary Class Description AbstractColumnSource<T> AbstractColumnSource.DefaultedImmutable<DATA_TYPE> AbstractColumnSource.DefaultedMutable<DATA_TYPE> AbstractHierarchicalTableInfo Base class containing common code for implementers of HierarchicalTableInfoAsOfJoinHelper BaseTable Base abstract class all standard table implementations.BaseTable.ListenerImpl Simplest appropriate InstrumentedShiftAwareListener implementation for BaseTable and descendants.BaseTable.ShiftObliviousListenerImpl Simplest appropriate legacy ShiftObliviousInstrumentedListener implementation for BaseTable and descendants.BucketedUpdateBy CodecLookup Utility class to concentrateObjectCodec
lookups.ColumnComparatorFactory ColumnSourceGetDefaults Defaulted interfaces for various baseColumnSource
types, in order to avoid having defaults at higher levels in the class hierarchy.ConstituentDependency A ConstituentDependency is used to establish adependency
relationship between a table and the constituent tables (or table-like things) that fill its columns.ContextWithChunk<ATTR extends Any,CONTEXT extends Context> CrossJoinHelper Implementation for chunk-oriented aggregation operations, includingTable.join(io.deephaven.engine.table.Table)
.CrossJoinShiftState Shift state used by theBitShiftingColumnSource
.DefaultGetContext<ATTR extends Any> DeferredViewTable An uncoalesced table with view and where operations to be applied afterUncoalescedTable.coalesce()
is forced.DeferredViewTable.SimpleTableReference DeferredViewTable.TableReference The table reference hides the table underlying table from us.DeferredViewTable.TableReference.TableAndRemainingFilters FlattenOperation GroupingUtils Utilities for creating or interacting with grouping information.HashTableAnnotations Annotations library for the column-oriented hash tables used by join and aggregation operations.HierarchicalTable This class is an extension of QueryTable that overrides many methods fromTable
which are not valid to perform on Hierarchical tables (treeTables() and rollups()).ImmutableColumnSourceGetDefaults Defaulted interfaces for various immutableColumnSource
types, in order to avoid having defaults at higher levels in the class hierarchy.IndexedDataColumn<TYPE> DataColumn implementation backed by a ColumnSource and a RowSet.InMemoryTable InstrumentedTableListenerBase InstrumentedTableUpdateListener InstrumentedTableUpdateListenerAdapter This class is used for ShiftAwareListeners that represent "leaf" nodes in the update propagation tree.InstrumentedUpdateSource JoinControl JoinRowRedirection Makes a redirection index based on the type provided by the join control.KeyedTableListener ListenerRecorder A listener recorder stores references to added, removed, modified, and shifted indices; and then notifies aMergedListener
that a change has occurred.MemoizedOperationKey Indices for memoized operations on QueryTable.MergedListener A merged listener has a collection ofListenerRecorder
s.MutableColumnSourceGetDefaults Defaulted interfaces for various mutableColumnSource
types, in order to avoid having defaults at higher levels in the class hierarchy.NaturalJoinModifiedSlotTracker A tracker for modified join hash table slots.OperationInitializationThreadPool PartitionAwareSourceTable A source table that can filter partitions before coalescing.PrevColumnSource<T> WrapperColumnSource
that maps current data accessors to previous data accessors (and disables previous data accessors).QueryTable Primary coalesced table implementation.QueryTable.FilteredTable QueryTable.Operation.Result<T extends DynamicNode & NotificationStepReceiver> The resulting table and listener of the operation.RandomDataGenerator RedefinableTable An uncoalesced table that may be redefined without triggering aUncoalescedTable.coalesce()
.ReverseLookup.Null A null implementation of a reverse lookup, suitable for a table without any key columns.ReverseLookupListener Maintains a map from key column values to their row key.ReverseOperation RightIncrementalAsOfJoinStateManager RightIncrementalChunkedAsOfJoinStateManager RightIncrementalNaturalJoinStateManager RollupAttributeCopier Copies attributes for constituent leafs or intermediate level rollups.RollupInfo SelectValidationResult ShiftObliviousInstrumentedListener ShiftObliviousInstrumentedListenerAdapter This class is used for Listeners that represent "leaf" nodes in the update propagation tree.ShiftObliviousSwapListener SimpleSourceTable Simple source table with no partitioning support.SliceLikeOperation SmartKeySource SortedColumnsAttribute Helper class for managing the sorted columns attribute.SortHelpers SortListener SortOperation SortPair A pair representing a column to sort by and its direction.SourcePartitionedTable SourceTable Basic uncoalesced table that only adds keys.SourceTable.QueryTableReference SparseSelect A simpler version ofTable.select(java.util.Collection<? extends io.deephaven.api.Selectable>)
that is guaranteed to preserve the original table's RowSet.StaticAsOfJoinStateManager StaticNaturalJoinStateManager StreamTableTools Tools for manipulating stream tables.SwapListener SwapListenerBase<T extends TableListener> Watch for ticks and when initialization is complete forward to the eventual listener.TableCreatorImpl.TableCreatorProvider TableKeyStateRegistry<VALUE_TYPE> A registry for states keyed byTableKey
.TableUpdateImpl Implementation ofTableUpdate
.TableUpdateValidator TimeTable A TimeTable adds rows at a fixed interval with a single column named "Timestamp".TimeTable.Builder TreeTableFilter Apply filters, preserving parents.TreeTableInfo TreeTableOrphanPromoter Identify orphan rows in a table destined for conversion into a tree table, and mask their parent column value to null, so that they show up at the top level of the hierarchy.TupleSourceFactory Factory for producing Deephaven engine TupleSource instances.UnboxedDateTimeColumnSource Reinterpret result for manyColumnSource
implementations that internally representDateTime
values aslong
values.UnboxedDateTimeWritableSource UncoalescedTable Abstract class for uncoalesced tables.UpdatableTable A live table that allows add, remove, and modify.UpdateBy The core of theTable.updateBy(UpdateByControl, Collection, Collection)
operation.UpdateByOperatorFactory A factory to visit all of theUpdateByOperation
s to produce a set ofUpdateByOperator
s thatUpdateBy
can use to produce a result.UpdateSourceQueryTable AQueryTable
that acts as an update source within theUpdateGraphProcessor
, withRowSet
changes queued externally by a single producer.WouldMatchOperation A table operation similar toTable.where(String...)
except that instead of filtering the rows in the table, it appends new columns containing the result of the filter evaluation on each row of the table. -
Enum Summary Enum Description BaseTable.CopyAttributeOperation JoinControl.RedirectionType KeyedTableListener.KeyEvent RollupInfo.LeafType The type of leaf nodes the rollup has.SortingOrder Enum value for ascending vs.TableCreatorImpl Engine-specific implementation ofTableCreator
.UpdateBy.UpdateType The type of update to be applied. -
Exception Summary Exception Description NoSuchColumnException Exception thrown when a column is not found. -
Annotation Types Summary Annotation Type Description HashTableAnnotations.EmptyStateValue We tag the empty state variable with this annotation, so we know what its name is in the source and destination.HashTableAnnotations.OverflowStateColumnSource We tag the overflow state ColumnSource with this annotation, so we know what its name is in the source and destination.HashTableAnnotations.StateColumnSource We tag the state ColumnSource with this annotation, so we know what its name is in the source and destination.