From 73c4933899f1d83c8701582bf927120f7e6cc643 Mon Sep 17 00:00:00 2001
From: masesdevelopers <94312179+masesdevelopers@users.noreply.github.com>
Date: Thu, 19 Sep 2024 23:44:45 +0000
Subject: [PATCH] Update generated classes after commit db32c1f
---
.../clients/consumer/ConsumerInterceptor.java | 93 +-
.../consumer/ConsumerPartitionAssignor.java | 99 +-
.../consumer/ConsumerRebalanceListener.java | 90 +-
.../consumer/OffsetCommitCallback.java | 84 +-
.../kafka/clients/producer/Callback.java | 84 +-
.../kafka/clients/producer/Partitioner.java | 93 +-
.../clients/producer/ProducerInterceptor.java | 93 +-
.../kafka/common/ClusterResourceListener.java | 84 +-
.../common/config/ConfigChangeCallback.java | 84 +-
.../kafka/common/metrics/MetricsReporter.java | 112 +-
.../common/serialization/Deserializer.java | 96 +-
.../kafka/common/serialization/Serde.java | 93 +-
.../common/serialization/Serializer.java | 93 +-
.../kafka/raft/RaftClient_Listener.java | 93 +-
.../kafka/streams/KafkaClientSupplier.java | 96 +-
.../streams/KafkaStreams_StateListener.java | 84 +-
.../StreamsUncaughtExceptionHandler.java | 84 +-
.../kafka/streams/kstream/Aggregator.java | 84 +-
.../kafka/streams/kstream/ForeachAction.java | 84 +-
.../kafka/streams/kstream/Initializer.java | 84 +-
.../kafka/streams/kstream/KeyValueMapper.java | 84 +-
.../apache/kafka/streams/kstream/Merger.java | 84 +-
.../kafka/streams/kstream/Predicate.java | 84 +-
.../apache/kafka/streams/kstream/Reducer.java | 84 +-
.../kafka/streams/kstream/Transformer.java | 90 +-
.../kafka/streams/kstream/ValueJoiner.java | 84 +-
.../streams/kstream/ValueJoinerWithKey.java | 84 +-
.../kafka/streams/kstream/ValueMapper.java | 84 +-
.../streams/kstream/ValueMapperWithKey.java | 84 +-
.../streams/kstream/ValueTransformer.java | 90 +-
.../kstream/ValueTransformerWithKey.java | 90 +-
.../BatchingStateRestoreCallback.java | 87 +-
.../kafka/streams/processor/Punctuator.java | 84 +-
.../processor/StateRestoreCallback.java | 84 +-
.../processor/StateRestoreListener.java | 93 +-
.../streams/processor/StreamPartitioner.java | 87 +-
.../streams/processor/TimestampExtractor.java | 84 +-
.../streams/processor/TopicNameExtractor.java | 84 +-
.../processor/api/FixedKeyProcessor.java | 90 +-
.../streams/processor/api/Processor.java | 90 +-
.../KNet/Generated/Kafka/Admin/AclCommand.cs | 239 +-
.../Kafka/Admin/AllPackageClasses.cs | 2083 ------
.../Kafka/Admin/BrokerApiVersionsCommand.cs | 96 +-
.../Generated/Kafka/Admin/ConfigCommand.cs | 190 +-
.../Kafka/Admin/ConsumerGroupCommand.cs | 523 +-
.../Generated/Kafka/Admin/FeatureCommand.cs | 49 +-
.../Kafka/Admin/LeaderElectionCommand.cs | 49 +-
.../Admin/LeaderElectionCommandOptions.cs | 49 +-
.../Generated/Kafka/Admin/RackAwareMode.cs | 51 +-
.../Kafka/Admin/ReassignPartitionsCommand.cs | 540 +-
.../Generated/Kafka/Admin/TopicCommand.cs | 331 +-
.../Kafka/Admin/ZkSecurityMigrator.cs | 49 +-
.../KNet/Generated/Kafka/AllPackageClasses.cs | 31 -
.../Clients/Admin/AbortTransactionOptions.cs | 49 +-
.../Clients/Admin/AbortTransactionResult.cs | 49 +-
.../Clients/Admin/AbortTransactionSpec.cs | 49 +-
.../Kafka/Clients/Admin/AbstractOptions.cs | 101 +-
.../Org/Apache/Kafka/Clients/Admin/Admin.cs | 51 +-
.../Apache/Kafka/Clients/Admin/AdminClient.cs | 51 +-
.../Kafka/Clients/Admin/AdminClientConfig.cs | 49 +-
.../Kafka/Clients/Admin/AllPackageClasses.cs | 6567 -----------------
.../Clients/Admin/AlterClientQuotasOptions.cs | 49 +-
.../Clients/Admin/AlterClientQuotasResult.cs | 49 +-
.../Kafka/Clients/Admin/AlterConfigOp.cs | 96 +-
.../Clients/Admin/AlterConfigsOptions.cs | 49 +-
.../Kafka/Clients/Admin/AlterConfigsResult.cs | 49 +-
.../Admin/AlterConsumerGroupOffsetsOptions.cs | 49 +-
.../Admin/AlterConsumerGroupOffsetsResult.cs | 49 +-
.../AlterPartitionReassignmentsOptions.cs | 49 +-
.../AlterPartitionReassignmentsResult.cs | 49 +-
.../Admin/AlterReplicaLogDirsOptions.cs | 49 +-
.../Admin/AlterReplicaLogDirsResult.cs | 49 +-
.../Admin/AlterUserScramCredentialsOptions.cs | 49 +-
.../Admin/AlterUserScramCredentialsResult.cs | 49 +-
.../Org/Apache/Kafka/Clients/Admin/Config.cs | 49 +-
.../Apache/Kafka/Clients/Admin/ConfigEntry.cs | 190 +-
.../Clients/Admin/ConsumerGroupDescription.cs | 49 +-
.../Clients/Admin/ConsumerGroupListing.cs | 49 +-
.../Kafka/Clients/Admin/CreateAclsOptions.cs | 49 +-
.../Kafka/Clients/Admin/CreateAclsResult.cs | 49 +-
.../Admin/CreateDelegationTokenOptions.cs | 49 +-
.../Admin/CreateDelegationTokenResult.cs | 49 +-
.../Clients/Admin/CreatePartitionsOptions.cs | 49 +-
.../Clients/Admin/CreatePartitionsResult.cs | 49 +-
.../Clients/Admin/CreateTopicsOptions.cs | 49 +-
.../Kafka/Clients/Admin/CreateTopicsResult.cs | 96 +-
.../Kafka/Clients/Admin/DeleteAclsOptions.cs | 49 +-
.../Kafka/Clients/Admin/DeleteAclsResult.cs | 143 +-
.../DeleteConsumerGroupOffsetsOptions.cs | 49 +-
.../Admin/DeleteConsumerGroupOffsetsResult.cs | 49 +-
.../Admin/DeleteConsumerGroupsOptions.cs | 49 +-
.../Admin/DeleteConsumerGroupsResult.cs | 49 +-
.../Clients/Admin/DeleteRecordsOptions.cs | 49 +-
.../Clients/Admin/DeleteRecordsResult.cs | 49 +-
.../Clients/Admin/DeleteTopicsOptions.cs | 49 +-
.../Kafka/Clients/Admin/DeleteTopicsResult.cs | 49 +-
.../Kafka/Clients/Admin/DeletedRecords.cs | 49 +-
.../Clients/Admin/DescribeAclsOptions.cs | 49 +-
.../Kafka/Clients/Admin/DescribeAclsResult.cs | 49 +-
.../Admin/DescribeClientQuotasOptions.cs | 49 +-
.../Admin/DescribeClientQuotasResult.cs | 49 +-
.../Clients/Admin/DescribeClusterOptions.cs | 49 +-
.../Clients/Admin/DescribeClusterResult.cs | 49 +-
.../Clients/Admin/DescribeConfigsOptions.cs | 49 +-
.../Clients/Admin/DescribeConfigsResult.cs | 49 +-
.../Admin/DescribeConsumerGroupsOptions.cs | 49 +-
.../Admin/DescribeConsumerGroupsResult.cs | 49 +-
.../Admin/DescribeDelegationTokenOptions.cs | 49 +-
.../Admin/DescribeDelegationTokenResult.cs | 49 +-
.../Clients/Admin/DescribeFeaturesOptions.cs | 49 +-
.../Clients/Admin/DescribeFeaturesResult.cs | 49 +-
.../Clients/Admin/DescribeLogDirsOptions.cs | 49 +-
.../Clients/Admin/DescribeLogDirsResult.cs | 49 +-
.../Admin/DescribeMetadataQuorumOptions.cs | 49 +-
.../Admin/DescribeMetadataQuorumResult.cs | 49 +-
.../Clients/Admin/DescribeProducersOptions.cs | 49 +-
.../Clients/Admin/DescribeProducersResult.cs | 96 +-
.../Admin/DescribeReplicaLogDirsOptions.cs | 49 +-
.../Admin/DescribeReplicaLogDirsResult.cs | 96 +-
.../Clients/Admin/DescribeTopicsOptions.cs | 49 +-
.../Clients/Admin/DescribeTopicsResult.cs | 49 +-
.../Admin/DescribeTransactionsOptions.cs | 49 +-
.../Admin/DescribeTransactionsResult.cs | 49 +-
.../DescribeUserScramCredentialsOptions.cs | 49 +-
.../DescribeUserScramCredentialsResult.cs | 49 +-
.../Clients/Admin/ElectLeadersOptions.cs | 49 +-
.../Kafka/Clients/Admin/ElectLeadersResult.cs | 49 +-
.../Admin/ExpireDelegationTokenOptions.cs | 49 +-
.../Admin/ExpireDelegationTokenResult.cs | 49 +-
.../Kafka/Clients/Admin/FeatureMetadata.cs | 49 +-
.../Kafka/Clients/Admin/FeatureUpdate.cs | 96 +-
.../Clients/Admin/FenceProducersOptions.cs | 49 +-
.../Clients/Admin/FenceProducersResult.cs | 49 +-
.../Clients/Admin/FinalizedVersionRange.cs | 49 +-
.../Kafka/Clients/Admin/ForwardingAdmin.cs | 49 +-
.../Kafka/Clients/Admin/KafkaAdminClient.cs | 49 +-
.../Admin/ListConsumerGroupOffsetsOptions.cs | 49 +-
.../Admin/ListConsumerGroupOffsetsResult.cs | 49 +-
.../Admin/ListConsumerGroupOffsetsSpec.cs | 49 +-
.../Admin/ListConsumerGroupsOptions.cs | 49 +-
.../Clients/Admin/ListConsumerGroupsResult.cs | 49 +-
.../Kafka/Clients/Admin/ListOffsetsOptions.cs | 49 +-
.../Kafka/Clients/Admin/ListOffsetsResult.cs | 96 +-
.../ListPartitionReassignmentsOptions.cs | 49 +-
.../Admin/ListPartitionReassignmentsResult.cs | 49 +-
.../Kafka/Clients/Admin/ListTopicsOptions.cs | 49 +-
.../Kafka/Clients/Admin/ListTopicsResult.cs | 49 +-
.../Clients/Admin/ListTransactionsOptions.cs | 49 +-
.../Clients/Admin/ListTransactionsResult.cs | 49 +-
.../Kafka/Clients/Admin/LogDirDescription.cs | 49 +-
.../Kafka/Clients/Admin/MemberAssignment.cs | 49 +-
.../Kafka/Clients/Admin/MemberDescription.cs | 49 +-
.../Kafka/Clients/Admin/MemberToRemove.cs | 49 +-
.../Clients/Admin/NewPartitionReassignment.cs | 49 +-
.../Kafka/Clients/Admin/NewPartitions.cs | 49 +-
.../Apache/Kafka/Clients/Admin/NewTopic.cs | 49 +-
.../Apache/Kafka/Clients/Admin/OffsetSpec.cs | 237 +-
.../Clients/Admin/PartitionReassignment.cs | 49 +-
.../Kafka/Clients/Admin/ProducerState.cs | 49 +-
.../Apache/Kafka/Clients/Admin/QuorumInfo.cs | 96 +-
.../Kafka/Clients/Admin/RecordsToDelete.cs | 49 +-
.../RemoveMembersFromConsumerGroupOptions.cs | 49 +-
.../RemoveMembersFromConsumerGroupResult.cs | 49 +-
.../Admin/RenewDelegationTokenOptions.cs | 49 +-
.../Admin/RenewDelegationTokenResult.cs | 49 +-
.../Apache/Kafka/Clients/Admin/ReplicaInfo.cs | 49 +-
.../Clients/Admin/ScramCredentialInfo.cs | 49 +-
.../Kafka/Clients/Admin/ScramMechanism.cs | 49 +-
.../Clients/Admin/SupportedVersionRange.cs | 49 +-
.../Kafka/Clients/Admin/TopicDescription.cs | 49 +-
.../Kafka/Clients/Admin/TopicListing.cs | 49 +-
.../Clients/Admin/TransactionDescription.cs | 49 +-
.../Kafka/Clients/Admin/TransactionListing.cs | 49 +-
.../Kafka/Clients/Admin/TransactionState.cs | 49 +-
.../Clients/Admin/UnregisterBrokerOptions.cs | 49 +-
.../Clients/Admin/UnregisterBrokerResult.cs | 49 +-
.../Clients/Admin/UpdateFeaturesOptions.cs | 49 +-
.../Clients/Admin/UpdateFeaturesResult.cs | 49 +-
.../Admin/UserScramCredentialAlteration.cs | 51 +-
.../Admin/UserScramCredentialDeletion.cs | 49 +-
.../Admin/UserScramCredentialUpsertion.cs | 49 +-
.../Admin/UserScramCredentialsDescription.cs | 49 +-
.../Apache/Kafka/Clients/AllPackageClasses.cs | 909 ---
.../Org/Apache/Kafka/Clients/ApiVersions.cs | 49 +-
.../Apache/Kafka/Clients/ClientDnsLookup.cs | 49 +-
.../Apache/Kafka/Clients/ClientResponse.cs | 49 +-
.../Org/Apache/Kafka/Clients/ClientUtils.cs | 49 +-
.../Kafka/Clients/CommonClientConfigs.cs | 49 +-
.../Apache/Kafka/Clients/ConnectionState.cs | 49 +-
.../Clients/Consumer/AllPackageClasses.cs | 1564 ----
.../Clients/Consumer/CommitFailedException.cs | 21 +-
.../Apache/Kafka/Clients/Consumer/Consumer.cs | 102 +-
.../Kafka/Clients/Consumer/ConsumerConfig.cs | 49 +-
.../Clients/Consumer/ConsumerGroupMetadata.cs | 49 +-
.../Clients/Consumer/ConsumerInterceptor.cs | 232 +-
.../Consumer/ConsumerPartitionAssignor.cs | 373 +-
.../Consumer/ConsumerRebalanceListener.cs | 106 +-
.../Kafka/Clients/Consumer/ConsumerRecord.cs | 98 +-
.../Kafka/Clients/Consumer/ConsumerRecords.cs | 98 +-
.../Consumer/CooperativeStickyAssignor.cs | 49 +-
.../Consumer/InvalidOffsetException.cs | 21 +-
.../Kafka/Clients/Consumer/KafkaConsumer.cs | 98 +-
.../Consumer/LogTruncationException.cs | 21 +-
.../Kafka/Clients/Consumer/MockConsumer.cs | 98 +-
.../Consumer/NoOffsetForPartitionException.cs | 21 +-
.../Clients/Consumer/OffsetAndMetadata.cs | 49 +-
.../Clients/Consumer/OffsetAndTimestamp.cs | 49 +-
.../Clients/Consumer/OffsetCommitCallback.cs | 84 +-
.../Consumer/OffsetOutOfRangeException.cs | 21 +-
.../Clients/Consumer/OffsetResetStrategy.cs | 49 +-
.../Kafka/Clients/Consumer/RangeAssignor.cs | 49 +-
.../RetriableCommitFailedException.cs | 21 +-
.../Clients/Consumer/RoundRobinAssignor.cs | 49 +-
.../Kafka/Clients/Consumer/StickyAssignor.cs | 49 +-
.../Kafka/Clients/DefaultHostResolver.cs | 49 +-
.../Kafka/Clients/GroupRebalanceConfig.cs | 96 +-
.../Org/Apache/Kafka/Clients/HostResolver.cs | 51 +-
.../Kafka/Clients/ManualMetadataUpdater.cs | 49 +-
.../Org/Apache/Kafka/Clients/Metadata.cs | 143 +-
.../Apache/Kafka/Clients/MetadataSnapshot.cs | 49 +-
.../Apache/Kafka/Clients/MetadataUpdater.cs | 51 +-
.../Kafka/Clients/NetworkClientUtils.cs | 49 +-
.../Apache/Kafka/Clients/NodeApiVersions.cs | 49 +-
.../Clients/Producer/AllPackageClasses.cs | 825 ---
.../Producer/BufferExhaustedException.cs | 21 +-
.../Apache/Kafka/Clients/Producer/Callback.cs | 84 +-
.../Kafka/Clients/Producer/KafkaProducer.cs | 98 +-
.../Kafka/Clients/Producer/MockProducer.cs | 98 +-
.../Kafka/Clients/Producer/Partitioner.cs | 105 +-
.../Apache/Kafka/Clients/Producer/Producer.cs | 102 +-
.../Kafka/Clients/Producer/ProducerConfig.cs | 49 +-
.../Clients/Producer/ProducerInterceptor.cs | 232 +-
.../Kafka/Clients/Producer/ProducerRecord.cs | 98 +-
.../Kafka/Clients/Producer/RecordMetadata.cs | 49 +-
.../Clients/Producer/RoundRobinPartitioner.cs | 49 +-
.../Kafka/Clients/RequestCompletionHandler.cs | 51 +-
.../Kafka/Clients/StaleMetadataException.cs | 21 +-
.../Kafka/Common/Acl/AccessControlEntry.cs | 49 +-
.../Common/Acl/AccessControlEntryFilter.cs | 49 +-
.../Org/Apache/Kafka/Common/Acl/AclBinding.cs | 49 +-
.../Kafka/Common/Acl/AclBindingFilter.cs | 49 +-
.../Apache/Kafka/Common/Acl/AclOperation.cs | 49 +-
.../Kafka/Common/Acl/AclPermissionType.cs | 49 +-
.../Kafka/Common/Acl/AllPackageClasses.cs | 301 -
.../Apache/Kafka/Common/AllPackageClasses.cs | 1419 ----
.../Common/Annotation/AllPackageClasses.cs | 217 -
.../Common/Annotation/InterfaceStability.cs | 196 +-
.../Kafka/Common/Cache/AllPackageClasses.cs | 311 -
.../Org/Apache/Kafka/Common/Cache/Cache.cs | 102 +-
.../Org/Apache/Kafka/Common/Cache/LRUCache.cs | 98 +-
.../Kafka/Common/Cache/SynchronizedCache.cs | 98 +-
.../Org/Apache/Kafka/Common/Cluster.cs | 49 +-
.../Apache/Kafka/Common/ClusterResource.cs | 49 +-
.../Kafka/Common/ClusterResourceListener.cs | 84 +-
.../Common/Compress/AllPackageClasses.cs | 301 -
.../Compress/KafkaLZ4BlockInputStream.cs | 49 +-
.../Compress/KafkaLZ4BlockOutputStream.cs | 143 +-
.../Kafka/Common/Compress/SnappyFactory.cs | 49 +-
.../Kafka/Common/Compress/ZstdFactory.cs | 49 +-
.../Kafka/Common/Config/AbstractConfig.cs | 49 +-
.../Kafka/Common/Config/AllPackageClasses.cs | 1514 ----
.../Org/Apache/Kafka/Common/Config/Config.cs | 49 +-
.../Common/Config/ConfigChangeCallback.cs | 84 +-
.../Apache/Kafka/Common/Config/ConfigData.cs | 49 +-
.../Apache/Kafka/Common/Config/ConfigDef.cs | 805 +-
.../Kafka/Common/Config/ConfigException.cs | 21 +-
.../Kafka/Common/Config/ConfigResource.cs | 96 +-
.../Kafka/Common/Config/ConfigTransformer.cs | 49 +-
.../Common/Config/ConfigTransformerResult.cs | 49 +-
.../Apache/Kafka/Common/Config/ConfigValue.cs | 49 +-
.../Kafka/Common/Config/LogLevelConfig.cs | 49 +-
.../Config/Provider/AllPackageClasses.cs | 213 -
.../Common/Config/Provider/ConfigProvider.cs | 51 +-
.../Provider/DirectoryConfigProvider.cs | 49 +-
.../Config/Provider/EnvVarConfigProvider.cs | 49 +-
.../Config/Provider/FileConfigProvider.cs | 49 +-
.../Apache/Kafka/Common/Config/SaslConfigs.cs | 49 +-
.../Kafka/Common/Config/SecurityConfig.cs | 49 +-
.../Kafka/Common/Config/SslClientAuth.cs | 49 +-
.../Apache/Kafka/Common/Config/SslConfigs.cs | 49 +-
.../Apache/Kafka/Common/Config/TopicConfig.cs | 49 +-
.../Common/Config/Types/AllPackageClasses.cs | 76 -
.../Kafka/Common/Config/Types/Password.cs | 49 +-
.../Org/Apache/Kafka/Common/Configurable.cs | 51 +-
.../Apache/Kafka/Common/ConsumerGroupState.cs | 49 +-
.../Org/Apache/Kafka/Common/ElectionType.cs | 49 +-
.../Org/Apache/Kafka/Common/Endpoint.cs | 49 +-
.../Kafka/Common/Errors/AllPackageClasses.cs | 2190 ------
.../Kafka/Common/Errors/ApiException.cs | 21 +-
.../Common/Errors/AuthenticationException.cs | 21 +-
.../Common/Errors/AuthorizationException.cs | 21 +-
.../Errors/AuthorizerNotReadyException.cs | 21 +-
.../Errors/BrokerIdNotRegisteredException.cs | 21 +-
.../Errors/BrokerNotAvailableException.cs | 21 +-
.../Errors/ClusterAuthorizationException.cs | 21 +-
.../Errors/ConcurrentTransactionsException.cs | 21 +-
.../Common/Errors/ControllerMovedException.cs | 21 +-
.../CoordinatorLoadInProgressException.cs | 21 +-
.../CoordinatorNotAvailableException.cs | 21 +-
.../Common/Errors/CorruptRecordException.cs | 21 +-
.../DelegationTokenAuthorizationException.cs | 21 +-
.../DelegationTokenDisabledException.cs | 21 +-
.../Errors/DelegationTokenExpiredException.cs | 21 +-
.../DelegationTokenNotFoundException.cs | 21 +-
.../DelegationTokenOwnerMismatchException.cs | 21 +-
.../Common/Errors/DisconnectException.cs | 21 +-
.../DuplicateBrokerRegistrationException.cs | 21 +-
.../Errors/DuplicateResourceException.cs | 21 +-
.../Errors/DuplicateSequenceException.cs | 21 +-
.../Errors/ElectionNotNeededException.cs | 21 +-
.../EligibleLeadersNotAvailableException.cs | 21 +-
.../Errors/FeatureUpdateFailedException.cs | 21 +-
.../Errors/FencedInstanceIdException.cs | 21 +-
.../Errors/FencedLeaderEpochException.cs | 21 +-
.../Errors/FencedMemberEpochException.cs | 21 +-
.../Errors/FetchSessionIdNotFoundException.cs | 21 +-
.../Errors/FetchSessionTopicIdException.cs | 21 +-
.../Errors/GroupAuthorizationException.cs | 21 +-
.../Common/Errors/GroupIdNotFoundException.cs | 21 +-
.../Errors/GroupMaxSizeReachedException.cs | 21 +-
.../Common/Errors/GroupNotEmptyException.cs | 21 +-
.../Errors/GroupSubscribedToTopicException.cs | 21 +-
.../Errors/IllegalGenerationException.cs | 21 +-
.../Errors/IllegalSaslStateException.cs | 21 +-
.../Errors/InconsistentClusterIdException.cs | 21 +-
.../InconsistentGroupProtocolException.cs | 21 +-
.../Errors/InconsistentTopicIdException.cs | 21 +-
.../Errors/InconsistentVoterSetException.cs | 21 +-
.../Errors/IneligibleReplicaException.cs | 21 +-
.../Kafka/Common/Errors/InterruptException.cs | 21 +-
.../InvalidCommitOffsetSizeException.cs | 21 +-
.../Errors/InvalidConfigurationException.cs | 21 +-
.../InvalidFetchSessionEpochException.cs | 21 +-
.../Errors/InvalidFetchSizeException.cs | 21 +-
.../Common/Errors/InvalidGroupIdException.cs | 21 +-
.../Common/Errors/InvalidMetadataException.cs | 21 +-
.../Common/Errors/InvalidOffsetException.cs | 21 +-
.../Errors/InvalidPartitionsException.cs | 21 +-
.../Errors/InvalidPidMappingException.cs | 21 +-
.../Errors/InvalidPrincipalTypeException.cs | 21 +-
.../Errors/InvalidProducerEpochException.cs | 21 +-
.../InvalidReplicaAssignmentException.cs | 21 +-
.../InvalidReplicationFactorException.cs | 21 +-
.../Common/Errors/InvalidRequestException.cs | 21 +-
.../Errors/InvalidRequiredAcksException.cs | 21 +-
.../Errors/InvalidSessionTimeoutException.cs | 21 +-
.../Errors/InvalidTimestampException.cs | 21 +-
.../Common/Errors/InvalidTopicException.cs | 21 +-
.../Common/Errors/InvalidTxnStateException.cs | 21 +-
.../Errors/InvalidTxnTimeoutException.cs | 21 +-
.../Errors/InvalidUpdateVersionException.cs | 21 +-
.../Common/Errors/KafkaStorageException.cs | 21 +-
.../Errors/LeaderNotAvailableException.cs | 21 +-
.../Errors/ListenerNotFoundException.cs | 21 +-
.../Common/Errors/LogDirNotFoundException.cs | 21 +-
.../Errors/MemberIdRequiredException.cs | 21 +-
.../Kafka/Common/Errors/NetworkException.cs | 21 +-
.../Errors/NewLeaderElectedException.cs | 21 +-
.../NoReassignmentInProgressException.cs | 21 +-
.../Common/Errors/NotControllerException.cs | 21 +-
.../Common/Errors/NotCoordinatorException.cs | 21 +-
.../NotEnoughReplicasAfterAppendException.cs | 21 +-
.../Errors/NotEnoughReplicasException.cs | 21 +-
.../Errors/NotLeaderOrFollowerException.cs | 21 +-
.../Common/Errors/OffsetMetadataTooLarge.cs | 21 +-
.../OffsetMovedToTieredStorageException.cs | 21 +-
.../Errors/OffsetNotAvailableException.cs | 21 +-
.../Errors/OffsetOutOfRangeException.cs | 21 +-
.../Errors/OperationNotAttemptedException.cs | 21 +-
.../Errors/OutOfOrderSequenceException.cs | 21 +-
.../Common/Errors/PolicyViolationException.cs | 21 +-
.../Errors/PositionOutOfRangeException.cs | 21 +-
.../PreferredLeaderNotAvailableException.cs | 21 +-
.../PrincipalDeserializationException.cs | 21 +-
.../Common/Errors/ProducerFencedException.cs | 21 +-
.../Errors/ReassignmentInProgressException.cs | 21 +-
.../Errors/RebalanceInProgressException.cs | 21 +-
.../Errors/RecordBatchTooLargeException.cs | 21 +-
.../Errors/RecordDeserializationException.cs | 21 +-
.../Common/Errors/RecordTooLargeException.cs | 21 +-
.../Errors/ReplicaNotAvailableException.cs | 21 +-
.../Errors/ResourceNotFoundException.cs | 21 +-
.../Kafka/Common/Errors/RetriableException.cs | 21 +-
.../Errors/SaslAuthenticationException.cs | 21 +-
.../Errors/SecurityDisabledException.cs | 21 +-
.../Common/Errors/SerializationException.cs | 21 +-
.../Errors/SnapshotNotFoundException.cs | 21 +-
.../Errors/SslAuthenticationException.cs | 21 +-
.../Errors/StaleBrokerEpochException.cs | 21 +-
.../Errors/StaleMemberEpochException.cs | 21 +-
.../ThrottlingQuotaExceededException.cs | 21 +-
.../Kafka/Common/Errors/TimeoutException.cs | 21 +-
.../Errors/TopicAuthorizationException.cs | 21 +-
.../Errors/TopicDeletionDisabledException.cs | 21 +-
.../Common/Errors/TopicExistsException.cs | 21 +-
.../Errors/TransactionAbortedException.cs | 21 +-
.../TransactionCoordinatorFencedException.cs | 21 +-
.../TransactionalIdAuthorizationException.cs | 21 +-
.../TransactionalIdNotFoundException.cs | 21 +-
.../Errors/UnacceptableCredentialException.cs | 21 +-
.../Errors/UnknownLeaderEpochException.cs | 21 +-
.../Common/Errors/UnknownMemberIdException.cs | 21 +-
.../Errors/UnknownProducerIdException.cs | 21 +-
.../Common/Errors/UnknownServerException.cs | 21 +-
.../Common/Errors/UnknownTopicIdException.cs | 21 +-
.../UnknownTopicOrPartitionException.cs | 21 +-
.../Errors/UnreleasedInstanceIdException.cs | 21 +-
.../Errors/UnstableOffsetCommitException.cs | 21 +-
.../Errors/UnsupportedAssignorException.cs | 21 +-
.../UnsupportedByAuthenticationException.cs | 21 +-
.../UnsupportedCompressionTypeException.cs | 21 +-
.../UnsupportedForMessageFormatException.cs | 21 +-
.../UnsupportedSaslMechanismException.cs | 21 +-
.../Errors/UnsupportedVersionException.cs | 21 +-
.../Kafka/Common/Errors/WakeupException.cs | 21 +-
.../Kafka/Common/Header/AllPackageClasses.cs | 125 -
.../Org/Apache/Kafka/Common/Header/Header.cs | 51 +-
.../Org/Apache/Kafka/Common/Header/Headers.cs | 51 +-
.../Kafka/Common/InvalidRecordException.cs | 21 +-
.../Org/Apache/Kafka/Common/IsolationLevel.cs | 49 +-
.../Org/Apache/Kafka/Common/KafkaException.cs | 21 +-
.../Org/Apache/Kafka/Common/KafkaFuture.cs | 301 +-
.../Kafka/Common/Memory/AllPackageClasses.cs | 168 -
.../Memory/GarbageCollectedMemoryPool.cs | 49 +-
.../Apache/Kafka/Common/Memory/MemoryPool.cs | 51 +-
.../Kafka/Common/Memory/SimpleMemoryPool.cs | 49 +-
.../Apache/Kafka/Common/MessageFormatter.cs | 51 +-
.../Org/Apache/Kafka/Common/Metric.cs | 51 +-
.../Org/Apache/Kafka/Common/MetricName.cs | 49 +-
.../Apache/Kafka/Common/MetricNameTemplate.cs | 49 +-
.../Kafka/Common/Metrics/AllPackageClasses.cs | 945 ---
.../Kafka/Common/Metrics/CompoundStat.cs | 98 +-
.../Org/Apache/Kafka/Common/Metrics/Gauge.cs | 101 +-
.../Kafka/Common/Metrics/JmxReporter.cs | 49 +-
.../Kafka/Common/Metrics/KafkaMetric.cs | 49 +-
.../Common/Metrics/KafkaMetricsContext.cs | 49 +-
.../Apache/Kafka/Common/Metrics/Measurable.cs | 51 +-
.../Kafka/Common/Metrics/MeasurableStat.cs | 51 +-
.../Kafka/Common/Metrics/MetricConfig.cs | 49 +-
.../Common/Metrics/MetricValueProvider.cs | 101 +-
.../Apache/Kafka/Common/Metrics/Metrics.cs | 49 +-
.../Kafka/Common/Metrics/MetricsContext.cs | 51 +-
.../Kafka/Common/Metrics/MetricsReporter.cs | 169 +-
.../Org/Apache/Kafka/Common/Metrics/Quota.cs | 49 +-
.../Common/Metrics/QuotaViolationException.cs | 21 +-
.../Org/Apache/Kafka/Common/Metrics/Sensor.cs | 96 +-
.../Org/Apache/Kafka/Common/Metrics/Stat.cs | 51 +-
.../Common/Metrics/Stats/AllPackageClasses.cs | 1025 ---
.../Apache/Kafka/Common/Metrics/Stats/Avg.cs | 49 +-
.../Common/Metrics/Stats/CumulativeCount.cs | 49 +-
.../Common/Metrics/Stats/CumulativeSum.cs | 49 +-
.../Kafka/Common/Metrics/Stats/Frequencies.cs | 49 +-
.../Kafka/Common/Metrics/Stats/Frequency.cs | 49 +-
.../Kafka/Common/Metrics/Stats/Histogram.cs | 192 +-
.../Apache/Kafka/Common/Metrics/Stats/Max.cs | 49 +-
.../Kafka/Common/Metrics/Stats/Meter.cs | 49 +-
.../Apache/Kafka/Common/Metrics/Stats/Min.cs | 49 +-
.../Kafka/Common/Metrics/Stats/Percentile.cs | 49 +-
.../Kafka/Common/Metrics/Stats/Percentiles.cs | 96 +-
.../Apache/Kafka/Common/Metrics/Stats/Rate.cs | 49 +-
.../Kafka/Common/Metrics/Stats/SampledStat.cs | 51 +-
.../Kafka/Common/Metrics/Stats/SimpleRate.cs | 49 +-
.../Kafka/Common/Metrics/Stats/TokenBucket.cs | 49 +-
.../Kafka/Common/Metrics/Stats/Value.cs | 49 +-
.../Common/Metrics/Stats/WindowedCount.cs | 49 +-
.../Kafka/Common/Metrics/Stats/WindowedSum.cs | 49 +-
.../Generated/Org/Apache/Kafka/Common/Node.cs | 49 +-
.../Org/Apache/Kafka/Common/PartitionInfo.cs | 49 +-
.../Kafka/Common/Quota/AllPackageClasses.cs | 256 -
.../Common/Quota/ClientQuotaAlteration.cs | 96 +-
.../Kafka/Common/Quota/ClientQuotaEntity.cs | 49 +-
.../Kafka/Common/Quota/ClientQuotaFilter.cs | 49 +-
.../Quota/ClientQuotaFilterComponent.cs | 49 +-
.../Org/Apache/Kafka/Common/Reconfigurable.cs | 51 +-
.../Record/AbstractLegacyRecordBatch.cs | 51 +-
.../Kafka/Common/Record/AllPackageClasses.cs | 1172 ---
.../Kafka/Common/Record/CompressionType.cs | 51 +-
.../Kafka/Common/Record/ControlRecordType.cs | 49 +-
.../Kafka/Common/Record/ControlRecordUtils.cs | 49 +-
.../Kafka/Common/Record/DefaultRecordBatch.cs | 49 +-
.../Kafka/Common/Record/FileLogInputStream.cs | 98 +-
.../Record/LazyDownConversionRecords.cs | 49 +-
.../Kafka/Common/Record/LegacyRecord.cs | 49 +-
.../Common/Record/MemoryRecordsBuilder.cs | 96 +-
.../Kafka/Common/Record/MultiRecordsSend.cs | 49 +-
.../Kafka/Common/Record/MutableRecordBatch.cs | 51 +-
.../Org/Apache/Kafka/Common/Record/Record.cs | 51 +-
.../Apache/Kafka/Common/Record/RecordBatch.cs | 51 +-
.../Common/Record/RecordConversionStats.cs | 49 +-
.../Kafka/Common/Record/RecordVersion.cs | 49 +-
.../Apache/Kafka/Common/Record/RecordsUtil.cs | 49 +-
.../Common/Record/RemoteLogInputStream.cs | 49 +-
.../Kafka/Common/Record/SimpleRecord.cs | 49 +-
.../Kafka/Common/Record/TimestampType.cs | 49 +-
.../Common/Record/TransferableRecords.cs | 51 +-
.../Common/Record/UnalignedFileRecords.cs | 49 +-
.../Common/Record/UnalignedMemoryRecords.cs | 49 +-
.../Kafka/Common/Record/UnalignedRecords.cs | 51 +-
.../Kafka/Common/Replica/AllPackageClasses.cs | 399 -
.../Kafka/Common/Replica/ClientMetadata.cs | 98 +-
.../Kafka/Common/Replica/PartitionView.cs | 98 +-
.../Replica/RackAwareReplicaSelector.cs | 49 +-
.../Kafka/Common/Replica/ReplicaSelector.cs | 51 +-
.../Kafka/Common/Replica/ReplicaView.cs | 98 +-
.../Common/Resource/AllPackageClasses.cs | 256 -
.../Kafka/Common/Resource/PatternType.cs | 49 +-
.../Apache/Kafka/Common/Resource/Resource.cs | 49 +-
.../Kafka/Common/Resource/ResourcePattern.cs | 49 +-
.../Common/Resource/ResourcePatternFilter.cs | 49 +-
.../Kafka/Common/Resource/ResourceType.cs | 49 +-
.../Common/Security/AllPackageClasses.cs | 166 -
.../Common/Security/Auth/AllPackageClasses.cs | 675 --
.../Auth/AuthenticateCallbackHandler.cs | 51 +-
.../Security/Auth/AuthenticationContext.cs | 51 +-
.../Common/Security/Auth/KafkaPrincipal.cs | 49 +-
.../Security/Auth/KafkaPrincipalBuilder.cs | 51 +-
.../Security/Auth/KafkaPrincipalSerde.cs | 51 +-
.../Kafka/Common/Security/Auth/Login.cs | 51 +-
.../Auth/PlaintextAuthenticationContext.cs | 49 +-
.../Auth/SaslAuthenticationContext.cs | 49 +-
.../Common/Security/Auth/SaslExtensions.cs | 49 +-
.../Security/Auth/SaslExtensionsCallback.cs | 49 +-
.../Common/Security/Auth/SecurityProtocol.cs | 49 +-
.../Security/Auth/SecurityProviderCreator.cs | 51 +-
.../Security/Auth/SslAuthenticationContext.cs | 49 +-
.../Common/Security/Auth/SslEngineFactory.cs | 51 +-
.../Security/Authenticator/AbstractLogin.cs | 98 +-
.../Authenticator/AllPackageClasses.cs | 664 --
.../Security/Authenticator/CredentialCache.cs | 144 +-
.../DefaultKafkaPrincipalBuilder.cs | 49 +-
.../Security/Authenticator/DefaultLogin.cs | 49 +-
.../Security/Authenticator/LoginManager.cs | 49 +-
.../Authenticator/SaslClientAuthenticator.cs | 96 +-
.../SaslClientCallbackHandler.cs | 49 +-
.../Authenticator/SaslInternalConfigs.cs | 49 +-
.../Authenticator/SaslServerAuthenticator.cs | 49 +-
.../SaslServerCallbackHandler.cs | 49 +-
.../Kafka/Common/Security/JaasContext.cs | 96 +-
.../Apache/Kafka/Common/Security/JaasUtils.cs | 49 +-
.../Security/Oauthbearer/AllPackageClasses.cs | 348 -
.../OAuthBearerExtensionsValidatorCallback.cs | 49 +-
.../OAuthBearerLoginCallbackHandler.cs | 49 +-
.../Oauthbearer/OAuthBearerLoginModule.cs | 49 +-
.../Security/Oauthbearer/OAuthBearerToken.cs | 51 +-
.../Oauthbearer/OAuthBearerTokenCallback.cs | 49 +-
.../OAuthBearerValidatorCallback.cs | 49 +-
.../OAuthBearerValidatorCallbackHandler.cs | 49 +-
.../Oauthbearer/Secured/AllPackageClasses.cs | 31 -
.../Security/Plain/AllPackageClasses.cs | 121 -
.../Plain/Internals/AllPackageClasses.cs | 211 -
.../Plain/Internals/PlainSaslServer.cs | 96 +-
.../Internals/PlainSaslServerProvider.cs | 49 +-
.../Internals/PlainServerCallbackHandler.cs | 49 +-
.../Plain/PlainAuthenticateCallback.cs | 49 +-
.../Common/Security/Plain/PlainLoginModule.cs | 49 +-
.../Security/Scram/AllPackageClasses.cs | 211 -
.../Common/Security/Scram/ScramCredential.cs | 49 +-
.../Security/Scram/ScramCredentialCallback.cs | 49 +-
.../Security/Scram/ScramExtensionsCallback.cs | 49 +-
.../Common/Security/Scram/ScramLoginModule.cs | 49 +-
.../Common/Security/Ssl/AllPackageClasses.cs | 183 -
.../Security/Ssl/DefaultSslEngineFactory.cs | 49 +-
.../Kafka/Common/Security/Ssl/SslFactory.cs | 49 +-
.../Common/Security/Ssl/SslPrincipalMapper.cs | 68 +-
.../Token/Delegation/AllPackageClasses.cs | 121 -
.../Token/Delegation/DelegationToken.cs | 49 +-
.../Token/Delegation/TokenInformation.cs | 49 +-
.../Common/Serialization/AllPackageClasses.cs | 2420 ------
.../Serialization/BooleanDeserializer.cs | 49 +-
.../Common/Serialization/BooleanSerializer.cs | 49 +-
.../Serialization/ByteArrayDeserializer.cs | 49 +-
.../Serialization/ByteArraySerializer.cs | 49 +-
.../Serialization/ByteBufferDeserializer.cs | 49 +-
.../Serialization/ByteBufferSerializer.cs | 49 +-
.../Common/Serialization/BytesDeserializer.cs | 49 +-
.../Common/Serialization/BytesSerializer.cs | 49 +-
.../Common/Serialization/Deserializer.cs | 257 +-
.../Serialization/DoubleDeserializer.cs | 49 +-
.../Common/Serialization/DoubleSerializer.cs | 49 +-
.../Common/Serialization/FloatDeserializer.cs | 49 +-
.../Common/Serialization/FloatSerializer.cs | 49 +-
.../Serialization/IntegerDeserializer.cs | 49 +-
.../Common/Serialization/IntegerSerializer.cs | 49 +-
.../Common/Serialization/ListDeserializer.cs | 97 +-
.../Common/Serialization/ListSerializer.cs | 97 +-
.../Common/Serialization/LongDeserializer.cs | 49 +-
.../Common/Serialization/LongSerializer.cs | 49 +-
.../Kafka/Common/Serialization/Serde.cs | 225 +-
.../Kafka/Common/Serialization/Serdes.cs | 803 +-
.../Kafka/Common/Serialization/Serializer.cs | 233 +-
.../Common/Serialization/ShortDeserializer.cs | 49 +-
.../Common/Serialization/ShortSerializer.cs | 49 +-
.../Serialization/StringDeserializer.cs | 49 +-
.../Common/Serialization/StringSerializer.cs | 49 +-
.../Common/Serialization/UUIDDeserializer.cs | 49 +-
.../Common/Serialization/UUIDSerializer.cs | 49 +-
.../Common/Serialization/VoidDeserializer.cs | 49 +-
.../Apache/Kafka/Common/TopicCollection.cs | 145 +-
.../Apache/Kafka/Common/TopicIdPartition.cs | 49 +-
.../Org/Apache/Kafka/Common/TopicPartition.cs | 49 +-
.../Apache/Kafka/Common/TopicPartitionInfo.cs | 49 +-
.../Kafka/Common/TopicPartitionReplica.cs | 49 +-
.../Kafka/Common/Utils/AbstractIterator.cs | 101 +-
.../Kafka/Common/Utils/AllPackageClasses.cs | 2558 -------
.../Kafka/Common/Utils/AppInfoParser.cs | 145 +-
.../Kafka/Common/Utils/BufferSupplier.cs | 98 +-
.../Common/Utils/ByteBufferInputStream.cs | 49 +-
.../Common/Utils/ByteBufferOutputStream.cs | 49 +-
.../Kafka/Common/Utils/ByteBufferUnmapper.cs | 49 +-
.../Apache/Kafka/Common/Utils/ByteUtils.cs | 49 +-
.../Org/Apache/Kafka/Common/Utils/Bytes.cs | 49 +-
.../Apache/Kafka/Common/Utils/Checksums.cs | 49 +-
.../Common/Utils/ChildFirstClassLoader.cs | 49 +-
.../Kafka/Common/Utils/ChunkedBytesStream.cs | 49 +-
.../Kafka/Common/Utils/CircularIterator.cs | 97 +-
.../Kafka/Common/Utils/CloseableIterator.cs | 101 +-
.../Kafka/Common/Utils/CollectionUtils.cs | 49 +-
.../Apache/Kafka/Common/Utils/ConfigUtils.cs | 49 +-
.../Kafka/Common/Utils/CopyOnWriteMap.cs | 98 +-
.../Org/Apache/Kafka/Common/Utils/Crc32C.cs | 49 +-
.../Org/Apache/Kafka/Common/Utils/Exit.cs | 147 +-
.../Kafka/Common/Utils/ExponentialBackoff.cs | 49 +-
.../Kafka/Common/Utils/FixedOrderMap.cs | 98 +-
.../Kafka/Common/Utils/FlattenedIterator.cs | 98 +-
.../Apache/Kafka/Common/Utils/KafkaThread.cs | 49 +-
.../Apache/Kafka/Common/Utils/LogContext.cs | 49 +-
.../Common/Utils/LoggingSignalHandler.cs | 49 +-
.../Kafka/Common/Utils/MappedIterator.cs | 98 +-
.../Kafka/Common/Utils/OperatingSystem.cs | 49 +-
.../Apache/Kafka/Common/Utils/PrimitiveRef.cs | 143 +-
.../Kafka/Common/Utils/ProducerIdAndEpoch.cs | 49 +-
.../Kafka/Common/Utils/PureJavaCrc32C.cs | 49 +-
.../Apache/Kafka/Common/Utils/Sanitizer.cs | 49 +-
.../Apache/Kafka/Common/Utils/Scheduler.cs | 51 +-
.../Kafka/Common/Utils/SecurityUtils.cs | 49 +-
.../Org/Apache/Kafka/Common/Utils/Shell.cs | 117 +-
.../Kafka/Common/Utils/SystemScheduler.cs | 49 +-
.../Apache/Kafka/Common/Utils/SystemTime.cs | 49 +-
.../Apache/Kafka/Common/Utils/ThreadUtils.cs | 49 +-
.../Org/Apache/Kafka/Common/Utils/Time.cs | 51 +-
.../Org/Apache/Kafka/Common/Utils/Timer.cs | 49 +-
.../Org/Apache/Kafka/Common/Utils/Utils.cs | 98 +-
.../Generated/Org/Apache/Kafka/Common/Uuid.cs | 49 +-
.../Kafka/Connect/Cli/AllPackageClasses.cs | 121 -
.../Kafka/Connect/Cli/ConnectDistributed.cs | 49 +-
.../Kafka/Connect/Cli/ConnectStandalone.cs | 49 +-
.../Connect/Components/AllPackageClasses.cs | 78 -
.../Kafka/Connect/Components/Versioned.cs | 51 +-
.../Connect/Connector/AllPackageClasses.cs | 267 -
.../Kafka/Connect/Connector/ConnectRecord.cs | 101 +-
.../Kafka/Connect/Connector/Connector.cs | 51 +-
.../Connect/Connector/ConnectorContext.cs | 51 +-
.../Apache/Kafka/Connect/Connector/Task.cs | 51 +-
.../Connect/Converters/AllPackageClasses.cs | 346 -
.../Connect/Converters/ByteArrayConverter.cs | 49 +-
.../Connect/Converters/DoubleConverter.cs | 49 +-
.../Connect/Converters/FloatConverter.cs | 49 +-
.../Connect/Converters/IntegerConverter.cs | 49 +-
.../Kafka/Connect/Converters/LongConverter.cs | 49 +-
.../Converters/NumberConverterConfig.cs | 49 +-
.../Connect/Converters/ShortConverter.cs | 49 +-
.../Kafka/Connect/Data/AllPackageClasses.cs | 618 --
.../Kafka/Connect/Data/ConnectSchema.cs | 49 +-
.../Org/Apache/Kafka/Connect/Data/Date.cs | 49 +-
.../Org/Apache/Kafka/Connect/Data/Decimal.cs | 49 +-
.../Org/Apache/Kafka/Connect/Data/Field.cs | 49 +-
.../Org/Apache/Kafka/Connect/Data/Schema.cs | 98 +-
.../Kafka/Connect/Data/SchemaAndValue.cs | 49 +-
.../Kafka/Connect/Data/SchemaBuilder.cs | 49 +-
.../Kafka/Connect/Data/SchemaProjector.cs | 49 +-
.../Org/Apache/Kafka/Connect/Data/Struct.cs | 49 +-
.../Org/Apache/Kafka/Connect/Data/Time.cs | 49 +-
.../Apache/Kafka/Connect/Data/Timestamp.cs | 49 +-
.../Org/Apache/Kafka/Connect/Data/Values.cs | 49 +-
.../Kafka/Connect/Errors/AllPackageClasses.cs | 167 -
.../Connect/Errors/AlreadyExistsException.cs | 21 +-
.../Kafka/Connect/Errors/ConnectException.cs | 21 +-
.../Kafka/Connect/Errors/DataException.cs | 21 +-
.../Errors/IllegalWorkerStateException.cs | 21 +-
.../Kafka/Connect/Errors/NotFoundException.cs | 21 +-
.../Connect/Errors/RetriableException.cs | 21 +-
.../Connect/Errors/SchemaBuilderException.cs | 21 +-
.../Errors/SchemaProjectorException.cs | 21 +-
.../Kafka/Connect/Header/AllPackageClasses.cs | 217 -
.../Kafka/Connect/Header/ConnectHeaders.cs | 49 +-
.../Org/Apache/Kafka/Connect/Header/Header.cs | 51 +-
.../Apache/Kafka/Connect/Header/Headers.cs | 100 +-
.../Kafka/Connect/Health/AbstractState.cs | 51 +-
.../Kafka/Connect/Health/AllPackageClasses.cs | 352 -
.../Connect/Health/ConnectClusterDetails.cs | 51 +-
.../Connect/Health/ConnectClusterState.cs | 51 +-
.../Kafka/Connect/Health/ConnectorHealth.cs | 49 +-
.../Kafka/Connect/Health/ConnectorState.cs | 49 +-
.../Kafka/Connect/Health/ConnectorType.cs | 49 +-
.../Apache/Kafka/Connect/Health/TaskState.cs | 49 +-
.../Kafka/Connect/Json/AllPackageClasses.cs | 301 -
.../Kafka/Connect/Json/DecimalFormat.cs | 49 +-
.../Kafka/Connect/Json/JsonConverter.cs | 49 +-
.../Kafka/Connect/Json/JsonConverterConfig.cs | 49 +-
.../Kafka/Connect/Json/JsonDeserializer.cs | 49 +-
.../Apache/Kafka/Connect/Json/JsonSchema.cs | 49 +-
.../Kafka/Connect/Json/JsonSerializer.cs | 49 +-
.../Kafka/Connect/Mirror/AllPackageClasses.cs | 1482 ----
.../Apache/Kafka/Connect/Mirror/Checkpoint.cs | 49 +-
.../Connect/Mirror/ConfigPropertyFilter.cs | 51 +-
.../Mirror/DefaultConfigPropertyFilter.cs | 49 +-
.../Connect/Mirror/DefaultGroupFilter.cs | 49 +-
.../Mirror/DefaultReplicationPolicy.cs | 49 +-
.../Connect/Mirror/DefaultTopicFilter.cs | 49 +-
.../Mirror/Formatters/AllPackageClasses.cs | 166 -
.../Mirror/Formatters/CheckpointFormatter.cs | 49 +-
.../Mirror/Formatters/HeartbeatFormatter.cs | 49 +-
.../Mirror/Formatters/OffsetSyncFormatter.cs | 49 +-
.../Kafka/Connect/Mirror/GroupFilter.cs | 51 +-
.../Apache/Kafka/Connect/Mirror/Heartbeat.cs | 49 +-
.../Mirror/IdentityReplicationPolicy.cs | 49 +-
.../Connect/Mirror/MirrorCheckpointConfig.cs | 49 +-
.../Mirror/MirrorCheckpointConnector.cs | 49 +-
.../Connect/Mirror/MirrorCheckpointTask.cs | 49 +-
.../Mirror/MirrorCheckpointTaskConfig.cs | 49 +-
.../Kafka/Connect/Mirror/MirrorClient.cs | 49 +-
.../Connect/Mirror/MirrorClientConfig.cs | 49 +-
.../Connect/Mirror/MirrorConnectorConfig.cs | 51 +-
.../Connect/Mirror/MirrorHeartbeatConfig.cs | 49 +-
.../Mirror/MirrorHeartbeatConnector.cs | 49 +-
.../Connect/Mirror/MirrorHeartbeatTask.cs | 49 +-
.../Kafka/Connect/Mirror/MirrorHerder.cs | 49 +-
.../Kafka/Connect/Mirror/MirrorMaker.cs | 49 +-
.../Kafka/Connect/Mirror/MirrorMakerConfig.cs | 49 +-
.../Connect/Mirror/MirrorSourceConfig.cs | 49 +-
.../Connect/Mirror/MirrorSourceConnector.cs | 49 +-
.../Kafka/Connect/Mirror/MirrorSourceTask.cs | 49 +-
.../Connect/Mirror/MirrorSourceTaskConfig.cs | 49 +-
.../Kafka/Connect/Mirror/MirrorUtils.cs | 49 +-
.../Apache/Kafka/Connect/Mirror/OffsetSync.cs | 49 +-
.../Connect/Mirror/RemoteClusterUtils.cs | 49 +-
.../Kafka/Connect/Mirror/ReplicationPolicy.cs | 51 +-
.../Kafka/Connect/Mirror/SourceAndTarget.cs | 49 +-
.../Kafka/Connect/Mirror/TopicFilter.cs | 51 +-
.../Kafka/Connect/Rest/AllPackageClasses.cs | 31 -
.../Basic/Auth/Extension/AllPackageClasses.cs | 211 -
.../BasicAuthSecurityRestExtension.cs | 49 +-
.../Auth/Extension/JaasBasicAuthFilter.cs | 96 +-
.../Auth/Extension/PropertyFileLoginModule.cs | 49 +-
.../Kafka/Connect/Sink/AllPackageClasses.cs | 311 -
.../Connect/Sink/ErrantRecordReporter.cs | 51 +-
.../Kafka/Connect/Sink/SinkConnector.cs | 51 +-
.../Connect/Sink/SinkConnectorContext.cs | 51 +-
.../Apache/Kafka/Connect/Sink/SinkRecord.cs | 49 +-
.../Org/Apache/Kafka/Connect/Sink/SinkTask.cs | 51 +-
.../Kafka/Connect/Sink/SinkTaskContext.cs | 51 +-
.../Kafka/Connect/Source/AllPackageClasses.cs | 446 --
.../Source/ConnectorTransactionBoundaries.cs | 49 +-
.../Connect/Source/ExactlyOnceSupport.cs | 49 +-
.../Kafka/Connect/Source/SourceConnector.cs | 51 +-
.../Connect/Source/SourceConnectorContext.cs | 51 +-
.../Kafka/Connect/Source/SourceRecord.cs | 49 +-
.../Apache/Kafka/Connect/Source/SourceTask.cs | 98 +-
.../Kafka/Connect/Source/SourceTaskContext.cs | 51 +-
.../Connect/Source/TransactionContext.cs | 51 +-
.../Connect/Transforms/AllPackageClasses.cs | 3443 ---------
.../Apache/Kafka/Connect/Transforms/Cast.cs | 291 +-
.../Kafka/Connect/Transforms/DropHeaders.cs | 97 +-
.../Kafka/Connect/Transforms/ExtractField.cs | 291 +-
.../Apache/Kafka/Connect/Transforms/Filter.cs | 97 +-
.../Kafka/Connect/Transforms/Flatten.cs | 291 +-
.../Kafka/Connect/Transforms/HeaderFrom.cs | 291 +-
.../Kafka/Connect/Transforms/HoistField.cs | 291 +-
.../Kafka/Connect/Transforms/InsertField.cs | 291 +-
.../Kafka/Connect/Transforms/InsertHeader.cs | 97 +-
.../Kafka/Connect/Transforms/MaskField.cs | 291 +-
.../Predicates/AllPackageClasses.cs | 400 -
.../Transforms/Predicates/HasHeaderKey.cs | 97 +-
.../Transforms/Predicates/Predicate.cs | 101 +-
.../Predicates/RecordIsTombstone.cs | 97 +-
.../Transforms/Predicates/TopicNameMatches.cs | 97 +-
.../Kafka/Connect/Transforms/RegexRouter.cs | 97 +-
.../Kafka/Connect/Transforms/ReplaceField.cs | 291 +-
.../Connect/Transforms/SetSchemaMetadata.cs | 291 +-
.../Connect/Transforms/TimestampConverter.cs | 291 +-
.../Connect/Transforms/TimestampRouter.cs | 97 +-
.../Connect/Transforms/Transformation.cs | 101 +-
.../Transforms/Util/AllPackageClasses.cs | 256 -
.../Transforms/Util/NonEmptyListValidator.cs | 49 +-
.../Connect/Transforms/Util/RegexValidator.cs | 49 +-
.../Connect/Transforms/Util/Requirements.cs | 49 +-
.../Connect/Transforms/Util/SchemaUtil.cs | 49 +-
.../Connect/Transforms/Util/SimpleConfig.cs | 49 +-
.../Kafka/Connect/Transforms/ValueToKey.cs | 97 +-
.../Kafka/Connect/Util/AllPackageClasses.cs | 1084 ---
.../Org/Apache/Kafka/Connect/Util/Callback.cs | 101 +-
.../Apache/Kafka/Connect/Util/ConnectUtils.cs | 49 +-
.../Kafka/Connect/Util/ConnectorTaskId.cs | 49 +-
.../Kafka/Connect/Util/ConnectorUtils.cs | 49 +-
.../Connect/Util/ConvertingFutureCallback.cs | 102 +-
.../Kafka/Connect/Util/FutureCallback.cs | 97 +-
.../Kafka/Connect/Util/KafkaBasedLog.cs | 98 +-
.../Kafka/Connect/Util/LoggingContext.cs | 96 +-
.../Apache/Kafka/Connect/Util/RetryUtil.cs | 49 +-
.../Connect/Util/SafeObjectInputStream.cs | 49 +-
.../Apache/Kafka/Connect/Util/SinkUtils.cs | 49 +-
.../Org/Apache/Kafka/Connect/Util/Table.cs | 99 +-
.../Apache/Kafka/Connect/Util/TopicAdmin.cs | 143 +-
.../Kafka/Connect/Util/TopicCreation.cs | 49 +-
.../Kafka/Connect/Util/TopicCreationGroup.cs | 49 +-
.../Apache/Kafka/Raft/AllPackageClasses.cs | 2451 ------
.../Generated/Org/Apache/Kafka/Raft/Batch.cs | 97 +-
.../Org/Apache/Kafka/Raft/BatchReader.cs | 101 +-
.../Org/Apache/Kafka/Raft/CandidateState.cs | 49 +-
.../Org/Apache/Kafka/Raft/ControlRecord.cs | 49 +-
.../Org/Apache/Kafka/Raft/ElectionState.cs | 49 +-
.../Org/Apache/Kafka/Raft/EpochState.cs | 51 +-
.../Kafka/Raft/Errors/AllPackageClasses.cs | 99 -
.../Raft/Errors/BufferAllocationException.cs | 21 +-
.../Kafka/Raft/Errors/NotLeaderException.cs | 21 +-
.../Apache/Kafka/Raft/Errors/RaftException.cs | 21 +-
.../Errors/UnexpectedBaseOffsetException.cs | 21 +-
.../Apache/Kafka/Raft/ExpirationService.cs | 51 +-
.../Apache/Kafka/Raft/FileBasedStateStore.cs | 49 +-
.../Org/Apache/Kafka/Raft/FollowerState.cs | 49 +-
.../Kafka/Raft/Generated/AllPackageClasses.cs | 211 -
.../Kafka/Raft/Generated/QuorumStateData.cs | 96 +-
.../Generated/QuorumStateDataJsonConverter.cs | 96 +-
.../Org/Apache/Kafka/Raft/Isolation.cs | 49 +-
.../Org/Apache/Kafka/Raft/KafkaRaftClient.cs | 97 +-
.../Org/Apache/Kafka/Raft/LeaderAndEpoch.cs | 49 +-
.../Org/Apache/Kafka/Raft/LeaderState.cs | 97 +-
.../Org/Apache/Kafka/Raft/LogAppendInfo.cs | 49 +-
.../Org/Apache/Kafka/Raft/LogFetchInfo.cs | 49 +-
.../Apache/Kafka/Raft/LogOffsetMetadata.cs | 49 +-
.../Org/Apache/Kafka/Raft/NetworkChannel.cs | 51 +-
.../Org/Apache/Kafka/Raft/OffsetAndEpoch.cs | 49 +-
.../Org/Apache/Kafka/Raft/OffsetMetadata.cs | 51 +-
.../Org/Apache/Kafka/Raft/QuorumState.cs | 49 +-
.../Org/Apache/Kafka/Raft/QuorumStateStore.cs | 51 +-
.../Org/Apache/Kafka/Raft/RaftClient.cs | 328 +-
.../Org/Apache/Kafka/Raft/RaftConfig.cs | 239 +-
.../Org/Apache/Kafka/Raft/RaftMessage.cs | 51 +-
.../Org/Apache/Kafka/Raft/RaftMessageQueue.cs | 51 +-
.../Org/Apache/Kafka/Raft/RaftRequest.cs | 145 +-
.../Org/Apache/Kafka/Raft/RaftResponse.cs | 145 +-
.../Org/Apache/Kafka/Raft/RaftUtil.cs | 49 +-
.../Apache/Kafka/Raft/ReplicatedCounter.cs | 49 +-
.../Org/Apache/Kafka/Raft/ReplicatedLog.cs | 51 +-
.../Org/Apache/Kafka/Raft/RequestManager.cs | 96 +-
.../Org/Apache/Kafka/Raft/ResignedState.cs | 49 +-
.../Org/Apache/Kafka/Raft/UnattachedState.cs | 49 +-
.../Apache/Kafka/Raft/ValidOffsetAndEpoch.cs | 96 +-
.../Org/Apache/Kafka/Raft/VotedState.cs | 49 +-
.../Kafka/Snapshot/AllPackageClasses.cs | 677 --
.../Kafka/Snapshot/FileRawSnapshotReader.cs | 49 +-
.../Kafka/Snapshot/FileRawSnapshotWriter.cs | 49 +-
.../Kafka/Snapshot/RawSnapshotReader.cs | 51 +-
.../Kafka/Snapshot/RawSnapshotWriter.cs | 51 +-
.../Kafka/Snapshot/RecordsSnapshotReader.cs | 97 +-
.../Kafka/Snapshot/RecordsSnapshotWriter.cs | 97 +-
.../Org/Apache/Kafka/Snapshot/SnapshotPath.cs | 49 +-
.../Apache/Kafka/Snapshot/SnapshotReader.cs | 101 +-
.../Apache/Kafka/Snapshot/SnapshotWriter.cs | 101 +-
.../Org/Apache/Kafka/Snapshot/Snapshots.cs | 49 +-
.../Apache/Kafka/Streams/AllPackageClasses.cs | 1405 ----
.../Kafka/Streams/Errors/AllPackageClasses.cs | 785 --
.../Streams/Errors/BrokerNotFoundException.cs | 21 +-
.../DefaultProductionExceptionHandler.cs | 49 +-
.../Errors/DeserializationExceptionHandler.cs | 98 +-
.../Errors/InvalidStateStoreException.cs | 21 +-
.../InvalidStateStorePartitionException.cs | 21 +-
.../Kafka/Streams/Errors/LockException.cs | 21 +-
.../Errors/LogAndContinueExceptionHandler.cs | 49 +-
.../Errors/LogAndFailExceptionHandler.cs | 49 +-
.../Errors/MissingSourceTopicException.cs | 21 +-
.../Streams/Errors/ProcessorStateException.cs | 21 +-
.../Errors/ProductionExceptionHandler.cs | 98 +-
.../Errors/StateStoreMigratedException.cs | 21 +-
.../Errors/StateStoreNotAvailableException.cs | 21 +-
.../Kafka/Streams/Errors/StreamsException.cs | 21 +-
.../Errors/StreamsNotStartedException.cs | 21 +-
.../Errors/StreamsRebalancingException.cs | 21 +-
.../Streams/Errors/StreamsStoppedException.cs | 21 +-
.../Errors/StreamsUncaughtExceptionHandler.cs | 132 +-
.../Streams/Errors/TaskAssignmentException.cs | 21 +-
.../Streams/Errors/TaskCorruptedException.cs | 21 +-
.../Streams/Errors/TaskIdFormatException.cs | 21 +-
.../Streams/Errors/TaskMigratedException.cs | 21 +-
.../Kafka/Streams/Errors/TopologyException.cs | 21 +-
.../Errors/UnknownStateStoreException.cs | 21 +-
.../Errors/UnknownTopologyException.cs | 21 +-
.../Kafka/Streams/KafkaClientSupplier.cs | 133 +-
.../Org/Apache/Kafka/Streams/KafkaStreams.cs | 225 +-
.../Apache/Kafka/Streams/KeyQueryMetadata.cs | 49 +-
.../Org/Apache/Kafka/Streams/KeyValue.cs | 98 +-
.../Kafka/Streams/Kstream/Aggregator.cs | 171 +-
.../Streams/Kstream/AllPackageClasses.cs | 5527 --------------
.../Apache/Kafka/Streams/Kstream/Branched.cs | 98 +-
.../Kafka/Streams/Kstream/BranchedKStream.cs | 102 +-
.../Kafka/Streams/Kstream/CogroupedKStream.cs | 102 +-
.../Apache/Kafka/Streams/Kstream/Consumed.cs | 98 +-
.../Kafka/Streams/Kstream/EmitStrategy.cs | 98 +-
.../Kafka/Streams/Kstream/ForeachAction.cs | 168 +-
.../Kafka/Streams/Kstream/ForeachProcessor.cs | 98 +-
.../Kafka/Streams/Kstream/GlobalKTable.cs | 102 +-
.../Apache/Kafka/Streams/Kstream/Grouped.cs | 98 +-
.../Kafka/Streams/Kstream/Initializer.cs | 165 +-
.../Kafka/Streams/Kstream/JoinWindows.cs | 49 +-
.../Apache/Kafka/Streams/Kstream/Joined.cs | 99 +-
.../Kafka/Streams/Kstream/KGroupedStream.cs | 102 +-
.../Kafka/Streams/Kstream/KGroupedTable.cs | 102 +-
.../Apache/Kafka/Streams/Kstream/KStream.cs | 102 +-
.../Apache/Kafka/Streams/Kstream/KTable.cs | 102 +-
.../Kafka/Streams/Kstream/KeyValueMapper.cs | 171 +-
.../Kafka/Streams/Kstream/Materialized.cs | 146 +-
.../Apache/Kafka/Streams/Kstream/Merger.cs | 170 +-
.../Org/Apache/Kafka/Streams/Kstream/Named.cs | 49 +-
.../Apache/Kafka/Streams/Kstream/Predicate.cs | 170 +-
.../Apache/Kafka/Streams/Kstream/Printed.cs | 98 +-
.../Apache/Kafka/Streams/Kstream/Produced.cs | 98 +-
.../Apache/Kafka/Streams/Kstream/Reducer.cs | 169 +-
.../Kafka/Streams/Kstream/Repartitioned.cs | 98 +-
.../SessionWindowedCogroupedKStream.cs | 102 +-
.../Kstream/SessionWindowedDeserializer.cs | 97 +-
.../Streams/Kstream/SessionWindowedKStream.cs | 102 +-
.../Kstream/SessionWindowedSerializer.cs | 97 +-
.../Kafka/Streams/Kstream/SessionWindows.cs | 49 +-
.../Kafka/Streams/Kstream/SlidingWindows.cs | 49 +-
.../Kafka/Streams/Kstream/StreamJoined.cs | 99 +-
.../Kafka/Streams/Kstream/Suppressed.cs | 298 +-
.../Kafka/Streams/Kstream/TableJoined.cs | 98 +-
.../Kstream/TimeWindowedCogroupedKStream.cs | 102 +-
.../Kstream/TimeWindowedDeserializer.cs | 97 +-
.../Streams/Kstream/TimeWindowedKStream.cs | 102 +-
.../Streams/Kstream/TimeWindowedSerializer.cs | 97 +-
.../Kafka/Streams/Kstream/TimeWindows.cs | 49 +-
.../Kafka/Streams/Kstream/Transformer.cs | 211 +-
.../Kafka/Streams/Kstream/UnlimitedWindows.cs | 49 +-
.../Kafka/Streams/Kstream/ValueJoiner.cs | 171 +-
.../Streams/Kstream/ValueJoinerWithKey.cs | 172 +-
.../Kafka/Streams/Kstream/ValueMapper.cs | 170 +-
.../Streams/Kstream/ValueMapperWithKey.cs | 171 +-
.../Kafka/Streams/Kstream/ValueTransformer.cs | 210 +-
.../Kstream/ValueTransformerWithKey.cs | 211 +-
.../Apache/Kafka/Streams/Kstream/Window.cs | 51 +-
.../Apache/Kafka/Streams/Kstream/Windowed.cs | 97 +-
.../Kafka/Streams/Kstream/WindowedSerdes.cs | 239 +-
.../Apache/Kafka/Streams/Kstream/Windows.cs | 101 +-
.../Org/Apache/Kafka/Streams/LagInfo.cs | 49 +-
.../Streams/Processor/AllPackageClasses.cs | 1282 ----
.../Processor/Api/AllPackageClasses.cs | 1016 ---
.../Api/ContextualFixedKeyProcessor.cs | 103 +-
.../Processor/Api/ContextualProcessor.cs | 104 +-
.../Processor/Api/FixedKeyProcessor.cs | 209 +-
.../Processor/Api/FixedKeyProcessorContext.cs | 102 +-
.../Streams/Processor/Api/FixedKeyRecord.cs | 98 +-
.../Api/InternalFixedKeyRecordFactory.cs | 49 +-
.../Processor/Api/ProcessingContext.cs | 51 +-
.../Kafka/Streams/Processor/Api/Processor.cs | 210 +-
.../Streams/Processor/Api/ProcessorContext.cs | 102 +-
.../Kafka/Streams/Processor/Api/Record.cs | 98 +-
.../Streams/Processor/Api/RecordMetadata.cs | 51 +-
.../Processor/BatchingStateRestoreCallback.cs | 95 +-
.../Kafka/Streams/Processor/Cancellable.cs | 51 +-
.../Kafka/Streams/Processor/CommitCallback.cs | 51 +-
.../Processor/ConnectedStoreProvider.cs | 51 +-
.../Processor/FailOnInvalidTimestamp.cs | 49 +-
.../Processor/LogAndSkipOnInvalidTimestamp.cs | 49 +-
.../Streams/Processor/ProcessorContext.cs | 51 +-
.../Streams/Processor/PunctuationType.cs | 49 +-
.../Kafka/Streams/Processor/Punctuator.cs | 84 +-
.../Kafka/Streams/Processor/RecordContext.cs | 51 +-
.../Streams/Processor/StateRestoreCallback.cs | 84 +-
.../Streams/Processor/StateRestoreListener.cs | 117 +-
.../Kafka/Streams/Processor/StateStore.cs | 51 +-
.../Streams/Processor/StateStoreContext.cs | 51 +-
.../Streams/Processor/StreamPartitioner.cs | 170 +-
.../Apache/Kafka/Streams/Processor/TaskId.cs | 49 +-
.../Streams/Processor/TimestampExtractor.cs | 85 +-
.../Org/Apache/Kafka/Streams/Processor/To.cs | 49 +-
.../Streams/Processor/TopicNameExtractor.cs | 170 +-
.../UsePartitionTimeOnInvalidTimestamp.cs | 49 +-
.../Processor/WallclockTimestampExtractor.cs | 49 +-
.../Kafka/Streams/Query/AllPackageClasses.cs | 996 ---
.../Kafka/Streams/Query/FailureReason.cs | 49 +-
.../Apache/Kafka/Streams/Query/KeyQuery.cs | 98 +-
.../Apache/Kafka/Streams/Query/Position.cs | 49 +-
.../Kafka/Streams/Query/PositionBound.cs | 49 +-
.../Org/Apache/Kafka/Streams/Query/Query.cs | 101 +-
.../Apache/Kafka/Streams/Query/QueryConfig.cs | 49 +-
.../Apache/Kafka/Streams/Query/QueryResult.cs | 101 +-
.../Apache/Kafka/Streams/Query/RangeQuery.cs | 98 +-
.../Kafka/Streams/Query/StateQueryRequest.cs | 144 +-
.../Kafka/Streams/Query/StateQueryResult.cs | 97 +-
.../Kafka/Streams/Query/WindowKeyQuery.cs | 98 +-
.../Kafka/Streams/Query/WindowRangeQuery.cs | 98 +-
.../Kafka/Streams/State/AllPackageClasses.cs | 2385 ------
.../Apache/Kafka/Streams/State/HostInfo.cs | 49 +-
.../State/KeyValueBytesStoreSupplier.cs | 51 +-
.../Kafka/Streams/State/KeyValueIterator.cs | 102 +-
.../Kafka/Streams/State/KeyValueStore.cs | 102 +-
.../Kafka/Streams/State/QueryableStoreType.cs | 101 +-
.../Streams/State/QueryableStoreTypes.cs | 337 +-
.../Streams/State/ReadOnlyKeyValueStore.cs | 102 +-
.../Streams/State/ReadOnlySessionStore.cs | 102 +-
.../Streams/State/ReadOnlyWindowStore.cs | 102 +-
.../Streams/State/RocksDBConfigSetter.cs | 51 +-
.../State/SessionBytesStoreSupplier.cs | 51 +-
.../Kafka/Streams/State/SessionStore.cs | 102 +-
.../Apache/Kafka/Streams/State/StateSerdes.cs | 98 +-
.../Kafka/Streams/State/StoreBuilder.cs | 101 +-
.../Kafka/Streams/State/StoreSupplier.cs | 101 +-
.../Org/Apache/Kafka/Streams/State/Stores.cs | 49 +-
.../Streams/State/TimestampedBytesStore.cs | 51 +-
.../Streams/State/TimestampedKeyValueStore.cs | 102 +-
.../Streams/State/TimestampedWindowStore.cs | 102 +-
.../Kafka/Streams/State/ValueAndTimestamp.cs | 97 +-
.../Streams/State/VersionedBytesStore.cs | 51 +-
.../State/VersionedBytesStoreSupplier.cs | 51 +-
.../Streams/State/VersionedKeyValueStore.cs | 102 +-
.../Kafka/Streams/State/VersionedRecord.cs | 97 +-
.../Streams/State/WindowBytesStoreSupplier.cs | 51 +-
.../Apache/Kafka/Streams/State/WindowStore.cs | 102 +-
.../Streams/State/WindowStoreIterator.cs | 101 +-
.../Kafka/Streams/StoreQueryParameters.cs | 97 +-
.../Apache/Kafka/Streams/StreamsBuilder.cs | 49 +-
.../Org/Apache/Kafka/Streams/StreamsConfig.cs | 96 +-
.../Apache/Kafka/Streams/StreamsMetadata.cs | 51 +-
.../Apache/Kafka/Streams/StreamsMetrics.cs | 51 +-
.../Org/Apache/Kafka/Streams/TaskMetadata.cs | 51 +-
.../Apache/Kafka/Streams/ThreadMetadata.cs | 51 +-
.../Org/Apache/Kafka/Streams/Topology.cs | 96 +-
.../Apache/Kafka/Streams/TopologyConfig.cs | 96 +-
.../Kafka/Streams/TopologyDescription.cs | 345 +-
.../Apache/Kafka/Tools/AllPackageClasses.cs | 1180 ---
.../Kafka/Tools/ClientCompatibilityTest.cs | 49 +-
.../Org/Apache/Kafka/Tools/ClusterTool.cs | 53 +-
.../Apache/Kafka/Tools/ConnectPluginPath.cs | 49 +-
.../Apache/Kafka/Tools/ConsumerPerformance.cs | 49 +-
.../Kafka/Tools/DelegationTokenCommand.cs | 53 +-
.../Kafka/Tools/DeleteRecordsCommand.cs | 49 +-
.../Org/Apache/Kafka/Tools/EndToEndLatency.cs | 53 +-
.../Org/Apache/Kafka/Tools/FeatureCommand.cs | 53 +-
.../Org/Apache/Kafka/Tools/JmxTool.cs | 49 +-
.../Org/Apache/Kafka/Tools/LogDirsCommand.cs | 53 +-
.../Apache/Kafka/Tools/ManifestWorkspace.cs | 148 +-
.../Kafka/Tools/MetadataQuorumCommand.cs | 53 +-
.../Kafka/Tools/OAuthCompatibilityTool.cs | 49 +-
.../Apache/Kafka/Tools/ProducerPerformance.cs | 49 +-
.../Kafka/Tools/PushHttpMetricsReporter.cs | 49 +-
.../Kafka/Tools/Reassign/AllPackageClasses.cs | 121 -
.../ReassignPartitionsCommandOptions.cs | 49 +-
.../Tools/Reassign/VerifyAssignmentResult.cs | 49 +-
.../Kafka/Tools/ReplicaVerificationTool.cs | 49 +-
.../Org/Apache/Kafka/Tools/StreamsResetter.cs | 49 +-
.../Org/Apache/Kafka/Tools/TerseException.cs | 21 +-
.../Org/Apache/Kafka/Tools/ToolsUtils.cs | 49 +-
.../Kafka/Tools/TransactionalMessageCopier.cs | 49 +-
.../Apache/Kafka/Tools/TransactionsCommand.cs | 51 +-
.../Apache/Kafka/Tools/VerifiableConsumer.cs | 49 +-
.../Kafka/Tools/VerifiableLog4jAppender.cs | 49 +-
.../Apache/Kafka/Tools/VerifiableProducer.cs | 49 +-
.../Org/Apache/Zookeeper/AllPackageClasses.cs | 31 -
1059 files changed, 62947 insertions(+), 62864 deletions(-)
delete mode 100644 src/net/KNet/Generated/Kafka/Admin/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Kafka/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Clients/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Clients/Consumer/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Clients/Producer/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Common/Acl/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Common/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Common/Annotation/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Common/Cache/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Common/Compress/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/Provider/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Common/Config/Types/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Common/Errors/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Common/Header/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Common/Memory/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Common/Metrics/Stats/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Common/Quota/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Common/Record/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Common/Replica/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Common/Resource/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Auth/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Authenticator/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Oauthbearer/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Oauthbearer/Secured/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Plain/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Plain/Internals/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Scram/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Ssl/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Common/Security/Token/Delegation/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Common/Serialization/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Common/Utils/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Connect/Cli/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Connect/Components/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Connect/Connector/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Connect/Converters/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Connect/Data/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Connect/Errors/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Connect/Header/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Connect/Health/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Connect/Json/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Connect/Mirror/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Connect/Mirror/Formatters/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Connect/Rest/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Connect/Rest/Basic/Auth/Extension/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Connect/Sink/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Connect/Source/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Connect/Transforms/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Connect/Transforms/Predicates/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Connect/Transforms/Util/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Connect/Util/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Raft/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Raft/Errors/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Raft/Generated/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Snapshot/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Streams/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Streams/Errors/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Streams/Kstream/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Streams/Processor/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Streams/Processor/Api/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Streams/Query/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Streams/State/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Tools/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Kafka/Tools/Reassign/AllPackageClasses.cs
delete mode 100644 src/net/KNet/Generated/Org/Apache/Zookeeper/AllPackageClasses.cs
diff --git a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/clients/consumer/ConsumerInterceptor.java b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/clients/consumer/ConsumerInterceptor.java
index c46b1e06f..a4bb72e10 100644
--- a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/clients/consumer/ConsumerInterceptor.java
+++ b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/clients/consumer/ConsumerInterceptor.java
@@ -1,47 +1,94 @@
/*
- * Copyright 2024 MASES s.r.l.
- *
- * Licensed 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.
- *
- * Refer to LICENSE for more information.
- */
+* Copyright 2024 MASES s.r.l.
+*
+* Licensed 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.
+*
+* Refer to LICENSE for more information.
+*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
*/
package org.mases.knet.generated.org.apache.kafka.clients.consumer;
-public final class ConsumerInterceptor extends org.mases.jcobridge.JCListener implements org.apache.kafka.clients.consumer.ConsumerInterceptor {
+public final class ConsumerInterceptor implements org.mases.jcobridge.IJCListener, org.apache.kafka.clients.consumer.ConsumerInterceptor {
+ final org.mases.jcobridge.JCListener _internalListener;
+
public ConsumerInterceptor(String key) throws org.mases.jcobridge.JCNativeException {
- super(key);
+ super();
+ _internalListener = new org.mases.jcobridge.JCListener(key);
+ }
+
+ public synchronized void release() {
+ _internalListener.release();
+ }
+
+ public synchronized void raiseEvent(String eventName) {
+ _internalListener.raiseEvent(eventName);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e) {
+ _internalListener.raiseEvent(eventName, e);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e, Object... objects) {
+ _internalListener.raiseEvent(eventName, e, objects);
+ }
+
+ public Object getEventData() {
+ return _internalListener.getEventData();
+ }
+
+ public boolean hasExtraData() {
+ return _internalListener.hasExtraData();
+ }
+
+ public int extraDataLength() {
+ return _internalListener.extraDataLength();
+ }
+
+ public Object[] extraData() {
+ return _internalListener.extraData();
+ }
+
+ public Object getReturnData() {
+ return _internalListener.getReturnData();
+ }
+
+ public void setReturnData(Object retData) {
+ _internalListener.setReturnData(retData);
}
//@Override
public org.apache.kafka.clients.consumer.ConsumerRecords onConsume(org.apache.kafka.clients.consumer.ConsumerRecords arg0) {
- raiseEvent("onConsume", arg0); Object retVal = getReturnData(); return (org.apache.kafka.clients.consumer.ConsumerRecords)retVal;
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("onConsume", eventDataExchange, arg0); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM"); Object retVal = eventDataExchange.getReturnData(); return (org.apache.kafka.clients.consumer.ConsumerRecords)retVal;
}
//@Override
public void close() {
- raiseEvent("close");
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("close", eventDataExchange); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM");
}
//@Override
public void onCommit(java.util.Map arg0) {
- raiseEvent("onCommit", arg0);
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("onCommit", eventDataExchange, arg0); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM");
}
//@Override
public void configure(java.util.Map arg0) {
- raiseEvent("configure", arg0);
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("configure", eventDataExchange, arg0); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM");
}
}
\ No newline at end of file
diff --git a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/clients/consumer/ConsumerPartitionAssignor.java b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/clients/consumer/ConsumerPartitionAssignor.java
index 5315e8b10..9748bcd86 100644
--- a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/clients/consumer/ConsumerPartitionAssignor.java
+++ b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/clients/consumer/ConsumerPartitionAssignor.java
@@ -1,43 +1,89 @@
/*
- * Copyright 2024 MASES s.r.l.
- *
- * Licensed 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.
- *
- * Refer to LICENSE for more information.
- */
+* Copyright 2024 MASES s.r.l.
+*
+* Licensed 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.
+*
+* Refer to LICENSE for more information.
+*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
*/
package org.mases.knet.generated.org.apache.kafka.clients.consumer;
-public final class ConsumerPartitionAssignor extends org.mases.jcobridge.JCListener implements org.apache.kafka.clients.consumer.ConsumerPartitionAssignor {
+public final class ConsumerPartitionAssignor implements org.mases.jcobridge.IJCListener, org.apache.kafka.clients.consumer.ConsumerPartitionAssignor {
+ final org.mases.jcobridge.JCListener _internalListener;
+
public ConsumerPartitionAssignor(String key) throws org.mases.jcobridge.JCNativeException {
- super(key);
+ super();
+ _internalListener = new org.mases.jcobridge.JCListener(key);
+ }
+
+ public synchronized void release() {
+ _internalListener.release();
+ }
+
+ public synchronized void raiseEvent(String eventName) {
+ _internalListener.raiseEvent(eventName);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e) {
+ _internalListener.raiseEvent(eventName, e);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e, Object... objects) {
+ _internalListener.raiseEvent(eventName, e, objects);
+ }
+
+ public Object getEventData() {
+ return _internalListener.getEventData();
+ }
+
+ public boolean hasExtraData() {
+ return _internalListener.hasExtraData();
+ }
+
+ public int extraDataLength() {
+ return _internalListener.extraDataLength();
+ }
+
+ public Object[] extraData() {
+ return _internalListener.extraData();
+ }
+
+ public Object getReturnData() {
+ return _internalListener.getReturnData();
+ }
+
+ public void setReturnData(Object retData) {
+ _internalListener.setReturnData(retData);
}
//@Override
public java.lang.String name() {
- raiseEvent("name"); Object retVal = getReturnData(); return (java.lang.String)retVal;
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("name", eventDataExchange); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM"); Object retVal = eventDataExchange.getReturnData(); return (java.lang.String)retVal;
}
//@Override
public org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.GroupAssignment assign(org.apache.kafka.common.Cluster arg0, org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.GroupSubscription arg1) {
- raiseEvent("assign", arg0, arg1); Object retVal = getReturnData(); return (org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.GroupAssignment)retVal;
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("assign", eventDataExchange, arg0, arg1); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM"); Object retVal = eventDataExchange.getReturnData(); return (org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.GroupAssignment)retVal;
}
//@Override
public java.nio.ByteBuffer subscriptionUserData(java.util.Set arg0) {
- raiseEvent("subscriptionUserData", arg0); Object retVal = getReturnData(); return (java.nio.ByteBuffer)retVal;
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("subscriptionUserData", eventDataExchange, arg0); Object retVal; if (!eventDataExchange.getHasOverride()) retVal = org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.super.subscriptionUserData(arg0); else retVal = eventDataExchange.getReturnData(); return (java.nio.ByteBuffer)retVal;
}
//@Override
public java.nio.ByteBuffer subscriptionUserDataDefault(java.util.Set arg0) {
@@ -45,7 +91,8 @@ public java.nio.ByteBuffer subscriptionUserDataDefault(java.util.Set arg0) {
}
//@Override
public java.util.List supportedProtocols() {
- raiseEvent("supportedProtocols"); Object retVal = getReturnData(); return (java.util.List)retVal;
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("supportedProtocols", eventDataExchange); Object retVal; if (!eventDataExchange.getHasOverride()) retVal = org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.super.supportedProtocols(); else retVal = eventDataExchange.getReturnData(); return (java.util.List)retVal;
}
//@Override
public java.util.List supportedProtocolsDefault() {
@@ -53,7 +100,8 @@ public java.util.List supportedProtocolsDefault() {
}
//@Override
public short version() {
- raiseEvent("version"); Object retVal = getReturnData(); return (short)retVal;
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("version", eventDataExchange); Object retVal; if (!eventDataExchange.getHasOverride()) retVal = org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.super.version(); else retVal = eventDataExchange.getReturnData(); return (short)retVal;
}
//@Override
public short versionDefault() {
@@ -61,7 +109,8 @@ public short versionDefault() {
}
//@Override
public void onAssignment(org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.Assignment arg0, org.apache.kafka.clients.consumer.ConsumerGroupMetadata arg1) {
- raiseEvent("onAssignment", arg0, arg1);
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("onAssignment", eventDataExchange, arg0, arg1); if (!eventDataExchange.getHasOverride()) org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.super.onAssignment(arg0, arg1);
}
//@Override
public void onAssignmentDefault(org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.Assignment arg0, org.apache.kafka.clients.consumer.ConsumerGroupMetadata arg1) {
diff --git a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/clients/consumer/ConsumerRebalanceListener.java b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/clients/consumer/ConsumerRebalanceListener.java
index 88e3fbcf2..e33befda4 100644
--- a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/clients/consumer/ConsumerRebalanceListener.java
+++ b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/clients/consumer/ConsumerRebalanceListener.java
@@ -1,43 +1,89 @@
/*
- * Copyright 2024 MASES s.r.l.
- *
- * Licensed 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.
- *
- * Refer to LICENSE for more information.
- */
+* Copyright 2024 MASES s.r.l.
+*
+* Licensed 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.
+*
+* Refer to LICENSE for more information.
+*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
*/
package org.mases.knet.generated.org.apache.kafka.clients.consumer;
-public final class ConsumerRebalanceListener extends org.mases.jcobridge.JCListener implements org.apache.kafka.clients.consumer.ConsumerRebalanceListener {
+public final class ConsumerRebalanceListener implements org.mases.jcobridge.IJCListener, org.apache.kafka.clients.consumer.ConsumerRebalanceListener {
+ final org.mases.jcobridge.JCListener _internalListener;
+
public ConsumerRebalanceListener(String key) throws org.mases.jcobridge.JCNativeException {
- super(key);
+ super();
+ _internalListener = new org.mases.jcobridge.JCListener(key);
+ }
+
+ public synchronized void release() {
+ _internalListener.release();
+ }
+
+ public synchronized void raiseEvent(String eventName) {
+ _internalListener.raiseEvent(eventName);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e) {
+ _internalListener.raiseEvent(eventName, e);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e, Object... objects) {
+ _internalListener.raiseEvent(eventName, e, objects);
+ }
+
+ public Object getEventData() {
+ return _internalListener.getEventData();
+ }
+
+ public boolean hasExtraData() {
+ return _internalListener.hasExtraData();
+ }
+
+ public int extraDataLength() {
+ return _internalListener.extraDataLength();
+ }
+
+ public Object[] extraData() {
+ return _internalListener.extraData();
+ }
+
+ public Object getReturnData() {
+ return _internalListener.getReturnData();
+ }
+
+ public void setReturnData(Object retData) {
+ _internalListener.setReturnData(retData);
}
//@Override
public void onPartitionsAssigned(java.util.Collection arg0) {
- raiseEvent("onPartitionsAssigned", arg0);
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("onPartitionsAssigned", eventDataExchange, arg0); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM");
}
//@Override
public void onPartitionsRevoked(java.util.Collection arg0) {
- raiseEvent("onPartitionsRevoked", arg0);
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("onPartitionsRevoked", eventDataExchange, arg0); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM");
}
//@Override
public void onPartitionsLost(java.util.Collection arg0) {
- raiseEvent("onPartitionsLost", arg0);
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("onPartitionsLost", eventDataExchange, arg0); if (!eventDataExchange.getHasOverride()) org.apache.kafka.clients.consumer.ConsumerRebalanceListener.super.onPartitionsLost(arg0);
}
//@Override
public void onPartitionsLostDefault(java.util.Collection arg0) {
diff --git a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/clients/consumer/OffsetCommitCallback.java b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/clients/consumer/OffsetCommitCallback.java
index 32128145c..b804cebbb 100644
--- a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/clients/consumer/OffsetCommitCallback.java
+++ b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/clients/consumer/OffsetCommitCallback.java
@@ -1,35 +1,79 @@
/*
- * Copyright 2024 MASES s.r.l.
- *
- * Licensed 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.
- *
- * Refer to LICENSE for more information.
- */
+* Copyright 2024 MASES s.r.l.
+*
+* Licensed 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.
+*
+* Refer to LICENSE for more information.
+*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
*/
package org.mases.knet.generated.org.apache.kafka.clients.consumer;
-public final class OffsetCommitCallback extends org.mases.jcobridge.JCListener implements org.apache.kafka.clients.consumer.OffsetCommitCallback {
+public final class OffsetCommitCallback implements org.mases.jcobridge.IJCListener, org.apache.kafka.clients.consumer.OffsetCommitCallback {
+ final org.mases.jcobridge.JCListener _internalListener;
+
public OffsetCommitCallback(String key) throws org.mases.jcobridge.JCNativeException {
- super(key);
+ super();
+ _internalListener = new org.mases.jcobridge.JCListener(key);
+ }
+
+ public synchronized void release() {
+ _internalListener.release();
+ }
+
+ public synchronized void raiseEvent(String eventName) {
+ _internalListener.raiseEvent(eventName);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e) {
+ _internalListener.raiseEvent(eventName, e);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e, Object... objects) {
+ _internalListener.raiseEvent(eventName, e, objects);
+ }
+
+ public Object getEventData() {
+ return _internalListener.getEventData();
+ }
+
+ public boolean hasExtraData() {
+ return _internalListener.hasExtraData();
+ }
+
+ public int extraDataLength() {
+ return _internalListener.extraDataLength();
+ }
+
+ public Object[] extraData() {
+ return _internalListener.extraData();
+ }
+
+ public Object getReturnData() {
+ return _internalListener.getReturnData();
+ }
+
+ public void setReturnData(Object retData) {
+ _internalListener.setReturnData(retData);
}
//@Override
public void onComplete(java.util.Map arg0, java.lang.Exception arg1) {
- raiseEvent("onComplete", arg0, arg1);
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("onComplete", eventDataExchange, arg0, arg1); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM");
}
}
\ No newline at end of file
diff --git a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/clients/producer/Callback.java b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/clients/producer/Callback.java
index 5df70a37f..e96efeed2 100644
--- a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/clients/producer/Callback.java
+++ b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/clients/producer/Callback.java
@@ -1,35 +1,79 @@
/*
- * Copyright 2024 MASES s.r.l.
- *
- * Licensed 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.
- *
- * Refer to LICENSE for more information.
- */
+* Copyright 2024 MASES s.r.l.
+*
+* Licensed 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.
+*
+* Refer to LICENSE for more information.
+*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
*/
package org.mases.knet.generated.org.apache.kafka.clients.producer;
-public final class Callback extends org.mases.jcobridge.JCListener implements org.apache.kafka.clients.producer.Callback {
+public final class Callback implements org.mases.jcobridge.IJCListener, org.apache.kafka.clients.producer.Callback {
+ final org.mases.jcobridge.JCListener _internalListener;
+
public Callback(String key) throws org.mases.jcobridge.JCNativeException {
- super(key);
+ super();
+ _internalListener = new org.mases.jcobridge.JCListener(key);
+ }
+
+ public synchronized void release() {
+ _internalListener.release();
+ }
+
+ public synchronized void raiseEvent(String eventName) {
+ _internalListener.raiseEvent(eventName);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e) {
+ _internalListener.raiseEvent(eventName, e);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e, Object... objects) {
+ _internalListener.raiseEvent(eventName, e, objects);
+ }
+
+ public Object getEventData() {
+ return _internalListener.getEventData();
+ }
+
+ public boolean hasExtraData() {
+ return _internalListener.hasExtraData();
+ }
+
+ public int extraDataLength() {
+ return _internalListener.extraDataLength();
+ }
+
+ public Object[] extraData() {
+ return _internalListener.extraData();
+ }
+
+ public Object getReturnData() {
+ return _internalListener.getReturnData();
+ }
+
+ public void setReturnData(Object retData) {
+ _internalListener.setReturnData(retData);
}
//@Override
public void onCompletion(org.apache.kafka.clients.producer.RecordMetadata arg0, java.lang.Exception arg1) {
- raiseEvent("onCompletion", arg0, arg1);
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("onCompletion", eventDataExchange, arg0, arg1); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM");
}
}
\ No newline at end of file
diff --git a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/clients/producer/Partitioner.java b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/clients/producer/Partitioner.java
index e844a977d..20df2eaee 100644
--- a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/clients/producer/Partitioner.java
+++ b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/clients/producer/Partitioner.java
@@ -1,47 +1,94 @@
/*
- * Copyright 2024 MASES s.r.l.
- *
- * Licensed 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.
- *
- * Refer to LICENSE for more information.
- */
+* Copyright 2024 MASES s.r.l.
+*
+* Licensed 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.
+*
+* Refer to LICENSE for more information.
+*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
*/
package org.mases.knet.generated.org.apache.kafka.clients.producer;
-public final class Partitioner extends org.mases.jcobridge.JCListener implements org.apache.kafka.clients.producer.Partitioner {
+public final class Partitioner implements org.mases.jcobridge.IJCListener, org.apache.kafka.clients.producer.Partitioner {
+ final org.mases.jcobridge.JCListener _internalListener;
+
public Partitioner(String key) throws org.mases.jcobridge.JCNativeException {
- super(key);
+ super();
+ _internalListener = new org.mases.jcobridge.JCListener(key);
+ }
+
+ public synchronized void release() {
+ _internalListener.release();
+ }
+
+ public synchronized void raiseEvent(String eventName) {
+ _internalListener.raiseEvent(eventName);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e) {
+ _internalListener.raiseEvent(eventName, e);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e, Object... objects) {
+ _internalListener.raiseEvent(eventName, e, objects);
+ }
+
+ public Object getEventData() {
+ return _internalListener.getEventData();
+ }
+
+ public boolean hasExtraData() {
+ return _internalListener.hasExtraData();
+ }
+
+ public int extraDataLength() {
+ return _internalListener.extraDataLength();
+ }
+
+ public Object[] extraData() {
+ return _internalListener.extraData();
+ }
+
+ public Object getReturnData() {
+ return _internalListener.getReturnData();
+ }
+
+ public void setReturnData(Object retData) {
+ _internalListener.setReturnData(retData);
}
//@Override
public int partition(java.lang.String arg0, java.lang.Object arg1, byte[] arg2, java.lang.Object arg3, byte[] arg4, org.apache.kafka.common.Cluster arg5) {
- raiseEvent("partition", arg0, arg1, arg2, arg3, arg4, arg5); Object retVal = getReturnData(); return (int)retVal;
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("partition", eventDataExchange, arg0, arg1, arg2, arg3, arg4, arg5); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM"); Object retVal = eventDataExchange.getReturnData(); return (int)retVal;
}
//@Override
public void close() {
- raiseEvent("close");
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("close", eventDataExchange); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM");
}
//@Override
public void configure(java.util.Map arg0) {
- raiseEvent("configure", arg0);
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("configure", eventDataExchange, arg0); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM");
}
//@Override
public void onNewBatch(java.lang.String arg0, org.apache.kafka.common.Cluster arg1, int arg2) {
- raiseEvent("onNewBatch", arg0, arg1, arg2);
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("onNewBatch", eventDataExchange, arg0, arg1, arg2); if (!eventDataExchange.getHasOverride()) org.apache.kafka.clients.producer.Partitioner.super.onNewBatch(arg0, arg1, arg2);
}
//@Override
public void onNewBatchDefault(java.lang.String arg0, org.apache.kafka.common.Cluster arg1, int arg2) {
diff --git a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/clients/producer/ProducerInterceptor.java b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/clients/producer/ProducerInterceptor.java
index e8765b5f5..bf85e35df 100644
--- a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/clients/producer/ProducerInterceptor.java
+++ b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/clients/producer/ProducerInterceptor.java
@@ -1,47 +1,94 @@
/*
- * Copyright 2024 MASES s.r.l.
- *
- * Licensed 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.
- *
- * Refer to LICENSE for more information.
- */
+* Copyright 2024 MASES s.r.l.
+*
+* Licensed 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.
+*
+* Refer to LICENSE for more information.
+*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
*/
package org.mases.knet.generated.org.apache.kafka.clients.producer;
-public final class ProducerInterceptor extends org.mases.jcobridge.JCListener implements org.apache.kafka.clients.producer.ProducerInterceptor {
+public final class ProducerInterceptor implements org.mases.jcobridge.IJCListener, org.apache.kafka.clients.producer.ProducerInterceptor {
+ final org.mases.jcobridge.JCListener _internalListener;
+
public ProducerInterceptor(String key) throws org.mases.jcobridge.JCNativeException {
- super(key);
+ super();
+ _internalListener = new org.mases.jcobridge.JCListener(key);
+ }
+
+ public synchronized void release() {
+ _internalListener.release();
+ }
+
+ public synchronized void raiseEvent(String eventName) {
+ _internalListener.raiseEvent(eventName);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e) {
+ _internalListener.raiseEvent(eventName, e);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e, Object... objects) {
+ _internalListener.raiseEvent(eventName, e, objects);
+ }
+
+ public Object getEventData() {
+ return _internalListener.getEventData();
+ }
+
+ public boolean hasExtraData() {
+ return _internalListener.hasExtraData();
+ }
+
+ public int extraDataLength() {
+ return _internalListener.extraDataLength();
+ }
+
+ public Object[] extraData() {
+ return _internalListener.extraData();
+ }
+
+ public Object getReturnData() {
+ return _internalListener.getReturnData();
+ }
+
+ public void setReturnData(Object retData) {
+ _internalListener.setReturnData(retData);
}
//@Override
public org.apache.kafka.clients.producer.ProducerRecord onSend(org.apache.kafka.clients.producer.ProducerRecord arg0) {
- raiseEvent("onSend", arg0); Object retVal = getReturnData(); return (org.apache.kafka.clients.producer.ProducerRecord)retVal;
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("onSend", eventDataExchange, arg0); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM"); Object retVal = eventDataExchange.getReturnData(); return (org.apache.kafka.clients.producer.ProducerRecord)retVal;
}
//@Override
public void close() {
- raiseEvent("close");
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("close", eventDataExchange); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM");
}
//@Override
public void onAcknowledgement(org.apache.kafka.clients.producer.RecordMetadata arg0, java.lang.Exception arg1) {
- raiseEvent("onAcknowledgement", arg0, arg1);
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("onAcknowledgement", eventDataExchange, arg0, arg1); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM");
}
//@Override
public void configure(java.util.Map arg0) {
- raiseEvent("configure", arg0);
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("configure", eventDataExchange, arg0); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM");
}
}
\ No newline at end of file
diff --git a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/common/ClusterResourceListener.java b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/common/ClusterResourceListener.java
index d73ca633b..f653d4631 100644
--- a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/common/ClusterResourceListener.java
+++ b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/common/ClusterResourceListener.java
@@ -1,35 +1,79 @@
/*
- * Copyright 2024 MASES s.r.l.
- *
- * Licensed 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.
- *
- * Refer to LICENSE for more information.
- */
+* Copyright 2024 MASES s.r.l.
+*
+* Licensed 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.
+*
+* Refer to LICENSE for more information.
+*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
*/
package org.mases.knet.generated.org.apache.kafka.common;
-public final class ClusterResourceListener extends org.mases.jcobridge.JCListener implements org.apache.kafka.common.ClusterResourceListener {
+public final class ClusterResourceListener implements org.mases.jcobridge.IJCListener, org.apache.kafka.common.ClusterResourceListener {
+ final org.mases.jcobridge.JCListener _internalListener;
+
public ClusterResourceListener(String key) throws org.mases.jcobridge.JCNativeException {
- super(key);
+ super();
+ _internalListener = new org.mases.jcobridge.JCListener(key);
+ }
+
+ public synchronized void release() {
+ _internalListener.release();
+ }
+
+ public synchronized void raiseEvent(String eventName) {
+ _internalListener.raiseEvent(eventName);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e) {
+ _internalListener.raiseEvent(eventName, e);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e, Object... objects) {
+ _internalListener.raiseEvent(eventName, e, objects);
+ }
+
+ public Object getEventData() {
+ return _internalListener.getEventData();
+ }
+
+ public boolean hasExtraData() {
+ return _internalListener.hasExtraData();
+ }
+
+ public int extraDataLength() {
+ return _internalListener.extraDataLength();
+ }
+
+ public Object[] extraData() {
+ return _internalListener.extraData();
+ }
+
+ public Object getReturnData() {
+ return _internalListener.getReturnData();
+ }
+
+ public void setReturnData(Object retData) {
+ _internalListener.setReturnData(retData);
}
//@Override
public void onUpdate(org.apache.kafka.common.ClusterResource arg0) {
- raiseEvent("onUpdate", arg0);
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("onUpdate", eventDataExchange, arg0); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM");
}
}
\ No newline at end of file
diff --git a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/common/config/ConfigChangeCallback.java b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/common/config/ConfigChangeCallback.java
index deab5f37d..da0b6ea5f 100644
--- a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/common/config/ConfigChangeCallback.java
+++ b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/common/config/ConfigChangeCallback.java
@@ -1,35 +1,79 @@
/*
- * Copyright 2024 MASES s.r.l.
- *
- * Licensed 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.
- *
- * Refer to LICENSE for more information.
- */
+* Copyright 2024 MASES s.r.l.
+*
+* Licensed 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.
+*
+* Refer to LICENSE for more information.
+*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
*/
package org.mases.knet.generated.org.apache.kafka.common.config;
-public final class ConfigChangeCallback extends org.mases.jcobridge.JCListener implements org.apache.kafka.common.config.ConfigChangeCallback {
+public final class ConfigChangeCallback implements org.mases.jcobridge.IJCListener, org.apache.kafka.common.config.ConfigChangeCallback {
+ final org.mases.jcobridge.JCListener _internalListener;
+
public ConfigChangeCallback(String key) throws org.mases.jcobridge.JCNativeException {
- super(key);
+ super();
+ _internalListener = new org.mases.jcobridge.JCListener(key);
+ }
+
+ public synchronized void release() {
+ _internalListener.release();
+ }
+
+ public synchronized void raiseEvent(String eventName) {
+ _internalListener.raiseEvent(eventName);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e) {
+ _internalListener.raiseEvent(eventName, e);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e, Object... objects) {
+ _internalListener.raiseEvent(eventName, e, objects);
+ }
+
+ public Object getEventData() {
+ return _internalListener.getEventData();
+ }
+
+ public boolean hasExtraData() {
+ return _internalListener.hasExtraData();
+ }
+
+ public int extraDataLength() {
+ return _internalListener.extraDataLength();
+ }
+
+ public Object[] extraData() {
+ return _internalListener.extraData();
+ }
+
+ public Object getReturnData() {
+ return _internalListener.getReturnData();
+ }
+
+ public void setReturnData(Object retData) {
+ _internalListener.setReturnData(retData);
}
//@Override
public void onChange(java.lang.String arg0, org.apache.kafka.common.config.ConfigData arg1) {
- raiseEvent("onChange", arg0, arg1);
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("onChange", eventDataExchange, arg0, arg1); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM");
}
}
\ No newline at end of file
diff --git a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/common/metrics/MetricsReporter.java b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/common/metrics/MetricsReporter.java
index 57f39ff97..f99427819 100644
--- a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/common/metrics/MetricsReporter.java
+++ b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/common/metrics/MetricsReporter.java
@@ -1,55 +1,104 @@
/*
- * Copyright 2024 MASES s.r.l.
- *
- * Licensed 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.
- *
- * Refer to LICENSE for more information.
- */
+* Copyright 2024 MASES s.r.l.
+*
+* Licensed 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.
+*
+* Refer to LICENSE for more information.
+*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
*/
package org.mases.knet.generated.org.apache.kafka.common.metrics;
-public final class MetricsReporter extends org.mases.jcobridge.JCListener implements org.apache.kafka.common.metrics.MetricsReporter {
+public final class MetricsReporter implements org.mases.jcobridge.IJCListener, org.apache.kafka.common.metrics.MetricsReporter {
+ final org.mases.jcobridge.JCListener _internalListener;
+
public MetricsReporter(String key) throws org.mases.jcobridge.JCNativeException {
- super(key);
+ super();
+ _internalListener = new org.mases.jcobridge.JCListener(key);
+ }
+
+ public synchronized void release() {
+ _internalListener.release();
+ }
+
+ public synchronized void raiseEvent(String eventName) {
+ _internalListener.raiseEvent(eventName);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e) {
+ _internalListener.raiseEvent(eventName, e);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e, Object... objects) {
+ _internalListener.raiseEvent(eventName, e, objects);
+ }
+
+ public Object getEventData() {
+ return _internalListener.getEventData();
+ }
+
+ public boolean hasExtraData() {
+ return _internalListener.hasExtraData();
+ }
+
+ public int extraDataLength() {
+ return _internalListener.extraDataLength();
+ }
+
+ public Object[] extraData() {
+ return _internalListener.extraData();
+ }
+
+ public Object getReturnData() {
+ return _internalListener.getReturnData();
+ }
+
+ public void setReturnData(Object retData) {
+ _internalListener.setReturnData(retData);
}
//@Override
public void configure(java.util.Map arg0) {
- raiseEvent("configure", arg0);
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("configure", eventDataExchange, arg0); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM");
}
//@Override
public void close() {
- raiseEvent("close");
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("close", eventDataExchange); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM");
}
//@Override
public void init(java.util.List arg0) {
- raiseEvent("init", arg0);
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("init", eventDataExchange, arg0); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM");
}
//@Override
public void metricChange(org.apache.kafka.common.metrics.KafkaMetric arg0) {
- raiseEvent("metricChange", arg0);
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("metricChange", eventDataExchange, arg0); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM");
}
//@Override
public void metricRemoval(org.apache.kafka.common.metrics.KafkaMetric arg0) {
- raiseEvent("metricRemoval", arg0);
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("metricRemoval", eventDataExchange, arg0); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM");
}
//@Override
public java.util.Set reconfigurableConfigs() {
- raiseEvent("reconfigurableConfigs"); Object retVal = getReturnData(); return (java.util.Set)retVal;
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("reconfigurableConfigs", eventDataExchange); Object retVal; if (!eventDataExchange.getHasOverride()) retVal = org.apache.kafka.common.metrics.MetricsReporter.super.reconfigurableConfigs(); else retVal = eventDataExchange.getReturnData(); return (java.util.Set)retVal;
}
//@Override
public java.util.Set reconfigurableConfigsDefault() {
@@ -57,7 +106,8 @@ public java.util.Set reconfigurableConfigsDefault() {
}
//@Override
public void contextChange(org.apache.kafka.common.metrics.MetricsContext arg0) {
- raiseEvent("contextChange", arg0);
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("contextChange", eventDataExchange, arg0); if (!eventDataExchange.getHasOverride()) org.apache.kafka.common.metrics.MetricsReporter.super.contextChange(arg0);
}
//@Override
public void contextChangeDefault(org.apache.kafka.common.metrics.MetricsContext arg0) {
@@ -65,18 +115,20 @@ public void contextChangeDefault(org.apache.kafka.common.metrics.MetricsContext
}
//@Override
public void reconfigure(java.util.Map arg0) {
- raiseEvent("reconfigure", arg0);
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("reconfigure", eventDataExchange, arg0); if (!eventDataExchange.getHasOverride()) org.apache.kafka.common.metrics.MetricsReporter.super.reconfigure(arg0);
}
//@Override
public void reconfigureDefault(java.util.Map arg0) {
org.apache.kafka.common.metrics.MetricsReporter.super.reconfigure(arg0);
}
//@Override
- public void validateReconfiguration(java.util.Map arg0) {
- raiseEvent("validateReconfiguration", arg0);
+ public void validateReconfiguration(java.util.Map arg0) throws org.apache.kafka.common.config.ConfigException {
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("validateReconfiguration", eventDataExchange, arg0); if (!eventDataExchange.getHasOverride()) org.apache.kafka.common.metrics.MetricsReporter.super.validateReconfiguration(arg0);
}
//@Override
- public void validateReconfigurationDefault(java.util.Map arg0) {
+ public void validateReconfigurationDefault(java.util.Map arg0) throws org.apache.kafka.common.config.ConfigException {
org.apache.kafka.common.metrics.MetricsReporter.super.validateReconfiguration(arg0);
}
diff --git a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/common/serialization/Deserializer.java b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/common/serialization/Deserializer.java
index 0ddd04a6c..0aa10bce2 100644
--- a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/common/serialization/Deserializer.java
+++ b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/common/serialization/Deserializer.java
@@ -1,39 +1,84 @@
/*
- * Copyright 2024 MASES s.r.l.
- *
- * Licensed 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.
- *
- * Refer to LICENSE for more information.
- */
+* Copyright 2024 MASES s.r.l.
+*
+* Licensed 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.
+*
+* Refer to LICENSE for more information.
+*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
*/
package org.mases.knet.generated.org.apache.kafka.common.serialization;
-public final class Deserializer extends org.mases.jcobridge.JCListener implements org.apache.kafka.common.serialization.Deserializer {
+public final class Deserializer implements org.mases.jcobridge.IJCListener, org.apache.kafka.common.serialization.Deserializer {
+ final org.mases.jcobridge.JCListener _internalListener;
+
public Deserializer(String key) throws org.mases.jcobridge.JCNativeException {
- super(key);
+ super();
+ _internalListener = new org.mases.jcobridge.JCListener(key);
+ }
+
+ public synchronized void release() {
+ _internalListener.release();
+ }
+
+ public synchronized void raiseEvent(String eventName) {
+ _internalListener.raiseEvent(eventName);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e) {
+ _internalListener.raiseEvent(eventName, e);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e, Object... objects) {
+ _internalListener.raiseEvent(eventName, e, objects);
+ }
+
+ public Object getEventData() {
+ return _internalListener.getEventData();
+ }
+
+ public boolean hasExtraData() {
+ return _internalListener.hasExtraData();
+ }
+
+ public int extraDataLength() {
+ return _internalListener.extraDataLength();
+ }
+
+ public Object[] extraData() {
+ return _internalListener.extraData();
+ }
+
+ public Object getReturnData() {
+ return _internalListener.getReturnData();
+ }
+
+ public void setReturnData(Object retData) {
+ _internalListener.setReturnData(retData);
}
//@Override
public java.lang.Object deserialize(java.lang.String arg0, byte[] arg1) {
- raiseEvent("deserialize", arg0, arg1); Object retVal = getReturnData(); return (java.lang.Object)retVal;
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("deserialize", eventDataExchange, arg0, arg1); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM"); Object retVal = eventDataExchange.getReturnData(); return (java.lang.Object)retVal;
}
//@Override
public java.lang.Object deserialize(java.lang.String arg0, org.apache.kafka.common.header.Headers arg1, byte[] arg2) {
- raiseEvent("deserialize3", arg0, arg1, arg2); Object retVal = getReturnData(); return (java.lang.Object)retVal;
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("deserialize3", eventDataExchange, arg0, arg1, arg2); Object retVal; if (!eventDataExchange.getHasOverride()) retVal = org.apache.kafka.common.serialization.Deserializer.super.deserialize(arg0, arg1, arg2); else retVal = eventDataExchange.getReturnData(); return (java.lang.Object)retVal;
}
//@Override
public java.lang.Object deserializeDefault(java.lang.String arg0, org.apache.kafka.common.header.Headers arg1, byte[] arg2) {
@@ -41,7 +86,8 @@ public java.lang.Object deserializeDefault(java.lang.String arg0, org.apache.kaf
}
//@Override
public java.lang.Object deserialize(java.lang.String arg0, org.apache.kafka.common.header.Headers arg1, java.nio.ByteBuffer arg2) {
- raiseEvent("deserialize3_2", arg0, arg1, arg2); Object retVal = getReturnData(); return (java.lang.Object)retVal;
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("deserialize3_2", eventDataExchange, arg0, arg1, arg2); Object retVal; if (!eventDataExchange.getHasOverride()) retVal = org.apache.kafka.common.serialization.Deserializer.super.deserialize(arg0, arg1, arg2); else retVal = eventDataExchange.getReturnData(); return (java.lang.Object)retVal;
}
//@Override
public java.lang.Object deserializeDefault(java.lang.String arg0, org.apache.kafka.common.header.Headers arg1, java.nio.ByteBuffer arg2) {
@@ -49,7 +95,8 @@ public java.lang.Object deserializeDefault(java.lang.String arg0, org.apache.kaf
}
//@Override
public void close() {
- raiseEvent("close");
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("close", eventDataExchange); if (!eventDataExchange.getHasOverride()) org.apache.kafka.common.serialization.Deserializer.super.close();
}
//@Override
public void closeDefault() {
@@ -57,7 +104,8 @@ public void closeDefault() {
}
//@Override
public void configure(java.util.Map arg0, boolean arg1) {
- raiseEvent("configure", arg0, arg1);
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("configure", eventDataExchange, arg0, arg1); if (!eventDataExchange.getHasOverride()) org.apache.kafka.common.serialization.Deserializer.super.configure(arg0, arg1);
}
//@Override
public void configureDefault(java.util.Map arg0, boolean arg1) {
diff --git a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/common/serialization/Serde.java b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/common/serialization/Serde.java
index 0c7fb00c2..6bf813624 100644
--- a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/common/serialization/Serde.java
+++ b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/common/serialization/Serde.java
@@ -1,43 +1,89 @@
/*
- * Copyright 2024 MASES s.r.l.
- *
- * Licensed 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.
- *
- * Refer to LICENSE for more information.
- */
+* Copyright 2024 MASES s.r.l.
+*
+* Licensed 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.
+*
+* Refer to LICENSE for more information.
+*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
*/
package org.mases.knet.generated.org.apache.kafka.common.serialization;
-public final class Serde extends org.mases.jcobridge.JCListener implements org.apache.kafka.common.serialization.Serde {
+public final class Serde implements org.mases.jcobridge.IJCListener, org.apache.kafka.common.serialization.Serde {
+ final org.mases.jcobridge.JCListener _internalListener;
+
public Serde(String key) throws org.mases.jcobridge.JCNativeException {
- super(key);
+ super();
+ _internalListener = new org.mases.jcobridge.JCListener(key);
+ }
+
+ public synchronized void release() {
+ _internalListener.release();
+ }
+
+ public synchronized void raiseEvent(String eventName) {
+ _internalListener.raiseEvent(eventName);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e) {
+ _internalListener.raiseEvent(eventName, e);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e, Object... objects) {
+ _internalListener.raiseEvent(eventName, e, objects);
+ }
+
+ public Object getEventData() {
+ return _internalListener.getEventData();
+ }
+
+ public boolean hasExtraData() {
+ return _internalListener.hasExtraData();
+ }
+
+ public int extraDataLength() {
+ return _internalListener.extraDataLength();
+ }
+
+ public Object[] extraData() {
+ return _internalListener.extraData();
+ }
+
+ public Object getReturnData() {
+ return _internalListener.getReturnData();
+ }
+
+ public void setReturnData(Object retData) {
+ _internalListener.setReturnData(retData);
}
//@Override
public org.apache.kafka.common.serialization.Deserializer deserializer() {
- raiseEvent("deserializer"); Object retVal = getReturnData(); return (org.apache.kafka.common.serialization.Deserializer)retVal;
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("deserializer", eventDataExchange); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM"); Object retVal = eventDataExchange.getReturnData(); return (org.apache.kafka.common.serialization.Deserializer)retVal;
}
//@Override
public org.apache.kafka.common.serialization.Serializer serializer() {
- raiseEvent("serializer"); Object retVal = getReturnData(); return (org.apache.kafka.common.serialization.Serializer)retVal;
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("serializer", eventDataExchange); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM"); Object retVal = eventDataExchange.getReturnData(); return (org.apache.kafka.common.serialization.Serializer)retVal;
}
//@Override
public void close() {
- raiseEvent("close");
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("close", eventDataExchange); if (!eventDataExchange.getHasOverride()) org.apache.kafka.common.serialization.Serde.super.close();
}
//@Override
public void closeDefault() {
@@ -45,7 +91,8 @@ public void closeDefault() {
}
//@Override
public void configure(java.util.Map arg0, boolean arg1) {
- raiseEvent("configure", arg0, arg1);
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("configure", eventDataExchange, arg0, arg1); if (!eventDataExchange.getHasOverride()) org.apache.kafka.common.serialization.Serde.super.configure(arg0, arg1);
}
//@Override
public void configureDefault(java.util.Map arg0, boolean arg1) {
diff --git a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/common/serialization/Serializer.java b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/common/serialization/Serializer.java
index f436d35ef..1e70323e9 100644
--- a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/common/serialization/Serializer.java
+++ b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/common/serialization/Serializer.java
@@ -1,39 +1,84 @@
/*
- * Copyright 2024 MASES s.r.l.
- *
- * Licensed 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.
- *
- * Refer to LICENSE for more information.
- */
+* Copyright 2024 MASES s.r.l.
+*
+* Licensed 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.
+*
+* Refer to LICENSE for more information.
+*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
*/
package org.mases.knet.generated.org.apache.kafka.common.serialization;
-public final class Serializer extends org.mases.jcobridge.JCListener implements org.apache.kafka.common.serialization.Serializer {
+public final class Serializer implements org.mases.jcobridge.IJCListener, org.apache.kafka.common.serialization.Serializer {
+ final org.mases.jcobridge.JCListener _internalListener;
+
public Serializer(String key) throws org.mases.jcobridge.JCNativeException {
- super(key);
+ super();
+ _internalListener = new org.mases.jcobridge.JCListener(key);
+ }
+
+ public synchronized void release() {
+ _internalListener.release();
+ }
+
+ public synchronized void raiseEvent(String eventName) {
+ _internalListener.raiseEvent(eventName);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e) {
+ _internalListener.raiseEvent(eventName, e);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e, Object... objects) {
+ _internalListener.raiseEvent(eventName, e, objects);
+ }
+
+ public Object getEventData() {
+ return _internalListener.getEventData();
+ }
+
+ public boolean hasExtraData() {
+ return _internalListener.hasExtraData();
+ }
+
+ public int extraDataLength() {
+ return _internalListener.extraDataLength();
+ }
+
+ public Object[] extraData() {
+ return _internalListener.extraData();
+ }
+
+ public Object getReturnData() {
+ return _internalListener.getReturnData();
+ }
+
+ public void setReturnData(Object retData) {
+ _internalListener.setReturnData(retData);
}
//@Override
public byte[] serialize(java.lang.String arg0, java.lang.Object arg1) {
- raiseEvent("serialize", arg0, arg1); Object retVal = getReturnData(); return (byte[])retVal;
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("serialize", eventDataExchange, arg0, arg1); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM"); Object retVal = eventDataExchange.getReturnData(); return (byte[])retVal;
}
//@Override
public byte[] serialize(java.lang.String arg0, org.apache.kafka.common.header.Headers arg1, java.lang.Object arg2) {
- raiseEvent("serialize3", arg0, arg1, arg2); Object retVal = getReturnData(); return (byte[])retVal;
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("serialize3", eventDataExchange, arg0, arg1, arg2); Object retVal; if (!eventDataExchange.getHasOverride()) retVal = org.apache.kafka.common.serialization.Serializer.super.serialize(arg0, arg1, arg2); else retVal = eventDataExchange.getReturnData(); return (byte[])retVal;
}
//@Override
public byte[] serializeDefault(java.lang.String arg0, org.apache.kafka.common.header.Headers arg1, java.lang.Object arg2) {
@@ -41,7 +86,8 @@ public byte[] serializeDefault(java.lang.String arg0, org.apache.kafka.common.he
}
//@Override
public void close() {
- raiseEvent("close");
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("close", eventDataExchange); if (!eventDataExchange.getHasOverride()) org.apache.kafka.common.serialization.Serializer.super.close();
}
//@Override
public void closeDefault() {
@@ -49,7 +95,8 @@ public void closeDefault() {
}
//@Override
public void configure(java.util.Map arg0, boolean arg1) {
- raiseEvent("configure", arg0, arg1);
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("configure", eventDataExchange, arg0, arg1); if (!eventDataExchange.getHasOverride()) org.apache.kafka.common.serialization.Serializer.super.configure(arg0, arg1);
}
//@Override
public void configureDefault(java.util.Map arg0, boolean arg1) {
diff --git a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/raft/RaftClient_Listener.java b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/raft/RaftClient_Listener.java
index e55e53481..140d2d855 100644
--- a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/raft/RaftClient_Listener.java
+++ b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/raft/RaftClient_Listener.java
@@ -1,43 +1,89 @@
/*
- * Copyright 2024 MASES s.r.l.
- *
- * Licensed 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.
- *
- * Refer to LICENSE for more information.
- */
+* Copyright 2024 MASES s.r.l.
+*
+* Licensed 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.
+*
+* Refer to LICENSE for more information.
+*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
*/
package org.mases.knet.generated.org.apache.kafka.raft;
-public final class RaftClient_Listener extends org.mases.jcobridge.JCListener implements org.apache.kafka.raft.RaftClient.Listener {
+public final class RaftClient_Listener implements org.mases.jcobridge.IJCListener, org.apache.kafka.raft.RaftClient.Listener {
+ final org.mases.jcobridge.JCListener _internalListener;
+
public RaftClient_Listener(String key) throws org.mases.jcobridge.JCNativeException {
- super(key);
+ super();
+ _internalListener = new org.mases.jcobridge.JCListener(key);
+ }
+
+ public synchronized void release() {
+ _internalListener.release();
+ }
+
+ public synchronized void raiseEvent(String eventName) {
+ _internalListener.raiseEvent(eventName);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e) {
+ _internalListener.raiseEvent(eventName, e);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e, Object... objects) {
+ _internalListener.raiseEvent(eventName, e, objects);
+ }
+
+ public Object getEventData() {
+ return _internalListener.getEventData();
+ }
+
+ public boolean hasExtraData() {
+ return _internalListener.hasExtraData();
+ }
+
+ public int extraDataLength() {
+ return _internalListener.extraDataLength();
+ }
+
+ public Object[] extraData() {
+ return _internalListener.extraData();
+ }
+
+ public Object getReturnData() {
+ return _internalListener.getReturnData();
+ }
+
+ public void setReturnData(Object retData) {
+ _internalListener.setReturnData(retData);
}
//@Override
public void handleCommit(org.apache.kafka.raft.BatchReader arg0) {
- raiseEvent("handleCommit", arg0);
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("handleCommit", eventDataExchange, arg0); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM");
}
//@Override
public void handleLoadSnapshot(org.apache.kafka.snapshot.SnapshotReader arg0) {
- raiseEvent("handleLoadSnapshot", arg0);
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("handleLoadSnapshot", eventDataExchange, arg0); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM");
}
//@Override
public void beginShutdown() {
- raiseEvent("beginShutdown");
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("beginShutdown", eventDataExchange); if (!eventDataExchange.getHasOverride()) org.apache.kafka.raft.RaftClient.Listener.super.beginShutdown();
}
//@Override
public void beginShutdownDefault() {
@@ -45,7 +91,8 @@ public void beginShutdownDefault() {
}
//@Override
public void handleLeaderChange(org.apache.kafka.raft.LeaderAndEpoch arg0) {
- raiseEvent("handleLeaderChange", arg0);
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("handleLeaderChange", eventDataExchange, arg0); if (!eventDataExchange.getHasOverride()) org.apache.kafka.raft.RaftClient.Listener.super.handleLeaderChange(arg0);
}
//@Override
public void handleLeaderChangeDefault(org.apache.kafka.raft.LeaderAndEpoch arg0) {
diff --git a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/KafkaClientSupplier.java b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/KafkaClientSupplier.java
index b0f2285ab..386b96b11 100644
--- a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/KafkaClientSupplier.java
+++ b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/KafkaClientSupplier.java
@@ -1,51 +1,99 @@
/*
- * Copyright 2024 MASES s.r.l.
- *
- * Licensed 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.
- *
- * Refer to LICENSE for more information.
- */
+* Copyright 2024 MASES s.r.l.
+*
+* Licensed 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.
+*
+* Refer to LICENSE for more information.
+*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
*/
package org.mases.knet.generated.org.apache.kafka.streams;
-public final class KafkaClientSupplier extends org.mases.jcobridge.JCListener implements org.apache.kafka.streams.KafkaClientSupplier {
+public final class KafkaClientSupplier implements org.mases.jcobridge.IJCListener, org.apache.kafka.streams.KafkaClientSupplier {
+ final org.mases.jcobridge.JCListener _internalListener;
+
public KafkaClientSupplier(String key) throws org.mases.jcobridge.JCNativeException {
- super(key);
+ super();
+ _internalListener = new org.mases.jcobridge.JCListener(key);
+ }
+
+ public synchronized void release() {
+ _internalListener.release();
+ }
+
+ public synchronized void raiseEvent(String eventName) {
+ _internalListener.raiseEvent(eventName);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e) {
+ _internalListener.raiseEvent(eventName, e);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e, Object... objects) {
+ _internalListener.raiseEvent(eventName, e, objects);
+ }
+
+ public Object getEventData() {
+ return _internalListener.getEventData();
+ }
+
+ public boolean hasExtraData() {
+ return _internalListener.hasExtraData();
+ }
+
+ public int extraDataLength() {
+ return _internalListener.extraDataLength();
+ }
+
+ public Object[] extraData() {
+ return _internalListener.extraData();
+ }
+
+ public Object getReturnData() {
+ return _internalListener.getReturnData();
+ }
+
+ public void setReturnData(Object retData) {
+ _internalListener.setReturnData(retData);
}
//@Override
public org.apache.kafka.clients.consumer.Consumer getConsumer(java.util.Map arg0) {
- raiseEvent("getConsumer", arg0); Object retVal = getReturnData(); return (org.apache.kafka.clients.consumer.Consumer)retVal;
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("getConsumer", eventDataExchange, arg0); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM"); Object retVal = eventDataExchange.getReturnData(); return (org.apache.kafka.clients.consumer.Consumer)retVal;
}
//@Override
public org.apache.kafka.clients.consumer.Consumer getGlobalConsumer(java.util.Map arg0) {
- raiseEvent("getGlobalConsumer", arg0); Object retVal = getReturnData(); return (org.apache.kafka.clients.consumer.Consumer)retVal;
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("getGlobalConsumer", eventDataExchange, arg0); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM"); Object retVal = eventDataExchange.getReturnData(); return (org.apache.kafka.clients.consumer.Consumer)retVal;
}
//@Override
public org.apache.kafka.clients.consumer.Consumer getRestoreConsumer(java.util.Map arg0) {
- raiseEvent("getRestoreConsumer", arg0); Object retVal = getReturnData(); return (org.apache.kafka.clients.consumer.Consumer)retVal;
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("getRestoreConsumer", eventDataExchange, arg0); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM"); Object retVal = eventDataExchange.getReturnData(); return (org.apache.kafka.clients.consumer.Consumer)retVal;
}
//@Override
public org.apache.kafka.clients.producer.Producer getProducer(java.util.Map arg0) {
- raiseEvent("getProducer", arg0); Object retVal = getReturnData(); return (org.apache.kafka.clients.producer.Producer)retVal;
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("getProducer", eventDataExchange, arg0); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM"); Object retVal = eventDataExchange.getReturnData(); return (org.apache.kafka.clients.producer.Producer)retVal;
}
//@Override
public org.apache.kafka.clients.admin.Admin getAdmin(java.util.Map arg0) {
- raiseEvent("getAdmin", arg0); Object retVal = getReturnData(); return (org.apache.kafka.clients.admin.Admin)retVal;
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("getAdmin", eventDataExchange, arg0); Object retVal; if (!eventDataExchange.getHasOverride()) retVal = org.apache.kafka.streams.KafkaClientSupplier.super.getAdmin(arg0); else retVal = eventDataExchange.getReturnData(); return (org.apache.kafka.clients.admin.Admin)retVal;
}
//@Override
public org.apache.kafka.clients.admin.Admin getAdminDefault(java.util.Map arg0) {
diff --git a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/KafkaStreams_StateListener.java b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/KafkaStreams_StateListener.java
index cb3528fb9..a3fcf8c15 100644
--- a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/KafkaStreams_StateListener.java
+++ b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/KafkaStreams_StateListener.java
@@ -1,35 +1,79 @@
/*
- * Copyright 2024 MASES s.r.l.
- *
- * Licensed 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.
- *
- * Refer to LICENSE for more information.
- */
+* Copyright 2024 MASES s.r.l.
+*
+* Licensed 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.
+*
+* Refer to LICENSE for more information.
+*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
*/
package org.mases.knet.generated.org.apache.kafka.streams;
-public final class KafkaStreams_StateListener extends org.mases.jcobridge.JCListener implements org.apache.kafka.streams.KafkaStreams.StateListener {
+public final class KafkaStreams_StateListener implements org.mases.jcobridge.IJCListener, org.apache.kafka.streams.KafkaStreams.StateListener {
+ final org.mases.jcobridge.JCListener _internalListener;
+
public KafkaStreams_StateListener(String key) throws org.mases.jcobridge.JCNativeException {
- super(key);
+ super();
+ _internalListener = new org.mases.jcobridge.JCListener(key);
+ }
+
+ public synchronized void release() {
+ _internalListener.release();
+ }
+
+ public synchronized void raiseEvent(String eventName) {
+ _internalListener.raiseEvent(eventName);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e) {
+ _internalListener.raiseEvent(eventName, e);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e, Object... objects) {
+ _internalListener.raiseEvent(eventName, e, objects);
+ }
+
+ public Object getEventData() {
+ return _internalListener.getEventData();
+ }
+
+ public boolean hasExtraData() {
+ return _internalListener.hasExtraData();
+ }
+
+ public int extraDataLength() {
+ return _internalListener.extraDataLength();
+ }
+
+ public Object[] extraData() {
+ return _internalListener.extraData();
+ }
+
+ public Object getReturnData() {
+ return _internalListener.getReturnData();
+ }
+
+ public void setReturnData(Object retData) {
+ _internalListener.setReturnData(retData);
}
//@Override
public void onChange(org.apache.kafka.streams.KafkaStreams.State arg0, org.apache.kafka.streams.KafkaStreams.State arg1) {
- raiseEvent("onChange", arg0, arg1);
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("onChange", eventDataExchange, arg0, arg1); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM");
}
}
\ No newline at end of file
diff --git a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/errors/StreamsUncaughtExceptionHandler.java b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/errors/StreamsUncaughtExceptionHandler.java
index 02fd71995..cf767f1df 100644
--- a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/errors/StreamsUncaughtExceptionHandler.java
+++ b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/errors/StreamsUncaughtExceptionHandler.java
@@ -1,35 +1,79 @@
/*
- * Copyright 2024 MASES s.r.l.
- *
- * Licensed 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.
- *
- * Refer to LICENSE for more information.
- */
+* Copyright 2024 MASES s.r.l.
+*
+* Licensed 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.
+*
+* Refer to LICENSE for more information.
+*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
*/
package org.mases.knet.generated.org.apache.kafka.streams.errors;
-public final class StreamsUncaughtExceptionHandler extends org.mases.jcobridge.JCListener implements org.apache.kafka.streams.errors.StreamsUncaughtExceptionHandler {
+public final class StreamsUncaughtExceptionHandler implements org.mases.jcobridge.IJCListener, org.apache.kafka.streams.errors.StreamsUncaughtExceptionHandler {
+ final org.mases.jcobridge.JCListener _internalListener;
+
public StreamsUncaughtExceptionHandler(String key) throws org.mases.jcobridge.JCNativeException {
- super(key);
+ super();
+ _internalListener = new org.mases.jcobridge.JCListener(key);
+ }
+
+ public synchronized void release() {
+ _internalListener.release();
+ }
+
+ public synchronized void raiseEvent(String eventName) {
+ _internalListener.raiseEvent(eventName);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e) {
+ _internalListener.raiseEvent(eventName, e);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e, Object... objects) {
+ _internalListener.raiseEvent(eventName, e, objects);
+ }
+
+ public Object getEventData() {
+ return _internalListener.getEventData();
+ }
+
+ public boolean hasExtraData() {
+ return _internalListener.hasExtraData();
+ }
+
+ public int extraDataLength() {
+ return _internalListener.extraDataLength();
+ }
+
+ public Object[] extraData() {
+ return _internalListener.extraData();
+ }
+
+ public Object getReturnData() {
+ return _internalListener.getReturnData();
+ }
+
+ public void setReturnData(Object retData) {
+ _internalListener.setReturnData(retData);
}
//@Override
public org.apache.kafka.streams.errors.StreamsUncaughtExceptionHandler.StreamThreadExceptionResponse handle(java.lang.Throwable arg0) {
- raiseEvent("handle", arg0); Object retVal = getReturnData(); return (org.apache.kafka.streams.errors.StreamsUncaughtExceptionHandler.StreamThreadExceptionResponse)retVal;
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("handle", eventDataExchange, arg0); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM"); Object retVal = eventDataExchange.getReturnData(); return (org.apache.kafka.streams.errors.StreamsUncaughtExceptionHandler.StreamThreadExceptionResponse)retVal;
}
}
\ No newline at end of file
diff --git a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/Aggregator.java b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/Aggregator.java
index f0dedcc77..0a2214184 100644
--- a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/Aggregator.java
+++ b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/Aggregator.java
@@ -1,35 +1,79 @@
/*
- * Copyright 2024 MASES s.r.l.
- *
- * Licensed 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.
- *
- * Refer to LICENSE for more information.
- */
+* Copyright 2024 MASES s.r.l.
+*
+* Licensed 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.
+*
+* Refer to LICENSE for more information.
+*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
*/
package org.mases.knet.generated.org.apache.kafka.streams.kstream;
-public final class Aggregator extends org.mases.jcobridge.JCListener implements org.apache.kafka.streams.kstream.Aggregator {
+public final class Aggregator implements org.mases.jcobridge.IJCListener, org.apache.kafka.streams.kstream.Aggregator {
+ final org.mases.jcobridge.JCListener _internalListener;
+
public Aggregator(String key) throws org.mases.jcobridge.JCNativeException {
- super(key);
+ super();
+ _internalListener = new org.mases.jcobridge.JCListener(key);
+ }
+
+ public synchronized void release() {
+ _internalListener.release();
+ }
+
+ public synchronized void raiseEvent(String eventName) {
+ _internalListener.raiseEvent(eventName);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e) {
+ _internalListener.raiseEvent(eventName, e);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e, Object... objects) {
+ _internalListener.raiseEvent(eventName, e, objects);
+ }
+
+ public Object getEventData() {
+ return _internalListener.getEventData();
+ }
+
+ public boolean hasExtraData() {
+ return _internalListener.hasExtraData();
+ }
+
+ public int extraDataLength() {
+ return _internalListener.extraDataLength();
+ }
+
+ public Object[] extraData() {
+ return _internalListener.extraData();
+ }
+
+ public Object getReturnData() {
+ return _internalListener.getReturnData();
+ }
+
+ public void setReturnData(Object retData) {
+ _internalListener.setReturnData(retData);
}
//@Override
public java.lang.Object apply(java.lang.Object arg0, java.lang.Object arg1, java.lang.Object arg2) {
- raiseEvent("apply", arg0, arg1, arg2); Object retVal = getReturnData(); return (java.lang.Object)retVal;
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("apply", eventDataExchange, arg0, arg1, arg2); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM"); Object retVal = eventDataExchange.getReturnData(); return (java.lang.Object)retVal;
}
}
\ No newline at end of file
diff --git a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/ForeachAction.java b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/ForeachAction.java
index 974d1d06b..8ad373417 100644
--- a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/ForeachAction.java
+++ b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/ForeachAction.java
@@ -1,35 +1,79 @@
/*
- * Copyright 2024 MASES s.r.l.
- *
- * Licensed 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.
- *
- * Refer to LICENSE for more information.
- */
+* Copyright 2024 MASES s.r.l.
+*
+* Licensed 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.
+*
+* Refer to LICENSE for more information.
+*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
*/
package org.mases.knet.generated.org.apache.kafka.streams.kstream;
-public final class ForeachAction extends org.mases.jcobridge.JCListener implements org.apache.kafka.streams.kstream.ForeachAction {
+public final class ForeachAction implements org.mases.jcobridge.IJCListener, org.apache.kafka.streams.kstream.ForeachAction {
+ final org.mases.jcobridge.JCListener _internalListener;
+
public ForeachAction(String key) throws org.mases.jcobridge.JCNativeException {
- super(key);
+ super();
+ _internalListener = new org.mases.jcobridge.JCListener(key);
+ }
+
+ public synchronized void release() {
+ _internalListener.release();
+ }
+
+ public synchronized void raiseEvent(String eventName) {
+ _internalListener.raiseEvent(eventName);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e) {
+ _internalListener.raiseEvent(eventName, e);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e, Object... objects) {
+ _internalListener.raiseEvent(eventName, e, objects);
+ }
+
+ public Object getEventData() {
+ return _internalListener.getEventData();
+ }
+
+ public boolean hasExtraData() {
+ return _internalListener.hasExtraData();
+ }
+
+ public int extraDataLength() {
+ return _internalListener.extraDataLength();
+ }
+
+ public Object[] extraData() {
+ return _internalListener.extraData();
+ }
+
+ public Object getReturnData() {
+ return _internalListener.getReturnData();
+ }
+
+ public void setReturnData(Object retData) {
+ _internalListener.setReturnData(retData);
}
//@Override
public void apply(java.lang.Object arg0, java.lang.Object arg1) {
- raiseEvent("apply", arg0, arg1);
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("apply", eventDataExchange, arg0, arg1); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM");
}
}
\ No newline at end of file
diff --git a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/Initializer.java b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/Initializer.java
index eb8cb7899..46eef19c7 100644
--- a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/Initializer.java
+++ b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/Initializer.java
@@ -1,35 +1,79 @@
/*
- * Copyright 2024 MASES s.r.l.
- *
- * Licensed 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.
- *
- * Refer to LICENSE for more information.
- */
+* Copyright 2024 MASES s.r.l.
+*
+* Licensed 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.
+*
+* Refer to LICENSE for more information.
+*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
*/
package org.mases.knet.generated.org.apache.kafka.streams.kstream;
-public final class Initializer extends org.mases.jcobridge.JCListener implements org.apache.kafka.streams.kstream.Initializer {
+public final class Initializer implements org.mases.jcobridge.IJCListener, org.apache.kafka.streams.kstream.Initializer {
+ final org.mases.jcobridge.JCListener _internalListener;
+
public Initializer(String key) throws org.mases.jcobridge.JCNativeException {
- super(key);
+ super();
+ _internalListener = new org.mases.jcobridge.JCListener(key);
+ }
+
+ public synchronized void release() {
+ _internalListener.release();
+ }
+
+ public synchronized void raiseEvent(String eventName) {
+ _internalListener.raiseEvent(eventName);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e) {
+ _internalListener.raiseEvent(eventName, e);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e, Object... objects) {
+ _internalListener.raiseEvent(eventName, e, objects);
+ }
+
+ public Object getEventData() {
+ return _internalListener.getEventData();
+ }
+
+ public boolean hasExtraData() {
+ return _internalListener.hasExtraData();
+ }
+
+ public int extraDataLength() {
+ return _internalListener.extraDataLength();
+ }
+
+ public Object[] extraData() {
+ return _internalListener.extraData();
+ }
+
+ public Object getReturnData() {
+ return _internalListener.getReturnData();
+ }
+
+ public void setReturnData(Object retData) {
+ _internalListener.setReturnData(retData);
}
//@Override
public java.lang.Object apply() {
- raiseEvent("apply"); Object retVal = getReturnData(); return (java.lang.Object)retVal;
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("apply", eventDataExchange); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM"); Object retVal = eventDataExchange.getReturnData(); return (java.lang.Object)retVal;
}
}
\ No newline at end of file
diff --git a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/KeyValueMapper.java b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/KeyValueMapper.java
index 5d77c4a4f..22dbc6f3e 100644
--- a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/KeyValueMapper.java
+++ b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/KeyValueMapper.java
@@ -1,35 +1,79 @@
/*
- * Copyright 2024 MASES s.r.l.
- *
- * Licensed 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.
- *
- * Refer to LICENSE for more information.
- */
+* Copyright 2024 MASES s.r.l.
+*
+* Licensed 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.
+*
+* Refer to LICENSE for more information.
+*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
*/
package org.mases.knet.generated.org.apache.kafka.streams.kstream;
-public final class KeyValueMapper extends org.mases.jcobridge.JCListener implements org.apache.kafka.streams.kstream.KeyValueMapper {
+public final class KeyValueMapper implements org.mases.jcobridge.IJCListener, org.apache.kafka.streams.kstream.KeyValueMapper {
+ final org.mases.jcobridge.JCListener _internalListener;
+
public KeyValueMapper(String key) throws org.mases.jcobridge.JCNativeException {
- super(key);
+ super();
+ _internalListener = new org.mases.jcobridge.JCListener(key);
+ }
+
+ public synchronized void release() {
+ _internalListener.release();
+ }
+
+ public synchronized void raiseEvent(String eventName) {
+ _internalListener.raiseEvent(eventName);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e) {
+ _internalListener.raiseEvent(eventName, e);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e, Object... objects) {
+ _internalListener.raiseEvent(eventName, e, objects);
+ }
+
+ public Object getEventData() {
+ return _internalListener.getEventData();
+ }
+
+ public boolean hasExtraData() {
+ return _internalListener.hasExtraData();
+ }
+
+ public int extraDataLength() {
+ return _internalListener.extraDataLength();
+ }
+
+ public Object[] extraData() {
+ return _internalListener.extraData();
+ }
+
+ public Object getReturnData() {
+ return _internalListener.getReturnData();
+ }
+
+ public void setReturnData(Object retData) {
+ _internalListener.setReturnData(retData);
}
//@Override
public java.lang.Object apply(java.lang.Object arg0, java.lang.Object arg1) {
- raiseEvent("apply", arg0, arg1); Object retVal = getReturnData(); return (java.lang.Object)retVal;
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("apply", eventDataExchange, arg0, arg1); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM"); Object retVal = eventDataExchange.getReturnData(); return (java.lang.Object)retVal;
}
}
\ No newline at end of file
diff --git a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/Merger.java b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/Merger.java
index b90f2f759..8bb71e818 100644
--- a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/Merger.java
+++ b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/Merger.java
@@ -1,35 +1,79 @@
/*
- * Copyright 2024 MASES s.r.l.
- *
- * Licensed 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.
- *
- * Refer to LICENSE for more information.
- */
+* Copyright 2024 MASES s.r.l.
+*
+* Licensed 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.
+*
+* Refer to LICENSE for more information.
+*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
*/
package org.mases.knet.generated.org.apache.kafka.streams.kstream;
-public final class Merger extends org.mases.jcobridge.JCListener implements org.apache.kafka.streams.kstream.Merger {
+public final class Merger implements org.mases.jcobridge.IJCListener, org.apache.kafka.streams.kstream.Merger {
+ final org.mases.jcobridge.JCListener _internalListener;
+
public Merger(String key) throws org.mases.jcobridge.JCNativeException {
- super(key);
+ super();
+ _internalListener = new org.mases.jcobridge.JCListener(key);
+ }
+
+ public synchronized void release() {
+ _internalListener.release();
+ }
+
+ public synchronized void raiseEvent(String eventName) {
+ _internalListener.raiseEvent(eventName);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e) {
+ _internalListener.raiseEvent(eventName, e);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e, Object... objects) {
+ _internalListener.raiseEvent(eventName, e, objects);
+ }
+
+ public Object getEventData() {
+ return _internalListener.getEventData();
+ }
+
+ public boolean hasExtraData() {
+ return _internalListener.hasExtraData();
+ }
+
+ public int extraDataLength() {
+ return _internalListener.extraDataLength();
+ }
+
+ public Object[] extraData() {
+ return _internalListener.extraData();
+ }
+
+ public Object getReturnData() {
+ return _internalListener.getReturnData();
+ }
+
+ public void setReturnData(Object retData) {
+ _internalListener.setReturnData(retData);
}
//@Override
public java.lang.Object apply(java.lang.Object arg0, java.lang.Object arg1, java.lang.Object arg2) {
- raiseEvent("apply", arg0, arg1, arg2); Object retVal = getReturnData(); return (java.lang.Object)retVal;
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("apply", eventDataExchange, arg0, arg1, arg2); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM"); Object retVal = eventDataExchange.getReturnData(); return (java.lang.Object)retVal;
}
}
\ No newline at end of file
diff --git a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/Predicate.java b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/Predicate.java
index 4f33cbcb9..f4e43bf9b 100644
--- a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/Predicate.java
+++ b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/Predicate.java
@@ -1,35 +1,79 @@
/*
- * Copyright 2024 MASES s.r.l.
- *
- * Licensed 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.
- *
- * Refer to LICENSE for more information.
- */
+* Copyright 2024 MASES s.r.l.
+*
+* Licensed 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.
+*
+* Refer to LICENSE for more information.
+*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
*/
package org.mases.knet.generated.org.apache.kafka.streams.kstream;
-public final class Predicate extends org.mases.jcobridge.JCListener implements org.apache.kafka.streams.kstream.Predicate {
+public final class Predicate implements org.mases.jcobridge.IJCListener, org.apache.kafka.streams.kstream.Predicate {
+ final org.mases.jcobridge.JCListener _internalListener;
+
public Predicate(String key) throws org.mases.jcobridge.JCNativeException {
- super(key);
+ super();
+ _internalListener = new org.mases.jcobridge.JCListener(key);
+ }
+
+ public synchronized void release() {
+ _internalListener.release();
+ }
+
+ public synchronized void raiseEvent(String eventName) {
+ _internalListener.raiseEvent(eventName);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e) {
+ _internalListener.raiseEvent(eventName, e);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e, Object... objects) {
+ _internalListener.raiseEvent(eventName, e, objects);
+ }
+
+ public Object getEventData() {
+ return _internalListener.getEventData();
+ }
+
+ public boolean hasExtraData() {
+ return _internalListener.hasExtraData();
+ }
+
+ public int extraDataLength() {
+ return _internalListener.extraDataLength();
+ }
+
+ public Object[] extraData() {
+ return _internalListener.extraData();
+ }
+
+ public Object getReturnData() {
+ return _internalListener.getReturnData();
+ }
+
+ public void setReturnData(Object retData) {
+ _internalListener.setReturnData(retData);
}
//@Override
public boolean test(java.lang.Object arg0, java.lang.Object arg1) {
- raiseEvent("test", arg0, arg1); Object retVal = getReturnData(); return (boolean)retVal;
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("test", eventDataExchange, arg0, arg1); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM"); Object retVal = eventDataExchange.getReturnData(); return (boolean)retVal;
}
}
\ No newline at end of file
diff --git a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/Reducer.java b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/Reducer.java
index 59f383edb..765a1fd4a 100644
--- a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/Reducer.java
+++ b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/Reducer.java
@@ -1,35 +1,79 @@
/*
- * Copyright 2024 MASES s.r.l.
- *
- * Licensed 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.
- *
- * Refer to LICENSE for more information.
- */
+* Copyright 2024 MASES s.r.l.
+*
+* Licensed 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.
+*
+* Refer to LICENSE for more information.
+*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
*/
package org.mases.knet.generated.org.apache.kafka.streams.kstream;
-public final class Reducer extends org.mases.jcobridge.JCListener implements org.apache.kafka.streams.kstream.Reducer {
+public final class Reducer implements org.mases.jcobridge.IJCListener, org.apache.kafka.streams.kstream.Reducer {
+ final org.mases.jcobridge.JCListener _internalListener;
+
public Reducer(String key) throws org.mases.jcobridge.JCNativeException {
- super(key);
+ super();
+ _internalListener = new org.mases.jcobridge.JCListener(key);
+ }
+
+ public synchronized void release() {
+ _internalListener.release();
+ }
+
+ public synchronized void raiseEvent(String eventName) {
+ _internalListener.raiseEvent(eventName);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e) {
+ _internalListener.raiseEvent(eventName, e);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e, Object... objects) {
+ _internalListener.raiseEvent(eventName, e, objects);
+ }
+
+ public Object getEventData() {
+ return _internalListener.getEventData();
+ }
+
+ public boolean hasExtraData() {
+ return _internalListener.hasExtraData();
+ }
+
+ public int extraDataLength() {
+ return _internalListener.extraDataLength();
+ }
+
+ public Object[] extraData() {
+ return _internalListener.extraData();
+ }
+
+ public Object getReturnData() {
+ return _internalListener.getReturnData();
+ }
+
+ public void setReturnData(Object retData) {
+ _internalListener.setReturnData(retData);
}
//@Override
public java.lang.Object apply(java.lang.Object arg0, java.lang.Object arg1) {
- raiseEvent("apply", arg0, arg1); Object retVal = getReturnData(); return (java.lang.Object)retVal;
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("apply", eventDataExchange, arg0, arg1); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM"); Object retVal = eventDataExchange.getReturnData(); return (java.lang.Object)retVal;
}
}
\ No newline at end of file
diff --git a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/Transformer.java b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/Transformer.java
index 516d6a238..5f432373d 100644
--- a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/Transformer.java
+++ b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/Transformer.java
@@ -1,43 +1,89 @@
/*
- * Copyright 2024 MASES s.r.l.
- *
- * Licensed 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.
- *
- * Refer to LICENSE for more information.
- */
+* Copyright 2024 MASES s.r.l.
+*
+* Licensed 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.
+*
+* Refer to LICENSE for more information.
+*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
*/
package org.mases.knet.generated.org.apache.kafka.streams.kstream;
-public final class Transformer extends org.mases.jcobridge.JCListener implements org.apache.kafka.streams.kstream.Transformer {
+public final class Transformer implements org.mases.jcobridge.IJCListener, org.apache.kafka.streams.kstream.Transformer {
+ final org.mases.jcobridge.JCListener _internalListener;
+
public Transformer(String key) throws org.mases.jcobridge.JCNativeException {
- super(key);
+ super();
+ _internalListener = new org.mases.jcobridge.JCListener(key);
+ }
+
+ public synchronized void release() {
+ _internalListener.release();
+ }
+
+ public synchronized void raiseEvent(String eventName) {
+ _internalListener.raiseEvent(eventName);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e) {
+ _internalListener.raiseEvent(eventName, e);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e, Object... objects) {
+ _internalListener.raiseEvent(eventName, e, objects);
+ }
+
+ public Object getEventData() {
+ return _internalListener.getEventData();
+ }
+
+ public boolean hasExtraData() {
+ return _internalListener.hasExtraData();
+ }
+
+ public int extraDataLength() {
+ return _internalListener.extraDataLength();
+ }
+
+ public Object[] extraData() {
+ return _internalListener.extraData();
+ }
+
+ public Object getReturnData() {
+ return _internalListener.getReturnData();
+ }
+
+ public void setReturnData(Object retData) {
+ _internalListener.setReturnData(retData);
}
//@Override
public java.lang.Object transform(java.lang.Object arg0, java.lang.Object arg1) {
- raiseEvent("transform", arg0, arg1); Object retVal = getReturnData(); return (java.lang.Object)retVal;
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("transform", eventDataExchange, arg0, arg1); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM"); Object retVal = eventDataExchange.getReturnData(); return (java.lang.Object)retVal;
}
//@Override
public void close() {
- raiseEvent("close");
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("close", eventDataExchange); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM");
}
//@Override
public void init(org.apache.kafka.streams.processor.ProcessorContext arg0) {
- raiseEvent("init", arg0);
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("init", eventDataExchange, arg0); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM");
}
}
\ No newline at end of file
diff --git a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/ValueJoiner.java b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/ValueJoiner.java
index 51f91e6b1..260ea87c1 100644
--- a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/ValueJoiner.java
+++ b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/ValueJoiner.java
@@ -1,35 +1,79 @@
/*
- * Copyright 2024 MASES s.r.l.
- *
- * Licensed 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.
- *
- * Refer to LICENSE for more information.
- */
+* Copyright 2024 MASES s.r.l.
+*
+* Licensed 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.
+*
+* Refer to LICENSE for more information.
+*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
*/
package org.mases.knet.generated.org.apache.kafka.streams.kstream;
-public final class ValueJoiner extends org.mases.jcobridge.JCListener implements org.apache.kafka.streams.kstream.ValueJoiner {
+public final class ValueJoiner implements org.mases.jcobridge.IJCListener, org.apache.kafka.streams.kstream.ValueJoiner {
+ final org.mases.jcobridge.JCListener _internalListener;
+
public ValueJoiner(String key) throws org.mases.jcobridge.JCNativeException {
- super(key);
+ super();
+ _internalListener = new org.mases.jcobridge.JCListener(key);
+ }
+
+ public synchronized void release() {
+ _internalListener.release();
+ }
+
+ public synchronized void raiseEvent(String eventName) {
+ _internalListener.raiseEvent(eventName);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e) {
+ _internalListener.raiseEvent(eventName, e);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e, Object... objects) {
+ _internalListener.raiseEvent(eventName, e, objects);
+ }
+
+ public Object getEventData() {
+ return _internalListener.getEventData();
+ }
+
+ public boolean hasExtraData() {
+ return _internalListener.hasExtraData();
+ }
+
+ public int extraDataLength() {
+ return _internalListener.extraDataLength();
+ }
+
+ public Object[] extraData() {
+ return _internalListener.extraData();
+ }
+
+ public Object getReturnData() {
+ return _internalListener.getReturnData();
+ }
+
+ public void setReturnData(Object retData) {
+ _internalListener.setReturnData(retData);
}
//@Override
public java.lang.Object apply(java.lang.Object arg0, java.lang.Object arg1) {
- raiseEvent("apply", arg0, arg1); Object retVal = getReturnData(); return (java.lang.Object)retVal;
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("apply", eventDataExchange, arg0, arg1); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM"); Object retVal = eventDataExchange.getReturnData(); return (java.lang.Object)retVal;
}
}
\ No newline at end of file
diff --git a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/ValueJoinerWithKey.java b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/ValueJoinerWithKey.java
index c5a6aa7f1..869beebb3 100644
--- a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/ValueJoinerWithKey.java
+++ b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/ValueJoinerWithKey.java
@@ -1,35 +1,79 @@
/*
- * Copyright 2024 MASES s.r.l.
- *
- * Licensed 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.
- *
- * Refer to LICENSE for more information.
- */
+* Copyright 2024 MASES s.r.l.
+*
+* Licensed 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.
+*
+* Refer to LICENSE for more information.
+*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
*/
package org.mases.knet.generated.org.apache.kafka.streams.kstream;
-public final class ValueJoinerWithKey extends org.mases.jcobridge.JCListener implements org.apache.kafka.streams.kstream.ValueJoinerWithKey {
+public final class ValueJoinerWithKey implements org.mases.jcobridge.IJCListener, org.apache.kafka.streams.kstream.ValueJoinerWithKey {
+ final org.mases.jcobridge.JCListener _internalListener;
+
public ValueJoinerWithKey(String key) throws org.mases.jcobridge.JCNativeException {
- super(key);
+ super();
+ _internalListener = new org.mases.jcobridge.JCListener(key);
+ }
+
+ public synchronized void release() {
+ _internalListener.release();
+ }
+
+ public synchronized void raiseEvent(String eventName) {
+ _internalListener.raiseEvent(eventName);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e) {
+ _internalListener.raiseEvent(eventName, e);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e, Object... objects) {
+ _internalListener.raiseEvent(eventName, e, objects);
+ }
+
+ public Object getEventData() {
+ return _internalListener.getEventData();
+ }
+
+ public boolean hasExtraData() {
+ return _internalListener.hasExtraData();
+ }
+
+ public int extraDataLength() {
+ return _internalListener.extraDataLength();
+ }
+
+ public Object[] extraData() {
+ return _internalListener.extraData();
+ }
+
+ public Object getReturnData() {
+ return _internalListener.getReturnData();
+ }
+
+ public void setReturnData(Object retData) {
+ _internalListener.setReturnData(retData);
}
//@Override
public java.lang.Object apply(java.lang.Object arg0, java.lang.Object arg1, java.lang.Object arg2) {
- raiseEvent("apply", arg0, arg1, arg2); Object retVal = getReturnData(); return (java.lang.Object)retVal;
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("apply", eventDataExchange, arg0, arg1, arg2); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM"); Object retVal = eventDataExchange.getReturnData(); return (java.lang.Object)retVal;
}
}
\ No newline at end of file
diff --git a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/ValueMapper.java b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/ValueMapper.java
index 2cc4096c8..6f17e3ae6 100644
--- a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/ValueMapper.java
+++ b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/ValueMapper.java
@@ -1,35 +1,79 @@
/*
- * Copyright 2024 MASES s.r.l.
- *
- * Licensed 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.
- *
- * Refer to LICENSE for more information.
- */
+* Copyright 2024 MASES s.r.l.
+*
+* Licensed 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.
+*
+* Refer to LICENSE for more information.
+*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
*/
package org.mases.knet.generated.org.apache.kafka.streams.kstream;
-public final class ValueMapper extends org.mases.jcobridge.JCListener implements org.apache.kafka.streams.kstream.ValueMapper {
+public final class ValueMapper implements org.mases.jcobridge.IJCListener, org.apache.kafka.streams.kstream.ValueMapper {
+ final org.mases.jcobridge.JCListener _internalListener;
+
public ValueMapper(String key) throws org.mases.jcobridge.JCNativeException {
- super(key);
+ super();
+ _internalListener = new org.mases.jcobridge.JCListener(key);
+ }
+
+ public synchronized void release() {
+ _internalListener.release();
+ }
+
+ public synchronized void raiseEvent(String eventName) {
+ _internalListener.raiseEvent(eventName);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e) {
+ _internalListener.raiseEvent(eventName, e);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e, Object... objects) {
+ _internalListener.raiseEvent(eventName, e, objects);
+ }
+
+ public Object getEventData() {
+ return _internalListener.getEventData();
+ }
+
+ public boolean hasExtraData() {
+ return _internalListener.hasExtraData();
+ }
+
+ public int extraDataLength() {
+ return _internalListener.extraDataLength();
+ }
+
+ public Object[] extraData() {
+ return _internalListener.extraData();
+ }
+
+ public Object getReturnData() {
+ return _internalListener.getReturnData();
+ }
+
+ public void setReturnData(Object retData) {
+ _internalListener.setReturnData(retData);
}
//@Override
public java.lang.Object apply(java.lang.Object arg0) {
- raiseEvent("apply", arg0); Object retVal = getReturnData(); return (java.lang.Object)retVal;
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("apply", eventDataExchange, arg0); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM"); Object retVal = eventDataExchange.getReturnData(); return (java.lang.Object)retVal;
}
}
\ No newline at end of file
diff --git a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/ValueMapperWithKey.java b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/ValueMapperWithKey.java
index ad65b2f70..6f5b5f208 100644
--- a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/ValueMapperWithKey.java
+++ b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/ValueMapperWithKey.java
@@ -1,35 +1,79 @@
/*
- * Copyright 2024 MASES s.r.l.
- *
- * Licensed 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.
- *
- * Refer to LICENSE for more information.
- */
+* Copyright 2024 MASES s.r.l.
+*
+* Licensed 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.
+*
+* Refer to LICENSE for more information.
+*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
*/
package org.mases.knet.generated.org.apache.kafka.streams.kstream;
-public final class ValueMapperWithKey extends org.mases.jcobridge.JCListener implements org.apache.kafka.streams.kstream.ValueMapperWithKey {
+public final class ValueMapperWithKey implements org.mases.jcobridge.IJCListener, org.apache.kafka.streams.kstream.ValueMapperWithKey {
+ final org.mases.jcobridge.JCListener _internalListener;
+
public ValueMapperWithKey(String key) throws org.mases.jcobridge.JCNativeException {
- super(key);
+ super();
+ _internalListener = new org.mases.jcobridge.JCListener(key);
+ }
+
+ public synchronized void release() {
+ _internalListener.release();
+ }
+
+ public synchronized void raiseEvent(String eventName) {
+ _internalListener.raiseEvent(eventName);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e) {
+ _internalListener.raiseEvent(eventName, e);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e, Object... objects) {
+ _internalListener.raiseEvent(eventName, e, objects);
+ }
+
+ public Object getEventData() {
+ return _internalListener.getEventData();
+ }
+
+ public boolean hasExtraData() {
+ return _internalListener.hasExtraData();
+ }
+
+ public int extraDataLength() {
+ return _internalListener.extraDataLength();
+ }
+
+ public Object[] extraData() {
+ return _internalListener.extraData();
+ }
+
+ public Object getReturnData() {
+ return _internalListener.getReturnData();
+ }
+
+ public void setReturnData(Object retData) {
+ _internalListener.setReturnData(retData);
}
//@Override
public java.lang.Object apply(java.lang.Object arg0, java.lang.Object arg1) {
- raiseEvent("apply", arg0, arg1); Object retVal = getReturnData(); return (java.lang.Object)retVal;
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("apply", eventDataExchange, arg0, arg1); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM"); Object retVal = eventDataExchange.getReturnData(); return (java.lang.Object)retVal;
}
}
\ No newline at end of file
diff --git a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/ValueTransformer.java b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/ValueTransformer.java
index f4889a2ee..075a4a5ec 100644
--- a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/ValueTransformer.java
+++ b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/ValueTransformer.java
@@ -1,43 +1,89 @@
/*
- * Copyright 2024 MASES s.r.l.
- *
- * Licensed 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.
- *
- * Refer to LICENSE for more information.
- */
+* Copyright 2024 MASES s.r.l.
+*
+* Licensed 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.
+*
+* Refer to LICENSE for more information.
+*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
*/
package org.mases.knet.generated.org.apache.kafka.streams.kstream;
-public final class ValueTransformer extends org.mases.jcobridge.JCListener implements org.apache.kafka.streams.kstream.ValueTransformer {
+public final class ValueTransformer implements org.mases.jcobridge.IJCListener, org.apache.kafka.streams.kstream.ValueTransformer {
+ final org.mases.jcobridge.JCListener _internalListener;
+
public ValueTransformer(String key) throws org.mases.jcobridge.JCNativeException {
- super(key);
+ super();
+ _internalListener = new org.mases.jcobridge.JCListener(key);
+ }
+
+ public synchronized void release() {
+ _internalListener.release();
+ }
+
+ public synchronized void raiseEvent(String eventName) {
+ _internalListener.raiseEvent(eventName);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e) {
+ _internalListener.raiseEvent(eventName, e);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e, Object... objects) {
+ _internalListener.raiseEvent(eventName, e, objects);
+ }
+
+ public Object getEventData() {
+ return _internalListener.getEventData();
+ }
+
+ public boolean hasExtraData() {
+ return _internalListener.hasExtraData();
+ }
+
+ public int extraDataLength() {
+ return _internalListener.extraDataLength();
+ }
+
+ public Object[] extraData() {
+ return _internalListener.extraData();
+ }
+
+ public Object getReturnData() {
+ return _internalListener.getReturnData();
+ }
+
+ public void setReturnData(Object retData) {
+ _internalListener.setReturnData(retData);
}
//@Override
public void close() {
- raiseEvent("close");
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("close", eventDataExchange); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM");
}
//@Override
public void init(org.apache.kafka.streams.processor.ProcessorContext arg0) {
- raiseEvent("init", arg0);
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("init", eventDataExchange, arg0); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM");
}
//@Override
public java.lang.Object transform(java.lang.Object arg0) {
- raiseEvent("transform", arg0); Object retVal = getReturnData(); return (java.lang.Object)retVal;
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("transform", eventDataExchange, arg0); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM"); Object retVal = eventDataExchange.getReturnData(); return (java.lang.Object)retVal;
}
}
\ No newline at end of file
diff --git a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/ValueTransformerWithKey.java b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/ValueTransformerWithKey.java
index 83dde3e14..14166287c 100644
--- a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/ValueTransformerWithKey.java
+++ b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/kstream/ValueTransformerWithKey.java
@@ -1,43 +1,89 @@
/*
- * Copyright 2024 MASES s.r.l.
- *
- * Licensed 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.
- *
- * Refer to LICENSE for more information.
- */
+* Copyright 2024 MASES s.r.l.
+*
+* Licensed 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.
+*
+* Refer to LICENSE for more information.
+*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
*/
package org.mases.knet.generated.org.apache.kafka.streams.kstream;
-public final class ValueTransformerWithKey extends org.mases.jcobridge.JCListener implements org.apache.kafka.streams.kstream.ValueTransformerWithKey {
+public final class ValueTransformerWithKey implements org.mases.jcobridge.IJCListener, org.apache.kafka.streams.kstream.ValueTransformerWithKey {
+ final org.mases.jcobridge.JCListener _internalListener;
+
public ValueTransformerWithKey(String key) throws org.mases.jcobridge.JCNativeException {
- super(key);
+ super();
+ _internalListener = new org.mases.jcobridge.JCListener(key);
+ }
+
+ public synchronized void release() {
+ _internalListener.release();
+ }
+
+ public synchronized void raiseEvent(String eventName) {
+ _internalListener.raiseEvent(eventName);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e) {
+ _internalListener.raiseEvent(eventName, e);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e, Object... objects) {
+ _internalListener.raiseEvent(eventName, e, objects);
+ }
+
+ public Object getEventData() {
+ return _internalListener.getEventData();
+ }
+
+ public boolean hasExtraData() {
+ return _internalListener.hasExtraData();
+ }
+
+ public int extraDataLength() {
+ return _internalListener.extraDataLength();
+ }
+
+ public Object[] extraData() {
+ return _internalListener.extraData();
+ }
+
+ public Object getReturnData() {
+ return _internalListener.getReturnData();
+ }
+
+ public void setReturnData(Object retData) {
+ _internalListener.setReturnData(retData);
}
//@Override
public void close() {
- raiseEvent("close");
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("close", eventDataExchange); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM");
}
//@Override
public void init(org.apache.kafka.streams.processor.ProcessorContext arg0) {
- raiseEvent("init", arg0);
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("init", eventDataExchange, arg0); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM");
}
//@Override
public java.lang.Object transform(java.lang.Object arg0, java.lang.Object arg1) {
- raiseEvent("transform", arg0, arg1); Object retVal = getReturnData(); return (java.lang.Object)retVal;
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("transform", eventDataExchange, arg0, arg1); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM"); Object retVal = eventDataExchange.getReturnData(); return (java.lang.Object)retVal;
}
}
\ No newline at end of file
diff --git a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/processor/BatchingStateRestoreCallback.java b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/processor/BatchingStateRestoreCallback.java
index 5a64625f6..d1d0b4303 100644
--- a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/processor/BatchingStateRestoreCallback.java
+++ b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/processor/BatchingStateRestoreCallback.java
@@ -1,39 +1,84 @@
/*
- * Copyright 2024 MASES s.r.l.
- *
- * Licensed 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.
- *
- * Refer to LICENSE for more information.
- */
+* Copyright 2024 MASES s.r.l.
+*
+* Licensed 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.
+*
+* Refer to LICENSE for more information.
+*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
*/
package org.mases.knet.generated.org.apache.kafka.streams.processor;
-public final class BatchingStateRestoreCallback extends org.mases.jcobridge.JCListener implements org.apache.kafka.streams.processor.BatchingStateRestoreCallback {
+public final class BatchingStateRestoreCallback implements org.mases.jcobridge.IJCListener, org.apache.kafka.streams.processor.BatchingStateRestoreCallback {
+ final org.mases.jcobridge.JCListener _internalListener;
+
public BatchingStateRestoreCallback(String key) throws org.mases.jcobridge.JCNativeException {
- super(key);
+ super();
+ _internalListener = new org.mases.jcobridge.JCListener(key);
+ }
+
+ public synchronized void release() {
+ _internalListener.release();
+ }
+
+ public synchronized void raiseEvent(String eventName) {
+ _internalListener.raiseEvent(eventName);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e) {
+ _internalListener.raiseEvent(eventName, e);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e, Object... objects) {
+ _internalListener.raiseEvent(eventName, e, objects);
+ }
+
+ public Object getEventData() {
+ return _internalListener.getEventData();
+ }
+
+ public boolean hasExtraData() {
+ return _internalListener.hasExtraData();
+ }
+
+ public int extraDataLength() {
+ return _internalListener.extraDataLength();
+ }
+
+ public Object[] extraData() {
+ return _internalListener.extraData();
+ }
+
+ public Object getReturnData() {
+ return _internalListener.getReturnData();
+ }
+
+ public void setReturnData(Object retData) {
+ _internalListener.setReturnData(retData);
}
//@Override
public void restoreAll(java.util.Collection arg0) {
- raiseEvent("restoreAll", arg0);
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("restoreAll", eventDataExchange, arg0); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM");
}
//@Override
public void restore(byte[] arg0, byte[] arg1) {
- raiseEvent("restore", arg0, arg1);
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("restore", eventDataExchange, arg0, arg1); if (!eventDataExchange.getHasOverride()) org.apache.kafka.streams.processor.BatchingStateRestoreCallback.super.restore(arg0, arg1);
}
//@Override
public void restoreDefault(byte[] arg0, byte[] arg1) {
diff --git a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/processor/Punctuator.java b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/processor/Punctuator.java
index 36bc5c1d0..5cbe0416a 100644
--- a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/processor/Punctuator.java
+++ b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/processor/Punctuator.java
@@ -1,35 +1,79 @@
/*
- * Copyright 2024 MASES s.r.l.
- *
- * Licensed 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.
- *
- * Refer to LICENSE for more information.
- */
+* Copyright 2024 MASES s.r.l.
+*
+* Licensed 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.
+*
+* Refer to LICENSE for more information.
+*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
*/
package org.mases.knet.generated.org.apache.kafka.streams.processor;
-public final class Punctuator extends org.mases.jcobridge.JCListener implements org.apache.kafka.streams.processor.Punctuator {
+public final class Punctuator implements org.mases.jcobridge.IJCListener, org.apache.kafka.streams.processor.Punctuator {
+ final org.mases.jcobridge.JCListener _internalListener;
+
public Punctuator(String key) throws org.mases.jcobridge.JCNativeException {
- super(key);
+ super();
+ _internalListener = new org.mases.jcobridge.JCListener(key);
+ }
+
+ public synchronized void release() {
+ _internalListener.release();
+ }
+
+ public synchronized void raiseEvent(String eventName) {
+ _internalListener.raiseEvent(eventName);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e) {
+ _internalListener.raiseEvent(eventName, e);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e, Object... objects) {
+ _internalListener.raiseEvent(eventName, e, objects);
+ }
+
+ public Object getEventData() {
+ return _internalListener.getEventData();
+ }
+
+ public boolean hasExtraData() {
+ return _internalListener.hasExtraData();
+ }
+
+ public int extraDataLength() {
+ return _internalListener.extraDataLength();
+ }
+
+ public Object[] extraData() {
+ return _internalListener.extraData();
+ }
+
+ public Object getReturnData() {
+ return _internalListener.getReturnData();
+ }
+
+ public void setReturnData(Object retData) {
+ _internalListener.setReturnData(retData);
}
//@Override
public void punctuate(long arg0) {
- raiseEvent("punctuate", arg0);
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("punctuate", eventDataExchange, arg0); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM");
}
}
\ No newline at end of file
diff --git a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/processor/StateRestoreCallback.java b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/processor/StateRestoreCallback.java
index 608375887..b9fe462c9 100644
--- a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/processor/StateRestoreCallback.java
+++ b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/processor/StateRestoreCallback.java
@@ -1,35 +1,79 @@
/*
- * Copyright 2024 MASES s.r.l.
- *
- * Licensed 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.
- *
- * Refer to LICENSE for more information.
- */
+* Copyright 2024 MASES s.r.l.
+*
+* Licensed 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.
+*
+* Refer to LICENSE for more information.
+*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
*/
package org.mases.knet.generated.org.apache.kafka.streams.processor;
-public final class StateRestoreCallback extends org.mases.jcobridge.JCListener implements org.apache.kafka.streams.processor.StateRestoreCallback {
+public final class StateRestoreCallback implements org.mases.jcobridge.IJCListener, org.apache.kafka.streams.processor.StateRestoreCallback {
+ final org.mases.jcobridge.JCListener _internalListener;
+
public StateRestoreCallback(String key) throws org.mases.jcobridge.JCNativeException {
- super(key);
+ super();
+ _internalListener = new org.mases.jcobridge.JCListener(key);
+ }
+
+ public synchronized void release() {
+ _internalListener.release();
+ }
+
+ public synchronized void raiseEvent(String eventName) {
+ _internalListener.raiseEvent(eventName);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e) {
+ _internalListener.raiseEvent(eventName, e);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e, Object... objects) {
+ _internalListener.raiseEvent(eventName, e, objects);
+ }
+
+ public Object getEventData() {
+ return _internalListener.getEventData();
+ }
+
+ public boolean hasExtraData() {
+ return _internalListener.hasExtraData();
+ }
+
+ public int extraDataLength() {
+ return _internalListener.extraDataLength();
+ }
+
+ public Object[] extraData() {
+ return _internalListener.extraData();
+ }
+
+ public Object getReturnData() {
+ return _internalListener.getReturnData();
+ }
+
+ public void setReturnData(Object retData) {
+ _internalListener.setReturnData(retData);
}
//@Override
public void restore(byte[] arg0, byte[] arg1) {
- raiseEvent("restore", arg0, arg1);
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("restore", eventDataExchange, arg0, arg1); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM");
}
}
\ No newline at end of file
diff --git a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/processor/StateRestoreListener.java b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/processor/StateRestoreListener.java
index e37fc5f4a..57d69a912 100644
--- a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/processor/StateRestoreListener.java
+++ b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/processor/StateRestoreListener.java
@@ -1,47 +1,94 @@
/*
- * Copyright 2024 MASES s.r.l.
- *
- * Licensed 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.
- *
- * Refer to LICENSE for more information.
- */
+* Copyright 2024 MASES s.r.l.
+*
+* Licensed 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.
+*
+* Refer to LICENSE for more information.
+*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
*/
package org.mases.knet.generated.org.apache.kafka.streams.processor;
-public final class StateRestoreListener extends org.mases.jcobridge.JCListener implements org.apache.kafka.streams.processor.StateRestoreListener {
+public final class StateRestoreListener implements org.mases.jcobridge.IJCListener, org.apache.kafka.streams.processor.StateRestoreListener {
+ final org.mases.jcobridge.JCListener _internalListener;
+
public StateRestoreListener(String key) throws org.mases.jcobridge.JCNativeException {
- super(key);
+ super();
+ _internalListener = new org.mases.jcobridge.JCListener(key);
+ }
+
+ public synchronized void release() {
+ _internalListener.release();
+ }
+
+ public synchronized void raiseEvent(String eventName) {
+ _internalListener.raiseEvent(eventName);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e) {
+ _internalListener.raiseEvent(eventName, e);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e, Object... objects) {
+ _internalListener.raiseEvent(eventName, e, objects);
+ }
+
+ public Object getEventData() {
+ return _internalListener.getEventData();
+ }
+
+ public boolean hasExtraData() {
+ return _internalListener.hasExtraData();
+ }
+
+ public int extraDataLength() {
+ return _internalListener.extraDataLength();
+ }
+
+ public Object[] extraData() {
+ return _internalListener.extraData();
+ }
+
+ public Object getReturnData() {
+ return _internalListener.getReturnData();
+ }
+
+ public void setReturnData(Object retData) {
+ _internalListener.setReturnData(retData);
}
//@Override
public void onBatchRestored(org.apache.kafka.common.TopicPartition arg0, java.lang.String arg1, long arg2, long arg3) {
- raiseEvent("onBatchRestored", arg0, arg1, arg2, arg3);
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("onBatchRestored", eventDataExchange, arg0, arg1, arg2, arg3); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM");
}
//@Override
public void onRestoreEnd(org.apache.kafka.common.TopicPartition arg0, java.lang.String arg1, long arg2) {
- raiseEvent("onRestoreEnd", arg0, arg1, arg2);
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("onRestoreEnd", eventDataExchange, arg0, arg1, arg2); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM");
}
//@Override
public void onRestoreStart(org.apache.kafka.common.TopicPartition arg0, java.lang.String arg1, long arg2, long arg3) {
- raiseEvent("onRestoreStart", arg0, arg1, arg2, arg3);
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("onRestoreStart", eventDataExchange, arg0, arg1, arg2, arg3); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM");
}
//@Override
public void onRestoreSuspended(org.apache.kafka.common.TopicPartition arg0, java.lang.String arg1, long arg2) {
- raiseEvent("onRestoreSuspended", arg0, arg1, arg2);
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("onRestoreSuspended", eventDataExchange, arg0, arg1, arg2); if (!eventDataExchange.getHasOverride()) org.apache.kafka.streams.processor.StateRestoreListener.super.onRestoreSuspended(arg0, arg1, arg2);
}
//@Override
public void onRestoreSuspendedDefault(org.apache.kafka.common.TopicPartition arg0, java.lang.String arg1, long arg2) {
diff --git a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/processor/StreamPartitioner.java b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/processor/StreamPartitioner.java
index ee2299413..99be7a1f8 100644
--- a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/processor/StreamPartitioner.java
+++ b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/processor/StreamPartitioner.java
@@ -1,39 +1,84 @@
/*
- * Copyright 2024 MASES s.r.l.
- *
- * Licensed 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.
- *
- * Refer to LICENSE for more information.
- */
+* Copyright 2024 MASES s.r.l.
+*
+* Licensed 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.
+*
+* Refer to LICENSE for more information.
+*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
*/
package org.mases.knet.generated.org.apache.kafka.streams.processor;
-public final class StreamPartitioner extends org.mases.jcobridge.JCListener implements org.apache.kafka.streams.processor.StreamPartitioner {
+public final class StreamPartitioner implements org.mases.jcobridge.IJCListener, org.apache.kafka.streams.processor.StreamPartitioner {
+ final org.mases.jcobridge.JCListener _internalListener;
+
public StreamPartitioner(String key) throws org.mases.jcobridge.JCNativeException {
- super(key);
+ super();
+ _internalListener = new org.mases.jcobridge.JCListener(key);
+ }
+
+ public synchronized void release() {
+ _internalListener.release();
+ }
+
+ public synchronized void raiseEvent(String eventName) {
+ _internalListener.raiseEvent(eventName);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e) {
+ _internalListener.raiseEvent(eventName, e);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e, Object... objects) {
+ _internalListener.raiseEvent(eventName, e, objects);
+ }
+
+ public Object getEventData() {
+ return _internalListener.getEventData();
+ }
+
+ public boolean hasExtraData() {
+ return _internalListener.hasExtraData();
+ }
+
+ public int extraDataLength() {
+ return _internalListener.extraDataLength();
+ }
+
+ public Object[] extraData() {
+ return _internalListener.extraData();
+ }
+
+ public Object getReturnData() {
+ return _internalListener.getReturnData();
+ }
+
+ public void setReturnData(Object retData) {
+ _internalListener.setReturnData(retData);
}
//@Override
public java.lang.Integer partition(java.lang.String arg0, java.lang.Object arg1, java.lang.Object arg2, int arg3) {
- raiseEvent("partition", arg0, arg1, arg2, arg3); Object retVal = getReturnData(); return (java.lang.Integer)retVal;
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("partition", eventDataExchange, arg0, arg1, arg2, arg3); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM"); Object retVal = eventDataExchange.getReturnData(); return (java.lang.Integer)retVal;
}
//@Override
public java.util.Optional partitions(java.lang.String arg0, java.lang.Object arg1, java.lang.Object arg2, int arg3) {
- raiseEvent("partitions", arg0, arg1, arg2, arg3); Object retVal = getReturnData(); return (java.util.Optional)retVal;
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("partitions", eventDataExchange, arg0, arg1, arg2, arg3); Object retVal; if (!eventDataExchange.getHasOverride()) retVal = org.apache.kafka.streams.processor.StreamPartitioner.super.partitions(arg0, arg1, arg2, arg3); else retVal = eventDataExchange.getReturnData(); return (java.util.Optional)retVal;
}
//@Override
public java.util.Optional partitionsDefault(java.lang.String arg0, java.lang.Object arg1, java.lang.Object arg2, int arg3) {
diff --git a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/processor/TimestampExtractor.java b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/processor/TimestampExtractor.java
index 5f1b1eac3..636acd150 100644
--- a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/processor/TimestampExtractor.java
+++ b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/processor/TimestampExtractor.java
@@ -1,35 +1,79 @@
/*
- * Copyright 2024 MASES s.r.l.
- *
- * Licensed 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.
- *
- * Refer to LICENSE for more information.
- */
+* Copyright 2024 MASES s.r.l.
+*
+* Licensed 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.
+*
+* Refer to LICENSE for more information.
+*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
*/
package org.mases.knet.generated.org.apache.kafka.streams.processor;
-public final class TimestampExtractor extends org.mases.jcobridge.JCListener implements org.apache.kafka.streams.processor.TimestampExtractor {
+public final class TimestampExtractor implements org.mases.jcobridge.IJCListener, org.apache.kafka.streams.processor.TimestampExtractor {
+ final org.mases.jcobridge.JCListener _internalListener;
+
public TimestampExtractor(String key) throws org.mases.jcobridge.JCNativeException {
- super(key);
+ super();
+ _internalListener = new org.mases.jcobridge.JCListener(key);
+ }
+
+ public synchronized void release() {
+ _internalListener.release();
+ }
+
+ public synchronized void raiseEvent(String eventName) {
+ _internalListener.raiseEvent(eventName);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e) {
+ _internalListener.raiseEvent(eventName, e);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e, Object... objects) {
+ _internalListener.raiseEvent(eventName, e, objects);
+ }
+
+ public Object getEventData() {
+ return _internalListener.getEventData();
+ }
+
+ public boolean hasExtraData() {
+ return _internalListener.hasExtraData();
+ }
+
+ public int extraDataLength() {
+ return _internalListener.extraDataLength();
+ }
+
+ public Object[] extraData() {
+ return _internalListener.extraData();
+ }
+
+ public Object getReturnData() {
+ return _internalListener.getReturnData();
+ }
+
+ public void setReturnData(Object retData) {
+ _internalListener.setReturnData(retData);
}
//@Override
public long extract(org.apache.kafka.clients.consumer.ConsumerRecord arg0, long arg1) {
- raiseEvent("extract", arg0, arg1); Object retVal = getReturnData(); return (long)retVal;
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("extract", eventDataExchange, arg0, arg1); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM"); Object retVal = eventDataExchange.getReturnData(); return (long)retVal;
}
}
\ No newline at end of file
diff --git a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/processor/TopicNameExtractor.java b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/processor/TopicNameExtractor.java
index b1a0e6e29..83cd78b65 100644
--- a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/processor/TopicNameExtractor.java
+++ b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/processor/TopicNameExtractor.java
@@ -1,35 +1,79 @@
/*
- * Copyright 2024 MASES s.r.l.
- *
- * Licensed 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.
- *
- * Refer to LICENSE for more information.
- */
+* Copyright 2024 MASES s.r.l.
+*
+* Licensed 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.
+*
+* Refer to LICENSE for more information.
+*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
*/
package org.mases.knet.generated.org.apache.kafka.streams.processor;
-public final class TopicNameExtractor extends org.mases.jcobridge.JCListener implements org.apache.kafka.streams.processor.TopicNameExtractor {
+public final class TopicNameExtractor implements org.mases.jcobridge.IJCListener, org.apache.kafka.streams.processor.TopicNameExtractor {
+ final org.mases.jcobridge.JCListener _internalListener;
+
public TopicNameExtractor(String key) throws org.mases.jcobridge.JCNativeException {
- super(key);
+ super();
+ _internalListener = new org.mases.jcobridge.JCListener(key);
+ }
+
+ public synchronized void release() {
+ _internalListener.release();
+ }
+
+ public synchronized void raiseEvent(String eventName) {
+ _internalListener.raiseEvent(eventName);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e) {
+ _internalListener.raiseEvent(eventName, e);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e, Object... objects) {
+ _internalListener.raiseEvent(eventName, e, objects);
+ }
+
+ public Object getEventData() {
+ return _internalListener.getEventData();
+ }
+
+ public boolean hasExtraData() {
+ return _internalListener.hasExtraData();
+ }
+
+ public int extraDataLength() {
+ return _internalListener.extraDataLength();
+ }
+
+ public Object[] extraData() {
+ return _internalListener.extraData();
+ }
+
+ public Object getReturnData() {
+ return _internalListener.getReturnData();
+ }
+
+ public void setReturnData(Object retData) {
+ _internalListener.setReturnData(retData);
}
//@Override
public java.lang.String extract(java.lang.Object arg0, java.lang.Object arg1, org.apache.kafka.streams.processor.RecordContext arg2) {
- raiseEvent("extract", arg0, arg1, arg2); Object retVal = getReturnData(); return (java.lang.String)retVal;
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("extract", eventDataExchange, arg0, arg1, arg2); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM"); Object retVal = eventDataExchange.getReturnData(); return (java.lang.String)retVal;
}
}
\ No newline at end of file
diff --git a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/processor/api/FixedKeyProcessor.java b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/processor/api/FixedKeyProcessor.java
index 99bfafe9a..dd6a1574a 100644
--- a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/processor/api/FixedKeyProcessor.java
+++ b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/processor/api/FixedKeyProcessor.java
@@ -1,39 +1,84 @@
/*
- * Copyright 2024 MASES s.r.l.
- *
- * Licensed 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.
- *
- * Refer to LICENSE for more information.
- */
+* Copyright 2024 MASES s.r.l.
+*
+* Licensed 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.
+*
+* Refer to LICENSE for more information.
+*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
*/
package org.mases.knet.generated.org.apache.kafka.streams.processor.api;
-public final class FixedKeyProcessor extends org.mases.jcobridge.JCListener implements org.apache.kafka.streams.processor.api.FixedKeyProcessor {
+public final class FixedKeyProcessor implements org.mases.jcobridge.IJCListener, org.apache.kafka.streams.processor.api.FixedKeyProcessor {
+ final org.mases.jcobridge.JCListener _internalListener;
+
public FixedKeyProcessor(String key) throws org.mases.jcobridge.JCNativeException {
- super(key);
+ super();
+ _internalListener = new org.mases.jcobridge.JCListener(key);
+ }
+
+ public synchronized void release() {
+ _internalListener.release();
+ }
+
+ public synchronized void raiseEvent(String eventName) {
+ _internalListener.raiseEvent(eventName);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e) {
+ _internalListener.raiseEvent(eventName, e);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e, Object... objects) {
+ _internalListener.raiseEvent(eventName, e, objects);
+ }
+
+ public Object getEventData() {
+ return _internalListener.getEventData();
+ }
+
+ public boolean hasExtraData() {
+ return _internalListener.hasExtraData();
+ }
+
+ public int extraDataLength() {
+ return _internalListener.extraDataLength();
+ }
+
+ public Object[] extraData() {
+ return _internalListener.extraData();
+ }
+
+ public Object getReturnData() {
+ return _internalListener.getReturnData();
+ }
+
+ public void setReturnData(Object retData) {
+ _internalListener.setReturnData(retData);
}
//@Override
public void process(org.apache.kafka.streams.processor.api.FixedKeyRecord arg0) {
- raiseEvent("process", arg0);
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("process", eventDataExchange, arg0); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM");
}
//@Override
public void close() {
- raiseEvent("close");
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("close", eventDataExchange); if (!eventDataExchange.getHasOverride()) org.apache.kafka.streams.processor.api.FixedKeyProcessor.super.close();
}
//@Override
public void closeDefault() {
@@ -41,7 +86,8 @@ public void closeDefault() {
}
//@Override
public void init(org.apache.kafka.streams.processor.api.FixedKeyProcessorContext arg0) {
- raiseEvent("init", arg0);
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("init", eventDataExchange, arg0); if (!eventDataExchange.getHasOverride()) org.apache.kafka.streams.processor.api.FixedKeyProcessor.super.init(arg0);
}
//@Override
public void initDefault(org.apache.kafka.streams.processor.api.FixedKeyProcessorContext arg0) {
diff --git a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/processor/api/Processor.java b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/processor/api/Processor.java
index f732a8d8d..646a87d78 100644
--- a/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/processor/api/Processor.java
+++ b/src/jvm/knet/src/main/java/org/mases/knet/generated/org/apache/kafka/streams/processor/api/Processor.java
@@ -1,39 +1,84 @@
/*
- * Copyright 2024 MASES s.r.l.
- *
- * Licensed 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.
- *
- * Refer to LICENSE for more information.
- */
+* Copyright 2024 MASES s.r.l.
+*
+* Licensed 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.
+*
+* Refer to LICENSE for more information.
+*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
*/
package org.mases.knet.generated.org.apache.kafka.streams.processor.api;
-public final class Processor extends org.mases.jcobridge.JCListener implements org.apache.kafka.streams.processor.api.Processor {
+public final class Processor implements org.mases.jcobridge.IJCListener, org.apache.kafka.streams.processor.api.Processor {
+ final org.mases.jcobridge.JCListener _internalListener;
+
public Processor(String key) throws org.mases.jcobridge.JCNativeException {
- super(key);
+ super();
+ _internalListener = new org.mases.jcobridge.JCListener(key);
+ }
+
+ public synchronized void release() {
+ _internalListener.release();
+ }
+
+ public synchronized void raiseEvent(String eventName) {
+ _internalListener.raiseEvent(eventName);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e) {
+ _internalListener.raiseEvent(eventName, e);
+ }
+
+ public synchronized void raiseEvent(String eventName, Object e, Object... objects) {
+ _internalListener.raiseEvent(eventName, e, objects);
+ }
+
+ public Object getEventData() {
+ return _internalListener.getEventData();
+ }
+
+ public boolean hasExtraData() {
+ return _internalListener.hasExtraData();
+ }
+
+ public int extraDataLength() {
+ return _internalListener.extraDataLength();
+ }
+
+ public Object[] extraData() {
+ return _internalListener.extraData();
+ }
+
+ public Object getReturnData() {
+ return _internalListener.getReturnData();
+ }
+
+ public void setReturnData(Object retData) {
+ _internalListener.setReturnData(retData);
}
//@Override
public void process(org.apache.kafka.streams.processor.api.Record arg0) {
- raiseEvent("process", arg0);
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("process", eventDataExchange, arg0); if (!eventDataExchange.getHasOverride()) throw new UnsupportedOperationException("The method shall be implemented in .NET side since does not have a default implementation within the JVM");
}
//@Override
public void close() {
- raiseEvent("close");
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("close", eventDataExchange); if (!eventDataExchange.getHasOverride()) org.apache.kafka.streams.processor.api.Processor.super.close();
}
//@Override
public void closeDefault() {
@@ -41,7 +86,8 @@ public void closeDefault() {
}
//@Override
public void init(org.apache.kafka.streams.processor.api.ProcessorContext arg0) {
- raiseEvent("init", arg0);
+ org.mases.jnet.developed.JNetEventResult eventDataExchange = new org.mases.jnet.developed.JNetEventResult();
+ raiseEvent("init", eventDataExchange, arg0); if (!eventDataExchange.getHasOverride()) org.apache.kafka.streams.processor.api.Processor.super.init(arg0);
}
//@Override
public void initDefault(org.apache.kafka.streams.processor.api.ProcessorContext arg0) {
diff --git a/src/net/KNet/Generated/Kafka/Admin/AclCommand.cs b/src/net/KNet/Generated/Kafka/Admin/AclCommand.cs
index ee0ed148f..62b584fef 100644
--- a/src/net/KNet/Generated/Kafka/Admin/AclCommand.cs
+++ b/src/net/KNet/Generated/Kafka/Admin/AclCommand.cs
@@ -17,7 +17,7 @@
*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
* using kafka_2.13-3.6.2.jar as reference
*/
@@ -25,7 +25,234 @@
namespace Kafka.Admin
{
- #region AclCommand
+ #region AclCommand declaration
+ ///
+ ///
+ ///
+ public partial class AclCommand : MASES.JCOBridge.C2JBridge.JVMBridgeBase, MASES.JCOBridge.C2JBridge.IJVMBridgeMain
+ {
+ const string _bridgeClassName = "kafka.admin.AclCommand";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public AclCommand() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public AclCommand(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => false;
+
+ // TODO: complete the class
+ #region AclCommandOptions declaration
+ ///
+ ///
+ ///
+ public partial class AclCommandOptions : MASES.JCOBridge.C2JBridge.JVMBridgeBase
+ {
+ const string _bridgeClassName = "kafka.admin.AclCommand$AclCommandOptions";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public AclCommandOptions() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public AclCommandOptions(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => true;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+ #region AclCommandService declaration
+ ///
+ ///
+ ///
+ public partial class AclCommandService : MASES.JCOBridge.C2JBridge.JVMBridgeBase
+ {
+ const string _bridgeClassName = "kafka.admin.AclCommand$AclCommandService";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ [global::System.Obsolete("AclCommandService class represents, in .NET, an instance of a JVM interface or abstract class. This public initializer is needed for JCOBridge internal use, other uses can produce unidentible behaviors.")]
+ public AclCommandService() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ [global::System.Obsolete("AclCommandService class represents, in .NET, an instance of a JVM interface or abstract class. This public initializer is needed for JCOBridge internal use, other uses can produce unidentible behaviors.")]
+ public AclCommandService(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => true;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => true;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => true;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+ #region AdminClientService declaration
+ ///
+ ///
+ ///
+ public partial class AdminClientService : MASES.JCOBridge.C2JBridge.JVMBridgeBase
+ {
+ const string _bridgeClassName = "kafka.admin.AclCommand$AdminClientService";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public AdminClientService() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public AdminClientService(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => true;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+ #region AuthorizerService declaration
+ ///
+ ///
+ ///
+ public partial class AuthorizerService : MASES.JCOBridge.C2JBridge.JVMBridgeBase
+ {
+ const string _bridgeClassName = "kafka.admin.AclCommand$AuthorizerService";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public AuthorizerService() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public AuthorizerService(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => true;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+
+ }
+ #endregion
+
+ #region AclCommand implementation
public partial class AclCommand
{
#region Constructors
@@ -89,7 +316,7 @@ public static void Main(Java.Lang.String[] args)
#endregion
#region Nested classes
- #region AclCommandOptions
+ #region AclCommandOptions implementation
public partial class AclCommandOptions
{
#region Constructors
@@ -143,7 +370,7 @@ public void CheckArgs()
}
#endregion
- #region AclCommandService
+ #region AclCommandService implementation
public partial class AclCommandService
{
#region Constructors
@@ -195,7 +422,7 @@ public void RemoveAcls()
}
#endregion
- #region AdminClientService
+ #region AdminClientService implementation
public partial class AdminClientService
{
#region Constructors
@@ -304,7 +531,7 @@ public void RemoveAcls()
}
#endregion
- #region AuthorizerService
+ #region AuthorizerService implementation
public partial class AuthorizerService
{
#region Constructors
diff --git a/src/net/KNet/Generated/Kafka/Admin/AllPackageClasses.cs b/src/net/KNet/Generated/Kafka/Admin/AllPackageClasses.cs
deleted file mode 100644
index c856d40b4..000000000
--- a/src/net/KNet/Generated/Kafka/Admin/AllPackageClasses.cs
+++ /dev/null
@@ -1,2083 +0,0 @@
-/*
-* Copyright 2024 MASES s.r.l.
-*
-* Licensed 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.
-*
-* Refer to LICENSE for more information.
-*/
-
-/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
-* using kafka_2.13-3.6.2.jar as reference
-*/
-
-using MASES.JCOBridge.C2JBridge.JVMInterop;
-using System;
-
-namespace Kafka.Admin
-{
- #region AclCommand
- ///
- ///
- ///
- public partial class AclCommand : MASES.JCOBridge.C2JBridge.JVMBridgeBase, MASES.JCOBridge.C2JBridge.IJVMBridgeMain
- {
- const string _bridgeClassName = "kafka.admin.AclCommand";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public AclCommand() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public AclCommand(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
- #region AclCommandOptions
- ///
- ///
- ///
- public partial class AclCommandOptions : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "kafka.admin.AclCommand$AclCommandOptions";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public AclCommandOptions() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public AclCommandOptions(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => true;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region AclCommandService
- ///
- ///
- ///
- public partial class AclCommandService : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "kafka.admin.AclCommand$AclCommandService";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- [global::System.Obsolete("AclCommandService class represents, in .NET, an instance of a JVM interface or abstract class. This public initializer is needed for JCOBridge internal use, other uses can produce unidentible behaviors.")]
- public AclCommandService() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- [global::System.Obsolete("AclCommandService class represents, in .NET, an instance of a JVM interface or abstract class. This public initializer is needed for JCOBridge internal use, other uses can produce unidentible behaviors.")]
- public AclCommandService(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => true;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => true;
- ///
- ///
- ///
- public override bool IsBridgeStatic => true;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region AdminClientService
- ///
- ///
- ///
- public partial class AdminClientService : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "kafka.admin.AclCommand$AdminClientService";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public AdminClientService() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public AdminClientService(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => true;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region AuthorizerService
- ///
- ///
- ///
- public partial class AuthorizerService : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "kafka.admin.AclCommand$AuthorizerService";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public AuthorizerService() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public AuthorizerService(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => true;
-
- // TODO: complete the class
-
- }
- #endregion
-
-
- }
- #endregion
-
- #region BrokerApiVersionsCommand
- ///
- ///
- ///
- public partial class BrokerApiVersionsCommand : MASES.JCOBridge.C2JBridge.JVMBridgeBase, MASES.JCOBridge.C2JBridge.IJVMBridgeMain
- {
- const string _bridgeClassName = "kafka.admin.BrokerApiVersionsCommand";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public BrokerApiVersionsCommand() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public BrokerApiVersionsCommand(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
- #region BrokerVersionCommandOptions
- ///
- ///
- ///
- public partial class BrokerVersionCommandOptions : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "kafka.admin.BrokerApiVersionsCommand$BrokerVersionCommandOptions";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public BrokerVersionCommandOptions() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public BrokerVersionCommandOptions(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => true;
-
- // TODO: complete the class
-
- }
- #endregion
-
-
- }
- #endregion
-
- #region ConfigCommand
- ///
- ///
- ///
- public partial class ConfigCommand : MASES.JCOBridge.C2JBridge.JVMBridgeBase, MASES.JCOBridge.C2JBridge.IJVMBridgeMain
- {
- const string _bridgeClassName = "kafka.admin.ConfigCommand";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public ConfigCommand() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public ConfigCommand(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
- #region ConfigCommandOptions
- ///
- ///
- ///
- public partial class ConfigCommandOptions : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "kafka.admin.ConfigCommand$ConfigCommandOptions";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public ConfigCommandOptions() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public ConfigCommandOptions(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => true;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region ConfigEntity
- ///
- ///
- ///
- public partial class ConfigEntity : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "kafka.admin.ConfigCommand$ConfigEntity";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public ConfigEntity() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public ConfigEntity(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => true;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region Entity
- ///
- ///
- ///
- public partial class Entity : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "kafka.admin.ConfigCommand$Entity";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public Entity() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public Entity(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => true;
-
- // TODO: complete the class
-
- }
- #endregion
-
-
- }
- #endregion
-
- #region ConsumerGroupCommand
- ///
- ///
- ///
- public partial class ConsumerGroupCommand : MASES.JCOBridge.C2JBridge.JVMBridgeBase, MASES.JCOBridge.C2JBridge.IJVMBridgeMain
- {
- const string _bridgeClassName = "kafka.admin.ConsumerGroupCommand";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public ConsumerGroupCommand() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public ConsumerGroupCommand(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
- #region ConsumerGroupCommandOptions
- ///
- ///
- ///
- public partial class ConsumerGroupCommandOptions : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "kafka.admin.ConsumerGroupCommand$ConsumerGroupCommandOptions";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public ConsumerGroupCommandOptions() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public ConsumerGroupCommandOptions(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => true;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region ConsumerGroupService
- ///
- ///
- ///
- public partial class ConsumerGroupService : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "kafka.admin.ConsumerGroupCommand$ConsumerGroupService";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public ConsumerGroupService() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public ConsumerGroupService(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => true;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region CsvRecord
- ///
- ///
- ///
- public partial class CsvRecord : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "kafka.admin.ConsumerGroupCommand$CsvRecord";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- [global::System.Obsolete("CsvRecord class represents, in .NET, an instance of a JVM interface or abstract class. This public initializer is needed for JCOBridge internal use, other uses can produce unidentible behaviors.")]
- public CsvRecord() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- [global::System.Obsolete("CsvRecord class represents, in .NET, an instance of a JVM interface or abstract class. This public initializer is needed for JCOBridge internal use, other uses can produce unidentible behaviors.")]
- public CsvRecord(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => true;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => true;
- ///
- ///
- ///
- public override bool IsBridgeStatic => true;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region CsvRecordNoGroup
- ///
- ///
- ///
- public partial class CsvRecordNoGroup : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "kafka.admin.ConsumerGroupCommand$CsvRecordNoGroup";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public CsvRecordNoGroup() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public CsvRecordNoGroup(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => true;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region CsvRecordWithGroup
- ///
- ///
- ///
- public partial class CsvRecordWithGroup : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "kafka.admin.ConsumerGroupCommand$CsvRecordWithGroup";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public CsvRecordWithGroup() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public CsvRecordWithGroup(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => true;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region CsvUtils
- ///
- ///
- ///
- public partial class CsvUtils : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "kafka.admin.ConsumerGroupCommand$CsvUtils";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public CsvUtils() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public CsvUtils(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => true;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region GroupState
- ///
- ///
- ///
- public partial class GroupState : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "kafka.admin.ConsumerGroupCommand$GroupState";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public GroupState() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public GroupState(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => true;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region LogOffsetResult
- ///
- ///
- ///
- public partial class LogOffsetResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "kafka.admin.ConsumerGroupCommand$LogOffsetResult";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- [global::System.Obsolete("LogOffsetResult class represents, in .NET, an instance of a JVM interface or abstract class. This public initializer is needed for JCOBridge internal use, other uses can produce unidentible behaviors.")]
- public LogOffsetResult() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- [global::System.Obsolete("LogOffsetResult class represents, in .NET, an instance of a JVM interface or abstract class. This public initializer is needed for JCOBridge internal use, other uses can produce unidentible behaviors.")]
- public LogOffsetResult(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => true;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => true;
- ///
- ///
- ///
- public override bool IsBridgeStatic => true;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region MemberAssignmentState
- ///
- ///
- ///
- public partial class MemberAssignmentState : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "kafka.admin.ConsumerGroupCommand$MemberAssignmentState";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public MemberAssignmentState() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public MemberAssignmentState(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => true;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region PartitionAssignmentState
- ///
- ///
- ///
- public partial class PartitionAssignmentState : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "kafka.admin.ConsumerGroupCommand$PartitionAssignmentState";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public PartitionAssignmentState() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public PartitionAssignmentState(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => true;
-
- // TODO: complete the class
-
- }
- #endregion
-
-
- }
- #endregion
-
- #region FeatureCommand
- ///
- ///
- ///
- public partial class FeatureCommand : MASES.JCOBridge.C2JBridge.JVMBridgeBase, MASES.JCOBridge.C2JBridge.IJVMBridgeMain
- {
- const string _bridgeClassName = "kafka.admin.FeatureCommand";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public FeatureCommand() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public FeatureCommand(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region LeaderElectionCommand
- ///
- ///
- ///
- public partial class LeaderElectionCommand : MASES.JCOBridge.C2JBridge.JVMBridgeBase, MASES.JCOBridge.C2JBridge.IJVMBridgeMain
- {
- const string _bridgeClassName = "kafka.admin.LeaderElectionCommand";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public LeaderElectionCommand() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public LeaderElectionCommand(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region LeaderElectionCommandOptions
- ///
- ///
- ///
- public partial class LeaderElectionCommandOptions : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "kafka.admin.LeaderElectionCommandOptions";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public LeaderElectionCommandOptions() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public LeaderElectionCommandOptions(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region RackAwareMode
- ///
- ///
- ///
- public partial class RackAwareMode : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "kafka.admin.RackAwareMode";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- [global::System.Obsolete("RackAwareMode class represents, in .NET, an instance of a JVM interface or abstract class. This public initializer is needed for JCOBridge internal use, other uses can produce unidentible behaviors.")]
- public RackAwareMode() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- [global::System.Obsolete("RackAwareMode class represents, in .NET, an instance of a JVM interface or abstract class. This public initializer is needed for JCOBridge internal use, other uses can produce unidentible behaviors.")]
- public RackAwareMode(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => true;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => true;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region ReassignPartitionsCommand
- ///
- ///
- ///
- public partial class ReassignPartitionsCommand : MASES.JCOBridge.C2JBridge.JVMBridgeBase, MASES.JCOBridge.C2JBridge.IJVMBridgeMain
- {
- const string _bridgeClassName = "kafka.admin.ReassignPartitionsCommand";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public ReassignPartitionsCommand() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public ReassignPartitionsCommand(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
- #region ActiveMoveState
- ///
- ///
- ///
- public partial class ActiveMoveState : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "kafka.admin.ReassignPartitionsCommand$ActiveMoveState";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public ActiveMoveState() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public ActiveMoveState(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => true;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region CancelledMoveState
- ///
- ///
- ///
- public partial class CancelledMoveState : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "kafka.admin.ReassignPartitionsCommand$CancelledMoveState";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public CancelledMoveState() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public CancelledMoveState(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => true;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region CompletedMoveState
- ///
- ///
- ///
- public partial class CompletedMoveState : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "kafka.admin.ReassignPartitionsCommand$CompletedMoveState";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public CompletedMoveState() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public CompletedMoveState(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => true;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region LogDirMoveState
- ///
- ///
- ///
- public partial class LogDirMoveState : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "kafka.admin.ReassignPartitionsCommand$LogDirMoveState";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- [global::System.Obsolete("LogDirMoveState class represents, in .NET, an instance of a JVM interface or abstract class. This public initializer is needed for JCOBridge internal use, other uses can produce unidentible behaviors.")]
- public LogDirMoveState() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- [global::System.Obsolete("LogDirMoveState class represents, in .NET, an instance of a JVM interface or abstract class. This public initializer is needed for JCOBridge internal use, other uses can produce unidentible behaviors.")]
- public LogDirMoveState(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => true;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => true;
- ///
- ///
- ///
- public override bool IsBridgeStatic => true;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region MissingLogDirMoveState
- ///
- ///
- ///
- public partial class MissingLogDirMoveState : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "kafka.admin.ReassignPartitionsCommand$MissingLogDirMoveState";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public MissingLogDirMoveState() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public MissingLogDirMoveState(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => true;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region MissingReplicaMoveState
- ///
- ///
- ///
- public partial class MissingReplicaMoveState : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "kafka.admin.ReassignPartitionsCommand$MissingReplicaMoveState";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public MissingReplicaMoveState() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public MissingReplicaMoveState(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => true;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region PartitionMove
- ///
- ///
- ///
- public partial class PartitionMove : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "kafka.admin.ReassignPartitionsCommand$PartitionMove";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public PartitionMove() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public PartitionMove(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => true;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region PartitionReassignmentState
- ///
- ///
- ///
- public partial class PartitionReassignmentState : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "kafka.admin.ReassignPartitionsCommand$PartitionReassignmentState";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public PartitionReassignmentState() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public PartitionReassignmentState(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => true;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region ReassignPartitionsCommandOptions
- ///
- ///
- ///
- public partial class ReassignPartitionsCommandOptions : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "kafka.admin.ReassignPartitionsCommand$ReassignPartitionsCommandOptions";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public ReassignPartitionsCommandOptions() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public ReassignPartitionsCommandOptions(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => true;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region TerseReassignmentFailureException
- ///
- ///
- ///
- public partial class TerseReassignmentFailureException : Org.Apache.Kafka.Common.KafkaException
- {
- const string _bridgeClassName = "kafka.admin.ReassignPartitionsCommand$TerseReassignmentFailureException";
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region VerifyAssignmentResult
- ///
- ///
- ///
- public partial class VerifyAssignmentResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "kafka.admin.ReassignPartitionsCommand$VerifyAssignmentResult";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public VerifyAssignmentResult() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public VerifyAssignmentResult(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => true;
-
- // TODO: complete the class
-
- }
- #endregion
-
-
- }
- #endregion
-
- #region TopicCommand
- ///
- ///
- ///
- public partial class TopicCommand : MASES.JCOBridge.C2JBridge.JVMBridgeBase, MASES.JCOBridge.C2JBridge.IJVMBridgeMain
- {
- const string _bridgeClassName = "kafka.admin.TopicCommand";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public TopicCommand() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public TopicCommand(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
- #region CommandTopicPartition
- ///
- ///
- ///
- public partial class CommandTopicPartition : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "kafka.admin.TopicCommand$CommandTopicPartition";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public CommandTopicPartition() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public CommandTopicPartition(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => true;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region DescribeOptions
- ///
- ///
- ///
- public partial class DescribeOptions : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "kafka.admin.TopicCommand$DescribeOptions";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public DescribeOptions() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public DescribeOptions(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => true;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region PartitionDescription
- ///
- ///
- ///
- public partial class PartitionDescription : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "kafka.admin.TopicCommand$PartitionDescription";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public PartitionDescription() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public PartitionDescription(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => true;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region TopicCommandOptions
- ///
- ///
- ///
- public partial class TopicCommandOptions : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "kafka.admin.TopicCommand$TopicCommandOptions";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public TopicCommandOptions() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public TopicCommandOptions(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => true;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region TopicDescription
- ///
- ///
- ///
- public partial class TopicDescription : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "kafka.admin.TopicCommand$TopicDescription";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public TopicDescription() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public TopicDescription(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => true;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region TopicService
- ///
- ///
- ///
- public partial class TopicService : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "kafka.admin.TopicCommand$TopicService";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public TopicService() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public TopicService(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => true;
-
- // TODO: complete the class
-
- }
- #endregion
-
-
- }
- #endregion
-
- #region ZkSecurityMigrator
- ///
- ///
- ///
- public partial class ZkSecurityMigrator : MASES.JCOBridge.C2JBridge.JVMBridgeBase, MASES.JCOBridge.C2JBridge.IJVMBridgeMain
- {
- const string _bridgeClassName = "kafka.admin.ZkSecurityMigrator";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public ZkSecurityMigrator() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public ZkSecurityMigrator(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
-
-
-}
\ No newline at end of file
diff --git a/src/net/KNet/Generated/Kafka/Admin/BrokerApiVersionsCommand.cs b/src/net/KNet/Generated/Kafka/Admin/BrokerApiVersionsCommand.cs
index 5c94050b6..4e2765935 100644
--- a/src/net/KNet/Generated/Kafka/Admin/BrokerApiVersionsCommand.cs
+++ b/src/net/KNet/Generated/Kafka/Admin/BrokerApiVersionsCommand.cs
@@ -17,7 +17,7 @@
*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
* using kafka_2.13-3.6.2.jar as reference
*/
@@ -25,7 +25,97 @@
namespace Kafka.Admin
{
- #region BrokerApiVersionsCommand
+ #region BrokerApiVersionsCommand declaration
+ ///
+ ///
+ ///
+ public partial class BrokerApiVersionsCommand : MASES.JCOBridge.C2JBridge.JVMBridgeBase, MASES.JCOBridge.C2JBridge.IJVMBridgeMain
+ {
+ const string _bridgeClassName = "kafka.admin.BrokerApiVersionsCommand";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public BrokerApiVersionsCommand() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public BrokerApiVersionsCommand(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => false;
+
+ // TODO: complete the class
+ #region BrokerVersionCommandOptions declaration
+ ///
+ ///
+ ///
+ public partial class BrokerVersionCommandOptions : MASES.JCOBridge.C2JBridge.JVMBridgeBase
+ {
+ const string _bridgeClassName = "kafka.admin.BrokerApiVersionsCommand$BrokerVersionCommandOptions";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public BrokerVersionCommandOptions() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public BrokerVersionCommandOptions(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => true;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+
+ }
+ #endregion
+
+ #region BrokerApiVersionsCommand implementation
public partial class BrokerApiVersionsCommand
{
#region Constructors
@@ -66,7 +156,7 @@ public static void Main(Java.Lang.String[] args)
#endregion
#region Nested classes
- #region BrokerVersionCommandOptions
+ #region BrokerVersionCommandOptions implementation
public partial class BrokerVersionCommandOptions
{
#region Constructors
diff --git a/src/net/KNet/Generated/Kafka/Admin/ConfigCommand.cs b/src/net/KNet/Generated/Kafka/Admin/ConfigCommand.cs
index 6dd918986..3c022c552 100644
--- a/src/net/KNet/Generated/Kafka/Admin/ConfigCommand.cs
+++ b/src/net/KNet/Generated/Kafka/Admin/ConfigCommand.cs
@@ -17,7 +17,7 @@
*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
* using kafka_2.13-3.6.2.jar as reference
*/
@@ -25,7 +25,187 @@
namespace Kafka.Admin
{
- #region ConfigCommand
+ #region ConfigCommand declaration
+ ///
+ ///
+ ///
+ public partial class ConfigCommand : MASES.JCOBridge.C2JBridge.JVMBridgeBase, MASES.JCOBridge.C2JBridge.IJVMBridgeMain
+ {
+ const string _bridgeClassName = "kafka.admin.ConfigCommand";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public ConfigCommand() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public ConfigCommand(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => false;
+
+ // TODO: complete the class
+ #region ConfigCommandOptions declaration
+ ///
+ ///
+ ///
+ public partial class ConfigCommandOptions : MASES.JCOBridge.C2JBridge.JVMBridgeBase
+ {
+ const string _bridgeClassName = "kafka.admin.ConfigCommand$ConfigCommandOptions";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public ConfigCommandOptions() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public ConfigCommandOptions(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => true;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+ #region ConfigEntity declaration
+ ///
+ ///
+ ///
+ public partial class ConfigEntity : MASES.JCOBridge.C2JBridge.JVMBridgeBase
+ {
+ const string _bridgeClassName = "kafka.admin.ConfigCommand$ConfigEntity";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public ConfigEntity() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public ConfigEntity(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => true;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+ #region Entity declaration
+ ///
+ ///
+ ///
+ public partial class Entity : MASES.JCOBridge.C2JBridge.JVMBridgeBase
+ {
+ const string _bridgeClassName = "kafka.admin.ConfigCommand$Entity";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public Entity() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public Entity(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => true;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+
+ }
+ #endregion
+
+ #region ConfigCommand implementation
public partial class ConfigCommand
{
#region Constructors
@@ -97,7 +277,7 @@ public static void Main(Java.Lang.String[] args)
#endregion
#region Nested classes
- #region ConfigCommandOptions
+ #region ConfigCommandOptions implementation
public partial class ConfigCommandOptions
{
#region Constructors
@@ -151,7 +331,7 @@ public void CheckArgs()
}
#endregion
- #region ConfigEntity
+ #region ConfigEntity implementation
public partial class ConfigEntity : Java.Io.ISerializable
{
#region Constructors
@@ -245,7 +425,7 @@ public Kafka.Admin.ConfigCommand.Entity Root()
}
#endregion
- #region Entity
+ #region Entity implementation
public partial class Entity : Java.Io.ISerializable
{
#region Constructors
diff --git a/src/net/KNet/Generated/Kafka/Admin/ConsumerGroupCommand.cs b/src/net/KNet/Generated/Kafka/Admin/ConsumerGroupCommand.cs
index 5a6c1c354..47816f528 100644
--- a/src/net/KNet/Generated/Kafka/Admin/ConsumerGroupCommand.cs
+++ b/src/net/KNet/Generated/Kafka/Admin/ConsumerGroupCommand.cs
@@ -17,7 +17,7 @@
*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
* using kafka_2.13-3.6.2.jar as reference
*/
@@ -25,7 +25,506 @@
namespace Kafka.Admin
{
- #region ConsumerGroupCommand
+ #region ConsumerGroupCommand declaration
+ ///
+ ///
+ ///
+ public partial class ConsumerGroupCommand : MASES.JCOBridge.C2JBridge.JVMBridgeBase, MASES.JCOBridge.C2JBridge.IJVMBridgeMain
+ {
+ const string _bridgeClassName = "kafka.admin.ConsumerGroupCommand";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public ConsumerGroupCommand() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public ConsumerGroupCommand(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => false;
+
+ // TODO: complete the class
+ #region ConsumerGroupCommandOptions declaration
+ ///
+ ///
+ ///
+ public partial class ConsumerGroupCommandOptions : MASES.JCOBridge.C2JBridge.JVMBridgeBase
+ {
+ const string _bridgeClassName = "kafka.admin.ConsumerGroupCommand$ConsumerGroupCommandOptions";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public ConsumerGroupCommandOptions() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public ConsumerGroupCommandOptions(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => true;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+ #region ConsumerGroupService declaration
+ ///
+ ///
+ ///
+ public partial class ConsumerGroupService : MASES.JCOBridge.C2JBridge.JVMBridgeBase
+ {
+ const string _bridgeClassName = "kafka.admin.ConsumerGroupCommand$ConsumerGroupService";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public ConsumerGroupService() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public ConsumerGroupService(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => true;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+ #region CsvRecord declaration
+ ///
+ ///
+ ///
+ public partial class CsvRecord : MASES.JCOBridge.C2JBridge.JVMBridgeBase
+ {
+ const string _bridgeClassName = "kafka.admin.ConsumerGroupCommand$CsvRecord";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ [global::System.Obsolete("CsvRecord class represents, in .NET, an instance of a JVM interface or abstract class. This public initializer is needed for JCOBridge internal use, other uses can produce unidentible behaviors.")]
+ public CsvRecord() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ [global::System.Obsolete("CsvRecord class represents, in .NET, an instance of a JVM interface or abstract class. This public initializer is needed for JCOBridge internal use, other uses can produce unidentible behaviors.")]
+ public CsvRecord(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => true;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => true;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => true;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+ #region CsvRecordNoGroup declaration
+ ///
+ ///
+ ///
+ public partial class CsvRecordNoGroup : MASES.JCOBridge.C2JBridge.JVMBridgeBase
+ {
+ const string _bridgeClassName = "kafka.admin.ConsumerGroupCommand$CsvRecordNoGroup";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public CsvRecordNoGroup() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public CsvRecordNoGroup(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => true;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+ #region CsvRecordWithGroup declaration
+ ///
+ ///
+ ///
+ public partial class CsvRecordWithGroup : MASES.JCOBridge.C2JBridge.JVMBridgeBase
+ {
+ const string _bridgeClassName = "kafka.admin.ConsumerGroupCommand$CsvRecordWithGroup";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public CsvRecordWithGroup() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public CsvRecordWithGroup(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => true;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+ #region CsvUtils declaration
+ ///
+ ///
+ ///
+ public partial class CsvUtils : MASES.JCOBridge.C2JBridge.JVMBridgeBase
+ {
+ const string _bridgeClassName = "kafka.admin.ConsumerGroupCommand$CsvUtils";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public CsvUtils() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public CsvUtils(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => true;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+ #region GroupState declaration
+ ///
+ ///
+ ///
+ public partial class GroupState : MASES.JCOBridge.C2JBridge.JVMBridgeBase
+ {
+ const string _bridgeClassName = "kafka.admin.ConsumerGroupCommand$GroupState";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public GroupState() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public GroupState(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => true;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+ #region LogOffsetResult declaration
+ ///
+ ///
+ ///
+ public partial class LogOffsetResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase
+ {
+ const string _bridgeClassName = "kafka.admin.ConsumerGroupCommand$LogOffsetResult";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ [global::System.Obsolete("LogOffsetResult class represents, in .NET, an instance of a JVM interface or abstract class. This public initializer is needed for JCOBridge internal use, other uses can produce unidentible behaviors.")]
+ public LogOffsetResult() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ [global::System.Obsolete("LogOffsetResult class represents, in .NET, an instance of a JVM interface or abstract class. This public initializer is needed for JCOBridge internal use, other uses can produce unidentible behaviors.")]
+ public LogOffsetResult(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => true;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => true;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => true;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+ #region MemberAssignmentState declaration
+ ///
+ ///
+ ///
+ public partial class MemberAssignmentState : MASES.JCOBridge.C2JBridge.JVMBridgeBase
+ {
+ const string _bridgeClassName = "kafka.admin.ConsumerGroupCommand$MemberAssignmentState";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public MemberAssignmentState() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public MemberAssignmentState(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => true;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+ #region PartitionAssignmentState declaration
+ ///
+ ///
+ ///
+ public partial class PartitionAssignmentState : MASES.JCOBridge.C2JBridge.JVMBridgeBase
+ {
+ const string _bridgeClassName = "kafka.admin.ConsumerGroupCommand$PartitionAssignmentState";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public PartitionAssignmentState() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public PartitionAssignmentState(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => true;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+
+ }
+ #endregion
+
+ #region ConsumerGroupCommand implementation
public partial class ConsumerGroupCommand
{
#region Constructors
@@ -89,7 +588,7 @@ public static void Run(Kafka.Admin.ConsumerGroupCommand.ConsumerGroupCommandOpti
#endregion
#region Nested classes
- #region ConsumerGroupCommandOptions
+ #region ConsumerGroupCommandOptions implementation
public partial class ConsumerGroupCommandOptions
{
#region Constructors
@@ -359,7 +858,7 @@ public void CheckArgs()
}
#endregion
- #region ConsumerGroupService
+ #region ConsumerGroupService implementation
public partial class ConsumerGroupService
{
#region Constructors
@@ -435,7 +934,7 @@ public void ListGroups()
}
#endregion
- #region CsvRecord
+ #region CsvRecord implementation
public partial class CsvRecord
{
#region Constructors
@@ -466,7 +965,7 @@ public partial class CsvRecord
}
#endregion
- #region CsvRecordNoGroup
+ #region CsvRecordNoGroup implementation
public partial class CsvRecordNoGroup : Java.Io.ISerializable
{
#region Constructors
@@ -589,7 +1088,7 @@ public long Offset()
}
#endregion
- #region CsvRecordWithGroup
+ #region CsvRecordWithGroup implementation
public partial class CsvRecordWithGroup : Java.Io.ISerializable
{
#region Constructors
@@ -722,7 +1221,7 @@ public long Offset()
}
#endregion
- #region CsvUtils
+ #region CsvUtils implementation
public partial class CsvUtils : Java.Io.ISerializable
{
#region Constructors
@@ -808,7 +1307,7 @@ public Kafka.Admin.ConsumerGroupCommand.CsvUtils Copy()
}
#endregion
- #region GroupState
+ #region GroupState implementation
public partial class GroupState : Java.Io.ISerializable
{
#region Constructors
@@ -951,7 +1450,7 @@ public Org.Apache.Kafka.Common.Node Coordinator()
}
#endregion
- #region LogOffsetResult
+ #region LogOffsetResult implementation
public partial class LogOffsetResult
{
#region Constructors
@@ -982,7 +1481,7 @@ public partial class LogOffsetResult
}
#endregion
- #region MemberAssignmentState
+ #region MemberAssignmentState implementation
public partial class MemberAssignmentState : Java.Io.ISerializable
{
#region Constructors
@@ -1108,7 +1607,7 @@ public Java.Lang.String ProductPrefix()
}
#endregion
- #region PartitionAssignmentState
+ #region PartitionAssignmentState implementation
public partial class PartitionAssignmentState : Java.Io.ISerializable
{
#region Constructors
diff --git a/src/net/KNet/Generated/Kafka/Admin/FeatureCommand.cs b/src/net/KNet/Generated/Kafka/Admin/FeatureCommand.cs
index cc951ee8b..c09923177 100644
--- a/src/net/KNet/Generated/Kafka/Admin/FeatureCommand.cs
+++ b/src/net/KNet/Generated/Kafka/Admin/FeatureCommand.cs
@@ -17,7 +17,7 @@
*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
* using kafka_2.13-3.6.2.jar as reference
*/
@@ -25,7 +25,52 @@
namespace Kafka.Admin
{
- #region FeatureCommand
+ #region FeatureCommand declaration
+ ///
+ ///
+ ///
+ public partial class FeatureCommand : MASES.JCOBridge.C2JBridge.JVMBridgeBase, MASES.JCOBridge.C2JBridge.IJVMBridgeMain
+ {
+ const string _bridgeClassName = "kafka.admin.FeatureCommand";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public FeatureCommand() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public FeatureCommand(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => false;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+ #region FeatureCommand implementation
public partial class FeatureCommand
{
#region Constructors
diff --git a/src/net/KNet/Generated/Kafka/Admin/LeaderElectionCommand.cs b/src/net/KNet/Generated/Kafka/Admin/LeaderElectionCommand.cs
index 3a6327238..06d14e275 100644
--- a/src/net/KNet/Generated/Kafka/Admin/LeaderElectionCommand.cs
+++ b/src/net/KNet/Generated/Kafka/Admin/LeaderElectionCommand.cs
@@ -17,7 +17,7 @@
*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
* using kafka_2.13-3.6.2.jar as reference
*/
@@ -25,7 +25,52 @@
namespace Kafka.Admin
{
- #region LeaderElectionCommand
+ #region LeaderElectionCommand declaration
+ ///
+ ///
+ ///
+ public partial class LeaderElectionCommand : MASES.JCOBridge.C2JBridge.JVMBridgeBase, MASES.JCOBridge.C2JBridge.IJVMBridgeMain
+ {
+ const string _bridgeClassName = "kafka.admin.LeaderElectionCommand";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public LeaderElectionCommand() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public LeaderElectionCommand(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => false;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+ #region LeaderElectionCommand implementation
public partial class LeaderElectionCommand
{
#region Constructors
diff --git a/src/net/KNet/Generated/Kafka/Admin/LeaderElectionCommandOptions.cs b/src/net/KNet/Generated/Kafka/Admin/LeaderElectionCommandOptions.cs
index 36dd51925..4caf2ef1a 100644
--- a/src/net/KNet/Generated/Kafka/Admin/LeaderElectionCommandOptions.cs
+++ b/src/net/KNet/Generated/Kafka/Admin/LeaderElectionCommandOptions.cs
@@ -17,7 +17,7 @@
*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
* using kafka_2.13-3.6.2.jar as reference
*/
@@ -25,7 +25,52 @@
namespace Kafka.Admin
{
- #region LeaderElectionCommandOptions
+ #region LeaderElectionCommandOptions declaration
+ ///
+ ///
+ ///
+ public partial class LeaderElectionCommandOptions : MASES.JCOBridge.C2JBridge.JVMBridgeBase
+ {
+ const string _bridgeClassName = "kafka.admin.LeaderElectionCommandOptions";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public LeaderElectionCommandOptions() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public LeaderElectionCommandOptions(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => false;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+ #region LeaderElectionCommandOptions implementation
public partial class LeaderElectionCommandOptions
{
#region Constructors
diff --git a/src/net/KNet/Generated/Kafka/Admin/RackAwareMode.cs b/src/net/KNet/Generated/Kafka/Admin/RackAwareMode.cs
index df8e78c2a..9d4c9ce7f 100644
--- a/src/net/KNet/Generated/Kafka/Admin/RackAwareMode.cs
+++ b/src/net/KNet/Generated/Kafka/Admin/RackAwareMode.cs
@@ -17,7 +17,7 @@
*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
* using kafka_2.13-3.6.2.jar as reference
*/
@@ -25,6 +25,53 @@
namespace Kafka.Admin
{
+ #region RackAwareMode declaration
+ ///
+ ///
+ ///
+ public partial class RackAwareMode : MASES.JCOBridge.C2JBridge.JVMBridgeBase
+ {
+ const string _bridgeClassName = "kafka.admin.RackAwareMode";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ [global::System.Obsolete("RackAwareMode class represents, in .NET, an instance of a JVM interface or abstract class. This public initializer is needed for JCOBridge internal use, other uses can produce unidentible behaviors.")]
+ public RackAwareMode() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ [global::System.Obsolete("RackAwareMode class represents, in .NET, an instance of a JVM interface or abstract class. This public initializer is needed for JCOBridge internal use, other uses can produce unidentible behaviors.")]
+ public RackAwareMode(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => true;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => true;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => false;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
#region IRackAwareMode
///
/// .NET interface for TO BE DEFINED FROM USER
@@ -43,7 +90,7 @@ public partial interface IRackAwareMode
}
#endregion
- #region RackAwareMode
+ #region RackAwareMode implementation
public partial class RackAwareMode : Kafka.Admin.IRackAwareMode
{
#region Constructors
diff --git a/src/net/KNet/Generated/Kafka/Admin/ReassignPartitionsCommand.cs b/src/net/KNet/Generated/Kafka/Admin/ReassignPartitionsCommand.cs
index efcd74ce5..fbf24173e 100644
--- a/src/net/KNet/Generated/Kafka/Admin/ReassignPartitionsCommand.cs
+++ b/src/net/KNet/Generated/Kafka/Admin/ReassignPartitionsCommand.cs
@@ -17,7 +17,7 @@
*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
* using kafka_2.13-3.6.2.jar as reference
*/
@@ -25,7 +25,521 @@
namespace Kafka.Admin
{
- #region ReassignPartitionsCommand
+ #region ReassignPartitionsCommand declaration
+ ///
+ ///
+ ///
+ public partial class ReassignPartitionsCommand : MASES.JCOBridge.C2JBridge.JVMBridgeBase, MASES.JCOBridge.C2JBridge.IJVMBridgeMain
+ {
+ const string _bridgeClassName = "kafka.admin.ReassignPartitionsCommand";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public ReassignPartitionsCommand() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public ReassignPartitionsCommand(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => false;
+
+ // TODO: complete the class
+ #region ActiveMoveState declaration
+ ///
+ ///
+ ///
+ public partial class ActiveMoveState : MASES.JCOBridge.C2JBridge.JVMBridgeBase
+ {
+ const string _bridgeClassName = "kafka.admin.ReassignPartitionsCommand$ActiveMoveState";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public ActiveMoveState() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public ActiveMoveState(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => true;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+ #region CancelledMoveState declaration
+ ///
+ ///
+ ///
+ public partial class CancelledMoveState : MASES.JCOBridge.C2JBridge.JVMBridgeBase
+ {
+ const string _bridgeClassName = "kafka.admin.ReassignPartitionsCommand$CancelledMoveState";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public CancelledMoveState() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public CancelledMoveState(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => true;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+ #region CompletedMoveState declaration
+ ///
+ ///
+ ///
+ public partial class CompletedMoveState : MASES.JCOBridge.C2JBridge.JVMBridgeBase
+ {
+ const string _bridgeClassName = "kafka.admin.ReassignPartitionsCommand$CompletedMoveState";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public CompletedMoveState() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public CompletedMoveState(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => true;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+ #region LogDirMoveState declaration
+ ///
+ ///
+ ///
+ public partial class LogDirMoveState : MASES.JCOBridge.C2JBridge.JVMBridgeBase
+ {
+ const string _bridgeClassName = "kafka.admin.ReassignPartitionsCommand$LogDirMoveState";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ [global::System.Obsolete("LogDirMoveState class represents, in .NET, an instance of a JVM interface or abstract class. This public initializer is needed for JCOBridge internal use, other uses can produce unidentible behaviors.")]
+ public LogDirMoveState() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ [global::System.Obsolete("LogDirMoveState class represents, in .NET, an instance of a JVM interface or abstract class. This public initializer is needed for JCOBridge internal use, other uses can produce unidentible behaviors.")]
+ public LogDirMoveState(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => true;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => true;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => true;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+ #region MissingLogDirMoveState declaration
+ ///
+ ///
+ ///
+ public partial class MissingLogDirMoveState : MASES.JCOBridge.C2JBridge.JVMBridgeBase
+ {
+ const string _bridgeClassName = "kafka.admin.ReassignPartitionsCommand$MissingLogDirMoveState";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public MissingLogDirMoveState() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public MissingLogDirMoveState(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => true;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+ #region MissingReplicaMoveState declaration
+ ///
+ ///
+ ///
+ public partial class MissingReplicaMoveState : MASES.JCOBridge.C2JBridge.JVMBridgeBase
+ {
+ const string _bridgeClassName = "kafka.admin.ReassignPartitionsCommand$MissingReplicaMoveState";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public MissingReplicaMoveState() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public MissingReplicaMoveState(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => true;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+ #region PartitionMove declaration
+ ///
+ ///
+ ///
+ public partial class PartitionMove : MASES.JCOBridge.C2JBridge.JVMBridgeBase
+ {
+ const string _bridgeClassName = "kafka.admin.ReassignPartitionsCommand$PartitionMove";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public PartitionMove() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public PartitionMove(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => true;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+ #region PartitionReassignmentState declaration
+ ///
+ ///
+ ///
+ public partial class PartitionReassignmentState : MASES.JCOBridge.C2JBridge.JVMBridgeBase
+ {
+ const string _bridgeClassName = "kafka.admin.ReassignPartitionsCommand$PartitionReassignmentState";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public PartitionReassignmentState() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public PartitionReassignmentState(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => true;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+ #region ReassignPartitionsCommandOptions declaration
+ ///
+ ///
+ ///
+ public partial class ReassignPartitionsCommandOptions : MASES.JCOBridge.C2JBridge.JVMBridgeBase
+ {
+ const string _bridgeClassName = "kafka.admin.ReassignPartitionsCommand$ReassignPartitionsCommandOptions";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public ReassignPartitionsCommandOptions() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public ReassignPartitionsCommandOptions(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => true;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+ #region TerseReassignmentFailureException declaration
+ ///
+ ///
+ ///
+ public partial class TerseReassignmentFailureException : Org.Apache.Kafka.Common.KafkaException
+ {
+ const string _bridgeClassName = "kafka.admin.ReassignPartitionsCommand$TerseReassignmentFailureException";
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+ #region VerifyAssignmentResult declaration
+ ///
+ ///
+ ///
+ public partial class VerifyAssignmentResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase
+ {
+ const string _bridgeClassName = "kafka.admin.ReassignPartitionsCommand$VerifyAssignmentResult";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public VerifyAssignmentResult() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public VerifyAssignmentResult(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => true;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+
+ }
+ #endregion
+
+ #region ReassignPartitionsCommand implementation
public partial class ReassignPartitionsCommand
{
#region Constructors
@@ -152,7 +666,7 @@ public static void Main(Java.Lang.String[] args)
#endregion
#region Nested classes
- #region ActiveMoveState
+ #region ActiveMoveState implementation
public partial class ActiveMoveState : Java.Io.ISerializable
{
#region Constructors
@@ -283,7 +797,7 @@ public Kafka.Admin.ReassignPartitionsCommand.ActiveMoveState Copy(Java.Lang.Stri
}
#endregion
- #region CancelledMoveState
+ #region CancelledMoveState implementation
public partial class CancelledMoveState : Java.Io.ISerializable
{
#region Constructors
@@ -404,7 +918,7 @@ public Kafka.Admin.ReassignPartitionsCommand.CancelledMoveState Copy(Java.Lang.S
}
#endregion
- #region CompletedMoveState
+ #region CompletedMoveState implementation
public partial class CompletedMoveState : Java.Io.ISerializable
{
#region Constructors
@@ -515,7 +1029,7 @@ public Kafka.Admin.ReassignPartitionsCommand.CompletedMoveState Copy(Java.Lang.S
}
#endregion
- #region LogDirMoveState
+ #region LogDirMoveState implementation
public partial class LogDirMoveState
{
#region Constructors
@@ -554,7 +1068,7 @@ public bool Done()
}
#endregion
- #region MissingLogDirMoveState
+ #region MissingLogDirMoveState implementation
public partial class MissingLogDirMoveState : Java.Io.ISerializable
{
#region Constructors
@@ -665,7 +1179,7 @@ public Kafka.Admin.ReassignPartitionsCommand.MissingLogDirMoveState Copy(Java.La
}
#endregion
- #region MissingReplicaMoveState
+ #region MissingReplicaMoveState implementation
public partial class MissingReplicaMoveState : Java.Io.ISerializable
{
#region Constructors
@@ -776,7 +1290,7 @@ public Kafka.Admin.ReassignPartitionsCommand.MissingReplicaMoveState Copy(Java.L
}
#endregion
- #region PartitionMove
+ #region PartitionMove implementation
public partial class PartitionMove : Java.Io.ISerializable
{
#region Constructors
@@ -854,7 +1368,7 @@ public Java.Lang.String ProductPrefix()
}
#endregion
- #region PartitionReassignmentState
+ #region PartitionReassignmentState implementation
public partial class PartitionReassignmentState : Java.Io.ISerializable
{
#region Constructors
@@ -940,7 +1454,7 @@ public Java.Lang.String ProductPrefix()
}
#endregion
- #region ReassignPartitionsCommandOptions
+ #region ReassignPartitionsCommandOptions implementation
public partial class ReassignPartitionsCommandOptions
{
#region Constructors
@@ -979,7 +1493,7 @@ public ReassignPartitionsCommandOptions(Java.Lang.String[] args)
}
#endregion
- #region TerseReassignmentFailureException
+ #region TerseReassignmentFailureException implementation
public partial class TerseReassignmentFailureException
{
#region Constructors
@@ -1010,7 +1524,7 @@ public partial class TerseReassignmentFailureException
}
#endregion
- #region VerifyAssignmentResult
+ #region VerifyAssignmentResult implementation
public partial class VerifyAssignmentResult : Java.Io.ISerializable
{
#region Constructors
diff --git a/src/net/KNet/Generated/Kafka/Admin/TopicCommand.cs b/src/net/KNet/Generated/Kafka/Admin/TopicCommand.cs
index 3274e4663..b429199ac 100644
--- a/src/net/KNet/Generated/Kafka/Admin/TopicCommand.cs
+++ b/src/net/KNet/Generated/Kafka/Admin/TopicCommand.cs
@@ -17,7 +17,7 @@
*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
* using kafka_2.13-3.6.2.jar as reference
*/
@@ -25,7 +25,322 @@
namespace Kafka.Admin
{
- #region TopicCommand
+ #region TopicCommand declaration
+ ///
+ ///
+ ///
+ public partial class TopicCommand : MASES.JCOBridge.C2JBridge.JVMBridgeBase, MASES.JCOBridge.C2JBridge.IJVMBridgeMain
+ {
+ const string _bridgeClassName = "kafka.admin.TopicCommand";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public TopicCommand() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public TopicCommand(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => false;
+
+ // TODO: complete the class
+ #region CommandTopicPartition declaration
+ ///
+ ///
+ ///
+ public partial class CommandTopicPartition : MASES.JCOBridge.C2JBridge.JVMBridgeBase
+ {
+ const string _bridgeClassName = "kafka.admin.TopicCommand$CommandTopicPartition";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public CommandTopicPartition() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public CommandTopicPartition(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => true;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+ #region DescribeOptions declaration
+ ///
+ ///
+ ///
+ public partial class DescribeOptions : MASES.JCOBridge.C2JBridge.JVMBridgeBase
+ {
+ const string _bridgeClassName = "kafka.admin.TopicCommand$DescribeOptions";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public DescribeOptions() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public DescribeOptions(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => true;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+ #region PartitionDescription declaration
+ ///
+ ///
+ ///
+ public partial class PartitionDescription : MASES.JCOBridge.C2JBridge.JVMBridgeBase
+ {
+ const string _bridgeClassName = "kafka.admin.TopicCommand$PartitionDescription";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public PartitionDescription() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public PartitionDescription(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => true;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+ #region TopicCommandOptions declaration
+ ///
+ ///
+ ///
+ public partial class TopicCommandOptions : MASES.JCOBridge.C2JBridge.JVMBridgeBase
+ {
+ const string _bridgeClassName = "kafka.admin.TopicCommand$TopicCommandOptions";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public TopicCommandOptions() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public TopicCommandOptions(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => true;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+ #region TopicDescription declaration
+ ///
+ ///
+ ///
+ public partial class TopicDescription : MASES.JCOBridge.C2JBridge.JVMBridgeBase
+ {
+ const string _bridgeClassName = "kafka.admin.TopicCommand$TopicDescription";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public TopicDescription() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public TopicDescription(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => true;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+ #region TopicService declaration
+ ///
+ ///
+ ///
+ public partial class TopicService : MASES.JCOBridge.C2JBridge.JVMBridgeBase
+ {
+ const string _bridgeClassName = "kafka.admin.TopicCommand$TopicService";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public TopicService() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public TopicService(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => true;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+
+ }
+ #endregion
+
+ #region TopicCommand implementation
public partial class TopicCommand
{
#region Constructors
@@ -82,7 +397,7 @@ public static void Main(Java.Lang.String[] args)
#endregion
#region Nested classes
- #region CommandTopicPartition
+ #region CommandTopicPartition implementation
public partial class CommandTopicPartition
{
#region Constructors
@@ -153,7 +468,7 @@ public Java.Util.Properties ConfigsToAdd()
}
#endregion
- #region DescribeOptions
+ #region DescribeOptions implementation
public partial class DescribeOptions
{
#region Constructors
@@ -208,7 +523,7 @@ public void MaybePrintPartitionDescription(Kafka.Admin.TopicCommand.PartitionDes
}
#endregion
- #region PartitionDescription
+ #region PartitionDescription implementation
public partial class PartitionDescription : Java.Io.ISerializable
{
#region Constructors
@@ -341,7 +656,7 @@ public void PrintDescription()
}
#endregion
- #region TopicCommandOptions
+ #region TopicCommandOptions implementation
public partial class TopicCommandOptions
{
#region Constructors
@@ -499,7 +814,7 @@ public void CheckArgs()
}
#endregion
- #region TopicDescription
+ #region TopicDescription implementation
public partial class TopicDescription : Java.Io.ISerializable
{
#region Constructors
@@ -659,7 +974,7 @@ public void PrintDescription()
}
#endregion
- #region TopicService
+ #region TopicService implementation
public partial class TopicService : Java.Lang.IAutoCloseable, Java.Io.ISerializable
{
#region Constructors
diff --git a/src/net/KNet/Generated/Kafka/Admin/ZkSecurityMigrator.cs b/src/net/KNet/Generated/Kafka/Admin/ZkSecurityMigrator.cs
index abe5d25db..558f25865 100644
--- a/src/net/KNet/Generated/Kafka/Admin/ZkSecurityMigrator.cs
+++ b/src/net/KNet/Generated/Kafka/Admin/ZkSecurityMigrator.cs
@@ -17,7 +17,7 @@
*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
* using kafka_2.13-3.6.2.jar as reference
*/
@@ -25,7 +25,52 @@
namespace Kafka.Admin
{
- #region ZkSecurityMigrator
+ #region ZkSecurityMigrator declaration
+ ///
+ ///
+ ///
+ public partial class ZkSecurityMigrator : MASES.JCOBridge.C2JBridge.JVMBridgeBase, MASES.JCOBridge.C2JBridge.IJVMBridgeMain
+ {
+ const string _bridgeClassName = "kafka.admin.ZkSecurityMigrator";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public ZkSecurityMigrator() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public ZkSecurityMigrator(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => false;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+ #region ZkSecurityMigrator implementation
public partial class ZkSecurityMigrator
{
#region Constructors
diff --git a/src/net/KNet/Generated/Kafka/AllPackageClasses.cs b/src/net/KNet/Generated/Kafka/AllPackageClasses.cs
deleted file mode 100644
index 89ef81eeb..000000000
--- a/src/net/KNet/Generated/Kafka/AllPackageClasses.cs
+++ /dev/null
@@ -1,31 +0,0 @@
-/*
-* Copyright 2024 MASES s.r.l.
-*
-* Licensed 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.
-*
-* Refer to LICENSE for more information.
-*/
-
-/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
-* using kafka_2.13-3.6.2.jar as reference
-*/
-
-using MASES.JCOBridge.C2JBridge.JVMInterop;
-using System;
-
-namespace Kafka
-{
-
-
-}
\ No newline at end of file
diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AbortTransactionOptions.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AbortTransactionOptions.cs
index 9715f707d..16f42af2c 100644
--- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AbortTransactionOptions.cs
+++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AbortTransactionOptions.cs
@@ -17,7 +17,7 @@
*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
* using kafka-clients-3.6.2.jar as reference
*/
@@ -25,7 +25,52 @@
namespace Org.Apache.Kafka.Clients.Admin
{
- #region AbortTransactionOptions
+ #region AbortTransactionOptions declaration
+ ///
+ ///
+ ///
+ public partial class AbortTransactionOptions : Org.Apache.Kafka.Clients.Admin.AbstractOptions
+ {
+ const string _bridgeClassName = "org.apache.kafka.clients.admin.AbortTransactionOptions";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public AbortTransactionOptions() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public AbortTransactionOptions(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => false;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+ #region AbortTransactionOptions implementation
public partial class AbortTransactionOptions
{
#region Constructors
diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AbortTransactionResult.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AbortTransactionResult.cs
index 7c125ecb6..0d7e91beb 100644
--- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AbortTransactionResult.cs
+++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AbortTransactionResult.cs
@@ -17,7 +17,7 @@
*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
* using kafka-clients-3.6.2.jar as reference
*/
@@ -25,7 +25,52 @@
namespace Org.Apache.Kafka.Clients.Admin
{
- #region AbortTransactionResult
+ #region AbortTransactionResult declaration
+ ///
+ ///
+ ///
+ public partial class AbortTransactionResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase
+ {
+ const string _bridgeClassName = "org.apache.kafka.clients.admin.AbortTransactionResult";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public AbortTransactionResult() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public AbortTransactionResult(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => false;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+ #region AbortTransactionResult implementation
public partial class AbortTransactionResult
{
#region Constructors
diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AbortTransactionSpec.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AbortTransactionSpec.cs
index 39f313955..af10551a1 100644
--- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AbortTransactionSpec.cs
+++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AbortTransactionSpec.cs
@@ -17,7 +17,7 @@
*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
* using kafka-clients-3.6.2.jar as reference
*/
@@ -25,7 +25,52 @@
namespace Org.Apache.Kafka.Clients.Admin
{
- #region AbortTransactionSpec
+ #region AbortTransactionSpec declaration
+ ///
+ ///
+ ///
+ public partial class AbortTransactionSpec : MASES.JCOBridge.C2JBridge.JVMBridgeBase
+ {
+ const string _bridgeClassName = "org.apache.kafka.clients.admin.AbortTransactionSpec";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public AbortTransactionSpec() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public AbortTransactionSpec(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => false;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+ #region AbortTransactionSpec implementation
public partial class AbortTransactionSpec
{
#region Constructors
diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AbstractOptions.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AbstractOptions.cs
index 3560677d6..1e9e1e08a 100644
--- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AbstractOptions.cs
+++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AbstractOptions.cs
@@ -17,7 +17,7 @@
*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
* using kafka-clients-3.6.2.jar as reference
*/
@@ -25,7 +25,102 @@
namespace Org.Apache.Kafka.Clients.Admin
{
- #region AbstractOptions
+ #region AbstractOptions declaration
+ ///
+ ///
+ ///
+ public partial class AbstractOptions : MASES.JCOBridge.C2JBridge.JVMBridgeBase
+ {
+ const string _bridgeClassName = "org.apache.kafka.clients.admin.AbstractOptions";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ [global::System.Obsolete("AbstractOptions class represents, in .NET, an instance of a JVM interface or abstract class. This public initializer is needed for JCOBridge internal use, other uses can produce unidentible behaviors.")]
+ public AbstractOptions() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ [global::System.Obsolete("AbstractOptions class represents, in .NET, an instance of a JVM interface or abstract class. This public initializer is needed for JCOBridge internal use, other uses can produce unidentible behaviors.")]
+ public AbstractOptions(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => true;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => false;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+ #region AbstractOptions declaration
+ ///
+ ///
+ ///
+ ///
+ public partial class AbstractOptions : MASES.JCOBridge.C2JBridge.JVMBridgeBase> where T : Org.Apache.Kafka.Clients.Admin.AbstractOptions
+ {
+ const string _bridgeClassName = "org.apache.kafka.clients.admin.AbstractOptions";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ [global::System.Obsolete("AbstractOptions class represents, in .NET, an instance of a JVM interface or abstract class. This public initializer is needed for JCOBridge internal use, other uses can produce unidentible behaviors.")]
+ public AbstractOptions() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ [global::System.Obsolete("AbstractOptions class represents, in .NET, an instance of a JVM interface or abstract class. This public initializer is needed for JCOBridge internal use, other uses can produce unidentible behaviors.")]
+ public AbstractOptions(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => true;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => false;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+ #region AbstractOptions implementation
public partial class AbstractOptions
{
#region Constructors
@@ -73,7 +168,7 @@ public Org.Apache.Kafka.Clients.Admin.AbstractOptions TimeoutMs(Java.Lang.Intege
}
#endregion
- #region AbstractOptions
+ #region AbstractOptions implementation
public partial class AbstractOptions
{
#region Constructors
diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/Admin.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/Admin.cs
index 7710003cf..d78fb772c 100644
--- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/Admin.cs
+++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/Admin.cs
@@ -17,7 +17,7 @@
*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
* using kafka-clients-3.6.2.jar as reference
*/
@@ -25,6 +25,53 @@
namespace Org.Apache.Kafka.Clients.Admin
{
+ #region Admin declaration
+ ///
+ ///
+ ///
+ public partial class Admin : Java.Lang.AutoCloseable
+ {
+ const string _bridgeClassName = "org.apache.kafka.clients.admin.Admin";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ [global::System.Obsolete("Admin class represents, in .NET, an instance of a JVM interface or abstract class. This public initializer is needed for JCOBridge internal use, other uses can produce unidentible behaviors.")]
+ public Admin() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ [global::System.Obsolete("Admin class represents, in .NET, an instance of a JVM interface or abstract class. This public initializer is needed for JCOBridge internal use, other uses can produce unidentible behaviors.")]
+ public Admin(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => true;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => true;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => false;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
#region IAdmin
///
/// .NET interface for TO BE DEFINED FROM USER
@@ -43,7 +90,7 @@ public partial interface IAdmin : Java.Lang.IAutoCloseable
}
#endregion
- #region Admin
+ #region Admin implementation
public partial class Admin : Org.Apache.Kafka.Clients.Admin.IAdmin
{
#region Constructors
diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AdminClient.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AdminClient.cs
index 2b7cb47b8..5f591e173 100644
--- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AdminClient.cs
+++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AdminClient.cs
@@ -17,7 +17,7 @@
*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
* using kafka-clients-3.6.2.jar as reference
*/
@@ -25,7 +25,54 @@
namespace Org.Apache.Kafka.Clients.Admin
{
- #region AdminClient
+ #region AdminClient declaration
+ ///
+ ///
+ ///
+ public partial class AdminClient : Org.Apache.Kafka.Clients.Admin.Admin
+ {
+ const string _bridgeClassName = "org.apache.kafka.clients.admin.AdminClient";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ [global::System.Obsolete("AdminClient class represents, in .NET, an instance of a JVM interface or abstract class. This public initializer is needed for JCOBridge internal use, other uses can produce unidentible behaviors.")]
+ public AdminClient() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ [global::System.Obsolete("AdminClient class represents, in .NET, an instance of a JVM interface or abstract class. This public initializer is needed for JCOBridge internal use, other uses can produce unidentible behaviors.")]
+ public AdminClient(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => true;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => false;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+ #region AdminClient implementation
public partial class AdminClient
{
#region Constructors
diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AdminClientConfig.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AdminClientConfig.cs
index 219b91718..efa4b6be3 100644
--- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AdminClientConfig.cs
+++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AdminClientConfig.cs
@@ -17,7 +17,7 @@
*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
* using kafka-clients-3.6.2.jar as reference
*/
@@ -25,7 +25,52 @@
namespace Org.Apache.Kafka.Clients.Admin
{
- #region AdminClientConfig
+ #region AdminClientConfig declaration
+ ///
+ ///
+ ///
+ public partial class AdminClientConfig : Org.Apache.Kafka.Common.Config.AbstractConfig, MASES.JCOBridge.C2JBridge.IJVMBridgeMain
+ {
+ const string _bridgeClassName = "org.apache.kafka.clients.admin.AdminClientConfig";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public AdminClientConfig() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public AdminClientConfig(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => false;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+ #region AdminClientConfig implementation
public partial class AdminClientConfig
{
#region Constructors
diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AllPackageClasses.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AllPackageClasses.cs
deleted file mode 100644
index aeabbb6a9..000000000
--- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AllPackageClasses.cs
+++ /dev/null
@@ -1,6567 +0,0 @@
-/*
-* Copyright 2024 MASES s.r.l.
-*
-* Licensed 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.
-*
-* Refer to LICENSE for more information.
-*/
-
-/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
-* using kafka-clients-3.6.2.jar as reference
-*/
-
-using MASES.JCOBridge.C2JBridge.JVMInterop;
-using System;
-
-namespace Org.Apache.Kafka.Clients.Admin
-{
- #region AbortTransactionOptions
- ///
- ///
- ///
- public partial class AbortTransactionOptions : Org.Apache.Kafka.Clients.Admin.AbstractOptions
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.AbortTransactionOptions";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public AbortTransactionOptions() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public AbortTransactionOptions(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region AbortTransactionResult
- ///
- ///
- ///
- public partial class AbortTransactionResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.AbortTransactionResult";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public AbortTransactionResult() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public AbortTransactionResult(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region AbortTransactionSpec
- ///
- ///
- ///
- public partial class AbortTransactionSpec : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.AbortTransactionSpec";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public AbortTransactionSpec() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public AbortTransactionSpec(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region AbstractOptions
- ///
- ///
- ///
- public partial class AbstractOptions : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.AbstractOptions";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- [global::System.Obsolete("AbstractOptions class represents, in .NET, an instance of a JVM interface or abstract class. This public initializer is needed for JCOBridge internal use, other uses can produce unidentible behaviors.")]
- public AbstractOptions() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- [global::System.Obsolete("AbstractOptions class represents, in .NET, an instance of a JVM interface or abstract class. This public initializer is needed for JCOBridge internal use, other uses can produce unidentible behaviors.")]
- public AbstractOptions(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => true;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region AbstractOptions
- ///
- ///
- ///
- ///
- public partial class AbstractOptions : MASES.JCOBridge.C2JBridge.JVMBridgeBase> where T : Org.Apache.Kafka.Clients.Admin.AbstractOptions
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.AbstractOptions";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- [global::System.Obsolete("AbstractOptions class represents, in .NET, an instance of a JVM interface or abstract class. This public initializer is needed for JCOBridge internal use, other uses can produce unidentible behaviors.")]
- public AbstractOptions() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- [global::System.Obsolete("AbstractOptions class represents, in .NET, an instance of a JVM interface or abstract class. This public initializer is needed for JCOBridge internal use, other uses can produce unidentible behaviors.")]
- public AbstractOptions(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => true;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region Admin
- ///
- ///
- ///
- public partial class Admin : Java.Lang.AutoCloseable
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.Admin";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- [global::System.Obsolete("Admin class represents, in .NET, an instance of a JVM interface or abstract class. This public initializer is needed for JCOBridge internal use, other uses can produce unidentible behaviors.")]
- public Admin() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- [global::System.Obsolete("Admin class represents, in .NET, an instance of a JVM interface or abstract class. This public initializer is needed for JCOBridge internal use, other uses can produce unidentible behaviors.")]
- public Admin(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => true;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => true;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region AdminClient
- ///
- ///
- ///
- public partial class AdminClient : Org.Apache.Kafka.Clients.Admin.Admin
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.AdminClient";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- [global::System.Obsolete("AdminClient class represents, in .NET, an instance of a JVM interface or abstract class. This public initializer is needed for JCOBridge internal use, other uses can produce unidentible behaviors.")]
- public AdminClient() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- [global::System.Obsolete("AdminClient class represents, in .NET, an instance of a JVM interface or abstract class. This public initializer is needed for JCOBridge internal use, other uses can produce unidentible behaviors.")]
- public AdminClient(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => true;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region AdminClientConfig
- ///
- ///
- ///
- public partial class AdminClientConfig : Org.Apache.Kafka.Common.Config.AbstractConfig, MASES.JCOBridge.C2JBridge.IJVMBridgeMain
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.AdminClientConfig";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public AdminClientConfig() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public AdminClientConfig(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region AlterClientQuotasOptions
- ///
- ///
- ///
- public partial class AlterClientQuotasOptions : Org.Apache.Kafka.Clients.Admin.AbstractOptions
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.AlterClientQuotasOptions";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public AlterClientQuotasOptions() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public AlterClientQuotasOptions(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region AlterClientQuotasResult
- ///
- ///
- ///
- public partial class AlterClientQuotasResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.AlterClientQuotasResult";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public AlterClientQuotasResult() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public AlterClientQuotasResult(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region AlterConfigOp
- ///
- ///
- ///
- public partial class AlterConfigOp : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.AlterConfigOp";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public AlterConfigOp() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public AlterConfigOp(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
- #region OpType
- ///
- ///
- ///
- public partial class OpType : Java.Lang.Enum
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.AlterConfigOp$OpType";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public OpType() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public OpType(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => true;
-
- // TODO: complete the class
-
- }
- #endregion
-
-
- }
- #endregion
-
- #region AlterConfigsOptions
- ///
- ///
- ///
- public partial class AlterConfigsOptions : Org.Apache.Kafka.Clients.Admin.AbstractOptions
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.AlterConfigsOptions";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public AlterConfigsOptions() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public AlterConfigsOptions(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region AlterConfigsResult
- ///
- ///
- ///
- public partial class AlterConfigsResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.AlterConfigsResult";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public AlterConfigsResult() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public AlterConfigsResult(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region AlterConsumerGroupOffsetsOptions
- ///
- ///
- ///
- public partial class AlterConsumerGroupOffsetsOptions : Org.Apache.Kafka.Clients.Admin.AbstractOptions
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.AlterConsumerGroupOffsetsOptions";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public AlterConsumerGroupOffsetsOptions() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public AlterConsumerGroupOffsetsOptions(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region AlterConsumerGroupOffsetsResult
- ///
- ///
- ///
- public partial class AlterConsumerGroupOffsetsResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.AlterConsumerGroupOffsetsResult";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public AlterConsumerGroupOffsetsResult() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public AlterConsumerGroupOffsetsResult(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region AlterPartitionReassignmentsOptions
- ///
- ///
- ///
- public partial class AlterPartitionReassignmentsOptions : Org.Apache.Kafka.Clients.Admin.AbstractOptions
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.AlterPartitionReassignmentsOptions";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public AlterPartitionReassignmentsOptions() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public AlterPartitionReassignmentsOptions(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region AlterPartitionReassignmentsResult
- ///
- ///
- ///
- public partial class AlterPartitionReassignmentsResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.AlterPartitionReassignmentsResult";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public AlterPartitionReassignmentsResult() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public AlterPartitionReassignmentsResult(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region AlterReplicaLogDirsOptions
- ///
- ///
- ///
- public partial class AlterReplicaLogDirsOptions : Org.Apache.Kafka.Clients.Admin.AbstractOptions
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.AlterReplicaLogDirsOptions";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public AlterReplicaLogDirsOptions() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public AlterReplicaLogDirsOptions(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region AlterReplicaLogDirsResult
- ///
- ///
- ///
- public partial class AlterReplicaLogDirsResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.AlterReplicaLogDirsResult";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public AlterReplicaLogDirsResult() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public AlterReplicaLogDirsResult(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region AlterUserScramCredentialsOptions
- ///
- ///
- ///
- public partial class AlterUserScramCredentialsOptions : Org.Apache.Kafka.Clients.Admin.AbstractOptions
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.AlterUserScramCredentialsOptions";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public AlterUserScramCredentialsOptions() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public AlterUserScramCredentialsOptions(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region AlterUserScramCredentialsResult
- ///
- ///
- ///
- public partial class AlterUserScramCredentialsResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.AlterUserScramCredentialsResult";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public AlterUserScramCredentialsResult() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public AlterUserScramCredentialsResult(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region Config
- ///
- ///
- ///
- public partial class Config : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.Config";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public Config() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public Config(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region ConfigEntry
- ///
- ///
- ///
- public partial class ConfigEntry : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.ConfigEntry";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public ConfigEntry() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public ConfigEntry(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
- #region ConfigSource
- ///
- ///
- ///
- public partial class ConfigSource : Java.Lang.Enum
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.ConfigEntry$ConfigSource";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public ConfigSource() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public ConfigSource(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => true;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region ConfigSynonym
- ///
- ///
- ///
- public partial class ConfigSynonym : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.ConfigEntry$ConfigSynonym";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public ConfigSynonym() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public ConfigSynonym(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => true;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region ConfigType
- ///
- ///
- ///
- public partial class ConfigType : Java.Lang.Enum
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.ConfigEntry$ConfigType";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public ConfigType() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public ConfigType(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => true;
-
- // TODO: complete the class
-
- }
- #endregion
-
-
- }
- #endregion
-
- #region ConsumerGroupDescription
- ///
- ///
- ///
- public partial class ConsumerGroupDescription : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.ConsumerGroupDescription";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public ConsumerGroupDescription() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public ConsumerGroupDescription(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region ConsumerGroupListing
- ///
- ///
- ///
- public partial class ConsumerGroupListing : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.ConsumerGroupListing";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public ConsumerGroupListing() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public ConsumerGroupListing(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region CreateAclsOptions
- ///
- ///
- ///
- public partial class CreateAclsOptions : Org.Apache.Kafka.Clients.Admin.AbstractOptions
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.CreateAclsOptions";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public CreateAclsOptions() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public CreateAclsOptions(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region CreateAclsResult
- ///
- ///
- ///
- public partial class CreateAclsResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.CreateAclsResult";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public CreateAclsResult() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public CreateAclsResult(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region CreateDelegationTokenOptions
- ///
- ///
- ///
- public partial class CreateDelegationTokenOptions : Org.Apache.Kafka.Clients.Admin.AbstractOptions
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.CreateDelegationTokenOptions";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public CreateDelegationTokenOptions() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public CreateDelegationTokenOptions(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region CreateDelegationTokenResult
- ///
- ///
- ///
- public partial class CreateDelegationTokenResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.CreateDelegationTokenResult";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public CreateDelegationTokenResult() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public CreateDelegationTokenResult(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region CreatePartitionsOptions
- ///
- ///
- ///
- public partial class CreatePartitionsOptions : Org.Apache.Kafka.Clients.Admin.AbstractOptions
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.CreatePartitionsOptions";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public CreatePartitionsOptions() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public CreatePartitionsOptions(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region CreatePartitionsResult
- ///
- ///
- ///
- public partial class CreatePartitionsResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.CreatePartitionsResult";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public CreatePartitionsResult() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public CreatePartitionsResult(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region CreateTopicsOptions
- ///
- ///
- ///
- public partial class CreateTopicsOptions : Org.Apache.Kafka.Clients.Admin.AbstractOptions
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.CreateTopicsOptions";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public CreateTopicsOptions() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public CreateTopicsOptions(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region CreateTopicsResult
- ///
- ///
- ///
- public partial class CreateTopicsResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.CreateTopicsResult";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public CreateTopicsResult() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public CreateTopicsResult(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
- #region TopicMetadataAndConfig
- ///
- ///
- ///
- public partial class TopicMetadataAndConfig : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.CreateTopicsResult$TopicMetadataAndConfig";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public TopicMetadataAndConfig() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public TopicMetadataAndConfig(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => true;
-
- // TODO: complete the class
-
- }
- #endregion
-
-
- }
- #endregion
-
- #region DeleteAclsOptions
- ///
- ///
- ///
- public partial class DeleteAclsOptions : Org.Apache.Kafka.Clients.Admin.AbstractOptions
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.DeleteAclsOptions";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public DeleteAclsOptions() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public DeleteAclsOptions(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region DeleteAclsResult
- ///
- ///
- ///
- public partial class DeleteAclsResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.DeleteAclsResult";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public DeleteAclsResult() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public DeleteAclsResult(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
- #region FilterResult
- ///
- ///
- ///
- public partial class FilterResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.DeleteAclsResult$FilterResult";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public FilterResult() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public FilterResult(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => true;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region FilterResults
- ///
- ///
- ///
- public partial class FilterResults : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.DeleteAclsResult$FilterResults";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public FilterResults() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public FilterResults(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => true;
-
- // TODO: complete the class
-
- }
- #endregion
-
-
- }
- #endregion
-
- #region DeleteConsumerGroupOffsetsOptions
- ///
- ///
- ///
- public partial class DeleteConsumerGroupOffsetsOptions : Org.Apache.Kafka.Clients.Admin.AbstractOptions
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.DeleteConsumerGroupOffsetsOptions";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public DeleteConsumerGroupOffsetsOptions() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public DeleteConsumerGroupOffsetsOptions(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region DeleteConsumerGroupOffsetsResult
- ///
- ///
- ///
- public partial class DeleteConsumerGroupOffsetsResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.DeleteConsumerGroupOffsetsResult";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public DeleteConsumerGroupOffsetsResult() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public DeleteConsumerGroupOffsetsResult(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region DeleteConsumerGroupsOptions
- ///
- ///
- ///
- public partial class DeleteConsumerGroupsOptions : Org.Apache.Kafka.Clients.Admin.AbstractOptions
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.DeleteConsumerGroupsOptions";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public DeleteConsumerGroupsOptions() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public DeleteConsumerGroupsOptions(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region DeleteConsumerGroupsResult
- ///
- ///
- ///
- public partial class DeleteConsumerGroupsResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.DeleteConsumerGroupsResult";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public DeleteConsumerGroupsResult() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public DeleteConsumerGroupsResult(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region DeletedRecords
- ///
- ///
- ///
- public partial class DeletedRecords : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.DeletedRecords";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public DeletedRecords() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public DeletedRecords(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region DeleteRecordsOptions
- ///
- ///
- ///
- public partial class DeleteRecordsOptions : Org.Apache.Kafka.Clients.Admin.AbstractOptions
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.DeleteRecordsOptions";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public DeleteRecordsOptions() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public DeleteRecordsOptions(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region DeleteRecordsResult
- ///
- ///
- ///
- public partial class DeleteRecordsResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.DeleteRecordsResult";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public DeleteRecordsResult() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public DeleteRecordsResult(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region DeleteTopicsOptions
- ///
- ///
- ///
- public partial class DeleteTopicsOptions : Org.Apache.Kafka.Clients.Admin.AbstractOptions
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.DeleteTopicsOptions";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public DeleteTopicsOptions() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public DeleteTopicsOptions(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region DeleteTopicsResult
- ///
- ///
- ///
- public partial class DeleteTopicsResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.DeleteTopicsResult";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public DeleteTopicsResult() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public DeleteTopicsResult(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region DescribeAclsOptions
- ///
- ///
- ///
- public partial class DescribeAclsOptions : Org.Apache.Kafka.Clients.Admin.AbstractOptions
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.DescribeAclsOptions";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public DescribeAclsOptions() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public DescribeAclsOptions(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region DescribeAclsResult
- ///
- ///
- ///
- public partial class DescribeAclsResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.DescribeAclsResult";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public DescribeAclsResult() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public DescribeAclsResult(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region DescribeClientQuotasOptions
- ///
- ///
- ///
- public partial class DescribeClientQuotasOptions : Org.Apache.Kafka.Clients.Admin.AbstractOptions
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.DescribeClientQuotasOptions";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public DescribeClientQuotasOptions() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public DescribeClientQuotasOptions(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region DescribeClientQuotasResult
- ///
- ///
- ///
- public partial class DescribeClientQuotasResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.DescribeClientQuotasResult";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public DescribeClientQuotasResult() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public DescribeClientQuotasResult(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region DescribeClusterOptions
- ///
- ///
- ///
- public partial class DescribeClusterOptions : Org.Apache.Kafka.Clients.Admin.AbstractOptions
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.DescribeClusterOptions";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public DescribeClusterOptions() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public DescribeClusterOptions(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region DescribeClusterResult
- ///
- ///
- ///
- public partial class DescribeClusterResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.DescribeClusterResult";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public DescribeClusterResult() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public DescribeClusterResult(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region DescribeConfigsOptions
- ///
- ///
- ///
- public partial class DescribeConfigsOptions : Org.Apache.Kafka.Clients.Admin.AbstractOptions
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.DescribeConfigsOptions";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public DescribeConfigsOptions() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public DescribeConfigsOptions(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region DescribeConfigsResult
- ///
- ///
- ///
- public partial class DescribeConfigsResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.DescribeConfigsResult";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public DescribeConfigsResult() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public DescribeConfigsResult(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region DescribeConsumerGroupsOptions
- ///
- ///
- ///
- public partial class DescribeConsumerGroupsOptions : Org.Apache.Kafka.Clients.Admin.AbstractOptions
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.DescribeConsumerGroupsOptions";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public DescribeConsumerGroupsOptions() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public DescribeConsumerGroupsOptions(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region DescribeConsumerGroupsResult
- ///
- ///
- ///
- public partial class DescribeConsumerGroupsResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.DescribeConsumerGroupsResult";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public DescribeConsumerGroupsResult() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public DescribeConsumerGroupsResult(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region DescribeDelegationTokenOptions
- ///
- ///
- ///
- public partial class DescribeDelegationTokenOptions : Org.Apache.Kafka.Clients.Admin.AbstractOptions
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.DescribeDelegationTokenOptions";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public DescribeDelegationTokenOptions() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public DescribeDelegationTokenOptions(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region DescribeDelegationTokenResult
- ///
- ///
- ///
- public partial class DescribeDelegationTokenResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.DescribeDelegationTokenResult";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public DescribeDelegationTokenResult() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public DescribeDelegationTokenResult(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region DescribeFeaturesOptions
- ///
- ///
- ///
- public partial class DescribeFeaturesOptions : Org.Apache.Kafka.Clients.Admin.AbstractOptions
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.DescribeFeaturesOptions";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public DescribeFeaturesOptions() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public DescribeFeaturesOptions(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region DescribeFeaturesResult
- ///
- ///
- ///
- public partial class DescribeFeaturesResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.DescribeFeaturesResult";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public DescribeFeaturesResult() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public DescribeFeaturesResult(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region DescribeLogDirsOptions
- ///
- ///
- ///
- public partial class DescribeLogDirsOptions : Org.Apache.Kafka.Clients.Admin.AbstractOptions
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.DescribeLogDirsOptions";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public DescribeLogDirsOptions() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public DescribeLogDirsOptions(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region DescribeLogDirsResult
- ///
- ///
- ///
- public partial class DescribeLogDirsResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.DescribeLogDirsResult";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public DescribeLogDirsResult() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public DescribeLogDirsResult(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region DescribeMetadataQuorumOptions
- ///
- ///
- ///
- public partial class DescribeMetadataQuorumOptions : Org.Apache.Kafka.Clients.Admin.AbstractOptions
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.DescribeMetadataQuorumOptions";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public DescribeMetadataQuorumOptions() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public DescribeMetadataQuorumOptions(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region DescribeMetadataQuorumResult
- ///
- ///
- ///
- public partial class DescribeMetadataQuorumResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.DescribeMetadataQuorumResult";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public DescribeMetadataQuorumResult() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public DescribeMetadataQuorumResult(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region DescribeProducersOptions
- ///
- ///
- ///
- public partial class DescribeProducersOptions : Org.Apache.Kafka.Clients.Admin.AbstractOptions
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.DescribeProducersOptions";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public DescribeProducersOptions() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public DescribeProducersOptions(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region DescribeProducersResult
- ///
- ///
- ///
- public partial class DescribeProducersResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.DescribeProducersResult";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public DescribeProducersResult() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public DescribeProducersResult(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
- #region PartitionProducerState
- ///
- ///
- ///
- public partial class PartitionProducerState : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.DescribeProducersResult$PartitionProducerState";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public PartitionProducerState() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public PartitionProducerState(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => true;
-
- // TODO: complete the class
-
- }
- #endregion
-
-
- }
- #endregion
-
- #region DescribeReplicaLogDirsOptions
- ///
- ///
- ///
- public partial class DescribeReplicaLogDirsOptions : Org.Apache.Kafka.Clients.Admin.AbstractOptions
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.DescribeReplicaLogDirsOptions";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public DescribeReplicaLogDirsOptions() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public DescribeReplicaLogDirsOptions(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region DescribeReplicaLogDirsResult
- ///
- ///
- ///
- public partial class DescribeReplicaLogDirsResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.DescribeReplicaLogDirsResult";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public DescribeReplicaLogDirsResult() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public DescribeReplicaLogDirsResult(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
- #region ReplicaLogDirInfo
- ///
- ///
- ///
- public partial class ReplicaLogDirInfo : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.DescribeReplicaLogDirsResult$ReplicaLogDirInfo";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public ReplicaLogDirInfo() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public ReplicaLogDirInfo(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => true;
-
- // TODO: complete the class
-
- }
- #endregion
-
-
- }
- #endregion
-
- #region DescribeTopicsOptions
- ///
- ///
- ///
- public partial class DescribeTopicsOptions : Org.Apache.Kafka.Clients.Admin.AbstractOptions
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.DescribeTopicsOptions";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public DescribeTopicsOptions() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public DescribeTopicsOptions(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region DescribeTopicsResult
- ///
- ///
- ///
- public partial class DescribeTopicsResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.DescribeTopicsResult";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public DescribeTopicsResult() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public DescribeTopicsResult(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region DescribeTransactionsOptions
- ///
- ///
- ///
- public partial class DescribeTransactionsOptions : Org.Apache.Kafka.Clients.Admin.AbstractOptions
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.DescribeTransactionsOptions";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public DescribeTransactionsOptions() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public DescribeTransactionsOptions(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region DescribeTransactionsResult
- ///
- ///
- ///
- public partial class DescribeTransactionsResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.DescribeTransactionsResult";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public DescribeTransactionsResult() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public DescribeTransactionsResult(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region DescribeUserScramCredentialsOptions
- ///
- ///
- ///
- public partial class DescribeUserScramCredentialsOptions : Org.Apache.Kafka.Clients.Admin.AbstractOptions
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.DescribeUserScramCredentialsOptions";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public DescribeUserScramCredentialsOptions() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public DescribeUserScramCredentialsOptions(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region DescribeUserScramCredentialsResult
- ///
- ///
- ///
- public partial class DescribeUserScramCredentialsResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.DescribeUserScramCredentialsResult";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public DescribeUserScramCredentialsResult() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public DescribeUserScramCredentialsResult(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region ElectLeadersOptions
- ///
- ///
- ///
- public partial class ElectLeadersOptions : Org.Apache.Kafka.Clients.Admin.AbstractOptions
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.ElectLeadersOptions";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public ElectLeadersOptions() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public ElectLeadersOptions(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region ElectLeadersResult
- ///
- ///
- ///
- public partial class ElectLeadersResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.ElectLeadersResult";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public ElectLeadersResult() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public ElectLeadersResult(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region ExpireDelegationTokenOptions
- ///
- ///
- ///
- public partial class ExpireDelegationTokenOptions : Org.Apache.Kafka.Clients.Admin.AbstractOptions
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.ExpireDelegationTokenOptions";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public ExpireDelegationTokenOptions() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public ExpireDelegationTokenOptions(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region ExpireDelegationTokenResult
- ///
- ///
- ///
- public partial class ExpireDelegationTokenResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.ExpireDelegationTokenResult";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public ExpireDelegationTokenResult() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public ExpireDelegationTokenResult(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region FeatureMetadata
- ///
- ///
- ///
- public partial class FeatureMetadata : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.FeatureMetadata";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public FeatureMetadata() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public FeatureMetadata(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region FeatureUpdate
- ///
- ///
- ///
- public partial class FeatureUpdate : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.FeatureUpdate";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public FeatureUpdate() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public FeatureUpdate(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
- #region UpgradeType
- ///
- ///
- ///
- public partial class UpgradeType : Java.Lang.Enum
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.FeatureUpdate$UpgradeType";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public UpgradeType() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public UpgradeType(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => true;
-
- // TODO: complete the class
-
- }
- #endregion
-
-
- }
- #endregion
-
- #region FenceProducersOptions
- ///
- ///
- ///
- public partial class FenceProducersOptions : Org.Apache.Kafka.Clients.Admin.AbstractOptions
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.FenceProducersOptions";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public FenceProducersOptions() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public FenceProducersOptions(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region FenceProducersResult
- ///
- ///
- ///
- public partial class FenceProducersResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.FenceProducersResult";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public FenceProducersResult() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public FenceProducersResult(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region FinalizedVersionRange
- ///
- ///
- ///
- public partial class FinalizedVersionRange : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.FinalizedVersionRange";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public FinalizedVersionRange() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public FinalizedVersionRange(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region ForwardingAdmin
- ///
- ///
- ///
- public partial class ForwardingAdmin : Org.Apache.Kafka.Clients.Admin.Admin
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.ForwardingAdmin";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public ForwardingAdmin() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public ForwardingAdmin(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region KafkaAdminClient
- ///
- ///
- ///
- public partial class KafkaAdminClient : Org.Apache.Kafka.Clients.Admin.AdminClient
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.KafkaAdminClient";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public KafkaAdminClient() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public KafkaAdminClient(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region ListConsumerGroupOffsetsOptions
- ///
- ///
- ///
- public partial class ListConsumerGroupOffsetsOptions : Org.Apache.Kafka.Clients.Admin.AbstractOptions
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.ListConsumerGroupOffsetsOptions";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public ListConsumerGroupOffsetsOptions() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public ListConsumerGroupOffsetsOptions(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region ListConsumerGroupOffsetsResult
- ///
- ///
- ///
- public partial class ListConsumerGroupOffsetsResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.ListConsumerGroupOffsetsResult";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public ListConsumerGroupOffsetsResult() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public ListConsumerGroupOffsetsResult(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region ListConsumerGroupOffsetsSpec
- ///
- ///
- ///
- public partial class ListConsumerGroupOffsetsSpec : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.ListConsumerGroupOffsetsSpec";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public ListConsumerGroupOffsetsSpec() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public ListConsumerGroupOffsetsSpec(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region ListConsumerGroupsOptions
- ///
- ///
- ///
- public partial class ListConsumerGroupsOptions : Org.Apache.Kafka.Clients.Admin.AbstractOptions
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.ListConsumerGroupsOptions";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public ListConsumerGroupsOptions() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public ListConsumerGroupsOptions(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region ListConsumerGroupsResult
- ///
- ///
- ///
- public partial class ListConsumerGroupsResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.ListConsumerGroupsResult";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public ListConsumerGroupsResult() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public ListConsumerGroupsResult(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region ListOffsetsOptions
- ///
- ///
- ///
- public partial class ListOffsetsOptions : Org.Apache.Kafka.Clients.Admin.AbstractOptions
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.ListOffsetsOptions";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public ListOffsetsOptions() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public ListOffsetsOptions(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region ListOffsetsResult
- ///
- ///
- ///
- public partial class ListOffsetsResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.ListOffsetsResult";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public ListOffsetsResult() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public ListOffsetsResult(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
- #region ListOffsetsResultInfo
- ///
- ///
- ///
- public partial class ListOffsetsResultInfo : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.ListOffsetsResult$ListOffsetsResultInfo";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public ListOffsetsResultInfo() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public ListOffsetsResultInfo(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => true;
-
- // TODO: complete the class
-
- }
- #endregion
-
-
- }
- #endregion
-
- #region ListPartitionReassignmentsOptions
- ///
- ///
- ///
- public partial class ListPartitionReassignmentsOptions : Org.Apache.Kafka.Clients.Admin.AbstractOptions
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.ListPartitionReassignmentsOptions";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public ListPartitionReassignmentsOptions() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public ListPartitionReassignmentsOptions(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region ListPartitionReassignmentsResult
- ///
- ///
- ///
- public partial class ListPartitionReassignmentsResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.ListPartitionReassignmentsResult";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public ListPartitionReassignmentsResult() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public ListPartitionReassignmentsResult(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region ListTopicsOptions
- ///
- ///
- ///
- public partial class ListTopicsOptions : Org.Apache.Kafka.Clients.Admin.AbstractOptions
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.ListTopicsOptions";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public ListTopicsOptions() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public ListTopicsOptions(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region ListTopicsResult
- ///
- ///
- ///
- public partial class ListTopicsResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.ListTopicsResult";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public ListTopicsResult() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public ListTopicsResult(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region ListTransactionsOptions
- ///
- ///
- ///
- public partial class ListTransactionsOptions : Org.Apache.Kafka.Clients.Admin.AbstractOptions
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.ListTransactionsOptions";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public ListTransactionsOptions() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public ListTransactionsOptions(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region ListTransactionsResult
- ///
- ///
- ///
- public partial class ListTransactionsResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.ListTransactionsResult";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public ListTransactionsResult() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public ListTransactionsResult(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region LogDirDescription
- ///
- ///
- ///
- public partial class LogDirDescription : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.LogDirDescription";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public LogDirDescription() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public LogDirDescription(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region MemberAssignment
- ///
- ///
- ///
- public partial class MemberAssignment : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.MemberAssignment";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public MemberAssignment() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public MemberAssignment(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region MemberDescription
- ///
- ///
- ///
- public partial class MemberDescription : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.MemberDescription";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public MemberDescription() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public MemberDescription(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region MemberToRemove
- ///
- ///
- ///
- public partial class MemberToRemove : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.MemberToRemove";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public MemberToRemove() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public MemberToRemove(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region NewPartitionReassignment
- ///
- ///
- ///
- public partial class NewPartitionReassignment : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.NewPartitionReassignment";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public NewPartitionReassignment() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public NewPartitionReassignment(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region NewPartitions
- ///
- ///
- ///
- public partial class NewPartitions : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.NewPartitions";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public NewPartitions() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public NewPartitions(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region NewTopic
- ///
- ///
- ///
- public partial class NewTopic : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.NewTopic";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public NewTopic() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public NewTopic(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region OffsetSpec
- ///
- ///
- ///
- public partial class OffsetSpec : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.OffsetSpec";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public OffsetSpec() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public OffsetSpec(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
- #region EarliestSpec
- ///
- ///
- ///
- public partial class EarliestSpec : Org.Apache.Kafka.Clients.Admin.OffsetSpec
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.OffsetSpec$EarliestSpec";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public EarliestSpec() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public EarliestSpec(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => true;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region LatestSpec
- ///
- ///
- ///
- public partial class LatestSpec : Org.Apache.Kafka.Clients.Admin.OffsetSpec
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.OffsetSpec$LatestSpec";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public LatestSpec() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public LatestSpec(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => true;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region MaxTimestampSpec
- ///
- ///
- ///
- public partial class MaxTimestampSpec : Org.Apache.Kafka.Clients.Admin.OffsetSpec
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.OffsetSpec$MaxTimestampSpec";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public MaxTimestampSpec() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public MaxTimestampSpec(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => true;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region TimestampSpec
- ///
- ///
- ///
- public partial class TimestampSpec : Org.Apache.Kafka.Clients.Admin.OffsetSpec
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.OffsetSpec$TimestampSpec";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public TimestampSpec() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public TimestampSpec(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => true;
-
- // TODO: complete the class
-
- }
- #endregion
-
-
- }
- #endregion
-
- #region PartitionReassignment
- ///
- ///
- ///
- public partial class PartitionReassignment : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.PartitionReassignment";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public PartitionReassignment() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public PartitionReassignment(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region ProducerState
- ///
- ///
- ///
- public partial class ProducerState : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.ProducerState";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public ProducerState() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public ProducerState(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region QuorumInfo
- ///
- ///
- ///
- public partial class QuorumInfo : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.QuorumInfo";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public QuorumInfo() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public QuorumInfo(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
- #region ReplicaState
- ///
- ///
- ///
- public partial class ReplicaState : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.QuorumInfo$ReplicaState";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public ReplicaState() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public ReplicaState(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => true;
-
- // TODO: complete the class
-
- }
- #endregion
-
-
- }
- #endregion
-
- #region RecordsToDelete
- ///
- ///
- ///
- public partial class RecordsToDelete : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.RecordsToDelete";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public RecordsToDelete() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public RecordsToDelete(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region RemoveMembersFromConsumerGroupOptions
- ///
- ///
- ///
- public partial class RemoveMembersFromConsumerGroupOptions : Org.Apache.Kafka.Clients.Admin.AbstractOptions
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.RemoveMembersFromConsumerGroupOptions";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public RemoveMembersFromConsumerGroupOptions() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public RemoveMembersFromConsumerGroupOptions(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region RemoveMembersFromConsumerGroupResult
- ///
- ///
- ///
- public partial class RemoveMembersFromConsumerGroupResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.RemoveMembersFromConsumerGroupResult";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public RemoveMembersFromConsumerGroupResult() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public RemoveMembersFromConsumerGroupResult(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region RenewDelegationTokenOptions
- ///
- ///
- ///
- public partial class RenewDelegationTokenOptions : Org.Apache.Kafka.Clients.Admin.AbstractOptions
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.RenewDelegationTokenOptions";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public RenewDelegationTokenOptions() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public RenewDelegationTokenOptions(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region RenewDelegationTokenResult
- ///
- ///
- ///
- public partial class RenewDelegationTokenResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.RenewDelegationTokenResult";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public RenewDelegationTokenResult() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public RenewDelegationTokenResult(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region ReplicaInfo
- ///
- ///
- ///
- public partial class ReplicaInfo : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.ReplicaInfo";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public ReplicaInfo() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public ReplicaInfo(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region ScramCredentialInfo
- ///
- ///
- ///
- public partial class ScramCredentialInfo : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.ScramCredentialInfo";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public ScramCredentialInfo() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public ScramCredentialInfo(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region ScramMechanism
- ///
- ///
- ///
- public partial class ScramMechanism : Java.Lang.Enum
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.ScramMechanism";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public ScramMechanism() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public ScramMechanism(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region SupportedVersionRange
- ///
- ///
- ///
- public partial class SupportedVersionRange : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.SupportedVersionRange";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public SupportedVersionRange() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public SupportedVersionRange(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region TopicDescription
- ///
- ///
- ///
- public partial class TopicDescription : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.TopicDescription";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public TopicDescription() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public TopicDescription(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region TopicListing
- ///
- ///
- ///
- public partial class TopicListing : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.TopicListing";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public TopicListing() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public TopicListing(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region TransactionDescription
- ///
- ///
- ///
- public partial class TransactionDescription : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.TransactionDescription";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public TransactionDescription() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public TransactionDescription(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region TransactionListing
- ///
- ///
- ///
- public partial class TransactionListing : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.TransactionListing";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public TransactionListing() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public TransactionListing(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region TransactionState
- ///
- ///
- ///
- public partial class TransactionState : Java.Lang.Enum
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.TransactionState";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public TransactionState() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public TransactionState(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region UnregisterBrokerOptions
- ///
- ///
- ///
- public partial class UnregisterBrokerOptions : Org.Apache.Kafka.Clients.Admin.AbstractOptions
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.UnregisterBrokerOptions";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public UnregisterBrokerOptions() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public UnregisterBrokerOptions(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region UnregisterBrokerResult
- ///
- ///
- ///
- public partial class UnregisterBrokerResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.UnregisterBrokerResult";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public UnregisterBrokerResult() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public UnregisterBrokerResult(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region UpdateFeaturesOptions
- ///
- ///
- ///
- public partial class UpdateFeaturesOptions : Org.Apache.Kafka.Clients.Admin.AbstractOptions
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.UpdateFeaturesOptions";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public UpdateFeaturesOptions() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public UpdateFeaturesOptions(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region UpdateFeaturesResult
- ///
- ///
- ///
- public partial class UpdateFeaturesResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.UpdateFeaturesResult";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public UpdateFeaturesResult() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public UpdateFeaturesResult(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region UserScramCredentialAlteration
- ///
- ///
- ///
- public partial class UserScramCredentialAlteration : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.UserScramCredentialAlteration";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- [global::System.Obsolete("UserScramCredentialAlteration class represents, in .NET, an instance of a JVM interface or abstract class. This public initializer is needed for JCOBridge internal use, other uses can produce unidentible behaviors.")]
- public UserScramCredentialAlteration() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- [global::System.Obsolete("UserScramCredentialAlteration class represents, in .NET, an instance of a JVM interface or abstract class. This public initializer is needed for JCOBridge internal use, other uses can produce unidentible behaviors.")]
- public UserScramCredentialAlteration(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => true;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region UserScramCredentialDeletion
- ///
- ///
- ///
- public partial class UserScramCredentialDeletion : Org.Apache.Kafka.Clients.Admin.UserScramCredentialAlteration
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.UserScramCredentialDeletion";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public UserScramCredentialDeletion() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public UserScramCredentialDeletion(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region UserScramCredentialsDescription
- ///
- ///
- ///
- public partial class UserScramCredentialsDescription : MASES.JCOBridge.C2JBridge.JVMBridgeBase
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.UserScramCredentialsDescription";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public UserScramCredentialsDescription() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public UserScramCredentialsDescription(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
- #region UserScramCredentialUpsertion
- ///
- ///
- ///
- public partial class UserScramCredentialUpsertion : Org.Apache.Kafka.Clients.Admin.UserScramCredentialAlteration
- {
- const string _bridgeClassName = "org.apache.kafka.clients.admin.UserScramCredentialUpsertion";
- ///
- /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
- ///
- public UserScramCredentialUpsertion() { }
- ///
- /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
- ///
- public UserScramCredentialUpsertion(params object[] args) : base(args) { }
-
- private static readonly IJavaType _LocalBridgeClazz = ClazzOf(_bridgeClassName);
- private static IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new InvalidOperationException($"Class {_bridgeClassName} was not found.");
-
- ///
- ///
- ///
- public override string BridgeClassName => _bridgeClassName;
- ///
- ///
- ///
- public override bool IsBridgeAbstract => false;
- ///
- ///
- ///
- public override bool IsBridgeCloseable => false;
- ///
- ///
- ///
- public override bool IsBridgeInterface => false;
- ///
- ///
- ///
- public override bool IsBridgeStatic => false;
-
- // TODO: complete the class
-
- }
- #endregion
-
-
-
-}
\ No newline at end of file
diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AlterClientQuotasOptions.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AlterClientQuotasOptions.cs
index 843d276c0..41697ac1c 100644
--- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AlterClientQuotasOptions.cs
+++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AlterClientQuotasOptions.cs
@@ -17,7 +17,7 @@
*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
* using kafka-clients-3.6.2.jar as reference
*/
@@ -25,7 +25,52 @@
namespace Org.Apache.Kafka.Clients.Admin
{
- #region AlterClientQuotasOptions
+ #region AlterClientQuotasOptions declaration
+ ///
+ ///
+ ///
+ public partial class AlterClientQuotasOptions : Org.Apache.Kafka.Clients.Admin.AbstractOptions
+ {
+ const string _bridgeClassName = "org.apache.kafka.clients.admin.AlterClientQuotasOptions";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public AlterClientQuotasOptions() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public AlterClientQuotasOptions(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => false;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+ #region AlterClientQuotasOptions implementation
public partial class AlterClientQuotasOptions
{
#region Constructors
diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AlterClientQuotasResult.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AlterClientQuotasResult.cs
index 39147e16b..26a6dfd8c 100644
--- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AlterClientQuotasResult.cs
+++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AlterClientQuotasResult.cs
@@ -17,7 +17,7 @@
*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
* using kafka-clients-3.6.2.jar as reference
*/
@@ -25,7 +25,52 @@
namespace Org.Apache.Kafka.Clients.Admin
{
- #region AlterClientQuotasResult
+ #region AlterClientQuotasResult declaration
+ ///
+ ///
+ ///
+ public partial class AlterClientQuotasResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase
+ {
+ const string _bridgeClassName = "org.apache.kafka.clients.admin.AlterClientQuotasResult";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public AlterClientQuotasResult() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public AlterClientQuotasResult(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => false;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+ #region AlterClientQuotasResult implementation
public partial class AlterClientQuotasResult
{
#region Constructors
diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AlterConfigOp.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AlterConfigOp.cs
index 688262bde..331ccf44e 100644
--- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AlterConfigOp.cs
+++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AlterConfigOp.cs
@@ -17,7 +17,7 @@
*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
* using kafka-clients-3.6.2.jar as reference
*/
@@ -25,7 +25,97 @@
namespace Org.Apache.Kafka.Clients.Admin
{
- #region AlterConfigOp
+ #region AlterConfigOp declaration
+ ///
+ ///
+ ///
+ public partial class AlterConfigOp : MASES.JCOBridge.C2JBridge.JVMBridgeBase
+ {
+ const string _bridgeClassName = "org.apache.kafka.clients.admin.AlterConfigOp";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public AlterConfigOp() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public AlterConfigOp(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => false;
+
+ // TODO: complete the class
+ #region OpType declaration
+ ///
+ ///
+ ///
+ public partial class OpType : Java.Lang.Enum
+ {
+ const string _bridgeClassName = "org.apache.kafka.clients.admin.AlterConfigOp$OpType";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public OpType() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public OpType(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => true;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+
+ }
+ #endregion
+
+ #region AlterConfigOp implementation
public partial class AlterConfigOp
{
#region Constructors
@@ -74,7 +164,7 @@ public Org.Apache.Kafka.Clients.Admin.ConfigEntry ConfigEntry()
#endregion
#region Nested classes
- #region OpType
+ #region OpType implementation
public partial class OpType
{
#region Constructors
diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AlterConfigsOptions.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AlterConfigsOptions.cs
index 3ad5c0884..d619ddd95 100644
--- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AlterConfigsOptions.cs
+++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AlterConfigsOptions.cs
@@ -17,7 +17,7 @@
*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
* using kafka-clients-3.6.2.jar as reference
*/
@@ -25,7 +25,52 @@
namespace Org.Apache.Kafka.Clients.Admin
{
- #region AlterConfigsOptions
+ #region AlterConfigsOptions declaration
+ ///
+ ///
+ ///
+ public partial class AlterConfigsOptions : Org.Apache.Kafka.Clients.Admin.AbstractOptions
+ {
+ const string _bridgeClassName = "org.apache.kafka.clients.admin.AlterConfigsOptions";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public AlterConfigsOptions() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public AlterConfigsOptions(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => false;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+ #region AlterConfigsOptions implementation
public partial class AlterConfigsOptions
{
#region Constructors
diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AlterConfigsResult.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AlterConfigsResult.cs
index d012ee3e1..74f70f55f 100644
--- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AlterConfigsResult.cs
+++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AlterConfigsResult.cs
@@ -17,7 +17,7 @@
*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
* using kafka-clients-3.6.2.jar as reference
*/
@@ -25,7 +25,52 @@
namespace Org.Apache.Kafka.Clients.Admin
{
- #region AlterConfigsResult
+ #region AlterConfigsResult declaration
+ ///
+ ///
+ ///
+ public partial class AlterConfigsResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase
+ {
+ const string _bridgeClassName = "org.apache.kafka.clients.admin.AlterConfigsResult";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public AlterConfigsResult() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public AlterConfigsResult(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => false;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+ #region AlterConfigsResult implementation
public partial class AlterConfigsResult
{
#region Constructors
diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AlterConsumerGroupOffsetsOptions.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AlterConsumerGroupOffsetsOptions.cs
index 0b5fe88e8..33207c383 100644
--- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AlterConsumerGroupOffsetsOptions.cs
+++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AlterConsumerGroupOffsetsOptions.cs
@@ -17,7 +17,7 @@
*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
* using kafka-clients-3.6.2.jar as reference
*/
@@ -25,7 +25,52 @@
namespace Org.Apache.Kafka.Clients.Admin
{
- #region AlterConsumerGroupOffsetsOptions
+ #region AlterConsumerGroupOffsetsOptions declaration
+ ///
+ ///
+ ///
+ public partial class AlterConsumerGroupOffsetsOptions : Org.Apache.Kafka.Clients.Admin.AbstractOptions
+ {
+ const string _bridgeClassName = "org.apache.kafka.clients.admin.AlterConsumerGroupOffsetsOptions";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public AlterConsumerGroupOffsetsOptions() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public AlterConsumerGroupOffsetsOptions(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => false;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+ #region AlterConsumerGroupOffsetsOptions implementation
public partial class AlterConsumerGroupOffsetsOptions
{
#region Constructors
diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AlterConsumerGroupOffsetsResult.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AlterConsumerGroupOffsetsResult.cs
index 9222e8c69..de84dad54 100644
--- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AlterConsumerGroupOffsetsResult.cs
+++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AlterConsumerGroupOffsetsResult.cs
@@ -17,7 +17,7 @@
*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
* using kafka-clients-3.6.2.jar as reference
*/
@@ -25,7 +25,52 @@
namespace Org.Apache.Kafka.Clients.Admin
{
- #region AlterConsumerGroupOffsetsResult
+ #region AlterConsumerGroupOffsetsResult declaration
+ ///
+ ///
+ ///
+ public partial class AlterConsumerGroupOffsetsResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase
+ {
+ const string _bridgeClassName = "org.apache.kafka.clients.admin.AlterConsumerGroupOffsetsResult";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public AlterConsumerGroupOffsetsResult() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public AlterConsumerGroupOffsetsResult(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => false;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+ #region AlterConsumerGroupOffsetsResult implementation
public partial class AlterConsumerGroupOffsetsResult
{
#region Constructors
diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AlterPartitionReassignmentsOptions.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AlterPartitionReassignmentsOptions.cs
index dd9f2816f..2c4ab8553 100644
--- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AlterPartitionReassignmentsOptions.cs
+++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AlterPartitionReassignmentsOptions.cs
@@ -17,7 +17,7 @@
*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
* using kafka-clients-3.6.2.jar as reference
*/
@@ -25,7 +25,52 @@
namespace Org.Apache.Kafka.Clients.Admin
{
- #region AlterPartitionReassignmentsOptions
+ #region AlterPartitionReassignmentsOptions declaration
+ ///
+ ///
+ ///
+ public partial class AlterPartitionReassignmentsOptions : Org.Apache.Kafka.Clients.Admin.AbstractOptions
+ {
+ const string _bridgeClassName = "org.apache.kafka.clients.admin.AlterPartitionReassignmentsOptions";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public AlterPartitionReassignmentsOptions() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public AlterPartitionReassignmentsOptions(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => false;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+ #region AlterPartitionReassignmentsOptions implementation
public partial class AlterPartitionReassignmentsOptions
{
#region Constructors
diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AlterPartitionReassignmentsResult.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AlterPartitionReassignmentsResult.cs
index 3f4f3c133..9e69cc615 100644
--- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AlterPartitionReassignmentsResult.cs
+++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AlterPartitionReassignmentsResult.cs
@@ -17,7 +17,7 @@
*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
* using kafka-clients-3.6.2.jar as reference
*/
@@ -25,7 +25,52 @@
namespace Org.Apache.Kafka.Clients.Admin
{
- #region AlterPartitionReassignmentsResult
+ #region AlterPartitionReassignmentsResult declaration
+ ///
+ ///
+ ///
+ public partial class AlterPartitionReassignmentsResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase
+ {
+ const string _bridgeClassName = "org.apache.kafka.clients.admin.AlterPartitionReassignmentsResult";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public AlterPartitionReassignmentsResult() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public AlterPartitionReassignmentsResult(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => false;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+ #region AlterPartitionReassignmentsResult implementation
public partial class AlterPartitionReassignmentsResult
{
#region Constructors
diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AlterReplicaLogDirsOptions.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AlterReplicaLogDirsOptions.cs
index 9d3f04607..b263bee89 100644
--- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AlterReplicaLogDirsOptions.cs
+++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AlterReplicaLogDirsOptions.cs
@@ -17,7 +17,7 @@
*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
* using kafka-clients-3.6.2.jar as reference
*/
@@ -25,7 +25,52 @@
namespace Org.Apache.Kafka.Clients.Admin
{
- #region AlterReplicaLogDirsOptions
+ #region AlterReplicaLogDirsOptions declaration
+ ///
+ ///
+ ///
+ public partial class AlterReplicaLogDirsOptions : Org.Apache.Kafka.Clients.Admin.AbstractOptions
+ {
+ const string _bridgeClassName = "org.apache.kafka.clients.admin.AlterReplicaLogDirsOptions";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public AlterReplicaLogDirsOptions() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public AlterReplicaLogDirsOptions(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => false;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+ #region AlterReplicaLogDirsOptions implementation
public partial class AlterReplicaLogDirsOptions
{
#region Constructors
diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AlterReplicaLogDirsResult.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AlterReplicaLogDirsResult.cs
index 07373da09..0ac4f2c74 100644
--- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AlterReplicaLogDirsResult.cs
+++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AlterReplicaLogDirsResult.cs
@@ -17,7 +17,7 @@
*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
* using kafka-clients-3.6.2.jar as reference
*/
@@ -25,7 +25,52 @@
namespace Org.Apache.Kafka.Clients.Admin
{
- #region AlterReplicaLogDirsResult
+ #region AlterReplicaLogDirsResult declaration
+ ///
+ ///
+ ///
+ public partial class AlterReplicaLogDirsResult : MASES.JCOBridge.C2JBridge.JVMBridgeBase
+ {
+ const string _bridgeClassName = "org.apache.kafka.clients.admin.AlterReplicaLogDirsResult";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public AlterReplicaLogDirsResult() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public AlterReplicaLogDirsResult(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///
+ ///
+ public override string BridgeClassName => _bridgeClassName;
+ ///
+ ///
+ ///
+ public override bool IsBridgeAbstract => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeCloseable => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeInterface => false;
+ ///
+ ///
+ ///
+ public override bool IsBridgeStatic => false;
+
+ // TODO: complete the class
+
+ }
+ #endregion
+
+ #region AlterReplicaLogDirsResult implementation
public partial class AlterReplicaLogDirsResult
{
#region Constructors
diff --git a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AlterUserScramCredentialsOptions.cs b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AlterUserScramCredentialsOptions.cs
index a9c0eca0f..2e9d4c501 100644
--- a/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AlterUserScramCredentialsOptions.cs
+++ b/src/net/KNet/Generated/Org/Apache/Kafka/Clients/Admin/AlterUserScramCredentialsOptions.cs
@@ -17,7 +17,7 @@
*/
/*
-* This file is generated by MASES.JNetReflector (ver. 2.5.8.0)
+* This file is generated by MASES.JNetReflector (ver. 2.5.9.0)
* using kafka-clients-3.6.2.jar as reference
*/
@@ -25,7 +25,52 @@
namespace Org.Apache.Kafka.Clients.Admin
{
- #region AlterUserScramCredentialsOptions
+ #region AlterUserScramCredentialsOptions declaration
+ ///
+ ///
+ ///
+ public partial class AlterUserScramCredentialsOptions : Org.Apache.Kafka.Clients.Admin.AbstractOptions
+ {
+ const string _bridgeClassName = "org.apache.kafka.clients.admin.AlterUserScramCredentialsOptions";
+ ///
+ /// Default constructor: even if the corresponding Java class does not have one, it is mandatory for JCOBridge
+ ///
+ public AlterUserScramCredentialsOptions() { }
+ ///
+ /// Generic constructor: it is useful for JCOBridge when there is a derived class which needs to pass arguments to the highest JVMBridgeBase class
+ ///
+ public AlterUserScramCredentialsOptions(params object[] args) : base(args) { }
+
+ private static readonly MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType _LocalBridgeClazz = JVMBridgeBase.ClazzOf(_bridgeClassName);
+ private static MASES.JCOBridge.C2JBridge.JVMInterop.IJavaType LocalBridgeClazz => _LocalBridgeClazz ?? throw new global::System.InvalidOperationException($"Class {_bridgeClassName} was not found.");
+
+ ///
+ ///