Index

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

A

absSumBy(SelectColumn...) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
accept(TableKey) - Method in class io.deephaven.enterprise.tabledataservice.filter.EnterpriseFilterWrapper
 
accept(TableKey) - Method in interface io.deephaven.enterprise.tabledataservice.filter.TableKeyFilter
 
accept(TableLocationKey) - Method in class io.deephaven.enterprise.tabledataservice.filter.EnterpriseFilterWrapper
 
accept(Object) - Method in class io.deephaven.pivot.PivotTableViewExchangeMarshaller
 
ACL_ATTRIBUTE - Static variable in interface io.deephaven.enterprise.acl.EdgeAclProvider
 
AclFilterGenerator - Interface in io.deephaven.enterprise.acl
This interface defines an object that generates WhereFilters to apply as ACLs to tables based upon a UserContext and potentially a namespace and table name.
AclHelper - Class in io.deephaven.enterprise.acl.impl
 
AclHelper() - Constructor for class io.deephaven.enterprise.acl.impl.AclHelper
 
AclSupport - Interface in io.deephaven.enterprise.acl
A support object to assist in the creation of Row and column ACLs.
activateUnderlyingDataSource() - Method in class io.deephaven.enterprise.compatibility.locationprovider.CoreFromEnterpriseTableLocationProvider
 
activateUnderlyingDataSource() - Method in class io.deephaven.enterprise.locations.local.deephaven.OnDiskDeephavenTableLocation
 
activateUnderlyingDataSource() - Method in class io.deephaven.enterprise.locations.remote.RemoteDeephavenTableLocation
 
adapt() - Method in interface io.deephaven.enterprise.locations.EnterpriseTableKey
Get an Enterprise formatted version of this EnterpriseTableKey, which will contain a V2 table type.
adapt() - Method in interface io.deephaven.enterprise.locations.FixedPartitionedEnterpriseTableLocationKey
Return an Enterprise TableLocationKey version of this key.
adapt() - Method in class io.deephaven.enterprise.locations.impl.BasicFixedPartitionedDeephavenTableLocationKey
 
adapt() - Method in class io.deephaven.enterprise.locations.impl.EnterpriseTableKeyImpl
 
adaptFlags(Row.Flags) - Static method in class io.deephaven.enterprise.dnd.logger.engine.impl.BinaryRowUtils
Adapt flags from Community Core to Enterprise Shadowed flags.
adaptOrderedKeys(OrderedKeys) - Method in class io.deephaven.enterprise.compatibility.chunk.FillContextWrapper
 
adaptWithV1TableType() - Method in interface io.deephaven.enterprise.locations.EnterpriseTableKey
Get an Enterprise formatted version of this EnterpriseTableKey, which will be logically equivalent, except for table type adapted to its V1 equivalent.
adaptWithV1TableType() - Method in class io.deephaven.enterprise.locations.impl.EnterpriseTableKeyImpl
 
addAcl(String, Object) - Static method in interface io.deephaven.enterprise.acl.EdgeAclProvider
 
addAcl(String, Object) - Static method in class io.deephaven.enterprise.acl.transform.GenericObjectTransformer
Add visibility for the specified object to the specified group.
addAggregations(int, Aggregation) - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
aggregations for the values
addAggregations(int, Aggregation.Builder) - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
aggregations for the values
addAggregations(Aggregation) - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
aggregations for the values
addAggregations(Aggregation.Builder) - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
aggregations for the values
addAggregationsBuilder() - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
aggregations for the values
addAggregationsBuilder(int) - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
aggregations for the values
addAllAggregations(Iterable<? extends Aggregation>) - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
aggregations for the values
addAllColumnKeys(Iterable<String>) - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
first reference is the input table
addAllColumnSorts(Iterable<? extends SortDescriptor>) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor column_sorts = 2;
addAllFilters(Iterable<? extends Condition>) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
The filters must be against the grouping columns (either row or columns)
addAllFilters(Iterable<String>) - Method in interface io.deephaven.enterprise.remote.SubscriptionOptions.Builder
Set the filters to apply in conjunction with SubscriptionOptions.filter() before subscribing.
addAllIncludedColumns(Iterable<String>) - Method in interface io.deephaven.enterprise.remote.SubscriptionOptions.Builder
Set the columns to subscribe to from the upstream.
addAllObjectNames(Iterable<String>) - Method in class io.deephaven.proto.pqworker.ObjectAccessRequest.Builder
repeated string objectNames = 1;
addAllOutputColumns(Iterable<String>) - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage.Builder
The name of the output columns that are sent, if not specified then all totals and value columns are sent.
addAllRowKeys(Iterable<String>) - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
repeated string row_keys = 2;
addAllRowSorts(Iterable<? extends SortDescriptor>) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor row_sorts = 1;
addAllValues(Iterable<String>) - Method in class io.deephaven.proto.pqworker.StringList.Builder
repeated string values = 1;
addColumnKeys(String) - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
first reference is the input table
addColumnKeysBytes(ByteString) - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
first reference is the input table
addColumnSorts(int, SortDescriptor) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor column_sorts = 2;
addColumnSorts(int, SortDescriptor.Builder) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor column_sorts = 2;
addColumnSorts(SortDescriptor) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor column_sorts = 2;
addColumnSorts(SortDescriptor.Builder) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor column_sorts = 2;
addColumnSortsBuilder() - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor column_sorts = 2;
addColumnSortsBuilder(int) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor column_sorts = 2;
addColumnsSize(FlatBufferBuilder, long) - Static method in class io.deephaven.enterprise.pivot.flatbuf.PivotUpdateMetadata
 
addEffectiveColumnViewport(FlatBufferBuilder, int) - Static method in class io.deephaven.enterprise.pivot.flatbuf.PivotUpdateMetadata
 
addEffectiveRowViewport(FlatBufferBuilder, int) - Static method in class io.deephaven.enterprise.pivot.flatbuf.PivotUpdateMetadata
 
addFilter(String, AclFilterGenerator) - Method in class io.deephaven.enterprise.acl.generator.CombiningFilterGenerator
Add a AclFilterGenerator that will be applied only if the user is a member of the specified group.
addFilters(int, Condition) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
The filters must be against the grouping columns (either row or columns)
addFilters(int, Condition.Builder) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
The filters must be against the grouping columns (either row or columns)
addFilters(Condition) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
The filters must be against the grouping columns (either row or columns)
addFilters(Condition.Builder) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
The filters must be against the grouping columns (either row or columns)
addFilters(String...) - Method in interface io.deephaven.enterprise.remote.SubscriptionOptions.Builder
Set the filters to apply before subscribing.
addFiltersBuilder() - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
The filters must be against the grouping columns (either row or columns)
addFiltersBuilder(int) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
The filters must be against the grouping columns (either row or columns)
addIncludedColumns(String...) - Method in interface io.deephaven.enterprise.remote.SubscriptionOptions.Builder
Set the columns to subscribe to from the upstream.
addInputTableSchema(String, String, TableDefinition, String...) - Method in class io.deephaven.enterprise.database.impl.DatabaseImpl
 
addInputTableSchema(String, String, TableDefinition, String...) - Method in interface io.deephaven.enterprise.database.WritableDatabase
Add a new input table schema using the TableDefinition and specified key column names.
addInputTableSchema(String, String, TableDefinition, String...) - Method in class io.deephaven.enterprise.replay.WritableReplayDatabase
 
addInputTableSchema(String, String, InputTableSpec) - Method in class io.deephaven.enterprise.database.impl.DatabaseImpl
 
addInputTableSchema(String, String, InputTableSpec) - Method in interface io.deephaven.enterprise.database.WritableDatabase
Add a new input table schema using the InputTableSpec.
addInputTableSchema(String, String, InputTableSpec) - Method in class io.deephaven.enterprise.replay.WritableReplayDatabase
 
addNamespace(String, ComposableTableReplayConfiguration) - Method in class io.deephaven.enterprise.replay.ReplayConfigurationImpl
 
addNotification(NotificationQueue.Notification) - Method in class io.deephaven.enterprise.test.CapturingUpdateGraph
 
addNotification(NotificationQueue.Notification) - Method in class io.deephaven.enterprise.compatibility.NotificationQueueAdapter
 
addNotifications(Collection<? extends NotificationQueue.Notification>) - Method in class io.deephaven.enterprise.test.CapturingUpdateGraph
 
addObjectNames(String) - Method in class io.deephaven.proto.pqworker.ObjectAccessRequest.Builder
repeated string objectNames = 1;
addObjectNamesBytes(ByteString) - Method in class io.deephaven.proto.pqworker.ObjectAccessRequest.Builder
repeated string objectNames = 1;
addObserver(PersistentQueryControllerClient.Observer) - Method in interface io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClient
Add an Observer.
addObserver(PersistentQueryControllerClient.Observer) - Method in class io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClientImpl
 
addObserverAndGetData(PersistentQueryControllerClient.Observer) - Method in interface io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClient
Add an Observer.
addObserverAndGetData(PersistentQueryControllerClient.Observer) - Method in class io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClientImpl
 
addOrValidateSchema() - Method in class io.deephaven.enterprise.kafkawriter.SchemaHelper
Validates the schema derived from SchemaHelper.getXmlSchema().
addOutputColumns(String) - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage.Builder
The name of the output columns that are sent, if not specified then all totals and value columns are sent.
addOutputColumnsBytes(ByteString) - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage.Builder
The name of the output columns that are sent, if not specified then all totals and value columns are sent.
addPartitionedTableSchema(String, String, String, TableDefinition) - Method in class io.deephaven.enterprise.database.impl.DatabaseImpl
 
addPartitionedTableSchema(String, String, String, TableDefinition) - Method in interface io.deephaven.enterprise.database.WritableDatabase
Adds a schema for a partitioned user table.
addPartitionedTableSchema(String, String, String, TableDefinition) - Method in class io.deephaven.enterprise.replay.WritableReplayDatabase
 
addQuery(PersistentQueryConfigMessage) - Method in interface io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClient
Adds a configuration to the controller's hash table.
addQuery(PersistentQueryConfigMessage) - Method in class io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClientImpl
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.pivot.ErrorResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.pivot.PivotTableApplyResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.pivot.PivotTableCreationResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.pivot.PivotTableDescriptorRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.pivot.PivotTableSourceExportRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.pivot.PivotTableSourceExportResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.pivot.PivotTableViewRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.pivot.PivotTableViewResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.pqworker.ListenErrorRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.pqworker.ListenErrorResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.pqworker.ObjectAccessRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.pqworker.ObjectAccessResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.pqworker.StringList.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.pqworker.ThreadDumpRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.pqworker.ThreadDumpResponse.Builder
 
addRowKeys(String) - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
repeated string row_keys = 2;
addRowKeysBytes(ByteString) - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
repeated string row_keys = 2;
addRowSorts(int, SortDescriptor) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor row_sorts = 1;
addRowSorts(int, SortDescriptor.Builder) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor row_sorts = 1;
addRowSorts(SortDescriptor) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor row_sorts = 1;
addRowSorts(SortDescriptor.Builder) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor row_sorts = 1;
addRowSortsBuilder() - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor row_sorts = 1;
addRowSortsBuilder(int) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor row_sorts = 1;
addRowsSize(FlatBufferBuilder, long) - Static method in class io.deephaven.enterprise.pivot.flatbuf.PivotUpdateMetadata
 
addSource(Runnable) - Method in class io.deephaven.enterprise.test.CapturingUpdateGraph
 
addTable(LiveTable) - Method in class io.deephaven.enterprise.compatibility.LiveTableRegistrarAdapter
 
addTable(String, String, ComposableTableReplayConfiguration) - Method in class io.deephaven.enterprise.replay.ReplayConfigurationImpl
 
addTablePartition(String, String, String, Table) - Method in class io.deephaven.enterprise.database.impl.DatabaseImpl
 
addTablePartition(String, String, String, Table) - Method in interface io.deephaven.enterprise.database.WritableDatabase
Adds a single column partition of data to a partitioned user table.
addTablePartition(String, String, String, Table) - Method in class io.deephaven.enterprise.replay.WritableReplayDatabase
 
addUnpartitionedTable(String, String, Table) - Method in class io.deephaven.enterprise.database.impl.DatabaseImpl
 
addUnpartitionedTable(String, String, Table) - Method in interface io.deephaven.enterprise.database.WritableDatabase
Adds an unpartitioned user table.
addUnpartitionedTable(String, String, Table) - Method in class io.deephaven.enterprise.replay.WritableReplayDatabase
 
addValues(String) - Method in class io.deephaven.proto.pqworker.StringList.Builder
repeated string values = 1;
addValuesBytes(ByteString) - Method in class io.deephaven.proto.pqworker.StringList.Builder
repeated string values = 1;
AdminOnlyConsoleAuthWiring - Class in io.deephaven.enterprise.dnd.authentication
This auth wiring only allows users marked as administrators for the query to perform console operations.
AdminOnlyConsoleAuthWiring() - Constructor for class io.deephaven.enterprise.dnd.authentication.AdminOnlyConsoleAuthWiring
 
AdminOnlyWorkerAuthWiring - Class in io.deephaven.enterprise.dnd.authentication
This auth wiring only allows users marked as administrators for the query to perform console operations.
AdminOnlyWorkerAuthWiring() - Constructor for class io.deephaven.enterprise.dnd.authentication.AdminOnlyWorkerAuthWiring
 
advance(long) - Method in class io.deephaven.enterprise.compatibility.rowset.OrderedKeysToRowSequenceIteratorAdapter
 
advance(long) - Method in class io.deephaven.enterprise.compatibility.rowset.RowSequenceToOrderedKeysIteratorAdapter
 
AGGREGATIONS_FIELD_NUMBER - Static variable in class io.deephaven.proto.pivot.PivotTableCreationRequest
 
aj(Table, MatchPair[], MatchPair[], Table.AsOfMatchRule) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
allocator - Variable in class io.deephaven.enterprise.dnd.client.DndSession
 
allocator() - Method in class io.deephaven.enterprise.dnd.client.DndSession
Get the underlying RootAllocator
allowsReinterpret(Class<ALTERNATE_DATA_TYPE>) - Method in class io.deephaven.enterprise.compatibility.filter.ColumnSourceAdapterForFilter
 
append(LogOutput) - Method in class io.deephaven.enterprise.locations.impl.EnterpriseTableKeyImpl
 
append(LogOutput) - Method in interface io.deephaven.enterprise.locations.DeephavenFormatTableLocation
 
append(LogOutput) - Method in class io.deephaven.enterprise.locations.remote.RemoteDeephavenTableLocation
 
append(ILoggingEvent) - Method in class io.deephaven.enterprise.dnd.ProcessEventLogAppender
 
append(LogOutput) - Method in class io.deephaven.enterprise.dnd.authentication.DheAuthContext
 
append(LogOutput) - Method in class io.deephaven.enterprise.locations.impl.BasicFixedPartitionedDeephavenTableLocationKey
 
append(LogOutput) - Method in class io.deephaven.enterprise.test.CapturingUpdateGraph
 
append(LogOutput) - Method in class io.deephaven.enterprise.dnd.authentication.DheAuthContext
 
append(LogOutput) - Method in class io.deephaven.enterprise.locations.impl.EnterpriseTableKeyImpl
 
appendAddColumns(BarrageMessageWriterImpl.RecordBatchMessageView, long, int, Consumer<DefensiveDrainable>, ChunkWriter.FieldNodeListener, ChunkWriter.BufferListener, ColumnChunksWriter<Chunk<Values>>[]) - Method in class io.deephaven.pivot.PivotBarrageMessageWriterImpl
 
appendLiveTable(String, String, String, Table) - Method in class io.deephaven.enterprise.database.impl.DatabaseImpl
 
appendLiveTable(String, String, String, Table) - Method in interface io.deephaven.enterprise.database.WritableDatabase
Appends all rows from a given table to a live user table partition.
appendLiveTable(String, String, String, Table) - Method in class io.deephaven.enterprise.replay.WritableReplayDatabase
 
appendLiveTableIncremental(String, String, String, Table) - Method in class io.deephaven.enterprise.database.impl.DatabaseImpl
 
appendLiveTableIncremental(String, String, String, Table) - Method in interface io.deephaven.enterprise.database.WritableDatabase
Appends all rows from a given table to a live user table partition.
appendLiveTableIncremental(String, String, String, Table) - Method in class io.deephaven.enterprise.replay.WritableReplayDatabase
 
appendLiveTableInternal(String, String, String, Table, String, boolean) - Method in class io.deephaven.enterprise.database.impl.DatabaseImpl
 
applicationVersion() - Method in class io.deephaven.enterprise.database.SystemTableLogger.Options
Get the application version used to write the log file.
applicationVersion(int) - Method in interface io.deephaven.enterprise.database.SystemTableLogger.Options.Builder
What application log version should the table be logged with (defaults to zero)
apply(Collection<SortColumn>, Collection<SortColumn>, List<? extends Filter>) - Method in interface io.deephaven.pivot.PivotTable
Apply transformations to this pivot.
APPLY - Enum constant in enum class io.deephaven.proto.pivot.PivotPluginRequest.RequestCase
 
APPLY - Enum constant in enum class io.deephaven.proto.pivot.PivotPluginResponse.ResponseCase
 
APPLY_FIELD_NUMBER - Static variable in class io.deephaven.proto.pivot.PivotPluginRequest
 
APPLY_FIELD_NUMBER - Static variable in class io.deephaven.proto.pivot.PivotPluginResponse
 
applyTo(RollupTable) - Method in interface io.deephaven.enterprise.acl.EdgeAclProvider
Applies the given provider to a RollupTable.
applyTo(TreeTable) - Method in interface io.deephaven.enterprise.acl.EdgeAclProvider
Applies the given provider to a TreeTable.
applyTo(Table) - Method in interface io.deephaven.enterprise.acl.EdgeAclProvider
Attach the ACLs to the specified table
applyTo(Table) - Method in class io.deephaven.enterprise.acl.impl.ColumnAcl
Apply these column ACLs to the specified base table
applyTo(EdgeAclProvider, HierarchicalTable<T>) - Static method in class io.deephaven.enterprise.acl.impl.EdgeAclImpl
 
applyTo(EdgeAclProvider, PivotTable) - Static method in class io.deephaven.enterprise.acl.impl.EdgeAclImpl
 
applyTo(PivotTable) - Method in interface io.deephaven.enterprise.acl.EdgeAclProvider
Applies the given provider to a PivotTable.
applyToAllBy(String, String, SelectColumn...) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
ARRAY_PREFIX - Static variable in class io.deephaven.enterprise.compatibility.shadow.ShadowCompatibility
 
asIndex() - Method in class io.deephaven.enterprise.compatibility.rowset.RowSequenceToOrderedKeysAdapter
 
asKeyIndicesChunk() - Method in class io.deephaven.enterprise.compatibility.rowset.RowSequenceToOrderedKeysAdapter
 
asKeyRangesChunk() - Method in class io.deephaven.enterprise.compatibility.rowset.RowSequenceToOrderedKeysAdapter
 
asOfTime(Instant) - Method in class io.deephaven.enterprise.dnd.query.util.perf.PerformanceOverview
Set the start of the time range to filter performance data.
asOfTimeString(String) - Method in class io.deephaven.enterprise.dnd.query.util.perf.PerformanceOverview
Set the start of the time range to filter performance data.
asRowKeyChunk() - Method in class io.deephaven.enterprise.compatibility.rowset.OrderedKeysToRowSequenceAdapter
 
asRowKeyRangesChunk() - Method in class io.deephaven.enterprise.compatibility.rowset.OrderedKeysToRowSequenceAdapter
 
asRowSet() - Method in class io.deephaven.enterprise.compatibility.rowset.OrderedKeysToRowSequenceAdapter
 
authenticate(AuthToken) - Method in interface io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClient
Use the specified auth token to authenticate this client to the hashtable server.
authenticate(AuthToken) - Method in class io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClientImpl
 
authenticateAndObtainAuthenticationInfo(Channel, AuthToken) - Static method in class io.deephaven.enterprise.dnd.authentication.DndAuthUtils
 
AuthWiringBase - Class in io.deephaven.enterprise.dnd.authentication
 
AuthWiringBase() - Constructor for class io.deephaven.enterprise.dnd.authentication.AuthWiringBase
 
autoDelete(Boolean) - Method in interface io.deephaven.enterprise.dnd.EnterpriseJettyComponent.Builder
Set if the worker should delete its corresponding query on shutdown
avgBy(SelectColumn...) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 

B

BasicFixedPartitionedDeephavenTableLocationKey - Class in io.deephaven.enterprise.locations.impl
An FixedPartitionedEnterpriseTableLocationKey that simply wraps an enterprise TableLocationKey
BasicFixedPartitionedDeephavenTableLocationKey(String, Map<String, Comparable<?>>) - Constructor for class io.deephaven.enterprise.locations.impl.BasicFixedPartitionedDeephavenTableLocationKey
 
BasicFixedPartitionedDeephavenTableLocationKey(String, TableLocationKey) - Constructor for class io.deephaven.enterprise.locations.impl.BasicFixedPartitionedDeephavenTableLocationKey
 
BinaryRowLoggerDnd - Class in io.deephaven.enterprise.dnd.logger.engine.impl
Base implementation for DnD components to log binary rows via LAS.
BinaryRowLoggerDnd(String, String, String[], SupportedType[], Object[], Map<String, Object>, int, boolean, String, ZoneId, TableIdentifier.NamespaceSet, String, String) - Constructor for class io.deephaven.enterprise.dnd.logger.engine.impl.BinaryRowLoggerDnd
 
BinaryRowLoggerDnd(String, String, String[], SupportedType[], Object[], Map<String, Object>, int, TableIdentifier.NamespaceSet) - Constructor for class io.deephaven.enterprise.dnd.logger.engine.impl.BinaryRowLoggerDnd
 
binaryRowPool - Variable in class io.deephaven.enterprise.dnd.logger.engine.impl.BinaryRowLoggerDnd
 
BinaryRowUtils - Class in io.deephaven.enterprise.dnd.logger.engine.impl
 
BinaryRowUtils() - Constructor for class io.deephaven.enterprise.dnd.logger.engine.impl.BinaryRowUtils
 
binaryTableWriter - Variable in class io.deephaven.enterprise.dnd.logger.engine.impl.BinaryRowLoggerDnd
 
bindCsvResolver(CsvTableResolver) - Method in interface io.deephaven.enterprise.dnd.modules.URIModule
 
bindDatabaseMethods(DatabaseAutocompleteDelegate) - Method in interface io.deephaven.enterprise.dnd.modules.GroovyConsoleSessionWithDatabaseModule
 
bindObjectServiceGrpcImpl(ObjectServiceGrpcBinding) - Method in interface io.deephaven.enterprise.dnd.modules.ObjectModuleOverride
 
bindParquetResolver(ParquetTableResolver) - Method in interface io.deephaven.enterprise.dnd.modules.URIModule
 
bindQueryScopeResolver(QueryScopeResolver) - Method in interface io.deephaven.enterprise.dnd.modules.URIModule
 
bindResolvers(Set<UriResolver>) - Static method in interface io.deephaven.enterprise.dnd.modules.URIModule
 
bindsBarrageTableResolver(BarrageTableResolver) - Method in interface io.deephaven.enterprise.dnd.modules.URIModule
 
bindService() - Method in class io.deephaven.enterprise.dnd.modules.ObjectServiceGrpcBinding
 
bindService() - Method in class io.deephaven.proto.pqworker.grpc.PQWorkerApiGrpc.PQWorkerApiImplBase
 
bindService(PQWorkerApiGrpc.AsyncService) - Static method in class io.deephaven.proto.pqworker.grpc.PQWorkerApiGrpc
 
BUFFER_BYTE_SIZE - Static variable in enum class io.deephaven.enterprise.sources.regioned.BufferedType
 
BufferedColumnRegion<ATTR extends Any> - Interface in io.deephaven.enterprise.sources.regioned
A ColumnRegion backed by a buffer of some sort.
BufferedColumnRegionBase<ATTR extends Values> - Class in io.deephaven.enterprise.sources.regioned.impl
The basic implementation for a BufferedColumnRegion.
BufferedColumnRegionByte<ATTR extends Values> - Class in io.deephaven.enterprise.sources.regioned.impl
ColumnRegionByte implementation for regions that support fetching primitive bytes from a FileDataBufferStore.
BufferedColumnRegionByte(FileDataBufferStore) - Constructor for class io.deephaven.enterprise.sources.regioned.impl.BufferedColumnRegionByte
 
BufferedColumnRegionChar<ATTR extends Values> - Class in io.deephaven.enterprise.sources.regioned.impl
ColumnRegionChar implementation for regions that support fetching primitive chars from a FileDataBufferStore.
BufferedColumnRegionChar(FileDataBufferStore) - Constructor for class io.deephaven.enterprise.sources.regioned.impl.BufferedColumnRegionChar
 
BufferedColumnRegionDouble<ATTR extends Values> - Class in io.deephaven.enterprise.sources.regioned.impl
ColumnRegionDouble implementation for regions that support fetching primitive doubles from a FileDataBufferStore.
BufferedColumnRegionDouble(FileDataBufferStore) - Constructor for class io.deephaven.enterprise.sources.regioned.impl.BufferedColumnRegionDouble
 
BufferedColumnRegionFloat<ATTR extends Values> - Class in io.deephaven.enterprise.sources.regioned.impl
ColumnRegionFloat implementation for regions that support fetching primitive floats from a FileDataBufferStore.
BufferedColumnRegionFloat(FileDataBufferStore) - Constructor for class io.deephaven.enterprise.sources.regioned.impl.BufferedColumnRegionFloat
 
BufferedColumnRegionInt<ATTR extends Values> - Class in io.deephaven.enterprise.sources.regioned.impl
ColumnRegionInt implementation for regions that support fetching primitive ints from a FileDataBufferStore.
BufferedColumnRegionInt(FileDataBufferStore) - Constructor for class io.deephaven.enterprise.sources.regioned.impl.BufferedColumnRegionInt
 
BufferedColumnRegionIntAsLong<ATTR extends Values> - Class in io.deephaven.enterprise.sources.regioned.impl
ColumnRegionLong implementation for regions that support fetching primitive ints from a FileDataBufferStore.
BufferedColumnRegionIntAsLong(FileDataBufferStore) - Constructor for class io.deephaven.enterprise.sources.regioned.impl.BufferedColumnRegionIntAsLong
 
BufferedColumnRegionLong<ATTR extends Values> - Class in io.deephaven.enterprise.sources.regioned.impl
ColumnRegionLongWithLength implementation for regions that support fetching primitive longs from a FileDataBufferStore.
BufferedColumnRegionLong(FileDataBufferStore) - Constructor for class io.deephaven.enterprise.sources.regioned.impl.BufferedColumnRegionLong
 
BufferedColumnRegionShort<ATTR extends Values> - Class in io.deephaven.enterprise.sources.regioned.impl
ColumnRegionShort implementation for regions that support fetching primitive shorts from a FileDataBufferStore.
BufferedColumnRegionShort(FileDataBufferStore) - Constructor for class io.deephaven.enterprise.sources.regioned.impl.BufferedColumnRegionShort
 
BufferedPage<ATTR extends Any> - Interface in io.deephaven.enterprise.sources.regioned
 
BufferedPageByte<ATTR extends Any> - Class in io.deephaven.enterprise.sources.regioned.impl
 
BufferedPageByte() - Constructor for class io.deephaven.enterprise.sources.regioned.impl.BufferedPageByte
 
BufferedPageChar<ATTR extends Any> - Class in io.deephaven.enterprise.sources.regioned.impl
 
BufferedPageChar() - Constructor for class io.deephaven.enterprise.sources.regioned.impl.BufferedPageChar
 
BufferedPageDouble<ATTR extends Any> - Class in io.deephaven.enterprise.sources.regioned.impl
 
BufferedPageDouble() - Constructor for class io.deephaven.enterprise.sources.regioned.impl.BufferedPageDouble
 
BufferedPageFloat<ATTR extends Any> - Class in io.deephaven.enterprise.sources.regioned.impl
 
BufferedPageFloat() - Constructor for class io.deephaven.enterprise.sources.regioned.impl.BufferedPageFloat
 
BufferedPageInt<ATTR extends Any> - Class in io.deephaven.enterprise.sources.regioned.impl
 
BufferedPageInt() - Constructor for class io.deephaven.enterprise.sources.regioned.impl.BufferedPageInt
 
BufferedPageIntAsLong<ATTR extends Any> - Class in io.deephaven.enterprise.sources.regioned.impl
 
BufferedPageIntAsLong() - Constructor for class io.deephaven.enterprise.sources.regioned.impl.BufferedPageIntAsLong
 
BufferedPageLong<ATTR extends Any> - Class in io.deephaven.enterprise.sources.regioned.impl
 
BufferedPageLong() - Constructor for class io.deephaven.enterprise.sources.regioned.impl.BufferedPageLong
 
BufferedPageShort<ATTR extends Any> - Class in io.deephaven.enterprise.sources.regioned.impl
 
BufferedPageShort() - Constructor for class io.deephaven.enterprise.sources.regioned.impl.BufferedPageShort
 
bufferedType() - Method in interface io.deephaven.enterprise.sources.regioned.BufferedPage
The BufferedType associated with a buffer page has all the helper functions for calculating offsets, lengths, etc.
bufferedType() - Method in class io.deephaven.enterprise.sources.regioned.impl.BufferedPageByte
 
bufferedType() - Method in class io.deephaven.enterprise.sources.regioned.impl.BufferedPageChar
 
bufferedType() - Method in class io.deephaven.enterprise.sources.regioned.impl.BufferedPageDouble
 
bufferedType() - Method in class io.deephaven.enterprise.sources.regioned.impl.BufferedPageFloat
 
bufferedType() - Method in class io.deephaven.enterprise.sources.regioned.impl.BufferedPageInt
 
bufferedType() - Method in class io.deephaven.enterprise.sources.regioned.impl.BufferedPageIntAsLong
 
bufferedType() - Method in class io.deephaven.enterprise.sources.regioned.impl.BufferedPageLong
 
bufferedType() - Method in class io.deephaven.enterprise.sources.regioned.impl.BufferedPageShort
 
BufferedType - Enum Class in io.deephaven.enterprise.sources.regioned
 
build() - Method in interface io.deephaven.enterprise.acl.EdgeAclProvider.Builder
Construct the ACL object.
build() - Method in interface io.deephaven.enterprise.database.SystemTableLogger.Options.Builder
Build an immutable Options object.
build() - Method in interface io.deephaven.enterprise.database.TableOptions.Builder
Create a TableOptions from this builder state.
build() - Method in interface io.deephaven.enterprise.dnd.EnterpriseJettyComponent.Builder
 
build() - Method in interface io.deephaven.enterprise.iceberg.discovery.DiscoveryConfig.Builder
Construct a new DiscoveryConfig from the state in this DiscoveryConfig.Builder.
build() - Method in interface io.deephaven.enterprise.iceberg.IcebergEndpoint.Builder
Construct an anonymous IcebergEndpoint from the builder state.
build() - Method in interface io.deephaven.enterprise.remote.ConnectionAwareRemoteTableParams.Builder
Construct a new ConnectionAwareRemoteTableParams from this builder state.
build() - Method in interface io.deephaven.enterprise.remote.SubscriptionOptions.Builder
Construct a new SubscriptionOptions from this builder state.
build() - Method in class io.deephaven.proto.pivot.ErrorResponse.Builder
 
build() - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
 
build() - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
 
build() - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
 
build() - Method in class io.deephaven.proto.pivot.PivotTableApplyResponse.Builder
 
build() - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
 
build() - Method in class io.deephaven.proto.pivot.PivotTableCreationResponse.Builder
 
build() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage.Builder
 
build() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorRequest.Builder
 
build() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse.Builder
 
build() - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest.Builder
 
build() - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse.Builder
 
build() - Method in class io.deephaven.proto.pivot.PivotTableSourceExportRequest.Builder
 
build() - Method in class io.deephaven.proto.pivot.PivotTableSourceExportResponse.Builder
 
build() - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage.Builder
 
build() - Method in class io.deephaven.proto.pivot.PivotTableViewRequest.Builder
 
build() - Method in class io.deephaven.proto.pivot.PivotTableViewResponse.Builder
 
build() - Method in class io.deephaven.proto.pqworker.ListenErrorRequest.Builder
 
build() - Method in class io.deephaven.proto.pqworker.ListenErrorResponse.Builder
 
build() - Method in class io.deephaven.proto.pqworker.ObjectAccessRequest.Builder
 
build() - Method in class io.deephaven.proto.pqworker.ObjectAccessResponse.Builder
 
build() - Method in class io.deephaven.proto.pqworker.StringList.Builder
 
build() - Method in class io.deephaven.proto.pqworker.ThreadDumpRequest.Builder
 
build() - Method in class io.deephaven.proto.pqworker.ThreadDumpResponse.Builder
 
build(String) - Method in interface io.deephaven.enterprise.iceberg.IcebergEndpoint.Builder
Construct a named IcebergEndpoint from the builder state.
build(Channel, CallOptions) - Method in class io.deephaven.proto.pqworker.grpc.PQWorkerApiGrpc.PQWorkerApiBlockingStub
 
build(Channel, CallOptions) - Method in class io.deephaven.proto.pqworker.grpc.PQWorkerApiGrpc.PQWorkerApiFutureStub
 
build(Channel, CallOptions) - Method in class io.deephaven.proto.pqworker.grpc.PQWorkerApiGrpc.PQWorkerApiStub
 
builder() - Static method in interface io.deephaven.enterprise.acl.EdgeAclProvider
Get a EdgeAclProvider.Builder to create ACLs for a table.
builder() - Static method in class io.deephaven.enterprise.acl.impl.EdgeAclImpl
Get a builder for constructing an EdgeAclImpl
builder() - Static method in interface io.deephaven.enterprise.iceberg.discovery.DiscoveryConfig
 
builder() - Static method in interface io.deephaven.enterprise.remote.ConnectionAwareRemoteTableParams
builder() - Static method in interface io.deephaven.enterprise.remote.SubscriptionOptions
buildPartial() - Method in class io.deephaven.proto.pivot.ErrorResponse.Builder
 
buildPartial() - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
 
buildPartial() - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
 
buildPartial() - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
 
buildPartial() - Method in class io.deephaven.proto.pivot.PivotTableApplyResponse.Builder
 
buildPartial() - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
 
buildPartial() - Method in class io.deephaven.proto.pivot.PivotTableCreationResponse.Builder
 
buildPartial() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage.Builder
 
buildPartial() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorRequest.Builder
 
buildPartial() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse.Builder
 
buildPartial() - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest.Builder
 
buildPartial() - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse.Builder
 
buildPartial() - Method in class io.deephaven.proto.pivot.PivotTableSourceExportRequest.Builder
 
buildPartial() - Method in class io.deephaven.proto.pivot.PivotTableSourceExportResponse.Builder
 
buildPartial() - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage.Builder
 
buildPartial() - Method in class io.deephaven.proto.pivot.PivotTableViewRequest.Builder
 
buildPartial() - Method in class io.deephaven.proto.pivot.PivotTableViewResponse.Builder
 
buildPartial() - Method in class io.deephaven.proto.pqworker.ListenErrorRequest.Builder
 
buildPartial() - Method in class io.deephaven.proto.pqworker.ListenErrorResponse.Builder
 
buildPartial() - Method in class io.deephaven.proto.pqworker.ObjectAccessRequest.Builder
 
buildPartial() - Method in class io.deephaven.proto.pqworker.ObjectAccessResponse.Builder
 
buildPartial() - Method in class io.deephaven.proto.pqworker.StringList.Builder
 
buildPartial() - Method in class io.deephaven.proto.pqworker.ThreadDumpRequest.Builder
 
buildPartial() - Method in class io.deephaven.proto.pqworker.ThreadDumpResponse.Builder
 
by(AggregationStateFactory, SelectColumn...) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
byExternal(boolean, String...) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
Byte - Enum constant in enum class io.deephaven.enterprise.sources.regioned.BufferedType
 
ByteColumnRegionAdapter<ATTR extends Values> - Class in io.deephaven.enterprise.compatibility.region
Adapts a Legacy ColumnRegionByte to a Core ColumnRegionByte.
ByteColumnRegionAdapter(ColumnRegionByte<?>) - Constructor for class io.deephaven.enterprise.compatibility.region.ByteColumnRegionAdapter
 

C

call(Table, String, String) - Method in interface io.deephaven.enterprise.derivedtablewriter.DerivedTableCreationFunction
 
canExecute(long) - Method in class io.deephaven.enterprise.compatibility.NotificationAdapter
 
canMemoize() - Method in class io.deephaven.enterprise.compatibility.filter.EnterpriseFilterAdapter
 
canTransform(T, boolean) - Method in class io.deephaven.enterprise.acl.transform.GenericObjectTransformer
 
canTransform(T, boolean) - Method in class io.deephaven.enterprise.acl.transform.HierarchicalTableTicketTransformer
 
canTransform(T, boolean) - Method in class io.deephaven.enterprise.acl.transform.PivotTableTicketTransformer
 
canTransform(T, boolean) - Method in class io.deephaven.enterprise.acl.transform.TableTicketTransformer
 
canTransform(T, boolean) - Method in interface io.deephaven.enterprise.dnd.authentication.transform.TicketTransformer
Check if this transformer can apply a transformation to the specified value.
CapturingUpdateGraph - Class in io.deephaven.enterprise.test
 
CapturingUpdateGraph(ControlledUpdateGraph) - Constructor for class io.deephaven.enterprise.test.CapturingUpdateGraph
 
catalogName(String) - Method in interface io.deephaven.enterprise.iceberg.IcebergEndpoint.Builder
Optional.
catalogTable() - Static method in class io.deephaven.enterprise.dnd.client.DndSession
Create a TableSpec based on the catalog table from the server.
catalogType(String) - Method in interface io.deephaven.enterprise.iceberg.IcebergEndpoint.Builder
Set the Iceberg catalog type.
catalogUri(String) - Method in interface io.deephaven.enterprise.iceberg.IcebergEndpoint.Builder
Set the URI for accessing the catalog.
channel - Variable in class io.deephaven.enterprise.dnd.client.DndSession
 
channel() - Method in class io.deephaven.enterprise.dnd.client.DndSession
Get the underlying ManagedChannel
Char - Enum constant in enum class io.deephaven.enterprise.sources.regioned.BufferedType
 
CharColumnRegionAdapter<ATTR extends Values> - Class in io.deephaven.enterprise.compatibility.region
Adapts a Legacy ColumnRegionChar to a Core ColumnRegionChar.
CharColumnRegionAdapter(ColumnRegionChar<?>) - Constructor for class io.deephaven.enterprise.compatibility.region.CharColumnRegionAdapter
 
check() - Method in interface io.deephaven.enterprise.remote.SubscriptionOptions
Ensure the state is valid.
checkColumnsForImportStates(Set<String>, List<ImportStateDetails>) - Static method in class io.deephaven.enterprise.ingester.impl.ImportStateDetails
Verify that all columns required by the list of importStateDetails are present in targetColumnNames
checkWidth(int) - Method in class io.deephaven.enterprise.compatibility.shadow.ShadowingSerializableDecoder
 
ChunkAdapter - Interface in io.deephaven.enterprise.compatibility.chunk
Implementors provide a method to adapt an Enterprise WritableChunk into a Community WritableChunk.
chunkSize(int) - Method in class io.deephaven.enterprise.derivedtablewriter.DerivedTableWriter.Options
How many rows should be read at one time? (defaults to 4096)
cleanup() - Method in class io.deephaven.enterprise.dnd.modules.GroovyConsoleSessionWithDatabaseModule.ScriptSessionWrapper
 
clear() - Method in class io.deephaven.proto.pivot.ErrorResponse.Builder
 
clear() - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
 
clear() - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
 
clear() - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
 
clear() - Method in class io.deephaven.proto.pivot.PivotTableApplyResponse.Builder
 
clear() - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
 
clear() - Method in class io.deephaven.proto.pivot.PivotTableCreationResponse.Builder
 
clear() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage.Builder
 
clear() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorRequest.Builder
 
clear() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse.Builder
 
clear() - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest.Builder
 
clear() - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse.Builder
 
clear() - Method in class io.deephaven.proto.pivot.PivotTableSourceExportRequest.Builder
 
clear() - Method in class io.deephaven.proto.pivot.PivotTableSourceExportResponse.Builder
 
clear() - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage.Builder
 
clear() - Method in class io.deephaven.proto.pivot.PivotTableViewRequest.Builder
 
clear() - Method in class io.deephaven.proto.pivot.PivotTableViewResponse.Builder
 
clear() - Method in class io.deephaven.proto.pqworker.ListenErrorRequest.Builder
 
clear() - Method in class io.deephaven.proto.pqworker.ListenErrorResponse.Builder
 
clear() - Method in class io.deephaven.proto.pqworker.ObjectAccessRequest.Builder
 
clear() - Method in class io.deephaven.proto.pqworker.ObjectAccessResponse.Builder
 
clear() - Method in class io.deephaven.proto.pqworker.StringList.Builder
 
clear() - Method in class io.deephaven.proto.pqworker.ThreadDumpRequest.Builder
 
clear() - Method in class io.deephaven.proto.pqworker.ThreadDumpResponse.Builder
 
clearAggregations() - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
aggregations for the values
clearApply() - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
.io.deephaven.proto.pivot.PivotTableApplyRequest apply = 6;
clearApply() - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
.io.deephaven.proto.pivot.PivotTableApplyResponse apply = 7;
clearColumnKeys() - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
first reference is the input table
clearColumnKeyTableActionColumn() - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage.Builder
The name of a column of bytes found in the key table that specifies the action desired for the node selected by the other columns for each row.
clearColumnKeyTableOffset() - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage.Builder
Offset (in the references) of a Table of expanded or contracted keys from a PivotTable (RollupTable or TreeTable).
clearColumnSorts() - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor column_sorts = 2;
clearCreation() - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
.io.deephaven.proto.pivot.PivotTableCreationRequest creation = 5;
clearCreation() - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
.io.deephaven.proto.pivot.PivotTableCreationResponse creation = 6;
clearEmptyExpansions() - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
.io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest empty_expansions = 4;
clearEmptyExpansions() - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
.io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse empty_expansions = 5;
clearError() - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
If the request failed (after we were able to parse and extract the request ID), then we return an error to the client; otherwise we return the appropriate response type.
clearErrorMessage() - Method in class io.deephaven.proto.pivot.ErrorResponse.Builder
string error_message = 1;
clearExistingViewOffset() - Method in class io.deephaven.proto.pivot.PivotTableViewRequest.Builder
Offset of the existing PivotTableView in the incoming plugin references array.
clearExpansions() - Method in class io.deephaven.proto.pivot.PivotTableViewRequest.Builder
Description for the expansions that define this view of the PivotTable.
clearExport() - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
.io.deephaven.proto.pivot.PivotTableSourceExportResponse export = 4;
clearExportSource() - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
.io.deephaven.proto.pivot.PivotTableSourceExportRequest export_source = 3;
clearField(Descriptors.FieldDescriptor) - Method in class io.deephaven.proto.pivot.ErrorResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class io.deephaven.proto.pivot.PivotTableApplyResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class io.deephaven.proto.pivot.PivotTableCreationResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class io.deephaven.proto.pivot.PivotTableDescriptorRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class io.deephaven.proto.pivot.PivotTableSourceExportRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class io.deephaven.proto.pivot.PivotTableSourceExportResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class io.deephaven.proto.pivot.PivotTableViewRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class io.deephaven.proto.pivot.PivotTableViewResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class io.deephaven.proto.pqworker.ListenErrorRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class io.deephaven.proto.pqworker.ListenErrorResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class io.deephaven.proto.pqworker.ObjectAccessRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class io.deephaven.proto.pqworker.ObjectAccessResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class io.deephaven.proto.pqworker.StringList.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class io.deephaven.proto.pqworker.ThreadDumpRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class io.deephaven.proto.pqworker.ThreadDumpResponse.Builder
 
clearFilters() - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
The filters must be against the grouping columns (either row or columns)
clearGetDescriptor() - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
.io.deephaven.proto.pivot.PivotTableDescriptorRequest get_descriptor = 7;
clearGetDescriptor() - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
.io.deephaven.proto.pivot.PivotTableDescriptorResponse get_descriptor = 8;
clearIsStatic() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage.Builder
Whether or not this table might change.
clearLocationCache() - Method in interface io.deephaven.enterprise.database.Database
Clear the location cache for all tables.
clearLocationCache() - Method in class io.deephaven.enterprise.database.impl.DatabaseImpl
 
clearLocationCache() - Method in class io.deephaven.enterprise.replay.ReplayDatabase
 
clearLocationCache(String, String) - Method in interface io.deephaven.enterprise.database.Database
Clear the location cache for the specified table.
clearLocationCache(String, String) - Method in class io.deephaven.enterprise.database.impl.DatabaseImpl
 
clearLocationCache(String, String) - Method in class io.deephaven.enterprise.replay.ReplayDatabase
 
clearMessage() - Method in class io.deephaven.proto.pqworker.ListenErrorResponse.Builder
string message = 1;
clearObjectGroups() - Method in class io.deephaven.proto.pqworker.ObjectAccessResponse.Builder
 
clearObjectNames() - Method in class io.deephaven.proto.pqworker.ObjectAccessRequest.Builder
repeated string objectNames = 1;
clearObserver(RemoteTableStateWatcher.Observer) - Method in class io.deephaven.enterprise.remote.ControllerStateWatcher
 
clearObserver(RemoteTableStateWatcher.Observer) - Method in interface io.deephaven.enterprise.remote.RemoteTableStateWatcher
clearOnDisconnect() - Method in interface io.deephaven.enterprise.remote.SubscriptionOptions
If the result table should clear its rows when a disconnect occurs.
clearOnDisconnect(boolean) - Method in interface io.deephaven.enterprise.remote.SubscriptionOptions.Builder
Set if the result table should clear its rows when a disconnect occurs.
clearOneof(Descriptors.OneofDescriptor) - Method in class io.deephaven.proto.pivot.ErrorResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class io.deephaven.proto.pivot.PivotTableApplyResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class io.deephaven.proto.pivot.PivotTableCreationResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class io.deephaven.proto.pivot.PivotTableDescriptorRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class io.deephaven.proto.pivot.PivotTableSourceExportRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class io.deephaven.proto.pivot.PivotTableSourceExportResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class io.deephaven.proto.pivot.PivotTableViewRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class io.deephaven.proto.pivot.PivotTableViewResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class io.deephaven.proto.pqworker.ListenErrorRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class io.deephaven.proto.pqworker.ListenErrorResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class io.deephaven.proto.pqworker.ObjectAccessRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class io.deephaven.proto.pqworker.ObjectAccessResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class io.deephaven.proto.pqworker.StringList.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class io.deephaven.proto.pqworker.ThreadDumpRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class io.deephaven.proto.pqworker.ThreadDumpResponse.Builder
 
clearOutputColumns() - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage.Builder
The name of the output columns that are sent, if not specified then all totals and value columns are sent.
clearPivotDescriptor() - Method in class io.deephaven.proto.pivot.PivotTableApplyResponse.Builder
first reference is the new pivot table
clearPivotDescriptor() - Method in class io.deephaven.proto.pivot.PivotTableCreationResponse.Builder
first reference is the created pivot table
clearPivotDescriptor() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse.Builder
The description of the table
clearPivotDescriptor() - Method in class io.deephaven.proto.pivot.PivotTableViewResponse.Builder
The description of the table
clearPivotTableOffset() - Method in class io.deephaven.proto.pivot.PivotTableViewRequest.Builder
Offset of the pivot table in the incoming plugin references.
clearReason() - Method in class io.deephaven.proto.pqworker.ThreadDumpRequest.Builder
optional string reason = 1;
clearRequest() - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
 
clearRequestId() - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
A client-specified identifier used to identify the response for this request when multiple requests are in flight.
clearRequestId() - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
Identifier copied from the request.
clearResponse() - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
 
clearRowKeys() - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
repeated string row_keys = 2;
clearRowKeyTableActionColumn() - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage.Builder
The name of a column of bytes found in the key table that specifies the action desired for the node selected by the other columns for each row.
clearRowKeyTableOffset() - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage.Builder
Offset (in the references) of a Table of expanded or contracted keys from a PivotTable (RollupTable or TreeTable).
clearRowSorts() - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor row_sorts = 1;
clearShortCauses() - Method in class io.deephaven.proto.pqworker.ListenErrorResponse.Builder
string shortCauses = 3;
clearSnapshotSchema() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage.Builder
Schema to be used for snapshot or subscription requests as described in Arrow Message.fbs::Message.
clearSortingRestrictions() - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
clearStackTrace() - Method in class io.deephaven.proto.pqworker.ListenErrorResponse.Builder
string stackTrace = 2;
clearSubscriberName() - Method in class io.deephaven.proto.pqworker.ListenErrorRequest.Builder
string subscriberName = 1;
clearTarget() - Method in class io.deephaven.proto.pivot.PivotTableViewRequest.Builder
 
clearTimestampMillis() - Method in class io.deephaven.proto.pqworker.ListenErrorResponse.Builder
int64 timestampMillis = 6;
clearValues() - Method in class io.deephaven.proto.pqworker.StringList.Builder
repeated string values = 1;
clearView() - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
.io.deephaven.proto.pivot.PivotTableViewRequest view = 2;
clearView() - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
.io.deephaven.proto.pivot.PivotTableViewResponse view = 3;
clearWasUncaught() - Method in class io.deephaven.proto.pqworker.ListenErrorResponse.Builder
bool wasUncaught = 4;
clock() - Method in class io.deephaven.enterprise.test.CapturingUpdateGraph
 
clone() - Method in class io.deephaven.proto.pivot.ErrorResponse.Builder
 
clone() - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
 
clone() - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
 
clone() - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
 
clone() - Method in class io.deephaven.proto.pivot.PivotTableApplyResponse.Builder
 
clone() - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
 
clone() - Method in class io.deephaven.proto.pivot.PivotTableCreationResponse.Builder
 
clone() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage.Builder
 
clone() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorRequest.Builder
 
clone() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse.Builder
 
clone() - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest.Builder
 
clone() - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse.Builder
 
clone() - Method in class io.deephaven.proto.pivot.PivotTableSourceExportRequest.Builder
 
clone() - Method in class io.deephaven.proto.pivot.PivotTableSourceExportResponse.Builder
 
clone() - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage.Builder
 
clone() - Method in class io.deephaven.proto.pivot.PivotTableViewRequest.Builder
 
clone() - Method in class io.deephaven.proto.pivot.PivotTableViewResponse.Builder
 
clone() - Method in class io.deephaven.proto.pqworker.ListenErrorRequest.Builder
 
clone() - Method in class io.deephaven.proto.pqworker.ListenErrorResponse.Builder
 
clone() - Method in class io.deephaven.proto.pqworker.ObjectAccessRequest.Builder
 
clone() - Method in class io.deephaven.proto.pqworker.ObjectAccessResponse.Builder
 
clone() - Method in class io.deephaven.proto.pqworker.StringList.Builder
 
clone() - Method in class io.deephaven.proto.pqworker.ThreadDumpRequest.Builder
 
clone() - Method in class io.deephaven.proto.pqworker.ThreadDumpResponse.Builder
 
close() - Method in class io.deephaven.enterprise.compatibility.chunk.FillContextWrapper
 
close() - Method in class io.deephaven.enterprise.compatibility.rowset.OrderedKeysToRowSequenceAdapter
 
close() - Method in class io.deephaven.enterprise.compatibility.rowset.OrderedKeysToRowSequenceIteratorAdapter
 
close() - Method in class io.deephaven.enterprise.compatibility.rowset.RowSequenceToOrderedKeysAdapter
 
close() - Method in class io.deephaven.enterprise.compatibility.rowset.RowSequenceToOrderedKeysIteratorAdapter
 
close() - Method in class io.deephaven.enterprise.dnd.client.DeephavenClusterConnection
Close all connections to the remote host.
close() - Method in class io.deephaven.enterprise.dnd.client.DndSession
Close and release the underlying session and channel for this session.
close() - Method in class io.deephaven.enterprise.dnd.client.DndSessionFactoryBarrage
Close all resources and connections with the server.
close() - Method in class io.deephaven.enterprise.dnd.logger.engine.impl.BinaryRowLoggerDnd
Close the table writer.
close() - Method in class io.deephaven.enterprise.dnd.modules.DndSessionListenerModule.SessionMonitor
 
close() - Method in class io.deephaven.enterprise.remote.ConnectionAwareRemoteTable
 
close() - Method in class io.deephaven.enterprise.remote.CorePlusClusterSessionFactory
 
close() - Method in class io.deephaven.enterprise.remote.CorePlusClusterSessionFactory.SessionAndChannel
 
close() - Method in interface io.deephaven.enterprise.remote.RemoteTableSessionFactory
Close any state associated with this factory.
close() - Method in class io.deephaven.enterprise.sources.regioned.impl.ColumnRegionFillContext
 
close() - Method in class io.deephaven.enterprise.sources.regioned.impl.ObjectRegionFillContext
 
CodecCompatibility - Class in io.deephaven.enterprise.compatibility
 
CodecCompatibility() - Constructor for class io.deephaven.enterprise.compatibility.CodecCompatibility
 
COLUMN_KEY_TABLE_ACTION_COLUMN_FIELD_NUMBER - Static variable in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage
 
COLUMN_KEY_TABLE_OFFSET_FIELD_NUMBER - Static variable in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage
 
COLUMN_KEYS_FIELD_NUMBER - Static variable in class io.deephaven.proto.pivot.PivotTableCreationRequest
 
COLUMN_SORTS_FIELD_NUMBER - Static variable in class io.deephaven.proto.pivot.PivotTableApplyRequest
 
COLUMN_VERSION_COLUMN_NAME - Static variable in class io.deephaven.enterprise.locations.hive.HiveLocationsTableKeyFinder
The column name containing the integer version of column files for Deephaven format.
columnAcl(String, String, AclFilterGenerator) - Method in interface io.deephaven.enterprise.acl.EdgeAclProvider.Builder
Add a Column ACL for the specified group and column to the table.
columnAcl(String, Collection<String>, AclFilterGenerator) - Method in interface io.deephaven.enterprise.acl.EdgeAclProvider.Builder
Add a Column ACL for the specified group and column to the table.
ColumnAcl - Class in io.deephaven.enterprise.acl.impl
A collection of WhereFilters by group and column.
columnCodecs() - Method in class io.deephaven.enterprise.database.SystemTableLogger.Options
A map of codec assignments for columns.
columnPartitionKey() - Method in class io.deephaven.enterprise.derivedtablewriter.DerivedTableWriter.PartitionedOptions
Retrieves the column partition key column name.
columnPartitionKey(String) - Method in class io.deephaven.enterprise.derivedtablewriter.DerivedTableWriter.PartitionedOptions
Sets the column partition key column name.
columnPartitionValue(String) - Method in class io.deephaven.enterprise.derivedtablewriter.DerivedTableWriter.PartitionedOptions
Sets the fixed column partition value.
ColumnRegionByteWithLength<ATTR extends Any> - Interface in io.deephaven.enterprise.sources.regioned
A ColumnRegionByte that supports querying its length.
ColumnRegionFillContext - Class in io.deephaven.enterprise.sources.regioned.impl
 
ColumnRegionFillContext() - Constructor for class io.deephaven.enterprise.sources.regioned.impl.ColumnRegionFillContext
 
ColumnRegionLongWithLength<ATTR extends Any> - Interface in io.deephaven.enterprise.sources.regioned
A ColumnRegionLong that supports querying its length.
ColumnRegionObjectCached<T,ATTR extends Values,OFFSET_LOOKUP_CACHE extends OffsetLookupCache<T,ChunkSource.FillContext>> - Class in io.deephaven.enterprise.sources.regioned.impl
Column region interface for regions that support fetching objects.
ColumnRegionObjectCached(ColumnRegionObjectCached.CacheFactory<T, OFFSET_LOOKUP_CACHE>, FillContextMaker, ColumnRegionObject<T, ATTR>) - Constructor for class io.deephaven.enterprise.sources.regioned.impl.ColumnRegionObjectCached
 
ColumnRegionObjectCached.CacheFactory<T,OFFSET_LOOKUP_CACHE extends OffsetLookupCache<T,ChunkSource.FillContext>> - Interface in io.deephaven.enterprise.sources.regioned.impl
 
ColumnRegionObjectCodecFixed<T,ATTR extends Values> - Class in io.deephaven.enterprise.sources.regioned.impl
A ColumnRegion for non-primitive types that have a fixed size.
ColumnRegionObjectCodecFixed(ObjectDecoder<T>, ColumnRegionByteWithLength<EncodedObjects>) - Constructor for class io.deephaven.enterprise.sources.regioned.impl.ColumnRegionObjectCodecFixed
 
ColumnRegionObjectCodecVariable<T,ATTR extends Values> - Class in io.deephaven.enterprise.sources.regioned.impl
A ColumnRegion for non-primitive types that have a variable size.
ColumnRegionObjectCodecVariable(ObjectDecoder<T>, ColumnRegionLongWithLength<Indices>, ColumnRegionByte<EncodedObjects>) - Constructor for class io.deephaven.enterprise.sources.regioned.impl.ColumnRegionObjectCodecVariable
 
ColumnRegionObjectWithDictionary<T,ATTR extends Values> - Class in io.deephaven.enterprise.sources.regioned.impl
A Column region for objects that is backed by a dictionary of values.
ColumnRegionObjectWithDictionary(ColumnRegionObject<T, ATTR>, ColumnRegionLong<DictionaryKeys>, int) - Constructor for class io.deephaven.enterprise.sources.regioned.impl.ColumnRegionObjectWithDictionary
 
ColumnRegionStringSet<ATTR extends Values> - Class in io.deephaven.enterprise.sources.regioned.impl
A ColumnRegionObject implementation for Deephaven format StringSet columns where stringsets are stored as a bitmask and dictionary column
ColumnRegionStringSet(ColumnRegionLong<StringSetBitmasks>, ColumnRegionObjectCached<String, ATTR, ReversibleCache>) - Constructor for class io.deephaven.enterprise.sources.regioned.impl.ColumnRegionStringSet
 
columnsDefinition() - Method in interface io.deephaven.pivot.PivotTable.PivotSnapshot
Get the definition for the column chunks in this snapshot.
ColumnSourceAdapterForFilter<T> - Class in io.deephaven.enterprise.compatibility.filter
An adapter from Community ColumnSource to Enterprise ColumnSource geared towards supporting Table.where().
ColumnSourceAdapterForFilter(ColumnSource<T>) - Constructor for class io.deephaven.enterprise.compatibility.filter.ColumnSourceAdapterForFilter
 
columnsSize() - Method in class io.deephaven.enterprise.pivot.flatbuf.PivotUpdateMetadata
The current number of columns in the table, with the applied expansions.
columnsSnapshot() - Method in interface io.deephaven.pivot.PivotTable.PivotSnapshot
 
CombiningFilterGenerator - Class in io.deephaven.enterprise.acl.generator
A Filter generator that provides a means to apply separate AclFilterGenerator sets based on a users groups.
CombiningFilterGenerator(CombiningFilterGenerator.Type) - Constructor for class io.deephaven.enterprise.acl.generator.CombiningFilterGenerator
 
CombiningFilterGenerator(PermissionFilterProvider, Database, CombiningFilterGenerator.Type, Map<String, List<FilterGenerator>>) - Constructor for class io.deephaven.enterprise.acl.generator.CombiningFilterGenerator
This is a compatibility constructor for converting an Enterprise version to Community.
commitToBroker(boolean) - Method in class io.deephaven.enterprise.kafkawriter.KafkaTableWriter.Options
Optionally, you can specify whether the ingester commits offsets to the Kafka broker.
CommunityLongChunkAdapter - Class in io.deephaven.chunk
 
CommunityLongChunkAdapter() - Constructor for class io.deephaven.chunk.CommunityLongChunkAdapter
 
compare(ImportStateDetails, ImportStateDetails) - Method in class io.deephaven.enterprise.ingester.impl.ImportStateComparator
 
compareTo(TableLocationKey) - Method in class io.deephaven.enterprise.locations.impl.BasicFixedPartitionedDeephavenTableLocationKey
 
compareTo(TableLocationKey) - Method in class io.deephaven.enterprise.locations.nestedpartitioned.NestedPartitionedDeephavenTableLocationKey
 
compareTo(TableLocationKey) - Method in class io.deephaven.enterprise.locations.nestedpartitioned.NestedPartitionedParquetTableLocationKey
 
compareTo(TableLocationKey) - Method in class io.deephaven.enterprise.locations.nestedpartitioned.NestedPartitionedUnresolvedTableLocationKey
 
compatibleClientConnection(Object, ObjectType.MessageStream) - Method in class io.deephaven.pivot.PivotServicePlugin
 
completed() - Method in class io.deephaven.pivot.PivotTableViewSubscription
 
CompleteTableName - Class in io.deephaven.enterprise.dnd.autocomplete
A class specifically for completing table names; to be called after the completer has discovered the name of the table.
CompleteTableName(ChunkerCompleter, ChunkerInvoke, Stream<String>) - Constructor for class io.deephaven.enterprise.dnd.autocomplete.CompleteTableName
 
CompleteTableNamespace - Class in io.deephaven.enterprise.dnd.autocomplete
A class specifically for completing table namespaces; to be called after the completer has discovered the name of the namespace.
CompleteTableNamespace(ChunkerCompleter, ChunkerInvoke, Stream<String>) - Constructor for class io.deephaven.enterprise.dnd.autocomplete.CompleteTableNamespace
 
ComposableTableReplayConfiguration - Class in io.deephaven.enterprise.replay
A concrete implementation of the replay configuration for one table.
ComposableTableReplayConfiguration(Boolean, String, Boolean) - Constructor for class io.deephaven.enterprise.replay.ComposableTableReplayConfiguration
Create a table replay configuration.
computeImportStateKeyColumnIndices(List<ImportStateDetails>, List<String>) - Static method in class io.deephaven.enterprise.ingester.impl.ImportStateDetails
Compute the indices of column names referenced by the import state details, or null if there are no import state details.
computeResult(Logger, Database, List<InputTableNameTarget>) - Method in class io.deephaven.enterprise.database.inputtables.InputTableSnapshotter
 
computeResult(Logger, Database, List<InputTableNameTarget>) - Method in interface io.deephaven.enterprise.database.inputtables.InputTableTool
Main input table tool logic, e.g.
configurationFor(String, String) - Method in interface io.deephaven.enterprise.replay.ReplayConfiguration
 
configurationFor(String, String) - Method in class io.deephaven.enterprise.replay.ReplayConfigurationImpl
 
configureReplay(Configuration, ReplaySettings) - Static method in class io.deephaven.enterprise.dnd.ConfigureReplay
Set up a ReplayDatabase for this worker.
ConfigureReplay - Class in io.deephaven.enterprise.dnd
Configure replay persistent queries.
ConfigureReplay() - Constructor for class io.deephaven.enterprise.dnd.ConfigureReplay
 
conjunctive(AclFilterGenerator...) - Static method in interface io.deephaven.enterprise.acl.AclFilterGenerator
Create an AclFilterGenerator that conjunctively combines the input generators.
conjunctive(Collection<AclFilterGenerator>) - Static method in interface io.deephaven.enterprise.acl.AclFilterGenerator
Create an AclFilterGenerator that conjunctively combines the input generators.
ConjunctiveFilterGenerator - Class in io.deephaven.enterprise.acl.generator
AclFilterGenerator for combining the results of multiple AclFilterGenerators conjunctively, i.e.
ConjunctiveFilterGenerator(AclFilterGenerator...) - Constructor for class io.deephaven.enterprise.acl.generator.ConjunctiveFilterGenerator
Construct a FilterGenerator that will generate a single WhereFilter that expresses the conjunction of the WhereFilters generated by filterGenerators.
ConjunctiveFilterGenerator(PermissionFilterProvider, Database, FilterGenerator...) - Constructor for class io.deephaven.enterprise.acl.generator.ConjunctiveFilterGenerator
Construct a FilterGenerator that will generate a single WhereFilter that expresses the conjunction of the WhereFilters generated by filterGenerators.
connect(InetSocketAddress) - Method in class io.deephaven.enterprise.tabledataservice.RemoteTableDataService
Connect to a remote server.
connect(Function.Nullary<SocketAddress>) - Method in class io.deephaven.enterprise.tabledataservice.RemoteTableDataService
Connect to a remote server by address function, allowing fallback to different server addresses.
ConnectionAwareRemoteTable - Class in io.deephaven.enterprise.remote
A Table that wraps a Barrage subscription, but can gracefully handle upstream query state changes.
ConnectionAwareRemoteTable(ConnectionAwareRemoteTableParams, SubscriptionOptions) - Constructor for class io.deephaven.enterprise.remote.ConnectionAwareRemoteTable
Construct a new ConnectionAwareRemoteTable based on the input parameters.
ConnectionAwareRemoteTableParams - Interface in io.deephaven.enterprise.remote
Implementations of this interface provide parameters for a ConnectionAwareRemoteTable to maintain a subscription to a remote table.
ConnectionAwareRemoteTableParams.Builder - Interface in io.deephaven.enterprise.remote
Implementations of this interface can be used to construct a new ConnectionAwareRemoteTableParams.
consumeToDis(KafkaTableWriter.Options) - Static method in class io.deephaven.enterprise.kafkawriter.KafkaTableWriter
Consume a Kafka stream to a persistent Deephaven table.
containsObjectGroups(String) - Method in class io.deephaven.proto.pqworker.ObjectAccessResponse.Builder
map<string, .io.deephaven.proto.pqworker.StringList> objectGroups = 1;
containsObjectGroups(String) - Method in class io.deephaven.proto.pqworker.ObjectAccessResponse
map<string, .io.deephaven.proto.pqworker.StringList> objectGroups = 1;
containsObjectGroups(String) - Method in interface io.deephaven.proto.pqworker.ObjectAccessResponseOrBuilder
map<string, .io.deephaven.proto.pqworker.StringList> objectGroups = 1;
ControllerClientClassLoader - Class in io.deephaven.enterprise.dnd.classloader
Gets groovy scripts over the network via controller client.
ControllerClientFactory - Class in io.deephaven.enterprise.dnd
A lazy provider of the singleton controller client for queries.
ControllerClientFactory(AuthenticationClient, Client, String) - Constructor for class io.deephaven.enterprise.dnd.ControllerClientFactory
 
ControllerStateWatcher - Class in io.deephaven.enterprise.remote
ControllerStateWatcher(PersistentQueryControllerClient, String) - Constructor for class io.deephaven.enterprise.remote.ControllerStateWatcher
Createa a new ControllerStateWatcher that monitors the state of the specified query by name.
ControllerStateWatcher.PersistentQueryStateToken - Class in io.deephaven.enterprise.remote
convertAndGetChunk(WritableChunk<EATTR>) - Method in class io.deephaven.enterprise.compatibility.chunk.FillContextWrapper
Convert the input Enterprise WritableChunk into a Community WritableChunk.
convertFilter(SelectFilter) - Static method in class io.deephaven.enterprise.compatibility.filter.FilterCompatibility
 
convertFilterGenerator(FilterGenerator) - Static method in class io.deephaven.enterprise.acl.impl.AclHelper
Convert the specified Enterprise FilterGenerator into a DnD AclFilterGenerator
convertFilterGeneratorObject(String) - Static method in class io.deephaven.enterprise.acl.impl.AclHelper
Convert the specified Enterprise FilterGenerator into a DnD AclFilterGenerator
convertInto(LongChunk, ResettableLongChunk) - Static method in class io.deephaven.chunk.CommunityLongChunkAdapter
Converts a LongChunk into a ResettableLongChunk.
convertRangeFilter(AbstractRangeFilter) - Static method in class io.deephaven.shadow.enterprise.com.illumon.iris.db.v2.select.RangeFilterAdapter
 
convertToCommunity(ColumnDefinition<?>) - Static method in class io.deephaven.enterprise.compatibility.TableDefinitionCompatibility
Convert the specified Enterprise format definition to a community ColumnDefinition.
convertToCommunity(TableDefinition) - Static method in class io.deephaven.enterprise.compatibility.TableDefinitionCompatibility
Convert the specified Enterprise format definition to a community TableDefinition.
convertToEnterprise(TableDefinition) - Static method in class io.deephaven.enterprise.compatibility.TableDefinitionCompatibility
This method does its best to convert a Community definition to an enterprise one.
convertToEnterprise(ColumnDefinition<?>) - Static method in class io.deephaven.enterprise.compatibility.TableDefinitionCompatibility
Convert a Core column definition to a Legacy column definition.
convertToIndex(RowSet) - Static method in class io.deephaven.enterprise.compatibility.rowset.RowSetCompatibility
 
convertToRowSet(ReadOnlyIndex) - Static method in class io.deephaven.enterprise.compatibility.rowset.RowSetCompatibility
 
convertWritableInto(WritableLongChunk, ResettableWritableLongChunk) - Static method in class io.deephaven.chunk.CommunityLongChunkAdapter
 
convertWritableInto(WritableChunk<?>, ResettableWritableChunk<?>) - Method in class io.deephaven.shadow.enterprise.com.illumon.iris.db.v2.sources.chunk.EnterpriseByteChunkAdapter
 
convertWritableInto(WritableChunk<?>, ResettableWritableChunk<?>) - Method in class io.deephaven.shadow.enterprise.com.illumon.iris.db.v2.sources.chunk.EnterpriseCharChunkAdapter
 
convertWritableInto(WritableChunk<?>, ResettableWritableChunk<?>) - Method in class io.deephaven.shadow.enterprise.com.illumon.iris.db.v2.sources.chunk.EnterpriseDoubleChunkAdapter
 
convertWritableInto(WritableChunk<?>, ResettableWritableChunk<?>) - Method in class io.deephaven.shadow.enterprise.com.illumon.iris.db.v2.sources.chunk.EnterpriseFloatChunkAdapter
 
convertWritableInto(WritableChunk<?>, ResettableWritableChunk<?>) - Method in class io.deephaven.shadow.enterprise.com.illumon.iris.db.v2.sources.chunk.EnterpriseIntChunkAdapter
 
convertWritableInto(WritableChunk<?>, ResettableWritableChunk<?>) - Method in class io.deephaven.shadow.enterprise.com.illumon.iris.db.v2.sources.chunk.EnterpriseLongChunkAdapter
 
convertWritableInto(WritableChunk<?>, ResettableWritableChunk<?>) - Method in class io.deephaven.shadow.enterprise.com.illumon.iris.db.v2.sources.chunk.EnterpriseObjectChunkAdapter
 
convertWritableInto(WritableChunk<?>, ResettableWritableChunk<?>) - Method in class io.deephaven.shadow.enterprise.com.illumon.iris.db.v2.sources.chunk.EnterpriseShortChunkAdapter
 
convertWritableInto(WritableChunk<?>, ResettableWritableChunk<?>) - Method in interface io.deephaven.enterprise.compatibility.chunk.ChunkAdapter
Convert the input Enterprise WritableChunk into a Community WritableChunk.
copy() - Method in class io.deephaven.enterprise.acl.impl.DeferredACLTable
 
copy() - Method in class io.deephaven.enterprise.compatibility.filter.EnterpriseFilterAdapter
 
copy() - Method in class io.deephaven.enterprise.extensions.UncoalescedBlinkTable
 
CoreFromEnterpriseTableLocationProvider - Class in io.deephaven.enterprise.compatibility.locationprovider
This class adapts a Legacy Enterprise TableLocationProvider into a Core TableLocationProvider.
CoreFromEnterpriseTableLocationProvider(TableLocationProvider, String, TableDefinition) - Constructor for class io.deephaven.enterprise.compatibility.locationprovider.CoreFromEnterpriseTableLocationProvider
Create a Core TableLocationProvider that wraps the given Enterprise TableLocationProvider.
CoreLastByTableImportState<KEY_TYPE> - Class in io.deephaven.enterprise.lastbystate
Core+ ImportState for lastBy DIS instances.
CoreLastByTableImportState() - Constructor for class io.deephaven.enterprise.lastbystate.CoreLastByTableImportState
Constructor for an empty import state with null name.
CoreLastByTableImportState(String) - Constructor for class io.deephaven.enterprise.lastbystate.CoreLastByTableImportState
Constructor for an empty import state.
CoreLastByTableImportState.ResultPartitionedTable - Class in io.deephaven.enterprise.lastbystate
LocalTableMap with an associated LiveTableRefreshCombiner.
CorePlusClusterSessionFactory - Class in io.deephaven.enterprise.remote
A session factory that knows how to associate a barrage session and its managed channel; the session is created authenticated to a DHE authentication service client.
CorePlusClusterSessionFactory(Supplier<PersistentQueryControllerClient>, ScheduledExecutorService, BufferAllocator, ManagedChannelFactory, AuthenticationClient, boolean) - Constructor for class io.deephaven.enterprise.remote.CorePlusClusterSessionFactory
CorePlusClusterSessionFactory.SessionAndChannel - Class in io.deephaven.enterprise.remote
 
CorePlusTestUtils - Class in io.deephaven.enterprise.test
 
countBy(String, SelectColumn...) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
create() - Static method in class io.deephaven.enterprise.database.inputtables.InputTableConverter
 
create() - Static method in class io.deephaven.enterprise.database.inputtables.InputTableSnapshotter
 
create() - Method in class io.deephaven.enterprise.dnd.autocomplete.DatabaseAutocompleteDelegate
 
create(Database) - Static method in class io.deephaven.enterprise.dnd.notebook.NotebookReader
Creates a notebook reader that takes a static snapshot of notebook state as the basis for its operations.
create(Database, Runnable) - Static method in class io.deephaven.enterprise.dnd.notebook.NotebookReader
Functions like NotebookReader.create(Database), except notebook state is live and a callback is executed when notebooks are added or removed.
create(OffsetLookup<T, ChunkSource.FillContext>, FillContextMaker) - Method in interface io.deephaven.enterprise.sources.regioned.impl.ColumnRegionObjectCached.CacheFactory
 
create(String, Scheduler, long, boolean) - Method in interface io.deephaven.enterprise.tabledataservice.ProtocolDriverFactory
 
create(PivotTableView, StreamObserver<BarrageMessageWriter.MessageView>, BarrageSubscriptionOptions, long) - Method in interface io.deephaven.pivot.PivotTableViewSubscription.Factory
 
create(ArrowFlightUtil.DoExchangeMarshaller, StreamObserver<BarrageMessageWriter.MessageView>) - Method in class io.deephaven.pivot.PivotMarshallerModule.PivotSubscriptionRequestHandlerFactory
 
create(Scheduler, SessionService.ErrorTransformer, BarrageMessageWriter.Factory) - Method in class io.deephaven.pivot.PivotTableViewExchangeMarshaller.Factory
 
createAdaptedCodecArgs(String, String) - Static method in class io.deephaven.enterprise.compatibility.CodecCompatibility
 
createDisjunctiveFilter(Collection<WhereFilter>[]) - Static method in class io.deephaven.enterprise.acl.impl.AclHelper
Create single where filter in Disjunctive Normal Form of the input filter collections
createEffectiveColumnViewportVector(FlatBufferBuilder, byte[]) - Static method in class io.deephaven.enterprise.pivot.flatbuf.PivotUpdateMetadata
 
createEffectiveColumnViewportVector(FlatBufferBuilder, ByteBuffer) - Static method in class io.deephaven.enterprise.pivot.flatbuf.PivotUpdateMetadata
 
createEffectiveRowViewportVector(FlatBufferBuilder, byte[]) - Static method in class io.deephaven.enterprise.pivot.flatbuf.PivotUpdateMetadata
 
createEffectiveRowViewportVector(FlatBufferBuilder, ByteBuffer) - Static method in class io.deephaven.enterprise.pivot.flatbuf.PivotUpdateMetadata
 
createFrom(Object) - Method in interface io.deephaven.enterprise.iceberg.IcebergDataInstructions.Factory
Create an implementation instance based on the opaque instructions object, or return null if this factory does not support it.
createFrom(Object) - Method in class io.deephaven.enterprise.iceberg.IcebergS3Instructions.Factory
 
createNullLoggerWithInterceptor() - Static method in class io.deephaven.enterprise.dnd.EnterpriseProcessEnvironmentCommunityAdapter
 
createNullLoggerWithInterceptor(Class<?>) - Static method in class io.deephaven.enterprise.dnd.EnterpriseProcessEnvironmentCommunityAdapter
 
createPartitionedTable(String, String, String) - Method in class io.deephaven.enterprise.lastbystate.LastByPartitionedTableFactory
createPartitionedTable(String, String, String, String) - Method in class io.deephaven.enterprise.lastbystate.LastByPartitionedTableFactory
Create a last-by indexed PartitionedTable for intraday data from the specified namespace, table name, and column partition value.
createPersistentQueryConfig(String, float, long) - Method in class io.deephaven.enterprise.dnd.client.DndSessionFactoryBarrage
Create a new Interactive Console Persistent Query configuration with a language set to `Python`
createPivotUpdateMetadata(FlatBufferBuilder, int, int, long, long) - Static method in class io.deephaven.enterprise.pivot.flatbuf.PivotUpdateMetadata
 
createSchemaFromXml(Path) - Static method in class io.deephaven.enterprise.test.CorePlusTestUtils
 
CREATION - Enum constant in enum class io.deephaven.proto.pivot.PivotPluginRequest.RequestCase
 
CREATION - Enum constant in enum class io.deephaven.proto.pivot.PivotPluginResponse.ResponseCase
 
CREATION_FIELD_NUMBER - Static variable in class io.deephaven.proto.pivot.PivotPluginRequest
 
CREATION_FIELD_NUMBER - Static variable in class io.deephaven.proto.pivot.PivotPluginResponse
 
CURRENT_DATE_SENTINEL - Static variable in class io.deephaven.enterprise.dnd.logger.engine.impl.BinaryRowLoggerDnd
Sentinel Object for current date partitioning.
currentDateColumnPartition() - Method in class io.deephaven.enterprise.database.SystemTableLogger.Options
Should we write to a column partition that is set to the Date when the row is logged?
currentDateColumnPartition(boolean) - Method in interface io.deephaven.enterprise.database.SystemTableLogger.Options.Builder
Should we write to a column partition that is set to the Date when the row is logged?
currentThreadProcessesUpdates() - Method in class io.deephaven.enterprise.test.CapturingUpdateGraph
 
currentTimeMicros() - Method in class io.deephaven.enterprise.replay.DeltaClockWithAdjustableSpeed
 
currentTimeMicros() - Method in class io.deephaven.enterprise.replay.DeltaClockWithSpeed
 
currentTimeMillis() - Method in class io.deephaven.enterprise.replay.DeltaClockWithAdjustableSpeed
 
currentTimeMillis() - Method in class io.deephaven.enterprise.replay.DeltaClockWithSpeed
 
currentTimeNanos() - Method in class io.deephaven.enterprise.replay.DeltaClockWithAdjustableSpeed
 
currentTimeNanos() - Method in class io.deephaven.enterprise.replay.DeltaClockWithSpeed
 

D

daily() - Static method in class io.deephaven.enterprise.kafkawriter.TimePartitionRotation
Return a function suitable for creating a daily column partition from nanoseconds since the epoch.
daily(ZoneId, int) - Static method in class io.deephaven.enterprise.kafkawriter.TimePartitionRotation
Return a function suitable for creating a daily column partition from nanoseconds since the epoch.
Database - Interface in io.deephaven.enterprise.database
This interface presents a view of the data store for the system in both Live, and Historical versions.
DatabaseAdapter - Class in io.deephaven.enterprise.database.impl
This class exists as an adapter shim between the Community implementation of DatabaseInternal and the enterprise version.
DatabaseAdapter(DatabaseInternal) - Constructor for class io.deephaven.enterprise.database.impl.DatabaseAdapter
 
DatabaseAutocompleteDelegate - Class in io.deephaven.enterprise.dnd.autocomplete
Custom autocomplete results for DHE.
DatabaseAutocompleteDelegate(Database) - Constructor for class io.deephaven.enterprise.dnd.autocomplete.DatabaseAutocompleteDelegate
 
DatabaseImpl - Class in io.deephaven.enterprise.database.impl
A basic implementation of the Database interface.
DatabaseImpl(TableDataService, SchemaService, GroupProvider, SourceAclProvider, UserContext, AuditEventLogger, ProcessInfo) - Constructor for class io.deephaven.enterprise.database.impl.DatabaseImpl
 
DatabaseInternal - Interface in io.deephaven.enterprise.database.impl
This partial interface defines methods that we need to include in Database for various reasons, but are not intended for use by client code.
DatabaseModule - Interface in io.deephaven.enterprise.dnd.modules
 
DatabaseTicketResolver - Class in io.deephaven.enterprise.dnd.service.ticket
 
DatabaseTicketResolver(AuthorizationProvider, Database) - Constructor for class io.deephaven.enterprise.dnd.service.ticket.DatabaseTicketResolver
 
databaseWrapper() - Static method in class io.deephaven.enterprise.acl.impl.AclHelper
Get the Database wrapper to use for Enterprise integration
dataImportServer(DataImportServer) - Method in class io.deephaven.enterprise.kafkawriter.KafkaTableWriter.Options
The DataImportServer to use for ingestion.
DataImportServerTools - Class in io.deephaven.enterprise.dataimportserver
 
dataInstructions(Object) - Method in interface io.deephaven.enterprise.iceberg.IcebergEndpoint.Builder
Set the opaque data instructions for Deephaven to use when fetching table data, for example an S3Instructions instance could be provided.
date(String) - Method in class io.deephaven.enterprise.dnd.query.util.perf.PerformanceOverview
Set the date to start filtering performance data
db - Variable in class io.deephaven.enterprise.workspace.WorkspaceDataSnapshot
 
DbArrayToByteVectorDecoder - Class in io.deephaven.enterprise.compatibility.vector
 
DbArrayToByteVectorDecoder(String) - Constructor for class io.deephaven.enterprise.compatibility.vector.DbArrayToByteVectorDecoder
 
DbArrayToCharVectorDecoder - Class in io.deephaven.enterprise.compatibility.vector
 
DbArrayToCharVectorDecoder(String) - Constructor for class io.deephaven.enterprise.compatibility.vector.DbArrayToCharVectorDecoder
 
DbArrayToDoubleVectorDecoder - Class in io.deephaven.enterprise.compatibility.vector
 
DbArrayToDoubleVectorDecoder(String) - Constructor for class io.deephaven.enterprise.compatibility.vector.DbArrayToDoubleVectorDecoder
 
DbArrayToFloatVectorDecoder - Class in io.deephaven.enterprise.compatibility.vector
 
DbArrayToFloatVectorDecoder(String) - Constructor for class io.deephaven.enterprise.compatibility.vector.DbArrayToFloatVectorDecoder
 
DbArrayToIntVectorDecoder - Class in io.deephaven.enterprise.compatibility.vector
 
DbArrayToIntVectorDecoder(String) - Constructor for class io.deephaven.enterprise.compatibility.vector.DbArrayToIntVectorDecoder
 
DbArrayToLongVectorDecoder - Class in io.deephaven.enterprise.compatibility.vector
 
DbArrayToLongVectorDecoder(String) - Constructor for class io.deephaven.enterprise.compatibility.vector.DbArrayToLongVectorDecoder
 
DbArrayToObjectVectorDecoder - Class in io.deephaven.enterprise.compatibility.vector
 
DbArrayToObjectVectorDecoder(String) - Constructor for class io.deephaven.enterprise.compatibility.vector.DbArrayToObjectVectorDecoder
 
DbArrayToShortVectorDecoder - Class in io.deephaven.enterprise.compatibility.vector
 
DbArrayToShortVectorDecoder(String) - Constructor for class io.deephaven.enterprise.compatibility.vector.DbArrayToShortVectorDecoder
 
deactivateUnderlyingDataSource() - Method in class io.deephaven.enterprise.compatibility.locationprovider.CoreFromEnterpriseTableLocationProvider
 
deactivateUnderlyingDataSource() - Method in class io.deephaven.enterprise.locations.local.deephaven.OnDiskDeephavenTableLocation
 
deactivateUnderlyingDataSource() - Method in class io.deephaven.enterprise.locations.remote.RemoteDeephavenTableLocation
 
decode(byte[], int, int) - Method in class io.deephaven.enterprise.compatibility.ObjectCodecAdapter
 
decode(byte[], int, int) - Method in class io.deephaven.enterprise.compatibility.shadow.ShadowingSerializableDecoder
 
decode(byte[], int, int) - Method in class io.deephaven.enterprise.compatibility.vector.DbArrayToByteVectorDecoder
 
decode(byte[], int, int) - Method in class io.deephaven.enterprise.compatibility.vector.DbArrayToCharVectorDecoder
 
decode(byte[], int, int) - Method in class io.deephaven.enterprise.compatibility.vector.DbArrayToDoubleVectorDecoder
 
decode(byte[], int, int) - Method in class io.deephaven.enterprise.compatibility.vector.DbArrayToFloatVectorDecoder
 
decode(byte[], int, int) - Method in class io.deephaven.enterprise.compatibility.vector.DbArrayToIntVectorDecoder
 
decode(byte[], int, int) - Method in class io.deephaven.enterprise.compatibility.vector.DbArrayToLongVectorDecoder
 
decode(byte[], int, int) - Method in class io.deephaven.enterprise.compatibility.vector.DbArrayToObjectVectorDecoder
 
decode(byte[], int, int) - Method in class io.deephaven.enterprise.compatibility.vector.DbArrayToShortVectorDecoder
 
DEEPHAVEN_ENTERPRISE_ROOT_FILE_PROPERTY - Static variable in class io.deephaven.enterprise.dnd.Main
 
DeephavenClusterConnection - Class in io.deephaven.enterprise.dnd.client
An object that maintains connections to Deephaven services on a remote cluster.
DeephavenClusterConnection(String) - Constructor for class io.deephaven.enterprise.dnd.client.DeephavenClusterConnection
Create a new, unauthenticated connection to the specified Deephaven cluster.
DeephavenFormatColumnLocation - Interface in io.deephaven.enterprise.locations
 
DeephavenFormatTableLocation - Interface in io.deephaven.enterprise.locations
A tagging interface for Deephaven formatted table locations.
DEFAULT - Static variable in interface io.deephaven.enterprise.tabledataservice.ProtocolDriverFactory
 
DEFAULT_TABLE_DATA_SERVICE_REQUEST_TIMEOUT_MILLIS - Static variable in class io.deephaven.enterprise.tabledataservice.TableDataServiceFactory
 
DeferredACLTable - Class in io.deephaven.enterprise.acl.impl
An UncoalescedTable that will apply row and column ACLs when it is coalesced.
DeferredACLTable(Table, Collection<WhereFilter>[], ColumnAcl) - Constructor for class io.deephaven.enterprise.acl.impl.DeferredACLTable
 
delegate - Variable in class io.deephaven.enterprise.compatibility.filter.ColumnSourceAdapterForFilter
 
delegate - Variable in class io.deephaven.enterprise.compatibility.ObjectCodecAdapter
 
delegateToken() - Method in class io.deephaven.enterprise.dnd.client.DndSessionFactoryBarrage
Use a delegate token to authenticate; automatically calling the default AuthenticationClientManager.
delegateToken(AuthToken) - Method in class io.deephaven.enterprise.dnd.client.DeephavenClusterConnection
Use a delegate token to authenticate.
delegateToken(AuthToken) - Method in class io.deephaven.enterprise.dnd.client.DndSessionFactoryBarrage
Use a delegate token to authenticate.
DELETED_COLUMN_NAME - Static variable in class io.deephaven.enterprise.database.inputtables.InputTableConstants
 
deleteInputTable(String, String) - Method in class io.deephaven.enterprise.database.impl.DatabaseImpl
 
deleteInputTable(String, String) - Method in interface io.deephaven.enterprise.database.WritableDatabase
Delete the input table given the namespace and table name.
deleteInputTable(String, String) - Method in class io.deephaven.enterprise.replay.WritableReplayDatabase
 
deleteLiveTablePartition(String, String, String) - Method in class io.deephaven.enterprise.database.impl.DatabaseImpl
 
deleteLiveTablePartition(String, String, String) - Method in interface io.deephaven.enterprise.database.WritableDatabase
Delete a partition from a live user table.
deleteLiveTablePartition(String, String, String) - Method in class io.deephaven.enterprise.replay.WritableReplayDatabase
 
deletePartitionedTable(String, String) - Method in class io.deephaven.enterprise.database.impl.DatabaseImpl
 
deletePartitionedTable(String, String) - Method in interface io.deephaven.enterprise.database.WritableDatabase
Delete all partitions, whether direct or live, and the schema, from a partitioned user table.
deletePartitionedTable(String, String) - Method in class io.deephaven.enterprise.replay.WritableReplayDatabase
 
deleteTablePartition(String, String, String) - Method in class io.deephaven.enterprise.database.impl.DatabaseImpl
 
deleteTablePartition(String, String, String) - Method in interface io.deephaven.enterprise.database.WritableDatabase
Deletes a single column partition of data from a partitioned user table.
deleteTablePartition(String, String, String) - Method in class io.deephaven.enterprise.replay.WritableReplayDatabase
 
deleteUnpartitionedTable(String, String) - Method in class io.deephaven.enterprise.database.impl.DatabaseImpl
 
deleteUnpartitionedTable(String, String) - Method in interface io.deephaven.enterprise.database.WritableDatabase
Deletes an unpartitioned user table and the schema.
deleteUnpartitionedTable(String, String) - Method in class io.deephaven.enterprise.replay.WritableReplayDatabase
 
DeltaClockWithAdjustableSpeed - Class in io.deephaven.enterprise.replay
A clock impl with a delta adjustment and a speed factor.
DeltaClockWithAdjustableSpeed(Clock, long, double) - Constructor for class io.deephaven.enterprise.replay.DeltaClockWithAdjustableSpeed
Constructs a delta clock with the provided clock and delta.
DeltaClockWithSpeed - Class in io.deephaven.enterprise.replay
A clock impl with a delta adjustment and a speed factor.
DeltaClockWithSpeed(Clock, long, double) - Constructor for class io.deephaven.enterprise.replay.DeltaClockWithSpeed
Constructs a delta clock with the provided clock and delta.
deploy(boolean) - Method in class io.deephaven.enterprise.iceberg.IcebergEndpoint.Named
Deploy this endpoint to configuration, optionally overwriting an existing one.
deployEndpoint(IcebergEndpoint.Named, boolean) - Static method in class io.deephaven.enterprise.iceberg.IcebergTools
Deploy the discovered endpoint to Deephaven's configuration service.
deploySchemaWithEmbeddedEndpoint(DiscoveryResult) - Static method in class io.deephaven.enterprise.iceberg.IcebergTools
Deploy the discovered schema to deephaven, embedding the endpoint directly in the schema
deploySchemaWithEndpointReference(DiscoveryResult) - Static method in class io.deephaven.enterprise.iceberg.IcebergTools
Deploy the discovered schema to deephaven, referencing the endpoint by name.
deployWithEmbeddedEndpoint() - Method in interface io.deephaven.enterprise.iceberg.discovery.DiscoveryResult
Deploy the discovered table as a Deephaven Schema, embedding the endpoint directly into the schema.
deployWithEndpointReference() - Method in interface io.deephaven.enterprise.iceberg.discovery.DiscoveryResult
Deploy the discovered table as a Deephaven Schema, referencing the endpoint by name.
DerivedPartitionedTableWriterQueryFunctions - Class in io.deephaven.enterprise.derivedtablewriter
Note this class is only to be used by the DerivedPartitionTableWriterImpl.
DerivedPartitionedTableWriterQueryFunctions() - Constructor for class io.deephaven.enterprise.derivedtablewriter.DerivedPartitionedTableWriterQueryFunctions
 
DerivedTableCreationFunction - Interface in io.deephaven.enterprise.derivedtablewriter
This interface is used internally by the PartitionedTable DerivedTableWriter.
DerivedTableWriter - Class in io.deephaven.enterprise.derivedtablewriter
Persist data from a Table to Deephaven storage using an in-worker DataImportServer.
DerivedTableWriter() - Constructor for class io.deephaven.enterprise.derivedtablewriter.DerivedTableWriter
 
DerivedTableWriter.Options - Class in io.deephaven.enterprise.derivedtablewriter
Represents Options for ingesting a table to a DIS partition.
DerivedTableWriter.PartitionedOptions - Class in io.deephaven.enterprise.derivedtablewriter
Represents options for partitioned table ingestion.
describe() - Method in class io.deephaven.enterprise.secrets.JsonFilesSecretsProvider
 
describe() - Method in class io.deephaven.enterprise.secrets.PropertiesSecretsProvider
 
describe() - Method in interface io.deephaven.enterprise.secrets.SecretsProvider
Describe this provider for logging purposes.
describe() - Method in class io.deephaven.enterprise.tabledataservice.RemoteTableDataService
 
description() - Method in class io.deephaven.enterprise.remote.ControllerStateWatcher
 
description() - Method in interface io.deephaven.enterprise.remote.RemoteTableStateWatcher
Get a description of the watcher.
deserialize(JsonParser, DeserializationContext) - Method in class io.deephaven.enterprise.iceberg.IcebergS3Instructions.Deserializer
 
Deserializer() - Constructor for class io.deephaven.enterprise.iceberg.IcebergS3Instructions.Deserializer
 
deserializeWithType(JsonParser, DeserializationContext, TypeDeserializer) - Method in class io.deephaven.enterprise.iceberg.IcebergS3Instructions.Deserializer
 
destroy() - Method in class io.deephaven.enterprise.remote.ConnectionAwareRemoteTable
 
destroy() - Method in class io.deephaven.pivot.PivotTableViewSubscription
 
DHC_SHARED_CONTEXT_KEY - Static variable in class io.deephaven.enterprise.compatibility.filter.ColumnSourceAdapterForFilter
 
DheAuthContext - Class in io.deephaven.enterprise.dnd.authentication
An AuthContext containing a single UserContext for Enterprise authentication.
DheAuthContext(UserContext) - Constructor for class io.deephaven.enterprise.dnd.authentication.DheAuthContext
 
DheAuthenticationHandler - Class in io.deephaven.enterprise.dnd.authentication
The authentication hook for enterprise clients to DnD workers.
DheAuthenticationHandler() - Constructor for class io.deephaven.enterprise.dnd.authentication.DheAuthenticationHandler
Create a new auth handler.
DheAuthorizationProvider - Class in io.deephaven.enterprise.dnd.authentication
The authorization provider for access to the worker.
DheAuthorizationProvider(UserContext, Set<TicketTransformer>) - Constructor for class io.deephaven.enterprise.dnd.authentication.DheAuthorizationProvider
 
discover(DiscoveryConfig) - Static method in class io.deephaven.enterprise.iceberg.IcebergTools
Discover a table from iceberg.
DiscoveryConfig - Interface in io.deephaven.enterprise.iceberg.discovery
A container for the configuration parameters of an Iceberg discovery.
DiscoveryConfig.Builder - Interface in io.deephaven.enterprise.iceberg.discovery
The interface for constructing a DiscoveryConfig.
DiscoveryResult - Interface in io.deephaven.enterprise.iceberg.discovery
The result of an Iceberg table discovery.
DiscoveryResultImpl - Class in io.deephaven.enterprise.iceberg.discovery
The implementation of a DiscoveryResult
DiscoveryResultImpl(DiscoveryConfig, IcebergTableAdapter, IcebergReadInstructions, String, String, DataInstructionsProviderLoader, TableIdentifier) - Constructor for class io.deephaven.enterprise.iceberg.discovery.DiscoveryResultImpl
disjunctive(AclFilterGenerator...) - Static method in interface io.deephaven.enterprise.acl.AclFilterGenerator
Create an AclFilterGenerator that disjunctively combines the input generators.
disjunctive(Collection<AclFilterGenerator>) - Static method in interface io.deephaven.enterprise.acl.AclFilterGenerator
Create an AclFilterGenerator that disjunctively combines the input generators.
DisjunctiveFilterGenerator - Class in io.deephaven.enterprise.acl.generator
AclFilterGenerator for combining the results of multiple AclFilterGenerators disjunctively, i.e.
DisjunctiveFilterGenerator(AclFilterGenerator...) - Constructor for class io.deephaven.enterprise.acl.generator.DisjunctiveFilterGenerator
Construct an AclFilterGenerator that will return an array of all the WhereFilters generated by filterGenerators, thereby expressing the disjunction of those WhereFilters.
DisjunctiveFilterGenerator(PermissionFilterProvider, Database, FilterGenerator...) - Constructor for class io.deephaven.enterprise.acl.generator.DisjunctiveFilterGenerator
 
disName(String) - Method in class io.deephaven.enterprise.kafkawriter.KafkaTableWriter.Options
The name of the DataImportServer (dis) to use for ingestion.
disNameWithStorage(String, String) - Method in class io.deephaven.enterprise.kafkawriter.KafkaTableWriter.Options
The name of the DataImportServer (dis) to use for ingestion.
DnDAuthorizationProvider - Interface in io.deephaven.enterprise.dnd.authentication
 
DndAuthUtils - Class in io.deephaven.enterprise.dnd.authentication
 
DndAuthUtils() - Constructor for class io.deephaven.enterprise.dnd.authentication.DndAuthUtils
 
DndClientHelper - Class in io.deephaven.enterprise.dnd.client
 
DndClientHelper() - Constructor for class io.deephaven.enterprise.dnd.client.DndClientHelper
 
DndGroovyClassLoader - Class in io.deephaven.enterprise.dnd.classloader
Despite class name, this class doesn't extend the Groovy class loader, but rather handles getting Groovy script resources.
DndSession - Class in io.deephaven.enterprise.dnd.client
A basic gRPC connection to a DnD worker.
DndSessionBarrage - Class in io.deephaven.enterprise.dnd.client
A session on a Persistent Query used to access tables using Barrage
DndSessionFactoryBarrage - Class in io.deephaven.enterprise.dnd.client
A factory class for creating barrage sessions.
DndSessionFactoryBarrage(String) - Constructor for class io.deephaven.enterprise.dnd.client.DndSessionFactoryBarrage
Create a new DndSessionFactoryBarrage for fetching barrage tables from a Persistent Query
DndSessionListenerModule - Interface in io.deephaven.enterprise.dnd.modules
 
DndSessionListenerModule.DndSessionCountListener - Interface in io.deephaven.enterprise.dnd.modules
 
DndSessionListenerModule.SessionMonitor - Class in io.deephaven.enterprise.dnd.modules
 
doCoalesce() - Method in class io.deephaven.enterprise.acl.impl.DeferredACLTable
 
doCoalesce() - Method in class io.deephaven.enterprise.extensions.UncoalescedBlinkTable
 
doCompare(ImportStateDetails, ImportStateDetails) - Static method in class io.deephaven.enterprise.ingester.impl.ImportStateComparator
 
doCompletion(Node, Collection<CompletionItem.Builder>, CompletionRequest) - Method in class io.deephaven.enterprise.dnd.autocomplete.CompleteTableName
 
doCompletion(Node, Collection<CompletionItem.Builder>, CompletionRequest) - Method in class io.deephaven.enterprise.dnd.autocomplete.CompleteTableNamespace
 
doConvertInto(ByteChunk<?>, ResettableByteChunk<?>) - Static method in class io.deephaven.shadow.enterprise.com.illumon.iris.db.v2.sources.chunk.EnterpriseByteChunkAdapter
 
doConvertInto(CharChunk<?>, ResettableCharChunk<?>) - Static method in class io.deephaven.shadow.enterprise.com.illumon.iris.db.v2.sources.chunk.EnterpriseCharChunkAdapter
 
doConvertInto(DoubleChunk<?>, ResettableDoubleChunk<?>) - Static method in class io.deephaven.shadow.enterprise.com.illumon.iris.db.v2.sources.chunk.EnterpriseDoubleChunkAdapter
 
doConvertInto(FloatChunk<?>, ResettableFloatChunk<?>) - Static method in class io.deephaven.shadow.enterprise.com.illumon.iris.db.v2.sources.chunk.EnterpriseFloatChunkAdapter
 
doConvertInto(IntChunk<?>, ResettableIntChunk<?>) - Static method in class io.deephaven.shadow.enterprise.com.illumon.iris.db.v2.sources.chunk.EnterpriseIntChunkAdapter
 
doConvertInto(LongChunk<?>, ResettableLongChunk<?>) - Static method in class io.deephaven.shadow.enterprise.com.illumon.iris.db.v2.sources.chunk.EnterpriseLongChunkAdapter
 
doConvertInto(ObjectChunk<?, ?>, ResettableObjectChunk<?, ?>) - Static method in class io.deephaven.shadow.enterprise.com.illumon.iris.db.v2.sources.chunk.EnterpriseObjectChunkAdapter
 
doConvertInto(ShortChunk<?>, ResettableShortChunk<?>) - Static method in class io.deephaven.shadow.enterprise.com.illumon.iris.db.v2.sources.chunk.EnterpriseShortChunkAdapter
 
doConvertWritableInto(WritableByteChunk<?>, ResettableWritableByteChunk<?>) - Static method in class io.deephaven.shadow.enterprise.com.illumon.iris.db.v2.sources.chunk.EnterpriseByteChunkAdapter
 
doConvertWritableInto(WritableCharChunk<?>, ResettableWritableCharChunk<?>) - Static method in class io.deephaven.shadow.enterprise.com.illumon.iris.db.v2.sources.chunk.EnterpriseCharChunkAdapter
 
doConvertWritableInto(WritableDoubleChunk<?>, ResettableWritableDoubleChunk<?>) - Static method in class io.deephaven.shadow.enterprise.com.illumon.iris.db.v2.sources.chunk.EnterpriseDoubleChunkAdapter
 
doConvertWritableInto(WritableFloatChunk<?>, ResettableWritableFloatChunk<?>) - Static method in class io.deephaven.shadow.enterprise.com.illumon.iris.db.v2.sources.chunk.EnterpriseFloatChunkAdapter
 
doConvertWritableInto(WritableIntChunk<?>, ResettableWritableIntChunk<?>) - Static method in class io.deephaven.shadow.enterprise.com.illumon.iris.db.v2.sources.chunk.EnterpriseIntChunkAdapter
 
doConvertWritableInto(WritableLongChunk<?>, ResettableWritableLongChunk<?>) - Static method in class io.deephaven.shadow.enterprise.com.illumon.iris.db.v2.sources.chunk.EnterpriseLongChunkAdapter
 
doConvertWritableInto(WritableObjectChunk<?, ?>, ResettableWritableObjectChunk<?, ?>) - Static method in class io.deephaven.shadow.enterprise.com.illumon.iris.db.v2.sources.chunk.EnterpriseObjectChunkAdapter
 
doConvertWritableInto(WritableShortChunk<?>, ResettableWritableShortChunk<?>) - Static method in class io.deephaven.shadow.enterprise.com.illumon.iris.db.v2.sources.chunk.EnterpriseShortChunkAdapter
 
doHttpGet(String) - Static method in class io.deephaven.enterprise.dnd.client.DndClientHelper
 
doOnAuthenticated() - Method in class io.deephaven.enterprise.dnd.client.DndSessionFactoryBarrage
 
Double - Enum constant in enum class io.deephaven.enterprise.sources.regioned.BufferedType
 
DoubleColumnRegionAdapter<ATTR extends Values> - Class in io.deephaven.enterprise.compatibility.region
Adapts a Legacy ColumnRegionDouble to a Core ColumnRegionDouble.
DoubleColumnRegionAdapter(ColumnRegionDouble<?>) - Constructor for class io.deephaven.enterprise.compatibility.region.DoubleColumnRegionAdapter
 
dropColumns(String...) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
dropColumns(String...) - Method in class io.deephaven.enterprise.extensions.UncoalescedBlinkTable
 
dropReference() - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
dynamicPartitionFunction(String, LongFunction<String>) - Method in class io.deephaven.enterprise.kafkawriter.KafkaTableWriter.Options
An input column (which must be a long) and a function to determine which column partition a row belongs to.

E

EdgeAclImpl - Class in io.deephaven.enterprise.acl.impl
A implementation of EdgeAclProvider that stores immutable maps of group to ACL definition.
EdgeAclProvider - Interface in io.deephaven.enterprise.acl
Objects that implement this interface provide ACLs for tables based on the requesting user at request time, as opposed to SourceAclProvider which applies ACLS to the table when it is fetched from the data source.
EdgeAclProvider.Builder - Interface in io.deephaven.enterprise.acl
A Builder to construct a set of ACLs to apply to a table based on the user fetching it.
effectiveColumnViewport(int) - Method in class io.deephaven.enterprise.pivot.flatbuf.PivotUpdateMetadata
The effectively subscribed column viewport as an encoded and compressed RowSet.
effectiveColumnViewportAsByteBuffer() - Method in class io.deephaven.enterprise.pivot.flatbuf.PivotUpdateMetadata
 
effectiveColumnViewportInByteBuffer(ByteBuffer) - Method in class io.deephaven.enterprise.pivot.flatbuf.PivotUpdateMetadata
 
effectiveColumnViewportLength() - Method in class io.deephaven.enterprise.pivot.flatbuf.PivotUpdateMetadata
 
effectiveColumnViewportVector() - Method in class io.deephaven.enterprise.pivot.flatbuf.PivotUpdateMetadata
 
effectiveColumnViewportVector(ByteVector) - Method in class io.deephaven.enterprise.pivot.flatbuf.PivotUpdateMetadata
 
effectiveRowViewport(int) - Method in class io.deephaven.enterprise.pivot.flatbuf.PivotUpdateMetadata
The effectively subscribed row viewport as an encoded and compressed RowSet.
effectiveRowViewportAsByteBuffer() - Method in class io.deephaven.enterprise.pivot.flatbuf.PivotUpdateMetadata
 
effectiveRowViewportInByteBuffer(ByteBuffer) - Method in class io.deephaven.enterprise.pivot.flatbuf.PivotUpdateMetadata
 
effectiveRowViewportLength() - Method in class io.deephaven.enterprise.pivot.flatbuf.PivotUpdateMetadata
 
effectiveRowViewportVector() - Method in class io.deephaven.enterprise.pivot.flatbuf.PivotUpdateMetadata
 
effectiveRowViewportVector(ByteVector) - Method in class io.deephaven.enterprise.pivot.flatbuf.PivotUpdateMetadata
 
EMPTY_EXPANSIONS - Enum constant in enum class io.deephaven.proto.pivot.PivotPluginRequest.RequestCase
 
EMPTY_EXPANSIONS - Enum constant in enum class io.deephaven.proto.pivot.PivotPluginResponse.ResponseCase
 
EMPTY_EXPANSIONS_FIELD_NUMBER - Static variable in class io.deephaven.proto.pivot.PivotPluginRequest
 
EMPTY_EXPANSIONS_FIELD_NUMBER - Static variable in class io.deephaven.proto.pivot.PivotPluginResponse
 
ENABLE_AUTO_COMMIT_PROPERTY - Static variable in class io.deephaven.enterprise.kafkawriter.KafkaTableWriter
 
enabled() - Method in class io.deephaven.enterprise.replay.ComposableTableReplayConfiguration
 
enabled() - Method in interface io.deephaven.enterprise.replay.TableReplayConfiguration
Should the table be replayed?
encode(T) - Method in class io.deephaven.enterprise.compatibility.shadow.ShadowingSerializableDecoder
 
encode(TYPE) - Method in class io.deephaven.enterprise.compatibility.ObjectCodecAdapter
 
endPivotUpdateMetadata(FlatBufferBuilder) - Static method in class io.deephaven.enterprise.pivot.flatbuf.PivotUpdateMetadata
 
endpoint() - Method in interface io.deephaven.enterprise.iceberg.discovery.DiscoveryConfig
 
endpoint(IcebergEndpoint) - Method in interface io.deephaven.enterprise.iceberg.discovery.DiscoveryConfig.Builder
enforceSessionCount(int) - Method in interface io.deephaven.enterprise.dnd.EnterpriseJettyComponent.Builder
Set if the worker should time out when there are fewer than enforceSessionCount active sessions.
EngineTableLoggersFactoryDndImpl - Class in io.deephaven.enterprise.dnd.logger.engine.impl
Provides DnD engine table logger implementations that will write DHE binary rows.
EngineTableLoggersFactoryDndImpl(ProcessInfo) - Constructor for class io.deephaven.enterprise.dnd.logger.engine.impl.EngineTableLoggersFactoryDndImpl
 
ensureInitialized(FullTableLocationKey) - Method in class io.deephaven.enterprise.lastbystate.CoreLastByTableImportState
 
EnterpriseAclAdapterProvider - Class in io.deephaven.enterprise.acl.impl
An SourceAclProvider that converts acls derived from Enterprise PermissionFilterProvider into Community equivalents.
EnterpriseAclAdapterProvider(UserContext, PermissionFilterProvider) - Constructor for class io.deephaven.enterprise.acl.impl.EnterpriseAclAdapterProvider
 
EnterpriseApiServerModule - Class in io.deephaven.enterprise.dnd.modules
 
EnterpriseApiServerModule() - Constructor for class io.deephaven.enterprise.dnd.modules.EnterpriseApiServerModule
 
EnterpriseAuthModule - Interface in io.deephaven.enterprise.dnd.modules
This dagger module provides the authorization bindings into the dagger context.
EnterpriseByteChunkAdapter - Class in io.deephaven.shadow.enterprise.com.illumon.iris.db.v2.sources.chunk
 
EnterpriseCalendarsModule - Class in io.deephaven.enterprise.dnd.modules
 
EnterpriseCalendarsModule() - Constructor for class io.deephaven.enterprise.dnd.modules.EnterpriseCalendarsModule
 
EnterpriseCharChunkAdapter - Class in io.deephaven.shadow.enterprise.com.illumon.iris.db.v2.sources.chunk
 
EnterpriseDoubleChunkAdapter - Class in io.deephaven.shadow.enterprise.com.illumon.iris.db.v2.sources.chunk
 
EnterpriseFilterAdapter - Class in io.deephaven.enterprise.compatibility.filter
An adapter from enterprise filters to community filters.
EnterpriseFilterAdapter(SelectFilter) - Constructor for class io.deephaven.enterprise.compatibility.filter.EnterpriseFilterAdapter
 
EnterpriseFilterWrapper - Class in io.deephaven.enterprise.tabledataservice.filter
A light wrapper around an Enterprise Filter.
EnterpriseFilterWrapper(Filter) - Constructor for class io.deephaven.enterprise.tabledataservice.filter.EnterpriseFilterWrapper
 
EnterpriseFloatChunkAdapter - Class in io.deephaven.shadow.enterprise.com.illumon.iris.db.v2.sources.chunk
 
EnterpriseIntChunkAdapter - Class in io.deephaven.shadow.enterprise.com.illumon.iris.db.v2.sources.chunk
 
EnterpriseJettyComponent - Interface in io.deephaven.enterprise.dnd
This is the root component definition for DnD workers.
EnterpriseJettyComponent.Builder - Interface in io.deephaven.enterprise.dnd
The root builder for the DnD jetty component.
EnterpriseLongChunkAdapter - Class in io.deephaven.shadow.enterprise.com.illumon.iris.db.v2.sources.chunk
 
EnterpriseObjectChunkAdapter - Class in io.deephaven.shadow.enterprise.com.illumon.iris.db.v2.sources.chunk
 
EnterpriseProcessEnvironmentCommunityAdapter - Class in io.deephaven.enterprise.dnd
 
EnterpriseProcessEnvironmentCommunityAdapter(String, Logger) - Constructor for class io.deephaven.enterprise.dnd.EnterpriseProcessEnvironmentCommunityAdapter
 
EnterpriseShortChunkAdapter - Class in io.deephaven.shadow.enterprise.com.illumon.iris.db.v2.sources.chunk
 
EnterpriseTableKey - Interface in io.deephaven.enterprise.locations
A TableKey implementation for addressing Deephaven Enterprise Tables.
EnterpriseTableKeyImpl - Class in io.deephaven.enterprise.locations.impl
A basic Enterprise format TableKey.
EnterpriseTableKeyImpl(String, String, TableType) - Constructor for class io.deephaven.enterprise.locations.impl.EnterpriseTableKeyImpl
 
EnterpriseTableLocationKey - Interface in io.deephaven.enterprise.locations
 
EnterpriseTableTools - Class in io.deephaven.enterprise.table
Provides utility methods to read and write individual Deephaven format Tables.
ENVIRONMENT_KEY_DISPATCHER_NAME - Static variable in class io.deephaven.enterprise.dnd.Main
 
ENVIRONMENT_KEY_WORKER_NONCE - Static variable in class io.deephaven.enterprise.dnd.Main
 
equals(Object) - Method in class io.deephaven.enterprise.locations.impl.BasicFixedPartitionedDeephavenTableLocationKey
 
equals(Object) - Method in class io.deephaven.enterprise.locations.nestedpartitioned.NestedPartitionedDeephavenTableLocationKey
 
equals(Object) - Method in class io.deephaven.enterprise.locations.nestedpartitioned.NestedPartitionedParquetTableLocationKey
 
equals(Object) - Method in class io.deephaven.enterprise.locations.nestedpartitioned.NestedPartitionedUnresolvedTableLocationKey
 
equals(Object) - Method in class io.deephaven.enterprise.compatibility.filter.EnterpriseFilterAdapter
 
equals(Object) - Method in class io.deephaven.enterprise.iceberg.IcebergConfiguration
 
equals(Object) - Method in class io.deephaven.enterprise.ingester.impl.ImportStateDetails
 
equals(Object) - Method in class io.deephaven.enterprise.locations.impl.EnterpriseTableKeyImpl
 
equals(Object) - Method in class io.deephaven.proto.pivot.ErrorResponse
 
equals(Object) - Method in class io.deephaven.proto.pivot.PivotPluginRequest
 
equals(Object) - Method in class io.deephaven.proto.pivot.PivotPluginResponse
 
equals(Object) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest
 
equals(Object) - Method in class io.deephaven.proto.pivot.PivotTableApplyResponse
 
equals(Object) - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest
 
equals(Object) - Method in class io.deephaven.proto.pivot.PivotTableCreationResponse
 
equals(Object) - Method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage
 
equals(Object) - Method in class io.deephaven.proto.pivot.PivotTableDescriptorRequest
 
equals(Object) - Method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse
 
equals(Object) - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest
 
equals(Object) - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse
 
equals(Object) - Method in class io.deephaven.proto.pivot.PivotTableSourceExportRequest
 
equals(Object) - Method in class io.deephaven.proto.pivot.PivotTableSourceExportResponse
 
equals(Object) - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage
 
equals(Object) - Method in class io.deephaven.proto.pivot.PivotTableViewRequest
 
equals(Object) - Method in class io.deephaven.proto.pivot.PivotTableViewResponse
 
equals(Object) - Method in class io.deephaven.proto.pqworker.ListenErrorRequest
 
equals(Object) - Method in class io.deephaven.proto.pqworker.ListenErrorResponse
 
equals(Object) - Method in class io.deephaven.proto.pqworker.ObjectAccessRequest
 
equals(Object) - Method in class io.deephaven.proto.pqworker.ObjectAccessResponse
 
equals(Object) - Method in class io.deephaven.proto.pqworker.StringList
 
equals(Object) - Method in class io.deephaven.proto.pqworker.ThreadDumpRequest
 
equals(Object) - Method in class io.deephaven.proto.pqworker.ThreadDumpResponse
 
ERROR - Enum constant in enum class io.deephaven.proto.pivot.PivotPluginResponse.ResponseCase
 
ERROR_FIELD_NUMBER - Static variable in class io.deephaven.proto.pivot.PivotPluginResponse
 
ERROR_MESSAGE_FIELD_NUMBER - Static variable in class io.deephaven.proto.pivot.ErrorResponse
 
ErrorResponse - Class in io.deephaven.proto.pivot
Protobuf type io.deephaven.proto.pivot.ErrorResponse
ErrorResponse.Builder - Class in io.deephaven.proto.pivot
Protobuf type io.deephaven.proto.pivot.ErrorResponse
ErrorResponseOrBuilder - Interface in io.deephaven.proto.pivot
 
evaluateScript(String, String) - Method in class io.deephaven.enterprise.dnd.modules.GroovyConsoleSessionWithDatabaseModule.ScriptSessionWrapper
 
evaluateScript(Path) - Method in class io.deephaven.enterprise.dnd.modules.GroovyConsoleSessionWithDatabaseModule.ScriptSessionWrapper
 
event(AuditEvent) - Method in class io.deephaven.enterprise.dnd.SimpleAuditEventLogger
 
exactJoin(Table, MatchPair[], MatchPair[]) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
exclusiveLock() - Method in class io.deephaven.enterprise.test.CapturingUpdateGraph
 
executeCode(String) - Method in class io.deephaven.enterprise.dnd.client.DndSession
Execute the specified code on the server.
EXISTING_VIEW_OFFSET - Enum constant in enum class io.deephaven.proto.pivot.PivotTableViewRequest.TargetCase
 
EXISTING_VIEW_OFFSET_FIELD_NUMBER - Static variable in class io.deephaven.proto.pivot.PivotTableViewRequest
 
exists() - Method in class io.deephaven.enterprise.locations.local.deephaven.OnDiskDeephavenColumnLocation
 
expandAllColumns(PivotTable) - Static method in class io.deephaven.pivot.PivotTestUtils
 
expandAllRows(PivotTable) - Static method in class io.deephaven.pivot.PivotTestUtils
 
expandedColumnSize() - Method in interface io.deephaven.pivot.PivotTable.PivotSnapshot
 
expandedRowSize() - Method in interface io.deephaven.pivot.PivotTable.PivotSnapshot
 
EXPANSIONS_FIELD_NUMBER - Static variable in class io.deephaven.proto.pivot.PivotTableViewRequest
 
expectedObjectWidth() - Method in class io.deephaven.enterprise.compatibility.ObjectCodecAdapter
 
expectedObjectWidth() - Method in class io.deephaven.enterprise.compatibility.shadow.ShadowingSerializableDecoder
 
expectedObjectWidth() - Method in class io.deephaven.enterprise.compatibility.vector.DbArrayToByteVectorDecoder
 
expectedObjectWidth() - Method in class io.deephaven.enterprise.compatibility.vector.DbArrayToCharVectorDecoder
 
expectedObjectWidth() - Method in class io.deephaven.enterprise.compatibility.vector.DbArrayToDoubleVectorDecoder
 
expectedObjectWidth() - Method in class io.deephaven.enterprise.compatibility.vector.DbArrayToFloatVectorDecoder
 
expectedObjectWidth() - Method in class io.deephaven.enterprise.compatibility.vector.DbArrayToIntVectorDecoder
 
expectedObjectWidth() - Method in class io.deephaven.enterprise.compatibility.vector.DbArrayToLongVectorDecoder
 
expectedObjectWidth() - Method in class io.deephaven.enterprise.compatibility.vector.DbArrayToObjectVectorDecoder
 
expectedObjectWidth() - Method in class io.deephaven.enterprise.compatibility.vector.DbArrayToShortVectorDecoder
 
EXPORT - Enum constant in enum class io.deephaven.proto.pivot.PivotPluginResponse.ResponseCase
 
EXPORT_FIELD_NUMBER - Static variable in class io.deephaven.proto.pivot.PivotPluginResponse
 
EXPORT_SOURCE - Enum constant in enum class io.deephaven.proto.pivot.PivotPluginRequest.RequestCase
 
EXPORT_SOURCE_FIELD_NUMBER - Static variable in class io.deephaven.proto.pivot.PivotPluginRequest
 
EXPORT_TICKET_PREFIX - Static variable in class io.deephaven.enterprise.dnd.authentication.DheAuthorizationProvider
 
ExtendedStorageProvider - Interface in io.deephaven.enterprise.tabledataservice.extended
Implementations of this internal interface are used to create appropriate TableLocationProvider instances for various extended table types.
ExtendedStorageProvider.Factory - Interface in io.deephaven.enterprise.tabledataservice.extended
Implementations of this create ExtendedStorageProviders based on the inputs.
ExtendedStorageService - Class in io.deephaven.enterprise.tabledataservice.extended
The service for loading ExtendedStorageProviders that provide special storage backends for the database.

F

Factory() - Constructor for class io.deephaven.enterprise.iceberg.IcebergExtendedStorageProvider.Factory
 
Factory() - Constructor for class io.deephaven.enterprise.iceberg.IcebergS3Instructions.Factory
 
Factory() - Constructor for class io.deephaven.enterprise.secrets.JsonFilesSecretsProvider.Factory
 
Factory() - Constructor for class io.deephaven.enterprise.secrets.PropertiesSecretsProvider.Factory
 
Factory() - Constructor for class io.deephaven.enterprise.tabledataservice.extended.HiveExtendedStorageProvider.Factory
 
Factory() - Constructor for class io.deephaven.enterprise.tabledataservice.extended.ParquetExtendedStorageProvider.Factory
 
Factory() - Constructor for class io.deephaven.pivot.PivotTableViewExchangeMarshaller.Factory
 
fetchDheAuthContext() - Static method in class io.deephaven.enterprise.dnd.authentication.DheAuthenticationHandler
Fetch an Enterprise DheAuthContext from the current ExecutionContext.
FILENAME_COLUMN_NAME - Static variable in class io.deephaven.enterprise.locations.hive.HiveLocationsTableKeyFinder
The column of file names, relative to the root of this table.
fillChunk(ChunkSource.FillContext, WritableChunk, RowSequence) - Method in class io.deephaven.enterprise.compatibility.region.ObjectColumnRegionAdapter
 
fillChunk(ChunkSource.FillContext, WritableChunk<? super Attributes.Values>, OrderedKeys) - Method in class io.deephaven.enterprise.compatibility.filter.ColumnSourceAdapterForFilter
 
fillChunk(ChunkSource.FillContext, WritableChunk, RowSequence) - Method in class io.deephaven.enterprise.compatibility.region.ByteColumnRegionAdapter
 
fillChunk(ChunkSource.FillContext, WritableChunk, RowSequence) - Method in class io.deephaven.enterprise.compatibility.region.CharColumnRegionAdapter
 
fillChunk(ChunkSource.FillContext, WritableChunk, RowSequence) - Method in class io.deephaven.enterprise.compatibility.region.DoubleColumnRegionAdapter
 
fillChunk(ChunkSource.FillContext, WritableChunk, RowSequence) - Method in class io.deephaven.enterprise.compatibility.region.FloatColumnRegionAdapter
 
fillChunk(ChunkSource.FillContext, WritableChunk, RowSequence) - Method in class io.deephaven.enterprise.compatibility.region.IntColumnRegionAdapter
 
fillChunk(ChunkSource.FillContext, WritableChunk, RowSequence) - Method in class io.deephaven.enterprise.compatibility.region.LongColumnRegionAdapter
 
fillChunk(ChunkSource.FillContext, WritableChunk, RowSequence) - Method in class io.deephaven.enterprise.compatibility.region.ShortColumnRegionAdapter
 
fillChunkAppend(ChunkSource.FillContext, WritableChunk<? super ATTR>, RowSequence) - Method in class io.deephaven.enterprise.sources.regioned.impl.BufferedPageByte
 
fillChunkAppend(ChunkSource.FillContext, WritableChunk<? super ATTR>, RowSequence) - Method in class io.deephaven.enterprise.sources.regioned.impl.BufferedPageChar
 
fillChunkAppend(ChunkSource.FillContext, WritableChunk<? super ATTR>, RowSequence) - Method in class io.deephaven.enterprise.sources.regioned.impl.BufferedPageDouble
 
fillChunkAppend(ChunkSource.FillContext, WritableChunk<? super ATTR>, RowSequence) - Method in class io.deephaven.enterprise.sources.regioned.impl.BufferedPageFloat
 
fillChunkAppend(ChunkSource.FillContext, WritableChunk<? super ATTR>, RowSequence) - Method in class io.deephaven.enterprise.sources.regioned.impl.BufferedPageInt
 
fillChunkAppend(ChunkSource.FillContext, WritableChunk<? super ATTR>, RowSequence) - Method in class io.deephaven.enterprise.sources.regioned.impl.BufferedPageIntAsLong
 
fillChunkAppend(ChunkSource.FillContext, WritableChunk<? super ATTR>, RowSequence) - Method in class io.deephaven.enterprise.sources.regioned.impl.BufferedPageLong
 
fillChunkAppend(ChunkSource.FillContext, WritableChunk<? super ATTR>, RowSequence) - Method in class io.deephaven.enterprise.sources.regioned.impl.BufferedPageShort
 
fillChunkAppend(ChunkSource.FillContext, WritableChunk<? super ATTR>, RowSequence) - Method in class io.deephaven.enterprise.sources.regioned.impl.ColumnRegionObjectCached
 
fillChunkAppend(ChunkSource.FillContext, WritableChunk<? super ATTR>, RowSequence) - Method in class io.deephaven.enterprise.sources.regioned.impl.ColumnRegionObjectWithDictionary
 
fillChunkAppend(ChunkSource.FillContext, WritableChunk, RowSequence.Iterator) - Method in class io.deephaven.enterprise.compatibility.region.ObjectColumnRegionAdapter
 
fillChunkAppend(ChunkSource.FillContext, WritableChunk<? super ATTR>, RowSequence) - Method in class io.deephaven.enterprise.sources.regioned.impl.ColumnRegionObjectCodecFixed
 
fillChunkAppend(ChunkSource.FillContext, WritableChunk<? super ATTR>, RowSequence) - Method in class io.deephaven.enterprise.sources.regioned.impl.ColumnRegionObjectCodecVariable
 
fillChunkAppend(ChunkSource.FillContext, WritableChunk<? super ATTR>, RowSequence) - Method in class io.deephaven.enterprise.sources.regioned.impl.ColumnRegionStringSet
 
fillChunkAppend(ChunkSource.FillContext, WritableChunk, RowSequence.Iterator) - Method in class io.deephaven.enterprise.compatibility.region.ByteColumnRegionAdapter
 
fillChunkAppend(ChunkSource.FillContext, WritableChunk, RowSequence.Iterator) - Method in class io.deephaven.enterprise.compatibility.region.CharColumnRegionAdapter
 
fillChunkAppend(ChunkSource.FillContext, WritableChunk, RowSequence.Iterator) - Method in class io.deephaven.enterprise.compatibility.region.DoubleColumnRegionAdapter
 
fillChunkAppend(ChunkSource.FillContext, WritableChunk, RowSequence.Iterator) - Method in class io.deephaven.enterprise.compatibility.region.FloatColumnRegionAdapter
 
fillChunkAppend(ChunkSource.FillContext, WritableChunk, RowSequence.Iterator) - Method in class io.deephaven.enterprise.compatibility.region.IntColumnRegionAdapter
 
fillChunkAppend(ChunkSource.FillContext, WritableChunk, RowSequence.Iterator) - Method in class io.deephaven.enterprise.compatibility.region.LongColumnRegionAdapter
 
fillChunkAppend(ChunkSource.FillContext, WritableChunk, RowSequence.Iterator) - Method in class io.deephaven.enterprise.compatibility.region.ShortColumnRegionAdapter
 
FillContextWrapper - Class in io.deephaven.enterprise.compatibility.chunk
An adapter FillContext for use when an Enterprise chunk must be filled by a Community source.
FillContextWrapper(ChunkSource.FillContext, ChunkType) - Constructor for class io.deephaven.enterprise.compatibility.chunk.FillContextWrapper
 
fillKeyIndicesChunk(WritableLongChunk<? extends Attributes.KeyIndices>) - Method in class io.deephaven.enterprise.compatibility.rowset.RowSequenceToOrderedKeysAdapter
 
fillKeyRangesChunk(WritableLongChunk<Attributes.OrderedKeyRanges>) - Method in class io.deephaven.enterprise.compatibility.rowset.RowSequenceToOrderedKeysAdapter
 
fillPrevChunk(ChunkSource.FillContext, WritableChunk<? super Attributes.Values>, OrderedKeys) - Method in class io.deephaven.enterprise.compatibility.filter.ColumnSourceAdapterForFilter
 
fillRowKeyChunk(WritableLongChunk<? super OrderedRowKeys>) - Method in class io.deephaven.enterprise.compatibility.rowset.OrderedKeysToRowSequenceAdapter
 
fillRowKeyRangesChunk(WritableLongChunk<OrderedRowKeyRanges>) - Method in class io.deephaven.enterprise.compatibility.rowset.OrderedKeysToRowSequenceAdapter
 
filter() - Method in interface io.deephaven.enterprise.remote.SubscriptionOptions
Get the Filter to be applied in conjunction with SubscriptionOptions.filters() before subscribing to the table.
filter(RowSet, RowSet, Table, boolean) - Method in class io.deephaven.enterprise.compatibility.filter.EnterpriseFilterAdapter
 
filter(Filter) - Method in interface io.deephaven.enterprise.remote.SubscriptionOptions.Builder
Set the Filter to apply in conjunction with SubscriptionOptions.filters() before subscribing.
FilterCompatibility - Class in io.deephaven.enterprise.compatibility.filter
 
FilterCompatibility() - Constructor for class io.deephaven.enterprise.compatibility.filter.FilterCompatibility
 
FilterGeneratorAdapter - Class in io.deephaven.enterprise.acl.generator
 
FilterGeneratorAdapter(FilterGenerator, PermissionFilterProvider, Database) - Constructor for class io.deephaven.enterprise.acl.generator.FilterGeneratorAdapter
 
filters() - Method in interface io.deephaven.enterprise.remote.SubscriptionOptions
Get the list of filters to be applied in conjunction with SubscriptionOptions.filter() before subscribing to the table.
FILTERS_FIELD_NUMBER - Static variable in class io.deephaven.proto.pivot.PivotTableApplyRequest
 
findKeys(Consumer<EnterpriseTableLocationKey>) - Method in class io.deephaven.enterprise.locations.hive.HiveKeyFinder
 
findKeys(Consumer<EnterpriseTableLocationKey>) - Method in class io.deephaven.enterprise.locations.hive.HiveLocationsTableKeyFinder
 
findKeys(Consumer<EnterpriseTableLocationKey>) - Method in class io.deephaven.enterprise.locations.nestedpartitioned.MetadataIndexKeyFinder
 
firstBy(SelectColumn...) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
firstKey() - Method in class io.deephaven.enterprise.compatibility.rowset.RowSequenceToOrderedKeysAdapter
 
firstRowKey() - Method in class io.deephaven.enterprise.compatibility.rowset.OrderedKeysToRowSequenceAdapter
 
firstRowOffset() - Method in interface io.deephaven.enterprise.sources.regioned.BufferedPage
 
fixedColumnPartition() - Method in class io.deephaven.enterprise.database.SystemTableLogger.Options
What column partition should we write to?
fixedColumnPartition(String) - Method in interface io.deephaven.enterprise.database.SystemTableLogger.Options.Builder
What column partition should we write to?
FixedPartitionedEnterpriseTableLocationKey - Interface in io.deephaven.enterprise.locations
This class represents an instance of a legacy style Deephaven table where there are two fixed partitions, the column partition and the internal partition
flatten() - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
flightInfoFor(SessionState, Flight.FlightDescriptor, String) - Method in class io.deephaven.enterprise.dnd.service.ticket.DatabaseTicketResolver
 
Float - Enum constant in enum class io.deephaven.enterprise.sources.regioned.BufferedType
 
FloatColumnRegionAdapter<ATTR extends Values> - Class in io.deephaven.enterprise.compatibility.region
Adapts a Legacy ColumnRegionFloat to a Core ColumnRegionFloat.
FloatColumnRegionAdapter(ColumnRegionFloat<?>) - Constructor for class io.deephaven.enterprise.compatibility.region.FloatColumnRegionAdapter
 
forAllFlightInfo(SessionState, Consumer<Flight.FlightInfo>) - Method in class io.deephaven.enterprise.dnd.service.ticket.DatabaseTicketResolver
 
forBlink() - Static method in class io.deephaven.enterprise.database.TableOptions
Get the default TableOptions for a live blink table.
forCluster(DeephavenClusterConnection, boolean) - Static method in class io.deephaven.enterprise.remote.CorePlusClusterSessionFactory
Create a new CorePlusClusterSessionFactory for connections to the specified cluster.
forDataImportServer(DataImportServer) - Static method in class io.deephaven.enterprise.lastbystate.LastByPartitionedTableFactory
Build a LastByTableMapFactory consuming data and last-by indexes from the supplied DataImportServer.
forEachLong(LongAbortableConsumer) - Method in class io.deephaven.enterprise.compatibility.rowset.RowSequenceToOrderedKeysAdapter
 
forEachLongRange(LongRangeAbortableConsumer) - Method in class io.deephaven.enterprise.compatibility.rowset.RowSequenceToOrderedKeysAdapter
 
forEachRowKey(LongAbortableConsumer) - Method in class io.deephaven.enterprise.compatibility.rowset.OrderedKeysToRowSequenceAdapter
 
forEachRowKeyRange(LongRangeAbortableConsumer) - Method in class io.deephaven.enterprise.compatibility.rowset.OrderedKeysToRowSequenceAdapter
 
forLive() - Static method in class io.deephaven.enterprise.database.TableOptions
Get the default TableOptions for a live ticking table.
forLocalCluster() - Static method in class io.deephaven.enterprise.remote.RemoteTableBuilder
Create a new RemoteTableBuilder for the current cluster.
FORMAT_COLUMN_NAME - Static variable in class io.deephaven.enterprise.locations.hive.HiveLocationsTableKeyFinder
The column name containing the format as a String value of TableLocation.Format (either "DEEPHAVEN" or "PARQUET").
formatSnapshot(PivotTable, PivotTable.PivotSnapshot) - Static method in class io.deephaven.pivot.PivotTestUtils
Given the pivot table and a snapshot, print out a table to a string
forNumber(int) - Static method in enum class io.deephaven.proto.pivot.PivotPluginRequest.RequestCase
 
forNumber(int) - Static method in enum class io.deephaven.proto.pivot.PivotPluginResponse.ResponseCase
 
forNumber(int) - Static method in enum class io.deephaven.proto.pivot.PivotTableViewRequest.TargetCase
 
forRemoteCluster(DeephavenClusterConnection) - Static method in class io.deephaven.enterprise.remote.RemoteTableBuilder
Create a new RemoteTableBuilder to connect to the specified remote cluster.
forRemoteCluster(String) - Static method in class io.deephaven.enterprise.remote.RemoteTableBuilder
Create a new RemoteTableBuilder to connect to the specified remote cluster.
forStatic() - Static method in class io.deephaven.enterprise.database.TableOptions
Get the default TableOptions for a static table.
fromJson(String) - Static method in class io.deephaven.enterprise.iceberg.IcebergEndpoint
Create a new IcebergEndpoint from the encoded JSON string.
fullAccess() - Static method in interface io.deephaven.enterprise.acl.AclFilterGenerator
Create an AclFilterGenerator that gives full access to the table.
FullAccessFilterGenerator - Class in io.deephaven.enterprise.acl.generator
An AclFilterGenerator that provides full access to everyone.
FullAccessFilterGenerator() - Constructor for class io.deephaven.enterprise.acl.generator.FullAccessFilterGenerator
 

G

gatherDictionaryValuesRowSet(RowSet.SearchIterator, RowSequence.Iterator, RowSetBuilderSequential) - Method in class io.deephaven.enterprise.sources.regioned.impl.ColumnRegionObjectCached
 
gatherDictionaryValuesRowSet(RowSet.SearchIterator, RowSequence.Iterator, RowSetBuilderSequential) - Method in class io.deephaven.enterprise.sources.regioned.impl.ColumnRegionObjectCodecFixed
 
gatherDictionaryValuesRowSet(RowSet.SearchIterator, RowSequence.Iterator, RowSetBuilderSequential) - Method in class io.deephaven.enterprise.sources.regioned.impl.ColumnRegionObjectCodecVariable
 
generateFilter(AclSupport, UserContext, String, String, boolean) - Method in interface io.deephaven.enterprise.acl.AclFilterGenerator
Generate a filter for a table access.
generateFilter(AclSupport, UserContext, String, String, boolean) - Method in class io.deephaven.enterprise.acl.generator.CombiningFilterGenerator
Generate a filter for table access, combining the filters between groups as specified.
generateFilter(AclSupport, UserContext, String, String, boolean) - Method in class io.deephaven.enterprise.acl.generator.ConjunctiveFilterGenerator
 
generateFilter(AclSupport, UserContext, String, String, boolean) - Method in class io.deephaven.enterprise.acl.generator.DisjunctiveFilterGenerator
 
generateFilter(AclSupport, UserContext, String, String, boolean) - Method in class io.deephaven.enterprise.acl.generator.FilterGeneratorAdapter
 
generateFilter(AclSupport, UserContext, String, String, boolean) - Method in class io.deephaven.enterprise.acl.generator.FullAccessFilterGenerator
 
generateFilter(AclSupport, UserContext, String, String, boolean) - Method in class io.deephaven.enterprise.acl.generator.NoAccessFilterGenerator
 
generateFilter(AclSupport, UserContext, String, String, boolean) - Method in class io.deephaven.enterprise.acl.generator.SimpleFilterGenerator
 
generateFilter(AclSupport, UserContext, String, String, boolean) - Method in class io.deephaven.enterprise.acl.generator.WhereInFilterGenerator
 
generateLocationsTable(File, Schema) - Static method in class io.deephaven.enterprise.locations.hive.HiveLocationsTableKeyFinder
Produce an in-memory table containing the files and relevant metadata for a given directory.
GenericObjectTransformer - Class in io.deephaven.enterprise.acl.transform
A Transformer for handling ACLs on generic objects.
get() - Static method in class io.deephaven.enterprise.dnd.ProcessInfoId
 
get() - Static method in class io.deephaven.enterprise.secrets.SecretsService
Get the extended storage service.
get() - Static method in class io.deephaven.enterprise.tabledataservice.extended.ExtendedStorageService
Get the extended storage service.
get(int) - Method in class io.deephaven.enterprise.pivot.flatbuf.PivotUpdateMetadata.Vector
 
get(long) - Method in class io.deephaven.enterprise.compatibility.filter.ColumnSourceAdapterForFilter
 
get(long) - Method in interface io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClient
Get the info for the specified query serial.
get(long) - Method in class io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClientImpl
 
get(long) - Method in class io.deephaven.enterprise.sources.regioned.impl.ReversibleCache
 
get(GroupProvider) - Static method in class io.deephaven.enterprise.acl.transform.GenericObjectTransformer
Get the singleton instance of this transformer.
get(String) - Method in interface io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClient
Get the info for the specified query name.
get(String) - Method in class io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClientImpl
 
get(String, String) - Method in interface io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClient
Get the info for the specified query owner and name.
get(String, String) - Method in class io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClientImpl
 
get(Database) - Method in class io.deephaven.enterprise.dnd.query.util.perf.PerformanceOverview
If process info id is not specified, then it will be inferred by other inputs like worker or PQ name.
get(PivotUpdateMetadata, int) - Method in class io.deephaven.enterprise.pivot.flatbuf.PivotUpdateMetadata.Vector
 
GET_DESCRIPTOR - Enum constant in enum class io.deephaven.proto.pivot.PivotPluginRequest.RequestCase
 
GET_DESCRIPTOR - Enum constant in enum class io.deephaven.proto.pivot.PivotPluginResponse.ResponseCase
 
GET_DESCRIPTOR_FIELD_NUMBER - Static variable in class io.deephaven.proto.pivot.PivotPluginRequest
 
GET_DESCRIPTOR_FIELD_NUMBER - Static variable in class io.deephaven.proto.pivot.PivotPluginResponse
 
getAggregations() - Method in interface io.deephaven.pivot.PivotTable
Get the aggregations used to construct this PivotTable.
getAggregations(int) - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
aggregations for the values
getAggregations(int) - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest
aggregations for the values
getAggregations(int) - Method in interface io.deephaven.proto.pivot.PivotTableCreationRequestOrBuilder
aggregations for the values
getAggregationsBuilder(int) - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
aggregations for the values
getAggregationsBuilderList() - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
aggregations for the values
getAggregationsCount() - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
aggregations for the values
getAggregationsCount() - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest
aggregations for the values
getAggregationsCount() - Method in interface io.deephaven.proto.pivot.PivotTableCreationRequestOrBuilder
aggregations for the values
getAggregationsList() - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
aggregations for the values
getAggregationsList() - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest
aggregations for the values
getAggregationsList() - Method in interface io.deephaven.proto.pivot.PivotTableCreationRequestOrBuilder
aggregations for the values
getAggregationsOrBuilder(int) - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
aggregations for the values
getAggregationsOrBuilder(int) - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest
aggregations for the values
getAggregationsOrBuilder(int) - Method in interface io.deephaven.proto.pivot.PivotTableCreationRequestOrBuilder
aggregations for the values
getAggregationsOrBuilderList() - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
aggregations for the values
getAggregationsOrBuilderList() - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest
aggregations for the values
getAggregationsOrBuilderList() - Method in interface io.deephaven.proto.pivot.PivotTableCreationRequestOrBuilder
aggregations for the values
getAllGroups() - Method in class io.deephaven.enterprise.test.PFPBackedTestGroupProvider
 
getAllowedGroups(T) - Method in class io.deephaven.enterprise.acl.transform.GenericObjectTransformer
 
getAllowedGroups(T) - Method in class io.deephaven.enterprise.acl.transform.HierarchicalTableTicketTransformer
 
getAllowedGroups(T) - Method in class io.deephaven.enterprise.acl.transform.PivotTableTicketTransformer
 
getAllowedGroups(T) - Method in class io.deephaven.enterprise.acl.transform.TableTicketTransformer
 
getAllowedGroups(T) - Method in interface io.deephaven.enterprise.dnd.authentication.transform.TicketTransformer
Get a set of groups that may access the specified object.
getAllUsers() - Method in class io.deephaven.enterprise.test.PFPBackedTestGroupProvider
 
getApplicationServiceAuthWiring() - Method in class io.deephaven.enterprise.dnd.authentication.DheAuthorizationProvider
 
getApply() - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
.io.deephaven.proto.pivot.PivotTableApplyRequest apply = 6;
getApply() - Method in class io.deephaven.proto.pivot.PivotPluginRequest
.io.deephaven.proto.pivot.PivotTableApplyRequest apply = 6;
getApply() - Method in interface io.deephaven.proto.pivot.PivotPluginRequestOrBuilder
.io.deephaven.proto.pivot.PivotTableApplyRequest apply = 6;
getApply() - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
.io.deephaven.proto.pivot.PivotTableApplyResponse apply = 7;
getApply() - Method in class io.deephaven.proto.pivot.PivotPluginResponse
.io.deephaven.proto.pivot.PivotTableApplyResponse apply = 7;
getApply() - Method in interface io.deephaven.proto.pivot.PivotPluginResponseOrBuilder
.io.deephaven.proto.pivot.PivotTableApplyResponse apply = 7;
getApplyBuilder() - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
.io.deephaven.proto.pivot.PivotTableApplyRequest apply = 6;
getApplyBuilder() - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
.io.deephaven.proto.pivot.PivotTableApplyResponse apply = 7;
getApplyOrBuilder() - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
.io.deephaven.proto.pivot.PivotTableApplyRequest apply = 6;
getApplyOrBuilder() - Method in class io.deephaven.proto.pivot.PivotPluginRequest
.io.deephaven.proto.pivot.PivotTableApplyRequest apply = 6;
getApplyOrBuilder() - Method in interface io.deephaven.proto.pivot.PivotPluginRequestOrBuilder
.io.deephaven.proto.pivot.PivotTableApplyRequest apply = 6;
getApplyOrBuilder() - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
.io.deephaven.proto.pivot.PivotTableApplyResponse apply = 7;
getApplyOrBuilder() - Method in class io.deephaven.proto.pivot.PivotPluginResponse
.io.deephaven.proto.pivot.PivotTableApplyResponse apply = 7;
getApplyOrBuilder() - Method in interface io.deephaven.proto.pivot.PivotPluginResponseOrBuilder
.io.deephaven.proto.pivot.PivotTableApplyResponse apply = 7;
getAttribute(String) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
getAttributeNames() - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
getAttributes(Collection<String>) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
getAuthenticatedUser() - Method in class io.deephaven.enterprise.dnd.authentication.DheAuthContext
 
getAuthenticatedUser() - Method in class io.deephaven.enterprise.dnd.ProcessInfo
 
getAuthenticationClient() - Method in class io.deephaven.enterprise.dnd.client.DeephavenClusterConnection
Get the AuthenticationClient for the cluster.
getAuthType() - Method in class io.deephaven.enterprise.dnd.authentication.DheAuthenticationHandler
 
getAverageRunLengthEstimate() - Method in class io.deephaven.enterprise.compatibility.rowset.OrderedKeysToRowSequenceAdapter
 
getAverageRunLengthEstimate() - Method in class io.deephaven.enterprise.compatibility.rowset.RowSequenceToOrderedKeysAdapter
 
getBarrageSession() - Method in class io.deephaven.enterprise.dnd.client.DndSessionBarrage
Get the underlying barrage session for this client.
getBoolean(long) - Method in class io.deephaven.enterprise.compatibility.filter.ColumnSourceAdapterForFilter
 
getBufferProvider() - Method in interface io.deephaven.enterprise.sources.regioned.BufferedColumnRegion
 
getBufferProvider() - Method in class io.deephaven.enterprise.sources.regioned.impl.BufferedColumnRegionBase
 
getBufferSize() - Method in enum class io.deephaven.enterprise.sources.regioned.BufferedType
 
getByte(long) - Method in class io.deephaven.enterprise.compatibility.filter.ColumnSourceAdapterForFilter
 
getByte(long) - Method in class io.deephaven.enterprise.compatibility.region.ByteColumnRegionAdapter
 
getByte(long) - Method in class io.deephaven.enterprise.sources.regioned.impl.BufferedColumnRegionByte
 
getByte(ChunkSource.FillContext, long) - Method in class io.deephaven.enterprise.sources.regioned.impl.BufferedColumnRegionByte
 
getByteOrder() - Method in interface io.deephaven.enterprise.locations.DeephavenFormatColumnLocation
Get the ByteOrder used by all FileDataBufferStores associated with this column location.
getByteOrder() - Method in class io.deephaven.enterprise.locations.local.deephaven.OnDiskDeephavenColumnLocation
 
getBytes() - Method in enum class io.deephaven.enterprise.sources.regioned.BufferedType
 
getBytes(long, byte[], int, int) - Method in class io.deephaven.enterprise.compatibility.region.ByteColumnRegionAdapter
 
getBytes(long, byte[], int, int) - Method in class io.deephaven.enterprise.sources.regioned.impl.BufferedColumnRegionByte
 
getCache() - Method in class io.deephaven.enterprise.sources.regioned.impl.ColumnRegionObjectCached
 
getCatalogName() - Method in class io.deephaven.enterprise.iceberg.IcebergConfiguration
Get the optional catalog name.
getCatalogTable() - Method in interface io.deephaven.enterprise.database.Database
Retrieve a table containing the tables that exist in this database.
getCatalogTable() - Method in class io.deephaven.enterprise.database.impl.DatabaseImpl
 
getCatalogTable() - Method in class io.deephaven.enterprise.replay.ReplayDatabase
 
getCatalogType() - Method in class io.deephaven.enterprise.iceberg.IcebergConfiguration
Get the catalog type.
getCatalogUri() - Method in class io.deephaven.enterprise.iceberg.IcebergConfiguration
Get the URI of the catalog.
getChannel() - Method in class io.deephaven.enterprise.remote.CorePlusClusterSessionFactory.SessionAndChannel
 
getChar(long) - Method in class io.deephaven.enterprise.compatibility.filter.ColumnSourceAdapterForFilter
 
getChar(long) - Method in class io.deephaven.enterprise.compatibility.region.CharColumnRegionAdapter
 
getChar(long) - Method in class io.deephaven.enterprise.sources.regioned.impl.BufferedColumnRegionChar
 
getChar(ChunkSource.FillContext, long) - Method in class io.deephaven.enterprise.sources.regioned.impl.BufferedColumnRegionChar
 
getChunk(ChunkSource.GetContext, long, long) - Method in class io.deephaven.enterprise.compatibility.region.ObjectColumnRegionAdapter
 
getChunk(ChunkSource.GetContext, RowSequence) - Method in class io.deephaven.enterprise.compatibility.region.ObjectColumnRegionAdapter
 
getChunk(ChunkSource.GetContext, long, long) - Method in class io.deephaven.enterprise.compatibility.region.ByteColumnRegionAdapter
 
getChunk(ChunkSource.GetContext, long, long) - Method in class io.deephaven.enterprise.compatibility.region.CharColumnRegionAdapter
 
getChunk(ChunkSource.GetContext, long, long) - Method in class io.deephaven.enterprise.compatibility.region.DoubleColumnRegionAdapter
 
getChunk(ChunkSource.GetContext, long, long) - Method in class io.deephaven.enterprise.compatibility.region.FloatColumnRegionAdapter
 
getChunk(ChunkSource.GetContext, long, long) - Method in class io.deephaven.enterprise.compatibility.region.IntColumnRegionAdapter
 
getChunk(ChunkSource.GetContext, long, long) - Method in class io.deephaven.enterprise.compatibility.region.LongColumnRegionAdapter
 
getChunk(ChunkSource.GetContext, long, long) - Method in class io.deephaven.enterprise.compatibility.region.ShortColumnRegionAdapter
 
getChunk(ChunkSource.GetContext, RowSequence) - Method in class io.deephaven.enterprise.compatibility.region.ByteColumnRegionAdapter
 
getChunk(ChunkSource.GetContext, RowSequence) - Method in class io.deephaven.enterprise.compatibility.region.CharColumnRegionAdapter
 
getChunk(ChunkSource.GetContext, RowSequence) - Method in class io.deephaven.enterprise.compatibility.region.DoubleColumnRegionAdapter
 
getChunk(ChunkSource.GetContext, RowSequence) - Method in class io.deephaven.enterprise.compatibility.region.FloatColumnRegionAdapter
 
getChunk(ChunkSource.GetContext, RowSequence) - Method in class io.deephaven.enterprise.compatibility.region.IntColumnRegionAdapter
 
getChunk(ChunkSource.GetContext, RowSequence) - Method in class io.deephaven.enterprise.compatibility.region.LongColumnRegionAdapter
 
getChunk(ChunkSource.GetContext, RowSequence) - Method in class io.deephaven.enterprise.compatibility.region.ShortColumnRegionAdapter
 
getChunkType() - Method in class io.deephaven.enterprise.sources.regioned.impl.BufferedPageByte
 
getChunkType() - Method in class io.deephaven.enterprise.sources.regioned.impl.BufferedPageChar
 
getChunkType() - Method in class io.deephaven.enterprise.sources.regioned.impl.BufferedPageDouble
 
getChunkType() - Method in class io.deephaven.enterprise.sources.regioned.impl.BufferedPageFloat
 
getChunkType() - Method in class io.deephaven.enterprise.sources.regioned.impl.BufferedPageInt
 
getChunkType() - Method in class io.deephaven.enterprise.sources.regioned.impl.BufferedPageIntAsLong
 
getChunkType() - Method in class io.deephaven.enterprise.sources.regioned.impl.BufferedPageLong
 
getChunkType() - Method in class io.deephaven.enterprise.sources.regioned.impl.BufferedPageShort
 
getCodecAdapterClassName(String) - Static method in class io.deephaven.enterprise.compatibility.CodecCompatibility
 
getCodecArgs(TableDefinition, String) - Static method in class io.deephaven.enterprise.compatibility.CodecCompatibility
 
getCodecArgs(String) - Method in class io.deephaven.enterprise.locations.local.deephaven.OnDiskDeephavenTableLocation
 
getCodecArgs(String) - Method in class io.deephaven.enterprise.locations.remote.RemoteDeephavenTableLocation
 
getCodecArgs(String, String, Class<?>) - Static method in class io.deephaven.enterprise.compatibility.CodecCompatibility
 
getCodecName(TableDefinition, String) - Static method in class io.deephaven.enterprise.compatibility.CodecCompatibility
 
getCodecName(String) - Method in class io.deephaven.enterprise.locations.local.deephaven.OnDiskDeephavenTableLocation
 
getCodecName(String) - Method in class io.deephaven.enterprise.locations.remote.RemoteDeephavenTableLocation
 
getCodecName(String, Class<?>) - Static method in class io.deephaven.enterprise.compatibility.CodecCompatibility
 
getColumn(String) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
getColumnArrays() - Method in class io.deephaven.enterprise.compatibility.filter.EnterpriseFilterAdapter
 
getColumnByColumns() - Method in interface io.deephaven.pivot.PivotTable
Get the column keys used to create this Pivot.
getColumnDepthColumn() - Method in interface io.deephaven.pivot.PivotTable
Get the name of a column that denotes column depth.
getColumnExpandedColumn() - Method in interface io.deephaven.pivot.PivotTable
Get the name of a column of Booleans that denotes whether a column is expanded (or expandable).
getColumnFileBufferStore(ColumnFileType) - Method in interface io.deephaven.enterprise.locations.DeephavenFormatColumnLocation
Get the FileDataBufferStore for buffers from this column location for the specified ColumnFileType.
getColumnFileBufferStore(ColumnFileType) - Method in class io.deephaven.enterprise.locations.local.deephaven.OnDiskDeephavenColumnLocation
 
getColumnFilters(AclSupport, UserContext, String[], boolean) - Method in interface io.deephaven.enterprise.acl.EdgeAclProvider
Get the column ACLs to apply to requested tables.
getColumnFilters(AclSupport, UserContext, String[], boolean) - Method in class io.deephaven.enterprise.acl.impl.EdgeAclImpl
 
getColumnFilters(AclSupport, String, String, String[], boolean) - Method in class io.deephaven.enterprise.acl.impl.EnterpriseAclAdapterProvider
 
getColumnFilters(AclSupport, String, String, String[], boolean) - Method in interface io.deephaven.enterprise.acl.SourceAclProvider
Get the column ACLs to apply to requested tables.
getColumnKeys(int) - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
first reference is the input table
getColumnKeys(int) - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest
first reference is the input table
getColumnKeys(int) - Method in interface io.deephaven.proto.pivot.PivotTableCreationRequestOrBuilder
first reference is the input table
getColumnKeysBytes(int) - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
first reference is the input table
getColumnKeysBytes(int) - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest
first reference is the input table
getColumnKeysBytes(int) - Method in interface io.deephaven.proto.pivot.PivotTableCreationRequestOrBuilder
first reference is the input table
getColumnKeysCount() - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
first reference is the input table
getColumnKeysCount() - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest
first reference is the input table
getColumnKeysCount() - Method in interface io.deephaven.proto.pivot.PivotTableCreationRequestOrBuilder
first reference is the input table
getColumnKeysList() - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
first reference is the input table
getColumnKeysList() - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest
first reference is the input table
getColumnKeysList() - Method in interface io.deephaven.proto.pivot.PivotTableCreationRequestOrBuilder
first reference is the input table
getColumnKeyTable() - Method in class io.deephaven.pivot.PivotTableView
 
getColumnKeyTableActionColumn() - Method in class io.deephaven.pivot.PivotTableView
 
getColumnKeyTableActionColumn() - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage.Builder
The name of a column of bytes found in the key table that specifies the action desired for the node selected by the other columns for each row.
getColumnKeyTableActionColumn() - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage
The name of a column of bytes found in the key table that specifies the action desired for the node selected by the other columns for each row.
getColumnKeyTableActionColumn() - Method in interface io.deephaven.proto.pivot.PivotTableViewExpansionsMessageOrBuilder
The name of a column of bytes found in the key table that specifies the action desired for the node selected by the other columns for each row.
getColumnKeyTableActionColumnBytes() - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage.Builder
The name of a column of bytes found in the key table that specifies the action desired for the node selected by the other columns for each row.
getColumnKeyTableActionColumnBytes() - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage
The name of a column of bytes found in the key table that specifies the action desired for the node selected by the other columns for each row.
getColumnKeyTableActionColumnBytes() - Method in interface io.deephaven.proto.pivot.PivotTableViewExpansionsMessageOrBuilder
The name of a column of bytes found in the key table that specifies the action desired for the node selected by the other columns for each row.
getColumnKeyTableOffset() - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage.Builder
Offset (in the references) of a Table of expanded or contracted keys from a PivotTable (RollupTable or TreeTable).
getColumnKeyTableOffset() - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage
Offset (in the references) of a Table of expanded or contracted keys from a PivotTable (RollupTable or TreeTable).
getColumnKeyTableOffset() - Method in interface io.deephaven.proto.pivot.PivotTableViewExpansionsMessageOrBuilder
Offset (in the references) of a Table of expanded or contracted keys from a PivotTable (RollupTable or TreeTable).
getColumnLocation(CharSequence) - Method in class io.deephaven.enterprise.locations.local.HybridSnapshotBackedTableLocation
 
getColumns() - Method in class io.deephaven.enterprise.compatibility.filter.EnterpriseFilterAdapter
 
getColumns(BarrageSubscriptionRequest) - Static method in class io.deephaven.pivot.PivotTableViewExchangeMarshaller
Helper to retrieve the viewport columns from a subscription request.
getColumnSortableColumns() - Method in interface io.deephaven.pivot.PivotTable
The set of column names that can be column sorted.
getColumnSorts(int) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor column_sorts = 2;
getColumnSorts(int) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor column_sorts = 2;
getColumnSorts(int) - Method in interface io.deephaven.proto.pivot.PivotTableApplyRequestOrBuilder
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor column_sorts = 2;
getColumnSortsBuilder(int) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor column_sorts = 2;
getColumnSortsBuilderList() - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor column_sorts = 2;
getColumnSortsCount() - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor column_sorts = 2;
getColumnSortsCount() - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor column_sorts = 2;
getColumnSortsCount() - Method in interface io.deephaven.proto.pivot.PivotTableApplyRequestOrBuilder
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor column_sorts = 2;
getColumnSortsList() - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor column_sorts = 2;
getColumnSortsList() - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor column_sorts = 2;
getColumnSortsList() - Method in interface io.deephaven.proto.pivot.PivotTableApplyRequestOrBuilder
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor column_sorts = 2;
getColumnSortsOrBuilder(int) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor column_sorts = 2;
getColumnSortsOrBuilder(int) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor column_sorts = 2;
getColumnSortsOrBuilder(int) - Method in interface io.deephaven.proto.pivot.PivotTableApplyRequestOrBuilder
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor column_sorts = 2;
getColumnSortsOrBuilderList() - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor column_sorts = 2;
getColumnSortsOrBuilderList() - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor column_sorts = 2;
getColumnSortsOrBuilderList() - Method in interface io.deephaven.proto.pivot.PivotTableApplyRequestOrBuilder
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor column_sorts = 2;
getColumnSource(String) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
getColumnSourceMap() - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
getColumnSources() - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
getColumnStructuralColumns() - Method in interface io.deephaven.pivot.PivotTable
 
getColumnTableDefinition() - Method in interface io.deephaven.pivot.PivotTable
 
getColumnVersion() - Method in class io.deephaven.enterprise.locations.hive.SimpleLocationSnapshot
 
getComponentType() - Method in class io.deephaven.enterprise.compatibility.filter.ColumnSourceAdapterForFilter
 
getConfig() - Method in interface io.deephaven.enterprise.iceberg.discovery.DiscoveryResult
Get the DiscoveryConfig used for the discovery.
getConfig() - Method in class io.deephaven.enterprise.iceberg.discovery.DiscoveryResultImpl
 
getConfigServiceAuthWiring() - Method in class io.deephaven.enterprise.dnd.authentication.DheAuthorizationProvider
 
getConfiguration() - Method in interface io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClient
getConfiguration() - Method in class io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClientImpl
 
getConfiguration() - Method in class io.deephaven.enterprise.iceberg.IcebergEndpoint
Get the configuration parameters needed to connect to an Iceberg Catalog and fetch Iceberg Tables.
getConsoleServiceAuthWiring() - Method in class io.deephaven.enterprise.dnd.authentication.DheAuthorizationProvider
 
getConstructorArguments() - Method in class io.deephaven.enterprise.ingester.impl.ImportStateDetails
 
getConstructorTypes() - Method in class io.deephaven.enterprise.ingester.impl.ImportStateDetails
 
getContents() - Method in class io.deephaven.enterprise.dnd.notebook.NotebookReader.FileOrFolder
 
getControllerClient() - Method in class io.deephaven.enterprise.dnd.client.DeephavenClusterConnection
Get the controller client for the cluster.
getControllerClient() - Method in class io.deephaven.enterprise.remote.CorePlusClusterSessionFactory
Get a subscribed PersistentQueryControllerClient for this cluster.
getCoreDefinition() - Method in class io.deephaven.enterprise.kafkawriter.SchemaHelper
Constructs a Core TableDefinition instance.
getCreation() - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
.io.deephaven.proto.pivot.PivotTableCreationRequest creation = 5;
getCreation() - Method in class io.deephaven.proto.pivot.PivotPluginRequest
.io.deephaven.proto.pivot.PivotTableCreationRequest creation = 5;
getCreation() - Method in interface io.deephaven.proto.pivot.PivotPluginRequestOrBuilder
.io.deephaven.proto.pivot.PivotTableCreationRequest creation = 5;
getCreation() - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
.io.deephaven.proto.pivot.PivotTableCreationResponse creation = 6;
getCreation() - Method in class io.deephaven.proto.pivot.PivotPluginResponse
.io.deephaven.proto.pivot.PivotTableCreationResponse creation = 6;
getCreation() - Method in interface io.deephaven.proto.pivot.PivotPluginResponseOrBuilder
.io.deephaven.proto.pivot.PivotTableCreationResponse creation = 6;
getCreationBuilder() - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
.io.deephaven.proto.pivot.PivotTableCreationRequest creation = 5;
getCreationBuilder() - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
.io.deephaven.proto.pivot.PivotTableCreationResponse creation = 6;
getCreationOrBuilder() - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
.io.deephaven.proto.pivot.PivotTableCreationRequest creation = 5;
getCreationOrBuilder() - Method in class io.deephaven.proto.pivot.PivotPluginRequest
.io.deephaven.proto.pivot.PivotTableCreationRequest creation = 5;
getCreationOrBuilder() - Method in interface io.deephaven.proto.pivot.PivotPluginRequestOrBuilder
.io.deephaven.proto.pivot.PivotTableCreationRequest creation = 5;
getCreationOrBuilder() - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
.io.deephaven.proto.pivot.PivotTableCreationResponse creation = 6;
getCreationOrBuilder() - Method in class io.deephaven.proto.pivot.PivotPluginResponse
.io.deephaven.proto.pivot.PivotTableCreationResponse creation = 6;
getCreationOrBuilder() - Method in interface io.deephaven.proto.pivot.PivotPluginResponseOrBuilder
.io.deephaven.proto.pivot.PivotTableCreationResponse creation = 6;
getDataCopy() - Method in interface io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClient
Get a copy of the current set of query data.
getDataCopy() - Method in class io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClientImpl
 
getDataIndex(String...) - Method in class io.deephaven.enterprise.locations.local.HybridSnapshotBackedTableLocation
 
getDataIndexColumns() - Method in class io.deephaven.enterprise.locations.local.deephaven.OnDiskDeephavenTableLocation
 
getDataIndexColumns() - Method in class io.deephaven.enterprise.locations.local.HybridSnapshotBackedTableLocation
 
getDataIndexColumns() - Method in class io.deephaven.enterprise.locations.remote.RemoteDeephavenTableLocation
 
getDataInstructions() - Method in class io.deephaven.enterprise.iceberg.IcebergEndpoint
Get the IcebergDataInstructions that can be used to create appropriate instructions for use with IcebergReadInstructions.Builder.dataInstructions(Object).
getDataInstructions(Map<String, String>) - Method in interface io.deephaven.enterprise.iceberg.IcebergDataInstructions
Get a completed data instructions instance to use for fetching data from the underlying storage.
getDataInstructions(Map<String, String>) - Method in class io.deephaven.enterprise.iceberg.IcebergS3Instructions
 
getDataInstructionsProvider() - Method in interface io.deephaven.enterprise.iceberg.discovery.DiscoveryResult
Get the DataInstructionsProviderLoader for use with Iceberg locations.
getDataInstructionsProvider() - Method in class io.deephaven.enterprise.iceberg.discovery.DiscoveryResultImpl
 
getDatePartitions(Table) - Static method in class io.deephaven.enterprise.database.inputtables.InputTableSnapshotter
Retrieve date partition values from a table.
getDefaultInstance() - Static method in class io.deephaven.proto.pivot.ErrorResponse
 
getDefaultInstance() - Static method in class io.deephaven.proto.pivot.PivotPluginRequest
 
getDefaultInstance() - Static method in class io.deephaven.proto.pivot.PivotPluginResponse
 
getDefaultInstance() - Static method in class io.deephaven.proto.pivot.PivotTableApplyRequest
 
getDefaultInstance() - Static method in class io.deephaven.proto.pivot.PivotTableApplyResponse
 
getDefaultInstance() - Static method in class io.deephaven.proto.pivot.PivotTableCreationRequest
 
getDefaultInstance() - Static method in class io.deephaven.proto.pivot.PivotTableCreationResponse
 
getDefaultInstance() - Static method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage
 
getDefaultInstance() - Static method in class io.deephaven.proto.pivot.PivotTableDescriptorRequest
 
getDefaultInstance() - Static method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse
 
getDefaultInstance() - Static method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest
 
getDefaultInstance() - Static method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse
 
getDefaultInstance() - Static method in class io.deephaven.proto.pivot.PivotTableSourceExportRequest
 
getDefaultInstance() - Static method in class io.deephaven.proto.pivot.PivotTableSourceExportResponse
 
getDefaultInstance() - Static method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage
 
getDefaultInstance() - Static method in class io.deephaven.proto.pivot.PivotTableViewRequest
 
getDefaultInstance() - Static method in class io.deephaven.proto.pivot.PivotTableViewResponse
 
getDefaultInstance() - Static method in class io.deephaven.proto.pqworker.ListenErrorRequest
 
getDefaultInstance() - Static method in class io.deephaven.proto.pqworker.ListenErrorResponse
 
getDefaultInstance() - Static method in class io.deephaven.proto.pqworker.ObjectAccessRequest
 
getDefaultInstance() - Static method in class io.deephaven.proto.pqworker.ObjectAccessResponse
 
getDefaultInstance() - Static method in class io.deephaven.proto.pqworker.StringList
 
getDefaultInstance() - Static method in class io.deephaven.proto.pqworker.ThreadDumpRequest
 
getDefaultInstance() - Static method in class io.deephaven.proto.pqworker.ThreadDumpResponse
 
getDefaultInstanceForType() - Method in class io.deephaven.proto.pivot.ErrorResponse.Builder
 
getDefaultInstanceForType() - Method in class io.deephaven.proto.pivot.ErrorResponse
 
getDefaultInstanceForType() - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
 
getDefaultInstanceForType() - Method in class io.deephaven.proto.pivot.PivotPluginRequest
 
getDefaultInstanceForType() - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
 
getDefaultInstanceForType() - Method in class io.deephaven.proto.pivot.PivotPluginResponse
 
getDefaultInstanceForType() - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
 
getDefaultInstanceForType() - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest
 
getDefaultInstanceForType() - Method in class io.deephaven.proto.pivot.PivotTableApplyResponse.Builder
 
getDefaultInstanceForType() - Method in class io.deephaven.proto.pivot.PivotTableApplyResponse
 
getDefaultInstanceForType() - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
 
getDefaultInstanceForType() - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest
 
getDefaultInstanceForType() - Method in class io.deephaven.proto.pivot.PivotTableCreationResponse.Builder
 
getDefaultInstanceForType() - Method in class io.deephaven.proto.pivot.PivotTableCreationResponse
 
getDefaultInstanceForType() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage.Builder
 
getDefaultInstanceForType() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage
 
getDefaultInstanceForType() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorRequest.Builder
 
getDefaultInstanceForType() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorRequest
 
getDefaultInstanceForType() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse.Builder
 
getDefaultInstanceForType() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse
 
getDefaultInstanceForType() - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest.Builder
 
getDefaultInstanceForType() - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest
 
getDefaultInstanceForType() - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse.Builder
 
getDefaultInstanceForType() - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse
 
getDefaultInstanceForType() - Method in class io.deephaven.proto.pivot.PivotTableSourceExportRequest.Builder
 
getDefaultInstanceForType() - Method in class io.deephaven.proto.pivot.PivotTableSourceExportRequest
 
getDefaultInstanceForType() - Method in class io.deephaven.proto.pivot.PivotTableSourceExportResponse.Builder
 
getDefaultInstanceForType() - Method in class io.deephaven.proto.pivot.PivotTableSourceExportResponse
 
getDefaultInstanceForType() - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage.Builder
 
getDefaultInstanceForType() - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage
 
getDefaultInstanceForType() - Method in class io.deephaven.proto.pivot.PivotTableViewRequest.Builder
 
getDefaultInstanceForType() - Method in class io.deephaven.proto.pivot.PivotTableViewRequest
 
getDefaultInstanceForType() - Method in class io.deephaven.proto.pivot.PivotTableViewResponse.Builder
 
getDefaultInstanceForType() - Method in class io.deephaven.proto.pivot.PivotTableViewResponse
 
getDefaultInstanceForType() - Method in class io.deephaven.proto.pqworker.ListenErrorRequest.Builder
 
getDefaultInstanceForType() - Method in class io.deephaven.proto.pqworker.ListenErrorRequest
 
getDefaultInstanceForType() - Method in class io.deephaven.proto.pqworker.ListenErrorResponse.Builder
 
getDefaultInstanceForType() - Method in class io.deephaven.proto.pqworker.ListenErrorResponse
 
getDefaultInstanceForType() - Method in class io.deephaven.proto.pqworker.ObjectAccessRequest.Builder
 
getDefaultInstanceForType() - Method in class io.deephaven.proto.pqworker.ObjectAccessRequest
 
getDefaultInstanceForType() - Method in class io.deephaven.proto.pqworker.ObjectAccessResponse.Builder
 
getDefaultInstanceForType() - Method in class io.deephaven.proto.pqworker.ObjectAccessResponse
 
getDefaultInstanceForType() - Method in class io.deephaven.proto.pqworker.StringList.Builder
 
getDefaultInstanceForType() - Method in class io.deephaven.proto.pqworker.StringList
 
getDefaultInstanceForType() - Method in class io.deephaven.proto.pqworker.ThreadDumpRequest.Builder
 
getDefaultInstanceForType() - Method in class io.deephaven.proto.pqworker.ThreadDumpRequest
 
getDefaultInstanceForType() - Method in class io.deephaven.proto.pqworker.ThreadDumpResponse.Builder
 
getDefaultInstanceForType() - Method in class io.deephaven.proto.pqworker.ThreadDumpResponse
 
getDefinition() - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
getDelegate() - Method in class io.deephaven.enterprise.compatibility.chunk.FillContextWrapper
Get the delegate Community ChunkSource.FillContext for the Community source to use.
getDescription() - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
getDescription() - Method in interface io.deephaven.pivot.PivotTable
 
getDescriptor() - Static method in class io.deephaven.proto.pivot.ErrorResponse.Builder
 
getDescriptor() - Static method in class io.deephaven.proto.pivot.ErrorResponse
 
getDescriptor() - Static method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
 
getDescriptor() - Static method in class io.deephaven.proto.pivot.PivotPluginRequest
 
getDescriptor() - Static method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
 
getDescriptor() - Static method in class io.deephaven.proto.pivot.PivotPluginResponse
 
getDescriptor() - Static method in class io.deephaven.proto.pivot.Pivottable
 
getDescriptor() - Static method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
 
getDescriptor() - Static method in class io.deephaven.proto.pivot.PivotTableApplyRequest
 
getDescriptor() - Static method in class io.deephaven.proto.pivot.PivotTableApplyResponse.Builder
 
getDescriptor() - Static method in class io.deephaven.proto.pivot.PivotTableApplyResponse
 
getDescriptor() - Static method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
 
getDescriptor() - Static method in class io.deephaven.proto.pivot.PivotTableCreationRequest
 
getDescriptor() - Static method in class io.deephaven.proto.pivot.PivotTableCreationResponse.Builder
 
getDescriptor() - Static method in class io.deephaven.proto.pivot.PivotTableCreationResponse
 
getDescriptor() - Static method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage.Builder
 
getDescriptor() - Static method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage
 
getDescriptor() - Static method in class io.deephaven.proto.pivot.PivotTableDescriptorRequest.Builder
 
getDescriptor() - Static method in class io.deephaven.proto.pivot.PivotTableDescriptorRequest
 
getDescriptor() - Static method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse.Builder
 
getDescriptor() - Static method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse
 
getDescriptor() - Static method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest.Builder
 
getDescriptor() - Static method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest
 
getDescriptor() - Static method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse.Builder
 
getDescriptor() - Static method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse
 
getDescriptor() - Static method in class io.deephaven.proto.pivot.PivotTableSourceExportRequest.Builder
 
getDescriptor() - Static method in class io.deephaven.proto.pivot.PivotTableSourceExportRequest
 
getDescriptor() - Static method in class io.deephaven.proto.pivot.PivotTableSourceExportResponse.Builder
 
getDescriptor() - Static method in class io.deephaven.proto.pivot.PivotTableSourceExportResponse
 
getDescriptor() - Static method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage.Builder
 
getDescriptor() - Static method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage
 
getDescriptor() - Static method in class io.deephaven.proto.pivot.PivotTableViewRequest.Builder
 
getDescriptor() - Static method in class io.deephaven.proto.pivot.PivotTableViewRequest
 
getDescriptor() - Static method in class io.deephaven.proto.pivot.PivotTableViewResponse.Builder
 
getDescriptor() - Static method in class io.deephaven.proto.pivot.PivotTableViewResponse
 
getDescriptor() - Static method in class io.deephaven.proto.pqworker.grpc.PqworkerService
 
getDescriptor() - Static method in class io.deephaven.proto.pqworker.ListenErrorRequest.Builder
 
getDescriptor() - Static method in class io.deephaven.proto.pqworker.ListenErrorRequest
 
getDescriptor() - Static method in class io.deephaven.proto.pqworker.ListenErrorResponse.Builder
 
getDescriptor() - Static method in class io.deephaven.proto.pqworker.ListenErrorResponse
 
getDescriptor() - Static method in class io.deephaven.proto.pqworker.ObjectAccessRequest.Builder
 
getDescriptor() - Static method in class io.deephaven.proto.pqworker.ObjectAccessRequest
 
getDescriptor() - Static method in class io.deephaven.proto.pqworker.ObjectAccessResponse.Builder
 
getDescriptor() - Static method in class io.deephaven.proto.pqworker.ObjectAccessResponse
 
getDescriptor() - Static method in class io.deephaven.proto.pqworker.Pqworker
 
getDescriptor() - Static method in class io.deephaven.proto.pqworker.StringList.Builder
 
getDescriptor() - Static method in class io.deephaven.proto.pqworker.StringList
 
getDescriptor() - Static method in class io.deephaven.proto.pqworker.ThreadDumpRequest.Builder
 
getDescriptor() - Static method in class io.deephaven.proto.pqworker.ThreadDumpRequest
 
getDescriptor() - Static method in class io.deephaven.proto.pqworker.ThreadDumpResponse.Builder
 
getDescriptor() - Static method in class io.deephaven.proto.pqworker.ThreadDumpResponse
 
getDescriptorForType() - Method in class io.deephaven.proto.pivot.ErrorResponse.Builder
 
getDescriptorForType() - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
 
getDescriptorForType() - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
 
getDescriptorForType() - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
 
getDescriptorForType() - Method in class io.deephaven.proto.pivot.PivotTableApplyResponse.Builder
 
getDescriptorForType() - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
 
getDescriptorForType() - Method in class io.deephaven.proto.pivot.PivotTableCreationResponse.Builder
 
getDescriptorForType() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage.Builder
 
getDescriptorForType() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorRequest.Builder
 
getDescriptorForType() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse.Builder
 
getDescriptorForType() - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest.Builder
 
getDescriptorForType() - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse.Builder
 
getDescriptorForType() - Method in class io.deephaven.proto.pivot.PivotTableSourceExportRequest.Builder
 
getDescriptorForType() - Method in class io.deephaven.proto.pivot.PivotTableSourceExportResponse.Builder
 
getDescriptorForType() - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage.Builder
 
getDescriptorForType() - Method in class io.deephaven.proto.pivot.PivotTableViewRequest.Builder
 
getDescriptorForType() - Method in class io.deephaven.proto.pivot.PivotTableViewResponse.Builder
 
getDescriptorForType() - Method in class io.deephaven.proto.pqworker.ListenErrorRequest.Builder
 
getDescriptorForType() - Method in class io.deephaven.proto.pqworker.ListenErrorResponse.Builder
 
getDescriptorForType() - Method in class io.deephaven.proto.pqworker.ObjectAccessRequest.Builder
 
getDescriptorForType() - Method in class io.deephaven.proto.pqworker.ObjectAccessResponse.Builder
 
getDescriptorForType() - Method in class io.deephaven.proto.pqworker.StringList.Builder
 
getDescriptorForType() - Method in class io.deephaven.proto.pqworker.ThreadDumpRequest.Builder
 
getDescriptorForType() - Method in class io.deephaven.proto.pqworker.ThreadDumpResponse.Builder
 
getDheDefinition() - Method in class io.deephaven.enterprise.locations.local.deephaven.OnDiskDeephavenTableLocation
Get the Enterprise TableDefinition for this location.
getDictionaryKeysRegion() - Method in class io.deephaven.enterprise.sources.regioned.impl.ColumnRegionObjectCached
 
getDictionaryKeysRegion() - Method in class io.deephaven.enterprise.sources.regioned.impl.ColumnRegionObjectWithDictionary
 
getDictionaryValuesRegion() - Method in class io.deephaven.enterprise.sources.regioned.impl.ColumnRegionObjectCached
 
getDictionaryValuesRegion() - Method in class io.deephaven.enterprise.sources.regioned.impl.ColumnRegionObjectWithDictionary
 
getDisByName(String) - Static method in class io.deephaven.enterprise.dataimportserver.DataImportServerTools
Retrieve a DataImportServer by name.
getDisByName(String) - Static method in class io.deephaven.enterprise.kafkawriter.KafkaTableWriter
Retrieve a DataImportServer by name.
getDisByName(String, Class<?>) - Static method in class io.deephaven.enterprise.dataimportserver.DataImportServerTools
Retrieve a DataImportServer by name.
getDisByNameWithStorage(String, String) - Static method in class io.deephaven.enterprise.dataimportserver.DataImportServerTools
Retrieve a DataImportServer by name, specifying the storage root.
getDisByNameWithStorage(String, String) - Static method in class io.deephaven.enterprise.kafkawriter.KafkaTableWriter
Retrieve a DataImportServer by name, specifying the storage root.
getDisByNameWithStorage(String, String, Class<?>) - Static method in class io.deephaven.enterprise.dataimportserver.DataImportServerTools
Retrieve a DataImportServer by name, specifying the storage root.
getDisProcessor() - Method in class io.deephaven.enterprise.ingester.impl.TableWriterContext
 
getDouble(long) - Method in class io.deephaven.enterprise.compatibility.filter.ColumnSourceAdapterForFilter
 
getDouble(long) - Method in class io.deephaven.enterprise.compatibility.region.DoubleColumnRegionAdapter
 
getDouble(long) - Method in class io.deephaven.enterprise.sources.regioned.impl.BufferedColumnRegionDouble
 
getDouble(ChunkSource.FillContext, long) - Method in class io.deephaven.enterprise.sources.regioned.impl.BufferedColumnRegionDouble
 
getEffectiveUser() - Method in class io.deephaven.enterprise.dnd.authentication.DheAuthContext
 
getEffectiveUser() - Method in class io.deephaven.enterprise.dnd.ProcessInfo
 
getEmptyColumnExpansionsTable() - Method in interface io.deephaven.pivot.PivotTable
Get a re-usable, static key Table with zero rows that will cause a snapshot to expand only the default nodes in the column dimension.
getEmptyExpansions() - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
.io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest empty_expansions = 4;
getEmptyExpansions() - Method in class io.deephaven.proto.pivot.PivotPluginRequest
.io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest empty_expansions = 4;
getEmptyExpansions() - Method in interface io.deephaven.proto.pivot.PivotPluginRequestOrBuilder
.io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest empty_expansions = 4;
getEmptyExpansions() - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
.io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse empty_expansions = 5;
getEmptyExpansions() - Method in class io.deephaven.proto.pivot.PivotPluginResponse
.io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse empty_expansions = 5;
getEmptyExpansions() - Method in interface io.deephaven.proto.pivot.PivotPluginResponseOrBuilder
.io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse empty_expansions = 5;
getEmptyExpansionsBuilder() - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
.io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest empty_expansions = 4;
getEmptyExpansionsBuilder() - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
.io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse empty_expansions = 5;
getEmptyExpansionsOrBuilder() - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
.io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest empty_expansions = 4;
getEmptyExpansionsOrBuilder() - Method in class io.deephaven.proto.pivot.PivotPluginRequest
.io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest empty_expansions = 4;
getEmptyExpansionsOrBuilder() - Method in interface io.deephaven.proto.pivot.PivotPluginRequestOrBuilder
.io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest empty_expansions = 4;
getEmptyExpansionsOrBuilder() - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
.io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse empty_expansions = 5;
getEmptyExpansionsOrBuilder() - Method in class io.deephaven.proto.pivot.PivotPluginResponse
.io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse empty_expansions = 5;
getEmptyExpansionsOrBuilder() - Method in interface io.deephaven.proto.pivot.PivotPluginResponseOrBuilder
.io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse empty_expansions = 5;
getEmptyRowExpansionsTable() - Method in interface io.deephaven.pivot.PivotTable
Get a re-usable, static key Table with zero rows that will cause a snapshot to expand only the default nodes in the row dimension.
getEndpointByName(String) - Static method in class io.deephaven.enterprise.iceberg.IcebergTools
Get the IcebergEndpoint from Deephaven configuration by name.
getEnterpriseVersion() - Method in class io.deephaven.enterprise.dnd.ProcessInfo
 
getError() - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
If the request failed (after we were able to parse and extract the request ID), then we return an error to the client; otherwise we return the appropriate response type.
getError() - Method in class io.deephaven.proto.pivot.PivotPluginResponse
If the request failed (after we were able to parse and extract the request ID), then we return an error to the client; otherwise we return the appropriate response type.
getError() - Method in interface io.deephaven.proto.pivot.PivotPluginResponseOrBuilder
If the request failed (after we were able to parse and extract the request ID), then we return an error to the client; otherwise we return the appropriate response type.
getErrorBuilder() - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
If the request failed (after we were able to parse and extract the request ID), then we return an error to the client; otherwise we return the appropriate response type.
getErrorMessage() - Method in class io.deephaven.proto.pivot.ErrorResponse.Builder
string error_message = 1;
getErrorMessage() - Method in class io.deephaven.proto.pivot.ErrorResponse
string error_message = 1;
getErrorMessage() - Method in interface io.deephaven.proto.pivot.ErrorResponseOrBuilder
string error_message = 1;
getErrorMessageBytes() - Method in class io.deephaven.proto.pivot.ErrorResponse.Builder
string error_message = 1;
getErrorMessageBytes() - Method in class io.deephaven.proto.pivot.ErrorResponse
string error_message = 1;
getErrorMessageBytes() - Method in interface io.deephaven.proto.pivot.ErrorResponseOrBuilder
string error_message = 1;
getErrorOrBuilder() - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
If the request failed (after we were able to parse and extract the request ID), then we return an error to the client; otherwise we return the appropriate response type.
getErrorOrBuilder() - Method in class io.deephaven.proto.pivot.PivotPluginResponse
If the request failed (after we were able to parse and extract the request ID), then we return an error to the client; otherwise we return the appropriate response type.
getErrorOrBuilder() - Method in interface io.deephaven.proto.pivot.PivotPluginResponseOrBuilder
If the request failed (after we were able to parse and extract the request ID), then we return an error to the client; otherwise we return the appropriate response type.
getExecutionContext() - Method in class io.deephaven.enterprise.dnd.modules.GroovyConsoleSessionWithDatabaseModule.ScriptSessionWrapper
 
getExecutor() - Method in class io.deephaven.enterprise.dnd.client.DeephavenClusterConnection
Get the ScheduledExecutorService used for connections created by this object.
getExistingViewOffset() - Method in class io.deephaven.proto.pivot.PivotTableViewRequest.Builder
Offset of the existing PivotTableView in the incoming plugin references array.
getExistingViewOffset() - Method in class io.deephaven.proto.pivot.PivotTableViewRequest
Offset of the existing PivotTableView in the incoming plugin references array.
getExistingViewOffset() - Method in interface io.deephaven.proto.pivot.PivotTableViewRequestOrBuilder
Offset of the existing PivotTableView in the incoming plugin references array.
getExpansions() - Method in class io.deephaven.proto.pivot.PivotTableViewRequest.Builder
Description for the expansions that define this view of the PivotTable.
getExpansions() - Method in class io.deephaven.proto.pivot.PivotTableViewRequest
Description for the expansions that define this view of the PivotTable.
getExpansions() - Method in interface io.deephaven.proto.pivot.PivotTableViewRequestOrBuilder
Description for the expansions that define this view of the PivotTable.
getExpansionsBuilder() - Method in class io.deephaven.proto.pivot.PivotTableViewRequest.Builder
Description for the expansions that define this view of the PivotTable.
getExpansionsOrBuilder() - Method in class io.deephaven.proto.pivot.PivotTableViewRequest.Builder
Description for the expansions that define this view of the PivotTable.
getExpansionsOrBuilder() - Method in class io.deephaven.proto.pivot.PivotTableViewRequest
Description for the expansions that define this view of the PivotTable.
getExpansionsOrBuilder() - Method in interface io.deephaven.proto.pivot.PivotTableViewRequestOrBuilder
Description for the expansions that define this view of the PivotTable.
getExport() - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
.io.deephaven.proto.pivot.PivotTableSourceExportResponse export = 4;
getExport() - Method in class io.deephaven.proto.pivot.PivotPluginResponse
.io.deephaven.proto.pivot.PivotTableSourceExportResponse export = 4;
getExport() - Method in interface io.deephaven.proto.pivot.PivotPluginResponseOrBuilder
.io.deephaven.proto.pivot.PivotTableSourceExportResponse export = 4;
getExportBuilder() - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
.io.deephaven.proto.pivot.PivotTableSourceExportResponse export = 4;
getExportOrBuilder() - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
.io.deephaven.proto.pivot.PivotTableSourceExportResponse export = 4;
getExportOrBuilder() - Method in class io.deephaven.proto.pivot.PivotPluginResponse
.io.deephaven.proto.pivot.PivotTableSourceExportResponse export = 4;
getExportOrBuilder() - Method in interface io.deephaven.proto.pivot.PivotPluginResponseOrBuilder
.io.deephaven.proto.pivot.PivotTableSourceExportResponse export = 4;
getExportSource() - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
.io.deephaven.proto.pivot.PivotTableSourceExportRequest export_source = 3;
getExportSource() - Method in class io.deephaven.proto.pivot.PivotPluginRequest
.io.deephaven.proto.pivot.PivotTableSourceExportRequest export_source = 3;
getExportSource() - Method in interface io.deephaven.proto.pivot.PivotPluginRequestOrBuilder
.io.deephaven.proto.pivot.PivotTableSourceExportRequest export_source = 3;
getExportSourceBuilder() - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
.io.deephaven.proto.pivot.PivotTableSourceExportRequest export_source = 3;
getExportSourceOrBuilder() - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
.io.deephaven.proto.pivot.PivotTableSourceExportRequest export_source = 3;
getExportSourceOrBuilder() - Method in class io.deephaven.proto.pivot.PivotPluginRequest
.io.deephaven.proto.pivot.PivotTableSourceExportRequest export_source = 3;
getExportSourceOrBuilder() - Method in interface io.deephaven.proto.pivot.PivotPluginRequestOrBuilder
.io.deephaven.proto.pivot.PivotTableSourceExportRequest export_source = 3;
getFileOrFolder(Database, String, boolean, String) - Static method in class io.deephaven.enterprise.dnd.notebook.NotebookReader
Functions as NotebookReader.getFileOrFolder(Database, String, boolean, String, Table), except without providing workspace data.
getFileOrFolder(Database, String, boolean, String, Table) - Static method in class io.deephaven.enterprise.dnd.notebook.NotebookReader
Gets a FileOrFolder pointed to by path.
getFilters() - Method in class io.deephaven.enterprise.acl.generator.WhereInFilterGenerator
Get the filters to be applied before filtering by the groupColumn.
getFilters(int) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
The filters must be against the grouping columns (either row or columns)
getFilters(int) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest
The filters must be against the grouping columns (either row or columns)
getFilters(int) - Method in interface io.deephaven.proto.pivot.PivotTableApplyRequestOrBuilder
The filters must be against the grouping columns (either row or columns)
getFiltersBuilder(int) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
The filters must be against the grouping columns (either row or columns)
getFiltersBuilderList() - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
The filters must be against the grouping columns (either row or columns)
getFiltersCount() - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
The filters must be against the grouping columns (either row or columns)
getFiltersCount() - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest
The filters must be against the grouping columns (either row or columns)
getFiltersCount() - Method in interface io.deephaven.proto.pivot.PivotTableApplyRequestOrBuilder
The filters must be against the grouping columns (either row or columns)
getFiltersList() - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
The filters must be against the grouping columns (either row or columns)
getFiltersList() - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest
The filters must be against the grouping columns (either row or columns)
getFiltersList() - Method in interface io.deephaven.proto.pivot.PivotTableApplyRequestOrBuilder
The filters must be against the grouping columns (either row or columns)
getFiltersOrBuilder(int) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
The filters must be against the grouping columns (either row or columns)
getFiltersOrBuilder(int) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest
The filters must be against the grouping columns (either row or columns)
getFiltersOrBuilder(int) - Method in interface io.deephaven.proto.pivot.PivotTableApplyRequestOrBuilder
The filters must be against the grouping columns (either row or columns)
getFiltersOrBuilderList() - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
The filters must be against the grouping columns (either row or columns)
getFiltersOrBuilderList() - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest
The filters must be against the grouping columns (either row or columns)
getFiltersOrBuilderList() - Method in interface io.deephaven.proto.pivot.PivotTableApplyRequestOrBuilder
The filters must be against the grouping columns (either row or columns)
getFloat(long) - Method in class io.deephaven.enterprise.compatibility.filter.ColumnSourceAdapterForFilter
 
getFloat(long) - Method in class io.deephaven.enterprise.compatibility.region.FloatColumnRegionAdapter
 
getFloat(long) - Method in class io.deephaven.enterprise.sources.regioned.impl.BufferedColumnRegionFloat
 
getFloat(ChunkSource.FillContext, long) - Method in class io.deephaven.enterprise.sources.regioned.impl.BufferedColumnRegionFloat
 
getFormat() - Method in class io.deephaven.enterprise.locations.hive.SimpleLocationSnapshot
 
getGetDescriptor() - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
.io.deephaven.proto.pivot.PivotTableDescriptorRequest get_descriptor = 7;
getGetDescriptor() - Method in class io.deephaven.proto.pivot.PivotPluginRequest
.io.deephaven.proto.pivot.PivotTableDescriptorRequest get_descriptor = 7;
getGetDescriptor() - Method in interface io.deephaven.proto.pivot.PivotPluginRequestOrBuilder
.io.deephaven.proto.pivot.PivotTableDescriptorRequest get_descriptor = 7;
getGetDescriptor() - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
.io.deephaven.proto.pivot.PivotTableDescriptorResponse get_descriptor = 8;
getGetDescriptor() - Method in class io.deephaven.proto.pivot.PivotPluginResponse
.io.deephaven.proto.pivot.PivotTableDescriptorResponse get_descriptor = 8;
getGetDescriptor() - Method in interface io.deephaven.proto.pivot.PivotPluginResponseOrBuilder
.io.deephaven.proto.pivot.PivotTableDescriptorResponse get_descriptor = 8;
getGetDescriptorBuilder() - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
.io.deephaven.proto.pivot.PivotTableDescriptorRequest get_descriptor = 7;
getGetDescriptorBuilder() - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
.io.deephaven.proto.pivot.PivotTableDescriptorResponse get_descriptor = 8;
getGetDescriptorOrBuilder() - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
.io.deephaven.proto.pivot.PivotTableDescriptorRequest get_descriptor = 7;
getGetDescriptorOrBuilder() - Method in class io.deephaven.proto.pivot.PivotPluginRequest
.io.deephaven.proto.pivot.PivotTableDescriptorRequest get_descriptor = 7;
getGetDescriptorOrBuilder() - Method in interface io.deephaven.proto.pivot.PivotPluginRequestOrBuilder
.io.deephaven.proto.pivot.PivotTableDescriptorRequest get_descriptor = 7;
getGetDescriptorOrBuilder() - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
.io.deephaven.proto.pivot.PivotTableDescriptorResponse get_descriptor = 8;
getGetDescriptorOrBuilder() - Method in class io.deephaven.proto.pivot.PivotPluginResponse
.io.deephaven.proto.pivot.PivotTableDescriptorResponse get_descriptor = 8;
getGetDescriptorOrBuilder() - Method in interface io.deephaven.proto.pivot.PivotPluginResponseOrBuilder
.io.deephaven.proto.pivot.PivotTableDescriptorResponse get_descriptor = 8;
getGetObjectAccessMethod() - Static method in class io.deephaven.proto.pqworker.grpc.PQWorkerApiGrpc
 
getGroupColumn() - Method in class io.deephaven.enterprise.acl.generator.WhereInFilterGenerator
Get the column in the set table that contains the Deephaven group name.
getGroupingBuilder() - Method in class io.deephaven.enterprise.compatibility.filter.ColumnSourceAdapterForFilter
 
getGroupingProvider() - Method in class io.deephaven.enterprise.compatibility.filter.ColumnSourceAdapterForFilter
 
getGroupProvider() - Method in interface io.deephaven.enterprise.acl.AclSupport
 
getGroupProvider() - Method in class io.deephaven.enterprise.database.impl.DatabaseImpl
 
getGroups() - Method in interface io.deephaven.enterprise.acl.EdgeAclProvider
Get the set of groups that may access the table this ACL guards.
getGroups() - Method in class io.deephaven.enterprise.acl.impl.EdgeAclImpl
 
getGroupsForUser(UserContext) - Method in interface io.deephaven.enterprise.dnd.authentication.GroupProvider
Get the groups to which the specified user belongs.
getGroupsForUser(UserContext) - Method in class io.deephaven.enterprise.dnd.authentication.WrappedGroupProvider
 
getGroupsForUser(UserContext) - Method in class io.deephaven.enterprise.test.PFPBackedTestGroupProvider
 
getHadoopConfig() - Method in class io.deephaven.enterprise.iceberg.IcebergConfiguration
Get the map of values for the hadoop configuration, required for Catalog access.
getHealthAuthWiring() - Method in class io.deephaven.enterprise.dnd.authentication.DheAuthorizationProvider
 
getHierarchicalTableServiceContextualAuthWiring() - Method in class io.deephaven.enterprise.dnd.authentication.DheAuthorizationProvider
 
getHost() - Method in class io.deephaven.enterprise.dnd.ProcessInfo
 
getIcebergTableAdapter() - Method in interface io.deephaven.enterprise.iceberg.discovery.DiscoveryResult
Get the discovered IcebergTableAdapter.
getIcebergTableAdapter() - Method in class io.deephaven.enterprise.iceberg.discovery.DiscoveryResultImpl
 
getId() - Method in class io.deephaven.enterprise.dnd.notebook.NotebookReader.FileOrFolder
 
getImplementationType() - Method in interface io.deephaven.enterprise.iceberg.IcebergDataInstructions.Factory
Get the concrete implementation class to inject into Jackson's serialization apis.
getImplementationType() - Method in class io.deephaven.enterprise.iceberg.IcebergS3Instructions.Factory
 
getImportStateClass() - Method in class io.deephaven.enterprise.ingester.impl.ImportStateDetails
 
getImportStateKeyColumns() - Method in class io.deephaven.enterprise.ingester.impl.ImportStateDetails
 
getIndex() - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
getInfo() - Method in class io.deephaven.enterprise.dnd.client.DndSession
Get the query info for the connected Persistent Query
getInputTableServiceContextualAuthWiring() - Method in class io.deephaven.enterprise.dnd.authentication.DheAuthorizationProvider
 
getInstance() - Static method in class io.deephaven.enterprise.compatibility.shadow.ShadowingSerializableDecoder
 
getInstance() - Static method in class io.deephaven.enterprise.dnd.SimpleAuditEventLogger
Retrieve the singleton instance of the SimpleAuditEventLogger.
getInstanceAuthContext() - Method in class io.deephaven.enterprise.dnd.authentication.DheAuthorizationProvider
 
getInt(long) - Method in class io.deephaven.enterprise.compatibility.filter.ColumnSourceAdapterForFilter
 
getInt(long) - Method in class io.deephaven.enterprise.compatibility.region.IntColumnRegionAdapter
 
getInt(long) - Method in class io.deephaven.enterprise.sources.regioned.impl.BufferedColumnRegionInt
 
getInt(ChunkSource.FillContext, long) - Method in class io.deephaven.enterprise.sources.regioned.impl.BufferedColumnRegionInt
 
getIsStatic() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage.Builder
Whether or not this table might change.
getIsStatic() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage
Whether or not this table might change.
getIsStatic() - Method in interface io.deephaven.proto.pivot.PivotTableDescriptorMessageOrBuilder
Whether or not this table might change.
getKey() - Method in class io.deephaven.enterprise.locations.local.HybridSnapshotBackedTableLocation
 
getLastModifiedTimeMillis() - Method in class io.deephaven.enterprise.compatibility.TableLocationStateAdapter
 
getLastModifiedTimeMillis() - Method in class io.deephaven.enterprise.locations.hive.SimpleLocationSnapshot
 
getLastModifiedTimeMillis() - Method in class io.deephaven.enterprise.locations.local.HybridSnapshotBackedTableLocation
 
getLastOffsetFromExistingColumnPartitions(TableDataService, String, String, String, MutableObject<String>) - Static method in class io.deephaven.enterprise.ingester.impl.OffsetUtils
For dynamic partitions, we read all existing partitions for this namespace, table and column partition.
getListenForErrorMethod() - Static method in class io.deephaven.proto.pqworker.grpc.PQWorkerApiGrpc
 
getLocalClusterDetails() - Method in interface io.deephaven.enterprise.dnd.EnterpriseJettyComponent
 
getLog(Class<?>) - Method in class io.deephaven.enterprise.dnd.EnterpriseProcessEnvironmentCommunityAdapter
 
getLogNameFor(ByteBuffer, String) - Method in class io.deephaven.enterprise.dnd.service.ticket.DatabaseTicketResolver
 
getLong(long) - Method in class io.deephaven.enterprise.compatibility.filter.ColumnSourceAdapterForFilter
 
getLong(long) - Method in class io.deephaven.enterprise.compatibility.region.LongColumnRegionAdapter
 
getLong(long) - Method in class io.deephaven.enterprise.sources.regioned.impl.BufferedColumnRegionIntAsLong
 
getLong(long) - Method in class io.deephaven.enterprise.sources.regioned.impl.BufferedColumnRegionLong
 
getLong(ChunkSource.FillContext, long) - Method in class io.deephaven.enterprise.sources.regioned.impl.BufferedColumnRegionIntAsLong
 
getLong(ChunkSource.FillContext, long) - Method in class io.deephaven.enterprise.sources.regioned.impl.BufferedColumnRegionLong
 
getMatchExpressions() - Method in class io.deephaven.enterprise.acl.generator.WhereInFilterGenerator
Get the MatchPairs used for the whereIn operation.
getMaxInboundMessageSize() - Static method in interface io.deephaven.enterprise.remote.SubscriptionOptions
Get the maximum inbound message size.
getMessage() - Method in class io.deephaven.proto.pqworker.ListenErrorResponse.Builder
string message = 1;
getMessage() - Method in class io.deephaven.proto.pqworker.ListenErrorResponse
string message = 1;
getMessage() - Method in interface io.deephaven.proto.pqworker.ListenErrorResponseOrBuilder
string message = 1;
getMessageBytes() - Method in class io.deephaven.proto.pqworker.ListenErrorResponse.Builder
string message = 1;
getMessageBytes() - Method in class io.deephaven.proto.pqworker.ListenErrorResponse
string message = 1;
getMessageBytes() - Method in interface io.deephaven.proto.pqworker.ListenErrorResponseOrBuilder
string message = 1;
getMetadata() - Method in class io.deephaven.enterprise.locations.nestedpartitioned.NestedPartitionedParquetTableLocationKey
 
getMutableObjectGroups() - Method in class io.deephaven.proto.pqworker.ObjectAccessResponse.Builder
Deprecated.
getName() - Method in class io.deephaven.enterprise.iceberg.IcebergEndpoint.Named
 
getName() - Method in class io.deephaven.enterprise.test.CapturingUpdateGraph
 
getNamespace() - Method in exception io.deephaven.enterprise.database.TableLoggerException
 
getNamespace() - Method in exception io.deephaven.enterprise.database.UserTablePermissionException
 
getNamespace() - Method in interface io.deephaven.enterprise.iceberg.discovery.DiscoveryResult
Get the namespace of the table.
getNamespace() - Method in class io.deephaven.enterprise.iceberg.discovery.DiscoveryResultImpl
 
getNamespace() - Method in interface io.deephaven.enterprise.locations.EnterpriseTableKey
Get the namespace of the table.
getNamespace() - Method in class io.deephaven.enterprise.locations.impl.EnterpriseTableKeyImpl
 
getNamespaces() - Method in interface io.deephaven.enterprise.database.Database
Get the available namespaces.
getNamespaces() - Method in class io.deephaven.enterprise.database.impl.DatabaseImpl
 
getNamespaces() - Method in class io.deephaven.enterprise.replay.ReplayDatabase
 
getNativeType() - Method in class io.deephaven.enterprise.compatibility.filter.ColumnSourceAdapterForFilter
 
getNextMark() - Method in class io.deephaven.enterprise.tabledataservice.TableLocationMarkSweepHelper
Get the next mark value for marking locations.
getNextOrderedKeysThrough(long) - Method in class io.deephaven.enterprise.compatibility.rowset.RowSequenceToOrderedKeysIteratorAdapter
 
getNextOrderedKeysWithLength(long) - Method in class io.deephaven.enterprise.compatibility.rowset.RowSequenceToOrderedKeysIteratorAdapter
 
getNextRowSequenceThrough(long) - Method in class io.deephaven.enterprise.compatibility.rowset.OrderedKeysToRowSequenceIteratorAdapter
 
getNextRowSequenceWithLength(long) - Method in class io.deephaven.enterprise.compatibility.rowset.OrderedKeysToRowSequenceIteratorAdapter
 
getNotebookPaths() - Method in class io.deephaven.enterprise.dnd.notebook.NotebookReader
Get the available notebook path names.
getNotebookPaths(String) - Method in class io.deephaven.enterprise.dnd.notebook.NotebookReader
Functions like NotebookReader.getNotebookPaths(), except notebooks will be filtered by the supplied suffix.
getNotebookText(Database, String) - Static method in class io.deephaven.enterprise.dnd.notebook.NotebookReader
Functions as NotebookReader.getNotebookText(Database, String, Table), except without providing workspace data.
getNotebookText(Database, String, Table) - Static method in class io.deephaven.enterprise.dnd.notebook.NotebookReader
Get the text of a notebook at the given path.
getNotebookText(String) - Method in class io.deephaven.enterprise.dnd.notebook.NotebookReader
Get the text of a notebook at the given path.
getNumber() - Method in enum class io.deephaven.proto.pivot.PivotPluginRequest.RequestCase
 
getNumber() - Method in enum class io.deephaven.proto.pivot.PivotPluginResponse.ResponseCase
 
getNumber() - Method in enum class io.deephaven.proto.pivot.PivotTableViewRequest.TargetCase
 
getObject(long) - Method in class io.deephaven.enterprise.compatibility.region.ObjectColumnRegionAdapter
 
getObject(long) - Method in class io.deephaven.enterprise.sources.regioned.impl.ColumnRegionObjectCached
 
getObject(long) - Method in class io.deephaven.enterprise.sources.regioned.impl.ColumnRegionObjectCodecFixed
 
getObject(long) - Method in class io.deephaven.enterprise.sources.regioned.impl.ColumnRegionObjectCodecVariable
 
getObject(long) - Method in class io.deephaven.enterprise.sources.regioned.impl.ColumnRegionObjectWithDictionary
 
getObject(long) - Method in class io.deephaven.enterprise.sources.regioned.impl.ColumnRegionStringSet
 
getObject(ChunkSource.FillContext, long) - Method in class io.deephaven.enterprise.compatibility.region.ObjectColumnRegionAdapter
 
getObject(ChunkSource.FillContext, long) - Method in class io.deephaven.enterprise.sources.regioned.impl.ColumnRegionObjectCached
 
getObject(ChunkSource.FillContext, long) - Method in class io.deephaven.enterprise.sources.regioned.impl.ColumnRegionObjectWithDictionary
 
getObject(ChunkSource.FillContext, long) - Method in class io.deephaven.enterprise.sources.regioned.impl.ColumnRegionObjectCodecFixed
 
getObject(ChunkSource.FillContext, long) - Method in class io.deephaven.enterprise.sources.regioned.impl.ColumnRegionObjectCodecVariable
 
getObject(ChunkSource.FillContext, long) - Method in class io.deephaven.enterprise.sources.regioned.impl.ColumnRegionStringSet
 
getObjectAccess(ObjectAccessRequest) - Method in class io.deephaven.proto.pqworker.grpc.PQWorkerApiGrpc.PQWorkerApiBlockingStub
 
getObjectAccess(ObjectAccessRequest) - Method in class io.deephaven.proto.pqworker.grpc.PQWorkerApiGrpc.PQWorkerApiFutureStub
 
getObjectAccess(ObjectAccessRequest, StreamObserver<ObjectAccessResponse>) - Method in class io.deephaven.enterprise.dnd.service.pqworker.PQWorkerServiceGrpcImpl
 
getObjectAccess(ObjectAccessRequest, StreamObserver<ObjectAccessResponse>) - Method in interface io.deephaven.proto.pqworker.grpc.PQWorkerApiGrpc.AsyncService
 
getObjectAccess(ObjectAccessRequest, StreamObserver<ObjectAccessResponse>) - Method in class io.deephaven.proto.pqworker.grpc.PQWorkerApiGrpc.PQWorkerApiStub
 
getObjectGroups() - Method in class io.deephaven.proto.pqworker.ObjectAccessResponse.Builder
Deprecated.
getObjectGroups() - Method in class io.deephaven.proto.pqworker.ObjectAccessResponse
Deprecated.
getObjectGroups() - Method in interface io.deephaven.proto.pqworker.ObjectAccessResponseOrBuilder
Deprecated.
getObjectGroupsCount() - Method in class io.deephaven.proto.pqworker.ObjectAccessResponse.Builder
 
getObjectGroupsCount() - Method in class io.deephaven.proto.pqworker.ObjectAccessResponse
 
getObjectGroupsCount() - Method in interface io.deephaven.proto.pqworker.ObjectAccessResponseOrBuilder
map<string, .io.deephaven.proto.pqworker.StringList> objectGroups = 1;
getObjectGroupsMap() - Method in class io.deephaven.proto.pqworker.ObjectAccessResponse.Builder
map<string, .io.deephaven.proto.pqworker.StringList> objectGroups = 1;
getObjectGroupsMap() - Method in class io.deephaven.proto.pqworker.ObjectAccessResponse
map<string, .io.deephaven.proto.pqworker.StringList> objectGroups = 1;
getObjectGroupsMap() - Method in interface io.deephaven.proto.pqworker.ObjectAccessResponseOrBuilder
map<string, .io.deephaven.proto.pqworker.StringList> objectGroups = 1;
getObjectGroupsOrDefault(String, StringList) - Method in class io.deephaven.proto.pqworker.ObjectAccessResponse.Builder
map<string, .io.deephaven.proto.pqworker.StringList> objectGroups = 1;
getObjectGroupsOrDefault(String, StringList) - Method in class io.deephaven.proto.pqworker.ObjectAccessResponse
map<string, .io.deephaven.proto.pqworker.StringList> objectGroups = 1;
getObjectGroupsOrDefault(String, StringList) - Method in interface io.deephaven.proto.pqworker.ObjectAccessResponseOrBuilder
map<string, .io.deephaven.proto.pqworker.StringList> objectGroups = 1;
getObjectGroupsOrThrow(String) - Method in class io.deephaven.proto.pqworker.ObjectAccessResponse.Builder
map<string, .io.deephaven.proto.pqworker.StringList> objectGroups = 1;
getObjectGroupsOrThrow(String) - Method in class io.deephaven.proto.pqworker.ObjectAccessResponse
map<string, .io.deephaven.proto.pqworker.StringList> objectGroups = 1;
getObjectGroupsOrThrow(String) - Method in interface io.deephaven.proto.pqworker.ObjectAccessResponseOrBuilder
map<string, .io.deephaven.proto.pqworker.StringList> objectGroups = 1;
getObjectNames(int) - Method in class io.deephaven.proto.pqworker.ObjectAccessRequest.Builder
repeated string objectNames = 1;
getObjectNames(int) - Method in class io.deephaven.proto.pqworker.ObjectAccessRequest
repeated string objectNames = 1;
getObjectNames(int) - Method in interface io.deephaven.proto.pqworker.ObjectAccessRequestOrBuilder
repeated string objectNames = 1;
getObjectNamesBytes(int) - Method in class io.deephaven.proto.pqworker.ObjectAccessRequest.Builder
repeated string objectNames = 1;
getObjectNamesBytes(int) - Method in class io.deephaven.proto.pqworker.ObjectAccessRequest
repeated string objectNames = 1;
getObjectNamesBytes(int) - Method in interface io.deephaven.proto.pqworker.ObjectAccessRequestOrBuilder
repeated string objectNames = 1;
getObjectNamesCount() - Method in class io.deephaven.proto.pqworker.ObjectAccessRequest.Builder
repeated string objectNames = 1;
getObjectNamesCount() - Method in class io.deephaven.proto.pqworker.ObjectAccessRequest
repeated string objectNames = 1;
getObjectNamesCount() - Method in interface io.deephaven.proto.pqworker.ObjectAccessRequestOrBuilder
repeated string objectNames = 1;
getObjectNamesList() - Method in class io.deephaven.proto.pqworker.ObjectAccessRequest.Builder
repeated string objectNames = 1;
getObjectNamesList() - Method in class io.deephaven.proto.pqworker.ObjectAccessRequest
repeated string objectNames = 1;
getObjectNamesList() - Method in interface io.deephaven.proto.pqworker.ObjectAccessRequestOrBuilder
repeated string objectNames = 1;
getObjectServiceAuthWiring() - Method in class io.deephaven.enterprise.dnd.authentication.DheAuthorizationProvider
 
getOrCreate(TableKey, ExtendedStorage) - Method in class io.deephaven.enterprise.iceberg.IcebergExtendedStorageProvider.Factory
 
getOrCreate(TableKey, ExtendedStorage) - Method in interface io.deephaven.enterprise.tabledataservice.extended.ExtendedStorageProvider.Factory
Get or create a ExtendedStorageProvider for the parameters.
getOrCreate(TableKey, ExtendedStorage) - Method in class io.deephaven.enterprise.tabledataservice.extended.ExtendedStorageService
Get or create a ExtendedStorageProvider for the parameters.
getOrCreate(TableKey, ExtendedStorage) - Method in class io.deephaven.enterprise.tabledataservice.extended.HiveExtendedStorageProvider.Factory
 
getOrCreate(TableKey, ExtendedStorage) - Method in class io.deephaven.enterprise.tabledataservice.extended.ParquetExtendedStorageProvider.Factory
 
getOrCreateTableDataService(TableDataServiceConfig, boolean, boolean) - Method in class io.deephaven.enterprise.tabledataservice.TableDataServiceFactory
Create the TableDataService starting with an actual TableDataServiceConfig instance
getOrCreateTableDataService(String, boolean, boolean) - Method in class io.deephaven.enterprise.tabledataservice.TableDataServiceFactory
Get a TableDataService based on the routing instructions provided by the DataRoutingService provided at construction time.
getOrderedKeysByKeyRange(long, long) - Method in class io.deephaven.enterprise.compatibility.rowset.RowSequenceToOrderedKeysAdapter
 
getOrderedKeysByPosition(long, long) - Method in class io.deephaven.enterprise.compatibility.rowset.RowSequenceToOrderedKeysAdapter
 
getOrderedKeysIterator() - Method in class io.deephaven.enterprise.compatibility.rowset.RowSequenceToOrderedKeysAdapter
 
getOutputColumns() - Method in interface io.deephaven.pivot.PivotTable
Get the column names of the aggregation outputs that are available for subscription.
getOutputColumns() - Method in class io.deephaven.pivot.PivotTableView
 
getOutputColumns(int) - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage.Builder
The name of the output columns that are sent, if not specified then all totals and value columns are sent.
getOutputColumns(int) - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage
The name of the output columns that are sent, if not specified then all totals and value columns are sent.
getOutputColumns(int) - Method in interface io.deephaven.proto.pivot.PivotTableViewExpansionsMessageOrBuilder
The name of the output columns that are sent, if not specified then all totals and value columns are sent.
getOutputColumnsBytes(int) - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage.Builder
The name of the output columns that are sent, if not specified then all totals and value columns are sent.
getOutputColumnsBytes(int) - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage
The name of the output columns that are sent, if not specified then all totals and value columns are sent.
getOutputColumnsBytes(int) - Method in interface io.deephaven.proto.pivot.PivotTableViewExpansionsMessageOrBuilder
The name of the output columns that are sent, if not specified then all totals and value columns are sent.
getOutputColumnsCount() - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage.Builder
The name of the output columns that are sent, if not specified then all totals and value columns are sent.
getOutputColumnsCount() - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage
The name of the output columns that are sent, if not specified then all totals and value columns are sent.
getOutputColumnsCount() - Method in interface io.deephaven.proto.pivot.PivotTableViewExpansionsMessageOrBuilder
The name of the output columns that are sent, if not specified then all totals and value columns are sent.
getOutputColumnsList() - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage.Builder
The name of the output columns that are sent, if not specified then all totals and value columns are sent.
getOutputColumnsList() - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage
The name of the output columns that are sent, if not specified then all totals and value columns are sent.
getOutputColumnsList() - Method in interface io.deephaven.proto.pivot.PivotTableViewExpansionsMessageOrBuilder
The name of the output columns that are sent, if not specified then all totals and value columns are sent.
getOwnerCredentials() - Static method in class io.deephaven.enterprise.dnd.authentication.DheAuthenticationHandler
 
getPageContaining(ChunkSource.FillContext, long) - Method in class io.deephaven.enterprise.sources.regioned.impl.BufferedColumnRegionBase
 
getParserForType() - Method in class io.deephaven.proto.pivot.ErrorResponse
 
getParserForType() - Method in class io.deephaven.proto.pivot.PivotPluginRequest
 
getParserForType() - Method in class io.deephaven.proto.pivot.PivotPluginResponse
 
getParserForType() - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest
 
getParserForType() - Method in class io.deephaven.proto.pivot.PivotTableApplyResponse
 
getParserForType() - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest
 
getParserForType() - Method in class io.deephaven.proto.pivot.PivotTableCreationResponse
 
getParserForType() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage
 
getParserForType() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorRequest
 
getParserForType() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse
 
getParserForType() - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest
 
getParserForType() - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse
 
getParserForType() - Method in class io.deephaven.proto.pivot.PivotTableSourceExportRequest
 
getParserForType() - Method in class io.deephaven.proto.pivot.PivotTableSourceExportResponse
 
getParserForType() - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage
 
getParserForType() - Method in class io.deephaven.proto.pivot.PivotTableViewRequest
 
getParserForType() - Method in class io.deephaven.proto.pivot.PivotTableViewResponse
 
getParserForType() - Method in class io.deephaven.proto.pqworker.ListenErrorRequest
 
getParserForType() - Method in class io.deephaven.proto.pqworker.ListenErrorResponse
 
getParserForType() - Method in class io.deephaven.proto.pqworker.ObjectAccessRequest
 
getParserForType() - Method in class io.deephaven.proto.pqworker.ObjectAccessResponse
 
getParserForType() - Method in class io.deephaven.proto.pqworker.StringList
 
getParserForType() - Method in class io.deephaven.proto.pqworker.ThreadDumpRequest
 
getParserForType() - Method in class io.deephaven.proto.pqworker.ThreadDumpResponse
 
getPartitionedTable(TableKey) - Static method in class io.deephaven.enterprise.lastbystate.CoreLastByTableImportState
Get a PartitionedTable keyed by TableLocationKey of Tables that contain only an RowSet and no user-facing ColumnSources.
getPartitionedTable(TableKey, String) - Static method in class io.deephaven.enterprise.lastbystate.CoreLastByTableImportState
Get a PartitionedTable keyed by TableLocationKey of Tables that contain only an RowSet and no user-facing ColumnSources.
getPartitionedTable(TableKey, String, Supplier<UpdateGraph>) - Static method in class io.deephaven.enterprise.lastbystate.CoreLastByTableImportState
Get a PartitionedTable keyed by TableLocationKey of Tables that contain only an RowSet and no user-facing ColumnSources.
getPartitionedTableServiceContextualAuthWiring() - Method in class io.deephaven.enterprise.dnd.authentication.DheAuthorizationProvider
 
getPartitions() - Method in interface io.deephaven.enterprise.locations.EnterpriseTableLocationKey
Get the Column and Internal partitions as a map.
getPartitions() - Method in class io.deephaven.enterprise.locations.impl.BasicFixedPartitionedDeephavenTableLocationKey
 
getPartitions() - Method in class io.deephaven.enterprise.locations.nestedpartitioned.NestedPartitionedDeephavenTableLocationKey
 
getPartitions() - Method in class io.deephaven.enterprise.locations.nestedpartitioned.NestedPartitionedParquetTableLocationKey
 
getPartitions() - Method in class io.deephaven.enterprise.locations.nestedpartitioned.NestedPartitionedUnresolvedTableLocationKey
 
getPathManager() - Method in class io.deephaven.enterprise.tabledataservice.OnDiskTableDataService
 
getPivotDescriptor() - Method in class io.deephaven.proto.pivot.PivotTableApplyResponse.Builder
first reference is the new pivot table
getPivotDescriptor() - Method in class io.deephaven.proto.pivot.PivotTableApplyResponse
first reference is the new pivot table
getPivotDescriptor() - Method in interface io.deephaven.proto.pivot.PivotTableApplyResponseOrBuilder
first reference is the new pivot table
getPivotDescriptor() - Method in class io.deephaven.proto.pivot.PivotTableCreationResponse.Builder
first reference is the created pivot table
getPivotDescriptor() - Method in class io.deephaven.proto.pivot.PivotTableCreationResponse
first reference is the created pivot table
getPivotDescriptor() - Method in interface io.deephaven.proto.pivot.PivotTableCreationResponseOrBuilder
first reference is the created pivot table
getPivotDescriptor() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse.Builder
The description of the table
getPivotDescriptor() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse
The description of the table
getPivotDescriptor() - Method in interface io.deephaven.proto.pivot.PivotTableDescriptorResponseOrBuilder
The description of the table
getPivotDescriptor() - Method in class io.deephaven.proto.pivot.PivotTableViewResponse.Builder
The description of the table
getPivotDescriptor() - Method in class io.deephaven.proto.pivot.PivotTableViewResponse
The description of the table
getPivotDescriptor() - Method in interface io.deephaven.proto.pivot.PivotTableViewResponseOrBuilder
The description of the table
getPivotDescriptorBuilder() - Method in class io.deephaven.proto.pivot.PivotTableApplyResponse.Builder
first reference is the new pivot table
getPivotDescriptorBuilder() - Method in class io.deephaven.proto.pivot.PivotTableCreationResponse.Builder
first reference is the created pivot table
getPivotDescriptorBuilder() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse.Builder
The description of the table
getPivotDescriptorBuilder() - Method in class io.deephaven.proto.pivot.PivotTableViewResponse.Builder
The description of the table
getPivotDescriptorOrBuilder() - Method in class io.deephaven.proto.pivot.PivotTableApplyResponse.Builder
first reference is the new pivot table
getPivotDescriptorOrBuilder() - Method in class io.deephaven.proto.pivot.PivotTableApplyResponse
first reference is the new pivot table
getPivotDescriptorOrBuilder() - Method in interface io.deephaven.proto.pivot.PivotTableApplyResponseOrBuilder
first reference is the new pivot table
getPivotDescriptorOrBuilder() - Method in class io.deephaven.proto.pivot.PivotTableCreationResponse.Builder
first reference is the created pivot table
getPivotDescriptorOrBuilder() - Method in class io.deephaven.proto.pivot.PivotTableCreationResponse
first reference is the created pivot table
getPivotDescriptorOrBuilder() - Method in interface io.deephaven.proto.pivot.PivotTableCreationResponseOrBuilder
first reference is the created pivot table
getPivotDescriptorOrBuilder() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse.Builder
The description of the table
getPivotDescriptorOrBuilder() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse
The description of the table
getPivotDescriptorOrBuilder() - Method in interface io.deephaven.proto.pivot.PivotTableDescriptorResponseOrBuilder
The description of the table
getPivotDescriptorOrBuilder() - Method in class io.deephaven.proto.pivot.PivotTableViewResponse.Builder
The description of the table
getPivotDescriptorOrBuilder() - Method in class io.deephaven.proto.pivot.PivotTableViewResponse
The description of the table
getPivotDescriptorOrBuilder() - Method in interface io.deephaven.proto.pivot.PivotTableViewResponseOrBuilder
The description of the table
getPivotTable() - Method in class io.deephaven.pivot.PivotTableView
 
getPivotTableOffset() - Method in class io.deephaven.proto.pivot.PivotTableViewRequest.Builder
Offset of the pivot table in the incoming plugin references.
getPivotTableOffset() - Method in class io.deephaven.proto.pivot.PivotTableViewRequest
Offset of the pivot table in the incoming plugin references.
getPivotTableOffset() - Method in interface io.deephaven.proto.pivot.PivotTableViewRequestOrBuilder
Offset of the pivot table in the incoming plugin references.
getPQ(long) - Method in class io.deephaven.enterprise.dnd.client.DndSessionFactoryBarrage
Get a PersistentQueryInfoMessage for the specified PQ serial.
getPQ(String) - Method in class io.deephaven.enterprise.dnd.client.DndSessionFactoryBarrage
Get a PersistentQueryInfoMessage for the specified PQ name.
getPQWorkerServiceAuthWiring() - Method in class io.deephaven.enterprise.dnd.authentication.DheAuthorizationProvider
 
getPQWorkerServiceAuthWiring() - Method in interface io.deephaven.enterprise.dnd.authentication.DnDAuthorizationProvider
 
getPrecision() - Method in class io.deephaven.enterprise.compatibility.ObjectCodecAdapter
 
getPrecision() - Method in class io.deephaven.enterprise.compatibility.shadow.ShadowingSerializableDecoder
 
getPrev(long) - Method in class io.deephaven.enterprise.compatibility.filter.ColumnSourceAdapterForFilter
 
getPrevBoolean(long) - Method in class io.deephaven.enterprise.compatibility.filter.ColumnSourceAdapterForFilter
 
getPrevByte(long) - Method in class io.deephaven.enterprise.compatibility.filter.ColumnSourceAdapterForFilter
 
getPrevChar(long) - Method in class io.deephaven.enterprise.compatibility.filter.ColumnSourceAdapterForFilter
 
getPrevDouble(long) - Method in class io.deephaven.enterprise.compatibility.filter.ColumnSourceAdapterForFilter
 
getPrevFloat(long) - Method in class io.deephaven.enterprise.compatibility.filter.ColumnSourceAdapterForFilter
 
getPrevInt(long) - Method in class io.deephaven.enterprise.compatibility.filter.ColumnSourceAdapterForFilter
 
getPrevLong(long) - Method in class io.deephaven.enterprise.compatibility.filter.ColumnSourceAdapterForFilter
 
getPrevShort(long) - Method in class io.deephaven.enterprise.compatibility.filter.ColumnSourceAdapterForFilter
 
getPriority() - Method in class io.deephaven.enterprise.config.HttpUrlPropertyInputStreamLoader
 
getPriority() - Method in class io.deephaven.enterprise.secrets.JsonFilesSecretsProvider
 
getPriority() - Method in class io.deephaven.enterprise.secrets.PropertiesSecretsProvider
 
getPriority() - Method in interface io.deephaven.enterprise.secrets.SecretsProvider
Get the priority of this SecretsProvider.
getPriority() - Method in class io.deephaven.enterprise.test.PropertyInputStreamLoaderResourcesOnly
 
getProcessEventLogTable() - Static method in class io.deephaven.coreplus.querylog.QueryLogSetupQuery
 
getProcessInfoId() - Method in class io.deephaven.enterprise.dnd.ProcessInfo
 
getProcessName() - Method in class io.deephaven.enterprise.dnd.ProcessInfo
 
getProperties() - Method in class io.deephaven.enterprise.iceberg.IcebergConfiguration
Get the plaintext properties for Iceberg.
getProvider(EnterpriseTableKey, Schema, ExtendedStorage, LocalTablePathManager, Set<EnterpriseTableKey>, boolean) - Method in interface io.deephaven.enterprise.tabledataservice.extended.ExtendedStorageProvider
Get the TableLocationProvider for the specified table key and extended storage type.
getProvider(EnterpriseTableKey, Schema, ExtendedStorage, LocalTablePathManager, Set<EnterpriseTableKey>, boolean) - Method in class io.deephaven.enterprise.tabledataservice.extended.HiveExtendedStorageProvider
 
getProvider(EnterpriseTableKey, Schema, ExtendedStorage, LocalTablePathManager, Set<EnterpriseTableKey>, boolean) - Method in class io.deephaven.enterprise.tabledataservice.extended.ParquetExtendedStorageProvider
Make a TableLocationProvider for parquet data stored with kv layout.
getProvider(EnterpriseTableKey, Schema, ExtendedStorage, LocalTablePathManager, Set<EnterpriseTableKey>, boolean) - Method in class io.deephaven.enterprise.iceberg.IcebergExtendedStorageProvider
 
getProviders() - Method in class io.deephaven.enterprise.secrets.JsonFilesSecretsProvider.Factory
 
getProviders() - Method in class io.deephaven.enterprise.secrets.PropertiesSecretsProvider.Factory
 
getProviders() - Method in interface io.deephaven.enterprise.secrets.SecretsProvider.Factory
Provide a list of SecretsProvider instances for resolving secrets
getQueryInfo() - Method in class io.deephaven.enterprise.remote.ControllerStateWatcher.PersistentQueryStateToken
 
getQueryScope() - Method in class io.deephaven.enterprise.dnd.modules.GroovyConsoleSessionWithDatabaseModule.ScriptSessionWrapper
 
getQuoteType(Node) - Method in class io.deephaven.enterprise.dnd.autocomplete.CompleteTableName
 
getQuoteType(Node) - Method in class io.deephaven.enterprise.dnd.autocomplete.CompleteTableNamespace
 
getReaderForType(String) - Method in class io.deephaven.enterprise.compatibility.shadow.ShadowingPersistentInputStream
There are a few different paths within WObjectInputStream that resolve packages to real classes, this one handles the path when the object is plainly encoded in the stream.
getReadInstructions() - Method in interface io.deephaven.enterprise.iceberg.discovery.DiscoveryResult
Get the completed IcebergReadInstructions that can be used to fetch Deephaven Tables.
getReadInstructions() - Method in class io.deephaven.enterprise.iceberg.discovery.DiscoveryResultImpl
 
getReason() - Method in class io.deephaven.proto.pqworker.ThreadDumpRequest.Builder
optional string reason = 1;
getReason() - Method in class io.deephaven.proto.pqworker.ThreadDumpRequest
optional string reason = 1;
getReason() - Method in interface io.deephaven.proto.pqworker.ThreadDumpRequestOrBuilder
optional string reason = 1;
getReasonBytes() - Method in class io.deephaven.proto.pqworker.ThreadDumpRequest.Builder
optional string reason = 1;
getReasonBytes() - Method in class io.deephaven.proto.pqworker.ThreadDumpRequest
optional string reason = 1;
getReasonBytes() - Method in interface io.deephaven.proto.pqworker.ThreadDumpRequestOrBuilder
optional string reason = 1;
getRecord(long, String...) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
getRelativePosition() - Method in class io.deephaven.enterprise.compatibility.rowset.OrderedKeysToRowSequenceIteratorAdapter
 
getRelativePosition() - Method in class io.deephaven.enterprise.compatibility.rowset.RowSequenceToOrderedKeysIteratorAdapter
 
getRequestCase() - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
 
getRequestCase() - Method in class io.deephaven.proto.pivot.PivotPluginRequest
 
getRequestCase() - Method in interface io.deephaven.proto.pivot.PivotPluginRequestOrBuilder
 
getRequestId() - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
A client-specified identifier used to identify the response for this request when multiple requests are in flight.
getRequestId() - Method in class io.deephaven.proto.pivot.PivotPluginRequest
A client-specified identifier used to identify the response for this request when multiple requests are in flight.
getRequestId() - Method in interface io.deephaven.proto.pivot.PivotPluginRequestOrBuilder
A client-specified identifier used to identify the response for this request when multiple requests are in flight.
getRequestId() - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
Identifier copied from the request.
getRequestId() - Method in class io.deephaven.proto.pivot.PivotPluginResponse
Identifier copied from the request.
getRequestId() - Method in interface io.deephaven.proto.pivot.PivotPluginResponseOrBuilder
Identifier copied from the request.
getRequestIdBytes() - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
A client-specified identifier used to identify the response for this request when multiple requests are in flight.
getRequestIdBytes() - Method in class io.deephaven.proto.pivot.PivotPluginRequest
A client-specified identifier used to identify the response for this request when multiple requests are in flight.
getRequestIdBytes() - Method in interface io.deephaven.proto.pivot.PivotPluginRequestOrBuilder
A client-specified identifier used to identify the response for this request when multiple requests are in flight.
getRequestIdBytes() - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
Identifier copied from the request.
getRequestIdBytes() - Method in class io.deephaven.proto.pivot.PivotPluginResponse
Identifier copied from the request.
getRequestIdBytes() - Method in interface io.deephaven.proto.pivot.PivotPluginResponseOrBuilder
Identifier copied from the request.
getRequestThreadDumpMethod() - Static method in class io.deephaven.proto.pqworker.grpc.PQWorkerApiGrpc
 
getResource(String) - Method in class io.deephaven.enterprise.dnd.classloader.DndGroovyClassLoader
 
getResponseCase() - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
 
getResponseCase() - Method in class io.deephaven.proto.pivot.PivotPluginResponse
 
getResponseCase() - Method in interface io.deephaven.proto.pivot.PivotPluginResponseOrBuilder
 
getRootAsPivotUpdateMetadata(ByteBuffer) - Static method in class io.deephaven.enterprise.pivot.flatbuf.PivotUpdateMetadata
 
getRootAsPivotUpdateMetadata(ByteBuffer, PivotUpdateMetadata) - Static method in class io.deephaven.enterprise.pivot.flatbuf.PivotUpdateMetadata
 
getRowByColumns() - Method in interface io.deephaven.pivot.PivotTable
Get the row keys used to create this Pivot.
getRowDepthColumn() - Method in interface io.deephaven.pivot.PivotTable
Get the name of a column that denotes row depth.
getRowExpandedColumn() - Method in interface io.deephaven.pivot.PivotTable
Get the name of a column of Booleans that denotes whether a row is expanded (or expandable).
getRowFilters(AclSupport, UserContext, boolean) - Method in interface io.deephaven.enterprise.acl.EdgeAclProvider
Get the set of WhereFilters that should be disjunctively applied to requested tables.
getRowFilters(AclSupport, UserContext, boolean) - Method in class io.deephaven.enterprise.acl.impl.EdgeAclImpl
 
getRowFilters(AclSupport, String, String, boolean) - Method in class io.deephaven.enterprise.acl.impl.EnterpriseAclAdapterProvider
 
getRowFilters(AclSupport, String, String, boolean) - Method in interface io.deephaven.enterprise.acl.SourceAclProvider
Get the set of WhereFilters that should be disjunctively applied to requested tables.
getRowGroupSizes() - Method in class io.deephaven.enterprise.locations.hive.SimpleLocationSnapshot
The row group sizes may not be present.
getRowKeys(int) - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
repeated string row_keys = 2;
getRowKeys(int) - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest
repeated string row_keys = 2;
getRowKeys(int) - Method in interface io.deephaven.proto.pivot.PivotTableCreationRequestOrBuilder
repeated string row_keys = 2;
getRowKeysBytes(int) - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
repeated string row_keys = 2;
getRowKeysBytes(int) - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest
repeated string row_keys = 2;
getRowKeysBytes(int) - Method in interface io.deephaven.proto.pivot.PivotTableCreationRequestOrBuilder
repeated string row_keys = 2;
getRowKeysCount() - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
repeated string row_keys = 2;
getRowKeysCount() - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest
repeated string row_keys = 2;
getRowKeysCount() - Method in interface io.deephaven.proto.pivot.PivotTableCreationRequestOrBuilder
repeated string row_keys = 2;
getRowKeysList() - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
repeated string row_keys = 2;
getRowKeysList() - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest
repeated string row_keys = 2;
getRowKeysList() - Method in interface io.deephaven.proto.pivot.PivotTableCreationRequestOrBuilder
repeated string row_keys = 2;
getRowKeyTable() - Method in class io.deephaven.pivot.PivotTableView
 
getRowKeyTableActionColumn() - Method in class io.deephaven.pivot.PivotTableView
 
getRowKeyTableActionColumn() - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage.Builder
The name of a column of bytes found in the key table that specifies the action desired for the node selected by the other columns for each row.
getRowKeyTableActionColumn() - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage
The name of a column of bytes found in the key table that specifies the action desired for the node selected by the other columns for each row.
getRowKeyTableActionColumn() - Method in interface io.deephaven.proto.pivot.PivotTableViewExpansionsMessageOrBuilder
The name of a column of bytes found in the key table that specifies the action desired for the node selected by the other columns for each row.
getRowKeyTableActionColumnBytes() - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage.Builder
The name of a column of bytes found in the key table that specifies the action desired for the node selected by the other columns for each row.
getRowKeyTableActionColumnBytes() - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage
The name of a column of bytes found in the key table that specifies the action desired for the node selected by the other columns for each row.
getRowKeyTableActionColumnBytes() - Method in interface io.deephaven.proto.pivot.PivotTableViewExpansionsMessageOrBuilder
The name of a column of bytes found in the key table that specifies the action desired for the node selected by the other columns for each row.
getRowKeyTableOffset() - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage.Builder
Offset (in the references) of a Table of expanded or contracted keys from a PivotTable (RollupTable or TreeTable).
getRowKeyTableOffset() - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage
Offset (in the references) of a Table of expanded or contracted keys from a PivotTable (RollupTable or TreeTable).
getRowKeyTableOffset() - Method in interface io.deephaven.proto.pivot.PivotTableViewExpansionsMessageOrBuilder
Offset (in the references) of a Table of expanded or contracted keys from a PivotTable (RollupTable or TreeTable).
getRowSequenceByKeyRange(long, long) - Method in class io.deephaven.enterprise.compatibility.rowset.OrderedKeysToRowSequenceAdapter
 
getRowSequenceByPosition(long, long) - Method in class io.deephaven.enterprise.compatibility.rowset.OrderedKeysToRowSequenceAdapter
 
getRowSequenceIterator() - Method in class io.deephaven.enterprise.compatibility.rowset.OrderedKeysToRowSequenceAdapter
 
getRowSet() - Method in class io.deephaven.enterprise.compatibility.TableLocationStateAdapter
 
getRowSet() - Method in class io.deephaven.enterprise.locations.local.HybridSnapshotBackedTableLocation
 
getRowSet() - Method in class io.deephaven.enterprise.locations.local.SnapshotBackedTableLocation
 
getRowSetFactoryAdapter() - Method in class io.deephaven.enterprise.lastbystate.CoreLastByTableImportState
 
getRowSortableColumns() - Method in interface io.deephaven.pivot.PivotTable
The set of column names that can be row sorted.
getRowSorts(int) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor row_sorts = 1;
getRowSorts(int) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor row_sorts = 1;
getRowSorts(int) - Method in interface io.deephaven.proto.pivot.PivotTableApplyRequestOrBuilder
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor row_sorts = 1;
getRowSortsBuilder(int) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor row_sorts = 1;
getRowSortsBuilderList() - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor row_sorts = 1;
getRowSortsCount() - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor row_sorts = 1;
getRowSortsCount() - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor row_sorts = 1;
getRowSortsCount() - Method in interface io.deephaven.proto.pivot.PivotTableApplyRequestOrBuilder
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor row_sorts = 1;
getRowSortsList() - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor row_sorts = 1;
getRowSortsList() - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor row_sorts = 1;
getRowSortsList() - Method in interface io.deephaven.proto.pivot.PivotTableApplyRequestOrBuilder
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor row_sorts = 1;
getRowSortsOrBuilder(int) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor row_sorts = 1;
getRowSortsOrBuilder(int) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor row_sorts = 1;
getRowSortsOrBuilder(int) - Method in interface io.deephaven.proto.pivot.PivotTableApplyRequestOrBuilder
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor row_sorts = 1;
getRowSortsOrBuilderList() - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor row_sorts = 1;
getRowSortsOrBuilderList() - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor row_sorts = 1;
getRowSortsOrBuilderList() - Method in interface io.deephaven.proto.pivot.PivotTableApplyRequestOrBuilder
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor row_sorts = 1;
getRowStructuralColumns() - Method in interface io.deephaven.pivot.PivotTable
 
getRowTableDefinition() - Method in interface io.deephaven.pivot.PivotTable
 
getScale() - Method in class io.deephaven.enterprise.compatibility.ObjectCodecAdapter
 
getScale() - Method in class io.deephaven.enterprise.compatibility.shadow.ShadowingSerializableDecoder
 
getScriptBody(String, boolean) - Method in interface io.deephaven.enterprise.dnd.controller.PersistentQueryScriptSource
Get the body of the specified script as the currently authenticated user.
getScriptBody(String, boolean, String) - Method in class io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClientImpl
 
getScriptBody(String, boolean, String) - Method in interface io.deephaven.enterprise.dnd.controller.PersistentQueryScriptSource
Get the body of the specified script as the currently authenticated user.
getScriptBodyByQuery(String, long, boolean) - Method in interface io.deephaven.enterprise.dnd.controller.PersistentQueryScriptSource
Get a script by path for the owner of a specific query by serial.
getScriptBodyByQuery(String, long, boolean, String) - Method in class io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClientImpl
 
getScriptBodyByQuery(String, long, boolean, String) - Method in interface io.deephaven.enterprise.dnd.controller.PersistentQueryScriptSource
Get a script by path for the owner of a specific query by serial, with optional script loader state information.
getScriptBodyByUser(String, String, boolean) - Method in interface io.deephaven.enterprise.dnd.controller.PersistentQueryScriptSource
Get the body of the specified script as the specified user.
getScriptBodyByUser(String, String, boolean, String) - Method in class io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClientImpl
 
getScriptBodyByUser(String, String, boolean, String) - Method in interface io.deephaven.enterprise.dnd.controller.PersistentQueryScriptSource
Get the body of the specified script as the specified user.
getScriptPath() - Method in class io.deephaven.enterprise.dnd.query.util.perf.PerformanceOverview.PerformanceOverviewTools
 
getScriptPaths(boolean) - Method in interface io.deephaven.enterprise.dnd.controller.PersistentQueryScriptSource
Get all script paths available for the currently authenticated user.
getScriptPaths(String, boolean) - Method in class io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClientImpl
 
getScriptPaths(String, boolean) - Method in interface io.deephaven.enterprise.dnd.controller.PersistentQueryScriptSource
Get all script paths available for the currently authenticated user.
getScriptPathsByQuery(long, boolean) - Method in interface io.deephaven.enterprise.dnd.controller.PersistentQueryScriptSource
Get all script paths available to the owner of a specific query by serial.
getScriptPathsByQuery(long, String, boolean) - Method in class io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClientImpl
 
getScriptPathsByQuery(long, String, boolean) - Method in interface io.deephaven.enterprise.dnd.controller.PersistentQueryScriptSource
Get all script paths available to the owner of a specific query by serial, providing optional script loader state information.
getScriptPathsByUser(String, boolean) - Method in interface io.deephaven.enterprise.dnd.controller.PersistentQueryScriptSource
Get the script paths available for the specified user.
getScriptPathsByUser(String, String, boolean) - Method in class io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClientImpl
 
getScriptPathsByUser(String, String, boolean) - Method in interface io.deephaven.enterprise.dnd.controller.PersistentQueryScriptSource
Get the script paths available for the specified user.
getScriptSession() - Method in interface io.deephaven.enterprise.dnd.EnterpriseJettyComponent
 
getSecret(String) - Method in class io.deephaven.enterprise.secrets.JsonFilesSecretsProvider
 
getSecret(String) - Method in class io.deephaven.enterprise.secrets.PropertiesSecretsProvider
 
getSecret(String) - Method in interface io.deephaven.enterprise.secrets.SecretsProvider
Get the named secret.
getSecrets() - Method in class io.deephaven.enterprise.iceberg.IcebergConfiguration
Get the map of protected secrets for Iceberg.
getSerializedSize() - Method in class io.deephaven.proto.pivot.ErrorResponse
 
getSerializedSize() - Method in class io.deephaven.proto.pivot.PivotPluginRequest
 
getSerializedSize() - Method in class io.deephaven.proto.pivot.PivotPluginResponse
 
getSerializedSize() - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest
 
getSerializedSize() - Method in class io.deephaven.proto.pivot.PivotTableApplyResponse
 
getSerializedSize() - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest
 
getSerializedSize() - Method in class io.deephaven.proto.pivot.PivotTableCreationResponse
 
getSerializedSize() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage
 
getSerializedSize() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorRequest
 
getSerializedSize() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse
 
getSerializedSize() - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest
 
getSerializedSize() - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse
 
getSerializedSize() - Method in class io.deephaven.proto.pivot.PivotTableSourceExportRequest
 
getSerializedSize() - Method in class io.deephaven.proto.pivot.PivotTableSourceExportResponse
 
getSerializedSize() - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage
 
getSerializedSize() - Method in class io.deephaven.proto.pivot.PivotTableViewRequest
 
getSerializedSize() - Method in class io.deephaven.proto.pivot.PivotTableViewResponse
 
getSerializedSize() - Method in class io.deephaven.proto.pqworker.ListenErrorRequest
 
getSerializedSize() - Method in class io.deephaven.proto.pqworker.ListenErrorResponse
 
getSerializedSize() - Method in class io.deephaven.proto.pqworker.ObjectAccessRequest
 
getSerializedSize() - Method in class io.deephaven.proto.pqworker.ObjectAccessResponse
 
getSerializedSize() - Method in class io.deephaven.proto.pqworker.StringList
 
getSerializedSize() - Method in class io.deephaven.proto.pqworker.ThreadDumpRequest
 
getSerializedSize() - Method in class io.deephaven.proto.pqworker.ThreadDumpResponse
 
getServiceDescriptor() - Static method in class io.deephaven.proto.pqworker.grpc.PQWorkerApiGrpc
 
getSession() - Method in class io.deephaven.enterprise.remote.CorePlusClusterSessionFactory.SessionAndChannel
 
getSessionServiceAuthWiring() - Method in class io.deephaven.enterprise.dnd.authentication.DheAuthorizationProvider
 
getSetNamespace() - Method in class io.deephaven.enterprise.acl.generator.WhereInFilterGenerator
Get the namespace of the set table.
getSetTable(AclSupport, UserContext, String, String) - Method in class io.deephaven.enterprise.acl.generator.WhereInFilterGenerator
Generate the set table for a particular userContext accessing namespace and table.
getSetTableName() - Method in class io.deephaven.enterprise.acl.generator.WhereInFilterGenerator
Get the name of the set table.
getShort(long) - Method in class io.deephaven.enterprise.compatibility.filter.ColumnSourceAdapterForFilter
 
getShort(long) - Method in class io.deephaven.enterprise.compatibility.region.ShortColumnRegionAdapter
 
getShort(long) - Method in class io.deephaven.enterprise.sources.regioned.impl.BufferedColumnRegionShort
 
getShort(ChunkSource.FillContext, long) - Method in class io.deephaven.enterprise.sources.regioned.impl.BufferedColumnRegionShort
 
getShortCauses() - Method in class io.deephaven.proto.pqworker.ListenErrorResponse.Builder
string shortCauses = 3;
getShortCauses() - Method in class io.deephaven.proto.pqworker.ListenErrorResponse
string shortCauses = 3;
getShortCauses() - Method in interface io.deephaven.proto.pqworker.ListenErrorResponseOrBuilder
string shortCauses = 3;
getShortCausesBytes() - Method in class io.deephaven.proto.pqworker.ListenErrorResponse.Builder
string shortCauses = 3;
getShortCausesBytes() - Method in class io.deephaven.proto.pqworker.ListenErrorResponse
string shortCauses = 3;
getShortCausesBytes() - Method in interface io.deephaven.proto.pqworker.ListenErrorResponseOrBuilder
string shortCauses = 3;
getSize() - Method in class io.deephaven.enterprise.compatibility.TableLocationStateAdapter
 
getSize() - Method in class io.deephaven.enterprise.locations.hive.SimpleLocationSnapshot
 
getSize() - Method in class io.deephaven.enterprise.locations.local.HybridSnapshotBackedTableLocation
 
getSize() - Method in class io.deephaven.enterprise.locations.local.SnapshotBackedTableLocation
 
getSnapshot() - Method in class io.deephaven.enterprise.locations.nestedpartitioned.NestedPartitionedSnapshotTableLocationKey
 
getSnapshot() - Method in interface io.deephaven.enterprise.locations.SnapshotProvidingLocationKey
Gets the TableLocationMetadataIndex.LocationSnapshot, which has been promised based on the overridden value of SnapshotProvidingLocationKey.hasLocationSnapshot()
getSnapshotSchema() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage.Builder
Schema to be used for snapshot or subscription requests as described in Arrow Message.fbs::Message.
getSnapshotSchema() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage
Schema to be used for snapshot or subscription requests as described in Arrow Message.fbs::Message.
getSnapshotSchema() - Method in interface io.deephaven.proto.pivot.PivotTableDescriptorMessageOrBuilder
Schema to be used for snapshot or subscription requests as described in Arrow Message.fbs::Message.
getSnapshotState() - Method in class io.deephaven.pivot.PivotTableView
 
getSortedColumns() - Method in class io.deephaven.enterprise.locations.local.deephaven.OnDiskDeephavenTableLocation
 
getSortedColumns() - Method in class io.deephaven.enterprise.locations.local.HybridSnapshotBackedTableLocation
 
getSortedColumns() - Method in class io.deephaven.enterprise.locations.remote.RemoteDeephavenTableLocation
 
getSource() - Method in interface io.deephaven.pivot.PivotTable
Return the source used to generate this PivotTable.
getSpeedFactor() - Method in class io.deephaven.enterprise.replay.DeltaClockWithAdjustableSpeed
 
getStackTrace() - Method in class io.deephaven.proto.pqworker.ListenErrorResponse.Builder
string stackTrace = 2;
getStackTrace() - Method in class io.deephaven.proto.pqworker.ListenErrorResponse
string stackTrace = 2;
getStackTrace() - Method in interface io.deephaven.proto.pqworker.ListenErrorResponseOrBuilder
string stackTrace = 2;
getStackTraceBytes() - Method in class io.deephaven.proto.pqworker.ListenErrorResponse.Builder
string stackTrace = 2;
getStackTraceBytes() - Method in class io.deephaven.proto.pqworker.ListenErrorResponse
string stackTrace = 2;
getStackTraceBytes() - Method in interface io.deephaven.proto.pqworker.ListenErrorResponseOrBuilder
string stackTrace = 2;
getStateLock() - Method in class io.deephaven.enterprise.compatibility.TableLocationStateAdapter
 
getStateLock() - Method in class io.deephaven.enterprise.locations.local.HybridSnapshotBackedTableLocation
 
getStateLogTable() - Static method in class io.deephaven.coreplus.querylog.QueryLogSetupQuery
 
getStorageServiceAuthWiring() - Method in class io.deephaven.enterprise.dnd.authentication.DheAuthorizationProvider
 
getStreamKey() - Method in class io.deephaven.enterprise.ingester.impl.TableWriterContext
 
getStringRepresentation() - Method in class io.deephaven.enterprise.lastbystate.CoreLastByTableImportState.ResultPartitionedTable
 
getSubscribed() - Method in class io.deephaven.enterprise.dnd.ControllerClientFactory
Get a controller client that is subscribed to all queries.
getSubscriberName() - Method in class io.deephaven.proto.pqworker.ListenErrorRequest.Builder
string subscriberName = 1;
getSubscriberName() - Method in class io.deephaven.proto.pqworker.ListenErrorRequest
string subscriberName = 1;
getSubscriberName() - Method in interface io.deephaven.proto.pqworker.ListenErrorRequestOrBuilder
string subscriberName = 1;
getSubscriberNameBytes() - Method in class io.deephaven.proto.pqworker.ListenErrorRequest.Builder
string subscriberName = 1;
getSubscriberNameBytes() - Method in class io.deephaven.proto.pqworker.ListenErrorRequest
string subscriberName = 1;
getSubscriberNameBytes() - Method in interface io.deephaven.proto.pqworker.ListenErrorRequestOrBuilder
string subscriberName = 1;
getSubTable(Index) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
getSubView(BarrageSubscriptionOptions, boolean, boolean, RowSet, boolean, RowSet, RowSet, BitSet, RowSet, PivotTable.PivotSnapshot) - Method in class io.deephaven.pivot.PivotBarrageMessageWriterImpl
 
getTable() - Method in class io.deephaven.enterprise.compatibility.filter.RecomputeListenerAdapter
 
getTableDefinition() - Method in class io.deephaven.enterprise.kafkawriter.SchemaHelper
Constructs a DHE TableDefinition instance.
getTableDefinition(String, String) - Method in interface io.deephaven.enterprise.database.Database
Fetch a TableDefinition from the database.
getTableDefinition(String, String) - Method in class io.deephaven.enterprise.database.impl.DatabaseImpl
 
getTableDefinition(String, String) - Method in class io.deephaven.enterprise.replay.ReplayDatabase
 
getTableDefinitionTable(String, String) - Method in interface io.deephaven.enterprise.database.Database
Fetch a table's definition table from the database.
getTableDefinitionTable(String, String) - Method in class io.deephaven.enterprise.database.impl.DatabaseImpl
 
getTableDefinitionTable(String, String) - Method in class io.deephaven.enterprise.replay.ReplayDatabase
 
getTableIdentifier() - Method in interface io.deephaven.enterprise.iceberg.discovery.DiscoveryResult
Get the TableIdentifier used to discover the table.
getTableIdentifier() - Method in class io.deephaven.enterprise.iceberg.discovery.DiscoveryResultImpl
 
getTableKey() - Method in class io.deephaven.enterprise.locations.local.HybridSnapshotBackedTableLocation
 
getTableName() - Method in exception io.deephaven.enterprise.database.TableLoggerException
 
getTableName() - Method in exception io.deephaven.enterprise.database.UserTablePermissionException
 
getTableName() - Method in interface io.deephaven.enterprise.iceberg.discovery.DiscoveryResult
Get the name of the table.
getTableName() - Method in class io.deephaven.enterprise.iceberg.discovery.DiscoveryResultImpl
 
getTableName() - Method in interface io.deephaven.enterprise.locations.EnterpriseTableKey
Get the name of the table.
getTableName() - Method in class io.deephaven.enterprise.locations.impl.EnterpriseTableKeyImpl
 
getTableNames(String) - Method in class io.deephaven.enterprise.database.impl.DatabaseImpl
 
getTableNames(String) - Method in interface io.deephaven.enterprise.database.Database
Get the tables within a namespace
getTableNames(String) - Method in class io.deephaven.enterprise.replay.ReplayDatabase
 
getTableServiceContextualAuthWiring() - Method in class io.deephaven.enterprise.dnd.authentication.DheAuthorizationProvider
 
getTableType() - Method in interface io.deephaven.enterprise.locations.EnterpriseTableKey
Get the table type.
getTableType() - Method in class io.deephaven.enterprise.locations.impl.EnterpriseTableKeyImpl
 
getTableWriter() - Method in class io.deephaven.enterprise.ingester.impl.TableWriterContext
 
getTargetCase() - Method in class io.deephaven.proto.pivot.PivotTableViewRequest.Builder
 
getTargetCase() - Method in class io.deephaven.proto.pivot.PivotTableViewRequest
 
getTargetCase() - Method in interface io.deephaven.proto.pivot.PivotTableViewRequestOrBuilder
 
getTicketResolverAuthorization() - Method in class io.deephaven.enterprise.dnd.authentication.DheAuthorizationProvider
 
getTimestampMillis() - Method in class io.deephaven.proto.pqworker.ListenErrorResponse.Builder
int64 timestampMillis = 6;
getTimestampMillis() - Method in class io.deephaven.proto.pqworker.ListenErrorResponse
int64 timestampMillis = 6;
getTimestampMillis() - Method in interface io.deephaven.proto.pqworker.ListenErrorResponseOrBuilder
int64 timestampMillis = 6;
getType() - Method in class io.deephaven.enterprise.compatibility.filter.ColumnSourceAdapterForFilter
 
getType() - Method in class io.deephaven.enterprise.dnd.notebook.NotebookReader.FileOrFolder
 
getUnsubscribed() - Method in class io.deephaven.enterprise.dnd.ControllerClientFactory
Get a (possibly) unsubscribed controller client.
getUpdateGraph() - Method in class io.deephaven.enterprise.test.CapturingUpdateGraph
 
getURI() - Method in interface io.deephaven.enterprise.locations.URIProvidingLocationKey
Gets the URI which backs this keyed location
getUseHistorical() - Method in class io.deephaven.enterprise.acl.generator.WhereInFilterGenerator
Get whether or not this generator will fetch its set table data from historical or intraday
getUserContext() - Method in class io.deephaven.enterprise.database.impl.DatabaseAdapter
 
getUserContext() - Method in class io.deephaven.enterprise.database.impl.DatabaseImpl
 
getUserContext() - Method in interface io.deephaven.enterprise.database.impl.DatabaseInternal
 
getUserContext() - Method in class io.deephaven.enterprise.dnd.client.DeephavenClusterConnection
Get the authenticated UserContext for this object.
getUserContext() - Method in class io.deephaven.enterprise.replay.WritableReplayDatabase
 
getUsersForGroup(String) - Method in class io.deephaven.enterprise.test.PFPBackedTestGroupProvider
 
getValues(int) - Method in class io.deephaven.proto.pqworker.StringList.Builder
repeated string values = 1;
getValues(int) - Method in class io.deephaven.proto.pqworker.StringList
repeated string values = 1;
getValues(int) - Method in interface io.deephaven.proto.pqworker.StringListOrBuilder
repeated string values = 1;
getValuesBytes(int) - Method in class io.deephaven.proto.pqworker.StringList.Builder
repeated string values = 1;
getValuesBytes(int) - Method in class io.deephaven.proto.pqworker.StringList
repeated string values = 1;
getValuesBytes(int) - Method in interface io.deephaven.proto.pqworker.StringListOrBuilder
repeated string values = 1;
getValuesCount() - Method in class io.deephaven.proto.pqworker.StringList.Builder
repeated string values = 1;
getValuesCount() - Method in class io.deephaven.proto.pqworker.StringList
repeated string values = 1;
getValuesCount() - Method in interface io.deephaven.proto.pqworker.StringListOrBuilder
repeated string values = 1;
getValuesList() - Method in class io.deephaven.proto.pqworker.StringList.Builder
repeated string values = 1;
getValuesList() - Method in class io.deephaven.proto.pqworker.StringList
repeated string values = 1;
getValuesList() - Method in interface io.deephaven.proto.pqworker.StringListOrBuilder
repeated string values = 1;
getValuesTableDefinition() - Method in interface io.deephaven.pivot.PivotTable
 
getView() - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
.io.deephaven.proto.pivot.PivotTableViewRequest view = 2;
getView() - Method in class io.deephaven.proto.pivot.PivotPluginRequest
.io.deephaven.proto.pivot.PivotTableViewRequest view = 2;
getView() - Method in interface io.deephaven.proto.pivot.PivotPluginRequestOrBuilder
.io.deephaven.proto.pivot.PivotTableViewRequest view = 2;
getView() - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
.io.deephaven.proto.pivot.PivotTableViewResponse view = 3;
getView() - Method in class io.deephaven.proto.pivot.PivotPluginResponse
.io.deephaven.proto.pivot.PivotTableViewResponse view = 3;
getView() - Method in interface io.deephaven.proto.pivot.PivotPluginResponseOrBuilder
.io.deephaven.proto.pivot.PivotTableViewResponse view = 3;
getViewBuilder() - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
.io.deephaven.proto.pivot.PivotTableViewRequest view = 2;
getViewBuilder() - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
.io.deephaven.proto.pivot.PivotTableViewResponse view = 3;
getViewOrBuilder() - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
.io.deephaven.proto.pivot.PivotTableViewRequest view = 2;
getViewOrBuilder() - Method in class io.deephaven.proto.pivot.PivotPluginRequest
.io.deephaven.proto.pivot.PivotTableViewRequest view = 2;
getViewOrBuilder() - Method in interface io.deephaven.proto.pivot.PivotPluginRequestOrBuilder
.io.deephaven.proto.pivot.PivotTableViewRequest view = 2;
getViewOrBuilder() - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
.io.deephaven.proto.pivot.PivotTableViewResponse view = 3;
getViewOrBuilder() - Method in class io.deephaven.proto.pivot.PivotPluginResponse
.io.deephaven.proto.pivot.PivotTableViewResponse view = 3;
getViewOrBuilder() - Method in interface io.deephaven.proto.pivot.PivotPluginResponseOrBuilder
.io.deephaven.proto.pivot.PivotTableViewResponse view = 3;
getWarehouseUri() - Method in class io.deephaven.enterprise.iceberg.IcebergConfiguration
Get the warehouse URI, that is, where the data actually resides.
getWasUncaught() - Method in class io.deephaven.proto.pqworker.ListenErrorResponse.Builder
bool wasUncaught = 4;
getWasUncaught() - Method in class io.deephaven.proto.pqworker.ListenErrorResponse
bool wasUncaught = 4;
getWasUncaught() - Method in interface io.deephaven.proto.pqworker.ListenErrorResponseOrBuilder
bool wasUncaught = 4;
getWeakReference() - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
getWorkerService() - Method in interface io.deephaven.enterprise.dnd.EnterpriseJettyComponent
 
getWorkspaceDataFiltered(boolean, Collection<Filter>) - Method in class io.deephaven.enterprise.workspace.WorkspaceDataSnapshot
Gets the most recent table representing the WorkspaceData, where supplied filters are applied prior to the sortedLastBy aggregation.
getWorkspaceDataFiltered(Collection<Filter>) - Method in class io.deephaven.enterprise.workspace.WorkspaceDataSnapshot
Gets the most recent live table representing the WorkspaceData, where supplied filters are applied prior to the sortedLastBy aggregation.
getWorkspaceDataUnfiltered() - Method in class io.deephaven.enterprise.workspace.WorkspaceDataSnapshot
Gets the most recent live table representing the WorkspaceData.
getWorkspaceDataUnfiltered(boolean) - Method in class io.deephaven.enterprise.workspace.WorkspaceDataSnapshot
Gets the most recent table representing the WorkspaceData.
getXmlSchema() - Method in class io.deephaven.enterprise.kafkawriter.SchemaHelper
Constructs a DHE Schema instance.
grandTotalsSnapshot() - Method in interface io.deephaven.pivot.PivotTable.PivotSnapshot
 
GroovyConsoleSessionWithDatabaseModule - Interface in io.deephaven.enterprise.dnd.modules
 
GroovyConsoleSessionWithDatabaseModule.ScriptSessionWrapper - Class in io.deephaven.enterprise.dnd.modules
A thin wrapper around a ScriptSession so that we can invalidate the controller class loader cache before evaluating scripts.
group(String) - Static method in interface io.deephaven.enterprise.acl.AclFilterGenerator
Create an AclFilterGenerator that filters rows based on group data contained within the table.
group(String, boolean) - Static method in interface io.deephaven.enterprise.acl.AclFilterGenerator
Create an AclFilterGenerator that filters rows based on group data contained within the table.
GroupProvider - Interface in io.deephaven.enterprise.dnd.authentication
A provider for group membership information for users of the system.

H

handleConfigUpdate(ControllerConfigurationMessage) - Method in interface io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClient.Observer
Handle an update to the ControllerConfigurationMessage
handleConfigUpdate(ControllerConfigurationMessage) - Method in class io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClient.ObserverImpl
 
handleConnectionEstablished() - Method in interface io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClient.Observer
Handle when the connection to the Controller has been established, or re-establisehd after a disconnection.
handleConnectionEstablished() - Method in class io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClient.ObserverImpl
 
handleConnectionLost() - Method in interface io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClient.Observer
Handle when the connection to the Controller has been lost.
handleConnectionLost() - Method in class io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClient.ObserverImpl
 
handleModify(PersistentQueryInfoMessage, PersistentQueryInfoMessage) - Method in interface io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClient.Observer
Handle a change to an existing query.
handleModify(PersistentQueryInfoMessage, PersistentQueryInfoMessage) - Method in class io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClient.ObserverImpl
 
handlePut(PersistentQueryInfoMessage) - Method in interface io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClient.Observer
Handle the addition of a query.
handlePut(PersistentQueryInfoMessage) - Method in class io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClient.ObserverImpl
 
handleRemove(PersistentQueryInfoMessage) - Method in interface io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClient.Observer
Handle the removal of a query.
handleRemove(PersistentQueryInfoMessage) - Method in class io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClient.ObserverImpl
 
handleUpdate(TableLocationState) - Method in class io.deephaven.enterprise.locations.remote.RemoteDeephavenTableLocation
 
hasApply() - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
.io.deephaven.proto.pivot.PivotTableApplyRequest apply = 6;
hasApply() - Method in class io.deephaven.proto.pivot.PivotPluginRequest
.io.deephaven.proto.pivot.PivotTableApplyRequest apply = 6;
hasApply() - Method in interface io.deephaven.proto.pivot.PivotPluginRequestOrBuilder
.io.deephaven.proto.pivot.PivotTableApplyRequest apply = 6;
hasApply() - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
.io.deephaven.proto.pivot.PivotTableApplyResponse apply = 7;
hasApply() - Method in class io.deephaven.proto.pivot.PivotPluginResponse
.io.deephaven.proto.pivot.PivotTableApplyResponse apply = 7;
hasApply() - Method in interface io.deephaven.proto.pivot.PivotPluginResponseOrBuilder
.io.deephaven.proto.pivot.PivotTableApplyResponse apply = 7;
hasAttribute(String) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
hasColumnFilters() - Method in interface io.deephaven.enterprise.acl.EdgeAclProvider
Returns true if there are any column Filters defined for this EdgeAclProvider.
hasColumnFilters() - Method in class io.deephaven.enterprise.acl.impl.EdgeAclImpl
 
hasColumnKeyTableActionColumn() - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage.Builder
The name of a column of bytes found in the key table that specifies the action desired for the node selected by the other columns for each row.
hasColumnKeyTableActionColumn() - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage
The name of a column of bytes found in the key table that specifies the action desired for the node selected by the other columns for each row.
hasColumnKeyTableActionColumn() - Method in interface io.deephaven.proto.pivot.PivotTableViewExpansionsMessageOrBuilder
The name of a column of bytes found in the key table that specifies the action desired for the node selected by the other columns for each row.
hasColumnKeyTableOffset() - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage.Builder
Offset (in the references) of a Table of expanded or contracted keys from a PivotTable (RollupTable or TreeTable).
hasColumnKeyTableOffset() - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage
Offset (in the references) of a Table of expanded or contracted keys from a PivotTable (RollupTable or TreeTable).
hasColumnKeyTableOffset() - Method in interface io.deephaven.proto.pivot.PivotTableViewExpansionsMessageOrBuilder
Offset (in the references) of a Table of expanded or contracted keys from a PivotTable (RollupTable or TreeTable).
hasCreation() - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
.io.deephaven.proto.pivot.PivotTableCreationRequest creation = 5;
hasCreation() - Method in class io.deephaven.proto.pivot.PivotPluginRequest
.io.deephaven.proto.pivot.PivotTableCreationRequest creation = 5;
hasCreation() - Method in interface io.deephaven.proto.pivot.PivotPluginRequestOrBuilder
.io.deephaven.proto.pivot.PivotTableCreationRequest creation = 5;
hasCreation() - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
.io.deephaven.proto.pivot.PivotTableCreationResponse creation = 6;
hasCreation() - Method in class io.deephaven.proto.pivot.PivotPluginResponse
.io.deephaven.proto.pivot.PivotTableCreationResponse creation = 6;
hasCreation() - Method in interface io.deephaven.proto.pivot.PivotPluginResponseOrBuilder
.io.deephaven.proto.pivot.PivotTableCreationResponse creation = 6;
hasDataIndex(String...) - Method in class io.deephaven.enterprise.locations.local.deephaven.OnDiskDeephavenTableLocation
 
hasDataIndex(String...) - Method in class io.deephaven.enterprise.locations.local.HybridSnapshotBackedTableLocation
 
hasDataIndex(String...) - Method in class io.deephaven.enterprise.locations.remote.RemoteDeephavenTableLocation
 
hasEmptyExpansions() - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
.io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest empty_expansions = 4;
hasEmptyExpansions() - Method in class io.deephaven.proto.pivot.PivotPluginRequest
.io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest empty_expansions = 4;
hasEmptyExpansions() - Method in interface io.deephaven.proto.pivot.PivotPluginRequestOrBuilder
.io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest empty_expansions = 4;
hasEmptyExpansions() - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
.io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse empty_expansions = 5;
hasEmptyExpansions() - Method in class io.deephaven.proto.pivot.PivotPluginResponse
.io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse empty_expansions = 5;
hasEmptyExpansions() - Method in interface io.deephaven.proto.pivot.PivotPluginResponseOrBuilder
.io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse empty_expansions = 5;
hasError() - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
If the request failed (after we were able to parse and extract the request ID), then we return an error to the client; otherwise we return the appropriate response type.
hasError() - Method in class io.deephaven.proto.pivot.PivotPluginResponse
If the request failed (after we were able to parse and extract the request ID), then we return an error to the client; otherwise we return the appropriate response type.
hasError() - Method in interface io.deephaven.proto.pivot.PivotPluginResponseOrBuilder
If the request failed (after we were able to parse and extract the request ID), then we return an error to the client; otherwise we return the appropriate response type.
hasExistingViewOffset() - Method in class io.deephaven.proto.pivot.PivotTableViewRequest.Builder
Offset of the existing PivotTableView in the incoming plugin references array.
hasExistingViewOffset() - Method in class io.deephaven.proto.pivot.PivotTableViewRequest
Offset of the existing PivotTableView in the incoming plugin references array.
hasExistingViewOffset() - Method in interface io.deephaven.proto.pivot.PivotTableViewRequestOrBuilder
Offset of the existing PivotTableView in the incoming plugin references array.
hasExpansions() - Method in class io.deephaven.proto.pivot.PivotTableViewRequest.Builder
Description for the expansions that define this view of the PivotTable.
hasExpansions() - Method in class io.deephaven.proto.pivot.PivotTableViewRequest
Description for the expansions that define this view of the PivotTable.
hasExpansions() - Method in interface io.deephaven.proto.pivot.PivotTableViewRequestOrBuilder
Description for the expansions that define this view of the PivotTable.
hasExport() - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
.io.deephaven.proto.pivot.PivotTableSourceExportResponse export = 4;
hasExport() - Method in class io.deephaven.proto.pivot.PivotPluginResponse
.io.deephaven.proto.pivot.PivotTableSourceExportResponse export = 4;
hasExport() - Method in interface io.deephaven.proto.pivot.PivotPluginResponseOrBuilder
.io.deephaven.proto.pivot.PivotTableSourceExportResponse export = 4;
hasExportSource() - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
.io.deephaven.proto.pivot.PivotTableSourceExportRequest export_source = 3;
hasExportSource() - Method in class io.deephaven.proto.pivot.PivotPluginRequest
.io.deephaven.proto.pivot.PivotTableSourceExportRequest export_source = 3;
hasExportSource() - Method in interface io.deephaven.proto.pivot.PivotPluginRequestOrBuilder
.io.deephaven.proto.pivot.PivotTableSourceExportRequest export_source = 3;
hasFullTableAccess(UserContext, String, String) - Static method in class io.deephaven.enterprise.acl.impl.AclHelper
 
hasGetDescriptor() - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
.io.deephaven.proto.pivot.PivotTableDescriptorRequest get_descriptor = 7;
hasGetDescriptor() - Method in class io.deephaven.proto.pivot.PivotPluginRequest
.io.deephaven.proto.pivot.PivotTableDescriptorRequest get_descriptor = 7;
hasGetDescriptor() - Method in interface io.deephaven.proto.pivot.PivotPluginRequestOrBuilder
.io.deephaven.proto.pivot.PivotTableDescriptorRequest get_descriptor = 7;
hasGetDescriptor() - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
.io.deephaven.proto.pivot.PivotTableDescriptorResponse get_descriptor = 8;
hasGetDescriptor() - Method in class io.deephaven.proto.pivot.PivotPluginResponse
.io.deephaven.proto.pivot.PivotTableDescriptorResponse get_descriptor = 8;
hasGetDescriptor() - Method in interface io.deephaven.proto.pivot.PivotPluginResponseOrBuilder
.io.deephaven.proto.pivot.PivotTableDescriptorResponse get_descriptor = 8;
hasGrouping() - Method in class io.deephaven.enterprise.compatibility.filter.ColumnSourceAdapterForFilter
 
hasGrouping(ReadOnlyIndex) - Method in class io.deephaven.enterprise.compatibility.filter.ColumnSourceAdapterForFilter
 
hashCode() - Method in class io.deephaven.enterprise.compatibility.filter.EnterpriseFilterAdapter
 
hashCode() - Method in class io.deephaven.enterprise.iceberg.IcebergConfiguration
 
hashCode() - Method in class io.deephaven.enterprise.ingester.impl.ImportStateDetails
 
hashCode() - Method in class io.deephaven.enterprise.locations.impl.BasicFixedPartitionedDeephavenTableLocationKey
 
hashCode() - Method in class io.deephaven.enterprise.locations.impl.EnterpriseTableKeyImpl
 
hashCode() - Method in class io.deephaven.enterprise.locations.nestedpartitioned.NestedPartitionedDeephavenTableLocationKey
 
hashCode() - Method in class io.deephaven.enterprise.locations.nestedpartitioned.NestedPartitionedParquetTableLocationKey
 
hashCode() - Method in class io.deephaven.enterprise.locations.nestedpartitioned.NestedPartitionedUnresolvedTableLocationKey
 
hashCode() - Method in class io.deephaven.proto.pivot.ErrorResponse
 
hashCode() - Method in class io.deephaven.proto.pivot.PivotPluginRequest
 
hashCode() - Method in class io.deephaven.proto.pivot.PivotPluginResponse
 
hashCode() - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest
 
hashCode() - Method in class io.deephaven.proto.pivot.PivotTableApplyResponse
 
hashCode() - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest
 
hashCode() - Method in class io.deephaven.proto.pivot.PivotTableCreationResponse
 
hashCode() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage
 
hashCode() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorRequest
 
hashCode() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse
 
hashCode() - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest
 
hashCode() - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse
 
hashCode() - Method in class io.deephaven.proto.pivot.PivotTableSourceExportRequest
 
hashCode() - Method in class io.deephaven.proto.pivot.PivotTableSourceExportResponse
 
hashCode() - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage
 
hashCode() - Method in class io.deephaven.proto.pivot.PivotTableViewRequest
 
hashCode() - Method in class io.deephaven.proto.pivot.PivotTableViewResponse
 
hashCode() - Method in class io.deephaven.proto.pqworker.ListenErrorRequest
 
hashCode() - Method in class io.deephaven.proto.pqworker.ListenErrorResponse
 
hashCode() - Method in class io.deephaven.proto.pqworker.ObjectAccessRequest
 
hashCode() - Method in class io.deephaven.proto.pqworker.ObjectAccessResponse
 
hashCode() - Method in class io.deephaven.proto.pqworker.StringList
 
hashCode() - Method in class io.deephaven.proto.pqworker.ThreadDumpRequest
 
hashCode() - Method in class io.deephaven.proto.pqworker.ThreadDumpResponse
 
hasLocationSnapshot() - Method in interface io.deephaven.enterprise.locations.EnterpriseTableLocationKey
Check if this table has a metadata index
hasLocationSnapshot() - Method in class io.deephaven.enterprise.locations.nestedpartitioned.NestedPartitionedSnapshotTableLocationKey
 
hasLocationSnapshot() - Method in interface io.deephaven.enterprise.locations.SnapshotProvidingLocationKey
 
hasMore() - Method in class io.deephaven.enterprise.compatibility.rowset.OrderedKeysToRowSequenceIteratorAdapter
 
hasMore() - Method in class io.deephaven.enterprise.compatibility.rowset.RowSequenceToOrderedKeysIteratorAdapter
 
hasNamespace(Database, String) - Static method in interface io.deephaven.enterprise.database.inputtables.InputTableTool
Whether a database contains a namespace.
hasOrphanPromotion() - Method in interface io.deephaven.enterprise.acl.EdgeAclProvider
Returns true if orphans should be promoted when this provider is applied to a TreeTable.
hasOrphanPromotion() - Method in class io.deephaven.enterprise.acl.impl.EdgeAclImpl
 
hasPivotDescriptor() - Method in class io.deephaven.proto.pivot.PivotTableApplyResponse.Builder
first reference is the new pivot table
hasPivotDescriptor() - Method in class io.deephaven.proto.pivot.PivotTableApplyResponse
first reference is the new pivot table
hasPivotDescriptor() - Method in interface io.deephaven.proto.pivot.PivotTableApplyResponseOrBuilder
first reference is the new pivot table
hasPivotDescriptor() - Method in class io.deephaven.proto.pivot.PivotTableCreationResponse.Builder
first reference is the created pivot table
hasPivotDescriptor() - Method in class io.deephaven.proto.pivot.PivotTableCreationResponse
first reference is the created pivot table
hasPivotDescriptor() - Method in interface io.deephaven.proto.pivot.PivotTableCreationResponseOrBuilder
first reference is the created pivot table
hasPivotDescriptor() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse.Builder
The description of the table
hasPivotDescriptor() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse
The description of the table
hasPivotDescriptor() - Method in interface io.deephaven.proto.pivot.PivotTableDescriptorResponseOrBuilder
The description of the table
hasPivotDescriptor() - Method in class io.deephaven.proto.pivot.PivotTableViewResponse.Builder
The description of the table
hasPivotDescriptor() - Method in class io.deephaven.proto.pivot.PivotTableViewResponse
The description of the table
hasPivotDescriptor() - Method in interface io.deephaven.proto.pivot.PivotTableViewResponseOrBuilder
The description of the table
hasPivotTableOffset() - Method in class io.deephaven.proto.pivot.PivotTableViewRequest.Builder
Offset of the pivot table in the incoming plugin references.
hasPivotTableOffset() - Method in class io.deephaven.proto.pivot.PivotTableViewRequest
Offset of the pivot table in the incoming plugin references.
hasPivotTableOffset() - Method in interface io.deephaven.proto.pivot.PivotTableViewRequestOrBuilder
Offset of the pivot table in the incoming plugin references.
hasReason() - Method in class io.deephaven.proto.pqworker.ThreadDumpRequest.Builder
optional string reason = 1;
hasReason() - Method in class io.deephaven.proto.pqworker.ThreadDumpRequest
optional string reason = 1;
hasReason() - Method in interface io.deephaven.proto.pqworker.ThreadDumpRequestOrBuilder
optional string reason = 1;
hasRowKeyTableActionColumn() - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage.Builder
The name of a column of bytes found in the key table that specifies the action desired for the node selected by the other columns for each row.
hasRowKeyTableActionColumn() - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage
The name of a column of bytes found in the key table that specifies the action desired for the node selected by the other columns for each row.
hasRowKeyTableActionColumn() - Method in interface io.deephaven.proto.pivot.PivotTableViewExpansionsMessageOrBuilder
The name of a column of bytes found in the key table that specifies the action desired for the node selected by the other columns for each row.
hasRowKeyTableOffset() - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage.Builder
Offset (in the references) of a Table of expanded or contracted keys from a PivotTable (RollupTable or TreeTable).
hasRowKeyTableOffset() - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage
Offset (in the references) of a Table of expanded or contracted keys from a PivotTable (RollupTable or TreeTable).
hasRowKeyTableOffset() - Method in interface io.deephaven.proto.pivot.PivotTableViewExpansionsMessageOrBuilder
Offset (in the references) of a Table of expanded or contracted keys from a PivotTable (RollupTable or TreeTable).
hasTable(Database, String, String) - Static method in interface io.deephaven.enterprise.database.inputtables.InputTableTool
Whether a database contains a table.
hasView() - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
.io.deephaven.proto.pivot.PivotTableViewRequest view = 2;
hasView() - Method in class io.deephaven.proto.pivot.PivotPluginRequest
.io.deephaven.proto.pivot.PivotTableViewRequest view = 2;
hasView() - Method in interface io.deephaven.proto.pivot.PivotPluginRequestOrBuilder
.io.deephaven.proto.pivot.PivotTableViewRequest view = 2;
hasView() - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
.io.deephaven.proto.pivot.PivotTableViewResponse view = 3;
hasView() - Method in class io.deephaven.proto.pivot.PivotPluginResponse
.io.deephaven.proto.pivot.PivotTableViewResponse view = 3;
hasView() - Method in interface io.deephaven.proto.pivot.PivotPluginResponseOrBuilder
.io.deephaven.proto.pivot.PivotTableViewResponse view = 3;
head(long) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
headBy(long, String...) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
headPct(double) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
HierarchicalTableTicketTransformer - Class in io.deephaven.enterprise.acl.transform
A TicketTransformer that handles transformation of HierarchicalTables to apply ACLs at the edge.
HierarchicalTableTicketTransformer(AclSupport) - Constructor for class io.deephaven.enterprise.acl.transform.HierarchicalTableTicketTransformer
 
historicalPartitionedTable(String, String) - Method in interface io.deephaven.enterprise.database.Database
Retrieve the specified historical table as a PartitionedTable from the Database.
historicalPartitionedTable(String, String, TableOptions) - Method in interface io.deephaven.enterprise.database.Database
Retrieve the specified historical table as a PartitionedTable from the Database.
historicalPartitionedTable(String, String, TableOptions) - Method in class io.deephaven.enterprise.database.impl.DatabaseImpl
 
historicalPartitionedTable(String, String, TableOptions) - Method in class io.deephaven.enterprise.replay.ReplayDatabase
 
historicalTable(String, String) - Method in interface io.deephaven.enterprise.acl.AclSupport
Fetch the specified historical table.
historicalTable(String, String) - Method in interface io.deephaven.enterprise.database.Database
Fetch a static historical Table from the database.
historicalTable(String, String) - Method in class io.deephaven.enterprise.database.impl.DatabaseImpl
 
historicalTable(String, String) - Static method in class io.deephaven.enterprise.dnd.client.DndSession
Create a TableSpec based on a historical table from the server.
historicalTable(String, String, TableOptions) - Method in interface io.deephaven.enterprise.database.Database
Fetch a static historical Table from the database.
historicalTable(String, String, TableOptions) - Method in class io.deephaven.enterprise.database.impl.DatabaseImpl
 
historicalTable(String, String, TableOptions) - Method in class io.deephaven.enterprise.replay.ReplayDatabase
 
HiveExtendedStorageProvider - Class in io.deephaven.enterprise.tabledataservice.extended
The provider for the coreplus:hive format, where tables are stored in the Apache Hive layout.
HiveExtendedStorageProvider() - Constructor for class io.deephaven.enterprise.tabledataservice.extended.HiveExtendedStorageProvider
 
HiveExtendedStorageProvider.Factory - Class in io.deephaven.enterprise.tabledataservice.extended
The factory class for creating this provider.
HiveKeyFinder - Class in io.deephaven.enterprise.locations.hive
A TableLocationKeyFinder that discovers Deephaven and parquet format tables that are laid out in Apache Hive style on disk.
HiveKeyFinder(File, TableDefinition) - Constructor for class io.deephaven.enterprise.locations.hive.HiveKeyFinder
 
HiveLocationsTableKeyFinder - Class in io.deephaven.enterprise.locations.hive
A TableLocationKeyFinder that uses a table of file names, sizes, and partitioning columns to provide table locations.
HiveLocationsTableKeyFinder(File, List<ColumnDefinition<?>>) - Constructor for class io.deephaven.enterprise.locations.hive.HiveLocationsTableKeyFinder
Construct a HiveLocationsTableKeyFinder using the tableRoot for resolving full paths and the specified locationsTable for locating keys.
HiveTableLocationFactory<TLK extends EnterpriseTableLocationKey> - Class in io.deephaven.enterprise.locations.hive
A TableLocationFactory for resolving Hive style keys to locations.
HiveTableLocationFactory(Schema) - Constructor for class io.deephaven.enterprise.locations.hive.HiveTableLocationFactory
 
hostName(String) - Method in class io.deephaven.enterprise.dnd.query.util.perf.PerformanceOverview
Set the host name of the desired worker.
hourly() - Static method in class io.deephaven.enterprise.kafkawriter.TimePartitionRotation
Return a function suitable for creating an hourly column partition from nanoseconds since the epoch.
hourly(ZoneId, int) - Static method in class io.deephaven.enterprise.kafkawriter.TimePartitionRotation
Return a function suitable for creating an hourly column partition from nanoseconds since the epoch.
HttpUrlPropertyInputStreamLoader - Class in io.deephaven.enterprise.config
A PropertyInputStreamLoader that loads files via HTTP GET requests to the specified host
HttpUrlPropertyInputStreamLoader() - Constructor for class io.deephaven.enterprise.config.HttpUrlPropertyInputStreamLoader
 
HybridSnapshotBackedTableLocation<REAL_LOCATION_TYPE extends AbstractTableLocation> - Class in io.deephaven.enterprise.locations.local
A TableLocation backed by a TableLocationMetadataIndex.LocationSnapshot that does not refresh and tries to avoid creating the actual location until it is truly needed.
HybridSnapshotBackedTableLocation(TableKey, TableLocationKey, TableLocationMetadataIndex.LocationSnapshot, Supplier<REAL_LOCATION_TYPE>) - Constructor for class io.deephaven.enterprise.locations.local.HybridSnapshotBackedTableLocation
 

I

IcebergConfiguration - Class in io.deephaven.enterprise.iceberg
Contains the configuration parameters needed to connect to an Iceberg Catalog and fetch Iceberg Tables.
IcebergDataInstructions - Interface in io.deephaven.enterprise.iceberg
This interface provides an adapter layer between type specific data instructions and JSON serialization for IcebergEndpoint.
IcebergDataInstructions.Factory - Interface in io.deephaven.enterprise.iceberg
The factory interface for injecting implementations using ServiceLoader.
IcebergEndpoint - Class in io.deephaven.enterprise.iceberg
The complete configuration required to locate an Iceberg table within a Catalog and then fetch the Iceberg table into Deephaven.
IcebergEndpoint.Builder - Interface in io.deephaven.enterprise.iceberg
A Builder object for construction of a IcebergEndpoint.
IcebergEndpoint.Named - Class in io.deephaven.enterprise.iceberg
An IcebergEndpoint that is also named.
IcebergExtendedStorageProvider - Class in io.deephaven.enterprise.iceberg
An ExtendedStorageProvider for the coreplus:iceberg type.
IcebergExtendedStorageProvider() - Constructor for class io.deephaven.enterprise.iceberg.IcebergExtendedStorageProvider
 
IcebergExtendedStorageProvider.Factory - Class in io.deephaven.enterprise.iceberg
The factory class for creating this provider.
IcebergS3Instructions - Class in io.deephaven.enterprise.iceberg
An implementation of IcebergDataInstructions used to serialize and deserialize S3Instructions for fetching tables from an S3 store.
IcebergS3Instructions.Deserializer - Class in io.deephaven.enterprise.iceberg
A deserializer for S3Instructions.
IcebergS3Instructions.Factory - Class in io.deephaven.enterprise.iceberg
The factory instance.
IcebergS3Instructions.Serializer - Class in io.deephaven.enterprise.iceberg
A serializer for S3Instructions that only writes values that do not match the deephaven default values.
IcebergTools - Class in io.deephaven.enterprise.iceberg
Common utilities for loading Iceberg tables as Deephaven Tables
ignoreColumn(String) - Method in class io.deephaven.enterprise.kafkawriter.KafkaTableWriter.Options
Specify a column from the source Kafka table that are ignored.
ignoreColumns(Collection<String>) - Method in class io.deephaven.enterprise.kafkawriter.KafkaTableWriter.Options
Specify columns from the source Kafka table that are ignored.
ignoreOffsetFromBroker(boolean) - Method in class io.deephaven.enterprise.kafkawriter.KafkaTableWriter.Options
Set a flag to determine whether previously-committed offsets at the broker will be respected.
ignoreOffsetFromCheckpoints(boolean) - Method in class io.deephaven.enterprise.kafkawriter.KafkaTableWriter.Options
Set a flag to determine whether previously-committed offsets from earlier checkpoint records will be respected.
ImportStateComparator - Class in io.deephaven.enterprise.ingester.impl
For the CompositeImportState we need to have a well-defined order.
ImportStateComparator() - Constructor for class io.deephaven.enterprise.ingester.impl.ImportStateComparator
 
ImportStateDetails - Class in io.deephaven.enterprise.ingester.impl
An import state details provides the class, constructor arguments, and key columns for an ImportState.
ImportStateDetails(Class<? extends TupleKeyedAbstractImportState>, List<String>, Class<?>[], Object[]) - Constructor for class io.deephaven.enterprise.ingester.impl.ImportStateDetails
 
ImportStateDetails(Class<? extends TupleKeyedAbstractImportState>, List<String>) - Constructor for class io.deephaven.enterprise.ingester.impl.ImportStateDetails
 
importStateKeyColumns() - Method in class io.deephaven.enterprise.ingester.impl.ImportStateDetails
 
includedColumns() - Method in interface io.deephaven.enterprise.remote.SubscriptionOptions
Get the columns to include from the upstream table.
ingestPartitionedTable(String, String, DataImportServer, PartitionedTable, DerivedTableWriter.PartitionedOptions, DerivedTableWriter.Options) - Static method in class io.deephaven.enterprise.derivedtablewriter.DerivedTableWriter
Ingest a PartitionedTable to an in-worker DIS.
ingestTable(String, String, String, String, DataImportServer, Table, DerivedTableWriter.Options) - Static method in class io.deephaven.enterprise.derivedtablewriter.DerivedTableWriter
Ingest a Table to an in-worker DIS.
init(TableDefinition) - Method in class io.deephaven.enterprise.compatibility.filter.EnterpriseFilterAdapter
 
init(Database) - Static method in class io.deephaven.coreplus.querylog.QueryLogSetupQuery
 
INITIAL_DECODER_BUFFER_SIZE - Static variable in class io.deephaven.enterprise.sources.regioned.impl.RegionUtilities
Initial size for new decoder buffers.
initialize(String) - Method in class io.deephaven.enterprise.dnd.authentication.DheAuthenticationHandler
 
inputTable(String, String) - Method in class io.deephaven.enterprise.database.impl.DatabaseImpl
 
inputTable(String, String) - Method in interface io.deephaven.enterprise.database.WritableDatabase
Retrieve the specified input table view.
inputTable(String, String) - Method in class io.deephaven.enterprise.replay.WritableReplayDatabase
 
InputTableConstants - Class in io.deephaven.enterprise.database.inputtables
 
InputTableConverter - Class in io.deephaven.enterprise.database.inputtables
Tool to convert Legacy input tables into new Core+ input tables.
InputTableSnapshotter - Class in io.deephaven.enterprise.database.inputtables
Tool to snapshot specified Core+ input tables.
inputTableSpecFor(String, String) - Method in class io.deephaven.enterprise.database.impl.DatabaseImpl
 
inputTableSpecFor(String, String) - Method in interface io.deephaven.enterprise.database.WritableDatabase
Retrieve the current InputTableSpec for the given namespace and table.
inputTableSpecFor(String, String) - Method in class io.deephaven.enterprise.replay.WritableReplayDatabase
 
InputTableTool - Interface in io.deephaven.enterprise.database.inputtables
Handles the targeting and reporting of Core+ executions on multiple input tables.
inputTableUpdater(String, String) - Method in class io.deephaven.enterprise.database.impl.DatabaseImpl
 
inputTableUpdater(String, String) - Method in interface io.deephaven.enterprise.database.WritableDatabase
Retrieve the specified InputTableUpdater, which can be used to programmatically add or delete rows.
inputTableUpdater(String, String) - Method in class io.deephaven.enterprise.replay.WritableReplayDatabase
 
InputTableUpdater - Interface in io.deephaven.enterprise.database.inputtables
An extension of InputTableUpdater that is a LivenessReferent and allows materializing the resulting Table.
INSTANCE - Static variable in class io.deephaven.shadow.enterprise.com.illumon.iris.db.v2.sources.chunk.EnterpriseByteChunkAdapter
 
INSTANCE - Static variable in class io.deephaven.shadow.enterprise.com.illumon.iris.db.v2.sources.chunk.EnterpriseCharChunkAdapter
 
INSTANCE - Static variable in class io.deephaven.shadow.enterprise.com.illumon.iris.db.v2.sources.chunk.EnterpriseDoubleChunkAdapter
 
INSTANCE - Static variable in class io.deephaven.shadow.enterprise.com.illumon.iris.db.v2.sources.chunk.EnterpriseFloatChunkAdapter
 
INSTANCE - Static variable in class io.deephaven.shadow.enterprise.com.illumon.iris.db.v2.sources.chunk.EnterpriseIntChunkAdapter
 
INSTANCE - Static variable in class io.deephaven.shadow.enterprise.com.illumon.iris.db.v2.sources.chunk.EnterpriseLongChunkAdapter
 
INSTANCE - Static variable in class io.deephaven.shadow.enterprise.com.illumon.iris.db.v2.sources.chunk.EnterpriseObjectChunkAdapter
 
INSTANCE - Static variable in class io.deephaven.shadow.enterprise.com.illumon.iris.db.v2.sources.chunk.EnterpriseShortChunkAdapter
 
instantMillis() - Method in class io.deephaven.enterprise.replay.DeltaClockWithAdjustableSpeed
 
instantMillis() - Method in class io.deephaven.enterprise.replay.DeltaClockWithSpeed
 
instantNanos() - Method in class io.deephaven.enterprise.replay.DeltaClockWithAdjustableSpeed
 
instantNanos() - Method in class io.deephaven.enterprise.replay.DeltaClockWithSpeed
 
Int - Enum constant in enum class io.deephaven.enterprise.sources.regioned.BufferedType
 
IntColumnRegionAdapter<ATTR extends Values> - Class in io.deephaven.enterprise.compatibility.region
Adapts a Legacy ColumnRegionInt to a Core ColumnRegionInt.
IntColumnRegionAdapter(ColumnRegionInt<?>) - Constructor for class io.deephaven.enterprise.compatibility.region.IntColumnRegionAdapter
 
intercept(String, Throwable, boolean) - Method in class io.deephaven.enterprise.dnd.service.pqworker.PQWorkerServiceGrpcImpl
 
intercept(PQWorkerApiGrpc.PQWorkerApiImplBase) - Method in interface io.deephaven.enterprise.dnd.authentication.PQWorkerServiceAuthWiring
Wrap the real implementation with authorization checks.
internalGetFieldAccessorTable() - Method in class io.deephaven.proto.pivot.ErrorResponse.Builder
 
internalGetFieldAccessorTable() - Method in class io.deephaven.proto.pivot.ErrorResponse
 
internalGetFieldAccessorTable() - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
 
internalGetFieldAccessorTable() - Method in class io.deephaven.proto.pivot.PivotPluginRequest
 
internalGetFieldAccessorTable() - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
 
internalGetFieldAccessorTable() - Method in class io.deephaven.proto.pivot.PivotPluginResponse
 
internalGetFieldAccessorTable() - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
 
internalGetFieldAccessorTable() - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest
 
internalGetFieldAccessorTable() - Method in class io.deephaven.proto.pivot.PivotTableApplyResponse.Builder
 
internalGetFieldAccessorTable() - Method in class io.deephaven.proto.pivot.PivotTableApplyResponse
 
internalGetFieldAccessorTable() - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
 
internalGetFieldAccessorTable() - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest
 
internalGetFieldAccessorTable() - Method in class io.deephaven.proto.pivot.PivotTableCreationResponse.Builder
 
internalGetFieldAccessorTable() - Method in class io.deephaven.proto.pivot.PivotTableCreationResponse
 
internalGetFieldAccessorTable() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage.Builder
 
internalGetFieldAccessorTable() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage
 
internalGetFieldAccessorTable() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorRequest.Builder
 
internalGetFieldAccessorTable() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorRequest
 
internalGetFieldAccessorTable() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse.Builder
 
internalGetFieldAccessorTable() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse
 
internalGetFieldAccessorTable() - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest.Builder
 
internalGetFieldAccessorTable() - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest
 
internalGetFieldAccessorTable() - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse.Builder
 
internalGetFieldAccessorTable() - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse
 
internalGetFieldAccessorTable() - Method in class io.deephaven.proto.pivot.PivotTableSourceExportRequest.Builder
 
internalGetFieldAccessorTable() - Method in class io.deephaven.proto.pivot.PivotTableSourceExportRequest
 
internalGetFieldAccessorTable() - Method in class io.deephaven.proto.pivot.PivotTableSourceExportResponse.Builder
 
internalGetFieldAccessorTable() - Method in class io.deephaven.proto.pivot.PivotTableSourceExportResponse
 
internalGetFieldAccessorTable() - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage.Builder
 
internalGetFieldAccessorTable() - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage
 
internalGetFieldAccessorTable() - Method in class io.deephaven.proto.pivot.PivotTableViewRequest.Builder
 
internalGetFieldAccessorTable() - Method in class io.deephaven.proto.pivot.PivotTableViewRequest
 
internalGetFieldAccessorTable() - Method in class io.deephaven.proto.pivot.PivotTableViewResponse.Builder
 
internalGetFieldAccessorTable() - Method in class io.deephaven.proto.pivot.PivotTableViewResponse
 
internalGetFieldAccessorTable() - Method in class io.deephaven.proto.pqworker.ListenErrorRequest.Builder
 
internalGetFieldAccessorTable() - Method in class io.deephaven.proto.pqworker.ListenErrorRequest
 
internalGetFieldAccessorTable() - Method in class io.deephaven.proto.pqworker.ListenErrorResponse.Builder
 
internalGetFieldAccessorTable() - Method in class io.deephaven.proto.pqworker.ListenErrorResponse
 
internalGetFieldAccessorTable() - Method in class io.deephaven.proto.pqworker.ObjectAccessRequest.Builder
 
internalGetFieldAccessorTable() - Method in class io.deephaven.proto.pqworker.ObjectAccessRequest
 
internalGetFieldAccessorTable() - Method in class io.deephaven.proto.pqworker.ObjectAccessResponse.Builder
 
internalGetFieldAccessorTable() - Method in class io.deephaven.proto.pqworker.ObjectAccessResponse
 
internalGetFieldAccessorTable() - Method in class io.deephaven.proto.pqworker.StringList.Builder
 
internalGetFieldAccessorTable() - Method in class io.deephaven.proto.pqworker.StringList
 
internalGetFieldAccessorTable() - Method in class io.deephaven.proto.pqworker.ThreadDumpRequest.Builder
 
internalGetFieldAccessorTable() - Method in class io.deephaven.proto.pqworker.ThreadDumpRequest
 
internalGetFieldAccessorTable() - Method in class io.deephaven.proto.pqworker.ThreadDumpResponse.Builder
 
internalGetFieldAccessorTable() - Method in class io.deephaven.proto.pqworker.ThreadDumpResponse
 
internalGetMapFieldReflection(int) - Method in class io.deephaven.proto.pqworker.ObjectAccessResponse.Builder
 
internalGetMapFieldReflection(int) - Method in class io.deephaven.proto.pqworker.ObjectAccessResponse
 
internalGetMutableMapFieldReflection(int) - Method in class io.deephaven.proto.pqworker.ObjectAccessResponse.Builder
 
internalPartition() - Method in class io.deephaven.enterprise.database.SystemTableLogger.Options
What internal partition should we write to?
internalPartition(String) - Method in interface io.deephaven.enterprise.database.SystemTableLogger.Options.Builder
What internal partition should we write to?
internalPartitionColumn() - Method in class io.deephaven.enterprise.database.TableOptions
The name of the internal partition column in the fetched table.
internalPartitionColumn(String) - Method in interface io.deephaven.enterprise.database.TableOptions.Builder
Sets the name of the internal partition column, defaults to null.
internalPartitionKey() - Method in class io.deephaven.enterprise.derivedtablewriter.DerivedTableWriter.PartitionedOptions
Retrieves the internal partition key column name.
internalPartitionKey(String) - Method in class io.deephaven.enterprise.derivedtablewriter.DerivedTableWriter.PartitionedOptions
Sets the internal partition key column name.
internalPartitionValue(String) - Method in class io.deephaven.enterprise.derivedtablewriter.DerivedTableWriter.PartitionedOptions
Sets the fixed internal partition value.
InvalidatableRegion<ATTR extends Values> - Class in io.deephaven.enterprise.sources.regioned.impl
 
InvalidatableRegion() - Constructor for class io.deephaven.enterprise.sources.regioned.impl.InvalidatableRegion
 
invalidate() - Method in class io.deephaven.enterprise.sources.regioned.impl.InvalidatableRegion
 
invalidateCache() - Method in class io.deephaven.enterprise.dnd.classloader.ControllerClientClassLoader
Made public so script session can invalidate cache on evaluations.
io.deephaven.chunk - package io.deephaven.chunk
 
io.deephaven.coreplus.querylog - package io.deephaven.coreplus.querylog
 
io.deephaven.enterprise.acl - package io.deephaven.enterprise.acl
 
io.deephaven.enterprise.acl.generator - package io.deephaven.enterprise.acl.generator
 
io.deephaven.enterprise.acl.impl - package io.deephaven.enterprise.acl.impl
 
io.deephaven.enterprise.acl.transform - package io.deephaven.enterprise.acl.transform
 
io.deephaven.enterprise.compatibility - package io.deephaven.enterprise.compatibility
 
io.deephaven.enterprise.compatibility.chunk - package io.deephaven.enterprise.compatibility.chunk
 
io.deephaven.enterprise.compatibility.filter - package io.deephaven.enterprise.compatibility.filter
 
io.deephaven.enterprise.compatibility.locationprovider - package io.deephaven.enterprise.compatibility.locationprovider
 
io.deephaven.enterprise.compatibility.region - package io.deephaven.enterprise.compatibility.region
 
io.deephaven.enterprise.compatibility.rowset - package io.deephaven.enterprise.compatibility.rowset
 
io.deephaven.enterprise.compatibility.shadow - package io.deephaven.enterprise.compatibility.shadow
 
io.deephaven.enterprise.compatibility.vector - package io.deephaven.enterprise.compatibility.vector
 
io.deephaven.enterprise.config - package io.deephaven.enterprise.config
 
io.deephaven.enterprise.database - package io.deephaven.enterprise.database
 
io.deephaven.enterprise.database.impl - package io.deephaven.enterprise.database.impl
 
io.deephaven.enterprise.database.inputtables - package io.deephaven.enterprise.database.inputtables
 
io.deephaven.enterprise.dataimportserver - package io.deephaven.enterprise.dataimportserver
 
io.deephaven.enterprise.derivedtablewriter - package io.deephaven.enterprise.derivedtablewriter
 
io.deephaven.enterprise.dnd - package io.deephaven.enterprise.dnd
 
io.deephaven.enterprise.dnd.authentication - package io.deephaven.enterprise.dnd.authentication
 
io.deephaven.enterprise.dnd.authentication.transform - package io.deephaven.enterprise.dnd.authentication.transform
 
io.deephaven.enterprise.dnd.autocomplete - package io.deephaven.enterprise.dnd.autocomplete
 
io.deephaven.enterprise.dnd.classloader - package io.deephaven.enterprise.dnd.classloader
 
io.deephaven.enterprise.dnd.client - package io.deephaven.enterprise.dnd.client
 
io.deephaven.enterprise.dnd.client.exception - package io.deephaven.enterprise.dnd.client.exception
 
io.deephaven.enterprise.dnd.controller - package io.deephaven.enterprise.dnd.controller
 
io.deephaven.enterprise.dnd.logger.engine.impl - package io.deephaven.enterprise.dnd.logger.engine.impl
 
io.deephaven.enterprise.dnd.modules - package io.deephaven.enterprise.dnd.modules
 
io.deephaven.enterprise.dnd.notebook - package io.deephaven.enterprise.dnd.notebook
 
io.deephaven.enterprise.dnd.query.util.perf - package io.deephaven.enterprise.dnd.query.util.perf
 
io.deephaven.enterprise.dnd.service.pqworker - package io.deephaven.enterprise.dnd.service.pqworker
 
io.deephaven.enterprise.dnd.service.ticket - package io.deephaven.enterprise.dnd.service.ticket
 
io.deephaven.enterprise.dnd.uri - package io.deephaven.enterprise.dnd.uri
 
io.deephaven.enterprise.extensions - package io.deephaven.enterprise.extensions
 
io.deephaven.enterprise.iceberg - package io.deephaven.enterprise.iceberg
 
io.deephaven.enterprise.iceberg.discovery - package io.deephaven.enterprise.iceberg.discovery
 
io.deephaven.enterprise.ingester.impl - package io.deephaven.enterprise.ingester.impl
Utilities for the Deephaven Core+ ingestion framework.
io.deephaven.enterprise.kafkawriter - package io.deephaven.enterprise.kafkawriter
 
io.deephaven.enterprise.lastbystate - package io.deephaven.enterprise.lastbystate
 
io.deephaven.enterprise.locations - package io.deephaven.enterprise.locations
 
io.deephaven.enterprise.locations.hive - package io.deephaven.enterprise.locations.hive
 
io.deephaven.enterprise.locations.impl - package io.deephaven.enterprise.locations.impl
 
io.deephaven.enterprise.locations.local - package io.deephaven.enterprise.locations.local
 
io.deephaven.enterprise.locations.local.deephaven - package io.deephaven.enterprise.locations.local.deephaven
 
io.deephaven.enterprise.locations.nestedpartitioned - package io.deephaven.enterprise.locations.nestedpartitioned
 
io.deephaven.enterprise.locations.remote - package io.deephaven.enterprise.locations.remote
 
io.deephaven.enterprise.pivot.flatbuf - package io.deephaven.enterprise.pivot.flatbuf
 
io.deephaven.enterprise.remote - package io.deephaven.enterprise.remote
 
io.deephaven.enterprise.replay - package io.deephaven.enterprise.replay
 
io.deephaven.enterprise.secrets - package io.deephaven.enterprise.secrets
 
io.deephaven.enterprise.sources.regioned - package io.deephaven.enterprise.sources.regioned
 
io.deephaven.enterprise.sources.regioned.impl - package io.deephaven.enterprise.sources.regioned.impl
 
io.deephaven.enterprise.table - package io.deephaven.enterprise.table
 
io.deephaven.enterprise.tabledataservice - package io.deephaven.enterprise.tabledataservice
 
io.deephaven.enterprise.tabledataservice.extended - package io.deephaven.enterprise.tabledataservice.extended
 
io.deephaven.enterprise.tabledataservice.filter - package io.deephaven.enterprise.tabledataservice.filter
 
io.deephaven.enterprise.test - package io.deephaven.enterprise.test
 
io.deephaven.enterprise.workspace - package io.deephaven.enterprise.workspace
 
io.deephaven.pivot - package io.deephaven.pivot
 
io.deephaven.proto.pivot - package io.deephaven.proto.pivot
 
io.deephaven.proto.pqworker - package io.deephaven.proto.pqworker
 
io.deephaven.proto.pqworker.grpc - package io.deephaven.proto.pqworker.grpc
 
io.deephaven.shadow.enterprise.com.illumon.iris.db.v2.select - package io.deephaven.shadow.enterprise.com.illumon.iris.db.v2.select
 
io.deephaven.shadow.enterprise.com.illumon.iris.db.v2.sources.chunk - package io.deephaven.shadow.enterprise.com.illumon.iris.db.v2.sources.chunk
 
IS_STATIC_FIELD_NUMBER - Static variable in class io.deephaven.proto.pivot.PivotTableDescriptorMessage
 
isAclEditor(UserContext) - Method in interface io.deephaven.enterprise.dnd.authentication.GroupProvider
Check if the specified user is an ACL editor.
isAclEditor(UserContext) - Method in class io.deephaven.enterprise.dnd.authentication.WrappedGroupProvider
 
isAdmin(UserContext) - Static method in class io.deephaven.enterprise.dnd.authentication.DheAuthenticationHandler
Check if the specified user is an administrator of this worker.
isAutomatedFilter() - Method in class io.deephaven.enterprise.compatibility.filter.EnterpriseFilterAdapter
 
isBlink() - Method in class io.deephaven.enterprise.database.TableOptions
Get if the result table will be a Blink table.
isBlink() - Method in interface io.deephaven.enterprise.remote.ConnectionAwareRemoteTableParams
Indicate that the table is a Blink table.
isBlink(boolean) - Method in interface io.deephaven.enterprise.database.TableOptions.Builder
Set if the result table will be a blink table.
isBlink(boolean) - Method in interface io.deephaven.enterprise.remote.ConnectionAwareRemoteTableParams.Builder
Set if the table is a blink table.
isBlink(boolean) - Method in class io.deephaven.enterprise.remote.RemoteTableBuilder
Mark the fetched table as a blink table.
isConnected() - Method in interface io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClient
Check if the client is connected to the Controller.
isConnected() - Method in class io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClientImpl
 
isContiguous() - Method in class io.deephaven.enterprise.compatibility.rowset.OrderedKeysToRowSequenceAdapter
 
isContiguous() - Method in class io.deephaven.enterprise.compatibility.rowset.RowSequenceToOrderedKeysAdapter
 
isEmpty() - Method in class io.deephaven.enterprise.compatibility.rowset.OrderedKeysToRowSequenceAdapter
 
isEmpty() - Method in class io.deephaven.enterprise.compatibility.rowset.RowSequenceToOrderedKeysAdapter
 
isFile() - Method in class io.deephaven.enterprise.dnd.notebook.NotebookReader.FileOrFolder
Is this a file?
isFlat() - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
isFolder() - Method in class io.deephaven.enterprise.dnd.notebook.NotebookReader.FileOrFolder
Is this a folder?
isImmutable() - Method in class io.deephaven.enterprise.compatibility.filter.ColumnSourceAdapterForFilter
 
isInitialized() - Method in class io.deephaven.proto.pivot.ErrorResponse.Builder
 
isInitialized() - Method in class io.deephaven.proto.pivot.ErrorResponse
 
isInitialized() - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
 
isInitialized() - Method in class io.deephaven.proto.pivot.PivotPluginRequest
 
isInitialized() - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
 
isInitialized() - Method in class io.deephaven.proto.pivot.PivotPluginResponse
 
isInitialized() - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
 
isInitialized() - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest
 
isInitialized() - Method in class io.deephaven.proto.pivot.PivotTableApplyResponse.Builder
 
isInitialized() - Method in class io.deephaven.proto.pivot.PivotTableApplyResponse
 
isInitialized() - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
 
isInitialized() - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest
 
isInitialized() - Method in class io.deephaven.proto.pivot.PivotTableCreationResponse.Builder
 
isInitialized() - Method in class io.deephaven.proto.pivot.PivotTableCreationResponse
 
isInitialized() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage.Builder
 
isInitialized() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage
 
isInitialized() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorRequest.Builder
 
isInitialized() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorRequest
 
isInitialized() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse.Builder
 
isInitialized() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse
 
isInitialized() - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest.Builder
 
isInitialized() - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest
 
isInitialized() - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse.Builder
 
isInitialized() - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse
 
isInitialized() - Method in class io.deephaven.proto.pivot.PivotTableSourceExportRequest.Builder
 
isInitialized() - Method in class io.deephaven.proto.pivot.PivotTableSourceExportRequest
 
isInitialized() - Method in class io.deephaven.proto.pivot.PivotTableSourceExportResponse.Builder
 
isInitialized() - Method in class io.deephaven.proto.pivot.PivotTableSourceExportResponse
 
isInitialized() - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage.Builder
 
isInitialized() - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage
 
isInitialized() - Method in class io.deephaven.proto.pivot.PivotTableViewRequest.Builder
 
isInitialized() - Method in class io.deephaven.proto.pivot.PivotTableViewRequest
 
isInitialized() - Method in class io.deephaven.proto.pivot.PivotTableViewResponse.Builder
 
isInitialized() - Method in class io.deephaven.proto.pivot.PivotTableViewResponse
 
isInitialized() - Method in class io.deephaven.proto.pqworker.ListenErrorRequest.Builder
 
isInitialized() - Method in class io.deephaven.proto.pqworker.ListenErrorRequest
 
isInitialized() - Method in class io.deephaven.proto.pqworker.ListenErrorResponse.Builder
 
isInitialized() - Method in class io.deephaven.proto.pqworker.ListenErrorResponse
 
isInitialized() - Method in class io.deephaven.proto.pqworker.ObjectAccessRequest.Builder
 
isInitialized() - Method in class io.deephaven.proto.pqworker.ObjectAccessRequest
 
isInitialized() - Method in class io.deephaven.proto.pqworker.ObjectAccessResponse.Builder
 
isInitialized() - Method in class io.deephaven.proto.pqworker.ObjectAccessResponse
 
isInitialized() - Method in class io.deephaven.proto.pqworker.StringList.Builder
 
isInitialized() - Method in class io.deephaven.proto.pqworker.StringList
 
isInitialized() - Method in class io.deephaven.proto.pqworker.ThreadDumpRequest.Builder
 
isInitialized() - Method in class io.deephaven.proto.pqworker.ThreadDumpRequest
 
isInitialized() - Method in class io.deephaven.proto.pqworker.ThreadDumpResponse.Builder
 
isInitialized() - Method in class io.deephaven.proto.pqworker.ThreadDumpResponse
 
isInputTable(String, String) - Method in class io.deephaven.enterprise.database.impl.DatabaseImpl
 
isInputTable(String, String) - Method in interface io.deephaven.enterprise.database.WritableDatabase
Determines whether a table is a Core+ input table.
isInputTable(String, String) - Method in class io.deephaven.enterprise.replay.WritableReplayDatabase
 
isIntraday(boolean) - Method in class io.deephaven.enterprise.dnd.query.util.perf.PerformanceOverview
Set if the performance overview should be generated from intraday data.
isLive(boolean) - Method in class io.deephaven.enterprise.dnd.query.util.perf.PerformanceOverview
Set if the performance overview should refresh once generated.
isMember(UserContext, String, String...) - Method in interface io.deephaven.enterprise.dnd.authentication.GroupProvider
Check if the specified user is a member or supervisor of any of the specified groups.
isMember(UserContext, String, String...) - Method in class io.deephaven.enterprise.dnd.authentication.WrappedGroupProvider
 
isNullable() - Method in class io.deephaven.enterprise.compatibility.ObjectCodecAdapter
 
isNullable() - Method in class io.deephaven.enterprise.compatibility.shadow.ShadowingSerializableDecoder
 
isNullOrTrueFilter(Filter) - Static method in class io.deephaven.enterprise.acl.impl.AclHelper
 
isReady() - Method in class io.deephaven.enterprise.remote.ControllerStateWatcher.PersistentQueryStateToken
 
isReady() - Method in interface io.deephaven.enterprise.remote.RemoteTableStateWatcher.StateToken
Is the upstream ready for subscriptions?
isRefreshing() - Method in class io.deephaven.enterprise.compatibility.filter.EnterpriseFilterAdapter
 
isRefreshing() - Method in class io.deephaven.enterprise.database.TableOptions
Get if the result table will be refreshing.
isResolvable(URI) - Method in class io.deephaven.enterprise.dnd.uri.PQUriResolver
 
isSameTarget(RemoteTableStateWatcher.StateToken) - Method in class io.deephaven.enterprise.remote.ControllerStateWatcher.PersistentQueryStateToken
 
isSameTarget(RemoteTableStateWatcher.StateToken) - Method in interface io.deephaven.enterprise.remote.RemoteTableStateWatcher.StateToken
Check if this RemoteTableStateWatcher.StateToken represents the same target connection.
isSimpleFilter() - Method in class io.deephaven.enterprise.compatibility.filter.EnterpriseFilterAdapter
 
isSuperUser(UserContext) - Method in interface io.deephaven.enterprise.dnd.authentication.GroupProvider
Check if the specified user is a superuser.
isSuperUser(UserContext) - Method in class io.deephaven.enterprise.dnd.authentication.WrappedGroupProvider
 
isType(Object) - Method in class io.deephaven.pivot.PivotServicePlugin
 
isType(Object) - Method in class io.deephaven.pivot.PivotTablePlugin
 
isValidTarget(Database, InputTableNameTarget) - Method in class io.deephaven.enterprise.database.inputtables.InputTableSnapshotter
 
isValidTarget(Database, InputTableNameTarget) - Method in interface io.deephaven.enterprise.database.inputtables.InputTableTool
Determines whether input table target is valid and should be executed.
isValidToRefresh() - Method in class io.deephaven.enterprise.lastbystate.CoreLastByTableImportState
 
isViewer(UserContext) - Static method in class io.deephaven.enterprise.dnd.authentication.DheAuthenticationHandler
Check if the specified user is a viewer of this worker.

J

join(Table, MatchPair[], MatchPair[], int) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
JsonFilesSecretsProvider - Class in io.deephaven.enterprise.secrets
A SecretsProvider that sources secrets from a file on disk in Property format.
JsonFilesSecretsProvider(Path, int, String) - Constructor for class io.deephaven.enterprise.secrets.JsonFilesSecretsProvider
Create a new instance using the provided path to the secrets file.
JsonFilesSecretsProvider.Factory - Class in io.deephaven.enterprise.secrets
A factory to create a JsonFilesSecretsProvider from an XML Element.

K

kafkaProperties(Properties) - Method in class io.deephaven.enterprise.kafkawriter.KafkaTableWriter.Options
Set the properties for the underlying KafkaConsumer, this is a required option.
KafkaTableWriter - Class in io.deephaven.enterprise.kafkawriter
The KafkaTableWriter creates a Deephaven Core KafkaIngester that persists the data to disk and serves it to other queries using an in-worker instance of the DataImportServer.
KafkaTableWriter() - Constructor for class io.deephaven.enterprise.kafkawriter.KafkaTableWriter
 
KafkaTableWriter.Options - Class in io.deephaven.enterprise.kafkawriter
A builder class containing the options for Kafka ingestion.
KEY_PROCESS_INFO_ID - Static variable in class io.deephaven.enterprise.dnd.Main
 
keySpec(KafkaTools.Consume.KeyOrValueSpec) - Method in class io.deephaven.enterprise.kafkawriter.KafkaTableWriter.Options
Determine how the key is converted to table columns.

L

lasEnabled() - Method in class io.deephaven.enterprise.database.SystemTableLogger.Options
If the LAS is explicitly specified, then use that value.
LAST_MODIFIED_NANOS_COLUMN_NAME - Static variable in class io.deephaven.enterprise.locations.hive.HiveLocationsTableKeyFinder
The column name containing the epoch timestamp of the time the partition was last modified.
lastBy(SelectColumn...) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
lastBy(String...) - Method in class io.deephaven.enterprise.kafkawriter.KafkaTableWriter.Options
Specify that this DIS should produce a lastBy view of the table with the given key columns using a CoreLastByTableImportState under the hood.
lastBy(String, Collection<String>) - Method in class io.deephaven.enterprise.derivedtablewriter.DerivedTableWriter.Options
Specify that this DIS should produce a lastBy view of the table with the given key columns using a CoreLastByTableImportState under the hood.
lastBy(String, Collection<String>) - Method in class io.deephaven.enterprise.kafkawriter.KafkaTableWriter.Options
Specify that this DIS should produce a lastBy view of the table with the given key columns using a CoreLastByTableImportState under the hood.
lastBy(Collection<String>) - Method in class io.deephaven.enterprise.derivedtablewriter.DerivedTableWriter.Options
Specify that this DIS should produce a lastBy view of the table with the given key columns using a CoreLastByTableImportState under the hood.
lastBy(Collection<String>) - Method in class io.deephaven.enterprise.kafkawriter.KafkaTableWriter.Options
Specify that this DIS should produce a lastBy view of the table with the given key columns using a CoreLastByTableImportState under the hood.
LastByPartitionedTableFactory - Class in io.deephaven.enterprise.lastbystate
The LastByPartitionedTableFactory attaches to an Enterprise DataImportServer and produces a Core PartitionedTable with one constituent entry per partition for a given namespace and table name.
lastKey() - Method in class io.deephaven.enterprise.compatibility.rowset.RowSequenceToOrderedKeysAdapter
 
lastRowKey() - Method in class io.deephaven.enterprise.compatibility.rowset.OrderedKeysToRowSequenceAdapter
 
latestSnapshot - Variable in class io.deephaven.enterprise.workspace.WorkspaceDataSnapshot
 
latestSnapshotDate - Variable in class io.deephaven.enterprise.workspace.WorkspaceDataSnapshot
 
layoutHints(String) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
lazyUpdate(SelectColumn...) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
leftJoin(Table, MatchPair[], MatchPair[]) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
lengthItems() - Method in interface io.deephaven.enterprise.sources.regioned.ColumnRegionByteWithLength
Get the total number of bytes within the region.
lengthItems() - Method in interface io.deephaven.enterprise.sources.regioned.ColumnRegionLongWithLength
Get the total number of longs within the region.
lengthItems() - Method in class io.deephaven.enterprise.sources.regioned.impl.BufferedColumnRegionBase
 
ListenErrorRequest - Class in io.deephaven.proto.pqworker
Protobuf type io.deephaven.proto.pqworker.ListenErrorRequest
ListenErrorRequest.Builder - Class in io.deephaven.proto.pqworker
Protobuf type io.deephaven.proto.pqworker.ListenErrorRequest
ListenErrorRequestOrBuilder - Exception in io.deephaven.proto.pqworker
 
ListenErrorRequestOrBuilder - Interface in io.deephaven.proto.pqworker
 
ListenErrorResponse - Class in io.deephaven.proto.pqworker
Protobuf type io.deephaven.proto.pqworker.ListenErrorResponse
ListenErrorResponse.Builder - Class in io.deephaven.proto.pqworker
Protobuf type io.deephaven.proto.pqworker.ListenErrorResponse
ListenErrorResponseOrBuilder - Exception in io.deephaven.proto.pqworker
 
ListenErrorResponseOrBuilder - Interface in io.deephaven.proto.pqworker
 
listenForError(ListenErrorRequest) - Method in class io.deephaven.proto.pqworker.grpc.PQWorkerApiGrpc.PQWorkerApiBlockingStub
 
listenForError(ListenErrorRequest, StreamObserver<ListenErrorResponse>) - Method in class io.deephaven.enterprise.dnd.service.pqworker.PQWorkerServiceGrpcImpl
 
listenForError(ListenErrorRequest, StreamObserver<ListenErrorResponse>) - Method in interface io.deephaven.proto.pqworker.grpc.PQWorkerApiGrpc.AsyncService
 
listenForError(ListenErrorRequest, StreamObserver<ListenErrorResponse>) - Method in class io.deephaven.proto.pqworker.grpc.PQWorkerApiGrpc.PQWorkerApiStub
 
livePartitionedTable(String, String) - Method in interface io.deephaven.enterprise.database.Database
Retrieve the specified live table as a PartitionedTable from the Database.
livePartitionedTable(String, String, TableOptions) - Method in interface io.deephaven.enterprise.database.Database
Retrieve the specified live table as a PartitionedTable from the Database.
livePartitionedTable(String, String, TableOptions) - Method in class io.deephaven.enterprise.database.impl.DatabaseImpl
 
livePartitionedTable(String, String, TableOptions) - Method in class io.deephaven.enterprise.replay.ReplayDatabase
 
liveTable(String, String) - Method in interface io.deephaven.enterprise.database.Database
Fetch a live Table for the specified namespace and table name.
liveTable(String, String) - Static method in class io.deephaven.enterprise.dnd.client.DndSession
Create a TableSpec based on a live table from the server.
liveTable(String, String, boolean) - Method in interface io.deephaven.enterprise.acl.AclSupport
Fetch the specified live (intraday) table.
liveTable(String, String, boolean) - Method in class io.deephaven.enterprise.database.impl.DatabaseImpl
 
liveTable(String, String, TableOptions) - Method in interface io.deephaven.enterprise.database.Database
Fetch a live Table for the specified namespace and table name.
liveTable(String, String, TableOptions) - Method in class io.deephaven.enterprise.database.impl.DatabaseImpl
 
liveTable(String, String, TableOptions) - Method in class io.deephaven.enterprise.replay.ReplayDatabase
 
LiveTableRegistrarAdapter - Class in io.deephaven.enterprise.compatibility
 
loadDataIndex(String...) - Method in class io.deephaven.enterprise.locations.local.deephaven.OnDiskDeephavenTableLocation
 
loadDataIndex(String...) - Method in class io.deephaven.enterprise.locations.remote.RemoteDeephavenTableLocation
 
loadDataIndexTable(File, String[]) - Static method in class io.deephaven.enterprise.locations.local.deephaven.OnDiskDeephavenTableLocation
Load a Data Index from an Enterprise on disk index table.
loadDefinitionFromDirectory(File, String) - Static method in class io.deephaven.enterprise.compatibility.TableDefinitionCompatibility
Load a TableDefinition from the definition file in the specified directory.
LOCATIONS_SUBDIRECTORY - Static variable in class io.deephaven.enterprise.locations.hive.HiveLocationsTableKeyFinder
The name of the subdirectory containing the locations table, in Deephaven format.
log - Variable in class io.deephaven.enterprise.workspace.WorkspaceDataSnapshot
 
log(long, String, String) - Method in class io.deephaven.enterprise.dnd.SimpleProcessEventLogger
 
log(UserContext, String, String, String, String) - Method in class io.deephaven.enterprise.dnd.SimpleAuditEventLogger
 
log(Row.Flags, long, String, String, String, String, long, long, long, long, long, long, long, long) - Method in class io.deephaven.enterprise.dnd.logger.engine.impl.ProcessMetricsLogLoggerDndImpl
 
log(String, long, long, char, String, long, long, long, long, long, long, long, long) - Method in class io.deephaven.enterprise.dnd.logger.engine.impl.ProcessMetricsLogLoggerDndImpl
 
log(String, String) - Method in class io.deephaven.enterprise.dnd.SimpleAuditEventLogger
 
log(String, String, String, String) - Method in class io.deephaven.enterprise.dnd.SimpleAuditEventLogger
 
logDependencies() - Method in class io.deephaven.enterprise.test.CapturingUpdateGraph
 
logDirectory() - Method in class io.deephaven.enterprise.database.SystemTableLogger.Options
Destination directory for binary log files.
logDirectory(String) - Method in interface io.deephaven.enterprise.database.SystemTableLogger.Options.Builder
Where should binary log files be written.
login(long, ByteBuffer, AuthenticationRequestHandler.HandshakeResponseListener) - Method in class io.deephaven.enterprise.dnd.authentication.DheAuthenticationHandler
 
login(String, AuthenticationRequestHandler.MetadataResponseListener) - Method in class io.deephaven.enterprise.dnd.authentication.DheAuthenticationHandler
 
logInitial(boolean) - Method in class io.deephaven.enterprise.derivedtablewriter.DerivedTableWriter.Options
Should the initial image of the table be logged?
logTable(Database, String, String, Table, SystemTableLogger.Options) - Static method in class io.deephaven.enterprise.database.SystemTableLogger
Write tableToLog to System storage.
logTable(Database, String, String, Table, SystemTableLogger.Options) - Static method in class io.deephaven.enterprise.database.impl.SystemTableLoggerImpl
 
logTableIncremental(Database, String, String, Table, SystemTableLogger.Options) - Static method in class io.deephaven.enterprise.database.SystemTableLogger
Write tableToLog and its updates to System storage.
logTableIncremental(Database, String, String, Table, SystemTableLogger.Options) - Static method in class io.deephaven.enterprise.database.impl.SystemTableLoggerImpl
 
logToRow(long, String, String) - Method in class io.deephaven.enterprise.dnd.SimpleProcessEventLogger
 
Long - Enum constant in enum class io.deephaven.enterprise.sources.regioned.BufferedType
 
LongColumnRegionAdapter<ATTR extends Values> - Class in io.deephaven.enterprise.compatibility.region
Adapts a Legacy ColumnRegionLong to a Core ColumnRegionLong.
LongColumnRegionAdapter(ColumnRegionLong<?>) - Constructor for class io.deephaven.enterprise.compatibility.region.LongColumnRegionAdapter
 
lookup(int, ChunkSource.FillContext) - Method in class io.deephaven.enterprise.sources.regioned.impl.ColumnRegionObjectCached
 
lookupSecretForTable(String, String, String, UserContext) - Method in class io.deephaven.enterprise.secrets.SecretsService
Look up the specified secret for the table.

M

main(String[]) - Static method in class io.deephaven.enterprise.dnd.Main
 
Main - Class in io.deephaven.enterprise.dnd
 
Main() - Constructor for class io.deephaven.enterprise.dnd.Main
 
make(String, int, int, Map<String, String>) - Method in interface io.deephaven.enterprise.remote.ManagedChannelFactory
Create a new ManagedChannel using the given host port and size.
make(ChunkType) - Static method in interface io.deephaven.enterprise.compatibility.chunk.ChunkAdapter
Create an appropriate adapter instance for the specified ChunkType
make(Table, Collection<Aggregation>, Collection<? extends ColumnName>, Collection<? extends ColumnName>) - Static method in interface io.deephaven.pivot.PivotTable
Create a new PivotTable.
makeColumnLocation(String) - Method in class io.deephaven.enterprise.locations.local.deephaven.OnDiskDeephavenTableLocation
 
makeColumnLocation(String) - Method in class io.deephaven.enterprise.locations.remote.RemoteDeephavenTableLocation
 
makeColumnRegionByte(ColumnDefinition<?>) - Method in interface io.deephaven.enterprise.locations.DeephavenFormatColumnLocation
 
makeColumnRegionChar(ColumnDefinition<?>) - Method in interface io.deephaven.enterprise.locations.DeephavenFormatColumnLocation
 
makeColumnRegionDouble(ColumnDefinition<?>) - Method in interface io.deephaven.enterprise.locations.DeephavenFormatColumnLocation
 
makeColumnRegionFloat(ColumnDefinition<?>) - Method in interface io.deephaven.enterprise.locations.DeephavenFormatColumnLocation
 
makeColumnRegionInt(ColumnDefinition<?>) - Method in interface io.deephaven.enterprise.locations.DeephavenFormatColumnLocation
 
makeColumnRegionLong(ColumnDefinition<?>) - Method in interface io.deephaven.enterprise.locations.DeephavenFormatColumnLocation
 
makeColumnRegionObject(ColumnDefinition<TYPE>) - Method in interface io.deephaven.enterprise.locations.DeephavenFormatColumnLocation
 
makeColumnRegionShort(ColumnDefinition<?>) - Method in interface io.deephaven.enterprise.locations.DeephavenFormatColumnLocation
 
makeControllerClientFactory() - Static method in class io.deephaven.enterprise.dnd.ControllerClientFactory
 
makeControllerClientFactory(AuthenticationClient, Client, ProcessInfo) - Static method in class io.deephaven.enterprise.dnd.ControllerClientFactory
 
makeControllerClientFactory(String) - Static method in class io.deephaven.enterprise.dnd.ControllerClientFactory
 
makeDefinition(boolean) - Method in class io.deephaven.enterprise.test.TestTableGenerator
 
makeDheDefinition() - Method in class io.deephaven.enterprise.test.TestTableGenerator
 
makeDheTable(String, int, String, long) - Method in class io.deephaven.enterprise.test.TestTableGenerator
 
makeDheTable(String, long) - Method in class io.deephaven.enterprise.test.TestTableGenerator
 
makeFillContext(int, SharedContext) - Method in class io.deephaven.enterprise.compatibility.region.ByteColumnRegionAdapter
 
makeFillContext(int, SharedContext) - Method in class io.deephaven.enterprise.compatibility.region.CharColumnRegionAdapter
 
makeFillContext(int, SharedContext) - Method in class io.deephaven.enterprise.compatibility.region.DoubleColumnRegionAdapter
 
makeFillContext(int, SharedContext) - Method in class io.deephaven.enterprise.compatibility.region.FloatColumnRegionAdapter
 
makeFillContext(int, SharedContext) - Method in class io.deephaven.enterprise.compatibility.region.IntColumnRegionAdapter
 
makeFillContext(int, SharedContext) - Method in class io.deephaven.enterprise.compatibility.region.LongColumnRegionAdapter
 
makeFillContext(int, SharedContext) - Method in class io.deephaven.enterprise.compatibility.region.ObjectColumnRegionAdapter
 
makeFillContext(int, SharedContext) - Method in class io.deephaven.enterprise.compatibility.region.ShortColumnRegionAdapter
 
makeFillContext(int, SharedContext) - Method in class io.deephaven.enterprise.sources.regioned.impl.BufferedColumnRegionBase
 
makeFillContext(int, SharedContext) - Method in class io.deephaven.enterprise.sources.regioned.impl.ColumnRegionObjectCodecFixed
 
makeFillContext(int, SharedContext) - Method in class io.deephaven.enterprise.sources.regioned.impl.ColumnRegionObjectCodecVariable
 
makeFillContext(int, SharedContext) - Method in class io.deephaven.enterprise.sources.regioned.impl.ColumnRegionObjectWithDictionary
 
makeFillContext(int, SharedContext) - Method in class io.deephaven.enterprise.compatibility.filter.ColumnSourceAdapterForFilter
 
makeFromExistingView(PivotTableView) - Static method in class io.deephaven.pivot.PivotTableView
Make a new PivotTableView from an existing one, which will snapshot the existing view's PivotTable with only the root expanded.
makeFromExistingView(PivotTableView, Table, Table, ColumnName, ColumnName, List<ColumnName>) - Static method in class io.deephaven.pivot.PivotTableView
Make a new PivotTableView from an existing one, which will snapshot the existing view's PivotTable according to the expansions described by rowKeyTable and columnKeyTable.
makeFromPivotTable(PivotTable) - Static method in class io.deephaven.pivot.PivotTableView
Make a new PivotTableView that will snapshot pivotTable with only the roots expanded.
makeFromPivotTable(PivotTable, Table, Table, ColumnName, ColumnName, List<ColumnName>) - Static method in class io.deephaven.pivot.PivotTableView
Make a new PivotTableView that will snapshot pivotTable according to the expansions described by rowKeyTable and columnKeyTable.
makeGetContext(int, SharedContext) - Method in class io.deephaven.enterprise.compatibility.region.ByteColumnRegionAdapter
 
makeGetContext(int, SharedContext) - Method in class io.deephaven.enterprise.compatibility.region.CharColumnRegionAdapter
 
makeGetContext(int, SharedContext) - Method in class io.deephaven.enterprise.compatibility.region.DoubleColumnRegionAdapter
 
makeGetContext(int, SharedContext) - Method in class io.deephaven.enterprise.compatibility.region.FloatColumnRegionAdapter
 
makeGetContext(int, SharedContext) - Method in class io.deephaven.enterprise.compatibility.region.IntColumnRegionAdapter
 
makeGetContext(int, SharedContext) - Method in class io.deephaven.enterprise.compatibility.region.LongColumnRegionAdapter
 
makeGetContext(int, SharedContext) - Method in class io.deephaven.enterprise.compatibility.region.ObjectColumnRegionAdapter
 
makeGetContext(int, SharedContext) - Method in class io.deephaven.enterprise.compatibility.region.ShortColumnRegionAdapter
 
makeGrpcChannel(String, int, Map<String, String>) - Method in class io.deephaven.enterprise.dnd.client.DeephavenClusterConnection
Construct a gRPC channel for communication with the Persistent Query
makeKey(Path, Map<String, Comparable<?>>) - Method in class io.deephaven.enterprise.locations.nestedpartitioned.NestedPartitionedKeyFinder
 
makeLocation(EnterpriseTableKey, EnterpriseTableLocationKey, TableDataRefreshService) - Method in class io.deephaven.enterprise.locations.hive.HiveTableLocationFactory
 
makeLocation(EnterpriseTableKey, EnterpriseTableLocationKey, TableDataRefreshService) - Method in class io.deephaven.enterprise.locations.nestedpartitioned.NestedPartitionedTableLocationFactory
 
makeParquetInstructions() - Method in class io.deephaven.enterprise.test.TestTableGenerator
 
makePartitionMap(String, TableLocationKey) - Static method in interface io.deephaven.enterprise.locations.FixedPartitionedEnterpriseTableLocationKey
Convert the enterprise TableLocationKey into a Community partition map.
makeRemoteTableDataService(String, DataRoutingService.PropertyProvider, boolean) - Method in class io.deephaven.enterprise.tabledataservice.TableDataServiceFactory
Create a new RemoteTableDataService, allowing for subclass overrides for testing.
makeSchemaFromDefinition(String, String, NamespaceSet, int, TableDefinition) - Static method in class io.deephaven.enterprise.test.CorePlusTestUtils
 
makeSchemaPayload(FlatBufferBuilder, PivotTable, List<Field>) - Static method in class io.deephaven.pivot.PivotTableSchemaUtil
Add a schema payload for a PivotTable to a FlatBufferBuilder.
makeSchemaPayload(FlatBufferBuilder, PivotTableView) - Static method in class io.deephaven.pivot.PivotTableSchemaUtil
Add a schema payload for a PivotTable to a FlatBufferBuilder.
makeSession(PersistentQueryInfoMessage, AuthToken, boolean, DeephavenClusterConnection) - Method in class io.deephaven.enterprise.dnd.client.DndSessionFactoryBarrage
 
makeSnapshotState() - Method in interface io.deephaven.pivot.PivotTable
Make a re-usable snapshot state.
makeTable(ExecutionContext, String, int, String, long) - Method in class io.deephaven.enterprise.test.TestTableGenerator
 
makeTable(ExecutionContext, String, long) - Method in class io.deephaven.enterprise.test.TestTableGenerator
 
makeTableLocation(TableLocationKey) - Method in class io.deephaven.enterprise.compatibility.locationprovider.CoreFromEnterpriseTableLocationProvider
 
makeTableLocationProvider(TableKey) - Method in class io.deephaven.enterprise.tabledataservice.OnDiskTableDataService
 
makeTableLocationProvider(TableKey) - Method in class io.deephaven.enterprise.tabledataservice.RemoteTableDataService
 
ManagedChannelFactory - Interface in io.deephaven.enterprise.remote
An object that produces a ManagedChannel given host, port and max message size.
MarkingPollingLocationProvider<TK extends TableKey,TLK extends TableLocationKey> - Class in io.deephaven.enterprise.tabledataservice
A TableLocationProvider that will perform a mark/sweep of active locations on refresh.
MarkingPollingLocationProvider(TK, TableLocationKeyFinder<TLK>, TableLocationFactory<TK, TLK>, TableDataRefreshService, TableUpdateMode, TableUpdateMode) - Constructor for class io.deephaven.enterprise.tabledataservice.MarkingPollingLocationProvider
 
mask() - Method in class io.deephaven.enterprise.compatibility.region.ByteColumnRegionAdapter
 
mask() - Method in class io.deephaven.enterprise.compatibility.region.CharColumnRegionAdapter
 
mask() - Method in class io.deephaven.enterprise.compatibility.region.DoubleColumnRegionAdapter
 
mask() - Method in class io.deephaven.enterprise.compatibility.region.FloatColumnRegionAdapter
 
mask() - Method in class io.deephaven.enterprise.compatibility.region.IntColumnRegionAdapter
 
mask() - Method in class io.deephaven.enterprise.compatibility.region.LongColumnRegionAdapter
 
mask() - Method in class io.deephaven.enterprise.compatibility.region.ObjectColumnRegionAdapter
 
mask() - Method in class io.deephaven.enterprise.compatibility.region.ShortColumnRegionAdapter
 
mask() - Method in interface io.deephaven.enterprise.sources.regioned.BufferedColumnRegion
 
mask() - Method in interface io.deephaven.enterprise.sources.regioned.BufferedPage
 
mask() - Method in class io.deephaven.enterprise.sources.regioned.impl.ColumnRegionObjectCached
 
mask() - Method in class io.deephaven.enterprise.sources.regioned.impl.ColumnRegionObjectCodecFixed
 
mask() - Method in class io.deephaven.enterprise.sources.regioned.impl.ColumnRegionObjectCodecVariable
 
mask() - Method in class io.deephaven.enterprise.sources.regioned.impl.ColumnRegionObjectWithDictionary
 
mask() - Method in class io.deephaven.enterprise.sources.regioned.impl.ColumnRegionStringSet
 
match(boolean, boolean, boolean, ReadOnlyIndex, Object...) - Method in class io.deephaven.enterprise.compatibility.filter.ColumnSourceAdapterForFilter
 
matchSubscriptionToken(T) - Method in class io.deephaven.enterprise.compatibility.locationprovider.CoreFromEnterpriseTableLocationProvider
 
matchSubscriptionToken(T) - Method in class io.deephaven.enterprise.locations.local.deephaven.OnDiskDeephavenTableLocation
 
matchSubscriptionToken(T) - Method in class io.deephaven.enterprise.locations.remote.RemoteDeephavenTableLocation
 
maxBy(SelectColumn...) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
maxRetriesWithinWindow() - Method in interface io.deephaven.enterprise.remote.SubscriptionOptions
The maximum number of retries to attempt within the window.
maxRetriesWithinWindow(long) - Method in interface io.deephaven.enterprise.remote.SubscriptionOptions.Builder
Set the maximum number of retries to attempt within the window.
maybeAddNotification(NotificationQueue.Notification, long) - Method in class io.deephaven.enterprise.test.CapturingUpdateGraph
 
maybeAddNotification(NotificationQueue.Notification, long) - Method in class io.deephaven.enterprise.compatibility.NotificationQueueAdapter
 
maybeEnabled() - Method in class io.deephaven.enterprise.replay.ComposableTableReplayConfiguration
Should the table be replayed?
maybeGetSpecialDecoderClass(Class<?>) - Static method in class io.deephaven.enterprise.compatibility.CodecCompatibility
 
maybeMutateCommunityType(Class<?>) - Static method in class io.deephaven.enterprise.compatibility.TableDefinitionCompatibility
Convert the column data types.
maybeRefreshTable(LiveTable, boolean) - Method in class io.deephaven.enterprise.compatibility.LiveTableRegistrarAdapter
 
maybeRemapShadowedClass(String) - Static method in class io.deephaven.enterprise.compatibility.shadow.ShadowCompatibility
Attempt to remap the specified type onto it's shadowed version.
maybeUpdate(long[], long[]) - Method in class io.deephaven.enterprise.lastbystate.CoreLastByTableImportState
 
maybeUseIntraday() - Method in class io.deephaven.enterprise.replay.ComposableTableReplayConfiguration
Should the replayed table be sourced from db.liveTable?
medianBy(SelectColumn...) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
mergeApply(PivotTableApplyRequest) - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
.io.deephaven.proto.pivot.PivotTableApplyRequest apply = 6;
mergeApply(PivotTableApplyResponse) - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
.io.deephaven.proto.pivot.PivotTableApplyResponse apply = 7;
mergeCreation(PivotTableCreationRequest) - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
.io.deephaven.proto.pivot.PivotTableCreationRequest creation = 5;
mergeCreation(PivotTableCreationResponse) - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
.io.deephaven.proto.pivot.PivotTableCreationResponse creation = 6;
mergeEmptyExpansions(PivotTableEmptyExpansionsRequest) - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
.io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest empty_expansions = 4;
mergeEmptyExpansions(PivotTableEmptyExpansionsResponse) - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
.io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse empty_expansions = 5;
mergeError(ErrorResponse) - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
If the request failed (after we were able to parse and extract the request ID), then we return an error to the client; otherwise we return the appropriate response type.
mergeExpansions(PivotTableViewExpansionsMessage) - Method in class io.deephaven.proto.pivot.PivotTableViewRequest.Builder
Description for the expansions that define this view of the PivotTable.
mergeExport(PivotTableSourceExportResponse) - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
.io.deephaven.proto.pivot.PivotTableSourceExportResponse export = 4;
mergeExportSource(PivotTableSourceExportRequest) - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
.io.deephaven.proto.pivot.PivotTableSourceExportRequest export_source = 3;
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.deephaven.proto.pivot.ErrorResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.deephaven.proto.pivot.PivotTableApplyResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.deephaven.proto.pivot.PivotTableCreationResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.deephaven.proto.pivot.PivotTableDescriptorRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.deephaven.proto.pivot.PivotTableSourceExportRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.deephaven.proto.pivot.PivotTableSourceExportResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.deephaven.proto.pivot.PivotTableViewRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.deephaven.proto.pivot.PivotTableViewResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.deephaven.proto.pqworker.ListenErrorRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.deephaven.proto.pqworker.ListenErrorResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.deephaven.proto.pqworker.ObjectAccessRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.deephaven.proto.pqworker.ObjectAccessResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.deephaven.proto.pqworker.StringList.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.deephaven.proto.pqworker.ThreadDumpRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.deephaven.proto.pqworker.ThreadDumpResponse.Builder
 
mergeFrom(Message) - Method in class io.deephaven.proto.pivot.ErrorResponse.Builder
 
mergeFrom(Message) - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
 
mergeFrom(Message) - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
 
mergeFrom(Message) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
 
mergeFrom(Message) - Method in class io.deephaven.proto.pivot.PivotTableApplyResponse.Builder
 
mergeFrom(Message) - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
 
mergeFrom(Message) - Method in class io.deephaven.proto.pivot.PivotTableCreationResponse.Builder
 
mergeFrom(Message) - Method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage.Builder
 
mergeFrom(Message) - Method in class io.deephaven.proto.pivot.PivotTableDescriptorRequest.Builder
 
mergeFrom(Message) - Method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse.Builder
 
mergeFrom(Message) - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest.Builder
 
mergeFrom(Message) - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse.Builder
 
mergeFrom(Message) - Method in class io.deephaven.proto.pivot.PivotTableSourceExportRequest.Builder
 
mergeFrom(Message) - Method in class io.deephaven.proto.pivot.PivotTableSourceExportResponse.Builder
 
mergeFrom(Message) - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage.Builder
 
mergeFrom(Message) - Method in class io.deephaven.proto.pivot.PivotTableViewRequest.Builder
 
mergeFrom(Message) - Method in class io.deephaven.proto.pivot.PivotTableViewResponse.Builder
 
mergeFrom(Message) - Method in class io.deephaven.proto.pqworker.ListenErrorRequest.Builder
 
mergeFrom(Message) - Method in class io.deephaven.proto.pqworker.ListenErrorResponse.Builder
 
mergeFrom(Message) - Method in class io.deephaven.proto.pqworker.ObjectAccessRequest.Builder
 
mergeFrom(Message) - Method in class io.deephaven.proto.pqworker.ObjectAccessResponse.Builder
 
mergeFrom(Message) - Method in class io.deephaven.proto.pqworker.StringList.Builder
 
mergeFrom(Message) - Method in class io.deephaven.proto.pqworker.ThreadDumpRequest.Builder
 
mergeFrom(Message) - Method in class io.deephaven.proto.pqworker.ThreadDumpResponse.Builder
 
mergeFrom(ErrorResponse) - Method in class io.deephaven.proto.pivot.ErrorResponse.Builder
 
mergeFrom(PivotPluginRequest) - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
 
mergeFrom(PivotPluginResponse) - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
 
mergeFrom(PivotTableApplyRequest) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
 
mergeFrom(PivotTableApplyResponse) - Method in class io.deephaven.proto.pivot.PivotTableApplyResponse.Builder
 
mergeFrom(PivotTableCreationRequest) - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
 
mergeFrom(PivotTableCreationResponse) - Method in class io.deephaven.proto.pivot.PivotTableCreationResponse.Builder
 
mergeFrom(PivotTableDescriptorMessage) - Method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage.Builder
 
mergeFrom(PivotTableDescriptorRequest) - Method in class io.deephaven.proto.pivot.PivotTableDescriptorRequest.Builder
 
mergeFrom(PivotTableDescriptorResponse) - Method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse.Builder
 
mergeFrom(PivotTableEmptyExpansionsRequest) - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest.Builder
 
mergeFrom(PivotTableEmptyExpansionsResponse) - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse.Builder
 
mergeFrom(PivotTableSourceExportRequest) - Method in class io.deephaven.proto.pivot.PivotTableSourceExportRequest.Builder
 
mergeFrom(PivotTableSourceExportResponse) - Method in class io.deephaven.proto.pivot.PivotTableSourceExportResponse.Builder
 
mergeFrom(PivotTableViewExpansionsMessage) - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage.Builder
 
mergeFrom(PivotTableViewRequest) - Method in class io.deephaven.proto.pivot.PivotTableViewRequest.Builder
 
mergeFrom(PivotTableViewResponse) - Method in class io.deephaven.proto.pivot.PivotTableViewResponse.Builder
 
mergeFrom(ListenErrorRequest) - Method in class io.deephaven.proto.pqworker.ListenErrorRequest.Builder
 
mergeFrom(ListenErrorResponse) - Method in class io.deephaven.proto.pqworker.ListenErrorResponse.Builder
 
mergeFrom(ObjectAccessRequest) - Method in class io.deephaven.proto.pqworker.ObjectAccessRequest.Builder
 
mergeFrom(ObjectAccessResponse) - Method in class io.deephaven.proto.pqworker.ObjectAccessResponse.Builder
 
mergeFrom(StringList) - Method in class io.deephaven.proto.pqworker.StringList.Builder
 
mergeFrom(ThreadDumpRequest) - Method in class io.deephaven.proto.pqworker.ThreadDumpRequest.Builder
 
mergeFrom(ThreadDumpResponse) - Method in class io.deephaven.proto.pqworker.ThreadDumpResponse.Builder
 
mergeGetDescriptor(PivotTableDescriptorRequest) - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
.io.deephaven.proto.pivot.PivotTableDescriptorRequest get_descriptor = 7;
mergeGetDescriptor(PivotTableDescriptorResponse) - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
.io.deephaven.proto.pivot.PivotTableDescriptorResponse get_descriptor = 8;
mergePivotDescriptor(PivotTableDescriptorMessage) - Method in class io.deephaven.proto.pivot.PivotTableApplyResponse.Builder
first reference is the new pivot table
mergePivotDescriptor(PivotTableDescriptorMessage) - Method in class io.deephaven.proto.pivot.PivotTableCreationResponse.Builder
first reference is the created pivot table
mergePivotDescriptor(PivotTableDescriptorMessage) - Method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse.Builder
The description of the table
mergePivotDescriptor(PivotTableDescriptorMessage) - Method in class io.deephaven.proto.pivot.PivotTableViewResponse.Builder
The description of the table
mergeUnknownFields(UnknownFieldSet) - Method in class io.deephaven.proto.pivot.ErrorResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class io.deephaven.proto.pivot.PivotTableApplyResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class io.deephaven.proto.pivot.PivotTableCreationResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class io.deephaven.proto.pivot.PivotTableDescriptorRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class io.deephaven.proto.pivot.PivotTableSourceExportRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class io.deephaven.proto.pivot.PivotTableSourceExportResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class io.deephaven.proto.pivot.PivotTableViewRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class io.deephaven.proto.pivot.PivotTableViewResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class io.deephaven.proto.pqworker.ListenErrorRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class io.deephaven.proto.pqworker.ListenErrorResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class io.deephaven.proto.pqworker.ObjectAccessRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class io.deephaven.proto.pqworker.ObjectAccessResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class io.deephaven.proto.pqworker.StringList.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class io.deephaven.proto.pqworker.ThreadDumpRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class io.deephaven.proto.pqworker.ThreadDumpResponse.Builder
 
mergeView(PivotTableViewRequest) - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
.io.deephaven.proto.pivot.PivotTableViewRequest view = 2;
mergeView(PivotTableViewResponse) - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
.io.deephaven.proto.pivot.PivotTableViewResponse view = 3;
MESSAGE_FIELD_NUMBER - Static variable in class io.deephaven.proto.pqworker.ListenErrorResponse
 
MetadataIndexKeyFinder - Class in io.deephaven.enterprise.locations.nestedpartitioned
A TableLocationKeyFinder that uses the Enterprise TableLocationMetadataIndex to find locations.
MetadataIndexKeyFinder(LocalTablePathManager, String, EnterpriseTableKey, TableLocationMetadataIndex) - Constructor for class io.deephaven.enterprise.locations.nestedpartitioned.MetadataIndexKeyFinder
Construct a MetadataIndexKeyFinder using the pathManager for resolving full paths and the specified metadataIndex for locating keys.
minBy(SelectColumn...) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
MissingTableDefinitionException - Exception in io.deephaven.enterprise.compatibility
An exception thrown when a TableDefinition can not be loaded from disk.
MissingTableDefinitionException(String, Throwable) - Constructor for exception io.deephaven.enterprise.compatibility.MissingTableDefinitionException
 
modifyQuery(PersistentQueryConfigMessage) - Method in interface io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClient
Modifies a configuration in the controller's hash table, and restart the query if it was running.
modifyQuery(PersistentQueryConfigMessage, boolean) - Method in interface io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClient
Modifies a configuration in the controller's hash table.
modifyQuery(PersistentQueryConfigMessage, boolean) - Method in class io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClientImpl
 

N

name() - Method in class io.deephaven.pivot.PivotServicePlugin
 
name() - Method in class io.deephaven.pivot.PivotTablePlugin
 
name(int) - Static method in class io.deephaven.enterprise.pivot.flatbuf.PivotBarrageMessageType
 
names - Static variable in class io.deephaven.enterprise.pivot.flatbuf.PivotBarrageMessageType
 
namespace() - Method in exception io.deephaven.enterprise.database.SchemaNotFoundException
 
namespace() - Method in interface io.deephaven.enterprise.iceberg.discovery.DiscoveryConfig
Optional; When supplied, this will be the namespace provided back in the DiscoveryResult
namespace(String) - Method in interface io.deephaven.enterprise.iceberg.discovery.DiscoveryConfig.Builder
An optional user specified namespace.
namespace(String) - Method in class io.deephaven.enterprise.kafkawriter.KafkaTableWriter.Options
The namespace of the table to ingest, this is a required option.
NAMESPACE_PATH_INDEX - Static variable in class io.deephaven.enterprise.dnd.service.ticket.DatabaseTicketResolver
 
naturalJoin(Table, MatchPair[], MatchPair[]) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
NestedPartitionedDeephavenTableLocationKey - Class in io.deephaven.enterprise.locations.nestedpartitioned
A TableLocationKey in Deephaven columnar format, located on a locally accessible filesystem.
NestedPartitionedDeephavenTableLocationKey(File, Map<String, Comparable<?>>) - Constructor for class io.deephaven.enterprise.locations.nestedpartitioned.NestedPartitionedDeephavenTableLocationKey
 
NestedPartitionedKeyFinder - Class in io.deephaven.enterprise.locations.nestedpartitioned
A TableLocationKeyFinder for locating tables stored in Legacy Deephaven Enterprise structured database.
NestedPartitionedKeyFinder(File, String, String, Predicate<String>) - Constructor for class io.deephaven.enterprise.locations.nestedpartitioned.NestedPartitionedKeyFinder
 
NestedPartitionedParquetTableLocationKey - Class in io.deephaven.enterprise.locations.nestedpartitioned
A TableLocationKey marking tables stored in a Deephaven Enterprise database in the Parquet format.
NestedPartitionedParquetTableLocationKey(URI, Map<String, Comparable<?>>) - Constructor for class io.deephaven.enterprise.locations.nestedpartitioned.NestedPartitionedParquetTableLocationKey
 
NestedPartitionedSnapshotTableLocationKey - Class in io.deephaven.enterprise.locations.nestedpartitioned
 
NestedPartitionedSnapshotTableLocationKey(URI, String, TableLocationMetadataIndex.TableLocationSnapshot) - Constructor for class io.deephaven.enterprise.locations.nestedpartitioned.NestedPartitionedSnapshotTableLocationKey
 
NestedPartitionedTableLocationFactory<TLK extends EnterpriseTableLocationKey> - Class in io.deephaven.enterprise.locations.nestedpartitioned
NestedPartitionedTableLocationFactory(Schema) - Constructor for class io.deephaven.enterprise.locations.nestedpartitioned.NestedPartitionedTableLocationFactory
 
NestedPartitionedUnresolvedTableLocationKey - Class in io.deephaven.enterprise.locations.nestedpartitioned
An EnterpriseTableLocationKey is an extension of FileTableLocationKey that defers the creation of the actual location key until the data is needed by the NestedPartitionedTableLocationFactory.
NestedPartitionedUnresolvedTableLocationKey(URI) - Constructor for class io.deephaven.enterprise.locations.nestedpartitioned.NestedPartitionedUnresolvedTableLocationKey
Construct a new EnterpriseTableLocationKeyUnresolved for the supplied uri without any partitioning support.
NestedPartitionedUnresolvedTableLocationKey(URI, Map<String, Comparable<?>>) - Constructor for class io.deephaven.enterprise.locations.nestedpartitioned.NestedPartitionedUnresolvedTableLocationKey
Construct a new EnterpriseTableLocationKeyUnresolved for the supplied uri and partitions.
newBlockingStub(Channel) - Static method in class io.deephaven.proto.pqworker.grpc.PQWorkerApiGrpc
Creates a new blocking-style stub that supports unary and streaming output calls on the service
newBuilder() - Static method in class io.deephaven.proto.pivot.ErrorResponse
 
newBuilder() - Static method in class io.deephaven.proto.pivot.PivotPluginRequest
 
newBuilder() - Static method in class io.deephaven.proto.pivot.PivotPluginResponse
 
newBuilder() - Static method in class io.deephaven.proto.pivot.PivotTableApplyRequest
 
newBuilder() - Static method in class io.deephaven.proto.pivot.PivotTableApplyResponse
 
newBuilder() - Static method in class io.deephaven.proto.pivot.PivotTableCreationRequest
 
newBuilder() - Static method in class io.deephaven.proto.pivot.PivotTableCreationResponse
 
newBuilder() - Static method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage
 
newBuilder() - Static method in class io.deephaven.proto.pivot.PivotTableDescriptorRequest
 
newBuilder() - Static method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse
 
newBuilder() - Static method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest
 
newBuilder() - Static method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse
 
newBuilder() - Static method in class io.deephaven.proto.pivot.PivotTableSourceExportRequest
 
newBuilder() - Static method in class io.deephaven.proto.pivot.PivotTableSourceExportResponse
 
newBuilder() - Static method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage
 
newBuilder() - Static method in class io.deephaven.proto.pivot.PivotTableViewRequest
 
newBuilder() - Static method in class io.deephaven.proto.pivot.PivotTableViewResponse
 
newBuilder() - Static method in class io.deephaven.proto.pqworker.ListenErrorRequest
 
newBuilder() - Static method in class io.deephaven.proto.pqworker.ListenErrorResponse
 
newBuilder() - Static method in class io.deephaven.proto.pqworker.ObjectAccessRequest
 
newBuilder() - Static method in class io.deephaven.proto.pqworker.ObjectAccessResponse
 
newBuilder() - Static method in class io.deephaven.proto.pqworker.StringList
 
newBuilder() - Static method in class io.deephaven.proto.pqworker.ThreadDumpRequest
 
newBuilder() - Static method in class io.deephaven.proto.pqworker.ThreadDumpResponse
 
newBuilder(ErrorResponse) - Static method in class io.deephaven.proto.pivot.ErrorResponse
 
newBuilder(PivotPluginRequest) - Static method in class io.deephaven.proto.pivot.PivotPluginRequest
 
newBuilder(PivotPluginResponse) - Static method in class io.deephaven.proto.pivot.PivotPluginResponse
 
newBuilder(PivotTableApplyRequest) - Static method in class io.deephaven.proto.pivot.PivotTableApplyRequest
 
newBuilder(PivotTableApplyResponse) - Static method in class io.deephaven.proto.pivot.PivotTableApplyResponse
 
newBuilder(PivotTableCreationRequest) - Static method in class io.deephaven.proto.pivot.PivotTableCreationRequest
 
newBuilder(PivotTableCreationResponse) - Static method in class io.deephaven.proto.pivot.PivotTableCreationResponse
 
newBuilder(PivotTableDescriptorMessage) - Static method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage
 
newBuilder(PivotTableDescriptorRequest) - Static method in class io.deephaven.proto.pivot.PivotTableDescriptorRequest
 
newBuilder(PivotTableDescriptorResponse) - Static method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse
 
newBuilder(PivotTableEmptyExpansionsRequest) - Static method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest
 
newBuilder(PivotTableEmptyExpansionsResponse) - Static method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse
 
newBuilder(PivotTableSourceExportRequest) - Static method in class io.deephaven.proto.pivot.PivotTableSourceExportRequest
 
newBuilder(PivotTableSourceExportResponse) - Static method in class io.deephaven.proto.pivot.PivotTableSourceExportResponse
 
newBuilder(PivotTableViewExpansionsMessage) - Static method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage
 
newBuilder(PivotTableViewRequest) - Static method in class io.deephaven.proto.pivot.PivotTableViewRequest
 
newBuilder(PivotTableViewResponse) - Static method in class io.deephaven.proto.pivot.PivotTableViewResponse
 
newBuilder(ListenErrorRequest) - Static method in class io.deephaven.proto.pqworker.ListenErrorRequest
 
newBuilder(ListenErrorResponse) - Static method in class io.deephaven.proto.pqworker.ListenErrorResponse
 
newBuilder(ObjectAccessRequest) - Static method in class io.deephaven.proto.pqworker.ObjectAccessRequest
 
newBuilder(ObjectAccessResponse) - Static method in class io.deephaven.proto.pqworker.ObjectAccessResponse
 
newBuilder(StringList) - Static method in class io.deephaven.proto.pqworker.StringList
 
newBuilder(ThreadDumpRequest) - Static method in class io.deephaven.proto.pqworker.ThreadDumpRequest
 
newBuilder(ThreadDumpResponse) - Static method in class io.deephaven.proto.pqworker.ThreadDumpResponse
 
newBuilderForType() - Method in class io.deephaven.proto.pivot.ErrorResponse
 
newBuilderForType() - Method in class io.deephaven.proto.pivot.PivotPluginRequest
 
newBuilderForType() - Method in class io.deephaven.proto.pivot.PivotPluginResponse
 
newBuilderForType() - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest
 
newBuilderForType() - Method in class io.deephaven.proto.pivot.PivotTableApplyResponse
 
newBuilderForType() - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest
 
newBuilderForType() - Method in class io.deephaven.proto.pivot.PivotTableCreationResponse
 
newBuilderForType() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage
 
newBuilderForType() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorRequest
 
newBuilderForType() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse
 
newBuilderForType() - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest
 
newBuilderForType() - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse
 
newBuilderForType() - Method in class io.deephaven.proto.pivot.PivotTableSourceExportRequest
 
newBuilderForType() - Method in class io.deephaven.proto.pivot.PivotTableSourceExportResponse
 
newBuilderForType() - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage
 
newBuilderForType() - Method in class io.deephaven.proto.pivot.PivotTableViewRequest
 
newBuilderForType() - Method in class io.deephaven.proto.pivot.PivotTableViewResponse
 
newBuilderForType() - Method in class io.deephaven.proto.pqworker.ListenErrorRequest
 
newBuilderForType() - Method in class io.deephaven.proto.pqworker.ListenErrorResponse
 
newBuilderForType() - Method in class io.deephaven.proto.pqworker.ObjectAccessRequest
 
newBuilderForType() - Method in class io.deephaven.proto.pqworker.ObjectAccessResponse
 
newBuilderForType() - Method in class io.deephaven.proto.pqworker.StringList
 
newBuilderForType() - Method in class io.deephaven.proto.pqworker.ThreadDumpRequest
 
newBuilderForType() - Method in class io.deephaven.proto.pqworker.ThreadDumpResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class io.deephaven.proto.pivot.ErrorResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class io.deephaven.proto.pivot.PivotPluginRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class io.deephaven.proto.pivot.PivotPluginResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class io.deephaven.proto.pivot.PivotTableApplyResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class io.deephaven.proto.pivot.PivotTableCreationResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class io.deephaven.proto.pivot.PivotTableDescriptorRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class io.deephaven.proto.pivot.PivotTableSourceExportRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class io.deephaven.proto.pivot.PivotTableSourceExportResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class io.deephaven.proto.pivot.PivotTableViewRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class io.deephaven.proto.pivot.PivotTableViewResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class io.deephaven.proto.pqworker.ListenErrorRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class io.deephaven.proto.pqworker.ListenErrorResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class io.deephaven.proto.pqworker.ObjectAccessRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class io.deephaven.proto.pqworker.ObjectAccessResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class io.deephaven.proto.pqworker.StringList
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class io.deephaven.proto.pqworker.ThreadDumpRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class io.deephaven.proto.pqworker.ThreadDumpResponse
 
newEndpoint() - Static method in class io.deephaven.enterprise.iceberg.IcebergTools
Get a new IcebergEndpoint.Builder to create an IcebergEndpoint for use with discovery.
newFutureStub(Channel) - Static method in class io.deephaven.proto.pqworker.grpc.PQWorkerApiGrpc
Creates a new ListenableFuture-style stub that supports unary calls on the service
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class io.deephaven.proto.pivot.ErrorResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class io.deephaven.proto.pivot.PivotPluginRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class io.deephaven.proto.pivot.PivotPluginResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class io.deephaven.proto.pivot.PivotTableApplyResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class io.deephaven.proto.pivot.PivotTableCreationResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class io.deephaven.proto.pivot.PivotTableDescriptorRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class io.deephaven.proto.pivot.PivotTableSourceExportRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class io.deephaven.proto.pivot.PivotTableSourceExportResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class io.deephaven.proto.pivot.PivotTableViewRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class io.deephaven.proto.pivot.PivotTableViewResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class io.deephaven.proto.pqworker.ListenErrorRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class io.deephaven.proto.pqworker.ListenErrorResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class io.deephaven.proto.pqworker.ObjectAccessRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class io.deephaven.proto.pqworker.ObjectAccessResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class io.deephaven.proto.pqworker.StringList
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class io.deephaven.proto.pqworker.ThreadDumpRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class io.deephaven.proto.pqworker.ThreadDumpResponse
 
newLiveBuilder() - Static method in class io.deephaven.enterprise.database.TableOptions
Create a new TableOptions.Builder for setting options on a live ticking table.
newOptionsBuilder() - Static method in class io.deephaven.enterprise.database.SystemTableLogger
Create an options builder for use with logTable.
newSession(RemoteTableStateWatcher.StateToken) - Method in class io.deephaven.enterprise.remote.CorePlusClusterSessionFactory
 
newSession(RemoteTableStateWatcher.StateToken) - Method in interface io.deephaven.enterprise.remote.RemoteTableSessionFactory
Create a new BarrageSession for susbcriptions using the RemoteTableStateWatcher.StateToken.
newStaticBuilder() - Static method in class io.deephaven.enterprise.database.TableOptions
Create a new TableOptions.Builder for setting options on a static table.
newStub(Channel) - Static method in class io.deephaven.proto.pqworker.grpc.PQWorkerApiGrpc
Creates a new async stub that supports all call types for the service
newWorker(PersistentQueryConfigMessage, long) - Method in class io.deephaven.enterprise.dnd.client.DndSessionFactoryBarrage
Create a new Interactive Console Persistent Query session.
newWorker(String, float, long, long) - Method in class io.deephaven.enterprise.dnd.client.DndSessionFactoryBarrage
 
noAccess() - Static method in interface io.deephaven.enterprise.acl.AclFilterGenerator
Create an AclFilterGenerator that gives no access to the table.
NoAccessFilterGenerator - Class in io.deephaven.enterprise.acl.generator
An AclFilterGenerator that provides no access to anyonne.
NoAccessFilterGenerator() - Constructor for class io.deephaven.enterprise.acl.generator.NoAccessFilterGenerator
 
NonSystemSchemaException - Exception in io.deephaven.enterprise.database
Exception thrown when an operation expects a System schema, but was passed a non-system schema.
NonSystemSchemaException(String, String, String) - Constructor for exception io.deephaven.enterprise.database.NonSystemSchemaException
 
normalizeTimeTypes(TableDefinition) - Static method in class io.deephaven.enterprise.ingester.impl.TypeMutations
 
normalizeTimeTypesAndRemovedIgnoredColumns(TableDefinition, Set<String>) - Static method in class io.deephaven.enterprise.ingester.impl.TypeMutations
 
NotebookReader - Class in io.deephaven.enterprise.dnd.notebook
Tools for getting Files and Folders out of the Web IDE notebooks that are stored in DbInternal.WorkspaceData.
NotebookReader.FileOrFolder - Class in io.deephaven.enterprise.dnd.notebook
A record class that represents a file or folder.
NotebookReader.NotFoundException - Exception in io.deephaven.enterprise.dnd.notebook
An exception thrown when a Notebook is not found.
NotificationAdapter - Class in io.deephaven.enterprise.compatibility
 
NotificationAdapter(NotificationQueue.Notification) - Constructor for class io.deephaven.enterprise.compatibility.NotificationAdapter
 
NotificationQueueAdapter - Class in io.deephaven.enterprise.compatibility
 
nullCheckedToString(Object, String) - Static method in class io.deephaven.enterprise.derivedtablewriter.DerivedPartitionedTableWriterQueryFunctions
 

O

ObjectAccessRequest - Class in io.deephaven.proto.pqworker
Protobuf type io.deephaven.proto.pqworker.ObjectAccessRequest
ObjectAccessRequest.Builder - Class in io.deephaven.proto.pqworker
Protobuf type io.deephaven.proto.pqworker.ObjectAccessRequest
ObjectAccessRequestOrBuilder - Exception in io.deephaven.proto.pqworker
 
ObjectAccessRequestOrBuilder - Interface in io.deephaven.proto.pqworker
 
ObjectAccessResponse - Class in io.deephaven.proto.pqworker
Protobuf type io.deephaven.proto.pqworker.ObjectAccessResponse
ObjectAccessResponse.Builder - Class in io.deephaven.proto.pqworker
Protobuf type io.deephaven.proto.pqworker.ObjectAccessResponse
ObjectAccessResponseOrBuilder - Exception in io.deephaven.proto.pqworker
 
ObjectAccessResponseOrBuilder - Interface in io.deephaven.proto.pqworker
 
ObjectCodecAdapter<TYPE> - Class in io.deephaven.enterprise.compatibility
This class adapts the DHE ObjectCodec to the DHC ObjectCodec.
ObjectCodecAdapter(String) - Constructor for class io.deephaven.enterprise.compatibility.ObjectCodecAdapter
 
ObjectColumnRegionAdapter<T,ATTR extends Values> - Class in io.deephaven.enterprise.compatibility.region
 
ObjectColumnRegionAdapter(ColumnRegionObject<T, ?>, ObjectDecoder<?>, boolean) - Constructor for class io.deephaven.enterprise.compatibility.region.ObjectColumnRegionAdapter
 
OBJECTGROUPS_FIELD_NUMBER - Static variable in class io.deephaven.proto.pqworker.ObjectAccessResponse
 
ObjectModuleOverride - Interface in io.deephaven.enterprise.dnd.modules
 
OBJECTNAMES_FIELD_NUMBER - Static variable in class io.deephaven.proto.pqworker.ObjectAccessRequest
 
ObjectRegionFillContext - Class in io.deephaven.enterprise.sources.regioned.impl
A ChunkSource.GetContext for Deephaven Format ColumnRegionObject implementations containing ChunkSource.GetContexts for the offset, dictionary and bitmask regions.
ObjectRegionFillContext(int, int) - Constructor for class io.deephaven.enterprise.sources.regioned.impl.ObjectRegionFillContext
 
ObjectServiceGrpcBinding - Class in io.deephaven.enterprise.dnd.modules
 
ObjectServiceGrpcBinding(AuthorizationProvider, ObjectServiceGrpcImpl, SessionService) - Constructor for class io.deephaven.enterprise.dnd.modules.ObjectServiceGrpcBinding
 
ObserverImpl() - Constructor for class io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClient.ObserverImpl
 
observeScopeChanges() - Method in class io.deephaven.enterprise.dnd.modules.GroovyConsoleSessionWithDatabaseModule.ScriptSessionWrapper
 
of(FilterGenerator) - Static method in interface io.deephaven.enterprise.acl.AclFilterGenerator
Create an AclFilterGenerator from an enterprise FilterGenerator.
of(String, String, String) - Static method in class io.deephaven.enterprise.locations.impl.BasicFixedPartitionedDeephavenTableLocationKey
Creates a simplified table location key with an internal partition and String partition column.
of(String, TableLocationKey) - Static method in interface io.deephaven.enterprise.locations.FixedPartitionedEnterpriseTableLocationKey
Create a TableLocationKey from its enterprise equivalent and the partitioning column key.
of(Table) - Static method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
Create an adapter for presenting a Community Table as an Enterprise Table.
OffsetUtils - Class in io.deephaven.enterprise.ingester.impl
Tools for reading offsets from existing partitions for use with in an Ingester.
OffsetUtils() - Constructor for class io.deephaven.enterprise.ingester.impl.OffsetUtils
 
ofHistorical(String, String, TableType) - Static method in interface io.deephaven.enterprise.locations.EnterpriseTableKey
Create an EnterpriseTableKey for a historical table.
ofTicking(String, String, TableType) - Static method in interface io.deephaven.enterprise.locations.EnterpriseTableKey
Create an EnterpriseTableKey for an Intraday table.
onCallStartedAutoCompleteStream(AuthContext) - Method in class io.deephaven.enterprise.dnd.authentication.AdminOnlyConsoleAuthWiring
 
onChanged(RemoteTableStateWatcher.StateToken) - Method in interface io.deephaven.enterprise.remote.RemoteTableStateWatcher.Observer
Called when there is a change of state.
onComplete(TableDataRequest) - Method in class io.deephaven.enterprise.locations.remote.RemoteDeephavenTableLocation
 
OnDiskDeephavenColumnLocation - Class in io.deephaven.enterprise.locations.local.deephaven
The ColumnLocation implementation for OnDiskDeephavenTableLocation locations.
OnDiskDeephavenColumnLocation(OnDiskDeephavenTableLocation, String) - Constructor for class io.deephaven.enterprise.locations.local.deephaven.OnDiskDeephavenColumnLocation
Construct a new LocalColumnLocation for the specified LocalTableLocation and column name.
OnDiskDeephavenTableLocation - Class in io.deephaven.enterprise.locations.local.deephaven
A TableLocation for reading Deephaven format tables from a local filesystem.
OnDiskDeephavenTableLocation(EnterpriseTableKey, EnterpriseTableLocationKey, Schema, File, boolean, TableDataRefreshService) - Constructor for class io.deephaven.enterprise.locations.local.deephaven.OnDiskDeephavenTableLocation
 
OnDiskTableDataService - Class in io.deephaven.enterprise.tabledataservice
A TableDataService implementation that expects data to be located on a local filesystem.
OnDiskTableDataService(Logger, String, Path, SchemaService, boolean) - Constructor for class io.deephaven.enterprise.tabledataservice.OnDiskTableDataService
Construct a TableDataService that sources tables from the local filesystem.
onGetObjectAccess(AuthContext, ObjectAccessRequest) - Method in class io.deephaven.enterprise.dnd.authentication.AdminOnlyWorkerAuthWiring
 
onGetObjectAccess(AuthContext, ObjectAccessRequest) - Method in interface io.deephaven.enterprise.dnd.authentication.PQWorkerServiceAuthWiring
 
onListenForError(AuthContext, ListenErrorRequest) - Method in class io.deephaven.enterprise.dnd.authentication.AdminOnlyWorkerAuthWiring
 
onListenForError(AuthContext, ListenErrorRequest) - Method in interface io.deephaven.enterprise.dnd.authentication.PQWorkerServiceAuthWiring
 
onMessageReceivedAutoCompleteStream(AuthContext, AutoCompleteRequest) - Method in class io.deephaven.enterprise.dnd.authentication.AdminOnlyConsoleAuthWiring
 
onMessageReceivedBindTableToVariable(AuthContext, BindTableToVariableRequest) - Method in class io.deephaven.enterprise.dnd.authentication.AdminOnlyConsoleAuthWiring
 
onMessageReceivedCancelAutoComplete(AuthContext, CancelAutoCompleteRequest) - Method in class io.deephaven.enterprise.dnd.authentication.AdminOnlyConsoleAuthWiring
 
onMessageReceivedCancelCommand(AuthContext, CancelCommandRequest) - Method in class io.deephaven.enterprise.dnd.authentication.AdminOnlyConsoleAuthWiring
 
onMessageReceivedExecuteCommand(AuthContext, ExecuteCommandRequest) - Method in class io.deephaven.enterprise.dnd.authentication.AdminOnlyConsoleAuthWiring
 
onMessageReceivedGetConsoleTypes(AuthContext, GetConsoleTypesRequest) - Method in class io.deephaven.enterprise.dnd.authentication.AdminOnlyConsoleAuthWiring
 
onMessageReceivedGetHeapInfo(AuthContext, GetHeapInfoRequest) - Method in class io.deephaven.enterprise.dnd.authentication.AdminOnlyConsoleAuthWiring
 
onMessageReceivedNewSession(AuthContext, HandshakeRequest) - Method in class io.deephaven.enterprise.dnd.authentication.SessionServiceAuthWiringImpl
 
onMessageReceivedNextAutoCompleteStream(AuthContext, AutoCompleteRequest) - Method in class io.deephaven.enterprise.dnd.authentication.AdminOnlyConsoleAuthWiring
 
onMessageReceivedOpenAutoCompleteStream(AuthContext, AutoCompleteRequest) - Method in class io.deephaven.enterprise.dnd.authentication.AdminOnlyConsoleAuthWiring
 
onMessageReceivedRefreshSessionToken(AuthContext, HandshakeRequest) - Method in class io.deephaven.enterprise.dnd.authentication.SessionServiceAuthWiringImpl
 
onMessageReceivedStartConsole(AuthContext, StartConsoleRequest) - Method in class io.deephaven.enterprise.dnd.authentication.AdminOnlyConsoleAuthWiring
 
onMessageReceivedSubscribeToLogs(AuthContext, LogSubscriptionRequest) - Method in class io.deephaven.enterprise.dnd.authentication.AdminOnlyConsoleAuthWiring
 
onRejection(TableDataRequest, String, TableDataProtocol.RequestRejectionType) - Method in class io.deephaven.enterprise.locations.remote.RemoteDeephavenTableLocation
 
onRequestThreadDump(AuthContext, ThreadDumpRequest) - Method in class io.deephaven.enterprise.dnd.authentication.AdminOnlyWorkerAuthWiring
 
onRequestThreadDump(AuthContext, ThreadDumpRequest) - Method in interface io.deephaven.enterprise.dnd.authentication.PQWorkerServiceAuthWiring
 
onResume(FullTableLocationKey) - Method in class io.deephaven.enterprise.lastbystate.CoreLastByTableImportState
 
onSessionCount(int, long) - Method in interface io.deephaven.enterprise.dnd.modules.DndSessionListenerModule.DndSessionCountListener
 
onSessionCreate(SessionState) - Method in class io.deephaven.enterprise.dnd.modules.DndSessionListenerModule.SessionMonitor
 
onShutdown() - Method in class io.deephaven.enterprise.dnd.EnterpriseProcessEnvironmentCommunityAdapter
 
onStartup() - Method in class io.deephaven.enterprise.dnd.EnterpriseProcessEnvironmentCommunityAdapter
 
onTableLocationKeyAdded(TableLocationKey) - Method in class io.deephaven.enterprise.locations.remote.RemoteDeephavenTableLocation
 
onTableLocationKeyRemoved(TableLocationKey) - Method in class io.deephaven.enterprise.locations.remote.RemoteDeephavenTableLocation
 
onTableLocationState(TableLocationState) - Method in class io.deephaven.enterprise.locations.remote.RemoteDeephavenTableLocation
 
onTerminate() - Method in interface io.deephaven.enterprise.dnd.modules.DndSessionListenerModule.DndSessionCountListener
 
onTimeout(TableDataRequest) - Method in class io.deephaven.enterprise.locations.remote.RemoteDeephavenTableLocation
 
onTruncate(FullTableLocationKey) - Method in class io.deephaven.enterprise.lastbystate.CoreLastByTableImportState
 
openConfiguration(String) - Method in class io.deephaven.enterprise.config.HttpUrlPropertyInputStreamLoader
 
openConfiguration(String) - Method in class io.deephaven.enterprise.test.PropertyInputStreamLoaderResourcesOnly
 
Options() - Constructor for class io.deephaven.enterprise.database.SystemTableLogger.Options
 
Options() - Constructor for class io.deephaven.enterprise.derivedtablewriter.DerivedTableWriter.Options
 
Options() - Constructor for class io.deephaven.enterprise.kafkawriter.KafkaTableWriter.Options
 
OrderedKeysToRowSequenceAdapter - Class in io.deephaven.enterprise.compatibility.rowset
A Mutable adapter for converting OrderedKeys into a RowSequence.
OrderedKeysToRowSequenceAdapter() - Constructor for class io.deephaven.enterprise.compatibility.rowset.OrderedKeysToRowSequenceAdapter
 
OrderedKeysToRowSequenceAdapter(OrderedKeys) - Constructor for class io.deephaven.enterprise.compatibility.rowset.OrderedKeysToRowSequenceAdapter
 
OrderedKeysToRowSequenceIteratorAdapter - Class in io.deephaven.enterprise.compatibility.rowset
 
OrderedKeysToRowSequenceIteratorAdapter(OrderedKeys.Iterator) - Constructor for class io.deephaven.enterprise.compatibility.rowset.OrderedKeysToRowSequenceIteratorAdapter
 
orphanPromotion(boolean) - Method in interface io.deephaven.enterprise.acl.EdgeAclProvider.Builder
When applied to a TreeTable, should orphans be promoted?
OUTPUT_COLUMNS_FIELD_NUMBER - Static variable in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage
 
owner(String) - Method in class io.deephaven.enterprise.dnd.query.util.perf.PerformanceOverview
Set the expected owner of the desired query

P

parallelismFactor() - Method in class io.deephaven.enterprise.test.CapturingUpdateGraph
 
ParquetExtendedStorageProvider - Class in io.deephaven.enterprise.tabledataservice.extended
An ExtendedStorageProvider implementation for parquet: types, including `flat` and `metadata`.
ParquetExtendedStorageProvider.Factory - Class in io.deephaven.enterprise.tabledataservice.extended
The factory class for creating this provider.
ParquetShadowHelper - Class in io.deephaven.enterprise.locations.local
 
ParquetShadowHelper() - Constructor for class io.deephaven.enterprise.locations.local.ParquetShadowHelper
 
parseDelimitedFrom(InputStream) - Static method in class io.deephaven.proto.pivot.ErrorResponse
 
parseDelimitedFrom(InputStream) - Static method in class io.deephaven.proto.pivot.PivotPluginRequest
 
parseDelimitedFrom(InputStream) - Static method in class io.deephaven.proto.pivot.PivotPluginResponse
 
parseDelimitedFrom(InputStream) - Static method in class io.deephaven.proto.pivot.PivotTableApplyRequest
 
parseDelimitedFrom(InputStream) - Static method in class io.deephaven.proto.pivot.PivotTableApplyResponse
 
parseDelimitedFrom(InputStream) - Static method in class io.deephaven.proto.pivot.PivotTableCreationRequest
 
parseDelimitedFrom(InputStream) - Static method in class io.deephaven.proto.pivot.PivotTableCreationResponse
 
parseDelimitedFrom(InputStream) - Static method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage
 
parseDelimitedFrom(InputStream) - Static method in class io.deephaven.proto.pivot.PivotTableDescriptorRequest
 
parseDelimitedFrom(InputStream) - Static method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse
 
parseDelimitedFrom(InputStream) - Static method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest
 
parseDelimitedFrom(InputStream) - Static method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse
 
parseDelimitedFrom(InputStream) - Static method in class io.deephaven.proto.pivot.PivotTableSourceExportRequest
 
parseDelimitedFrom(InputStream) - Static method in class io.deephaven.proto.pivot.PivotTableSourceExportResponse
 
parseDelimitedFrom(InputStream) - Static method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage
 
parseDelimitedFrom(InputStream) - Static method in class io.deephaven.proto.pivot.PivotTableViewRequest
 
parseDelimitedFrom(InputStream) - Static method in class io.deephaven.proto.pivot.PivotTableViewResponse
 
parseDelimitedFrom(InputStream) - Static method in class io.deephaven.proto.pqworker.ListenErrorRequest
 
parseDelimitedFrom(InputStream) - Static method in class io.deephaven.proto.pqworker.ListenErrorResponse
 
parseDelimitedFrom(InputStream) - Static method in class io.deephaven.proto.pqworker.ObjectAccessRequest
 
parseDelimitedFrom(InputStream) - Static method in class io.deephaven.proto.pqworker.ObjectAccessResponse
 
parseDelimitedFrom(InputStream) - Static method in class io.deephaven.proto.pqworker.StringList
 
parseDelimitedFrom(InputStream) - Static method in class io.deephaven.proto.pqworker.ThreadDumpRequest
 
parseDelimitedFrom(InputStream) - Static method in class io.deephaven.proto.pqworker.ThreadDumpResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.ErrorResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotPluginRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotPluginResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableApplyRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableApplyResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableCreationRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableCreationResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableDescriptorRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableSourceExportRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableSourceExportResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableViewRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableViewResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pqworker.ListenErrorRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pqworker.ListenErrorResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pqworker.ObjectAccessRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pqworker.ObjectAccessResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pqworker.StringList
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pqworker.ThreadDumpRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pqworker.ThreadDumpResponse
 
parseFrom(byte[]) - Static method in class io.deephaven.proto.pivot.ErrorResponse
 
parseFrom(byte[]) - Static method in class io.deephaven.proto.pivot.PivotPluginRequest
 
parseFrom(byte[]) - Static method in class io.deephaven.proto.pivot.PivotPluginResponse
 
parseFrom(byte[]) - Static method in class io.deephaven.proto.pivot.PivotTableApplyRequest
 
parseFrom(byte[]) - Static method in class io.deephaven.proto.pivot.PivotTableApplyResponse
 
parseFrom(byte[]) - Static method in class io.deephaven.proto.pivot.PivotTableCreationRequest
 
parseFrom(byte[]) - Static method in class io.deephaven.proto.pivot.PivotTableCreationResponse
 
parseFrom(byte[]) - Static method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage
 
parseFrom(byte[]) - Static method in class io.deephaven.proto.pivot.PivotTableDescriptorRequest
 
parseFrom(byte[]) - Static method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse
 
parseFrom(byte[]) - Static method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest
 
parseFrom(byte[]) - Static method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse
 
parseFrom(byte[]) - Static method in class io.deephaven.proto.pivot.PivotTableSourceExportRequest
 
parseFrom(byte[]) - Static method in class io.deephaven.proto.pivot.PivotTableSourceExportResponse
 
parseFrom(byte[]) - Static method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage
 
parseFrom(byte[]) - Static method in class io.deephaven.proto.pivot.PivotTableViewRequest
 
parseFrom(byte[]) - Static method in class io.deephaven.proto.pivot.PivotTableViewResponse
 
parseFrom(byte[]) - Static method in class io.deephaven.proto.pqworker.ListenErrorRequest
 
parseFrom(byte[]) - Static method in class io.deephaven.proto.pqworker.ListenErrorResponse
 
parseFrom(byte[]) - Static method in class io.deephaven.proto.pqworker.ObjectAccessRequest
 
parseFrom(byte[]) - Static method in class io.deephaven.proto.pqworker.ObjectAccessResponse
 
parseFrom(byte[]) - Static method in class io.deephaven.proto.pqworker.StringList
 
parseFrom(byte[]) - Static method in class io.deephaven.proto.pqworker.ThreadDumpRequest
 
parseFrom(byte[]) - Static method in class io.deephaven.proto.pqworker.ThreadDumpResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.ErrorResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotPluginRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotPluginResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableApplyRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableApplyResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableCreationRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableCreationResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableDescriptorRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableSourceExportRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableSourceExportResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableViewRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableViewResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.deephaven.proto.pqworker.ListenErrorRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.deephaven.proto.pqworker.ListenErrorResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.deephaven.proto.pqworker.ObjectAccessRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.deephaven.proto.pqworker.ObjectAccessResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.deephaven.proto.pqworker.StringList
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.deephaven.proto.pqworker.ThreadDumpRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.deephaven.proto.pqworker.ThreadDumpResponse
 
parseFrom(ByteString) - Static method in class io.deephaven.proto.pivot.ErrorResponse
 
parseFrom(ByteString) - Static method in class io.deephaven.proto.pivot.PivotPluginRequest
 
parseFrom(ByteString) - Static method in class io.deephaven.proto.pivot.PivotPluginResponse
 
parseFrom(ByteString) - Static method in class io.deephaven.proto.pivot.PivotTableApplyRequest
 
parseFrom(ByteString) - Static method in class io.deephaven.proto.pivot.PivotTableApplyResponse
 
parseFrom(ByteString) - Static method in class io.deephaven.proto.pivot.PivotTableCreationRequest
 
parseFrom(ByteString) - Static method in class io.deephaven.proto.pivot.PivotTableCreationResponse
 
parseFrom(ByteString) - Static method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage
 
parseFrom(ByteString) - Static method in class io.deephaven.proto.pivot.PivotTableDescriptorRequest
 
parseFrom(ByteString) - Static method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse
 
parseFrom(ByteString) - Static method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest
 
parseFrom(ByteString) - Static method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse
 
parseFrom(ByteString) - Static method in class io.deephaven.proto.pivot.PivotTableSourceExportRequest
 
parseFrom(ByteString) - Static method in class io.deephaven.proto.pivot.PivotTableSourceExportResponse
 
parseFrom(ByteString) - Static method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage
 
parseFrom(ByteString) - Static method in class io.deephaven.proto.pivot.PivotTableViewRequest
 
parseFrom(ByteString) - Static method in class io.deephaven.proto.pivot.PivotTableViewResponse
 
parseFrom(ByteString) - Static method in class io.deephaven.proto.pqworker.ListenErrorRequest
 
parseFrom(ByteString) - Static method in class io.deephaven.proto.pqworker.ListenErrorResponse
 
parseFrom(ByteString) - Static method in class io.deephaven.proto.pqworker.ObjectAccessRequest
 
parseFrom(ByteString) - Static method in class io.deephaven.proto.pqworker.ObjectAccessResponse
 
parseFrom(ByteString) - Static method in class io.deephaven.proto.pqworker.StringList
 
parseFrom(ByteString) - Static method in class io.deephaven.proto.pqworker.ThreadDumpRequest
 
parseFrom(ByteString) - Static method in class io.deephaven.proto.pqworker.ThreadDumpResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.ErrorResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotPluginRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotPluginResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableApplyRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableApplyResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableCreationRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableCreationResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableDescriptorRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableSourceExportRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableSourceExportResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableViewRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableViewResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pqworker.ListenErrorRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pqworker.ListenErrorResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pqworker.ObjectAccessRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pqworker.ObjectAccessResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pqworker.StringList
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pqworker.ThreadDumpRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pqworker.ThreadDumpResponse
 
parseFrom(CodedInputStream) - Static method in class io.deephaven.proto.pivot.ErrorResponse
 
parseFrom(CodedInputStream) - Static method in class io.deephaven.proto.pivot.PivotPluginRequest
 
parseFrom(CodedInputStream) - Static method in class io.deephaven.proto.pivot.PivotPluginResponse
 
parseFrom(CodedInputStream) - Static method in class io.deephaven.proto.pivot.PivotTableApplyRequest
 
parseFrom(CodedInputStream) - Static method in class io.deephaven.proto.pivot.PivotTableApplyResponse
 
parseFrom(CodedInputStream) - Static method in class io.deephaven.proto.pivot.PivotTableCreationRequest
 
parseFrom(CodedInputStream) - Static method in class io.deephaven.proto.pivot.PivotTableCreationResponse
 
parseFrom(CodedInputStream) - Static method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage
 
parseFrom(CodedInputStream) - Static method in class io.deephaven.proto.pivot.PivotTableDescriptorRequest
 
parseFrom(CodedInputStream) - Static method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse
 
parseFrom(CodedInputStream) - Static method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest
 
parseFrom(CodedInputStream) - Static method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse
 
parseFrom(CodedInputStream) - Static method in class io.deephaven.proto.pivot.PivotTableSourceExportRequest
 
parseFrom(CodedInputStream) - Static method in class io.deephaven.proto.pivot.PivotTableSourceExportResponse
 
parseFrom(CodedInputStream) - Static method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage
 
parseFrom(CodedInputStream) - Static method in class io.deephaven.proto.pivot.PivotTableViewRequest
 
parseFrom(CodedInputStream) - Static method in class io.deephaven.proto.pivot.PivotTableViewResponse
 
parseFrom(CodedInputStream) - Static method in class io.deephaven.proto.pqworker.ListenErrorRequest
 
parseFrom(CodedInputStream) - Static method in class io.deephaven.proto.pqworker.ListenErrorResponse
 
parseFrom(CodedInputStream) - Static method in class io.deephaven.proto.pqworker.ObjectAccessRequest
 
parseFrom(CodedInputStream) - Static method in class io.deephaven.proto.pqworker.ObjectAccessResponse
 
parseFrom(CodedInputStream) - Static method in class io.deephaven.proto.pqworker.StringList
 
parseFrom(CodedInputStream) - Static method in class io.deephaven.proto.pqworker.ThreadDumpRequest
 
parseFrom(CodedInputStream) - Static method in class io.deephaven.proto.pqworker.ThreadDumpResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.ErrorResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotPluginRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotPluginResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableApplyRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableApplyResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableCreationRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableCreationResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableDescriptorRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableSourceExportRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableSourceExportResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableViewRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableViewResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pqworker.ListenErrorRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pqworker.ListenErrorResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pqworker.ObjectAccessRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pqworker.ObjectAccessResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pqworker.StringList
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pqworker.ThreadDumpRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pqworker.ThreadDumpResponse
 
parseFrom(InputStream) - Static method in class io.deephaven.proto.pivot.ErrorResponse
 
parseFrom(InputStream) - Static method in class io.deephaven.proto.pivot.PivotPluginRequest
 
parseFrom(InputStream) - Static method in class io.deephaven.proto.pivot.PivotPluginResponse
 
parseFrom(InputStream) - Static method in class io.deephaven.proto.pivot.PivotTableApplyRequest
 
parseFrom(InputStream) - Static method in class io.deephaven.proto.pivot.PivotTableApplyResponse
 
parseFrom(InputStream) - Static method in class io.deephaven.proto.pivot.PivotTableCreationRequest
 
parseFrom(InputStream) - Static method in class io.deephaven.proto.pivot.PivotTableCreationResponse
 
parseFrom(InputStream) - Static method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage
 
parseFrom(InputStream) - Static method in class io.deephaven.proto.pivot.PivotTableDescriptorRequest
 
parseFrom(InputStream) - Static method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse
 
parseFrom(InputStream) - Static method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest
 
parseFrom(InputStream) - Static method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse
 
parseFrom(InputStream) - Static method in class io.deephaven.proto.pivot.PivotTableSourceExportRequest
 
parseFrom(InputStream) - Static method in class io.deephaven.proto.pivot.PivotTableSourceExportResponse
 
parseFrom(InputStream) - Static method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage
 
parseFrom(InputStream) - Static method in class io.deephaven.proto.pivot.PivotTableViewRequest
 
parseFrom(InputStream) - Static method in class io.deephaven.proto.pivot.PivotTableViewResponse
 
parseFrom(InputStream) - Static method in class io.deephaven.proto.pqworker.ListenErrorRequest
 
parseFrom(InputStream) - Static method in class io.deephaven.proto.pqworker.ListenErrorResponse
 
parseFrom(InputStream) - Static method in class io.deephaven.proto.pqworker.ObjectAccessRequest
 
parseFrom(InputStream) - Static method in class io.deephaven.proto.pqworker.ObjectAccessResponse
 
parseFrom(InputStream) - Static method in class io.deephaven.proto.pqworker.StringList
 
parseFrom(InputStream) - Static method in class io.deephaven.proto.pqworker.ThreadDumpRequest
 
parseFrom(InputStream) - Static method in class io.deephaven.proto.pqworker.ThreadDumpResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.ErrorResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotPluginRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotPluginResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableApplyRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableApplyResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableCreationRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableCreationResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableDescriptorRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableSourceExportRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableSourceExportResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableViewRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableViewResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pqworker.ListenErrorRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pqworker.ListenErrorResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pqworker.ObjectAccessRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pqworker.ObjectAccessResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pqworker.StringList
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pqworker.ThreadDumpRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pqworker.ThreadDumpResponse
 
parseFrom(ByteBuffer) - Static method in class io.deephaven.proto.pivot.ErrorResponse
 
parseFrom(ByteBuffer) - Static method in class io.deephaven.proto.pivot.PivotPluginRequest
 
parseFrom(ByteBuffer) - Static method in class io.deephaven.proto.pivot.PivotPluginResponse
 
parseFrom(ByteBuffer) - Static method in class io.deephaven.proto.pivot.PivotTableApplyRequest
 
parseFrom(ByteBuffer) - Static method in class io.deephaven.proto.pivot.PivotTableApplyResponse
 
parseFrom(ByteBuffer) - Static method in class io.deephaven.proto.pivot.PivotTableCreationRequest
 
parseFrom(ByteBuffer) - Static method in class io.deephaven.proto.pivot.PivotTableCreationResponse
 
parseFrom(ByteBuffer) - Static method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage
 
parseFrom(ByteBuffer) - Static method in class io.deephaven.proto.pivot.PivotTableDescriptorRequest
 
parseFrom(ByteBuffer) - Static method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse
 
parseFrom(ByteBuffer) - Static method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest
 
parseFrom(ByteBuffer) - Static method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse
 
parseFrom(ByteBuffer) - Static method in class io.deephaven.proto.pivot.PivotTableSourceExportRequest
 
parseFrom(ByteBuffer) - Static method in class io.deephaven.proto.pivot.PivotTableSourceExportResponse
 
parseFrom(ByteBuffer) - Static method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage
 
parseFrom(ByteBuffer) - Static method in class io.deephaven.proto.pivot.PivotTableViewRequest
 
parseFrom(ByteBuffer) - Static method in class io.deephaven.proto.pivot.PivotTableViewResponse
 
parseFrom(ByteBuffer) - Static method in class io.deephaven.proto.pqworker.ListenErrorRequest
 
parseFrom(ByteBuffer) - Static method in class io.deephaven.proto.pqworker.ListenErrorResponse
 
parseFrom(ByteBuffer) - Static method in class io.deephaven.proto.pqworker.ObjectAccessRequest
 
parseFrom(ByteBuffer) - Static method in class io.deephaven.proto.pqworker.ObjectAccessResponse
 
parseFrom(ByteBuffer) - Static method in class io.deephaven.proto.pqworker.StringList
 
parseFrom(ByteBuffer) - Static method in class io.deephaven.proto.pqworker.ThreadDumpRequest
 
parseFrom(ByteBuffer) - Static method in class io.deephaven.proto.pqworker.ThreadDumpResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.ErrorResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotPluginRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotPluginResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableApplyRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableApplyResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableCreationRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableCreationResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableDescriptorRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableSourceExportRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableSourceExportResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableViewRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.PivotTableViewResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pqworker.ListenErrorRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pqworker.ListenErrorResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pqworker.ObjectAccessRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pqworker.ObjectAccessResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pqworker.StringList
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pqworker.ThreadDumpRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.deephaven.proto.pqworker.ThreadDumpResponse
 
parser() - Static method in class io.deephaven.proto.pivot.ErrorResponse
 
parser() - Static method in class io.deephaven.proto.pivot.PivotPluginRequest
 
parser() - Static method in class io.deephaven.proto.pivot.PivotPluginResponse
 
parser() - Static method in class io.deephaven.proto.pivot.PivotTableApplyRequest
 
parser() - Static method in class io.deephaven.proto.pivot.PivotTableApplyResponse
 
parser() - Static method in class io.deephaven.proto.pivot.PivotTableCreationRequest
 
parser() - Static method in class io.deephaven.proto.pivot.PivotTableCreationResponse
 
parser() - Static method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage
 
parser() - Static method in class io.deephaven.proto.pivot.PivotTableDescriptorRequest
 
parser() - Static method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse
 
parser() - Static method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest
 
parser() - Static method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse
 
parser() - Static method in class io.deephaven.proto.pivot.PivotTableSourceExportRequest
 
parser() - Static method in class io.deephaven.proto.pivot.PivotTableSourceExportResponse
 
parser() - Static method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage
 
parser() - Static method in class io.deephaven.proto.pivot.PivotTableViewRequest
 
parser() - Static method in class io.deephaven.proto.pivot.PivotTableViewResponse
 
parser() - Static method in class io.deephaven.proto.pqworker.ListenErrorRequest
 
parser() - Static method in class io.deephaven.proto.pqworker.ListenErrorResponse
 
parser() - Static method in class io.deephaven.proto.pqworker.ObjectAccessRequest
 
parser() - Static method in class io.deephaven.proto.pqworker.ObjectAccessResponse
 
parser() - Static method in class io.deephaven.proto.pqworker.StringList
 
parser() - Static method in class io.deephaven.proto.pqworker.ThreadDumpRequest
 
parser() - Static method in class io.deephaven.proto.pqworker.ThreadDumpResponse
 
partialProcessInfoId(String) - Method in class io.deephaven.enterprise.dnd.query.util.perf.PerformanceOverview
Set a part of the ProcessInfoId.
PARTITIONED_TABLE_INTERNAL_PARTITION_COLUMN - Static variable in interface io.deephaven.enterprise.database.Database
PartitionedOptions() - Constructor for class io.deephaven.enterprise.derivedtablewriter.DerivedTableWriter.PartitionedOptions
 
partitionFilter(IntPredicate) - Method in class io.deephaven.enterprise.kafkawriter.KafkaTableWriter.Options
Set a filter to select which partitions to ingest.
partitionFormatter - Variable in class io.deephaven.enterprise.dnd.logger.engine.impl.BinaryRowLoggerDnd
 
PARTITIONING_COLUMN_NAME - Static variable in class io.deephaven.enterprise.database.inputtables.InputTableConstants
 
partitionOnlyCompare(EnterpriseTableLocationKey, TableLocationKey) - Static method in interface io.deephaven.enterprise.locations.EnterpriseTableLocationKey
Compare two location keys, automatically mapping the column and internal partition values.
partitionOnlyEquals(EnterpriseTableLocationKey, Object) - Static method in interface io.deephaven.enterprise.locations.EnterpriseTableLocationKey
Check for equality between two location keys using only the partition values.
partitionOnlyHashCode(EnterpriseTableLocationKey) - Static method in interface io.deephaven.enterprise.locations.EnterpriseTableLocationKey
Compute the hash code of the key using only the partitions.
partitionToInitialOffsetFallback(IntToLongFunction) - Method in class io.deephaven.enterprise.kafkawriter.KafkaTableWriter.Options
Set a function to determine what offset to consume from when other methods fail.
partitionValue(String) - Method in class io.deephaven.enterprise.kafkawriter.KafkaTableWriter.Options
The fixed column partition value to ingest into.
password(String, String) - Method in class io.deephaven.enterprise.dnd.client.DeephavenClusterConnection
Authenticate with the server using a username and password
password(String, String) - Method in class io.deephaven.enterprise.dnd.client.DndSessionFactoryBarrage
Authenticate with the server using a username and password
password(String, String) - Method in class io.deephaven.enterprise.remote.RemoteTableBuilder.Unauthenticated
Authenticate with the server using a username and password
peekNextKey() - Method in class io.deephaven.enterprise.compatibility.rowset.OrderedKeysToRowSequenceIteratorAdapter
 
peekNextKey() - Method in class io.deephaven.enterprise.compatibility.rowset.RowSequenceToOrderedKeysIteratorAdapter
 
PerformanceOverview - Class in io.deephaven.enterprise.dnd.query.util.perf
Builder class that accepts inputs as setters and uses said inputs to get a map of performance analysis tables and plots.
PerformanceOverview() - Constructor for class io.deephaven.enterprise.dnd.query.util.perf.PerformanceOverview
 
PerformanceOverview.PerformanceOverviewTools - Class in io.deephaven.enterprise.dnd.query.util.perf
 
PerformanceOverviewTools() - Constructor for class io.deephaven.enterprise.dnd.query.util.perf.PerformanceOverview.PerformanceOverviewTools
 
permissionFilterProvider() - Static method in class io.deephaven.enterprise.acl.impl.AclHelper
Get the PermissionFilterProvider to use for Enterprise integration
persistentQuery(long) - Method in class io.deephaven.enterprise.dnd.client.DndSessionFactoryBarrage
Create a new DndSession to the specified Persistent Query by serial.
persistentQuery(String) - Method in class io.deephaven.enterprise.dnd.client.DndSessionFactoryBarrage
Create a new DndSession to the specified Persistent Query by name.
PersistentQueryControllerClient - Interface in io.deephaven.enterprise.dnd.controller
Implementations of this interface provide a client that can communicate with the Persistent Query Controller to query and manage the state of Persistent Queries.
PersistentQueryControllerClient.Observer - Interface in io.deephaven.enterprise.dnd.controller
An object that will be notified of changes to the state of the Controller.
PersistentQueryControllerClient.ObserverImpl - Class in io.deephaven.enterprise.dnd.controller
A basic PersistentQueryControllerClient.Observer implementation with do-nothing methods.
PersistentQueryControllerClientImpl - Class in io.deephaven.enterprise.dnd.controller
 
PersistentQueryControllerClientImpl(ControllerClientGrpc) - Constructor for class io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClientImpl
 
PersistentQueryControllerClientImpl(String, ManagedChannel) - Constructor for class io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClientImpl
 
PersistentQueryControllerClientImpl(String, ManagedChannel, ScheduledExecutorService) - Constructor for class io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClientImpl
 
PersistentQueryControllerClientImpl(String, ManagedChannel, ScheduledExecutorService, AuthenticationClient, long, long) - Constructor for class io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClientImpl
 
PersistentQueryScriptSource - Interface in io.deephaven.enterprise.dnd.controller
Implementations of this class provide a way to access script code and paths for execution.
PersistentQueryStateToken(PersistentQueryInfoMessage) - Constructor for class io.deephaven.enterprise.remote.ControllerStateWatcher.PersistentQueryStateToken
PFPBackedTestGroupProvider - Class in io.deephaven.enterprise.test
A simple test adapter for using an InMemoryPermissionFilterProvider as an IrisGroupProvider for testing.
PFPBackedTestGroupProvider(InMemoryPermissionFilterProvider) - Constructor for class io.deephaven.enterprise.test.PFPBackedTestGroupProvider
 
PIVOT_DESCRIPTOR_FIELD_NUMBER - Static variable in class io.deephaven.proto.pivot.PivotTableApplyResponse
 
PIVOT_DESCRIPTOR_FIELD_NUMBER - Static variable in class io.deephaven.proto.pivot.PivotTableCreationResponse
 
PIVOT_DESCRIPTOR_FIELD_NUMBER - Static variable in class io.deephaven.proto.pivot.PivotTableDescriptorResponse
 
PIVOT_DESCRIPTOR_FIELD_NUMBER - Static variable in class io.deephaven.proto.pivot.PivotTableViewResponse
 
PIVOT_TABLE_AGGREGATION_INPUT_COLUMN_NAME - Static variable in class io.deephaven.pivot.PivotTableSchemaConstants
"pivotTable.aggregationInputColumnName" is set to the (string) name of the corresponding constituent column that was used as input to this column.
PIVOT_TABLE_COLUMN_COLUMNS_ATTRIBUTES - Static variable in class io.deephaven.pivot.PivotTableSchemaConstants
 
PIVOT_TABLE_GRAND_TOTAL_COLUMNS_ATTRIBUTES - Static variable in class io.deephaven.pivot.PivotTableSchemaConstants
 
PIVOT_TABLE_IS_COLUMN_DEPTH_COLUMN - Static variable in class io.deephaven.pivot.PivotTableSchemaConstants
"pivotTable.isColumnDepthColumn" is always "true" if set, and is set on a single column that specifies the depth of a column.
PIVOT_TABLE_IS_COLUMN_EXPAND_BY_COLUMN - Static variable in class io.deephaven.pivot.PivotTableSchemaConstants
"pivotTable.isExpandByColumn" is always "true" if set, and is set on all the columns that must be included in a PivotTableViewRequest's key table, if a key table is specified.
PIVOT_TABLE_IS_COLUMN_EXPANDED_COLUMN - Static variable in class io.deephaven.pivot.PivotTableSchemaConstants
"pivotTable.isColumnExpandedColumn" is always "true" if set, and is set on a single nullable column of booleans that specifies whether a column is expandable or expanded.
PIVOT_TABLE_IS_COLUMN_GROUP_BY_COLUMN - Static variable in class io.deephaven.pivot.PivotTableSchemaConstants
"pivotTable.isColumnGroupByColumn" is always "true" if set, and is set on all columns of a pivot that are column by-columns Such columns will always have "pivotTable.isColumnExpandByColumn" set.
PIVOT_TABLE_IS_COLUMN_VALUE_COLUMN - Static variable in class io.deephaven.pivot.PivotTableSchemaConstants
"pivotTable.isColumnValueColumn" is always "true" if set, and is set on all columns that are totals for a given column.
PIVOT_TABLE_IS_GRAND_TOTAL_VALUE_COLUMN - Static variable in class io.deephaven.pivot.PivotTableSchemaConstants
"pivotTable.isGrandTotalValueColumn" is always "true" if set, and is set on all columns that are a grand total the given table.
PIVOT_TABLE_IS_ROW_DEPTH_COLUMN - Static variable in class io.deephaven.pivot.PivotTableSchemaConstants
"pivotTable.isRowDepthColumn" is always "true" if set, and is set on a single column that specifies the depth of a row.
PIVOT_TABLE_IS_ROW_EXPAND_BY_COLUMN - Static variable in class io.deephaven.pivot.PivotTableSchemaConstants
"pivotTable.isRowExpandByColumn" is always "true" if set, and is set on all the columns that must be included in a PivotTableViewRequest's row key table, if a row key table is specified.
PIVOT_TABLE_IS_ROW_EXPANDED_COLUMN - Static variable in class io.deephaven.pivot.PivotTableSchemaConstants
"pivotTable.isRowExpandedColumn" is always "true" if set, and is set on a single nullable column of booleans that specifies whether a row is expandable or expanded.
PIVOT_TABLE_IS_ROW_GROUP_BY_COLUMN - Static variable in class io.deephaven.pivot.PivotTableSchemaConstants
"pivotTable.isRowGroupByColumn" is always "true" if set, and is set on all columns of a pivot that are row by-columns Such columns will always have "pivotTable.isRowExpandByColumn" set.
PIVOT_TABLE_IS_ROW_VALUE_COLUMN - Static variable in class io.deephaven.pivot.PivotTableSchemaConstants
"pivotTable.isRowValueColumn" is always "true" if set, and is set on all columns that are totals for a given row.
PIVOT_TABLE_IS_STRUCTURAL_COLUMN - Static variable in class io.deephaven.pivot.PivotTableSchemaConstants
"pivotTable.isStructuralColumn" is always "true" if set, and is set on columns that should be included on every snapshot or subscription request, but should not be directly user-visible.
PIVOT_TABLE_IS_VALUE_COLUMN - Static variable in class io.deephaven.pivot.PivotTableSchemaConstants
"pivotTable.isValueColumn" is always "true" if set, and is set on all columns that are part of the main field (grid) of values.
PIVOT_TABLE_OFFSET - Enum constant in enum class io.deephaven.proto.pivot.PivotTableViewRequest.TargetCase
 
PIVOT_TABLE_OFFSET_FIELD_NUMBER - Static variable in class io.deephaven.proto.pivot.PivotTableViewRequest
 
PIVOT_TABLE_ROW_COLUMN_ATTRIBUTES - Static variable in class io.deephaven.pivot.PivotTableSchemaConstants
 
PIVOT_TABLE_VALUE_COLUMNS_ATTRIBUTES - Static variable in class io.deephaven.pivot.PivotTableSchemaConstants
 
PivotBarrageMessageType - Class in io.deephaven.enterprise.pivot.flatbuf
 
PivotBarrageMessageWriterImpl - Class in io.deephaven.pivot
 
PivotBarrageMessageWriterImpl(BarrageMessage, ChunkWriter<Chunk<Values>>[], BarragePerformanceLog.WriteMetricsConsumer) - Constructor for class io.deephaven.pivot.PivotBarrageMessageWriterImpl
Create a barrage stream writer that can slice and dice the barrage message for delivery to clients.
PivotMarshallerModule - Class in io.deephaven.pivot
 
PivotMarshallerModule() - Constructor for class io.deephaven.pivot.PivotMarshallerModule
 
PivotMarshallerModule.PivotSubscriptionRequestHandlerFactory - Class in io.deephaven.pivot
Factory to handle Barrage DoExchange subscription requests.
PivotPluginRequest - Class in io.deephaven.proto.pivot
We have not created a service, but rather make a request using the oneof message; and reply using the corresponding message in the PivotPluginResponse.
PivotPluginRequest.Builder - Class in io.deephaven.proto.pivot
We have not created a service, but rather make a request using the oneof message; and reply using the corresponding message in the PivotPluginResponse.
PivotPluginRequest.RequestCase - Enum Class in io.deephaven.proto.pivot
 
PivotPluginRequestOrBuilder - Interface in io.deephaven.proto.pivot
 
PivotPluginResponse - Class in io.deephaven.proto.pivot
Protobuf type io.deephaven.proto.pivot.PivotPluginResponse
PivotPluginResponse.Builder - Class in io.deephaven.proto.pivot
Protobuf type io.deephaven.proto.pivot.PivotPluginResponse
PivotPluginResponse.ResponseCase - Enum Class in io.deephaven.proto.pivot
 
PivotPluginResponseOrBuilder - Interface in io.deephaven.proto.pivot
 
PivotServicePlugin - Class in io.deephaven.pivot
 
PivotServicePlugin() - Constructor for class io.deephaven.pivot.PivotServicePlugin
 
PivotSubscriptionRequest - Static variable in class io.deephaven.enterprise.pivot.flatbuf.PivotBarrageMessageType
 
PivotSubscriptionRequestHandlerFactory() - Constructor for class io.deephaven.pivot.PivotMarshallerModule.PivotSubscriptionRequestHandlerFactory
 
Pivottable - Class in io.deephaven.proto.pivot
 
PivotTable - Interface in io.deephaven.pivot
A pivot table is a display-only object that aggregates using a list of row by-columns and column by-columns, presenting the aggregated value for each combination of row and column by-column as a single cell.
PivotTable.PivotSnapshot - Interface in io.deephaven.pivot
A pivot snapshot contains three logical tables (represented as parallel definitions and chunks) that can be assembled into a view on the screen: Rows: The rows "table" contain the values of the row keys, their depth, and expanded state.
PivotTable.SnapshotState - Interface in io.deephaven.pivot
Opaque interface for objects used to cache snapshot state across multiple invocations of PivotTable.snapshot(SnapshotState, Table, Table, ColumnName, ColumnName, Collection, RowSequence, RowSequence)
PivotTableApplyRequest - Class in io.deephaven.proto.pivot
Protobuf type io.deephaven.proto.pivot.PivotTableApplyRequest
PivotTableApplyRequest.Builder - Class in io.deephaven.proto.pivot
Protobuf type io.deephaven.proto.pivot.PivotTableApplyRequest
PivotTableApplyRequestOrBuilder - Interface in io.deephaven.proto.pivot
 
PivotTableApplyResponse - Class in io.deephaven.proto.pivot
Protobuf type io.deephaven.proto.pivot.PivotTableApplyResponse
PivotTableApplyResponse.Builder - Class in io.deephaven.proto.pivot
Protobuf type io.deephaven.proto.pivot.PivotTableApplyResponse
PivotTableApplyResponseOrBuilder - Interface in io.deephaven.proto.pivot
 
PivotTableCreationRequest - Class in io.deephaven.proto.pivot
Protobuf type io.deephaven.proto.pivot.PivotTableCreationRequest
PivotTableCreationRequest.Builder - Class in io.deephaven.proto.pivot
Protobuf type io.deephaven.proto.pivot.PivotTableCreationRequest
PivotTableCreationRequestOrBuilder - Interface in io.deephaven.proto.pivot
 
PivotTableCreationResponse - Class in io.deephaven.proto.pivot
Protobuf type io.deephaven.proto.pivot.PivotTableCreationResponse
PivotTableCreationResponse.Builder - Class in io.deephaven.proto.pivot
Protobuf type io.deephaven.proto.pivot.PivotTableCreationResponse
PivotTableCreationResponseOrBuilder - Interface in io.deephaven.proto.pivot
 
PivotTableDescriptorMessage - Class in io.deephaven.proto.pivot
Protobuf type io.deephaven.proto.pivot.PivotTableDescriptorMessage
PivotTableDescriptorMessage.Builder - Class in io.deephaven.proto.pivot
Protobuf type io.deephaven.proto.pivot.PivotTableDescriptorMessage
PivotTableDescriptorMessageOrBuilder - Interface in io.deephaven.proto.pivot
 
PivotTableDescriptorRequest - Class in io.deephaven.proto.pivot
the first object is the pivot table
PivotTableDescriptorRequest.Builder - Class in io.deephaven.proto.pivot
the first object is the pivot table
PivotTableDescriptorRequestOrBuilder - Interface in io.deephaven.proto.pivot
 
PivotTableDescriptorResponse - Class in io.deephaven.proto.pivot
Protobuf type io.deephaven.proto.pivot.PivotTableDescriptorResponse
PivotTableDescriptorResponse.Builder - Class in io.deephaven.proto.pivot
Protobuf type io.deephaven.proto.pivot.PivotTableDescriptorResponse
PivotTableDescriptorResponseOrBuilder - Interface in io.deephaven.proto.pivot
 
PivotTableEmptyExpansionsRequest - Class in io.deephaven.proto.pivot
the first object is the pivot table
PivotTableEmptyExpansionsRequest.Builder - Class in io.deephaven.proto.pivot
the first object is the pivot table
PivotTableEmptyExpansionsRequestOrBuilder - Interface in io.deephaven.proto.pivot
 
PivotTableEmptyExpansionsResponse - Class in io.deephaven.proto.pivot
the first object is the result rows expansion table the second object is the result columns expansion table
PivotTableEmptyExpansionsResponse.Builder - Class in io.deephaven.proto.pivot
the first object is the result rows expansion table the second object is the result columns expansion table
PivotTableEmptyExpansionsResponseOrBuilder - Interface in io.deephaven.proto.pivot
 
PivotTablePlugin - Class in io.deephaven.pivot
 
PivotTablePlugin() - Constructor for class io.deephaven.pivot.PivotTablePlugin
 
PivotTableSchemaConstants - Class in io.deephaven.pivot
Constants for interpreting Arrow schemas from io.deephaven.pivot.PivotTable instances.
PivotTableSchemaConstants() - Constructor for class io.deephaven.pivot.PivotTableSchemaConstants
 
PivotTableSchemaUtil - Class in io.deephaven.pivot
Utilities for creating schemas from PivotTable instances.
PivotTableSchemaUtil() - Constructor for class io.deephaven.pivot.PivotTableSchemaUtil
 
PivotTableSourceExportRequest - Class in io.deephaven.proto.pivot
the first object is the pivot table
PivotTableSourceExportRequest.Builder - Class in io.deephaven.proto.pivot
the first object is the pivot table
PivotTableSourceExportRequestOrBuilder - Interface in io.deephaven.proto.pivot
 
PivotTableSourceExportResponse - Class in io.deephaven.proto.pivot
the first object is the result source table
PivotTableSourceExportResponse.Builder - Class in io.deephaven.proto.pivot
the first object is the result source table
PivotTableSourceExportResponseOrBuilder - Interface in io.deephaven.proto.pivot
 
PivotTableTicketTransformer - Class in io.deephaven.enterprise.acl.transform
A TicketTransformer that handles transformation of PivotTables to apply ACLs at the edge.
PivotTableTicketTransformer(AclSupport) - Constructor for class io.deephaven.enterprise.acl.transform.PivotTableTicketTransformer
 
PivotTableView - Class in io.deephaven.pivot
Server-side "view" object representing a client's snapshot target for HierarchicalTable data.
PivotTableViewExchangeMarshaller - Class in io.deephaven.pivot
An ExchangeMarshaller for PivotTableView.
PivotTableViewExchangeMarshaller(PivotTableViewSubscription.Factory) - Constructor for class io.deephaven.pivot.PivotTableViewExchangeMarshaller
 
PivotTableViewExchangeMarshaller.Factory - Class in io.deephaven.pivot
 
PivotTableViewExpansionsMessage - Class in io.deephaven.proto.pivot
Protobuf type io.deephaven.proto.pivot.PivotTableViewExpansionsMessage
PivotTableViewExpansionsMessage.Builder - Class in io.deephaven.proto.pivot
Protobuf type io.deephaven.proto.pivot.PivotTableViewExpansionsMessage
PivotTableViewExpansionsMessageOrBuilder - Interface in io.deephaven.proto.pivot
 
PivotTableViewRequest - Class in io.deephaven.proto.pivot
Protobuf type io.deephaven.proto.pivot.PivotTableViewRequest
PivotTableViewRequest.Builder - Class in io.deephaven.proto.pivot
Protobuf type io.deephaven.proto.pivot.PivotTableViewRequest
PivotTableViewRequest.TargetCase - Enum Class in io.deephaven.proto.pivot
 
PivotTableViewRequestOrBuilder - Interface in io.deephaven.proto.pivot
 
PivotTableViewResponse - Class in io.deephaven.proto.pivot
Protobuf type io.deephaven.proto.pivot.PivotTableViewResponse
PivotTableViewResponse.Builder - Class in io.deephaven.proto.pivot
Protobuf type io.deephaven.proto.pivot.PivotTableViewResponse
PivotTableViewResponseOrBuilder - Interface in io.deephaven.proto.pivot
 
PivotTableViewSubscription - Class in io.deephaven.pivot
Tool that manages an active subscription to a PivotTableView.
PivotTableViewSubscription(Scheduler, SessionService.ErrorTransformer, BarrageMessageWriter.Factory, PivotTableView, StreamObserver<BarrageMessageWriter.MessageView>, BarrageSubscriptionOptions, long) - Constructor for class io.deephaven.pivot.PivotTableViewSubscription
 
PivotTableViewSubscription.Factory - Interface in io.deephaven.pivot
 
PivotTestUtils - Class in io.deephaven.pivot
 
PivotTestUtils() - Constructor for class io.deephaven.pivot.PivotTestUtils
 
PivotUpdateMetadata - Class in io.deephaven.enterprise.pivot.flatbuf
A data header describing the shared memory layout of a "record" or "row" batch for a ticking barrage table.
PivotUpdateMetadata - Static variable in class io.deephaven.enterprise.pivot.flatbuf.PivotBarrageMessageType
 
PivotUpdateMetadata() - Constructor for class io.deephaven.enterprise.pivot.flatbuf.PivotUpdateMetadata
 
PivotUpdateMetadata.Vector - Class in io.deephaven.enterprise.pivot.flatbuf
 
pqName(String) - Method in class io.deephaven.enterprise.dnd.query.util.perf.PerformanceOverview
Set the PQ name of the desired worker.
PQUriResolver - Class in io.deephaven.enterprise.dnd.uri
A UriResolver specifically for resolving requests for tables from persistent queries by serial or name.
PQUriResolver(ControllerClientFactory) - Constructor for class io.deephaven.enterprise.dnd.uri.PQUriResolver
 
Pqworker - Class in io.deephaven.proto.pqworker
 
PQWorkerApiGrpc - Class in io.deephaven.proto.pqworker.grpc
 
PQWorkerApiGrpc.AsyncService - Interface in io.deephaven.proto.pqworker.grpc
 
PQWorkerApiGrpc.PQWorkerApiBlockingStub - Class in io.deephaven.proto.pqworker.grpc
A stub to allow clients to do synchronous rpc calls to service PQWorkerApi.
PQWorkerApiGrpc.PQWorkerApiFutureStub - Class in io.deephaven.proto.pqworker.grpc
A stub to allow clients to do ListenableFuture-style rpc calls to service PQWorkerApi.
PQWorkerApiGrpc.PQWorkerApiImplBase - Class in io.deephaven.proto.pqworker.grpc
Base class for the server implementation of the service PQWorkerApi.
PQWorkerApiGrpc.PQWorkerApiStub - Class in io.deephaven.proto.pqworker.grpc
A stub to allow clients to do asynchronous rpc calls to service PQWorkerApi.
PQWorkerApiImplBase() - Constructor for class io.deephaven.proto.pqworker.grpc.PQWorkerApiGrpc.PQWorkerApiImplBase
 
PqworkerService - Class in io.deephaven.proto.pqworker.grpc
 
PQWorkerServiceAuthWiring - Interface in io.deephaven.enterprise.dnd.authentication
 
PQWorkerServiceGrpcImpl - Class in io.deephaven.enterprise.dnd.service.pqworker
 
PQWorkerServiceGrpcImpl(Provider<ScriptSession>, Set<TicketTransformer>) - Constructor for class io.deephaven.enterprise.dnd.service.pqworker.PQWorkerServiceGrpcImpl
 
PQWorkerServiceModule - Interface in io.deephaven.enterprise.dnd.modules
 
preemptiveSnapshotTable(long) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
preemptiveUpdatesTable(long) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
priority() - Method in class io.deephaven.enterprise.acl.transform.GenericObjectTransformer
 
priority() - Method in class io.deephaven.enterprise.acl.transform.HierarchicalTableTicketTransformer
 
priority() - Method in class io.deephaven.enterprise.acl.transform.PivotTableTicketTransformer
 
priority() - Method in class io.deephaven.enterprise.acl.transform.TableTicketTransformer
 
priority() - Method in interface io.deephaven.enterprise.dnd.authentication.transform.TicketTransformer
The relative priority of the transformer.
priority() - Method in class io.deephaven.enterprise.dnd.query.util.perf.PerformanceOverview.PerformanceOverviewTools
 
priority() - Method in class io.deephaven.pivot.PivotTableViewExchangeMarshaller
 
privateKey(String) - Method in class io.deephaven.enterprise.dnd.client.DeephavenClusterConnection
Authenticate to the server using a private key file.
privateKey(String) - Method in class io.deephaven.enterprise.dnd.client.DndSessionFactoryBarrage
Authenticate to the server using a private key file.
privateKey(String) - Method in class io.deephaven.enterprise.remote.RemoteTableBuilder.Unauthenticated
Authenticate to the server using a private key file.
ProcessEventLogAppender - Class in io.deephaven.enterprise.dnd
 
ProcessEventLogAppender() - Constructor for class io.deephaven.enterprise.dnd.ProcessEventLogAppender
 
ProcessInfo - Class in io.deephaven.enterprise.dnd
 
ProcessInfo(String, String, String, String, String) - Constructor for class io.deephaven.enterprise.dnd.ProcessInfo
 
processInfoId(String) - Method in class io.deephaven.enterprise.dnd.query.util.perf.PerformanceOverview
Set the ProcessInfoId to narrow the performance data.
ProcessInfoId - Class in io.deephaven.enterprise.dnd
Static accessor for this worker's process information ID.
processInfoLogLogger() - Method in class io.deephaven.enterprise.dnd.logger.engine.impl.EngineTableLoggersFactoryDndImpl
 
processMetadata(ParquetMetadata) - Static method in class io.deephaven.enterprise.locations.local.ParquetShadowHelper
Process a ParquetMetadata object, potentially rewriting codec mappings to account for enterprise shadowing.
processMetricsLogLogger() - Method in class io.deephaven.enterprise.dnd.logger.engine.impl.EngineTableLoggersFactoryDndImpl
 
ProcessMetricsLogLoggerDndImpl - Class in io.deephaven.enterprise.dnd.logger.engine.impl
 
PropertiesSecretsProvider - Class in io.deephaven.enterprise.secrets
A SecretsProvider that loads secrets from Configuration.
PropertiesSecretsProvider() - Constructor for class io.deephaven.enterprise.secrets.PropertiesSecretsProvider
 
PropertiesSecretsProvider.Factory - Class in io.deephaven.enterprise.secrets
The factory for creating a SecretsProvider that loads secrets from configuration.
PropertyInputStreamLoaderResourcesOnly - Class in io.deephaven.enterprise.test
A PropertyInputStreamLoader that loads the property input stream from resources only.
PropertyInputStreamLoaderResourcesOnly() - Constructor for class io.deephaven.enterprise.test.PropertyInputStreamLoaderResourcesOnly
 
ProtocolDriverFactory - Interface in io.deephaven.enterprise.tabledataservice
An interface for creating TableDataProtocolDriver instances for use with RemoteTableDataService and RemoteTableLocationImpl
provideAppStateListener(ApplicationServiceGrpcImpl) - Static method in class io.deephaven.enterprise.dnd.modules.EnterpriseApiServerModule
 
provideAuthClient() - Static method in interface io.deephaven.enterprise.dnd.modules.EnterpriseAuthModule
 
provideDatabase(DatabaseImpl, Function<Database, Database>) - Static method in interface io.deephaven.enterprise.dnd.modules.DatabaseModule
 
provideEnterpriseCalendars() - Static method in class io.deephaven.enterprise.dnd.modules.EnterpriseCalendarsModule
 
provideGroovySession(UpdateGraph, OperationInitializer, ObjectTypeLookup, ScriptSession.Listener, GroovyDeephavenSession.RunScripts, Database, File, String, UserContext, ControllerClientFactory) - Static method in interface io.deephaven.enterprise.dnd.modules.GroovyConsoleSessionWithDatabaseModule
 
provideHierarchicalTableTransformer(AclSupport) - Static method in interface io.deephaven.enterprise.dnd.modules.EnterpriseAuthModule
 
provideLocalClusterFactory(Supplier<PersistentQueryControllerClient>, ScheduledExecutorService, BufferAllocator, ClientChannelFactory, AuthenticationClient, SSLConfig) - Static method in class io.deephaven.enterprise.dnd.modules.EnterpriseApiServerModule
 
provideObjectTransformer(GroupProvider) - Static method in interface io.deephaven.enterprise.dnd.modules.EnterpriseAuthModule
 
providePivotTableTransformer(AclSupport) - Static method in interface io.deephaven.enterprise.dnd.modules.EnterpriseAuthModule
 
providePythonSession(UpdateGraph, ThreadInitializationFactory, OperationInitializer, ObjectTypeLookup, ScriptSession.Listener, PythonEvaluatorJpy, Database, ControllerClientFactory, String, String) - Static method in interface io.deephaven.enterprise.dnd.modules.PythonConsoleSessionWithDatabaseModule
 
provideReplayTransformer(Configuration, ReplaySettings) - Method in class io.deephaven.enterprise.dnd.ConfigureReplay
 
providesAclprovider(UserContext, PermissionFilterProvider, Client) - Static method in interface io.deephaven.enterprise.dnd.modules.EnterpriseAuthModule
 
providesAppStateFactory() - Static method in class io.deephaven.enterprise.dnd.modules.EnterpriseApiServerModule
 
providesAuth(DheAuthorizationProvider) - Static method in interface io.deephaven.enterprise.dnd.modules.EnterpriseAuthModule
 
provideScriptSession(Map<String, Provider<ScriptSession>>, long, String, UserContext) - Method in class io.deephaven.enterprise.dnd.modules.EnterpriseApiServerModule
 
provideScriptSession(PythonDeephavenSession) - Static method in interface io.deephaven.enterprise.dnd.modules.PythonConsoleSessionWithDatabaseModule
 
providesDatabaseTicketResolver(DatabaseTicketResolver) - Method in interface io.deephaven.enterprise.dnd.modules.DatabaseModule
 
providesDheAuthProvider(UserContext, Set<String>, Set<String>, ProcessInfo, Set<TicketTransformer>) - Static method in interface io.deephaven.enterprise.dnd.modules.EnterpriseAuthModule
 
providesDnDAuth(DheAuthorizationProvider) - Static method in interface io.deephaven.enterprise.dnd.modules.EnterpriseAuthModule
 
provideSessionListener(int, Long, PrintStream, DispatcherClient, Set<DndSessionListenerModule.DndSessionCountListener>) - Static method in interface io.deephaven.enterprise.dnd.modules.DndSessionListenerModule
 
providesGroupProvider(PermissionFilterProvider) - Static method in interface io.deephaven.enterprise.dnd.modules.EnterpriseAuthModule
 
providesImpl(UserContext, PermissionFilterProvider, GroupProvider, SourceAclProvider, AuditEventLogger, ProcessInfo) - Static method in interface io.deephaven.enterprise.dnd.modules.DatabaseModule
 
providesListener(ApplicationServiceGrpcImpl, Set<ScriptSession.Listener>) - Static method in class io.deephaven.enterprise.dnd.modules.EnterpriseApiServerModule
 
providesPermissionFilterProvider(UserContext, Client) - Static method in interface io.deephaven.enterprise.dnd.modules.EnterpriseAuthModule
 
providesPQUriResolver(PQUriResolver) - Method in interface io.deephaven.enterprise.dnd.modules.URIModule
 
providesPQWorkerService(DnDAuthorizationProvider, PQWorkerServiceGrpcImpl) - Static method in interface io.deephaven.enterprise.dnd.modules.PQWorkerServiceModule
 
providesSupport(DatabaseImpl) - Static method in interface io.deephaven.enterprise.dnd.modules.DatabaseModule
 
providesWorkerService(Provider<ScriptSession>, Set<TicketTransformer>) - Static method in interface io.deephaven.enterprise.dnd.modules.PQWorkerServiceModule
 
provideTableTransformer(AclSupport) - Static method in interface io.deephaven.enterprise.dnd.modules.EnterpriseAuthModule
 
provideUriConfig(boolean) - Static method in interface io.deephaven.enterprise.dnd.modules.SSLConfigModule
 
publish(SessionState, ByteBuffer, String, Runnable) - Method in class io.deephaven.enterprise.dnd.service.ticket.DatabaseTicketResolver
 
publish(SessionState, Flight.FlightDescriptor, String, Runnable) - Method in class io.deephaven.enterprise.dnd.service.ticket.DatabaseTicketResolver
 
PushSessionChangeListener - Class in io.deephaven.enterprise.dnd
The PushSessionChangeListener creates a ScriptSession.Listener when enabled that tracks changes to the query scope and sends them to the Controller to update a query state.
PushSessionChangeListener() - Constructor for class io.deephaven.enterprise.dnd.PushSessionChangeListener
 
pushSessionChanges(boolean) - Method in interface io.deephaven.enterprise.dnd.EnterpriseJettyComponent.Builder
Set if the worker should push session changes to the controller.
putAllObjectGroups(Map<String, StringList>) - Method in class io.deephaven.proto.pqworker.ObjectAccessResponse.Builder
map<string, .io.deephaven.proto.pqworker.StringList> objectGroups = 1;
putColumnCodecs(String, ObjectCodec<?>) - Method in interface io.deephaven.enterprise.database.SystemTableLogger.Options.Builder
Set the codec information for a column.
putHadoopOptions(String...) - Method in interface io.deephaven.enterprise.iceberg.IcebergEndpoint.Builder
Add the passed hadoop options to the builder.
putHadoopOptions(Map<String, ? extends String>) - Method in interface io.deephaven.enterprise.iceberg.IcebergEndpoint.Builder
Add the passed hadoop options to the builder.
putObjectGroups(String, StringList) - Method in class io.deephaven.proto.pqworker.ObjectAccessResponse.Builder
map<string, .io.deephaven.proto.pqworker.StringList> objectGroups = 1;
putObjectGroupsBuilderIfAbsent(String) - Method in class io.deephaven.proto.pqworker.ObjectAccessResponse.Builder
map<string, .io.deephaven.proto.pqworker.StringList> objectGroups = 1;
putProperties(String...) - Method in interface io.deephaven.enterprise.iceberg.IcebergEndpoint.Builder
Add the passed properties to the builder.
putProperties(Map<String, ? extends String>) - Method in interface io.deephaven.enterprise.iceberg.IcebergEndpoint.Builder
Add the passed properties to the builder.
putSecrets(String...) - Method in interface io.deephaven.enterprise.iceberg.IcebergEndpoint.Builder
Add the passed secrets to the builder.
putSecrets(Map<String, ? extends String>) - Method in interface io.deephaven.enterprise.iceberg.IcebergEndpoint.Builder
Add the passed secrets to the builder.
PythonConsoleSessionWithDatabaseModule - Interface in io.deephaven.enterprise.dnd.modules
 

Q

queryDeletionHook(Boolean, Long, ControllerClientFactory, ProcessInfo) - Static method in class io.deephaven.enterprise.dnd.QueryDeletionHook
 
QueryDeletionHook - Class in io.deephaven.enterprise.dnd
A hook that is called from the session monitor to delete our persistent query when we are complete.
QueryDeletionHook() - Constructor for class io.deephaven.enterprise.dnd.QueryDeletionHook
 
QueryLogSetupQuery - Class in io.deephaven.coreplus.querylog
Sets up the QueryLogs Query which supplies access to log tables for the web client.
queryMap - Variable in class io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClientImpl
 
queryName(String) - Method in class io.deephaven.enterprise.remote.RemoteTableBuilder
Set the name of the query to fetch the table from.
queryOperationPerformanceLogLogger() - Method in class io.deephaven.enterprise.dnd.logger.engine.impl.EngineTableLoggersFactoryDndImpl
 
queryPerformanceLogLogger() - Method in class io.deephaven.enterprise.dnd.logger.engine.impl.EngineTableLoggersFactoryDndImpl
 

R

raj(Table, MatchPair[], MatchPair[], Table.AsOfMatchRule) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
RangeFilterAdapter - Class in io.deephaven.shadow.enterprise.com.illumon.iris.db.v2.select
 
RangeFilterAdapter() - Constructor for class io.deephaven.shadow.enterprise.com.illumon.iris.db.v2.select.RangeFilterAdapter
 
readOffsetFromSourceRecord(Logger, TableDataService, FullTableLocationKey, String, String) - Static method in class io.deephaven.enterprise.ingester.impl.OffsetUtils
Given the key of a stream, and the prior column partition for this stream, read the expected offset that should be used to resume the stream.
readTable(File) - Static method in class io.deephaven.enterprise.table.EnterpriseTableTools
Read the Deephaven format table at the specified path.
readTable(File, TableDefinition) - Static method in class io.deephaven.enterprise.table.EnterpriseTableTools
Read the Deephaven format table at the specified path and given definition.
readTable(String) - Static method in class io.deephaven.enterprise.table.EnterpriseTableTools
Read the Deephaven format table at the specified path.
REASON_FIELD_NUMBER - Static variable in class io.deephaven.proto.pqworker.ThreadDumpRequest
 
rebase(Table) - Method in interface io.deephaven.pivot.PivotTable
Create a new PivotTable based on newSource, inheriting this Pivot's aggregations, PivotTable.getRowByColumns() row by-columns, column by-columns, and applied operations (i.e.
RecomputeListenerAdapter - Class in io.deephaven.enterprise.compatibility.filter
An adapter class to map a Community WhereFilter.RecomputeListener onto the Enterprise SelectFilter.RecomputeListener.
RecomputeListenerAdapter(WhereFilter.RecomputeListener) - Constructor for class io.deephaven.enterprise.compatibility.filter.RecomputeListenerAdapter
 
referenceDefinition() - Method in interface io.deephaven.enterprise.iceberg.discovery.DiscoveryConfig
Optional; A reference TableDefinition that the discovered table must be compatible with.
referenceDefinition(TableDefinition) - Method in interface io.deephaven.enterprise.iceberg.discovery.DiscoveryConfig.Builder
An optional user specified reference TableDefinition.
refresh() - Method in class io.deephaven.enterprise.compatibility.locationprovider.CoreFromEnterpriseTableLocationProvider
 
refresh() - Method in class io.deephaven.enterprise.locations.local.deephaven.OnDiskDeephavenTableLocation
 
refresh() - Method in class io.deephaven.enterprise.locations.local.HybridSnapshotBackedTableLocation
 
refresh() - Method in class io.deephaven.enterprise.locations.remote.RemoteDeephavenTableLocation
 
refresh() - Method in class io.deephaven.enterprise.tabledataservice.MarkingPollingLocationProvider
 
refreshSources() - Method in class io.deephaven.enterprise.test.CapturingUpdateGraph
 
RegionUtilities - Class in io.deephaven.enterprise.sources.regioned.impl
Minor utility methods used by column region and RegionedColumnSource implementations.
registerAllExtensions(ExtensionRegistry) - Static method in class io.deephaven.proto.pivot.Pivottable
 
registerAllExtensions(ExtensionRegistry) - Static method in class io.deephaven.proto.pqworker.grpc.PqworkerService
 
registerAllExtensions(ExtensionRegistry) - Static method in class io.deephaven.proto.pqworker.Pqworker
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class io.deephaven.proto.pivot.Pivottable
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class io.deephaven.proto.pqworker.grpc.PqworkerService
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class io.deephaven.proto.pqworker.Pqworker
 
reinterpret(Class<ALTERNATE_DATA_TYPE>) - Method in class io.deephaven.enterprise.compatibility.filter.ColumnSourceAdapterForFilter
 
releaseCachedResources() - Method in class io.deephaven.enterprise.sources.regioned.impl.BufferedColumnRegionBase
 
releaseCachedResources() - Method in class io.deephaven.enterprise.sources.regioned.impl.ColumnRegionObjectCached
 
releaseCachedResources() - Method in class io.deephaven.enterprise.sources.regioned.impl.ColumnRegionObjectCodecFixed
 
releaseCachedResources() - Method in class io.deephaven.enterprise.sources.regioned.impl.ColumnRegionObjectCodecVariable
 
releaseCachedResources() - Method in class io.deephaven.enterprise.sources.regioned.impl.ColumnRegionObjectWithDictionary
 
releaseCachedResources() - Method in class io.deephaven.enterprise.sources.regioned.impl.ColumnRegionStringSet
 
reloadConfiguration() - Method in interface io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClient
Command the PersistentQueryController to reload parts of its configuration without requiring a controller restart.
reloadConfiguration() - Method in class io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClientImpl
 
RELOCATED_PACKAGES - Static variable in class io.deephaven.enterprise.compatibility.shadow.ShadowCompatibility
 
RemoteDeephavenTableLocation - Class in io.deephaven.enterprise.locations.remote
A TableLocation implementation for remote table subscriptions discovered by a io.deephaven.enterprise.tabledataservice.RemoteTableDataService.
RemoteDeephavenTableLocation(TableDataProtocolDriver, EnterpriseTableKey, EnterpriseTableLocationKey, TableDefinition) - Constructor for class io.deephaven.enterprise.locations.remote.RemoteDeephavenTableLocation
Create a remote table location using the specified protocol driver for acquiring table data.
RemoteTableBuilder - Class in io.deephaven.enterprise.remote
A Builder class for creating reliable subscriptions to remote tables.
RemoteTableBuilder(CorePlusClusterSessionFactory) - Constructor for class io.deephaven.enterprise.remote.RemoteTableBuilder
Create a new RemoteTableBuilder for connecting to queries within a Core+ cluster.
RemoteTableBuilder.Unauthenticated - Class in io.deephaven.enterprise.remote
An interposed interface that forces users to authenticate with the remote system before they can call any subscription methods.
RemoteTableDataService - Class in io.deephaven.enterprise.tabledataservice
A TableDataService implementation that uses Enterprise's TableDataProtocol to locate tables.
RemoteTableDataService(SchemaService, TableDataProtocolDriver, String) - Constructor for class io.deephaven.enterprise.tabledataservice.RemoteTableDataService
Construct a new remote table data service, ready to be connected.
RemoteTableSessionFactory - Interface in io.deephaven.enterprise.remote
A Factory class for creating sessions for a ConnectionAwareRemoteTable to connect to.
RemoteTableStateWatcher - Interface in io.deephaven.enterprise.remote
An Observable interface for ConnectionAwareRemoteTable to monitor the state of a remote table.
RemoteTableStateWatcher.Observer - Interface in io.deephaven.enterprise.remote
An Observer of state changes for this watcher.
RemoteTableStateWatcher.StateToken - Interface in io.deephaven.enterprise.remote
A Token representing the state of the remote table object.
removeAggregations(int) - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
aggregations for the values
removeColumnSorts(int) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor column_sorts = 2;
removeFilters(int) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
The filters must be against the grouping columns (either row or columns)
removeObjectGroups(String) - Method in class io.deephaven.proto.pqworker.ObjectAccessResponse.Builder
map<string, .io.deephaven.proto.pqworker.StringList> objectGroups = 1;
removeObserver(PersistentQueryControllerClient.Observer) - Method in interface io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClient
Remove the specified PersistentQueryControllerClient.Observer from the notification list.
removeObserver(PersistentQueryControllerClient.Observer) - Method in class io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClientImpl
 
removeQuery(long) - Method in interface io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClient
Removes a configuration from the controller's hash table by serial ID.
removeQuery(long) - Method in class io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClientImpl
 
removeQuery(PersistentQueryConfigMessage) - Method in interface io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClient
Removes a configuration from the controller's hash table.
removeRowSorts(int) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor row_sorts = 1;
removeSource(Runnable) - Method in class io.deephaven.enterprise.test.CapturingUpdateGraph
 
removeTable(LiveTable) - Method in class io.deephaven.enterprise.compatibility.LiveTableRegistrarAdapter
 
renameColumns(MatchPair...) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
renameColumns(Collection<Pair>) - Method in class io.deephaven.enterprise.extensions.UncoalescedBlinkTable
 
ReplayConfiguration - Interface in io.deephaven.enterprise.replay
An interface for providing TableReplayConfigurations by namespace and table name.
ReplayConfigurationImpl - Class in io.deephaven.enterprise.replay
A holder for TableReplayConfigurations, that allows the configurations to be accessed by namespace and tablename.
ReplayConfigurationImpl(ComposableTableReplayConfiguration) - Constructor for class io.deephaven.enterprise.replay.ReplayConfigurationImpl
 
ReplayDatabase - Class in io.deephaven.enterprise.replay
The ReplayDatabase wraps another Database implementation; applying ClockFilters to liveTables before returning them to the user.
ReplayDatabase(Clock, Database, ReplaySettings, ReplayConfiguration) - Constructor for class io.deephaven.enterprise.replay.ReplayDatabase
Create a new ReplayDatabase that wraps an underlying database.
ReplayDatabase.ReplayException - Exception in io.deephaven.enterprise.replay
 
reportUpdateError(Throwable) - Method in class io.deephaven.enterprise.dnd.service.pqworker.PQWorkerServiceGrpcImpl
 
REQUEST_ID_FIELD_NUMBER - Static variable in class io.deephaven.proto.pivot.PivotPluginRequest
 
REQUEST_ID_FIELD_NUMBER - Static variable in class io.deephaven.proto.pivot.PivotPluginResponse
 
REQUEST_NOT_SET - Enum constant in enum class io.deephaven.proto.pivot.PivotPluginRequest.RequestCase
 
requestRecompute() - Method in class io.deephaven.enterprise.compatibility.filter.RecomputeListenerAdapter
 
requestRecomputeMatched() - Method in class io.deephaven.enterprise.compatibility.filter.RecomputeListenerAdapter
 
requestRecomputeUnmatched() - Method in class io.deephaven.enterprise.compatibility.filter.RecomputeListenerAdapter
 
requestRefresh() - Method in class io.deephaven.enterprise.test.CapturingUpdateGraph
 
requestRefresh(LiveTable) - Method in class io.deephaven.enterprise.compatibility.LiveTableRegistrarAdapter
 
requestThreadDump(ThreadDumpRequest) - Method in class io.deephaven.proto.pqworker.grpc.PQWorkerApiGrpc.PQWorkerApiBlockingStub
request that the worker writes a thread dump to the log, can be useful for debugging queries that are seemingly hung
requestThreadDump(ThreadDumpRequest) - Method in class io.deephaven.proto.pqworker.grpc.PQWorkerApiGrpc.PQWorkerApiFutureStub
request that the worker writes a thread dump to the log, can be useful for debugging queries that are seemingly hung
requestThreadDump(ThreadDumpRequest, StreamObserver<ThreadDumpResponse>) - Method in class io.deephaven.enterprise.dnd.service.pqworker.PQWorkerServiceGrpcImpl
 
requestThreadDump(ThreadDumpRequest, StreamObserver<ThreadDumpResponse>) - Method in interface io.deephaven.proto.pqworker.grpc.PQWorkerApiGrpc.AsyncService
request that the worker writes a thread dump to the log, can be useful for debugging queries that are seemingly hung
requestThreadDump(ThreadDumpRequest, StreamObserver<ThreadDumpResponse>) - Method in class io.deephaven.proto.pqworker.grpc.PQWorkerApiGrpc.PQWorkerApiStub
request that the worker writes a thread dump to the log, can be useful for debugging queries that are seemingly hung
requireAclsToExport() - Static method in class io.deephaven.enterprise.acl.impl.AclHelper
If any ACLs have been applied, then any exported table must have ACLs applied.
resetForUnitTests(boolean) - Method in class io.deephaven.enterprise.test.CapturingUpdateGraph
 
resolve(SessionState, ByteBuffer, String) - Method in class io.deephaven.enterprise.dnd.service.ticket.DatabaseTicketResolver
 
resolve(SessionState, Flight.FlightDescriptor, String) - Method in class io.deephaven.enterprise.dnd.service.ticket.DatabaseTicketResolver
 
resolve(URI) - Method in class io.deephaven.enterprise.dnd.uri.PQUriResolver
 
resolveClassDescriptorOverride(ObjectStreamClass) - Method in class io.deephaven.enterprise.compatibility.shadow.ShadowingObjectInputStream
 
resolveClassDescriptorOverride(ObjectStreamClass) - Method in class io.deephaven.enterprise.compatibility.shadow.ShadowingPersistentInputStream
 
RESPONSE_NOT_SET - Enum constant in enum class io.deephaven.proto.pivot.PivotPluginResponse.ResponseCase
 
restartQueries(List<PersistentQueryConfigMessage>) - Method in interface io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClient
Restarts one or more persistent queries.
restartQueriesBySerial(long[]) - Method in interface io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClient
Restarts one or more persistent queries.
restartQueriesBySerial(List<Long>) - Method in interface io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClient
Restarts one or more persistent queries.
restartQueriesBySerial(List<Long>) - Method in class io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClientImpl
 
restartQuery(PersistentQueryConfigMessage) - Method in interface io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClient
Restart a persistent query.
restartReplicas(List<ReplicaSpecifier>) - Method in interface io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClient
Restart one or more query replicas and/or spares.
restartReplicas(List<ReplicaSpecifier>) - Method in class io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClientImpl
 
restrictSortTo(String...) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
resumeFrom(UnaryOperator<String>) - Method in class io.deephaven.enterprise.kafkawriter.KafkaTableWriter.Options
Optional function that determines a prior column partition to read a size record from.
retryWindowMillis() - Method in interface io.deephaven.enterprise.remote.SubscriptionOptions
The width of the window in milliseconds in which to attempt to reconnect.
retryWindowMillis(long) - Method in interface io.deephaven.enterprise.remote.SubscriptionOptions.Builder
Set the width of the window in milliseconds in which to attempt to reconnect.
reverse() - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
ReversibleCache - Class in io.deephaven.enterprise.sources.regioned.impl
An ArrayBackedOffsetLookupCache that allows for forward and backwards lookups of values.
ReversibleCache(OffsetLookup<String, ChunkSource.FillContext>, FillContextMaker) - Constructor for class io.deephaven.enterprise.sources.regioned.impl.ReversibleCache
 
rget(int, String) - Method in class io.deephaven.enterprise.sources.regioned.impl.ReversibleCache
 
rollup(ComboAggregateFactory, boolean, SelectColumn...) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
ROW_GROUP_SIZES_COLUMN_NAME - Static variable in class io.deephaven.enterprise.locations.hive.HiveLocationsTableKeyFinder
The column name sizes of each row group in parquet format.
ROW_KEY_TABLE_ACTION_COLUMN_FIELD_NUMBER - Static variable in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage
 
ROW_KEY_TABLE_OFFSET_FIELD_NUMBER - Static variable in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage
 
ROW_KEYS_FIELD_NUMBER - Static variable in class io.deephaven.proto.pivot.PivotTableCreationRequest
 
ROW_SORTS_FIELD_NUMBER - Static variable in class io.deephaven.proto.pivot.PivotTableApplyRequest
 
rowAcl(String, AclFilterGenerator) - Method in interface io.deephaven.enterprise.acl.EdgeAclProvider.Builder
Add a Row ACL for the specified group to the table.
rowsDefinition() - Method in interface io.deephaven.pivot.PivotTable.PivotSnapshot
Get the definition for the row chunks in this snapshot.
RowSequenceToOrderedKeysAdapter - Class in io.deephaven.enterprise.compatibility.rowset
A Mutable adapter for converting RowSequence into an OrderedKeys.
RowSequenceToOrderedKeysAdapter() - Constructor for class io.deephaven.enterprise.compatibility.rowset.RowSequenceToOrderedKeysAdapter
 
RowSequenceToOrderedKeysAdapter(RowSequence) - Constructor for class io.deephaven.enterprise.compatibility.rowset.RowSequenceToOrderedKeysAdapter
 
RowSequenceToOrderedKeysIteratorAdapter - Class in io.deephaven.enterprise.compatibility.rowset
Given a Core RowSet.Iterator present it as a Legacy OrderedKeys.Iterator.
RowSequenceToOrderedKeysIteratorAdapter(RowSequence.Iterator) - Constructor for class io.deephaven.enterprise.compatibility.rowset.RowSequenceToOrderedKeysIteratorAdapter
 
RowSetCompatibility - Class in io.deephaven.enterprise.compatibility.rowset
 
RowSetCompatibility() - Constructor for class io.deephaven.enterprise.compatibility.rowset.RowSetCompatibility
 
rowsSize() - Method in class io.deephaven.enterprise.pivot.flatbuf.PivotUpdateMetadata
The current number of rows in the table, with the applied expansions.
rowsSnapshot() - Method in interface io.deephaven.pivot.PivotTable.PivotSnapshot
 
run() - Method in class io.deephaven.enterprise.compatibility.NotificationAdapter
 
run() - Method in class io.deephaven.enterprise.lastbystate.CoreLastByTableImportState.ResultPartitionedTable
 
run() - Method in class io.deephaven.enterprise.remote.ConnectionAwareRemoteTable
 
run(Database, String, String, String, String) - Method in class io.deephaven.enterprise.database.inputtables.InputTableConverter
Converts the specified Legacy input table into a copied Core+ input table.
runAll(Database) - Method in interface io.deephaven.enterprise.database.inputtables.InputTableTool
Execute Core+ input table tool against all user tables.
runByNamespace(Database, String...) - Method in interface io.deephaven.enterprise.database.inputtables.InputTableTool
Execute Core+ input table tool by specifying namespaces.
runByTableName(Database, String, String...) - Method in interface io.deephaven.enterprise.database.inputtables.InputTableTool
Execute Core+ input table tool by specifying namespace and table names.
runDhcServer(Configuration, PrintStream, PrintStream, UserContext, int, DispatcherClient, Client, Future<Boolean>, AuditEventLogger, WorkerDetails, CreationJsonParser, String, Logger, File, ProcessInfo) - Static method in class io.deephaven.enterprise.dnd.Main
 
runDispatcherClient(PrintStream, PrintStream, String, Future<Client>) - Static method in class io.deephaven.enterprise.dnd.Main
 
runWithinUnitTestCycle(ThrowingRunnable<T>) - Method in class io.deephaven.enterprise.test.CapturingUpdateGraph
 
runWithinUnitTestCycle(ThrowingRunnable<T>, boolean) - Method in class io.deephaven.enterprise.test.CapturingUpdateGraph
 

S

satisfied(long) - Method in class io.deephaven.enterprise.test.CapturingUpdateGraph
 
SchemaHelper - Class in io.deephaven.enterprise.kafkawriter
The SchemaHelper assists query-builders with creating and validating Deephaven Enterprise schemas from a Core+ KafkaTableWriter.Options instance.
SchemaHelper(KafkaTableWriter.Options) - Constructor for class io.deephaven.enterprise.kafkawriter.SchemaHelper
Instantiate a SchemaHelper instance.
SchemaHelper(KafkaTableWriter.Options, String) - Constructor for class io.deephaven.enterprise.kafkawriter.SchemaHelper
Instantiate a SchemaHelper instance.
SchemaHelper(KafkaTableWriter.Options, String, int) - Constructor for class io.deephaven.enterprise.kafkawriter.SchemaHelper
Instantiate a SchemaHelper instance.
SchemaNotFoundException - Exception in io.deephaven.enterprise.database
Indicates that a requested schema was not found / does not exist.
SchemaNotFoundException(String, String, String) - Constructor for exception io.deephaven.enterprise.database.SchemaNotFoundException
 
schemes() - Method in class io.deephaven.enterprise.dnd.uri.PQUriResolver
 
scopeTable(String) - Static method in class io.deephaven.enterprise.dnd.client.DndSession
Create a TableSpec based on a table from the server query scope.
ScriptSessionWrapper(ScriptSession, ControllerClientClassLoader) - Constructor for class io.deephaven.enterprise.dnd.modules.GroovyConsoleSessionWithDatabaseModule.ScriptSessionWrapper
 
scriptType() - Method in class io.deephaven.enterprise.dnd.modules.GroovyConsoleSessionWithDatabaseModule.ScriptSessionWrapper
 
SecretsProvider - Interface in io.deephaven.enterprise.secrets
Implementations provide access to secrets.
SecretsProvider.Factory - Interface in io.deephaven.enterprise.secrets
Implementations create instances of SecretsProviders.
SecretsService - Class in io.deephaven.enterprise.secrets
The service for loading SecretsProviders to be used with various authentication methods.
select(SelectColumn...) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
selectDistinct(SelectColumn...) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
sequenceColumn(String) - Method in class io.deephaven.enterprise.derivedtablewriter.DerivedTableWriter.Options
Specify a column in the source table that contains a sequence number.
serialize(IcebergS3Instructions, JsonGenerator, SerializerProvider) - Method in class io.deephaven.enterprise.iceberg.IcebergS3Instructions.Serializer
 
Serializer() - Constructor for class io.deephaven.enterprise.iceberg.IcebergS3Instructions.Serializer
 
serializeWithType(IcebergS3Instructions, JsonGenerator, SerializerProvider, TypeSerializer) - Method in class io.deephaven.enterprise.iceberg.IcebergS3Instructions.Serializer
 
serialTableOperationsSafe() - Method in class io.deephaven.enterprise.test.CapturingUpdateGraph
 
serverStateLogLogger() - Method in class io.deephaven.enterprise.dnd.logger.engine.impl.EngineTableLoggersFactoryDndImpl
 
SERVICE_NAME - Static variable in class io.deephaven.proto.pqworker.grpc.PQWorkerApiGrpc
 
session() - Method in class io.deephaven.enterprise.dnd.client.DndSession
Get the underlying SessionImpl
sessionFactory() - Method in interface io.deephaven.enterprise.remote.ConnectionAwareRemoteTableParams
The SessionFactory for creating BarrageSessions to subscribe to tables.
sessionFactory(RemoteTableSessionFactory) - Method in interface io.deephaven.enterprise.remote.ConnectionAwareRemoteTableParams.Builder
Set the function to produce a BarrageSession from a hostname and port.
sessionImpl - Variable in class io.deephaven.enterprise.dnd.client.DndSession
 
SessionServiceAuthWiringImpl - Class in io.deephaven.enterprise.dnd.authentication
This auth wiring explicitly denies the newSession and refreshSession calls as they are deprecated on the upstream
SessionServiceAuthWiringImpl() - Constructor for class io.deephaven.enterprise.dnd.authentication.SessionServiceAuthWiringImpl
 
sessionTimeoutMillis(Long) - Method in interface io.deephaven.enterprise.dnd.EnterpriseJettyComponent.Builder
How long is the session timeout grace period.
setAclsApplied() - Static method in class io.deephaven.enterprise.acl.impl.AclHelper
Note that ACLs have been applied and our return policy has changed.
setAdminGroups(Set<String>) - Static method in class io.deephaven.enterprise.dnd.authentication.DheAuthenticationHandler
 
setAggregations(int, Aggregation) - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
aggregations for the values
setAggregations(int, Aggregation.Builder) - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
aggregations for the values
setApply(PivotTableApplyRequest) - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
.io.deephaven.proto.pivot.PivotTableApplyRequest apply = 6;
setApply(PivotTableApplyRequest.Builder) - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
.io.deephaven.proto.pivot.PivotTableApplyRequest apply = 6;
setApply(PivotTableApplyResponse) - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
.io.deephaven.proto.pivot.PivotTableApplyResponse apply = 7;
setApply(PivotTableApplyResponse.Builder) - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
.io.deephaven.proto.pivot.PivotTableApplyResponse apply = 7;
setAttribute(String, Object) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
setAuthClient(AuthenticationClient) - Static method in class io.deephaven.enterprise.dnd.authentication.DheAuthenticationHandler
 
setAutomatedFilter(boolean) - Method in class io.deephaven.enterprise.compatibility.filter.EnterpriseFilterAdapter
 
setCatalog(DatabaseCatalog) - Method in class io.deephaven.enterprise.database.impl.DatabaseImpl
 
setClassFinderLogic() - Static method in class io.deephaven.enterprise.compatibility.shadow.ShadowCompatibility
Injects logic into DHE ClassFinder to remap to fully qualified shadow class names.
setColumnKeys(int, String) - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
first reference is the input table
setColumnKeyTableActionColumn(String) - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage.Builder
The name of a column of bytes found in the key table that specifies the action desired for the node selected by the other columns for each row.
setColumnKeyTableActionColumnBytes(ByteString) - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage.Builder
The name of a column of bytes found in the key table that specifies the action desired for the node selected by the other columns for each row.
setColumnKeyTableOffset(int) - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage.Builder
Offset (in the references) of a Table of expanded or contracted keys from a PivotTable (RollupTable or TreeTable).
setColumnRenderers(ColumnRenderersBuilder) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
setColumnSorts(int, SortDescriptor) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor column_sorts = 2;
setColumnSorts(int, SortDescriptor.Builder) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor column_sorts = 2;
setCreation(PivotTableCreationRequest) - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
.io.deephaven.proto.pivot.PivotTableCreationRequest creation = 5;
setCreation(PivotTableCreationRequest.Builder) - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
.io.deephaven.proto.pivot.PivotTableCreationRequest creation = 5;
setCreation(PivotTableCreationResponse) - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
.io.deephaven.proto.pivot.PivotTableCreationResponse creation = 6;
setCreation(PivotTableCreationResponse.Builder) - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
.io.deephaven.proto.pivot.PivotTableCreationResponse creation = 6;
setDatabaseWrapper(Database) - Static method in class io.deephaven.enterprise.acl.impl.AclHelper
Set the Enterprise Database to use for integrating with Enterprise classes
setDelegate(RowSequence) - Method in class io.deephaven.enterprise.compatibility.rowset.RowSequenceToOrderedKeysAdapter
 
setDelegate(OrderedKeys) - Method in class io.deephaven.enterprise.compatibility.rowset.OrderedKeysToRowSequenceAdapter
 
setDndClassLoader(File, Database, String, ControllerClientFactory) - Static method in class io.deephaven.enterprise.dnd.classloader.DndGroovyClassLoader
Set custom DnD class loader to retrieve Groovy scripts on imports over the network from DHE workspace data and controller script loader.
setEmptyExpansions(PivotTableEmptyExpansionsRequest) - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
.io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest empty_expansions = 4;
setEmptyExpansions(PivotTableEmptyExpansionsRequest.Builder) - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
.io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest empty_expansions = 4;
setEmptyExpansions(PivotTableEmptyExpansionsResponse) - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
.io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse empty_expansions = 5;
setEmptyExpansions(PivotTableEmptyExpansionsResponse.Builder) - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
.io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse empty_expansions = 5;
setEphemeral() - Method in interface io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClient
Make this client ephemeral.
setEphemeral() - Method in class io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClientImpl
 
setError(ErrorResponse) - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
If the request failed (after we were able to parse and extract the request ID), then we return an error to the client; otherwise we return the appropriate response type.
setError(ErrorResponse.Builder) - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
If the request failed (after we were able to parse and extract the request ID), then we return an error to the client; otherwise we return the appropriate response type.
setErrorMessage(String) - Method in class io.deephaven.proto.pivot.ErrorResponse.Builder
string error_message = 1;
setErrorMessageBytes(ByteString) - Method in class io.deephaven.proto.pivot.ErrorResponse.Builder
string error_message = 1;
setExistingViewOffset(int) - Method in class io.deephaven.proto.pivot.PivotTableViewRequest.Builder
Offset of the existing PivotTableView in the incoming plugin references array.
setExpansions(PivotTableViewExpansionsMessage) - Method in class io.deephaven.proto.pivot.PivotTableViewRequest.Builder
Description for the expansions that define this view of the PivotTable.
setExpansions(PivotTableViewExpansionsMessage.Builder) - Method in class io.deephaven.proto.pivot.PivotTableViewRequest.Builder
Description for the expansions that define this view of the PivotTable.
setExport(PivotTableSourceExportResponse) - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
.io.deephaven.proto.pivot.PivotTableSourceExportResponse export = 4;
setExport(PivotTableSourceExportResponse.Builder) - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
.io.deephaven.proto.pivot.PivotTableSourceExportResponse export = 4;
setExportSource(PivotTableSourceExportRequest) - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
.io.deephaven.proto.pivot.PivotTableSourceExportRequest export_source = 3;
setExportSource(PivotTableSourceExportRequest.Builder) - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
.io.deephaven.proto.pivot.PivotTableSourceExportRequest export_source = 3;
setField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.pivot.ErrorResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.pivot.PivotTableApplyResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.pivot.PivotTableCreationResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.pivot.PivotTableDescriptorRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.pivot.PivotTableSourceExportRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.pivot.PivotTableSourceExportResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.pivot.PivotTableViewRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.pivot.PivotTableViewResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.pqworker.ListenErrorRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.pqworker.ListenErrorResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.pqworker.ObjectAccessRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.pqworker.ObjectAccessResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.pqworker.StringList.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.pqworker.ThreadDumpRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class io.deephaven.proto.pqworker.ThreadDumpResponse.Builder
 
setFilters(int, Condition) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
The filters must be against the grouping columns (either row or columns)
setFilters(int, Condition.Builder) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
The filters must be against the grouping columns (either row or columns)
setGetDescriptor(PivotTableDescriptorRequest) - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
.io.deephaven.proto.pivot.PivotTableDescriptorRequest get_descriptor = 7;
setGetDescriptor(PivotTableDescriptorRequest.Builder) - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
.io.deephaven.proto.pivot.PivotTableDescriptorRequest get_descriptor = 7;
setGetDescriptor(PivotTableDescriptorResponse) - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
.io.deephaven.proto.pivot.PivotTableDescriptorResponse get_descriptor = 8;
setGetDescriptor(PivotTableDescriptorResponse.Builder) - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
.io.deephaven.proto.pivot.PivotTableDescriptorResponse get_descriptor = 8;
setGroupingProvider(GroupingProvider) - Method in class io.deephaven.enterprise.compatibility.filter.ColumnSourceAdapterForFilter
 
setGroupProvider(GroupProvider) - Static method in class io.deephaven.enterprise.dnd.authentication.DheAuthenticationHandler
 
setInstance(SimpleAuditEventLogger) - Static method in class io.deephaven.enterprise.dnd.SimpleAuditEventLogger
Set an instance of the SimpleAuditEventLogger.
setIsRefreshing(boolean) - Method in class io.deephaven.enterprise.compatibility.filter.RecomputeListenerAdapter
 
setIsStatic(boolean) - Method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage.Builder
Whether or not this table might change.
setLocalClusterDetails(CorePlusClusterSessionFactory) - Static method in class io.deephaven.enterprise.remote.RemoteTableBuilder
Set the CorePlusClusterSessionFactory details for the current cluster.
setMaxInboundMessageSize(int) - Method in class io.deephaven.enterprise.dnd.client.DeephavenClusterConnection
Set the maximum inbound message size for connections created by this object.
setMaxInboundMessageSize(int) - Method in class io.deephaven.enterprise.dnd.client.DndSessionFactoryBarrage
 
setMessage(String) - Method in class io.deephaven.proto.pqworker.ListenErrorResponse.Builder
string message = 1;
setMessageBytes(ByteString) - Method in class io.deephaven.proto.pqworker.ListenErrorResponse.Builder
string message = 1;
setObjectNames(int, String) - Method in class io.deephaven.proto.pqworker.ObjectAccessRequest.Builder
repeated string objectNames = 1;
setObserver(RemoteTableStateWatcher.Observer) - Method in class io.deephaven.enterprise.remote.ControllerStateWatcher
 
setObserver(RemoteTableStateWatcher.Observer) - Method in interface io.deephaven.enterprise.remote.RemoteTableStateWatcher
Set the RemoteTableStateWatcher.Observer to notify of state changes.
setOutputColumns(int, String) - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage.Builder
The name of the output columns that are sent, if not specified then all totals and value columns are sent.
setOwnerCredentials(UserContext) - Static method in class io.deephaven.enterprise.dnd.authentication.DheAuthenticationHandler
 
setPermissionFilterProvider(PermissionFilterProvider) - Static method in class io.deephaven.enterprise.acl.impl.AclHelper
Set the Enterprise PermissionFilterProvider to be used when calling enterprse acl code
setPivotDescriptor(PivotTableDescriptorMessage) - Method in class io.deephaven.proto.pivot.PivotTableApplyResponse.Builder
first reference is the new pivot table
setPivotDescriptor(PivotTableDescriptorMessage) - Method in class io.deephaven.proto.pivot.PivotTableCreationResponse.Builder
first reference is the created pivot table
setPivotDescriptor(PivotTableDescriptorMessage) - Method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse.Builder
The description of the table
setPivotDescriptor(PivotTableDescriptorMessage) - Method in class io.deephaven.proto.pivot.PivotTableViewResponse.Builder
The description of the table
setPivotDescriptor(PivotTableDescriptorMessage.Builder) - Method in class io.deephaven.proto.pivot.PivotTableApplyResponse.Builder
first reference is the new pivot table
setPivotDescriptor(PivotTableDescriptorMessage.Builder) - Method in class io.deephaven.proto.pivot.PivotTableCreationResponse.Builder
first reference is the created pivot table
setPivotDescriptor(PivotTableDescriptorMessage.Builder) - Method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse.Builder
The description of the table
setPivotDescriptor(PivotTableDescriptorMessage.Builder) - Method in class io.deephaven.proto.pivot.PivotTableViewResponse.Builder
The description of the table
setPivotTableOffset(int) - Method in class io.deephaven.proto.pivot.PivotTableViewRequest.Builder
Offset of the pivot table in the incoming plugin references.
setProcessInfoId(String) - Static method in class io.deephaven.enterprise.dnd.authentication.DheAuthenticationHandler
 
setReason(String) - Method in class io.deephaven.proto.pqworker.ThreadDumpRequest.Builder
optional string reason = 1;
setReasonBytes(ByteString) - Method in class io.deephaven.proto.pqworker.ThreadDumpRequest.Builder
optional string reason = 1;
setRecomputeListener(WhereFilter.RecomputeListener) - Method in class io.deephaven.enterprise.compatibility.filter.EnterpriseFilterAdapter
 
setRecordBatchLength(BarrageMessageWriterImpl.RecordBatchMessageView, FlatBufferBuilder, int) - Method in class io.deephaven.pivot.PivotBarrageMessageWriterImpl
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.deephaven.proto.pivot.ErrorResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.deephaven.proto.pivot.PivotTableApplyResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.deephaven.proto.pivot.PivotTableCreationResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.deephaven.proto.pivot.PivotTableDescriptorRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.deephaven.proto.pivot.PivotTableSourceExportRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.deephaven.proto.pivot.PivotTableSourceExportResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.deephaven.proto.pivot.PivotTableViewRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.deephaven.proto.pivot.PivotTableViewResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.deephaven.proto.pqworker.ListenErrorRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.deephaven.proto.pqworker.ListenErrorResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.deephaven.proto.pqworker.ObjectAccessRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.deephaven.proto.pqworker.ObjectAccessResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.deephaven.proto.pqworker.StringList.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.deephaven.proto.pqworker.ThreadDumpRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class io.deephaven.proto.pqworker.ThreadDumpResponse.Builder
 
setRequestId(String) - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
A client-specified identifier used to identify the response for this request when multiple requests are in flight.
setRequestId(String) - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
Identifier copied from the request.
setRequestIdBytes(ByteString) - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
A client-specified identifier used to identify the response for this request when multiple requests are in flight.
setRequestIdBytes(ByteString) - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
Identifier copied from the request.
setRowKeys(int, String) - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
repeated string row_keys = 2;
setRowKeyTableActionColumn(String) - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage.Builder
The name of a column of bytes found in the key table that specifies the action desired for the node selected by the other columns for each row.
setRowKeyTableActionColumnBytes(ByteString) - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage.Builder
The name of a column of bytes found in the key table that specifies the action desired for the node selected by the other columns for each row.
setRowKeyTableOffset(int) - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage.Builder
Offset (in the references) of a Table of expanded or contracted keys from a PivotTable (RollupTable or TreeTable).
setRowSorts(int, SortDescriptor) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor row_sorts = 1;
setRowSorts(int, SortDescriptor.Builder) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
repeated .io.deephaven.proto.backplane.grpc.SortDescriptor row_sorts = 1;
setSchemaService(SchemaService) - Static method in class io.deephaven.enterprise.lastbystate.CoreLastByTableImportState
Set the schema service to use when creating a new state for use in unit tests.
setSerialTableOperationsSafe(boolean) - Method in class io.deephaven.enterprise.test.CapturingUpdateGraph
 
setServerUrl(String) - Static method in class io.deephaven.enterprise.config.HttpUrlPropertyInputStreamLoader
 
setShortCauses(String) - Method in class io.deephaven.proto.pqworker.ListenErrorResponse.Builder
string shortCauses = 3;
setShortCausesBytes(ByteString) - Method in class io.deephaven.proto.pqworker.ListenErrorResponse.Builder
string shortCauses = 3;
setSimpleProcessEventLogger(SimpleProcessEventLogger) - Static method in class io.deephaven.enterprise.dnd.ProcessEventLogAppender
 
setSnapshot(TableLocationMetadataIndex.LocationSnapshot) - Method in class io.deephaven.enterprise.locations.local.deephaven.OnDiskDeephavenTableLocation
Set the location snapshot data from the metadata index.
setSnapshotSchema(ByteString) - Method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage.Builder
Schema to be used for snapshot or subscription requests as described in Arrow Message.fbs::Message.
setSpeedFactor(double) - Method in class io.deephaven.enterprise.replay.DeltaClockWithAdjustableSpeed
 
setStackTrace(String) - Method in class io.deephaven.proto.pqworker.ListenErrorResponse.Builder
string stackTrace = 2;
setStackTraceBytes(ByteString) - Method in class io.deephaven.proto.pqworker.ListenErrorResponse.Builder
string stackTrace = 2;
setSubscriberName(String) - Method in class io.deephaven.proto.pqworker.ListenErrorRequest.Builder
string subscriberName = 1;
setSubscriberNameBytes(ByteString) - Method in class io.deephaven.proto.pqworker.ListenErrorRequest.Builder
string subscriberName = 1;
setTimestampMillis(long) - Method in class io.deephaven.proto.pqworker.ListenErrorResponse.Builder
int64 timestampMillis = 6;
setTotalsTable(TotalsTableBuilder) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
setUnknownFields(UnknownFieldSet) - Method in class io.deephaven.proto.pivot.ErrorResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class io.deephaven.proto.pivot.PivotTableApplyResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class io.deephaven.proto.pivot.PivotTableCreationResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class io.deephaven.proto.pivot.PivotTableDescriptorRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class io.deephaven.proto.pivot.PivotTableSourceExportRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class io.deephaven.proto.pivot.PivotTableSourceExportResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class io.deephaven.proto.pivot.PivotTableViewRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class io.deephaven.proto.pivot.PivotTableViewResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class io.deephaven.proto.pqworker.ListenErrorRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class io.deephaven.proto.pqworker.ListenErrorResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class io.deephaven.proto.pqworker.ObjectAccessRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class io.deephaven.proto.pqworker.ObjectAccessResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class io.deephaven.proto.pqworker.StringList.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class io.deephaven.proto.pqworker.ThreadDumpRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class io.deephaven.proto.pqworker.ThreadDumpResponse.Builder
 
setUpdateGraph(UpdateGraph) - Method in class io.deephaven.enterprise.lastbystate.CoreLastByTableImportState
Set the update graph to use for this state.
setValues(int, String) - Method in class io.deephaven.proto.pqworker.StringList.Builder
repeated string values = 1;
setView(PivotTableViewRequest) - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
.io.deephaven.proto.pivot.PivotTableViewRequest view = 2;
setView(PivotTableViewRequest.Builder) - Method in class io.deephaven.proto.pivot.PivotPluginRequest.Builder
.io.deephaven.proto.pivot.PivotTableViewRequest view = 2;
setView(PivotTableViewResponse) - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
.io.deephaven.proto.pivot.PivotTableViewResponse view = 3;
setView(PivotTableViewResponse.Builder) - Method in class io.deephaven.proto.pivot.PivotPluginResponse.Builder
.io.deephaven.proto.pivot.PivotTableViewResponse view = 3;
setViewerGroups(Set<String>) - Static method in class io.deephaven.enterprise.dnd.authentication.DheAuthenticationHandler
 
setViewport(RowSet, RowSet, boolean) - Method in class io.deephaven.pivot.PivotTableViewSubscription
 
setWasUncaught(boolean) - Method in class io.deephaven.proto.pqworker.ListenErrorResponse.Builder
bool wasUncaught = 4;
setWriterCheckpointRecord(MutableObject<CheckpointRecord.SourceFileSizeRecord>, Supplier<CheckpointRecord.SourceFileSizeRecord>) - Method in class io.deephaven.enterprise.ingester.impl.TableWriterContext
Set the checkpoint record to our tableWriterStreamConsumer, done outside the constructor so that we can read it in first.
SHADOW_PREFIX - Static variable in class io.deephaven.enterprise.compatibility.shadow.ShadowCompatibility
 
ShadowCompatibility - Class in io.deephaven.enterprise.compatibility.shadow
This class contains static methods and fields that help in converting serialized non-shadowed enterprise types into their shadowed packages before they're classloaded
ShadowCompatibility() - Constructor for class io.deephaven.enterprise.compatibility.shadow.ShadowCompatibility
 
ShadowingObjectInputStream - Class in io.deephaven.enterprise.compatibility.shadow
Enterprise makes extensive use of Java serialization through WObjectOutput/InputStream.
ShadowingObjectInputStream(InputStream) - Constructor for class io.deephaven.enterprise.compatibility.shadow.ShadowingObjectInputStream
 
ShadowingPersistentInputStream - Class in io.deephaven.enterprise.compatibility.shadow
Enterprise makes extensive use of Java serialization through WObjectOutput/InputStream.
ShadowingPersistentInputStream(InputStream, ClassLoader) - Constructor for class io.deephaven.enterprise.compatibility.shadow.ShadowingPersistentInputStream
 
ShadowingSerializableDecoder<T> - Class in io.deephaven.enterprise.compatibility.shadow
An ObjectCodec implementation for Serializable object that internally uses a ShadowingObjectInputStream to automatically replace detected shadowed classes in the object stream with their shadowed versions.
ShadowingSerializableDecoder(String) - Constructor for class io.deephaven.enterprise.compatibility.shadow.ShadowingSerializableDecoder
 
sharedLock() - Method in class io.deephaven.enterprise.test.CapturingUpdateGraph
 
Short - Enum constant in enum class io.deephaven.enterprise.sources.regioned.BufferedType
 
SHORTCAUSES_FIELD_NUMBER - Static variable in class io.deephaven.proto.pqworker.ListenErrorResponse
 
ShortColumnRegionAdapter<ATTR extends Values> - Class in io.deephaven.enterprise.compatibility.region
Adapts a Legacy ColumnRegionShort to a Core ColumnRegionShort.
ShortColumnRegionAdapter(ColumnRegionShort<?>) - Constructor for class io.deephaven.enterprise.compatibility.region.ShortColumnRegionAdapter
 
shutdown() - Method in interface io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClient
Shut down the client.
shutdown() - Method in class io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClientImpl
 
SimpleAuditEventLogger - Class in io.deephaven.enterprise.dnd
 
SimpleAuditEventLogger(Map<String, Object>, UserContext) - Constructor for class io.deephaven.enterprise.dnd.SimpleAuditEventLogger
 
SimpleFilterGenerator - Class in io.deephaven.enterprise.acl.generator
An AclFilterGenerator that simply applies the specified WhereFilters in Disjunctive Normal Form
SimpleFilterGenerator(Collection<WhereFilter>...) - Constructor for class io.deephaven.enterprise.acl.generator.SimpleFilterGenerator
 
SimpleLocationSnapshot - Class in io.deephaven.enterprise.locations.hive
A simple immutable location snapshot.
SimpleProcessEventLogger - Class in io.deephaven.enterprise.dnd
 
SimpleProcessEventLogger(LogAggregatorServiceBinaryStoreWriterFactory, ProcessInfo) - Constructor for class io.deephaven.enterprise.dnd.SimpleProcessEventLogger
 
SimpleProcessEventLogger(String, ProcessInfo) - Constructor for class io.deephaven.enterprise.dnd.SimpleProcessEventLogger
 
size() - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
size() - Method in class io.deephaven.enterprise.compatibility.rowset.OrderedKeysToRowSequenceAdapter
 
size() - Method in class io.deephaven.enterprise.compatibility.rowset.RowSequenceToOrderedKeysAdapter
 
SIZE_COLUMN_NAME - Static variable in class io.deephaven.enterprise.locations.hive.HiveLocationsTableKeyFinder
The column of partition sizes, in rows.
slice(long, long) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
snapshot() - Method in class io.deephaven.enterprise.remote.RemoteTableBuilder
Create a static snapshot of the entire upstream Table.
snapshot(PivotTable.SnapshotState, Table, Table, ColumnName, ColumnName, Collection<ColumnName>, RowSequence, RowSequence) - Method in interface io.deephaven.pivot.PivotTable
Generate a snapshot of this PivotTable.
snapshot(Set<String>) - Method in class io.deephaven.enterprise.remote.RemoteTableBuilder
Create a static snapshot of the upstream Table including only the specified columns.
snapshot(BarrageSnapshotRequest, BarrageSnapshotOptions, Object, BarragePerformanceLog.SnapshotMetricsHelper, StreamObserver<BarrageMessageWriter.MessageView>, String, BarrageMessageWriter.Factory) - Method in class io.deephaven.pivot.PivotTableViewExchangeMarshaller
 
snapshot(Table, boolean, String...) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
snapshot(String...) - Method in class io.deephaven.enterprise.remote.RemoteTableBuilder
Create a static snapshot of the upstream Table including only the specified columns.
SNAPSHOT_SCHEMA_FIELD_NUMBER - Static variable in class io.deephaven.proto.pivot.PivotTableDescriptorMessage
 
SnapshotBackedTableLocation<LOCATION_TYPE extends AbstractTableLocation> - Class in io.deephaven.enterprise.locations.local
A TableLocation backed by a TableLocationMetadataIndex.TableLocationSnapshot that does not refresh and tries to avoid creating the actual location until it is truly needed.
SnapshotBackedTableLocation(TableKey, TableLocationKey, TableLocationMetadataIndex.LocationSnapshot, Supplier<LOCATION_TYPE>) - Constructor for class io.deephaven.enterprise.locations.local.SnapshotBackedTableLocation
 
SnapshotException - Exception in io.deephaven.enterprise.dnd.client.exception
An Exception thrown when there is a problem completing a Snapshot
SnapshotException(String, Throwable) - Constructor for exception io.deephaven.enterprise.dnd.client.exception.SnapshotException
 
snapshotHistory(Table) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
snapshotId() - Method in interface io.deephaven.enterprise.iceberg.discovery.DiscoveryConfig
The Snapshot ID to use when discovering the table from the catalog.
snapshotId(long) - Method in interface io.deephaven.enterprise.iceberg.discovery.DiscoveryConfig.Builder
Set the snapshot id to use for fetching the Iceberg table.
snapshotIncremental(Table, boolean, String...) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
snapshotOf(TableSpec) - Method in class io.deephaven.enterprise.dnd.client.DndSessionBarrage
Fetch a snapshot of the table from the server.
SnapshotProvidingLocationKey - Interface in io.deephaven.enterprise.locations
An EnterpriseTableLocationKey implementation which is backed by a TableLocationMetadataIndex.LocationSnapshot instance
sort(SortPair...) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
SourceAclProvider - Interface in io.deephaven.enterprise.acl
A provider object for creating row and column ACLs from the data source.
splitAndLinearizeAndFilters(Filter) - Static method in class io.deephaven.enterprise.acl.impl.AclHelper
If a filter is a conjunction of filters (an "and" of filters), decompose it in a list of element filters.
SSLConfigModule - Interface in io.deephaven.enterprise.dnd.modules
 
STACKTRACE_FIELD_NUMBER - Static variable in class io.deephaven.proto.pqworker.ListenErrorResponse
 
STANDALONE - Static variable in interface io.deephaven.enterprise.locations.EnterpriseTableKey
 
STANDALONE_PARTITIONS - Static variable in class io.deephaven.enterprise.table.EnterpriseTableTools
 
start() - Method in class io.deephaven.enterprise.dnd.ProcessEventLogAppender
 
startEffectiveColumnViewportVector(FlatBufferBuilder, int) - Static method in class io.deephaven.enterprise.pivot.flatbuf.PivotUpdateMetadata
 
startEffectiveRowViewportVector(FlatBufferBuilder, int) - Static method in class io.deephaven.enterprise.pivot.flatbuf.PivotUpdateMetadata
 
startPivotUpdateMetadata(FlatBufferBuilder) - Static method in class io.deephaven.enterprise.pivot.flatbuf.PivotUpdateMetadata
 
startRefreshing() - Method in class io.deephaven.enterprise.lastbystate.CoreLastByTableImportState
 
stateWatcher() - Method in interface io.deephaven.enterprise.remote.ConnectionAwareRemoteTableParams
The RemoteTableStateWatcher so the ConnectionAwareRemoteTable can monitor the state of the destination.
stateWatcher(RemoteTableStateWatcher) - Method in interface io.deephaven.enterprise.remote.ConnectionAwareRemoteTableParams.Builder
Set the RemoteTableStateWatcher so the ConnectionAwareRemoteTable can monitor the state of the destination.
stdBy(SelectColumn...) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
stop() - Method in class io.deephaven.enterprise.test.CapturingUpdateGraph
 
stopQueries(List<PersistentQueryConfigMessage>) - Method in interface io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClient
Stops one or more persistent queries.
stopQueriesBySerial(long[]) - Method in interface io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClient
Stops one or more persistent query by serial id.
stopQueriesBySerial(List<Long>) - Method in interface io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClient
Stop the specified queries by serial.
stopQueriesBySerial(List<Long>) - Method in class io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClientImpl
 
stopQuery(PersistentQueryConfigMessage) - Method in interface io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClient
Stops a persistent query.
stopRefreshing() - Method in class io.deephaven.enterprise.lastbystate.CoreLastByTableImportState
 
StringList - Class in io.deephaven.proto.pqworker
Protobuf type io.deephaven.proto.pqworker.StringList
StringList.Builder - Class in io.deephaven.proto.pqworker
Protobuf type io.deephaven.proto.pqworker.StringList
StringListOrBuilder - Exception in io.deephaven.proto.pqworker
 
StringListOrBuilder - Interface in io.deephaven.proto.pqworker
 
stringLiteral(Node) - Static method in class io.deephaven.enterprise.dnd.autocomplete.DatabaseAutocompleteDelegate
 
subscribe() - Method in class io.deephaven.enterprise.remote.RemoteTableBuilder
Subscribe to the entire table using the default SubscriptionOptions.
subscribe(TableLocation.Listener) - Method in class io.deephaven.enterprise.locations.local.HybridSnapshotBackedTableLocation
 
subscribe(SubscriptionOptions) - Method in class io.deephaven.enterprise.remote.RemoteTableBuilder
Subscribe to the table using the specified SubscriptionOptions.
subscribe(BarrageSubscriptionRequest, BarrageSubscriptionOptions, Object, StreamObserver<BarrageMessageWriter.MessageView>) - Method in class io.deephaven.pivot.PivotTableViewExchangeMarshaller
 
SUBSCRIBERNAME_FIELD_NUMBER - Static variable in class io.deephaven.proto.pqworker.ListenErrorRequest
 
subscribeTo(TableSpec) - Method in class io.deephaven.enterprise.dnd.client.DndSessionBarrage
Fetch a fully subscribed table from the server.
subscribeToAll() - Method in interface io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClient
Subscribe for updates for all visible queries.
subscribeToAll() - Method in class io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClientImpl
 
SubscriptionException - Exception in io.deephaven.enterprise.dnd.client.exception
An Exception thrown when there is a problem completing a subscription
SubscriptionException(String, Throwable) - Constructor for exception io.deephaven.enterprise.dnd.client.exception.SubscriptionException
 
SubscriptionOptions - Interface in io.deephaven.enterprise.remote
Implementations of this interface provide parameters for a ConnectionAwareRemoteTable to maintain a subscription to a remote table.
SubscriptionOptions.Builder - Interface in io.deephaven.enterprise.remote
Implementations of this interface can be used to construct a new SubscriptionOptions.
sumBy(SelectColumn...) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
supportedTypes() - Method in class io.deephaven.enterprise.iceberg.IcebergExtendedStorageProvider.Factory
 
supportedTypes() - Method in interface io.deephaven.enterprise.tabledataservice.extended.ExtendedStorageProvider.Factory
Get the set of supported types for this factory.
supportedTypes() - Method in class io.deephaven.enterprise.tabledataservice.extended.HiveExtendedStorageProvider.Factory
 
supportedTypes() - Method in class io.deephaven.enterprise.tabledataservice.extended.ParquetExtendedStorageProvider.Factory
 
supportsDictionaryFormat(RowSet.SearchIterator) - Method in class io.deephaven.enterprise.sources.regioned.impl.ColumnRegionObjectCached
 
supportsDictionaryFormat(RowSet.SearchIterator) - Method in class io.deephaven.enterprise.sources.regioned.impl.ColumnRegionObjectWithDictionary
 
supportsRefreshing() - Method in class io.deephaven.enterprise.test.CapturingUpdateGraph
 
supportsSubscriptions() - Method in class io.deephaven.enterprise.locations.local.HybridSnapshotBackedTableLocation
 
sweepUnvisited(AbstractTableLocationProvider, long) - Method in class io.deephaven.enterprise.tabledataservice.TableLocationMarkSweepHelper
Remove all locations that have not been visited after a call to TableLocationMarkSweepHelper.getNextMark().
symbolFileExists() - Method in interface io.deephaven.enterprise.locations.DeephavenFormatColumnLocation
Check if the symbol table file exists.
symbolFileExists() - Method in class io.deephaven.enterprise.locations.local.deephaven.OnDiskDeephavenColumnLocation
 
SystemTableLogger - Class in io.deephaven.enterprise.database
Utility to log Table objects to System tables via the Log Aggregator Server.
SystemTableLogger() - Constructor for class io.deephaven.enterprise.database.SystemTableLogger
 
SystemTableLogger.Options - Class in io.deephaven.enterprise.database
Options for writing a system table using a logger.
SystemTableLogger.Options.Builder - Interface in io.deephaven.enterprise.database
 
SystemTableLoggerImpl - Class in io.deephaven.enterprise.database.impl
 
SystemTableLoggerImpl() - Constructor for class io.deephaven.enterprise.database.impl.SystemTableLoggerImpl
 
SystemTableMissingSchemaException - Exception in io.deephaven.enterprise.database
 
SystemTableMissingSchemaException(String, String) - Constructor for exception io.deephaven.enterprise.database.SystemTableMissingSchemaException
 

T

table() - Method in interface io.deephaven.enterprise.database.inputtables.InputTableUpdater
The input table view for this input table updater.
TABLE_NAME_PATH_INDEX - Static variable in class io.deephaven.enterprise.dnd.service.ticket.DatabaseTicketResolver
 
TableAdapterForFilters - Class in io.deephaven.enterprise.compatibility.filter
 
TableAdapterForFilters(Table) - Constructor for class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
TableDataServiceFactory - Class in io.deephaven.enterprise.tabledataservice
The standard factory for creating TableDataService instances using a DataRoutingService instance
TableDataServiceFactory(DataRoutingService, SchemaService, ProtocolDriverFactory) - Constructor for class io.deephaven.enterprise.tabledataservice.TableDataServiceFactory
 
tableDefinition() - Method in interface io.deephaven.enterprise.remote.ConnectionAwareRemoteTableParams
The prototype TableDefinition for the result table.
tableDefinition(TableDefinition) - Method in class io.deephaven.enterprise.remote.RemoteTableBuilder
Set the prototype TableDefinition of the table to fetch.
tableDefinition(TableDefinition) - Method in interface io.deephaven.enterprise.remote.ConnectionAwareRemoteTableParams.Builder
Set the prototype TableDefinition for the result table.
TableDefinitionCompatibility - Class in io.deephaven.enterprise.compatibility
A compatibility class for converting enterprise TableDefinition into community TableDefinition
tableIdentifier() - Method in interface io.deephaven.enterprise.iceberg.discovery.DiscoveryConfig
 
tableIdentifier(String) - Method in interface io.deephaven.enterprise.iceberg.discovery.DiscoveryConfig.Builder
Set the Iceberg table identifier for discovery.
TableKeyFilter - Interface in io.deephaven.enterprise.tabledataservice.filter
 
TableLocationMarkSweepHelper - Class in io.deephaven.enterprise.tabledataservice
An helper for TableLocationProvider implementations that can mark and sweep table locations based on if they have been visited in the current cycle.
TableLocationMarkSweepHelper() - Constructor for class io.deephaven.enterprise.tabledataservice.TableLocationMarkSweepHelper
 
TableLocationStateAdapter - Class in io.deephaven.enterprise.compatibility
This class adapts an enterprise TableLocationState into a Community formatted TableLocationState for use for Table data subscriptions
TableLocationStateAdapter(TableLocationState) - Constructor for class io.deephaven.enterprise.compatibility.TableLocationStateAdapter
 
TableLoggerException - Exception in io.deephaven.enterprise.database
Unchecked exception that is decorated with the namespace and table was being operated on.
TableLoggerException(String, String) - Constructor for exception io.deephaven.enterprise.database.TableLoggerException
 
TableLoggerException(String, String, String) - Constructor for exception io.deephaven.enterprise.database.TableLoggerException
 
tableName() - Method in exception io.deephaven.enterprise.database.SchemaNotFoundException
 
tableName() - Method in interface io.deephaven.enterprise.iceberg.discovery.DiscoveryConfig
Optional; When supplied, this will be the table name provided back in the DiscoveryResult.
tableName() - Method in interface io.deephaven.enterprise.remote.ConnectionAwareRemoteTableParams
The name of the table to fetch from the query scope.
tableName(String) - Method in interface io.deephaven.enterprise.iceberg.discovery.DiscoveryConfig.Builder
An optional user specified table name.
tableName(String) - Method in class io.deephaven.enterprise.remote.RemoteTableBuilder
Set the Table name to fetch from the query.
tableName(String) - Method in class io.deephaven.enterprise.kafkawriter.KafkaTableWriter.Options
The name of the table to ingest, this is a required option.
tableName(String) - Method in interface io.deephaven.enterprise.remote.ConnectionAwareRemoteTableParams.Builder
Set the name of the table to fetch from the query scope.
TableOptions - Class in io.deephaven.enterprise.database
A collection of options that control the construction of a live table
TableOptions() - Constructor for class io.deephaven.enterprise.database.TableOptions
 
TableOptions.Builder - Interface in io.deephaven.enterprise.database
A Builder object for TableOptions
TableReplayConfiguration - Interface in io.deephaven.enterprise.replay
The replay configuration for one table.
TableTicketTransformer - Class in io.deephaven.enterprise.acl.transform
A TicketTransformer that handles transformation of Tables to apply ACLs at the edge.
TableTicketTransformer(AclSupport) - Constructor for class io.deephaven.enterprise.acl.transform.TableTicketTransformer
 
TableWriterContext - Class in io.deephaven.enterprise.ingester.impl
Holder for a TableWriter and the processor for use in implementing an ingester.
TableWriterContext(Logger, SimpleDataImportStreamProcessor, Runnable, Runnable, String, TableDefinition, Set<String>, List<ImportStateDetails>) - Constructor for class io.deephaven.enterprise.ingester.impl.TableWriterContext
 
tail(long) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
tailBy(long, String...) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
tailPct(double) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
TARGET_NOT_SET - Enum constant in enum class io.deephaven.proto.pivot.PivotTableViewRequest.TargetCase
 
testSchemaPathForTable(Path, String, String) - Static method in class io.deephaven.enterprise.test.CorePlusTestUtils
 
TestTableGenerator - Class in io.deephaven.enterprise.test
This class can be used to generate identical tables in memory to the ones stored in the resources for this project.
TestTableGenerator(int, int) - Constructor for class io.deephaven.enterprise.test.TestTableGenerator
 
ThreadDumpRequest - Class in io.deephaven.proto.pqworker
Protobuf type io.deephaven.proto.pqworker.ThreadDumpRequest
ThreadDumpRequest.Builder - Class in io.deephaven.proto.pqworker
Protobuf type io.deephaven.proto.pqworker.ThreadDumpRequest
ThreadDumpRequestOrBuilder - Exception in io.deephaven.proto.pqworker
 
ThreadDumpRequestOrBuilder - Interface in io.deephaven.proto.pqworker
 
ThreadDumpResponse - Class in io.deephaven.proto.pqworker
Protobuf type io.deephaven.proto.pqworker.ThreadDumpResponse
ThreadDumpResponse.Builder - Class in io.deephaven.proto.pqworker
Protobuf type io.deephaven.proto.pqworker.ThreadDumpResponse
ThreadDumpResponseOrBuilder - Exception in io.deephaven.proto.pqworker
 
ThreadDumpResponseOrBuilder - Interface in io.deephaven.proto.pqworker
 
throwIfInvalidated() - Method in class io.deephaven.enterprise.sources.regioned.impl.InvalidatableRegion
 
TicketTransformer - Interface in io.deephaven.enterprise.dnd.authentication.transform
Implementations of this interface provide transformations of values before they are returned as Exports to clients.
TimePartitionRotation - Class in io.deephaven.enterprise.kafkawriter
Create functions for generating column partitions from an epoch timestamp.
timestampColumnName() - Method in class io.deephaven.enterprise.replay.ComposableTableReplayConfiguration
What column in the source table should be used for the replay timestamp.
timestampColumnName() - Method in interface io.deephaven.enterprise.replay.TableReplayConfiguration
What column in the source table should be used for the replay timestamp.
TIMESTAMPMILLIS_FIELD_NUMBER - Static variable in class io.deephaven.proto.pqworker.ListenErrorResponse
 
toBufferByteOffset(long) - Method in enum class io.deephaven.enterprise.sources.regioned.BufferedType
 
toBufferIndex(long) - Method in enum class io.deephaven.enterprise.sources.regioned.BufferedType
 
toBufferOffset(long) - Method in enum class io.deephaven.enterprise.sources.regioned.BufferedType
 
toBufferSizeInBytes(long) - Method in enum class io.deephaven.enterprise.sources.regioned.BufferedType
 
toBuilder() - Method in class io.deephaven.proto.pivot.ErrorResponse
 
toBuilder() - Method in class io.deephaven.proto.pivot.PivotPluginRequest
 
toBuilder() - Method in class io.deephaven.proto.pivot.PivotPluginResponse
 
toBuilder() - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest
 
toBuilder() - Method in class io.deephaven.proto.pivot.PivotTableApplyResponse
 
toBuilder() - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest
 
toBuilder() - Method in class io.deephaven.proto.pivot.PivotTableCreationResponse
 
toBuilder() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage
 
toBuilder() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorRequest
 
toBuilder() - Method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse
 
toBuilder() - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest
 
toBuilder() - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse
 
toBuilder() - Method in class io.deephaven.proto.pivot.PivotTableSourceExportRequest
 
toBuilder() - Method in class io.deephaven.proto.pivot.PivotTableSourceExportResponse
 
toBuilder() - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage
 
toBuilder() - Method in class io.deephaven.proto.pivot.PivotTableViewRequest
 
toBuilder() - Method in class io.deephaven.proto.pivot.PivotTableViewResponse
 
toBuilder() - Method in class io.deephaven.proto.pqworker.ListenErrorRequest
 
toBuilder() - Method in class io.deephaven.proto.pqworker.ListenErrorResponse
 
toBuilder() - Method in class io.deephaven.proto.pqworker.ObjectAccessRequest
 
toBuilder() - Method in class io.deephaven.proto.pqworker.ObjectAccessResponse
 
toBuilder() - Method in class io.deephaven.proto.pqworker.StringList
 
toBuilder() - Method in class io.deephaven.proto.pqworker.ThreadDumpRequest
 
toBuilder() - Method in class io.deephaven.proto.pqworker.ThreadDumpResponse
 
toJson() - Method in class io.deephaven.enterprise.iceberg.IcebergEndpoint
Get this object encoded as a JSON string.
topic(String) - Method in class io.deephaven.enterprise.kafkawriter.KafkaTableWriter.Options
Set the topic to consume, this is a required option.
toRegionByteOffset(long) - Method in enum class io.deephaven.enterprise.sources.regioned.BufferedType
 
toRegionSizeInBytes(long) - Method in enum class io.deephaven.enterprise.sources.regioned.BufferedType
 
toString() - Method in class io.deephaven.enterprise.ingester.impl.ImportStateDetails
 
toString() - Method in class io.deephaven.enterprise.locations.impl.BasicFixedPartitionedDeephavenTableLocationKey
 
toString() - Method in class io.deephaven.enterprise.locations.impl.EnterpriseTableKeyImpl
 
toString() - Method in class io.deephaven.enterprise.secrets.JsonFilesSecretsProvider
 
toString() - Method in class io.deephaven.enterprise.secrets.PropertiesSecretsProvider
 
toString() - Method in class io.deephaven.enterprise.tabledataservice.filter.EnterpriseFilterWrapper
 
toString() - Method in class io.deephaven.enterprise.tabledataservice.OnDiskTableDataService
 
toString() - Method in class io.deephaven.enterprise.tabledataservice.RemoteTableDataService
 
toUri(File, boolean) - Static method in class io.deephaven.enterprise.locations.UriHelper
 
toUri(Path, boolean) - Static method in class io.deephaven.enterprise.locations.UriHelper
 
transactionsEnabled(boolean) - Method in class io.deephaven.enterprise.derivedtablewriter.DerivedTableWriter.Options
Should transactions be enabled for each set of data written? (defaults to false)
transactionsEnabled(boolean) - Method in class io.deephaven.enterprise.kafkawriter.KafkaTableWriter.Options
Deephaven tables support transactions, which allow a set of contiguous rows to be appended to a table atomically or not at all.
transform(DheAuthContext, T) - Method in class io.deephaven.enterprise.acl.transform.GenericObjectTransformer
 
transform(DheAuthContext, T) - Method in class io.deephaven.enterprise.acl.transform.HierarchicalTableTicketTransformer
 
transform(DheAuthContext, T) - Method in class io.deephaven.enterprise.acl.transform.PivotTableTicketTransformer
 
transform(DheAuthContext, T) - Method in class io.deephaven.enterprise.acl.transform.TableTicketTransformer
 
transform(DheAuthContext, T) - Method in interface io.deephaven.enterprise.dnd.authentication.transform.TicketTransformer
Transform the specified object using the auth context.
transformation(Function<Table, Table>) - Method in class io.deephaven.enterprise.kafkawriter.KafkaTableWriter.Options
A transformation to apply after Core produces data from Kafka.
treeTable(String, String) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
TRUE_STRING - Static variable in class io.deephaven.pivot.PivotTableSchemaConstants
Re-usable constant for the "true" value.
truncate(TableLocationLookupKey<String>) - Method in class io.deephaven.enterprise.lastbystate.CoreLastByTableImportState.ResultPartitionedTable
 
trustAll(boolean) - Method in interface io.deephaven.enterprise.dnd.EnterpriseJettyComponent.Builder
Set if the worker should ignore the truststore with regard for PQ uri resolution.
tryAdapt(TableLocationKey) - Static method in interface io.deephaven.enterprise.locations.FixedPartitionedEnterpriseTableLocationKey
 
tryManage(LivenessReferent) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
tryRetainReference() - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
type() - Method in class io.deephaven.pivot.PivotMarshallerModule.PivotSubscriptionRequestHandlerFactory
 
TYPE_PATH_INDEX - Static variable in class io.deephaven.enterprise.dnd.service.ticket.DatabaseTicketResolver
 
TypeMutations - Class in io.deephaven.enterprise.ingester.impl
Utilities for converting types from Core to Enterprise for use in ingesters.
TypeMutations() - Constructor for class io.deephaven.enterprise.ingester.impl.TypeMutations
 

U

UGP_ADAPTER - Static variable in class io.deephaven.enterprise.compatibility.LiveTableRegistrarAdapter
 
UGP_ADAPTER - Static variable in class io.deephaven.enterprise.compatibility.NotificationQueueAdapter
 
UncoalescedBlinkTable - Class in io.deephaven.enterprise.extensions
An UncoalescedTable implementation that wraps another uncoalesced table.
UncoalescedBlinkTable(Table) - Constructor for class io.deephaven.enterprise.extensions.UncoalescedBlinkTable
 
ungroup(boolean, String...) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
unpackTo(String, Path) - Static method in class io.deephaven.enterprise.test.UnpackUtils
Locate the specified resource on the classpath and unpack it onto the filesystem at the specified path.
UnpackUtils - Class in io.deephaven.enterprise.test
We would like to be able to put all of the test data files in one package and reuse them.
UnpackUtils() - Constructor for class io.deephaven.enterprise.test.UnpackUtils
 
UNPARTITIONED_KEY_PLACEHOLDER - Static variable in interface io.deephaven.enterprise.locations.FixedPartitionedEnterpriseTableLocationKey
 
unsubscribe(TableLocation.Listener) - Method in class io.deephaven.enterprise.locations.local.HybridSnapshotBackedTableLocation
 
update(SelectColumn...) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
updateBy(UpdateByControl, Collection<UpdateByClause>, MatchPair...) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
updateDheDefinition(TableDefinition) - Static method in class io.deephaven.enterprise.test.TestTableGenerator
 
updateInputTableSchema(String, String, InputTableSpec) - Method in class io.deephaven.enterprise.database.impl.DatabaseImpl
 
updateInputTableSchema(String, String, InputTableSpec) - Method in interface io.deephaven.enterprise.database.WritableDatabase
Update an existing input table schema using the provided InputTableSpec.
updateInputTableSchema(String, String, InputTableSpec) - Method in class io.deephaven.enterprise.replay.WritableReplayDatabase
 
updatePartitionedTableSchema(String, String, TableDefinition) - Method in class io.deephaven.enterprise.database.impl.DatabaseImpl
 
updatePartitionedTableSchema(String, String, TableDefinition) - Method in interface io.deephaven.enterprise.database.WritableDatabase
Updates a preexisting User table schema.
updatePartitionedTableSchema(String, String, TableDefinition) - Method in class io.deephaven.enterprise.replay.WritableReplayDatabase
 
updatePerformanceAncestorLogger() - Method in class io.deephaven.enterprise.dnd.logger.engine.impl.EngineTableLoggersFactoryDndImpl
 
updatePerformanceLogLogger() - Method in class io.deephaven.enterprise.dnd.logger.engine.impl.EngineTableLoggersFactoryDndImpl
 
updateQueryStatus(long, String, PersistentQueryStatusEnum, Map<String, ExportedObjectInfoMessage>, Map<String, String[]>) - Method in interface io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClient
Publish an update for a persistent query.
updateQueryStatus(long, String, PersistentQueryStatusEnum, Map<String, ExportedObjectInfoMessage>, Map<String, String[]>) - Method in class io.deephaven.enterprise.dnd.controller.PersistentQueryControllerClientImpl
 
updateView(SelectColumn...) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
updateView(String...) - Method in class io.deephaven.enterprise.extensions.UncoalescedBlinkTable
 
UriHelper - Class in io.deephaven.enterprise.locations
A Temporary class to help with efficient conversions between File and URI
UriHelper() - Constructor for class io.deephaven.enterprise.locations.UriHelper
 
URIModule - Interface in io.deephaven.enterprise.dnd.modules
This module injects the PQUriResolver into the URI Resolver set for the worker.
URIProvidingLocationKey - Interface in io.deephaven.enterprise.locations
An EnterpriseTableLocationKey implementation which provides a URI to back a keyed location
URISnapshotProvidingLocationKey - Interface in io.deephaven.enterprise.locations
Defines a EnterpriseTableLocationKey which is backed by both a URI location and a TableLocationMetadataIndex.LocationSnapshot
USE_RANGES_AVERAGE_RUN_LENGTH - Static variable in interface io.deephaven.enterprise.sources.regioned.BufferedPage
Minimum average run length in an RowSequence that should trigger copy-by-ranges in BufferedPage implementations.
useIntraday() - Method in class io.deephaven.enterprise.replay.ComposableTableReplayConfiguration
 
useIntraday() - Method in interface io.deephaven.enterprise.replay.TableReplayConfiguration
Should the replayed table be sourced from db.liveTable?
useLas() - Method in class io.deephaven.enterprise.database.SystemTableLogger.Options
Get if we should use the Log Aggregator service to write the table.
useLas(boolean) - Method in interface io.deephaven.enterprise.database.SystemTableLogger.Options.Builder
Should the table be written via the log aggregator service (LAS)?
useLocationCaches(boolean) - Method in interface io.deephaven.enterprise.database.Database
Set whether the database should cache the result of table location discovery and re-use them.
useLocationCaches(boolean) - Method in class io.deephaven.enterprise.database.impl.DatabaseImpl
 
useLocationCaches(boolean) - Method in class io.deephaven.enterprise.replay.ReplayDatabase
 
UserInputTableException - Exception in io.deephaven.enterprise.database
Unchecked exception representing issues with Core+ user input tables.
UserInputTableException(String, String, String) - Constructor for exception io.deephaven.enterprise.database.UserInputTableException
 
UserTableColumnDefinitionException - Exception in io.deephaven.enterprise.database
Unchecked exception representing an incompatible user table definition.
UserTableColumnDefinitionException(String, String, String) - Constructor for exception io.deephaven.enterprise.database.UserTableColumnDefinitionException
 
UserTableDeleteException - Exception in io.deephaven.enterprise.database
Unchecked exception representing a failure in deleting part or all of a user table.
UserTableDeleteException(String, String, String, Throwable) - Constructor for exception io.deephaven.enterprise.database.UserTableDeleteException
 
UserTableIOException - Exception in io.deephaven.enterprise.database
Unchecked exception representing a failure in IO, e.g.
UserTableIOException(String, String, String) - Constructor for exception io.deephaven.enterprise.database.UserTableIOException
 
UserTableIOException(String, String, String, Throwable) - Constructor for exception io.deephaven.enterprise.database.UserTableIOException
 
UserTableMissingSchemaException - Exception in io.deephaven.enterprise.database
Unchecked exception representing a missing user table definition.
UserTableMissingSchemaException(String, String, String) - Constructor for exception io.deephaven.enterprise.database.UserTableMissingSchemaException
 
UserTableMissingSchemaException(String, String, String, Throwable) - Constructor for exception io.deephaven.enterprise.database.UserTableMissingSchemaException
 
UserTableNamespaceException - Exception in io.deephaven.enterprise.database
Unchecked exception representing a user table operation specifying a system namespace.
UserTableNamespaceException(String, String, String) - Constructor for exception io.deephaven.enterprise.database.UserTableNamespaceException
 
UserTablePermissionException - Exception in io.deephaven.enterprise.database
Unchecked exception representing insufficient access permissions to a user table operation.
UserTablePermissionException(String, String, String) - Constructor for exception io.deephaven.enterprise.database.UserTablePermissionException
 
UserTablePreexistingSchemaException - Exception in io.deephaven.enterprise.database
Unchecked exception representing a preexisting user table definition.
UserTablePreexistingSchemaException(String, String, String) - Constructor for exception io.deephaven.enterprise.database.UserTablePreexistingSchemaException
 
UserTableStorageTypeException - Exception in io.deephaven.enterprise.database
Unchecked exception representing an incompatible table storage type.
UserTableStorageTypeException(String, String, String) - Constructor for exception io.deephaven.enterprise.database.UserTableStorageTypeException
 
UserTableWriteException - Exception in io.deephaven.enterprise.database
Unchecked exception representing a failure in writing part or all of a user table.
UserTableWriteException(String, String, String) - Constructor for exception io.deephaven.enterprise.database.UserTableWriteException
 
UserTableWriteException(String, String, String, Throwable) - Constructor for exception io.deephaven.enterprise.database.UserTableWriteException
 

V

validateOrUpdateSchema() - Method in class io.deephaven.enterprise.kafkawriter.SchemaHelper
Validates the schema derived from SchemaHelper.getXmlSchema().
validateRequestedColumns(TableDefinition, Set<String>) - Static method in class io.deephaven.enterprise.remote.ConnectionAwareRemoteTable
 
validateSchema() - Method in class io.deephaven.enterprise.kafkawriter.SchemaHelper
Validates the schema derived from SchemaHelper.getXmlSchema().
validateSelect(SelectColumn...) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
ValidateVersion() - Static method in class io.deephaven.enterprise.pivot.flatbuf.PivotUpdateMetadata
 
valueOf(int) - Static method in enum class io.deephaven.proto.pivot.PivotPluginRequest.RequestCase
Deprecated.
valueOf(int) - Static method in enum class io.deephaven.proto.pivot.PivotPluginResponse.ResponseCase
Deprecated.
valueOf(int) - Static method in enum class io.deephaven.proto.pivot.PivotTableViewRequest.TargetCase
Deprecated.
valueOf(String) - Static method in enum class io.deephaven.enterprise.sources.regioned.BufferedType
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class io.deephaven.proto.pivot.PivotPluginRequest.RequestCase
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class io.deephaven.proto.pivot.PivotPluginResponse.ResponseCase
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class io.deephaven.proto.pivot.PivotTableViewRequest.TargetCase
Returns the enum constant of this class with the specified name.
values() - Static method in enum class io.deephaven.enterprise.sources.regioned.BufferedType
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class io.deephaven.proto.pivot.PivotPluginRequest.RequestCase
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class io.deephaven.proto.pivot.PivotPluginResponse.ResponseCase
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class io.deephaven.proto.pivot.PivotTableViewRequest.TargetCase
Returns an array containing the constants of this enum class, in the order they are declared.
VALUES_FIELD_NUMBER - Static variable in class io.deephaven.proto.pqworker.StringList
 
valuesDefinition() - Method in interface io.deephaven.pivot.PivotTable.PivotSnapshot
Get the definition for the value chunks in this snapshot.
valueSpec(KafkaTools.Consume.KeyOrValueSpec) - Method in class io.deephaven.enterprise.kafkawriter.KafkaTableWriter.Options
Determine how the value is converted to table columns.
valuesSnapshot() - Method in interface io.deephaven.pivot.PivotTable.PivotSnapshot
 
varBy(SelectColumn...) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
Vector() - Constructor for class io.deephaven.enterprise.pivot.flatbuf.PivotUpdateMetadata.Vector
 
view(SelectColumn...) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
view(String...) - Method in class io.deephaven.enterprise.extensions.UncoalescedBlinkTable
 
VIEW - Enum constant in enum class io.deephaven.proto.pivot.PivotPluginRequest.RequestCase
 
VIEW - Enum constant in enum class io.deephaven.proto.pivot.PivotPluginResponse.ResponseCase
 
VIEW_FIELD_NUMBER - Static variable in class io.deephaven.proto.pivot.PivotPluginRequest
 
VIEW_FIELD_NUMBER - Static variable in class io.deephaven.proto.pivot.PivotPluginResponse
 
visitLocationKey(TableLocationKey) - Method in class io.deephaven.enterprise.tabledataservice.MarkingPollingLocationProvider
 
visitLocationKey(TableLocationKey) - Method in class io.deephaven.enterprise.tabledataservice.TableLocationMarkSweepHelper
Visit a specific location.

W

warehouseUri(String) - Method in interface io.deephaven.enterprise.iceberg.IcebergEndpoint.Builder
Set the URI for accessing table data.
WASUNCAUGHT_FIELD_NUMBER - Static variable in class io.deephaven.proto.pqworker.ListenErrorResponse
 
wavgBy(String, SelectColumn...) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
where(WhereFilter...) - Static method in interface io.deephaven.enterprise.acl.AclFilterGenerator
Create an AclFilterGenerator from a set of simple where clauses.
where(String...) - Static method in interface io.deephaven.enterprise.acl.AclFilterGenerator
Create an AclFilterGenerator from a set of simple where clauses.
where(Collection<WhereFilter>) - Static method in interface io.deephaven.enterprise.acl.AclFilterGenerator
Create an AclFilterGenerator from a set of simple where clauses.
where(Filter) - Method in class io.deephaven.enterprise.acl.impl.DeferredACLTable
 
where(SelectFilter...) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
where(String...) - Method in class io.deephaven.enterprise.extensions.UncoalescedBlinkTable
 
whereIn(Table, String, String[], String...) - Static method in interface io.deephaven.enterprise.acl.AclFilterGenerator
Create an AclFilterGenerator that applies a TableOperations.whereIn(Object, String...) filter from a "Set" table containing the group information.
whereIn(String, String, String, String[], boolean, String...) - Static method in interface io.deephaven.enterprise.acl.AclFilterGenerator
Create an AclFilterGenerator that applies a TableOperations.whereIn(Object, String...) filter from a "Set" table containing the group information.
whereIn(Table, boolean, MatchPair...) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
WhereInFilterGenerator - Class in io.deephaven.enterprise.acl.generator
A filter generator that specifies a set table, and a list of match expressions (FilteredColumn=SetColumn), to apply a TableOperations.whereIn(Object, String...) operation to the filtered table.
WhereInFilterGenerator(Table, String, String[], MatchPair...) - Constructor for class io.deephaven.enterprise.acl.generator.WhereInFilterGenerator
Creates a whereIn filter generator, using the given set table, filters, and groupColumn to determine the visible rows for a given user.
WhereInFilterGenerator(String, String, String, String[], boolean, MatchPair...) - Constructor for class io.deephaven.enterprise.acl.generator.WhereInFilterGenerator
Creates a whereIn filter generator, using the given namespace, tablename, filters, and groupColumn to determine the visible rows for a given user.
WhereInFilterGenerator(String, String, String, String[], boolean, MatchPair...) - Constructor for class io.deephaven.enterprise.acl.generator.WhereInFilterGenerator
Creates a whereIn filter generator, using the given namespace, tablename, filters, and groupColumn to determine the visible rows for a given user.
withAdminGroups(Set<String>) - Method in interface io.deephaven.enterprise.dnd.EnterpriseJettyComponent.Builder
 
withAuditEventLogger(AuditEventLogger) - Method in interface io.deephaven.enterprise.dnd.EnterpriseJettyComponent.Builder
 
withCacheDir(File) - Method in interface io.deephaven.enterprise.dnd.EnterpriseJettyComponent.Builder
 
withColumnDescription(Map<String, String>) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
withDefaults(ComposableTableReplayConfiguration) - Method in class io.deephaven.enterprise.replay.ComposableTableReplayConfiguration
Apply the given default configuration to this configuration; and return a possibly new configuration representing this configuration with the defaults.
withDispatcherClient(DispatcherClient) - Method in interface io.deephaven.enterprise.dnd.EnterpriseJettyComponent.Builder
Set the DispatcherClient for components.
withEnterpriseConfiguration(Configuration) - Method in interface io.deephaven.enterprise.dnd.EnterpriseJettyComponent.Builder
Set the Enterprise configuration object.
withEtcdClient(Client) - Method in interface io.deephaven.enterprise.dnd.EnterpriseJettyComponent.Builder
Set the Client which can be used for worker etcd operations.
withGroupingCols(String...) - Method in class io.deephaven.enterprise.kafkawriter.SchemaHelper
Define column(s) as GroupingColumns.
withGroupingCols(Collection<String>) - Method in class io.deephaven.enterprise.kafkawriter.SchemaHelper
Define column(s) as GroupingColumns.
withJettyConfig(JettyConfig) - Method in interface io.deephaven.enterprise.dnd.EnterpriseJettyComponent.Builder
Set the Jetty configuration to use for the server.
withKeys(String...) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
withMergeKeyFormula(String) - Method in class io.deephaven.enterprise.kafkawriter.SchemaHelper
Define KeyFormula used for merge process.
withName(String) - Method in class io.deephaven.enterprise.iceberg.IcebergEndpoint
Get a copy of this endpoint, decorated with a name.
withPersistentQueryScriptPathLoaderState(String) - Method in interface io.deephaven.enterprise.dnd.EnterpriseJettyComponent.Builder
 
withPersistentQuerySerial(long) - Method in interface io.deephaven.enterprise.dnd.EnterpriseJettyComponent.Builder
 
withPqName(String) - Method in interface io.deephaven.enterprise.dnd.EnterpriseJettyComponent.Builder
 
withProcessInfo(ProcessInfo) - Method in interface io.deephaven.enterprise.dnd.EnterpriseJettyComponent.Builder
 
withReplaySettings(ReplaySettings) - Method in interface io.deephaven.enterprise.dnd.EnterpriseJettyComponent.Builder
 
withSymbolTableNone(String...) - Method in class io.deephaven.enterprise.kafkawriter.SchemaHelper
Define column(s) which should be written without a SymbolTable.
withSymbolTableNone(Collection<String>) - Method in class io.deephaven.enterprise.kafkawriter.SchemaHelper
Define column(s) which should be written without a SymbolTable.
withTableDescription(String) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
withUniqueKeys(String...) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
withUserContext(UserContext) - Method in interface io.deephaven.enterprise.dnd.EnterpriseJettyComponent.Builder
Set the user context of the owning user
withViewerGroups(Set<String>) - Method in interface io.deephaven.enterprise.dnd.EnterpriseJettyComponent.Builder
 
withVirtualEnvironment(String) - Method in interface io.deephaven.enterprise.dnd.EnterpriseJettyComponent.Builder
 
workerName(String) - Method in class io.deephaven.enterprise.dnd.query.util.perf.PerformanceOverview
Set the name of the worker to filter performamnce data
WorkspaceDataSnapshot - Class in io.deephaven.enterprise.workspace
 
WorkspaceDataSnapshot(Database) - Constructor for class io.deephaven.enterprise.workspace.WorkspaceDataSnapshot
 
WorkspaceDataSnapshot(Logger, Database) - Constructor for class io.deephaven.enterprise.workspace.WorkspaceDataSnapshot
 
wouldMatch(WouldMatchPair...) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 
wrap(Filter) - Static method in class io.deephaven.enterprise.tabledataservice.filter.EnterpriseFilterWrapper
 
WrappedGroupProvider - Class in io.deephaven.enterprise.dnd.authentication
A Simple GroupProvider that wraps the Enterprise implementation IrisGroupProvider
WrappedGroupProvider(IrisGroupProvider) - Constructor for class io.deephaven.enterprise.dnd.authentication.WrappedGroupProvider
Create a new provider delegating to the underlying Enterprise provider.
WritableDatabase - Interface in io.deephaven.enterprise.database
Interface for writing tables to persistent Deephaven storage.
WritableReplayDatabase - Class in io.deephaven.enterprise.replay
A ReplayDatabase that also wraps a WritableDatabase.
WritableReplayDatabase(Clock, WritableDatabase, Database, ReplaySettings, ReplayConfigurationImpl) - Constructor for class io.deephaven.enterprise.replay.WritableReplayDatabase
Create a new WritableReplayDatabase that wraps an underlying database.
writeChunkData(WritableChunk<Values>[], int, int) - Method in class io.deephaven.enterprise.ingester.impl.TableWriterContext
 
writeCompatibleObjectTo(Exporter, Object, OutputStream) - Method in class io.deephaven.pivot.PivotTablePlugin
 
writeLocationsTable(File, Schema) - Static method in class io.deephaven.enterprise.locations.hive.HiveLocationsTableKeyFinder
Write a locations table to disk for the given directory and schema.
writeTable(Table, TableDefinition, File) - Static method in class io.deephaven.enterprise.table.EnterpriseTableTools
Write the input table to the specified path in Deephaven format.
writeTable(Table, TableDefinition, File, String...) - Static method in class io.deephaven.enterprise.table.EnterpriseTableTools
Write the input table to the specified path in Deephaven format.
writeTable(Table, TableDefinition, String) - Static method in class io.deephaven.enterprise.table.EnterpriseTableTools
Write the input table to the specified path in Deephaven format.
writeTable(Table, File) - Static method in class io.deephaven.enterprise.table.EnterpriseTableTools
Write the input table to the specified path in Deephaven format.
writeTable(Table, String) - Static method in class io.deephaven.enterprise.table.EnterpriseTableTools
Write the input table to the specified path in Deephaven format.
writeTo(CodedOutputStream) - Method in class io.deephaven.proto.pivot.ErrorResponse
 
writeTo(CodedOutputStream) - Method in class io.deephaven.proto.pivot.PivotPluginRequest
 
writeTo(CodedOutputStream) - Method in class io.deephaven.proto.pivot.PivotPluginResponse
 
writeTo(CodedOutputStream) - Method in class io.deephaven.proto.pivot.PivotTableApplyRequest
 
writeTo(CodedOutputStream) - Method in class io.deephaven.proto.pivot.PivotTableApplyResponse
 
writeTo(CodedOutputStream) - Method in class io.deephaven.proto.pivot.PivotTableCreationRequest
 
writeTo(CodedOutputStream) - Method in class io.deephaven.proto.pivot.PivotTableCreationResponse
 
writeTo(CodedOutputStream) - Method in class io.deephaven.proto.pivot.PivotTableDescriptorMessage
 
writeTo(CodedOutputStream) - Method in class io.deephaven.proto.pivot.PivotTableDescriptorRequest
 
writeTo(CodedOutputStream) - Method in class io.deephaven.proto.pivot.PivotTableDescriptorResponse
 
writeTo(CodedOutputStream) - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsRequest
 
writeTo(CodedOutputStream) - Method in class io.deephaven.proto.pivot.PivotTableEmptyExpansionsResponse
 
writeTo(CodedOutputStream) - Method in class io.deephaven.proto.pivot.PivotTableSourceExportRequest
 
writeTo(CodedOutputStream) - Method in class io.deephaven.proto.pivot.PivotTableSourceExportResponse
 
writeTo(CodedOutputStream) - Method in class io.deephaven.proto.pivot.PivotTableViewExpansionsMessage
 
writeTo(CodedOutputStream) - Method in class io.deephaven.proto.pivot.PivotTableViewRequest
 
writeTo(CodedOutputStream) - Method in class io.deephaven.proto.pivot.PivotTableViewResponse
 
writeTo(CodedOutputStream) - Method in class io.deephaven.proto.pqworker.ListenErrorRequest
 
writeTo(CodedOutputStream) - Method in class io.deephaven.proto.pqworker.ListenErrorResponse
 
writeTo(CodedOutputStream) - Method in class io.deephaven.proto.pqworker.ObjectAccessRequest
 
writeTo(CodedOutputStream) - Method in class io.deephaven.proto.pqworker.ObjectAccessResponse
 
writeTo(CodedOutputStream) - Method in class io.deephaven.proto.pqworker.StringList
 
writeTo(CodedOutputStream) - Method in class io.deephaven.proto.pqworker.ThreadDumpRequest
 
writeTo(CodedOutputStream) - Method in class io.deephaven.proto.pqworker.ThreadDumpResponse
 
wsumBy(String, SelectColumn...) - Method in class io.deephaven.enterprise.compatibility.filter.TableAdapterForFilters
 

Z

ZERO_LENGTH_FILTER_GENERATOR_ARRAY - Static variable in interface io.deephaven.enterprise.acl.AclFilterGenerator
 
zoneId() - Method in class io.deephaven.enterprise.database.SystemTableLogger.Options
Get the zone ID used for binary log files.
zoneId(ZoneId) - Method in interface io.deephaven.enterprise.database.SystemTableLogger.Options.Builder
ZoneId for binary log files.

_

__assign(int, int, ByteBuffer) - Method in class io.deephaven.enterprise.pivot.flatbuf.PivotUpdateMetadata.Vector
 
__assign(int, ByteBuffer) - Method in class io.deephaven.enterprise.pivot.flatbuf.PivotUpdateMetadata
 
__init(int, ByteBuffer) - Method in class io.deephaven.enterprise.pivot.flatbuf.PivotUpdateMetadata
 
A B C D E F G H I J K L M N O P Q R S T U V W Z _ 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form