Many resources are needed to download a project. Please understand that we have to compensate our server costs. Thank you in advance. Project price only 1 $
You can buy this project and download/modify it how often you want.
/*
* Licensed to the Apache Software Foundation (ASF) under one or more
* contributor license agreements. See the NOTICE file distributed with
* this work for additional information regarding copyright ownership.
* The ASF licenses this file to You under the Apache License, Version 2.0
* (the "License"); you may not use this file except in compliance with
* the License. You may obtain a copy of the License at
*
* http://www.apache.org/licenses/LICENSE-2.0
*
* Unless required by applicable law or agreed to in writing, software
* distributed under the License is distributed on an "AS IS" BASIS,
* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
* See the License for the specific language governing permissions and
* limitations under the License.
*/
package org.apache.kafka.streams.kstream.internals;
import org.apache.kafka.common.serialization.Serdes;
import org.apache.kafka.common.utils.Bytes;
import org.apache.kafka.streams.kstream.Aggregator;
import org.apache.kafka.streams.kstream.Initializer;
import org.apache.kafka.streams.kstream.KGroupedTable;
import org.apache.kafka.streams.kstream.KTable;
import org.apache.kafka.streams.kstream.Materialized;
import org.apache.kafka.streams.kstream.Named;
import org.apache.kafka.streams.kstream.Reducer;
import org.apache.kafka.streams.kstream.internals.graph.GroupedTableOperationRepartitionNode;
import org.apache.kafka.streams.kstream.internals.graph.ProcessorParameters;
import org.apache.kafka.streams.kstream.internals.graph.StatefulProcessorNode;
import org.apache.kafka.streams.kstream.internals.graph.StreamsGraphNode;
import org.apache.kafka.streams.processor.ProcessorSupplier;
import org.apache.kafka.streams.state.KeyValueStore;
import java.util.Collections;
import java.util.Objects;
import java.util.Set;
/**
* The implementation class of {@link KGroupedTable}.
*
* @param the key type
* @param the value type
*/
public class KGroupedTableImpl extends AbstractStream implements KGroupedTable {
private static final String AGGREGATE_NAME = "KTABLE-AGGREGATE-";
private static final String REDUCE_NAME = "KTABLE-REDUCE-";
private final String userProvidedRepartitionTopicName;
private final Initializer countInitializer = () -> 0L;
private final Aggregator countAdder = (aggKey, value, aggregate) -> aggregate + 1L;
private final Aggregator countSubtractor = (aggKey, value, aggregate) -> aggregate - 1L;
private StreamsGraphNode repartitionGraphNode;
KGroupedTableImpl(final InternalStreamsBuilder builder,
final String name,
final Set subTopologySourceNodes,
final GroupedInternal groupedInternal,
final StreamsGraphNode streamsGraphNode) {
super(name, groupedInternal.keySerde(), groupedInternal.valueSerde(), subTopologySourceNodes, streamsGraphNode, builder);
this.userProvidedRepartitionTopicName = groupedInternal.name();
}
private KTable doAggregate(final ProcessorSupplier> aggregateSupplier,
final NamedInternal named,
final String functionName,
final MaterializedInternal> materialized) {
final String sinkName = named.suffixWithOrElseGet("-sink", builder, KStreamImpl.SINK_NAME);
final String sourceName = named.suffixWithOrElseGet("-source", builder, KStreamImpl.SOURCE_NAME);
final String funcName = named.orElseGenerateWithPrefix(builder, functionName);
final String repartitionTopic = (userProvidedRepartitionTopicName != null ? userProvidedRepartitionTopicName : materialized.storeName())
+ KStreamImpl.REPARTITION_TOPIC_SUFFIX;
if (repartitionGraphNode == null || userProvidedRepartitionTopicName == null) {
repartitionGraphNode = createRepartitionNode(sinkName, sourceName, repartitionTopic);
}
// the passed in StreamsGraphNode must be the parent of the repartition node
builder.addGraphNode(this.streamsGraphNode, repartitionGraphNode);
final StatefulProcessorNode statefulProcessorNode = new StatefulProcessorNode<>(
funcName,
new ProcessorParameters<>(aggregateSupplier, funcName),
new TimestampedKeyValueStoreMaterializer<>(materialized).materialize()
);
// now the repartition node must be the parent of the StateProcessorNode
builder.addGraphNode(repartitionGraphNode, statefulProcessorNode);
// return the KTable representation with the intermediate topic as the sources
return new KTableImpl<>(funcName,
materialized.keySerde(),
materialized.valueSerde(),
Collections.singleton(sourceName),
materialized.queryableStoreName(),
aggregateSupplier,
statefulProcessorNode,
builder);
}
private GroupedTableOperationRepartitionNode createRepartitionNode(final String sinkName,
final String sourceName,
final String topic) {
return GroupedTableOperationRepartitionNode.groupedTableOperationNodeBuilder()
.withRepartitionTopic(topic)
.withSinkName(sinkName)
.withSourceName(sourceName)
.withKeySerde(keySerde)
.withValueSerde(valueSerde)
.withNodeName(sourceName).build();
}
@Override
public KTable reduce(final Reducer adder,
final Reducer subtractor,
final Materialized> materialized) {
return reduce(adder, subtractor, NamedInternal.empty(), materialized);
}
@Override
public KTable reduce(final Reducer adder,
final Reducer subtractor,
final Named named,
final Materialized> materialized) {
Objects.requireNonNull(adder, "adder can't be null");
Objects.requireNonNull(subtractor, "subtractor can't be null");
Objects.requireNonNull(named, "named can't be null");
Objects.requireNonNull(materialized, "materialized can't be null");
final MaterializedInternal> materializedInternal =
new MaterializedInternal<>(materialized, builder, AGGREGATE_NAME);
if (materializedInternal.keySerde() == null) {
materializedInternal.withKeySerde(keySerde);
}
if (materializedInternal.valueSerde() == null) {
materializedInternal.withValueSerde(valueSerde);
}
final ProcessorSupplier> aggregateSupplier = new KTableReduce<>(
materializedInternal.storeName(),
adder,
subtractor);
return doAggregate(aggregateSupplier, new NamedInternal(named), REDUCE_NAME, materializedInternal);
}
@Override
public KTable reduce(final Reducer adder,
final Reducer subtractor) {
return reduce(adder, subtractor, Materialized.with(keySerde, valueSerde));
}
@Override
public KTable count(final Materialized> materialized) {
return count(NamedInternal.empty(), materialized);
}
@Override
public KTable count(final Named named, final Materialized> materialized) {
final MaterializedInternal> materializedInternal =
new MaterializedInternal<>(materialized, builder, AGGREGATE_NAME);
if (materializedInternal.keySerde() == null) {
materializedInternal.withKeySerde(keySerde);
}
if (materializedInternal.valueSerde() == null) {
materializedInternal.withValueSerde(Serdes.Long());
}
final ProcessorSupplier> aggregateSupplier = new KTableAggregate<>(
materializedInternal.storeName(),
countInitializer,
countAdder,
countSubtractor);
return doAggregate(aggregateSupplier, new NamedInternal(named), AGGREGATE_NAME, materializedInternal);
}
@Override
public KTable count() {
return count(Materialized.with(keySerde, Serdes.Long()));
}
@Override
public KTable count(final Named named) {
return count(named, Materialized.with(keySerde, Serdes.Long()));
}
@Override
public KTable aggregate(final Initializer initializer,
final Aggregator super K, ? super V, VR> adder,
final Aggregator super K, ? super V, VR> subtractor,
final Materialized> materialized) {
return aggregate(initializer, adder, subtractor, NamedInternal.empty(), materialized);
}
@Override
public KTable aggregate(final Initializer initializer,
final Aggregator super K, ? super V, VR> adder,
final Aggregator super K, ? super V, VR> subtractor,
final Named named,
final Materialized> materialized) {
Objects.requireNonNull(initializer, "initializer can't be null");
Objects.requireNonNull(adder, "adder can't be null");
Objects.requireNonNull(subtractor, "subtractor can't be null");
Objects.requireNonNull(named, "named can't be null");
Objects.requireNonNull(materialized, "materialized can't be null");
final MaterializedInternal> materializedInternal =
new MaterializedInternal<>(materialized, builder, AGGREGATE_NAME);
if (materializedInternal.keySerde() == null) {
materializedInternal.withKeySerde(keySerde);
}
final ProcessorSupplier> aggregateSupplier = new KTableAggregate<>(
materializedInternal.storeName(),
initializer,
adder,
subtractor);
return doAggregate(aggregateSupplier, new NamedInternal(named), AGGREGATE_NAME, materializedInternal);
}
@Override
public KTable aggregate(final Initializer initializer,
final Aggregator super K, ? super V, T> adder,
final Aggregator super K, ? super V, T> subtractor,
final Named named) {
return aggregate(initializer, adder, subtractor, named, Materialized.with(keySerde, null));
}
@Override
public KTable aggregate(final Initializer initializer,
final Aggregator super K, ? super V, T> adder,
final Aggregator super K, ? super V, T> subtractor) {
return aggregate(initializer, adder, subtractor, Materialized.with(keySerde, null));
}
}