use of io.confluent.ksql.parser.tree.Expression in project ksql by confluentinc.
the class AstBuilder method visitSelectSingle.
@Override
public Node visitSelectSingle(SqlBaseParser.SelectSingleContext context) {
Expression selectItemExpression = (Expression) visit(context.expression());
Optional<String> alias = Optional.ofNullable(context.identifier()).map(AstBuilder::getIdentifierText);
if (!alias.isPresent()) {
if (selectItemExpression instanceof QualifiedNameReference) {
QualifiedNameReference qualifiedNameReference = (QualifiedNameReference) selectItemExpression;
alias = Optional.of(qualifiedNameReference.getName().getSuffix());
} else if (selectItemExpression instanceof DereferenceExpression) {
DereferenceExpression dereferenceExpression = (DereferenceExpression) selectItemExpression;
if ((dataSourceExtractor.getJoinLeftSchema() != null) && (dataSourceExtractor.getCommonFieldNames().contains(dereferenceExpression.getFieldName()))) {
alias = Optional.of(dereferenceExpression.getBase().toString() + "_" + dereferenceExpression.getFieldName());
} else {
alias = Optional.of(dereferenceExpression.getFieldName());
}
} else {
alias = Optional.of("KSQL_COL_" + selectItemIndex);
}
} else {
alias = Optional.of(alias.get());
}
selectItemIndex++;
return new SingleColumn(getLocation(context), selectItemExpression, alias);
}
use of io.confluent.ksql.parser.tree.Expression in project ksql by confluentinc.
the class AstBuilder method visitFunctionCall.
@Override
public Node visitFunctionCall(SqlBaseParser.FunctionCallContext context) {
Optional<Window> window = visitIfPresent(context.over(), Window.class);
QualifiedName name = getQualifiedName(context.qualifiedName());
boolean distinct = false;
if (name.toString().equals("NULLIF")) {
check(context.expression().size() == 2, "Invalid number of arguments for 'nullif' function", context);
check(!window.isPresent(), "OVER clause not valid for 'nullif' function", context);
check(!distinct, "DISTINCT not valid for 'nullif' function", context);
return new NullIfExpression(getLocation(context), (Expression) visit(context.expression(0)), (Expression) visit(context.expression(1)));
}
return new FunctionCall(getLocation(context), getQualifiedName(context.qualifiedName()), window, distinct, visit(context.expression(), Expression.class));
}
use of io.confluent.ksql.parser.tree.Expression in project ksql by confluentinc.
the class KsqlRestApplication method buildApplication.
public static KsqlRestApplication buildApplication(KsqlRestConfig restConfig, boolean isUiEnabled, VersionCheckerAgent versionCheckerAgent) throws Exception {
Map<String, Object> ksqlConfProperties = new HashMap<>();
ksqlConfProperties.putAll(restConfig.getKsqlConfigProperties());
KsqlConfig ksqlConfig = new KsqlConfig(ksqlConfProperties);
adminClient = AdminClient.create(ksqlConfig.getKsqlAdminClientConfigProps());
KsqlEngine ksqlEngine = new KsqlEngine(ksqlConfig, new KafkaTopicClientImpl(adminClient));
KafkaTopicClient topicClient = ksqlEngine.getTopicClient();
final String kafkaClusterId;
try {
kafkaClusterId = adminClient.describeCluster().clusterId().get();
} catch (final UnsupportedVersionException e) {
throw new KsqlException("The kafka brokers are incompatible with. " + "KSQL requires broker versions >= 0.10.1.x");
}
String commandTopic = restConfig.getCommandTopic(ksqlConfig.getString(KsqlConfig.KSQL_SERVICE_ID_CONFIG));
ensureCommandTopic(restConfig, topicClient, commandTopic);
Map<String, Expression> commandTopicProperties = new HashMap<>();
commandTopicProperties.put(DdlConfig.VALUE_FORMAT_PROPERTY, new StringLiteral("json"));
commandTopicProperties.put(DdlConfig.KAFKA_TOPIC_NAME_PROPERTY, new StringLiteral(commandTopic));
ksqlEngine.getDdlCommandExec().execute(new RegisterTopicCommand(new RegisterTopic(QualifiedName.of(COMMANDS_KSQL_TOPIC_NAME), false, commandTopicProperties)));
ksqlEngine.getDdlCommandExec().execute(new CreateStreamCommand("statementText", new CreateStream(QualifiedName.of(COMMANDS_STREAM_NAME), Collections.singletonList(new TableElement("STATEMENT", "STRING")), false, Collections.singletonMap(DdlConfig.TOPIC_NAME_PROPERTY, new StringLiteral(COMMANDS_KSQL_TOPIC_NAME))), Collections.emptyMap(), ksqlEngine.getTopicClient(), true));
Map<String, Object> commandConsumerProperties = restConfig.getCommandConsumerProperties();
KafkaConsumer<CommandId, Command> commandConsumer = new KafkaConsumer<>(commandConsumerProperties, getJsonDeserializer(CommandId.class, true), getJsonDeserializer(Command.class, false));
KafkaProducer<CommandId, Command> commandProducer = new KafkaProducer<>(restConfig.getCommandProducerProperties(), getJsonSerializer(true), getJsonSerializer(false));
CommandStore commandStore = new CommandStore(commandTopic, commandConsumer, commandProducer, new CommandIdAssigner(ksqlEngine.getMetaStore()));
StatementParser statementParser = new StatementParser(ksqlEngine);
StatementExecutor statementExecutor = new StatementExecutor(ksqlEngine, statementParser);
CommandRunner commandRunner = new CommandRunner(statementExecutor, commandStore);
RootDocument rootDocument = new RootDocument(isUiEnabled, restConfig.getList(RestConfig.LISTENERS_CONFIG).get(0));
StatusResource statusResource = new StatusResource(statementExecutor);
StreamedQueryResource streamedQueryResource = new StreamedQueryResource(ksqlEngine, statementParser, restConfig.getLong(KsqlRestConfig.STREAMED_QUERY_DISCONNECT_CHECK_MS_CONFIG));
KsqlResource ksqlResource = new KsqlResource(ksqlEngine, commandStore, statementExecutor, restConfig.getLong(KsqlRestConfig.DISTRIBUTED_COMMAND_RESPONSE_TIMEOUT_MS_CONFIG));
commandRunner.processPriorCommands();
return new KsqlRestApplication(ksqlEngine, restConfig, commandRunner, rootDocument, statusResource, streamedQueryResource, ksqlResource, isUiEnabled, versionCheckerAgent, new ServerInfo(Version.getVersion(), kafkaClusterId));
}
use of io.confluent.ksql.parser.tree.Expression in project ksql by confluentinc.
the class AggregateAnalyzer method visitFunctionCall.
@Override
protected Node visitFunctionCall(final FunctionCall node, final AnalysisContext context) {
String functionName = node.getName().getSuffix();
if (functionRegistry.isAnAggregateFunction(functionName)) {
if (node.getArguments().isEmpty()) {
Expression argExpression;
if (analysis.getJoin() != null) {
Expression baseExpression = new QualifiedNameReference(QualifiedName.of(analysis.getJoin().getLeftAlias()));
argExpression = new DereferenceExpression(baseExpression, SchemaUtil.ROWTIME_NAME);
} else {
Expression baseExpression = new QualifiedNameReference(QualifiedName.of(analysis.getFromDataSources().get(0).getRight()));
argExpression = new DereferenceExpression(baseExpression, SchemaUtil.ROWTIME_NAME);
}
aggregateAnalysis.addAggregateFunctionArgument(argExpression);
node.getArguments().add(argExpression);
} else {
aggregateAnalysis.addAggregateFunctionArgument(node.getArguments().get(0));
}
aggregateAnalysis.addFunction(node);
hasAggregateFunction = true;
}
for (Expression argExp : node.getArguments()) {
process(argExp, context);
}
return null;
}
use of io.confluent.ksql.parser.tree.Expression in project ksql by confluentinc.
the class Analyzer method analyzeGroupBy.
private void analyzeGroupBy(final GroupBy groupBy) {
for (GroupingElement groupingElement : groupBy.getGroupingElements()) {
Set<Expression> groupingSet = groupingElement.enumerateGroupingSets().get(0);
analysis.getGroupByExpressions().addAll(groupingSet);
}
}
Aggregations