@ApplicationScoped public class StreamsRegistryConfiguration extends Object
Constructor and Description |
---|
StreamsRegistryConfiguration() |
Modifier and Type | Method and Description |
---|---|
ForeachActionDispatcher<String,Str.Data> |
dataDispatcher() |
void |
destroy(io.quarkus.runtime.ShutdownEvent event,
org.apache.kafka.streams.KafkaStreams streams) |
void |
destroy(io.quarkus.runtime.ShutdownEvent event,
Lifecycle lifecycle) |
void |
destroyGlobaIdStore(io.quarkus.runtime.ShutdownEvent event,
org.apache.kafka.streams.state.ReadOnlyKeyValueStore<Long,Str.TupleValue> store) |
void |
destroyStateService(io.quarkus.runtime.ShutdownEvent event,
AsyncBiFunctionService<Void,Void,org.apache.kafka.streams.KafkaStreams.State> service) |
void |
destroyStorageStore(io.quarkus.runtime.ShutdownEvent event,
ExtReadOnlyKeyValueStore<String,Str.Data> store) |
void |
destroyWaitForDataUpdateService(io.quarkus.runtime.ShutdownEvent event,
AsyncBiFunctionService<String,Long,Str.Data> service) |
FilterPredicate<String,Str.Data> |
filterPredicate() |
org.apache.kafka.streams.state.ReadOnlyKeyValueStore<Long,Str.TupleValue> |
globalIdKeyValueStore(org.apache.kafka.streams.KafkaStreams streams,
org.apache.kafka.streams.state.HostInfo storageLocalHost,
StreamsProperties properties) |
void |
init(io.quarkus.runtime.StartupEvent event,
org.apache.kafka.streams.KafkaStreams streams) |
void |
init(io.quarkus.runtime.StartupEvent event,
Lifecycle lifecycle) |
LocalService<AsyncBiFunctionService.WithSerdes<Void,Void,org.apache.kafka.streams.KafkaStreams.State>> |
localStateService(StateService localService) |
LocalService<AsyncBiFunctionService.WithSerdes<String,Long,Str.Data>> |
localWaitForDataService(WaitForDataService localService) |
AsyncBiFunctionService<Void,Void,org.apache.kafka.streams.KafkaStreams.State> |
stateService(org.apache.kafka.streams.KafkaStreams streams,
org.apache.kafka.streams.state.HostInfo storageLocalHost,
LocalService<AsyncBiFunctionService.WithSerdes<Void,Void,org.apache.kafka.streams.KafkaStreams.State>> localStateService) |
StateService |
stateServiceImpl(org.apache.kafka.streams.KafkaStreams streams) |
void |
stopStorageProducer(ProducerActions<String,Str.StorageValue> producer) |
AsyncBiFunctionServiceGrpc.AsyncBiFunctionServiceImplBase |
storageAsyncBiFunctionServiceGrpcImpl(LocalService<AsyncBiFunctionService.WithSerdes<String,Long,Str.Data>> localWaitForDataService,
LocalService<AsyncBiFunctionService.WithSerdes<Void,Void,org.apache.kafka.streams.KafkaStreams.State>> localStateService) |
Lifecycle |
storageGrpcServer(org.apache.kafka.streams.state.HostInfo storageLocalHost,
KeyValueStoreGrpc.KeyValueStoreImplBase storageStoreGrpcImpl,
AsyncBiFunctionServiceGrpc.AsyncBiFunctionServiceImplBase storageAsyncBiFunctionServiceGrpcImpl) |
ExtReadOnlyKeyValueStore<String,Str.Data> |
storageKeyValueStore(org.apache.kafka.streams.KafkaStreams streams,
org.apache.kafka.streams.state.HostInfo storageLocalHost,
StreamsProperties properties,
FilterPredicate<String,Str.Data> filterPredicate) |
org.apache.kafka.streams.state.HostInfo |
storageLocalHost(StreamsProperties props) |
ProducerActions<String,Str.StorageValue> |
storageProducer(Properties properties) |
org.apache.kafka.streams.KafkaStreams |
storageStreams(StreamsProperties properties,
org.apache.kafka.streams.kstream.ForeachAction<? super String,? super Str.Data> dataDispatcher,
ArtifactTypeUtilProviderFactory factory) |
KeyValueStoreGrpc.KeyValueStoreImplBase |
streamsKeyValueStoreGrpcImpl(org.apache.kafka.streams.KafkaStreams streams,
StreamsProperties props,
FilterPredicate<String,Str.Data> filterPredicate) |
StreamsProperties |
streamsProperties(Properties properties) |
WaitForDataService |
waitForDataServiceImpl(org.apache.kafka.streams.state.ReadOnlyKeyValueStore<String,Str.Data> storageKeyValueStore,
ForeachActionDispatcher<String,Str.Data> storageDispatcher) |
AsyncBiFunctionService<String,Long,Str.Data> |
waitForDataUpdateService(StreamsProperties properties,
org.apache.kafka.streams.KafkaStreams streams,
org.apache.kafka.streams.state.HostInfo storageLocalHost,
LocalService<AsyncBiFunctionService.WithSerdes<String,Long,Str.Data>> localWaitForDataUpdateService) |
@Produces @ApplicationScoped public StreamsProperties streamsProperties(Properties properties)
@Produces @ApplicationScoped public ProducerActions<String,Str.StorageValue> storageProducer(Properties properties)
public void stopStorageProducer(@Disposes ProducerActions<String,Str.StorageValue> producer) throws Exception
Exception
@Produces @Singleton public org.apache.kafka.streams.KafkaStreams storageStreams(StreamsProperties properties, org.apache.kafka.streams.kstream.ForeachAction<? super String,? super Str.Data> dataDispatcher, ArtifactTypeUtilProviderFactory factory)
public void init(@Observes io.quarkus.runtime.StartupEvent event, org.apache.kafka.streams.KafkaStreams streams)
public void destroy(@Observes io.quarkus.runtime.ShutdownEvent event, org.apache.kafka.streams.KafkaStreams streams)
@Produces @Singleton public org.apache.kafka.streams.state.HostInfo storageLocalHost(StreamsProperties props)
@Produces @ApplicationScoped public FilterPredicate<String,Str.Data> filterPredicate()
@Produces @ApplicationScoped public ExtReadOnlyKeyValueStore<String,Str.Data> storageKeyValueStore(org.apache.kafka.streams.KafkaStreams streams, org.apache.kafka.streams.state.HostInfo storageLocalHost, StreamsProperties properties, FilterPredicate<String,Str.Data> filterPredicate)
public void destroyStorageStore(@Observes io.quarkus.runtime.ShutdownEvent event, ExtReadOnlyKeyValueStore<String,Str.Data> store)
@Produces @ApplicationScoped public org.apache.kafka.streams.state.ReadOnlyKeyValueStore<Long,Str.TupleValue> globalIdKeyValueStore(org.apache.kafka.streams.KafkaStreams streams, org.apache.kafka.streams.state.HostInfo storageLocalHost, StreamsProperties properties)
public void destroyGlobaIdStore(@Observes io.quarkus.runtime.ShutdownEvent event, org.apache.kafka.streams.state.ReadOnlyKeyValueStore<Long,Str.TupleValue> store)
@Produces @Singleton public ForeachActionDispatcher<String,Str.Data> dataDispatcher()
@Produces @Singleton public WaitForDataService waitForDataServiceImpl(org.apache.kafka.streams.state.ReadOnlyKeyValueStore<String,Str.Data> storageKeyValueStore, ForeachActionDispatcher<String,Str.Data> storageDispatcher)
@Produces @Singleton public LocalService<AsyncBiFunctionService.WithSerdes<String,Long,Str.Data>> localWaitForDataService(WaitForDataService localService)
@Produces @ApplicationScoped public AsyncBiFunctionService<String,Long,Str.Data> waitForDataUpdateService(StreamsProperties properties, org.apache.kafka.streams.KafkaStreams streams, org.apache.kafka.streams.state.HostInfo storageLocalHost, LocalService<AsyncBiFunctionService.WithSerdes<String,Long,Str.Data>> localWaitForDataUpdateService)
public void destroyWaitForDataUpdateService(@Observes io.quarkus.runtime.ShutdownEvent event, AsyncBiFunctionService<String,Long,Str.Data> service)
@Produces @Singleton public StateService stateServiceImpl(org.apache.kafka.streams.KafkaStreams streams)
@Produces @Singleton public LocalService<AsyncBiFunctionService.WithSerdes<Void,Void,org.apache.kafka.streams.KafkaStreams.State>> localStateService(StateService localService)
@Produces @ApplicationScoped public AsyncBiFunctionService<Void,Void,org.apache.kafka.streams.KafkaStreams.State> stateService(org.apache.kafka.streams.KafkaStreams streams, org.apache.kafka.streams.state.HostInfo storageLocalHost, LocalService<AsyncBiFunctionService.WithSerdes<Void,Void,org.apache.kafka.streams.KafkaStreams.State>> localStateService)
public void destroyStateService(@Observes io.quarkus.runtime.ShutdownEvent event, AsyncBiFunctionService<Void,Void,org.apache.kafka.streams.KafkaStreams.State> service)
@Produces @ApplicationScoped public Lifecycle storageGrpcServer(org.apache.kafka.streams.state.HostInfo storageLocalHost, KeyValueStoreGrpc.KeyValueStoreImplBase storageStoreGrpcImpl, AsyncBiFunctionServiceGrpc.AsyncBiFunctionServiceImplBase storageAsyncBiFunctionServiceGrpcImpl)
public void init(@Observes io.quarkus.runtime.StartupEvent event, Lifecycle lifecycle)
public void destroy(@Observes io.quarkus.runtime.ShutdownEvent event, Lifecycle lifecycle)
@Produces @Singleton public KeyValueStoreGrpc.KeyValueStoreImplBase streamsKeyValueStoreGrpcImpl(org.apache.kafka.streams.KafkaStreams streams, StreamsProperties props, FilterPredicate<String,Str.Data> filterPredicate)
@Produces @Singleton public AsyncBiFunctionServiceGrpc.AsyncBiFunctionServiceImplBase storageAsyncBiFunctionServiceGrpcImpl(LocalService<AsyncBiFunctionService.WithSerdes<String,Long,Str.Data>> localWaitForDataService, LocalService<AsyncBiFunctionService.WithSerdes<Void,Void,org.apache.kafka.streams.KafkaStreams.State>> localStateService)
Copyright © 2020 Red Hat. All rights reserved.