Package org.apache.beam.sdk.extensions.sql.impl
package org.apache.beam.sdk.extensions.sql.impl
Implementation classes of BeamSql.
-
ClassDescriptionAdapter from
TableProvider
toSchema
.Adapter fromBeamSqlTable
to a calcite Table.Contains the metadata of tables/UDF functions, and exposes APIs to query/validate/optimize/translate SQL statements.BeamSqlEnv's Builder.Options used to configure BeamSQL.AutoService
registrar forBeamSqlPipelineOptions
.This class stores row count statistics.Abstract wrapper forCalciteConnection
to simplify extension.Wrapper forCalciteFactory
.The core component to handle through a SQL statement, from explain execution plan, to generate a Beam pipeline.LoadsUdfProvider
implementations from user-provided jars.Beam JDBC Connection.Calcite JDBC driver with Beam defaults.LazyAggregateCombineFn<InputT,AccumT, OutputT> Combine.CombineFn
that wraps anAggregateFn
.Exception thrown when Beam SQL is unable to parse the statement.An interface that planners should implement to convert sql statement toBeamRelNode
orSqlNode
.Reflection-based implementation logic forScalarFn
.Beam-customized version fromScalarFunctionImpl
, to address BEAM-5921.Exception thrown when BeamSQL cannot convert sql to BeamRelNode.Represents a parsed table name that is specified in a FROM clause (and other places).TVFSlidingWindowFn assigns window based on input row's "window_start" and "window_end" timestamps.UdafImpl<InputT,AccumT, OutputT> ImplementAggregateFunction
to take aCombine.CombineFn
as UDAF.Beam-customized version fromReflectiveFunctionBase
, to address BEAM-5921.Helps build lists ofFunctionParameter
.This is a class to indicate that a TVF is a ZetaSQL SQL native UDTVF.