Skip to content
Merged
Show file tree
Hide file tree
Changes from all commits
Commits
File filter

Filter by extension

Filter by extension

Conversations
Failed to load comments.
Loading
Jump to
Jump to file
Failed to load files.
Loading
Diff view
Diff view
2 changes: 1 addition & 1 deletion .github/trigger_files/beam_PostCommit_XVR_Direct.json
Original file line number Diff line number Diff line change
@@ -1,4 +1,4 @@
{
"https://github.com/apache/beam/pull/32648": "testing Flink 1.19 support",
"modification": 2
"modification": 3
}
3 changes: 1 addition & 2 deletions .github/trigger_files/beam_PostCommit_XVR_Flink.json
Original file line number Diff line number Diff line change
@@ -1,4 +1,3 @@
{
"https://github.com/apache/beam/pull/32440": "testing datastream optimizations",
"https://github.com/apache/beam/pull/32648": "testing addition of Flink 1.19 support"
"modification": 1
}
1 change: 1 addition & 0 deletions CHANGES.md
Original file line number Diff line number Diff line change
Expand Up @@ -77,6 +77,7 @@
## Breaking Changes

* X behavior was changed ([#X](https://github.com/apache/beam/issues/X)).
* Previously deprecated Beam ZetaSQL component has been removed from new releases ([#34423](https://github.com/apache/beam/issues/34423)).

## Deprecations

Expand Down
1 change: 0 additions & 1 deletion build.gradle.kts
Original file line number Diff line number Diff line change
Expand Up @@ -385,7 +385,6 @@ tasks.register("sqlPreCommit") {
dependsOn(":sdks:java:extensions:sql:perf-tests:build")
dependsOn(":sdks:java:extensions:sql:udf-test-provider:build")
dependsOn(":sdks:java:extensions:sql:udf:build")
dependsOn(":sdks:java:extensions:sql:zetasql:build")
}

tasks.register("javaPreCommitPortabilityApi") {
Expand Down
2 changes: 1 addition & 1 deletion sdks/go/examples/xlang/sql/sql.go
Original file line number Diff line number Diff line change
Expand Up @@ -98,7 +98,7 @@ func main() {

// Options for the sql transform have to be defined before the Transform call.
var opts []sql.Option
// Dialect options are "calcite" and "zetasql"
// Dialect options is always "calcite"
opts = append(opts, sql.Dialect("calcite"))
// The expansion address can be specified per-call here or overwritten for all
// calls using xlangx.RegisterOverrideForUrn(sqlx.Urn, *expansionAddr).
Expand Down
2 changes: 1 addition & 1 deletion sdks/go/pkg/beam/transforms/sql/sql.go
Original file line number Diff line number Diff line change
Expand Up @@ -65,7 +65,7 @@ func OutputType(t reflect.Type, components ...typex.FullType) Option {
}
}

// Dialect specifies the SQL dialect, e.g. use 'zetasql' for ZetaSQL.
// Dialect specifies the SQL dialect. It is always Calcite
func Dialect(dialect string) Option {
return func(o sqlx.Options) {
o.(*options).dialect = dialect
Expand Down
1 change: 0 additions & 1 deletion sdks/go/pkg/beam/transforms/sql/sql_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -190,7 +190,6 @@ func TestMultipleOptions(t *testing.T) {
{
name: "all_options",
inputName: "test",
dialect: "zetasql",
expansionAddr: "localhost:8080",
typ: reflect.TypeOf(int64(0)),
customOpt: sqlx.Option{Urn: "test"},
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -43,9 +43,6 @@
<suppress id="ForbidNonVendoredGuava" files=".*bigtable.*BigtableServiceImplTest\.java" />
<suppress id="ForbidNonVendoredGuava" files=".*sql.*BeamValuesRel\.java" />
<suppress id="ForbidNonVendoredGuava" files=".*sql.*BeamEnumerableConverterTest\.java" />
<suppress id="ForbidNonVendoredGuava" files=".*zetasql.*TableScanConverter\.java" />
<suppress id="ForbidNonVendoredGuava" files=".*zetasql.*ExpressionConverter\.java" />
<suppress id="ForbidNonVendoredGuava" files=".*zetasql.*BeamZetaSqlCatalog\.java" />
<suppress id="ForbidNonVendoredGuava" files=".*pubsublite.*BufferingPullSubscriberTest\.java" />
<suppress id="ForbidNonVendoredGuava" files=".*cdap.*Plugin\.java" />
<suppress id="ForbidNonVendoredGuava" files=".*cdap.*PluginConfigInstantiationUtils\.java" />
Expand All @@ -69,13 +66,6 @@
<suppress id="ForbidNonVendoredGrpcProtobuf" files=".*extensions.*sql.*pubsublite.RowHandler.*" />
<suppress id="ForbidNonVendoredGrpcProtobuf" files=".*extensions.*sql.*ProtoPayloadSerializerProvider.*" />
<suppress id="ForbidNonVendoredGrpcProtobuf" files=".*datacatalog.*DataCatalogTableProvider\.java" />
<suppress id="ForbidNonVendoredGrpcProtobuf" files=".*zetasql.*DateTimeUtils\.java" />
<suppress id="ForbidNonVendoredGrpcProtobuf" files=".*zetasql.*ZetaSqlBeamTranslationUtils\.java" />
<suppress id="ForbidNonVendoredGrpcProtobuf" files=".*zetasql.*ZetaSqlDialectSpecTest\.java" />
<suppress id="ForbidNonVendoredGrpcProtobuf" files=".*zetasql.*ZetaSqlTimeFunctionsTest\.java" />
<suppress id="ForbidNonVendoredGrpcProtobuf" files=".*zetasql.*ZetaSqlBeamTranslationUtilsTest\.java" />
<suppress id="ForbidNonVendoredGrpcProtobuf" files=".*zetasql.*TableResolutionTest\.java" />
<suppress id="ForbidNonVendoredGrpcProtobuf" files=".*zetasql.*ZetaSQLPushDownTest\.java" />
<suppress id="ForbidNonVendoredGrpcProtobuf" files=".*examples.*datatokenization.*BigTableIO\.java" />
<suppress id="ForbidNonVendoredGrpcProtobuf" files=".*aws2.*kinesis.*RecordsAggregator\.java" />
<suppress id="ForbidNonVendoredGrpcProtobuf" files=".*testinfra.*pipelines.*" />
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -29,15 +29,15 @@ public class SqlTypes {

private SqlTypes() {}

/** Beam LogicalType corresponding to ZetaSQL/CalciteSQL DATE type. */
/** Beam LogicalType corresponding to CalciteSQL DATE type. */
public static final LogicalType<LocalDate, Long> DATE = new Date();

/** Beam LogicalType corresponding to ZetaSQL/CalciteSQL TIME type. */
/** Beam LogicalType corresponding to CalciteSQL TIME type. */
public static final LogicalType<LocalTime, Long> TIME = new Time();

/** Beam LogicalType corresponding to ZetaSQL DATETIME type. */
/** Beam LogicalType corresponding to DATETIME type. */
public static final LogicalType<LocalDateTime, Row> DATETIME = new DateTime();

/** Beam LogicalType corresponding to ZetaSQL TIMESTAMP type. */
/** Beam LogicalType corresponding to TIMESTAMP type. */
public static final LogicalType<Instant, Row> TIMESTAMP = new MicrosInstant();
}
1 change: 0 additions & 1 deletion sdks/java/extensions/sql/datacatalog/build.gradle
Original file line number Diff line number Diff line change
Expand Up @@ -46,7 +46,6 @@ dependencies {
implementation library.java.slf4j_api

testImplementation project(":sdks:java:extensions:sql")
testImplementation project(":sdks:java:extensions:sql:zetasql")
testImplementation project(":runners:direct-java")
testImplementation project(":sdks:java:io:google-cloud-platform")
testImplementation library.java.google_api_services_bigquery
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -26,7 +26,6 @@
import org.apache.beam.sdk.extensions.sql.impl.BeamSqlPipelineOptions;
import org.apache.beam.sdk.extensions.sql.impl.CalciteQueryPlanner;
import org.apache.beam.sdk.extensions.sql.impl.QueryPlanner;
import org.apache.beam.sdk.extensions.sql.zetasql.ZetaSQLQueryPlanner;
import org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO;
import org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO.Write.Method;
import org.apache.beam.sdk.io.gcp.bigquery.BigQueryUtils;
Expand Down Expand Up @@ -59,11 +58,7 @@ public static class DialectSensitiveTests {
/** Parameterized by which SQL dialect, since the syntax here is the same. */
@Parameterized.Parameters(name = "{0}")
public static Iterable<Object[]> dialects() {
return Arrays.asList(
new Object[][] {
{"ZetaSQL", ZetaSQLQueryPlanner.class},
{"CalciteSQL", CalciteQueryPlanner.class}
});
return Arrays.asList(new Object[][] {{"CalciteSQL", CalciteQueryPlanner.class}});
}

@SuppressWarnings("initialization.fields.uninitialized")
Expand Down
1 change: 0 additions & 1 deletion sdks/java/extensions/sql/expansion-service/build.gradle
Original file line number Diff line number Diff line change
Expand Up @@ -42,7 +42,6 @@ dependencies {
implementation project(path: ":sdks:java:expansion-service")
permitUnusedDeclared project(path: ":sdks:java:expansion-service") // BEAM-11761
implementation project(path: ":sdks:java:extensions:sql")
implementation project(path: ":sdks:java:extensions:sql:zetasql")
implementation library.java.vendored_guava_32_1_2_jre

}
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -23,7 +23,6 @@
import org.apache.beam.sdk.extensions.sql.SqlTransform;
import org.apache.beam.sdk.extensions.sql.impl.CalciteQueryPlanner;
import org.apache.beam.sdk.extensions.sql.impl.QueryPlanner;
import org.apache.beam.sdk.extensions.sql.zetasql.ZetaSQLQueryPlanner;
import org.apache.beam.sdk.transforms.ExternalTransformBuilder;
import org.apache.beam.sdk.transforms.PTransform;
import org.apache.beam.sdk.values.PCollection;
Expand All @@ -37,7 +36,6 @@ public class ExternalSqlTransformRegistrar implements ExternalTransformRegistrar
private static final String URN = "beam:external:java:sql:v1";
private static final ImmutableMap<String, Class<? extends QueryPlanner>> DIALECTS =
ImmutableMap.<String, Class<? extends QueryPlanner>>builder()
.put("zetasql", ZetaSQLQueryPlanner.class)
.put("calcite", CalciteQueryPlanner.class)
.build();

Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -50,9 +50,7 @@
public class SqlTransformSchemaTransformProvider implements SchemaTransformProvider {

private static final Map<String, Class<? extends QueryPlanner>> QUERY_PLANNERS =
ImmutableMap.of(
"zetasql", org.apache.beam.sdk.extensions.sql.zetasql.ZetaSQLQueryPlanner.class,
"calcite", org.apache.beam.sdk.extensions.sql.impl.CalciteQueryPlanner.class);
ImmutableMap.of("calcite", org.apache.beam.sdk.extensions.sql.impl.CalciteQueryPlanner.class);
private static final EnumerationType QUERY_ENUMERATION =
EnumerationType.create(QUERY_PLANNERS.keySet().stream().collect(Collectors.toList()));

Expand Down
75 changes: 0 additions & 75 deletions sdks/java/extensions/sql/zetasql/build.gradle

This file was deleted.

This file was deleted.

Loading
Loading