Trait

com.twitter.finatra.kafkastreams.dsl

FinatraDslWindowedAggregations

Related Doc: package dsl

Permalink

trait FinatraDslWindowedAggregations extends KafkaStreamsTwitterServer with FlushingAwareServer with FinatraTransformerFlags with ScalaStreamsImplicits with Logging

This trait adds Enhanced Windowed Aggregation DSL methods which offer additional control that is not included in the default Kafka Streams DSL

Note: We extend FlushingAwareServer, because WindowStore flags are used by the AggregatorTransformer which requires us to be a "Flushing Aware" server. We plan to improve this coupling in the future.

Linear Supertypes
FinatraTransformerFlags, FlushingAwareServer, KafkaStreamsTwitterServer, ScalaStreamsImplicits, KafkaFlagUtils, TwitterServer, Warmup, Ports, DeprecatedLogging, Logging, TwitterServer, Lifecycle, AdminHttpServer, Hooks, DtabFlags, Linters, Stats, Slf4jBridge, App, Logging, Logging, App, CloseOnceAwaitably, CloseOnceAwaitably0[Unit], Awaitable[Unit], ClosableOnce, CloseOnce, Closable, AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. FinatraDslWindowedAggregations
  2. FinatraTransformerFlags
  3. FlushingAwareServer
  4. KafkaStreamsTwitterServer
  5. ScalaStreamsImplicits
  6. KafkaFlagUtils
  7. TwitterServer
  8. Warmup
  9. Ports
  10. DeprecatedLogging
  11. Logging
  12. TwitterServer
  13. Lifecycle
  14. AdminHttpServer
  15. Hooks
  16. DtabFlags
  17. Linters
  18. Stats
  19. Slf4jBridge
  20. App
  21. Logging
  22. Logging
  23. App
  24. CloseOnceAwaitably
  25. CloseOnceAwaitably0
  26. Awaitable
  27. ClosableOnce
  28. CloseOnce
  29. Closable
  30. AnyRef
  31. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Type Members

  1. implicit class FinatraKStream[K] extends Logging

    Permalink
  2. implicit class FinatraKeyToWindowedValueStream[K, TimeWindowedType <: TimeWindowed[Int]] extends Logging

    Permalink
  3. implicit class FinatraKeyValueStream[K, V] extends AnyRef

    Permalink
  4. implicit class KStreamJConversions[K, V] extends AnyRef

    Permalink
    Definition Classes
    ScalaStreamsImplicits
  5. implicit class KStreamSConversions[K, V] extends AnyRef

    Permalink
    Definition Classes
    ScalaStreamsImplicits
  6. implicit class StreamsBuilderConversions extends AnyRef

    Permalink
    Definition Classes
    ScalaStreamsImplicits

Abstract Value Members

  1. abstract def configureKafkaStreams(builder: StreamsBuilder): Unit

    Permalink

    Callback method which is executed after the injector is created and before any other lifecycle methods.

    Callback method which is executed after the injector is created and before any other lifecycle methods.

    Use the provided StreamsBuilder to create your KafkaStreams topology.

    Attributes
    protected
    Definition Classes
    KafkaStreamsTwitterServer
    Note

    It is NOT expected that you block in this method as you will prevent completion of the server lifecycle.

