Modifier and Type | Method and Description |
---|---|
Session |
Session.beginTransactionId(TransactionId transactionId,
TransactionManager transactionManager,
AccessControl accessControl) |
Session |
Session.SessionBuilder.build() |
Session |
FullConnectorSession.getSession() |
Session |
SessionRepresentation.toSession(SessionPropertyManager sessionPropertyManager) |
Session |
SessionRepresentation.toSession(SessionPropertyManager sessionPropertyManager,
Map<String,String> extraCredentials) |
Session |
Session.withDefaultProperties(Map<String,String> systemPropertyDefaults,
Map<String,Map<String,String>> catalogPropertyDefaults) |
Modifier and Type | Method and Description |
---|---|
static Session.SessionBuilder |
Session.builder(Session session) |
static io.airlift.units.DataSize |
SystemSessionProperties.getAggregationOperatorUnspillMemoryLimit(Session session) |
static OptionalInt |
SystemSessionProperties.getConcurrentLifespansPerNode(Session session) |
static String |
SystemSessionProperties.getExecutionPolicy(Session session) |
static int |
SystemSessionProperties.getFilterAndProjectMinOutputPageRowCount(Session session) |
static io.airlift.units.DataSize |
SystemSessionProperties.getFilterAndProjectMinOutputPageSize(Session session) |
static int |
SystemSessionProperties.getHashPartitionCount(Session session) |
static int |
SystemSessionProperties.getInitialSplitsPerNode(Session session) |
static FeaturesConfig.JoinDistributionType |
SystemSessionProperties.getJoinDistributionType(Session session) |
static Optional<io.airlift.units.DataSize> |
SystemSessionProperties.getJoinMaxBroadcastTableSize(Session session) |
static FeaturesConfig.JoinReorderingStrategy |
SystemSessionProperties.getJoinReorderingStrategy(Session session) |
static OptionalInt |
SystemSessionProperties.getMaxDriversPerTask(Session session) |
static int |
SystemSessionProperties.getMaxGroupingSets(Session session) |
static int |
SystemSessionProperties.getMaxReorderedJoins(Session session) |
static io.airlift.units.Duration |
SystemSessionProperties.getOptimizerTimeout(Session session) |
static io.airlift.units.Duration |
SystemSessionProperties.getQueryMaxCpuTime(Session session) |
static io.airlift.units.Duration |
SystemSessionProperties.getQueryMaxExecutionTime(Session session) |
static io.airlift.units.DataSize |
SystemSessionProperties.getQueryMaxMemory(Session session) |
static io.airlift.units.Duration |
SystemSessionProperties.getQueryMaxRunTime(Session session) |
static int |
SystemSessionProperties.getQueryMaxStageCount(Session session) |
static io.airlift.units.DataSize |
SystemSessionProperties.getQueryMaxTotalMemory(Session session) |
static int |
SystemSessionProperties.getQueryPriority(Session session) |
static Optional<String> |
SystemSessionProperties.getSpatialPartitioningTableName(Session session) |
static io.airlift.units.Duration |
SystemSessionProperties.getSplitConcurrencyAdjustmentInterval(Session session) |
static int |
SystemSessionProperties.getTaskConcurrency(Session session) |
static int |
SystemSessionProperties.getTaskWriterCount(Session session) |
static io.airlift.units.DataSize |
SystemSessionProperties.getWriterMinSize(Session session) |
static boolean |
SystemSessionProperties.isColocatedJoinEnabled(Session session) |
static boolean |
SystemSessionProperties.isDefaultFilterFactorEnabled(Session session) |
static boolean |
SystemSessionProperties.isDictionaryAggregationEnabled(Session session) |
static boolean |
SystemSessionProperties.isDistributedIndexJoinEnabled(Session session) |
static boolean |
SystemSessionProperties.isDistributedSortEnabled(Session session) |
static boolean |
SystemSessionProperties.isDynamicSchduleForGroupedExecution(Session session) |
static boolean |
SystemSessionProperties.isEnableForcedExchangeBelowGroupId(Session session) |
static boolean |
SystemSessionProperties.isEnableIntermediateAggregations(Session session) |
static boolean |
SystemSessionProperties.isEnableStatsCalculator(Session session) |
static boolean |
SystemSessionProperties.isExchangeCompressionEnabled(Session session) |
static boolean |
SystemSessionProperties.isFastInequalityJoin(Session session) |
static boolean |
SystemSessionProperties.isForceSingleNodeOutput(Session session) |
static boolean |
SystemSessionProperties.isGroupedExecutionEnabled(Session session) |
static boolean |
SystemSessionProperties.isIgnoreStatsCalculatorFailures(Session session) |
static boolean |
SystemSessionProperties.isLegacyRowFieldOrdinalAccessEnabled(Session session) |
static boolean |
SystemSessionProperties.isLegacyTimestamp(Session session)
Deprecated.
|
static boolean |
SystemSessionProperties.isLegacyUnnest(Session session) |
static boolean |
SystemSessionProperties.isNewOptimizerEnabled(Session session) |
static boolean |
SystemSessionProperties.isOptimizeDistinctAggregationEnabled(Session session) |
static boolean |
SystemSessionProperties.isOptimizeHashGenerationEnabled(Session session) |
static boolean |
SystemSessionProperties.isOptimizeMetadataQueries(Session session) |
static boolean |
SystemSessionProperties.isOptimizeTopNRowNumber(Session session) |
static boolean |
SystemSessionProperties.isParseDecimalLiteralsAsDouble(Session session) |
static boolean |
SystemSessionProperties.isPushAggregationThroughJoin(Session session) |
static boolean |
SystemSessionProperties.isPushTableWriteThroughUnion(Session session) |
static boolean |
SystemSessionProperties.isRedistributeWrites(Session session) |
static boolean |
SystemSessionProperties.isScaleWriters(Session session) |
static boolean |
SystemSessionProperties.isShareIndexLoading(Session session) |
static boolean |
SystemSessionProperties.isSpatialJoinEnabled(Session session) |
static boolean |
SystemSessionProperties.isSpillEnabled(Session session) |
static boolean |
SystemSessionProperties.isSpillOrderBy(Session session) |
static boolean |
SystemSessionProperties.isSpillWindowOperator(Session session) |
static boolean |
SystemSessionProperties.isStatisticsCpuTimerEnabled(Session session) |
static boolean |
SystemSessionProperties.planWithTableNodePartitioning(Session session) |
static boolean |
SystemSessionProperties.preferPartialAggregation(Session session) |
static boolean |
SystemSessionProperties.preferStreamingOperators(Session session) |
static boolean |
SystemSessionProperties.resourceOvercommit(Session session) |
static boolean |
SystemSessionProperties.shouldPushAggregationThroughJoin(Session session) |
static boolean |
SystemSessionProperties.useMarkDistinct(Session session) |
Constructor and Description |
---|
FullConnectorSession(Session session,
ConnectorIdentity identity) |
FullConnectorSession(Session session,
ConnectorIdentity identity,
Map<String,String> properties,
ConnectorId connectorId,
String catalog,
SessionPropertyManager sessionPropertyManager) |
Modifier and Type | Method and Description |
---|---|
InternalTable |
InformationSchemaPageSourceProvider.getInformationSchemaTable(Session session,
String catalog,
SchemaTableName table,
Set<QualifiedTablePrefix> prefixes) |
Modifier and Type | Method and Description |
---|---|
static Session |
SystemConnectorSessionUtil.toSession(ConnectorTransactionHandle transactionHandle,
ConnectorSession session) |
Constructor and Description |
---|
CachingCostProvider(CostCalculator costCalculator,
StatsProvider statsProvider,
Optional<Memo> memo,
Session session,
TypeProvider types) |
CachingCostProvider(CostCalculator costCalculator,
StatsProvider statsProvider,
Session session,
TypeProvider types) |
CachingStatsProvider(StatsCalculator statsCalculator,
Optional<Memo> memo,
Lookup lookup,
Session session,
TypeProvider types) |
CachingStatsProvider(StatsCalculator statsCalculator,
Session session,
TypeProvider types) |
Modifier and Type | Method and Description |
---|---|
Session |
StageStateMachine.getSession() |
Session |
QueryTracker.TrackedQuery.getSession() |
Session |
SqlQueryExecution.getSession() |
Session |
FailedQueryExecution.getSession() |
Session |
QueryStateMachine.getSession() |
Session |
ManagedQueryExecution.getSession() |
Session |
DataDefinitionExecution.getSession() |
Modifier and Type | Method and Description |
---|---|
static QueryStateMachine |
QueryStateMachine.begin(String query,
Session session,
URI self,
ResourceGroupId resourceGroup,
boolean transactionControl,
TransactionManager transactionManager,
AccessControl accessControl,
Executor executor,
Metadata metadata,
WarningCollector warningCollector)
Created QueryStateMachines must be transitioned to terminal states to clean up resources.
|
SqlTaskExecution |
SqlTaskExecutionFactory.create(Session session,
QueryContext queryContext,
TaskStateMachine taskStateMachine,
OutputBuffer outputBuffer,
PlanFragment fragment,
List<TaskSource> sources,
OptionalInt totalPartitions) |
T |
QueryExecution.QueryExecutionFactory.createQueryExecution(String query,
Session session,
QueryPreparer.PreparedQuery preparedQuery,
ResourceGroupId resourceGroup,
WarningCollector warningCollector) |
QueryExecution |
SqlQueryExecution.SqlQueryExecutionFactory.createQueryExecution(String query,
Session session,
QueryPreparer.PreparedQuery preparedQuery,
ResourceGroupId resourceGroup,
WarningCollector warningCollector) |
DataDefinitionExecution<?> |
DataDefinitionExecution.DataDefinitionExecutionFactory.createQueryExecution(String query,
Session session,
QueryPreparer.PreparedQuery preparedQuery,
ResourceGroupId resourceGroup,
WarningCollector warningCollector) |
RemoteTask |
RemoteTaskFactory.createRemoteTask(Session session,
TaskId taskId,
Node node,
PlanFragment fragment,
com.google.common.collect.Multimap<PlanNodeId,Split> initialSplits,
OptionalInt totalPartitions,
OutputBuffers outputBuffers,
NodeTaskMap.PartitionedSplitCountTracker partitionedSplitCountTracker,
boolean summarizeTaskInfo) |
RemoteTask |
MemoryTrackingRemoteTaskFactory.createRemoteTask(Session session,
TaskId taskId,
Node node,
PlanFragment fragment,
com.google.common.collect.Multimap<PlanNodeId,Split> initialSplits,
OptionalInt totalPartitions,
OutputBuffers outputBuffers,
NodeTaskMap.PartitionedSplitCountTracker partitionedSplitCountTracker,
boolean summarizeTaskInfo) |
static SqlStageExecution |
SqlStageExecution.createSqlStageExecution(StageId stageId,
URI location,
PlanFragment fragment,
RemoteTaskFactory remoteTaskFactory,
Session session,
boolean summarizeTaskInfo,
NodeTaskMap nodeTaskMap,
ExecutorService executor,
FailureDetector failureDetector,
SplitSchedulerStats schedulerStats) |
static QueryInfo |
QueryInfo.immediateFailureQueryInfo(Session session,
String query,
URI self,
Optional<ResourceGroupId> resourceGroupId,
Throwable throwable) |
com.google.common.util.concurrent.ListenableFuture<?> |
CreateTableTask.internalExecute(CreateTable statement,
Metadata metadata,
AccessControl accessControl,
Session session,
List<Expression> parameters) |
QueryPreparer.PreparedQuery |
QueryPreparer.prepareQuery(Session session,
Statement wrappedStatement) |
QueryPreparer.PreparedQuery |
QueryPreparer.prepareQuery(Session session,
String query) |
TaskInfo |
SqlTask.updateTask(Session session,
Optional<PlanFragment> fragment,
List<TaskSource> sources,
OutputBuffers outputBuffers,
OptionalInt totalPartitions) |
TaskInfo |
TaskManager.updateTask(Session session,
TaskId taskId,
Optional<PlanFragment> fragment,
List<TaskSource> sources,
OutputBuffers outputBuffers,
OptionalInt totalPartitions)
Updates the task plan, sources and output buffers.
|
TaskInfo |
SqlTaskManager.updateTask(Session session,
TaskId taskId,
Optional<PlanFragment> fragment,
List<TaskSource> sources,
OutputBuffers outputBuffers,
OptionalInt totalPartitions) |
Constructor and Description |
---|
FailedQueryExecution(Session session,
String query,
URI self,
Optional<ResourceGroupId> resourceGroup,
Executor executor,
Throwable cause) |
StageStateMachine(StageId stageId,
URI location,
Session session,
PlanFragment fragment,
ExecutorService executor,
SplitSchedulerStats schedulerStats) |
Modifier and Type | Method and Description |
---|---|
static SqlQueryScheduler |
SqlQueryScheduler.createSqlQueryScheduler(QueryStateMachine queryStateMachine,
LocationFactory locationFactory,
StageExecutionPlan plan,
NodePartitioningManager nodePartitioningManager,
NodeScheduler nodeScheduler,
RemoteTaskFactory remoteTaskFactory,
Session session,
boolean summarizeTaskInfo,
int splitBatchSize,
ExecutorService queryExecutor,
ScheduledExecutorService schedulerExecutor,
FailureDetector failureDetector,
OutputBuffers rootOutputBuffers,
NodeTaskMap nodeTaskMap,
ExecutionPolicy executionPolicy,
SplitSchedulerStats schedulerStats) |
Modifier and Type | Method and Description |
---|---|
ConnectorIndex |
IndexManager.getIndex(Session session,
IndexHandle indexHandle,
List<ColumnHandle> lookupSchema,
List<ColumnHandle> outputSchema) |
Modifier and Type | Method and Description |
---|---|
TaskContext |
QueryContext.addTaskContext(TaskStateMachine taskStateMachine,
Session session,
boolean perOperatorCpuTimerEnabled,
boolean cpuTimerEnabled,
OptionalInt totalPartitions) |
Modifier and Type | Method and Description |
---|---|
void |
Metadata.addColumn(Session session,
TableHandle tableHandle,
ColumnMetadata column)
Add the specified column to the table.
|
void |
MetadataManager.addColumn(Session session,
TableHandle tableHandle,
ColumnMetadata column) |
OutputTableHandle |
Metadata.beginCreateTable(Session session,
String catalogName,
ConnectorTableMetadata tableMetadata,
Optional<NewTableLayout> layout)
Begin the atomic creation of a table with data.
|
OutputTableHandle |
MetadataManager.beginCreateTable(Session session,
String catalogName,
ConnectorTableMetadata tableMetadata,
Optional<NewTableLayout> layout) |
TableHandle |
Metadata.beginDelete(Session session,
TableHandle tableHandle)
Begin delete query
|
TableHandle |
MetadataManager.beginDelete(Session session,
TableHandle tableHandle) |
InsertTableHandle |
Metadata.beginInsert(Session session,
TableHandle tableHandle)
Begin insert query
|
InsertTableHandle |
MetadataManager.beginInsert(Session session,
TableHandle tableHandle) |
void |
Metadata.beginQuery(Session session,
Set<ConnectorId> connectors)
Start a SELECT/UPDATE/INSERT/DELETE query
|
void |
MetadataManager.beginQuery(Session session,
Set<ConnectorId> connectors) |
AnalyzeTableHandle |
Metadata.beginStatisticsCollection(Session session,
TableHandle tableHandle)
Begin statistics collection
|
AnalyzeTableHandle |
MetadataManager.beginStatisticsCollection(Session session,
TableHandle tableHandle) |
boolean |
Metadata.catalogExists(Session session,
String catalogName) |
boolean |
MetadataManager.catalogExists(Session session,
String catalogName) |
void |
Metadata.cleanupQuery(Session session)
Cleanup after a query.
|
void |
MetadataManager.cleanupQuery(Session session) |
static String |
MetadataUtil.createCatalogName(Session session,
Node node) |
static CatalogSchemaName |
MetadataUtil.createCatalogSchemaName(Session session,
Node node,
Optional<QualifiedName> schema) |
static PrestoPrincipal |
MetadataUtil.createPrincipal(Session session,
GrantorSpecification specification) |
static QualifiedObjectName |
MetadataUtil.createQualifiedObjectName(Session session,
Node node,
QualifiedName name) |
void |
Metadata.createRole(Session session,
String role,
Optional<PrestoPrincipal> grantor,
String catalog)
Creates the specified role in the specified catalog.
|
void |
MetadataManager.createRole(Session session,
String role,
Optional<PrestoPrincipal> grantor,
String catalog) |
void |
Metadata.createSchema(Session session,
CatalogSchemaName schema,
Map<String,Object> properties)
Creates a schema.
|
void |
MetadataManager.createSchema(Session session,
CatalogSchemaName schema,
Map<String,Object> properties) |
void |
Metadata.createTable(Session session,
String catalogName,
ConnectorTableMetadata tableMetadata,
boolean ignoreExisting)
Creates a table using the specified table metadata.
|
void |
MetadataManager.createTable(Session session,
String catalogName,
ConnectorTableMetadata tableMetadata,
boolean ignoreExisting) |
void |
Metadata.createView(Session session,
QualifiedObjectName viewName,
String viewData,
boolean replace)
Creates the specified view with the specified view definition.
|
void |
MetadataManager.createView(Session session,
QualifiedObjectName viewName,
String viewData,
boolean replace) |
void |
Metadata.dropColumn(Session session,
TableHandle tableHandle,
ColumnHandle column)
Drop the specified column.
|
void |
MetadataManager.dropColumn(Session session,
TableHandle tableHandle,
ColumnHandle column) |
void |
Metadata.dropRole(Session session,
String role,
String catalog)
Drops the specified role in the specified catalog.
|
void |
MetadataManager.dropRole(Session session,
String role,
String catalog) |
void |
Metadata.dropSchema(Session session,
CatalogSchemaName schema)
Drops the specified schema.
|
void |
MetadataManager.dropSchema(Session session,
CatalogSchemaName schema) |
void |
Metadata.dropTable(Session session,
TableHandle tableHandle)
Drops the specified table
|
void |
MetadataManager.dropTable(Session session,
TableHandle tableHandle) |
void |
Metadata.dropView(Session session,
QualifiedObjectName viewName)
Drops the specified view.
|
void |
MetadataManager.dropView(Session session,
QualifiedObjectName viewName) |
static Object |
SessionPropertyManager.evaluatePropertyValue(Expression expression,
Type expectedType,
Session session,
Metadata metadata,
List<Expression> parameters) |
Optional<ConnectorOutputMetadata> |
Metadata.finishCreateTable(Session session,
OutputTableHandle tableHandle,
Collection<io.airlift.slice.Slice> fragments,
Collection<ComputedStatistics> computedStatistics)
Finish a table creation with data after the data is written.
|
Optional<ConnectorOutputMetadata> |
MetadataManager.finishCreateTable(Session session,
OutputTableHandle tableHandle,
Collection<io.airlift.slice.Slice> fragments,
Collection<ComputedStatistics> computedStatistics) |
void |
Metadata.finishDelete(Session session,
TableHandle tableHandle,
Collection<io.airlift.slice.Slice> fragments)
Finish delete query
|
void |
MetadataManager.finishDelete(Session session,
TableHandle tableHandle,
Collection<io.airlift.slice.Slice> fragments) |
Optional<ConnectorOutputMetadata> |
Metadata.finishInsert(Session session,
InsertTableHandle tableHandle,
Collection<io.airlift.slice.Slice> fragments,
Collection<ComputedStatistics> computedStatistics)
Finish insert query
|
Optional<ConnectorOutputMetadata> |
MetadataManager.finishInsert(Session session,
InsertTableHandle tableHandle,
Collection<io.airlift.slice.Slice> fragments,
Collection<ComputedStatistics> computedStatistics) |
void |
Metadata.finishStatisticsCollection(Session session,
AnalyzeTableHandle tableHandle,
Collection<ComputedStatistics> computedStatistics)
Finish statistics collection
|
void |
MetadataManager.finishStatisticsCollection(Session session,
AnalyzeTableHandle tableHandle,
Collection<ComputedStatistics> computedStatistics) |
List<SessionPropertyManager.SessionPropertyValue> |
SessionPropertyManager.getAllSessionProperties(Session session,
Map<String,ConnectorId> catalogs) |
TableLayoutHandle |
Metadata.getAlternativeLayoutHandle(Session session,
TableLayoutHandle tableLayoutHandle,
PartitioningHandle partitioningHandle)
Return a table layout handle whose partitioning is converted to the provided partitioning handle,
but otherwise identical to the provided table layout handle.
|
TableLayoutHandle |
MetadataManager.getAlternativeLayoutHandle(Session session,
TableLayoutHandle tableLayoutHandle,
PartitioningHandle partitioningHandle) |
Optional<ConnectorId> |
Metadata.getCatalogHandle(Session session,
String catalogName)
Returns a connector id for the specified catalog name.
|
Optional<ConnectorId> |
MetadataManager.getCatalogHandle(Session session,
String catalogName) |
Map<String,ConnectorId> |
Metadata.getCatalogNames(Session session)
Gets all the loaded catalogs
|
Map<String,ConnectorId> |
MetadataManager.getCatalogNames(Session session) |
Map<String,ColumnHandle> |
Metadata.getColumnHandles(Session session,
TableHandle tableHandle)
Gets all of the columns on the specified table, or an empty map if the columns can not be enumerated.
|
Map<String,ColumnHandle> |
MetadataManager.getColumnHandles(Session session,
TableHandle tableHandle) |
ColumnMetadata |
Metadata.getColumnMetadata(Session session,
TableHandle tableHandle,
ColumnHandle columnHandle)
Gets the metadata for the specified table column.
|
ColumnMetadata |
MetadataManager.getColumnMetadata(Session session,
TableHandle tableHandle,
ColumnHandle columnHandle) |
Optional<PartitioningHandle> |
Metadata.getCommonPartitioning(Session session,
PartitioningHandle left,
PartitioningHandle right)
Return a partitioning handle which the connector can transparently convert both
left and right into. |
Optional<PartitioningHandle> |
MetadataManager.getCommonPartitioning(Session session,
PartitioningHandle left,
PartitioningHandle right) |
ConnectorId |
CatalogMetadata.getConnectorId(Session session,
QualifiedObjectName table) |
Optional<Object> |
Metadata.getInfo(Session session,
TableLayoutHandle handle) |
Optional<Object> |
MetadataManager.getInfo(Session session,
TableLayoutHandle handle) |
Optional<NewTableLayout> |
Metadata.getInsertLayout(Session session,
TableHandle target) |
Optional<NewTableLayout> |
MetadataManager.getInsertLayout(Session session,
TableHandle table) |
TableLayout |
Metadata.getLayout(Session session,
TableLayoutHandle handle) |
TableLayout |
MetadataManager.getLayout(Session session,
TableLayoutHandle handle) |
List<TableLayoutResult> |
Metadata.getLayouts(Session session,
TableHandle tableHandle,
Constraint<ColumnHandle> constraint,
Optional<Set<ColumnHandle>> desiredColumns) |
List<TableLayoutResult> |
MetadataManager.getLayouts(Session session,
TableHandle table,
Constraint<ColumnHandle> constraint,
Optional<Set<ColumnHandle>> desiredColumns) |
Optional<NewTableLayout> |
Metadata.getNewTableLayout(Session session,
String catalogName,
ConnectorTableMetadata tableMetadata) |
Optional<NewTableLayout> |
MetadataManager.getNewTableLayout(Session session,
String catalogName,
ConnectorTableMetadata tableMetadata) |
TableStatisticsMetadata |
Metadata.getStatisticsCollectionMetadata(Session session,
String catalogName,
ConnectorTableMetadata tableMetadata)
Describe statistics that must be collected during a statistics collection
|
TableStatisticsMetadata |
MetadataManager.getStatisticsCollectionMetadata(Session session,
String catalogName,
ConnectorTableMetadata tableMetadata) |
TableStatisticsMetadata |
Metadata.getStatisticsCollectionMetadataForWrite(Session session,
String catalogName,
ConnectorTableMetadata tableMetadata)
Describes statistics that must be collected during a write.
|
TableStatisticsMetadata |
MetadataManager.getStatisticsCollectionMetadataForWrite(Session session,
String catalogName,
ConnectorTableMetadata tableMetadata) |
Optional<SystemTable> |
Metadata.getSystemTable(Session session,
QualifiedObjectName tableName) |
Optional<SystemTable> |
MetadataManager.getSystemTable(Session session,
QualifiedObjectName tableName) |
Optional<TableHandle> |
Metadata.getTableHandle(Session session,
QualifiedObjectName tableName)
Returns a table handle for the specified table name.
|
Optional<TableHandle> |
MetadataManager.getTableHandle(Session session,
QualifiedObjectName table) |
Optional<TableHandle> |
Metadata.getTableHandleForStatisticsCollection(Session session,
QualifiedObjectName tableName,
Map<String,Object> analyzeProperties) |
Optional<TableHandle> |
MetadataManager.getTableHandleForStatisticsCollection(Session session,
QualifiedObjectName table,
Map<String,Object> analyzeProperties) |
TableMetadata |
Metadata.getTableMetadata(Session session,
TableHandle tableHandle)
Return the metadata for the specified table handle.
|
TableMetadata |
MetadataManager.getTableMetadata(Session session,
TableHandle tableHandle) |
TableStatistics |
Metadata.getTableStatistics(Session session,
TableHandle tableHandle,
Constraint<ColumnHandle> constraint)
Return statistics for specified table for given filtering contraint.
|
TableStatistics |
MetadataManager.getTableStatistics(Session session,
TableHandle tableHandle,
Constraint<ColumnHandle> constraint) |
ColumnHandle |
Metadata.getUpdateRowIdColumnHandle(Session session,
TableHandle tableHandle)
Get the row ID column handle used with UpdatablePageSource.
|
ColumnHandle |
MetadataManager.getUpdateRowIdColumnHandle(Session session,
TableHandle tableHandle) |
Optional<ViewDefinition> |
Metadata.getView(Session session,
QualifiedObjectName viewName)
Returns the view definition for the specified view name.
|
Optional<ViewDefinition> |
MetadataManager.getView(Session session,
QualifiedObjectName viewName) |
Map<QualifiedObjectName,ViewDefinition> |
Metadata.getViews(Session session,
QualifiedTablePrefix prefix)
Get the view definitions that match the specified table prefix (never null).
|
Map<QualifiedObjectName,ViewDefinition> |
MetadataManager.getViews(Session session,
QualifiedTablePrefix prefix) |
void |
Metadata.grantRoles(Session session,
Set<String> roles,
Set<PrestoPrincipal> grantees,
boolean withAdminOption,
Optional<PrestoPrincipal> grantor,
String catalog)
Grants the specified roles to the specified grantees in the specified catalog
|
void |
MetadataManager.grantRoles(Session session,
Set<String> roles,
Set<PrestoPrincipal> grantees,
boolean withAdminOption,
Optional<PrestoPrincipal> grantor,
String catalog) |
void |
Metadata.grantTablePrivileges(Session session,
QualifiedObjectName tableName,
Set<Privilege> privileges,
PrestoPrincipal grantee,
boolean grantOption)
Grants the specified privilege to the specified user on the specified table
|
void |
MetadataManager.grantTablePrivileges(Session session,
QualifiedObjectName tableName,
Set<Privilege> privileges,
PrestoPrincipal grantee,
boolean grantOption) |
Set<RoleGrant> |
Metadata.listApplicableRoles(Session session,
PrestoPrincipal principal,
String catalog)
List applicable roles, including the transitive grants, for the specified principal
|
Set<RoleGrant> |
MetadataManager.listApplicableRoles(Session session,
PrestoPrincipal principal,
String catalog) |
static SortedMap<String,ConnectorId> |
MetadataListing.listCatalogs(Session session,
Metadata metadata,
AccessControl accessControl) |
Set<String> |
Metadata.listEnabledRoles(Session session,
String catalog)
List applicable roles, including the transitive grants, in given session
|
Set<String> |
MetadataManager.listEnabledRoles(Session session,
String catalog) |
Set<RoleGrant> |
Metadata.listRoleGrants(Session session,
String catalog,
PrestoPrincipal principal)
List roles grants in the specified catalog for a given principal, not recursively.
|
Set<RoleGrant> |
MetadataManager.listRoleGrants(Session session,
String catalog,
PrestoPrincipal principal) |
Set<String> |
Metadata.listRoles(Session session,
String catalog)
List available roles in specified catalog.
|
Set<String> |
MetadataManager.listRoles(Session session,
String catalog) |
List<String> |
Metadata.listSchemaNames(Session session,
String catalogName) |
List<String> |
MetadataManager.listSchemaNames(Session session,
String catalogName) |
static SortedSet<String> |
MetadataListing.listSchemas(Session session,
Metadata metadata,
AccessControl accessControl,
String catalogName) |
static Map<SchemaTableName,List<ColumnMetadata>> |
MetadataListing.listTableColumns(Session session,
Metadata metadata,
AccessControl accessControl,
QualifiedTablePrefix prefix) |
Map<QualifiedObjectName,List<ColumnMetadata>> |
Metadata.listTableColumns(Session session,
QualifiedTablePrefix prefix)
Gets the metadata for all columns that match the specified table prefix.
|
Map<QualifiedObjectName,List<ColumnMetadata>> |
MetadataManager.listTableColumns(Session session,
QualifiedTablePrefix prefix) |
static Set<GrantInfo> |
MetadataListing.listTablePrivileges(Session session,
Metadata metadata,
AccessControl accessControl,
QualifiedTablePrefix prefix) |
List<GrantInfo> |
Metadata.listTablePrivileges(Session session,
QualifiedTablePrefix prefix)
Gets the privileges for the specified table available to the given grantee considering the selected session role
|
List<GrantInfo> |
MetadataManager.listTablePrivileges(Session session,
QualifiedTablePrefix prefix) |
static Set<SchemaTableName> |
MetadataListing.listTables(Session session,
Metadata metadata,
AccessControl accessControl,
QualifiedTablePrefix prefix) |
List<QualifiedObjectName> |
Metadata.listTables(Session session,
QualifiedTablePrefix prefix)
Get the names that match the specified table prefix (never null).
|
List<QualifiedObjectName> |
MetadataManager.listTables(Session session,
QualifiedTablePrefix prefix) |
static Set<SchemaTableName> |
MetadataListing.listViews(Session session,
Metadata metadata,
AccessControl accessControl,
QualifiedTablePrefix prefix) |
List<QualifiedObjectName> |
Metadata.listViews(Session session,
QualifiedTablePrefix prefix)
Get the names that match the specified table prefix (never null).
|
List<QualifiedObjectName> |
MetadataManager.listViews(Session session,
QualifiedTablePrefix prefix) |
OptionalLong |
Metadata.metadataDelete(Session session,
TableHandle tableHandle,
TableLayoutHandle tableLayoutHandle)
Delete the provide table layout
|
OptionalLong |
MetadataManager.metadataDelete(Session session,
TableHandle tableHandle,
TableLayoutHandle tableLayoutHandle) |
void |
Metadata.renameColumn(Session session,
TableHandle tableHandle,
ColumnHandle source,
String target)
Rename the specified column.
|
void |
MetadataManager.renameColumn(Session session,
TableHandle tableHandle,
ColumnHandle source,
String target) |
void |
Metadata.renameSchema(Session session,
CatalogSchemaName source,
String target)
Renames the specified schema.
|
void |
MetadataManager.renameSchema(Session session,
CatalogSchemaName source,
String target) |
void |
Metadata.renameTable(Session session,
TableHandle tableHandle,
QualifiedObjectName newTableName)
Rename the specified table.
|
void |
MetadataManager.renameTable(Session session,
TableHandle tableHandle,
QualifiedObjectName newTableName) |
Optional<ResolvedIndex> |
Metadata.resolveIndex(Session session,
TableHandle tableHandle,
Set<ColumnHandle> indexableColumns,
Set<ColumnHandle> outputColumns,
TupleDomain<ColumnHandle> tupleDomain)
Try to locate a table index that can lookup results by indexableColumns and provide the requested outputColumns.
|
Optional<ResolvedIndex> |
MetadataManager.resolveIndex(Session session,
TableHandle tableHandle,
Set<ColumnHandle> indexableColumns,
Set<ColumnHandle> outputColumns,
TupleDomain<ColumnHandle> tupleDomain) |
void |
Metadata.revokeRoles(Session session,
Set<String> roles,
Set<PrestoPrincipal> grantees,
boolean adminOptionFor,
Optional<PrestoPrincipal> grantor,
String catalog)
Revokes the specified roles from the specified grantees in the specified catalog
|
void |
MetadataManager.revokeRoles(Session session,
Set<String> roles,
Set<PrestoPrincipal> grantees,
boolean adminOptionFor,
Optional<PrestoPrincipal> grantor,
String catalog) |
void |
Metadata.revokeTablePrivileges(Session session,
QualifiedObjectName tableName,
Set<Privilege> privileges,
PrestoPrincipal grantee,
boolean grantOption)
Revokes the specified privilege on the specified table from the specified user
|
void |
MetadataManager.revokeTablePrivileges(Session session,
QualifiedObjectName tableName,
Set<Privilege> privileges,
PrestoPrincipal grantee,
boolean grantOption) |
boolean |
Metadata.schemaExists(Session session,
CatalogSchemaName schema) |
boolean |
MetadataManager.schemaExists(Session session,
CatalogSchemaName schema) |
boolean |
Metadata.supportsMetadataDelete(Session session,
TableHandle tableHandle,
TableLayoutHandle tableLayoutHandle) |
boolean |
MetadataManager.supportsMetadataDelete(Session session,
TableHandle tableHandle,
TableLayoutHandle tableLayoutHandle) |
static boolean |
MetadataUtil.tableExists(Metadata metadata,
Session session,
String table) |
Modifier and Type | Method and Description |
---|---|
Session |
OperatorContext.getSession() |
Session |
PipelineContext.getSession() |
Session |
DriverContext.getSession() |
Session |
TaskContext.getSession() |
Constructor and Description |
---|
JoinHashSupplier(Session session,
PagesHashStrategy pagesHashStrategy,
it.unimi.dsi.fastutil.longs.LongArrayList addresses,
List<List<Block>> channels,
Optional<JoinFilterFunctionCompiler.JoinFilterFunctionFactory> filterFunctionFactory,
Optional<Integer> sortChannel,
List<JoinFilterFunctionCompiler.JoinFilterFunctionFactory> searchFunctionFactories) |
MarkDistinctHash(Session session,
List<Type> types,
int[] channels,
Optional<Integer> hashChannel,
int expectedDistinctValues,
JoinCompiler joinCompiler,
UpdateMemory updateMemory) |
MarkDistinctHash(Session session,
List<Type> types,
int[] channels,
Optional<Integer> hashChannel,
JoinCompiler joinCompiler,
UpdateMemory updateMemory) |
MetadataDeleteOperator(OperatorContext operatorContext,
TableLayoutHandle tableLayout,
Metadata metadata,
Session session,
TableHandle tableHandle) |
MetadataDeleteOperatorFactory(int operatorId,
PlanNodeId planNodeId,
TableLayoutHandle tableLayout,
Metadata metadata,
Session session,
TableHandle tableHandle) |
PagesRTreeIndex(Session session,
it.unimi.dsi.fastutil.longs.LongArrayList addresses,
List<Type> types,
List<Integer> outputChannels,
List<List<Block>> channels,
org.locationtech.jts.index.strtree.STRtree rtree,
Optional<Integer> radiusChannel,
SpatialIndexBuilderOperator.SpatialPredicate spatialRelationshipTest,
Optional<JoinFilterFunctionCompiler.JoinFilterFunctionFactory> filterFunctionFactory,
Map<Integer,Rectangle> partitions) |
PagesSpatialIndexSupplier(Session session,
it.unimi.dsi.fastutil.longs.LongArrayList addresses,
List<Type> types,
List<Integer> outputChannels,
List<List<Block>> channels,
int geometryChannel,
Optional<Integer> radiusChannel,
Optional<Integer> partitionChannel,
SpatialIndexBuilderOperator.SpatialPredicate spatialRelationshipTest,
Optional<JoinFilterFunctionCompiler.JoinFilterFunctionFactory> filterFunctionFactory,
Map<Integer,Rectangle> partitions) |
TableFinishOperatorFactory(int operatorId,
PlanNodeId planNodeId,
TableFinishOperator.TableFinisher tableFinisher,
OperatorFactory statisticsAggregationOperatorFactory,
StatisticAggregationsDescriptor<Integer> descriptor,
Session session) |
TableWriterOperatorFactory(int operatorId,
PlanNodeId planNodeId,
PageSinkManager pageSinkManager,
TableWriterNode.WriterTarget writerTarget,
List<Integer> columnChannels,
Session session,
OperatorFactory statisticsAggregationOperatorFactory,
List<Type> types) |
Modifier and Type | Method and Description |
---|---|
AccumulatorFactory |
InternalAggregationFunction.bind(List<Integer> inputChannels,
Optional<Integer> maskChannel,
List<Type> sourceTypes,
List<Integer> orderByChannels,
List<SortOrder> orderings,
PagesIndex.Factory pagesIndexFactory,
boolean distinct,
JoinCompiler joinCompiler,
List<LambdaProvider> lambdaProviders,
Session session) |
AccumulatorFactory |
AccumulatorFactoryBinder.bind(List<Integer> argumentChannels,
Optional<Integer> maskChannel,
List<Type> sourceTypes,
List<Integer> orderByChannels,
List<SortOrder> orderings,
PagesIndex.Factory pagesIndexFactory,
boolean distinct,
JoinCompiler joinCompiler,
List<LambdaProvider> lambdaProviders,
Session session) |
AccumulatorFactory |
LazyAccumulatorFactoryBinder.bind(List<Integer> argumentChannels,
Optional<Integer> maskChannel,
List<Type> sourceTypes,
List<Integer> orderByChannels,
List<SortOrder> orderings,
PagesIndex.Factory pagesIndexFactory,
boolean distinct,
JoinCompiler joinCompiler,
List<LambdaProvider> lambdaProviders,
Session session) |
AccumulatorFactory |
GenericAccumulatorFactoryBinder.bind(List<Integer> argumentChannels,
Optional<Integer> maskChannel,
List<Type> sourceTypes,
List<Integer> orderByChannels,
List<SortOrder> orderings,
PagesIndex.Factory pagesIndexFactory,
boolean distinct,
JoinCompiler joinCompiler,
List<LambdaProvider> lambdaProviders,
Session session) |
Constructor and Description |
---|
GenericAccumulatorFactory(List<AggregationMetadata.AccumulatorStateDescriptor> stateDescriptors,
Constructor<? extends Accumulator> accumulatorConstructor,
Constructor<? extends GroupedAccumulator> groupedAccumulatorConstructor,
List<LambdaProvider> lambdaProviders,
List<Integer> inputChannels,
Optional<Integer> maskChannel,
List<Type> sourceTypes,
List<Integer> orderByChannels,
List<SortOrder> orderings,
PagesIndex.Factory pagesIndexFactory,
JoinCompiler joinCompiler,
Session session,
boolean distinct) |
Constructor and Description |
---|
UnloadedIndexKeyRecordSet(Session session,
IndexSnapshot existingSnapshot,
Set<Integer> channelsForDistinct,
List<Type> types,
List<io.prestosql.operator.index.UpdateRequest> requests,
JoinCompiler joinCompiler) |
Constructor and Description |
---|
InterpretedPageFilter(Expression expression,
TypeProvider symbolTypes,
Map<Symbol,Integer> symbolToInputMappings,
Metadata metadata,
SqlParser sqlParser,
Session session) |
InterpretedPageProjection(Expression expression,
TypeProvider symbolTypes,
Map<Symbol,Integer> symbolToInputMappings,
Metadata metadata,
SqlParser sqlParser,
Session session) |
Modifier and Type | Method and Description |
---|---|
Session |
SessionSupplier.createSession(QueryId queryId,
SessionContext context) |
Session |
QuerySessionSupplier.createSession(QueryId queryId,
SessionContext context) |
Session |
NoOpSessionSupplier.createSession(QueryId queryId,
SessionContext context) |
Session |
SessionPropertyDefaults.newSessionWithDefaultProperties(Session session,
Optional<String> queryType,
ResourceGroupId resourceGroupId) |
Modifier and Type | Method and Description |
---|---|
RemoteTask |
HttpRemoteTaskFactory.createRemoteTask(Session session,
TaskId taskId,
Node node,
PlanFragment fragment,
com.google.common.collect.Multimap<PlanNodeId,Split> initialSplits,
OptionalInt totalPartitions,
OutputBuffers outputBuffers,
NodeTaskMap.PartitionedSplitCountTracker partitionedSplitCountTracker,
boolean summarizeTaskInfo) |
Session |
SessionPropertyDefaults.newSessionWithDefaultProperties(Session session,
Optional<String> queryType,
ResourceGroupId resourceGroupId) |
Constructor and Description |
---|
HttpRemoteTask(Session session,
TaskId taskId,
String nodeId,
URI location,
PlanFragment planFragment,
com.google.common.collect.Multimap<PlanNodeId,Split> initialSplits,
OptionalInt totalPartitions,
OutputBuffers outputBuffers,
io.airlift.http.client.HttpClient httpClient,
Executor executor,
ScheduledExecutorService updateScheduledExecutor,
ScheduledExecutorService errorScheduledExecutor,
io.airlift.units.Duration maxErrorDuration,
io.airlift.units.Duration taskStatusRefreshMaxWait,
io.airlift.units.Duration taskInfoUpdateInterval,
boolean summarizeTaskInfo,
io.airlift.json.JsonCodec<TaskStatus> taskStatusCodec,
io.airlift.json.JsonCodec<TaskInfo> taskInfoCodec,
io.airlift.json.JsonCodec<TaskUpdateRequest> taskUpdateRequestCodec,
NodeTaskMap.PartitionedSplitCountTracker partitionedSplitCountTracker,
RemoteTaskStats stats) |
Modifier and Type | Method and Description |
---|---|
ConnectorPageSink |
PageSinkProvider.createPageSink(Session session,
InsertTableHandle tableHandle) |
ConnectorPageSink |
PageSinkManager.createPageSink(Session session,
InsertTableHandle tableHandle) |
ConnectorPageSink |
PageSinkProvider.createPageSink(Session session,
OutputTableHandle tableHandle) |
ConnectorPageSink |
PageSinkManager.createPageSink(Session session,
OutputTableHandle tableHandle) |
ConnectorPageSource |
PageSourceManager.createPageSource(Session session,
Split split,
List<ColumnHandle> columns) |
ConnectorPageSource |
PageSourceProvider.createPageSource(Session session,
Split split,
List<ColumnHandle> columns) |
SplitSource |
SplitManager.getSplits(Session session,
TableLayoutHandle layout,
ConnectorSplitManager.SplitSchedulingStrategy splitSchedulingStrategy) |
Modifier and Type | Method and Description |
---|---|
static ParsingOptions |
ParsingUtil.createParsingOptions(Session session) |
Modifier and Type | Method and Description |
---|---|
Analysis |
QueryExplainer.analyze(Session session,
Statement statement,
List<Expression> parameters,
WarningCollector warningCollector) |
static ExpressionAnalysis |
ExpressionAnalyzer.analyzeExpression(Session session,
Metadata metadata,
AccessControl accessControl,
SqlParser sqlParser,
Scope scope,
Analysis analysis,
Expression expression,
WarningCollector warningCollector) |
static ExpressionAnalysis |
ExpressionAnalyzer.analyzeExpressions(Session session,
Metadata metadata,
SqlParser sqlParser,
RelationType tupleDescriptor,
TypeProvider types,
Iterable<? extends Expression> expressions,
List<Expression> parameters,
WarningCollector warningCollector) |
static ExpressionAnalysis |
ExpressionAnalyzer.analyzeExpressionsWithSymbols(Session session,
Metadata metadata,
SqlParser sqlParser,
TypeProvider types,
Iterable<Expression> expressions,
List<Expression> parameters,
WarningCollector warningCollector,
boolean isDescribe) |
static ExpressionAnalyzer |
ExpressionAnalyzer.create(Analysis analysis,
Session session,
Metadata metadata,
SqlParser sqlParser,
AccessControl accessControl,
TypeProvider types,
WarningCollector warningCollector) |
static ExpressionAnalyzer |
ExpressionAnalyzer.createConstantAnalyzer(Metadata metadata,
Session session,
List<Expression> parameters,
WarningCollector warningCollector) |
static ExpressionAnalyzer |
ExpressionAnalyzer.createConstantAnalyzer(Metadata metadata,
Session session,
List<Expression> parameters,
WarningCollector warningCollector,
boolean isDescribe) |
static ExpressionAnalyzer |
ExpressionAnalyzer.createWithoutSubqueries(FunctionRegistry functionRegistry,
TypeManager typeManager,
Session session,
List<Expression> parameters,
SemanticErrorCode errorCode,
String message,
WarningCollector warningCollector,
boolean isDescribe) |
static ExpressionAnalyzer |
ExpressionAnalyzer.createWithoutSubqueries(FunctionRegistry functionRegistry,
TypeManager typeManager,
Session session,
TypeProvider symbolTypes,
List<Expression> parameters,
Function<? super Node,? extends RuntimeException> statementAnalyzerRejection,
WarningCollector warningCollector,
boolean isDescribe) |
static Map<NodeRef<Expression>,Type> |
ExpressionAnalyzer.getExpressionTypes(Session session,
Metadata metadata,
SqlParser sqlParser,
TypeProvider types,
Expression expression,
List<Expression> parameters,
WarningCollector warningCollector) |
static Map<NodeRef<Expression>,Type> |
ExpressionAnalyzer.getExpressionTypes(Session session,
Metadata metadata,
SqlParser sqlParser,
TypeProvider types,
Expression expression,
List<Expression> parameters,
WarningCollector warningCollector,
boolean isDescribe) |
static Map<NodeRef<Expression>,Type> |
ExpressionAnalyzer.getExpressionTypes(Session session,
Metadata metadata,
SqlParser sqlParser,
TypeProvider types,
Iterable<Expression> expressions,
List<Expression> parameters,
WarningCollector warningCollector,
boolean isDescribe) |
static Map<NodeRef<Expression>,Type> |
ExpressionAnalyzer.getExpressionTypesFromInput(Session session,
Metadata metadata,
SqlParser sqlParser,
Map<Integer,Type> types,
Expression expression,
List<Expression> parameters,
WarningCollector warningCollector) |
static Map<NodeRef<Expression>,Type> |
ExpressionAnalyzer.getExpressionTypesFromInput(Session session,
Metadata metadata,
SqlParser sqlParser,
Map<Integer,Type> types,
Iterable<Expression> expressions,
List<Expression> parameters,
WarningCollector warningCollector) |
String |
QueryExplainer.getGraphvizPlan(Session session,
Statement statement,
ExplainType.Type planType,
List<Expression> parameters,
WarningCollector warningCollector) |
String |
QueryExplainer.getJsonPlan(Session session,
Statement statement,
ExplainType.Type planType,
List<Expression> parameters,
WarningCollector warningCollector) |
Plan |
QueryExplainer.getLogicalPlan(Session session,
Statement statement,
List<Expression> parameters,
WarningCollector warningCollector) |
String |
QueryExplainer.getPlan(Session session,
Statement statement,
ExplainType.Type planType,
List<Expression> parameters,
WarningCollector warningCollector) |
Constructor and Description |
---|
Analyzer(Session session,
Metadata metadata,
SqlParser sqlParser,
AccessControl accessControl,
Optional<QueryExplainer> queryExplainer,
List<Expression> parameters,
WarningCollector warningCollector) |
ExpressionAnalyzer(FunctionRegistry functionRegistry,
TypeManager typeManager,
Function<Node,io.prestosql.sql.analyzer.StatementAnalyzer> statementAnalyzerFactory,
Session session,
TypeProvider symbolTypes,
List<Expression> parameters,
WarningCollector warningCollector,
boolean isDescribe) |
Modifier and Type | Method and Description |
---|---|
LookupSourceSupplier |
JoinCompiler.LookupSourceSupplierFactory.createLookupSourceSupplier(Session session,
it.unimi.dsi.fastutil.longs.LongArrayList addresses,
List<List<Block>> channels,
OptionalInt hashChannel,
Optional<JoinFilterFunctionCompiler.JoinFilterFunctionFactory> filterFunctionFactory,
Optional<Integer> sortChannel,
List<JoinFilterFunctionCompiler.JoinFilterFunctionFactory> searchFunctionFactories) |
Modifier and Type | Method and Description |
---|---|
SubPlan |
PlanFragmenter.createSubPlans(Session session,
Plan plan,
boolean forceSingleNode) |
static Object |
ExpressionInterpreter.evaluateConstantExpression(Expression expression,
Type expectedType,
Metadata metadata,
Session session,
List<Expression> parameters) |
static ExpressionInterpreter |
ExpressionInterpreter.expressionInterpreter(Expression expression,
Metadata metadata,
Session session,
Map<NodeRef<Expression>,Type> expressionTypes) |
static ExpressionInterpreter |
ExpressionInterpreter.expressionOptimizer(Expression expression,
Metadata metadata,
Session session,
Map<NodeRef<Expression>,Type> expressionTypes) |
static DomainTranslator.ExtractionResult |
DomainTranslator.fromPredicate(Metadata metadata,
Session session,
Expression predicate,
TypeProvider types)
Convert an Expression predicate into an ExtractionResult consisting of:
1) A successfully extracted TupleDomain
2) An Expression fragment which represents the part of the original Expression that will need to be re-evaluated
after filtering with the TupleDomain.
|
BucketNodeMap |
NodePartitioningManager.getBucketNodeMap(Session session,
PartitioningHandle partitioningHandle,
boolean preferDynamic) |
NodePartitionMap |
NodePartitioningManager.getNodePartitioningMap(Session session,
PartitioningHandle partitioningHandle) |
NodePartitionMap |
SystemPartitioningHandle.getNodePartitionMap(Session session,
NodeScheduler nodeScheduler) |
PartitionFunction |
NodePartitioningManager.getPartitionFunction(Session session,
PartitioningScheme partitioningScheme,
List<Type> partitionChannelTypes) |
boolean |
Partitioning.isCompatibleWith(Partitioning right,
Function<Symbol,Set<Symbol>> leftToRightMappings,
Function<Symbol,Optional<NullableValue>> leftConstantMapping,
Function<Symbol,Optional<NullableValue>> rightConstantMapping,
Metadata metadata,
Session session) |
boolean |
Partitioning.isCompatibleWith(Partitioning right,
Metadata metadata,
Session session) |
List<ConnectorPartitionHandle> |
NodePartitioningManager.listPartitionHandles(Session session,
PartitioningHandle partitioningHandle) |
StageExecutionPlan |
DistributedExecutionPlanner.plan(SubPlan root,
Session session) |
static Expression |
DesugarAtTimeZoneRewriter.rewrite(Expression expression,
Session session,
Metadata metadata,
SqlParser sqlParser,
SymbolAllocator symbolAllocator) |
Constructor and Description |
---|
InputExtractor(Metadata metadata,
Session session) |
LogicalPlanner(Session session,
List<PlanOptimizer> planOptimizers,
PlanNodeIdAllocator idAllocator,
Metadata metadata,
SqlParser sqlParser,
StatsCalculator statsCalculator,
CostCalculator costCalculator,
WarningCollector warningCollector) |
LogicalPlanner(Session session,
List<PlanOptimizer> planOptimizers,
PlanSanityChecker planSanityChecker,
PlanNodeIdAllocator idAllocator,
Metadata metadata,
SqlParser sqlParser,
StatsCalculator statsCalculator,
CostCalculator costCalculator,
WarningCollector warningCollector) |
Modifier and Type | Method and Description |
---|---|
Session |
Rule.Context.getSession() |
Modifier and Type | Method and Description |
---|---|
default boolean |
Rule.isEnabled(Session session) |
PlanNode |
IterativeOptimizer.optimize(PlanNode plan,
Session session,
TypeProvider types,
SymbolAllocator symbolAllocator,
PlanNodeIdAllocator idAllocator,
WarningCollector warningCollector) |
Modifier and Type | Method and Description |
---|---|
boolean |
PushPartialAggregationThroughJoin.isEnabled(Session session) |
boolean |
AddIntermediateAggregations.isEnabled(Session session) |
boolean |
PushAggregationThroughOuterJoin.isEnabled(Session session) |
boolean |
ReorderJoins.isEnabled(Session session) |
boolean |
EliminateCrossJoins.isEnabled(Session session) |
boolean |
PushTableWriteThroughUnion.isEnabled(Session session) |
boolean |
ExtractSpatialJoins.ExtractSpatialInnerJoin.isEnabled(Session session) |
boolean |
ExtractSpatialJoins.ExtractSpatialLeftJoin.isEnabled(Session session) |
static List<PlanNode> |
PickTableLayout.listTableLayouts(TableScanNode node,
Expression predicate,
boolean pruneWithPredicateExpression,
Session session,
TypeProvider types,
PlanNodeIdAllocator idAllocator,
Metadata metadata,
SqlParser parser,
DomainTranslator domainTranslator) |
Modifier and Type | Method and Description |
---|---|
boolean |
ExpressionEquivalence.areExpressionsEquivalent(Session session,
Expression leftExpression,
Expression rightExpression,
TypeProvider types) |
static StreamPreferredProperties |
StreamPreferredProperties.defaultParallelism(Session session) |
static ActualProperties |
PropertyDerivations.deriveProperties(PlanNode node,
List<ActualProperties> inputProperties,
Metadata metadata,
Session session,
TypeProvider types,
SqlParser parser) |
static StreamPropertyDerivations.StreamProperties |
StreamPropertyDerivations.deriveProperties(PlanNode node,
List<StreamPropertyDerivations.StreamProperties> inputProperties,
Metadata metadata,
Session session,
TypeProvider types,
SqlParser parser) |
static StreamPropertyDerivations.StreamProperties |
StreamPropertyDerivations.deriveProperties(PlanNode node,
StreamPropertyDerivations.StreamProperties inputProperties,
Metadata metadata,
Session session,
TypeProvider types,
SqlParser parser) |
static StreamPropertyDerivations.StreamProperties |
StreamPropertyDerivations.derivePropertiesRecursively(PlanNode node,
Metadata metadata,
Session session,
TypeProvider types,
SqlParser parser) |
static ActualProperties |
PropertyDerivations.derivePropertiesRecursively(PlanNode node,
Metadata metadata,
Session session,
TypeProvider types,
SqlParser parser) |
boolean |
ActualProperties.isCompatibleTablePartitioningWith(ActualProperties other,
Function<Symbol,Set<Symbol>> symbolMappings,
Metadata metadata,
Session session) |
boolean |
ActualProperties.isCompatibleTablePartitioningWith(Partitioning partitioning,
boolean nullsAndAnyReplicated,
Metadata metadata,
Session session) |
PlanNode |
StatsRecordingPlanOptimizer.optimize(PlanNode plan,
Session session,
TypeProvider types,
SymbolAllocator symbolAllocator,
PlanNodeIdAllocator idAllocator,
WarningCollector warningCollector) |
PlanNode |
MetadataQueryOptimizer.optimize(PlanNode plan,
Session session,
TypeProvider types,
SymbolAllocator symbolAllocator,
PlanNodeIdAllocator idAllocator,
WarningCollector warningCollector) |
PlanNode |
ImplementIntersectAndExceptAsUnion.optimize(PlanNode plan,
Session session,
TypeProvider types,
SymbolAllocator symbolAllocator,
PlanNodeIdAllocator idAllocator,
WarningCollector warningCollector) |
PlanNode |
MetadataDeleteOptimizer.optimize(PlanNode plan,
Session session,
TypeProvider types,
SymbolAllocator symbolAllocator,
PlanNodeIdAllocator idAllocator,
WarningCollector warningCollector) |
PlanNode |
OptimizeMixedDistinctAggregations.optimize(PlanNode plan,
Session session,
TypeProvider types,
SymbolAllocator symbolAllocator,
PlanNodeIdAllocator idAllocator,
WarningCollector warningCollector) |
PlanNode |
ReplicateSemiJoinInDelete.optimize(PlanNode plan,
Session session,
TypeProvider types,
SymbolAllocator symbolAllocator,
PlanNodeIdAllocator idAllocator,
WarningCollector warningCollector) |
PlanNode |
TransformQuantifiedComparisonApplyToLateralJoin.optimize(PlanNode plan,
Session session,
TypeProvider types,
SymbolAllocator symbolAllocator,
PlanNodeIdAllocator idAllocator,
WarningCollector warningCollector) |
PlanNode |
PredicatePushDown.optimize(PlanNode plan,
Session session,
TypeProvider types,
SymbolAllocator symbolAllocator,
PlanNodeIdAllocator idAllocator,
WarningCollector warningCollector) |
PlanNode |
CheckSubqueryNodesAreRewritten.optimize(PlanNode plan,
Session session,
TypeProvider types,
SymbolAllocator symbolAllocator,
PlanNodeIdAllocator idAllocator,
WarningCollector warningCollector) |
PlanNode |
AddLocalExchanges.optimize(PlanNode plan,
Session session,
TypeProvider types,
SymbolAllocator symbolAllocator,
PlanNodeIdAllocator idAllocator,
WarningCollector warningCollector) |
PlanNode |
PruneUnreferencedOutputs.optimize(PlanNode plan,
Session session,
TypeProvider types,
SymbolAllocator symbolAllocator,
PlanNodeIdAllocator idAllocator,
WarningCollector warningCollector) |
PlanNode |
LimitPushDown.optimize(PlanNode plan,
Session session,
TypeProvider types,
SymbolAllocator symbolAllocator,
PlanNodeIdAllocator idAllocator,
WarningCollector warningCollector) |
PlanNode |
PlanOptimizer.optimize(PlanNode plan,
Session session,
TypeProvider types,
SymbolAllocator symbolAllocator,
PlanNodeIdAllocator idAllocator,
WarningCollector warningCollector) |
PlanNode |
AddExchanges.optimize(PlanNode plan,
Session session,
TypeProvider types,
SymbolAllocator symbolAllocator,
PlanNodeIdAllocator idAllocator,
WarningCollector warningCollector) |
PlanNode |
BeginTableWrite.optimize(PlanNode plan,
Session session,
TypeProvider types,
SymbolAllocator symbolAllocator,
PlanNodeIdAllocator idAllocator,
WarningCollector warningCollector) |
PlanNode |
IndexJoinOptimizer.optimize(PlanNode plan,
Session session,
TypeProvider type,
SymbolAllocator symbolAllocator,
PlanNodeIdAllocator idAllocator,
WarningCollector warningCollector) |
PlanNode |
HashGenerationOptimizer.optimize(PlanNode plan,
Session session,
TypeProvider types,
SymbolAllocator symbolAllocator,
PlanNodeIdAllocator idAllocator,
WarningCollector warningCollector) |
PlanNode |
SetFlatteningOptimizer.optimize(PlanNode plan,
Session session,
TypeProvider types,
SymbolAllocator symbolAllocator,
PlanNodeIdAllocator idAllocator,
WarningCollector warningCollector) |
PlanNode |
UnaliasSymbolReferences.optimize(PlanNode plan,
Session session,
TypeProvider types,
SymbolAllocator symbolAllocator,
PlanNodeIdAllocator idAllocator,
WarningCollector warningCollector) |
PlanNode |
WindowFilterPushDown.optimize(PlanNode plan,
Session session,
TypeProvider types,
SymbolAllocator symbolAllocator,
PlanNodeIdAllocator idAllocator,
WarningCollector warningCollector) |
static ActualProperties |
PropertyDerivations.streamBackdoorDeriveProperties(PlanNode node,
List<ActualProperties> inputProperties,
Metadata metadata,
Session session,
TypeProvider types,
SqlParser parser) |
StreamPreferredProperties |
StreamPreferredProperties.withDefaultParallelism(Session session) |
Modifier and Type | Method and Description |
---|---|
static String |
PlanPrinter.jsonFragmentPlan(PlanNode root,
Map<Symbol,Type> symbols,
FunctionRegistry functionRegistry,
Session session) |
static String |
PlanPrinter.textDistributedPlan(StageInfo outputStageInfo,
FunctionRegistry functionRegistry,
Session session,
boolean verbose) |
static String |
PlanPrinter.textDistributedPlan(SubPlan plan,
FunctionRegistry functionRegistry,
Session session,
boolean verbose) |
static String |
IoPlanPrinter.textIoPlan(PlanNode plan,
Metadata metadata,
Session session) |
static String |
PlanPrinter.textLogicalPlan(PlanNode plan,
TypeProvider types,
FunctionRegistry functionRegistry,
StatsAndCosts estimatedStatsAndCosts,
Session session,
int level) |
static String |
PlanPrinter.textLogicalPlan(PlanNode plan,
TypeProvider types,
FunctionRegistry functionRegistry,
StatsAndCosts estimatedStatsAndCosts,
Session session,
int level,
boolean verbose) |
static String |
PlanPrinter.textLogicalPlan(PlanNode plan,
TypeProvider types,
Optional<StageExecutionDescriptor> stageExecutionStrategy,
FunctionRegistry functionRegistry,
StatsAndCosts estimatedStatsAndCosts,
Session session,
Optional<Map<PlanNodeId,PlanNodeStats>> stats,
int level,
boolean verbose) |
Modifier and Type | Method and Description |
---|---|
void |
TypeValidator.validate(PlanNode plan,
Session session,
Metadata metadata,
SqlParser sqlParser,
TypeProvider types,
WarningCollector warningCollector) |
void |
ValidateDependenciesChecker.validate(PlanNode plan,
Session session,
Metadata metadata,
SqlParser sqlParser,
TypeProvider types,
WarningCollector warningCollector) |
void |
VerifyNoFilteredAggregations.validate(PlanNode plan,
Session session,
Metadata metadata,
SqlParser sqlParser,
TypeProvider types,
WarningCollector warningCollector) |
void |
VerifyOnlyOneOutputNode.validate(PlanNode plan,
Session session,
Metadata metadata,
SqlParser sqlParser,
TypeProvider types,
WarningCollector warningCollector) |
void |
ValidateAggregationsWithDefaultValues.validate(PlanNode planNode,
Session session,
Metadata metadata,
SqlParser sqlParser,
TypeProvider types,
WarningCollector warningCollector) |
void |
NoDuplicatePlanNodeIdsChecker.validate(PlanNode planNode,
Session session,
Metadata metadata,
SqlParser sqlParser,
TypeProvider types,
WarningCollector warningCollector) |
void |
ValidateStreamingAggregations.validate(PlanNode planNode,
Session session,
Metadata metadata,
SqlParser sqlParser,
TypeProvider types,
WarningCollector warningCollector) |
void |
NoSubqueryExpressionLeftChecker.validate(PlanNode plan,
Session session,
Metadata metadata,
SqlParser sqlParser,
TypeProvider types,
WarningCollector warningCollector) |
void |
NoIdentifierLeftChecker.validate(PlanNode plan,
Session session,
Metadata metadata,
SqlParser sqlParser,
TypeProvider types,
WarningCollector warningCollector) |
void |
PlanSanityChecker.Checker.validate(PlanNode planNode,
Session session,
Metadata metadata,
SqlParser sqlParser,
TypeProvider types,
WarningCollector warningCollector) |
void |
PlanSanityChecker.validateFinalPlan(PlanNode planNode,
Session session,
Metadata metadata,
SqlParser sqlParser,
TypeProvider types,
WarningCollector warningCollector) |
void |
PlanSanityChecker.validateIntermediatePlan(PlanNode planNode,
Session session,
Metadata metadata,
SqlParser sqlParser,
TypeProvider types,
WarningCollector warningCollector) |
Modifier and Type | Method and Description |
---|---|
static RowExpression |
SqlToRowExpressionTranslator.translate(Expression expression,
FunctionKind functionKind,
Map<NodeRef<Expression>,Type> types,
FunctionRegistry functionRegistry,
TypeManager typeManager,
Session session,
boolean optimize) |
Constructor and Description |
---|
ExpressionOptimizer(FunctionRegistry registry,
TypeManager typeManager,
Session session) |
Modifier and Type | Method and Description |
---|---|
static Statement |
StatementRewrite.rewrite(Session session,
Metadata metadata,
SqlParser parser,
Optional<QueryExplainer> queryExplainer,
Statement node,
List<Expression> parameters,
AccessControl accessControl,
WarningCollector warningCollector) |
Statement |
ShowStatsRewrite.rewrite(Session session,
Metadata metadata,
SqlParser parser,
Optional<QueryExplainer> queryExplainer,
Statement node,
List<Expression> parameters,
AccessControl accessControl,
WarningCollector warningCollector) |
Modifier and Type | Method and Description |
---|---|
Session |
QueryRunner.getDefaultSession() |
Session |
LocalQueryRunner.getDefaultSession() |
Modifier and Type | Method and Description |
---|---|
static TestingTaskContext.Builder |
TestingTaskContext.builder(Executor notificationExecutor,
ScheduledExecutorService yieldExecutor,
Session session) |
List<Driver> |
LocalQueryRunner.createDrivers(Session session,
String sql,
OutputFactory outputFactory,
TaskContext taskContext) |
Plan |
LocalQueryRunner.createPlan(Session session,
String sql,
List<PlanOptimizer> optimizers,
LogicalPlanner.Stage stage,
WarningCollector warningCollector) |
Plan |
LocalQueryRunner.createPlan(Session session,
String sql,
List<PlanOptimizer> optimizers,
WarningCollector warningCollector) |
Plan |
LocalQueryRunner.createPlan(Session session,
String sql,
LogicalPlanner.Stage stage,
boolean forceSingleNode,
WarningCollector warningCollector) |
Plan |
LocalQueryRunner.createPlan(Session session,
String sql,
LogicalPlanner.Stage stage,
WarningCollector warningCollector) |
default Plan |
QueryRunner.createPlan(Session session,
String sql,
WarningCollector warningCollector) |
Plan |
LocalQueryRunner.createPlan(Session session,
String sql,
WarningCollector warningCollector) |
static TaskContext |
TestingTaskContext.createTaskContext(Executor notificationExecutor,
ScheduledExecutorService yieldExecutor,
Session session) |
static TaskContext |
TestingTaskContext.createTaskContext(Executor notificationExecutor,
ScheduledExecutorService yieldExecutor,
Session session,
io.airlift.units.DataSize maxMemory) |
static TaskContext |
TestingTaskContext.createTaskContext(Executor notificationExecutor,
ScheduledExecutorService yieldExecutor,
Session session,
TaskStateMachine taskStateMachine) |
static TaskContext |
TestingTaskContext.createTaskContext(QueryContext queryContext,
Executor executor,
Session session) |
MaterializedResult |
QueryRunner.execute(Session session,
String sql) |
MaterializedResult |
LocalQueryRunner.execute(Session session,
String sql) |
default QueryRunner.MaterializedResultWithPlan |
QueryRunner.executeWithPlan(Session session,
String sql,
WarningCollector warningCollector) |
QueryRunner.MaterializedResultWithPlan |
LocalQueryRunner.executeWithPlan(Session session,
String sql,
WarningCollector warningCollector) |
<T> T |
LocalQueryRunner.inTransaction(Session session,
Function<Session,T> transactionSessionConsumer) |
List<QualifiedObjectName> |
QueryRunner.listTables(Session session,
String catalog,
String schema) |
List<QualifiedObjectName> |
LocalQueryRunner.listTables(Session session,
String catalog,
String schema) |
static MaterializedResult |
MaterializedResult.materializeSourceDataStream(Session session,
ConnectorPageSource pageSource,
List<Type> types) |
static LocalQueryRunner |
LocalQueryRunner.queryRunnerWithFakeNodeCountForStats(Session defaultSession,
int nodeCount) |
static LocalQueryRunner |
LocalQueryRunner.queryRunnerWithInitialTransaction(Session defaultSession) |
static MaterializedResult.Builder |
MaterializedResult.resultBuilder(Session session,
Iterable<? extends Type> types) |
static MaterializedResult.Builder |
MaterializedResult.resultBuilder(Session session,
Type... types) |
static SqlTime |
DateTimeTestingUtils.sqlTimeOf(int hourOfDay,
int minuteOfHour,
int secondOfMinute,
int millisOfSecond,
Session session) |
static SqlTime |
DateTimeTestingUtils.sqlTimeOf(LocalTime time,
Session session) |
static SqlTimestamp |
DateTimeTestingUtils.sqlTimestampOf(org.joda.time.DateTime dateTime,
Session session) |
static SqlTimestamp |
DateTimeTestingUtils.sqlTimestampOf(int year,
int monthOfYear,
int dayOfMonth,
int hourOfDay,
int minuteOfHour,
int secondOfMinute,
int millisOfSecond,
Session session) |
boolean |
QueryRunner.tableExists(Session session,
String table) |
boolean |
LocalQueryRunner.tableExists(Session session,
String table) |
Modifier and Type | Method and Description |
---|---|
<T> T |
LocalQueryRunner.inTransaction(Function<Session,T> transactionSessionConsumer) |
<T> T |
LocalQueryRunner.inTransaction(Session session,
Function<Session,T> transactionSessionConsumer) |
Constructor and Description |
---|
LocalQueryRunner(Session defaultSession) |
LocalQueryRunner(Session defaultSession,
FeaturesConfig featuresConfig) |
LocalQueryRunner(Session defaultSession,
FeaturesConfig featuresConfig,
NodeSpillConfig nodeSpillConfig,
boolean withInitialTransaction,
boolean alwaysRevokeMemory) |
Modifier and Type | Method and Description |
---|---|
default void |
TransactionManager.activateTransaction(Session session,
boolean transactionControl,
AccessControl accessControl) |
void |
TransactionBuilder.execute(Session session,
Consumer<Session> callback) |
<T> T |
TransactionBuilder.execute(Session session,
Function<Session,T> callback) |
Modifier and Type | Method and Description |
---|---|
void |
TransactionBuilder.execute(Session session,
Consumer<Session> callback) |
<T> T |
TransactionBuilder.execute(Session session,
Function<Session,T> callback) |
Copyright © 2012–2019. All rights reserved.