Modifier and Type | Field and Description |
---|---|
static TypeArg<TcpEventBusBridge> |
TcpEventBusBridge.__TYPE_ARG |
Modifier and Type | Method and Description |
---|---|
static <U> TypeArg<U> |
TypeArg.of(Class<U> type) |
static <T> TypeArg<T> |
TypeArg.unknown() |
Modifier and Type | Field and Description |
---|---|
static TypeArg<AmqpBridge> |
AmqpBridge.__TYPE_ARG |
Modifier and Type | Field and Description |
---|---|
static TypeArg<CircuitBreaker> |
CircuitBreaker.__TYPE_ARG |
static TypeArg<HystrixMetricHandler> |
HystrixMetricHandler.__TYPE_ARG |
Modifier and Type | Field and Description |
---|---|
static TypeArg<ConfigRetriever> |
ConfigRetriever.__TYPE_ARG |
Modifier and Type | Field and Description |
---|---|
static TypeArg<CompositeFuture> |
CompositeFuture.__TYPE_ARG |
static TypeArg<Context> |
Context.__TYPE_ARG |
static TypeArg<Future> |
Future.__TYPE_ARG |
static TypeArg<MultiMap> |
MultiMap.__TYPE_ARG |
static TypeArg<TimeoutStream> |
TimeoutStream.__TYPE_ARG |
static TypeArg<Vertx> |
Vertx.__TYPE_ARG |
static TypeArg<WorkerExecutor> |
WorkerExecutor.__TYPE_ARG |
TypeArg<T> |
Future.__typeArg_0 |
Modifier and Type | Method and Description |
---|---|
static <T> Future<T> |
Future.newInstance(Future arg,
TypeArg<T> __typeArg_T) |
Constructor and Description |
---|
Future(Future delegate,
TypeArg<T> typeArg_0) |
Modifier and Type | Field and Description |
---|---|
static TypeArg<Buffer> |
Buffer.__TYPE_ARG |
Modifier and Type | Field and Description |
---|---|
static TypeArg<CLI> |
CLI.__TYPE_ARG |
static TypeArg<CommandLine> |
CommandLine.__TYPE_ARG |
Modifier and Type | Field and Description |
---|---|
static TypeArg<DatagramPacket> |
DatagramPacket.__TYPE_ARG |
static TypeArg<DatagramSocket> |
DatagramSocket.__TYPE_ARG |
Modifier and Type | Field and Description |
---|---|
static TypeArg<DnsClient> |
DnsClient.__TYPE_ARG |
static TypeArg<MxRecord> |
MxRecord.__TYPE_ARG |
static TypeArg<SrvRecord> |
SrvRecord.__TYPE_ARG |
Modifier and Type | Field and Description |
---|---|
static TypeArg<EventBus> |
EventBus.__TYPE_ARG |
static TypeArg<Message> |
Message.__TYPE_ARG |
static TypeArg<MessageConsumer> |
MessageConsumer.__TYPE_ARG |
static TypeArg<MessageProducer> |
MessageProducer.__TYPE_ARG |
static TypeArg<SendContext> |
SendContext.__TYPE_ARG |
TypeArg<T> |
Message.__typeArg_0 |
TypeArg<T> |
MessageConsumer.__typeArg_0 |
TypeArg<T> |
MessageProducer.__typeArg_0 |
TypeArg<T> |
SendContext.__typeArg_0 |
Modifier and Type | Method and Description |
---|---|
static <T> MessageConsumer<T> |
MessageConsumer.newInstance(MessageConsumer arg,
TypeArg<T> __typeArg_T) |
static <T> MessageProducer<T> |
MessageProducer.newInstance(MessageProducer arg,
TypeArg<T> __typeArg_T) |
static <T> Message<T> |
Message.newInstance(Message arg,
TypeArg<T> __typeArg_T) |
static <T> SendContext<T> |
SendContext.newInstance(SendContext arg,
TypeArg<T> __typeArg_T) |
Constructor and Description |
---|
Message(Message delegate,
TypeArg<T> typeArg_0) |
MessageConsumer(MessageConsumer delegate,
TypeArg<T> typeArg_0) |
MessageProducer(MessageProducer delegate,
TypeArg<T> typeArg_0) |
SendContext(SendContext delegate,
TypeArg<T> typeArg_0) |
Modifier and Type | Field and Description |
---|---|
static TypeArg<AsyncFile> |
AsyncFile.__TYPE_ARG |
static TypeArg<FileProps> |
FileProps.__TYPE_ARG |
static TypeArg<FileSystem> |
FileSystem.__TYPE_ARG |
static TypeArg<FileSystemProps> |
FileSystemProps.__TYPE_ARG |
Modifier and Type | Field and Description |
---|---|
static TypeArg<HttpClient> |
HttpClient.__TYPE_ARG |
static TypeArg<HttpClientRequest> |
HttpClientRequest.__TYPE_ARG |
static TypeArg<HttpClientResponse> |
HttpClientResponse.__TYPE_ARG |
static TypeArg<HttpConnection> |
HttpConnection.__TYPE_ARG |
static TypeArg<HttpFrame> |
HttpFrame.__TYPE_ARG |
static TypeArg<HttpServer> |
HttpServer.__TYPE_ARG |
static TypeArg<HttpServerFileUpload> |
HttpServerFileUpload.__TYPE_ARG |
static TypeArg<HttpServerRequest> |
HttpServerRequest.__TYPE_ARG |
static TypeArg<HttpServerResponse> |
HttpServerResponse.__TYPE_ARG |
static TypeArg<ServerWebSocket> |
ServerWebSocket.__TYPE_ARG |
static TypeArg<WebSocket> |
WebSocket.__TYPE_ARG |
static TypeArg<WebSocketFrame> |
WebSocketFrame.__TYPE_ARG |
Modifier and Type | Field and Description |
---|---|
static TypeArg<NetClient> |
NetClient.__TYPE_ARG |
static TypeArg<NetServer> |
NetServer.__TYPE_ARG |
static TypeArg<NetSocket> |
NetSocket.__TYPE_ARG |
static TypeArg<SelfSignedCertificate> |
SelfSignedCertificate.__TYPE_ARG |
static TypeArg<SocketAddress> |
SocketAddress.__TYPE_ARG |
Modifier and Type | Field and Description |
---|---|
static TypeArg<RecordParser> |
RecordParser.__TYPE_ARG |
Modifier and Type | Field and Description |
---|---|
static TypeArg<AsyncMap> |
AsyncMap.__TYPE_ARG |
static TypeArg<Counter> |
Counter.__TYPE_ARG |
static TypeArg<LocalMap> |
LocalMap.__TYPE_ARG |
static TypeArg<Lock> |
Lock.__TYPE_ARG |
static TypeArg<SharedData> |
SharedData.__TYPE_ARG |
TypeArg<K> |
AsyncMap.__typeArg_0 |
TypeArg<K> |
LocalMap.__typeArg_0 |
TypeArg<V> |
AsyncMap.__typeArg_1 |
TypeArg<V> |
LocalMap.__typeArg_1 |
Modifier and Type | Method and Description |
---|---|
static <K,V> AsyncMap<K,V> |
AsyncMap.newInstance(AsyncMap arg,
TypeArg<K> __typeArg_K,
TypeArg<V> __typeArg_V) |
static <K,V> AsyncMap<K,V> |
AsyncMap.newInstance(AsyncMap arg,
TypeArg<K> __typeArg_K,
TypeArg<V> __typeArg_V) |
static <K,V> LocalMap<K,V> |
LocalMap.newInstance(LocalMap arg,
TypeArg<K> __typeArg_K,
TypeArg<V> __typeArg_V) |
static <K,V> LocalMap<K,V> |
LocalMap.newInstance(LocalMap arg,
TypeArg<K> __typeArg_K,
TypeArg<V> __typeArg_V) |
Constructor and Description |
---|
AsyncMap(AsyncMap delegate,
TypeArg<K> typeArg_0,
TypeArg<V> typeArg_1) |
AsyncMap(AsyncMap delegate,
TypeArg<K> typeArg_0,
TypeArg<V> typeArg_1) |
LocalMap(LocalMap delegate,
TypeArg<K> typeArg_0,
TypeArg<V> typeArg_1) |
LocalMap(LocalMap delegate,
TypeArg<K> typeArg_0,
TypeArg<V> typeArg_1) |
Modifier and Type | Field and Description |
---|---|
static TypeArg<Pump> |
Pump.__TYPE_ARG |
Modifier and Type | Method and Description |
---|---|
static <T> ReadStream<T> |
ReadStream.newInstance(ReadStream arg,
TypeArg<T> __typeArg_T) |
static <T> WriteStream<T> |
WriteStream.newInstance(WriteStream arg,
TypeArg<T> __typeArg_T) |
Modifier and Type | Field and Description |
---|---|
static TypeArg<AsyncSQLClient> |
AsyncSQLClient.__TYPE_ARG |
static TypeArg<MySQLClient> |
MySQLClient.__TYPE_ARG |
static TypeArg<PostgreSQLClient> |
PostgreSQLClient.__TYPE_ARG |
Modifier and Type | Field and Description |
---|---|
static TypeArg<AuthProvider> |
AuthProvider.__TYPE_ARG |
static TypeArg<ChainAuth> |
ChainAuth.__TYPE_ARG |
static TypeArg<User> |
User.__TYPE_ARG |
static TypeArg<VertxContextPRNG> |
VertxContextPRNG.__TYPE_ARG |
Modifier and Type | Field and Description |
---|---|
static TypeArg<HtdigestAuth> |
HtdigestAuth.__TYPE_ARG |
Modifier and Type | Field and Description |
---|---|
static TypeArg<JDBCAuth> |
JDBCAuth.__TYPE_ARG |
Modifier and Type | Field and Description |
---|---|
static TypeArg<JWTAuth> |
JWTAuth.__TYPE_ARG |
Modifier and Type | Field and Description |
---|---|
static TypeArg<HashStrategy> |
HashStrategy.__TYPE_ARG |
static TypeArg<MongoAuth> |
MongoAuth.__TYPE_ARG |
Modifier and Type | Field and Description |
---|---|
static TypeArg<AccessToken> |
AccessToken.__TYPE_ARG |
static TypeArg<KeycloakHelper> |
KeycloakHelper.__TYPE_ARG |
static TypeArg<OAuth2Auth> |
OAuth2Auth.__TYPE_ARG |
Modifier and Type | Field and Description |
---|---|
static TypeArg<ShiroAuth> |
ShiroAuth.__TYPE_ARG |
Modifier and Type | Field and Description |
---|---|
static TypeArg<ConsulClient> |
ConsulClient.__TYPE_ARG |
static TypeArg<Watch> |
Watch.__TYPE_ARG |
TypeArg<T> |
Watch.__typeArg_0 |
Modifier and Type | Method and Description |
---|---|
static <T> Watch<T> |
Watch.newInstance(Watch arg,
TypeArg<T> __typeArg_T) |
Constructor and Description |
---|
Watch(Watch delegate,
TypeArg<T> typeArg_0) |
Modifier and Type | Field and Description |
---|---|
static TypeArg<MetricsService> |
MetricsService.__TYPE_ARG |
Modifier and Type | Field and Description |
---|---|
static TypeArg<HealthCheckHandler> |
HealthCheckHandler.__TYPE_ARG |
static TypeArg<HealthChecks> |
HealthChecks.__TYPE_ARG |
Modifier and Type | Field and Description |
---|---|
static TypeArg<JDBCClient> |
JDBCClient.__TYPE_ARG |
Modifier and Type | Field and Description |
---|---|
static TypeArg<MailClient> |
MailClient.__TYPE_ARG |
static TypeArg<MailService> |
MailService.__TYPE_ARG |
Modifier and Type | Field and Description |
---|---|
static TypeArg<MongoClient> |
MongoClient.__TYPE_ARG |
Modifier and Type | Field and Description |
---|---|
static TypeArg<Shell> |
Shell.__TYPE_ARG |
static TypeArg<ShellServer> |
ShellServer.__TYPE_ARG |
static TypeArg<ShellService> |
ShellService.__TYPE_ARG |
Modifier and Type | Field and Description |
---|---|
static TypeArg<CliToken> |
CliToken.__TYPE_ARG |
static TypeArg<Completion> |
Completion.__TYPE_ARG |
Modifier and Type | Field and Description |
---|---|
static TypeArg<Command> |
Command.__TYPE_ARG |
static TypeArg<CommandBuilder> |
CommandBuilder.__TYPE_ARG |
static TypeArg<CommandProcess> |
CommandProcess.__TYPE_ARG |
static TypeArg<CommandRegistry> |
CommandRegistry.__TYPE_ARG |
static TypeArg<CommandResolver> |
CommandResolver.__TYPE_ARG |
Modifier and Type | Field and Description |
---|---|
static TypeArg<Session> |
Session.__TYPE_ARG |
Modifier and Type | Field and Description |
---|---|
static TypeArg<Job> |
Job.__TYPE_ARG |
static TypeArg<JobController> |
JobController.__TYPE_ARG |
static TypeArg<Process> |
Process.__TYPE_ARG |
Modifier and Type | Field and Description |
---|---|
static TypeArg<Pty> |
Pty.__TYPE_ARG |
static TypeArg<SignalHandler> |
SignalHandler.__TYPE_ARG |
static TypeArg<SockJSTermHandler> |
SockJSTermHandler.__TYPE_ARG |
static TypeArg<Term> |
Term.__TYPE_ARG |
static TypeArg<TermServer> |
TermServer.__TYPE_ARG |
static TypeArg<Tty> |
Tty.__TYPE_ARG |
Modifier and Type | Field and Description |
---|---|
static TypeArg<SQLClient> |
SQLClient.__TYPE_ARG |
static TypeArg<SQLConnection> |
SQLConnection.__TYPE_ARG |
static TypeArg<SQLRowStream> |
SQLRowStream.__TYPE_ARG |
Modifier and Type | Field and Description |
---|---|
static TypeArg<Acknowledgement> |
Acknowledgement.__TYPE_ARG |
static TypeArg<Destination> |
Destination.__TYPE_ARG |
static TypeArg<DestinationFactory> |
DestinationFactory.__TYPE_ARG |
static TypeArg<Frames> |
Frames.__TYPE_ARG |
static TypeArg<ServerFrame> |
ServerFrame.__TYPE_ARG |
static TypeArg<StompClient> |
StompClient.__TYPE_ARG |
static TypeArg<StompClientConnection> |
StompClientConnection.__TYPE_ARG |
static TypeArg<StompServer> |
StompServer.__TYPE_ARG |
static TypeArg<StompServerConnection> |
StompServerConnection.__TYPE_ARG |
static TypeArg<StompServerHandler> |
StompServerHandler.__TYPE_ARG |
Modifier and Type | Field and Description |
---|---|
static TypeArg<Async> |
Async.__TYPE_ARG |
static TypeArg<Completion> |
Completion.__TYPE_ARG |
static TypeArg<TestCase> |
TestCase.__TYPE_ARG |
static TypeArg<TestCompletion> |
TestCompletion.__TYPE_ARG |
static TypeArg<TestContext> |
TestContext.__TYPE_ARG |
static TypeArg<TestSuite> |
TestSuite.__TYPE_ARG |
TypeArg<T> |
Completion.__typeArg_0 |
Modifier and Type | Method and Description |
---|---|
static <T> Completion<T> |
Completion.newInstance(Completion arg,
TypeArg<T> __typeArg_T) |
Constructor and Description |
---|
Completion(Completion delegate,
TypeArg<T> typeArg_0) |
Modifier and Type | Field and Description |
---|---|
static TypeArg<EventBusCollector> |
EventBusCollector.__TYPE_ARG |
Modifier and Type | Field and Description |
---|---|
static TypeArg<Failure> |
Failure.__TYPE_ARG |
static TypeArg<TestCaseReport> |
TestCaseReport.__TYPE_ARG |
static TypeArg<TestResult> |
TestResult.__TYPE_ARG |
static TypeArg<TestSuiteReport> |
TestSuiteReport.__TYPE_ARG |
Modifier and Type | Field and Description |
---|---|
static TypeArg<Cookie> |
Cookie.__TYPE_ARG |
static TypeArg<FileUpload> |
FileUpload.__TYPE_ARG |
static TypeArg<LanguageHeader> |
LanguageHeader.__TYPE_ARG |
static TypeArg<Locale> |
Locale.__TYPE_ARG |
static TypeArg<MIMEHeader> |
MIMEHeader.__TYPE_ARG |
static TypeArg<ParsedHeaderValues> |
ParsedHeaderValues.__TYPE_ARG |
static TypeArg<Route> |
Route.__TYPE_ARG |
static TypeArg<Router> |
Router.__TYPE_ARG |
static TypeArg<RoutingContext> |
RoutingContext.__TYPE_ARG |
static TypeArg<Session> |
Session.__TYPE_ARG |
Modifier and Type | Field and Description |
---|---|
static TypeArg<HttpRequest> |
HttpRequest.__TYPE_ARG |
static TypeArg<HttpResponse> |
HttpResponse.__TYPE_ARG |
static TypeArg<WebClient> |
WebClient.__TYPE_ARG |
TypeArg<T> |
HttpRequest.__typeArg_0 |
TypeArg<T> |
HttpResponse.__typeArg_0 |
Modifier and Type | Method and Description |
---|---|
static <T> HttpRequest<T> |
HttpRequest.newInstance(HttpRequest arg,
TypeArg<T> __typeArg_T) |
static <T> HttpResponse<T> |
HttpResponse.newInstance(HttpResponse arg,
TypeArg<T> __typeArg_T) |
Constructor and Description |
---|
HttpRequest(HttpRequest delegate,
TypeArg<T> typeArg_0) |
HttpResponse(HttpResponse delegate,
TypeArg<T> typeArg_0) |
Modifier and Type | Field and Description |
---|---|
static TypeArg<BodyCodec> |
BodyCodec.__TYPE_ARG |
TypeArg<T> |
BodyCodec.__typeArg_0 |
Modifier and Type | Method and Description |
---|---|
static <T> BodyCodec<T> |
BodyCodec.newInstance(BodyCodec arg,
TypeArg<T> __typeArg_T) |
Constructor and Description |
---|
BodyCodec(BodyCodec delegate,
TypeArg<T> typeArg_0) |
Modifier and Type | Field and Description |
---|---|
static TypeArg<BridgeEvent> |
BridgeEvent.__TYPE_ARG |
static TypeArg<SockJSHandler> |
SockJSHandler.__TYPE_ARG |
static TypeArg<SockJSSocket> |
SockJSSocket.__TYPE_ARG |
Modifier and Type | Field and Description |
---|---|
static TypeArg<ClusteredSessionStore> |
ClusteredSessionStore.__TYPE_ARG |
static TypeArg<LocalSessionStore> |
LocalSessionStore.__TYPE_ARG |
static TypeArg<SessionStore> |
SessionStore.__TYPE_ARG |
Modifier and Type | Field and Description |
---|---|
static TypeArg<FreeMarkerTemplateEngine> |
FreeMarkerTemplateEngine.__TYPE_ARG |
static TypeArg<HandlebarsTemplateEngine> |
HandlebarsTemplateEngine.__TYPE_ARG |
static TypeArg<JadeTemplateEngine> |
JadeTemplateEngine.__TYPE_ARG |
static TypeArg<MVELTemplateEngine> |
MVELTemplateEngine.__TYPE_ARG |
static TypeArg<PebbleTemplateEngine> |
PebbleTemplateEngine.__TYPE_ARG |
static TypeArg<TemplateEngine> |
TemplateEngine.__TYPE_ARG |
static TypeArg<ThymeleafTemplateEngine> |
ThymeleafTemplateEngine.__TYPE_ARG |
Modifier and Type | Field and Description |
---|---|
static TypeArg<AdminUtils> |
AdminUtils.__TYPE_ARG |
Modifier and Type | Field and Description |
---|---|
static TypeArg<KafkaConsumer> |
KafkaConsumer.__TYPE_ARG |
static TypeArg<KafkaConsumerRecord> |
KafkaConsumerRecord.__TYPE_ARG |
static TypeArg<KafkaConsumerRecords> |
KafkaConsumerRecords.__TYPE_ARG |
TypeArg<K> |
KafkaConsumer.__typeArg_0 |
TypeArg<K> |
KafkaConsumerRecord.__typeArg_0 |
TypeArg<K> |
KafkaConsumerRecords.__typeArg_0 |
TypeArg<V> |
KafkaConsumer.__typeArg_1 |
TypeArg<V> |
KafkaConsumerRecord.__typeArg_1 |
TypeArg<V> |
KafkaConsumerRecords.__typeArg_1 |
Modifier and Type | Method and Description |
---|---|
static <K,V> KafkaConsumerRecords<K,V> |
KafkaConsumerRecords.newInstance(KafkaConsumerRecords arg,
TypeArg<K> __typeArg_K,
TypeArg<V> __typeArg_V) |
static <K,V> KafkaConsumerRecords<K,V> |
KafkaConsumerRecords.newInstance(KafkaConsumerRecords arg,
TypeArg<K> __typeArg_K,
TypeArg<V> __typeArg_V) |
static <K,V> KafkaConsumerRecord<K,V> |
KafkaConsumerRecord.newInstance(KafkaConsumerRecord arg,
TypeArg<K> __typeArg_K,
TypeArg<V> __typeArg_V) |
static <K,V> KafkaConsumerRecord<K,V> |
KafkaConsumerRecord.newInstance(KafkaConsumerRecord arg,
TypeArg<K> __typeArg_K,
TypeArg<V> __typeArg_V) |
static <K,V> KafkaConsumer<K,V> |
KafkaConsumer.newInstance(KafkaConsumer arg,
TypeArg<K> __typeArg_K,
TypeArg<V> __typeArg_V) |
static <K,V> KafkaConsumer<K,V> |
KafkaConsumer.newInstance(KafkaConsumer arg,
TypeArg<K> __typeArg_K,
TypeArg<V> __typeArg_V) |
Constructor and Description |
---|
KafkaConsumer(KafkaConsumer delegate,
TypeArg<K> typeArg_0,
TypeArg<V> typeArg_1) |
KafkaConsumer(KafkaConsumer delegate,
TypeArg<K> typeArg_0,
TypeArg<V> typeArg_1) |
KafkaConsumerRecord(KafkaConsumerRecord delegate,
TypeArg<K> typeArg_0,
TypeArg<V> typeArg_1) |
KafkaConsumerRecord(KafkaConsumerRecord delegate,
TypeArg<K> typeArg_0,
TypeArg<V> typeArg_1) |
KafkaConsumerRecords(KafkaConsumerRecords delegate,
TypeArg<K> typeArg_0,
TypeArg<V> typeArg_1) |
KafkaConsumerRecords(KafkaConsumerRecords delegate,
TypeArg<K> typeArg_0,
TypeArg<V> typeArg_1) |
Modifier and Type | Field and Description |
---|---|
static TypeArg<KafkaProducer> |
KafkaProducer.__TYPE_ARG |
static TypeArg<KafkaProducerRecord> |
KafkaProducerRecord.__TYPE_ARG |
TypeArg<K> |
KafkaProducer.__typeArg_0 |
TypeArg<K> |
KafkaProducerRecord.__typeArg_0 |
TypeArg<V> |
KafkaProducer.__typeArg_1 |
TypeArg<V> |
KafkaProducerRecord.__typeArg_1 |
Modifier and Type | Method and Description |
---|---|
static <K,V> KafkaProducerRecord<K,V> |
KafkaProducerRecord.newInstance(KafkaProducerRecord arg,
TypeArg<K> __typeArg_K,
TypeArg<V> __typeArg_V) |
static <K,V> KafkaProducerRecord<K,V> |
KafkaProducerRecord.newInstance(KafkaProducerRecord arg,
TypeArg<K> __typeArg_K,
TypeArg<V> __typeArg_V) |
static <K,V> KafkaProducer<K,V> |
KafkaProducer.newInstance(KafkaProducer arg,
TypeArg<K> __typeArg_K,
TypeArg<V> __typeArg_V) |
static <K,V> KafkaProducer<K,V> |
KafkaProducer.newInstance(KafkaProducer arg,
TypeArg<K> __typeArg_K,
TypeArg<V> __typeArg_V) |
Constructor and Description |
---|
KafkaProducer(KafkaProducer delegate,
TypeArg<K> typeArg_0,
TypeArg<V> typeArg_1) |
KafkaProducer(KafkaProducer delegate,
TypeArg<K> typeArg_0,
TypeArg<V> typeArg_1) |
KafkaProducerRecord(KafkaProducerRecord delegate,
TypeArg<K> typeArg_0,
TypeArg<V> typeArg_1) |
KafkaProducerRecord(KafkaProducerRecord delegate,
TypeArg<K> typeArg_0,
TypeArg<V> typeArg_1) |
Modifier and Type | Field and Description |
---|---|
static TypeArg<MqttAuth> |
MqttAuth.__TYPE_ARG |
static TypeArg<MqttClient> |
MqttClient.__TYPE_ARG |
static TypeArg<MqttEndpoint> |
MqttEndpoint.__TYPE_ARG |
static TypeArg<MqttServer> |
MqttServer.__TYPE_ARG |
static TypeArg<MqttTopicSubscription> |
MqttTopicSubscription.__TYPE_ARG |
static TypeArg<MqttWill> |
MqttWill.__TYPE_ARG |
Modifier and Type | Field and Description |
---|---|
static TypeArg<MqttConnAckMessage> |
MqttConnAckMessage.__TYPE_ARG |
static TypeArg<MqttPublishMessage> |
MqttPublishMessage.__TYPE_ARG |
static TypeArg<MqttSubAckMessage> |
MqttSubAckMessage.__TYPE_ARG |
static TypeArg<MqttSubscribeMessage> |
MqttSubscribeMessage.__TYPE_ARG |
static TypeArg<MqttUnsubscribeMessage> |
MqttUnsubscribeMessage.__TYPE_ARG |
Modifier and Type | Field and Description |
---|---|
static TypeArg<RabbitMQClient> |
RabbitMQClient.__TYPE_ARG |
Modifier and Type | Field and Description |
---|---|
static TypeArg<RedisClient> |
RedisClient.__TYPE_ARG |
static TypeArg<RedisTransaction> |
RedisTransaction.__TYPE_ARG |
static TypeArg<Script> |
Script.__TYPE_ARG |
Modifier and Type | Field and Description |
---|---|
static TypeArg<ServiceDiscovery> |
ServiceDiscovery.__TYPE_ARG |
static TypeArg<ServiceReference> |
ServiceReference.__TYPE_ARG |
Modifier and Type | Field and Description |
---|---|
static TypeArg<ServiceExporter> |
ServiceExporter.__TYPE_ARG |
static TypeArg<ServiceImporter> |
ServiceImporter.__TYPE_ARG |
static TypeArg<ServicePublisher> |
ServicePublisher.__TYPE_ARG |
Modifier and Type | Field and Description |
---|---|
static TypeArg<EventBusService> |
EventBusService.__TYPE_ARG |
static TypeArg<HttpEndpoint> |
HttpEndpoint.__TYPE_ARG |
static TypeArg<JDBCDataSource> |
JDBCDataSource.__TYPE_ARG |
static TypeArg<MessageSource> |
MessageSource.__TYPE_ARG |
static TypeArg<MongoDataSource> |
MongoDataSource.__TYPE_ARG |
static TypeArg<RedisDataSource> |
RedisDataSource.__TYPE_ARG |
Copyright © 2017. All rights reserved.