Concrete Value Members

  1. final def !=(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  2. final def ##(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  3. final def ==(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  4. final val MinGrace: Duration

    Permalink
    Definition Classes
    App
  5. def addAdminRoute(route: Route): Unit

    Permalink
    Definition Classes
    AdminHttpServer
  6. def addAdminRoutes(newRoutes: Seq[Route]): Unit

    Permalink
    Definition Classes
    AdminHttpServer
  7. def addDtabs(): Unit

    Permalink
    Definition Classes
    DtabFlags
  8. def addFrameworkModule(module: Module): Unit

    Permalink
    Attributes
    protected[com.twitter]
    Definition Classes
    App
  9. def addFrameworkModules(modules: Module*): Unit

    Permalink
    Attributes
    protected[com.twitter]
    Definition Classes
    App
  10. def addFrameworkOverrideModules(modules: Module*): Unit

    Permalink
    Attributes
    protected[com.twitter.inject]
    Definition Classes
    App
  11. def adminBoundAddress: InetSocketAddress

    Permalink
    Definition Classes
    AdminHttpServer
  12. var adminHttpServer: ListeningServer

    Permalink
    Attributes
    protected
    Definition Classes
    AdminHttpServer
  13. val adminPort: Flag[InetSocketAddress]

    Permalink
    Definition Classes
    AdminHttpServer
  14. def afterPostWarmup(): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    TwitterServer → App
    Annotations
    @Lifecycle()
  15. def allowUndefinedFlags: Boolean

    Permalink
    Attributes
    protected
    Definition Classes
    App
  16. val allowedLateness: Flag[Duration]

    Permalink
    Attributes
    protected
  17. val appendFlag: Flag[Boolean]

    Permalink
    Attributes
    protected[this]
    Definition Classes
    Logging
  18. val applicationId: Flag[String]

    Permalink
    Attributes
    protected[com.twitter.finatra.kafkastreams]
    Definition Classes
    KafkaStreamsTwitterServer
  19. val applicationServerConfig: Flag[String]

    Permalink
    Attributes
    protected[com.twitter.finatra.kafkastreams]
    Definition Classes
    KafkaStreamsTwitterServer
  20. def args: Array[String]

    Permalink
    Definition Classes
    App
  21. final def asInstanceOf[T0]: T0

    Permalink
    Definition Classes
    Any
  22. val asyncFlag: Flag[Boolean]

    Permalink
    Attributes
    protected[this]
    Definition Classes
    Logging
  23. val asyncMaxSizeFlag: Flag[Int]

    Permalink
    Attributes
    protected[this]
    Definition Classes
    Logging
  24. val autoWatermarkIntervalFlag: Flag[Duration]

    Permalink
    Attributes
    protected
    Definition Classes
    FinatraTransformerFlags
  25. def await(awaitables: Awaitable[_]*): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    TwitterServer
  26. def await[T <: Awaitable[_]](awaitable: T): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    TwitterServer
  27. def beforePostWarmup(): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    TwitterServer → App
    Annotations
    @Lifecycle()
  28. val bootstrapServer: Flag[String]

    Permalink
    Attributes
    protected[com.twitter.finatra.kafkastreams]
    Definition Classes
    KafkaStreamsTwitterServer
  29. def clone(): AnyRef

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  30. final def close(deadline: Time): Future[Unit]

    Permalink
    Definition Classes
    CloseOnce
  31. def close(after: Duration): Future[Unit]

    Permalink
    Definition Classes
    Closable
  32. final def close(): Future[Unit]

    Permalink
    Definition Classes
    Closable
  33. final def closeFuture: Future[Unit]

    Permalink
    Attributes
    protected
    Definition Classes
    CloseOnce
  34. final def closeOnExit(closable: Closable): Unit

    Permalink
    Definition Classes
    App
  35. final def closeOnExitLast(closable: Closable): Unit

    Permalink
    Definition Classes
    App
  36. def closeOnce(deadline: Time): Future[Unit]

    Permalink
    Attributes
    protected
    Definition Classes
    App → CloseOnce
  37. val commitInterval: Flag[Duration]

    Permalink
    Attributes
    protected
    Definition Classes
    KafkaStreamsTwitterServer
  38. def configureAdminHttpServer(server: Server): Server

    Permalink
    Attributes
    protected
    Definition Classes
    AdminHttpServer
  39. def configureLoggerFactories(): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    DeprecatedLogging → Logging
  40. def consumerFlagWithKafkaDefault[T](key: String)(implicit arg0: Flaggable[T]): Flag[T]

    Permalink

    Create a flag prefixed by "kafka.consumer." with a default value and help string that is populated from the Kafka ConsumerConfig class

    Create a flag prefixed by "kafka.consumer." with a default value and help string that is populated from the Kafka ConsumerConfig class

    T

    Type of the flag value

    key

    Name of the KafkaStreams flag as specified in the ConsumerConfig class

    returns

    Flag for the specified key

    Definition Classes
    KafkaFlagUtils
  41. def createAndStartKafkaStreams(): Unit

    Permalink
    Attributes
    protected[com.twitter.finatra]
    Definition Classes
    KafkaStreamsTwitterServer
  42. def createKafkaStreamsProperties(): Properties

    Permalink
    Attributes
    protected[com.twitter.finatra]
    Definition Classes
    KafkaStreamsTwitterServer
  43. def createKafkaStreamsTopology(): Topology

    Permalink
    Attributes
    protected[com.twitter.finatra]
    Definition Classes
    KafkaStreamsTwitterServer
  44. def debug(marker: Marker, message: ⇒ Any, cause: Throwable): Unit

    Permalink
    Attributes
    protected[this]
    Definition Classes
    Logging
  45. def debug(message: ⇒ Any, cause: Throwable): Unit

    Permalink
    Attributes
    protected[this]
    Definition Classes
    Logging
  46. def debug(marker: Marker, message: ⇒ Any): Unit

    Permalink
    Attributes
    protected[this]
    Definition Classes
    Logging
  47. def debug(message: ⇒ Any): Unit

    Permalink
    Attributes
    protected[this]
    Definition Classes
    Logging
  48. def debugFutureResult[T](msg: String)(func: ⇒ Future[T]): Future[T]

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  49. def debugResult[T](message: ⇒ String)(fn: ⇒ T): T

    Permalink
    Attributes
    protected[this]
    Definition Classes
    Logging
  50. def defaultAdminPort: Int

    Permalink
    Definition Classes
    AdminHttpServer
  51. def defaultAppend: Boolean

    Permalink
    Definition Classes
    Logging
  52. val defaultCloseGracePeriod: Duration

    Permalink
    Definition Classes
    KafkaStreamsTwitterServer → App
  53. def defaultFormatter: Formatter

    Permalink
    Definition Classes
    Logging
  54. def defaultLogLevel: Level

    Permalink
    Definition Classes
    Logging
  55. def defaultOutput: String

    Permalink
    Definition Classes
    Logging
  56. def defaultRollPolicy: Policy

    Permalink
    Definition Classes
    Logging
  57. def defaultRotateCount: Int

    Permalink
    Definition Classes
    Logging
  58. def disableAdminHttpServer: Boolean

    Permalink
    Attributes
    protected
    Definition Classes
    AdminHttpServer
  59. val dtabAddBaseFlag: Flag[Dtab]

    Permalink
    Definition Classes
    DtabFlags
  60. val emitOnClose: Flag[Boolean]

    Permalink
    Attributes
    protected
  61. val emitUpdatedEntriesOnCommit: Flag[Boolean]

    Permalink
    Attributes
    protected
  62. val emitWatermarkPerMessageFlag: Flag[Boolean]

    Permalink
    Attributes
    protected
    Definition Classes
    FinatraTransformerFlags
  63. final def eq(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  64. def equals(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  65. def error(marker: Marker, message: ⇒ Any, cause: Throwable): Unit

    Permalink
    Attributes
    protected[this]
    Definition Classes
    Logging
  66. def error(message: ⇒ Any, cause: Throwable): Unit

    Permalink
    Attributes
    protected[this]
    Definition Classes
    Logging
  67. def error(marker: Marker, message: ⇒ Any): Unit

    Permalink
    Attributes
    protected[this]
    Definition Classes
    Logging
  68. def error(message: ⇒ Any): Unit

    Permalink
    Attributes
    protected[this]
    Definition Classes
    Logging
  69. def errorResult[T](message: ⇒ String)(fn: ⇒ T): T

    Permalink
    Attributes
    protected[this]
    Definition Classes
    Logging
  70. def exitOnError(reason: String, details: ⇒ String): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    App
  71. def exitOnError(reason: String): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    App
  72. def exitOnError(throwable: Throwable): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    App
  73. def failfastOnFlagsNotParsed: Boolean

    Permalink
    Attributes
    protected
    Definition Classes
    App → App
  74. def finalize(): Unit

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  75. val flag: Flags

    Permalink
    Definition Classes
    App
  76. def flagWithKafkaDefault[T](key: String)(implicit arg0: Flaggable[T]): Flag[T]

    Permalink

    Create a flag prefixed by "kafka." with a default value and help string that is populated from the Kafka Streams StreamsConfig class

    Create a flag prefixed by "kafka." with a default value and help string that is populated from the Kafka Streams StreamsConfig class

    T

    Type of the flag value

    key

    Name of the KafkaStreams flag as specified in the StreamsConfig class

    returns

    Flag for the specified key

    Definition Classes
    KafkaFlagUtils
  77. final def getClass(): Class[_]

    Permalink
    Definition Classes
    AnyRef → Any
  78. val group: String

    Permalink
    Definition Classes
    Lifecycle
  79. def handle(clazz: Class[_ <: Handler]): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    TwitterServer
  80. def handle[T <: Handler]()(implicit arg0: Manifest[T]): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    TwitterServer
  81. def handlers: List[() ⇒ Handler]

    Permalink
    Definition Classes
    Logging
  82. def hashCode(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  83. def httpExternalPort: Option[Int]

    Permalink
    Definition Classes
    Ports
  84. def httpsExternalPort: Option[Int]

    Permalink
    Definition Classes
    Ports
  85. val inferClassNamesFlag: Flag[Boolean]

    Permalink
    Attributes
    protected[this]
    Definition Classes
    Logging
  86. def info(marker: Marker, message: ⇒ Any, cause: Throwable): Unit

    Permalink
    Attributes
    protected[this]
    Definition Classes
    Logging
  87. def info(message: ⇒ Any, cause: Throwable): Unit

    Permalink
    Attributes
    protected[this]
    Definition Classes
    Logging
  88. def info(marker: Marker, message: ⇒ Any): Unit

    Permalink
    Attributes
    protected[this]
    Definition Classes
    Logging
  89. def info(message: ⇒ Any): Unit

    Permalink
    Attributes
    protected[this]
    Definition Classes
    Logging
  90. def infoResult[T](message: ⇒ String)(fn: ⇒ T): T

    Permalink
    Attributes
    protected[this]
    Definition Classes
    Logging
  91. final def init(f: ⇒ Unit): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    App
  92. def injector: Injector

    Permalink
    Definition Classes
    App
  93. final def isClosed: Boolean

    Permalink
    Definition Classes
    CloseOnce
  94. def isDebugEnabled(marker: Marker): Boolean

    Permalink
    Attributes
    protected[this]
    Definition Classes
    Logging
  95. def isDebugEnabled: Boolean

    Permalink
    Attributes
    protected[this]
    Definition Classes
    Logging
  96. def isErrorEnabled(marker: Marker): Boolean

    Permalink
    Attributes
    protected[this]
    Definition Classes
    Logging
  97. def isErrorEnabled: Boolean

    Permalink
    Attributes
    protected[this]
    Definition Classes
    Logging
  98. def isInfoEnabled(marker: Marker): Boolean

    Permalink
    Attributes
    protected[this]
    Definition Classes
    Logging
  99. def isInfoEnabled: Boolean

    Permalink
    Attributes
    protected[this]
    Definition Classes
    Logging
  100. final def isInstanceOf[T0]: Boolean

    Permalink
    Definition Classes
    Any
  101. def isReady(implicit permit: CanAwait): Boolean

    Permalink
    Definition Classes
    CloseOnceAwaitably0 → Awaitable
  102. def isTraceEnabled(marker: Marker): Boolean

    Permalink
    Attributes
    protected[this]
    Definition Classes
    Logging
  103. def isTraceEnabled: Boolean

    Permalink
    Attributes
    protected[this]
    Definition Classes
    Logging
  104. def isWarnEnabled(marker: Marker): Boolean

    Permalink
    Attributes
    protected[this]
    Definition Classes
    Logging
  105. def isWarnEnabled: Boolean

    Permalink
    Attributes
    protected[this]
    Definition Classes
    Logging
  106. def javaModules: Collection[Module]

    Permalink
    Attributes
    protected
    Definition Classes
    App
  107. def javaOverrideModules: Collection[Module]

    Permalink
    Attributes
    protected
    Definition Classes
    App
  108. def kafkaFlag[T](key: String, default: ⇒ T)(implicit arg0: Flaggable[T]): Flag[T]

    Permalink

    Create a flag prefixed by "kafka." with the specified default value and a help string that is populated from the Kafka Streams StreamsConfig class

    Create a flag prefixed by "kafka." with the specified default value and a help string that is populated from the Kafka Streams StreamsConfig class

    T

    Type of the flag value

    key

    Name of the KafkaStreams flag as specified in the StreamsConfig class

    default

    Default value for this flag

    returns

    Flag for the specified key

    Definition Classes
    KafkaFlagUtils
  109. var kafkaStreams: KafkaStreams

    Permalink
    Attributes
    protected
    Definition Classes
    KafkaStreamsTwitterServer
  110. val kafkaStreamsBuilder: StreamsBuilder

    Permalink
    Attributes
    protected[com.twitter.finatra.kafkastreams]
    Definition Classes
    KafkaStreamsTwitterServer
  111. def kafkaStreamsClientSupplier: KafkaClientSupplier

    Permalink
    Attributes
    protected
    Definition Classes
    KafkaStreamsTwitterServer
  112. val levelFlag: Flag[Level]

    Permalink
    Attributes
    protected[this]
    Definition Classes
    Logging
  113. def libraryName: String

    Permalink
    Attributes
    protected
    Definition Classes
    TwitterServer → AdminHttpServer
  114. def linterRules: Seq[Rule]

    Permalink
    Definition Classes
    Linters
  115. def loadModules(): InstalledModules

    Permalink
    Attributes
    protected[com.twitter.inject]
    Definition Classes
    App
  116. def loadServiceBindings: Seq[Binding[_]]

    Permalink
    Attributes
    protected[this]
    Definition Classes
    App
  117. final def logger: Logger

    Permalink
    Attributes
    protected[this]
    Definition Classes
    Logging
  118. def loggerFactories: List[LoggerFactory]

    Permalink
    Definition Classes
    Logging
  119. final def loggerName: String

    Permalink
    Attributes
    protected[this]
    Definition Classes
    Logging
  120. final def main(): Unit

    Permalink
    Definition Classes
    TwitterServer → App
  121. final def main(args: Array[String]): Unit

    Permalink
    Definition Classes
    App
  122. def modules: Seq[Module]

    Permalink
    Attributes
    protected
    Definition Classes
    App
  123. val name: String

    Permalink
    Definition Classes
    App
  124. final def ne(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  125. final def nonExitingMain(args: Array[String]): Unit

    Permalink
    Definition Classes
    App
  126. final def notify(): Unit

    Permalink
    Definition Classes
    AnyRef
  127. final def notifyAll(): Unit

    Permalink
    Definition Classes
    AnyRef
  128. final def onExit(f: ⇒ Unit): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    App
  129. final def onExitLast(f: ⇒ Unit): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    App
  130. def onStateChange(newState: State, oldState: State): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    KafkaStreamsTwitterServer
  131. val outputFlag: Flag[String]

    Permalink
    Attributes
    protected[this]
    Definition Classes
    Logging
  132. def overrideModules: Seq[Module]

    Permalink
    Attributes
    protected
    Definition Classes
    App
  133. def parseArgs(args: Array[String]): Unit

    Permalink
    Attributes
    protected[this]
    Definition Classes
    App
  134. def postInjectorStartup(): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    KafkaStreamsTwitterServer → TwitterServer → App
  135. def postWarmup(): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    KafkaStreamsTwitterServer → TwitterServer → App
  136. final def postmain(f: ⇒ Unit): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    App
  137. def prebindWarmup(): Unit

    Permalink
    Definition Classes
    Warmup
  138. final def premain(f: ⇒ Unit): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    App
  139. def producerFlagWithKafkaDefault[T](key: String)(implicit arg0: Flaggable[T]): Flag[T]

    Permalink

    Create a flag prefixed by "kafka.producer." with a default value and help string that is populated from the Kafka ProducerConfig class

    Create a flag prefixed by "kafka.producer." with a default value and help string that is populated from the Kafka ProducerConfig class

    T

    Type of the flag value

    key

    Name of the KafkaStreams flag as specified in the ProducerConfig class

    returns

    Flag for the specified key

    Definition Classes
    KafkaFlagUtils
  140. var properties: Properties

    Permalink
    Attributes
    protected[com.twitter.finatra.kafkastreams]
    Definition Classes
    KafkaStreamsTwitterServer
  141. val queryableAfterClose: Flag[Duration]

    Permalink
    Attributes
    protected
  142. def ready(timeout: Duration)(implicit permit: CanAwait): FinatraDslWindowedAggregations.this.type

    Permalink
    Definition Classes
    CloseOnceAwaitably0 → Awaitable
  143. def requiredKafkaFlag[T](key: String, helpPrefix: String = "")(implicit arg0: Flaggable[T], arg1: Manifest[T]): Flag[T]

    Permalink

    Create a required flag prefixed by "kafka." with a help string this is populated from the Kafka Streams StreamsConfig class

    Create a required flag prefixed by "kafka." with a help string this is populated from the Kafka Streams StreamsConfig class

    T

    Type of the flag value

    key

    Name of the KafkaStreams flag as specified in the StreamsConfig class

    helpPrefix

    A string to be added to the front of the Kafka documentation for this key

    returns

    Flag for the specified key

    Definition Classes
    KafkaFlagUtils
  144. def resolveFinagleClientsOnStartup: Boolean

    Permalink
    Attributes
    protected
    Definition Classes
    TwitterServer
  145. def result(timeout: Duration)(implicit permit: CanAwait): Unit

    Permalink
    Definition Classes
    CloseOnceAwaitably0 → Awaitable
  146. val rollPolicyFlag: Flag[Policy]

    Permalink
    Attributes
    protected[this]
    Definition Classes
    Logging
  147. val rotateCountFlag: Flag[Int]

    Permalink
    Attributes
    protected[this]
    Definition Classes
    Logging
  148. def routes: Seq[Route]

    Permalink
    Definition Classes
    AdminHttpServer
  149. final def run(): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    TwitterServer → App
  150. def setExceptionHandler(streams: KafkaStreams): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    KafkaStreamsTwitterServer
  151. def setup(): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    TwitterServer
  152. lazy val shutdownTimer: Timer

    Permalink
    Attributes
    protected
    Definition Classes
    TwitterServer → App
  153. def start(): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    TwitterServer
  154. def statsReceiver: StatsReceiver

    Permalink
    Definition Classes
    Stats
  155. def statsReceiverModule: Module

    Permalink
    Attributes
    protected
    Definition Classes
    TwitterServer
  156. def streamsProperties(config: KafkaStreamsConfig): KafkaStreamsConfig

    Permalink

    Callback method which is executed after the injector is created and before KafkaStreams is configured.

    Callback method which is executed after the injector is created and before KafkaStreams is configured.

    Use the provided KafkaStreamsConfig and augment to configure your KafkaStreams topology.

    Example:

    override def streamsProperties(config: KafkaStreamsConfig): KafkaStreamsConfig = {
      super
        .streamsProperties(config)
        .retries(60)
        .retryBackoff(1.second)
        .consumer.sessionTimeout(10.seconds)
        .consumer.heartbeatInterval(1.second)
        .producer.retries(300)
        .producer.retryBackoff(1.second)
        .producer.requestTimeout(2.minutes)
        .producer.transactionTimeout(2.minutes)
        .producer.batchSize(500.kilobytes)
    }
    config

    the default KafkaStreamsConfig defined at createKafkaStreamsProperties

    returns

    a KafkaStreamsConfig with your additional configurations applied.

    Definition Classes
    FlushingAwareServerKafkaStreamsTwitterServer
  157. def streamsStatsReceiver: StatsReceiver

    Permalink
    Attributes
    protected
    Definition Classes
    KafkaStreamsTwitterServer
  158. final val suppressGracefulShutdownErrors: Boolean

    Permalink
    Definition Classes
    TwitterServer → App
  159. final def synchronized[T0](arg0: ⇒ T0): T0

    Permalink
    Definition Classes
    AnyRef
  160. def thriftPort: Option[Int]

    Permalink
    Definition Classes
    Ports
  161. def time[T](formatStr: String)(func: ⇒ T): T

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  162. def toString(): String

    Permalink
    Definition Classes
    AnyRef → Any
  163. var topology: Topology

    Permalink
    Attributes
    protected[com.twitter.finatra.kafkastreams]
    Definition Classes
    KafkaStreamsTwitterServer
  164. def trace(marker: Marker, message: ⇒ Any, cause: Throwable): Unit

    Permalink
    Attributes
    protected[this]
    Definition Classes
    Logging
  165. def trace(message: ⇒ Any, cause: Throwable): Unit

    Permalink
    Attributes
    protected[this]
    Definition Classes
    Logging
  166. def trace(marker: Marker, message: ⇒ Any): Unit

    Permalink
    Attributes
    protected[this]
    Definition Classes
    Logging
  167. def trace(message: ⇒ Any): Unit

    Permalink
    Attributes
    protected[this]
    Definition Classes
    Logging
  168. def traceResult[T](message: ⇒ String)(fn: ⇒ T): T

    Permalink
    Attributes
    protected[this]
    Definition Classes
    Logging
  169. implicit def transformerFunctionToSupplier[K, V, K1, V1](transformerFactory: () ⇒ Transformer[K, V, (K1, V1)]): TransformerSupplier[K, V, KeyValue[K1, V1]]

    Permalink
    Definition Classes
    ScalaStreamsImplicits
  170. def uncaughtException: Throwable

    Permalink
    Definition Classes
    KafkaStreamsTwitterServer
  171. final def wait(): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  172. final def wait(arg0: Long, arg1: Int): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  173. final def wait(arg0: Long): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  174. def warmup(): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    TwitterServer → App
  175. def warmupComplete(): Unit

    Permalink
    Definition Classes
    Warmup
  176. def warn(marker: Marker, message: ⇒ Any, cause: Throwable): Unit

    Permalink
    Attributes
    protected[this]
    Definition Classes
    Logging
  177. def warn(message: ⇒ Any, cause: Throwable): Unit

    Permalink
    Attributes
    protected[this]
    Definition Classes
    Logging
  178. def warn(marker: Marker, message: ⇒ Any): Unit

    Permalink
    Attributes
    protected[this]
    Definition Classes
    Logging
  179. def warn(message: ⇒ Any): Unit

    Permalink
    Attributes
    protected[this]
    Definition Classes
    Logging
  180. def warnResult[T](message: ⇒ String)(fn: ⇒ T): T

    Permalink
    Attributes
    protected[this]
    Definition Classes
    Logging
  181. val windowSize: Flag[Duration]

    Permalink
    Attributes
    protected

Deprecated Value Members

  1. lazy val log: Logger

    Permalink
    Definition Classes
    DeprecatedLogging → Logging
    Annotations
    @deprecated
    Deprecated

    (Since version 2017-10-06) For backwards compatibility only.

Inherited from FinatraTransformerFlags

Inherited from FlushingAwareServer

Inherited from KafkaStreamsTwitterServer

Inherited from ScalaStreamsImplicits

Inherited from KafkaFlagUtils

Inherited from TwitterServer

Inherited from Warmup

Inherited from Ports

Inherited from DeprecatedLogging

Inherited from Logging

Inherited from TwitterServer

Inherited from Lifecycle

Inherited from AdminHttpServer

Inherited from Hooks

Inherited from DtabFlags

Inherited from Linters

Inherited from Stats

Inherited from Slf4jBridge

Inherited from App

Inherited from Logging

Inherited from Logging

Inherited from App

Inherited from CloseOnceAwaitably

Inherited from CloseOnceAwaitably0[Unit]

Inherited from Awaitable[Unit]

Inherited from ClosableOnce

Inherited from CloseOnce

Inherited from Closable

Inherited from AnyRef

Inherited from Any

Ungrouped