You are viewing a plain text version of this content. The canonical link for it is here.
Posted to jira@kafka.apache.org by "Richard Yu (JIRA)" <ji...@apache.org> on 2017/12/15 22:00:21 UTC

[jira] [Issue Comment Deleted] (KAFKA-6265) GlobalKTable missing #queryableStoreName()

     [ https://issues.apache.org/jira/browse/KAFKA-6265?page=com.atlassian.jira.plugin.system.issuetabpanels:all-tabpanel ]

Richard Yu updated KAFKA-6265:
------------------------------
    Comment: was deleted

(was: I am not sure if this is a second way to instantiate it: (I found it in {{KStreamBuilder}})

{code:java}
    @SuppressWarnings("unchecked")
    private <K, V> GlobalKTable<K, V> doGlobalTable(final Serde<K> keySerde,
                                                    final Serde<V> valSerde,
                                                    final TimestampExtractor timestampExtractor,
                                                    final String topic,
                                                    final org.apache.kafka.streams.processor.StateStoreSupplier<KeyValueStore> storeSupplier) {
        try {
            Objects.requireNonNull(storeSupplier, "storeSupplier can't be null");
            final String sourceName = newName(KStreamImpl.SOURCE_NAME);
            final String processorName = newName(KTableImpl.SOURCE_NAME);
            final KTableSource<K, V> tableSource = new KTableSource<>(storeSupplier.name());

            final Deserializer<K> keyDeserializer = keySerde == null ? null : keySerde.deserializer();
            final Deserializer<V> valueDeserializer = valSerde == null ? null : valSerde.deserializer();

            internalTopologyBuilder.addGlobalStore(storeSupplier, sourceName, timestampExtractor, keyDeserializer, valueDeserializer, topic, processorName, tableSource);
            return new GlobalKTableImpl(new KTableSourceValueGetterSupplier<>(storeSupplier.name()));
        } catch (final org.apache.kafka.streams.errors.TopologyException e) {
            throw new org.apache.kafka.streams.errors.TopologyBuilderException(e);
        }
    }
{code}

The constructor for {{GlobalKTableImpl}} is called here. Does this affect our approach in any way?)

> GlobalKTable missing #queryableStoreName()
> ------------------------------------------
>
>                 Key: KAFKA-6265
>                 URL: https://issues.apache.org/jira/browse/KAFKA-6265
>             Project: Kafka
>          Issue Type: Bug
>          Components: streams
>    Affects Versions: 1.0.0
>            Reporter: Antony Stubbs
>              Labels: beginner, needs-kip, newbie
>
> KTable has the nicely useful #queryableStoreName(), it seems to be missing from GlobalKTable



--
This message was sent by Atlassian JIRA
(v6.4.14#64029)